serverstatus

package
v0.0.0-...-b77287d Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Dec 12, 2016 License: Apache-2.0 Imports: 2 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type Asserts

type Asserts struct {
	Regular   uint `bson:"regular,omitempty"              json:"regular,omitempty"`
	Warning   uint `bson:"warning,omitempty"              json:"warning,omitempty"`
	Msg       uint `bson:"msg,omitempty"                  json:"msg,omitempty"`
	User      uint `bson:"user,omitempty"                 json:"user,omitempty"`
	Rollovers uint `bson:"rollovers,omitempty"            json:"rollovers,omitempty"`
}

Asserts is the 'asserts' key of serverStatus output

type Async

type Async struct {
	NumberOfAllocationStateRaces              uint `bson:"number of allocation state races" json:"number_of_allocation_state_races,omitempty,omitempty"`
	NumberOfOperationSlotsViewedForAllocation uint `` /* 129-byte string literal not displayed */
	CurrentWorkQueueLength                    uint `bson:"current work queue length" json:"current_work_queue_length,omitempty,omitempty"`
	NumberOfFlushCalls                        uint `bson:"number of flush calls" json:"number_of_flush_calls,omitempty,omitempty"`
	NumberOfTimesOperationAllocationFailed    uint `bson:"number of times operation allocation failed" json:"number_of_times_operation_allocation_failed,omitempty"`
	MaximumWorkQueueLength                    uint `bson:"maximum work queue length" json:"maximum_work_queue_length,omitempty"`
	NumberOfTimesWorkerFoundNoWork            uint `bson:"number of times worker found no work" json:"number_of_times_worker_found_no_work,omitempty"`
	TotalAllocations                          uint `bson:"total allocations" json:"total_allocations,omitempty"`
	TotalCompactCalls                         uint `bson:"total compact calls" json:"total_compact_calls,omitempty"`
	TotalInsertCalls                          uint `bson:"total insert calls" json:"total_insert_calls,omitempty"`
	TotalRemoveCalls                          uint `bson:"total remove calls" json:"total_remove_calls,omitempty"`
	TotalSearchCalls                          uint `bson:"total search calls" json:"total_search_calls,omitempty"`
	TotalUpdateCalls                          uint `bson:"total update calls" json:"total_update_calls,omitempty"`
}

Async ...

type BackgroundFlushing

type BackgroundFlushing struct {
	Flushes      uint      `bson:"flushes,omitempty"        json:"flushes,omitempty"`
	TotalMs      uint      `bson:"total_ms,omitempty"       json:"total_ms,omitempty"`
	AverageMs    float64   `bson:"average_ms,omitempty"     json:"avg_ms,omitempty"`
	LastMs       uint      `bson:"last_ms,omitempty"        json:"last_ms,omitempty"`
	LastFinished time.Time `bson:"last_finished,omitempty"  json:"last_finished,omitempty"`
}

BackgroundFlushing is the 'backgroundFlushing' key of serverStatus output

type BlockManager

type BlockManager struct {
	MappedBytesRead  uint `bson:"mapped bytes read" json:"mapped_bytes_read,omitempty"`
	BytesRead        uint `bson:"bytes read" json:"bytes_read,omitempty"`
	BytesWritten     uint `bson:"bytes written" json:"bytes_written,omitempty"`
	MappedBlocksRead uint `bson:"mapped blocks read" json:"mapped_blocked_read,omitempty"`
	BlocksPreLoaded  uint `bson:"blocks pre-loaded" json:"blocks_pre_loaded,omitempty"`
	BlocksRead       uint `bson:"blocks read" json:"blocks_read,omitempty"`
	BlocksWritten    uint `bson:"blocks written" json:"blocks_written,omitempty"`
}

BlockManager ...

type Cache

type Cache struct {
	TrackedDirtyBytesInTheCache                         uint `bson:"tracked dirty bytes in the cache" json:"tracked_dirty_bytes_in_the_cache,omitempty"`
	BytesCurrentlyInTheCache                            uint `bson:"bytes currently in the cache" json:"bytes_currently_in_the_cache,omitempty"`
	MaximumBytesConfigured                              uint `bson:"maximum bytes configured" json:"maximum_bytes_configured,omitempty"`
	BytesReadIntoCache                                  uint `bson:"bytes read into cache" json:"bytes_read_into_cache,omitempty"`
	BytesWrittenFromCache                               uint `bson:"bytes written from cache" json:"bytes_written_from_cache,omitempty"`
	PagesEvictedByApplicationThreads                    uint `bson:"pages evicted by application threads" json:"pages_evicted_by_application_threads,omitempty"`
	CheckpointBlockedPageEviction                       uint `bson:"checkpoint blocked page eviction" json:"checkpoint_blocked_page_eviction,omitempty"`
	UnmodifiedPagesEvicted                              uint `bson:"unmodified pages evicted" json:"unmodified_pages_evicted,omitempty"`
	PageSplitDuringEvictionDeepenedTheTree              uint `bson:"page split during eviction deepened the tree" json:"page_split_during_eviction_deepened_the_tree,omitempty"`
	ModifiedPagesEvicted                                uint `bson:"modified pages evicted" json:"modified_pages_evicted,omitempty"`
	PagesSelectedForEvictionUnableToBeEvicted           uint `bson:"pages selected for eviction unable to be evicted" json:"pages_selected_for_eviction_unable_to_be_evicted,omitempty"`
	PagesEvictedBecauseTheyExceededTheInMemoryMaximum   uint `` /* 139-byte string literal not displayed */
	PagesEvictedBecauseTheyHadChainsOfDeletedItems      uint `` /* 133-byte string literal not displayed */
	FailedEvictionOfPagesThatExceededTheInMemoryMaximum uint `` /* 145-byte string literal not displayed */
	HazardPointerBlockedPageEviction                    uint `bson:"hazard pointer blocked page eviction" json:"hazard_pointer_blocked_page_eviction,omitempty"`
	InternalPagesEvicted                                uint `bson:"internal pages evicted" json:"internal_pages_evicted,omitempty"`
	MaximumPageSizeAtEviction                           uint `bson:"maximum page size at eviction" json:"max_page_size_at_eviction,omitempty"`
	EvictionServerCandidateQueueEmptyWhenToppingUp      uint `` /* 131-byte string literal not displayed */
	EvictionServerCandidateQueueNotEmptyWhenToppingUp   uint `` /* 139-byte string literal not displayed */
	EvictionServerEvictingPages                         uint `bson:"eviction server evicting pages" json:"eviction_server_evicting_pages,omitempty"`
	EvictionServerPopulatingQueueButNotEvictingPages    uint `` /* 136-byte string literal not displayed */
	EvictionServerUnableToReachEvictionGoal             uint `bson:"eviction server unable to reach eviction goal" json:"eviction_server_unable_to_reach_eviction_goal,omitempty"`
	PagesSplitDuringEviction                            uint `bson:"pages split during eviction" json:"pages_split_during_eviction,omitempty"`
	PagesWalkedForEviction                              uint `bson:"pages walked for eviction" json:"pages_walked_for_eviction,omitempty"`
	EvictionWorkerThreadEvictingPages                   uint `bson:"eviction worker thread evicting pages" json:"eviction_worker_thread_evicting_pages,omitempty"`
	InMemoryPageSplits                                  uint `bson:"in-memory page splits" json:"in_memory_page_splits,omitempty"`
	PercentageOverhead                                  uint `bson:"percentage overhead" json:"percentage_overhead,omitempty"`
	TrackedDirtyPagesInTheCache                         uint `bson:"tracked dirty pages in the cache" json:"tracked_dirty_pages_in_the_cache,omitempty"`
	PagesCurrentlyHeldInTheCache                        uint `bson:"pages currently held in the cache" json:"pages_currently_held_in_the_cache,omitempty"`
	PagesReadIntoCache                                  uint `bson:"pages read into cache" json:"pages_read_into_cache,omitempty"`
	PagesWrittenFromCache                               uint `bson:"pages written from cache" json:"pages_written_from_cache,omitempty"`
}

Cache ...

type ConcurrentTransactions

type ConcurrentTransactions struct {
	Write struct {
		Out          uint `bson:"out" json:"out,omitempty"`
		Available    uint `bson:"available" json:"available,omitempty"`
		TotalTickets uint `bson:"totalTickets" json:"total_tickets,omitempty"`
	} `bson:"write" json:"write,omitempty"`

	Read struct {
		Out          uint `bson:"out" json:"out,omitempty"`
		Available    uint `bson:"available" json:"available,omitempty"`
		TotalTickets uint `bson:"totalTickets" json:"total_tickets,omitempty"`
	} `bson:"read" json:"read,omitempty"`
}

ConcurrentTransactions ...

type Connection

type Connection struct {
	PThreadMutexConditionWaitCalls       uint `bson:"pthread mutex condition wait calls" json:"pthread_mutex_condition_wait_calls,omitempty"`
	FilesCurrentlyOpen                   uint `bson:"files currently open" json:"files_currently_open,omitempty"`
	MemoryAllocations                    uint `bson:"memory allocations" json:"memory_allocations,omitempty"`
	MemoryFrees                          uint `bson:"memory frees" json:"memory_frees,omitempty"`
	MemoryReAllocations                  uint `bson:"memory re-allocations" json:"memory_re_allocations,omitempty"`
	TotalReadIOs                         uint `bson:"total read I/Os" json:"total_read_IOs,omitempty"`
	PThreadMutexSharedLockReadLockCalls  uint `bson:"pthread mutex shared lock read-lock calls" json:"pthread_mutex_shared_lock_read_lock_calls,omitempty"`
	PThreadMutexSharedLockWriteLockCalls uint `bson:"pthread mutex shared lock write-lock calls" json:"pthread_mutex_shared_lock_write_lock_calls,omitempty"`
	TotalWriteIOs                        uint `bson:"total write I/Os" json:"total_write_IOs,omitempty"`
}

Connection ...

type Connections

type Connections struct {
	Current      uint   `bson:"current,omitempty"       json:"current,omitempty"`
	Available    uint   `bson:"available,omitempty"     json:"available,omitempty"`
	TotalCreated uint64 `bson:"totalCreated,omitempty"  json:"total_created,omitempty"`
}

Connections is the 'connections' key of serverStatus output

type Cursor

type Cursor struct {
	TimedOut uint64 `bson:"timedOut,omitempty"      json:"timed_out,omitempty"`
	Open     struct {
		NoTimeout uint64 `bson:"noTimeout,omitempty"   json:"no_timeout,omitempty"`
		Pinned    uint64 `bson:"pinned,omitempty"      json:"pinned,omitempty"`
		Total     uint64 `bson:"total,omitempty"       json:"total,omitempty"`
	} `bson:"open,omitempty" json:"open,omitempty"`
}

Cursor ...

type DataHandle

type DataHandle struct {
	ConnectionDHandlesSwept       uint `bson:"connection dhandles swept" json:"connection_d_handles_swept,omitempty"`
	ConnectionCandidateReferences uint `bson:"connection candidate references" json:"connection_candidate_referenced,omitempty"`
	ConnectionSweeps              uint `bson:"connection sweeps" json:"connection_sweeps,omitempty"`
	ConnectionsTimeOfDeathSets    uint `bson:"connection time-of-death sets" json:"connection_time_of_death_sets,omitempty"`
	SessionDHandlesSwept          uint `bson:"connection dhandles swept" json:"connection_d_handles_swept,omitempty"`
	SessionSweepAttempts          uint `bson:"session sweep attempts" json:"session_sweep_attempts,omitempty"`
}

DataHandle ...

type Document

type Document struct {
	Deleted  uint64 `bson:"deleted,omitempty"  json:"deleted,omitempty"`
	Inserted uint64 `bson:"inserted,omitempty" json:"inserted,omitempty"`
	Returned uint64 `bson:"returned,omitempty" json:"returned,omitempty"`
	Updated  uint64 `bson:"updated,omitempty"  json:"updated,omitempty"`
}

Document ...

type Dur

type Dur struct {
	Commmits           uint `bson:"commits,omitempty"             json:"commits,omitempty"`
	JournaledMB        uint `bson:"journaledMB,omitempty"         json:"journaled_mb,omitempty"`
	WriteToDataFilesMB uint `bson:"writeToDataFilesMB,omitempty"  json:"write_to_data_files_mb,omitempty"`
	Compression        uint `bson:"compression,omitempty"         json:"compression,omitempty"`
	CommitsInWriteLock uint `bson:"commitsInWriteLock,omitempty"  json:"commits_in_write_lock,omitempty"`
	EarlyCommits       uint `bson:"earlyCommits,omitempty"        json:"early_commits,omitempty"`

	TimeMS struct {
		Dt                 uint `bson:"dt,omitempty"                   json:"dt,omitempty"`
		PrepLogBuffer      uint `bson:"prepLogBuffer,omitempty"        json:"prep_log_buffer,omitempty"`
		WriteToJournal     uint `bson:"writeToJournal,omitempty"       json:"write_to_journal,omitempty"`
		RemapPrivateView   uint `bson:"remapPrivateView,omitempty"     json:"remap_private_view,omitempty"`
		Commits            uint `bson:"commits,omitempty"              json:"commits,omitempty"`
		CommitsInWriteLock uint `bson:"commitsInWriteLock,omitempty"   json:"commits_in_write_lock,omitempty"`
	} `bson:"timeMs,omitempty" json:"time_ms,omitempty"`
}

Dur is the 'dur' key of serverStatus output

type ExtraInfo

type ExtraInfo struct {
	Note       string `bson:"note,omitempty"          json:"note,omitempty"`
	PageFaults uint   `bson:"page_faults,omitempty"   json:"page_faults,omitempty"`
	// unix systems only
	HeapUsageBytes uint64 `bson:"heap_usage_bytes,omitempty" json:"heap_usage_bytes,omitempty"`
}

ExtraInfo is the 'extraInfo' key of serverStatus output

type GetLastError

type GetLastError struct {
	WTime struct {
		Num         uint `bson:"num,omitempty" json:"num,omitempty"`
		TotalMillis uint `bson:"totalMillis,omitempty" json:"total_ms,omitempty"`
	} `bson:"wtime,omitempty" json:"wtime,omitempty"`
	WTimeouts uint64 `bson:"wtimeouts,omitempty" json:"write_timeouts,omitempty"`
}

GetLastError ...

type GlobalLock

type GlobalLock struct {
	TotalTime    uint64 `bson:"totalTime,omitempty" json:"total_time,omitempty"`
	CurrentQueue struct {
		Total   uint `bson:"total,omitempty"   json:"total,omitempty"`
		Readers uint `bson:"readers,omitempty" json:"readers,omitempty"`
		Writers uint `bson:"writers,omitempty" json:"writers,omitempty"`
	} `bson:"currentQueue,omitempty" json:"current_queue,omitempty"`
	ActiveClients struct {
		Total   uint `bson:"total,omitempty"   json:"total,omitempty"`
		Readers uint `bson:"readers,omitempty" json:"readers,omitempty"`
		Writers uint `bson:"writers,omitempty" json:"writers,omitempty"`
	} `bson:"activeClients,omitempty" json:"active_clients,omitempty"`
}

GlobalLock is the 'globalLock' key of serverStatus output

type LSM

type LSM struct {
	SleepForLSMCheckpointThrottle       uint `bson:"sleep for LSM checkpoint throttle" json:"sleep_for_lsm_checkpoint_throttle,omitempty"`
	SleepForLSMMergeThrottle            uint `bson:"sleep for LSM merge throttle" json:"sleep_for_lsm_merge_throttle,omitempty"`
	RowsMergedInAnLSMTree               uint `bson:"rows merged in an LSM tree" json:"rows_merged_in_an_lsm_tree,omitempty"`
	ApplicationWorkUnitsCurrentlyQueued uint `bson:"application work units currently queued" json:"application_work_units_currently_queued,omitempty"`
	MergeWorkUnitsCurrentlyQueued       uint `bson:"merge work units currently queued" json:"merge_work_units_currently_queued,omitempty"`
	TreeQueueHitMaximum                 uint `bson:"tree queue hit maximum" json:"tree_queue_hit_maximum,omitempty"`
	SwitchWorkUnitsCurrentlyQueued      uint `bson:"switch work units currently queued" json:"switch_work_units_currently_queued,omitempty"`
	TreeMaintenanceOperationsScheduled  uint `bson:"tree maintenance operations scheduled" json:"tree_maintenance_operations_scheduled,omitempty"`
	TreeMaintenanceOperationsDiscarded  uint `bson:"tree maintenance operations discarded" json:"tree_maintenance_operations_discarded,omitempty"`
	TreeMaintenanceOperationsExecuted   uint `bson:"tree maintenance operations executed" json:"tree_operations_executed,omitempty"`
}

LSM ...

type LockMode

type LockMode struct {
	R  uint64 `bson:"r,omitempty" json:"intent_shared_lock,omitempty"`
	RR uint64 `bson:"R,omitempty" json:"shared_lock,omitempty"`
	W  uint64 `bson:"w,omitempty" json:"intent_exclusive_lock,omitempty"`
	WW uint64 `bson:"W,omitempty" json:"exclusive_lock,omitempty"`
}

LockMode ...

type LockType

type LockType struct {
	AcquireCount        LockMode `bson:"acquireCount,omitempty" json:"acquire_count,omitempty"`
	AcquireWaitCount    LockMode `bson:"acquireWaitCount,omitempty" json:"acquire_wait_count,omitempty"`
	TimeAcquiringMicros LockMode `bson:"timeAcquiringMicros,omitempty" json:"time_acquiring_micros,omitempty"`
	DeadLockCount       LockMode `bson:"deadLockCount,omitempty" json:"dead_lock_count,omitempty"`
}

LockType ..

type Locks

type Locks struct {
	Global        LockType `bson:"Global,omitempty" json:"global,omitempty"`
	MMAPV1Journal LockType `bson:"MMAPV1Journal,omitempty" json:"mmap_v1_journal,omitempty"`
	Database      LockType `bson:"Database,omitempty" json:"database,omitempty"`
	Collection    LockType `bson:"Collection,omitempty" json:"collection,omitempty"`
	Metadata      LockType `bson:"Metadata,omitempty" json:"metadata,omitempty"`
	Oplog         LockType `bson:"oplog,omitempty" json:"oplog,omitempty"`
}

Locks is the 'locks' key of serverStatus output

type Log

type Log struct {
	LogBufferSizeIncreases                       uint `bson:"log buffer size increases" json:"log_buff_size_increases,omitempty"`
	TotalLogBufferSize                           uint `bson:"total log buffer size" json:"total_log_buffer_size,omitempty"`
	LogBytesOfPayLoadData                        uint `bson:"log bytes of payload data" json:"load_bytes_of_payload_data,omitempty"`
	LogBytesWritten                              uint `bson:"log bytes written" json:"log_bytes_written,omitempty"`
	YieldsWaitingForPreviousLogFileClose         uint `bson:"yields waiting for previous log file close" json:"yields_waiting_for_previous_log_file_close,omitempty"`
	TotalSizeOfCompressedRecords                 uint `bson:"total size of compressed records" json:"total_size_of_compressed_records,omitempty"`
	TotalInMemorySizeOfCompressedRecords         uint `bson:"total in-memory size of compressed records" json:"total_in_memory_size_of_compressed_records,omitempty"`
	LogRecordsTooSmallToCompress                 uint `bson:"log records too small to compress" json:"log_records_too_small_to_compress,omitempty"`
	LogRecordsNotCompressed                      uint `bson:"log records not compressed" json:"log_records_not_compressed,omitempty"`
	LogRecordsCompressed                         uint `bson:"log records compressed" json:"log_records_compressed,omitempty"`
	MaximumLogFileSize                           uint `bson:"maximum log file size" json:"max_log_file_size,omitempty"`
	PreAllocatedLogFilesPrepared                 uint `bson:"pre-allocated log files prepared" json:"pre_allocated_log_files_prepared,omitempty"`
	NumberOfPreAllocatedLogFilesToCreate         uint `bson:"number of pre-allocated log files to create" json:"number_of_pre_allocated_log_files_to_create,omitempty"`
	PreAllocatedLogFilesUsed                     uint `bson:"pre-allocated log files used" json:"pre_allocated_log_files_used,omitempty"`
	LogReadOperations                            uint `bson:"log read operations" json:"log_read_operations,omitempty"`
	LogReleaseAdvancesWriteLSN                   uint `bson:"log release advances write LSN" json:"log_release_advances_write_lsn,omitempty"`
	RecordsProcessedByLogScan                    uint `bson:"records processed by log scan" json:"records_processed_by_log_scan,omitempty"`
	LogScanRecordsRequiringTwoReads              uint `bson:"log scan records requiring two reads" json:"log_scan_records_requiring_two_reads,omitempty"`
	LogScanOperations                            uint `bson:"log scan operations" json:"log_scan_operations,omitempty"`
	ConsolidatedSlotClosures                     uint `bson:"consolidated slot closures" json:"consolidated slot closures,omitempty"`
	LoggingBytesConsolidated                     uint `bson:"logging bytes consolidated" json:"logging_bytes_consolidated,omitempty"`
	ConsolidatedSlotJoins                        uint `bson:"consolidated slot joins" json:"consolidated_slot_joins,omitempty"`
	ConsolidatedSlotJoinsRaces                   uint `bson:"consolidated slot joins races" json:"consolidated_slot_joins_races,omitempty"`
	SlotsSelectedForSwitchingThatWereUnavailable uint `bson:"slots selected for switching that were unavailable" json:"slots_selected_for_switching_that_were_unavailable,omitempty"`
	RecordSizeExceededMaximum                    uint `bson:"record size exceeded maximum" json:"record_size_exceeded_maximum,omitempty"`
	FailedToFindASlotLargeEnoughForRecord        uint `bson:"failed to find a slot large enough for record" json:"failed_to_find_a_slot_large_enough_for_record,omitempty"`
	ConsolidatedSlotJoinTransitions              uint `bson:"consolidated slot join transitions" json:"consolidated slot join transitions,omitempty"`
	LogSyncOperations                            uint `bson:"log sync operations" json:"log_sync_operations,omitempty"`
	LogSyncDirOperations                         uint `bson:"log sync_dir operations" json:"log_sync_dir_operations,omitempty"`
	LogWriteOperations                           uint `bson:"log write operations" json:"log_write_operations,omitempty"`
}

Log ...

type Mem

type Mem struct {
	Bits              uint `bson:"bits,omitempty"                  json:"bits,omitempty"`
	Resident          uint `bson:"resident,omitempty"              json:"resident,omitempty"`
	Virtual           uint `bson:"virtual,omitempty"               json:"virtual,omitempty"`
	Supported         bool `bson:"supported,omitempty"             json:"supported,omitempty"`
	Mapped            uint `bson:"mapped,omitempty"                json:"mapped,omitempty"`
	MappedWithJournal uint `bson:"mappedWithJournal,omitempty"     json:"mapped_with_journal,omitempty"`
}

Mem is the 'mem' key of serverStatus output

type Metrics

type Metrics struct {
	Cursor        `bson:"cursor,omitempty" json:"cursor,omitempty"`
	Document      `bson:"document,omitempty" json:"document,omitempty"`
	GetLastError  `bson:"getLastError,omitempty" json:"get_last_error,omitempty"`
	Operation     `bson:"operation,omitempty" json:"operation,omitempty"`
	QueryExecutor `bson:"queryExecutor,omitempty" json:"query_executor,omitempty"`
	Record        `bson:"record,omitempty" json:"record,omitempty"`
	MetricsRepl   `bson:"repl,omitempty" json:"repl,omitempty"`
	Storage       `bson:"storage,omitempty" json:"storage,omitempty"`
	TTL           `bson:"ttl,omitempty" json:"ttl,omitempty"`
}

Metrics is the 'metrics' key of serverStatus output

type MetricsRepl

type MetricsRepl struct {
	Executor struct {
		Counters struct {
			EventCreated       uint `bson:"eventCreated,omitempty" json:"event_created,omitempty"`
			EventWait          uint `bson:"eventWait,omitempty" json:"event_wait,omitempty"`
			Cancels            uint `bson:"waits,omitempty" json:"waits,omitempty"`
			ScheduledNetCmd    uint `bson:"scheduledNetCmd,omitempty" json:"scheduled_net_command,omitempty"`
			ScheduledDBWork    uint `bson:"scheduledDBWork,omitempty" json:"scheduled_db_work,omitempty"`
			ScheduledXclWork   uint `bson:"scheduledXclWork,omitempty" json:"scheduled_xcl_work,omitempty"`
			ScheduledWorkAt    uint `bson:"scheduledWorkAt,omitempty" json:"scheduled_work_at,omitempty"`
			ScheduledWork      uint `bson:"scheduledWork,omitempty" json:"scheduled_work,omitempty"`
			SchedulingFailures uint `bson:"schedulingFailures,omitempty" json:"scheduling_failures,omitempty"`
		} `bson:"counters,omitempty" json:"counters,omitempty"`
		Queues struct {
			NetworkInProgress   uint `bson:"networkInProgress,omitempty" json:"network_in_progress,omitempty"`
			DBWorkInProgress    uint `bson:"dbWorkInProgress,omitempty" json:"db_work_in_progress,omitempty"`
			ExclusiveInProgress uint `bson:"exclusiveInProgress,omitempty" json:"exclusive_in_progress,omitempty"`
			Sleepers            uint `bson:"sleepers,omitempty" json:"sleepers,omitempty"`
			Ready               uint `bson:"ready,omitempty" json:"ready,omitempty"`
			Free                uint `bson:"free,omitempty" json:"free,omitempty"`
		} `bson:"queues,omitempty" json:"queues,omitempty"`
		UnsignaledEvents uint   `bson:"unsignaledEvents,omitempty" json:"unsignaled_events,omitempty"`
		EventWaiters     uint   `bson:"eventWaiters,omitempty" json:"event_waiters,omitempty"`
		ShuttingDown     bool   `bson:"shuttingDown,omitempty" json:"shutting_down,omitempty"`
		NetworkInterface string `bson:"networkInterface,omitempty" json:"network_interface,omitempty"`
	} `bson:"executor,omitempty" json:"executor,omitempty"`
	Apply struct {
		Batches struct {
			Num         uint `bson:"num,omitempty" json:"num,omitempty"`
			TotalMillis uint `bson:"totalMillis,omitempty" json:"total_ms,omitempty"`
		} `bson:"batches,omitempty" json:"batches,omitempty"`
		Ops uint64 `bson:"ops,omitempty" json:"ops,omitempty"`
	} `bson:"apply,omitempty" json:"apply,omitempty"`
	Buffer struct {
		Count        uint64 `bson:"count,omitempty" json:"count,omitempty"`
		MaxSizeBytes uint   `bson:"maxSizeBytes,omitempty" json:"max_size_bytes,omitempty"`
		SizeBytes    uint64 `bson:"sizeBytes,omitempty" json:"sizeBytes,omitempty"`
	} `bson:"buffer,omitempty" json:"buffer,omitempty"`
	Network struct {
		Bytes    uint64 `bson:"bytes,omitempty" json:"bytes,omitempty"`
		GetMores struct {
			Num         uint `bson:"num,omitempty" json:"num,omitempty"`
			TotalMillis uint `bson:"totalMillis,omitempty" json:"total_ms,omitempty"`
		} `bson:"getmores,omitempty" json:"get_mores,omitempty"`
		Ops            uint64 `bson:"ops,omitempty" json:"ops,omitempty"`
		ReadersCreated uint64 `bson:"readersCreated,omitempty" json:"readers_created,omitempty"`
	} `bson:"network,omitempty" json:"network,omitempty"`
	Preload struct {
		Docs struct {
			Num         uint `bson:"num,omitempty" json:"num,omitempty"`
			TotalMillis uint `bson:"totalMillis,omitempty" json:"total_ms,omitempty"`
		} `bson:"docs,omitempty" json:"docs,omitempty"`
		Indexes struct {
			Num         uint `bson:"num,omitempty" json:"num,omitempty"`
			TotalMillis uint `bson:"totalMillis,omitempty" json:"total_ms,omitempty"`
		} `bson:"indexes,omitempty" json:"indexes,omitempty"`
	} `bson:"preload,omitempty" json:"preload,omitempty"`
}

MetricsRepl ...

type Network

type Network struct {
	BytesIn     uint64 `bson:"bytesIn,omitempty"     json:"bytes_in,omitempty"`
	BytesOut    uint64 `bson:"bytesOut,omitempty"    json:"bytes_out,omitempty"`
	NumRequests uint64 `bson:"numRequests,omitempty" json:"num_requests,omitempty"`
}

Network is the 'network' key of serverStatus output

type Operation

type Operation struct {
	FastMod        uint64 `bson:"fastmod,omitempty" json:"fast_mod,omitempty"`
	IDHack         uint64 `bson:"idhack,omitempty" json:"id_hack,omitempty"`
	ScanAndOrder   uint64 `bson:"scanAndOrder,omitempty" json:"scan_and_order,omitempty"`
	WriteConflicts uint64 `bson:"writeConflicts,omitempty" json:"write_conflicts,omitempty"`
}

Operation ...

type OpsCounters

type OpsCounters struct {
	Insert  uint `bson:"insert,omitempty"  json:"insert,omitempty"`
	Query   uint `bson:"query,omitempty"   json:"query,omitempty"`
	Update  uint `bson:"update,omitempty"  json:"update,omitempty"`
	Delete  uint `bson:"delete,omitempty"  json:"delete,omitempty"`
	Getmore uint `bson:"getmore,omitempty" json:"get_more,omitempty"`
	Command uint `bson:"command,omitempty" json:"command,omitempty"`
}

OpsCounters is the 'opscounters' key of serverStatus output

type OpsCountersRepl

type OpsCountersRepl struct {
	Insert  uint `bson:"insert,omitempty"  json:"insert,omitempty"`
	Query   uint `bson:"query,omitempty"   json:"query,omitempty"`
	Update  uint `bson:"update,omitempty"  json:"update,omitempty"`
	Delete  uint `bson:"delete,omitempty"  json:"delete,omitempty"`
	Getmore uint `bson:"getmore,omitempty" json:"get_more,omitempty"`
	Command uint `bson:"command,omitempty" json:"command,omitempty"`
}

OpsCountersRepl is the 'opscountersRepl' key of serverStatus output

type QueryExecutor

type QueryExecutor struct {
	Scanned        uint64 `bson:"scanned,omitempty" json:"scanned,omitempty"`
	ScannedObjects uint64 `bson:"scannedObjects,omitempty" json:"scanned_objects,omitempty"`
}

QueryExecutor ...

type Reconciliation

type Reconciliation struct {
	PageReconciliationCalls            uint `bson:"page reconciliation calls" json:"page_reconciliation_calls,omitempty"`
	PageReconciliationCallsForEviction uint `bson:"page reconciliation calls for eviction" json:"page_reconciliation_calls_for_eviction,omitempty"`
	SplitBytesCurrentlyAwaitingFree    uint `bson:"split bytes currently awaiting free" json:"split_bytes_currently_awaiting_free,omitempty"`
	SplitObjectsCurrentlyAwaitingFree  uint `bson:"split objects currently awaiting free" json:"split_objects_currently_awaiting_free,omitempty"`
}

Reconciliation ...

type Record

type Record struct {
	Moves uint64 `bson:"moves,omitempty" json:"moves,omitempty"`
}

Record ...

type Repl

type Repl struct {
	SetName    string        `bson:"setName,omitempty" json:"set_name,omitempty"`
	SetVersion uint          `bson:"setVersion,omitempty" json:"set_version,omitempty"`
	IsMaster   bool          `bson:"ismaster,omitempty" json:"is_master,omitempty"`
	Secondary  bool          `bson:"secondary,omitempty" json:"secondary,omitempty"`
	Hosts      []string      `bson:"hosts,omitempty" json:"hosts,omitempty"`
	Primary    string        `bson:"primary,omitempty" json:"primary,omitempty"`
	Me         string        `bson:"me,omitempty" json:"me,omitempty"`
	ElectionID bson.ObjectId `bson:"electionId,omitempty" json:"election_id,omitempty"`
	RBid       uint          `bson:"rbid,omitempty" json:"rbid,omitempty"`
	// 3.0 uses key 'slaves'
	Slaves []ReplProgress `bson:"slaves,omitempty,omitempty" json:"replication_progress,omitempty"`
	// Changed in 3.2 to 'replication_progress'
	ReplicationProgress []ReplProgress `bson:"replicationProgress,omitempty,omitempty" json:"replication_progress,omitempty"`
}

Repl ...

type ReplProgress

type ReplProgress struct {
	Rid      bson.ObjectId `bson:"rid,omitempty" json:"rid,omitempty"`
	OpTime   time.Time     `bson:"optime,omitempty" json:"op_time,omitempty"`
	Host     string        `bson:"host,omitempty" json:"host,omitempty"`
	MemberID uint          `bson:"memberID,omitempty" json:"member_id,omitempty"`
}

ReplProgress ...

type ServerStatus

type ServerStatus struct {
	Ok   uint   `bson:"ok,omitempty"                   json:"ok,omitempty"`
	Host string `bson:"host,omitempty"                 json:"host,omitempty"`
	// New in 3.2
	AdvisoryHostFQDNs     []string  `bson:"advisoryHostFQDNs,omitempty"    json:"advisory_host_fqdns,omitempty"`
	Version               string    `bson:"version,omitempty"              json:"version,omitempty"`
	Process               string    `bson:"process,omitempty"              json:"process,omitempty"`
	PID                   uint64    `bson:"pid,omitempty"                  json:"pid,omitempty"`
	Uptime                uint      `bson:"uptime,omitempty"               json:"uptime_sec,omitempty"`
	UptimeMillis          uint64    `bson:"uptimeMillis,omitempty"         json:"uptime_ms,omitempty"`
	UptimeEstimate        uint      `bson:"uptimeEstimate,omitempty"       json:"uptime_estimate,omitempty"`
	LocalTime             time.Time `bson:"localTime,omitempty"            json:"local_time,omitempty"`
	Asserts               `bson:"asserts,omitempty" json:"asserts,omitempty"`
	BackgroundFlushing    `bson:"backgroundFlushing,omitempty" json:"backgroung_flushing,omitempty"`
	Connections           `bson:"connections,omitempty" json:"connections,omitempty"`
	Dur                   `bson:"dur,omitempty" json:"dur,omitempty"`
	ExtraInfo             `bson:"extra_info "json:"extra_info,omitempty"`
	GlobalLock            `bson:"globalLock,omitempty" json:"global_lock,omitempty"`
	Locks                 `bson:"locks,omitempty" json:"locks,omitempty"`
	Network               `bson:"network,omitempty" json:"network,omitempty"`
	OpsCounters           `bson:"opscounters,omitempty" json:"ops_counters,omitempty"`
	OpsCountersRepl       `bson:"opscountersRepl,omitempty" json:"ops_counters_repl,omitempty"`
	Repl                  `bson:"repl,omitempty" json:"repl,omitempty"`
	StorageEngine         `bson:"storageEngine,omitempty" json:"storage_engine,omitempty"`
	WriteBacksBacksQueued bool `bson:"writeBacksQueued,omitempty" json:"write_backs_queued,omitempty"`
	Mem                   `bson:"mem,omitempty" json:"mem,omitempty"`
	Metrics               `bson:"metrics,omitempty" json:"metrics,omitempty"`
	WiredTiger            `bson:"wiredTiger,omitempty" json:"wired_tiger,omitempty"`
}

ServerStatus represents the comprehensive serverStatus output

type Session

type Session struct {
	OpenCursorCount  uint `bson:"open cursor count" json:"open_cursor_count,omitempty"`
	OpenSessionCount uint `bson:"open session count" json:"open_session_count,omitempty"`
}

Session ...

type Storage

type Storage struct {
	FreeList struct {
		Search struct {
			BucketExhausted uint64 `bson:"bucketExhausted,omitempty" json:"bucket_exhausted,omitempty"`
			Requests        uint64 `bson:"requests,omitempty" json:"requests,omitempty"`
			Scanned         uint64 `bson:"scanned,omitempty" json:"scanned,omitempty"`
		} `bson:"search,omitempty" json:"search,omitempty"`
	} `bson:"freelist,omitempty" json:"free_list,omitempty"`
}

Storage ...

type StorageEngine

type StorageEngine struct {
	Name string `bson:"name,omitempty" json:"name,omitempty"`
	// New in 3.2
	SupportsCommittedReads bool `bson:"supportsCommittedReads,omitempty" json:"supports_committed_reads,omitempty"`
	// New in 3.2.6
	Persistent bool `bson:"persistent,omitempty" json:"persistent,omitempty"`
}

StorageEngine is the 'storageEngine' key of serverStatus output

type TTL

type TTL struct {
	DeletedDocuments uint64 `bson:"deletedDocuments,omitempty" json:"deleted_documents,omitempty"`
	Passes           uint64 `bson:"passes,omitempty" json:"passes,omitempty"`
}

TTL ...

type ThreadYield

type ThreadYield struct {
	PageAcquireBusyBlocked     uint `bson:"page acquire busy blocked" json:"page_acquire_busy_blocked,omitempty"`
	PageAcquireEvictionBlocked uint `bson:"page acquire eviction blocked" json:"page_acquire_eviction_blocked,omitempty"`
	PageAcquireLockedBlocked   uint `bson:"page acquire locked blocked" json:"page_acquire_locked_blocked,omitempty"`
	PageAcquireReadBlocked     uint `bson:"page acquire read blocked" json:"page_acquire_read_blocked,omitempty"`
	PageAcquireTimeSleeping    uint `bson:"page acquire time sleeping" json:"page_acquire_time_sleeping,omitempty"`
}

ThreadYield ...

type Transaction

type Transaction struct {
	TransactionBegins                     uint `bson:"transaction begins" json:"transaction_begins,omitempty"`
	TransactionCheckPoints                uint `bson:"transaction checkpoints" json:"tansaction_checkpoints,omitempty"`
	TransactionCheckPointCurrentlyRunning uint `bson:"transaction checkpoint curently running" json:"transaction_checkpoint_currently_running,omitempty"`
	TransactionCheckPointMaxTime          uint `bson:"transaction checkpoint max time (msecs)" json:"transaction_checkpoint_max_time_ms,omitempty"`
	TransactionCheckPointMinTime          uint `bson:"transaction checkpoint min time (msecs)" json:"transaction_checkpoint_min_time_ms,omitempty"`
	TransactionCheckPointMostRecentTime   uint `bson:"transaction checkpoint most recent time (msecs)" json:"transaction_checkpoint_most_recent_time_ms,omitempty"`
	TransactionCheckPointTotalTime        uint `bson:"transaction checkpoint total time (msecs)" json:"transaction_checkpoint_total_time_ms,omitempty"`
	TransactionsCommitted                 uint `bson:"transactions committed" json:"transactions_committed,omitempty"`
	TransactionFailuresDueToCacheOverflow uint `bson:"transaction failures due to chache overflow" json:"transaction_failures_due_to_cache_overflow,omitempty"`
	TransactionRangeOfIDsCurrentlyPinned  uint `bson:"transaction range of IDs currently pinned" json:"transaction_range_of_ids_currently_pinned,omitempty"`
	TransactionsRolledBack                uint `bson:"transactions rolled back" json:"transactions_rolled_back,omitempty"`
}

Transaction ...

type WiredTiger

type WiredTiger struct {
	URI                    string `bson:"uri,omitempty" json:"uri,omitempty"`
	LSM                    `bson:"LSM,omitempty" json:"lsm,omitempty"`
	Async                  `bson:"async,omitempty" json:"async,omitempty"`
	BlockManager           `bson:"block-manager,omitempty" json:"block_manager,omitempty"`
	Cache                  `bson:"cache,omitempty" json:"cache,omitempty"`
	Connection             `bson:"connection,omitempty" json:"connection,omitempty"`
	WiredTigerCursor       `bson:"cursor,omitempty" json:"cursor,omitempty"`
	DataHandle             `bson:"data-handle,omitempty" json:"data_handle,omitempty"`
	Log                    `bson:"log,omitempty" json:"log,omitempty"`
	Reconciliation         `bson:"reconciliation,omitempty" json:"reconciliation,omitempty"`
	Session                `bson:"session,omitempty" json:"session,omitempty"`
	ThreadYield            `bson:"thread-yield,omitempty" json:"thread_yield,omitempty"`
	Transaction            `bson:"transaction,omitempty" json:"transaction,omitempty"`
	ConcurrentTransactions `bson:"concurrentTransactions,omitempty" json:"concurrent_transactions,omitempty"`
}

WiredTiger ...

type WiredTigerCursor

type WiredTigerCursor struct {
	CursorCreateCalls     uint `bson:"cursor create calls" json:"cursor_create_calls,omitempty"`
	CursorInsertCalls     uint `bson:"cursor insert calls" json:"cursor_insert_calls,omitempty"`
	CursorNextCalls       uint `bson:"cursor next calls" json:"cursor_next_calls,omitempty"`
	CursorPrevCalls       uint `bson:"cursor prev calls" json:"cursor_prev_calls,omitempty"`
	CursorRemoveCalls     uint `bson:"cursor remove calls" json:"cursor_remove_calls,omitempty"`
	CursorResetCalls      uint `bson:"cursor reset calls" json:"cursor_reset_calls,omitempty"`
	CursorSearchCalls     uint `bson:"cursor search calls" json:"cursor_search_calls,omitempty"`
	CursorSearchNearCalls uint `bson:"cursor search near calls" json:"cursor_search_near_calls,omitempty"`
	CursorUpdateCalls     uint `bson:"cursor update calls" json:"cursor_update_calls,omitempty"`
}

WiredTigerCursor ...

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL