283 lines
24 KiB
YAML
283 lines
24 KiB
YAML
cpu_usage_idle: CPU空闲率(单位:%)
|
||
cpu_usage_active: CPU使用率(单位:%)
|
||
cpu_usage_system: CPU内核态时间占比(单位:%)
|
||
cpu_usage_user: CPU用户态时间占比(单位:%)
|
||
cpu_usage_nice: 低优先级用户态CPU时间占比,也就是进程nice值被调整为1-19之间的CPU时间。这里注意,nice可取值范围是-20到19,数值越大,优先级反而越低(单位:%)
|
||
cpu_usage_iowait: CPU等待I/O的时间占比(单位:%)
|
||
cpu_usage_irq: CPU处理硬中断的时间占比(单位:%)
|
||
cpu_usage_softirq: CPU处理软中断的时间占比(单位:%)
|
||
cpu_usage_steal: 在虚拟机环境下有该指标,表示CPU被其他虚拟机争用的时间占比,超过20就表示争抢严重(单位:%)
|
||
cpu_usage_guest: 通过虚拟化运行其他操作系统的时间,也就是运行虚拟机的CPU时间占比(单位:%)
|
||
cpu_usage_guest_nice: 以低优先级运行虚拟机的时间占比(单位:%)
|
||
|
||
disk_free: 硬盘分区剩余量(单位:byte)
|
||
disk_used: 硬盘分区使用量(单位:byte)
|
||
disk_used_percent: 硬盘分区使用率(单位:%)
|
||
disk_total: 硬盘分区总量(单位:byte)
|
||
disk_inodes_free: 硬盘分区inode剩余量
|
||
disk_inodes_used: 硬盘分区inode使用量
|
||
disk_inodes_total: 硬盘分区inode总量
|
||
|
||
diskio_io_time: 从设备视角来看I/O请求总时间,队列中有I/O请求就计数(单位:毫秒),counter类型,需要用函数求rate才有使用价值
|
||
diskio_iops_in_progress: 已经分配给设备驱动且尚未完成的IO请求,不包含在队列中但尚未分配给设备驱动的IO请求,gauge类型
|
||
diskio_merged_reads: 相邻读请求merge读的次数,counter类型
|
||
diskio_merged_writes: 相邻写请求merge写的次数,counter类型
|
||
diskio_read_bytes: 读取的byte数量,counter类型,需要用函数求rate才有使用价值
|
||
diskio_read_time: 读请求总时间(单位:毫秒),counter类型,需要用函数求rate才有使用价值
|
||
diskio_reads: 读请求次数,counter类型,需要用函数求rate才有使用价值
|
||
diskio_weighted_io_time: 从I/O请求视角来看I/O等待总时间,如果同时有多个I/O请求,时间会叠加(单位:毫秒)
|
||
diskio_write_bytes: 写入的byte数量,counter类型,需要用函数求rate才有使用价值
|
||
diskio_write_time: 写请求总时间(单位:毫秒),counter类型,需要用函数求rate才有使用价值
|
||
diskio_writes: 写请求次数,counter类型,需要用函数求rate才有使用价值
|
||
|
||
kernel_boot_time: 内核启动时间
|
||
kernel_context_switches: 内核上下文切换次数
|
||
kernel_entropy_avail: linux系统内部的熵池
|
||
kernel_interrupts: 内核中断次数
|
||
kernel_processes_forked: fork的进程数
|
||
|
||
mem_active: 活跃使用的内存总数(包括cache和buffer内存)
|
||
mem_available: 应用程序可用内存数
|
||
mem_available_percent: 内存剩余百分比(0~100)
|
||
mem_buffered: 用来给文件做缓冲大小
|
||
mem_cached: 被高速缓冲存储器(cache memory)用的内存的大小(等于 diskcache minus SwapCache )
|
||
mem_commit_limit: 根据超额分配比率('vm.overcommit_ratio'),这是当前在系统上分配可用的内存总量,这个限制只是在模式2('vm.overcommit_memory')时启用
|
||
mem_committed_as: 目前在系统上分配的内存量。是所有进程申请的内存的总和
|
||
mem_dirty: 等待被写回到磁盘的内存大小
|
||
mem_free: 空闲内存数
|
||
mem_high_free: 未被使用的高位内存大小
|
||
mem_high_total: 高位内存总大小(Highmem是指所有内存高于860MB的物理内存,Highmem区域供用户程序使用,或用于页面缓存。该区域不是直接映射到内核空间。内核必须使用不同的手法使用该段内存)
|
||
mem_huge_page_size: 每个大页的大小
|
||
mem_huge_pages_free: 池中尚未分配的 HugePages 数量
|
||
mem_huge_pages_total: 预留HugePages的总个数
|
||
mem_inactive: 空闲的内存数(包括free和avalible的内存)
|
||
mem_low_free: 未被使用的低位大小
|
||
mem_low_total: 低位内存总大小,低位可以达到高位内存一样的作用,而且它还能够被内核用来记录一些自己的数据结构
|
||
mem_mapped: 设备和文件等映射的大小
|
||
mem_page_tables: 管理内存分页页面的索引表的大小
|
||
mem_shared: 多个进程共享的内存总额
|
||
mem_slab: 内核数据结构缓存的大小,可以减少申请和释放内存带来的消耗
|
||
mem_sreclaimable: 可收回Slab的大小
|
||
mem_sunreclaim: 不可收回Slab的大小(SUnreclaim+SReclaimable=Slab)
|
||
mem_swap_cached: 被高速缓冲存储器(cache memory)用的交换空间的大小,已经被交换出来的内存,但仍然被存放在swapfile中。用来在需要的时候很快的被替换而不需要再次打开I/O端口
|
||
mem_swap_free: 未被使用交换空间的大小
|
||
mem_swap_total: 交换空间的总大小
|
||
mem_total: 内存总数
|
||
mem_used: 已用内存数
|
||
mem_used_percent: 已用内存数百分比(0~100)
|
||
mem_vmalloc_chunk: 最大的连续未被使用的vmalloc区域
|
||
mem_vmalloc_totalL: 可以vmalloc虚拟内存大小
|
||
mem_vmalloc_used: vmalloc已使用的虚拟内存大小
|
||
mem_write_back: 正在被写回到磁盘的内存大小
|
||
mem_write_back_tmp: FUSE用于临时写回缓冲区的内存
|
||
|
||
net_bytes_recv: 网卡收包总数(bytes)
|
||
net_bytes_sent: 网卡发包总数(bytes)
|
||
net_drop_in: 网卡收丢包数量
|
||
net_drop_out: 网卡发丢包数量
|
||
net_err_in: 网卡收包错误数量
|
||
net_err_out: 网卡发包错误数量
|
||
net_packets_recv: 网卡收包数量
|
||
net_packets_sent: 网卡发包数量
|
||
|
||
netstat_tcp_established: ESTABLISHED状态的网络链接数
|
||
netstat_tcp_fin_wait1: FIN_WAIT1状态的网络链接数
|
||
netstat_tcp_fin_wait2: FIN_WAIT2状态的网络链接数
|
||
netstat_tcp_last_ack: LAST_ACK状态的网络链接数
|
||
netstat_tcp_listen: LISTEN状态的网络链接数
|
||
netstat_tcp_syn_recv: SYN_RECV状态的网络链接数
|
||
netstat_tcp_syn_sent: SYN_SENT状态的网络链接数
|
||
netstat_tcp_time_wait: TIME_WAIT状态的网络链接数
|
||
netstat_udp_socket: UDP状态的网络链接数
|
||
|
||
processes_blocked: 不可中断的睡眠状态下的进程数('U','D','L')
|
||
processes_dead: 回收中的进程数('X')
|
||
processes_idle: 挂起的空闲进程数('I')
|
||
processes_paging: 分页进程数('P')
|
||
processes_running: 运行中的进程数('R')
|
||
processes_sleeping: 可中断进程数('S')
|
||
processes_stopped: 暂停状态进程数('T')
|
||
processes_total: 总进程数
|
||
processes_total_threads: 总线程数
|
||
processes_unknown: 未知状态进程数
|
||
processes_zombies: 僵尸态进程数('Z')
|
||
|
||
swap_used_percent: Swap空间换出数据量
|
||
|
||
system_load1: 1分钟平均load值
|
||
system_load5: 5分钟平均load值
|
||
system_load15: 15分钟平均load值
|
||
system_n_users: 用户数
|
||
system_n_cpus: CPU核数
|
||
system_uptime: 系统启动时间
|
||
|
||
nginx_accepts: 自nginx启动起,与客户端建立过得连接总数
|
||
nginx_active: 当前nginx正在处理的活动连接数,等于Reading/Writing/Waiting总和
|
||
nginx_handled: 自nginx启动起,处理过的客户端连接总数
|
||
nginx_reading: 正在读取HTTP请求头部的连接总数
|
||
nginx_requests: 自nginx启动起,处理过的客户端请求总数,由于存在HTTP Krrp-Alive请求,该值会大于handled值
|
||
nginx_upstream_check_fall: upstream_check模块检测到后端失败的次数
|
||
nginx_upstream_check_rise: upstream_check模块对后端的检测次数
|
||
nginx_upstream_check_status_code: 后端upstream的状态,up为1,down为0
|
||
nginx_waiting: 开启 keep-alive 的情况下,这个值等于 active – (reading+writing), 意思就是 Nginx 已经处理完正在等候下一次请求指令的驻留连接
|
||
nginx_writing: 正在向客户端发送响应的连接总数
|
||
|
||
http_response_content_length: HTTP消息实体的传输长度
|
||
http_response_http_response_code: http响应状态码
|
||
http_response_response_time: http响应用时
|
||
http_response_result_code: url探测结果0为正常否则url无法访问
|
||
|
||
# [mysqld_exporter]
|
||
mysql_global_status_uptime: The number of seconds that the server has been up.(Gauge)
|
||
mysql_global_status_uptime_since_flush_status: The number of seconds since the most recent FLUSH STATUS statement.(Gauge)
|
||
mysql_global_status_queries: The number of statements executed by the server. This variable includes statements executed within stored programs, unlike the Questions variable. It does not count COM_PING or COM_STATISTICS commands.(Counter)
|
||
mysql_global_status_threads_connected: The number of currently open connections.(Counter)
|
||
mysql_global_status_connections: The number of connection attempts (successful or not) to the MySQL server.(Gauge)
|
||
mysql_global_status_max_used_connections: The maximum number of connections that have been in use simultaneously since the server started.(Gauge)
|
||
mysql_global_status_threads_running: The number of threads that are not sleeping.(Gauge)
|
||
mysql_global_status_questions: The number of statements executed by the server. This includes only statements sent to the server by clients and not statements executed within stored programs, unlike the Queries variable. This variable does not count COM_PING, COM_STATISTICS, COM_STMT_PREPARE, COM_STMT_CLOSE, or COM_STMT_RESET commands.(Counter)
|
||
mysql_global_status_threads_cached: The number of threads in the thread cache.(Counter)
|
||
mysql_global_status_threads_created: The number of threads created to handle connections. If Threads_created is big, you may want to increase the thread_cache_size value. The cache miss rate can be calculated as Threads_created/Connections.(Counter)
|
||
mysql_global_status_created_tmp_tables: The number of internal temporary tables created by the server while executing statements.(Counter)
|
||
mysql_global_status_created_tmp_disk_tables: The number of internal on-disk temporary tables created by the server while executing statements. You can compare the number of internal on-disk temporary tables created to the total number of internal temporary tables created by comparing Created_tmp_disk_tables and Created_tmp_tables values.(Counter)
|
||
mysql_global_status_created_tmp_files: How many temporary files mysqld has created.(Counter)
|
||
mysql_global_status_select_full_join: The number of joins that perform table scans because they do not use indexes. If this value is not 0, you should carefully check the indexes of your tables.(Counter)
|
||
mysql_global_status_select_full_range_join: The number of joins that used a range search on a reference table.(Counter)
|
||
mysql_global_status_select_range: The number of joins that used ranges on the first table. This is normally not a critical issue even if the value is quite large.(Counter)
|
||
mysql_global_status_select_range_check: The number of joins without keys that check for key usage after each row. If this is not 0, you should carefully check the indexes of your tables.(Counter)
|
||
mysql_global_status_select_scan: The number of joins that did a full scan of the first table.(Counter)
|
||
mysql_global_status_sort_rows: The number of sorted rows.(Counter)
|
||
mysql_global_status_sort_range: The number of sorts that were done using ranges.(Counter)
|
||
mysql_global_status_sort_merge_passes: The number of merge passes that the sort algorithm has had to do. If this value is large, you should consider increasing the value of the sort_buffer_size system variable.(Counter)
|
||
mysql_global_status_sort_scan: The number of sorts that were done by scanning the table.(Counter)
|
||
mysql_global_status_slow_queries: The number of queries that have taken more than long_query_time seconds. This counter increments regardless of whether the slow query log is enabled.(Counter)
|
||
mysql_global_status_aborted_connects: The number of failed attempts to connect to the MySQL server.(Counter)
|
||
mysql_global_status_aborted_clients: The number of connections that were aborted because the client died without closing the connection properly.(Counter)
|
||
mysql_global_status_table_locks_immediate: The number of times that a request for a table lock could be granted immediately. Locks Immediate rising and falling is normal activity.(Counter)
|
||
mysql_global_status_table_locks_waited: The number of times that a request for a table lock could not be granted immediately and a wait was needed. If this is high and you have performance problems, you should first optimize your queries, and then either split your table or tables or use replication.(Counter)
|
||
mysql_global_status_bytes_received: The number of bytes received from all clients.(Counter)
|
||
mysql_global_status_bytes_sent: The number of bytes sent to all clients.(Counter)
|
||
mysql_global_status_innodb_page_size: InnoDB page size (default 16KB). Many values are counted in pages; the page size enables them to be easily converted to bytes.(Gauge)
|
||
mysql_global_status_buffer_pool_pages: The number of pages in the InnoDB buffer pool.(Gauge)
|
||
mysql_global_status_commands_total: The number of times each xxx statement has been executed.(Counter)
|
||
mysql_global_status_handlers_total: Handler statistics are internal statistics on how MySQL is selecting, updating, inserting, and modifying rows, tables, and indexes. This is in fact the layer between the Storage Engine and MySQL.(Counter)
|
||
mysql_global_status_opened_files: The number of files that have been opened with my_open() (a mysys library function). Parts of the server that open files without using this function do not increment the count.(Counter)
|
||
mysql_global_status_open_tables: The number of tables that are open.(Gauge)
|
||
mysql_global_status_opened_tables: The number of tables that have been opened. If Opened_tables is big, your table_open_cache value is probably too small.(Counter)
|
||
mysql_global_status_table_open_cache_hits: The number of hits for open tables cache lookups.(Counter)
|
||
mysql_global_status_table_open_cache_misses: The number of misses for open tables cache lookups.(Counter)
|
||
mysql_global_status_table_open_cache_overflows: The number of overflows for the open tables cache.(Counter)
|
||
mysql_global_status_innodb_num_open_files: The number of files InnoDB currently holds open.(Gauge)
|
||
mysql_global_status_connection_errors_total: These variables provide information about errors that occur during the client connection process.(Counter)
|
||
mysql_global_status_innodb_buffer_pool_read_requests: The number of logical read requests.(Counter)
|
||
mysql_global_status_innodb_buffer_pool_reads: The number of logical reads that InnoDB could not satisfy from the buffer pool, and had to read directly from disk.(Counter)
|
||
|
||
mysql_global_variables_thread_cache_size: How many threads the server should cache for reuse.(Gauge)
|
||
mysql_global_variables_max_connections: The maximum permitted number of simultaneous client connections.(Gauge)
|
||
mysql_global_variables_innodb_buffer_pool_size: The size in bytes of the buffer pool, the memory area where InnoDB caches table and index data. The default value is 134217728 bytes (128MB).(Gauge)
|
||
mysql_global_variables_innodb_log_buffer_size: The size in bytes of the buffer that InnoDB uses to write to the log files on disk.(Gauge)
|
||
mysql_global_variables_key_buffer_size: Index blocks for MyISAM tables are buffered and are shared by all threads.(Gauge)
|
||
mysql_global_variables_query_cache_size: The amount of memory allocated for caching query results.(Gauge)
|
||
mysql_global_variables_table_open_cache: The number of open tables for all threads.(Gauge)
|
||
mysql_global_variables_open_files_limit: The number of file descriptors available to mysqld from the operating system.(Gauge)
|
||
|
||
# [redis_exporter]
|
||
redis_active_defrag_running: When activedefrag is enabled, this indicates whether defragmentation is currently active, and the CPU percentage it intends to utilize.
|
||
redis_allocator_active_bytes: Total bytes in the allocator active pages, this includes external-fragmentation.
|
||
redis_allocator_allocated_bytes: Total bytes allocated form the allocator, including internal-fragmentation. Normally the same as used_memory.
|
||
redis_allocator_frag_bytes: Delta between allocator_active and allocator_allocated. See note about mem_fragmentation_bytes.
|
||
redis_allocator_frag_ratio: Ratio between allocator_active and allocator_allocated. This is the true (external) fragmentation metric (not mem_fragmentation_ratio).
|
||
redis_allocator_resident_bytes: Total bytes resident (RSS) in the allocator, this includes pages that can be released to the OS (by MEMORY PURGE, or just waiting).
|
||
redis_allocator_rss_bytes: Delta between allocator_resident and allocator_active.
|
||
redis_allocator_rss_ratio: Ratio between allocator_resident and allocator_active. This usually indicates pages that the allocator can and probably will soon release back to the OS.
|
||
redis_aof_current_rewrite_duration_sec: Duration of the on-going AOF rewrite operation if any.
|
||
redis_aof_enabled: Flag indicating AOF logging is activated.
|
||
redis_aof_last_bgrewrite_status: Status of the last AOF rewrite operation.
|
||
redis_aof_last_cow_size_bytes: The size in bytes of copy-on-write memory during the last AOF rewrite operation.
|
||
redis_aof_last_rewrite_duration_sec: Duration of the last AOF rewrite operation in seconds.
|
||
redis_aof_last_write_status: Status of the last write operation to the AOF.
|
||
redis_aof_rewrite_in_progress: Flag indicating a AOF rewrite operation is on-going.
|
||
redis_aof_rewrite_scheduled: Flag indicating an AOF rewrite operation will be scheduled once the on-going RDB save is complete.
|
||
redis_blocked_clients: Number of clients pending on a blocking call (BLPOP, BRPOP, BRPOPLPUSH, BLMOVE, BZPOPMIN, BZPOPMAX).
|
||
redis_client_recent_max_input_buffer_bytes: Biggest input buffer among current client connections.
|
||
redis_client_recent_max_output_buffer_bytes: Biggest output buffer among current client connections.
|
||
redis_cluster_enabled: Indicate Redis cluster is enabled.
|
||
redis_commands_duration_seconds_total: The total CPU time consumed by these commands.(Counter)
|
||
redis_commands_processed_total: Total number of commands processed by the server.(Counter)
|
||
redis_commands_total: The number of calls that reached command execution (not rejected).(Counter)
|
||
redis_config_maxclients: The value of the maxclients configuration directive. This is the upper limit for the sum of connected_clients, connected_slaves and cluster_connections.
|
||
redis_config_maxmemory: The value of the maxmemory configuration directive.
|
||
redis_connected_clients: Number of client connections (excluding connections from replicas).
|
||
redis_connected_slaves: Number of connected replicas.
|
||
redis_connections_received_total: Total number of connections accepted by the server.(Counter)
|
||
redis_cpu_sys_children_seconds_total: System CPU consumed by the background processes.(Counter)
|
||
redis_cpu_sys_seconds_total: System CPU consumed by the Redis server, which is the sum of system CPU consumed by all threads of the server process (main thread and background threads).(Counter)
|
||
redis_cpu_user_children_seconds_total: User CPU consumed by the background processes.(Counter)
|
||
redis_cpu_user_seconds_total: User CPU consumed by the Redis server, which is the sum of user CPU consumed by all threads of the server process (main thread and background threads).(Counter)
|
||
redis_db_keys: Total number of keys by DB.
|
||
redis_db_keys_expiring: Total number of expiring keys by DB
|
||
redis_defrag_hits: Number of value reallocations performed by active the defragmentation process.
|
||
redis_defrag_misses: Number of aborted value reallocations started by the active defragmentation process.
|
||
redis_defrag_key_hits: Number of keys that were actively defragmented.
|
||
redis_defrag_key_misses: Number of keys that were skipped by the active defragmentation process.
|
||
redis_evicted_keys_total: Number of evicted keys due to maxmemory limit.(Counter)
|
||
redis_expired_keys_total: Total number of key expiration events.(Counter)
|
||
redis_expired_stale_percentage: The percentage of keys probably expired.
|
||
redis_expired_time_cap_reached_total: The count of times that active expiry cycles have stopped early.
|
||
redis_exporter_last_scrape_connect_time_seconds: The duration(in seconds) to connect when scrape.
|
||
redis_exporter_last_scrape_duration_seconds: The last scrape duration.
|
||
redis_exporter_last_scrape_error: The last scrape error status.
|
||
redis_exporter_scrape_duration_seconds_count: Durations of scrapes by the exporter
|
||
redis_exporter_scrape_duration_seconds_sum: Durations of scrapes by the exporter
|
||
redis_exporter_scrapes_total: Current total redis scrapes.(Counter)
|
||
redis_instance_info: Information about the Redis instance.
|
||
redis_keyspace_hits_total: Hits total.(Counter)
|
||
redis_keyspace_misses_total: Misses total.(Counter)
|
||
redis_last_key_groups_scrape_duration_milliseconds: Duration of the last key group metrics scrape in milliseconds.
|
||
redis_last_slow_execution_duration_seconds: The amount of time needed for last slow execution, in seconds.
|
||
redis_latest_fork_seconds: The amount of time needed for last fork, in seconds.
|
||
redis_lazyfree_pending_objects: The number of objects waiting to be freed (as a result of calling UNLINK, or FLUSHDB and FLUSHALL with the ASYNC option).
|
||
redis_master_repl_offset: The server's current replication offset.
|
||
redis_mem_clients_normal: Memory used by normal clients.(Gauge)
|
||
redis_mem_clients_slaves: Memory used by replica clients - Starting Redis 7.0, replica buffers share memory with the replication backlog, so this field can show 0 when replicas don't trigger an increase of memory usage.
|
||
redis_mem_fragmentation_bytes: Delta between used_memory_rss and used_memory. Note that when the total fragmentation bytes is low (few megabytes), a high ratio (e.g. 1.5 and above) is not an indication of an issue.
|
||
redis_mem_fragmentation_ratio: Ratio between used_memory_rss and used_memory. Note that this doesn't only includes fragmentation, but also other process overheads (see the allocator_* metrics), and also overheads like code, shared libraries, stack, etc.
|
||
redis_mem_not_counted_for_eviction_bytes: (Gauge)
|
||
redis_memory_max_bytes: Max memory limit in bytes.
|
||
redis_memory_used_bytes: Total number of bytes allocated by Redis using its allocator (either standard libc, jemalloc, or an alternative allocator such as tcmalloc)
|
||
redis_memory_used_dataset_bytes: The size in bytes of the dataset (used_memory_overhead subtracted from used_memory)
|
||
redis_memory_used_lua_bytes: Number of bytes used by the Lua engine.
|
||
redis_memory_used_overhead_bytes: The sum in bytes of all overheads that the server allocated for managing its internal data structures.
|
||
redis_memory_used_peak_bytes: Peak memory consumed by Redis (in bytes)
|
||
redis_memory_used_rss_bytes: Number of bytes that Redis allocated as seen by the operating system (a.k.a resident set size). This is the number reported by tools such as top(1) and ps(1)
|
||
redis_memory_used_scripts_bytes: Number of bytes used by cached Lua scripts
|
||
redis_memory_used_startup_bytes: Initial amount of memory consumed by Redis at startup in bytes
|
||
redis_migrate_cached_sockets_total: The number of sockets open for MIGRATE purposes
|
||
redis_net_input_bytes_total: Total input bytes(Counter)
|
||
redis_net_output_bytes_total: Total output bytes(Counter)
|
||
redis_process_id: Process ID
|
||
redis_pubsub_channels: Global number of pub/sub channels with client subscriptions
|
||
redis_pubsub_patterns: Global number of pub/sub pattern with client subscriptions
|
||
redis_rdb_bgsave_in_progress: Flag indicating a RDB save is on-going
|
||
redis_rdb_changes_since_last_save: Number of changes since the last dump
|
||
redis_rdb_current_bgsave_duration_sec: Duration of the on-going RDB save operation if any
|
||
redis_rdb_last_bgsave_duration_sec: Duration of the last RDB save operation in seconds
|
||
redis_rdb_last_bgsave_status: Status of the last RDB save operation
|
||
redis_rdb_last_cow_size_bytes: The size in bytes of copy-on-write memory during the last RDB save operation
|
||
redis_rdb_last_save_timestamp_seconds: Epoch-based timestamp of last successful RDB save
|
||
redis_rejected_connections_total: Number of connections rejected because of maxclients limit(Counter)
|
||
redis_repl_backlog_first_byte_offset: The master offset of the replication backlog buffer
|
||
redis_repl_backlog_history_bytes: Size in bytes of the data in the replication backlog buffer
|
||
redis_repl_backlog_is_active: Flag indicating replication backlog is active
|
||
redis_replica_partial_resync_accepted: The number of accepted partial resync requests(Gauge)
|
||
redis_replica_partial_resync_denied: The number of denied partial resync requests(Gauge)
|
||
redis_replica_resyncs_full: The number of full resyncs with replicas
|
||
redis_replication_backlog_bytes: Memory used by replication backlog
|
||
redis_second_repl_offset: The offset up to which replication IDs are accepted.
|
||
redis_slave_expires_tracked_keys: The number of keys tracked for expiry purposes (applicable only to writable replicas)(Gauge)
|
||
redis_slowlog_last_id: Last id of slowlog
|
||
redis_slowlog_length: Total slowlog
|
||
redis_start_time_seconds: Start time of the Redis instance since unix epoch in seconds.
|
||
redis_target_scrape_request_errors_total: Errors in requests to the exporter
|
||
redis_up: Flag indicating redis instance is up
|
||
redis_uptime_in_seconds: Number of seconds since Redis server start |