Monitoring tables

These are very brief descriptions for Adaptive Server monitoring tables. See Reference Manual: Tables for complete information, or the Monitoring Tables Diagram poster for a visual presentation of the tables, columns, and the relationships between tables.

monCachedObject

Stores statistics for all tables, partitions, and indexes with pages currently in a data cache.Columns: CacheID, InstanceID, DBID, IndexID, PartitionID, CachedKB, CacheName, ObjectID, DBName, OwnerUserID, OwnerName, ObjectName, PartitionName, ObjectTypeTotalSizeKB, ProcessesAccessing

monCachePool

Stores statistics for all pools allocated for all data caches. Columns: CacheID, InstanceID, IOBufferSize, AllocatedKB, PhysicalReads, Stalls, PagesTouched, PagesRead, BuffersToMRU, BuffersToLRU, CacheName

monCachedProcedures

Stores statistics for all stored procedures, triggers, and compiled plans currently stored in the procedure cache. Columns: ObjectID, InstanceID, OwnerUID, DBID, PlanID, MemUsageKB, CompileDate, ObjectName, ObjectType, OwnerName, DBName, RequestCnt, TempdbRemapCnt, AvgTempdbRemapTime

monCachedStatement

Stores detailed monitoring information about the statement cache, including information about resources used during the previous executions of a statement, how frequently a statement is executed, the settings in effect for a particular plan, the number of concurrent uses of a statement, and so on. Columns: SSQLID, HashKey, UserID, SUserID, DBID, DBName, CachedDate, LastUsedDate, CurrentUsageCount, StatementSize, MaxUsageCount, SessionSettings, ParallelDegree, QuotedIdentifier, TransactionIsolationLevel, TransactionMode, SAAuthorization, SystemCatalogUpdates, ExecutionMetrics, MetricsCount, MaxElapsedTime, MinElapsedTime, AvgElapsedTime, MaxLIO, MinLIO, AvgLIO, MaxPIO, MinPIO, AvgPIO, NumRecompilesPlanFlushes, NumRecompilesSchemaChanges, MaxPlanSize, MinPlanSize, LastRecompiledDate, UseCount, HasAutoParams

monCIPC

Specific to the Cluster Edition – provides summary figures for total messaging within the cluster, as viewed from the current instance or all instances. Columns: InstanceID, ReceiveCount, TransmitCount, Multicast, Synchronous, ReceiveSoftError, ReceiveHardError, TransmitsSoftError, TransmitHardError, Retransmits, Switches, FailedSwitches, RegularBuffersInUse, FreeRegularBuffers, MaxRegularBuffersInUse, LargeBuffersInUse, FreeLargeBuffers, MaxLargeBuffersInUse

monCIPCEndpoints

Specific to the Cluster Edition – provides a detailed summary, giving traffic data for each subsystem within the cluster instance. Columns: InstanceID, ReceiveCount, TransmitCount, ReceiveBytes, TransmitBytes, ReceiveQ, MaxReceiveQ, DoneQ, MaxDoneQ, MaxRecvQTime, AvgRecvQTime, EndPoint

monCIPCLinks

Specific to the Cluster Edition – monitors the state of the links between instances in the cluster. Columns: InstanceID, LocalInterface, RemoteInterface, PassiveState, PassiveStateAge, ActiveState, ActiveStateAge

monCIPCMesh

Specific to the Cluster Edition – gives summary figures for the mesh of connections, from the current instance to all other instances in the cluster, on a per-instance basis. Columns: InstanceID, FarInstanceID, , Received, Dropped, Transmitted, Resent, Retry, ControlRx, ControlTx, SendQ, MaxSendQ, SentQ, MaxSentQ, MaxSendQTime, AvgSendQTime, Mesh, MinRTT, MaxRTT, AverageRTT

monCLMObjectActivity

Specific to the Cluster Edition – Collects cluster lock information. Columns: InstanceID, DBID, Object_PartitionID, LockRequests, LocalMaster, Waited, Granted, RWConflictWaited, AvgRWConflictWaitTime, MaxRWConflictWaitTime, WWConflictWaited, AvgWWConflictWaitTime, MaxWWConflictWaitTime, ClusterMsgWaits, AvgClusterMsgWaitTime, MaxClusterMsgWaitTime, DowngradeReqRecv, DowngradeReqRecvWithNoBlocker, ClusterDeadlock, Locktype

monClusterCacheManager

Specific to the Cluster Edition – stores diagnostic information about the cluster cache manager daemon running on each instance. monClusterCacheManager reports cluster-wide information on a per-instance basis. Columns: InstanceID, RequestsQueued, RequestsRequeued, RequestsServiced, DiskWrites, SleepCount, DaemonName, TransfersInitiated, Downgrades, Releases, AvgServiceTime, MaxQSize

monCMSFailover

Specific to the Cluster Edition – Tracks the time at which the cluster membership service (CMS) detects the failure, gets a new cluster view, resynchronizes the heartbeat, posts the failure event, and completes the failure event. Columns: InstanceID, FailedInstanceID, FailDetectTime, InitViewTime, FinalViewTime, ResynchHBTime, NotifyFailTime, EventdoneTime

monDataCache

Stores statistics relating to Adaptive Server data caches. Columns: CacheID, InstanceID, RelaxedReplacement, BufferPools, CacheSearches, PhysicalReads, LogicalReads, PhysicalWrites, Stalls, CachePartitions, CacheName

monDBRecovery

Specific to the Cluster Edition – Contains rows from all instances in the cluster and contains rows for every database that contributes to recovery. Columns: DBID, InstanceID, MaxOpenXacts, MaxPFTSEntries, Buckets, LogBTotPages, LogBTotAPFWaited, LogBTotIO, AnlTotRec, AnlPhase1Recs, AnlPhase1RedoRecs, AnlPhase2Recs, AnlPhase2RedoRecs, AnlTotPages, AnlTotAPFWaited, AnlTotIO, RedoOps, RedoOpsNotRedonePFTS, RedoOpsRedonePFTS, RedoOpsRedoneTS, RedoOpsNotRedoneTS, RedoLogTotPages, RedoLogTotAPFWaited, RedoLogTotIO, RedoRecTotPage, RedoRecTotAPFWaited, RedoRecTotIO, UndoRecsUndone, UndoLogTotPages, UndoLogTotAPFWaited, UndoLogTotIO, UndoRecTotPages, UndoRecTotAPFWaited, UndoRedTotIO, DBName, FailedInstanceID, Command, RecType, LobBStartTime, LogBEndTime, AnlStartTime, AnlEndTime, RedoStartTime, RedoEndTime, UndoStartTime, UndoEndTime

monDBRecoveryLRTypes

Specific to the Cluster Edition – Tracks log records seen during recovery. Contains a row for each log record type for which at least one log record was seen by recovery. Columns: DBID ,InstanceID ,NumRecs, LogRecType

monDeadLock

Provides information about deadlocks. Use deadlock pipe max messages to tune the maximum number of messages returned. Columns: DeadLockID, VictimKPID, InstanceID, ResolveTime, ObjectDBID, PageNumber, RowNumber, HeldFamilyId, HeldSPID, HeldKPID, HeldProcDBID, HeldProcedureID, HeldBatchID, HeldContextID, HeldLineNumber, WaitFamilyId, WaitSPID, WaitKPID, WaitTime, ObjectName, HeldUserName, HeldApplName, HeldTranName, HeldLockType, HeldCommand, WaitUserName, WaitLockType, HeldSourceCodeID, WaitSourceCodeID

monDeviceIO

Returns statistical information relating to activity on database devices. Columns: InstanceID, Reads, APFReads, Writes, DevSemaphoreRequests, DevSemaphoreWaits, IOTime, LogicalName, PhysicalName

monEngine

Provides statistics regarding Adaptive Server engines. Columns: EngineNumber, InstanceID, CurrentKPID, PreviousKPID, CPUTime, SystemCPUTime, UserCPUTime, IOCPUTime, IdleCPUTime, Yields, Connections, DiskIOChecks, DiskIOPolled, DiskIOCompleted, MaxOutstandingIOs, ProcessesAffinitied, ContextSwitches, HkgcMaxQSize, HkgcPendingItems, HkgcHWMItems, HkgcOverflows, Status, Starttime, StopTime, AffinitiedToCPU, OSPID

monErrorLog

Returns the most recent error messages from the Adaptive Server error log. Columns: SPID, InstanceID, KPID, FamilyID, EngineNumber, ErrorNumber, Severity, State, Time, ErrorMessage

monFailoverRecovery

Specific to the Cluster Edition – Contains aggregated failover recovery diagnostic information for the cluster lock manager (CLM), database recovery, and cluster membership service (CMS) modules. Columns: InstanceID, ModuleName, FailedInstanceID, StartTime, EndTime

monIOQueue

Provides device I/O statistics displayed as data and log I/O for normal and temporary databases on each device. Columns: InstanceID, IOs, IOTime, LogicalName, IOType

monLicense

Provides a list of all licences currently checked out by the Adaptive Server. Columns: InstanceID, Quantity, Name, Edition, Type, Version, Status, LicenseExpiry, GraceExpiry, LicenseID, Filter, Attributes

monLocks

Returns a list of granted locks and pending lock requests.

Columns: SPID, InstanceID, KPID, DBID, ParentSPID, LockID, Context, DBName, ObjectID, LockState, LockType, LockLevel, WaitTIme, PageNumber, RowNumber, BlockedBy, BlockedState, SourceCodeID

monLogicalCluster

Specific to the Cluster Edition – displays information about the logical clusters currently configured on the system. Columns: LCID, Attributes, ActiveConnections, BaseInstances, ActiveBaseInstances, FailoverInstances, ActiveFailoverInstances, Name, State, DownRoutingMode, FailoverMode, StartupMode, SystemView, Roles, LoadProfile, ActionnRelease, Gather

monLogicalClusterAction

Specific to the Cluster Edition – shows all administrative actions against local clusters from start-up until these actions are released. Columns: Handle, State, LCID, LogicalClusterName, Action, FromInstances, ToInstances, InstancesWaiting, WaitType, StartTime, Deadline, CompleteTime, ConnectionsRemaining, NonMigConnections, NonHAConnections

monLogicalClusterInstance

Specific to the Cluster Edition – Displays information about the many-to-many relationship between instances and logical clusters. Columns: LCID, LogicalClusterName, InstanceID, InstanceName, Type, FailoverGroup, State, ActiveConnections, NonMigConnections, NonHAConnections, LoadScore

monLogicalClusterRoute

Specific to the Cluster Edition – displays information about the configured routes (application, login, and alias bindings). Columns: LCID, LogicalClusterName, RouteType, RouteKey

monNetworkIO

Returns network I/O statistics for all communication between Adaptive Server and client connections. Columns: InstanceID, PacketsSent, PacketsReceived, BytesSent, BytesReceived

monOpenDatabases

Provides state and statistical information pertaining to databases that are currently in the server’s metadata cache. Columns: DBID, InstanceID, BackupInProgress, LastBackupFailed, TransactionLogFull, AppendLogRequests, AppendLogWaits, DBName, BackupStartTime, SuspendedProcesses, QuiesceTag, LastCheckpointTime, LastTranLogDumpTime

monOpenObjectActivity

Provides statistics for all open tables and indexes. Columns: DBID, ObjectID, IndexID, InstanceID, DBName, ObjectName, LogicalReads, PhysicalReads, APFReads, PagesRead, PhysicalWrites, PagesWritten, RowsInserted, RowsDeleted, RowsUpdated, Operations, LockRequests, LockWaits, OptSelectCount, LastOptSelectDate, UsedCount, LastUsedDate, HkgcRequests, HkgcPending, HkgcOverflows, PhysicalLocks, PhsycialLocksRetained, PhysicalLocksRetainWaited, PhysicalLocksDeadlocks, PhysicalLocksWaited, PhysicalLocksPageTransfer, TransferReqWaited, AvgPhysicalLocksWaitTime, AvgTransferReqWaitTime, TotalServiceRequests, PhysicalLocksDowngraded, PagesTransferred, ClusterPageWrites, AvgServiceTime, AvgTimeWaitedOnLocalUsers, AvgTransferSendWaitTime, AvgIOServiceTime, AvgDowngradeServiceTime

monOpenPartitionActivity

Provides information about the use of each open partition on the server. Columns: DBID, ObjectID, IndexID, PartitionID, InstanceID, DBName, ObjectName, PartitionName, LogicalReads, PhysicalReads, APFReads, PagesRead, PhysicalWrites, PagesWritten, RowsInserted, RowsDeleted, RowsUpdated, OptSelectCount, LastOptSelectDate, UsedCount, LastUsedDate, HkgcRequests, HkgcPending, HkgcOverflows, PhysicalLocks, PhsycialLocksRetained, PhysicalLocksRetainWaited, PhysicalLocksDeadlocks, PhysicalLocksWaited, PhysicalLocksPageTransfer, TransferReqWaited, AvgPhysicalLockWaitTime, AvgTransferReqWaitTime, TotalServiceRequests, PhysicalLocksDowngraded, PagesTransferred, ClusterPageWrites, AvgServiceTime, AvgTimeWaitedOnLocalUsers, AvgTransferSendWaitTime, AvgIOServiceTime, AvgDowngradeServiceTime

monPCIBridge

Contains information about the Java PCI Bridge. Columns: InstanceID, Status, ConfiguredSlots, ActiveSlots, ConfiguredPCIMemoryKB, UsedPCIMemoryKB

monPCIEngine

Displays engine information for the PCI Bridge and its plug-ins. Columns: InstanceID, Engine, Status, PLBStatus, NumberofActiveThreads, PLBRequests, PLBwakeupRequests

monPCISlots

Contains information about the plug-in bound to each slot in the PCI Bridge. Columns: InstanceID, Slot, Status, Modulename, engine

monPCM

Specific to the Cluster Edition – Tracks the peer coordination module (PCM) client activities in the cluster, and contains a row for each PCM client. Columns: InstanceID, Sent, Fragments_sent, Fragments_received, Received, Reply, Unicast, Mulicat, Sync, Async, MinBytes, AvgBytes, MaxBytes , MinDialog, AvgDialog, MaxDialog, Dialog, MinTimeSyncApi, AvgTimeSyncApi, MaxTimeSyncApi, MinTimeAsyncApi, AvgTimeAsyncApi, MaxTimeAsyncApi, MinTimeCIPCMsgAlloc, AvgTimeCIPCMsgAlloc, MaxTimeCIPCMsgAlloc, MinTimeCIPCSendCB, AvgTimeCIPCSendCB , MaxTimeCIPCSendCB, MinTimeCIPCUnicastsmsg, AvgTimeCIPCUnicastsmsg, MaxTimeCIPCUnicastsmsg, MinTimeCIPCMulticastsmsg, AvgTimeCIPCMulticastsmsg, MaxTimeCIPCMulticastsmsg, MinTimeClientRecvCB, AvgTimeClientRecvCB, MaxTimeClientRecvCB, ModuleName

monProcedureCache

Returns statistics relating to Adaptive Server procedure cache. Columns: Requests, Loads, Writes, Stalls, InstanceID

monProcedureCacheMemoryUsage

Includes one row for each procedure cache allocator. Columns: InstanceID, AllocatorID, ModuleID, Active, HWM, ChunkHWM, AllocatorName, NumReuseCaused

monProcedureCacheModuleUsage

Includes one row for each module that allocates memory from procedure cache. Columns: InstanceID, ModuleID, Active, HWM, NumPagesReused, ModuleName

monProcess

Provides detailed statistics about processes that are currently executing or waiting. Columns: SPID, InstanceID, KPID, ServerUserID, BatchID, ContextID, LineNumber, SecondsConnected, DBID, EngineNumber, Priority, FamilyID, Login, Application, Command, NumChildren, SecondsWaiting, WaitEventID, BlockingSPID, BlockingXLOID, DBName, EngineGroupName, ExecutionClass, MasterTransactionID

monProcessActivity

Provides detailed statistics about process activity. Columns: SPID, InstanceID, KPID, ServerUserID, CPUTime, WaitTime, PhysicalReads, LogicalReads, PagesRead, PhysicalWrites, PagesWritten, MemUsageKB, LocksHeld, TableAccesses, IndexAccesses, WorkTables, TempDbObjects, ULCBytesWritten, ULCFlushes, ULCFlushFull, ULCMaxUsage, ULCCurrentUsage, Transactions, Commits, Rollbacks

monProcessLookup

Provides identifying information about each process on the server. Columns: SPID, InstanceID, KPID, Login, Application, ClientHost, ClientIP, ClientOSPID

monProcessMigration

Specific to the Cluster Edition – displays information about the connection currently migrating. Columns: SPID, KPID, LogicalCluster, Instance, MigrationLogicalCluster, MigrationInstance, Command

monProcessNetIO

Provides the network I/O activity information for each process. Columns: SPID, InstanceID, KPID, NetworkPacketSize, PacketSent, PacketsReceived, BytesSent, BytesRecieved, NetworkEngineNumber

monProcessObject

Provides statistical information regarding objects currently being accessed by processes. Columns: SPID, InstanceID, KPID, DBID, ObjectID, PartitionID, IndexID, OwnerUserID, LogicalReads, PhysicalReads, PhysicalAPFReads, DBName, ObjectName, PartitionName, ObjectType, PartitionSize

monProcessProcedures

Returns a list of all procedures being executed by processes. Columns: SPID, InstanceID, KPID, DBID, OwnerUID, ObjectID, PlanID, MemUsageKB, CompileDate, ContextID, LineNumber, DBName, OwnerName, ObjectName, ObjectType

monProcessSQLText

Provides the SQL text currently being executed by the process. Columns: SPID, InstanceID, KPID, ServerUserID, BatchID, LineNumber, SequenceInLine, SQLText

monProcessStatement

Provides information about the statement currently executing. Columns: SPID, InstanceID, KPID, DBID, ProcedureID, PlanID, BatchID, ContextID, LineNumber, CPUTime, WaitTime, MemUsageKB, PhysicalReads, LogicalReads, PagesModified, PacketsSent, PacketsReceived, NetworkPacketSize, PlansAltered, RowsAffected, DBName, StartTime

monProcessWaits

Provides a list of all wait events for which current processes on the server are waiting. Columns: SPID, InstanceID, KPID, ServerUserID, WaitEventID, Waits, WaitTime

monProcessWorkerThread

Provides statistics for the activity of each currently configured worker process. Columns: SPID, InstanceID, KPID, ThreadsActive, MaxParallelDegree, MaxScanParallelDegree, ParallelQueries, PlansAltered, FamilyID

monState

Provides information regarding the overall state of Adaptive Server. Columns: InstanceID, LockWaitThreshold, LockWaits, DaysRunning, CheckPoints, NumDeadlocks, Diagnostic Dumps, Connections, MaxRecovery, Transactions, StartDate, CountersCleared

monStatementCache

Provides statistical information about the statement cache. Columns: InstanceID, TotalSizeKB, UsedSizeKB, NumStatements, NumSearches, HitCount, NumInserts, NumRemovals, NumRecompilesSchemaChanges, NumRecompilesPlanFlushes

monSysLoad

Specific to the Cluster Edition – provides trended statistics on a per-engine basis. Columns: InstanceID, EngineNumber, SteadyState, Avg_1min, Avg_5min, Avg_15min, Max_1min, Max_5min, Max_15min, Max_1min_Time, Max_5min_Time, Max_15min_Time, Statistic, Sample, Peak, Peak_time, StatisticID

monSysPlanText

Provides the history of the query plans for recently executed queries. Columns: PlanID, InstanceID, SPID, KPID, BatchID, ContextID, SequenceNumber, DBID, ProcedureID, DBName, PlanText

monSysSQLText

Provides the most recently executed SQL text, or the SQL text currently executing. Columns: SPID, InstanceID, KPID, ServerUserID, BatchID, SequenceInBatch, SQLText

monSysStatement

Provides a history of the most recently executed statements on the server. Columns: SPID, InstanceID, KPID, DBID, ProcedureID, PlanID, BatchID, ContextID, LineNumber, CpuTime, WaitTime, MemUsageKB, PhysicalReads, LogicalReads, PagesModified, PacketsSent, PacketsReceived, NetworkPacketSize, PlansAltered, RowsAffected, ErrorStatus, HashKey, SsqlId, ProcNestLevel, StatementNumber, DBName, StartTime, EndTime

monSysWaits

Provides a server-wide view of the statistics for events on which processes have waited. Columns: InstanceID, WaitEventID, WaitTime, Waits

monSysWorkerThread

Returns server-wide statistics related to worker thread configuration and execution. Columns: InstanceID, ThreadsActive, TotalWorkerThreads, HighWater, ParallelQueries, PlansAltered, WorkerMemory, TotalWorkerMemory, WorkerMemoryHWM, MaxParallelDegree, MaxScanParallelDegree

monTableColumns

Describes all the columns for each monitoring table. Columns: TableID, ColumnID, TypeID, Precision, Scale, Length, Indicators, TableName, ColumnName, TypeName, Description

monTableParameters

Provides a description for all columns in a monitoring table used to optimize query performance for the monitoring tables. Columns: TableID, ParameterID, TypeID, Precision, Scale, Length, TableName, ParameterName, TypeName, Description

monTables

Provides a description of all monitoring tables. Columns: TableID, Columns, Parameters, Indicators, Size, TableName, Description

monTableTransfer

MonTableTransfer provides historical transfer information for tables in Adaptive Server’s active memory. Columns: InstanceID, DBID, TableID, TableName, SequenceID, TrackingID, PercentDone, BeginTime, EndTime, EndCode, TransferFloor, TransferCeiling, RowsSent, BytesSent, Format

monTempdbActivity

Specific to the Cluster Edition – provides statistics for all open local temporary databases, including global system tempdb when the instance is started in tempdb configuration mode. Columns: DBID InstanceID, DBName, AppendLogRequest, AppendLogWaits, LogicalReads, PhysicalReads, APFReads, PagesRead, PhysicalWrites, PagesWritten, LockRequests, LockWaits, CatLockRequests, CatLockWaits, AssignedCnt, SharableTabCnt

monWaitClassInfo

Provides a textual description for all of the wait classes (for example, waiting for a disk read to complete). Columns: WaitClassID, Description

monWaitEventInfo

Provides a textual description for every possible situation where a process is forced to wait within Adaptive Server. Columns: WaitEventID, WaitClassID, Description

monWorkload

Specific to the Cluster Edition – displays the workload score for each logical cluster on each instance according to its load profile. Columns: LCID, InstanceID, LoadProfileID, LoadScore, ConnectionsScore, CpuScore, RunQueueScore, IoLoadScore, EngineScore, UserScore, LogicalClusterName, InstanceName, LoadProfileName

monWorkloadPreview

Specific to the Cluster Edition – provides an estimate of how a load profile impacts the workload score without enabling the profile. Columns: InstanceID, LoadProfileID, LoadScore, ConnectionScore, CpuScore, RunQueueScore, IoLoadScore, EngineScore, UserScore, InstanceName, LoadProfileName

monWorkloadProfile

Specific to the Cluster Edition – displays currently configured workload profiles. Columns: ProfileID, ConnectionsWeight, CpuWeight, RunQueueWeight, IoLoadWeight, EngineWeight, UserWeight, LoginThreshold, DynamicThreshold, Hysteresis, Name, Type

monWorkloadRaw

Specific to the Cluster Edition – provides the raw workload statistics for each instance. You need not have the mon_role role to query this monitor table. Columns: InstanceID, ConnectionsRaw, CpuRaw, RunQueueRaw, IoLoadRaw, EngineRaw, UserRaw, InstanceName