Prometheus自带指标整理

go_gc_duration_seconds

summary

垃圾收集周期的暂停持续时间

A summary of the pause duration of garbage collection cycles

2

go_goroutines

gauge

当前存在的goroutine数

Number of goroutines that currently exist.

3

go_info

gauge

有关GO环境的信息

Information about the Go environment.

4

go_memstats_alloc_bytes

gauge

已分配但仍在使用的字节数

Number of bytes allocated and still in use.

5

go_memstats_alloc_bytes_total

counter

分配的总字节数,即使已释放

Total number of bytes allocated, even if freed.

6

go_memstats_buck_hash_sys_bytes

gauge

桶哈希表使用的字节数

Number of bytes used by the profiling bucket hash table.

7

go_memstats_frees_total

counter

空闲的总数

Total number of frees.

8

go_memstats_gc_cpu_fraction

gauge

自程序启动以来GC使用的该程序可用CPU时间

The fraction of this program's available CPU time used by the GC since the program started.

9

go_memstats_gc_sys_bytes

gauge

用于垃圾收集系统元数据的字节数

Number of bytes used for garbage collection system metadata.

10

go_memstats_heap_alloc_bytes

gauge

已分配但仍在使用的堆字节数

Number of heap bytes allocated and still in use.

11

go_memstats_heap_idle_bytes

gauge

等待使用的堆字节数

Number of heap bytes waiting to be used.

12

go_memstats_heap_inuse_bytes

gauge

正在使用的堆字节数

Number of heap bytes that are in use.

13

go_memstats_heap_objects

gauge

分配的对象数

Number of allocated objects.

14

go_memstats_heap_released_bytes

gauge

释放到操作系统的堆字节数

Number of heap bytes released to OS.

15

go_memstats_heap_sys_bytes

gauge

从系统获得的堆字节数

Number of heap bytes obtained from system.

16

go_memstats_last_gc_time_seconds

gauge

自上次垃圾回收1970以来的秒数

Number of seconds since 1970 of last garbage collection.

17

go_memstats_lookups_total

counter

指针查找的总数

Total number of pointer lookups.

18

go_memstats_mallocs_total

counter

malloc的总数

Total number of mallocs.

19

go_memstats_mcache_inuse_bytes

gauge

mcache结构使用的字节数

Number of bytes in use by mcache structures.

20

go_memstats_mcache_sys_bytes

gauge

从系统中获取的用于mcache结构的字节数

Number of bytes used for mcache structures obtained from system.

21

go_memstats_mspan_inuse_bytes

gauge

mspan结构使用的字节数

Number of bytes in use by mspan structures.

22

go_memstats_mspan_sys_bytes

gauge

从系统获取的mspan结构所用的字节数

Number of bytes used for mspan structures obtained from system.

23

go_memstats_next_gc_bytes

gauge

下次垃圾回收将发生堆字节数

Number of heap bytes when next garbage collection will take place.

24

go_memstats_other_sys_bytes

gauge

用于其他系统分配的字节数

Number of bytes used for other system allocations.

25

go_memstats_stack_inuse_bytes

gauge

堆栈分配器使用的字节数

Number of bytes in use by the stack allocator.

26

go_memstats_stack_sys_bytes

gauge

从堆栈分配器系统获得的字节数

Number of bytes obtained from system for stack allocator.

27

go_memstats_sys_bytes

gauge

从系统中获得的字节数

Number of bytes obtained from system.

28

go_threads

gauge

创建的OS线程数

Number of OS threads created.

29

net_conntrack_dialer_conn_attempted_total

counter

给定拨号器以给定名称尝试的连接总数

Total number of connections attempted by the given dialer a given name.

30

net_conntrack_dialer_conn_closed_total

counter

给定名称的拨号器中关闭的连接总数

Total number of connections closed which originated from the dialer of a given name.

31

net_conntrack_dialer_conn_established_total

counter

给定拨号器以给定名称成功建立的连接总数

Total number of connections successfully established by the given dialer a given name.

32

net_conntrack_dialer_conn_failed_total

counter

给定拨号器以给定名称连接失败总数

Total number of connections failed to dial by the dialer a given name.

33

net_conntrack_listener_conn_accepted_total

counter

向给定名称的侦听器打开的连接总数

Total number of connections opened to the listener of a given name.

34

net_conntrack_listener_conn_closed_total

counter

对给定名称的侦听器关闭的连接总数

Total number of connections closed that were made to the listener of a given name.

35

process_cpu_seconds_total

counter

用户和系统CPU总时间(秒)

Total user and system CPU time spent in seconds.

36

process_max_fds

gauge

打开的文件描述符的最大数目

Maximum number of open file descriptors.

37

process_open_fds

gauge

打开的文件描述符数

Number of open file descriptors.

38

process_resident_memory_bytes

gauge

常驻内存大小(字节)

Resident memory size in bytes.

39

process_start_time_seconds

gauge

自unix时代以来进程的开始时间(秒)

Start time of the process since unix epoch in seconds.

40

process_virtual_memory_bytes

gauge

虚拟内存大小(字节)

Virtual memory size in bytes.

41

process_virtual_memory_max_bytes

gauge

可用的最大虚拟内存量(字节)

Maximum amount of virtual memory available in bytes.

42

prometheus_api_remote_read_queries

gauge

当前正在执行或等待的远程读取查询数。

The current number of remote read queries being executed or waiting.

43

prometheus_build_info

gauge

prometheus信息    
A metric with a constant '1' value labeled by version, revision, branch, and goversion from which prometheus was built.

44

prometheus_config_last_reload_success_timestamp_seconds

gauge

上次成功配置重新加载的时间戳

Timestamp of the last successful configuration reload.

45

prometheus_config_last_reload_successful

gauge

上次配置重新加载尝试是否成功

Whether the last configuration reload attempt was successful.

46

prometheus_engine_queries

gauge

当前正在执行或等待的查询数

The current number of queries being executed or waiting.

47

prometheus_engine_queries_concurrent_max

gauge

最大并发查询数

The max number of concurrent queries.

48

prometheus_engine_query_duration_seconds

summary

查询耗时分布

Query timings

49

prometheus_engine_query_log_enabled

gauge

查询日志的状态

State of the query log.

50

prometheus_engine_query_log_failures_total

counter

查询日志失败数

The number of query log failures.

51

prometheus_http_request_duration_seconds

histogram

HTTP请求的延迟直方图

Histogram of latencies for HTTP requests.

52

prometheus_http_requests_total

counter

http请求数量    
Counter of HTTP requests.

53

prometheus_http_response_size_bytes

histogram

HTTP请求的响应大小    
Histogram of response size for HTTP requests.

54

prometheus_notifications_alertmanagers_discovered

gauge

发现并激活了警报管理器的数量

The number of alertmanagers discovered and active.

55

prometheus_notifications_dropped_total

counter

发送到Alertmanager时由于错误而丢弃的警报总数

Total number of alerts dropped due to errors when sending to Alertmanager.

56

prometheus_notifications_queue_capacity

gauge

警报通知队列的容量

The capacity of the alert notifications queue.

57

prometheus_notifications_queue_length

gauge

队列中的警报通知数

The number of alert notifications in the queue.

58

prometheus_remote_storage_highest_timestamp_in_seconds

gauge

通过Appender接口进入远程存储器的最高时间戳,以秒为单位

Highest timestamp that has come into the remote storage via the Appender interface, in seconds since epoch.

59

prometheus_remote_storage_samples_in_total

counter

采集样本总数

Samples in to remote storage, compare to samples out for queue managers.

60

prometheus_remote_storage_string_interner_zero_reference_releases_total

counter

对于未被插入的字符串调用了释放次数。

The number of times release has been called for strings that are not interned.

61

prometheus_rule_evaluation_duration_seconds

summary

规则执行的耗时

The duration for a rule to execute.

62

prometheus_rule_group_duration_seconds

summary

规则组评估的耗时

The duration of rule group evaluations.

63

prometheus_sd_consul_rpc_duration_seconds

summary

RPC调用的耗时

The duration of a Consul RPC call in seconds.

64

prometheus_sd_consul_rpc_failures_total

counter

RPC调用失败的次数

The number of Consul RPC call failures.

65

prometheus_sd_discovered_targets

gauge

当前发现的目标数

Current number of discovered targets.

66

prometheus_sd_dns_lookup_failures_total

counter

DNS-SD查找失败的次数

The number of DNS-SD lookup failures.

67

prometheus_sd_dns_lookups_total

counter

DNS-SD查找的数目。

The number of DNS-SD lookups.

68

prometheus_sd_failed_configs

gauge

当前无法加载的服务发现配置数。

Current number of service discovery configurations that failed to load.

69

prometheus_sd_file_mtime_seconds

gauge

FileSD读取的文件的时间戳(mtime)。时间戳在读取时设置。

Timestamp (mtime) of files read by FileSD. Timestamp is set at read time.

70

prometheus_sd_file_read_errors_total

counter

FileSD读取错误数

The number of File-SD read errors.

71

prometheus_sd_file_scan_duration_seconds

summary

FileSD扫描的耗时(秒)

The duration of the File-SD scan in seconds.

72

prometheus_sd_kubernetes_events_total

counter

Kubernetes事件处理数量

The number of Kubernetes events handled.

72

prometheus_sd_received_updates_total

counter

从SD提供商接收的更新事件总数

Total number of update events received from the SD providers.

74

prometheus_sd_updates_total

counter

发送给SD消费者的更新事件总数

Total number of update events sent to the SD consumers.

75

prometheus_target_interval_length_seconds

summary

刮擦之间的实际间隔。

Actual intervals between scrapes.

76

prometheus_target_metadata_cache_bytes

gauge

当前用于在缓存中存储度量元数据的字节数。

The number of bytes that are currently used for storing metric metadata in the cache

77

prometheus_target_metadata_cache_entries

gauge

高速缓存中的度量元数据项总数

Total number of metric metadata entries in the cache

78

prometheus_target_scrape_pool_exceeded_target_limit_total

counter

同步或配置重新加载期间,刮取池达到目标限制的总次数。

Total number of times scrape pools hit the target limit, during sync or config reload.

79

prometheus_target_scrape_pool_reloads_failed_total

counter

刮擦池重新加载失败的总数。

Total number of failed scrape pool reloads.

80

prometheus_target_scrape_pool_reloads_total

counter

刮擦池重新加载的总数。

Total number of scrape pool reloads.

81

prometheus_target_scrape_pool_sync_total

counter

在刮擦池中执行的同步的总数。

Total number of syncs that were executed on a scrape pool.

82

prometheus_target_scrape_pool_targets

gauge

此刮擦池中的当前目标数。

Current number of targets in this scrape pool.

83

prometheus_target_scrape_pools_failed_total

counter

失败的刮擦池创作总数。

Total number of scrape pool creations that failed.

84

prometheus_target_scrape_pools_total

counter

刮擦池创建总数的尝试。

Total number of scrape pool creation attempts.

85

prometheus_target_scrapes_cache_flush_forced_total

counter

有多少次刮擦缓存被冲洗,因为大,而刮擦是失败的。

How many times a scrape cache was flushed due to getting big while scrapes are failing.

86

prometheus_target_scrapes_exceeded_sample_limit_total

counter

达到样本限制并被拒绝的刮擦总数。

Total number of scrapes that hit the sample limit and were rejected.

87

prometheus_target_scrapes_sample_duplicate_timestamp_total

counter

由于重复的时间戳但不同的值拒绝的样本总数

Total number of samples rejected due to duplicate timestamps but different values

88

prometheus_target_scrapes_sample_out_of_bounds_total

counter

由于时间戳超出时间界限而拒绝的样本总数

Total number of samples rejected due to timestamp falling outside of the time bounds

89

prometheus_target_scrapes_sample_out_of_order_total

counter

由于不超出预期顺序而拒绝的样品总数

Total number of samples rejected due to not being out of the expected order

90

prometheus_target_sync_length_seconds

summary

同步刮擦池的实际间隔

Actual interval to sync the scrape pool.

91

prometheus_template_text_expansion_failures_total

counter

模板文本扩展失败的总数

The total number of template text expansion failures.

92

prometheus_template_text_expansions_total

counter

模板文本扩展的总数

The total number of template text expansions.

93

prometheus_treecache_watcher_goroutines

gauge

当前观察者的数量

The current number of watcher goroutines.

94

prometheus_treecache_zookeeper_failures_total

counter

ZooKeeper失败的总数

The total number of ZooKeeper failures.

95

prometheus_tsdb_blocks_loaded

gauge

当前加载的数据块数

Number of currently loaded data blocks

96

prometheus_tsdb_checkpoint_creations_failed_total

counter

失败的检查点创建总数

Total number of checkpoint creations that failed.

97

prometheus_tsdb_checkpoint_creations_total

counter

检查点创建总数。

Total number of checkpoint creations attempted.

98

prometheus_tsdb_checkpoint_deletions_failed_total

counter

失败的检查点删除总数。

Total number of checkpoint deletions that failed.

99

prometheus_tsdb_checkpoint_deletions_total

counter

尝试删除检查点的总数。

Total number of checkpoint deletions attempted.

100

prometheus_tsdb_compaction_chunk_range_seconds

histogram

第一次压缩时块的最终时间范围

Final time range of chunks on their first compaction

101

prometheus_tsdb_compaction_chunk_samples

histogram

第一次压缩时的最终样品数量

Final number of samples on their first compaction

102

prometheus_tsdb_compaction_chunk_size_bytes

histogram

第一次压缩时块的最终大小

Final size of chunks on their first compaction

103

prometheus_tsdb_compaction_duration_seconds

histogram

压缩运行耗时

Duration of compaction runs

104

prometheus_tsdb_compaction_populating_block

gauge

当一个块当前被写入磁盘时,设置为1

Set to 1 when a block is currently being written to the disk.

105

prometheus_tsdb_compactions_failed_total

counter

分区失败的压缩数

Total number of compactions that failed for the partition.

106

prometheus_tsdb_compactions_skipped_total

counter

由于禁用自动压缩而跳过的压缩总数

Total number of skipped compactions due to disabled auto compaction.

107

prometheus_tsdb_compactions_total

counter

为分区执行的压缩数

Total number of compactions that were executed for the partition.

108

prometheus_tsdb_compactions_triggered_total

counter

分区的触发压缩数

Total number of triggered compactions for the partition.

109

prometheus_tsdb_data_replay_duration_seconds

gauge

在磁盘上重放数据所花费的时间

Time taken to replay the data on disk.

110

prometheus_tsdb_head_active_appenders

gauge

当前活动的代理事务数

Number of currently active appender transactions

111

prometheus_tsdb_head_chunks

gauge

头部中的块总数

Total number of chunks in the head block.

112

prometheus_tsdb_head_chunks_created_total

counter

在头部中创建的块总数

Total number of chunks created in the head

113

prometheus_tsdb_head_chunks_removed_total

counter

在头部移除的块总数

Total number of chunks removed in the head

114

prometheus_tsdb_head_gc_duration_seconds

summary

头部中垃圾回收的耗时

Runtime of garbage collection in the head block.

115

prometheus_tsdb_head_max_time

gauge

头部中的最大时间戳

Maximum timestamp of the head block. The unit is decided by the library consumer.

116

prometheus_tsdb_head_max_time_seconds

gauge

头部的最大时间戳

Maximum timestamp of the head block.

117

prometheus_tsdb_head_min_time

gauge

头部中的最小时间戳

Minimum time bound of the head block. The unit is decided by the library consumer.

118

prometheus_tsdb_head_min_time_seconds

gauge

头部的最小时间戳

Minimum time bound of the head block.

119

prometheus_tsdb_head_samples_appended_total

counter

样本数量

Total number of appended samples.

120

prometheus_tsdb_head_series

gauge

头块中的series总数

Total number of series in the head block.

121

prometheus_tsdb_head_series_created_total

counter

头块中的series创建总数

Total number of series created in the head

122

prometheus_tsdb_head_series_not_found_total

counter

找不到serie的请求总数

Total number of requests for series that were not found.

123

prometheus_tsdb_head_series_removed_total

counter

头块中的series删除总数

Total number of series removed in the head

124

prometheus_tsdb_head_truncations_failed_total

counter

失败的标头截断总数

Total number of head truncations that failed.

125

prometheus_tsdb_head_truncations_total

counter

尝试的标头截断总数。

Total number of head truncations attempted.

126

prometheus_tsdb_isolation_high_watermark

gauge

最高的TSDB追加已发出的ID

The highest TSDB append ID that has been given out.

127

prometheus_tsdb_isolation_low_watermark

gauge

最低的TSDB追加已发出的ID

The lowest TSDB append ID that is still referenced.

128

prometheus_tsdb_lowest_timestamp

gauge

存储在数据库中的最低时间戳值

Lowest timestamp value stored in the database. The unit is decided by the library consumer.

129

prometheus_tsdb_lowest_timestamp_seconds

gauge

存储在数据库中的最低时间戳值

Lowest timestamp value stored in the database.

130

 prometheus_tsdb_mmap_chunk_corruptions_total

counter

内存映射块损坏的总数

Total number of memory-mapped chunk corruptions.

131

prometheus_tsdb_out_of_bound_samples_total

counter

尝试摄取失败的出界样本总数

Total number of out of bound samples ingestion failed attempts.

132

prometheus_tsdb_out_of_order_samples_total

counter

尝试摄取失败的无序样本总数

Total number of out of order samples ingestion failed attempts.

133

prometheus_tsdb_reloads_failures_total

counter

数据库无法从磁盘重新加载块数据的次数

Number of times the database failed to reloadBlocks block data from disk.

134

prometheus_tsdb_reloads_total

counter

数据库从磁盘重新加载块数据的次数

Number of times the database reloaded block data from disk.

135

prometheus_tsdb_retention_limit_bytes

gauge

tsdb块中保留的最大字节数,配置为0表示禁用

Max number of bytes to be retained in the tsdb blocks, configured 0 means disabled

136

prometheus_tsdb_size_retentions_total

counter

由于超过最大字节数而删除块的次数

The number of times that blocks were deleted because the maximum number of bytes was exceeded.

137

prometheus_tsdb_storage_blocks_bytes

gauge

所有块当前用于本地存储的字节数

The number of bytes that are currently used for local storage by all blocks.

138

prometheus_tsdb_symbol_table_size_bytes

gauge

加载块内存中符号表的大小

Size of symbol table in memory for loaded blocks

139

prometheus_tsdb_time_retentions_total

counter

由于超过了最大时间限制,删除了块的次数

The number of times that blocks were deleted because the maximum time limit was exceeded.

140

prometheus_tsdb_tombstone_cleanup_seconds

histogram

重新压缩块以移除墓碑所需的时间

The time taken to recompact blocks to remove tombstones.

141

prometheus_tsdb_vertical_compactions_total

counter    
重叠块上压缩的总数

Total number of compactions done on overlapping blocks.

142

prometheus_tsdb_wal_completed_pages_total

counter

已完成页的总数

Total number of completed pages.

143

prometheus_tsdb_wal_corruptions_total

counter

WAL腐败的总数

Total number of WAL corruptions.

144

prometheus_tsdb_wal_fsync_duration_seconds

summary

WAL fsync耗时    
Duration of WAL fsync.

145

prometheus_tsdb_wal_page_flushes_total

counter

 页面刷新总数

Total number of page flushes.

146

prometheus_tsdb_wal_segment_current

gauge

TSDB当前正在写入的WAL段索引    
WAL segment index that TSDB is currently writing to.

147

prometheus_tsdb_wal_truncate_duration_seconds

summary

WAL截断的耗时

Duration of WAL truncation.

148

prometheus_tsdb_wal_truncations_failed_total

counter

WAL截断的失败总数

Total number of WAL truncations that failed.

149

prometheus_tsdb_wal_truncations_total

counter

WAL截断的总数

Total number of WAL truncations attempted.

150

prometheus_tsdb_wal_writes_failed_total

counter

WAL写入失败的总数

Total number of WAL writes that failed.

151

prometheus_web_federation_errors_total

counter

发送响应时发生的错误总数

Total number of errors that occurred while sending federation responses.

152

prometheus_web_federation_warnings_total

counter

发送响应时发生的警告总数

Total number of warnings that occurred while sending federation responses.

153

promhttp_metric_handler_requests_in_flight

gauge

目前的刮擦服务数量

Current number of scrapes being served.

154

promhttp_metric_handler_requests_total

counter

HTTP状态代码的总数

Total number of scrapes by HTTP status code.

  • 2
    点赞
  • 5
    收藏
    觉得还不错? 一键收藏
  • 0
    评论

“相关推荐”对你有帮助么?

  • 非常没帮助
  • 没帮助
  • 一般
  • 有帮助
  • 非常有帮助
提交
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值