gem5  v20.1.0.0
Classes | Namespaces | Typedefs | Functions
statistics.hh File Reference
#include <algorithm>
#include <cassert>
#include <cmath>
#include <functional>
#include <iosfwd>
#include <list>
#include <map>
#include <memory>
#include <string>
#include <vector>
#include "base/stats/group.hh"
#include "base/stats/info.hh"
#include "base/stats/output.hh"
#include "base/stats/types.hh"
#include "base/cast.hh"
#include "base/cprintf.hh"
#include "base/intmath.hh"
#include "base/str.hh"
#include "base/types.hh"

Go to the source code of this file.

Classes

class  Stats::InfoProxy< Stat, Base >
 
class  Stats::ScalarInfoProxy< Stat >
 
class  Stats::VectorInfoProxy< Stat >
 
class  Stats::DistInfoProxy< Stat >
 
class  Stats::VectorDistInfoProxy< Stat >
 
class  Stats::Vector2dInfoProxy< Stat >
 
struct  Stats::StorageParams
 
class  Stats::InfoAccess
 
class  Stats::DataWrap< Derived, InfoProxyType >
 
class  Stats::DataWrapVec< Derived, InfoProxyType >
 
class  Stats::DataWrapVec2d< Derived, InfoProxyType >
 
class  Stats::StatStor
 Templatized storage and interface for a simple scalar stat. More...
 
struct  Stats::StatStor::Params
 
class  Stats::AvgStor
 Templatized storage and interface to a per-tick average stat. More...
 
struct  Stats::AvgStor::Params
 
class  Stats::ScalarBase< Derived, Stor >
 Implementation of a scalar stat. More...
 
class  Stats::ProxyInfo
 
class  Stats::ValueProxy< T >
 
class  Stats::FunctorProxy< T, Enabled >
 
class  Stats::MethodProxy< T, V >
 A proxy similar to the FunctorProxy, but allows calling a method of a bound object, instead of a global free-standing function. More...
 
class  Stats::ValueBase< Derived >
 
class  Stats::ScalarProxy< Stat >
 A proxy class to access the stat at a given index in a VectorBase stat. More...
 
class  Stats::VectorBase< Derived, Stor >
 Implementation of a vector of stats. More...
 
class  Stats::VectorProxy< Stat >
 
class  Stats::Vector2dBase< Derived, Stor >
 
struct  Stats::DistParams
 The parameters for a distribution stat. More...
 
class  Stats::DistStor
 Templatized storage and interface for a distribution stat. More...
 
struct  Stats::DistStor::Params
 The parameters for a distribution stat. More...
 
class  Stats::HistStor
 Templatized storage and interface for a histogram stat. More...
 
struct  Stats::HistStor::Params
 The parameters for a distribution stat. More...
 
class  Stats::SampleStor
 Templatized storage and interface for a distribution that calculates mean and variance. More...
 
struct  Stats::SampleStor::Params
 
class  Stats::AvgSampleStor
 Templatized storage for distribution that calculates per tick mean and variance. More...
 
struct  Stats::AvgSampleStor::Params
 
class  Stats::DistBase< Derived, Stor >
 Implementation of a distribution stat. More...
 
class  Stats::DistProxy< Stat >
 
class  Stats::VectorDistBase< Derived, Stor >
 
class  Stats::DistProxy< Stat >
 
class  Stats::Node
 Base class for formula statistic node. More...
 
class  Stats::ScalarStatNode
 
class  Stats::ScalarProxyNode< Stat >
 
class  Stats::VectorStatNode
 
class  Stats::ConstNode< T >
 
class  Stats::ConstVectorNode< T >
 
struct  Stats::OpString< Op >
 
struct  Stats::OpString< std::plus< Result > >
 
struct  Stats::OpString< std::minus< Result > >
 
struct  Stats::OpString< std::multiplies< Result > >
 
struct  Stats::OpString< std::divides< Result > >
 
struct  Stats::OpString< std::modulus< Result > >
 
struct  Stats::OpString< std::negate< Result > >
 
class  Stats::UnaryNode< Op >
 
class  Stats::BinaryNode< Op >
 
class  Stats::SumNode< Op >
 
class  Stats::Scalar
 This is a simple scalar statistic, like a counter. More...
 
class  Stats::Average
 A stat that calculates the per tick average of a value. More...
 
class  Stats::Value
 
class  Stats::Vector
 A vector of scalar stats. More...
 
class  Stats::AverageVector
 A vector of Average stats. More...
 
class  Stats::Vector2d
 A 2-Dimensional vecto of scalar stats. More...
 
class  Stats::Distribution
 A simple distribution stat. More...
 
class  Stats::Histogram
 A simple histogram stat. More...
 
class  Stats::StandardDeviation
 Calculates the mean and variance of all the samples. More...
 
class  Stats::AverageDeviation
 Calculates the per tick mean and variance of the samples. More...
 
class  Stats::VectorDistribution
 A vector of distributions. More...
 
class  Stats::VectorStandardDeviation
 This is a vector of StandardDeviation stats. More...
 
class  Stats::VectorAverageDeviation
 This is a vector of AverageDeviation stats. More...
 
class  Stats::FormulaInfoProxy< Stat >
 
class  Stats::SparseHistInfoProxy< Stat >
 
class  Stats::SparseHistBase< Derived, Stor >
 Implementation of a sparse histogram stat. More...
 
class  Stats::SparseHistStor
 Templatized storage and interface for a sparse histogram stat. More...
 
struct  Stats::SparseHistStor::Params
 The parameters for a sparse histogram stat. More...
 
class  Stats::SparseHistogram
 
class  Stats::Formula
 A formula for statistics that is calculated when printed. More...
 
class  Stats::FormulaNode
 
class  Stats::Temp
 Helper class to construct formula node trees. More...
 

Namespaces

 Stats
 

Typedefs

typedef std::shared_ptr< Node > Stats::NodePtr
 Shared pointer to a function Node. More...
 
typedef void(* Stats::Handler) ()
 Register reset and dump handlers. More...
 
typedef std::map< const void *, Info * > Stats::MapType
 
typedef std::map< std::string, Info * > Stats::NameMapType
 

Functions

Tick curTick ()
 The current simulated tick. More...
 
Temp Stats::operator+ (Temp l, Temp r)
 
Temp Stats::operator- (Temp l, Temp r)
 
Temp Stats::operator* (Temp l, Temp r)
 
Temp Stats::operator/ (Temp l, Temp r)
 
Temp Stats::operator- (Temp l)
 
template<typename T >
Temp Stats::constant (T val)
 
template<typename T >
Temp Stats::constantVector (T val)
 
Temp Stats::sum (Temp val)
 
void Stats::dump ()
 Dump all statistics data to the registered outputs. More...
 
void Stats::reset ()
 
void Stats::enable ()
 
bool Stats::enabled ()
 
const Info * Stats::resolve (const std::string &name)
 
void Stats::registerHandlers (Handler reset_handler, Handler dump_handler)
 
void Stats::registerResetCallback (const std::function< void()> &callback)
 Register a callback that should be called whenever statistics are reset. More...
 
void Stats::registerDumpCallback (const std::function< void()> &callback)
 Register a callback that should be called whenever statistics are about to be dumped. More...
 
void Stats::processResetQueue ()
 Process all the callbacks in the reset callbacks queue. More...
 
void Stats::processDumpQueue ()
 Process all the callbacks in the dump callbacks queue. More...
 
list< Info * > & Stats::statsList ()
 
MapType & Stats::statsMap ()
 
NameMapType & Stats::nameMap ()
 
bool Stats::validateStatName (const std::string &name)
 
void debugDumpStats ()
 

Detailed Description

Declaration of Statistics objects.

Definition in file statistics.hh.

Function Documentation

◆ curTick()

Tick curTick ( )
inline

The current simulated tick.

Todo:

Generalized N-dimensinal vector documentation key stats interval stats – these both can use the same function that prints out a specific set of stats VectorStandardDeviation totals Document Namespaces

The current simulated tick.

Definition at line 45 of file core.hh.

Referenced by Prefetcher::SBOOE::Sandbox::access(), Prefetcher::SBOOE::access(), DRAMSim2::accessAndRespond(), DRAMsim3::accessAndRespond(), MemCtrl::accessAndRespond(), FlashDevice::accessDevice(), SimpleCache::accessTiming(), FlashDevice::actionComplete(), O3ThreadContext< Impl >::activate(), SimpleThread::activate(), FullO3CPU< O3CPUImpl >::activateContext(), ElasticTrace::addDepTraceRecord(), MemCtrl::addToReadQueue(), MemCtrl::addToWriteQueue(), CacheMemory::allocate(), BaseTrafficGen::allocateWaitingRespSlot(), SwitchAllocator::arbitrate_inports(), SwitchAllocator::arbitrate_outports(), DefaultFetch< Impl >::buildInst(), NVMInterface::burstReady(), BaseXBar::calcPacketTiming(), DistIface::RecvScheduler::calcReceiveTick(), BaseCache::calculateAccessLatency(), Prefetcher::SBOOE::calculatePrefetch(), NetworkInterface::calculateVC(), ArmSemihosting::callClock(), ArmSemihosting::callElapsed32(), ArmSemihosting::callElapsed64(), ArmSemihosting::callTime(), VncInput::captureFrameBuffer(), Sinic::Device::changeConfig(), TraceCPU::checkAndSchedExitEvent(), UncoalescedTable::checkDeadlock(), FlashDevice::checkDrain(), DRAMInterface::Rank::checkDrainDone(), DRAMInterface::checkRefreshState(), NetworkInterface::checkReschedule(), NetworkInterface::checkStallQueue(), IGbE::chkInterrupt(), MemCtrl::chooseNextFRFCFS(), NVMInterface::chooseRead(), BaseCache::CacheResponsePort::clearBlocked(), UFSHostDevice::clearInterrupt(), Intel8254Timer::Counter::CounterEvent::clocksLeft(), Minor::Execute::commit(), DefaultCommit< Impl >::commitHead(), GPUCoalescer::completeHitCallback(), MemTest::completeRequest(), LSQUnit< Impl >::completeStore(), SMMUTranslationProcess::completeTransaction(), PowerState::computeStats(), DRAMInterface::Rank::computeStats(), BaseTags::computeStatsVisitor(), Sinic::Base::cpuInterrupt(), NSGigE::cpuInterrupt(), Sinic::Base::cpuIntrPost(), NSGigE::cpuIntrPost(), IGbE::cpuPostInt(), CPUProgressEvent::CPUProgressEvent(), TraceCPU::dcacheRetryRecvd(), DefaultDecode< Impl >::decodeInsts(), PacketQueue::deferredPacketReady(), MSHR::delay(), Prefetcher::BOP::delayQueueEventWrapper(), MessageBuffer::dequeue(), SimpleMemory::dequeue(), Sinic::Device::devIntrChangeMask(), NSGigE::devIntrChangeMask(), Sinic::Device::devIntrPost(), NSGigE::devIntrPost(), Linux::devRandom(), GPUDispatcher::dispatch(), DefaultIEW< Impl >::dispatchInsts(), Shader::dispatchWorkgroups(), Pl111::dmaDone(), HSADevice::dmaVirt(), HSAPacketProcessor::dmaVirt(), SMMUProcess::doBroadcastSignal(), DRAMInterface::doBurstAccess(), NVMInterface::doBurstAccess(), IdeDisk::doDmaDataRead(), IdeDisk::doDmaDataWrite(), IdeDisk::doDmaRead(), IdeDisk::doDmaTransfer(), IdeDisk::doDmaWrite(), ArmISA::TableWalker::doL1DescriptorWrapper(), ArmISA::TableWalker::doL2DescriptorWrapper(), ArmISA::TableWalker::doLongDescriptorWrapper(), SMMUProcess::doSemaphoreUp(), doSimLoop(), ThermalModel::doStep(), StoreTrace::downgrade(), MemCtrl::drain(), PCEventQueue::dump(), Trace::TarmacParserRecord::dump(), EventQueue::dump(), CheckerCPU::dumpAndExit(), EtherDump::dumpPacket(), PseudoInst::dumpresetstats(), PseudoInst::dumpstats(), LdsState::earliestReturnTime(), RegisterFile::enqRegBusyEvent(), RegisterFile::enqRegFreeEvent(), EtherSwitch::Interface::enqueue(), TraceGen::enter(), Event::Event(), GlobalMemPipeline::exec(), GPUDispatcher::exec(), Shader::execScheduledAdds(), TraceCPU::ElasticDataGen::execute(), exitSimLoop(), DefaultFetch< Impl >::fetch(), IGbE::DescCache< iGbReg::RxDesc >::fetchDescriptors(), IGbE::DescCache< iGbReg::RxDesc >::fetchDescriptors1(), ElasticTrace::fetchReqTrace(), GoodbyeObject::fillBuffer(), UFSHostDevice::finalUTP(), Minor::LSQ::SplitDataRequest::finish(), DefaultFetch< Impl >::finishTranslation(), ArmISA::flattenIntRegModeIndex(), NetworkInterface::flitisizeMessage(), DRAMInterface::Rank::flushCmdList(), getElapsedTimeMicro(), getElapsedTimeNano(), Queue< WriteQueueEntry >::getNext(), BaseCache::getNextQueueEntry(), Prefetcher::Multi::getPacket(), PowerState::getWeights(), Stats::Global::Global(), MipsISA::haltThread(), MipsISA::handleLockedWrite(), RiscvISA::handleLockedWrite(), Checker< O3CPUImpl >::handlePendingInt(), MemTraceProbe::handleRequest(), DmaPort::handleResp(), SimpleCache::handleResponse(), MSHR::handleSnoop(), X86ISA::GpuTLB::handleTranslationReturn(), OutputUnit::has_credit(), OutputUnit::has_free_vc(), RubyPort::MemResponsePort::hitCallback(), RubyDirectedTester::hitCallback(), TraceCPU::icacheRetryRecvd(), NetworkInterface::incrementStats(), ComputeUnit::injectGlobalMemFence(), Prefetcher::Queued::insert(), CacheBlk::insert(), BaseTags::insertBlock(), Prefetcher::BOP::insertIntoDelayQueue(), GPUComputeDriver::ioctl(), Minor::Execute::issue(), LocalMemPipeline::issueRequest(), VIPERCoalescer::issueRequest(), GlobalMemPipeline::issueRequest(), Sequencer::issueRequest(), X86ISA::GpuTLB::issueTLBLookup(), EtherSwitch::Interface::learnSenderAddr(), BaseRemoteGDB::listen(), QoS::MemCtrl::logRequest(), QoS::MemCtrl::logResponse(), EtherSwitch::Interface::lookupDestPort(), UFSHostDevice::LUNSignal(), PseudoInst::m5checkpoint(), PseudoInst::m5exit(), PseudoInst::m5fail(), SMMUTranslationProcess::main(), GPUCoalescer::makeRequest(), RubySystem::memWriteback(), DRAMInterface::minBankPrep(), sc_gem5::Gem5ToTlmBridge< BITWIDTH >::nb_transport_bw(), TraceCPU::FixedRetryGen::nextExecute(), RandomGen::nextPacketTick(), LinearGen::nextPacketTick(), HybridGen::nextPacketTick(), TraceGen::nextPacketTick(), Shader::notifyCuSleep(), Prefetcher::SBOOE::notifyFill(), GPUDispatcher::notifyWgCompl(), BaseXBar::Layer< RequestPort, ResponsePort >::occupyLayer(), FreeBSD::onUDelay(), Linux::onUDelay(), Linux::openSpecialFile(), DistIface::packetOut(), ArmISA::TableWalker::pendingChange(), DVFSHandler::perfLevel(), Stats::periodicStatDump(), IGbE::RxDescCache::pktComplete(), IGbE::TxDescCache::pktComplete(), DistIface::RecvScheduler::popPacket(), IGbE::postInterrupt(), BaseSimpleCPU::preExecute(), Stats::AvgStor::prepare(), Stats::AvgSampleStor::prepare(), Trace::TarmacTracerRecordV8::TraceInstEntryV8::print(), Trace::TarmacTracerRecord::TraceInstEntry::print(), Trace::TarmacTracerRecordV8::TraceRegEntryV8::print(), Trace::TarmacTracerRecord::TraceRegEntry::print(), Trace::TarmacTracerRecordV8::TraceMemEntryV8::print(), Trace::TarmacTracerRecord::TraceMemEntry::print(), Trace::TarmacParserRecord::printMismatchHeader(), MC146818::RTCEvent::process(), GlobalSimLoopExitEvent::process(), MC146818::RTCTickEvent::process(), CPUProgressEvent::process(), ArmISA::DumpStats::process(), Stats::StatEvent::process(), GlobalSyncEvent::process(), DistIface::SyncEvent::process(), DRAMInterface::Rank::processActivateEvent(), HelloObject::processEvent(), Uart8250::processIntrEvent(), ComputeUnit::DataPort::processMemRespEvent(), QoS::MemSinkCtrl::processNextReqEvent(), MemCtrl::processNextReqEvent(), DRAMInterface::Rank::processPowerEvent(), DRAMInterface::Rank::processPrechargeEvent(), TLBCoalescer::processProbeTLBEvent(), NVMInterface::processReadReadyEvent(), DRAMInterface::Rank::processRefreshEvent(), MemCtrl::processRespondEvent(), EtherLink::Link::processTxQueue(), DRAMInterface::Rank::processWakeUpEvent(), ArmISA::TableWalker::processWalk(), ArmISA::TableWalker::processWalkAArch64(), ArmISA::TableWalker::processWalkLPAE(), ArmISA::TableWalker::processWalkWrapper(), NVMInterface::processWriteRespondEvent(), MSHR::promoteDeferredTargets(), MemCtrl::pruneBurstTick(), MemChecker::ByteTracker::pruneTransactions(), EtherSwitch::Interface::PortFifo::push(), PowerDomain::pwrStateChangeCallback(), pybind_init_core(), QoS::MemCtrl::qosSchedule(), PseudoInst::quiesceNs(), PL031::read(), Sp804::Timer::read(), A9GlobalTimer::Timer::read(), CpuLocalTimer::Timer::read(), RealViewCtrl::read(), LSQUnit< Impl >::read(), UFSHostDevice::readCallback(), DRAMSim2::readComplete(), Pl111::readFramebuffer(), CheckerCPU::readMem(), X86ISA::Interrupts::readReg(), ElasticTrace::recordExecTick(), Sequencer::recordMissLatency(), ElasticTrace::recordToCommTick(), BaseCache::recvAtomic(), TLBCoalescer::MemSidePort::recvReqRetry(), StubSlavePort::recvTimingReq(), SimpleTimingPort::recvTimingReq(), RubyPort::MemResponsePort::recvTimingReq(), MemDelay::ResponsePort::recvTimingReq(), TLBCoalescer::CpuSidePort::recvTimingReq(), sc_gem5::Gem5ToTlmBridge< BITWIDTH >::recvTimingReq(), SimpleMemory::recvTimingReq(), MemCheckerMonitor::recvTimingReq(), QoS::MemSinkCtrl::recvTimingReq(), CommMonitor::recvTimingReq(), MemCtrl::recvTimingReq(), RubyPort::MemRequestPort::recvTimingResp(), MemDelay::RequestPort::recvTimingResp(), BaseTrafficGen::recvTimingResp(), RubyPort::PioRequestPort::recvTimingResp(), NoncoherentXBar::recvTimingResp(), MemCheckerMonitor::recvTimingResp(), CommMonitor::recvTimingResp(), X86ISA::GpuTLB::MemSidePort::recvTimingResp(), CoherentXBar::recvTimingResp(), BaseCache::recvTimingResp(), ComputeUnit::DataPort::recvTimingResp(), ComputeUnit::DTLBPort::recvTimingResp(), MemDelay::ResponsePort::recvTimingSnoopResp(), CoherentXBar::recvTimingSnoopResp(), ElasticTrace::regEtraceListeners(), ElasticTrace::regProbeListeners(), UFSHostDevice::requestHandler(), BankedArray::reserve(), BIPRP::reset(), WeightedLRUPolicy::reset(), LRURP::reset(), MRURP::reset(), FIFORP::reset(), Stats::AvgStor::reset(), Clocked::resetClock(), PseudoInst::resetstats(), DRAMInterface::Rank::resetStats(), DRAMInterface::DRAMStats::resetStats(), DRAMInterface::respondEvent(), Sp804::Timer::restartCounter(), Sp805::restartCounter(), A9GlobalTimer::Timer::restartCounter(), CpuLocalTimer::Timer::restartTimerCounter(), CpuLocalTimer::Timer::restartWatchdogCounter(), MipsISA::restoreThread(), Stats::AvgStor::result(), BasePixelPump::PixelEvent::resume(), DistIface::RecvScheduler::resumeRecvTicks(), SMMUTranslationProcess::resumeTransaction(), PL031::resyncMatch(), EtherTapBase::retransmit(), BaseTrafficGen::retryReq(), PseudoInst::rpns(), HTMSequencer::rubyHtmCallback(), StatTest::run(), DistIface::SyncNode::run(), DistIface::SyncSwitch::run(), Sinic::Device::rxKick(), NSGigE::rxKick(), CommMonitor::samplePeriodic(), HSAPacketProcessor::schedAQLProcessing(), TraceCPU::schedIcacheNext(), schedRelBreak(), PacketQueue::schedSendEvent(), PacketQueue::schedSendTiming(), Shader::ScheduleAdd(), GPUDispatcher::scheduleDispatch(), MC146818::RTCEvent::scheduleIntr(), Uart8250::scheduleIntr(), NetworkInterface::scheduleOutputPort(), DRAMInterface::Rank::schedulePowerEvent(), InstructionQueue< Impl >::scheduleReadyInsts(), BaseTrafficGen::scheduleUpdate(), DRAMInterface::Rank::scheduleWakeUpEvent(), HWScheduler::schedWakeup(), OutputUnit::select_free_vc(), Iris::ThreadContext::semihostingEvent(), EtherBus::send(), SwitchAllocator::send_allowed(), X86ISA::IntRequestPort< X86ISA::I82094AA >::sendMessage(), ComputeUnit::sendRequest(), DRAMSim2::sendResponse(), DRAMsim3::sendResponse(), EtherTapBase::sendSimulated(), Globals::serialize(), MC146818::serialize(), Intel8254Timer::Counter::serialize(), Sinic::Device::serialize(), NSGigE::serialize(), PowerState::set(), Stats::AvgStor::set(), Request::setAccessLatency(), CheckpointIn::setDir(), Pl011::setInterrupts(), CacheMemory::setMRU(), X86ISA::Interrupts::setReg(), Wavefront::setStatus(), Intel8254Timer::Counter::CounterEvent::setTo(), Request::setTranslateLatency(), Request::setVirt(), Event::setWhen(), simulate(), SMMUTranslationProcess::smmuTranslation(), DefaultRename< Impl >::sortInsts(), DistIface::SyncEvent::start(), IdeDisk::startDma(), sc_gem5::Kernel::startup(), CommMonitor::startup(), BaseKvmCPU::startup(), RubySystem::startup(), MC146818::startup(), ThermalModel::startup(), Intel8254Timer::Counter::startup(), DRAMSim2::startup(), DRAMsim3::startup(), DRAMInterface::Rank::startup(), MemCtrl::startup(), DRAMInterface::startup(), Stats::statElapsedTicks(), Stats::statFinalTick(), StoreTrace::store(), O3ThreadContext< Impl >::suspend(), SimpleThread::suspend(), BasePixelPump::PixelEvent::suspend(), takeCheckpoint(), CacheMemory::testCacheAccess(), GarnetSyntheticTraffic::tick(), AtomicSimpleCPU::tick(), IGbE::tick(), DRAMSim2::tick(), DRAMsim3::tick(), BaseKvmCPU::tick(), timesFunc(), Root::timeSync(), Root::timeSyncEnable(), WeightedLRUPolicy::touch(), LRURP::touch(), MRURP::touch(), BaseCPU::traceFunctionsInternal(), Trace::InstPBTrace::traceInst(), BaseTrafficGen::transition(), Prefetcher::Queued::translationComplete(), X86ISA::GpuTLB::translationReturn(), EtherLink::Link::transmit(), DistEtherLink::TxLink::transmit(), EtherSwitch::Interface::transmit(), NSGigE::transmit(), BankedArray::tryAccess(), CacheMemory::tryCacheAccess(), SerialLink::SerialLinkResponsePort::trySendTiming(), Bridge::BridgeResponsePort::trySendTiming(), SerialLink::SerialLinkRequestPort::trySendTiming(), Bridge::BridgeRequestPort::trySendTiming(), EtherLink::Link::txDone(), Sinic::Device::txKick(), NSGigE::txKick(), Sinic::Device::unserialize(), NSGigE::unserialize(), Clocked::update(), BaseTrafficGen::update(), ElasticTrace::updateCommitOrderDep(), Stats::updateEvents(), DefaultIEW< Impl >::updateExeInstStats(), VGic::updateIntState(), GicV2::updateIntState(), GPUDispatcher::updateInvCounter(), ElasticTrace::updateIssueOrderDep(), X86ISA::GpuTLB::updatePageFootprint(), TLBCoalescer::updatePhysAddresses(), DRAMInterface::Rank::updatePowerStats(), CommMonitor::MonitorStats::updateReqStats(), SystemCounter::updateTick(), SystemCounter::updateValue(), Checker< O3CPUImpl >::validateExecution(), Checker< O3CPUImpl >::validateInst(), Checker< O3CPUImpl >::validateState(), Checker< O3CPUImpl >::verify(), HDLcd::virtRefresh(), CrossbarSwitch::wakeup(), InputUnit::wakeup(), OutputUnit::wakeup(), NetworkLink::wakeup(), NetworkBridge::wakeup(), NetworkInterface::wakeup(), Router::wakeup(), RubyDirectedTester::wakeup(), RubyTester::wakeup(), GPUCoalescer::wakeup(), ArmISA::TableWalker::walk(), SystemCounter::whenValue(), System::workItemBegin(), System::workItemEnd(), Uart8250::write(), PL031::write(), EnergyCtrl::write(), UFSHostDevice::write(), IGbE::DescCache< iGbReg::RxDesc >::writeback(), IGbE::DescCache< iGbReg::RxDesc >::writeback1(), LSQUnit< Impl >::writebackStores(), DRAMSim2::writeComplete(), MC146818::writeData(), UFSHostDevice::writeDevice(), CheckerCPU::writeMem(), and MipsISA::yieldThread().

◆ debugDumpStats()

void debugDumpStats ( )

Definition at line 597 of file statistics.cc.

References Stats::dump().


Generated on Wed Sep 30 2020 14:02:18 for gem5 by doxygen 1.8.17