Skip to content

Latest commit

 

History

History
548 lines (501 loc) · 64.2 KB

prom-metrics.md

File metadata and controls

548 lines (501 loc) · 64.2 KB

Prometheus metrics

This guide covers the performance metrics availabe through Prometheus and assumes Prometheus has already been set up. For a Prometheus overview and setup guide, see the admin guide.

Recommended metrics

We recommend tracking the following key performance metrics through Prometheus. Typically this is done by creating dashboards of related metrics, so the metrics are grouped into logical dashboards.

If you're using Grafana for dashboards and have connected Sourcegraph's Prometheus instance to it, you can import these dashboards directly from JSON.

Dashboard: frontend

  1. frontend QPS, by HTTP code (5m avg):

    sum(label_replace(job:src_http_request_count:rate5m, \"c\", \"00s\", \"code\", \"([0-9]).*\")) by (c)
    
  2. frontend QPS, by route (5m avg):

    sum(route:src_http_request_count:rate5m{route=~\"blob|graphql|home|page.def.landing|page.repo.landing|repo|repo-branches|search|settings|sign-in|site-admin|tree\"}) by (route)
    
  3. frontend 90th-percentile request duration (5m avg):

    histogram_quantile(0.90, route:src_http_request_duration_seconds_bucket:rate5m{route=~\"blob|graphql|home|page.def.landing|page.repo.landing|repo|repo-branches|search|settings|sign-in|site-admin|tree\"})
    
  4. frontend 75th-percentile request duration (5m avg):

    histogram_quantile(0.75, route:src_http_request_duration_seconds_bucket:rate5m{route=~\"blob|graphql|home|page.def.landing|page.repo.landing|repo|repo-branches|search|settings|sign-in|site-admin|tree\"})
    
  5. frontend CPU usage, by pod (%)

    label_replace( irate(process_cpu_seconds_total{app=\"sourcegraph-frontend\"}[10m]), \"inst\", \"\", \"instance\", \"[a-z0-9\\-]+\\-([a-z0-9]+)\" ) * 100
    
  6. frontend resident memory, by pod (GB)

    label_replace( process_resident_memory_bytes{app=\"sourcegraph-frontend\"}, \"inst\", \"\", \"instance\", \"[a-z0-9\\-]+\\-([a-z0-9]+)\" ) / 1024 / 1024 / 1024
    
  7. frontend virtual memory, by pod (GB)

    label_replace( process_virtual_memory_bytes{app=\"sourcegraph-frontend\"}, \"inst\", \"\", \"instance\", \"[a-z0-9\\-]+\\-([a-z0-9]+)\" ) / 1024 / 1024 / 1024
    

Dashboard: gitserver

  1. gitserver total QPS (10m avg):

    sum(rate(src_gitserver_exec_duration_seconds_count{status=~\"[0-9]+\"}[10m])) by (job)"
    
  2. gitserver QPS, by operation (10m avg):

    sum(rate(src_gitserver_exec_duration_seconds_count{status=~\"[0-9]+\"}[10m])) by (cmd, job)"
    
  3. gitserver p90 request duration, by operation (10m avg):

    histogram_quantile(0.9, sum(rate(src_gitserver_exec_duration_seconds_bucket{status=~\"[0-9]+\"}[10m])) by (le, cmd, job))"
    
  4. gitserver p75 request duration, by operation (10m avg):

    histogram_quantile(0.75, sum(rate(src_gitserver_exec_duration_seconds_bucket{status=~\"[0-9]+\"}[10m])) by (le, cmd, job))"
    
  5. git execs running

    sum by (job)(src_gitserver_exec_running)"
    
  6. exit status QPS, by operation (10m avg):

    sum by (status, cmd)(rate(src_gitserver_exec_duration_seconds_count{status!=\"\"}[10m]))"
    
  7. free disk space (TB):

    min(src_gitserver_disk_space_available) BY (job) / 1000 / 1000 / 1000"
    

Dashboard: resources

  1. max CPU, by service

    (max by (job)(irate(process_cpu_seconds_total[5m]))) * 100
    
  2. max resident memory, by service (GB):

    (max by (job)(process_resident_memory_bytes)) / 1024 / 1024 / 1024
    
  3. max virtual memory, by service (GB):

    max by (job)(process_virtual_memory_bytes) / 1024 / 1024 / 1024
    

All metrics

This is a list of all metrics available through Prometheus. Though most critical information is covered by the recommended dashboards above, these additional metrics can be useful for creating custom dashboards or investigating specific issues.

<style> span.gray { color: gray; } </style>
  • go_gc_duration_seconds : summary : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    A summary of the GC invocation durations.
  • go_goroutines : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of goroutines that currently exist.
  • go_info : gauge : github-proxy, gitserver, pgsql, query-runner, repo-updater, searcher, sourcegraph-frontend, symbols
    Information about the Go environment.
  • go_memstats_alloc_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes allocated and still in use.
  • go_memstats_alloc_bytes_total : counter : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Total number of bytes allocated, even if freed.
  • go_memstats_buck_hash_sys_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes used by the profiling bucket hash table.
  • go_memstats_frees_total : counter : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Total number of frees.
  • go_memstats_gc_cpu_fraction : gauge : github-proxy, gitserver, pgsql, query-runner, repo-updater, searcher, sourcegraph-frontend, symbols
    The fraction of this program's available CPU time used by the GC since the program started.
  • go_memstats_gc_sys_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes used for garbage collection system metadata.
  • go_memstats_heap_alloc_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of heap bytes allocated and still in use.
  • go_memstats_heap_idle_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of heap bytes waiting to be used.
  • go_memstats_heap_inuse_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of heap bytes that are in use.
  • go_memstats_heap_objects : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of allocated objects.
  • go_memstats_heap_released_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of heap bytes released to OS.
  • go_memstats_heap_released_bytes_total : counter : redis-cache, redis-store
    Total number of heap bytes released to OS.
  • go_memstats_heap_sys_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of heap bytes obtained from system.
  • go_memstats_last_gc_time_seconds : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of seconds since 1970 of last garbage collection.
  • go_memstats_lookups_total : counter : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Total number of pointer lookups.
  • go_memstats_mallocs_total : counter : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Total number of mallocs.
  • go_memstats_mcache_inuse_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes in use by mcache structures.
  • go_memstats_mcache_sys_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes used for mcache structures obtained from system.
  • go_memstats_mspan_inuse_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes in use by mspan structures.
  • go_memstats_mspan_sys_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes used for mspan structures obtained from system.
  • go_memstats_next_gc_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of heap bytes when next garbage collection will take place.
  • go_memstats_other_sys_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes used for other system allocations.
  • go_memstats_stack_inuse_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes in use by the stack allocator.
  • go_memstats_stack_sys_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes obtained from system for stack allocator.
  • go_memstats_sys_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of bytes obtained from system.
  • go_threads : gauge : github-proxy, gitserver, pgsql, query-runner, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of OS threads created.
  • http_request_duration_microseconds : summary : github-proxy, redis-cache, redis-store
    The HTTP request latencies in microseconds.
  • http_request_size_bytes : summary : github-proxy, redis-cache, redis-store
    The HTTP request sizes in bytes.
  • http_requests_total : counter : github-proxy, redis-cache, redis-store
    Total number of HTTP requests made.
  • http_response_size_bytes : summary : github-proxy, redis-cache, redis-store
    The HTTP response sizes in bytes.
  • pg_exporter_last_scrape_duration_seconds : gauge : pgsql
    Duration of the last scrape of metrics from PostgresSQL.
  • pg_exporter_last_scrape_error : gauge : pgsql
    Whether the last scrape of metrics from PostgreSQL resulted in an error (1 for error, 0 for success).
  • pg_exporter_scrapes_total : counter : pgsql
    Total number of times PostgresSQL was scraped for metrics.
  • pg_locks_count : gauge : pgsql
    Number of locks
  • pg_settings_allow_system_table_mods : gauge : pgsql
    Allows modifications of the structure of system tables.
  • pg_settings_archive_timeout_seconds : gauge : pgsql
    Forces a switch to the next WAL file if a new file has not been started within N seconds. [Units converted to seconds.]
  • pg_settings_array_nulls : gauge : pgsql
    Enable input of NULL elements in arrays.
  • pg_settings_authentication_timeout_seconds : gauge : pgsql
    Sets the maximum allowed time to complete client authentication. [Units converted to seconds.]
  • pg_settings_autovacuum : gauge : pgsql
    Starts the autovacuum subprocess.
  • pg_settings_autovacuum_analyze_scale_factor : gauge : pgsql
    Number of tuple inserts, updates, or deletes prior to analyze as a fraction of reltuples.
  • pg_settings_autovacuum_analyze_threshold : gauge : pgsql
    Minimum number of tuple inserts, updates, or deletes prior to analyze.
  • pg_settings_autovacuum_freeze_max_age : gauge : pgsql
    Age at which to autovacuum a table to prevent transaction ID wraparound.
  • pg_settings_autovacuum_max_workers : gauge : pgsql
    Sets the maximum number of simultaneously running autovacuum worker processes.
  • pg_settings_autovacuum_multixact_freeze_max_age : gauge : pgsql
    Multixact age at which to autovacuum a table to prevent multixact wraparound.
  • pg_settings_autovacuum_naptime_seconds : gauge : pgsql
    Time to sleep between autovacuum runs. [Units converted to seconds.]
  • pg_settings_autovacuum_vacuum_cost_delay_seconds : gauge : pgsql
    Vacuum cost delay in milliseconds, for autovacuum. [Units converted to seconds.]
  • pg_settings_autovacuum_vacuum_cost_limit : gauge : pgsql
    Vacuum cost amount available before napping, for autovacuum.
  • pg_settings_autovacuum_vacuum_scale_factor : gauge : pgsql
    Number of tuple updates or deletes prior to vacuum as a fraction of reltuples.
  • pg_settings_autovacuum_vacuum_threshold : gauge : pgsql
    Minimum number of tuple updates or deletes prior to vacuum.
  • pg_settings_autovacuum_work_mem_bytes : gauge : pgsql
    Sets the maximum memory to be used by each autovacuum worker process. [Units converted to bytes.]
  • pg_settings_backend_flush_after_bytes : gauge : pgsql
    Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]
  • pg_settings_bgwriter_delay_seconds : gauge : pgsql
    Background writer sleep time between rounds. [Units converted to seconds.]
  • pg_settings_bgwriter_flush_after_bytes : gauge : pgsql
    Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]
  • pg_settings_bgwriter_lru_maxpages : gauge : pgsql
    Background writer maximum number of LRU pages to flush per round.
  • pg_settings_bgwriter_lru_multiplier : gauge : pgsql
    Multiple of the average buffer usage to free per round.
  • pg_settings_block_size : gauge : pgsql
    Shows the size of a disk block.
  • pg_settings_bonjour : gauge : pgsql
    Enables advertising the server via Bonjour.
  • pg_settings_check_function_bodies : gauge : pgsql
    Check function bodies during CREATE FUNCTION.
  • pg_settings_checkpoint_completion_target : gauge : pgsql
    Time spent flushing dirty buffers during checkpoint, as fraction of checkpoint interval.
  • pg_settings_checkpoint_flush_after_bytes : gauge : pgsql
    Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]
  • pg_settings_checkpoint_timeout_seconds : gauge : pgsql
    Sets the maximum time between automatic WAL checkpoints. [Units converted to seconds.]
  • pg_settings_checkpoint_warning_seconds : gauge : pgsql
    Enables warnings if checkpoint segments are filled more frequently than this. [Units converted to seconds.]
  • pg_settings_commit_delay : gauge : pgsql
    Sets the delay in microseconds between transaction commit and flushing WAL to disk.
  • pg_settings_commit_siblings : gauge : pgsql
    Sets the minimum concurrent open transactions before performing commit_delay.
  • pg_settings_cpu_index_tuple_cost : gauge : pgsql
    Sets the planner's estimate of the cost of processing each index entry during an index scan.
  • pg_settings_cpu_operator_cost : gauge : pgsql
    Sets the planner's estimate of the cost of processing each operator or function call.
  • pg_settings_cpu_tuple_cost : gauge : pgsql
    Sets the planner's estimate of the cost of processing each tuple (row).
  • pg_settings_cursor_tuple_fraction : gauge : pgsql
    Sets the planner's estimate of the fraction of a cursor's rows that will be retrieved.
  • pg_settings_data_checksums : gauge : pgsql
    Shows whether data checksums are turned on for this cluster.
  • pg_settings_data_directory_mode : gauge : pgsql
    Mode of the data directory.
  • pg_settings_db_user_namespace : gauge : pgsql
    Enables per-database user names.
  • pg_settings_deadlock_timeout_seconds : gauge : pgsql
    Sets the time to wait on a lock before checking for deadlock. [Units converted to seconds.]
  • pg_settings_debug_assertions : gauge : pgsql
    Shows whether the running server has assertion checks enabled.
  • pg_settings_debug_pretty_print : gauge : pgsql
    Indents parse and plan tree displays.
  • pg_settings_debug_print_parse : gauge : pgsql
    Logs each query's parse tree.
  • pg_settings_debug_print_plan : gauge : pgsql
    Logs each query's execution plan.
  • pg_settings_debug_print_rewritten : gauge : pgsql
    Logs each query's rewritten parse tree.
  • pg_settings_default_statistics_target : gauge : pgsql
    Sets the default statistics target.
  • pg_settings_default_transaction_deferrable : gauge : pgsql
    Sets the default deferrable status of new transactions.
  • pg_settings_default_transaction_read_only : gauge : pgsql
    Sets the default read-only status of new transactions.
  • pg_settings_default_with_oids : gauge : pgsql
    Create new tables with OIDs by default.
  • pg_settings_effective_cache_size_bytes : gauge : pgsql
    Sets the planner's assumption about the total size of the data caches. [Units converted to bytes.]
  • pg_settings_effective_io_concurrency : gauge : pgsql
    Number of simultaneous requests that can be handled efficiently by the disk subsystem.
  • pg_settings_enable_bitmapscan : gauge : pgsql
    Enables the planner's use of bitmap-scan plans.
  • pg_settings_enable_gathermerge : gauge : pgsql
    Enables the planner's use of gather merge plans.
  • pg_settings_enable_hashagg : gauge : pgsql
    Enables the planner's use of hashed aggregation plans.
  • pg_settings_enable_hashjoin : gauge : pgsql
    Enables the planner's use of hash join plans.
  • pg_settings_enable_indexonlyscan : gauge : pgsql
    Enables the planner's use of index-only-scan plans.
  • pg_settings_enable_indexscan : gauge : pgsql
    Enables the planner's use of index-scan plans.
  • pg_settings_enable_material : gauge : pgsql
    Enables the planner's use of materialization.
  • pg_settings_enable_mergejoin : gauge : pgsql
    Enables the planner's use of merge join plans.
  • pg_settings_enable_nestloop : gauge : pgsql
    Enables the planner's use of nested-loop join plans.
  • pg_settings_enable_parallel_append : gauge : pgsql
    Enables the planner's use of parallel append plans.
  • pg_settings_enable_parallel_hash : gauge : pgsql
    Enables the planner's use of parallel hash plans.
  • pg_settings_enable_partition_pruning : gauge : pgsql
    Enable plan-time and run-time partition pruning.
  • pg_settings_enable_partitionwise_aggregate : gauge : pgsql
    Enables partitionwise aggregation and grouping.
  • pg_settings_enable_partitionwise_join : gauge : pgsql
    Enables partitionwise join.
  • pg_settings_enable_seqscan : gauge : pgsql
    Enables the planner's use of sequential-scan plans.
  • pg_settings_enable_sort : gauge : pgsql
    Enables the planner's use of explicit sort steps.
  • pg_settings_enable_tidscan : gauge : pgsql
    Enables the planner's use of TID scan plans.
  • pg_settings_escape_string_warning : gauge : pgsql
    Warn about backslash escapes in ordinary string literals.
  • pg_settings_exit_on_error : gauge : pgsql
    Terminate session on any error.
  • pg_settings_extra_float_digits : gauge : pgsql
    Sets the number of digits displayed for floating-point values.
  • pg_settings_from_collapse_limit : gauge : pgsql
    Sets the FROM-list size beyond which subqueries are not collapsed.
  • pg_settings_fsync : gauge : pgsql
    Forces synchronization of updates to disk.
  • pg_settings_full_page_writes : gauge : pgsql
    Writes full pages to WAL when first modified after a checkpoint.
  • pg_settings_geqo : gauge : pgsql
    Enables genetic query optimization.
  • pg_settings_geqo_effort : gauge : pgsql
    GEQO: effort is used to set the default for other GEQO parameters.
  • pg_settings_geqo_generations : gauge : pgsql
    GEQO: number of iterations of the algorithm.
  • pg_settings_geqo_pool_size : gauge : pgsql
    GEQO: number of individuals in the population.
  • pg_settings_geqo_seed : gauge : pgsql
    GEQO: seed for random path selection.
  • pg_settings_geqo_selection_bias : gauge : pgsql
    GEQO: selective pressure within the population.
  • pg_settings_geqo_threshold : gauge : pgsql
    Sets the threshold of FROM items beyond which GEQO is used.
  • pg_settings_gin_fuzzy_search_limit : gauge : pgsql
    Sets the maximum allowed result for exact search by GIN.
  • pg_settings_gin_pending_list_limit_bytes : gauge : pgsql
    Sets the maximum size of the pending list for GIN index. [Units converted to bytes.]
  • pg_settings_hot_standby : gauge : pgsql
    Allows connections and queries during recovery.
  • pg_settings_hot_standby_feedback : gauge : pgsql
    Allows feedback from a hot standby to the primary that will avoid query conflicts.
  • pg_settings_idle_in_transaction_session_timeout_seconds : gauge : pgsql
    Sets the maximum allowed duration of any idling transaction. [Units converted to seconds.]
  • pg_settings_ignore_checksum_failure : gauge : pgsql
    Continues processing after a checksum failure.
  • pg_settings_ignore_system_indexes : gauge : pgsql
    Disables reading from system indexes.
  • pg_settings_integer_datetimes : gauge : pgsql
    Datetimes are integer based.
  • pg_settings_jit : gauge : pgsql
    Allow JIT compilation.
  • pg_settings_jit_above_cost : gauge : pgsql
    Perform JIT compilation if query is more expensive.
  • pg_settings_jit_debugging_support : gauge : pgsql
    Register JIT compiled function with debugger.
  • pg_settings_jit_dump_bitcode : gauge : pgsql
    Write out LLVM bitcode to facilitate JIT debugging.
  • pg_settings_jit_expressions : gauge : pgsql
    Allow JIT compilation of expressions.
  • pg_settings_jit_inline_above_cost : gauge : pgsql
    Perform JIT inlining if query is more expensive.
  • pg_settings_jit_optimize_above_cost : gauge : pgsql
    Optimize JITed functions if query is more expensive.
  • pg_settings_jit_profiling_support : gauge : pgsql
    Register JIT compiled function with perf profiler.
  • pg_settings_jit_tuple_deforming : gauge : pgsql
    Allow JIT compilation of tuple deforming.
  • pg_settings_join_collapse_limit : gauge : pgsql
    Sets the FROM-list size beyond which JOIN constructs are not flattened.
  • pg_settings_krb_caseins_users : gauge : pgsql
    Sets whether Kerberos and GSSAPI user names should be treated as case-insensitive.
  • pg_settings_lo_compat_privileges : gauge : pgsql
    Enables backward compatibility mode for privilege checks on large objects.
  • pg_settings_lock_timeout_seconds : gauge : pgsql
    Sets the maximum allowed duration of any wait for a lock. [Units converted to seconds.]
  • pg_settings_log_autovacuum_min_duration_seconds : gauge : pgsql
    Sets the minimum execution time above which autovacuum actions will be logged. [Units converted to seconds.]
  • pg_settings_log_checkpoints : gauge : pgsql
    Logs each checkpoint.
  • pg_settings_log_connections : gauge : pgsql
    Logs each successful connection.
  • pg_settings_log_disconnections : gauge : pgsql
    Logs end of a session, including duration.
  • pg_settings_log_duration : gauge : pgsql
    Logs the duration of each completed SQL statement.
  • pg_settings_log_executor_stats : gauge : pgsql
    Writes executor performance statistics to the server log.
  • pg_settings_log_file_mode : gauge : pgsql
    Sets the file permissions for log files.
  • pg_settings_log_hostname : gauge : pgsql
    Logs the host name in the connection logs.
  • pg_settings_log_lock_waits : gauge : pgsql
    Logs long lock waits.
  • pg_settings_log_min_duration_statement_seconds : gauge : pgsql
    Sets the minimum execution time above which statements will be logged. [Units converted to seconds.]
  • pg_settings_log_parser_stats : gauge : pgsql
    Writes parser performance statistics to the server log.
  • pg_settings_log_planner_stats : gauge : pgsql
    Writes planner performance statistics to the server log.
  • pg_settings_log_replication_commands : gauge : pgsql
    Logs each replication command.
  • pg_settings_log_rotation_age_seconds : gauge : pgsql
    Automatic log file rotation will occur after N minutes. [Units converted to seconds.]
  • pg_settings_log_rotation_size_bytes : gauge : pgsql
    Automatic log file rotation will occur after N kilobytes. [Units converted to bytes.]
  • pg_settings_log_statement_stats : gauge : pgsql
    Writes cumulative performance statistics to the server log.
  • pg_settings_log_temp_files_bytes : gauge : pgsql
    Log the use of temporary files larger than this number of kilobytes. [Units converted to bytes.]
  • pg_settings_log_truncate_on_rotation : gauge : pgsql
    Truncate existing log files of same name during log rotation.
  • pg_settings_logging_collector : gauge : pgsql
    Start a subprocess to capture stderr output and/or csvlogs into log files.
  • pg_settings_maintenance_work_mem_bytes : gauge : pgsql
    Sets the maximum memory to be used for maintenance operations. [Units converted to bytes.]
  • pg_settings_max_connections : gauge : pgsql
    Sets the maximum number of concurrent connections.
  • pg_settings_max_files_per_process : gauge : pgsql
    Sets the maximum number of simultaneously open files for each server process.
  • pg_settings_max_function_args : gauge : pgsql
    Shows the maximum number of function arguments.
  • pg_settings_max_identifier_length : gauge : pgsql
    Shows the maximum identifier length.
  • pg_settings_max_index_keys : gauge : pgsql
    Shows the maximum number of index keys.
  • pg_settings_max_locks_per_transaction : gauge : pgsql
    Sets the maximum number of locks per transaction.
  • pg_settings_max_logical_replication_workers : gauge : pgsql
    Maximum number of logical replication worker processes.
  • pg_settings_max_parallel_maintenance_workers : gauge : pgsql
    Sets the maximum number of parallel processes per maintenance operation.
  • pg_settings_max_parallel_workers : gauge : pgsql
    Sets the maximum number of parallel workers that can be active at one time.
  • pg_settings_max_parallel_workers_per_gather : gauge : pgsql
    Sets the maximum number of parallel processes per executor node.
  • pg_settings_max_pred_locks_per_page : gauge : pgsql
    Sets the maximum number of predicate-locked tuples per page.
  • pg_settings_max_pred_locks_per_relation : gauge : pgsql
    Sets the maximum number of predicate-locked pages and tuples per relation.
  • pg_settings_max_pred_locks_per_transaction : gauge : pgsql
    Sets the maximum number of predicate locks per transaction.
  • pg_settings_max_prepared_transactions : gauge : pgsql
    Sets the maximum number of simultaneously prepared transactions.
  • pg_settings_max_replication_slots : gauge : pgsql
    Sets the maximum number of simultaneously defined replication slots.
  • pg_settings_max_stack_depth_bytes : gauge : pgsql
    Sets the maximum stack depth, in kilobytes. [Units converted to bytes.]
  • pg_settings_max_standby_archive_delay_seconds : gauge : pgsql
    Sets the maximum delay before canceling queries when a hot standby server is processing archived WAL data. [Units converted to seconds.]
  • pg_settings_max_standby_streaming_delay_seconds : gauge : pgsql
    Sets the maximum delay before canceling queries when a hot standby server is processing streamed WAL data. [Units converted to seconds.]
  • pg_settings_max_sync_workers_per_subscription : gauge : pgsql
    Maximum number of table synchronization workers per subscription.
  • pg_settings_max_wal_senders : gauge : pgsql
    Sets the maximum number of simultaneously running WAL sender processes.
  • pg_settings_max_wal_size_bytes : gauge : pgsql
    Sets the WAL size that triggers a checkpoint. [Units converted to bytes.]
  • pg_settings_max_worker_processes : gauge : pgsql
    Maximum number of concurrent worker processes.
  • pg_settings_min_parallel_index_scan_size_bytes : gauge : pgsql
    Sets the minimum amount of index data for a parallel scan. [Units converted to bytes.]
  • pg_settings_min_parallel_table_scan_size_bytes : gauge : pgsql
    Sets the minimum amount of table data for a parallel scan. [Units converted to bytes.]
  • pg_settings_min_wal_size_bytes : gauge : pgsql
    Sets the minimum size to shrink the WAL to. [Units converted to bytes.]
  • pg_settings_old_snapshot_threshold_seconds : gauge : pgsql
    Time before a snapshot is too old to read pages changed after the snapshot was taken. [Units converted to seconds.]
  • pg_settings_operator_precedence_warning : gauge : pgsql
    Emit a warning for constructs that changed meaning since PostgreSQL 9.4.
  • pg_settings_parallel_leader_participation : gauge : pgsql
    Controls whether Gather and Gather Merge also run subplans.
  • pg_settings_parallel_setup_cost : gauge : pgsql
    Sets the planner's estimate of the cost of starting up worker processes for parallel query.
  • pg_settings_parallel_tuple_cost : gauge : pgsql
    Sets the planner's estimate of the cost of passing each tuple (row) from worker to master backend.
  • pg_settings_port : gauge : pgsql
    Sets the TCP port the server listens on.
  • pg_settings_post_auth_delay_seconds : gauge : pgsql
    Waits N seconds on connection startup after authentication. [Units converted to seconds.]
  • pg_settings_pre_auth_delay_seconds : gauge : pgsql
    Waits N seconds on connection startup before authentication. [Units converted to seconds.]
  • pg_settings_quote_all_identifiers : gauge : pgsql
    When generating SQL fragments, quote all identifiers.
  • pg_settings_random_page_cost : gauge : pgsql
    Sets the planner's estimate of the cost of a nonsequentially fetched disk page.
  • pg_settings_restart_after_crash : gauge : pgsql
    Reinitialize server after backend crash.
  • pg_settings_row_security : gauge : pgsql
    Enable row security.
  • pg_settings_segment_size_bytes : gauge : pgsql
    Shows the number of pages per disk file. [Units converted to bytes.]
  • pg_settings_seq_page_cost : gauge : pgsql
    Sets the planner's estimate of the cost of a sequentially fetched disk page.
  • pg_settings_server_version_num : gauge : pgsql
    Shows the server version as an integer.
  • pg_settings_shared_buffers_bytes : gauge : pgsql
    Sets the number of shared memory buffers used by the server. [Units converted to bytes.]
  • pg_settings_ssl : gauge : pgsql
    Enables SSL connections.
  • pg_settings_ssl_passphrase_command_supports_reload : gauge : pgsql
    Also use ssl_passphrase_command during server reload.
  • pg_settings_ssl_prefer_server_ciphers : gauge : pgsql
    Give priority to server ciphersuite order.
  • pg_settings_standard_conforming_strings : gauge : pgsql
    Causes '...' strings to treat backslashes literally.
  • pg_settings_statement_timeout_seconds : gauge : pgsql
    Sets the maximum allowed duration of any statement. [Units converted to seconds.]
  • pg_settings_superuser_reserved_connections : gauge : pgsql
    Sets the number of connection slots reserved for superusers.
  • pg_settings_synchronize_seqscans : gauge : pgsql
    Enable synchronized sequential scans.
  • pg_settings_syslog_sequence_numbers : gauge : pgsql
    Add sequence number to syslog messages to avoid duplicate suppression.
  • pg_settings_syslog_split_messages : gauge : pgsql
    Split messages sent to syslog by lines and to fit into 1024 bytes.
  • pg_settings_tcp_keepalives_count : gauge : pgsql
    Maximum number of TCP keepalive retransmits.
  • pg_settings_tcp_keepalives_idle_seconds : gauge : pgsql
    Time between issuing TCP keepalives. [Units converted to seconds.]
  • pg_settings_tcp_keepalives_interval_seconds : gauge : pgsql
    Time between TCP keepalive retransmits. [Units converted to seconds.]
  • pg_settings_temp_buffers_bytes : gauge : pgsql
    Sets the maximum number of temporary buffers used by each session. [Units converted to bytes.]
  • pg_settings_temp_file_limit_bytes : gauge : pgsql
    Limits the total size of all temporary files used by each process. [Units converted to bytes.]
  • pg_settings_trace_notify : gauge : pgsql
    Generates debugging output for LISTEN and NOTIFY.
  • pg_settings_trace_sort : gauge : pgsql
    Emit information about resource usage in sorting.
  • pg_settings_track_activities : gauge : pgsql
    Collects information about executing commands.
  • pg_settings_track_activity_query_size_bytes : gauge : pgsql
    Sets the size reserved for pg_stat_activity.query, in bytes. [Units converted to bytes.]
  • pg_settings_track_commit_timestamp : gauge : pgsql
    Collects transaction commit time.
  • pg_settings_track_counts : gauge : pgsql
    Collects statistics on database activity.
  • pg_settings_track_io_timing : gauge : pgsql
    Collects timing statistics for database I/O activity.
  • pg_settings_transaction_deferrable : gauge : pgsql
    Whether to defer a read-only serializable transaction until it can be executed with no possible serialization failures.
  • pg_settings_transaction_read_only : gauge : pgsql
    Sets the current transaction's read-only status.
  • pg_settings_transform_null_equals : gauge : pgsql
    Treats "expr=NULL" as "expr IS NULL".
  • pg_settings_unix_socket_permissions : gauge : pgsql
    Sets the access permissions of the Unix-domain socket.
  • pg_settings_update_process_title : gauge : pgsql
    Updates the process title to show the active SQL command.
  • pg_settings_vacuum_cleanup_index_scale_factor : gauge : pgsql
    Number of tuple inserts prior to index cleanup as a fraction of reltuples.
  • pg_settings_vacuum_cost_delay_seconds : gauge : pgsql
    Vacuum cost delay in milliseconds. [Units converted to seconds.]
  • pg_settings_vacuum_cost_limit : gauge : pgsql
    Vacuum cost amount available before napping.
  • pg_settings_vacuum_cost_page_dirty : gauge : pgsql
    Vacuum cost for a page dirtied by vacuum.
  • pg_settings_vacuum_cost_page_hit : gauge : pgsql
    Vacuum cost for a page found in the buffer cache.
  • pg_settings_vacuum_cost_page_miss : gauge : pgsql
    Vacuum cost for a page not found in the buffer cache.
  • pg_settings_vacuum_defer_cleanup_age : gauge : pgsql
    Number of transactions by which VACUUM and HOT cleanup should be deferred, if any.
  • pg_settings_vacuum_freeze_min_age : gauge : pgsql
    Minimum age at which VACUUM should freeze a table row.
  • pg_settings_vacuum_freeze_table_age : gauge : pgsql
    Age at which VACUUM should scan whole table to freeze tuples.
  • pg_settings_vacuum_multixact_freeze_min_age : gauge : pgsql
    Minimum age at which VACUUM should freeze a MultiXactId in a table row.
  • pg_settings_vacuum_multixact_freeze_table_age : gauge : pgsql
    Multixact age at which VACUUM should scan whole table to freeze tuples.
  • pg_settings_wal_block_size : gauge : pgsql
    Shows the block size in the write ahead log.
  • pg_settings_wal_buffers_bytes : gauge : pgsql
    Sets the number of disk-page buffers in shared memory for WAL. [Units converted to bytes.]
  • pg_settings_wal_compression : gauge : pgsql
    Compresses full-page writes written in WAL file.
  • pg_settings_wal_keep_segments : gauge : pgsql
    Sets the number of WAL files held for standby servers.
  • pg_settings_wal_log_hints : gauge : pgsql
    Writes full pages to WAL when first modified after a checkpoint, even for a non-critical modifications.
  • pg_settings_wal_receiver_status_interval_seconds : gauge : pgsql
    Sets the maximum interval between WAL receiver status reports to the primary. [Units converted to seconds.]
  • pg_settings_wal_receiver_timeout_seconds : gauge : pgsql
    Sets the maximum wait time to receive data from the primary. [Units converted to seconds.]
  • pg_settings_wal_retrieve_retry_interval_seconds : gauge : pgsql
    Sets the time to wait before retrying to retrieve WAL after a failed attempt. [Units converted to seconds.]
  • pg_settings_wal_segment_size_bytes : gauge : pgsql
    Shows the size of write ahead log segments. [Units converted to bytes.]
  • pg_settings_wal_sender_timeout_seconds : gauge : pgsql
    Sets the maximum time to wait for WAL replication. [Units converted to seconds.]
  • pg_settings_wal_writer_delay_seconds : gauge : pgsql
    Time between WAL flushes performed in the WAL writer. [Units converted to seconds.]
  • pg_settings_wal_writer_flush_after_bytes : gauge : pgsql
    Amount of WAL written out by WAL writer that triggers a flush. [Units converted to bytes.]
  • pg_settings_work_mem_bytes : gauge : pgsql
    Sets the maximum memory to be used for query workspaces. [Units converted to bytes.]
  • pg_settings_zero_damaged_pages : gauge : pgsql
    Continues processing past damaged page headers.
  • pg_stat_activity_count : gauge : pgsql
    number of connections in this state
  • pg_stat_activity_max_tx_duration : gauge : pgsql
    max duration in seconds any active transaction has been running
  • pg_stat_bgwriter_buffers_alloc : counter : pgsql
    Number of buffers allocated
  • pg_stat_bgwriter_buffers_backend : counter : pgsql
    Number of buffers written directly by a backend
  • pg_stat_bgwriter_buffers_backend_fsync : counter : pgsql
    Number of times a backend had to execute its own fsync call (normally the background writer handles those even when the backend does its own write)
  • pg_stat_bgwriter_buffers_checkpoint : counter : pgsql
    Number of buffers written during checkpoints
  • pg_stat_bgwriter_buffers_clean : counter : pgsql
    Number of buffers written by the background writer
  • pg_stat_bgwriter_checkpoint_sync_time : counter : pgsql
    Total amount of time that has been spent in the portion of checkpoint processing where files are synchronized to disk, in milliseconds
  • pg_stat_bgwriter_checkpoint_write_time : counter : pgsql
    Total amount of time that has been spent in the portion of checkpoint processing where files are written to disk, in milliseconds
  • pg_stat_bgwriter_checkpoints_req : counter : pgsql
    Number of requested checkpoints that have been performed
  • pg_stat_bgwriter_checkpoints_timed : counter : pgsql
    Number of scheduled checkpoints that have been performed
  • pg_stat_bgwriter_maxwritten_clean : counter : pgsql
    Number of times the background writer stopped a cleaning scan because it had written too many buffers
  • pg_stat_bgwriter_stats_reset : counter : pgsql
    Time at which these statistics were last reset
  • pg_stat_database_blk_read_time : counter : pgsql
    Time spent reading data file blocks by backends in this database, in milliseconds
  • pg_stat_database_blk_write_time : counter : pgsql
    Time spent writing data file blocks by backends in this database, in milliseconds
  • pg_stat_database_blks_hit : counter : pgsql
    Number of times disk blocks were found already in the buffer cache, so that a read was not necessary (this only includes hits in the PostgreSQL buffer cache, not the operating system's file system cache)
  • pg_stat_database_blks_read : counter : pgsql
    Number of disk blocks read in this database
  • pg_stat_database_conflicts : counter : pgsql
    Number of queries canceled due to conflicts with recovery in this database. (Conflicts occur only on standby servers; see pg_stat_database_conflicts for details.)
  • pg_stat_database_conflicts_confl_bufferpin : counter : pgsql
    Number of queries in this database that have been canceled due to pinned buffers
  • pg_stat_database_conflicts_confl_deadlock : counter : pgsql
    Number of queries in this database that have been canceled due to deadlocks
  • pg_stat_database_conflicts_confl_lock : counter : pgsql
    Number of queries in this database that have been canceled due to lock timeouts
  • pg_stat_database_conflicts_confl_snapshot : counter : pgsql
    Number of queries in this database that have been canceled due to old snapshots
  • pg_stat_database_conflicts_confl_tablespace : counter : pgsql
    Number of queries in this database that have been canceled due to dropped tablespaces
  • pg_stat_database_deadlocks : counter : pgsql
    Number of deadlocks detected in this database
  • pg_stat_database_numbackends : gauge : pgsql
    Number of backends currently connected to this database. This is the only column in this view that returns a value reflecting current state; all other columns return the accumulated values since the last reset.
  • pg_stat_database_stats_reset : counter : pgsql
    Time at which these statistics were last reset
  • pg_stat_database_temp_bytes : counter : pgsql
    Total amount of data written to temporary files by queries in this database. All temporary files are counted, regardless of why the temporary file was created, and regardless of the log_temp_files setting.
  • pg_stat_database_temp_files : counter : pgsql
    Number of temporary files created by queries in this database. All temporary files are counted, regardless of why the temporary file was created (e.g., sorting or hashing), and regardless of the log_temp_files setting.
  • pg_stat_database_tup_deleted : counter : pgsql
    Number of rows deleted by queries in this database
  • pg_stat_database_tup_fetched : counter : pgsql
    Number of rows fetched by queries in this database
  • pg_stat_database_tup_inserted : counter : pgsql
    Number of rows inserted by queries in this database
  • pg_stat_database_tup_returned : counter : pgsql
    Number of rows returned by queries in this database
  • pg_stat_database_tup_updated : counter : pgsql
    Number of rows updated by queries in this database
  • pg_stat_database_xact_commit : counter : pgsql
    Number of transactions in this database that have been committed
  • pg_stat_database_xact_rollback : counter : pgsql
    Number of transactions in this database that have been rolled back
  • pg_static : untyped : pgsql
    Version string as reported by postgres
  • pg_up : gauge : pgsql
    Whether the last scrape of metrics from PostgreSQL was able to connect to the server (1 for yes, 0 for no).
  • process_cpu_seconds_total : counter : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Total user and system CPU time spent in seconds.
  • process_max_fds : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Maximum number of open file descriptors.
  • process_open_fds : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Number of open file descriptors.
  • process_resident_memory_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Resident memory size in bytes.
  • process_start_time_seconds : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Start time of the process since unix epoch in seconds.
  • process_virtual_memory_bytes : gauge : github-proxy, gitserver, pgsql, query-runner, redis-cache, redis-store, repo-updater, searcher, sourcegraph-frontend, symbols
    Virtual memory size in bytes.
  • process_virtual_memory_max_bytes : gauge : github-proxy, gitserver, query-runner, repo-updater, searcher, sourcegraph-frontend, symbols
    Maximum amount of virtual memory available in bytes.
  • promhttp_metric_handler_requests_in_flight : gauge : github-proxy, gitserver, query-runner, repo-updater, searcher, sourcegraph-frontend, symbols
    Current number of scrapes being served.
  • promhttp_metric_handler_requests_total : counter : github-proxy, gitserver, query-runner, repo-updater, searcher, sourcegraph-frontend, symbols
    Total number of scrapes by HTTP status code.
  • redis_aof_current_rewrite_duration_sec : gauge : redis-cache, redis-store
  • redis_aof_enabled : gauge : redis-cache, redis-store
  • redis_aof_last_rewrite_duration_sec : gauge : redis-cache, redis-store
  • redis_aof_rewrite_in_progress : gauge : redis-cache, redis-store
  • redis_aof_rewrite_scheduled : gauge : redis-cache, redis-store
  • redis_blocked_clients : gauge : redis-cache, redis-store
  • redis_client_biggest_input_buf : gauge : redis-cache, redis-store
  • redis_client_longest_output_list : gauge : redis-cache, redis-store
  • redis_cluster_enabled : gauge : redis-cache, redis-store
  • redis_command_call_duration_seconds_count : gauge : redis-cache, redis-store
    Total number of calls per command
  • redis_command_call_duration_seconds_sum : gauge : redis-cache, redis-store
    Total amount of time in seconds spent per command
  • redis_commands_processed_total : gauge : redis-cache, redis-store
  • redis_config_maxmemory : gauge : redis-cache, redis-store
  • redis_connected_clients : gauge : redis-cache, redis-store
  • redis_connected_slaves : gauge : redis-cache, redis-store
  • redis_connections_received_total : gauge : redis-cache, redis-store
  • redis_db_avg_ttl_seconds : gauge : redis-cache, redis-store
    Avg TTL in seconds
  • redis_db_keys : gauge : redis-cache, redis-store
    Total number of keys by DB
  • redis_db_keys_expiring : gauge : redis-cache, redis-store
    Total number of expiring keys by DB
  • redis_evicted_keys_total : gauge : redis-cache, redis-store
  • redis_expired_keys_total : gauge : redis-cache, redis-store
  • redis_exporter_build_info : gauge : redis-cache, redis-store
    redis exporter build_info
  • redis_exporter_last_scrape_duration_seconds : gauge : redis-cache, redis-store
    The last scrape duration.
  • redis_exporter_last_scrape_error : gauge : redis-cache, redis-store
    The last scrape error status.
  • redis_exporter_scrapes_total : counter : redis-cache, redis-store
    Current total redis scrapes.
  • redis_instance_info : gauge : redis-cache, redis-store
    Information about the Redis instance
  • redis_instantaneous_input_kbps : gauge : redis-cache, redis-store
  • redis_instantaneous_ops_per_sec : gauge : redis-cache, redis-store
  • redis_instantaneous_output_kbps : gauge : redis-cache, redis-store
  • redis_keyspace_hits_total : gauge : redis-cache, redis-store
  • redis_keyspace_misses_total : gauge : redis-cache, redis-store
  • redis_latest_fork_usec : gauge : redis-cache, redis-store
  • redis_loading_dump_file : gauge : redis-cache, redis-store
  • redis_master_repl_offset : gauge : redis-cache, redis-store
  • redis_memory_fragmentation_ratio : gauge : redis-cache, redis-store
  • redis_memory_max_bytes : gauge : redis-cache, redis-store
  • redis_memory_used_bytes : gauge : redis-cache, redis-store
  • redis_memory_used_lua_bytes : gauge : redis-cache, redis-store
  • redis_memory_used_peak_bytes : gauge : redis-cache, redis-store
  • redis_memory_used_rss_bytes : gauge : redis-cache, redis-store
  • redis_net_input_bytes_total : gauge : redis-cache, redis-store
  • redis_net_output_bytes_total : gauge : redis-cache, redis-store
  • redis_process_id : gauge : redis-cache, redis-store
  • redis_pubsub_channels : gauge : redis-cache, redis-store
  • redis_pubsub_patterns : gauge : redis-cache, redis-store
  • redis_rdb_changes_since_last_save : gauge : redis-cache, redis-store
  • redis_rdb_current_bgsave_duration_sec : gauge : redis-cache, redis-store
  • redis_rdb_last_bgsave_duration_sec : gauge : redis-cache, redis-store
  • redis_rejected_connections_total : gauge : redis-cache, redis-store
  • redis_replication_backlog_bytes : gauge : redis-cache, redis-store
  • redis_up : gauge : redis-cache, redis-store
  • redis_uptime_in_seconds : gauge : redis-cache, redis-store
  • redis_used_cpu_sys : gauge : redis-cache, redis-store
  • redis_used_cpu_sys_children : gauge : redis-cache, redis-store
  • redis_used_cpu_user : gauge : redis-cache, redis-store
  • redis_used_cpu_user_children : gauge : redis-cache, redis-store
  • searcher_service_request_total : counter : searcher
    Number of returned search requests.
  • searcher_service_running : gauge : searcher
    Number of running search requests.
  • searcher_store_cache_size_bytes : gauge : searcher
    The total size of items in the on disk cache.
  • searcher_store_evictions : counter : searcher
    The total number of items evicted from the cache.
  • searcher_store_fetch_failed : counter : searcher
    The total number of archive fetches that failed.
  • searcher_store_fetch_queue_size : gauge : searcher
    The number of fetch jobs enqueued.
  • searcher_store_fetching : gauge : searcher
    The number of fetches currently running.
  • src_backend_client_request_duration_seconds : histogram : sourcegraph-frontend
    Total time spent on backend endpoints.
  • src_backend_client_requests : gauge : sourcegraph-frontend
    Current number of requests running for a method.
  • src_github_rate_limit_remaining : gauge : github-proxy
    Number of calls to GitHub's API remaining before hitting the rate limit.
  • src_github_requests_total : counter : repo-updater, sourcegraph-frontend
    Total number of requests sent to the GitHub API.
  • src_gitlab_requests_total : counter : repo-updater
    Total number of requests sent to the GitLab API.
  • src_gitserver_client_deadline_exceeded : counter : gitserver, repo-updater, searcher, sourcegraph-frontend, symbols
    Times that Client.sendExec() returned context.DeadlineExceeded
  • src_gitserver_clone_queue : gauge : gitserver
    number of repos waiting to be cloned.
  • src_gitserver_disk_space_available : gauge : gitserver
    Amount of free space disk space on the repos mount.
  • src_gitserver_echo_duration_seconds : gauge : gitserver
    Duration of executing the echo command.
  • src_gitserver_exec_duration_seconds : histogram : gitserver
    gitserver.Command latencies in seconds.
  • src_gitserver_exec_running : gauge : gitserver
    number of gitserver.Command running concurrently.
  • src_gitserver_lsremote_queue : gauge : gitserver
    number of repos waiting to check existence on remote code host (git ls-remote).
  • src_gitserver_repo_cloned : counter : gitserver
    number of successful git clones run
  • src_gitserver_repos_recloned : counter : gitserver
    number of repos removed and recloned due to age
  • src_gitserver_repos_removed : counter : gitserver
    number of repos removed during cleanup
  • src_graphql_field_seconds : histogram : sourcegraph-frontend
    GraphQL field resolver latencies in seconds.
  • src_graphql_links_for_repository_failed_total : counter : sourcegraph-frontend
    The total number of times the GraphQL field LinksForRepository failed.
  • src_http_request_duration_seconds : histogram : sourcegraph-frontend
    The HTTP request latencies in seconds.
  • src_http_requests_last_timestamp_unixtime : gauge : sourcegraph-frontend
    Last time a request finished for a http endpoint.
  • src_legacy_def_landing_webapp : counter : sourcegraph-frontend
    Number of times a legacy def landing page has been served.
  • src_legacy_repo_landing_webapp : counter : sourcegraph-frontend
    Number of times a legacy repo landing page has been served.
  • src_pgsql_app_open_connections : gauge : sourcegraph-frontend
    Number of open connections to pgsql DB, as reported by pgsql.DB.Stats()
  • src_projs_gitlab_cache_hit : counter : repo-updater
    Counts cache hits and misses for GitLab project metadata.
  • src_registry_requests_error : counter : sourcegraph-frontend
    Number of failed (non-HTTP 200) requests to the HTTP registry API
  • src_registry_requests_success : counter : sourcegraph-frontend
    Number of successful requests (HTTP 200) to the HTTP registry API
  • src_repos_github_cache_hit : counter : repo-updater
    Counts cache hits and misses for GitHub repo metadata.
  • src_repoupdater_purge_failed : counter : repo-updater
    Incremented each time we try and fail to remove a repository clone.
  • src_repoupdater_purge_skipped : counter : repo-updater
    Incremented each time we skip a repository clone to remove.
  • src_repoupdater_purge_success : counter : repo-updater
    Incremented each time we remove a repository clone.
  • src_repoupdater_sched_auto_fetch : counter : repo-updater
    Incremented each time the scheduler updates a managed repository due to hitting a deadline.
  • src_repoupdater_sched_error : counter : repo-updater
    Incremented each time we encounter an error updating a repository.
  • src_repoupdater_sched_known_repos : gauge : repo-updater
    The number of repositories that are managed by the scheduler.
  • src_repoupdater_sched_loops : counter : repo-updater
    Incremented each time the scheduler loops.
  • src_repoupdater_sched_manual_fetch : counter : repo-updater
    Incremented each time the scheduler updates a repository due to user traffic.
  • src_repoupdater_time_last_github_sync : gauge : repo-updater
    The last time a comprehensive GitHub sync finished
  • src_repoupdater_time_last_gitlab_sync : gauge : repo-updater
    The last time a comprehensive GitLab sync finished
  • src_repoupdater_time_last_gitolite_sync : gauge : repo-updater
    The last time a comprehensive Gitolite sync finished
  • src_updatecheck_requests : counter : sourcegraph-frontend
    Number of requests to the update check handler.
  • src_updatecheck_requests_has_update : counter : sourcegraph-frontend
    Number of requests to the update check handler where an update is available.
  • symbols_parse_parse_failed : counter : symbols
    The total number of parse jobs that failed.
  • symbols_parse_parse_queue_size : gauge : symbols
    The number of parse jobs enqueued.
  • symbols_parse_parsing : gauge : symbols
    The number of parse jobs currently running.
  • symbols_store_cache_size_bytes : gauge : symbols
    The total size of items in the on disk cache.
  • symbols_store_evictions : counter : symbols
    The total number of items evicted from the cache.
  • symbols_store_fetch_failed : counter : symbols
    The total number of archive fetches that failed.
  • symbols_store_fetch_queue_size : gauge : symbols
    The number of fetch jobs enqueued.
  • symbols_store_fetching : gauge : symbols
    The number of fetches currently running.
  • vfsutil_vfs_cached_file_evict : counter : sourcegraph-frontend
    Total number of evictions to cachedFetch archives.
  • vfsutil_vfs_github_fetch_failed_total : counter : sourcegraph-frontend
    Total number of fetches by GitHubRepoVFS that failed.
  • vfsutil_vfs_github_fetch_total : counter : sourcegraph-frontend
    Total number of fetches by GitHubRepoVFS.
  • vfsutil_vfs_gitserver_fetch_failed_total : counter : sourcegraph-frontend
    Total number of fetches to GitServer that failed.
  • vfsutil_vfs_gitserver_fetch_total : counter : sourcegraph-frontend
    Total number of fetches to GitServer.