Management Center automatically reformats all Hazelcast cluster metrics for compatibility with Prometheus. In addition, Management Center updates a subset of metrics to align with Prometheus best practice recommendations. This makes it easier to construct complex queries, build dashboards, and work alongside metrics from other applications.
By default, Management Center exposes two versions of metrics based on Hazelcast’s JMX metrics system:
-
Version 1 (V1) metrics apply a basic transformation for compatibility with Prometheus:
-
Convert
.to_ -
Add
hz_prefix
-
-
Version 2 (V2) metrics (currently in BETA) apply an advanced transformation for conformity with Prometheus naming conventions:
-
Use
snake_case -
Add
hazelcast_prefix -
Update metric names where appropriate
-
Combine related metrics and add labels
-
Convert to recommended base units:
-
Time in seconds
-
Memory in bytes
-
Percentages as ratios (for example, 50% converts to 0.5)
-
-
Append units to metric names
-
Remove unit labels
-
Append
_totalto accumulated metrics
-
You can optionally change which set of metrics is exposed.
The following examples illustrate the differences between the V1 and V2 metrics.
-
Rename and remove
unitlabel, add_totalsuffix:# V1 hz_map_queryCount{name="map-1",mc_member="127.0.0.1:5701",mc_cluster="Cluster-1",unit="COUNT",} 0.0 1737715903399 # V2 hazelcast_map_queries_total{name="map-1",mc_member="127.0.0.1:5701",mc_cluster="Cluster-1",} 0.0 1737715903399 -
Rename and append unit, remove
unitlabel, convert value (1.7x1012 milliseconds to 1.7x109 seconds):# V1 hz_map_creationTime{name="map-1",mc_member="127.0.0.1:5701",mc_cluster="Cluster-1",unit="MS",} 1.737715861118E12 1737715903399 # V2 hazelcast_map_creation_timestamp_seconds{name="map-1",mc_member="127.0.0.1:5701",mc_cluster="Cluster-1",} 1.737715861118E9 1737715903399 -
Rename and append unit, remove
unitlabel, addremovelabel:# V1 hz_map_totalMaxRemoveLatency{name="map-1",mc_member="127.0.0.1:5701",mc_cluster="Cluster-1",unit="MS",} 0.0 1737715903399 # V2 hazelcast_map_latency_max_seconds{name="map-1",mc_member="127.0.0.1:5701",mc_cluster="Cluster-1",operation="remove",} 0.0 1737715903399 -
Rename, append unit suffix and
_totalsuffix, removeunitlabel, addremovelabel, convert value from milliseconds to seconds:# V1 hz_map_totalPutLatency{name="map-1",mc_member="127.0.0.1:5701",mc_cluster="Cluster-1",unit="MS",} 2019.0 1743601193973 # V2 hazelcast_map_latency_seconds_total{name="map-1",mc_member="127.0.0.1:5701",mc_cluster="Cluster-1",operation="put",} 2.019 1743601193973
Change the metrics version
To change which set of metrics is exposed to Prometheus, update the hazelcast.mc.prometheusExporter.printers system property:
-
V1:
hazelcast.mc.prometheusExporter.printers=V1 -
V2:
hazelcast.mc.prometheusExporter.printers=V2 -
V1 and V2 (default):
hazelcast.mc.prometheusExporter.printers=V1,V2
If you set the property to V2, Management Center will only expose the subset of metrics that have updated versions available.
|
Metrics list
The following table lists all V2 metrics with their V1 equivalents. The full list of Hazelcast metrics and descriptions is provided in the Hazelcast Platform documentation.
In some cases, several V1 metrics are combined into a single V2 metric differentiated by labels. For example, hazelcast_map_operations_total replaces hz_map_getCount and hz_map_setCount by adding operation="get" and operation="set" labels.
Map
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
map_backupCount |
map_backups_total |
n/a |
map_backupEntryCount |
map_backup_entries_total |
n/a |
map_backupEntryMemoryCost |
map_backup_entries_memory_cost_bytes |
n/a |
map_creationTime |
map_creation_timestamp_seconds |
n/a |
map_dirtyEntryCount |
map_dirty_entries_total |
n/a |
map_evictionCount |
map_evictions_total |
n/a |
map_expirationCount |
map_expirations_total |
n/a |
map_getCount |
map_operations_total |
operation=get |
map_heapCost |
map_heap_cost_bytes |
n/a |
map_indexedQueryCount |
map_indexed_queries_total |
n/a |
map_lastAccessTime |
map_last_access_timestamp_seconds |
n/a |
map_lastUpdateTime |
map_last_update_timestamp_seconds |
n/a |
map_lockedEntryCount |
map_locked_entries_total |
n/a |
map_merkleTreesCost |
map_merkle_trees_cost_bytes |
n/a |
map_numberOfEvents |
map_events_total |
n/a |
map_numberOfOtherOperations |
map_operations_total |
operation=other |
map_ownedEntryCount |
map_owned_entries_total |
n/a |
map_ownedEntryMemoryCost |
map_owned_entry_memory_cost_bytes |
n/a |
map_putCount |
map_operations_total |
operation=put |
map_queryCount |
map_queries_total |
n/a |
map_removeCount |
map_operations_total |
operation=remove |
map_setCount |
map_operations_total |
operation=set |
map_hits |
map_hits_total |
n/a |
map_totalGetLatency |
map_latency_seconds_total |
operation=get |
map_totalMaxGetLatency |
map_latency_max_seconds |
operation=get |
map_totalPutLatency |
map_latency_seconds_total |
operation=put |
map_totalMaxPutLatency |
map_latency_max_seconds |
operation=put |
map_totalRemoveLatency |
map_latency_seconds_total |
operation=remove |
map_totalMaxRemoveLatency |
map_latency_max_seconds |
operation=remove |
map_totalSetLatency |
map_latency_seconds_total |
operation=set |
map_totalMaxSetLatency |
map_latency_max_seconds |
operation=set |
map_index_creationTime |
map_index_creation_timestamp_seconds |
n/a |
map_index_hitCount |
map_index_hits_total |
n/a |
map_index_insertCount |
map_index_inserts_total |
n/a |
map_index_memoryCost |
map_index_memory_cost_bytes |
n/a |
map_index_queryCount |
map_index_queries_total |
n/a |
map_index_removeCount |
map_index_removes_total |
n/a |
map_index_totalInsertLatency |
map_index_latency_seconds_total |
operation=insert |
map_index_totalRemoveLatency |
map_index_latency_seconds_total |
operation=remove |
map_index_totalUpdateLatency |
map_index_latency_seconds_total |
operation=update |
map_index_updateCount |
map_index_updates_total |
n/a |
Set
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
set_creationTime |
set_creation_timestamp_seconds |
n/a |
set_lastAccessTime |
set_last_access_timestamp_seconds |
n/a |
set_lastUpdateTime |
set_last_update_timestamp_seconds |
n/a |
List
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
list_creationTime |
list_creation_timestamp_seconds |
n/a |
list_lastAccessTime |
list_last_access_timestamp_seconds |
n/a |
list_lastUpdateTime |
list_last_update_timestamp_seconds |
n/a |
Operating System
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
os.committedVirtualMemorySize |
os_committed_virtual_memory_size_bytes |
n/a |
os.freePhysicalMemorySize |
os_free_physical_memory_size_bytes |
n/a |
os.freeSwapSpaceSize |
os_free_swap_space_size_bytes |
n/a |
os.maxFileDescriptorCount |
os_max_file_descriptor_total |
n/a |
os.openFileDescriptorCount |
os_open_file_descriptor_total |
n/a |
os.processCpuLoad |
os_process_cpu_load_ratio |
n/a |
os.processCpuTime |
os_process_cpu_time_seconds |
n/a |
os.systemCpuLoad |
os_system_cpu_load_ratio |
n/a |
os.systemLoadAverage |
os_system_load_average_ratio |
n/a |
os.totalPhysicalMemorySize |
os_total_physical_memory_size_bytes |
n/a |
os.totalSwapSpaceSize |
os_total_swap_space_size_bytes |
n/a |
Events
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
event.eventQueueSize |
event_queue_size_total |
n/a |
event.eventsProcessed |
event_processed_total |
n/a |
event.listenerCount |
event_listeners_total |
n/a |
event.publicationCount |
event_publications_total |
n/a |
event.queueCapacity |
event_queue_capacity_total |
n/a |
event.rejectedCount |
event_rejected_total |
n/a |
event.syncDeliveryFailureCount |
event_sync_delivery_failures_total |
n/a |
event.threadCount |
event_threads_total |
n/a |
event.totalFailureCount |
event_failures_total |
n/a |
Listeners
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
listeners.eventsProcessed |
listeners_events_processed_total |
n/a |
listeners.eventQueueSize |
listeners_event_queue_size_total |
n/a |
Capacity
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
file.partition.freeSpace |
file_partition_free_space_bytes |
n/a |
file.partition.totalSpace |
file_partition_total_space_bytes |
n/a |
file.partition.usableSpace |
file_partition_usable_space_bytes |
n/a |
Garbage Collection
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
gc.majorCount |
gc_major_total |
n/a |
gc.majorTime |
gc_major_time_seconds_total |
n/a |
gc.minorCount |
gc_minor_total |
n/a |
gc.minorTime |
gc_minor_time_seconds_total |
n/a |
gc.unknownCount |
gc_unknown_total |
n/a |
gc.unknownTime |
gc_unknown_time_seconds_total |
n/a |
Memory
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
memory.committedHeap |
memory_committed_heap_bytes |
n/a |
memory.committedNative |
memory_committed_native_bytes |
n/a |
memory.freeHeap |
memory_free_heap_bytes |
n/a |
memory.freeNative |
memory_free_native_bytes |
n/a |
memory.freePhysical |
memory_free_physical_bytes |
n/a |
memory.maxHeap |
memory_max_heap_bytes |
n/a |
memory.maxMetadata |
memory_max_metadata_bytes |
n/a |
memory.maxNative |
memory_max_native_bytes |
n/a |
memory.totalPhysical |
memory_total_physical_bytes |
n/a |
memory.usedHeap |
memory_used_heap_bytes |
n/a |
memory.usedMetadata |
memory_used_metadata_bytes |
n/a |
memory.usedNative |
memory_used_native_bytes |
n/a |
Operations
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
operation.adhoc.executedOperationsCount |
operation_adhoc_executed_operations_total |
n/a |
operation.asyncOperations |
operation_async_operations_total |
n/a |
operation.completedCount |
operation_completed_total |
n/a |
operation.failedBackups |
operation_failed_backups_total |
n/a |
operation.generic.executedOperationsCount |
operation_generic_executed_operations_total |
n/a |
operation.genericPriorityQueueSize |
operation_generic_priority_queue_size_total |
n/a |
operation.genericQueueSize |
operation_generic_queue_size_total |
n/a |
operation.genericThreadCount |
operation_generic_threads_total |
n/a |
operation.invocations.backupTimeoutMillis |
operation_invocations_backup_timeout_seconds |
n/a |
operation.invocations.backupTimeouts |
operation_invocations_backup_timeouts_total |
n/a |
operation.invocations.delayedExecutionCount |
operation_invocations_delayed_executions_total |
n/a |
operation.invocations.heartbeatBroadcastPeriodMillis |
operation_invocations_heartbeat_broadcast_period_seconds |
n/a |
operation.invocations.heartbeatPacketsReceived |
operation_invocations_heartbeat_packets_received_total |
n/a |
operation.invocations.heartbeatPacketsSent |
operation_invocations_heartbeat_packets_sent_total |
n/a |
operation.invocations.invocationScanPeriodMillis |
operation_invocations_invocation_scan_period_seconds |
n/a |
operation.invocations.invocationTimeoutMillis |
operation_invocations_invocation_timeout_seconds |
n/a |
operation.invocations.lastCallId |
operation_invocations_last_call_id_total |
n/a |
operation.invocations.normalTimeouts |
operation_invocations_normal_timeouts_total |
n/a |
operation.invocations.pending |
operation_invocations_pending_total |
n/a |
operation.invocations.usedPercentage |
operation_invocations_used_ratio |
n/a |
operation.parker.parkQueueCount |
operation_parker_park_queue_total |
n/a |
operation.parker.totalParkedOperationCount |
operation_parker_parked_operations_total |
n/a |
operation.partition.executedOperationsCount |
operation_partition_executed_operations_total |
n/a |
operation.partitionThreadCount |
operation_partition_threads_total |
n/a |
operation.priorityQueueSize |
operation_priority_queue_size_total |
n/a |
operation.queueSize |
operation_queue_size_total |
n/a |
operation.responseQueueSize |
operation_response_queue_size_total |
n/a |
operation.responses.backupCount |
operation_responses_backups_total |
n/a |
operation.responses.errorCount |
operation_responses_errors_total |
n/a |
operation.responses.missingCount |
operation_responses_missing_total |
n/a |
operation.responses.normalCount |
operation_responses_normal_total |
n/a |
operation.responses.timeoutCount |
operation_responses_timeouts_total |
n/a |
operation.retryCount |
operation_retries_total |
n/a |
operation.runningCount |
operation_running_total |
n/a |
operation.runningGenericCount |
operation_running_generic_total |
n/a |
operation.runningPartitionCount |
operation_running_partition_total |
n/a |
operation.thread.completedOperationCount |
operation_thread_completed_operations_total |
n/a |
operation.thread.completedOperationBatchCount |
operation_thread_completed_operation_batches_total |
n/a |
operation.thread.completedPacketCount |
operation_thread_completed_packets_total |
n/a |
operation.thread.completedPartitionSpecificRunnableCount |
operation_thread_completed_partition_specific_runnables_total |
n/a |
operation.thread.completedRunnableCount |
operation_thread_completed_runnables_total |
n/a |
operation.thread.completedTotalCount |
operation_thread_completed_total |
n/a |
operation.thread.errorCount |
operation_thread_errors_total |
n/a |
operation.thread.normalPendingCount |
operation_thread_normal_pending_total |
n/a |
operation.thread.priorityPendingCount |
operation_thread_priority_pending_total |
n/a |
Runtime
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
runtime.availableProcessors |
runtime_available_processors_total |
n/a |
runtime.freeMemory |
runtime_free_memory_bytes |
n/a |
runtime.maxMemory |
runtime_max_memory_bytes |
n/a |
runtime.totalMemory |
runtime_total_memory_bytes |
n/a |
runtime.uptime |
runtime_up_time_seconds_total |
n/a |
runtime.usedMemory |
runtime_used_memory_bytes |
n/a |
TCP
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
tcp.acceptor.eventCount |
tcp_acceptor_events_total |
n/a |
tcp.acceptor.exceptionCount |
tcp_acceptor_exceptions_total |
n/a |
tcp.acceptor.idleTimeMillis |
tcp_acceptor_idle_time_seconds |
n/a |
tcp.acceptor.selectorRecreateCount |
tcp_acceptor_selector_recreate_total |
n/a |
tcp.balancer.imbalanceDetectedCount |
tcp_balancer_imbalance_detected_total |
n/a |
tcp.balancer.migrationCompletedCount |
tcp_balancer_migration_completed_total |
n/a |
tcp.bytesReceived |
tcp_received_bytes |
n/a |
tcp.bytesSend |
tcp_sent_bytes |
n/a |
tcp.connection.acceptedSocketCount |
tcp_connection_accepted_socket_total |
n/a |
tcp.connection.activeCount |
tcp_connection_active_total |
n/a |
tcp.connection.clientCount |
tcp_connection_clients_total |
n/a |
tcp.connection.closedCount |
tcp_connection_closed_total |
n/a |
tcp.connection.connectionListenerCount |
tcp_connection_listeners_total |
n/a |
tcp.connection.count |
tcp_connection_total |
n/a |
tcp.connection.inProgressCount |
tcp_connection_in_progress_total |
n/a |
tcp.connection.openedCount |
tcp_connection_opened_total |
n/a |
tcp.connection.textCount |
tcp_connection_text_total |
n/a |
tcp.connection.in.completedMigrations |
tcp_connection_completed_migrations_total |
direction=in |
tcp.connection.out.completedMigrations |
tcp_connection_completed_migrations_total |
direction=out |
tcp.connection.in.opsInterested |
tcp_connection_ops_interested_total |
direction=in |
tcp.connection.out.opsInterested |
tcp_connection_ops_interested_total |
direction=out |
tcp.connection.in.opsReady |
tcp_connection_ops_ready_total |
direction=in |
tcp.connection.out.opsReady |
tcp_connection_ops_ready_total |
direction=out |
tcp.connection.in.ownerId |
tcp_connection_owner_id_total |
direction=in |
tcp.connection.out.ownerId |
tcp_connection_owner_id_total |
direction=out |
tcp.connection.in.processCount |
tcp_connection_process_total |
direction=in |
tcp.connection.out.processCount |
tcp_connection_process_total |
direction=out |
tcp.connection.in.startedMigrations |
tcp_connection_started_migrations_total |
direction=in |
tcp.connection.out.startedMigrations |
tcp_connection_started_migrations_total |
direction=out |
tcp.connection.in.bytesRead |
tcp_connection_in_read_bytes |
n/a |
tcp.connection.in.idleTimeMs |
tcp_connection_in_idle_time_seconds |
n/a |
tcp.connection.in.normalFramesRead |
tcp_connection_in_normal_frames_read_total |
n/a |
tcp.connection.in.priorityFramesRead |
tcp_connection_in_priority_frames_read_total |
n/a |
tcp.connection.out.bytesWritten |
tcp_connection_out_written_bytes |
n/a |
tcp.connection.out.idleTimeMillis |
tcp_connection_out_idle_time_seconds |
n/a |
tcp.connection.out.normalFramesWritten |
tcp_connection_out_normal_frames_written_total |
n/a |
tcp.connection.out.priorityFramesWritten |
tcp_connection_out_priority_frames_written_total |
n/a |
tcp.connection.out.priorityWriteQueuePendingBytes |
tcp_connection_out_priority_write_queue_pending_bytes |
n/a |
tcp.connection.out.priorityWriteQueueSize |
tcp_connection_out_priority_write_queue_size_total |
n/a |
tcp.connection.out.scheduled |
tcp_connection_out_scheduled_total |
n/a |
tcp.connection.out.writeQueuePendingBytes |
tcp_connection_out_write_queue_pending_bytes |
n/a |
tcp.connection.out.writeQueueSize |
tcp_connection_out_write_queue_size_total |
n/a |
tcp.inputThread.bytesTransceived |
tcp_transceived_bytes |
thread=input |
tcp.outputThread.bytesTransceived |
tcp_transceived_bytes |
thread=output |
tcp.inputThread.completedTaskCount |
tcp_completed_tasks_total |
thread=input |
tcp.outputThread.completedTaskCount |
tcp_completed_tasks_total |
thread=output |
tcp.inputThread.eventCount |
tcp_events_total |
thread=input |
tcp.outputThread.eventCount |
tcp_events_total |
thread=output |
tcp.inputThread.framesTransceived |
tcp_transceived_frames_total |
thread=input |
tcp.outputThread.framesTransceived |
tcp_transceived_frames_total |
thread=output |
tcp.inputThread.idleTimeMillis |
tcp_idle_seconds |
thread=input |
tcp.outputThread.idleTimeMillis |
tcp_idle_seconds |
thread=output |
tcp.inputThread.ioThreadId |
tcp_io_thread_id_total |
thread=input |
tcp.outputThread.ioThreadId |
tcp_io_thread_id_total |
thread=output |
tcp.inputThread.priorityFramesTransceived |
tcp_priority_frames_transceived_total |
thread=input |
tcp.outputThread.priorityFramesTransceived |
tcp_priority_frames_transceived_total |
thread=output |
tcp.inputThread.processCount |
tcp_process_total |
thread=input |
tcp.outputThread.processCount |
tcp_process_total |
thread=output |
tcp.inputThread.selectorIOExceptionCount |
tcp_selector_io_exceptions_total |
thread=input |
tcp.outputThread.selectorIOExceptionCount |
tcp_selector_io_exceptions_total |
thread=output |
tcp.inputThread.taskQueueSize |
tcp_task_queue_size_total |
thread=input |
tcp.outputThread.taskQueueSize |
tcp_task_queue_size_total |
thread=output |
Threads
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
thread.daemonThreadCount |
thread_daemon_total |
n/a |
thread.peakThreadCount |
thread_peak_total |
n/a |
thread.threadCount |
thread_total |
n/a |
thread.totalStartedThreadCount |
thread_started_total |
n/a |
Topic
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
topic.creationTime |
topic_creation_timestamp_seconds |
n/a |
topic.totalPublishes |
topic_publishes_total |
n/a |
topic.totalReceivedMessages |
topic_received_messages_total |
n/a |
Reliable Topic
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
reliableTopic.creationTime |
reliable_topic_creation_timestamp_seconds |
n/a |
reliableTopic.totalPublishes |
reliable_topic_publishes_total |
n/a |
reliableTopic.totalReceivedMessages |
reliable_topic_received_messages_total |
n/a |
Flake ID Generator
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
flakeIdGenerator.batchCount |
flake_id_generator_batches_total |
n/a |
flakeIdGenerator.creationTime |
flake_id_generator_creation_timestamp_seconds |
n/a |
flakeIdGenerator.idCount |
flake_id_generator_ids_total |
n/a |
PN Counter
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
pnCounter.creationTime |
pn_counter_creation_timestamp_seconds |
n/a |
pnCounter.totalDecrementOperationCount |
pn_counter_decrement_operations_total |
n/a |
pnCounter.totalIncrementOperationCount |
pn_counter_increment_operations_total |
n/a |
pnCounter.value |
pn_counter_value_total |
n/a |
User Code Deployment
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
classloading.loadedClassesCount |
user_code_deployment_currently_loaded_classes_total |
n/a |
classloading.totalLoadedClassesCount |
user_code_deployment_loaded_classes_total |
n/a |
classloading.unloadedClassesCount |
user_code_deployment_unloaded_classes_total |
n/a |
Clients
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
client.endpoint.count |
client_endpoints_total |
n/a |
client.endpoint.totalRegistrations |
client_endpoint_registrations_total |
n/a |
Client Invocations
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
invocations.maxCurrentInvocations |
invocations_max_current_total |
n/a |
invocations.pendingCalls |
invocations_pending_calls_total |
n/a |
invocations.startedInvocations |
invocations_started_total |
n/a |
HD Memory Store
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
map.usedMemory |
map_hd_used_memory_bytes |
n/a |
map.forceEvictionCount |
map_hd_force_evictions_total |
n/a |
map.forceEvictedEntryCount |
map_hd_force_evicted_entries_total |
n/a |
map.entryCount |
map_hd_entries_total |
n/a |
Proxies
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
proxy.createdCount |
proxy_created_total |
n/a |
proxy.destroyedCount |
proxy_destroyed_total |
n/a |
proxy.proxyCount |
proxy_active_total |
n/a |
Transactions
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
transactions.commitCount |
transactions_committed_total |
n/a |
transactions.rollbackCount |
transactions_rolled_back_total |
n/a |
transactions.startCount |
transactions_started_total |
n/a |
User Code Namespace (UCN)
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
ucn.updateTime |
ucn_update_timestamp_seconds |
n/a |
ucn.resourceCount |
ucn_resources_total |
n/a |
ucn.resource.resourceType |
ucn_resource_type_info |
n/a |
ucn.resource.resourceSizeBytes |
ucn_resource_size_bytes |
n/a |
Persistence
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
persistence.liveTombstones |
persistence_live_tombstones_total |
n/a |
persistence.liveValues |
persistence_live_values_total |
n/a |
persistence.tombGarbage |
persistence_tomb_garbage_bytes |
n/a |
persistence.tombOccupancy |
persistence_tomb_occupancy_bytes |
n/a |
persistence.valGarbage |
persistence_val_garbage_bytes |
n/a |
persistence.valOccupancy |
persistence_val_occupancy_bytes |
n/a |
Streaming Engine
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
blockingWorkerCount |
streaming_engine_blocking_workers_total |
n/a |
jobs.submitted |
streaming_engine_jobs_submitted_total |
n/a |
jobs.completedSuccessfully |
streaming_engine_jobs_completed_successfully_total |
n/a |
jobs.completedWithFailure |
streaming_engine_jobs_completed_with_failure_total |
n/a |
jobs.executionStarted |
streaming_engine_jobs_executions_started_total |
n/a |
jobs.executionTerminated |
streaming_engine_jobs_executions_terminated_total |
n/a |
iterationCount |
streaming_engine_iterations_total |
n/a |
taskletCount |
streaming_engine_tasklets_total |
n/a |
Cluster
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
cluster.clock.clusterStartTime |
cluster_clock_cluster_start_timestamp_seconds |
n/a |
cluster.clock.clusterTime |
cluster_clock_cluster_time_seconds_total |
n/a |
cluster.clock.clusterTimeDiff |
cluster_clock_cluster_time_diff_seconds |
n/a |
cluster.clock.clusterUpTime |
cluster_clock_cluster_up_time_seconds_total |
n/a |
cluster.clock.localClockTime |
cluster_clock_local_clock_timestamp_seconds |
n/a |
cluster.clock.maxClusterTimeDiff |
cluster_clock_max_cluster_time_diff_seconds |
n/a |
cluster.connection.closedTime |
cluster_connection_closed_timestamp_seconds |
n/a |
cluster.connection.connectionId |
cluster_connection_connection_id_info |
n/a |
cluster.connection.eventHandlerCount |
cluster_connection_event_handlers_total |
n/a |
cluster.heartbeat.lastHeartbeat |
cluster_heartbeat_last_heartbeat_timestamp_seconds |
n/a |
cluster.size |
cluster_size_total |
n/a |
Executor Service
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
executor.cancelled |
executor_operations_total |
operation=cancelled |
executor.completed |
executor_operations_total |
operation=completed |
executor.creationTime |
executor_creation_timestamp_seconds |
n/a |
executor.pending |
executor_operations_total |
operation=pending |
executor.started |
executor_operations_total |
operation=started |
executor.totalExecutionTime |
executor_execution_time_seconds_total |
n/a |
executor.totalStartLatency |
executor_start_latency_seconds_total |
n/a |
executor.internal.completedTasks |
executor_internal_completed_tasks_total |
n/a |
executor.internal.maximumPoolSize |
executor_internal_maximum_pool_size_total |
n/a |
executor.internal.poolSize |
executor_internal_pool_size_total |
n/a |
executor.internal.queueSize |
executor_internal_queue_size_total |
n/a |
executor.internal.remainingQueueCapacity |
executor_internal_remaining_queue_capacity_total |
n/a |
Queue
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
queue.averageAge |
queue_average_age_seconds |
n/a |
queue.backupItemCount |
queue_backup_items_total |
n/a |
queue.creationTime |
queue_creation_timestamp_seconds |
n/a |
queue.eventOperationCount |
queue_event_operations_total |
n/a |
queue.maxAge |
queue_max_age_seconds |
n/a |
queue.minAge |
queue_min_age_seconds |
n/a |
queue.numberOfEmptyPolls |
queue_empty_polls_total |
n/a |
queue.numberOfEvents |
queue_events_total |
n/a |
queue.numberOfOffers |
queue_operations_total |
operation=offer |
queue.numberOfOtherOperations |
queue_operations_total |
operation=other |
queue.numberOfPolls |
queue_operations_total |
operation=poll |
queue.numberOfRejectedOffers |
queue_rejected_offers_total |
n/a |
queue.ownedItemCount |
queue_owned_items_total |
n/a |
queue.total |
queue_operations_total |
n/a |
Near Cache
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
nearcache.creationTime |
nearcache_creation_timestamp_seconds |
n/a |
nearcache.evictions |
nearcache_evictions_total |
n/a |
nearcache.expirations |
nearcache_expirations_total |
n/a |
nearcache.hits |
nearcache_hits_total |
n/a |
nearcache.invalidationRequests |
nearcache_invalidation_requests_total |
n/a |
nearcache.invalidations |
nearcache_invalidations_total |
n/a |
nearcache.lastPersistenceDuration |
nearcache_last_persistence_duration_seconds |
n/a |
nearcache.lastPersistenceKeyCount |
nearcache_last_persistence_keys_total |
n/a |
nearcache.lastPersistenceTime |
nearcache_last_persistence_timestamp_seconds |
n/a |
nearcache.lastPersistenceWrittenBytes |
nearcache_last_persistence_written_bytes |
n/a |
nearcache.misses |
nearcache_misses_total |
n/a |
nearcache.ownedEntryCount |
nearcache_owned_entries_total |
n/a |
nearcache.ownedEntryMemoryCost |
nearcache_owned_entries_memory_cost_bytes |
n/a |
nearcache.persistenceCount |
nearcache_persistences_total |
n/a |
Cache
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
cache.averageGetTime |
cache_average_operation_time_seconds |
operation=get |
cache.averagePutTime |
cache_average_operation_time_seconds |
operation=put |
cache.averageRemovalTime |
cache_average_operation_time_seconds |
operation=remove |
cache.cacheEvictions |
cache_evictions_total |
n/a |
cache.cacheGets |
cache_operations_total |
operation=get |
cache.cacheHits |
cache_hits_total |
n/a |
cache.cacheHitPercentage |
cache_hit_ratio |
n/a |
cache.cachePuts |
cache_operations_total |
operation=put |
cache.cacheRemovals |
cache_operations_total |
operation=remove |
cache.cacheMisses |
cache_misses_total |
n/a |
cache.cacheMissPercentage |
cache_miss_ratio |
n/a |
cache.creationTime |
cache_creation_timestamp_seconds |
n/a |
cache.lastAccessTime |
cache_last_access_timestamp_seconds |
n/a |
cache.lastUpdateTime |
cache_last_update_timestamp_seconds |
n/a |
cache.ownedEntryCount |
cache_owned_entries_total |
n/a |
Raft
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
raft.destroyedGroupIds |
raft_destroyed_group_ids_total |
n/a |
raft.group.availableLogCapacity |
raft_group_available_log_capacity_total |
n/a |
raft.group.commitIndex |
raft_group_commit_index_total |
n/a |
raft.group.lastApplied |
raft_group_last_applied_total |
n/a |
raft.group.lastLogIndex |
raft_group_last_log_index_total |
n/a |
raft.group.lastLogTerm |
raft_group_last_log_term_total |
n/a |
raft.group.memberCount |
raft_group_members_total |
n/a |
raft.group.snapshotIndex |
raft_group_snapshot_index_total |
n/a |
raft.group.term |
raft_group_term_total |
n/a |
raft.metadata.activeMembersCommitIndex |
raft_metadata_active_members_commit_index_total |
n/a |
raft.metadata.activeMembers |
raft_metadata_active_members_total |
n/a |
raft.metadata.groups |
raft_metadata_groups_total |
n/a |
raft.missingMembers |
raft_missing_members_total |
n/a |
raft.nodes |
raft_nodes_total |
n/a |
raft.terminatedRaftNodeGroupIds |
raft_terminated_node_group_ids_total |
n/a |
Replicated Map
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
replicatedMap.creationTime |
replicated_map_creation_timestamp_seconds |
n/a |
replicatedMap.getCount |
replicated_map_operations_total |
operation=get |
replicatedMap.hits |
replicated_map_hits_total |
n/a |
replicatedMap.lastAccessTime |
replicated_map_last_access_timestamp_seconds |
n/a |
replicatedMap.lastUpdateTime |
replicated_map_last_update_timestamp_seconds |
n/a |
replicatedMap.maxGetLatency |
replicated_map_latency_max_seconds |
operation=get |
replicatedMap.maxPutLatency |
replicated_map_latency_max_seconds |
operation=put |
replicatedMap.maxRemoveLatency |
replicated_map_latency_max_seconds |
operation=remove |
replicatedMap.numberOfEvents |
replicated_map_events_total |
n/a |
replicatedMap.numberOfOtherOperations |
replicated_map_operations_total |
operation=other |
replicatedMap.ownedEntryCount |
replicated_map_owned_entries_total |
n/a |
replicatedMap.ownedEntryMemoryCost |
replicated_map_owned_entry_memory_cost_bytes |
n/a |
replicatedMap.putCount |
replicated_map_operations_total |
operation=put |
replicatedMap.removeCount |
replicated_map_operations_total |
operation=remove |
replicatedMap.totalGetLatencies |
replicated_map_latency_seconds_total |
operation=get |
replicatedMap.totalPutLatencies |
replicated_map_latency_seconds_total |
operation=put |
replicatedMap.totalRemoveLatencies |
replicated_map_latency_seconds_total |
operation=remove |
replicatedMap.total |
replicated_map_operations_total |
n/a |
Streaming Engine Job-Specific
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
executionStartTime |
streaming_job_execution_timestamp_seconds |
phase=start |
executionCompletionTime |
streaming_job_execution_timestamp_seconds |
phase=completion |
status |
streaming_job_status_info |
n/a |
userCancelled |
streaming_job_user_cancelled_info |
n/a |
snapshotBytes |
streaming_job_snapshot_bytes |
n/a |
snapshotKeys |
streaming_job_snapshot_keys_total |
n/a |
distributedBytesIn |
streaming_job_distributed_bytes |
direction=in |
distributedBytesOut |
streaming_job_distributed_bytes |
direction=out |
distributedItemsIn |
streaming_job_distributed_items_total |
direction=in |
distributedItemsOut |
streaming_job_distributed_items_total |
direction=out |
topObservedWm |
streaming_job_watermark_seconds |
type=top_observed |
coalescedWm |
streaming_job_watermark_seconds |
type=coalesced |
lastForwardedWm |
streaming_job_watermark_seconds |
type=last_forwarded |
lastForwardedWmLatency |
streaming_job_watermark_latency_seconds |
n/a |
queuesCapacity |
streaming_job_queues_capacity_total |
n/a |
queuesSize |
streaming_job_queues_size_total |
n/a |
emittedCount |
streaming_job_items_emitted_total |
n/a |
receivedCount |
streaming_job_items_received_total |
n/a |
receivedBatches |
streaming_job_batches_received_total |
n/a |
numInFlightOps |
streaming_job_operations_in_flight_total |
n/a |
totalKeys |
streaming_job_keys_total |
n/a |
totalWindows |
streaming_job_windows_total |
n/a |
totalFrames |
streaming_job_frames_total |
n/a |
totalKeysInFrames |
streaming_job_keys_in_frames_total |
n/a |
lateEventsDropped |
streaming_job_late_events_dropped_total |
n/a |
Vector Collection
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
vectorCollection.backupCount |
vector_collection_backups_total |
n/a |
vectorCollection.backupEntryCount |
vector_collection_backup_entries_total |
n/a |
vectorCollection.backupEntryHeapMemoryCost |
vector_collection_backup_entry_heap_memory_cost_bytes |
n/a |
vectorCollection.clearCount |
vector_collection_operations_total |
operation=clear |
vectorCollection.creationTime |
vector_collection_creation_timestamp_seconds |
n/a |
vectorCollection.deleteCount |
vector_collection_operations_total |
operation=delete |
vectorCollection.getCount |
vector_collection_operations_total |
operation=get |
vectorCollection.heapCost |
vector_collection_heap_cost_bytes |
n/a |
vectorCollection.lastAccessTime |
vector_collection_last_access_timestamp_seconds |
n/a |
vectorCollection.lastUpdateTime |
vector_collection_last_update_timestamp_seconds |
n/a |
vectorCollection.maxClearLatency |
vector_collection_latency_max_seconds |
operation=clear |
vectorCollection.maxOptimizeLatency |
vector_collection_latency_max_seconds |
operation=optimize |
vectorCollection.maxSearchLatency |
vector_collection_latency_max_seconds |
operation=search |
vectorCollection.maxSizeLatency |
vector_collection_latency_max_seconds |
operation=size |
vectorCollection.optimizeCount |
vector_collection_operations_total |
operation=optimize |
vectorCollection.ownedEntryCount |
vector_collection_owned_entries_total |
n/a |
vectorCollection.ownedEntryHeapMemoryCost |
vector_collection_owned_entry_heap_memory_cost_bytes |
n/a |
vectorCollection.putAllCount |
vector_collection_operations_total |
operation=put_all |
vectorCollection.putAllEntryCount |
vector_collection_put_all_entries_total |
n/a |
vectorCollection.putCount |
vector_collection_operations_total |
operation=put |
vectorCollection.removeCount |
vector_collection_operations_total |
operation=remove |
vectorCollection.searchCount |
vector_collection_operations_total |
operation=search |
vectorCollection.searchIndexQueryCount |
vector_collection_search_index_queries_total |
n/a |
vectorCollection.searchIndexVisitedNodes |
vector_collection_search_index_visited_nodes_total |
n/a |
vectorCollection.searchResultsCount |
vector_collection_search_results_total |
n/a |
vectorCollection.setCount |
vector_collection_operations_total |
operation=set |
vectorCollection.sizeCount |
vector_collection_operations_total |
operation=size |
vectorCollection.totalClearLatency |
vector_collection_latency_seconds_total |
operation=clear |
vectorCollection.totalDeleteLatency |
vector_collection_latency_seconds_total |
operation=delete |
vectorCollection.totalGetLatency |
vector_collection_latency_seconds_total |
operation=get |
vectorCollection.totalMaxDeleteLatency |
vector_collection_latency_max_seconds |
operation=delete |
vectorCollection.totalMaxGetLatency |
vector_collection_latency_max_seconds |
operation=get |
vectorCollection.totalMaxPutAllLatency |
vector_collection_latency_max_seconds |
operation=put_all |
vectorCollection.totalMaxPutLatency |
vector_collection_latency_max_seconds |
operation=put |
vectorCollection.totalMaxRemoveLatency |
vector_collection_latency_max_seconds |
operation=remove |
vectorCollection.totalMaxSetLatency |
vector_collection_latency_max_seconds |
operation=set |
vectorCollection.totalOptimizeLatency |
vector_collection_latency_seconds_total |
operation=optimize |
vectorCollection.totalPutAllLatency |
vector_collection_latency_seconds_total |
operation=put_all |
vectorCollection.totalPutLatency |
vector_collection_latency_seconds_total |
operation=put |
vectorCollection.totalRemoveLatency |
vector_collection_latency_seconds_total |
operation=remove |
vectorCollection.totalSearchLatency |
vector_collection_latency_seconds_total |
operation=search |
vectorCollection.totalSetLatency |
vector_collection_latency_seconds_total |
operation=set |
vectorCollection.totalSizeLatency |
vector_collection_latency_seconds_total |
operation=size |
MultiMap
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
multiMap.backupCount |
multi_map_backups_total |
n/a |
multiMap.backupEntryCount |
multi_map_backup_entries_total |
n/a |
multiMap.backupEntryMemoryCost |
multi_map_backup_entries_memory_cost_bytes |
n/a |
multiMap.creationTime |
multi_map_creation_timestamp_seconds |
n/a |
multiMap.dirtyEntryCount |
multi_map_dirty_entries_total |
n/a |
multiMap.getCount |
multi_map_operations_total |
operation=get |
multiMap.heapCost |
multi_map_heap_cost_bytes |
n/a |
multiMap.hits |
multi_map_hits_total |
n/a |
multiMap.indexedQueryCount |
multi_map_indexed_queries_total |
n/a |
multiMap.lastAccessTime |
multi_map_last_access_timestamp_seconds |
n/a |
multiMap.lastUpdateTime |
multi_map_last_update_timestamp_seconds |
n/a |
multiMap.lockedEntryCount |
multi_map_locked_entries_total |
n/a |
multiMap.merkleTreesCost |
multi_map_merkle_trees_cost_bytes |
n/a |
multiMap.numberOfEvents |
multi_map_events_total |
n/a |
multiMap.numberOfOtherOperations |
multi_map_operations_total |
operation=other |
multiMap.ownedEntryCount |
multi_map_owned_entries_total |
n/a |
multiMap.ownedEntryMemoryCost |
multi_map_owned_entry_memory_cost_bytes |
n/a |
multiMap.putCount |
multi_map_operations_total |
operation=put |
multiMap.queryCount |
multi_map_queries_total |
n/a |
multiMap.removeCount |
multi_map_operations_total |
operation=remove |
multiMap.setCount |
multi_map_operations_total |
operation=set |
multiMap.totalGetLatency |
multi_map_latency_seconds_total |
operation=get |
multiMap.totalMaxGetLatency |
multi_map_latency_max_seconds |
operation=get |
multiMap.totalMaxPutLatency |
multi_map_latency_max_seconds |
operation=put |
multiMap.totalMaxRemoveLatency |
multi_map_latency_max_seconds |
operation=remove |
multiMap.totalMaxSetLatency |
multi_map_latency_max_seconds |
operation=set |
multiMap.totalPutLatency |
multi_map_latency_seconds_total |
operation=put |
multiMap.totalRemoveLatency |
multi_map_latency_seconds_total |
operation=remove |
multiMap.totalSetLatency |
multi_map_latency_seconds_total |
operation=set |
CP Subsystem
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
cp.atomiclong.value |
cp_atomiclong_value_info |
n/a |
cp.countdownlatch.count |
cp_countdownlatch_total |
n/a |
cp.countdownlatch.remaining |
cp_countdownlatch_remaining_total |
n/a |
cp.countdownlatch.round |
cp_countdownlatch_round_total |
n/a |
cp.lock.acquireLimit |
cp_lock_acquire_limit_total |
n/a |
cp.lock.lockCount |
cp_lock_locks_total |
n/a |
cp.lock.owner |
cp_lock_owner_info |
n/a |
cp.lock.ownerSessionId |
cp_lock_owner_session_id_info |
n/a |
cp.semaphore.available |
cp_semaphore_available_total |
n/a |
cp.semaphore.initialized |
cp_semaphore_initialized_info |
n/a |
cp.map.size |
cp_map_size_total |
n/a |
cp.map.sizeBytes |
cp_map_size_bytes |
n/a |
cp.session.creationTime |
cp_session_creation_timestamp_seconds |
n/a |
cp.session.endpoint |
cp_session_endpoint_info |
n/a |
cp.session.endpointType |
cp_session_endpoint_type_info |
n/a |
cp.session.expirationTime |
cp_session_expiration_timestamp_seconds |
n/a |
cp.session.version |
cp_session_version_total |
n/a |
cp.atomiclong.summary.destroyed.count |
cp_summary_total |
object_type=atomiclong, state=destroyed |
cp.atomiclong.summary.live.count |
cp_summary_total |
object_type=atomiclong, state=live |
cp.atomicref.summary.destroyed.count |
cp_summary_total |
object_type=atomicref, state=destroyed |
cp.atomicref.summary.live.count |
cp_summary_total |
object_type=atomicref, state=live |
cp.countdownlatch.summary.destroyed.count |
cp_summary_total |
object_type=countdownlatch, state=destroyed |
cp.countdownlatch.summary.live.count |
cp_summary_total |
object_type=countdownlatch, state=live |
cp.lock.summary.destroyed.count |
cp_summary_total |
object_type=lock, state=destroyed |
cp.lock.summary.live.count |
cp_summary_total |
object_type=lock, state=live |
cp.map.summary.destroyed.count |
cp_summary_total |
object_type=map, state=destroyed |
cp.map.summary.live.count |
cp_summary_total |
object_type=map, state=live |
cp.semaphore.summary.destroyed.count |
cp_summary_total |
object_type=semaphore, state=destroyed |
cp.semaphore.summary.live.count |
cp_summary_total |
object_type=semaphore, state=live |
Partitions
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
partitions.activePartitionCount |
partitions_active_total |
n/a |
partitions.completedMigrations |
partitions_completed_migrations_total |
period=latest_repartitioning |
partitions.elapsedDestinationCommitTime |
partitions_elapsed_destination_commit_time_seconds_total |
period=latest_repartitioning |
partitions.elapsedMigrationOperationTime |
partitions_elapsed_migration_operation_time_seconds_total |
period=latest_repartitioning |
partitions.elapsedMigrationTime |
partitions_elapsed_migration_time_seconds_total |
period=latest_repartitioning |
partitions.lastRepartitionTime |
partitions_last_repartition_timestamp_seconds |
n/a |
partitions.localPartitionCount |
partitions_local_total |
n/a |
partitions.maxBackupCount |
partitions_max_backups_total |
n/a |
partitions.memberGroupsSize |
partitions_member_groups_size_total |
n/a |
partitions.migrationActive |
partitions_migration_active_info |
n/a |
partitions.migrationQueueSize |
partitions_migration_queue_size_total |
n/a |
partitions.partitionCount |
partitions_total |
n/a |
partitions.plannedMigrations |
partitions_planned_migrations_total |
n/a |
partitions.replicaSyncRequestsCounter |
partitions_replica_sync_requests_total |
n/a |
partitions.replicaSyncSemaphore |
partitions_replica_sync_semaphore_permits_total |
n/a |
partitions.stateStamp |
partitions_state_stamp_info |
n/a |
partitions.totalCompletedMigrations |
partitions_completed_migrations_total |
period=since_beginning |
partitions.totalElapsedDestinationCommitTime |
partitions_elapsed_destination_commit_time_seconds_total |
period=since_beginning |
partitions.totalElapsedMigrationOperationTime |
partitions_elapsed_migration_operation_time_seconds_total |
period=since_beginning |
partitions.totalElapsedMigrationTime |
partitions_elapsed_migration_time_seconds_total |
period=since_beginning |
WAN Replication
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
wan.ackDelayCurrentMillis |
wan_ack_delay_current_time_seconds |
n/a |
wan.ackDelayLastEnd |
wan_ack_delay_last_end_timestamp_seconds |
n/a |
wan.ackDelayLastStart |
wan_ack_delay_last_start_timestamp_seconds |
n/a |
wan.ackDelayTotalCount |
wan_ack_delay_total |
n/a |
wan.ackDelayTotalMillis |
wan_ack_delay_total_time_seconds |
n/a |
wan.consistencyCheck.lastCheckedPartitionCount |
wan_consistency_check_last_checked_partitions_total |
n/a |
wan.consistencyCheck.lastCheckedLeafCount |
wan_consistency_check_last_checked_leaves_total |
n/a |
wan.consistencyCheck.lastDiffLeafCount |
wan_consistency_check_last_diff_leaves_total |
n/a |
wan.consistencyCheck.lastDiffPartitionCount |
wan_consistency_check_last_diff_partitions_total |
n/a |
wan.consistencyCheck.lastEntriesToSync |
wan_consistency_check_last_entries_to_sync_total |
n/a |
wan.droppedCount |
wan_events_total |
event_type=drop |
wan.outboundQueueSize |
wan_outbound_queue_size_total |
n/a |
wan.removeCount |
wan_events_total |
event_type=remove |
wan.syncCount |
wan_events_total |
event_type=sync |
wan.sync.avgEntriesPerLeaf |
wan_sync_entries_per_leaf_total |
aggregation=avg |
wan.sync.maxLeafEntryCount |
wan_sync_entries_per_leaf_total |
aggregation=max |
wan.sync.minLeafEntryCount |
wan_sync_entries_per_leaf_total |
aggregation=min |
wan.sync.nodesSynced |
wan_sync_nodes_synced_total |
n/a |
wan.sync.partitionsSynced |
wan_sync_partitions_synced_total |
n/a |
wan.sync.partitionsToSync |
wan_sync_partitions_to_sync_total |
n/a |
wan.sync.recordsSynced |
wan_sync_records_synced_total |
n/a |
wan.sync.syncDurationNanos |
wan_sync_duration_seconds |
n/a |
wan.sync.stdDevEntriesPerLeaf |
wan_sync_entries_per_leaf_total |
aggregation=std_dev |
wan.sync.syncStartNanos |
wan_sync_start_time_seconds |
n/a |
wan.totalPublishLatency |
wan_publish_latency_seconds_total |
n/a |
wan.totalPublishedEventCount |
wan_published_events_total |
n/a |
wan.updateCount |
wan_events_total |
event_type=update |
wan.connectionHealth |
wan_connection_healthy_info |
n/a |
wan.failedTransmitCount |
wan_failed_transmits_total |
n/a |
Management Center
V1 metric hz_ |
V2 metric hazelcast_ |
Additional labels |
|---|---|---|
healthcheck_status_fail |
healthcheck_failures_total |
n/a |
healthcheck_status_warning |
healthcheck_warnings_total |
n/a |
healthcheck_status_info |
healthcheck_info_total |
n/a |
healthcheck_status_pass |
healthcheck_passes_total |
n/a |
healthcheck_status_na |
healthcheck_na_total |
n/a |
slow_operation_invocation_duration |
slow_operation_invocations_duration_seconds_total |
n/a |
slow_operation_total_invocations |
slow_operation_invocations_total |
n/a |