gcp.cloudsql.database.active_directory.domain_reachable (gauge) | Indicates whether the instance is able to ping a domain controller from the connected Managed Active Directory domain. If false, Windows Authentication may not work as expected. |
gcp.cloudsql.database.active_directory.instance_available (gauge) | Indicates whether the instance is currently available using Windows Authentication. |
gcp.cloudsql.database.auto_failover_request_count (count) | Delta of number of instance auto-failover requests. Shown as request |
gcp.cloudsql.database.available_for_failover (gauge) | This is greater than 0 if the failover operation is available on the instance. |
gcp.cloudsql.database.cpu.reserved_cores (gauge) | Number of cores reserved for the database. Shown as core |
gcp.cloudsql.database.cpu.usage_time (gauge) | Cumulative CPU usage time. Shown as second |
gcp.cloudsql.database.cpu.utilization (gauge) | Fraction of the reserved CPU that is currently in use. Shown as fraction |
gcp.cloudsql.database.data_cache.bytes_used (gauge) | Data cache usage in bytes. Shown as byte |
gcp.cloudsql.database.data_cache.quota (gauge) | Maximum data cache size in bytes. Shown as byte |
gcp.cloudsql.database.disk.bytes_used (gauge) | Disk space used. Shown as byte |
gcp.cloudsql.database.disk.bytes_used_by_data_type (gauge) | Data utilization in bytes. Shown as byte |
gcp.cloudsql.database.disk.quota (gauge) | Maximum data disk size in bytes. Shown as byte |
gcp.cloudsql.database.disk.read_ops_count (count) | Disk read I/O operations. Shown as operation |
gcp.cloudsql.database.disk.utilization (gauge) | The fraction of the disk quota that is currently in use. Shown as fraction |
gcp.cloudsql.database.disk.write_ops_count (count) | Disk write I/O operations. Shown as operation |
gcp.cloudsql.database.instance_state (gauge) | Serving state of the Cloud SQL instance. |
gcp.cloudsql.database.memory.components (gauge) | Memory stats components in percentage as usage, cache and free memory for the database. |
gcp.cloudsql.database.memory.quota (gauge) | Maximum RAM in bytes. Shown as byte |
gcp.cloudsql.database.memory.total_usage (gauge) | Total RAM usage in bytes including buffer cache. Shown as byte |
gcp.cloudsql.database.memory.usage (gauge) | RAM usage in bytes. Shown as byte |
gcp.cloudsql.database.memory.utilization (gauge) | Fraction of memory quota currently in use. Shown as fraction |
gcp.cloudsql.database.mysql.aborted_clients_count (count) | Connections that were aborted because the client died without closing the connection properly, since the last sample. |
gcp.cloudsql.database.mysql.aborted_connects_count (count) | Failed attempts to connect to the MySQL server, since the last sample. |
gcp.cloudsql.database.mysql.connections_count (count) | Connection attempts (successful or not) to the MySQL server, since the last sample. |
gcp.cloudsql.database.mysql.ddl_operations_count (count) | MySQL DDL operations, since the last sample. |
gcp.cloudsql.database.mysql.dml_operations_count (count) | MySQL DML operations, since the last sample. |
gcp.cloudsql.database.mysql.handler_operations_count (count) | MySQL handler operations, since the last sample. |
gcp.cloudsql.database.mysql.innodb.active_transactions (gauge) | Number of active Transaction details (transactions which are in progress), Values in bracket are meant for innodb_transaction_state (Total/running/lock_wait/rolling_back/committing ). |
gcp.cloudsql.database.mysql.innodb.active_trx_longest_time (gauge) | Largest transaction time from currently active InnoDB transactions. |
gcp.cloudsql.database.mysql.innodb.active_trx_rows_locked (gauge) | Number of rows locked by currently active InnoDB transactions. |
gcp.cloudsql.database.mysql.innodb.active_trx_rows_modified (gauge) | Number of rows modified by currently active InnoDB transactions. |
gcp.cloudsql.database.mysql.innodb.active_trx_total_time (gauge) | Duration of currently active InnoDB transactions. Shown as second |
gcp.cloudsql.database.mysql.innodb.adaptive_hash_operation_count (count) | Total internal row operations (rows added, updated, removed) performed to maintain the AHI since last sample. |
gcp.cloudsql.database.mysql.innodb.ahi_search_count (count) | Total search operations on the InnoDB AHI and its efficiency since the last sample. |
gcp.cloudsql.database.mysql.innodb.buffer_flush_sync_waits_count (count) | Number of times InnoDB has performed synchronous buffer flush operations and blocking the user transactions since last sample. |
gcp.cloudsql.database.mysql.innodb.buffer_pool_pages (gauge) | Number of InnoDB buffer pool pages, innodbpagetype field stores count of InnoDB pages in each state. |
gcp.cloudsql.database.mysql.innodb.buffer_pool_read_requests_count (count) | Logical read requests from InnoDB buffer pool, since the last sample. |
gcp.cloudsql.database.mysql.innodb.buffer_pool_reads_count (count) | Logical reads that InnoDB could not satisfy from the buffer pool, and had to read directly from disk, since the last sample. |
gcp.cloudsql.database.mysql.innodb.buffer_pool_write_requests_count (count) | Writes done to the InnoDB buffer pool, since the last sample. |
gcp.cloudsql.database.mysql.innodb.data_cache.cache_hit_count (count) | Total number of data cache hit read operations for this instance. |
gcp.cloudsql.database.mysql.innodb.data_cache.cache_miss_count (count) | Total number of data cache miss read operations for this instance. |
gcp.cloudsql.database.mysql.innodb.data_cache.pages (gauge) | The number of InnoDB pages in Mysqls E+ Data cache feature. |
gcp.cloudsql.database.mysql.innodb.data_fsyncs_count (count) | InnoDB fsync() calls, since the last sample. |
gcp.cloudsql.database.mysql.innodb.data_pending_fsyncs (gauge) | Number of pending fsync() operations in the MySQL server. |
gcp.cloudsql.database.mysql.innodb.data_pending_reads (gauge) | Number of pending reads in the MySQL Server. |
gcp.cloudsql.database.mysql.innodb.data_pending_writes (gauge) | Number of pending writes in the MySQL Server. |
gcp.cloudsql.database.mysql.innodb.deadlocks_count (count) | Deadlocks, since the last sample. |
gcp.cloudsql.database.mysql.innodb.dictionary_memory (gauge) | Memory allocated for InnoDB dictionary cache. Shown as byte |
gcp.cloudsql.database.mysql.innodb.history_list_length (gauge) | Indicates the size of undo logs which are used to store modifications made to older versions of rows. |
gcp.cloudsql.database.mysql.innodb.ibuf_merge_operation_count (count) | Total number of records type merged by the change buffering operation since the last sample. |
gcp.cloudsql.database.mysql.innodb.ibuf_merges_count (count) | Total number of change buffer merges since the last sample. This shows the efficiency of all change buffer operations. |
gcp.cloudsql.database.mysql.innodb.innodb_log_waits_count (count) | Total number of transactions wait for space to become available in the InnoDB log buffer, to help tune innodblogbuffer_size configuration. |
gcp.cloudsql.database.mysql.innodb.lock_timeout_count (count) | Row lock wait timeouts, since the last sample. |
gcp.cloudsql.database.mysql.innodb.lsn (gauge) | Value of InnoDB current/flushed/last_checkpoint log sequence number. Shown as byte |
gcp.cloudsql.database.mysql.innodb.operation_disk_io_count (count) | Disk I/O operations performed by InnoDB since the last sample. |
gcp.cloudsql.database.mysql.innodb.os_log_fsyncs_count (count) | InnoDB fsync() calls to the log file, since the last sample. |
gcp.cloudsql.database.mysql.innodb.os_log_pending_fsyncs (gauge) | Number of pending fsync() operations for the InnoDB redo log files in the MySQL server. |
gcp.cloudsql.database.mysql.innodb.os_log_pending_writes (gauge) | Number of pending writes to the InnoDB redo log files in the MySQL server. |
gcp.cloudsql.database.mysql.innodb.pages_read_count (count) | InnoDB pages read, since the last sample. |
gcp.cloudsql.database.mysql.innodb.pages_written_count (count) | InnoDB pages written, since the last sample. |
gcp.cloudsql.database.mysql.innodb.row_lock_time (gauge) | The total time spent in acquiring row locks for InnoDB tables. Shown as millisecond |
gcp.cloudsql.database.mysql.innodb.row_lock_waits_count (count) | Times operations on InnoDB tables had to wait for a row lock, since the last sample. |
gcp.cloudsql.database.mysql.innodb.row_operations_count (count) | InnoDB row operations. |
gcp.cloudsql.database.mysql.innodb_buffer_pool_pages_dirty (gauge) | Number of unflushed pages in the InnoDB buffer pool. Shown as page |
gcp.cloudsql.database.mysql.innodb_buffer_pool_pages_free (gauge) | Number of unused pages in the InnoDB buffer pool. Shown as page |
gcp.cloudsql.database.mysql.innodb_buffer_pool_pages_total (gauge) | Total number of pages in the InnoDB buffer pool. Shown as page |
gcp.cloudsql.database.mysql.innodb_data_fsyncs (count) | InnoDB fsync calls. Shown as operation |
gcp.cloudsql.database.mysql.innodb_os_log_fsyncs (count) | InnoDB fsync calls to the log file. Shown as operation |
gcp.cloudsql.database.mysql.innodb_pages_read (count) | InnoDB pages read. Shown as page |
gcp.cloudsql.database.mysql.innodb_pages_written (count) | InnoDB pages written. Shown as page |
gcp.cloudsql.database.mysql.max_connections (gauge) | Value of the MySQL max_connections configuration. |
gcp.cloudsql.database.mysql.memory.by_code_area (gauge) | Memory allocated to each code area, reported by mysql performance_schema. Shown as byte |
gcp.cloudsql.database.mysql.memory.by_event (gauge) | Memory allocated by each event, reported by performance_schema. Shown as byte |
gcp.cloudsql.database.mysql.memory.global (gauge) | The total allocated memory, reported by performance_schema. Shown as byte |
gcp.cloudsql.database.mysql.open_table_definitions (gauge) | The number of table definitions that are currently cached. |
gcp.cloudsql.database.mysql.open_tables (gauge) | The number of tables that are currently open. |
gcp.cloudsql.database.mysql.opened_table_count (count) | The number of tables that have been opened since the last sample. |
gcp.cloudsql.database.mysql.opened_table_definitions_count (count) | The number of table definitions that have been cached since the last sample. |
gcp.cloudsql.database.mysql.queries (count) | Number of query statements executed by the server. Shown as query |
gcp.cloudsql.database.mysql.questions (count) | Number of question statements executed by the server. Includes only statements sent to the server by clients and not statements executed within stored programs. Shown as question |
gcp.cloudsql.database.mysql.received_bytes_count (count) | Delta count of bytes received by MySQL process. Shown as byte |
gcp.cloudsql.database.mysql.replication.last_io_errno (gauge) | Error number of most recent error that caused I/O thread to stop. Shown as second |
gcp.cloudsql.database.mysql.replication.last_sql_errno (gauge) | Error number of most recent error that caused SQL thread to stop. Shown as second |
gcp.cloudsql.database.mysql.replication.seconds_behind_master (gauge) | Approximate number of seconds the read replica is behind its' master. Shown as second |
gcp.cloudsql.database.mysql.replication.slave_io_running (gauge) | Indicates whether the I/O thread for reading the master's binary log is running. Possible values are Yes, No, and Connecting. |
gcp.cloudsql.database.mysql.replication.slave_io_running_state (gauge) | Indicates whether the I/O thread for reading the master's binary log is running. Possible values are Yes, No, and Connecting, values exposed through 'state' field. |
gcp.cloudsql.database.mysql.replication.slave_sql_running (gauge) | Indicates whether the SQL thread for executing events in the relay log is running. |
gcp.cloudsql.database.mysql.replication.slave_sql_running_state (gauge) | Indicates whether the SQL thread for executing events in the relay log is running, values exposed through 'state' field. |
gcp.cloudsql.database.mysql.sent_bytes_count (count) | Delta count of bytes sent by MySQL process. Shown as byte |
gcp.cloudsql.database.mysql.slow_queries_count (count) | The total number of queries that took longer than longquerytime seconds. |
gcp.cloudsql.database.mysql.thread_cache_size (gauge) | Value of the MySQL thread_cache_size configuration. |
gcp.cloudsql.database.mysql.thread_state (gauge) | The state of running threads by querying information_schema.processlist table, this information helps to understand locking or contention issues. |
gcp.cloudsql.database.mysql.threads (gauge) | Number of Threads. threads_cached indicates threads in the thread cache, threads_connected indicates currently open connections, threads_running indicates threads that are not sleeping. |
gcp.cloudsql.database.mysql.threads_created_count (count) | Threads created to handle connections, since the last sample. |
gcp.cloudsql.database.mysql.tmp_disk_tables_created_count (count) | Internal on-disk temporary tables created by the MySQL server while executing statements, since the last sample. |
gcp.cloudsql.database.mysql.tmp_files_created_count (count) | Temporary files created by the MySQL server, since the last sample. |
gcp.cloudsql.database.mysql.tmp_tables_created_count (count) | MySQL temporary tables created, since the last sample. |
gcp.cloudsql.database.network.connections (gauge) | Number of connections to the Cloud SQL instance. Shown as connection |
gcp.cloudsql.database.network.received_bytes_count (count) | Delta count of bytes received through the network. Shown as byte |
gcp.cloudsql.database.network.sent_bytes_count (count) | Number of bytes sent through the network. Shown as byte |
gcp.cloudsql.database.postgresql.backends_in_wait ( gauge) | Number of backends in wait in Postgres instance. Shown as connection |
gcp.cloudsql.database.postgresql.blocks_read_count (count) | Number of disk blocks read by this database. The source field distingushes actual reads from disk versus reads from buffer cache. |
gcp.cloudsql.database.postgresql.data_cache.hit_count (count) | Total number of data cache hit read operations for this instance. |
gcp.cloudsql.database.postgresql.data_cache.hit_ratio (gauge) | Ratio of data cache hit read operations for this instance. |
gcp.cloudsql.database.postgresql.data_cache.miss_count (count) | Total number of data cache miss read operations for this instance. |
gcp.cloudsql.database.postgresql.deadlock_count (count) | Number of deadlocks detected for this database. |
gcp.cloudsql.database.postgresql.external_sync.initial_sync_complete (gauge) | Whether all databases on the Postgres External Server (ES) replica have completed the initial sync and are replicating changes from the source. |
gcp.cloudsql.database.postgresql.external_sync.max_replica_byte_lag (gauge) | Replication lag in bytes for Postgres External Server (ES) replicas. Aggregated across all DBs on the replica. Shown as byte |
gcp.cloudsql.database.postgresql.insights.aggregate.execution_time (gauge) | Cumulative query execution time per user per database. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.aggregate.io_time (gauge) | Cumulative I/O time per user per database. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.aggregate.latencies.avg (gauge) | The average of the cumulative Query latency distribution per user per database. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.aggregate.latencies.p95 (gauge) | The 95th percentile of the cumulative Query latency distribution per user per database. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.aggregate.latencies.p99 (gauge) | The 99th percentile of the cumulative Query latency distribution per user per database. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.aggregate.latencies.samplecount (gauge) | The sample counts for the cumulative Query latency distribution per user per database. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.aggregate.latencies.sumsqdev (gauge) | The sum of Squared Deviation for the cumulative Query latency distribution per user per database. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.aggregate.lock_time (gauge) | Cumulative lock wait time per user per database. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.aggregate.row_count (count) | Cumulative number of retrieved or affected rows per database. |
gcp.cloudsql.database.postgresql.insights.aggregate.shared_blk_access_count (count) | Cumulative shared blocks accessed by statement execution. |
gcp.cloudsql.database.postgresql.insights.perquery.execution_time (gauge) | Cumulative execution times per user per database per query. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.perquery.io_time (gauge) | Cumulative I/O time per user per query. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.perquery.latencies (gauge) | Query latency distribution per user per query. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.perquery.lock_time (gauge) | Cumulative lock wait time per user per query. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.perquery.row_count (count) | Cumulative number of retrived or affected rows per query. |
gcp.cloudsql.database.postgresql.insights.perquery.shared_blk_access_count (count) | Cumulative shared blocks accessed by statement execution per query. |
gcp.cloudsql.database.postgresql.insights.pertag.execution_time (gauge) | Cumulative execution time per user per database per tag. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.pertag.io_time (gauge) | Cumulative I/O write time per user per database per tag. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.pertag.latencies (gauge) | Query latency distribution per user per database per tag. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.pertag.lock_time (gauge) | Cumulative lock wait time per user per database per tag. Shown as microsecond |
gcp.cloudsql.database.postgresql.insights.pertag.row_count (count) | Cumulative number of retrieved or affected rows. |
gcp.cloudsql.database.postgresql.insights.pertag.shared_blk_access_count (count) | Cumulative shared blocks accessed by statement execution. |
gcp.cloudsql.database.postgresql.new_connection_count (count) | Count of new connections added to the Postgres instance. |
gcp.cloudsql.database.postgresql.num_backends (gauge) | Number of connections to the Cloud SQL PostgreSQL instance. Shown as connection |
gcp.cloudsql.database.postgresql.num_backends_by_application (gauge) | Number of connections to the Cloud SQL PostgreSQL instance, grouped by applications. Shown as connection |
gcp.cloudsql.database.postgresql.num_backends_by_state (gauge) | Number of connections to the Cloud SQL PostgreSQL instance, grouped by its state. Shown as connection |
gcp.cloudsql.database.postgresql.replication.replica_byte_lag (gauge) | Replication lag in bytes. Shown as byte |
gcp.cloudsql.database.postgresql.statements_executed_count (count) | Total count of statements executed in PostgreSQL instance. |
gcp.cloudsql.database.postgresql.temp_bytes_written_count (count) | Total amount of data (in bytes) written to temporary files by the queries per database. |
gcp.cloudsql.database.postgresql.temp_files_written_count (count) | Total number of temporary files used for writing data while performing algorithms such as join and sort. |
gcp.cloudsql.database.postgresql.transaction_count (count) | Delta count of number of transactions. Shown as transaction |
gcp.cloudsql.database.postgresql.transaction_id_count (count) | Delta count of transaction ID. The tag 'action' describes the type of action, which is either assigned (count of transaction IDs assigned and consumed by the instance) or frozen (count of transaction IDs replenished by the VACUUM's freeze operation). |
gcp.cloudsql.database.postgresql.transaction_id_utilization (gauge) | Current utilization represented as a percentage of transaction IDs consumed by the Cloud SQL PostgreSQL instance. Values are typically numbers between 0.0 and 1.0. Charts display the values as a percentage between 0% and 100%. Shown as percent (multiplied by 100) |
gcp.cloudsql.database.postgresql.tuple_size (gauge) | Number of tuples (rows) in the database. |
gcp.cloudsql.database.postgresql.tuples_fetched_count (count) | Total number of rows fetched as a result of queries per database in the PostgreSQL instance. |
gcp.cloudsql.database.postgresql.tuples_processed_count (count) | Number of tuples(rows) processed for a given database for operations like insert, update or delete. |
gcp.cloudsql.database.postgresql.tuples_returned_count (count) | Total number of rows scanned while processing the queries per database in the PostgreSQL instance. |
gcp.cloudsql.database.postgresql.vacuum.oldest_transaction_age (gauge) | Age of the oldest transaction yet to be vacuumed in the Cloud SQL PostgreSQL instance, measured in number of transactions that have happened since the oldest transaction. |
gcp.cloudsql.database.replication.log_archive_failure_count (count) | Number of failed attempts for archiving replication log files. |
gcp.cloudsql.database.replication.log_archive_success_count (count) | Number of successful attempts for archiving replication log files. |
gcp.cloudsql.database.replication.network_lag (gauge) | Indicates time taken from primary binary log to I/O thread on replica. Shown as second |
gcp.cloudsql.database.replication.replica_lag (gauge) | Number of seconds read replica is behind primary. Shown as second |
gcp.cloudsql.database.replication.state (gauge) | Current serving state of replication. |
gcp.cloudsql.database.sqlserver.audits_size (gauge) | Tracks the size in bytes of stored SQLServer audit files on an instance. Shown as byte |
gcp.cloudsql.database.sqlserver.audits_upload_count (count) | Counts total number of SQLServer audit file uploads to a GCS bucket and whether or not an upload was successful. |
gcp.cloudsql.database.sqlserver.connections.connection_reset_count (count) | Total number of logins started from the connection pool since the last restart of SQL Server service. |
gcp.cloudsql.database.sqlserver.connections.login_attempt_count (count) | Total number of login attempts since the last restart of SQL Server service. This does not include pooled connections. |
gcp.cloudsql.database.sqlserver.connections.logout_count (count) | Total number of logout operations since the last restart of SQL Server service. |
gcp.cloudsql.database.sqlserver.connections.processes_blocked (gauge) | Current number of blocked processes. |
gcp.cloudsql.database.sqlserver.data_cache.hit_count (count) | Total number of data cache hit read operations for this instance. |
gcp.cloudsql.database.sqlserver.data_cache.hit_ratio (gauge) | Ratio of successful data cache hit read operations for this instance. |
gcp.cloudsql.database.sqlserver.data_cache.miss_count (count) | Total number of data cache miss read operations for this instance. |
gcp.cloudsql.database.sqlserver.databases (gauge) | Current number of databases on the instance excluding system databases. |
gcp.cloudsql.database.sqlserver.external_sync.primary_to_replica_connection_health (gauge) | Indicates whether there is connectivity from Primary to the Replica to push replication updates. |
gcp.cloudsql.database.sqlserver.memory.buffer_cache_hit_ratio (gauge) | Current percentage of pages found in the buffer cache without having to read from disk. The ratio is the total number of cache hits divided by the total number of cache lookups. Shown as percent |
gcp.cloudsql.database.sqlserver.memory.checkpoint_page_count (count) | Total number of pages flushed to disk by a checkpoint or other operation that requires all dirty pages to be flushed. |
gcp.cloudsql.database.sqlserver.memory.free_list_stall_count (count) | Total number of requests that had to wait for a free page. |
gcp.cloudsql.database.sqlserver.memory.lazy_write_count (count) | Total number of buffers written by the buffer manager's lazy writer. The lazy writer is a system process that flushes out batches of dirty, aged buffers (buffers that contain changes that must be written back to disk before the buffer can be reused for a different page) and makes them available to user processes. |
gcp.cloudsql.database.sqlserver.memory.memory_grants_pending (gauge) | Current number of processes waiting for a workspace memory grant. |
gcp.cloudsql.database.sqlserver.memory.page_life_expectancy (gauge) | Current number of seconds a page will stay in the buffer pool without references. Shown as second |
gcp.cloudsql.database.sqlserver.memory.page_operation_count (count) | Total number of physical database page reads or writes. This statistic counts physical page reads or writes across all databases. |
gcp.cloudsql.database.sqlserver.replication.bytes_sent_to_replica_count (count) | Total number of bytes sent to the remote availability replica. Before compression for async replica. Actual number of bytes for sync replica which has no compression. Shown as byte |
gcp.cloudsql.database.sqlserver.replication.log_apply_pending_queue (gauge) | Current number of log blocks that are waiting to be applied to all database replicas. |
gcp.cloudsql.database.sqlserver.replication.log_bytes_received_count (count) | Total amount of log records received by the secondary replica for all databases. Shown as byte |
gcp.cloudsql.database.sqlserver.replication.recovery_queue (gauge) | Current amount of log records in kilobytes in the log files of the secondary replica that have not been redone. Shown as kilobyte |
gcp.cloudsql.database.sqlserver.replication.redone_bytes_count (count) | Total amount of log records redone on all secondary databases. Shown as byte |
gcp.cloudsql.database.sqlserver.replication.resent_message_count (count) | Total number of Always On messages resent. A resent message is a message that was attempted to be sent but was unable to complete and must be attempted to be sent again. |
gcp.cloudsql.database.sqlserver.schedulers.active_workers (gauge) | Current number of workers that are active. An active worker is never preemptive, must have an associated task, and is either running, runnable, or suspended. |
gcp.cloudsql.database.sqlserver.schedulers.by_status (gauge) | Current number of schedulers reporting a particular status. |
gcp.cloudsql.database.sqlserver.schedulers.current_tasks (gauge) | Current number of current tasks that are associated with a scheduler. This count includes tasks that are waiting for a worker to execute them and tasks that are currently waiting or running (in SUSPENDED or RUNNABLE state). |
gcp.cloudsql.database.sqlserver.schedulers.current_workers (gauge) | Current number of workers that are associated with a scheduler. It includes workers that are not assigned any task. |
gcp.cloudsql.database.sqlserver.schedulers.pending_disk_io (gauge) | Current number of pending I/Os that are waiting to be completed. Each scheduler has a list of pending I/Os that are checked to determine whether they have been completed every time there is a context switch. The count is incremented when the request is inserted. This count is decremented when the request is completed. This number does not indicate the state of the I/Os. |
gcp.cloudsql.database.sqlserver.schedulers.runnable_tasks (gauge) | Current number of workers, with tasks assigned to them, that are waiting to be scheduled on the runnable queue. |
gcp.cloudsql.database.sqlserver.schedulers.work_queue (gauge) | Current number of tasks in the pending queue. These tasks are waiting for a worker to pick them up. |
gcp.cloudsql.database.sqlserver.server_principals (gauge) | Current number of server principals on the instance. |
gcp.cloudsql.database.sqlserver.sql_agent.jobs (gauge) | Current number of SQL Server agent jobs on the instance. |
gcp.cloudsql.database.sqlserver.transactions.batch_request_count (count) | Total number of Transact-SQL command batches received. |
gcp.cloudsql.database.sqlserver.transactions.deadlock_count (count) | Total number of lock requests that resulted in a deadlock. |
gcp.cloudsql.database.sqlserver.transactions.forwarded_record_count (count) | Total number of records fetched through forwarded record pointers. |
gcp.cloudsql.database.sqlserver.transactions.full_scan_count (count) | Total number of unrestricted full scans. These can be either base-table or full-index scans. |
gcp.cloudsql.database.sqlserver.transactions.lock_wait_count (count) | Total number of lock requests that required the caller to wait. |
gcp.cloudsql.database.sqlserver.transactions.lock_wait_time (count) | Total time lock requests were waiting for locks. Shown as millisecond |
gcp.cloudsql.database.sqlserver.transactions.log_bytes_flushed_count (count) | Total number of log bytes flushed. Shown as byte |
gcp.cloudsql.database.sqlserver.transactions.page_split_count (count) | Total number of page splits that occur as the result of overflowing index pages. |
gcp.cloudsql.database.sqlserver.transactions.probe_scan_count (count) | Total number of probe scans that are used to find at most one single qualified row in an index or base table directly. |
gcp.cloudsql.database.sqlserver.transactions.sql_compilation_count (count) | Total number of SQL compilations. |
gcp.cloudsql.database.sqlserver.transactions.sql_recompilation_count (count) | Total number of SQL recompilations. |
gcp.cloudsql.database.sqlserver.transactions.transaction_count (count) | Total number of transactions started. |
gcp.cloudsql.database.sqlserver.xevents_size (gauge) | Tracks the size in bytes of stored SQLServer XEvents files on an instance. Shown as byte |
gcp.cloudsql.database.sqlserver.xevents_upload_count (count) | Counts total number of SQLServer XEvents file uploads to a GCS bucket and whether or not an upload was successful. |
gcp.cloudsql.database.swap.bytes_used (gauge) | Swap space used by the database container. Shown as byte |
gcp.cloudsql.database.swap.pages_swapped_in_count (count) | Total count of pages swapped in of disk since the system was booted. Shown as byte |
gcp.cloudsql.database.swap.pages_swapped_out_count (count) | Total count of pages swapped out of disk since the system was booted. Shown as byte |
gcp.cloudsql.database.up (gauge) | Indicates if the server is up or not. |
gcp.cloudsql.database.uptime (gauge) | Number of seconds the instance has been running. Shown as second |
gcp.cloudsql.per_database.postgresql.external_sync.initial_sync_complete (gauge) | Migration phase of each database on the external server (ES) replica. This only applies to instances that are replicating from an external server. |
gcp.cloudsql.per_database.postgresql.external_sync.replication_byte_lag (gauge) | Replication lag in bytes of each database on the external server (ES) replica. This only applies to instances that are replicating from an external server. |