cpu_usage_system:"CPU kernel state time proportion(unit:%)"
cpu_usage_user:"CPU user attitude time proportion(unit:%)"
cpu_usage_nice:"The proportion of low priority CPU time, that is, the process NICE value is adjusted to the CPU time between 1-19. Note here that the value range of NICE is -20 to 19, the larger the value, the lower the priority, the lower the priority(unit:%)"
cpu_usage_iowait:"CPU waiting for I/O time proportion(unit:%)"
cpu_usage_irq:"CPU processing hard interrupt time proportion(unit:%)"
cpu_usage_softirq:"CPU processing soft interrupt time proportion(unit:%)"
cpu_usage_steal:"In the virtual machine environment, there is this indicator, which means that the CPU is used by other virtual machines for the proportion of time.(unit:%)"
cpu_usage_guest:"The time to run other operating systems by virtualization, that is, the proportion of CPU time running the virtual machine(unit:%)"
cpu_usage_guest_nice:"The proportion of time to run the virtual machine at low priority(unit:%)"
disk_free:"The remaining amount of the hard disk partition (unit: byte)"
disk_used:"Hard disk partitional use (unit: byte)"
disk_used_percent:"Hard disk partitional use rate (unit:%)"
disk_total:"Total amount of hard disk partition (unit: byte)"
disk_inodes_free:"Hard disk partition INODE remaining amount"
disk_inodes_used:"Hard disk partition INODE usage amount"
disk_inodes_total:"The total amount of hard disk partition INODE"
diskio_io_time:"From the perspective of the device perspective, the total time of I/O request, the I/O request in the queue is count (unit: millisecond), the counter type, you need to use the function to find the value"
diskio_iops_in_progress:"IO requests that have been assigned to device -driven and have not yet been completed, not included in the queue but not yet assigned to the device -driven IO request, Gauge type"
diskio_merged_reads:"The number of times of adjacent reading request Merge, the counter type"
diskio_merged_writes:"The number of times the request Merge writes, the counter type"
diskio_read_bytes:"The number of byte reads, the counter type, you need to use the function to find the Rate to use the value"
diskio_read_time:"The total time of reading request (unit: millisecond), the counter type, you need to use the function to find the Rate to have the value of use"
diskio_reads:"Read the number of requests, the counter type, you need to use the function to find the Rate to use the value"
diskio_weighted_io_time:"From the perspective of the I/O request perspective, I/O wait for the total time. If there are multiple I/O requests at the same time, the time will be superimposed (unit: millisecond)"
diskio_write_bytes:"The number of bytes written, the counter type, you need to use the function to find the Rate to use the value"
diskio_write_time:"The total time of the request (unit: millisecond), the counter type, you need to use the function to find the rate to have the value of use"
diskio_writes:"Write the number of requests, the counter type, you need to use the function to find the rate to use value"
kernel_boot_time:"Kernel startup time"
kernel_context_switches:"Number of kernel context switching times"
kernel_entropy_avail:"Entropy pool inside the Linux system"
kernel_interrupts:"Number of kernel interruption"
kernel_processes_forked:"ForK's process number"
mem_active:"The total number of memory (including Cache and BUFFER memory)"
mem_available:"Application can use memory numbers"
mem_buffered:"Used to make buffer size for the file"
mem_cached:"The size of the memory used by the cache memory (equal to diskcache minus Swap Cache )"
mem_commit_limit:"According to the over allocation ratio ('vm.overCommit _ Ratio'), this is the current total memory that can be allocated on the system."
mem_committed_as:"Currently allocated on the system. It is the sum of the memory of all process applications"
mem_dirty:"Waiting to be written back to the memory size of the disk"
mem_free:"Senior memory number"
mem_high_free:"Unused high memory size"
mem_high_total:"The total memory size of the high memory (Highmem refers to all the physical memory that is higher than 860 MB of memory, the HighMem area is used for user programs, or for page cache. This area is not directly mapped to the kernel space. The kernels must use different methods to use this section of memory. )"
mem_huge_page_size:"The size of each big page"
mem_huge_pages_free:"The number of Huge Pages in the pool that have not been allocated"
mem_huge_pages_total:"Reserve the total number of Huge Pages"
mem_inactive:"Free memory (including the memory of free and avalible)"
mem_low_free:"Unused low size"
mem_low_total:"The total size of the low memory memory can achieve the same role of high memory, and it can be used by the kernel to record some of its own data structure"
mem_mapped:"The size of the mapping of equipment and files"
mem_page_tables:"The size of the index table of the management of the memory paging page"
mem_shared:"The total memory shared by multiple processes"
mem_slab:"The size of the kernel data structure cache can reduce the consumption of application and release memory"
mem_sreclaimable:"The size of the SLAB can be recovered"
mem_sunreclaim:"The size of the SLAB cannot be recovered(SUnreclaim+SReclaimable=Slab)"
mem_swap_cached:"The size of the swap space used by the cache memory (cache memory), the memory that has been swapped out, but is still stored in the swapfile. Used to be quickly replaced when needed without opening the I/O port again"
mem_swap_free:"The size of the switching space is not used"
mem_swap_total:"The total size of the exchange space"
mem_total:"Total memory"
mem_used:"Memory number"
mem_used_percent:"The memory has been used by several percentage (0 ~ 100)"
mem_vmalloc_chunk:"The largest continuous unused vmalloc area"
mem_vmalloc_totalL:"You can vmalloc virtual memory size"
mem_vmalloc_used:"Vmalloc's virtual memory size"
mem_write_back:"The memory size of the disk is being written back to the disk"
mem_write_back_tmp:"Fuse is used to temporarily write back the memory of the buffer area"
net_bytes_recv:"The total number of packaging of the network card (bytes)"
net_bytes_sent:"Total number of network cards (bytes)"
net_drop_in:"The number of packets for network cards"
net_drop_out:"The number of packets issued by the network card"
net_err_in:"The number of incorrect packets of the network card"
net_err_out:"Number of incorrect number of network cards"
net_packets_recv:"Net card collection quantity"
net_packets_sent:"Number of network card issuance"
netstat_tcp_established:"ESTABLISHED status network link number"
netstat_tcp_fin_wait1:"FIN _ WAIT1 status network link number"
netstat_tcp_fin_wait2:"FIN _ WAIT2 status number of network links"
netstat_tcp_last_ack:"LAST_ ACK status number of network links"
netstat_tcp_listen:"Number of network links in Listen status"
netstat_tcp_syn_recv:"SYN _ RECV status number of network links"
netstat_tcp_syn_sent:"SYN _ SENT status number of network links"
netstat_tcp_time_wait:"Time _ WAIT status network link number"
netstat_udp_socket:"Number of network links in UDP status"
processes_blocked:"The number of processes in the unreprudible sleep state('U','D','L')"
processes_dead:"Number of processes in recycling('X')"
processes_idle:"Number of idle processes hanging('I')"
processes_paging:"Number of paging processes('P')"
processes_running:"Number of processes during operation('R')"
processes_sleeping:"Can interrupt the number of processes('S')"
processes_stopped:"Pushing status process number('T')"
processes_total:"Total process number"
processes_total_threads:"Number of threads"
processes_unknown:"Unknown status process number"
processes_zombies:"Number of zombies('Z')"
swap_used_percent:"SWAP space replace the data volume"
system_load1:"1 minute average load value"
system_load5:"5 minutes average load value"
system_load15:"15 minutes average load value"
system_n_users:"User number"
system_n_cpus:"CPU nuclear number"
system_uptime:"System startup time"
nginx_accepts:"Since Nginx started, the total number of connections has been established with the client"
nginx_active:"The current number of activity connections that Nginx is being processed is equal to Reading/Writing/Waiting"
nginx_handled:"Starting from Nginx, the total number of client connections that have been processed"
nginx_reading:"Reading the total number of connections on the http request header"
nginx_requests:"Since nginx is started, the total number of client requests processed, due to the existence of HTTP Krrp - Alive requests, this value will be greater than the handled value"
nginx_upstream_check_fall:"UPStream_CHECK module detects the number of back -end failures"
nginx_upstream_check_rise:"UPSTREAM _ Check module to detect the number of back -end"
nginx_upstream_check_status_code:"The state of the backstream is 1, and the down is 0"
nginx_waiting:"When keep-alive is enabled, this value is equal to active – (reading+writing), which means that Nginx has processed the resident connection that is waiting for the next request command"
nginx_writing:"The total number of connections to send a response to the client"
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_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_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)
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_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_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_uptime_in_seconds:Number of seconds since Redis server start
# [windows_exporter]
windows_cpu_clock_interrupts_total:Total number of received and serviced clock tick interrupts(counter)
windows_cpu_core_frequency_mhz:Core frequency in megahertz(gauge)
windows_cpu_cstate_seconds_total:Time spent in low-power idle state(counter)
windows_cpu_dpcs_total:Total number of received and serviced deferred procedure calls (DPCs)(counter)
windows_cpu_idle_break_events_total:Total number of time processor was woken from idle(counter)
windows_cpu_interrupts_total:Total number of received and serviced hardware interrupts(counter)
windows_cpu_parking_status:Parking Status represents whether a processor is parked or not(gauge)
windows_cpu_processor_performance:Processor Performance is the average performance of the processor while it is executing instructions, as a percentage of the nominal performance of the processor. On some processors, Processor Performance may exceed 100%(gauge)
windows_cpu_time_total:Time that processor spent in different modes (idle, user, system, ...)(counter)
windows_cs_hostname:Labeled system hostname information as provided by ComputerSystem.DNSHostName and ComputerSystem.Domain(gauge)
windows_exporter_build_info:A metric with a constant '1' value labeled by version, revision, branch, and goversion from which windows_exporter was built.(gauge)
windows_exporter_collector_duration_seconds:Duration of a collection.(gauge)
windows_exporter_collector_success:Whether the collector was successful.(gauge)
windows_exporter_collector_timeout:Whether the collector timed out.(gauge)
windows_exporter_perflib_snapshot_duration_seconds:Duration of perflib snapshot capture(gauge)
windows_logical_disk_free_bytes:Free space in bytes (LogicalDisk.PercentFreeSpace)(gauge)
windows_logical_disk_idle_seconds_total:Seconds that the disk was idle (LogicalDisk.PercentIdleTime)(counter)
windows_logical_disk_read_bytes_total:The number of bytes transferred from the disk during read operations (LogicalDisk.DiskReadBytesPerSec)(counter)
windows_logical_disk_read_latency_seconds_total:Shows the average time, in seconds, of a read operation from the disk (LogicalDisk.AvgDiskSecPerRead)(counter)
windows_logical_disk_read_seconds_total:Seconds that the disk was busy servicing read requests (LogicalDisk.PercentDiskReadTime)(counter)
windows_logical_disk_read_write_latency_seconds_total:Shows the time, in seconds, of the average disk transfer (LogicalDisk.AvgDiskSecPerTransfer)(counter)
windows_logical_disk_reads_total:The number of read operations on the disk (LogicalDisk.DiskReadsPerSec)(counter)
windows_logical_disk_requests_queued:The number of requests queued to the disk (LogicalDisk.CurrentDiskQueueLength)(gauge)
windows_logical_disk_size_bytes:Total space in bytes (LogicalDisk.PercentFreeSpace_Base)(gauge)
windows_logical_disk_split_ios_total:The number of I/Os to the disk were split into multiple I/Os (LogicalDisk.SplitIOPerSec)(counter)
windows_logical_disk_write_bytes_total:The number of bytes transferred to the disk during write operations (LogicalDisk.DiskWriteBytesPerSec)(counter)
windows_logical_disk_write_latency_seconds_total:Shows the average time, in seconds, of a write operation to the disk (LogicalDisk.AvgDiskSecPerWrite)(counter)
windows_logical_disk_write_seconds_total:Seconds that the disk was busy servicing write requests (LogicalDisk.PercentDiskWriteTime)(counter)
windows_logical_disk_writes_total:The number of write operations on the disk (LogicalDisk.DiskWritesPerSec)(counter)