Versions in this module Expand all Collapse all v1 v1.1.11 Mar 9, 2023 v1.1.10 Feb 14, 2023 v1.1.9 Feb 14, 2023 v1.1.8 Aug 6, 2021 Changes in this version + const DefaultMountPoint + type ARPEntry struct + Device string + HWAddr net.HardwareAddr + IPAddr net.IP + type BuddyInfo struct + Node string + Sizes []float64 + Zone string + type CPUInfo struct — linux/amd64 + APICID string + AddressSizes string + BogoMips float64 + Bugs []string + CLFlushSize uint + CPUCores uint + CPUFamily string + CPUIDLevel uint + CPUMHz float64 + CacheAlignment uint + CacheSize string + CoreID string + FPU string + FPUException string + Flags []string + InitialAPICID string + Microcode string + Model string + ModelName string + PhysicalID string + PowerManagement string + Processor uint + Siblings uint + Stepping string + VendorID string + WP string + type CPUStat struct + Guest float64 + GuestNice float64 + IRQ float64 + Idle float64 + Iowait float64 + Nice float64 + SoftIRQ float64 + Steal float64 + System float64 + User float64 + type Cgroup struct + Controllers []string + HierarchyID int + Path string + type ConntrackStatEntry struct + Drop uint64 + EarlyDrop uint64 + Entries uint64 + Found uint64 + Ignore uint64 + Insert uint64 + InsertFailed uint64 + Invalid uint64 + SearchRestart uint64 + type Crypto struct + Alignmask *uint64 + Async bool + Blocksize *uint64 + Chunksize *uint64 + Ctxsize *uint64 + Digestsize *uint64 + Driver string + Geniv string + Internal string + Ivsize *uint64 + MaxKeysize *uint64 + Maxauthsize *uint64 + MinKeysize *uint64 + Module string + Name string + Priority *int64 + Refcnt *int64 + Seedsize *uint64 + Selftest string + Type string + Walksize *uint64 + type FS struct + func NewDefaultFS() (FS, error) + func NewFS(mountPoint string) (FS, error) + func (fs FS) AllProcs() (Procs, error) + func (fs FS) BuddyInfo() ([]BuddyInfo, error) + func (fs FS) CPUInfo() ([]CPUInfo, error) + func (fs FS) ConntrackStat() ([]ConntrackStatEntry, error) + func (fs FS) Crypto() ([]Crypto, error) + func (fs FS) Fscacheinfo() (Fscacheinfo, error) + func (fs FS) GatherARPEntries() ([]ARPEntry, error) + func (fs FS) IPVSBackendStatus() ([]IPVSBackendStatus, error) + func (fs FS) IPVSStats() (IPVSStats, error) + func (fs FS) KernelRandom() (KernelRandom, error) + func (fs FS) LoadAvg() (*LoadAvg, error) + func (fs FS) MDStat() ([]MDStat, error) + func (fs FS) Meminfo() (Meminfo, error) + func (fs FS) NetDev() (NetDev, error) + func (fs FS) NetProtocols() (NetProtocolStats, error) + func (fs FS) NetSockstat() (*NetSockstat, error) + func (fs FS) NetSockstat6() (*NetSockstat, error) + func (fs FS) NetSoftnetStat() ([]SoftnetStat, error) + func (fs FS) NetTCP() (NetTCP, error) + func (fs FS) NetTCP6() (NetTCP, error) + func (fs FS) NetTCP6Summary() (*NetTCPSummary, error) + func (fs FS) NetTCPSummary() (*NetTCPSummary, error) + func (fs FS) NetUDP() (NetUDP, error) + func (fs FS) NetUDP6() (NetUDP, error) + func (fs FS) NetUDP6Summary() (*NetUDPSummary, error) + func (fs FS) NetUDPSummary() (*NetUDPSummary, error) + func (fs FS) NetUNIX() (*NetUNIX, error) + func (fs FS) NewProc(pid int) (Proc, error) + func (fs FS) NewStat() (Stat, error) + func (fs FS) NewXfrmStat() (XfrmStat, error) + func (fs FS) PSIStatsForResource(resource string) (PSIStats, error) + func (fs FS) Proc(pid int) (Proc, error) + func (fs FS) Schedstat() (*Schedstat, error) + func (fs FS) Self() (Proc, error) + func (fs FS) SlabInfo() (SlabInfo, error) + func (fs FS) Stat() (Stat, error) + func (fs FS) Swaps() ([]*Swap, error) + func (fs FS) VM() (*VM, error) + func (fs FS) Zoneinfo() ([]Zoneinfo, error) + type Fscacheinfo struct + AcquireCookiesRequestSeen uint64 + AcquireRequestsFailedDueToEnomem uint64 + AcquireRequestsRejectedDueToError uint64 + AcquireRequestsRejectedNoCacheAvailable uint64 + AcquireRequestsSucceeded uint64 + AcquireRequestsWithNullParent uint64 + AllocationOkRequests uint64 + AllocationOperationsSubmitted uint64 + AllocationRequestsSeen uint64 + AllocationWaitingOnLookup uint64 + AllocationsAbortedDueToErestartsys uint64 + AllocationsAbortedDueToObjectDeath uint64 + AllocationsRejectedDueToEnobufs uint64 + AllocationsWaitedForCPU uint64 + AttributeChangedFailedDueToEnomem uint64 + AttributeChangedOps uint64 + AttributeChangedRejectDueToEnobufs uint64 + AttributeChangedRequestsQueued uint64 + AttributeChangedRequestsSeen uint64 + CacheevLookupsAndCreationsRejectedLackSpace uint64 + CacheevObjectsCulled uint64 + CacheevRetiredWhenReliquished uint64 + CacheevStaleObjectsDeleted uint64 + CacheopAllocatePageInProgress uint64 + CacheopAllocatePagesInProgress uint64 + CacheopAllocationsinProgress uint64 + CacheopAttributeChangeInProgress uint64 + CacheopDissociatePagesInProgress uint64 + CacheopDropObjectInProgress uint64 + CacheopGrabObjectInProgress uint64 + CacheopInvalidations uint64 + CacheopLookupCompleteInPorgress uint64 + CacheopLookupObjectInProgress uint64 + CacheopPutObjectInProgress uint64 + CacheopReadOrAllocPageInProgress uint64 + CacheopReadOrAllocPagesInProgress uint64 + CacheopSyncCacheInProgress uint64 + CacheopUncachePagesInProgress uint64 + CacheopUpdateObjectInProgress uint64 + CacheopWritePagesInProgress uint64 + DataStorageCookiesAllocated uint64 + IndexCookiesAllocated uint64 + InvalidationsNumber uint64 + InvalidationsRunning uint64 + LookupsNegative uint64 + LookupsNumber uint64 + LookupsPositive uint64 + LookupsTimedOutAndRequed uint64 + ObjectAllocationsFailure uint64 + ObjectsAllocated uint64 + ObjectsAvailable uint64 + ObjectsCreatedByLookup uint64 + ObjectsDead uint64 + ObjectsDeclaredObsolete uint64 + ObjectsNeedCoherencyCheckUpdate uint64 + ObjectsWithCoherencyCheck uint64 + ObjectsWithoutCoherencyCheck uint64 + OpsCancelled uint64 + OpsDeferred uint64 + OpsEnqueued uint64 + OpsGarbageCollected uint64 + OpsInitialised uint64 + OpsPending uint64 + OpsRejected uint64 + OpsReleased uint64 + OpsRunning uint64 + PageStoresCancelledByReleaseRequests uint64 + PagesMarkedAsBeingCached uint64 + ReleaseRequestsAgainstPagesStoredByTimeLockGranted uint64 + ReleaseRequestsAgainstPagesWithNoPendingStorage uint64 + ReleaseRequestsIgnoredDueToInProgressStore uint64 + RelinquishCookiesRequestSeen uint64 + RelinquishCookiesWithNullParent uint64 + RelinquishRequestsWaitingCompleteCreation uint64 + RelinquishRetries uint64 + RetrievalsAbortedDueToErestartsys uint64 + RetrievalsAbortedDueToObjectDeath uint64 + RetrievalsFailedDueToEnomem uint64 + RetrievalsOk uint64 + RetrievalsReadRequests uint64 + RetrievalsRejectedDueToEnobufs uint64 + RetrievalsRequests uint64 + RetrievalsReturnedEnodata uint64 + RetrievalsWaitingCPU uint64 + RetrievalsWaitingLookupCompletion uint64 + SpecialCookiesAllocated uint64 + StorePagesWithRequestsProcessing uint64 + StoreRequestsDeleted uint64 + StoreRequestsFailedDueToEnomem uint64 + StoreRequestsOnPendingStorage uint64 + StoreRequestsOverStoreLimit uint64 + StoreRequestsRejectedDueToEnobufs uint64 + StoreRequestsRunning uint64 + StoreRequestsSubmitted uint64 + StoreSuccessfulRequests uint64 + StoreWriteRequests uint64 + UncachePagesRequestSeen uint64 + UpdateCookieRequestSeen uint64 + UpdateRequestsRunning uint64 + UpdateRequestsWithNullParent uint64 + VmscanWaiting uint64 + type IPVSBackendStatus struct + ActiveConn uint64 + InactConn uint64 + LocalAddress net.IP + LocalMark string + LocalPort uint16 + Proto string + RemoteAddress net.IP + RemotePort uint16 + Weight uint64 + type IPVSStats struct + Connections uint64 + IncomingBytes uint64 + IncomingPackets uint64 + OutgoingBytes uint64 + OutgoingPackets uint64 + type InotifyInfo struct + Ino string + Mask string + Sdev string + WD string + type KernelRandom struct — darwin/amd64, js/wasm, linux/amd64 + EntropyAvaliable *uint64 + PoolSize *uint64 + ReadWakeupThreshold *uint64 + URandomMinReseedSeconds *uint64 + WriteWakeupThreshold *uint64 + type LoadAvg struct + Load1 float64 + Load15 float64 + Load5 float64 + type MDStat struct + ActivityState string + BlocksSynced int64 + BlocksTotal int64 + Devices []string + DisksActive int64 + DisksFailed int64 + DisksSpare int64 + DisksTotal int64 + Name string + type Meminfo struct + Active *uint64 + ActiveAnon *uint64 + ActiveFile *uint64 + AnonHugePages *uint64 + AnonPages *uint64 + Bounce *uint64 + Buffers *uint64 + Cached *uint64 + CmaFree *uint64 + CmaTotal *uint64 + CommitLimit *uint64 + CommittedAS *uint64 + DirectMap1G *uint64 + DirectMap2M *uint64 + DirectMap4k *uint64 + Dirty *uint64 + HardwareCorrupted *uint64 + HugePagesFree *uint64 + HugePagesRsvd *uint64 + HugePagesSurp *uint64 + HugePagesTotal *uint64 + Hugepagesize *uint64 + Inactive *uint64 + InactiveAnon *uint64 + InactiveFile *uint64 + KernelStack *uint64 + Mapped *uint64 + MemAvailable *uint64 + MemFree *uint64 + MemTotal *uint64 + Mlocked *uint64 + NFSUnstable *uint64 + PageTables *uint64 + SReclaimable *uint64 + SUnreclaim *uint64 + Shmem *uint64 + ShmemHugePages *uint64 + ShmemPmdMapped *uint64 + Slab *uint64 + SwapCached *uint64 + SwapFree *uint64 + SwapTotal *uint64 + Unevictable *uint64 + VmallocChunk *uint64 + VmallocTotal *uint64 + VmallocUsed *uint64 + Writeback *uint64 + WritebackTmp *uint64 + type Mount struct + Device string + Mount string + Stats MountStats + Type string + type MountInfo struct + FSType string + MajorMinorVer string + MountID int + MountPoint string + OptionalFields map[string]string + Options map[string]string + ParentID int + Root string + Source string + SuperOptions map[string]string + func GetMounts() ([]*MountInfo, error) + func GetProcMounts(pid int) ([]*MountInfo, error) + type MountStats interface + type MountStatsNFS struct + Age time.Duration + Bytes NFSBytesStats + Events NFSEventsStats + Operations []NFSOperationStats + Opts map[string]string + StatVersion string + Transport NFSTransportStats + type NFSBytesStats struct + DirectRead uint64 + DirectWrite uint64 + Read uint64 + ReadPages uint64 + ReadTotal uint64 + Write uint64 + WritePages uint64 + WriteTotal uint64 + type NFSEventsStats struct + AttributeInvalidate uint64 + CongestionWait uint64 + DataInvalidate uint64 + DnodeRevalidate uint64 + InodeRevalidate uint64 + JukeboxDelay uint64 + PNFSRead uint64 + PNFSWrite uint64 + ShortRead uint64 + ShortWrite uint64 + SillyRename uint64 + Truncation uint64 + VFSAccess uint64 + VFSFileRelease uint64 + VFSFlush uint64 + VFSFsync uint64 + VFSGetdents uint64 + VFSLock uint64 + VFSLookup uint64 + VFSOpen uint64 + VFSReadPage uint64 + VFSReadPages uint64 + VFSSetattr uint64 + VFSUpdatePage uint64 + VFSWritePage uint64 + VFSWritePages uint64 + WriteExtension uint64 + type NFSOperationStats struct + BytesReceived uint64 + BytesSent uint64 + CumulativeQueueMilliseconds uint64 + CumulativeTotalRequestMilliseconds uint64 + CumulativeTotalResponseMilliseconds uint64 + Errors uint64 + MajorTimeouts uint64 + Operation string + Requests uint64 + Transmissions uint64 + type NFSTransportStats struct + BadTransactionIDs uint64 + Bind uint64 + Connect uint64 + ConnectIdleTime uint64 + CumulativeActiveRequests uint64 + CumulativeBacklog uint64 + CumulativePendingQueue uint64 + CumulativeSendingQueue uint64 + IdleTimeSeconds uint64 + MaximumRPCSlotsUsed uint64 + Port uint64 + Protocol string + Receives uint64 + Sends uint64 + type Namespace struct + Inode uint32 + Type string + type Namespaces map[string]Namespace + type NetDev map[string]NetDevLine + func (netDev NetDev) Total() NetDevLine + type NetDevLine struct + Name string + RxBytes uint64 + RxCompressed uint64 + RxDropped uint64 + RxErrors uint64 + RxFIFO uint64 + RxFrame uint64 + RxMulticast uint64 + RxPackets uint64 + TxBytes uint64 + TxCarrier uint64 + TxCollisions uint64 + TxCompressed uint64 + TxDropped uint64 + TxErrors uint64 + TxFIFO uint64 + TxPackets uint64 + type NetIPSocket []*netIPSocketLine + type NetIPSocketSummary struct + RxQueueLength uint64 + TxQueueLength uint64 + UsedSockets uint64 + type NetProtocolCapabilities struct + Accept bool + BacklogRcv bool + Bind bool + Close bool + Connect bool + Destroy bool + Disconnect bool + EnterMemoryPressure bool + GetPort bool + GetSockOpt bool + Hash bool + Init bool + IoCtl bool + RecvMsg bool + SendMsg bool + SendPage bool + SetSockOpt bool + Shutdown bool + UnHash bool + type NetProtocolStatLine struct + Capabilities NetProtocolCapabilities + MaxHeader uint64 + Memory int64 + ModuleName string + Name string + Pressure int + Size uint64 + Slab bool + Sockets int64 + type NetProtocolStats map[string]NetProtocolStatLine + type NetSockstat struct + Protocols []NetSockstatProtocol + Used *int + type NetSockstatProtocol struct + Alloc *int + InUse int + Mem *int + Memory *int + Orphan *int + Protocol string + TW *int + type NetTCP []*netIPSocketLine + type NetTCPSummary NetIPSocketSummary + type NetUDP []*netIPSocketLine + type NetUDPSummary NetIPSocketSummary + type NetUNIX struct + Rows []*NetUNIXLine + type NetUNIXFlags uint64 + func (f NetUNIXFlags) String() string + type NetUNIXLine struct + Flags NetUNIXFlags + Inode uint64 + KernelPtr string + Path string + Protocol uint64 + RefCount uint64 + State NetUNIXState + Type NetUNIXType + type NetUNIXState uint64 + func (s NetUNIXState) String() string + type NetUNIXType uint64 + func (t NetUNIXType) String() string + type PSILine struct + Avg10 float64 + Avg300 float64 + Avg60 float64 + Total uint64 + type PSIStats struct + Full *PSILine + Some *PSILine + type Proc struct + PID int + func NewProc(pid int) (Proc, error) + func Self() (Proc, error) + func (p Proc) Cgroups() ([]Cgroup, error) + func (p Proc) CmdLine() ([]string, error) + func (p Proc) Comm() (string, error) + func (p Proc) Cwd() (string, error) + func (p Proc) Environ() ([]string, error) + func (p Proc) Executable() (string, error) + func (p Proc) FDInfo(fd string) (*ProcFDInfo, error) + func (p Proc) FileDescriptorTargets() ([]string, error) + func (p Proc) FileDescriptors() ([]uintptr, error) + func (p Proc) FileDescriptorsInfo() (ProcFDInfos, error) + func (p Proc) FileDescriptorsLen() (int, error) + func (p Proc) IO() (ProcIO, error) + func (p Proc) Limits() (ProcLimits, error) + func (p Proc) MountInfo() ([]*MountInfo, error) + func (p Proc) MountStats() ([]*Mount, error) + func (p Proc) Namespaces() (Namespaces, error) + func (p Proc) NetDev() (NetDev, error) + func (p Proc) NewLimits() (ProcLimits, error) + func (p Proc) NewStat() (ProcStat, error) + func (p Proc) NewStatus() (ProcStatus, error) + func (p Proc) ProcMaps() ([]*ProcMap, error) + func (p Proc) ProcSMapsRollup() (ProcSMapsRollup, error) + func (p Proc) RootDir() (string, error) + func (p Proc) Schedstat() (ProcSchedstat, error) + func (p Proc) Stat() (ProcStat, error) + func (p Proc) Wchan() (string, error) + type ProcFDInfo struct + FD string + Flags string + InotifyInfos []InotifyInfo + MntID string + Pos string + type ProcFDInfos []ProcFDInfo + func (p ProcFDInfos) InotifyWatchLen() (int, error) + func (p ProcFDInfos) Len() int + func (p ProcFDInfos) Less(i, j int) bool + func (p ProcFDInfos) Swap(i, j int) + type ProcIO struct + CancelledWriteBytes int64 + RChar uint64 + ReadBytes uint64 + SyscR uint64 + SyscW uint64 + WChar uint64 + WriteBytes uint64 + type ProcLimits struct + AddressSpace uint64 + CPUTime uint64 + CoreFileSize uint64 + DataSize uint64 + FileLocks uint64 + FileSize uint64 + LockedMemory uint64 + MsqqueueSize uint64 + NicePriority uint64 + OpenFiles uint64 + PendingSignals uint64 + Processes uint64 + RealtimePriority uint64 + RealtimeTimeout uint64 + ResidentSet uint64 + StackSize uint64 + type ProcMap struct — darwin/amd64, linux/amd64 + Dev uint64 + EndAddr uintptr + Inode uint64 + Offset int64 + Pathname string + Perms *ProcMapPermissions + StartAddr uintptr + type ProcMapPermissions struct — darwin/amd64, linux/amd64 + Execute bool + Private bool + Read bool + Shared bool + Write bool + type ProcSMapsRollup struct — darwin/amd64, js/wasm, linux/amd64 + Anonymous uint64 + PrivateClean uint64 + PrivateDirty uint64 + Pss uint64 + Referenced uint64 + Rss uint64 + SharedClean uint64 + SharedDirty uint64 + Swap uint64 + SwapPss uint64 + type ProcSchedstat struct + RunTimeslices uint64 + RunningNanoseconds uint64 + WaitingNanoseconds uint64 + type ProcStat struct + CMajFlt uint + CMinFlt uint + CSTime uint + CUTime uint + Comm string + Flags uint + MajFlt uint + MinFlt uint + Nice int + NumThreads int + PGRP int + PID int + PPID int + Priority int + RSS int + STime uint + Session int + Starttime uint64 + State string + TPGID int + TTY int + UTime uint + VSize uint + func (s ProcStat) CPUTime() float64 + func (s ProcStat) ResidentMemory() int + func (s ProcStat) StartTime() (float64, error) + func (s ProcStat) VirtualMemory() uint + type ProcStatus struct + GIDs [4]string + HugetlbPages uint64 + Name string + NonVoluntaryCtxtSwitches uint64 + PID int + RssAnon uint64 + RssFile uint64 + RssShmem uint64 + TGID int + UIDs [4]string + VmData uint64 + VmExe uint64 + VmHWM uint64 + VmLck uint64 + VmLib uint64 + VmPMD uint64 + VmPTE uint64 + VmPeak uint64 + VmPin uint64 + VmRSS uint64 + VmSize uint64 + VmStk uint64 + VmSwap uint64 + VoluntaryCtxtSwitches uint64 + func (s ProcStatus) TotalCtxtSwitches() uint64 + type Procs []Proc + func AllProcs() (Procs, error) + func (p Procs) Len() int + func (p Procs) Less(i, j int) bool + func (p Procs) Swap(i, j int) + type Schedstat struct + CPUs []*SchedstatCPU + type SchedstatCPU struct + CPUNum string + RunTimeslices uint64 + RunningNanoseconds uint64 + WaitingNanoseconds uint64 + type Slab struct + Batch int64 + Limit int64 + Name string + ObjActive int64 + ObjNum int64 + ObjPerSlab int64 + ObjSize int64 + PagesPerSlab int64 + SharedAvail int64 + SharedFactor int64 + SlabActive int64 + SlabNum int64 + type SlabInfo struct + Slabs []*Slab + type SoftIRQStat struct + Block uint64 + BlockIoPoll uint64 + Hi uint64 + Hrtimer uint64 + NetRx uint64 + NetTx uint64 + Rcu uint64 + Sched uint64 + Tasklet uint64 + Timer uint64 + type SoftnetStat struct + Dropped uint32 + Processed uint32 + TimeSqueezed uint32 + type Stat struct + BootTime uint64 + CPU []CPUStat + CPUTotal CPUStat + ContextSwitches uint64 + IRQ []uint64 + IRQTotal uint64 + ProcessCreated uint64 + ProcessesBlocked uint64 + ProcessesRunning uint64 + SoftIRQ SoftIRQStat + SoftIRQTotal uint64 + func NewStat() (Stat, error) + type Swap struct + Filename string + Priority int + Size int + Type string + Used int + type VM struct — darwin/amd64, js/wasm, linux/amd64 + AdminReserveKbytes *int64 + BlockDump *int64 + CompactUnevictableAllowed *int64 + DirtyBackgroundBytes *int64 + DirtyBackgroundRatio *int64 + DirtyBytes *int64 + DirtyExpireCentisecs *int64 + DirtyRatio *int64 + DirtyWritebackCentisecs *int64 + DirtytimeExpireSeconds *int64 + DropCaches *int64 + ExtfragThreshold *int64 + HugetlbShmGroup *int64 + LaptopMode *int64 + LegacyVaLayout *int64 + LowmemReserveRatio []*int64 + MaxMapCount *int64 + MemoryFailureEarlyKill *int64 + MemoryFailureRecovery *int64 + MinFreeKbytes *int64 + MinSlabRatio *int64 + MinUnmappedRatio *int64 + MmapMinAddr *int64 + NrHugepages *int64 + NrHugepagesMempolicy *int64 + NrOvercommitHugepages *int64 + NumaStat *int64 + NumaZonelistOrder string + OomDumpTasks *int64 + OomKillAllocatingTask *int64 + OvercommitKbytes *int64 + OvercommitMemory *int64 + OvercommitRatio *int64 + PageCluster *int64 + PanicOnOom *int64 + PercpuPagelistFraction *int64 + StatInterval *int64 + Swappiness *int64 + UserReserveKbytes *int64 + VfsCachePressure *int64 + WatermarkBoostFactor *int64 + WatermarkScaleFactor *int64 + ZoneReclaimMode *int64 + type XfrmStat struct + XfrmAcquireError int + XfrmFwdHdrError int + XfrmInBufferError int + XfrmInError int + XfrmInHdrError int + XfrmInNoPols int + XfrmInNoStates int + XfrmInPolBlock int + XfrmInPolError int + XfrmInStateExpired int + XfrmInStateInvalid int + XfrmInStateMismatch int + XfrmInStateModeError int + XfrmInStateProtoError int + XfrmInStateSeqError int + XfrmInTmplMismatch int + XfrmOutBundleCheckError int + XfrmOutBundleGenError int + XfrmOutError int + XfrmOutNoStates int + XfrmOutPolBlock int + XfrmOutPolDead int + XfrmOutPolError int + XfrmOutStateExpired int + XfrmOutStateInvalid int + XfrmOutStateModeError int + XfrmOutStateProtoError int + XfrmOutStateSeqError int + func NewXfrmStat() (XfrmStat, error) + type Zoneinfo struct — darwin/amd64, js/wasm, linux/amd64 + High *int64 + Low *int64 + Managed *int64 + Min *int64 + Node string + NrActiveAnon *int64 + NrActiveFile *int64 + NrAnonPages *int64 + NrAnonTransparentHugepages *int64 + NrDirtied *int64 + NrDirty *int64 + NrFilePages *int64 + NrFreePages *int64 + NrInactiveAnon *int64 + NrInactiveFile *int64 + NrIsolatedAnon *int64 + NrIsolatedFile *int64 + NrKernelStack *int64 + NrMapped *int64 + NrMlockStack *int64 + NrShmem *int64 + NrSlabReclaimable *int64 + NrSlabUnreclaimable *int64 + NrUnevictable *int64 + NrWriteback *int64 + NrWritten *int64 + NumaForeign *int64 + NumaHit *int64 + NumaInterleave *int64 + NumaLocal *int64 + NumaMiss *int64 + NumaOther *int64 + Present *int64 + Protection []*int64 + Scanned *int64 + Spanned *int64 + Zone string