- Activities
- ActivityHandler
- EndpointLimiting
- EventRouter
- Events
- ExecutorStats
- JDBCDatasource
- JVM
- JVM.ClassLoading
- JVM.Compilation
- JVM.GarbageCollector
- JVM.Memory
- JVM.MemoryPool
- JVM.OperatingSystem
- JVM.Runtime
- JVM.Thread
- LicenseAccounting
- Limiters
- LockManagers
- MemDB-Local
- MemDB-Replicated
- Metrics.Services.cmp
- Metrics.Services.lifecycle
- ObjectPools
- Savanna-Group
- Savanna-Membership
- Services
- StagingThreads
- StagingThreads-Misc
- Transactions
Activities
Activity Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
active |
Activity count |
Counter |
Gauge |
|||
created |
Activities created |
Counter |
||||
ended |
Activities ended |
Counter |
||||
rejected |
Activities rejected |
Counter |
||||
startSuspended (stsusp) |
Number of activities started suspended |
Counter |
|
|||
suspendActivity (susp) |
Number of activities suspended |
Counter |
|
ActivityHandler
Rhino Activity Handler statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
activitiesCollected (actsC) |
Number of activities collected |
Counter |
|
|||
activitiesScanned (scan) |
Number of activities scanned by GC |
Counter |
|
|||
activitiesUnclean (uncln) |
Number of activities not cleaned by GC and retained for next GC |
Counter |
|
|||
ancestorCount (ances) |
Ancestor activities created |
Counter |
|
|||
gcCount (agcs) |
Number of activities queried by GC |
Counter |
|
|||
generationsCollected (gensC) |
Activity MVCC generations collected |
Counter |
|
|||
nonTxCreate (NtxCre) |
Non-transacted Activity Creation |
Counter |
|
|||
nonTxEnd (NtxEnd) |
Non-transacted Activity Ends |
Counter |
|
|||
nonTxFire (NtxFire) |
Events Fired Non-transacted |
Counter |
|
|||
nonTxLookup (NtxLook) |
Non-transacted lookups |
Counter |
|
|||
nonTxLookupMiss (NtxLkMiss) |
Misses in non-transacted lookups |
Counter |
|
|||
txCreate (txCre) |
Transacted Activity Creation |
Counter |
|
|||
txEnd (txEnd) |
Transacted Activity Ends |
Counter |
|
|||
txFire (txFire) |
Events Fired Transacted |
Counter |
|
|||
txLookup (txLook) |
Transacted lookups |
Counter |
|
|||
txLookupMiss (txLkMiss) |
Misses in transacted lookups |
Counter |
|
EndpointLimiting
SLEE Endpoint Limiting Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
submitted (sub) |
Activities and events submitted to a SLEE endpoint |
Counter |
||||
accepted (acc) |
Activities and events accepted by a SLEE endpoint |
Counter |
||||
userAccepted (usrAcc) |
Activities and events accepted by the user rate limiter (SystemInput) |
Counter |
||||
userRejected (usrRej) |
Activities and events rejected by the user rate limiter (SystemInput) |
Counter |
||||
licenseRejected (licRej) |
Activities and events rejected due to the SDK license limit |
Counter |
EventRouter
EventRouter Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
badGuyHandlerStages (bgh) |
Badguy handler stages executed |
Counter |
||||
cleanupStages (clh) |
Cleanup stages executed |
Counter |
||||
eventHandlerStages (evh) |
Event handler stages executed |
Counter |
||||
processingRetrys (retr) |
Number of event processing retries due to concurrent activity updates |
Counter |
||||
rollbackHandlerStages (rbh) |
Rollback handler stages executed |
Counter |
||||
rootSbbFinds (rootf) |
Number of root SBBs resolved |
Counter |
||||
sbbCreates (cre) |
Number of SBBs created |
Counter |
||||
sbbExceptions (exc) |
Number of SBB thrown exceptions caught |
Counter |
||||
sbbsResolved (res) |
Number of SBBs resolved |
Counter |
||||
vEPs (vep) |
Event router setup (virgin events) |
Counter |
Events
Event Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
accepted (acc) |
Accepted events |
Counter |
||||
eventProcessingTime (EPT) |
Total event processing time |
Sample |
µsec |
ns |
ms |
|
eventRouterSetupTime (ERT) |
Event router setup time |
Sample |
µsec |
ns |
ms |
|
failed (fail) |
Events that failed in event processing |
Counter |
||||
rejected (rej) |
Events rejected due to overload |
Counter |
||||
sbbProcessingTime (SBBT) |
SBB processing time |
Sample |
µsec |
ns |
ms |
ExecutorStats
Executor pool statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
executorTaskExecutionTime (etExecTime) |
Time a task spends executing |
Sample |
ns |
ms |
||
executorTasksExecuted (etExecuted) |
Number of executor tasks executed |
Counter |
|
|||
executorTasksExecuting (etExecuting) |
Number of executor tasks currently executing |
Counter |
|
|||
executorTasksRejected (etRejected) |
Number of executor tasks rejected |
Counter |
|
|||
executorTasksSubmitted (etSubmitted) |
Number of executor tasks submitted |
Counter |
|
|||
executorTasksWaiting (etWaiting) |
Number of executor tasks waiting to execute |
Counter |
|
|||
executorTaskWaitingTime (etWaitTime) |
Time a task spends waiting for execution |
Sample |
ns |
ms |
||
executorThreadsIdle (thrIdle) |
Number of idle executor threads |
Counter |
|
|||
executorThreadsTotal (thrTotal) |
Total number of executor threads |
Counter |
|
JDBCDatasource
JDBC Datasource Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
create (create) |
Number of new connections created |
Counter |
||||
duration (duration) |
Time that connections spent in use (allocated to a client) |
Sample |
msec |
ms |
ms |
|
getError (getErr) |
Number of getConnection() requests that failed due to a connection error |
Counter |
||||
getRequest (getReq) |
Number of getConnection() requests made |
Counter |
||||
getSuccess (getOk) |
Number of getConnection() requests that succeeded |
Counter |
||||
getTimeout (getTO) |
Number of getConnection() requests that failed due to a timeout |
Counter |
||||
getWait (getWait) |
Time spent by threads waiting for a connection (that eventually succeeded) |
Sample |
msec |
ms |
ms |
|
idleConnections (cIdle) |
Number of idle, pooled, connections |
Counter |
|
|||
inUseConnections (cInUse) |
Number of in use connections |
Counter |
|
|||
maxConnections (cMax) |
Maximum number of open connections |
Counter |
|
|||
pendingConnections (cPend) |
Number of connections in the process of being created |
Counter |
|
|||
putError (putErr) |
Number of connections returned to the pool that were closed due to a connection error |
Counter |
||||
putOk (putOk) |
Number of connections returned to the pool that were retained |
Counter |
||||
putOverflow (putOver) |
Number of connections returned to the pool that were closed because the idle pool was at maximum size |
Counter |
||||
removeError (remErr) |
Number of connections removed from the pool due to a connection error |
Counter |
||||
removeIdle (remIdle) |
Number of connections removed from the pool due to being idle |
Counter |
||||
removeOverflow (remOver) |
Number of connections removed from the pool due to the idle pool being full |
Counter |
||||
totalConnections (cTotal) |
Total number of open connections |
Counter |
|
JVM
JVM Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
classesCurrentLoaded (cLoad) |
Number of classes currently loaded |
Counter |
|
|||
classesTotalLoaded (cTotLoad) |
Total number of classes loaded since JVM start |
Counter |
|
|||
classesTotalUnloaded (cTotUnload) |
Total number of classes unloaded since JVM start |
Counter |
|
|||
heapCommitted (hcomm) |
Committed heap memory |
Counter |
|
|||
heapInitial (hinit) |
Initial heap memory |
Counter |
|
|||
heapMaximum (hmax) |
Maximum heap memory |
Counter |
|
|||
heapUsed (husd) |
Used heap memory |
Counter |
|
|||
nonHeapCommitted (nhcomm) |
Committed non-heap memory |
Counter |
|
|||
nonHeapInitial (nhinit) |
Initial non-heap memory |
Counter |
|
|||
nonHeapMaximum (nhmax) |
Maximum non-heap memory |
Counter |
|
|||
nonHeapUsed (nhusd) |
Used non-heap memory |
Counter |
|
JVM.ClassLoading
JVM Class Loading Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
loadedClassCount (loadClasses) |
Number of classes currently loaded |
Counter |
|
|||
totalLoadedClassCount (totLoadClasses) |
Total number of classes loaded since JVM start |
Counter |
|
|||
unloadedClassCount (unloadClasses) |
Total number of classes unloaded since JVM start |
Counter |
|
JVM.Compilation
JVM Compilation Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
totalCompilationTime (totCompTime) |
The total compilation time |
Counter |
|
JVM.GarbageCollector
JVM Garbage Collector Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
collectionCount (collCount) |
Garbage Collector Collection Count |
Counter |
|
|||
collectionTime (collTime) |
Garbage Collector Collection Time |
Counter |
|
JVM.Memory
JVM Memory Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
heapInitial (heapInit) |
Memory Heap Usage Initial |
Counter |
|
|||
heapUsed (heapUsed) |
Memory Heap Usage Used |
Counter |
|
|||
heapMax (heapMax) |
Memory Heap Usage Max |
Counter |
|
|||
heapCommitted (heapComm) |
Memory Heap Usage Committed |
Counter |
|
|||
nonHeapInitial (nonheapInit) |
Memory Non Heap Usage Initial |
Counter |
|
|||
nonHeapUsed (nonheapUsed) |
Memory Non Heap Usage Used |
Counter |
|
|||
nonHeapMax (nonheapMax) |
Memory Non Heap Usage Max |
Counter |
|
|||
nonHeapCommitted (nonheapComm) |
Memory Non Heap Usage Committed |
Counter |
|
JVM.MemoryPool
JVM Memory Pool Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
collectionUsageInitial (collUsageInit) |
Memory Pool Collection Usage Initial |
Counter |
|
|||
collectionUsageUsed (collUsageUsed) |
Memory Pool Collection Usage Used |
Counter |
|
|||
collectionUsageMax (collUsageMax) |
Memory Pool Collection Usage Max |
Counter |
|
|||
collectionUsageCommitted (collUsageComm) |
Memory Pool Collection Usage Committed |
Counter |
|
|||
collectionUsageThreshold (collUsageThresh) |
Memory Pool Collection Usage Threshold |
Counter |
|
|||
collectionUsageThresholdCount (collUseThrCount) |
Memory Pool Collection Usage Threshold Count |
Counter |
|
|||
peakUsageInitial (peakUsageInit) |
Memory Pool Peak Usage Initial |
Counter |
|
|||
peakUsageUsed (peakUsageUsed) |
Memory Pool Peak Usage Used |
Counter |
|
|||
peakUsageMax (peakUsageMax) |
Memory Pool Peak Usage Max |
Counter |
|
|||
peakUsageCommitted (peakUsageComm) |
Memory Pool Peak Usage Committed |
Counter |
|
|||
usageThreshold (usageThresh) |
Memory Pool Usage Threshold |
Counter |
|
|||
usageThresholdCount (usageThreshCount) |
Memory Pool Usage Threshold Count |
Counter |
|
|||
usageInitial (usageInit) |
Memory Pool Usage Initial |
Counter |
|
|||
usageUsed (usageUsed) |
Memory Pool Usage Used |
Counter |
|
|||
usageMax (usageMax) |
Memory Pool Usage Max |
Counter |
|
|||
usageCommitted (usageComm) |
Memory Pool Usage Committed |
Counter |
|
JVM.OperatingSystem
JVM Operating System Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
availableProcessors (availProc) |
Operating System Available Processors |
Counter |
|
|||
committedVirtualMemorySize (commVirtMem) |
Operating System Committed Virtual Memory |
Counter |
|
|||
freePhysicalMemorySize (freePhysMem) |
Operating System Free Physical Memory Size |
Counter |
|
|||
freeSwapSpaceSize (freeSwapSpc) |
Operating System Free Swap Space Size |
Counter |
|
|||
processCpuTime (procCpuTime) |
Operating System Process Cpu Time |
Counter |
|
|||
totalPhysicalMemorySize (totPhysMem) |
Operating System Total Physical Memory Size |
Counter |
|
|||
totalSwapSpaceSize (totSwapSpc) |
Operating System Total Swap Space Size |
Counter |
|
|||
maxFileDescriptorCount (maxFileDesc) |
Operating System Max File Descriptor Count |
Counter |
|
|||
openFileDescriptorCount (openFileDesc) |
Operating System Open File Descriptor Count |
Counter |
|
JVM.Runtime
JVM Runtime Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
uptime (uptime) |
Runtime Uptime |
Counter |
|
|||
startTime (startTime) |
Runtime Start Time |
Counter |
|
JVM.Thread
JVM Thread Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
currentThreadCpuTime (currThrdCpuTm) |
Thread Current Thread Cpu Time |
Counter |
|
|||
currentThreadUserTime (currThrdUsrTm) |
Thread Current Thread User Time |
Counter |
|
|||
daemonThreadCount (daeThrds) |
Thread Daemon Thread Count |
Counter |
|
|||
peakThreadCount (peakThrds) |
Thread Peak Thread Count |
Counter |
|
|||
threadCount (threads) |
Thread Thread Count |
Counter |
|
|||
totalStartedThreadCount (totStartThrds) |
Thread Total Started Thread Count |
Counter |
|
LicenseAccounting
License Accounting Information
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
accountedUnits (acc) |
Accounted License Units Consumed |
Counter |
units |
|||
unaccountedUnits (unacc) |
Unaccounted License Units Consumed |
Counter |
units |
Limiters
_Limiter Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
unitsRejected (rejected) |
Number of units rejected (both here and by parent) |
Counter |
||||
unitsRejectedByParent (rejectedByParent) |
Number of units rejected by parent limiter |
Counter |
||||
unitsUsed (used) |
Number of units used |
Counter |
LockManagers
Lock Manager Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
abortMessages (msgAbort) |
LOCK_ABORT_ACQUIRE messages sent |
Counter |
||||
acquireMessages (msgAcquire) |
LOCK_ACQUIRE messages sent |
Counter |
||||
knownLocks (locks) |
Total number of locks with state |
Counter |
|
|||
lockAcquisitionTime (LAT) |
Lock acquisition time |
Sample |
µsec |
ns |
ms |
|
locksAcquired (acq) |
Locks acquired |
Counter |
||||
locksReleased (rel) |
Locks released |
Counter |
||||
lockTimeouts (timeout) |
Lock timeouts occurred |
Counter |
||||
lockWaits (wait) |
Lock waits occurred |
Counter |
||||
lockWaitTime (LWT) |
Time waited for contested locks |
Sample |
µsec |
ns |
ms |
|
migrationReleaseMessages (msgMigRel) |
LOCK_MIGRATION_RELEASE messages sent |
Counter |
||||
migrationRequestMessages (msgMigReq) |
LOCK_MIGRATION_REQUEST messages sent |
Counter |
||||
releaseMessages (msgRelease) |
LOCK_RELEASE_TRANSACTION messages sent |
Counter |
MemDB-Local
Local Memory Database Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units | Replicated |
---|---|---|---|---|---|---|---|
churnSize (churn) |
Churn space used by the database, in bytes |
Counter |
b |
false |
|||
cleanupCount (cleanups) |
Number of state cleanups performed by the database |
Counter |
# |
No |
|||
committedSize (csize) |
Current committed size in kilobytes |
Counter |
kb |
|
|||
maxCommittedSize (max) |
Maximum allowed committed size in kilobytes |
Counter |
kb |
|
MemDB-Replicated
Replicated Memory Database Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units | Replicated |
---|---|---|---|---|---|---|---|
churnSize (churn) |
Churn space used by the database, in bytes |
Counter |
b |
No |
|||
cleanupCount (cleanups) |
Number of state cleanups performed by the database |
Counter |
# |
No |
|||
committedSize (csize) |
Current committed size in kilobytes |
Counter |
kb |
|
Yes |
||
maxCommittedSize (max) |
Maximum allowed committed size in kilobytes |
Counter |
kb |
|
Yes |
Metrics.Services.cmp
SBB CMP field metrics. These metrics are generated for every CMP field in each SBB.
The metrics recording can be turned on/off with rhino-console commands. |
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
<cmpfield>Reads |
CMP field <cmpfield> reads |
Counter |
||||
<cmpfield>Writes |
CMP field <cmpfield> writes |
Counter |
||||
<cmpfield>ReferenceCacheHits |
CMP field <cmpfield> reference cache hits during field reads |
Counter |
||||
<cmpfield>ReferenceCacheMisses |
CMP field <cmpfield> reference cache misses during field reads |
Counter |
||||
<cmpfield>WriteTime |
CMP field <cmpfield> serialisation time |
Sample |
||||
<cmpfield>ReadTime |
CMP field <cmpfield> deserialisation time |
Sample |
||||
<cmpfield>Size |
CMP field <cmpfield> serialised size |
Sample |
Metrics.Services.lifecycle
SBB lifecycle method metrics. These stats records invocations of SBB lifecycle methods.
The metrics recording can be turned on/off with rhino-console commands. |
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
sbbSetContexts |
Total number of setSbbContext invocations |
Counter |
||||
sbbUnsetContexts |
Total number of unsetSbbContext invocations |
Counter |
||||
sbbCreates |
Total number of sbbCreate invocations |
Counter |
||||
sbbRemoves |
Total number of sbbRemove invocations |
Counter |
||||
sbbLoads |
Total number of sbbLoad invocations |
Counter |
||||
sbbStores |
Total number of sbbStore invocations |
Counter |
||||
sbbActivates |
Total number of sbbActivate invocations |
Counter |
||||
sbbPassivates |
Total number of sbbPassivate invocations |
Counter |
||||
sbbRollbacks |
Total number of sbbRolledBack invocations |
Counter |
||||
sbbExceptionsThrown |
Total number of sbbExceptionThrown invocations |
Counter |
ObjectPools
Object Pool Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
added |
Objects added to pool |
Counter |
||||
capacity |
Object pool capacity |
Counter |
|
|||
miss |
Object pool misses |
Counter |
||||
overflow |
Object pool overflows |
Counter |
||||
removed |
Objects removed from pool |
Counter |
||||
size |
Object pool size |
Counter |
|
Savanna-Group
Per-group Savanna statistics
Production Rhino Only |
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
activityEstimate (activityEst) |
Cluster activity time estimate |
Counter |
msec |
|
||
appBytesReceived (appBytesRx) |
Number of application message bytes received |
Counter |
bytes |
|||
appBytesSent (appBytesTx) |
Number of application message bytes sent |
Counter |
bytes |
|||
appDeliveryDelay (appDelivDelay) |
Time from a received message being eligible for delivery, to it being delivered to the application |
Sample |
ns |
ms |
||
appMessageSize (appMsgSize) |
Sent application message size Samples |
Sample |
count/bytes |
count/bytes |
||
appMessagesReceived (appRx) |
Number of application messages received and fully reassembled |
Counter |
count |
|||
appMessagesSent (appTx) |
Number of application messages sent |
Counter |
count |
|||
appPartialMessagesReceived (appPartialRx) |
Number of application messages received and partially reassembled |
Counter |
count |
|||
appRoundTripTime (appRTT) |
Time from sending a message to the message being delivered to application code on the same node |
Sample |
ns |
ms |
||
appSendErrors (appErrorTx) |
Number of application messages dropped due to full buffers |
Counter |
count |
|||
appTransmitDelay (appXmitDelay) |
Time from sending an application message to savanna, to it being sent at the network level |
Sample |
ns |
ms |
||
deliveryQueueBytes (dyQBytes) |
Size of messages waiting to be delivered locally |
Counter |
bytes |
|
||
deliveryQueueSize (dyQSize) |
Size of messages waiting to be delivered locally |
Counter |
bytes |
|
||
fcCongestionWindowSize (fcConWin) |
Flowcontrol congestion window size |
Counter |
bytes |
|
||
fcLimitedSends (fcLimited) |
Number of token rotations where we wanted to send more data than flowcontrol allowed |
Counter |
count |
|||
fcReceiveBufferSize (fcRcvBuf) |
Flowcontrol receive buffer size |
Counter |
bytes |
|
||
fcRetransmissionRequests (fcRetrans) |
Number of current retransmission requests |
Counter |
count |
|
||
fcSendWindowSize (fcSendWin) |
Flowcontrol send window size |
Counter |
bytes |
|
||
fcTokenRotationEstimate (fcTokEst) |
Flow control token rotation time estimate |
Counter |
msec |
|
||
fragEndSent (fragEndTx) |
Number of final message fragments sent |
Counter |
count |
|||
fragmentSize (appFragSize) |
Size of sent message fragments |
Sample |
count/bytes |
count/bytes |
||
fragmentsPerAppMessage (appMsgFrags) |
Number of fragments making up a single application message |
Sample |
count/fragments |
count/fragments |
||
fragmentsPerRegularMessage (rgmFrags) |
Number of application message fragments in a single regular message |
Sample |
count/fragments |
count/fragments |
||
fragMidSent (fragMidTx) |
Number of middle message fragments sent |
Counter |
count |
|||
fragNonSent (fragNonTx) |
Number of messages sent unfragmented |
Counter |
count |
|||
fragStartSent (fragStartTx) |
Number of start message fragments sent |
Counter |
count |
|||
groupIdles (idles) |
Number of times group has gone idle |
Counter |
count |
|||
installTokensReceived (itokRx) |
Number of install tokens received |
Counter |
count |
|||
installTokensSent (itokTx) |
Number of install tokens sent |
Counter |
count |
|||
messageDeliveryTime (dyMsgTime) |
Time taken to locally deliver a single message |
Sample |
ns |
ms |
||
messageRetransmits (msgRetrans) |
Number of message retransmits |
Counter |
count |
|||
messagesLessThanARU (belowARU) |
Number of messages seen less than ARU |
Counter |
count |
|||
recoveryMessagesReceived (rcmRx) |
Number of recovery messages received |
Counter |
count |
|||
recoveryMessagesSent (rcmTx) |
Number of recovery messages sent |
Counter |
count |
|||
regularMessageSize (rgmSize) |
Sent regular message size Samples |
Sample |
count/bytes |
count/bytes |
||
regularMessagesReceived (rgmRx) |
Number of regular messages received |
Counter |
count |
|||
regularMessagesSent (rgmTx) |
Number of regular messages sent |
Counter |
count |
|||
regularTokensReceived (rtokRx) |
Number of regular tokens received |
Counter |
count |
|||
regularTokensSent (rtokTx) |
Number of regular tokens sent |
Counter |
count |
|||
restartGroupMessageRetransmits (rsmRetrans) |
Number of restart group messages retransmitted |
Counter |
count |
|||
restartGroupMessagesReceived (rsmRx) |
Number of restart group messages received |
Counter |
count |
|||
restartGroupMessagesSent (rsmTx) |
Number of restart group messages sent |
Counter |
count |
|||
shiftToInstall (toInstall) |
Number of times group has shifted to install |
Counter |
count |
|||
shiftToOperational (toOper) |
Number of times group has shifted to operational |
Counter |
count |
|||
shiftToRecovery (toRecovery) |
Number of times group has shifted to recovery |
Counter |
count |
|||
tokenRetransmits (tokRetrans) |
Number of token retransmits |
Counter |
count |
|||
tokenRotationTime (tokRotation) |
Token rotation time Samples |
Sample |
ms |
ms |
||
transmitBatchBytes (txBatchBytes) |
Size of messages sent per token rotation |
Sample |
count/bytes |
count/bytes |
||
transmitQueueBytes (txQBytes) |
Size of messages waiting to send |
Counter |
bytes |
|
||
transmitQueueSize (txQSize) |
Number of messages waiting to send |
Counter |
bytes |
|
||
udpBytesReceived (udpBytesRx) |
Total UDP bytes received |
Counter |
bytes |
|||
udpBytesSent (udpBytesTx) |
Total UDP bytes sent |
Counter |
bytes |
|||
udpDatagramSendErrors (udpErrorTx) |
Number of UDP datagrams that failed to be sent |
Counter |
count |
|||
udpDatagramsReceived (udpRx) |
Number of valid UDP datagrams received |
Counter |
count |
|||
udpDatagramsSent (udpTx) |
Number of UDP datagrams successfully sent |
Counter |
count |
|||
udpInvalidDatagramsReceived (udpErrorRx) |
Number of invalid UDP datagrams received |
Counter |
count |
Savanna-Membership
Membership ring Savanna statistics
Production Rhino Only |
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
activityEstimate (activityEst) |
Cluster activity time estimate |
Counter |
msec |
|
||
commitTokensReceived (ctokRx) |
Number of commit tokens received |
Counter |
count |
|||
commitTokensSent (ctokTx) |
Number of commit tokens sent |
Counter |
count |
|||
joinMessagesReceived (joinRx) |
Number of join messages received |
Counter |
count |
|||
joinMessagesSent (joinTx) |
Number of join messages sent |
Counter |
count |
|||
membershipTokensReceived (mtokRx) |
Number of membership tokens received |
Counter |
count |
|||
membershipTokensSent (mtokTx) |
Number of membership tokens sent |
Counter |
count |
|||
shiftToCommit (toCommit) |
Number of times group has shifted to commit |
Counter |
count |
|||
shiftToGather (toGather) |
Number of times group has shifted to gather |
Counter |
count |
|||
shiftToInstall (toInstall) |
Number of times group has shifted to install |
Counter |
count |
|||
shiftToOperational (toOper) |
Number of times group has shifted to operational |
Counter |
count |
|||
tokenRetransmits (tokRetrans) |
Number of token retransmits |
Counter |
count |
|||
tokenRetransmitTimeouts (tokTimeout) |
Number of token retransmission timeouts |
Counter |
count |
|||
tokenRotationTime (tokRotation) |
Token rotation time Samples |
Sample |
ms |
ms |
||
udpBytesReceived (udpBytesRx) |
Total UDP bytes received |
Counter |
bytes |
|||
udpBytesSent (udpBytesTx) |
Total UDP bytes sent |
Counter |
bytes |
|||
udpDatagramSendErrors (udpErrorTx) |
Number of UDP datagrams that failed to be sent |
Counter |
count |
|||
udpDatagramsReceived (udpRx) |
Number of valid UDP datagrams received |
Counter |
count |
|||
udpDatagramsSent (udpTx) |
Number of UDP datagrams successfully sent |
Counter |
count |
|||
udpInvalidDatagramsReceived (udpErrorRx) |
Number of invalid UDP datagrams received |
Counter |
count |
Services
Service Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
activeRootSbbs (active) |
# of active root sbbs |
Counter |
|
|||
rootSbbsCreated (created) |
Root sbbs created |
Counter |
||||
rootSbbsRemoved (removed) |
Root sbbs removed |
Counter |
||||
sbbLifeTime (lifeT) |
Root SBB lifetime |
Sample |
msec |
ms |
StagingThreads
Staging Thread Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
activeThreads (activ) |
Worker threads currently active processing work |
Counter |
|
|||
availableThreads (avail) |
Number of idle worker threads |
Counter |
|
|||
dropped (drop) |
Number of dropped stage items |
Counter |
||||
itemsAdded |
Items of work submitted to the thread pool |
Counter |
||||
itemsCompleted |
Items of work completed by the thread pool |
Counter |
||||
maxThreads (max) |
Configured maximum size of the thread pool |
Counter |
|
|||
minThreads (min) |
Configured minimum size of the thread pool |
Counter |
|
|||
numThreads (numthrd) |
Current size of the thread pool |
Counter |
|
|||
peakThreads (peak) |
The most threads that were ever active in the thread pool |
Counter |
|
|||
queueSize (qSize) |
Size of the work item queue |
Counter |
|
|||
waitTime (waitT) |
Time spent waiting on stage queue |
Sample |
msec |
ns |
StagingThreads-Misc
Distributed Resource Manager Runnable Stage Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
activeThreads (activ) |
Worker threads currently active processing work |
Counter |
|
|||
availableThreads (avail) |
Number of idle worker threads |
Counter |
|
|||
dropped (drop) |
Number of dropped stage items |
Counter |
||||
itemsAdded |
Items of work submitted to the thread pool |
Counter |
||||
itemsCompleted |
Items of work completed by the thread pool |
Counter |
||||
maxThreads (max) |
Configured maximum size of the thread pool |
Counter |
|
|||
minThreads (min) |
Configured minimum size of the thread pool |
Counter |
|
|||
numThreads (numthrd) |
Current size of the thread pool |
Counter |
|
|||
peakThreads (peak) |
The most threads that were ever active in the thread pool |
Counter |
|
|||
queueSize (qSize) |
Size of the work item queue |
Counter |
|
|||
waitTime (waitT) |
Time spent waiting on stage queue |
Sample |
msec |
ns |
Transactions
Transaction Manager Statistics
Name | Description | Type | Unit Label | View | Source Units | Default Display Units |
---|---|---|---|---|---|---|
active |
Number of active transactions |
Counter |
|
|||
committed (commit) |
Transactions committed |
Counter |
||||
rolledBack (rollback) |
Transactions rolled back |
Counter |
||||
started (started) |
Transactions started |
Counter |