gem5
v19.0.0.0
|
FullO3CPU class, has each of the stages (fetch through commit) within it, as well as all of the time buffers between stages. More...
#include <cpu.hh>
Public Types | |
enum | Status { Running, Idle, Halted, Blocked, SwitchedOut } |
enum | StageIdx { FetchIdx, DecodeIdx, RenameIdx, IEWIdx, CommitIdx, NumStages } |
Enum to give each stage a specific index, so when calling activateStage() or deactivateStage(), they can specify which stage is being activated/deactivated. More... | |
typedef Impl::CPUPol | CPUPolicy |
typedef Impl::DynInstPtr | DynInstPtr |
typedef Impl::O3CPU | O3CPU |
using | VecElem = TheISA::VecElem |
using | VecRegContainer = TheISA::VecRegContainer |
using | VecPredRegContainer = TheISA::VecPredRegContainer |
typedef O3ThreadState< Impl > | ImplState |
typedef O3ThreadState< Impl > | Thread |
typedef std::list< DynInstPtr >::iterator | ListIt |
using | LSQRequest = typename LSQ< Impl >::LSQRequest |
typedef CPUPolicy::TimeStruct | TimeStruct |
Typedefs from the Impl to get the structs that each of the time buffers should use. More... | |
typedef CPUPolicy::FetchStruct | FetchStruct |
typedef CPUPolicy::DecodeStruct | DecodeStruct |
typedef CPUPolicy::RenameStruct | RenameStruct |
typedef CPUPolicy::IEWStruct | IEWStruct |
![]() | |
typedef BaseCPUParams | Params |
![]() | |
typedef ClockedObjectParams | Params |
Parameters of ClockedObject. More... | |
![]() | |
typedef SimObjectParams | Params |
Public Member Functions | |
FullO3CPU (DerivO3CPUParams *params) | |
Constructs a CPU with the given parameters. More... | |
~FullO3CPU () | |
Destructor. More... | |
void | regStats () override |
Registers statistics. More... | |
void | regProbePoints () override |
Register probe points. More... | |
void | demapPage (Addr vaddr, uint64_t asn) |
void | demapInstPage (Addr vaddr, uint64_t asn) |
void | demapDataPage (Addr vaddr, uint64_t asn) |
void | tick () |
Ticks CPU, calling tick() on each stage, and checking the overall activity to see if the CPU should deschedule itself. More... | |
void | init () override |
Initialize the CPU. More... | |
void | startup () override |
startup() is the final initialization call before simulation. More... | |
int | numActiveThreads () |
Returns the Number of Active Threads in the CPU. More... | |
void | activateThread (ThreadID tid) |
Add Thread to Active Threads List. More... | |
void | deactivateThread (ThreadID tid) |
Remove Thread from Active Threads List. More... | |
void | insertThread (ThreadID tid) |
Setup CPU to insert a thread's context. More... | |
void | removeThread (ThreadID tid) |
Remove all of a thread's context from CPU. More... | |
Counter | totalInsts () const override |
Count the Total Instructions Committed in the CPU. More... | |
Counter | totalOps () const override |
Count the Total Ops (including micro ops) committed in the CPU. More... | |
void | activateContext (ThreadID tid) override |
Add Thread to Active Threads List. More... | |
void | suspendContext (ThreadID tid) override |
Remove Thread from Active Threads List. More... | |
void | haltContext (ThreadID tid) override |
Remove Thread from Active Threads List && Remove Thread Context from CPU. More... | |
void | updateThreadPriority () |
Update The Order In Which We Process Threads. More... | |
bool | isDraining () const |
Is the CPU draining? More... | |
void | serializeThread (CheckpointOut &cp, ThreadID tid) const override |
Serialize a single thread. More... | |
void | unserializeThread (CheckpointIn &cp, ThreadID tid) override |
Unserialize one thread. More... | |
void | addThreadToExitingList (ThreadID tid) |
Insert tid to the list of threads trying to exit. More... | |
bool | isThreadExiting (ThreadID tid) const |
Is the thread trying to exit? More... | |
void | scheduleThreadExitEvent (ThreadID tid) |
If a thread is trying to exit and its corresponding trap event has been completed, schedule an event to terminate the thread. More... | |
void | exitThreads () |
Terminate all threads that are ready to exit. More... | |
void | syscall (ThreadID tid, Fault *fault) |
Executes a syscall. More... | |
DrainState | drain () override |
Starts draining the CPU's pipeline of all instructions in order to stop all memory accesses. More... | |
void | drainResume () override |
Resumes execution after a drain. More... | |
void | commitDrained (ThreadID tid) |
Commit has reached a safe point to drain a thread. More... | |
void | switchOut () override |
Switches out this CPU. More... | |
void | takeOverFrom (BaseCPU *oldCPU) override |
Takes over from another CPU. More... | |
void | verifyMemoryMode () const override |
Verify that the system is in a memory mode supported by the CPU. More... | |
InstSeqNum | getAndIncrementInstSeq () |
Get the current instruction sequence number, and increment it. More... | |
void | trap (const Fault &fault, ThreadID tid, const StaticInstPtr &inst) |
Traps to handle given fault. More... | |
void | switchRenameMode (ThreadID tid, UnifiedFreeList *freelist) |
Check if a change in renaming is needed for vector registers. More... | |
Fault | getInterrupts () |
Returns the Fault for any valid interrupt. More... | |
void | processInterrupts (const Fault &interrupt) |
Processes any an interrupt fault. More... | |
void | halt () |
Halts the CPU. More... | |
RegVal | readMiscRegNoEffect (int misc_reg, ThreadID tid) const |
Register accessors. More... | |
RegVal | readMiscReg (int misc_reg, ThreadID tid) |
Reads a misc. More... | |
void | setMiscRegNoEffect (int misc_reg, RegVal val, ThreadID tid) |
Sets a miscellaneous register. More... | |
void | setMiscReg (int misc_reg, RegVal val, ThreadID tid) |
Sets a misc. More... | |
RegVal | readIntReg (PhysRegIdPtr phys_reg) |
RegVal | readFloatReg (PhysRegIdPtr phys_reg) |
const VecRegContainer & | readVecReg (PhysRegIdPtr reg_idx) const |
VecRegContainer & | getWritableVecReg (PhysRegIdPtr reg_idx) |
Read physical vector register for modification. More... | |
Enums::VecRegRenameMode | vecRenameMode () const |
Returns current vector renaming mode. More... | |
void | vecRenameMode (Enums::VecRegRenameMode vec_mode) |
Sets the current vector renaming mode. More... | |
template<typename VecElem , int LaneIdx> | |
VecLaneT< VecElem, true > | readVecLane (PhysRegIdPtr phys_reg) const |
Read physical vector register lane. More... | |
template<typename VecElem > | |
VecLaneT< VecElem, true > | readVecLane (PhysRegIdPtr phys_reg) const |
Read physical vector register lane. More... | |
template<typename LD > | |
void | setVecLane (PhysRegIdPtr phys_reg, const LD &val) |
Write a lane of the destination vector register. More... | |
const VecElem & | readVecElem (PhysRegIdPtr reg_idx) const |
const VecPredRegContainer & | readVecPredReg (PhysRegIdPtr reg_idx) const |
VecPredRegContainer & | getWritableVecPredReg (PhysRegIdPtr reg_idx) |
RegVal | readCCReg (PhysRegIdPtr phys_reg) |
void | setIntReg (PhysRegIdPtr phys_reg, RegVal val) |
void | setFloatReg (PhysRegIdPtr phys_reg, RegVal val) |
void | setVecReg (PhysRegIdPtr reg_idx, const VecRegContainer &val) |
void | setVecElem (PhysRegIdPtr reg_idx, const VecElem &val) |
void | setVecPredReg (PhysRegIdPtr reg_idx, const VecPredRegContainer &val) |
void | setCCReg (PhysRegIdPtr phys_reg, RegVal val) |
RegVal | readArchIntReg (int reg_idx, ThreadID tid) |
RegVal | readArchFloatReg (int reg_idx, ThreadID tid) |
const VecRegContainer & | readArchVecReg (int reg_idx, ThreadID tid) const |
VecRegContainer & | getWritableArchVecReg (int reg_idx, ThreadID tid) |
Read architectural vector register for modification. More... | |
template<typename VecElem > | |
VecLaneT< VecElem, true > | readArchVecLane (int reg_idx, int lId, ThreadID tid) const |
Read architectural vector register lane. More... | |
template<typename LD > | |
void | setArchVecLane (int reg_idx, int lId, ThreadID tid, const LD &val) |
Write a lane of the destination vector register. More... | |
const VecElem & | readArchVecElem (const RegIndex ®_idx, const ElemIndex &ldx, ThreadID tid) const |
const VecPredRegContainer & | readArchVecPredReg (int reg_idx, ThreadID tid) const |
VecPredRegContainer & | getWritableArchVecPredReg (int reg_idx, ThreadID tid) |
RegVal | readArchCCReg (int reg_idx, ThreadID tid) |
void | setArchIntReg (int reg_idx, RegVal val, ThreadID tid) |
Architectural register accessors. More... | |
void | setArchFloatReg (int reg_idx, RegVal val, ThreadID tid) |
void | setArchVecPredReg (int reg_idx, const VecPredRegContainer &val, ThreadID tid) |
void | setArchVecReg (int reg_idx, const VecRegContainer &val, ThreadID tid) |
void | setArchVecElem (const RegIndex ®_idx, const ElemIndex &ldx, const VecElem &val, ThreadID tid) |
void | setArchCCReg (int reg_idx, RegVal val, ThreadID tid) |
void | pcState (const TheISA::PCState &newPCState, ThreadID tid) |
Sets the commit PC state of a specific thread. More... | |
TheISA::PCState | pcState (ThreadID tid) |
Reads the commit PC state of a specific thread. More... | |
Addr | instAddr (ThreadID tid) |
Reads the commit PC of a specific thread. More... | |
MicroPC | microPC (ThreadID tid) |
Reads the commit micro PC of a specific thread. More... | |
Addr | nextInstAddr (ThreadID tid) |
Reads the next PC of a specific thread. More... | |
void | squashFromTC (ThreadID tid) |
Initiates a squash of all in-flight instructions for a given thread. More... | |
ListIt | addInst (const DynInstPtr &inst) |
Function to add instruction onto the head of the list of the instructions. More... | |
void | instDone (ThreadID tid, const DynInstPtr &inst) |
Function to tell the CPU that an instruction has completed. More... | |
void | removeFrontInst (const DynInstPtr &inst) |
Remove an instruction from the front end of the list. More... | |
void | removeInstsNotInROB (ThreadID tid) |
Remove all instructions that are not currently in the ROB. More... | |
void | removeInstsUntil (const InstSeqNum &seq_num, ThreadID tid) |
Remove all instructions younger than the given sequence number. More... | |
void | squashInstIt (const ListIt &instIt, ThreadID tid) |
Removes the instruction pointed to by the iterator. More... | |
void | cleanUpRemovedInsts () |
Cleans up all instructions on the remove list. More... | |
void | dumpInsts () |
Debug function to print all instructions on the list. More... | |
void | activityThisCycle () |
Records that there was time buffer activity this cycle. More... | |
void | activateStage (const StageIdx idx) |
Changes a stage's status to active within the activity recorder. More... | |
void | deactivateStage (const StageIdx idx) |
Changes a stage's status to inactive within the activity recorder. More... | |
void | wakeCPU () |
Wakes the CPU, rescheduling the CPU if it's not already active. More... | |
virtual void | wakeup (ThreadID tid) override |
ThreadID | getFreeTid () |
Gets a free thread id. More... | |
ThreadContext * | tcBase (ThreadID tid) |
Returns a pointer to a thread context. More... | |
Fault | pushRequest (const DynInstPtr &inst, bool isLoad, uint8_t *data, unsigned int size, Addr addr, Request::Flags flags, uint64_t *res, AtomicOpFunctorPtr amo_op=nullptr, const std::vector< bool > &byte_enable=std::vector< bool >()) |
CPU pushRequest function, forwards request to LSQ. More... | |
Fault | read (LSQRequest *req, int load_idx) |
CPU read function, forwards read to LSQ. More... | |
Fault | write (LSQRequest *req, uint8_t *data, int store_idx) |
CPU write function, forwards write to LSQ. More... | |
Port & | getInstPort () override |
Used by the fetch unit to get a hold of the instruction port. More... | |
Port & | getDataPort () override |
Get the dcache port (used to find block size for translations). More... | |
![]() | |
BaseO3CPU (BaseCPUParams *params) | |
![]() | |
virtual PortProxy::SendFunctionalFunc | getSendFunctional () |
Returns a sendFunctional delegate for use with port proxies. More... | |
int | cpuId () const |
Reads this CPU's ID. More... | |
uint32_t | socketId () const |
Reads this CPU's Socket ID. More... | |
MasterID | dataMasterId () const |
Reads this CPU's unique data requestor ID. More... | |
MasterID | instMasterId () const |
Reads this CPU's unique instruction requestor ID. More... | |
Port & | getPort (const std::string &if_name, PortID idx=InvalidPortID) override |
Get a port on this CPU. More... | |
uint32_t | taskId () const |
Get cpu task id. More... | |
void | taskId (uint32_t id) |
Set cpu task id. More... | |
uint32_t | getPid () const |
void | setPid (uint32_t pid) |
void | workItemBegin () |
void | workItemEnd () |
Tick | instCount () |
BaseInterrupts * | getInterruptController (ThreadID tid) |
void | postInterrupt (ThreadID tid, int int_num, int index) |
void | clearInterrupt (ThreadID tid, int int_num, int index) |
void | clearInterrupts (ThreadID tid) |
bool | checkInterrupts (ThreadContext *tc) const |
void | processProfileEvent () |
Trace::InstTracer * | getTracer () |
Provide access to the tracer pointer. More... | |
int | findContext (ThreadContext *tc) |
Given a Thread Context pointer return the thread num. More... | |
virtual ThreadContext * | getContext (int tn) |
Given a thread num get tho thread context for it. More... | |
unsigned | numContexts () |
Get the number of thread contexts available. More... | |
ThreadID | contextToThread (ContextID cid) |
Convert ContextID to threadID. More... | |
const Params * | params () const |
BaseCPU (Params *params, bool is_checker=false) | |
virtual | ~BaseCPU () |
void | registerThreadContexts () |
void | deschedulePowerGatingEvent () |
void | schedulePowerGatingEvent () |
void | flushTLBs () |
Flush all TLBs in the CPU. More... | |
bool | switchedOut () const |
Determine if the CPU is switched out. More... | |
unsigned int | cacheLineSize () const |
Get the cache line size of the system. More... | |
void | serialize (CheckpointOut &cp) const override |
Serialize this object to the given output stream. More... | |
void | unserialize (CheckpointIn &cp) override |
Reconstruct the state of this object from a checkpoint. More... | |
void | scheduleInstStop (ThreadID tid, Counter insts, const char *cause) |
Schedule an event that exits the simulation loops after a predefined number of instructions. More... | |
uint64_t | getCurrentInstCount (ThreadID tid) |
Get the number of instructions executed by the specified thread on this CPU. More... | |
void | traceFunctions (Addr pc) |
void | armMonitor (ThreadID tid, Addr address) |
bool | mwait (ThreadID tid, PacketPtr pkt) |
void | mwaitAtomic (ThreadID tid, ThreadContext *tc, BaseTLB *dtb) |
AddressMonitor * | getCpuAddrMonitor (ThreadID tid) |
bool | waitForRemoteGDB () const |
virtual void | probeInstCommit (const StaticInstPtr &inst, Addr pc) |
Helper method to trigger PMU probes for a committed instruction. More... | |
![]() | |
ClockedObject (const ClockedObjectParams *p) | |
const Params * | params () const |
void | serialize (CheckpointOut &cp) const override |
Serialize an object. More... | |
void | unserialize (CheckpointIn &cp) override |
Unserialize an object. More... | |
Enums::PwrState | pwrState () const |
std::string | pwrStateName () const |
std::vector< double > | pwrStateWeights () const |
Returns the percentage residency for each power state. More... | |
void | computeStats () |
Record stats values like state residency by computing the time difference from previous update. More... | |
void | pwrState (Enums::PwrState) |
![]() | |
const Params * | params () const |
SimObject (const Params *_params) | |
virtual | ~SimObject () |
virtual const std::string | name () const |
virtual void | loadState (CheckpointIn &cp) |
loadState() is called on each SimObject when restoring from a checkpoint. More... | |
virtual void | initState () |
initState() is called on each SimObject when not restoring from a checkpoint. More... | |
virtual void | regProbeListeners () |
Register probe listeners for this object. More... | |
ProbeManager * | getProbeManager () |
Get the probe manager for this object. More... | |
DrainState | drain () override |
Provide a default implementation of the drain interface for objects that don't need draining. More... | |
virtual void | memWriteback () |
Write back dirty buffers to memory using functional writes. More... | |
virtual void | memInvalidate () |
Invalidate the contents of memory buffers. More... | |
void | serialize (CheckpointOut &cp) const override |
Serialize an object. More... | |
void | unserialize (CheckpointIn &cp) override |
Unserialize an object. More... | |
![]() | |
EventManager (EventManager &em) | |
EventManager (EventManager *em) | |
EventManager (EventQueue *eq) | |
EventQueue * | eventQueue () const |
void | schedule (Event &event, Tick when) |
void | deschedule (Event &event) |
void | reschedule (Event &event, Tick when, bool always=false) |
void | schedule (Event *event, Tick when) |
void | deschedule (Event *event) |
void | reschedule (Event *event, Tick when, bool always=false) |
void | wakeupEventQueue (Tick when=(Tick) -1) |
void | setCurTick (Tick newVal) |
![]() | |
Serializable () | |
virtual | ~Serializable () |
void | serializeSection (CheckpointOut &cp, const char *name) const |
Serialize an object into a new section. More... | |
void | serializeSection (CheckpointOut &cp, const std::string &name) const |
void | unserializeSection (CheckpointIn &cp, const char *name) |
Unserialize an a child object. More... | |
void | unserializeSection (CheckpointIn &cp, const std::string &name) |
![]() | |
DrainState | drainState () const |
Return the current drain state of an object. More... | |
virtual void | notifyFork () |
Notify a child process of a fork. More... | |
![]() | |
Group ()=delete | |
Group (const Group &)=delete | |
Group & | operator= (const Group &)=delete |
Group (Group *parent, const char *name=nullptr) | |
Construct a new statistics group. More... | |
virtual | ~Group () |
virtual void | resetStats () |
Callback to reset stats. More... | |
virtual void | preDumpStats () |
Callback before stats are dumped. More... | |
void | addStat (Stats::Info *info) |
Register a stat with this group. More... | |
const std::map< std::string, Group * > & | getStatGroups () const |
Get all child groups associated with this object. More... | |
const std::vector< Info * > & | getStats () const |
Get all stats associated with this object. More... | |
void | addStatGroup (const char *name, Group *block) |
Add a stat block as a child of this block. More... | |
![]() | |
void | updateClockPeriod () |
Update the tick to the current tick. More... | |
Tick | clockEdge (Cycles cycles=Cycles(0)) const |
Determine the tick when a cycle begins, by default the current one, but the argument also enables the caller to determine a future cycle. More... | |
Cycles | curCycle () const |
Determine the current cycle, corresponding to a tick aligned to a clock edge. More... | |
Tick | nextCycle () const |
Based on the clock of the object, determine the start tick of the first cycle that is at least one cycle in the future. More... | |
uint64_t | frequency () const |
Tick | clockPeriod () const |
double | voltage () const |
Cycles | ticksToCycles (Tick t) const |
Tick | cyclesToTicks (Cycles c) const |
Public Attributes | |
BaseTLB * | itb |
BaseTLB * | dtb |
Status | _status |
Overall CPU status. More... | |
ProbePointArg< PacketPtr > * | ppInstAccessComplete |
ProbePointArg< std::pair< DynInstPtr, PacketPtr > > * | ppDataAccessComplete |
int | instcount |
Count of total number of dynamic instructions in flight. More... | |
std::list< DynInstPtr > | instList |
List of all the instructions in flight. More... | |
std::queue< ListIt > | removeList |
List of all the instructions that will be removed at the end of this cycle. More... | |
bool | removeInstsThisCycle |
Records if instructions need to be removed this cycle due to being retired or squashed. More... | |
TimeBuffer< TimeStruct > | timeBuffer |
The main time buffer to do backwards communication. More... | |
TimeBuffer< FetchStruct > | fetchQueue |
The fetch stage's instruction queue. More... | |
TimeBuffer< DecodeStruct > | decodeQueue |
The decode stage's instruction queue. More... | |
TimeBuffer< RenameStruct > | renameQueue |
The rename stage's instruction queue. More... | |
TimeBuffer< IEWStruct > | iewQueue |
The IEW stage's instruction queue. More... | |
InstSeqNum | globalSeqNum |
The global sequence number counter. More... | |
Checker< Impl > * | checker |
Pointer to the checker, which can dynamically verify instruction results at run time. More... | |
System * | system |
Pointer to the system. More... | |
std::vector< Thread * > | thread |
Pointers to all of the threads in the CPU. More... | |
std::list< int > | cpuWaitList |
Threads Scheduled to Enter CPU. More... | |
Cycles | lastRunningCycle |
The cycle that the CPU was last running, used for statistics. More... | |
Tick | lastActivatedCycle |
The cycle that the CPU was last activated by a new thread. More... | |
std::map< ThreadID, unsigned > | threadMap |
Mapping for system thread id to cpu id. More... | |
std::vector< ThreadID > | tids |
Available thread ids in the cpu. More... | |
Stats::Scalar | timesIdled |
Stat for total number of times the CPU is descheduled. More... | |
Stats::Scalar | idleCycles |
Stat for total number of cycles the CPU spends descheduled. More... | |
Stats::Scalar | quiesceCycles |
Stat for total number of cycles the CPU spends descheduled due to a quiesce operation or waiting for an interrupt. More... | |
Stats::Vector | committedInsts |
Stat for the number of committed instructions per thread. More... | |
Stats::Vector | committedOps |
Stat for the number of committed ops (including micro ops) per thread. More... | |
Stats::Formula | cpi |
Stat for the CPI per thread. More... | |
Stats::Formula | totalCpi |
Stat for the total CPI. More... | |
Stats::Formula | ipc |
Stat for the IPC per thread. More... | |
Stats::Formula | totalIpc |
Stat for the total IPC. More... | |
Stats::Scalar | intRegfileReads |
Stats::Scalar | intRegfileWrites |
Stats::Scalar | fpRegfileReads |
Stats::Scalar | fpRegfileWrites |
Stats::Scalar | vecRegfileReads |
Stats::Scalar | vecRegfileWrites |
Stats::Scalar | vecPredRegfileReads |
Stats::Scalar | vecPredRegfileWrites |
Stats::Scalar | ccRegfileReads |
Stats::Scalar | ccRegfileWrites |
Stats::Scalar | miscRegfileReads |
Stats::Scalar | miscRegfileWrites |
![]() | |
TheISA::MicrocodeRom | microcodeRom |
EventFunctionWrapper * | profileEvent |
ThreadID | numThreads |
Number of threads we're actually simulating (<= SMT_MAX_THREADS). More... | |
System * | system |
Stats::Scalar | numCycles |
Stats::Scalar | numWorkItemsStarted |
Stats::Scalar | numWorkItemsCompleted |
Cycles | syscallRetryLatency |
Protected Attributes | |
CPUPolicy::Fetch | fetch |
The fetch stage. More... | |
CPUPolicy::Decode | decode |
The decode stage. More... | |
CPUPolicy::Rename | rename |
The dispatch stage. More... | |
CPUPolicy::IEW | iew |
The issue/execute/writeback stages. More... | |
CPUPolicy::Commit | commit |
The commit stage. More... | |
Enums::VecRegRenameMode | vecMode |
The rename mode of the vector registers. More... | |
PhysRegFile | regFile |
The register file. More... | |
CPUPolicy::FreeList | freeList |
The free list. More... | |
CPUPolicy::RenameMap | renameMap [Impl::MaxThreads] |
The rename map. More... | |
CPUPolicy::RenameMap | commitRenameMap [Impl::MaxThreads] |
The commit rename map. More... | |
CPUPolicy::ROB | rob |
The re-order buffer. More... | |
std::list< ThreadID > | activeThreads |
Active Threads List. More... | |
std::unordered_map< ThreadID, bool > | exitingThreads |
This is a list of threads that are trying to exit. More... | |
Scoreboard | scoreboard |
Integer Register Scoreboard. More... | |
std::vector< TheISA::ISA * > | isa |
![]() | |
Tick | instCnt |
Instruction count used for SPARC misc register. More... | |
int | _cpuId |
const uint32_t | _socketId |
Each cpu will have a socket ID that corresponds to its physical location in the system. More... | |
MasterID | _instMasterId |
instruction side request id that must be placed in all requests More... | |
MasterID | _dataMasterId |
data side request id that must be placed in all requests More... | |
uint32_t | _taskId |
An intrenal representation of a task identifier within gem5. More... | |
uint32_t | _pid |
The current OS process ID that is executing on this processor. More... | |
bool | _switchedOut |
Is the CPU switched out or active? More... | |
const unsigned int | _cacheLineSize |
Cache the cache line size that we get from the system. More... | |
std::vector< BaseInterrupts * > | interrupts |
std::vector< ThreadContext * > | threadContexts |
Trace::InstTracer * | tracer |
Cycles | previousCycle |
CPUState | previousState |
const Cycles | pwrGatingLatency |
const bool | powerGatingOnIdle |
EventFunctionWrapper | enterPwrGatingEvent |
ProbePoints::PMUUPtr | ppRetiredInsts |
Instruction commit probe point. More... | |
ProbePoints::PMUUPtr | ppRetiredInstsPC |
ProbePoints::PMUUPtr | ppRetiredLoads |
Retired load instructions. More... | |
ProbePoints::PMUUPtr | ppRetiredStores |
Retired store instructions. More... | |
ProbePoints::PMUUPtr | ppRetiredBranches |
Retired branches (any type) More... | |
ProbePoints::PMUUPtr | ppAllCycles |
CPU cycle counter even if any thread Context is suspended. More... | |
ProbePoints::PMUUPtr | ppActiveCycles |
CPU cycle counter, only counts if any thread contexts is active. More... | |
ProbePointArg< bool > * | ppSleeping |
ProbePoint that signals transitions of threadContexts sets. More... | |
![]() | |
Enums::PwrState | _currPwrState |
To keep track of the current power state. More... | |
Tick | prvEvalTick |
ClockedObject::ClockedObjectStats | stats |
![]() | |
const SimObjectParams * | _params |
Cached copy of the object parameters. More... | |
![]() | |
EventQueue * | eventq |
A pointer to this object's event queue. More... | |
Private Member Functions | |
void | scheduleTickEvent (Cycles delay) |
Schedule tick event, regardless of its current state. More... | |
void | unscheduleTickEvent () |
Unschedule tick event, regardless of its current state. More... | |
bool | tryDrain () |
Check if the pipeline has drained and signal drain done. More... | |
void | drainSanityCheck () const |
Perform sanity checks after a drain. More... | |
bool | isCpuDrained () const |
Check if a system is in a drained state. More... | |
Private Attributes | |
EventFunctionWrapper | tickEvent |
The tick event used for scheduling CPU ticks. More... | |
EventFunctionWrapper | threadExitEvent |
The exit event used for terminating all ready-to-exit threads. More... | |
ActivityRecorder | activityRec |
The activity recorder; used to tell if the CPU has any activity remaining or if it can go to idle and deschedule itself. More... | |
Friends | |
class | O3ThreadContext< Impl > |
Additional Inherited Members | |
![]() | |
static int | numSimulatedInsts () |
static int | numSimulatedOps () |
static void | wakeup (ThreadID tid) |
static int | numSimulatedCPUs () |
static Counter | numSimulatedInsts () |
static Counter | numSimulatedOps () |
![]() | |
static void | serializeAll (CheckpointOut &cp) |
Serialize all SimObjects in the system. More... | |
static SimObject * | find (const char *name) |
Find the SimObject with the given name and return a pointer to it. More... | |
![]() | |
static const std::string & | currentSection () |
Get the fully-qualified name of the active section. More... | |
static void | serializeAll (const std::string &cpt_dir) |
static void | unserializeGlobals (CheckpointIn &cp) |
![]() | |
static const uint32_t | invldPid = std::numeric_limits<uint32_t>::max() |
Invalid or unknown Pid. More... | |
static const Addr | PCMask = ~((Addr)sizeof(TheISA::MachInst) - 1) |
![]() | |
static int | ckptCount = 0 |
static int | ckptMaxCount = 0 |
static int | ckptPrevCount = -1 |
![]() | |
enum | CPUState { CPU_STATE_ON, CPU_STATE_SLEEP, CPU_STATE_WAKEUP } |
![]() | |
void | updateCycleCounters (CPUState state) |
base method keeping track of cycle progression More... | |
void | enterPwrGating () |
ProbePoints::PMUUPtr | pmuProbePoint (const char *name) |
Helper method to instantiate probe points belonging to this object. More... | |
![]() | |
Drainable () | |
virtual | ~Drainable () |
void | signalDrainDone () const |
Signal that an object is drained. More... | |
![]() | |
Clocked (ClockDomain &clk_domain) | |
Create a clocked object and set the clock domain based on the parameters. More... | |
Clocked (Clocked &)=delete | |
Clocked & | operator= (Clocked &)=delete |
virtual | ~Clocked () |
Virtual destructor due to inheritance. More... | |
void | resetClock () const |
Reset the object's clock using the current global tick value. More... | |
virtual void | clockPeriodUpdated () |
A hook subclasses can implement so they can do any extra work that's needed when the clock rate is changed. More... | |
FullO3CPU class, has each of the stages (fetch through commit) within it, as well as all of the time buffers between stages.
The tick() function for the CPU is defined here.
typedef CPUPolicy::DecodeStruct FullO3CPU< Impl >::DecodeStruct |
typedef Impl::DynInstPtr FullO3CPU< Impl >::DynInstPtr |
typedef CPUPolicy::FetchStruct FullO3CPU< Impl >::FetchStruct |
typedef O3ThreadState<Impl> FullO3CPU< Impl >::ImplState |
typedef std::list<DynInstPtr>::iterator FullO3CPU< Impl >::ListIt |
using FullO3CPU< Impl >::LSQRequest = typename LSQ<Impl>::LSQRequest |
typedef CPUPolicy::RenameStruct FullO3CPU< Impl >::RenameStruct |
typedef O3ThreadState<Impl> FullO3CPU< Impl >::Thread |
typedef CPUPolicy::TimeStruct FullO3CPU< Impl >::TimeStruct |
using FullO3CPU< Impl >::VecPredRegContainer = TheISA::VecPredRegContainer |
using FullO3CPU< Impl >::VecRegContainer = TheISA::VecRegContainer |
enum FullO3CPU::StageIdx |
Enum to give each stage a specific index, so when calling activateStage() or deactivateStage(), they can specify which stage is being activated/deactivated.
Enumerator | |
---|---|
FetchIdx | |
DecodeIdx | |
RenameIdx | |
IEWIdx | |
CommitIdx | |
NumStages |
enum FullO3CPU::Status |
Add Thread to Active Threads List.
Reimplemented from BaseCPU.
Definition at line 691 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::drain(), and FullO3CPU< O3CPUImpl >::insertThread().
Add Thread to Active Threads List.
Definition at line 626 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::activateContext(), and FullO3CPU< O3CPUImpl >::drainResume().
|
inline |
FullO3CPU< Impl >::ListIt FullO3CPU< Impl >::addInst | ( | const DynInstPtr & | inst | ) |
void FullO3CPU< Impl >::cleanUpRemovedInsts | ( | ) |
Cleans up all instructions on the remove list.
Definition at line 1637 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::tick().
Remove Thread from Active Threads List.
Definition at line 644 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::haltContext(), and FullO3CPU< O3CPUImpl >::suspendContext().
|
overridevirtual |
|
overridevirtual |
|
private |
Perform sanity checks after a drain.
This method is called from drain() when it has determined that the CPU is fully drained when gem5 is compiled with the NDEBUG macro undefined. The intention of this method is to do more extensive tests than the isDrained() method to weed out any draining bugs.
Definition at line 1027 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::drain().
void FullO3CPU< Impl >::dumpInsts | ( | ) |
void FullO3CPU< Impl >::exitThreads | ( | ) |
Terminate all threads that are ready to exit.
Definition at line 1805 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU().
|
inline |
auto FullO3CPU< Impl >::getWritableVecPredReg | ( | PhysRegIdPtr | reg_idx | ) |
Definition at line 1243 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::getWritableArchVecPredReg().
auto FullO3CPU< Impl >::getWritableVecReg | ( | PhysRegIdPtr | reg_idx | ) |
Read physical vector register for modification.
Definition at line 1217 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::getWritableArchVecReg().
|
inline |
Remove Thread from Active Threads List && Remove Thread Context from CPU.
Reimplemented from BaseCPU.
Definition at line 751 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::exitThreads().
|
overridevirtual |
void FullO3CPU< Impl >::instDone | ( | ThreadID | tid, |
const DynInstPtr & | inst | ||
) |
|
private |
Check if a system is in a drained state.
Definition at line 1039 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::drainSanityCheck(), and FullO3CPU< O3CPUImpl >::tryDrain().
|
inline |
|
inline |
void FullO3CPU< Impl >::pcState | ( | const TheISA::PCState & | newPCState, |
ThreadID | tid | ||
) |
Sets the commit PC state of a specific thread.
Definition at line 1462 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::cleanUpRemovedInsts(), FullO3CPU< O3CPUImpl >::insertThread(), and FullO3CPU< O3CPUImpl >::switchRenameMode().
|
inline |
|
inline |
RegVal FullO3CPU< Impl >::readCCReg | ( | PhysRegIdPtr | phys_reg | ) |
RegVal FullO3CPU< Impl >::readFloatReg | ( | PhysRegIdPtr | phys_reg | ) |
RegVal FullO3CPU< Impl >::readIntReg | ( | PhysRegIdPtr | phys_reg | ) |
auto FullO3CPU< Impl >::readVecElem | ( | PhysRegIdPtr | reg_idx | ) | const |
Definition at line 1226 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::readArchVecElem().
|
inline |
|
inline |
auto FullO3CPU< Impl >::readVecPredReg | ( | PhysRegIdPtr | reg_idx | ) | const |
Definition at line 1234 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::readArchVecPredReg().
auto FullO3CPU< Impl >::readVecReg | ( | PhysRegIdPtr | reg_idx | ) | const |
Definition at line 1208 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::readArchVecReg().
|
overridevirtual |
|
overridevirtual |
void FullO3CPU< Impl >::removeFrontInst | ( | const DynInstPtr & | inst | ) |
void FullO3CPU< Impl >::removeInstsUntil | ( | const InstSeqNum & | seq_num, |
ThreadID | tid | ||
) |
Remove all of a thread's context from CPU.
Definition at line 817 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::haltContext().
Schedule tick event, regardless of its current state.
Definition at line 143 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::activateContext().
|
overridevirtual |
void FullO3CPU< Impl >::setArchVecPredReg | ( | int | reg_idx, |
const VecPredRegContainer & | val, | ||
ThreadID | tid | ||
) |
void FullO3CPU< Impl >::setArchVecReg | ( | int | reg_idx, |
const VecRegContainer & | val, | ||
ThreadID | tid | ||
) |
void FullO3CPU< Impl >::setCCReg | ( | PhysRegIdPtr | phys_reg, |
RegVal | val | ||
) |
void FullO3CPU< Impl >::setFloatReg | ( | PhysRegIdPtr | phys_reg, |
RegVal | val | ||
) |
void FullO3CPU< Impl >::setIntReg | ( | PhysRegIdPtr | phys_reg, |
RegVal | val | ||
) |
void FullO3CPU< Impl >::setVecElem | ( | PhysRegIdPtr | reg_idx, |
const VecElem & | val | ||
) |
Definition at line 1284 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::setArchVecElem().
|
inline |
void FullO3CPU< Impl >::setVecPredReg | ( | PhysRegIdPtr | reg_idx, |
const VecPredRegContainer & | val | ||
) |
Definition at line 1292 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::setArchVecPredReg().
void FullO3CPU< Impl >::setVecReg | ( | PhysRegIdPtr | reg_idx, |
const VecRegContainer & | val | ||
) |
Definition at line 1276 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::setArchVecReg().
|
inline |
Removes the instruction pointed to by the iterator.
Definition at line 1616 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::removeInstsNotInROB(), and FullO3CPU< O3CPUImpl >::removeInstsUntil().
|
overridevirtual |
startup() is the final initialization call before simulation.
All state is initialized (including unserialized state, if any, such as the curTick() value), so this is the appropriate place to schedule initial event(s) for objects that need them.
Reimplemented from BaseCPU.
Definition at line 611 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::startup().
|
overridevirtual |
void FullO3CPU< Impl >::switchRenameMode | ( | ThreadID | tid, |
UnifiedFreeList * | freelist | ||
) |
|
inline |
Returns a pointer to a thread context.
Definition at line 678 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::addThreadToExitingList(), FullO3CPU< O3CPUImpl >::exitThreads(), FullO3CPU< O3CPUImpl >::insertThread(), FullO3CPU< O3CPUImpl >::readMiscReg(), and FullO3CPU< O3CPUImpl >::setMiscReg().
void FullO3CPU< Impl >::tick | ( | ) |
Ticks CPU, calling tick() on each stage, and checking the overall activity to see if the CPU should deschedule itself.
Definition at line 531 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU().
void FullO3CPU< Impl >::trap | ( | const Fault & | fault, |
ThreadID | tid, | ||
const StaticInstPtr & | inst | ||
) |
Traps to handle given fault.
Definition at line 905 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::processInterrupts().
|
private |
Check if the pipeline has drained and signal drain done.
This method checks if a drain has been requested and if the CPU has drained successfully (i.e., there are no instructions in the pipeline). If the CPU has drained, it deschedules the tick event and signals the drain manager.
Definition at line 1011 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::tick().
|
inlineprivate |
Unschedule tick event, regardless of its current state.
Definition at line 152 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::suspendContext().
|
overridevirtual |
void FullO3CPU< Impl >::updateThreadPriority | ( | ) |
Update The Order In Which We Process Threads.
Definition at line 1740 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::tick().
|
inline |
|
inline |
|
overridevirtual |
Verify that the system is in a memory mode supported by the CPU.
Implementations are expected to query the system for the current memory mode and ensure that it is what the CPU model expects. If the check fails, the implementation should terminate the simulation using fatal().
Reimplemented from BaseCPU.
Definition at line 1152 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::drainResume().
void FullO3CPU< Impl >::wakeCPU | ( | ) |
Wakes the CPU, rescheduling the CPU if it's not already active.
Definition at line 1691 of file cpu.cc.
Referenced by FullO3CPU< O3CPUImpl >::drain(), and FullO3CPU< O3CPUImpl >::wakeup().
|
inline |
|
friend |
Overall CPU status.
Definition at line 132 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::activateContext(), FullO3CPU< O3CPUImpl >::drainResume(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::suspendContext(), FullO3CPU< O3CPUImpl >::switchOut(), FullO3CPU< O3CPUImpl >::takeOverFrom(), and FullO3CPU< O3CPUImpl >::tick().
Active Threads List.
Definition at line 593 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::activateThread(), FullO3CPU< O3CPUImpl >::deactivateThread(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::suspendContext(), and FullO3CPU< O3CPUImpl >::updateThreadPriority().
|
private |
The activity recorder; used to tell if the CPU has any activity remaining or if it can go to idle and deschedule itself.
Definition at line 653 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::activateContext(), FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::switchOut(), FullO3CPU< O3CPUImpl >::tick(), and FullO3CPU< O3CPUImpl >::wakeCPU().
Stats::Scalar FullO3CPU< Impl >::ccRegfileReads |
Definition at line 784 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::readArchCCReg(), FullO3CPU< O3CPUImpl >::readCCReg(), and FullO3CPU< O3CPUImpl >::regStats().
Stats::Scalar FullO3CPU< Impl >::ccRegfileWrites |
Definition at line 785 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::setArchCCReg(), and FullO3CPU< O3CPUImpl >::setCCReg().
Pointer to the checker, which can dynamically verify instruction results at run time.
This can be set to NULL if it is not being used.
Definition at line 690 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::switchOut().
|
protected |
The commit stage.
Definition at line 572 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::deactivateThread(), FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::drainResume(), FullO3CPU< O3CPUImpl >::drainSanityCheck(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::init(), FullO3CPU< O3CPUImpl >::insertThread(), FullO3CPU< O3CPUImpl >::instAddr(), FullO3CPU< O3CPUImpl >::isCpuDrained(), FullO3CPU< O3CPUImpl >::microPC(), FullO3CPU< O3CPUImpl >::nextInstAddr(), FullO3CPU< O3CPUImpl >::pcState(), FullO3CPU< O3CPUImpl >::regProbePoints(), FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::removeThread(), FullO3CPU< O3CPUImpl >::squashFromTC(), FullO3CPU< O3CPUImpl >::startup(), FullO3CPU< O3CPUImpl >::takeOverFrom(), and FullO3CPU< O3CPUImpl >::tick().
|
protected |
The commit rename map.
Definition at line 587 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::getWritableArchVecPredReg(), FullO3CPU< O3CPUImpl >::getWritableArchVecReg(), FullO3CPU< O3CPUImpl >::readArchCCReg(), FullO3CPU< O3CPUImpl >::readArchFloatReg(), FullO3CPU< O3CPUImpl >::readArchIntReg(), FullO3CPU< O3CPUImpl >::readArchVecElem(), FullO3CPU< O3CPUImpl >::readArchVecPredReg(), FullO3CPU< O3CPUImpl >::readArchVecReg(), FullO3CPU< O3CPUImpl >::setArchCCReg(), FullO3CPU< O3CPUImpl >::setArchFloatReg(), FullO3CPU< O3CPUImpl >::setArchIntReg(), FullO3CPU< O3CPUImpl >::setArchVecElem(), FullO3CPU< O3CPUImpl >::setArchVecPredReg(), FullO3CPU< O3CPUImpl >::setArchVecReg(), and FullO3CPU< O3CPUImpl >::switchRenameMode().
Stats::Vector FullO3CPU< Impl >::committedInsts |
Stat for the number of committed instructions per thread.
Definition at line 759 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::instDone(), and FullO3CPU< O3CPUImpl >::regStats().
Stats::Vector FullO3CPU< Impl >::committedOps |
Stat for the number of committed ops (including micro ops) per thread.
Definition at line 761 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::instDone(), and FullO3CPU< O3CPUImpl >::regStats().
Stats::Formula FullO3CPU< Impl >::cpi |
Stat for the CPI per thread.
Definition at line 763 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats().
|
protected |
The decode stage.
Definition at line 563 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drainSanityCheck(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::isCpuDrained(), FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::removeThread(), FullO3CPU< O3CPUImpl >::startup(), FullO3CPU< O3CPUImpl >::takeOverFrom(), and FullO3CPU< O3CPUImpl >::tick().
TimeBuffer<DecodeStruct> FullO3CPU< Impl >::decodeQueue |
The decode stage's instruction queue.
Definition at line 640 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::tick().
This is a list of threads that are trying to exit.
Each thread id is mapped to a boolean value denoting whether the thread is ready to exit.
Definition at line 600 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::addThreadToExitingList(), FullO3CPU< O3CPUImpl >::exitThreads(), FullO3CPU< O3CPUImpl >::isThreadExiting(), and FullO3CPU< O3CPUImpl >::scheduleThreadExitEvent().
|
protected |
The fetch stage.
Definition at line 560 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::activateContext(), FullO3CPU< O3CPUImpl >::commitDrained(), FullO3CPU< O3CPUImpl >::deactivateThread(), FullO3CPU< O3CPUImpl >::drainResume(), FullO3CPU< O3CPUImpl >::drainSanityCheck(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::isCpuDrained(), FullO3CPU< O3CPUImpl >::regProbePoints(), FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::removeThread(), FullO3CPU< O3CPUImpl >::startup(), FullO3CPU< O3CPUImpl >::takeOverFrom(), and FullO3CPU< O3CPUImpl >::tick().
TimeBuffer<FetchStruct> FullO3CPU< Impl >::fetchQueue |
The fetch stage's instruction queue.
Definition at line 637 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::tick().
Stats::Scalar FullO3CPU< Impl >::fpRegfileReads |
Definition at line 775 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::readArchFloatReg(), FullO3CPU< O3CPUImpl >::readFloatReg(), and FullO3CPU< O3CPUImpl >::regStats().
Stats::Scalar FullO3CPU< Impl >::fpRegfileWrites |
Definition at line 776 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::setArchFloatReg(), and FullO3CPU< O3CPUImpl >::setFloatReg().
|
protected |
The free list.
Definition at line 581 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::insertThread().
InstSeqNum FullO3CPU< Impl >::globalSeqNum |
The global sequence number counter.
Definition at line 684 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::takeOverFrom().
Stats::Scalar FullO3CPU< Impl >::idleCycles |
Stat for total number of cycles the CPU spends descheduled.
Definition at line 754 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats(), and FullO3CPU< O3CPUImpl >::wakeCPU().
|
protected |
The issue/execute/writeback stages.
Definition at line 569 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drainSanityCheck(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::isCpuDrained(), FullO3CPU< O3CPUImpl >::regProbePoints(), FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::removeThread(), FullO3CPU< O3CPUImpl >::startup(), FullO3CPU< O3CPUImpl >::takeOverFrom(), and FullO3CPU< O3CPUImpl >::tick().
TimeBuffer<IEWStruct> FullO3CPU< Impl >::iewQueue |
The IEW stage's instruction queue.
Definition at line 646 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::tick().
int FullO3CPU< Impl >::instcount |
Count of total number of dynamic instructions in flight.
Definition at line 535 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU().
std::list<DynInstPtr> FullO3CPU< Impl >::instList |
List of all the instructions in flight.
Definition at line 539 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::addInst(), FullO3CPU< O3CPUImpl >::cleanUpRemovedInsts(), FullO3CPU< O3CPUImpl >::dumpInsts(), FullO3CPU< O3CPUImpl >::isCpuDrained(), FullO3CPU< O3CPUImpl >::removeInstsNotInROB(), and FullO3CPU< O3CPUImpl >::removeInstsUntil().
Stats::Scalar FullO3CPU< Impl >::intRegfileReads |
Definition at line 772 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::readArchIntReg(), FullO3CPU< O3CPUImpl >::readIntReg(), and FullO3CPU< O3CPUImpl >::regStats().
Stats::Scalar FullO3CPU< Impl >::intRegfileWrites |
Definition at line 773 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::setArchIntReg(), and FullO3CPU< O3CPUImpl >::setIntReg().
Stats::Formula FullO3CPU< Impl >::ipc |
Stat for the IPC per thread.
Definition at line 767 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats().
|
protected |
The cycle that the CPU was last activated by a new thread.
Definition at line 705 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::activateContext(), and FullO3CPU< O3CPUImpl >::FullO3CPU().
The cycle that the CPU was last running, used for statistics.
Definition at line 702 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::activateContext(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::suspendContext(), FullO3CPU< O3CPUImpl >::takeOverFrom(), FullO3CPU< O3CPUImpl >::tick(), and FullO3CPU< O3CPUImpl >::wakeCPU().
Stats::Scalar FullO3CPU< Impl >::miscRegfileReads |
Definition at line 787 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::readMiscReg(), and FullO3CPU< O3CPUImpl >::regStats().
Stats::Scalar FullO3CPU< Impl >::miscRegfileWrites |
Definition at line 788 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats(), and FullO3CPU< O3CPUImpl >::setMiscReg().
ProbePointArg<std::pair<DynInstPtr, PacketPtr> >* FullO3CPU< Impl >::ppDataAccessComplete |
Definition at line 195 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regProbePoints().
ProbePointArg<PacketPtr>* FullO3CPU< Impl >::ppInstAccessComplete |
Definition at line 194 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regProbePoints().
Stats::Scalar FullO3CPU< Impl >::quiesceCycles |
Stat for total number of cycles the CPU spends descheduled due to a quiesce operation or waiting for an interrupt.
Definition at line 757 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::activateContext(), and FullO3CPU< O3CPUImpl >::regStats().
|
protected |
The register file.
Definition at line 578 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::getWritableVecPredReg(), FullO3CPU< O3CPUImpl >::getWritableVecReg(), FullO3CPU< O3CPUImpl >::readArchCCReg(), FullO3CPU< O3CPUImpl >::readArchFloatReg(), FullO3CPU< O3CPUImpl >::readArchIntReg(), FullO3CPU< O3CPUImpl >::readCCReg(), FullO3CPU< O3CPUImpl >::readFloatReg(), FullO3CPU< O3CPUImpl >::readIntReg(), FullO3CPU< O3CPUImpl >::readVecElem(), FullO3CPU< O3CPUImpl >::readVecPredReg(), FullO3CPU< O3CPUImpl >::readVecReg(), FullO3CPU< O3CPUImpl >::setArchCCReg(), FullO3CPU< O3CPUImpl >::setArchFloatReg(), FullO3CPU< O3CPUImpl >::setArchIntReg(), FullO3CPU< O3CPUImpl >::setCCReg(), FullO3CPU< O3CPUImpl >::setFloatReg(), FullO3CPU< O3CPUImpl >::setIntReg(), FullO3CPU< O3CPUImpl >::setVecElem(), FullO3CPU< O3CPUImpl >::setVecPredReg(), and FullO3CPU< O3CPUImpl >::setVecReg().
bool FullO3CPU< Impl >::removeInstsThisCycle |
Records if instructions need to be removed this cycle due to being retired or squashed.
Definition at line 556 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::cleanUpRemovedInsts(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::removeFrontInst(), FullO3CPU< O3CPUImpl >::removeInstsNotInROB(), FullO3CPU< O3CPUImpl >::removeInstsUntil(), and FullO3CPU< O3CPUImpl >::tick().
List of all the instructions that will be removed at the end of this cycle.
Definition at line 544 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::cleanUpRemovedInsts(), FullO3CPU< O3CPUImpl >::isCpuDrained(), FullO3CPU< O3CPUImpl >::removeFrontInst(), and FullO3CPU< O3CPUImpl >::squashInstIt().
|
protected |
The dispatch stage.
Definition at line 566 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drainSanityCheck(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::isCpuDrained(), FullO3CPU< O3CPUImpl >::regProbePoints(), FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::removeThread(), FullO3CPU< O3CPUImpl >::startup(), FullO3CPU< O3CPUImpl >::takeOverFrom(), and FullO3CPU< O3CPUImpl >::tick().
|
protected |
The rename map.
Definition at line 584 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::insertThread(), and FullO3CPU< O3CPUImpl >::switchRenameMode().
TimeBuffer<RenameStruct> FullO3CPU< Impl >::renameQueue |
The rename stage's instruction queue.
Definition at line 643 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::tick().
|
protected |
The re-order buffer.
Definition at line 590 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::regStats(), and FullO3CPU< O3CPUImpl >::removeInstsNotInROB().
|
protected |
Integer Register Scoreboard.
Definition at line 603 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::insertThread().
Pointer to the system.
Definition at line 693 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::insertThread(), FullO3CPU< O3CPUImpl >::instDone(), and FullO3CPU< O3CPUImpl >::verifyMemoryMode().
std::vector<Thread *> FullO3CPU< Impl >::thread |
Pointers to all of the threads in the CPU.
Definition at line 696 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drainResume(), FullO3CPU< O3CPUImpl >::FullO3CPU(), FullO3CPU< O3CPUImpl >::init(), FullO3CPU< O3CPUImpl >::instDone(), FullO3CPU< O3CPUImpl >::serializeThread(), FullO3CPU< O3CPUImpl >::squashFromTC(), FullO3CPU< O3CPUImpl >::syscall(), FullO3CPU< O3CPUImpl >::totalInsts(), FullO3CPU< O3CPUImpl >::totalOps(), FullO3CPU< O3CPUImpl >::unserializeThread(), and FullO3CPU< O3CPUImpl >::wakeup().
|
private |
The exit event used for terminating all ready-to-exit threads.
Definition at line 140 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::scheduleThreadExitEvent().
|
private |
The tick event used for scheduling CPU ticks.
Definition at line 137 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::drainResume(), FullO3CPU< O3CPUImpl >::takeOverFrom(), FullO3CPU< O3CPUImpl >::tick(), FullO3CPU< O3CPUImpl >::tryDrain(), and FullO3CPU< O3CPUImpl >::wakeCPU().
std::vector<ThreadID> FullO3CPU< Impl >::tids |
Available thread ids in the cpu.
Definition at line 711 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::getFreeTid().
TimeBuffer<TimeStruct> FullO3CPU< Impl >::timeBuffer |
The main time buffer to do backwards communication.
Definition at line 634 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::drain(), FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::tick().
Stats::Scalar FullO3CPU< Impl >::timesIdled |
Stat for total number of times the CPU is descheduled.
Definition at line 752 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats(), and FullO3CPU< O3CPUImpl >::tick().
Stats::Formula FullO3CPU< Impl >::totalCpi |
Stat for the total CPI.
Definition at line 765 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats().
Stats::Formula FullO3CPU< Impl >::totalIpc |
Stat for the total IPC.
Definition at line 769 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::regStats().
|
protected |
The rename mode of the vector registers.
Definition at line 575 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::switchRenameMode().
|
mutable |
Definition at line 781 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::readVecPredReg(), and FullO3CPU< O3CPUImpl >::regStats().
Stats::Scalar FullO3CPU< Impl >::vecPredRegfileWrites |
Definition at line 782 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::getWritableVecPredReg(), FullO3CPU< O3CPUImpl >::regStats(), and FullO3CPU< O3CPUImpl >::setVecPredReg().
|
mutable |
Definition at line 778 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::readVecElem(), FullO3CPU< O3CPUImpl >::readVecReg(), and FullO3CPU< O3CPUImpl >::regStats().
Stats::Scalar FullO3CPU< Impl >::vecRegfileWrites |
Definition at line 779 of file cpu.hh.
Referenced by FullO3CPU< O3CPUImpl >::getWritableVecReg(), FullO3CPU< O3CPUImpl >::regStats(), FullO3CPU< O3CPUImpl >::setVecElem(), and FullO3CPU< O3CPUImpl >::setVecReg().