All Metrics

A list of all the metrics in use for Hydrolix

This page contains most metrics used in Hydrolix for the following:

Use find on page to locate specific metrics.

Custom Hydrolix metrics

Custom general metrics

MetricTypeComponentsPurpose
bytes_writtenCounterBatch peer, Stream peerBytes written to the indexer.
partitions_createdCounterBatch peer, Stream peerCount of partitions created.
upload_durationSummaryAny intake peerTime spent uploading a file, in milliseconds.

Custom query metrics

MetricTypeComponentsPurpose
net_connect_attempts_totalHistogramHead/Query peerHistogram of TCP connection attempts to the storage service.
net_connect_secondsHistogramHead/Query peerHistogram of time to connect over TCP to the storage service, in seconds.
net_dns_resolve_secondsHistogramHead/Query peerHistogram of DNS resolution time for the storage service, in seconds.
net_http_response_timeHistogramHead/Query peerHistogram of HTTP response times from the storage service, in seconds.
net_http_response_bytesHistogramHead/Query peerHistogram of HTTP bytes downloaded from the storage service.
net_http_attempts_totalHistogramHead/Query peerHistogram of HTTP connection attempts to the storage service.
net_http_status_codeHistogramHead/Query peerHistogram of HTTP status codes from the storage service.
vfs_cache_hitmiss_totalHistogramHead/Query peerHistogram of cache status (bucket=0 cache miss, bucket=1 cache hit).
vfs_cache_read_bytesHistogramHead/Query peerHistogram of bytes read from the cache.
vfs_net_read_bytesHistogramHead/Query peerHistogram of bytes read from the network.
vfs_cache_lru_file_eviction_totalHistogramHead/Query peerHistogram of file evictions from the cache.
epoll_cpu_secondsHistogramHead/Query peerHistogram of CPU usage in seconds.
epoll_io_secondsHistogramHead/Query peerHistogram of I/O times in seconds.
epoll_poll_secondsHistogramHead/Query peerHistogram of wait times for file descriptors, in seconds.
hdx_storage_r_catalog_partitions_totalHistogramHead/Query peerHistogram of per-query catalog partition count.
hdx_storage_r_partitions_read_totalHistogramHead/Query peerHistogram of per-query partition read count.
hdx_storage_r_partitions_per_core_totalHistogramHead/Query peerHistogram of per-core partition usage count.
hdx_storage_r_peers_used_totalHistogramQuery peerHistogram of storage used total.
hdx_storage_r_cores_used_totalHistogramQuery peerHistogram of cores used total.
hdx_storage_r_catalog_timerangeHistogramHead/Query peerHistogram of query time-range distribution.
hdx_partition_columns_read_totalHistogramHead/Query peerHistogram of columns read.
hdx_partition_block_decode_secondsHistogramHead/Query peerHistogram of time spent decoding HDX blocks, in seconds.
hdx_partition_open_secondsHistogramHead/Query peerHistogram of time spent opening HDX partitions, in seconds.
hdx_partition_read_secondsHistogramHead/Query peerHistogram of time spent reading HDX partitions, in seconds.
hdx_partition_skipped_totalHistogramHead/Query peerHistogram of partitions skipped due to no matching columns.
hdx_partition_blocks_read_totalHistogramHead/Query peerHistogram of partition-block read counts.
hdx_partition_blocks_avail_totalHistogramHead/Query peerHistogram of partition blocks available.
hdx_partition_index_decisionHistogramHead/Query peerHistogram of partition decisions (bucket=0 full scan, 1 partial scan, 2 no match).
hdx_partition_index_lookup_secondsHistogramHead/Query peerHistogram of index lookup times, in seconds.
hdx_partition_index_blocks_skipped_percentHistogramHead/Query peerHistogram of skipped index blocks, in percentage.
hdx_partition_index_blocks_skipped_totalHistogramHead/Query peerHistogram of total skipped index blocks.
hdx_partition_rd_w_err_totalHistogramHead/Query peerHistogram of read/write errors (bucket=0 read error, 1 write error, 3 error).
query_iowait_secondsHistogramHead/Query peerHistogram of query I/O wait times, in seconds.
query_cpuwait_secondsHistogramHead/Query peerHistogram of query CPU wait times, in seconds.
query_hdx_ch_conv_secondsHistogramHead/Query peerHistogram of time spent converting HDX blocks to ClickHouse, in seconds.
query_healthHistogramHead/Query peerHistogram of query health (bucket=0 initiated error, 1 succeeded, 2 error).
query_peer_availabilityHistogramHead/Query peerHistogram of peer availability (bucket=0 primary_peer_available, 1 secondary_peer_available, 2 no_reachable_peers).
query_attempts_totalHistogramHead/Query peerHistogram of total query attempts.
query_response_secondsHistogramHead/Query peerHistogram of total query response times, in seconds.
query_rows_read_totalHistogramHead/Query peerHistogram of total query rows read.
query_read_bytesHistogramHead/Query peerHistogram of total query read bytes.
query_rows_written_totalHistogramHead/Query peerHistogram of total query rows written.

Custom batch metrics

MetricTypeComponentsPurpose
processed_countCounterBatch peerCount of items processed.
processed_failureCounterBatch peerCount of processing failures.
processing_duration_histoHistogramBatch peerHistogram of Batch processing durations (milliseconds).
processing_duration_summarySummaryBatch peerSummary of Batch processing durations (milliseconds).
rows_readCounterBatch peerCount of rows read.

Custom merge metrics

MetricTypeComponentsPurpose
merge_duration_summarySummaryMerge peerMerge processing duration, in milliseconds.
merge_duration_histoHistogramMerge peerMerge processing duration, in milliseconds.
merge_sdk_duration_summarySummaryMerge peerMerge SDK processing duration, in milliseconds.
merge_sdk_duration_histoHistogramMerge peerMerge SDK processing duration, in milliseconds.
merge_candidate_histoHistogramMerge peerPartitions per merge candidate.
merge_candidate_inactiveCounterMerge peerMerge candidates skipped due to an inactive partition within the candidate.
merge_candidate_construction_summarySummaryMerge headTime spent building merge candidates, in milliseconds.
merge_queue_fullCounterMerge headTimes candidate generation was skipped due to a full queue.
merge_successCounterMerge peerCount of merge successes.
merge_failureCounterMerge peerCount of merge failures.

Custom streaming metrics

MetricTypeComponentsPurpose
hdx_sink_backlog_bytes_countGaugeIntake headTotal bytes of all partition buckets in the sink backlog waiting to be indexed (requires intake_head_index_backlog_enabled = true).
hdx_sink_backlog_items_countGaugeIntake headTotal count of partition buckets in the backlog (requires intake_head_index_backlog_enabled = true).
hdx_sink_backlog_dropped_bytes_countCounterIntake headTotal bytes of partition buckets dropped due to backlog overflow (requires intake_head_index_backlog_enabled = true).
hdx_sink_backlog_dropped_items_countCounterIntake headCount of partition buckets dropped due to backlog overflow (requires intake_head_index_backlog_enabled = true).
hdx_sink_backlog_delivery_countCounterIntake headCount of backlog buckets successfully handed off to indexing (requires intake_head_index_backlog_enabled = true).
hdx_sink_backlog_trim_duration_nsHistogramIntake headTime to trim the backlog in nanoseconds (requires intake_head_index_backlog_enabled = true).
http_source_byte_countCounterStream headCount of bytes processed.
http_source_request_countCounterStream headCount of HTTP requests.
http_source_request_duration_nsHistogramStream headHistogram of HTTP request durations in nanoseconds.
http_source_request_error_countCounterStream headCount of HTTP request failures.
http_source_row_countCounterStream headCount of rows processed.
http_source_value_countCounterStream headCount of values processed.

Custom Kinesis metrics

MetricTypeComponentsPurpose
kinesis_source_byte_countCounterStream peerCount of bytes read from Kinesis.
kinesis_source_checkpoint_countCounterStream peerCount of Kinesis checkpoint operations.
kinesis_source_checkpoint_duration_nsHistogramStream peerDuration of Kinesis checkpoint operations, in nanoseconds.
kinesis_source_checkpoint_error_countCounterStream peerCount of Kinesis checkpoint operation errors.
kinesis_source_error_countCounterStream peerCount of errors reading from Kinesis.
kinesis_source_lag_msGaugeStream peerMeasure of lag in Kinesis, in milliseconds.
kinesis_source_operation_countCounterStream peerCount of Kinesis operations.
kinesis_source_operation_duration_nsHistogramStream peerHistogram of Kinesis operation durations, in nanoseconds.
kinesis_source_record_countCounterStream peerCount of records read from Kinesis.
kinesis_source_row_countCounterStream peerCount of rows read from Kinesis.
kinesis_source_value_countCounterStream peerCount of values read from Kinesis.

Custom Kafka metrics

MetricTypeComponentsPurpose
kafka_source_byte_countCounterStream peerCount of bytes read from Kafka.
kafka_source_commit_duration_nsHistogramStream peerKafka commit duration, in nanoseconds.
kafka_source_read_countCounterStream peerCount of Kafka reads.
kafka_source_read_duration_nsHistogramStream peerKafka read duration, in nanoseconds.
kafka_source_read_error_countCounterStream peerCount of Kafka errors.
kafka_source_row_countCounterStream peerCount of rows processed from Kafka.
kafka_source_value_countCounterStream peerCount of values processed from Kafka.

Custom DNS metrics

MetricTypeComponentsPurpose
dns_num_ips_in_cacheHistogram(ingest)The size of the IP pool used in the DNS system.
dns_lookup_timeHistogram(ingest)Milliseconds per lookup.
dns_ttlHistogram(ingest)TTLs received per lookup.

Custom PostgreSQL metrics

MetricTypePurpose
pgx_pool_total_acquire_countCountThe cumulative count of successful acquires from the pool.
pgx_pool_total_acquire_duration_ns_countCountThe total duration (ns) of all successful acquires from the pool.
pgx_pool_total_acquire_cancel_countCountThe cumulative count of acquires from the pool that were canceled by a context.
pgx_pool_total_acquire_empty_countCountThe cumulative count of successful acquires from the pool that had to wait for a resource because the pool was empty.
pgx_pool_total_conns_opened_countCountThe cumulative count of new connections opened.
pgx_pool_total_destroyed_max_lifetime_countCountThe cumulative count of connections destroyed because they exceeded MaxConnLifetime.
pgx_pool_total_destroyed_max_idle_countCountThe cumulative count of connections destroyed because they exceeded MaxConnIdleTime.
pgx_pool_current_sizeGaugeThe total number of resources currently in the pool.
pgx_pool_current_constructingGaugeThe number of connections currently being constructed.
pgx_pool_current_acquiredGaugeThe number of connections currently acquired.
pgx_pool_current_idleGaugeThe number of currently idle connections in the pool.
pgx_pool_maxGaugeThe maximum size of the pool.

Age metrics

Metric NameTypeComponentsPurpose
query_countCounterDecay/Reaper calls to the Catalog.
query_failureCounterDecay/Reaper failed Catalog calls.
query_latency_summaryCounterLatency in calls to catalog.
query_latency_summary_count/sumCounterLatency in calls to catalog.

Alter metrics

Metric NameTypeComponentsPurpose
query_countCounterDecay/Reaper calls to the Catalog.
query_failureCounterDecay/Reaper failed Catalog calls.
query_latency_summaryCounterLatency in calls to catalog.
query_latency_summary_count/sumCounterLatency in calls to catalog.

Merge metrics

Metric NameTypeComponentsPurpose
merge_successCounterCount of merge successes.
merge_failureCounterCount of merge successes.
query_countCounterMerge calls to the Catalog.
query_failureCounterMerge failed Catalog calls.
query_latency_summaryCounterLatency in calls to catalog.
query_latency_summary_count/sumCounterLatency in calls to catalog.
merge_duration_histo_bucket/count/sumHistogramMerge processing duration, in milliseconds.
merge_duration_summarySummaryMerge processing duration, in milliseconds.

RabbitMQ metrics

Metric NameTypeComponentsPurpose
rabbitmq_queue_messagesCounterSum of ready and unacknowledged messages (queue depth).
rabbitmq_queuesCounterRabbitMQ Queues count.
erlang_vm_statistics_bytes_received_totalCounterThe total number of bytes received through RabbitMQ ports.
erlang_vm_statistics_bytes_output_totalCounterThe total number of bytes output through RabbitMQ ports.

Prometheus

Prometheus batch metrics

Metric NameTypeComponentsPurpose
processed_countCounterBatch peerCount of items processed.
processed_failureCounterBatch peerCount of processing failures.
rows_readCounterBatch peerCount of rows read.
processing_duration_histoHistogramBatch peerHistogram of Batch processing durations in milliseconds.
processing_duration_summarySummaryBatch peerSummary of Batch processing durations in milliseconds.

Prometheus DNS metrics

Metric NameTypeComponentsPurpose
dns_num_ips_in_cacheHistogram(ingest)The size of the IP pool used in the DNS system.
dns_lookup_timeHistogram(ingest)Milliseconds per lookup.
dns_ttlHistogram(ingest)TTLs received per lookup.

Prometheus general metrics

Metric NameTypeComponentsPurpose
bytes_writtenCounterBatch peer, Stream peerBytes written to the indexer.
partitions_createdCounterBatch peer, Stream peerCount of partitions created.
process_cpu_seconds_totalCounterBatch peer, Stream head, Stream peerTotal user and system CPU time spent in seconds.
promhttp_metric_handler_requests_totalCounterBatch peer, Stream head, Stream peerTotal number of scrapes by HTTP status code.
process_max_fdsGaugeBatch peer, Stream head, Stream peerMaximum number of open file descriptors.
process_open_fdsGaugeBatch peer, Stream head, Stream peerNumber of open file descriptors.
process_resident_memory_bytesGaugeBatch peer, Stream head, Stream peerResident memory size in bytes.
process_start_time_secondsGaugeBatch peer, Stream head, Stream peerStart time of the process since unix epoch in seconds.
process_virtual_memory_bytesGaugeBatch peer, Stream head, Stream peerVirtual memory size in bytes.
process_virtual_memory_max_bytesGaugeBatch peer, Stream head, Stream peerMaximum amount of virtual memory available in bytes.
promhttp_metric_handler_requests_in_flightGaugeBatch peer, Stream head, Stream peerCurrent number of scrapes being served.
upload_durationSummaryAny intake peerTime spent uploading a file, in milliseconds

Prometheus Go metrics

Metric NameTypeComponentsPurpose
go_memstats_alloc_bytes_totalCounterBatch peer, Stream head, Stream peerTotal number of bytes allocated, even if freed.
go_memstats_frees_totalCounterBatch peer, Stream head, Stream peerTotal number of frees.
go_memstats_lookups_totalCounterBatch peer, Stream head, Stream peerTotal number of pointer lookups.
go_memstats_mallocs_totalCounterBatch peer, Stream head, Stream peerTotal number of mallocs.
go_goroutinesGaugeBatch peer, Stream head, Stream peerNumber of goroutines that currently exist.
go_infoGaugeBatch peer, Stream head, Stream peerInformation about the Go environment.
go_memstats_alloc_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes allocated and still in use.
go_memstats_buck_hash_sys_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes used by the profiling bucket hash table.
go_memstats_gc_cpu_fractionGaugeBatch peer, Stream head, Stream peerThe fraction of this program's available CPU time used by the GC since the program started.
go_memstats_gc_sys_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes used for garbage collection system metadata.
go_memstats_heap_alloc_bytesGaugeBatch peer, Stream head, Stream peerNumber of heap bytes allocated and still in use.
go_memstats_heap_idle_bytesGaugeBatch peer, Stream head, Stream peerNumber of heap bytes waiting to be used.
go_memstats_heap_inuse_bytesGaugeBatch peer, Stream head, Stream peerNumber of heap bytes that are in use.
go_memstats_heap_objectsGaugeBatch peer, Stream head, Stream peerNumber of allocated objects.
go_memstats_heap_released_bytesGaugeBatch peer, Stream head, Stream peerNumber of heap bytes released to OS.
go_memstats_heap_sys_bytesGaugeBatch peer, Stream head, Stream peerNumber of heap bytes obtained from system.
go_memstats_last_gc_time_secondsGaugeBatch peer, Stream head, Stream peerNumber of seconds since 1970 of last garbage collection.
go_memstats_mcache_inuse_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes in use by mcache structures.
go_memstats_mcache_sys_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes used for mcache structures obtained from system.
go_memstats_mspan_inuse_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes in use by mspan structures.
go_memstats_mspan_sys_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes used for mspan structures obtained from system.
go_memstats_next_gc_bytesGaugeBatch peer, Stream head, Stream peerNumber of heap bytes when next garbage collection will take place.
go_memstats_other_sys_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes used for other system allocations.
go_memstats_stack_inuse_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes in use by the stack allocator.
go_memstats_stack_sys_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes obtained from system for stack allocator.
go_memstats_sys_bytesGaugeBatch peer, Stream head, Stream peerNumber of bytes obtained from system.
go_threadsGaugeBatch peer, Stream head, Stream peerNumber of OS threads created.
go_gc_duration_secondsSummaryBatch peer, Stream head, Stream peerA summary of the pause duration of garbage collection cycles.

Prometheus stream ingest metrics

Metric NameTypeComponentsPurpose
hdx_sink_backlog_dropped_bytes_countCounterIntake headTotal bytes of partition buckets dropped due to backlog growing too big. Only produced when intake_head_index_backlog_enabled is true.
hdx_sink_backlog_dropped_items_countCounterIntake headCount of partition buckets dropped due to backlog growing too big. Only produced when intake_head_index_backlog_enabled is true.
hdx_sink_backlog_delivery_countCounterIntake headCount of backlog buckets successfully handed off to indexing. Only produced when intake_head_index_backlog_enabled is true.
http_source_byte_countCounterStream headCount of bytes processed.
http_source_request_countCounterStream headCount of http requests.
http_source_request_error_countCounterStream headCount of http request failures.
http_source_row_countCounterStream headCount of rows processed.
http_source_value_countCounterStream headCount of values processed.
kinesis_source_byte_countCounterStream peerCount of bytes read from Kinesis.
kinesis_source_checkpoint_countCounterStream peerCount of Kinesis checkpoint operations.
kinesis_source_checkpoint_error_countCounterStream peerCount of errors in Kinesis checkpoint operations.
kinesis_source_error_countCounterStream peerCount of errors in Kinesis source reads.
kinesis_source_operation_countCounterStream peerCount of operations on Kinesis.
kinesis_source_record_countCounterStream peerCount of records read from Kinesis.
kinesis_source_row_countCounterStream peerCount of rows read from Kinesis.
kinesis_source_value_countCounterStream peerCount of values read from Kinesis.
hdx_sink_backlog_bytes_countGaugeIntake headTotal bytes of all partition buckets in sink backlog waiting to be indexed. Only produced when intake_head_index_backlog_enabled is true.
hdx_sink_backlog_items_countGaugeIntake headTotal count of partition buckets in sink backlog waiting to be indexed. Only produced when intake_head_index_backlog_enabled is true.
kinesis_source_lag_msGaugeStream peerMeasure of lag in Kinesis source.
hdx_sink_backlog_trim_duration_nsHistogramIntake headTime to trim the backlog in nanoseconds. Only produced when intake_head_index_backlog_enabled is true.
http_source_request_duration_nsHistogramStream headA histogram of HTTP request durations in nanoseconds.
kinesis_source_checkpoint_duration_nsHistogramStream peerDuration of Kinesis checkpoint operations.
kinesis_source_operation_duration_nsHistogramStream peerHistogram of duration of operations on Kinesis.

Prometheus Kafka metrics

Metric NameTypeComponentsPurpose
kafka_source_byte_countCounterStream peerCount of bytes read from Kafka.
kafka_source_read_countCounterStream peerCount of Kafka reads.
kafka_source_read_error_countCounterStream peerCount of Kafka errors.
kafka_source_row_countCounterStream peerCount of rows processed.
kafka_source_value_countCounterStream peerCount of values processed.
kafka_source_commit_duration_nsHistogramStream peerKafka commit duration.
kafka_source_read_duration_nsHistogramStream peerKafka read duration.

Prometheus merge metrics

Metric NameTypeComponentsPurpose
merge_candidate_inactiveCounterMerge peerMerge candidates skipped due to an inactive partition within the candidate
merge_queue_fullCounterMerge headTimes candidate generation was skipped due to a full queue
merge_successCounterMerge peerCount of merge successes.
merge_failureCounterMerge peerCount of merge successes.
merge_duration_histoHistogramMerge peerMerge processing duration, in milliseconds.
merge_sdk_duration_histoHistogramMerge peerMerge SDK processing duration, in milliseconds.
merge_candidate_histoHistogramMerge peerPartitions per merge candidate.
merge_duration_summarySummaryMerge peerMerge processing duration, in milliseconds.
merge_sdk_duration_summarySummaryMerge peerMerge SDK processing duration, in milliseconds.
merge_candidate_construction_summarySummaryMerge headTime spent building merge candidates, in milliseconds.

Prometheus PostgreSQL metrics

Metric NameTypeComponentsPurpose
pgx_pool_total_acquire_countCountThe cumulative count of successful acquires from the pool.
pgx_pool_total_acquire_duration_ns_countCountThe total duration of all successful acquires from the pool.
pgx_pool_total_acquire_cancel_countCountThe cumulative count of acquires from the pool that were canceled by a context.
pgx_pool_total_acquire_empty_countCountThe cumulative count of successful acquires from the pool that waited for a resource to be released or constructed because the pool was empty.
pgx_pool_total_conns_opened_countCountThe cumulative count of new connections opened.
pgx_pool_total_destroyed_max_lifetime_countCountThe cumulative count of connections destroyed because they exceeded MaxConnLifetime.
pgx_pool_total_destroyed_max_idle_countCountThe cumulative count of connections destroyed because they exceeded MaxConnIdleTime.
pgx_pool_current_sizeGaugeThe total number of resources currently in the pool.
pgx_pool_current_constructingGaugeThe number of connections with construction in progress in the pool.
pgx_pool_current_acquiredGaugeThe number of currently acquired connections in the pool.
pgx_pool_current_idleGaugeThe number of currently idle connections in the pool.
pgx_pool_maxGaugeThe maximum size of the pool.

Prometheus query metrics

Metric NameTypeComponentsPurpose
net_connect_attempts_totalHistogramHead/Query peerHistogram of TCP connection attempted to storage service
net_connect_secondsHistogramHead/Query peerHistogram of time to connect over TCP to storage service in seconds
net_dns_resolve_secondsHistogramHead/Query peerHistogram of DNS resolution time to storage service in seconds.
net_http_response_timeHistogramHead/Query peerHistogram HTTP response time to storage service in seconds
net_http_response_bytesHistogramHead/Query peerHistogram of HTTP bytes downloaded from the storage service
net_http_attempts_totalHistogramHead/Query peerHistogram of HTTP connection attempted to storage service
net_http_status_codeHistogramHead/Query peerHistogram of HTTP status code result from storage service
vfs_cache_hitmiss_totalHistogramHead/Query peerHistogram of cache status if bucket = 0 cache miss, and 1 cache hit
vfs_cache_read_bytesHistogramHead/Query peerHistogram bytes read from cache
vfs_net_read_bytesHistogramHead/Query peerHistogram bytes read from network
vfs_cache_lru_file_eviction_totalHistogramHead/Query peerHistogram cache eviction of files
epoll_cpu_secondsHistogramHead/Query peerHistogram CPU used in seconds
epoll_io_secondsHistogramHead/Query peerHistogram I/O in seconds
epoll_poll_secondsHistogramHead/Query peerHistogram wait for file descriptor in seconds
hdx_storage_r_catalog_partitions_totalHistogramHead/Query peerHistogram of per query catalog partition count
hdx_storage_r_partitions_read_totalHistogramHead/Query peerHistogram of per query partition read count
hdx_storage_r_partitions_per_core_totalHistogramHead/Query peerHistogram of per core partition used count
hdx_storage_r_peers_used_totalHistogramQuery peerHistogram of storage used total
hdx_storage_r_cores_used_totalHistogramQuery peerHistogram of Cores used total
hdx_storage_r_catalog_timerangeHistogramHead/Query peerHistogram of query time range distribution
hdx_partition_columns_read_totalHistogramHead/Query peerHistogram of column read
hdx_partition_block_decode_secondsHistogramHead/Query peerHistogram of time spent decoding hdx blocks in seconds
hdx_partition_open_secondsHistogramHead/Query peerHistogram of time spent opening hdx partition in seconds
hdx_partition_read_secondsHistogramHead/Query peerHistogram of time spent reading hdx partition in seconds
hdx_partition_skipped_totalHistogramHead/Query peerHistogram of partition skip count due to no matching columns
hdx_partition_blocks_read_totalHistogramHead/Query peerHistogram of partition read count
hdx_partition_blocks_avail_totalHistogramHead/Query peerHistogram of partition blocks available
hdx_partition_index_decisionHistogramHead/Query peerHistogram of partition decision if bucket = 0 fullscan, 1 partial scan and 2 no match
hdx_partition_index_lookup_secondsHistogramHead/Query peerHistogram of index lookup in seconds
hdx_partition_index_blocks_skipped_percentHistogramHead/Query peerHistogram of skipped index blocked in percentage
hdx_partition_index_blocks_skipped_totalHistogramHead/Query peerHistogram of skipped index blocked in total
hdx_partition_rd_w_err_totalHistogramHead/Query peerHistogram of errors if bucket = 0 read error, 1 written error and 3 error
query_iowait_secondsHistogramHead/Query peerHistogram query IO wait in seconds
query_cpuwait_secondsHistogramHead/Query peerHistogram query cpu wait in seconds
query_hdx_ch_conv_secondsHistogramHead/Query peerHistogram of time spent converting hdx blocks to clickhouse in seconds
query_healthHistogramHead/Query peerHistogram of query health if bucket = 0 initiated error, 1 succeeded and 2 error
query_peer_availabilityHistogramHead/Query peerHistogram of query peer availability if bucket = 0 primary_peer_available, 1 secondary_peer_available and 2 no_reachable_peers
query_attempts_totalHistogramHead/Query peerHistogram of query attempts total
query_response_secondsHistogramHead/Query peerHistogram of query response total in seconds
query_rows_read_totalHistogramHead/Query peerHistogram of query rows read total
query_read_bytesHistogramHead/Query peerHistogram of query read bytes total
query_rows_written_totalHistogramHead/Query peerHistogram of query rows written total

Summary table

Summary table general metrics

Metric NameTypeComponentsPurpose
process_cpu_seconds_totalCounterTotal user and system CPU time spent in seconds.
promhttp_metric_handler_requests_totalCounterTotal number of scrapes by HTTP status code.
process_max_fdsGaugeMaximum number of open file descriptors.
process_open_fdsGaugeNumber of open file descriptors.
process_resident_memory_bytesGaugeResident memory size in bytes.
process_start_time_secondsGaugeStart time of the process since unix epoch in seconds.
process_virtual_memory_bytesGaugeVirtual memory size in bytes.
process_virtual_memory_max_bytesGaugeMaximum amount of virtual memory available in bytes.
promhttp_metric_handler_requests_in_flightGaugeCurrent number of scrapes being served.

Summary table Go metrics

Metric NameTypeComponentsPurpose
go_memstats_alloc_bytes_totalCounterTotal number of bytes allocated, even if freed.
go_memstats_frees_totalCounterTotal number of frees.
go_memstats_lookups_totalCounterTotal number of pointer lookups.
go_memstats_mallocs_totalCounterTotal number of mallocs.
go_goroutinesGaugeNumber of goroutines that currently exist.
go_infoGaugeInformation about the Go environment.
go_memstats_alloc_bytesGaugeNumber of bytes allocated and still in use.
go_memstats_buck_hash_sys_bytesGaugeNumber of bytes used by the profiling bucket hash table.
go_memstats_gc_cpu_fractionGaugeThe fraction of this program's available CPU time used by the GC since the program started.
go_memstats_gc_sys_bytesGaugeNumber of bytes used for garbage collection system metadata.
go_memstats_heap_alloc_bytesGaugeNumber of heap bytes allocated and still in use.
go_memstats_heap_idle_bytesGaugeNumber of heap bytes waiting to be used.
go_memstats_heap_inuse_bytesGaugeNumber of heap bytes that are in use.
go_memstats_heap_objectsGaugeNumber of allocated objects.
go_memstats_heap_released_bytesGaugeNumber of heap bytes released to OS.
go_memstats_heap_sys_bytesGaugeNumber of heap bytes obtained from system.
go_memstats_last_gc_time_secondsGaugeNumber of seconds since 1970 of last garbage collection.
go_memstats_mcache_inuse_bytesGaugeNumber of bytes in use by mcache structures.
go_memstats_mcache_sys_bytesGaugeNumber of bytes used for mcache structures obtained from system.
go_memstats_mspan_inuse_bytesGaugeNumber of bytes in use by mspan structures.
go_memstats_mspan_sys_bytesGaugeNumber of bytes used for mspan structures obtained from system.
go_memstats_next_gc_bytesGaugeNumber of heap bytes when next garbage collection will take place.
go_memstats_other_sys_bytesGaugeNumber of bytes used for other system allocations.
go_memstats_stack_inuse_bytesGaugeNumber of bytes in use by the stack allocator.
go_memstats_stack_sys_bytesGaugeNumber of bytes obtained from system for stack allocator.
go_memstats_sys_bytesGaugeNumber of bytes obtained from system.
go_threadsGaugeNumber of OS threads created.
go_gc_duration_secondsSummaryA summary of the pause duration of garbage collection cycles.

Summary table indexer metrics

Metric NameTypeComponentsPurpose
hdx_sink_row_countCounterBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadCount of rows processed by the indexer and uploaded to storage. Includes Hot and Cold reporting.
hdx_sink_byte_countCounterBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadCount of bytes processed by the indexer and uploaded to storage. Includes Hot and Cold reporting.
hdx_sink_value_countCounterBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadCount of values processed by the indexer and uploaded to storage. Includes Hot and Cold reporting.
hdx_sink_error_countCounterBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadCount of errors in indexing and uploading to storage.
indexer_rows_written_count/bucket/sumHistogramBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadTotal rows indexed (written to partitions)
indexer_bytes_written_count/bucket/sumHistogramBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadTotal bytes indexed (written to partitions)
indexer_partitions_rejected_count/bucket/sumHistogramBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadHistogram of partitions not able to written. If value is 0=raw data parsing failed, 1=raw data / transform schema mismatch, 3=Error writing partition file, 4= Other Error during indexing
indexer_partitions_written_count/bucket/sumHistogramBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadTotal partitions created
indexer_partition_write_seconds_count/bucket/sumHistogramBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadTime from receiving indexing query to writing partition file (seconds)

Summary table Redpanda metrics

Metric NameTypeComponentsPurpose
internal_event_queue_byte_count{mode="sink"}CounterStream HeadByte Count sent to Redpanda
internal_event_queue_row_count{mode="sink""}CounterStream HeadRow Count sent to Redpanda
internal_event_queue_byte_count{mode="sink""}CounterStream HeadByte Count sent to Redpanda
internal_event_queue_row_count{mode="source"}CounterStream SummaryRow Count received from Redpanda
internal_event_queue_value_count{mode="source"}CounterStream SummaryValue Count recieved from Redpanda

Summary table storage metrics

Metric NameTypeComponentsPurpose
object_store_http_status_code_countCountBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadA count of successful HTTP requests against object storage (replaces net_http_status_code_count). Requests resulting in 500 are still considered successful.
object_store_http_error_countCountBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadA count of HTTP request errors (timeouts, connection errors, etc.)
object_store_http_bytes_txCountBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadA count of bytes transmitted to object storage (request body only)
object_store_http_bytes_rxCountBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadA count of bytes received from object storage (response body only)
net_http_status_code_bucketCounterBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadHTTP Status Code histogram count from Storage.
object_store_http_histoHistogramBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadA histogram of object storage interaction latencies
object_store_http_summarySummaryBatch (inc. Autoingest), Kafka, Kinesis, Stream HTTP, Intake HeadA summary of object storage interaction latencies

Summary table stream and intake head metrics

Metric NameTypeComponentsPurpose
http_source_byte_countCounterStream headCount of bytes processed.
http_source_request_countCounterStream headCount of http requests.
http_source_request_error_countCounterStream headCount of http request failures.
http_source_row_countCounterStream headCount of rows processed.
http_source_value_countCounterStream headCount of values processed.
http_source_request_duration_ns_count/bucket/sumHistogramStream headA histogram of HTTP request durations in nanoseconds.

Summary table stream summary metrics

Metric NameTypeComponentsPurpose
query_latency_summary_count/sumCount/SumSummary PeerLatency of calls to catalog.
query_countCounterSummary PeerCount of calls to the Catalog.
query_failureCounterSummary PeerCount of failed Catalog calls.
query_latency_summaryCounterSummary PeerLatency of calls to catalog.

Summary table Traefik metrics

Metric NameTypeComponentsPurpose
traefik_service_requests_totalCounterTraefikHTTP Traefik request information.
traefik_service_request_duration_seconds_count/sum/bucketCounterTraefikResponse time of traefik to client.
http_source_request_duration_ns_count/sum/bucketCounterTraefikResponse time from Stream-Head.