Name | Type | Description |
Master.AbsentCacheHits |
GAUGE |
Number of cache hits on the absent cache |
Master.AbsentCacheMisses |
GAUGE |
Number of cache misses on the absent cache |
Master.AbsentCacheSize |
GAUGE |
Size of the absent cache |
Master.AbsentPathCacheQueueSize |
GAUGE |
Alluxio maintains a cache of absent UFS paths. This is the number of UFS paths being processed. |
Master.AsyncPersistCancel |
COUNTER |
The number of cancelled AsyncPersist operations |
Master.AsyncPersistFail |
COUNTER |
The number of failed AsyncPersist operations |
Master.AsyncPersistFileCount |
COUNTER |
The number of files created by AsyncPersist operations |
Master.AsyncPersistFileSize |
COUNTER |
The total size of files created by AsyncPersist operations |
Master.AsyncPersistSuccess |
COUNTER |
The number of successful AsyncPersist operations |
Master.AuditLogEntriesSize |
GAUGE |
The size of the audit log entries blocking queue |
Master.BlockHeapSize |
GAUGE |
An estimate of the blocks heap size |
Master.BlockReplicaCount |
GAUGE |
Total number of block replicas in Alluxio |
Master.CachedBlockLocations |
GAUGE |
Total number of cached block locations |
Master.CompleteFileOps |
COUNTER |
Total number of the CompleteFile operations |
Master.CompletedOperationRetryCount |
COUNTER |
Total number of completed operations that has been retried by client. |
Master.CreateDirectoryOps |
COUNTER |
Total number of the CreateDirectory operations |
Master.CreateFileOps |
COUNTER |
Total number of the CreateFile operations |
Master.DeletePathOps |
COUNTER |
Total number of the Delete operations |
Master.DirectoriesCreated |
COUNTER |
Total number of the succeed CreateDirectory operations |
Master.EdgeCacheEvictions |
GAUGE |
Total number of edges (inode metadata) that was evicted from cache. The edge cache is responsible for managing the mapping from (parentId, childName) to childId. |
Master.EdgeCacheHits |
GAUGE |
Total number of hits in the edge (inode metadata) cache. The edge cache is responsible for managing the mapping from (parentId, childName) to childId. |
Master.EdgeCacheLoadTimes |
GAUGE |
Total load times in the edge (inode metadata) cache that resulted from a cache miss. The edge cache is responsible for managing the mapping from (parentId, childName) to childId. |
Master.EdgeCacheMisses |
GAUGE |
Total number of misses in the edge (inode metadata) cache. The edge cache is responsible for managing the mapping from (parentId, childName) to childId. |
Master.EdgeCacheSize |
GAUGE |
Total number of edges (inode metadata) cached. The edge cache is responsible for managing the mapping from (parentId, childName) to childId. |
Master.EdgeLockPoolSize |
GAUGE |
The size of master edge lock pool |
Master.EmbeddedJournalLastSnapshotDownloadDiskSize |
GAUGE |
Describes the size on disk of the snapshot downloaded from other masters in the cluster the previous time the download occurred. Only valid when using the embedded journal. |
Master.EmbeddedJournalLastSnapshotDownloadDurationMs |
GAUGE |
Describes the amount of time taken to download journal snapshots from other masters in the cluster the previous time the download occurred. Only valid when using the embedded journal. |
Master.EmbeddedJournalLastSnapshotDownloadSize |
GAUGE |
Describes the size of the snapshot downloaded from other masters in the cluster the previous time the download occurred. Only valid when using the embedded journal. |
Master.EmbeddedJournalLastSnapshotDurationMs |
GAUGE |
Describes the amount of time taken to generate the last local journal snapshots on this master. Only valid when using the embedded journal. |
Master.EmbeddedJournalLastSnapshotEntriesCount |
GAUGE |
Describes the number of entries in the last local journal snapshots on this master. Only valid when using the embedded journal. |
Master.EmbeddedJournalLastSnapshotReplayDurationMs |
GAUGE |
Represents the time the last restore from checkpoint operation took in milliseconds. |
Master.EmbeddedJournalLastSnapshotReplayEntriesCount |
GAUGE |
Represents the time the last restore from checkpoint operation took in milliseconds. |
Master.EmbeddedJournalLastSnapshotUploadDiskSize |
GAUGE |
Describes the size on disk of the snapshot uploaded to other masters in the cluster the previous time the download occurred. Only valid when using the embedded journal. |
Master.EmbeddedJournalLastSnapshotUploadDurationMs |
GAUGE |
Describes the amount of time taken to upload journal snapshots to another master in the cluster the previous time the upload occurred. Only valid when using the embedded journal. |
Master.EmbeddedJournalLastSnapshotUploadSize |
GAUGE |
Describes the size of the snapshot uploaded to other masters in the cluster the previous time the download occurred. Only valid when using the embedded journal. |
Master.EmbeddedJournalSnapshotDownloadDiskHistogram |
HISTOGRAM |
Describes the size on disk of the snapshot downloaded from another master in the cluster. Only valid when using the embedded journal. Long running average. |
Master.EmbeddedJournalSnapshotDownloadGenerate |
TIMER |
Describes the amount of time taken to download journal snapshots from other masters in the cluster. Only valid when using the embedded journal. Long running average. |
Master.EmbeddedJournalSnapshotDownloadHistogram |
HISTOGRAM |
Describes the size of the snapshot downloaded from another master in the cluster. Only valid when using the embedded journal. Long running average. |
Master.EmbeddedJournalSnapshotGenerateTimer |
TIMER |
Describes the amount of time taken to generate local journal snapshots on this master. Only valid when using the embedded journal. Use this metric to measure the performance of Alluxio's snapshot generation. |
Master.EmbeddedJournalSnapshotInstallTimer |
TIMER |
Describes the amount of time taken to install a downloaded journal snapshot from another master. Only valid only when using the embedded journal. Use this metric to determine the performance of Alluxio when installing snapshots from the leader. Higher numbers may indicate a slow disk or CPU contention. |
Master.EmbeddedJournalSnapshotLastIndex |
GAUGE |
Represents the latest journal index that was recorded by this master in the most recent local snapshot or from a snapshot downloaded from another master in the cluster. Only valid when using the embedded journal. |
Master.EmbeddedJournalSnapshotReplayTimer |
TIMER |
Describes the amount of time taken to replay a journal snapshot onto the master's state machine. Only valid only when using the embedded journal. Use this metric to determine the performance of Alluxio when replaying journal snapshot file. Higher numbers may indicate a slow disk or CPU contention |
Master.EmbeddedJournalSnapshotUploadDiskHistogram |
HISTOGRAM |
Describes the size on disk of the snapshot uploaded to another master in the cluster. Only valid when using the embedded journal. Long running average. |
Master.EmbeddedJournalSnapshotUploadHistogram |
HISTOGRAM |
Describes the size of the snapshot uploaded to another master in the cluster. Only valid when using the embedded journal. Long running average. |
Master.EmbeddedJournalSnapshotUploadTimer |
TIMER |
Describes the amount of time taken to upload journal snapshots to another master in the cluster. Only valid when using the embedded journal. long running average |
Master.FileBlockInfosGot |
COUNTER |
Total number of succeed GetFileBlockInfo operations |
Master.FileInfosGot |
COUNTER |
Total number of the succeed GetFileInfo operations |
Master.FileSize |
GAUGE |
File size distribution |
Master.FilesCompleted |
COUNTER |
Total number of the succeed CompleteFile operations |
Master.FilesCreated |
COUNTER |
Total number of the succeed CreateFile operations |
Master.FilesFreed |
COUNTER |
Total number of succeed FreeFile operations |
Master.FilesPersisted |
COUNTER |
Total number of successfully persisted files |
Master.FilesPinned |
GAUGE |
Total number of currently pinned files. Note that IDs for these files are stored in memory. |
Master.FilesToBePersisted |
GAUGE |
Total number of currently to be persisted files. Note that the IDs for these files are stored in memory. |
Master.FreeFileOps |
COUNTER |
Total number of FreeFile operations |
Master.GetFileBlockInfoOps |
COUNTER |
Total number of GetFileBlockInfo operations |
Master.GetFileInfoOps |
COUNTER |
Total number of the GetFileInfo operations |
Master.GetNewBlockOps |
COUNTER |
Total number of the GetNewBlock operations |
Master.InodeCacheEvictions |
GAUGE |
Total number of inodes that was evicted from the cache. |
Master.InodeCacheHitRatio |
GAUGE |
Inode Cache hit ratio |
Master.InodeCacheHits |
GAUGE |
Total number of hits in the inodes (inode metadata) cache. |
Master.InodeCacheLoadTimes |
GAUGE |
Total load times in the inodes (inode metadata) cache that resulted from a cache miss. |
Master.InodeCacheMisses |
GAUGE |
Total number of misses in the inodes (inode metadata) cache. |
Master.InodeCacheSize |
GAUGE |
Total number of inodes (inode metadata) cached. |
Master.InodeHeapSize |
GAUGE |
An estimate of the inode heap size |
Master.InodeLockPoolSize |
GAUGE |
The size of master inode lock pool |
Master.JobCanceled |
COUNTER |
The number of canceled status job |
Master.JobCompleted |
COUNTER |
The number of completed status job |
Master.JobCount |
GAUGE |
The number of all status job |
Master.JobCreated |
COUNTER |
The number of created status job |
Master.JobDistributedLoadBlockSizes |
COUNTER |
The total block size loaded by load commands |
Master.JobDistributedLoadCancel |
COUNTER |
The number of cancelled DistributedLoad operations |
Master.JobDistributedLoadFail |
COUNTER |
The number of failed DistributedLoad operations |
Master.JobDistributedLoadFileCount |
COUNTER |
The number of files by DistributedLoad operations |
Master.JobDistributedLoadFileSizes |
COUNTER |
The total file size by DistributedLoad operations |
Master.JobDistributedLoadRate |
METER |
The average DistributedLoad loading rate |
Master.JobDistributedLoadSuccess |
COUNTER |
The number of successful DistributedLoad operations |
Master.JobFailed |
COUNTER |
The number of failed status job |
Master.JobLoadBlockCount |
COUNTER |
The number of blocks loaded by load commands |
Master.JobLoadBlockFail |
COUNTER |
The number of blocks failed to be loaded by load commands |
Master.JobLoadFail |
COUNTER |
The number of failed Load commands |
Master.JobLoadRate |
METER |
The average loading rate of Load commands |
Master.JobLoadSuccess |
COUNTER |
The number of successful Load commands |
Master.JobRunning |
COUNTER |
The number of running status job |
Master.JournalCheckpointWarn |
GAUGE |
If the raft log index exceeds alluxio.master.journal.checkpoint.period.entries, and the last checkpoint exceeds alluxio.master.journal.checkpoint.warning.threshold.time, it returns 1 to indicate that a warning is required, otherwise it returns 0 |
Master.JournalEntriesSinceCheckPoint |
GAUGE |
Journal entries since last checkpoint |
Master.JournalFlushFailure |
COUNTER |
Total number of failed journal flush |
Master.JournalFlushTimer |
TIMER |
The timer statistics of journal flush |
Master.JournalFreeBytes |
GAUGE |
Bytes left on the journal disk(s) for an Alluxio master. This metric is only valid on Linux and when embedded journal is used. Use this metric to monitor whether your journal is running out of disk space. |
Master.JournalFreePercent |
GAUGE |
Percentage of free space left on the journal disk(s) for an Alluxio master.This metric is only valid on Linux and when embedded journal is used. Use this metric to monitor whether your journal is running out of disk space. |
Master.JournalGainPrimacyTimer |
TIMER |
The timer statistics of journal gain primacy |
Master.JournalLastAppliedCommitIndex |
GAUGE |
The last raft log index which was applied to the state machine |
Master.JournalLastCheckPointTime |
GAUGE |
Last Journal Checkpoint Time |
Master.JournalSequenceNumber |
GAUGE |
Current journal sequence number |
Master.LastBackupEntriesCount |
GAUGE |
The total number of entries written in the last leading master metadata backup |
Master.LastBackupRestoreCount |
GAUGE |
The total number of entries restored from backup when a leading master initializes its metadata |
Master.LastBackupRestoreTimeMs |
GAUGE |
The process time of the last restore from backup |
Master.LastBackupTimeMs |
GAUGE |
The process time of the last backup |
Master.LastGainPrimacyTime |
GAUGE |
Last time the master gains primacy |
Master.LastLosePrimacyTime |
GAUGE |
Last time the master loses primacy |
Master.ListingCacheEvictions |
COUNTER |
The total number of evictions in master listing cache |
Master.ListingCacheHits |
COUNTER |
The total number of hits in master listing cache |
Master.ListingCacheLoadTimes |
COUNTER |
The total load time (in nanoseconds) in master listing cache that resulted from a cache miss. |
Master.ListingCacheMisses |
COUNTER |
The total number of misses in master listing cache |
Master.ListingCacheSize |
GAUGE |
The size of master listing cache |
Master.LostBlockCount |
GAUGE |
Count of lost unique blocks |
Master.LostFileCount |
GAUGE |
Count of lost files. This number is cached and may not be in sync with Master.LostBlockCount |
Master.MetadataSyncActivePaths |
COUNTER |
The number of in-progress paths from all InodeSyncStream instances |
Master.MetadataSyncExecutor |
EXECUTOR_SERVICE |
Metrics concerning the master metadata sync executor threads. Master.MetadataSyncExecutor.submitted is a meter of the tasks submitted to the executor. Master.MetadataSyncExecutor.completed is a meter of the tasks completed by the executor. Master.MetadataSyncExecutor.activeTaskQueue is exponentially-decaying random reservoir of the number of active tasks (running or submitted) at the executor calculated each time a new task is added to the executor. The max value is the maximum number of active tasks at any time during execution. Master.MetadataSyncExecutor.running is the number of tasks actively being run by the executor. Master.MetadataSyncExecutor.idle is the time spent idling by the submitted tasks (i.e. waiting the the queue before being executed). Master.MetadataSyncExecutor.duration is the time spent running the submitted tasks. If the executor is a thread pool executor then Master.MetadataSyncExecutor.queueSize is the size of the task queue. |
Master.MetadataSyncExecutorQueueSize |
GAUGE |
The number of queuing sync tasks in the metadata sync thread pool controlled by alluxio.master.metadata.sync.executor.pool.size |
Master.MetadataSyncFail |
COUNTER |
The number of InodeSyncStream that failed, either partially or fully |
Master.MetadataSyncNoChange |
COUNTER |
The number of InodeSyncStream that finished with no change to inodes. |
Master.MetadataSyncOpsCount |
COUNTER |
The number of metadata sync operations. Each sync operation corresponds to one InodeSyncStream instance. |
Master.MetadataSyncPathsCancel |
COUNTER |
The number of pending paths from all InodeSyncStream instances that are ignored in the end instead of processed |
Master.MetadataSyncPathsFail |
COUNTER |
The number of paths that failed during metadata sync from all InodeSyncStream instances |
Master.MetadataSyncPathsSuccess |
COUNTER |
The number of paths sync-ed from all InodeSyncStream instances |
Master.MetadataSyncPendingPaths |
COUNTER |
The number of pending paths from all active InodeSyncStream instances,waiting for metadata sync |
Master.MetadataSyncPrefetchCancel |
COUNTER |
Number of cancelled prefetch jobs from metadata sync |
Master.MetadataSyncPrefetchExecutor |
EXECUTOR_SERVICE |
Metrics concerning the master metadata sync prefetchexecutor threads. Master.MetadataSyncPrefetchExecutor.submitted is a meter of the tasks submitted to the executor. Master.MetadataSyncPrefetchExecutor.completed is a meter of the tasks completed by the executor. Master.MetadataSyncPrefetchExecutor.activeTaskQueue is exponentially-decaying random reservoir of the number of active tasks (running or submitted) at the executor calculated each time a new task is added to the executor. The max value is the maximum number of active tasks at any time during execution. Master.MetadataSyncPrefetchExecutor.running is the number of tasks actively being run by the executor. Master.MetadataSyncPrefetchExecutor.idle is the time spent idling by the submitted tasks (i.e. waiting the the queue before being executed). Master.MetadataSyncPrefetchExecutor.duration is the time spent running the submitted tasks. If the executor is a thread pool executor then Master.MetadataSyncPrefetchExecutor.queueSize is the size of the task queue. |
Master.MetadataSyncPrefetchExecutorQueueSize |
GAUGE |
The number of queuing prefetch tasks in the metadata sync thread pool controlled by alluxio.master.metadata.sync.ufs.prefetch.pool.size |
Master.MetadataSyncPrefetchFail |
COUNTER |
Number of failed prefetch jobs from metadata sync |
Master.MetadataSyncPrefetchOpsCount |
COUNTER |
The number of prefetch operations handled by the prefetch thread pool |
Master.MetadataSyncPrefetchPaths |
COUNTER |
Total number of UFS paths fetched by prefetch jobs from metadata sync |
Master.MetadataSyncPrefetchRetries |
COUNTER |
Number of retries to get from prefetch jobs from metadata sync |
Master.MetadataSyncPrefetchSuccess |
COUNTER |
Number of successful prefetch jobs from metadata sync |
Master.MetadataSyncSkipped |
COUNTER |
The number of InodeSyncStream that are skipped because the Alluxio metadata is fresher than alluxio.user.file.metadata.sync.interval |
Master.MetadataSyncSuccess |
COUNTER |
The number of InodeSyncStream that succeeded |
Master.MetadataSyncTimeMs |
COUNTER |
The total time elapsed in all InodeSyncStream instances |
Master.MetadataSyncUfsMount. |
COUNTER |
The number of UFS sync operations for a given mount point |
Master.MetadataSyncV2CancelledTasks |
COUNTER |
The number of cancelled metadata sync tasks |
Master.MetadataSyncV2CompletedTasks |
COUNTER |
The number of completed metadata sync tasks |
Master.MetadataSyncV2FailedTasks |
COUNTER |
The number of failed metadata sync tasks |
Master.MetadataSyncV2FilesCreated |
COUNTER |
The number of files created during processing during metadata sync |
Master.MetadataSyncV2FilesDeleted |
COUNTER |
The number of files deleted during processing during metadata sync |
Master.MetadataSyncV2FilesNoop |
COUNTER |
The number of files at parity between alluxio and UFS during processing during metadata sync |
Master.MetadataSyncV2FilesRecreated |
COUNTER |
The number of files recreated during processing during metadata sync |
Master.MetadataSyncV2FilesSkippedConcurrentUpdate |
COUNTER |
The number of files skipped due to concurrent update during processing during metadata sync |
Master.MetadataSyncV2FilesSkippedMountPoint |
COUNTER |
The number of files skipped because the inode is a mount point during processing during metadata sync |
Master.MetadataSyncV2FilesSkippedNonPersisted |
COUNTER |
The number of files skipped because the inode is not persisted during processing during metadata sync |
Master.MetadataSyncV2FilesUpdated |
COUNTER |
The number of files updated during processing during metadata sync |
Master.MetadataSyncV2LoadsFailed |
COUNTER |
The number of failed load requests during metadata sync |
Master.MetadataSyncV2ProcessingFailed |
COUNTER |
The number loads failed during processing during metadata sync |
Master.MetadataSyncV2QueuedLoads |
GAUGE |
Total number of load requests that are pending |
Master.MetadataSyncV2RunningLoads |
GAUGE |
The number of load requests that are in progress or have completed, but not yet been processed |
Master.MetadataSyncV2RunningTasks |
GAUGE |
The number of metadata sync tasks currently running |
Master.MigrateJobCancel |
COUNTER |
The number of cancelled MigrateJob operations |
Master.MigrateJobFail |
COUNTER |
The number of failed MigrateJob operations |
Master.MigrateJobFileCount |
COUNTER |
The number of MigrateJob files |
Master.MigrateJobFileSize |
COUNTER |
The total size of MigrateJob files |
Master.MigrateJobSuccess |
COUNTER |
The number of successful MigrateJob operations |
Master.MountOps |
COUNTER |
Total number of Mount operations |
Master.NewBlocksGot |
COUNTER |
Total number of the succeed GetNewBlock operations |
Master.PathsDeleted |
COUNTER |
Total number of the succeed Delete operations |
Master.PathsMounted |
COUNTER |
Total number of succeed Mount operations |
Master.PathsRenamed |
COUNTER |
Total number of succeed Rename operations |
Master.PathsUnmounted |
COUNTER |
Total number of succeed Unmount operations |
Master.PolicyCommitExecutorQueueSize |
GAUGE |
The queue size of commit executor in action scheduler |
Master.PolicyExecutionExecutorQueueSize |
GAUGE |
The queue size of execution executor in action scheduler |
Master.PolicyRunningActionCount |
GAUGE |
The number of running actions in action scheduler |
Master.PolicyScanTimer |
TIMER |
The timer statistics of policy scan |
Master.PolicyScheduledActionCount |
GAUGE |
The number of actions scheduled by action scheduler |
Master.PolicySyncTaskCount |
GAUGE |
The number of active sync tasks |
Master.RenamePathOps |
COUNTER |
Total number of Rename operations |
Master.ReplicaMgmtActiveJobSize |
GAUGE |
Number of active block replication/eviction jobs. These jobs are created by the master to maintain the block replica factor. The value is an estimate with lag. |
Master.ReplicationLimitedFiles |
COUNTER |
Number of files that have a replication count set to a non-default value. Note that these files have IDs that are stored in memory. |
Master.RocksBlockBackgroundErrors |
GAUGE |
RocksDB block table. Accumulated number of background errors. |
Master.RocksBlockBlockCacheCapacity |
GAUGE |
RocksDB block table. Block cache capacity. |
Master.RocksBlockBlockCachePinnedUsage |
GAUGE |
RocksDB block table. Memory size for the entries being pinned. |
Master.RocksBlockBlockCacheUsage |
GAUGE |
RocksDB block table. Memory size for the entries residing in block cache. |
Master.RocksBlockCompactionPending |
GAUGE |
RocksDB block table. This metric 1 if at least one compaction is pending; otherwise, the metric reports 0. |
Master.RocksBlockCurSizeActiveMemTable |
GAUGE |
RocksDB block table. Approximate size of active memtable in bytes. |
Master.RocksBlockCurSizeAllMemTables |
GAUGE |
RocksDB block table. Approximate size of active, unflushed immutable, and pinned immutable memtables in bytes. Pinned immutable memtables are flushed memtables that are kept in memory to maintain write history in memory. |
Master.RocksBlockEstimateNumKeys |
GAUGE |
RocksDB block table. Estimated number of total keys in the active and unflushed immutable memtables and storage. |
Master.RocksBlockEstimatePendingCompactionBytes |
GAUGE |
RocksDB block table. Estimated total number of bytes a compaction needs to rewrite on disk to get all levels down to under target size. In other words, this metrics relates to the write amplification in level compaction. Thus, this metric is not valid for compactions other than level-based. |
Master.RocksBlockEstimateTableReadersMem |
GAUGE |
RocksDB inode table. Estimated memory in bytes used for reading SST tables, excluding memory used in block cache (e.g., filter and index blocks). This metric records the memory used by iterators as well as filters and indices if the filters and indices are not maintained in the block cache. Basically this metric reports the memory used outside the block cache to read data. |
Master.RocksBlockEstimatedMemUsage |
GAUGE |
RocksDB block table. This metric estimates the memory usage of the RockDB Block table by aggregating the values of Master.RocksBlockBlockCacheUsage, Master.RocksBlockEstimateTableReadersMem, Master.RocksBlockCurSizeAllMemTables, and Master.RocksBlockBlockCachePinnedUsage |
Master.RocksBlockLiveSstFilesSize |
GAUGE |
RocksDB block table. Total size in bytes of all SST files that belong to the latest LSM tree. |
Master.RocksBlockMemTableFlushPending |
GAUGE |
RocksDB block table. This metric returns 1 if a memtable flush is pending; otherwhise it returns 0. |
Master.RocksBlockNumDeletesActiveMemTable |
GAUGE |
RocksDB block table. Total number of delete entries in the active memtable. |
Master.RocksBlockNumDeletesImmMemTables |
GAUGE |
RocksDB block table. Total number of delete entries in the unflushed immutable memtables. |
Master.RocksBlockNumEntriesActiveMemTable |
GAUGE |
RocksDB block table. Total number of entries in the active memtable. |
Master.RocksBlockNumEntriesImmMemTables |
GAUGE |
RocksDB block table. Total number of entries in the unflushed immutable memtables. |
Master.RocksBlockNumImmutableMemTable |
GAUGE |
RocksDB block table. Number of immutable memtables that have not yet been flushed. |
Master.RocksBlockNumLiveVersions |
GAUGE |
RocksDB inode table. Number of live versions. More live versions often mean more SST files are held from being deleted, by iterators or unfinished compactions. |
Master.RocksBlockNumRunningCompactions |
GAUGE |
RocksDB block table. Number of currently running compactions. |
Master.RocksBlockNumRunningFlushes |
GAUGE |
RocksDB block table. Number of currently running flushes. |
Master.RocksBlockSizeAllMemTables |
GAUGE |
RocksDB block table. Size all mem tables. |
Master.RocksBlockTotalSstFilesSize |
GAUGE |
RocksDB block table. Total size in bytes of all SST files. |
Master.RocksInodeBackgroundErrors |
GAUGE |
RocksDB inode table. Accumulated number of background errors. |
Master.RocksInodeBlockCacheCapacity |
GAUGE |
RocksDB inode table. Block cache capacity. |
Master.RocksInodeBlockCachePinnedUsage |
GAUGE |
RocksDB inode table. Memory size for the entries being pinned. |
Master.RocksInodeBlockCacheUsage |
GAUGE |
RocksDB inode table. Memory size for the entries residing in block cache. |
Master.RocksInodeCompactionPending |
GAUGE |
RocksDB inode table. This metric 1 if at least one compaction is pending; otherwise, the metric reports 0. |
Master.RocksInodeCurSizeActiveMemTable |
GAUGE |
RocksDB inode table. Approximate size of active memtable in bytes. |
Master.RocksInodeCurSizeAllMemTables |
GAUGE |
RocksDB inode table. Approximate size of active and unflushed immutable memtable in bytes. |
Master.RocksInodeEstimateNumKeys |
GAUGE |
RocksDB inode table. Estimated number of total keys in the active and unflushed immutable memtables and storage. |
Master.RocksInodeEstimatePendingCompactionBytes |
GAUGE |
RocksDB block table. Estimated total number of bytes a compaction needs to rewrite on disk to get all levels down to under target size. In other words, this metrics relates to the write amplification in level compaction. Thus, this metric is not valid for compactions other than level-based. |
Master.RocksInodeEstimateTableReadersMem |
GAUGE |
RocksDB inode table. Estimated memory in bytes used for reading SST tables, excluding memory used in block cache (e.g., filter and index blocks). This metric records the memory used by iterators as well as filters and indices if the filters and indices are not maintained in the block cache. Basically this metric reports the memory used outside the block cache to read data. |
Master.RocksInodeEstimatedMemUsage |
GAUGE |
RocksDB block table. This metric estimates the memory usage of the RockDB Inode table by aggregating the values of Master.RocksInodeBlockCacheUsage, Master.RocksInodeEstimateTableReadersMem, Master.RocksInodeCurSizeAllMemTables, and Master.RocksInodeBlockCachePinnedUsage |
Master.RocksInodeLiveSstFilesSize |
GAUGE |
RocksDB inode table. Total size in bytes of all SST files that belong to the latest LSM tree. |
Master.RocksInodeMemTableFlushPending |
GAUGE |
RocksDB inode table. This metric returns 1 if a memtable flush is pending; otherwhise it returns 0. |
Master.RocksInodeNumDeletesActiveMemTable |
GAUGE |
RocksDB inode table. Total number of delete entries in the active memtable. |
Master.RocksInodeNumDeletesImmMemTables |
GAUGE |
RocksDB inode table. Total number of delete entries in the unflushed immutable memtables. |
Master.RocksInodeNumEntriesActiveMemTable |
GAUGE |
RocksDB inode table. Total number of entries in the active memtable. |
Master.RocksInodeNumEntriesImmMemTables |
GAUGE |
RocksDB inode table. Total number of entries in the unflushed immutable memtables. |
Master.RocksInodeNumImmutableMemTable |
GAUGE |
RocksDB inode table. Number of immutable memtables that have not yet been flushed. |
Master.RocksInodeNumLiveVersions |
GAUGE |
RocksDB inode table. Number of live versions. More live versions often mean more SST files are held from being deleted, by iterators or unfinished compactions. |
Master.RocksInodeNumRunningCompactions |
GAUGE |
RocksDB inode table. Number of currently running compactions. |
Master.RocksInodeNumRunningFlushes |
GAUGE |
RocksDB inode table. Number of currently running flushes. |
Master.RocksInodeSizeAllMemTables |
GAUGE |
RocksDB inode table. Approximate size of active, unflushed immutable, and pinned immutable memtables in bytes. Pinned immutable memtables are flushed memtables that are kept in memory to maintain write history in memory. |
Master.RocksInodeTotalSstFilesSize |
GAUGE |
RocksDB inode table. Total size in bytes of all SST files. |
Master.RocksTotalEstimatedMemUsage |
GAUGE |
This metric gives an estimate of the total memory used by RocksDB by aggregating the values of Master.RocksBlockEstimatedMemUsage and Master.RocksInodeEstimatedMemUsage |
Master.RoleId |
GAUGE |
Display master role id |
Master.RpcQueueLength |
GAUGE |
Length of the master rpc queue. Use this metric to monitor the RPC pressure on master. |
Master.RpcThreadActiveCount |
GAUGE |
The number of threads that are actively executing tasks in the master RPC executor thread pool. Use this metric to monitor the RPC pressure on master. |
Master.RpcThreadCurrentCount |
GAUGE |
Current count of threads in the master RPC executor thread pool. Use this metric to monitor the RPC pressure on master. |
Master.SetAclOps |
COUNTER |
Total number of SetAcl operations |
Master.SetAttributeOps |
COUNTER |
Total number of SetAttribute operations |
Master.StartTime |
GAUGE |
The start time of the master process |
Master.TTLBuckets |
GAUGE |
The number of TTL buckets at the master. Note that these buckets are stored in memory. |
Master.TTLInodes |
GAUGE |
The total number of inodes contained in TTL buckets at the mater. Note that these inodes are stored in memory. |
Master.ToRemoveBlockCount |
GAUGE |
Count of block replicas to be removed from the workers. If 1 block is to be removed from 2 workers, 2 will be counted here. |
Master.TotalPaths |
GAUGE |
Total number of files and directory in Alluxio namespace |
Master.TotalRpcs |
TIMER |
Throughput of master RPC calls. This metrics indicates how busy the master is serving client and worker requests |
Master.UfsJournalCatchupTimer |
TIMER |
The timer statistics of journal catchupOnly valid when ufs journal is used. This provides a summary of how long a standby master takes to catch up with primary master, and should be monitored if master transition takes too long |
Master.UfsJournalFailureRecoverTimer |
TIMER |
The timer statistics of ufs journal failure recover |
Master.UfsJournalInitialReplayTimeMs |
GAUGE |
The process time of the ufs journal initial replay.Only valid when ufs journal is used. It records the time it took for the very first journal replay. Use this metric to monitor when your master boot-up time is high。 |
Master.UfsStatusCacheChildrenSize |
COUNTER |
Total number of UFS file metadata cached. The cache is used during metadata sync. |
Master.UfsStatusCacheSize |
COUNTER |
Total number of Alluxio paths being processed by the metadata sync prefetch thread pool. |
Master.UniqueBlocks |
GAUGE |
Total number of unique blocks in Alluxio |
Master.UnmountOps |
COUNTER |
Total number of Unmount operations |