In This Section
- Overview
- Measurements
- client.admin
- system
- system.disk
- system.threads
- system.gc
- xvm.heartbeats.logger
- xvm.heartbeats.logger.disruptor
- xvm.heartbeats.logger.latencies
- pools
- application
- application.disruptor
- application.disruptor.latencies
- application.multiplexer
- application.events
- application.flows
- application.messages
- application.transaction
- application.messages.type
- application.messages.type.latencies (MsgProcessing)
- application.messages.type.latencies (MsgFiltering)
- application.backup
- application.transaction.latencies (CommitEpilogue)
- application.transaction.latencies (CommitFull)
- application.transaction.latencies (CommitPrologue)
- application.transaction.latencies (CommitSend)
- application.transaction.latencies (CommitStart)
- application.transaction.latencies (CommitStore)
- application.transaction.latencies (CommitTransition)
- application.transaction.latencies (InAck)
- application.transaction.latencies (InOut)
- application.transaction.latencies (MsgFiltering)
- application.transaction.latencies (MsgPreProc)
- application.transaction.latencies (MsgProcessing)
- application.transaction.latencies (MsgSendCore)
- application.transaction.latencies (MsgSend)
- application.transaction.latencies (TransactionLeg1)
- application.transaction.latencies (TransactionLeg2)
- application.transaction.latencies (TransactionLeg3)
- application.messagelogger.inbound
- application.messagelogger.inbound.disruptor
- application.messagelogger.inbound.latencies
- application.messagelogger.outbound
- application.messagelogger.outbound.disruptor
- application.messagelogger.outbound.latencies
- application.pertransactionstats.logger
- application.pertransactionstats.logger.disruptor
- application.pertransactionstats.logger.latencies
- application.store
- application.store.latencies (CommitQueueSize)
- application.store.latencies (Commit)
- application.store.latencies (Deserialize)
- application.store.latencies (IcrSend)
- application.store.latencies (Index)
- application.store.latencies (Persist)
- application.store.latencies (Serialize)
- application.store.latencies (SerializeToPersist)
- application.store.latencies (SerializeToWire)
- application.store.latencies (Wire)
- application.store.latencies (WireToDeserialize)
- application.store.persister
- application.store.persister.disruptor
- application.store.persister.latencies
- application.store.icr_sender
- application.store.icr_sender.disruptor
- application.store.icr_sender.latencies
- application.bus
- application.bus.disruptor
- application.bus.disruptor.latencies
- application.bus.latencies (CreateToSend)
- application.bus.latencies (Deserialize)
- application.bus.latencies (DeserializeToReceive)
- application.bus.latencies (OriginToReceive)
- application.bus.latencies (SendToSerialize)
- application.bus.latencies (Serialize)
- application.bus.latencies (SerializeToWire)
- application.bus.latencies (Wire)
- application.bus.latencies (WireSend)
- application.bus.latencies (WireToDeserialize)
- application.bus.latencies (WireToWire)
- application.user.gauge
- application.user.counter
- application.user.series
Overview
The XVM heartbeat collector listens for XVM heartbeats from discovered XVMs and extracts the stats from each heartbeat into point series data. XVM heartbeats contain a wealth of information about each XVM and the applications it hosts. This section describes how XVM heartbeats are collected and converted to time series data.
The Stats Collection Process
Types of Stats
Stats Collection Format
Top level message type that Lumino receives and processes is ISrvMonHeartbeatMessage. This message type embeds other entities which group stats depending on their origin (e.g. user stats, process-level stats, pooling stats etc.). These contain individual stats being measured.
Integer Histogram Data Points
Histogram stats hold statistically computed data for two intervals:
- Sampling Interval - For the points taken within sample interval, as configured for the stat.
- Running Interval - For the points taken since XVM started.
When collecting ISrvMonIntSeries type of stat, the Stats Collector will derive histogram fields. Common fields for this stats of this type are listed in the table below.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
points | ISrvMonIntSeries .numDataPoints | The number of data points collected in this interval. |
skipped | ISrvMonIntSeries .skippedDatapoints | The number of data points skipped due to undersampling. |
sno | ISrvMonIntSeries .lastSequenceNumber | The sequence number of the last data point collected or 0 if no data points have been collected. |
sample | ISrvMonIntSeries .intervalStats .sampleSize | The number of datapoints over which results were calculated. (For sampling interval) |
min | ISrvMonIntSeries .intervalStats .minimum | The minimum value recorded in the sample set. (For sampling interval ) |
max | ISrvMonIntSeries .intervalStats .maximum | The maximum value recorded in the sample set. (For sampling interval ) |
mean | ISrvMonIntSeries .intervalStats .mean | The mean value for the sample set. (For sampling interval ) |
median | ISrvMonIntSeries .intervalStats .median | The median value for the sample set. (For sampling interval ) |
pct75 | ISrvMonIntSeries .intervalStats .pct75 | The 75th percentile for the sample set. (For sampling interval ) |
pct90 | ISrvMonIntSeries .intervalStats .pct90 | The 90th percentile for the sample set. (For sampling interval ) |
pct99 | ISrvMonIntSeries .intervalStats .pct99 | The 99th percentile for the sample set. (For sampling interval ) |
pct999 | ISrvMonIntSeries .intervalStats .pct999 | The 99.9th percentile for the sample set. (For sampling interval ) |
pct9999 | ISrvMonIntSeries .intervalStats .pct9999 | The 99.99th percentile for the sample set. (For sampling interval ) |
running_sample | ISrvMonIntSeries .runningStats .sampleSize | The number of datapoints over which results were calculated. (For XVM running interval) |
running_min | ISrvMonIntSeries .runningStats .minimum | The minimum value recorded in the sample set. (For XVM running interval) |
running_max | ISrvMonIntSeries .runningStats .maximum | The maximum value recorded in the sample set. (For XVM running interval) |
running_mean | ISrvMonIntSeries .runningStats .mean | The mean value for the sample set. (For XVM running interval) |
running_median | ISrvMonIntSeries .runningStats .median | The median value for the sample set. (For XVM running interval) |
running_pct75 | ISrvMonIntSeries .runningStats .pct75 | The 75th percentile for the sample set. (For XVM running interval) |
running_pct90 | ISrvMonIntSeries .runningStats .pct90 | The 90th percentile for the sample set. (For XVM running interval) |
running_pct99 | ISrvMonIntSeries .runningStats .pct99 | The 99th percentile for the sample set. (For XVM running interval) |
running_pct999 | ISrvMonIntSeries .runningStats .pct999 | The 99.9th percentile for the sample set. (For XVM running interval) |
running_pct9999 | ISrvMonIntSeries .runningStats .pct9999 | The 99.99th percentile for the sample set. (For XVM running interval) |
Common Heartbeat Tags and Fields
Below are tables listing tags and fields common to all measurements processed by XVM Stats Collector.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
host_name | ISrvMonHeartbeatMessage .serverHostName | The server's hostname. |
vm_name | ISrvMonHeartbeatMessage .serverName | The name of the Talon server. |
system_name | ISrvMonHeartbeatMessage .systemName | The name of the Talon system to which the server belongs. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
system_version | ISrvMonHeartbeatMessage.systemVersion | The version of the Talon system to which the server belongs. |
Common XVM Application Tags and Fields
All measurements pertinent to specific XVM Application will have common application tags and fields. The data comes from ISrvMonAppInfo type.
Measurements in namespaces "application.*" and "user.*" have common application tags and fields.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
app_name | ISrvMonAppInfo .name | The application's name. |
app_state | ISrvMonAppInfo .state | The application's current state. |
app_role | ISrvMonAppInfo .role | The application's current HA role. |
app_ha_policy | ISrvMonAppInfo .HAPolicy | The application's HAPolicy. |
Measurements
client.admin
Description: Holds stats for a connected admin client.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | ISrvMonHeartbeatMessage .adminClientStats[i] .name | Name of the admin client |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
lifecyclesSent | ISrvMonHeartbeatMessage .adminClientStats[i] .lifecyclesSent | The number of lifecycle events sent to the client. |
heartbeatsSent | ISrvMonHeartbeatMessage .adminClientStats[i] .heartbeatsSent | The number of heartbeats sent to the client. |
heartbeatsDropped | ISrvMonHeartbeatMessage .adminClientStats[i] .heartbeatsDropped | The number of heartbeats dropped due to congestion. |
outboundQueueCapacity | ISrvMonHeartbeatMessage .adminClientStats[i] .outboundQueueCapacity | The capacity, in bytes, of the client's outbound queue. |
outboundQueueSize | ISrvMonHeartbeatMessage .adminClientStats[i] .outboundQueueSize | The size, in bytes, of the client's outbound queue. |
outboundQueueCount | ISrvMonHeartbeatMessage .adminClientStats[i] .outboundQueueCount | The number of elements in the client's outbound queue. |
system
Description: Stats related to the JVM / System on which the server is running.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
jit_name | ISrvMonHeartbeatMessage .sysStats .jitStats .name | The name of the Just-in-time (JIT) compiler in use. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
xvm_loaded_time | ISrvMonHeartbeatMessage .loadedTimeAsTimestamp | The timestamp when server loaded. |
processors | ISrvMonHeartbeatMessage .sysStats .availableProcessors | Number of processors available to JVM. |
load_average | ISrvMonHeartbeatMessage .sysStats .systemLoadAverage | System load average in the last minute. |
process_cpu_load | ISrvMonHeartbeatMessage .sysStats .processCpuLoad | Holds recent CPU usage by the XVM process (on a 0.0 to 1.0 scale). |
system_cpu_load | ISrvMonHeartbeatMessage .sysStats .systemCpuLoad | Holds recent CPU usage by the system (on a 0.0 to 1.0 scale). |
threads_count | ISrvMonHeartbeatMessage .sysStats .threadStats .threadCount | The number of active threads in the system. |
threads_daemon_count | ISrvMonHeartbeatMessage .sysStats .threadStats .daemonThreadCount | The number of active daemon threads in the system. |
threads_peak_count | ISrvMonHeartbeatMessage .sysStats .threadStats .peakThreadCount | The peak number of threads observed in the system. |
jit_time | ISrvMonHeartbeatMessage .sysStats .jitStats .totalCompilationTime | The commulative time spent in JIT compilation (in milliseconds). |
gc_count | SUM( ISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectionCount ) | The total number of garbage collections that have occurred. |
gc_time | SUM( ISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectionTime ) | The approximate accumulated collection elapsed time in milliseconds. |
memory_heap_init | ISrvMonHeartbeatMessage .sysStats .memoryStats .heapUsage .init | The amount of heap memory in bytes that the Java virtual machine initially requests from the operating system. A value of -1 indicates that the initial memory size is undefined. |
memory_heap_used | ISrvMonHeartbeatMessage .sysStats .memoryStats .heapUsage .used | The amount of used heap memory in bytes. |
memory_heap_committed | ISrvMonHeartbeatMessage .sysStats .memoryStats .heapUsage .committed | The amount of memory in bytes that is committed for the Java virtual machine to use as heap. The amount of memory is guaranteed for the Java virtual machine to use. |
memory_heap_max | ISrvMonHeartbeatMessage .sysStats .memoryStats .heapUsage .max | The maximum amount of memory in bytes that can be used for heap memory management. This amount of memory is not guaranteed to be available for memory management if it is greater than the amount of committed memory. The Java virtual machine may fail to allocate memory even if the amount of used memory does not exceed this maximum size. A value of -1 indicates that the maximum memory size is undefined. |
memory_non_heap_init | ISrvMonHeartbeatMessage .sysStats .memoryStats .nonHeapUsage .init | The amount of off-heap memory in bytes that the Java virtual machine initially requests from the operating system for off-heap memory management. A value of -1 indicates that the initial memory size is undefined. |
memory_non_heap_used | ISrvMonHeartbeatMessage .sysStats .memoryStats .nonHeapUsage .used | The amount of used off-heap memory in bytes. |
memory_non_heap_committed | ISrvMonHeartbeatMessage .sysStats .memoryStats .nonHeapUsage .committed | The maximum amount of memory in bytes that can be used for off-heap memory management. This amount of memory is not guaranteed to be available for memory management if it is greater than the amount of committed memory. The Java virtual machine may fail to allocate memory even if the amount of used memory does not exceed this maximum size. A value of -1 indicates that the maximum memory size is undefined. |
memory_non_heap_max | ISrvMonHeartbeatMessage .sysStats .memoryStats .nonHeapUsage .max | The maximum off-heap memory size in bytes. |
memory_physical_size_total | ISrvMonHeartbeatMessage .sysStats .memoryStats .totalPhysicalMemorySize | The total amount of physical memory in bytes. |
memory_physical_size_free | ISrvMonHeartbeatMessage .sysStats .memoryStats .freePhysicalMemorySize | The amount of free physical memory in bytes. |
memory_swap_size_total | ISrvMonHeartbeatMessage .sysStats .memoryStats .totalSwapSpaceSize | The total amount of swap space in bytes. |
memory_swap_size_free | ISrvMonHeartbeatMessage .sysStats .memoryStats .freeSwapSpaceSize | The amount of free swap space in bytes. |
system.disk
Description: Stats on disk usage.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
disk_root | ISrvMonHeartbeatMessage .sysStats .diskStats[i] .rootPath | Root path where disk is mounted in the operating system. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
disk_total_space | ISrvMonHeartbeatMessage .sysStats .diskStats[i] .totalSpace | The size, in bytes, of the partition. |
disk_usable_space | ISrvMonHeartbeatMessage .sysStats .diskStats[i] .usableSpace | The number of bytes available to the XVM for the disk or partition. |
disk_free_space | ISrvMonHeartbeatMessage .sysStats .diskStats[i] .freeSpace | Free space in bytes for the disk or partition. |
system.threads
Description: Stats per XVM thread.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
id | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .id | Thread ID. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
id | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .id | Thread ID. |
name | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .name | Thread name. |
state | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .state | Last thread state when heartbeat occurred. |
cpu_time | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .cpuTime | The CPU time used by the thread (in nanoseconds). |
usr_time | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .usrTime | The cpu time user time used by the thread (in nanoseconds). |
collect_time | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .collectTime | The time in nanoseconds just after cpu times were collected. |
affinity | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .affinity | Affinitization details for the thread (if affinitized). |
wait_count | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .waitCount | The number of times the thread was recorded as waiting. |
wait_time | ISrvMonHeartbeatMessage .sysStats .threadStats[i] .waitTime | The time in nanoseconds spent waiting for events. |
system.gc
Description: Stats per GC.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
collector_name | ISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectorName | The name of the collector that performed the gc. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
num_collections | ISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectionCount | The total number of collections that have occurred. |
cum_time | ISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectionTime | The approximate accumulated collection elapsed time in milliseconds. |
xvm.heartbeats.logger
Description: General stats for the application message logger.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
detached | ISrvMonHeartbeatMessage .heartbeatLoggerStats .detachedPersist | Indicates if the message logger is operating in detached mode. |
commits | ISrvMonHeartbeatMessage .heartbeatLoggerStats .numCommits | The number of commits to the message logger. |
forks | ISrvMonHeartbeatMessage .heartbeatLoggerStats .numForks | The number of forked message packets persisted. |
messages | ISrvMonHeartbeatMessage .heartbeatLoggerStats .numMessagesRecorded | The number of messages persisted by the message logger. |
file_size | ISrvMonHeartbeatMessage .heartbeatLoggerStats .fileSize | The size of the allocated log file in bytes. |
file_size_used | ISrvMonHeartbeatMessage .heartbeatLoggerStats .fileSizeUsed | The size of the allocated log file used in bytes. |
xvm.heartbeats.logger.disruptor
Description: Disruptor stats for the application message logger.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .capacity | The size of the disruptor's ringbuffer. |
remaining | ISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .remaining | The number of free ringbuffer slots. |
used | {capacity} - {remaining} | The number of used ringbuffer slots. |
claim_strategy | ISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .claimStrategy or "N/A" if not having claim strategy | The claim strategy used by threads inputing events to the disruptor. |
wait_strategy | ISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .waitStrategy or "N/A" if not having wait strategy | The wait strategy used by thread processing events in the disruptor. |
xvm.heartbeats.logger.latencies
Description: Latency of events passing in the application message logger disruptor.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "OfferToPoll". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .offerToPollLatencies | Measures latency of events passing in the message logger disruptor. |
For the list of fields for histogram data see Integer Histogram Data Points
pools
Description: Object pool stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | ISrvMonHeartbeatMessage .poolStats[i] .key | The name of the pool. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .poolStats[i] .capacity | The current number of slots in the pool to hold elements that are not in use. |
detached_washes | ISrvMonHeartbeatMessage .poolStats[i] .detachedWashes | The number of elements initialized by the detached pool washer thread. |
evicts | ISrvMonHeartbeatMessage .poolStats[i] .evicts | The number of elements that have been evicted from the pool because the pool doesn't have capcity. |
gets | ISrvMonHeartbeatMessage .poolStats[i] .gets | The number of times an element has been requested from the pool. |
growths | ISrvMonHeartbeatMessage .poolStats[i] .growths | The number of times the pool capacity has been increased to accomodate free elements. |
hits | ISrvMonHeartbeatMessage .poolStats[i] .hits | The number of times an element has been requested from the pool without needing to allocate a new object. |
misses | ISrvMonHeartbeatMessage .poolStats[i] .misses | The number of times an element has been requested from the pool which required allocating a new object. |
preallocated | ISrvMonHeartbeatMessage .poolStats[i] .preallocated | The number of elements initially preallocated in the pool. |
puts | ISrvMonHeartbeatMessage .poolStats[i] .puts | The number of times an element has been put (returned) to the pool. |
size | ISrvMonHeartbeatMessage .poolStats[i] .size | The number of elements currently available in the pool to satisfy gets. |
application
Description: XVM application information.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
version | ISrvMonHeartbeatMessage .appsInfo[i] .version | The application version if (if specified/known). Typically this will come from the app's @AppVersion. |
role | ISrvMonHeartbeatMessage .appsInfo[i] .role | The application's current HA role, or "N/A". |
ha_policy | ISrvMonHeartbeatMessage .appsInfo[i] .haPolicy | The application's HAPolicy, or "N/A". |
state | ISrvMonHeartbeatMessage .appsInfo[i] .state | The application's current state. |
loaded_time | ISrvMonHeartbeatMessage .appsInfo[i] .loadedTimeAsTimestamp | The time at which the app was last loaded if applicable. |
jar_version | ISrvMonHeartbeatMessage .appsInfo[i] .jarVersionString | The jar version of the application (if specified/known). |
bindings | Length of ISrvMonHeartbeatMessage .appsInfo[i] .busBindingsInfo | The jar version of the application (if specified/known). |
clients | Length of ISrvMonHeartbeatMessage .appsInfo[i] .clientsInfo | Count of application's connected clients. |
flows | Length of ISrvMonHeartbeatMessage .appsInfo[i] .flowsInfo | Count of application's active message flows. |
application.disruptor
Description: Disruptor stats for the XVM application.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .capacity | The size of the disruptor's ringbuffer. |
remaining | ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .remaining | The number of free ringbuffer slots. |
used | {capacity} - {remaining} | The number of used ringbuffer slots. |
claim_strategy | ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .claimStrategy or "N/A" if not having claim strategy | The claim strategy used by threads inputing events to the disruptor. |
wait_strategy | ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .waitStrategy or "N/A" if not having wait strategy | The wait strategy used by thread processing events in the disruptor. |
application.disruptor.latencies
Description: Latency of events passing in the XVM application disruptor.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
app_name | ISrvMonHeartbeatMessage .appsStats[i] .name | XVM application name. |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .offerToPollLatencies | Measures latency of events passing in the application disruptor. |
For the list of fields for histogram data see Integer Histogram Data Points
application.multiplexer
Description: Stats for the XVM application's multiplexer.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
last_decongested | ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .lastDecongested | The last feeder queue decongested. |
max_concurrency | ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .maxConcurrency | The maximum number of feeder queue supported by the multiplexer. |
schedule_queue_size | ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .scheduleQueueSize | The number of scheduled events awaiting dispatch. |
application.events
Description: Application Engine event stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
rcvd | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numEventsRcvd | The number of events received by the engine. |
proc | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numEventsProcessed | The number of events processed by the engine. |
application.flows
Description: Application Engine flow stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
count | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlows | The number of active flows in the application. |
application.messages
Description: Application Engine message summary stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
in_best_effort | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsRcvdBestEffort | The number of best effort messages the application has received. |
in_guaranteed | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsRcvdGuaranteed | The number of guaranteed messages the application has received. |
in_proc_complete | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsProcComplete | The number of flow related events that have been completely processed by the engine. |
in_proc_fail | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsProcFail | The number of flow related events unsuccessfully processed by the engine. |
in_proc_success | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsProcSuccess | The number of flow related events successfully processed by the engine. |
in_dups | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numDupMsgsRcvd | The number of duplicate messages the application has received. |
in_filtered | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsFiltered | The number of messages that were filtered. |
in_sourced | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsSourced | The number of messages that were sourced. |
in_value | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsRcvd | The number of flow related events processed by the engine. |
out_best_effort | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsSentBestEffort | The number of best effort messages sent by the application. |
out_guaranteed | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsSentGuaranteed | The number of guaranteed messages sent by the application. |
out_resent | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsResent | The number of messages the application has retransmitted. |
out_sno | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundSno | The current outbound sequence number for the engine. |
out_stable_sno | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundStableSno | The current stable outbound sequence number for the engine. |
out_value | out_guaranteed + out_best_effort | Total messages sent by the application. |
application.transaction
Description: Application Engine transaction stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
count | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numTransactions | The number of transactions created by the engine. |
started | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numCommitsStarted | The number of transaction commits started by the engine. |
completed | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numCommitsCompleted | The number of transaction commits completed by the engine. |
rollbacks | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numRollbacks | The number of transactions that have been rolled back. |
inflight | started - completed | The number of in-flight transaction commits. |
store_commits_started | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numStoreCommitsStarted | The number of store commits started by the engine. |
store_commits_completed | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numStoreCommitsCompleted | The number of store commits completed by the engine. |
store_commit_queue_completion_size | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .storeCommitCompletionQueueSize | The number of store commits pending completion for the engine. |
send_commits_started | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numSendCommitsStarted | The number of send (message bus) commits started by the engine. |
send_commits_completed | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numSendCommitsCompleted | The number of send (message bus) commits completed by the engine. |
send_commit_queue_completion_size | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .sendCommitCompletionQueueSize | The number of send commits pending completion. |
events_per_commit | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsProcComplete - ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numCommitsStarted | Number of events per commit. |
application.messages.type
Description: Application Engine message stats per message type.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
msg_id | "{msg_name}_{msg_factory_id}_{msg_type_id}" See Fields table. | Message type ID. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
msg_name | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeName | The fully qualified name of the message type. |
msg_factory_id | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .getMessageFactoryId | The factory id for the message type (unique within the application). |
msg_type_id | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeId | The message type id within its factory (unique within the type's factory). |
in_dups | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numDupMsgsRcvd | The number of duplicate messages the application has received. |
in_filtered | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsFiltered | The number of messages that were filtered. |
in_best_effort | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsRcvdBestEffort | The number of best effort messages the application has received. |
in_guaranteed | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsRcvdGuaranteed | The number of guaranteed messages the application has received. |
in_sourced | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsSourced | The number of messages that were sourced. |
out_best_effort | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsSentBestEffort | The number of best effort messages sent by the application. |
out_guaranteed | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsSentGuaranteed | The number of guaranteed messages sent by the application. |
out_resent | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsResent | The number of messages the application has retransmitted. |
application.messages.type.latencies (MsgProcessing)
Description: Application Engine message latency stats per message type.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
msg_id | "{msg_name}_{msg_factory_id}_{msg_type_id}" See Fields table. | Message type ID. |
name | N/A | Always set to "MsgProcessing". |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
msg_name | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeName | The fully qualified name of the message type. |
msg_factory_id | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .getMessageFactoryId | The factory id for the message type (unique within the application). |
msg_type_id | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeId | The message type id within its factory (unique within the type's factory). |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .msgProcessingLatencies | Latencies for application message process times (in an EventHandler) (aka 'mproc'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.messages.type.latencies (MsgFiltering)
Description: Application Engine message latency stats per message type.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
msg_id | "{msg_name}_{msg_factory_id}_{msg_type_id}" See Fields table. | Message type ID. |
name | N/A | Always set to "MsgFiltering". |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
msg_name | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeName | The fully qualified name of the message type. |
msg_factory_id | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .getMessageFactoryId | The factory id for the message type (unique within the application). |
msg_type_id | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeId | The message type id within its factory (unique within the type's factory). |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .msgFilteringLatencies | Records latencies for application message filtering times (by a message filter) (aka 'mfilt'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.backup
Description: Application engine backup queue stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
outbound_queue_size | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .backupOutboundQueueSize | Number of messages in backup outbound queue. |
outbound_log_queue_size | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .backupOutboundLogQueueSize | Number of messages in backup outbound loq queue. |
application.transaction.latencies (CommitEpilogue)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "CommitEpilogue". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitEpilogueLatencies | Time spent from the point the store or send commit completes, whichever is last, to commit completion (aka 'cepilo'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (CommitFull)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "CommitFull". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitFullLatencies | Time spent from the time the first message of a transaction is received to commit completion (aka 'cfull'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (CommitPrologue)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "CommitPrologue". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitPrologueLatencies | Time spent from the point where transaction commit is started to send or store commit whichever is first (aka 'cprolo'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (CommitSend)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "CommitSend". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitSendLatencies | Time spent for send commits to complete i.e. time from when send commit is initiated to receipt of send completion event (aka 'csend'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (CommitStart)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "CommitStart". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitStartLatencies | Time spent from the point the first message of a transaction is received to the time the transaction is committed (aka 'cstart'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (CommitStore)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "CommitStore". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitStoreLatencies | Time spent in store commit i.e. time from when store commit is initiated to receipt of store completion event (aka 'cstore'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (CommitTransition)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "CommitTransition". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitTransitionLatencies | Time spent from the point the store or send commit completes, whichever is first to the start of next stage - send or commit (aka 'ctrans'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (InAck)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "InAck". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inAckLatencies | Records latencies for receipt of a message to stabilization (and upstream acknowledgement for Guaranteed) (aka 'inack'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (InOut)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "InOut". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inOutLatencies | Records latencies for receipt of a message to transmission of the last outbound message (aka 'inout'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (MsgFiltering)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "MsgFiltering". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgFilteringLatencies | Records latencies for application message filtering times (by a message filter) (aka 'mfilt'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (MsgPreProc)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "MsgPreProc". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgPreProcLatencies | Records the time (in microseconds) spent by the engine dispatching the message to an application (aka 'mpproc'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (MsgProcessing)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "MsgProcessing". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgProcessingLatencies | Records latencies for application message process times (in an EventHandler) (aka 'mproc'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (MsgSendCore)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "MsgSendCore". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgSendCoreLatencies | Time spent in AepEngine.sendMessageCore() (aka 'msendc'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (MsgSend)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "MsgSend". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgSendLatencies | Time spent in AepEngine.sendMessage() (aka 'msend'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (TransactionLeg1)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "TransactionLeg1". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .transactionLeg1ProcessingTimes | Records latencies for the first transaction processing leg. |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (TransactionLeg2)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "TransactionLeg2". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .transactionLeg2ProcessingTimes | Records latencies for the second transaction processing leg. |
For the list of fields for histogram data see Integer Histogram Data Points
application.transaction.latencies (TransactionLeg3)
Description: Application Engine transaction latencies.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "TransactionLeg3". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .transactionLeg3ProcessingTimes | Transaction Leg Three includes time spent from the point where the store/store commit completion is received to the completion of the transaction commit (aka 'tleg3'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.messagelogger.inbound
Description: Application inbound message logger general stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
detached | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .detachedPersist | Indicates if the message logger is operating in detached mode. |
commits | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .numCommits | The number of commits to the message logger. |
forks | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .numForks | The number of forked message packets persisted. |
messages | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .numMessagesRecorded | The number of messages persisted by the message logger. |
file_size | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .fileSize | The size of the file on disk. |
file_size_used | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .fileSizeUsed | The size of the allocated log file used in bytes. |
application.messagelogger.inbound.disruptor
Description: Application inbound message logger disruptor stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .capacity | The size of the diruptor's ringbuffer. |
remaining | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .remaining | The number of free ringbuffer slots. |
used | {capacity} - {remaining} | The number of used ringbuffer slots. |
claim_strategy | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .claimStrategy | The claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable. |
wait_strategy | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .waitStrategy | The wait strategy used by thread processing events in the disruptor, or "N/A" if not applicable. |
application.messagelogger.inbound.latencies
Description: Application inbound message logger latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "OfferToPoll". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .offerToPollLatencies | Measures latency of events passing in the disruptor. |
For the list of fields for histogram data see Integer Histogram Data Points
application.messagelogger.outbound
Description: Application outbound message logger general stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
detached | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .detachedPersist | Indicates if the message logger is operating in detached mode. |
commits | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .numCommits | The number of commits to the message logger. |
forks | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .numForks | The number of forked message packets persisted. |
messages | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .numMessagesRecorded | The number of messages persisted by the message logger. |
file_size | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .fileSize | The size of the file on disk. |
file_size_used | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .fileSizeUsed | The size of the allocated log file used in bytes. |
application.messagelogger.outbound.disruptor
Description: Application outbound message logger disruptor stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .capacity | The size of the diruptor's ringbuffer. |
remaining | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .remaining | The number of free ringbuffer slots. |
used | {capacity} - {remaining} | The number of used ringbuffer slots. |
claim_strategy | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .claimStrategy | The claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable. |
wait_strategy | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .waitStrategy | The wait strategy used by thread processing events in the disruptor, or "N/A" if not applicable. |
application.messagelogger.outbound.latencies
Description: Application outbound message logger latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "OfferToPoll". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .offerToPollLatencies | Measures latency of events passing in the disruptor. |
For the list of fields for histogram data see Integer Histogram Data Points
application.pertransactionstats.logger
Description: Application per transaction logger stats general.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
detached | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .detachedPersist | Indicates if the message logger is operating in detached mode. |
commits | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .numCommits | The number of commits to the message logger. |
forks | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .numForks | The number of forked message packets persisted. |
messages | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .numMessagesRecorded | The number of messages persisted by the message logger. |
file_size | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .fileSize | The size of the file on disk. |
file_size_used | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .fileSizeUsed | The size of the allocated log file used in bytes. |
application.pertransactionstats.logger.disruptor
Description: Application per transaction logger disruptor stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .capacity | The size of the diruptor's ringbuffer. |
remaining | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .remaining | The number of free ringbuffer slots. |
used | {capacity} - {remaining} | The number of used ringbuffer slots. |
claim_strategy | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .claimStrategy | The claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable. |
wait_strategy | ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .waitStrategy | The wait strategy used by thread processing events in the disruptor, or "N/A" if not applicable. |
application.pertransactionstats.logger.latencies
Description: Application per transaction logger latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "OfferToPoll". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .offerToPollLatencies | Measures latency of events passing in the disruptor. |
For the list of fields for histogram data see Integer Histogram Data Points
application.store
Description: Application store general stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
state | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .state | The store state if applicable, else "N/A". |
role | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .role | The HA Role for the store if applicable, else "N/A". |
icr_role | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRRole | The store's ICR Role. |
size | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .size | The number of objects in the store. |
data_size | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .dataSize | The total size of serialized object data held by the store. |
commit_completions_received | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitCompletionsReceived | The number of commit acknowledgements received by this store member from followers. |
commit_completions_sent | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitCompletionsSent | The number of commit acknowledgements sent by this store member to the leader. |
commit_entries_rcvd | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitEntriesReceived | The number of committed entries replicated to this store. |
commit_entries_sent | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitEntriesSent | The number of committed entries replicated by the store. |
commit_commits_rcvd | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitsReceived | The number of committed transactions replicated to this store. |
commit_commits_sent | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitsSent | The number of committed transactions replicated by the store. |
application.store.latencies (CommitQueueSize)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "CommitQueueSize". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .commitQueueSize | The number of entries commited per commit (aka 'cqs'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (Commit)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "Commit". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .commitLatencies | Latencies statistics for transaction commit (aka 'c'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (Deserialize)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "Deserialize". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .deserializeLatencies | The time spent deserializing a transactions entries (by a backup store member) (aka 'd'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (IcrSend)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "IcrSend". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .icrSendLatencies | The amount of time spent sending transaction entries through an ICR receiver (aka 'icr'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (Index)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "Index". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .indexLatencies | Latencies statistics for store object indexing (if enabled) (aka 'idx'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (Persist)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "Persist". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persistLatencies | The amount of time spent persisting transaction entries to disk (aka 'per'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (Serialize)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "Serialize". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .serializeLatencies | The amount of time spent serializing transaction entries in preparation of replication / and persistence (aka 's'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (SerializeToPersist)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "SerializeToPersist". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .serializeToPersistLatencies | The time between serializing transaction entries to the time that entries have been passed to the persister for write to disk (but not yet synced) (aka 's2p'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (SerializeToWire)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "SerializeToWire". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .serializeToWireLatencies | The time between serializing transaction entries to the last entry being written to the wire (but not stabilized) for replication (aka 's2w'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (Wire)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "Wire". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .wireLatencies | The round trip time on the wire from when the last commit entry is written to the last commit entry be read from the wire (aka 'w'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.latencies (WireToDeserialize)
Description: Application Store latency stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "WireToDeserialize". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .wireToDeserializeLatencies | The time between receipt of a commit packet to the point at which deserialization of the entries has started (by a backup store member) (aka 'w2d'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.persister
Description: Application store persister general stats.
Fields
application.store.persister.disruptor
Description: Application store persister disruptor stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .capacity | The size of the diruptor's ringbuffer. |
remaining | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .remaining | The number of free ringbuffer slots. |
used | {capacity} - {remaining} | The number of used ringbuffer slots. |
claim_strategy | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .claimStrategy | The claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable. |
wait_strategy | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .waitStrategy | The wait strategy used by thread processing events in the disruptor, or "N/A" if not applicable. |
application.store.persister.latencies
Description: Application store persister disruptor latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "OfferToPoll". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .offerToPollLatencies | Measures latency of events passing in the disruptor. |
For the list of fields for histogram data see Integer Histogram Data Points
application.store.icr_sender
Description: Application store ICR sender general stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
detached | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .detachedPersist | Indicates if the sender is operating in detached mode. |
commits | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numCommits | The number of commits recorded by the sender. |
puts | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numPutsRecorded | The number of puts recorded by the sender. |
removes | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numRemovesRecorded | The number of removes recorded by the sender. |
sends | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numSendsRecorded | The number of sends recorded by the sender. |
updates | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numUpdatesRecorded | The number of updates recorded by the sender. |
application.store.icr_sender.disruptor
Description: Application ICR Sender disruptor stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .capacity | The size of the diruptor's ringbuffer. |
remaining | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .remaining | The number of free ringbuffer slots. |
used | {capacity} - {remaining} | The number of used ringbuffer slots. |
claim_strategy | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .claimStrategy | The claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable. |
wait_strategy | ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .waitStrategy | The wait strategy used by thread processing events in the disruptor, or "N/A" if not applicable. |
application.store.icr_sender.latencies
Description: Application ICR Sender disruptor latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | N/A | Always set to "OfferToPoll". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .offerToPollLatencies | Measures latency of events passing in the disruptor. |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus
Description: Application bus general stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
internal | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .internal | Indicates if this is an internal bus. |
detached_commmit | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .detachedCommit | If the bus binding is operating in detached mode. |
commits | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numCommits | The number transactions committed by the bus. |
rollbacks | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numRollbacks | The number transactions rolled back for the bus. |
failures | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numBindingFailures | The number of binding failures that have occurred for this bus. |
channels_up | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numChannelsUp | The number of channels brought up by this bus. |
clients | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numClients | The number of connected clients (if applicable). |
msgs_rcvd | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsRcvd | The number of messages received by the bus. |
msgs_sent | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsSent | The total number of batch messages enqueued message that were actually sent by the bus. |
stability_rcvd | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numStabilityRcvd | The number of stability events (acks) received by this bus. |
msgs_enqueued | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsEnqueued | The total number of batch messages enqueued for delivery by this bus. |
msgs_flushed_async | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsFlushedAsync | The number of messages flushed by asynchronous flushes. |
msgs_flushed_sync | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsFlushedSync | The number of messages flushed by synchronous flushes. |
async_flush_completions | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numAsyncFlushCompletions | The number of asynchronous flushes for this that have completed. |
async_flushes | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numFlushesAsync | The number of times this bus has been asynchronously flushed. |
sync_flushes | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numFlushesSync | The number of times this bus has been synchronously flushed. |
rcvd_batches | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgBatchesRcvd | The number of batch messages received by the bus. |
rcvd_batch_msgs | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsInBatchesRcvd | The number of messages received by the bus that were part of a batch. |
acks_sent | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numAcksSent | The number of inbound messages acknowledged by the bus. |
packets_rcvd | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numPacketsRcvd | The number of raw packets received by the bus. |
stability_batches_rcvd | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numStabilityBatchesRcvd | The number of batched stability events received by this bus. |
stability_rcvd_in_batches | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numStabilityInBatchesRcvd | The number of stability events received by this bus that were part of a stability batch. |
application.bus.disruptor
Description: Application bus disruptor stats.
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
capacity | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .capacity | The size of the diruptor's ringbuffer. |
remaining | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .remaining | The number of free ringbuffer slots. |
used | {capacity} - {remaining} | The number of used ringbuffer slots. |
claim_strategy | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .claimStrategy | The claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable. |
wait_strategy | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .waitStrategy | The wait strategy used by thread processing events in the disruptor, or "N/A" if not applicable. |
application.bus.disruptor.latencies
Description: Application bus disruptor latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "OfferToPoll". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .offerToPollLatencies | Measures latency of events passing in the disruptor. |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (CreateToSend)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "CreateToSend". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .createToSendLatencies | The create to send latencies in microseconds, the time in microseconds from message creation to when send was called for it (aka 'c2o'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (Deserialize)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "Deserialize". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .deserializeLatencies | The time (in microseconds) spent deserializing the message and wrapping it in a MessageView (aka: 'd'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (DeserializeToReceive)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "DeserializeToReceive". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .deserializeToReceiveLatencies | The time (in microseconds) from when the message was deserialized to when it is received by the engine (aka: 'd2i'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (OriginToReceive)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "OriginToReceive". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .originToReceiveLatencies | The origin to receive latencies in microseconds (aka: 'o2i'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (SendToSerialize)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "SendToSerialize". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .sendToSerializeLatencies | The send to serialize latencies in microseconds, the time from when the message send is started until it was serialized in preparation for transmission on the wire (aka: 'o2s'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (Serialize)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "Serialize". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .serializeLatencies | The serialize latencies in microseconds, the spent serializing the MessageView to its transport encoding (aka: 's'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (SerializeToWire)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "SerializeToWire". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .serializeToWireLatencies | The serialize to wire latencies in microseconds, the time post deserialize to when just before the message is written to the wire (aka: 's2w'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (Wire)
Description: Application bus wire latency stats
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "Wire". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .wireLatencies | The wire latencies in microseconds, the time spent by the message bus provider writing the message to the wire. (aka: 'w'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (WireSend)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "WireSend". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .wireSendLatencies | The wire send latencies in microseconds, the time spent by the message bus provider writing the message to the wire. (aka: 'ws'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (WireToDeserialize)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "WireToDeserialize". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .wireToDeserializeLatencies | The time from when the serialized form was received from the wire to deserialization (aka: 'w2d'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.bus.latencies (WireToWire)
Description: Application bus latencies stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
bus_name | ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingName | The name of the bus. |
name | N/A | Always set to "WireToWire". |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .wireToWireLatencies | The wire to wire latencies in microseconds, for outbound messages the time from when the corresponding inbound message was received off of the wire to when the outbound message was written to the wire. (aka: 'w2w'). |
For the list of fields for histogram data see Integer Histogram Data Points
application.user.gauge
Description: User-defined gauge stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | ISrvMonHeartbeatMessage .appsStats[i] .userStats .gauges[i] .name | Gauge name. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
numeric_value | N/A | Gauges of type Byte, Short, Integer, Long, Float, and Double are written to this field |
string_value | N/A | String representation of the gauge value. Gauges of type String, Char, and Boolean are any other type are written to this field. |
value | Deprecated Prior to version 1.3 numeric values were written to this field. |
application.user.counter
Description: User-defined counter stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | ISrvMonHeartbeatMessage .appsStats[i] .userStats .counters[i] .name | Counter name. |
Fields
Field Name | Java Type Mapping | Description |
---|---|---|
value | ISrvMonHeartbeatMessage .appsStats[i] .userStats .counters[i] .count | The counter value. |
application.user.series
Description: User-defined series stats.
Tags
Tag Name | Java Type Mapping | Description |
---|---|---|
name | ISrvMonHeartbeatMessage .appsStats[i] .userStats .series[i] .name | Series name. |
Histogram Data
Java Type Mapping | Description |
---|---|
ISrvMonHeartbeatMessage .appsStats[i] .userStats .series[i] .intSeries | The user-defined series values. |
For the list of fields for histogram data see Integer Histogram Data Points