WMI classes (FAST Search Server 2010 for SharePoint)

 

Applies to: FAST Search Server 2010

This topic gives an overview of the available Windows Management Instrumentation (WMI) classes for Microsoft FAST Search Server 2010 for SharePoint.

FAST Search Server 2010 for SharePoint WMI classes

WMI Class - "Indexer"

WMI Class - "CrawlerCollection"

WMI Class - "QRServer"

WMI Class - "Collection"

WMI Class - "DocumentProcessor"

WMI Class - "ContentDistributor"

WMI Class - "IndexingDispatcher"

WMI Class - "WebAnalyzer"

WMI Class - "Crawler"

WMI Class - "Dataset"

WMI Class - "FDispatch"

WMI Class - "IndexerPartition"

WMI Class - "IndexerStatus"

WMI Class - "BEStatistics"

WMI Class - "NodeConfGlobal"

WMI Class – “NodeConfProcess”

WMI Class – “AccessControlCoordinator”

WMI Class – “AccessControlNonCachedRequestAverage”

WMI Class – “AccessControlNonCachedRequestCount”

WMI Class – “AccessControlRequestAverage”

WMI Class – “AccessControlRequestCount”

WMI Class – “DomainWMIProxy”

WMI Class – “PrincipalAliaserWMIProxy”

WMI Class - "Indexer"

Name Description Type

APIOperations

Indicates the total number of API operations (documents indexed and updated) that the indexer has processed.

int

APIOperPerSec

Indicates the average number of processed API operations per second by the indexer.

float

APIPartialUpdateOper

Indicates the number of API operations processed by the indexer that are partial update operations.

int

APIQueueLoad

Shows the current size (in bytes) of the API queue divided by the maximum allowed size of the API queue (in bytes).

float

APIQueueSize

Indicates the number of batches that are currently in the API queue. The API queue is used by the indexer to hold pending operations that are waiting to be persisted.

int

APIRemOperations

Indicates the number of API operations processed by the indexer that are remove operations.

int

APIStatusUpdateOper

Indicates the number of API operations processed by the indexer that are status updates (failed_operations).

int

CachePercentagePart0

Indicates the percentage of the total cache given to partition 0 used by the search process.

int

CachePercentagePart1

Indicates the percentage of the total cache given to partition 1 used by the search process.

int

CachePercentagePart2

Indicates the percentage of the total cache given to partition 2 used by the search process.

int

CachePercentagePart3

Indicates the percentage of the total cache given to partition 3 used by the search process.

int

CachePercentagePart4

Indicates the percentage of the total cache given to partition 4 used by the search process.

int

ColectionsRemoved

Indicates the number of API operations processed by the indexer that are remove collection operations.

int

ColumnId

Indicates which column number the indexer is part of.

int

ColumnRole

Indicates if the indexer is a primary or a backup indexer (fault tolerance).

string

DiskLow

Indicates if the indexer has little disk to work with to persist documents and to build new indices.

int

DiskLowState

Indicates if the indexer is in a state where it has little disk to work with to persist documents and to build new indices.

bool

DocsIndexed

Indicates the number of API operations processed by the indexer that are add or update operations.

int

DocsInIndexer

Indicates the total number of documents in the indexer. This is the current total number of valid documents contained in the docindex of the indexer. The docindex is a mapping to the persisted documents on disk, so it translates the number of valid documents persisted on disk (fixml).

int

ExcludedDocsPart0

Indicates the number of documents on the exclusion list in the currently active index on partition 0. This translates to documents that are in the index, but that should not be searchable (deleted, present in other partitions, etc).

int

ExcludedDocsPart1

Indicates the number of documents on the exclusion list in the currently active index on partition 1. This translates to documents that are in the index but that should not be searchable (deleted, present in other partitions, etc).

int

ExcludedDocsPart2

Indicates the number of documents on the exclusion list in the currently active index on partition 2. This translates to documents that are in the index but that should not be searchable (deleted, present in other partitions, etc).

int

ExcludedDocsPart3

Indicates the number of documents on the exclusion list in the currently active index on partition 3. This translates to documents that are in the index but that should not be searchable (deleted, present in other partitions, etc).

int

ExcludedDocsPart4

Indicates the number of documents on the exclusion list in the currently active index on partition 4. This translates to documents that are in the index but that should not be searchable (deleted, present in other partitions, etc).

int

FailedOperations

Indicates the number of API operations that could not be processed successfully.

int

FixmlDir

Location of the directory where the FiXML is stored. This directory is used by the indexer to persist the new documents to disk. The directory is also used by the indexer processes when building the index itself from disk (FiXML).

string

FixmlFillRate

Indicates an approximation of the ratio between the number of valid documents in a persisted file (FiXML file) and the total number of persisted documents. A value close to 100% means that the files on disk are well compacted together.

float

HeartbeatStatus

Indicates the status of the heartbeat thread: if it is running, suspended or in an unknown state. In a fault tolerant deployment the heartbeat thread periodically checks for the state of the indexer in the column.

string

IndexDir

Indicates where the binary indices are located on disk.

string

IndexecedDocsPerSecPart0

Indicates the average number of documents that are indexed per second in partition 0.

float

IndexecedDocsPerSecPart1

Indicates the average number of documents that are indexed per second in partition 1.

float

IndexecedDocsPerSecPart2

Indicates the average number of documents that are indexed per second in partition 2.

float

IndexecedDocsPerSecPart3

Indicates the average number of documents that are indexed per second in partition 3.

float

IndexecedDocsPerSecPart4

Indicates the average number of documents that are indexed per second in partition 4.

float

IndexingSuspendedState

Indicates if the indexer has currently suspended indexing. This means that the indexer is not creating new indices, even though it might be persisting new documents to disk.

bool

LastBatchSize

Indicates the size (in bytes) of the previous batch processed by the indexer.

int

LastIndexSwitch

Indicates the time (in time_t) when the last index was finalized and activated on the indexer.

int

LastProcDate

Indicates the time when the latest operation was processed by the indexer in the sequence_builder.

string

LastProcOperation

Indicates the identifier of the last operation that was processed by the indexer in the sequence_builder.

string

ManualFTSyncNeeded

Indicates if a manual fault-tolerant sync is needed, and is always set to false.

bool

ManualResetState

Indicates when the indexer is in a reset index state manually performed by the user.

bool

MaxBatchSize

Indicates the size of the largest batch (in bytes) as seen during processing by the indexer.

int

MaxCacheKBPart0

Indicates the maximum cache (in kilobytes) used by the search processes for partition 0.

int

MaxCacheKBPart1

Indicates the maximum cache (in kilobytes) used by the search processes for partition 1.

int

MaxCacheKBPart2

Indicates the maximum cache (in kilobytes) used by the search processes for partition 2.

int

MaxCacheKBPart3

Indicates the maximum cache (in kilobytes) used by the search processes for partition 3.

int

MaxCacheKBPart4

Indicates the maximum cache (in kilobytes) used by the search processes for partition 4.

int

MaxDocsPerSec

Indicates the highest achieved ratio between the number of indexed documents in an index job and the time it took to perform the job.

float

MinDocsPerSec

Indicates the lowest achieved ratio between the number of indexed documents in an index job and the time it took to perform the job.

float

NumDocsInPart0

Indicates the number of searchable documents in the current active index on partition 0.

int

NumDocsInPart1

Indicates the number of searchable documents in the current active index on partition 1.

int

NumDocsInPart2

Indicates the number of searchable documents in the current active index on partition 2.

int

NumDocsInPart3

Indicates the number of searchable documents in the current active index on partition 3.

int

NumDocsInPart4

Indicates the number of searchable documents in the current active index on partition 4.

int

OngoingFTSequenceRecovery

Indicates if the ongoing fault-tolerant sequence recovery is used in order to find out if an indexer is currently recovering operations from other indexers in the column.

bool

PerformingResetIndexState

Indicates if the indexer currently is in a reset index state, meaning that it is indexing documents from disk (file_id), and not performing incremental indexing.

bool

RegFileReceivers

Indicates the number of file receivers currently registered on the indexer. This can apply to both backup indexers and search controllers.

int

RegSearchControllers

Indicates the number of search controllers currently registered on the indexer. These search controllers register to get new indices over from the indexer.

int

RowId

Indicates which row number the indexer is part of.

int

SCtlCurrAlloc

Indicates how many search_controller_stubs are currently allocated by the indexer, and translates how many search_controllers the indexer is communicating with.

int

SCtlTotalAlloc

Indicates how many times a search controller has been allocated on the indexer side. The search_controller_stub is used to communicate with a remote search_controller.

int

SizeOfDocuments

Indicates the total size of documents (in bytes) of all the valid documents persisted to disk (FiXML).

long

TotalIdxRunsPart0

Indicates the total number of times that a new index has been built on partition 0.

int

TotalIdxRunsPart1

Indicates the total number of times that a new index has been built on partition 1.

int

TotalIdxRunsPart2

Indicates the total number of times that a new index has been built on partition 2.

int

TotalIdxRunsPart3

Indicates the total number of times that a new index has been built on partition 3.

int

TotalIdxRunsPart4

Indicates the total number of times that a new index has been built on partition 4.

int

WMI Class - "CrawlerCollection"

Applies to the FAST Search Web crawler only.

Name Description Type

ActiveSites

The number of sites that is being crawled right now.

long

ContentIndexingAdded

The number of ADD operations that is sent to content indexing.

long

ContentIndexingDeleted

The number of DELETE operations that is sent to content indexing.

long

ContentIndexingFailed

The total number of failed operations.

long

ContentIndexingModified

The number of MOD operations that is sent to content indexing.

long

ContentIndexingOperations

The total number of operations that is submitted to content indexing.

long

ContentIndexingSucceeded

The number of operations that is sent to content indexing that succeeded.

long

ContentIndexingUrlschanges

The number of urlschange operations sent to content indexing.

long

DataReadRate

Current network read rate (in bytes per second).

float

DataWriteRate

Current network write rate (in bytes per second).

float

DocRate

Current document download rate (in documents per second).

float

DocsInCrawlerStore

The number of documents (approximate) in the FAST Search Web crawler store.

long

DocSize

Total document size in bytes.

long

DocSizeAverage

Average document size in bytes.

long

DocSizeMaximum

Maximum document size in bytes.

long

DocsSkippedChecksumCache

The number of skipped documents due to the documents being screened by the run-time checksum cache (used for duplicate detection).

long

DocsSkippedChunkError

The number of skipped documents due to problems with chunked encoding. Failure to de-chunk content.

long

DocsSkippedConnectError

The number of skipped documents due to failure to connect to the remote Web server.

long

DocsSkippedConnectTimeout

The number of skipped documents due to a time out of the connection attempt to the remote Web server.

long

DocsSkippedEmptyDocument

The number of skipped documents because their size was 0 bytes.

long

DocsSkippedEncoding

The number of skipped documents due to problems with the document encoding. This typically indicates that there are problems with compressed content.

long

DocsSkippedHeaderExclude

The number of skipped document because they matched the 'exclude_headers' setting in the collection.

long

DocsSkippedHTTPHeader

The number of skipped documents due to errors with HTTP header.

long

DocsSkippedIncomplete

The number of skipped documents because they were incomplete. The Web server did not return the complete document as indicated by the HTTP header.

long

DocsSkippedMIMEType

The number of skipped documents because they did not match the 'allowed_types' setting in the collection.

long

DocsSkippedNetworkError

The number of skipped documents due to network errors.

long

DocsSkippedNoIndex

The number of skipped documents due to containing a META robots No Index tag.

long

DocsSkippedNoIndexRSS

The number of skipped documents because RSS feed indexing was disabled by the 'index_feed' setting.

long

DocsSkippedNoXXXxTarget

The number of skipped documents due to the documents not having a redirect target (but did have a redirect return code returned by the Web server).

long

DocsSkippedOtherError

The number of skipped documents due to other reasons.

long

DocsSkippedTimeout

The number of skipped documents because it took longer time to download them than the 'fetch_timeout' setting allowed.

long

DocsSkippedTooLarge

The number of skipped documents due to exceeding the collection 'cut_off' setting.

long

DocumentsDeleted

The number of documents deleted from the document store.

long

DocumentsDownloaded

The number of documents that were downloaded.

long

DocumentsModified

The number of stored documents that were modified.

long

DocumentsRequested

The number of URIs that the FAST Search Web crawler attempted to download.

long

DocumentsStored

The number of document that were written to the FAST Search Web crawler store.

long

DocumentsUnchanged

The number of documents that were downloaded that were unchanged.

long

DownloadAvgTime

Indicates the average download time.

float

DownloadMaxTime

Indicates the maximum download time.

float

DownloadTotTime

Indicates the total download time.

float

FeedingStatus

Specifies whether content submission to indexing is active (1) or paused (0).

long

FirstUpdateTime

Time of the initial statistics update (timestamp).

long

HTTPResponse200

The number of times the FAST Search Web crawler received the response HTTP 200 (OK).

long

HTTPResponse226

The number of times the FAST Search Web crawler received the response FTP 226 (Successful).

long

HTTPResponse300

The number of times the FAST Search Web crawler received the response HTTP 300 (Multiple Choices).

long

HTTPResponse301

The number of times the FAST Search Web crawler received the response HTTP 301 (Moved Permanently).

long

HTTPResponse302

The number of times the FAST Search Web crawler received the response HTTP 302 (Found).

long

HTTPResponse303

The number of times the FAST Search Web crawler received the response HTTP 303 (See Other).

long

HTTPResponse304

The number of times the FAST Search Web crawler received the response HTTP 304 (Not Modified).

long

HTTPResponse307

The number of times the FAST Search Web crawler received the response HTTP 307 (Temporary Redirect).

long

HTTPResponse400

The number of times the FAST Search Web crawler received the response HTTP 400 (Bad Request).

long

HTTPResponse401

The number of times the FAST Search Web crawler received the response HTTP 401 (Unauthorized).

long

HTTPResponse403

The number of times the FAST Search Web crawler received the response HTTP 403 (Forbidden).

long

HTTPResponse404

The number of times the FAST Search Web crawler received the response HTTP 404 (Not Found).

long

HTTPResponse406

The number of times the FAST Search Web crawler received the response HTTP 406 (Not Acceptable).

long

HTTPResponse407

The number of times the FAST Search Web crawler received the response HTTP 407 (Proxy Authentication Required).

long

HTTPResponse426

The number of times the FAST Search Web crawler received the response FTP 426 (Transfer Aborted).

long

HTTPResponse500

The number of times the FAST Search Web crawler received the response HTTP 500 (Internal Server Error).

long

HTTPResponse503

The number of times the FAST Search Web crawler received the response HTTP 503 (Service Unavailable).

long

LastRefreshTime

Indicates the last time the collection was refreshed (timestamp).

long

LastUpdateTime

Indicates the last time the statistics were updated (timestamp).

long

LinksFwdNodeScheduler

The number of URIs/links forwarded to the Node Scheduler.

long

LinksFwdSiteManager

The number of URIs/links forwarded within a Site Manager.

long

LinksFwdSiteWorker

The numer of URIs/links forwarded within a Site Worker.

long

NetworkBytesReceived

The number of bytes (HTTP, HTTPS and FTP) that were read from the network.

long

NetworkBytesSent

The number of bytes (HTTP, HTTPS and FTP) that were written to the network.

long

NumMimeAtomXml

The number of documents with MIME type: application/atom+xml

long

NumMimeExcel

The number of documents with MIME type: application/msexcel

long

NumMimeHtml

The number of documents with MIME type: text/html

long

NumMimeJavascript

The number of documents with MIME type: application/x-javascript

long

NumMimeOctet

The number of documents with MIME type: application/octet-stream

long

NumMimePdf

The number of documents with MIME type: application/pdf

long

NumMimePlain

The number of documents with MIME type: text/plain

long

NumMimePostscript

The number of documents with MIME type: application/postscript

long

NumMimeRssXml

The number of documents with MIME type: application/rss+xml

long

NumMimeRtf

The number of documents with MIME type: application/rtf

long

NumMimeUnknown

The number of documents with MIME type: application/unknown

long

NumMimeVncPowerpoint

The number of documents with MIME type: application/vnd.ms-powerpoint

long

NumMimeVndExcel

The number of documents with MIME type: application/vnd.ms-excel

long

NumMimeVndWord

The number of documents with MIME type: application/vnd.ms-word

long

NumMimeWord

The number of documents with MIME type: application/msword

long

NumMimeZip

The number of documents with MIME type: application/zip

long

NumMineCss

The number of documents with MIME type: text/css

long

NumMineTextXml

The number of documents with MIME type: text/xml

long

NumMineXml

The number of documents with MIME type: application/xml

long

ProgressCycle

The current refresh cycle number.

long

ProgressNextRefresh

Time until next refresh.

string

RetriesURIs

The number of URIs that were retried.

long

StateUpdated

Time since the last statistics update.

string

Status

The crawl status of the current collection.

string

UniqueChecksumsStored

The number of unique checksums in the FAST Search Web crawler store

long

Uptime

Time since the FAST Search Web crawler was started or the collection was added (timestamp)

long

UrisSkipped

The number of skipped URIs due to the 'include_uris' or 'exclude_uris' settings.

long

UrisSkippedDomain

The number of skipped URIs due to the 'include_domains' or 'exclude_domains' settings.

long

UrisSkippedScheme

The number of skipped URIs due to the 'allowed_schemes' setting.

long

WMI Class - "QRServer"

Name Description Type

AverageQPS

Average number of QPS (Queries Per Second).

float

AvgDocsumLatency

Average Docsum latency.

float

AvgLatency

Average latency.

float

AvgLatencyLast

Average latency for the last x queries.

float

AvgSearchLatency

Average Search latency.

float

CurrentQPS

Current QPS (Queries Per Second) over the last x seconds.

float

NumFailSys

Number of failed queries (system).

int

NumFailTotal

Number of failed queries (total).

int

NumFailUser

Number of failed queries (user).

int

NumQueries

Number of queries.

long

NumRequests

Number of requests.

long

PeakQPS

Peak QPS (Queries Per Second).

float

SamplingPeriod

Sampling period.

float

WMI Class - "Collection"

Name Description Type

Cluster

Indicates the cluster of the collection.

string

Complete

Indicates whether or not the collection is complete.

bool

Description

Contains the description of the collection.

string

Name

Indicates the name of the collection.

string

Pipeline

Indicates the pipeline of the collection.

string

WMI Class - "DocumentProcessor"

Name Description Type

EndReassign

The number of times the reassignment of the content distributor dispatcher has completed.

int

LastProcessed

The last processed URI.

string

PipelineAttachments

Indicates whether or not the attachments pipeline is initialized.

bool

PipelineOffice14

Indicates whether or not the Office14 pipeline is initialized.

bool

ProcessOperations

Indicates whether or not the document processor server is processing a set of operations.

bool

QueueFull

Indicates whether or not the indexing dispatcher input queue is full.

bool

ResolveDispatcher

Indicates the name server resolve of the content distributor dispatcher scope total.

bool

ResolveMaster

Indicates the name server resolve of the content distributor master scope total.

bool

StartReassign

The number of times the reassignment of the content distributor dispatcher has been started.

int

StartServant

Indicates whether or not the document processor server is initializing.

bool

StartServantTotal

The number of times the document processor server has been initialized.

int

SubmitOperations

Indicates whether or not the document processor server is submitting a set of operations to the indexing dispatcher.

bool

WMI Class - "ContentDistributor"

Name Description Type

AvgDispatchTime

The average dispatch time over the last period.

float

AvgProcessingTime

The average processing time over the last period.

float

DocumentProcessors

The number of document processors

long

DocumentProcessorsBusy

The number of document processors that are busy.

long

DocumentProcessorsInvalid

The number of invalid document processors.

long

DocumentProcessorsUnused

The number of unused document processors.

long

Mode

Indicates the dispatcher running mode.

string

OperationsLastPeriod

The number of operations over the last period.

int

OperationsPerSec

The number of operations per second over the last period.

float

OperationsReceived

The number of receive operations.

int

ProcessingLoad

The processing load.

float

ProcserverProcess

The number of operation sets that was submitted to document processors.

int

SessionCreate

The number of clients creating a feeding session.

int

WMI Class - "IndexingDispatcher"

Name Description Type

BatchesProcessed

The total number of batches processed by this indexing dispatcher instance.

int

Mode

The indexing dispatcher fault tolerance mode.

string

NumOfDispatchers

The number of indexing dispatchers currently registered in the name service.

int

WMI Class - "WebAnalyzer"

Name Description Type

AnalysisStatus

Indicates whether or not analysis is active.

string

ContributingLinks

The number of links involved in the analysis.

long

CurrentAnalysisRuntime

Current analysis runtime.

int

LastAnalysisEnded

The time that the last analysis ended.

long

PreviousAnalysisRuntime

The time it took to complete the last analysis.

int

SitesServed

The number of sites in the anchor database.

long

URIsServed

The number of URIs in the anchor database.

long

WMI Class - "Crawler"

Name Description Type

DNSNetworkReadBytes

The number of bytes read from the network with respect to DNS resolving.

long

DNSNetworkWriteBytes

The number of bytes written to the network with respect to DNS resolving.

long

DNSRateLimit

Current DNS rate threshold (requests/second)

long

DNSRequests

The number of issued DNS requests.

long

DNSResponses

The number of received DNS responses.

long

DNSRetries

The number of issued DNS request retries.

long

DNSTimeouts

The number of issued DNS requests that timed out.

long

WMI Class - "Dataset"

Name Description Type

ActiveNodes

The number of active nodes.

int

ActivePartitions

The number of active partitions.

int

AvgSearchesPerSec

Average number of searches per second.

float

AvgSecondsPerSearch

Average number of seconds per search.

float

AvgUncachedSearchTime

Average uncached search time.

float

FirstPartition

First partition number.

int

MaxActiveNodes

Maximum number of active nodes.

int

MaxActivePartitions

Maximum number of active partitions.

int

Partitions

The number of partitions.

int

Samples

Samples

long

TimedOut

The number of timeouts

long

TimeoutPercentage

Timeout percentage.

float

TotalSearches

The total number of searches.

long

TotalSearchTime

The total search time.

float

TotalSelectionCost

The total selection cost.

int

UnitSelectionCost

The unit selection cost.

int

UpTime

Dataset uptime.

float

WMI Class - "FDispatch"

Name Description Type

ActiveCount

Active count.

long

InstantiateCount

Instantiate count.

long

ResourceUsage

Resource usage.

long

TotalResourceCount

Total resource count.

long

Version

Indicates the software version.

string

WaitQueueLen

Indicates the length of the wait queue.

long

WMI Class - "IndexerPartition"

Name Description Type

ActiveDocuments

The number of active/live documents.

long

IndexedPerSecond

The number of documents indexed per second for this partition.

float

IndexId

Internal index id.

long

PendingExclusionlist

The number of documents yet to be excluded.

long

Range

The file id range represented by this index.

string

Status

The current state of the partition.

string

StatusCode

The current state code of the partition.

int

TimestampIndexed

The time stamp of the index.

long

TotalDocuments

The total number of documents, including the exclusion listed.

long

Type

The partition type. A static partition may not be indexed.

string

TypeCode

The partition type code. A static partition may not be indexed.

int

WMI Class - "IndexerStatus"

Name Description Type

APIOperationsProcessed

The total number of API operations processed.

long

Cluster

The Cluster name.

string

Column

The Column number.

int

ConnectedFeeds

The number of connected feeds.

int

CurrentQueueSize

The current indexer queue size in bytes.

long

DocApiFrequence

The average number of processed operations per second.

float

DocApiLoad

The current indexer queue load in percentage.

float

ExclusionInterval

The exclusion interval in seconds. Using the exclusion list is a mechanism to remove documents from the search results without rebuilding the indexes.

int

Heartbeat

The heart beat periodically checks all other servers, answering a broadcast for missing client IDs and missing packets. The heart beat may suspend while synchronizing the fault tolerance storage with another indexer.

string

HeartbeatCode

The heart beat periodically checks all other servers, answering a broadcast for missing client IDs and missing packets. The heart beat may suspend while synchronizing the fault tolerance storage with another indexer.

int

Hostname

The Hostname.

string

LastSequence

The last processed sequence id in the indexer's internal sequence processor.

long

NumberOfElements

The current number of unprocessed elements on the indexer queue.

long

NumStatusUpdates

The current number of status updates.

long

PreferredMaster

A preferred main indexer will force other main indexers in the column to unregister.

bool

Row

The row number.

int

Status

The status.

string

StatusCode

The status code.

int

TCPPort

The TCP port.

int

TimeSinceLastIndex

Time since the last index was built, in seconds.

long

WMI Class - "BEStatistics"

Name Description Type

ProcessedRequests

Total number of Web items processed by the Browser Engine

int64

FailedRequests

The number of failed Web items.

int64

TimedOutDocuments

The number of Web items that timed out during processing.

int64

DownloadedRequests

The number of Web items retrieved from the FAST Search Web crawler.

int64

ProcessTimeMax

The longest amount of time, in milliseconds, used to process a Web item.

int64

ProcessTimeMin

The shortest amount of time, in milliseconds, used to download a Web item.

int64

ProcessTimeCount

The number of processed Web items.

int64

ProcessTimeAverage

Average time, in milliseconds, used to process Web items.

float

DownloadTimeMax

The longest amount of time, in milliseconds, used to download a Web item.

int64

DownloadTimeMin

The shortest amount of time, in milliseconds, used to download a Web item.

int64

DownloadTimeTotal

Total time, in milliseconds, used to download Web items.

int64

DownloadTimeCount

The number of downloaded Web items.

int64

DownloadTimeAverage

Average time, in milliseconds, used to download Web items.

float

CacheHits

The number of cache hits.

int64

CacheMisses

The number of cache misses.

int64

CacheInserts

The number of Web items inserted to the cache.

int64

CacheSize

The current number of cache entries.

int64

CacheBytes

The current cache size, in bytes.

int64

WMI Class - "NodeConfGlobal"

Name Description

BasePort

Base TCP/IP port number.

Column

Search column number or -1 if no column index is specified

Row

Search row number or -1 if no row index is specified

ConfigHostEntry

The configuration file etc\NodeConf.xml can contain the configuration for multiple nodes. This string matches the hostname attribute for this host’s node element. Typically, NodeConf.xml only contains configuration for one node. The hostname attribute will then be set to ‘localhost’.

MiddlewareHost

Hostname used for middleware name server registration. A host can have multiple host names, so to ensure proper host matching in the middleware this string should be used to reference a node.

InstanceID

Instance id for the search installation, specified when installing. This value is shared by all nodes and is used to group/cluster nodes in monitoring tools like System Center Operations Manager.

WMI Class – “NodeConfProcess”

Name Description Type

Id

Component instance identifier.

string

Name

Component name.

string

Description

Component description.

string

Executable

The name of the executable.

string

Param

Command line arguments.

string

Port

Process instance TCP/IP port base.

int

PortBase

TCP/IP port base for this component type.

int

PortIncrement

TCP/IP port increment for additional processes of this type.

int

PortCount

Number of ports used (from base).

int

Status

Process status.

string

StatusCode

Process status code.

int

Pid

Process identifier (PID).

int

Index

Not used (always 0).

int

WMI Class – “AccessControlCoordinator”

Name Description Type

RawCountAllRequests

Count of FSA create filter requests.

int64

RawCountNonCachedRequests

Count of FSA create filter requests not found in cache.

int64

RawNonCachedRequestsMS

The total number of elapsed milliseconds of NonCached FSA create filter requests.

int64

RawTotalAllRequestsMS

The total number of elapsed milliseconds of all FSA create filter requests.

int64

WMI Class – “AccessControlNonCachedRequestAverage”

Name Description Type

NonCachedRequestAverageMS

Average time (in milliseconds) to generate user security filter requests that are not in the cache.

int

WMI Class – “AccessControlNonCachedRequestCount”

Name Description Type

NonCachedRequestCount

The number of user security filter requests that are not in the cache.

int

WMI Class – “AccessControlRequestAverage”

Name Description Type

RequestAverageMS

Average time (in milliseconds) to generate user security filter requests.

int

WMI Class – “AccessControlRequestCount”

Name Description Type

RequestCount

The number of user security filter requests.

int

WMI Class – “DomainWMIProxy”

Name Description Type

RequestCount

Total Request Count to this FSA domain.

int

WMI Class – “PrincipalAliaserWMIProxy”

Name

Description

Type

RequestCount

Total Request Count to this principal aliaser.

int