1. trace_log(跟踪信息)
记录由抽样查询分析器收集的堆栈调用信息。
ClickHouse只有在trace_log服务器配置配置部分设置时才会创建这个表。还应该设置 query_profiler_real_time__ns 和 query_profiler_cpu_time__ns 配置。
要分析日志,请使用addressToLine、addressToSymbol和demangle自检功能。
| name | type | comment |
|---|---|---|
| event_date | Date | 采样时刻信息 |
| event_time | DateTime | 采样时间戳 |
| event_time_microseconds | DateTime64(6) | 采样毫秒时间 |
| timestamp_ns | UInt64 | 采样纳秒时间 |
| revision | UInt32 | clickhouse 版本 |
| trace_type | Enum8( ‘Real’ = 0, ‘CPU’ = 1, ‘Memory’ = 2, ‘MemorySample’ = 3) |
跟踪类型 |
| thread_id | UInt64 | 线程 ID |
| query_id | String | 查询 ID |
| trace | Array(UInt64) | 抽样时间的对战调用跟踪 |
| size | Int64 |
2. stack_trace(堆栈跟踪)
包含所有服务器线程的堆栈跟踪
| name | type | comment |
|---|---|---|
| thread_id | UInt64 | 线程 ID |
| query_id | String | 查询 ID |
| trace | Array(UInt64) | 堆栈跟踪,表示存储调用方法的物理地址列表 |
3. asynchronous_metric_log(异步指标日志)
记录 asynchronous_metric的日志变化记录
| name | type | comment |
|---|---|---|
| event_date | Date | 事件日期 |
| event_time | DateTime | 事件时间 |
| event_time_microseconds | DateTime64(6) | 事件毫秒 |
| name | String | 事件名称 |
| value | Float64 | 事件值 |
4. errors(错误信息)
包含错误代码以及它们被触发的次数。
| name | type | comment |
|---|---|---|
| name | String | 错误的名称 (errorCodeToName)。 |
| code | Int32 | 错误的代码编号 |
| value | UInt64 | 此错误发生的次数。 |
| last_error_time | DateTime | 上次发生错误的时间。 |
| last_error_message | String | 最后一个错误的消息。 |
| last_error_trace | Array(UInt64) | 堆栈跟踪,表示存储调用方法的物理地址列表。 |
| remote | UInt8 | 远程异常(即在分布式查询之一期间收到)。 |
5. metric_log(监控指标日志)
包含来自表 system.metrics 和 system.events 的指标值的历史记录,定期刷新到磁盘
| name | type | comment |
|---|---|---|
| event_date | Date | |
| event_time | DateTime | |
| event_time_microseconds | DateTime64(6) | |
| milliseconds | UInt64 | |
| ProfileEvent_Query | UInt64 | |
| ProfileEvent_SelectQuery | UInt64 | |
| ProfileEvent_InsertQuery | UInt64 | |
| ProfileEvent_FailedQuery | UInt64 | |
| ProfileEvent_FailedSelectQuery | UInt64 | |
| ProfileEvent_FailedInsertQuery | UInt64 | |
| ProfileEvent_QueryTimeMicroseconds | UInt64 | |
| ProfileEvent_SelectQueryTimeMicroseconds | UInt64 | |
| ProfileEvent_InsertQueryTimeMicroseconds | UInt64 | |
| ProfileEvent_FileOpen | UInt64 | |
| ProfileEvent_Seek | UInt64 | |
| ProfileEvent_ReadBufferFromFileDescriptorRead | UInt64 | |
| ProfileEvent_ReadBufferFromFileDescriptorReadFailed | UInt64 | |
| ProfileEvent_ReadBufferFromFileDescriptorReadBytes | UInt64 | |
| ProfileEvent_WriteBufferFromFileDescriptorWrite | UInt64 | |
| ProfileEvent_WriteBufferFromFileDescriptorWriteFailed | UInt64 | |
| ProfileEvent_WriteBufferFromFileDescriptorWriteBytes | UInt64 | |
| ProfileEvent_ReadBufferAIORead | UInt64 | |
| ProfileEvent_ReadBufferAIOReadBytes | UInt64 | |
| ProfileEvent_WriteBufferAIOWrite | UInt64 | |
| ProfileEvent_WriteBufferAIOWriteBytes | UInt64 | |
| ProfileEvent_ReadCompressedBytes | UInt64 | |
| ProfileEvent_CompressedReadBufferBlocks | UInt64 | |
| ProfileEvent_CompressedReadBufferBytes | UInt64 | |
| ProfileEvent_UncompressedCacheHits | UInt64 | |
| ProfileEvent_UncompressedCacheMisses | UInt64 | |
| ProfileEvent_UncompressedCacheWeightLost | UInt64 | |
| ProfileEvent_MMappedFileCacheHits | UInt64 | |
| ProfileEvent_MMappedFileCacheMisses | UInt64 | |
| ProfileEvent_IOBufferAllocs | UInt64 | |
| ProfileEvent_IOBufferAllocBytes | UInt64 | |
| ProfileEvent_ArenaAllocChunks | UInt64 | |
| ProfileEvent_ArenaAllocBytes | UInt64 | |
| ProfileEvent_FunctionExecute | UInt64 | |
| ProfileEvent_TableFunctionExecute | UInt64 | |
| ProfileEvent_MarkCacheHits | UInt64 | |
| ProfileEvent_MarkCacheMisses | UInt64 | |
| ProfileEvent_CreatedReadBufferOrdinary | UInt64 | |
| ProfileEvent_CreatedReadBufferAIO | UInt64 | |
| ProfileEvent_CreatedReadBufferAIOFailed | UInt64 | |
| ProfileEvent_CreatedReadBufferMMap | UInt64 | |
| ProfileEvent_CreatedReadBufferMMapFailed | UInt64 | |
| ProfileEvent_DiskReadElapsedMicroseconds | UInt64 | |
| ProfileEvent_DiskWriteElapsedMicroseconds | UInt64 | |
| ProfileEvent_NetworkReceiveElapsedMicroseconds | UInt64 | |
| ProfileEvent_NetworkSendElapsedMicroseconds | UInt64 | |
| ProfileEvent_ThrottlerSleepMicroseconds | UInt64 | |
| ProfileEvent_QueryMaskingRulesMatch | UInt64 | |
| ProfileEvent_ReplicatedPartFetches | UInt64 | |
| ProfileEvent_ReplicatedPartFailedFetches | UInt64 | |
| ProfileEvent_ObsoleteReplicatedParts | UInt64 | |
| ProfileEvent_ReplicatedPartMerges | UInt64 | |
| ProfileEvent_ReplicatedPartFetchesOfMerged | UInt64 | |
| ProfileEvent_ReplicatedPartMutations | UInt64 | |
| ProfileEvent_ReplicatedPartChecks | UInt64 | |
| ProfileEvent_ReplicatedPartChecksFailed | UInt64 | |
| ProfileEvent_ReplicatedDataLoss | UInt64 | |
| ProfileEvent_InsertedRows | UInt64 | |
| ProfileEvent_InsertedBytes | UInt64 | |
| ProfileEvent_DelayedInserts | UInt64 | |
| ProfileEvent_RejectedInserts | UInt64 | |
| ProfileEvent_DelayedInsertsMilliseconds | UInt64 | |
| ProfileEvent_DistributedDelayedInserts | UInt64 | |
| ProfileEvent_DistributedRejectedInserts | UInt64 | |
| ProfileEvent_DistributedDelayedInsertsMilliseconds | UInt64 | |
| ProfileEvent_DuplicatedInsertedBlocks | UInt64 | |
| ProfileEvent_ZooKeeperInit | UInt64 | |
| ProfileEvent_ZooKeeperTransactions | UInt64 | |
| ProfileEvent_ZooKeeperList | UInt64 | |
| ProfileEvent_ZooKeeperCreate | UInt64 | |
| ProfileEvent_ZooKeeperRemove | UInt64 | |
| ProfileEvent_ZooKeeperExists | UInt64 | |
| ProfileEvent_ZooKeeperGet | UInt64 | |
| ProfileEvent_ZooKeeperSet | UInt64 | |
| ProfileEvent_ZooKeeperMulti | UInt64 | |
| ProfileEvent_ZooKeeperCheck | UInt64 | |
| ProfileEvent_ZooKeeperClose | UInt64 | |
| ProfileEvent_ZooKeeperWatchResponse | UInt64 | |
| ProfileEvent_ZooKeeperUserExceptions | UInt64 | |
| ProfileEvent_ZooKeeperHardwareExceptions | UInt64 | |
| ProfileEvent_ZooKeeperOtherExceptions | UInt64 | |
| ProfileEvent_ZooKeeperWaitMicroseconds | UInt64 | |
| ProfileEvent_ZooKeeperBytesSent | UInt64 | |
| ProfileEvent_ZooKeeperBytesReceived | UInt64 | |
| ProfileEvent_DistributedConnectionFailTry | UInt64 | |
| ProfileEvent_DistributedConnectionMissingTable | UInt64 | |
| ProfileEvent_DistributedConnectionStaleReplica | UInt64 | |
| ProfileEvent_DistributedConnectionFailAtAll | UInt64 | |
| ProfileEvent_HedgedRequestsChangeReplica | UInt64 | |
| ProfileEvent_CompileFunction | UInt64 | |
| ProfileEvent_CompiledFunctionExecute | UInt64 | |
| ProfileEvent_CompileExpressionsMicroseconds | UInt64 | |
| ProfileEvent_CompileExpressionsBytes | UInt64 | |
| ProfileEvent_ExternalSortWritePart | UInt64 | |
| ProfileEvent_ExternalSortMerge | UInt64 | |
| ProfileEvent_ExternalAggregationWritePart | UInt64 | |
| ProfileEvent_ExternalAggregationMerge | UInt64 | |
| ProfileEvent_ExternalAggregationCompressedBytes | UInt64 | |
| ProfileEvent_ExternalAggregationUncompressedBytes | UInt64 | |
| ProfileEvent_SlowRead | UInt64 | |
| ProfileEvent_ReadBackoff | UInt64 | |
| ProfileEvent_ReplicaPartialShutdown | UInt64 | |
| ProfileEvent_SelectedParts | UInt64 | |
| ProfileEvent_SelectedRanges | UInt64 | |
| ProfileEvent_SelectedMarks | UInt64 | |
| ProfileEvent_SelectedRows | UInt64 | |
| ProfileEvent_SelectedBytes | UInt64 | |
| ProfileEvent_Merge | UInt64 | |
| ProfileEvent_MergedRows | UInt64 | |
| ProfileEvent_MergedUncompressedBytes | UInt64 | |
| ProfileEvent_MergesTimeMilliseconds | UInt64 | |
| ProfileEvent_MergeTreeDataWriterRows | UInt64 | |
| ProfileEvent_MergeTreeDataWriterUncompressedBytes | UInt64 | |
| ProfileEvent_MergeTreeDataWriterCompressedBytes | UInt64 | |
| ProfileEvent_MergeTreeDataWriterBlocks | UInt64 | |
| ProfileEvent_MergeTreeDataWriterBlocksAlreadySorted | UInt64 | |
| ProfileEvent_CannotRemoveEphemeralNode | UInt64 | |
| ProfileEvent_RegexpCreated | UInt64 | |
| ProfileEvent_ContextLock | UInt64 | |
| ProfileEvent_StorageBufferFlush | UInt64 | |
| ProfileEvent_StorageBufferErrorOnFlush | UInt64 | |
| ProfileEvent_StorageBufferPassedAllMinThresholds | UInt64 | |
| ProfileEvent_StorageBufferPassedTimeMaxThreshold | UInt64 | |
| ProfileEvent_StorageBufferPassedRowsMaxThreshold | UInt64 | |
| ProfileEvent_StorageBufferPassedBytesMaxThreshold | UInt64 | |
| ProfileEvent_DictCacheKeysRequested | UInt64 | |
| ProfileEvent_DictCacheKeysRequestedMiss | UInt64 | |
| ProfileEvent_DictCacheKeysRequestedFound | UInt64 | |
| ProfileEvent_DictCacheKeysExpired | UInt64 | |
| ProfileEvent_DictCacheKeysNotFound | UInt64 | |
| ProfileEvent_DictCacheKeysHit | UInt64 | |
| ProfileEvent_DictCacheRequestTimeNs | UInt64 | |
| ProfileEvent_DictCacheRequests | UInt64 | |
| ProfileEvent_DictCacheLockWriteNs | UInt64 | |
| ProfileEvent_DictCacheLockReadNs | UInt64 | |
| ProfileEvent_DistributedSyncInsertionTimeoutExceeded | UInt64 | |
| ProfileEvent_DataAfterMergeDiffersFromReplica | UInt64 | |
| ProfileEvent_DataAfterMutationDiffersFromReplica | UInt64 | |
| ProfileEvent_PolygonsAddedToPool | UInt64 | |
| ProfileEvent_PolygonsInPoolAllocatedBytes | UInt64 | |
| ProfileEvent_RWLockAcquiredReadLocks | UInt64 | |
| ProfileEvent_RWLockAcquiredWriteLocks | UInt64 | |
| ProfileEvent_RWLockReadersWaitMilliseconds | UInt64 | |
| ProfileEvent_RWLockWritersWaitMilliseconds | UInt64 | |
| ProfileEvent_DNSError | UInt64 | |
| ProfileEvent_RealTimeMicroseconds | UInt64 | |
| ProfileEvent_UserTimeMicroseconds | UInt64 | |
| ProfileEvent_SystemTimeMicroseconds | UInt64 | |
| ProfileEvent_SoftPageFaults | UInt64 | |
| ProfileEvent_HardPageFaults | UInt64 | |
| ProfileEvent_VoluntaryContextSwitches | UInt64 | |
| ProfileEvent_InvoluntaryContextSwitches | UInt64 | |
| ProfileEvent_OSIOWaitMicroseconds | UInt64 | |
| ProfileEvent_OSCPUWaitMicroseconds | UInt64 | |
| ProfileEvent_OSCPUVirtualTimeMicroseconds | UInt64 | |
| ProfileEvent_OSReadBytes | UInt64 | |
| ProfileEvent_OSWriteBytes | UInt64 | |
| ProfileEvent_OSReadChars | UInt64 | |
| ProfileEvent_OSWriteChars | UInt64 | |
| ProfileEvent_PerfCpuCycles | UInt64 | |
| ProfileEvent_PerfInstructions | UInt64 | |
| ProfileEvent_PerfCacheReferences | UInt64 | |
| ProfileEvent_PerfCacheMisses | UInt64 | |
| ProfileEvent_PerfBranchInstructions | UInt64 | |
| ProfileEvent_PerfBranchMisses | UInt64 | |
| ProfileEvent_PerfBusCycles | UInt64 | |
| ProfileEvent_PerfStalledCyclesFrontend | UInt64 | |
| ProfileEvent_PerfStalledCyclesBackend | UInt64 | |
| ProfileEvent_PerfRefCpuCycles | UInt64 | |
| ProfileEvent_PerfCpuClock | UInt64 | |
| ProfileEvent_PerfTaskClock | UInt64 | |
| ProfileEvent_PerfContextSwitches | UInt64 | |
| ProfileEvent_PerfCpuMigrations | UInt64 | |
| ProfileEvent_PerfAlignmentFaults | UInt64 | |
| ProfileEvent_PerfEmulationFaults | UInt64 | |
| ProfileEvent_PerfMinEnabledTime | UInt64 | |
| ProfileEvent_PerfMinEnabledRunningTime | UInt64 | |
| ProfileEvent_PerfDataTLBReferences | UInt64 | |
| ProfileEvent_PerfDataTLBMisses | UInt64 | |
| ProfileEvent_PerfInstructionTLBReferences | UInt64 | |
| ProfileEvent_PerfInstructionTLBMisses | UInt64 | |
| ProfileEvent_PerfLocalMemoryReferences | UInt64 | |
| ProfileEvent_PerfLocalMemoryMisses | UInt64 | |
| ProfileEvent_CreatedHTTPConnections | UInt64 | |
| ProfileEvent_CannotWriteToWriteBufferDiscard | UInt64 | |
| ProfileEvent_QueryProfilerSignalOverruns | UInt64 | |
| ProfileEvent_CreatedLogEntryForMerge | UInt64 | |
| ProfileEvent_NotCreatedLogEntryForMerge | UInt64 | |
| ProfileEvent_CreatedLogEntryForMutation | UInt64 | |
| ProfileEvent_NotCreatedLogEntryForMutation | UInt64 | |
| ProfileEvent_S3ReadMicroseconds | UInt64 | |
| ProfileEvent_S3ReadBytes | UInt64 | |
| ProfileEvent_S3ReadRequestsCount | UInt64 | |
| ProfileEvent_S3ReadRequestsErrors | UInt64 | |
| ProfileEvent_S3ReadRequestsThrottling | UInt64 | |
| ProfileEvent_S3ReadRequestsRedirects | UInt64 | |
| ProfileEvent_S3WriteMicroseconds | UInt64 | |
| ProfileEvent_S3WriteBytes | UInt64 | |
| ProfileEvent_S3WriteRequestsCount | UInt64 | |
| ProfileEvent_S3WriteRequestsErrors | UInt64 | |
| ProfileEvent_S3WriteRequestsThrottling | UInt64 | |
| ProfileEvent_S3WriteRequestsRedirects | UInt64 | |
| ProfileEvent_QueryMemoryLimitExceeded | UInt64 | |
| CurrentMetric_Query | Int64 | |
| CurrentMetric_Merge | Int64 | |
| CurrentMetric_PartMutation | Int64 | |
| CurrentMetric_ReplicatedFetch | Int64 | |
| CurrentMetric_ReplicatedSend | Int64 | |
| CurrentMetric_ReplicatedChecks | Int64 | |
| CurrentMetric_BackgroundPoolTask | Int64 | |
| CurrentMetric_BackgroundFetchesPoolTask | Int64 | |
| CurrentMetric_BackgroundMovePoolTask | Int64 | |
| CurrentMetric_BackgroundSchedulePoolTask | Int64 | |
| CurrentMetric_BackgroundBufferFlushSchedulePoolTask | Int64 | |
| CurrentMetric_BackgroundDistributedSchedulePoolTask | Int64 | |
| CurrentMetric_BackgroundMessageBrokerSchedulePoolTask | Int64 | |
| CurrentMetric_CacheDictionaryUpdateQueueBatches | Int64 | |
| CurrentMetric_CacheDictionaryUpdateQueueKeys | Int64 | |
| CurrentMetric_DiskSpaceReservedForMerge | Int64 | |
| CurrentMetric_DistributedSend | Int64 | |
| CurrentMetric_QueryPreempted | Int64 | |
| CurrentMetric_TCPConnection | Int64 | |
| CurrentMetric_MySQLConnection | Int64 | |
| CurrentMetric_HTTPConnection | Int64 | |
| CurrentMetric_InterserverConnection | Int64 | |
| CurrentMetric_PostgreSQLConnection | Int64 | |
| CurrentMetric_OpenFileForRead | Int64 | |
| CurrentMetric_OpenFileForWrite | Int64 | |
| CurrentMetric_Read | Int64 | |
| CurrentMetric_Write | Int64 | |
| CurrentMetric_SendScalars | Int64 | |
| CurrentMetric_SendExternalTables | Int64 | |
| CurrentMetric_QueryThread | Int64 | |
| CurrentMetric_ReadonlyReplica | Int64 | |
| CurrentMetric_MemoryTracking | Int64 | |
| CurrentMetric_EphemeralNode | Int64 | |
| CurrentMetric_ZooKeeperSession | Int64 | |
| CurrentMetric_ZooKeeperWatch | Int64 | |
| CurrentMetric_ZooKeeperRequest | Int64 | |
| CurrentMetric_DelayedInserts | Int64 | |
| CurrentMetric_ContextLockWait | Int64 | |
| CurrentMetric_StorageBufferRows | Int64 | |
| CurrentMetric_StorageBufferBytes | Int64 | |
| CurrentMetric_DictCacheRequests | Int64 | |
| CurrentMetric_Revision | Int64 | |
| CurrentMetric_VersionInteger | Int64 | |
| CurrentMetric_RWLockWaitingReaders | Int64 | |
| CurrentMetric_RWLockWaitingWriters | Int64 | |
| CurrentMetric_RWLockActiveReaders | Int64 | |
| CurrentMetric_RWLockActiveWriters | Int64 | |
| CurrentMetric_GlobalThread | Int64 | |
| CurrentMetric_GlobalThreadActive | Int64 | |
| CurrentMetric_LocalThread | Int64 | |
| CurrentMetric_LocalThreadActive | Int64 | |
| CurrentMetric_DistributedFilesToInsert | Int64 | |
| CurrentMetric_TablesToDropQueueSize | Int64 | |
| CurrentMetric_MaxDDLEntryID | Int64 | |
| CurrentMetric_PartsTemporary | Int64 | |
| CurrentMetric_PartsPreCommitted | Int64 | |
| CurrentMetric_PartsCommitted | Int64 | |
| CurrentMetric_PartsOutdated | Int64 | |
| CurrentMetric_PartsDeleting | Int64 | |
| CurrentMetric_PartsDeleteOnDestroy | Int64 | |
| CurrentMetric_PartsWide | Int64 | |
| CurrentMetric_PartsCompact | Int64 | |
| CurrentMetric_PartsInMemory | Int64 | |
| CurrentMetric_MMappedFiles | Int64 | |
| CurrentMetric_MMappedFileBytes | Int64 |