The Lumino Manua (v1.6)

Skip to end of metadata
Go to start of metadata

You are viewing an old version of this page. View the current version.

Compare with Current View Page History

« Previous Version 5 Current »

In This Section

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

Lumino Agent receives X Platform messages from running Talon XVMs which are then processed and written into Lumino storage.

Types of Stats

Stats can be built-in platform stats or user-defined stats defined in application code. See more info in the Monitoring and Stats section of the Talon Manual. Stats can be one of Gauge, Counter, or Histogram data. Gauges measure last instantaneous value of some piece of data. Counters measures number of events up to a point, and Histogram contains not just the value at the moment of taking the sample, but also various statistical computations performed on it for a period of time - such as mean and median value, etc. More details on Histogram data can be found below.

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 NameJava Type MappingDescription
pointsISrvMonIntSeries .numDataPointsThe number of data points collected in this interval.
skippedISrvMonIntSeries .skippedDatapointsThe number of data points skipped due to undersampling.
snoISrvMonIntSeries .lastSequenceNumberThe sequence number of the last data point collected or 0 if no data points have been collected.
sampleISrvMonIntSeries .intervalStats .sampleSizeThe number of datapoints over which results were calculated. (For sampling interval)
minISrvMonIntSeries .intervalStats .minimumThe minimum value recorded in the sample set. (For sampling interval )
maxISrvMonIntSeries .intervalStats .maximumThe maximum value recorded in the sample set. (For sampling interval )
meanISrvMonIntSeries .intervalStats .meanThe mean value for the sample set. (For sampling interval )
medianISrvMonIntSeries .intervalStats .medianThe median value for the sample set. (For sampling interval )
pct75ISrvMonIntSeries .intervalStats .pct75The 75th percentile for the sample set. (For sampling interval )
pct90ISrvMonIntSeries .intervalStats .pct90The 90th percentile for the sample set. (For sampling interval )
pct99ISrvMonIntSeries .intervalStats .pct99The 99th percentile for the sample set. (For sampling interval )
pct999ISrvMonIntSeries .intervalStats .pct999The 99.9th percentile for the sample set. (For sampling interval )
pct9999ISrvMonIntSeries .intervalStats .pct9999The 99.99th percentile for the sample set. (For sampling interval )
running_sampleISrvMonIntSeries .runningStats .sampleSizeThe number of datapoints over which results were calculated.  (For XVM running interval)
running_minISrvMonIntSeries .runningStats .minimumThe minimum value recorded in the sample set. (For XVM running interval)
running_maxISrvMonIntSeries .runningStats .maximumThe maximum value recorded in the sample set.  (For XVM running interval)
running_meanISrvMonIntSeries .runningStats .meanThe mean value for the sample set.  (For XVM running interval)
running_medianISrvMonIntSeries .runningStats .medianThe median value for the sample set.  (For XVM running interval)
running_pct75ISrvMonIntSeries .runningStats .pct75The 75th percentile for the sample set.  (For XVM running interval)
running_pct90ISrvMonIntSeries .runningStats .pct90The 90th percentile for the sample set.  (For XVM running interval)
running_pct99ISrvMonIntSeries .runningStats .pct99The 99th percentile for the sample set.  (For XVM running interval)
running_pct999ISrvMonIntSeries .runningStats .pct999The 99.9th percentile for the sample set.  (For XVM running interval)
running_pct9999ISrvMonIntSeries .runningStats .pct9999The 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 NameJava Type MappingDescription
 host_nameISrvMonHeartbeatMessage .serverHostNameThe server's hostname.
vm_nameISrvMonHeartbeatMessage .serverNameThe name of the Talon server.
system_nameISrvMonHeartbeatMessage .systemNameThe name of the Talon system to which the server belongs.


Fields

Field NameJava Type MappingDescription
system_versionISrvMonHeartbeatMessage.systemVersionThe 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 NameJava Type MappingDescription
app_nameISrvMonAppInfo .nameThe application's name.
app_stateISrvMonAppInfo .stateThe application's current state.
app_roleISrvMonAppInfo .roleThe application's current HA role.
app_ha_policyISrvMonAppInfo .HAPolicyThe application's HAPolicy.

 

Measurements

client.admin

Description: Holds stats for a connected admin client.

Tags

Tag NameJava Type MappingDescription
nameISrvMonHeartbeatMessage .adminClientStats[i] .nameName of the admin client

 

Fields

Field NameJava Type MappingDescription
lifecyclesSentISrvMonHeartbeatMessage .adminClientStats[i] .lifecyclesSentThe number of lifecycle events sent to the client.
heartbeatsSentISrvMonHeartbeatMessage .adminClientStats[i] .heartbeatsSentThe number of heartbeats sent to the client.
heartbeatsDroppedISrvMonHeartbeatMessage .adminClientStats[i] .heartbeatsDroppedThe number of heartbeats dropped due to congestion.
outboundQueueCapacityISrvMonHeartbeatMessage .adminClientStats[i] .outboundQueueCapacityThe capacity, in bytes, of the client's outbound queue.
outboundQueueSizeISrvMonHeartbeatMessage .adminClientStats[i] .outboundQueueSizeThe size, in bytes, of the client's outbound queue.
outboundQueueCountISrvMonHeartbeatMessage .adminClientStats[i] .outboundQueueCountThe 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 NameJava Type MappingDescription
jit_nameISrvMonHeartbeatMessage .sysStats .jitStats .nameThe name of the Just-in-time (JIT) compiler in use.

 

Fields

Field NameJava Type MappingDescription
xvm_loaded_timeISrvMonHeartbeatMessage .loadedTimeAsTimestampThe timestamp when server loaded.
processorsISrvMonHeartbeatMessage .sysStats .availableProcessorsNumber of processors available to JVM.
load_averageISrvMonHeartbeatMessage .sysStats .systemLoadAverageSystem load average in the last minute.
process_cpu_loadISrvMonHeartbeatMessage .sysStats .processCpuLoadHolds recent CPU usage by the XVM process (on a 0.0 to 1.0 scale).
system_cpu_loadISrvMonHeartbeatMessage .sysStats .systemCpuLoadHolds recent CPU usage by the system (on a 0.0 to 1.0 scale).
threads_countISrvMonHeartbeatMessage .sysStats .threadStats .threadCountThe number of active threads in the system.
threads_daemon_countISrvMonHeartbeatMessage .sysStats .threadStats .daemonThreadCountThe number of active daemon threads in the system.
threads_peak_countISrvMonHeartbeatMessage .sysStats .threadStats .peakThreadCountThe peak number of threads observed in the system.
jit_timeISrvMonHeartbeatMessage .sysStats .jitStats .totalCompilationTimeThe commulative time spent in JIT compilation (in milliseconds).
gc_countSUM( ISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectionCount )The total number of garbage collections that have occurred.
gc_timeSUM( ISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectionTime )The approximate accumulated collection elapsed time in milliseconds.
memory_heap_initISrvMonHeartbeatMessage .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_usedISrvMonHeartbeatMessage .sysStats .memoryStats .heapUsage .usedThe amount of used heap memory in bytes.
memory_heap_committedISrvMonHeartbeatMessage .sysStats .memoryStats .heapUsage .committedThe 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_maxISrvMonHeartbeatMessage .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_initISrvMonHeartbeatMessage .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_usedISrvMonHeartbeatMessage .sysStats .memoryStats .nonHeapUsage .usedThe amount of used off-heap memory in bytes.
memory_non_heap_committedISrvMonHeartbeatMessage .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_maxISrvMonHeartbeatMessage .sysStats .memoryStats .nonHeapUsage .maxThe maximum off-heap memory size in bytes.
memory_physical_size_totalISrvMonHeartbeatMessage .sysStats .memoryStats .totalPhysicalMemorySizeThe total amount of physical memory in bytes.
memory_physical_size_freeISrvMonHeartbeatMessage .sysStats .memoryStats .freePhysicalMemorySizeThe amount of free physical memory in bytes.
memory_swap_size_totalISrvMonHeartbeatMessage .sysStats .memoryStats .totalSwapSpaceSizeThe total amount of swap space in bytes.
memory_swap_size_freeISrvMonHeartbeatMessage .sysStats .memoryStats .freeSwapSpaceSizeThe amount of free swap space in bytes.

 

system.disk

Description: Stats on disk usage.

Tags

Tag NameJava Type MappingDescription
disk_rootISrvMonHeartbeatMessage .sysStats .diskStats[i] .rootPathRoot path where disk is mounted in the operating system.

 

Fields

Field NameJava Type MappingDescription
disk_total_spaceISrvMonHeartbeatMessage .sysStats .diskStats[i] .totalSpaceThe size, in bytes, of the partition.
disk_usable_spaceISrvMonHeartbeatMessage .sysStats .diskStats[i] .usableSpaceThe number of bytes available to the XVM for the disk or partition.
disk_free_spaceISrvMonHeartbeatMessage .sysStats .diskStats[i] .freeSpaceFree space in bytes for the disk or partition.

 

system.threads

Description: Stats per XVM thread.

Tags

Tag NameJava Type MappingDescription
idISrvMonHeartbeatMessage .sysStats .threadStats[i] .idThread ID.

 

Fields

Field NameJava Type MappingDescription
idISrvMonHeartbeatMessage .sysStats .threadStats[i] .idThread ID.
nameISrvMonHeartbeatMessage .sysStats .threadStats[i] .nameThread name.
stateISrvMonHeartbeatMessage .sysStats .threadStats[i] .stateLast thread state when heartbeat occurred.
cpu_timeISrvMonHeartbeatMessage .sysStats .threadStats[i] .cpuTimeThe CPU time used by the thread (in nanoseconds).
usr_timeISrvMonHeartbeatMessage .sysStats .threadStats[i] .usrTimeThe cpu time user time used by the thread (in nanoseconds).
collect_timeISrvMonHeartbeatMessage .sysStats .threadStats[i] .collectTimeThe time in nanoseconds just after cpu times were collected.
affinityISrvMonHeartbeatMessage .sysStats .threadStats[i] .affinityAffinitization details for the thread (if affinitized).
wait_countISrvMonHeartbeatMessage .sysStats .threadStats[i] .waitCountThe number of times the thread was recorded as waiting.
wait_timeISrvMonHeartbeatMessage .sysStats .threadStats[i] .waitTimeThe time in nanoseconds spent waiting for events.

 

system.gc

Description: Stats per GC.

Tags

Tag NameJava Type MappingDescription
collector_nameISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectorNameThe name of the collector that performed the gc.

 

Fields

Field NameJava Type MappingDescription
num_collectionsISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectionCountThe total number of collections that have occurred.
cum_timeISrvMonHeartbeatMessage .sysStats .gcStats .collectorsStats[i] .collectionTimeThe approximate accumulated collection elapsed time in milliseconds.

 

xvm.heartbeats.logger

Description: General stats for the application message logger.

Fields

Field NameJava Type MappingDescription
detachedISrvMonHeartbeatMessage .heartbeatLoggerStats .detachedPersistIndicates if the message logger is operating in detached mode.
commitsISrvMonHeartbeatMessage .heartbeatLoggerStats .numCommitsThe number of commits to the message logger.
forksISrvMonHeartbeatMessage .heartbeatLoggerStats .numForksThe number of forked message packets persisted.
messagesISrvMonHeartbeatMessage .heartbeatLoggerStats .numMessagesRecordedThe number of messages persisted by the message logger.
file_sizeISrvMonHeartbeatMessage .heartbeatLoggerStats .fileSizeThe size of the allocated log file in bytes.
file_size_usedISrvMonHeartbeatMessage .heartbeatLoggerStats .fileSizeUsedThe size of the allocated log file used in bytes.

 

xvm.heartbeats.logger.disruptor

Description: Disruptor stats for the application message logger.

Fields

Field NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .capacityThe size of the disruptor's ringbuffer.
remainingISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .remainingThe number of free ringbuffer slots.
used{capacity} - {remaining}The number of used ringbuffer slots.
claim_strategyISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .claimStrategy or "N/A" if not having claim strategyThe claim strategy used by threads inputing events to the disruptor.
wait_strategyISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .waitStrategy or "N/A" if not having wait strategyThe 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 NameJava Type MappingDescription
nameN/AAlways set to "OfferToPoll".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .heartbeatLoggerStats .disruptorStats .offerToPollLatenciesMeasures 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 NameJava Type MappingDescription
nameISrvMonHeartbeatMessage .poolStats[i] .keyThe name of the pool.

 

Fields

Field NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .poolStats[i] .capacityThe current number of slots in the pool to hold elements that are not in use.
detached_washesISrvMonHeartbeatMessage .poolStats[i] .detachedWashesThe number of elements initialized by the detached pool washer thread.
evictsISrvMonHeartbeatMessage .poolStats[i] .evictsThe number of elements that have been evicted from the pool because the pool doesn't have capcity.
getsISrvMonHeartbeatMessage .poolStats[i] .getsThe number of times an element has been requested from the pool.
growthsISrvMonHeartbeatMessage .poolStats[i] .growthsThe number of times the pool capacity has been increased to accomodate free elements.
hitsISrvMonHeartbeatMessage .poolStats[i] .hitsThe number of times an element has been requested from the pool without needing to allocate a new object.
missesISrvMonHeartbeatMessage .poolStats[i] .missesThe number of times an element has been requested from the pool which required allocating a new object.
preallocatedISrvMonHeartbeatMessage .poolStats[i] .preallocatedThe number of elements initially preallocated in the pool.
putsISrvMonHeartbeatMessage .poolStats[i] .putsThe number of times an element has been put (returned) to the pool.
sizeISrvMonHeartbeatMessage .poolStats[i] .sizeThe number of elements currently available in the pool to satisfy gets.

 

application

Description: XVM application information.

Fields

Field NameJava Type MappingDescription
versionISrvMonHeartbeatMessage .appsInfo[i] .versionThe application version if (if specified/known). Typically this will come from the app's @AppVersion.
roleISrvMonHeartbeatMessage .appsInfo[i] .roleThe application's current HA role, or "N/A".
ha_policyISrvMonHeartbeatMessage .appsInfo[i] .haPolicyThe application's HAPolicy, or "N/A".
stateISrvMonHeartbeatMessage .appsInfo[i] .stateThe application's current state.
loaded_timeISrvMonHeartbeatMessage .appsInfo[i] .loadedTimeAsTimestampThe time at which the app was last loaded if applicable.
jar_versionISrvMonHeartbeatMessage .appsInfo[i] .jarVersionStringThe jar version of the application (if specified/known).
bindingsLength of ISrvMonHeartbeatMessage .appsInfo[i] .busBindingsInfoThe jar version of the application (if specified/known).
clientsLength of ISrvMonHeartbeatMessage .appsInfo[i] .clientsInfoCount of application's connected clients.
flowsLength of ISrvMonHeartbeatMessage .appsInfo[i] .flowsInfoCount of application's active message flows.

 

application.disruptor

Description: Disruptor stats for the XVM application.

Fields

Field NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .capacityThe size of the disruptor's ringbuffer.
remainingISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .remainingThe number of free ringbuffer slots.
used{capacity} - {remaining}The number of used ringbuffer slots.
claim_strategyISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .claimStrategy or "N/A" if not having claim strategyThe claim strategy used by threads inputing events to the disruptor.
wait_strategyISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .waitStrategy or "N/A" if not having wait strategyThe 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 NameJava Type MappingDescription
app_nameISrvMonHeartbeatMessage .appsStats[i] .nameXVM application name.

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .disruptorStats .offerToPollLatenciesMeasures 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 NameJava Type MappingDescription
last_decongestedISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .lastDecongestedThe last feeder queue decongested.
max_concurrencyISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .maxConcurrencyThe maximum number of feeder queue supported by the multiplexer.
schedule_queue_sizeISrvMonHeartbeatMessage .appsStats[i] .eventMultiplexerStats .scheduleQueueSizeThe number of scheduled events awaiting dispatch.

 

application.events

Description: Application Engine event stats.

Fields

Field NameJava Type MappingDescription
rcvdISrvMonHeartbeatMessage .appsStats[i] .engineStats .numEventsRcvdThe number of events received by the engine.
procISrvMonHeartbeatMessage .appsStats[i] .engineStats .numEventsProcessedThe number of events processed by the engine.

 

application.flows

Description: Application Engine flow stats.

Fields

Field NameJava Type MappingDescription
countISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowsThe number of active flows in the application.

 

application.messages

Description: Application Engine message summary stats.

Fields

Field NameJava Type MappingDescription
in_best_effortISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsRcvdBestEffortThe number of best effort messages the application has received.
in_guaranteedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsRcvdGuaranteedThe number of guaranteed messages the application has received.
in_proc_completeISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsProcCompleteThe number of flow related events that have been completely processed by the engine.
in_proc_failISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsProcFailThe number of flow related events unsuccessfully processed by the engine.
in_proc_successISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsProcSuccessThe number of flow related events successfully processed by the engine.
in_dupsISrvMonHeartbeatMessage .appsStats[i] .engineStats .numDupMsgsRcvdThe number of duplicate messages the application has received.
in_filteredISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsFilteredThe number of messages that were filtered.
in_sourcedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsSourced The number of messages that were sourced.
in_valueISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsRcvdThe number of flow related events processed by the engine.
out_best_effortISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsSentBestEffortThe number of best effort messages sent by the application.
out_guaranteedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsSentGuaranteedThe number of guaranteed messages sent by the application.
out_resentISrvMonHeartbeatMessage .appsStats[i] .engineStats .numMsgsResentThe number of messages the application has retransmitted.
out_snoISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundSnoThe current outbound sequence number for the engine.
out_stable_snoISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundStableSnoThe current stable outbound sequence number for the engine.
out_valueout_guaranteed + out_best_effortTotal messages sent by the application.

 

application.transaction

Description: Application Engine transaction stats.

Fields

Field NameJava Type MappingDescription
countISrvMonHeartbeatMessage .appsStats[i] .engineStats .numTransactionsThe number of transactions created by the engine.
startedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numCommitsStartedThe number of transaction commits started by the engine.
completedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numCommitsCompletedThe number of transaction commits completed by the engine.
rollbacksISrvMonHeartbeatMessage .appsStats[i] .engineStats .numRollbacksThe number of transactions that have been rolled back.
inflightstarted - completedThe number of in-flight transaction commits.
store_commits_startedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numStoreCommitsStartedThe number of store commits started by the engine.
store_commits_completedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numStoreCommitsCompletedThe number of store commits completed by the engine.
store_commit_queue_completion_sizeISrvMonHeartbeatMessage .appsStats[i] .engineStats .storeCommitCompletionQueueSizeThe number of store commits pending completion for the engine.
send_commits_startedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numSendCommitsStartedThe number of send (message bus) commits started by the engine.
send_commits_completedISrvMonHeartbeatMessage .appsStats[i] .engineStats .numSendCommitsCompletedThe number of send (message bus) commits completed by the engine.
send_commit_queue_completion_sizeISrvMonHeartbeatMessage .appsStats[i] .engineStats .sendCommitCompletionQueueSizeThe number of send commits pending completion.
events_per_commitISrvMonHeartbeatMessage .appsStats[i] .engineStats .numFlowEventsProcComplete - ISrvMonHeartbeatMessage .appsStats[i] .engineStats .numCommitsStartedNumber of events per commit.

 

application.messages.type

Description: Application Engine message stats per message type.

Tags

Tag NameJava Type MappingDescription
msg_id"{msg_name}_{msg_factory_id}_{msg_type_id}" See Fields table.Message type ID.

 

Fields

Field NameJava Type MappingDescription
msg_nameISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeNameThe fully qualified name of the message type.
msg_factory_idISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .getMessageFactoryIdThe factory id for the message type (unique within the application).
msg_type_idISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeIdThe message type id within its factory (unique within the type's factory).
in_dupsISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numDupMsgsRcvdThe number of duplicate messages the application has received.
in_filteredISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsFilteredThe number of messages that were filtered.
in_best_effortISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsRcvdBestEffortThe number of best effort messages the application has received.
in_guaranteedISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsRcvdGuaranteedThe number of guaranteed messages the application has received.
in_sourcedISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsSourcedThe number of messages that were sourced.
out_best_effortISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsSentBestEffortThe number of best effort messages sent by the application.
out_guaranteedISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsSentGuaranteedThe number of guaranteed messages sent by the application.
out_resentISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .numMsgsResentThe number of messages the application has retransmitted.

 

application.messages.type.latencies (MsgProcessing)

Description: Application Engine message latency stats per message type.

Tags

Tag NameJava Type MappingDescription
msg_id"{msg_name}_{msg_factory_id}_{msg_type_id}" See Fields table.Message type ID.
nameN/AAlways set to "MsgProcessing".

 

Fields

Field NameJava Type MappingDescription
msg_nameISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeNameThe fully qualified name of the message type.
msg_factory_idISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .getMessageFactoryIdThe factory id for the message type (unique within the application).
msg_type_idISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeIdThe message type id within its factory (unique within the type's factory).

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .msgProcessingLatenciesLatencies 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 NameJava Type MappingDescription
msg_id"{msg_name}_{msg_factory_id}_{msg_type_id}" See Fields table.Message type ID.
nameN/AAlways set to "MsgFiltering".

 

Fields

Field NameJava Type MappingDescription
msg_nameISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeNameThe fully qualified name of the message type.
msg_factory_idISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .getMessageFactoryIdThe factory id for the message type (unique within the application).
msg_type_idISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .messageTypeIdThe message type id within its factory (unique within the type's factory).

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgTypeStats[i] .msgFilteringLatenciesRecords 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 NameJava Type MappingDescription
outbound_queue_sizeISrvMonHeartbeatMessage .appsStats[i] .engineStats .backupOutboundQueueSizeNumber of messages in backup outbound queue.
outbound_log_queue_sizeISrvMonHeartbeatMessage .appsStats[i] .engineStats .backupOutboundLogQueueSizeNumber of messages in backup outbound loq queue.

 

application.transaction.latencies (CommitEpilogue)

Description: Application Engine transaction latencies.

Tags

Tag NameJava Type MappingDescription
nameN/AAlways set to "CommitEpilogue".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitEpilogueLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "CommitFull".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitFullLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "CommitPrologue".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitPrologueLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "CommitSend".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitSendLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "CommitStart".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitStartLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "CommitStore".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitStoreLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "CommitTransition".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .commitTransitionLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "InAck".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inAckLatenciesRecords 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 NameJava Type MappingDescription
nameN/AAlways set to "InOut".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inOutLatenciesRecords 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 NameJava Type MappingDescription
nameN/AAlways set to "MsgFiltering".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgFilteringLatenciesRecords 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 NameJava Type MappingDescription
nameN/AAlways set to "MsgPreProc".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgPreProcLatenciesRecords 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 NameJava Type MappingDescription
nameN/AAlways set to "MsgProcessing".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgProcessingLatenciesRecords 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 NameJava Type MappingDescription
nameN/AAlways set to "MsgSendCore".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgSendCoreLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "MsgSend".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .msgSendLatenciesTime 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 NameJava Type MappingDescription
nameN/AAlways set to "TransactionLeg1".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .transactionLeg1ProcessingTimesRecords 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 NameJava Type MappingDescription
nameN/AAlways set to "TransactionLeg2".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .transactionLeg2ProcessingTimesRecords 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 NameJava Type MappingDescription
nameN/AAlways set to "TransactionLeg3".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .transactionLeg3ProcessingTimesTransaction 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 NameJava Type MappingDescription
detachedISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .detachedPersistIndicates if the message logger is operating in detached mode.
commitsISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .numCommitsThe number of commits to the message logger.
forksISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .numForksThe number of forked message packets persisted.
messagesISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .numMessagesRecordedThe number of messages persisted by the message logger.
file_sizeISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .fileSizeThe size of the file on disk.
file_size_usedISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .fileSizeUsedThe size of the allocated log file used in bytes.

 

application.messagelogger.inbound.disruptor

Description: Application inbound message logger disruptor stats.

Fields

Field NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .capacityThe size of the diruptor's ringbuffer.
remainingISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .remainingThe number of free ringbuffer slots.
used{capacity} - {remaining}The number of used ringbuffer slots.
claim_strategyISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .claimStrategyThe claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable.
wait_strategyISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .waitStrategyThe 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 NameJava Type MappingDescription
nameN/AAlways set to "OfferToPoll".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .inboundMessageLoggerStats .disruptorStats .offerToPollLatenciesMeasures 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 NameJava Type MappingDescription
detachedISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .detachedPersistIndicates if the message logger is operating in detached mode.
commitsISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .numCommitsThe number of commits to the message logger.
forksISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .numForksThe number of forked message packets persisted.
messagesISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .numMessagesRecordedThe number of messages persisted by the message logger.
file_sizeISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .fileSizeThe size of the file on disk.
file_size_usedISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .fileSizeUsedThe size of the allocated log file used in bytes.

 

application.messagelogger.outbound.disruptor

Description: Application outbound message logger disruptor stats.

Fields

Field NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .capacityThe size of the diruptor's ringbuffer.
remainingISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .remainingThe number of free ringbuffer slots.
used{capacity} - {remaining}The number of used ringbuffer slots.
claim_strategyISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .claimStrategyThe claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable.
wait_strategyISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .waitStrategyThe 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 NameJava Type MappingDescription
nameN/AAlways set to "OfferToPoll".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .outboundMessageLoggerStats .disruptorStats .offerToPollLatenciesMeasures 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 NameJava Type MappingDescription
detachedISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .detachedPersistIndicates if the message logger is operating in detached mode.
commitsISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .numCommitsThe number of commits to the message logger.
forksISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .numForksThe number of forked message packets persisted.
messagesISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .numMessagesRecordedThe number of messages persisted by the message logger.
file_sizeISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .fileSizeThe size of the file on disk.
file_size_usedISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .fileSizeUsedThe size of the allocated log file used in bytes.

 

application.pertransactionstats.logger.disruptor

Description: Application per transaction logger disruptor stats.

Fields

Field NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .capacityThe size of the diruptor's ringbuffer.
remainingISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .remainingThe number of free ringbuffer slots.
used{capacity} - {remaining}The number of used ringbuffer slots.
claim_strategyISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .claimStrategyThe claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable.
wait_strategyISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .waitStrategyThe 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 NameJava Type MappingDescription
nameN/AAlways set to "OfferToPoll".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .engineStats .perTransactionStatsLoggerStats .disruptorStats .offerToPollLatenciesMeasures 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 NameJava Type MappingDescription
stateISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .stateThe store state if applicable, else "N/A".
roleISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .roleThe HA Role for the store if applicable, else "N/A".
icr_roleISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRRoleThe store's ICR Role.
sizeISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .sizeThe number of objects in the store.
data_sizeISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .dataSizeThe total size of serialized object data held by the store.
commit_completions_receivedISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitCompletionsReceivedThe number of commit acknowledgements received by this store member from followers.
commit_completions_sentISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitCompletionsSentThe number of commit acknowledgements sent by this store member to the leader.
commit_entries_rcvdISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitEntriesReceivedThe number of committed entries replicated to this store.
commit_entries_sentISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitEntriesSentThe number of committed entries replicated by the store.
commit_commits_rcvdISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitsReceivedThe number of committed transactions replicated to this store.
commit_commits_sentISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .numCommitsSentThe number of committed transactions replicated by the store.

 

application.store.latencies (CommitQueueSize)

Description: Application Store latency stats.

Tags

Tag NameJava Type MappingDescription
nameN/AAlways set to "CommitQueueSize".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .commitQueueSizeThe 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 NameJava Type MappingDescription
nameN/AAlways set to "Commit".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .commitLatenciesLatencies 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 NameJava Type MappingDescription
nameN/AAlways set to "Deserialize".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .deserializeLatenciesThe 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 NameJava Type MappingDescription
nameN/AAlways set to "IcrSend".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .icrSendLatenciesThe 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 NameJava Type MappingDescription
nameN/AAlways set to "Index".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .indexLatenciesLatencies 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 NameJava Type MappingDescription
nameN/AAlways set to "Persist".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persistLatenciesThe 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 NameJava Type MappingDescription
nameN/AAlways set to "Serialize".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .serializeLatenciesThe 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 NameJava Type MappingDescription
nameN/AAlways set to "SerializeToPersist".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .serializeToPersistLatenciesThe 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 NameJava Type MappingDescription
nameN/AAlways set to "SerializeToWire".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .serializeToWireLatenciesThe 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 NameJava Type MappingDescription
nameN/AAlways set to "Wire".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .wireLatenciesThe 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 NameJava Type MappingDescription
nameN/AAlways set to "WireToDeserialize".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .wireToDeserializeLatenciesThe 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

Field NameJava Type MappingDescription
detachedISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .detachedPersistIndicates if the persister is operating in detached mode.
commitsISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .numCommitsThe number of commits recorded by the persister.
forksISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .numForksThe number of forked packets persisted.
putsISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .numPutsRecordedThe number of puts recorded by the persister.
removesISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .numRemovesRecordedThe number of removes recorded by the persister.
sendsISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .numSendsRecordedThe number of sends recorded by the persister.
updatesISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .numUpdatesRecordedThe number of updates recorded by the persister.
file_sizeISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .fileSizeThe size of the file on disk.
file_size_usedISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .fileSizeUsedThe size of the allocated log file used in bytes.

 

application.store.persister.disruptor

Description: Application store persister disruptor stats.

Fields

Field NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .capacityThe size of the diruptor's ringbuffer.
remainingISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .remainingThe number of free ringbuffer slots.
used{capacity} - {remaining}The number of used ringbuffer slots.
claim_strategyISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .claimStrategyThe claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable.
wait_strategyISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .waitStrategyThe 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 NameJava Type MappingDescription
nameN/AAlways set to "OfferToPoll".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .persisterStats .disruptorStats .offerToPollLatenciesMeasures 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 NameJava Type MappingDescription
detachedISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .detachedPersistIndicates if the sender is operating in detached mode.
commitsISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numCommitsThe number of commits recorded by the sender.
putsISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numPutsRecordedThe number of puts recorded by the sender.
removesISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numRemovesRecordedThe number of removes recorded by the sender.
sendsISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numSendsRecordedThe number of sends recorded by the sender.
updatesISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .numUpdatesRecordedThe number of updates recorded by the sender.

 

application.store.icr_sender.disruptor

Description: Application ICR Sender disruptor stats.

Fields

Field NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .capacityThe size of the diruptor's ringbuffer.
remainingISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .remainingThe number of free ringbuffer slots.
used{capacity} - {remaining}The number of used ringbuffer slots.
claim_strategyISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .claimStrategyThe claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable.
wait_strategyISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .waitStrategyThe 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 NameJava Type MappingDescription
nameN/AAlways set to "OfferToPoll".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .storeBindingStats .ICRSenderStats .disruptorStats .offerToPollLatenciesMeasures 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.

 

Fields

Field NameJava Type MappingDescription
internalISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .internalIndicates if this is an internal bus.
detached_commmitISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .detachedCommitIf the bus binding is operating in detached mode.
commitsISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numCommitsThe number transactions committed by the bus.
rollbacksISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numRollbacksThe number transactions rolled back for the bus.
failuresISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numBindingFailuresThe number of binding failures that have occurred for this bus.
channels_upISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numChannelsUpThe number of channels brought up by this bus.
clientsISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numClientsThe number of connected clients (if applicable).
msgs_rcvdISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsRcvdThe number of messages received by the bus.
msgs_sentISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsSentThe total number of batch messages enqueued message that were actually sent by the bus.
stability_rcvdISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numStabilityRcvdThe number of stability events (acks) received by this bus.
msgs_enqueuedISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsEnqueuedThe total number of batch messages enqueued for delivery by this bus.
msgs_flushed_asyncISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsFlushedAsyncThe number of messages flushed by asynchronous flushes.
msgs_flushed_syncISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsFlushedSyncThe number of messages flushed by synchronous flushes.
async_flush_completionsISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numAsyncFlushCompletionsThe number of asynchronous flushes for this that have completed.
async_flushesISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numFlushesAsyncThe number of times this bus has been asynchronously flushed.
sync_flushesISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numFlushesSyncThe number of times this bus has been synchronously flushed.
rcvd_batchesISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgBatchesRcvdThe number of batch messages received by the bus.
rcvd_batch_msgsISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numMsgsInBatchesRcvdThe number of messages received by the bus that were part of a batch.
acks_sentISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numAcksSentThe number of inbound messages acknowledged by the bus.
packets_rcvdISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numPacketsRcvdThe number of raw packets received by the bus.
stability_batches_rcvdISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numStabilityBatchesRcvdThe number of batched stability events received by this bus.
stability_rcvd_in_batchesISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .numStabilityInBatchesRcvdThe 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 NameJava Type MappingDescription
capacityISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .capacityThe size of the diruptor's ringbuffer.
remainingISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .remainingThe number of free ringbuffer slots.
used{capacity} - {remaining}The number of used ringbuffer slots.
claim_strategyISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .claimStrategyThe claim strategy used by threads inputing events to the disruptor, or "N/A" if not applicable.
wait_strategyISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .waitStrategyThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "OfferToPoll".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .disruptorStats .offerToPollLatenciesMeasures 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "CreateToSend".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .createToSendLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "Deserialize".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .deserializeLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "DeserializeToReceive".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .deserializeToReceiveLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "OriginToReceive".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .originToReceiveLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "SendToSerialize".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .sendToSerializeLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "Serialize".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .serializeLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "SerializeToWire".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .serializeToWireLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "Wire".

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .wireLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "WireSend".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .wireSendLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "WireToDeserialize".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .wireToDeserializeLatenciesThe 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 NameJava Type MappingDescription
bus_nameISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .busBindingNameThe name of the bus.
nameN/AAlways set to "WireToWire".

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .busBindingStats[i] .wireToWireLatenciesThe 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 NameJava Type MappingDescription
nameISrvMonHeartbeatMessage .appsStats[i] .userStats .gauges[i] .nameGauge name.

 

Fields

Field NameJava Type MappingDescription
numeric_valueN/AGauges of type Byte, Short, Integer, Long, Float, and Double are written to this field
string_valueN/AString 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 NameJava Type MappingDescription
nameISrvMonHeartbeatMessage .appsStats[i] .userStats .counters[i] .nameCounter name.

 

Fields

Field NameJava Type MappingDescription
valueISrvMonHeartbeatMessage .appsStats[i] .userStats .counters[i] .countThe counter value.

 

application.user.series

Description: User-defined series stats.

Tags

Tag NameJava Type MappingDescription
nameISrvMonHeartbeatMessage .appsStats[i] .userStats .series[i] .nameSeries name.

 

Histogram Data

Java Type MappingDescription
ISrvMonHeartbeatMessage .appsStats[i] .userStats .series[i] .intSeriesThe user-defined series values.

For the list of fields for histogram data see Integer Histogram Data Points

  • No labels