Perfmon variable
|
Description
|
---|---|
Time (sec)
|
In onetime report: length of the measurement time interval, in seconds. The latest interval is on the right side of the table.
|
TimeMs
|
In a differential report: measurement time interval, in milliseconds. The oldest interval is in the first row of the table.
|
File open
|
File open calls/sec
|
File read
|
File read calls/sec
|
File write
|
File write calls/sec
|
File append
|
File append calls/sec
|
File flush
|
File flush calls/sec
|
File lock
|
File lock calls/sec
|
Cache find
|
Cache fetches/sec
|
Cache read
|
Cache misses/sec
|
Cache write
|
Cache page flushes/sec
|
Cache prefetch
|
Cache prefetched pages/sec
|
Cache prefetch wait
|
Cache waits for prefetched pages/sec
|
Cache preflush
|
Preflushing cache pages/sec
|
Cache LRU write
|
A write from cache is done when performing an LRU replacement. This indicates that the client thread must write one block to disk before reading a new block from the disk because there has not been a free disk block available. A very high value can indicate high I/O load, or it can indicate that I/O preflusher values are not optimal.
|
Cache slot wait
|
This counter indicates that there is concurrent access to the same block and one thread must wait for the other. Depending on the cache configuration, it can also indicate that the mutex count for the cache is not optimal and there are false conflicts. The default mutex count does not cause false conflicts here.
|
Cache slot replace
|
Database cache slot is replaced and old slot is removed.
|
Cache write storage leaf
|
Database cache has written a storage tree leaf page to disk.
|
Cache write storage index
|
Database cache has written a storage tree index page to disk.
|
Cache write bonsai leaf
|
Database cache has written a Bonsai-tree leaf page to disk.
|
Cache write bonsai index
|
Database cache has written a Bonsai-tree index page to disk.
|
Cache preflush bytes
|
Number of bytes written by preflusher before log file is flushed. The counter is reset at each flush.
|
Cache preflush flush
|
Number of preflush calls/sec before log file is flushed.
|
RPC messages
|
Total number of sent messages/sec
|
RPC read
|
Total number of read messages/s
|
RPC write
|
Total number of write messages/sec
|
RPC uncompressed
|
When RPC compression enabled, number of bytes/sec
|
RPC compressed
|
When RPC compression enabled, number of compressed byte/s
|
RPC connected
|
Number of client connect requests
|
RPC disconnected
|
Number of client disconnect requests
|
Com sel empty
|
TCP socket select nil returns/sec
|
Com sel found
|
TCP socket select successes/sec
|
SQL prepare
|
SQL prepare statements/sec
|
SQL execute
|
SQL execute statements/sec
|
SQL fetch
|
SQL fetch statements/sec
|
SQL direct execute
|
SQL execute statements/sec using direct statement execute
|
SQL execute simple
|
Number of simple SQL statement executes
A simple SQL statement is a statement that accesses a single table and does not contain joins, subqueries, function calls, ORDER BY or GROUP BY constructions, and all WHERE conditions are combined with an AND logical operator.
|
SQL execute complex
|
Number of complex SQL executes
|
SQL direct fetch
|
SQL fetch statements/sec using direct statement execute
|
DBE insert
|
Table engine row inserts/sec
|
DBE delete
|
Table engine row deletes /sec
|
DBE update
|
Table engine row updates /sec
|
DBE fetch
|
Table engine row fetches /sec
|
DBE fetch M-table
|
Number of rows fetched from in-memory tables
|
DBE fetch D-table
|
Number of rows fetched from disk-based tables
|
DBE dd operation
|
Server has executed SQL data dictionary operation.
|
Parallel fetch
|
Number of rows fetched using parallel operations
|
Parallel fetch wait
|
Number of waits for user connections when using parallel operations
|
Parallel threads active
|
Number of threads used for parallel operations
|
Proc compile
|
Number of procedure compilations
|
Proc exec
|
Procedure executions/sec
|
Proc SQL prepare
|
Number of SQL prepare calls from a procedure code
|
Proc SQL execute
|
Number of SQL execute calls from a procedure code
|
Proc SQL fetch
|
Number of SQL fetch calls from a procedure code
|
Trig compile
|
Number of trigger compilations
|
Trig exec
|
Trigger executions/sec
|
Trig SQL prepare
|
Number of SQL prepare calls from a trigger code
|
Trig SQL execute
|
Number of SQL execute calls from a trigger code
|
Trig SQL fetch
|
Number of SQL fetch calls from a trigger code
|
SA fetch
|
SA-level row fetches/sec
|
SA insert
|
SA-level row inserts/sec
|
SA delete
|
SA-level row deletes/sec
|
SA update
|
SA-level row updates/sec
|
Trans commit
|
Committed transactions/sec
|
Trans abort
|
Aborted transactions/sec
|
Trans rollback
|
Rolled back transactions/sec
|
Trans readonly
|
Read-only transactions/sec
|
Trans buf
|
Current transaction buffer size
|
Trans buf cleanup
|
Cumulative number of cleanup operations since startup
|
Trans validate
|
Current number of active commit-time validations
|
Trans active
|
Current number of active transactions
|
Trans read level
|
This counter indicates the current transaction read level. This counter value increases all the time. Because the counter value is 32-bit variable, it can have a negative value, but still logically the value is increasing. If the value stays the same for a long time with concurrent write transactions, it indicates that a long transaction is blocking the read level and can cause merge blocking and an increase in the Bonsai tree size.
|
Ind write
|
Index writes/sec
|
Ind nomrg write
|
number of nonmerged rows (committed and uncommitted)
|
Search active
|
Table engine-level active searches.
|
Search replan
|
Number of search replans
A search is replanned when table content is significantly changed. Replan is done to make sure that search plans are optimal for the changed table content.
|
Db size
|
Total database size on disk, in KB
|
Db free size
|
Free space in the database (page level), in KB
|
Mem size
|
Total size of dynamically allocated memory, in KB
|
Mem page alloc
|
Number of explicitly allocated pages
|
Mem page free
|
Number of free pages
|
Merge quickstep
|
Quick merge steps/sec
|
Merge step
|
Full merge steps/sec
|
Merge step (purge)
|
Node split-inflicted merge keys/sec (if enabled)
|
Merge step (user)
|
User thread-activated merge row/sec
|
Merge oper
|
Lower-level merge operations/sec
|
Merge cleanup
|
Transaction buffer cleanup calls/sec (if split purge enabled)
|
Merge active
|
Yes/no (1/0)
|
Merge nomrg write
|
Current number of index entries waiting for merge
|
Merge file write
|
Merge-inflicted file writes/sec
|
Merge file read
|
Merge-inflicted file reads/sec
|
Merge level
|
Current merge level (read level of the oldest active transaction)
|
Backup step
|
Database backup steps/sec (also in netbackup and netcopy)
|
Backup active
|
Yes/no (1/0)
|
Checkpoint active
|
Checkpoint status
Value 0 means checkpoint is not active. Values 1 and above means checkpoint is active; values above 1 indicate the progress of the checkpoint.
|
Checkpoint count
|
Checkpoint serial number from startup
|
Checkpoint file write
|
Checkpoint file writes/sec
|
Checkpoint file read
|
Checkpoint file reads/sec
|
Est read samples
|
Estimator sample refresh call/s
|
Sorter start sort
|
Number of external sorts started
|
Sorter add row
|
Number of rows added to external sorter
|
Sorter fetch row
|
Number of rows read from external sorter
|
Sorter open file
|
Number of files opened/sec in external sorter
|
Sorter activecnt
|
Number of currently active external sorts
|
Sorter waitcnt
|
Number of external sort requests waiting to be started.
|
Sorter wait
|
Number of external sort requests waits/sec.
|
Sorter filecnt
|
Number of temporary files currently used for external sorting.
|
Sorter memblockcnt
|
Number of memory blocks currently used for external sorting.
|
Sorter failed
|
Number of time external sort has failed to start.
|
Sync repl msg forw
|
Replica: forwarded messages/sec
|
Sync repl msg getr
|
Replica: received message replies/sec
|
Sync repl msg exec
|
Replica: executed messages/sec
|
Sync mast msg read
|
Master: message reads/sec
|
Sync mast msg exec
|
Master: message execs/sec
|
Sync mast msg write
|
Master: message writes/sec
|
Sync mast subs
|
Master: refreshes/sec
|
Log write
|
Log record writes/sec
|
Log file write
|
Log block writes/sec
|
Log file write bytes
|
Number of log block writes in bytes before log file is flushed
|
Log nocp write
|
Pending log records since last checkpoint
|
Log size
|
Total size of log file, in KB
|
Log flush (L)
|
Logical log flushes/sec (for example, commit)
|
Log flush (P)
|
Physical log flushes/sec
|
Log grpcommwkup
|
Group commit wakeups/sec
|
Log flush full
|
Log page full flushes/sec
|
Log wait flush
|
Current number of user threads waiting for log operation
|
Log writeq full rec
|
Log writes while log write queue full (in number of records)
|
Log writeq full byt (byte size)
|
Log writes while log write queue full (in bytes)
|
Log writeq records
|
Number of records in current log writer queue.
|
Log writeq bytes
|
Number of bytes in log writer queue.
|
Log writeq pending bytes
|
Number of bytes for the next log writer queue flush.
|
Log availq items
|
Number of records added to available items queue
|
Log writeq add
|
Number of records added to log writer queue.
|
Log writeq write
|
Number of records written from log writer queue to log file.
|
Log writeq items allocated count
|
Number of write queue items in the system
|
Log writeq bytes allocated count
|
Amount of memory in bytes allocated for write queue items in the system
|
Log writeq items freed
|
Internal use only.
|
Log writeq items blocking waits
|
Internal use only.
|
Log writeq items only distribute
|
Internal use only.
|
Log writeq remove abort stmt
|
Number of aborted statements removed from the log queue
|
Perfmon variable
|
Description
|
Log writeq remove abort trx
|
Number of aborted transactions removed from the log queue
|
Log grpcommits
|
Number of transactions in the most recent group commit
Transaction commits are grouped in one log burst which is written to the log file in a single write.
|
Log grpcommits (phase2)
|
Number of HotStandby phase 2 transactions in the most recent group commit.
You can use this counter only in HotStandby setups.
|
HSB operation count
|
Primary/Secondary: transferred log record/sec
|
HSB commit count
|
Primary: commit record/sec
|
HSB packet count
|
Primary: messages/sec
|
HSB flush count
|
Primary/Secondary: message flushes/sec
|
HSB cached bytes
|
Primary/Secondary: current size memory based log buffer, in bytes
|
HSB cached ops
|
Primary/Secondary: current size of the memory-based log buffer, in operations (log records)
|
HSB flusher bytes
|
Number of bytes of the HSB log in the send queue to the Secondary
|
HSB notsent bytes
|
Number of bytes in the HSB log that has been accumulated (for example, during a catchup) and not sent to the Secondary yet
|
HSB grouped acks
|
Secondary: current number of ack groups (physical acks)
|
HSB state
|
Name of the current HSB state
|
HSB wait cpmes
|
Yes/no (1/0) Primary: waiting for checkpoint ack from the Secondary
|
HSB secondary queues
|
Secondary: current number of queues pending processing
|
HSB log reqcount
|
HSB log write requests/sec
|
HSB log waitct
|
HSB log waits-for-write requests/sec
|
HSB log freespc
|
HSB: number of log operations there is space for in the protocol window
|
HSB last catchup recs
|
Size of HSB catchup in number of sent log records
The counter is reset when the catchup is started.
You can use this pmon to monitor the progress of the catchup. After catchup is complete, the value shows the size of the completed catchup.
|
HSB catchup reqcnt
|
HSB log write requests/sec, for catchup
|
HSB catchup waitcnt
|
HSB log waits-for-write requests/sec, for catchup
|
HSB catchup freespc
|
HSB: number of log operations there is space for in the protocol window, for catchup
|
HSB alone freespc
|
Primary: in Primary alone, bytes there is room for in the transaction log
|
HSB grpcommits
|
Number of transactions in the most recent group commit
Transaction commits are grouped in one log burst which is send to Secondary as one packet.
You can only use this counter on the Primary.
|
HSB phase1 wait
|
Internal use only.
|
HSB secondary ops in packet
|
Number of log records the Secondary received from the Primary in the most recent log record packet.
|
HSB secondary trx count
|
Number of open transactions the Secondary has received from the Primary
|
HSB secondary locks
|
Number of row-level locks on the Secondary
|
HSB secondary lock reqs
|
Number of lock requests on the Secondary
|
HSB secondary lock waits
|
Number of lock waits on the Secondary since the server was started
|
HSB secondary op waits
|
Number of times operations (transactions) on the Secondary have been waiting to continue execution
|
HSB secondary buffers
|
Number of buffered log record packets the Secondary has received from the Primary
|
HSB secondary serial mode count
|
Number of times the Secondary parallel executor has switched to serial mode instead of running in parallel
|
HSB secondary dispatch queuelength
|
Size of the most recent dispatch thread (operations to dispatch) on the Secondary
|
Tabcur create
|
Number of internal table cursor calls
|
Tabcur reset full
|
Number of full constraint reset calls in table cursor
|
Tabcur reset smpl
|
Number of simple constraint reset calls in table cursor
|
Tabcur estimate
|
Number of cost estimate calls in table cursor
|
Tabcur cached estimate
|
Number of table cursor cost estimates found from cached estimates
|
Tabcur table scan
|
Number of table scans executed in SQL statements.
A high number of table scans can mean that SQL statements are not executed optimally or some index definitions are missing from tables.
|
Tabcur index access
|
Number of index accesses executed in SQL statements
A high number of index accesses in comparison to number of table scans usually means that SQL statements are properly optimized and correct indexes are defined for tables.
|
Thread count
|
Current number of threads
|
Trans wait readlvl
|
Waits/sec for read level at commit
Trans wait readlvl is a counter that is incremented every time a transaction needs to wait for global read level to become sufficiently high so that the transaction changes become visible (to others) at commit. In regular load situations, this is instantaneous and no wait is needed. In high load situations, a short wait loop might be required.
The value of this counter is never decremented. Minor increments (single digits) during 30 second pmon interval are only an indication of a short high-load situation in the server.
|
Lock ok
|
Successful lock requests/sec
|
Lock timeout
|
Lock timeouts/sec
|
Lock deadlock
|
Deadlocks/s
|
Lock deadlock check
|
Number of lock manager deadlock checks done.
|
Lock deadlock loop
|
Number of lock manager deadlock check loops done.
|
Lock wait
|
Lock waits/sec
|
Lock count
|
Number of locks in lock manager.
|
Dropped search buffers
|
Number of search buffers removed from disk-based table searches because too many buffers were used.
|
Number of search buffers
|
Current number of search buffers used for disk-based tables.
|
NOCHECK operations
|
Internal number of nocheck operations performed.
|
MME cur num of locks
|
Current no. MME locks
|
MME max num of locks
|
Peak number of MME locks (since startup)
|
MME cur num of lock chains
|
Current no. MME hash buckets
|
MME max num of lock chains
|
Peak no. MME hash buckets (since startup)
|
MME longest lock chain path
|
MME: longest hash overflow path
|
MME mem used by tuples
|
MME memory allocated to tuples in kilobytes
|
MME mem used by indexes
|
MME memory allocated to indexes in kilobytes
|
MME mem used by page structs
|
MME memory allocated to the shadow structures in kilobytes
|
MME page splits
|
Number of MME page splits
|
MME page joins
|
Number of MME page joins
|
MME unnec mutexed searches
|
Number of MME rows fetched while unnecessarily in exclusive mode
|
MME nonmatched (RO)
|
Number of MME rows that did not match search criteria fetched in shared mode
|
MME nonmatched (EXCL)
|
Number of MME rows that did not match search criteria fetched in exclusive mode
|
MME inserts with x gate
|
Number of inserts done in exclusive mode. Insert switches from shared mode to exclusive mode for example, when the insert causes index node split.
|
MME deletes with x gate
|
Number of MME deletes performed in exclusive mode
|
MME hotspot protection
|
Number of times an MME search enters exclusive mode to access a hotspot
|
MME index key inserts
|
Number of keys inserted to MME indexes, includes keys inserted during a database recovery (not accurate1)
|
MME index key deletes
|
Number of keys deleted from MME indexes. (not accurate1)
|
MME bnode resizes
|
Number of times a MME bnode has been resized
|
MME vtrie mutex collisions
|
Number of times optimistic mutexing in vtrie has collided (not accurate1, congestion2)
|
MME vtrie version colls
|
Number of times a version check in vtrie has collided (not accurate1, congestion2)
|
MME vtrie vertical splits
|
Number of times a search path in vtrie has been vertically split by a key insert (not accurate1)
|
MME vtrie new branches
|
Number of times a new branch has been added to a vtrie node (not accurate1)
The approximate branching factor of the vtrie can be calculated as
(MME vtrie new branches - MME vtrie branch deletes) / (MME vtrie vertical splits - MME vtrie vertical joins) + 2.
This branching factor is only for the vtrie part of the index, the bnode leaf level branching factor cannot be estimated.
|
MME vtrie vertical joins
|
Number of times a key delete from vtrie has caused a node on the search path to be deleted (not accurate1)
|
MME vtrie branch deletes
|
Number of times a key delete from vtrie has caused a branch to be removed from a vtrie node (not accurate1)
|
MME vtrie search retries
|
Number of vtrie search retries per second
|
MME vtrie insert retries
|
Number of times a vtrie insert has been retried because of a collision (not accurate1, congestion2)
|
MME vtrie delete retries
|
Number of times a vtrie delete has been retried because of a collision (not accurate1, congestion2)
|
MME bnode mutex collisions
|
Number of times bnode accesses have caused a mutex collision (not accurate1, congestion2)
|
MME bnode version colls
|
Number of times bnode accesses have failed because of a version collision (not accurate1, congestion2)
|
MME purge invalidations
|
Number of purge invalidations per second
|
MME ffmem privctx init
|
Internal use only
|
MME ffmem privctx done
|
Internal use only
|
MME ffmem purge
|
How frequently in seconds the purge routine is called
|
MME ffmem purge step
|
How frequently in seconds the purge step routine is called
|
Posted events queue
|
Number of posted events that have not been consummated by the subscribers
|
Index search both
|
Search is done from both the Bonsai tree and the storage tree
|
Index search storage
|
Index search is done from storage tree only
|
B-tree node search keys
|
DBE B tree searches/sec
|
B-tree node search mismatch
|
A search was done by using the mismatch index search structure within a B-tree node. Mismatch index is a search structure where an array of mismatch index positions is built within a B-tree node. This mismatch index is a compact and linear data structure that is used to perform a fast scan over compressed key information to find a key position within the B-tree node. It attempts to optimize the search by using fast access in the processor cache row by packing relevant search information in one to three processor cache pages.
|
B-tree node build mismatch
|
A new mismatch index search structure is built within a B-tree node. Mismatch index is a search structure where an array of mismatch index positions is built within a B-tree node. This mismatch index is a compact and linear data structure that is used to perform a fast scan over compressed key information to find a key position within the B-tree node. It attempts to optimize the search by using fast access in the processor cache row by packing relevant search information in one to three processor cache pages.
|
B-tree node split
|
Number of B-tree node splits/sec
|
B-tree node join
|
Number of joined B-tree nodes
|
B-tree node relocate
|
A B-tree node is relocated. This happens when a block that belongs to a previous checkpoint is changed for the first time. Typically, this value is highest immediately after a checkpoint.
|
B-tree node delete empty
|
An empty B-tree node is deleted.
|
B-tree node storage fill factor
|
|
B-tree node Bonsai fill factor
|
|
B-tree node exclusive
|
Exclusive access to the B-tree is used. This can happen, for example, in a node split case such as when the tree root is split.
|
B-tree key read
|
Normal key value is read from the B-tree.
|
B-tree key read delete
|
Delete mark is read from the B-tree.
|
B-tree key read oldversion
|
Old row version is read from the B-tree.
|
B-tree key read abort
|
A row from an aborted transaction is read from the B-tree. This includes all transactions that were not successfully completed.
|
Bonsai-tree height
|
Current Bonsai tree height in levels.
|
Storage tree height
|
Current storage tree height in levels.
|
B-tree lock node
|
Number of B-tree node lock calls.
|
B-tree lock tree
|
Number of whole B-tree lock calls.
|
B-tree lock full path
|
Number of B-tree full node path lock calls.
|
B-tree lock partial path
|
Number of B-tree partial node path lock calls.
|
B-tree get no lock
|
Number of B-tree no lock calls.
|
B-tree get shared lock
|
Number of B-tree shared lock calls.
|
Pessimistic gate wait
|
Number of waits for pessimistic disk-based table gate.
|
Merge gate wait
|
Number of waits for merge gate.
|
Storage gate wait
|
Number of waits for storage tree gate.
|
Bonsai Gate wait
|
Number of waits for Bonsai-tree gate.
|
Action gate wait
|
Number of action gait waits
|
MME pages gate wait
|
Number of gate waits when accessing pages in MME storage
|
MME index gate wait
|
Number of gate waits when accessing MME index
|
Gate wait
|
There is a wait in a gate object. A gate object is an internal synchronization mechanism.
|
Logreader spm reqcount
|
Logreader log space request/sec
|
Logreader spm waitct
|
Logreader log space waits/sec
|
Logreader spm freespc min
|
Minimum value of log reader space manager free space (number of operations that can be buffered).
Each log reader cursor has its own free space counter; if there are multiple open log reader cursors, the value is the minimum value of free space of all open cursors. If the free space of any log reader cursor is zero, the value of this counter is zero and transaction throttling (slowdown) is enacted.
|
Logreader spm freespc max
|
Maximum value of log reader space manager free space (number of operations that can be buffered). If there are multiple open log reader cursors, the value is the maximum value of free space of all open cursors.
|
Logreader logdata queue len
|
Logreader: number of log record blocks waiting for processing.
|
Logreader record queue len
|
Logreader: number of log records waiting for propagation.
|
Logreader stmt queue len
|
Logreader: number of statements waiting for statement commit/rollback.
|
Logreader open cursors
|
Logreader: number of open cursors to SYS_LOG.
|
Logreader records processed
|
Logreader: number of log records processed/sec.
|
Logreader records sent
|
Logreader: number of log records sent for propagation/sec.
|
Logreader commits processed
|
Logreader: number of commits processed/sec.
|
Logreader commits sent
|
Logreader: number of commits sent to the propagator/sec.
|
Logreader messages sent
|
Logreader: number of wakeup messages to open cursors/sec.
|
Logreader catchup state
|
Logreader catchup state.
|
Logreader catchup queue len
|
Logreader: number of log records in catchup queue.
|
Logreader catchup queue size
|
Logreader: size of the catchup queue, in bytes.
|
Logreader pending queue len
|
Logreader: number of pending log records in the in-memory log buffer.
|
Logreader memcache queue len
|
Logreader: length of the in-memory buffer queue, in operations.
|
Logreader batch queue len
|
Logreader: current number of operations queued for the next batch.
|
Logreader flush batch full
|
Logreader: a full transaction back was flushed from logreader.
|
Logreader flush batch force
|
Logreader: a non-full transaction batch was flushed from logreader.
|
XA trans start
|
Number of XA transactions that have been started
|
XA trans end
|
Number of XA transactions that have ended
|
XA trans resume
|
Number of XA transactions that have been resumed
|
XA trans prepare
|
Number of XA transactions that have been prepared
|
XA trans commit
|
Number of XA transactions that have been committed
|
XA trans rollback
|
Number of XA transactions that have been rolled back
|
XA trans forget
|
Number of XA transactions that have been forgotten
|
XA trans recover
|
Number of XA transactions that have been recovered
|
XA trans active
|
Number of XA transactions that are active at the time of the query
|
SMA connection count
|
Number of SMA connections
|
SMA shared memory used
|
Amount of shared memory used
|
TC wait read level
|
Number of times read operations on the Secondary have been waiting to be executed, when using Transparent Connectivity (TC)
|
DB actiongate lock time, latest
|
Amount of time in milliseconds the last lock lasted
|
DB actiongate lock time, sum
|
Amount of time in milliseconds all locks have lasted since server startup
|
DB actiongate lock count
|
Number of locks since server startup
|
Latency below 1 ms
|
Number of statements for which the latency is below 1 millisecond.
To enable the collection of latency statistics:
1 Start the collection of latency statistics with the command:
ADMIN COMMAND 'perfmon timers start'
2 View the latency statistics with the command:
ADMINCOMMAND 'perfmon latency'
|
Latency below 2 ms
|
Number of statements for which the latency is below 1 millisecond.
|
Latency below 4 ms
|
Number of statements for which the latency is below 2 milliseconds.
|
Latency below 8 ms
|
Number of statements for which the latency is below 4 milliseconds.
|
Latency below 16 ms
|
Number of statements for which the latency is below 16 milliseconds.
|
Latency below 32 ms
|
Number of statements for which the latency is below 32 milliseconds.
|
Latency below 64 ms
|
Number of statements for which the latency is below 64 milliseconds.
|
Latency below 128 ms
|
Number of statements for which the latency is below 128 milliseconds.
|
Latency below 256 ms
|
Number of statements for which the latency is below 256 milliseconds.
|
Latency below 512 ms
|
Number of statements for which the latency is below 512 milliseconds.
|
Latency over 512 ms
|
Number of statements for which the latency is over 512 milliseconds.
|
Time sec
|
Printout time of this pmon in seconds
|
Cache seg remains default contra request
|
Number of cache pages (per second) that are allocated to default (unassigned) segment against request
|
Cache seg remains special contra request
|
Number of cache pages (per second) that are allocated to assigned segments against request
|
Cache seg set default, victim from other
|
Number of cache pages (per second) that came from assigned segment
|
Cache seg set default, victim from self
|
Number of cache pages (per second) that came from the same segment
|
Cache seg set special, victim from other
|
Number of cache pages (per second) that came from other assigned or unassigned segment
|
Cache seg set special, victim from self
|
Number of cache pages (per second) that came from the same assigned segment
|
Cache seg remains default per request
|
Number of cache pages (per second) that are allocated to default (unassigned) segment as requested
|
Cache seg remains special per request
|
Number of cache pages (per second) that are allocated to default assigned segments as requested
|
Cache seg set default, original dropped
|
Number of cache pages in a dropped segment
|
Audit log queue len
|
The current length of the Audit Info log queue
|
Audit log queue wait
|
The number of waits for the Audit Info log once the queue is full
|
Compressed node compress
|
Node compression operation
|
Compressed node recompress insert
|
Insert operation of uncompressed record causes a node recompression
|
Compressed node recompress delete
|
Delete operation may cause a recompression of a node
|
Compressed node decompress
|
The fill-ratio of a node has become low enough to decompress the node
|
Compressed node insert
|
Row inserted to a compressed node
|
Compressed node delete
|
Row deleted from a compressed node
|
Compressed node search mismatch
|
Search operations inside compressed node
|
Compressed node split
|
Splitting a filled compressed node to two compressed nodes
|
Compressed node try join
|
Checking the feasibility of joining two consecutive compressed nodes with low fill ratio to one compressed node. If feasible, will result to a node join.
|
Compressed node join
|
Joining two consecutive compressed nodes with low fill ratio to one compressed node
|
Compressed node bytes in
|
Number of uncompressed bytes going into compression
|
Compressed node bytes out
|
Number of compressed bytes coming out of compression. Compression rate during the interval can be calculated by formula 1 – (Compr bytes out/ Compr bytes in).
|