gem5  v19.0.0.0
All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Friends Macros Modules Pages
Public Types | Public Member Functions | Public Attributes | Protected Attributes | Private Member Functions | Private Attributes | Friends | List of all members
FullO3CPU< Impl > Class Template Reference

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>

Inheritance diagram for FullO3CPU< Impl >:
BaseO3CPU BaseCPU ClockedObject SimObject Clocked EventManager Serializable Drainable Stats::Group

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
 
- Public Types inherited from BaseCPU
typedef BaseCPUParams Params
 
- Public Types inherited from ClockedObject
typedef ClockedObjectParams Params
 Parameters of ClockedObject. More...
 
- Public Types inherited from SimObject
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 VecRegContainerreadVecReg (PhysRegIdPtr reg_idx) const
 
VecRegContainergetWritableVecReg (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 VecElemreadVecElem (PhysRegIdPtr reg_idx) const
 
const VecPredRegContainerreadVecPredReg (PhysRegIdPtr reg_idx) const
 
VecPredRegContainergetWritableVecPredReg (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 VecRegContainerreadArchVecReg (int reg_idx, ThreadID tid) const
 
VecRegContainergetWritableArchVecReg (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 VecElemreadArchVecElem (const RegIndex &reg_idx, const ElemIndex &ldx, ThreadID tid) const
 
const VecPredRegContainerreadArchVecPredReg (int reg_idx, ThreadID tid) const
 
VecPredRegContainergetWritableArchVecPredReg (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 &reg_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...
 
ThreadContexttcBase (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...
 
PortgetInstPort () override
 Used by the fetch unit to get a hold of the instruction port. More...
 
PortgetDataPort () override
 Get the dcache port (used to find block size for translations). More...
 
- Public Member Functions inherited from BaseO3CPU
 BaseO3CPU (BaseCPUParams *params)
 
- Public Member Functions inherited from BaseCPU
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...
 
PortgetPort (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 ()
 
BaseInterruptsgetInterruptController (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::InstTracergetTracer ()
 Provide access to the tracer pointer. More...
 
int findContext (ThreadContext *tc)
 Given a Thread Context pointer return the thread num. More...
 
virtual ThreadContextgetContext (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 Paramsparams () 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)
 
AddressMonitorgetCpuAddrMonitor (ThreadID tid)
 
bool waitForRemoteGDB () const
 
virtual void probeInstCommit (const StaticInstPtr &inst, Addr pc)
 Helper method to trigger PMU probes for a committed instruction. More...
 
- Public Member Functions inherited from ClockedObject
 ClockedObject (const ClockedObjectParams *p)
 
const Paramsparams () 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)
 
- Public Member Functions inherited from SimObject
const Paramsparams () 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...
 
ProbeManagergetProbeManager ()
 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...
 
- Public Member Functions inherited from EventManager
 EventManager (EventManager &em)
 
 EventManager (EventManager *em)
 
 EventManager (EventQueue *eq)
 
EventQueueeventQueue () 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)
 
- Public Member Functions inherited from Serializable
 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)
 
- Public Member Functions inherited from Drainable
DrainState drainState () const
 Return the current drain state of an object. More...
 
virtual void notifyFork ()
 Notify a child process of a fork. More...
 
- Public Member Functions inherited from Stats::Group
 Group ()=delete
 
 Group (const Group &)=delete
 
Groupoperator= (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...
 
- Public Member Functions inherited from Clocked
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

BaseTLBitb
 
BaseTLBdtb
 
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< DynInstPtrinstList
 List of all the instructions in flight. More...
 
std::queue< ListItremoveList
 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< TimeStructtimeBuffer
 The main time buffer to do backwards communication. More...
 
TimeBuffer< FetchStructfetchQueue
 The fetch stage's instruction queue. More...
 
TimeBuffer< DecodeStructdecodeQueue
 The decode stage's instruction queue. More...
 
TimeBuffer< RenameStructrenameQueue
 The rename stage's instruction queue. More...
 
TimeBuffer< IEWStructiewQueue
 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...
 
Systemsystem
 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< ThreadIDtids
 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
 
- Public Attributes inherited from BaseCPU
TheISA::MicrocodeRom microcodeRom
 
EventFunctionWrapperprofileEvent
 
ThreadID numThreads
 Number of threads we're actually simulating (<= SMT_MAX_THREADS). More...
 
Systemsystem
 
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< ThreadIDactiveThreads
 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
 
- Protected Attributes inherited from BaseCPU
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::InstTracertracer
 
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...
 
- Protected Attributes inherited from ClockedObject
Enums::PwrState _currPwrState
 To keep track of the current power state. More...
 
Tick prvEvalTick
 
ClockedObject::ClockedObjectStats stats
 
- Protected Attributes inherited from SimObject
const SimObjectParams * _params
 Cached copy of the object parameters. More...
 
- Protected Attributes inherited from EventManager
EventQueueeventq
 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 Public Member Functions inherited from BaseCPU
static int numSimulatedInsts ()
 
static int numSimulatedOps ()
 
static void wakeup (ThreadID tid)
 
static int numSimulatedCPUs ()
 
static Counter numSimulatedInsts ()
 
static Counter numSimulatedOps ()
 
- Static Public Member Functions inherited from SimObject
static void serializeAll (CheckpointOut &cp)
 Serialize all SimObjects in the system. More...
 
static SimObjectfind (const char *name)
 Find the SimObject with the given name and return a pointer to it. More...
 
- Static Public Member Functions inherited from Serializable
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 Public Attributes inherited from BaseCPU
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 Public Attributes inherited from Serializable
static int ckptCount = 0
 
static int ckptMaxCount = 0
 
static int ckptPrevCount = -1
 
- Protected Types inherited from BaseCPU
enum  CPUState { CPU_STATE_ON, CPU_STATE_SLEEP, CPU_STATE_WAKEUP }
 
- Protected Member Functions inherited from BaseCPU
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...
 
- Protected Member Functions inherited from Drainable
 Drainable ()
 
virtual ~Drainable ()
 
void signalDrainDone () const
 Signal that an object is drained. More...
 
- Protected Member Functions inherited from Clocked
 Clocked (ClockDomain &clk_domain)
 Create a clocked object and set the clock domain based on the parameters. More...
 
 Clocked (Clocked &)=delete
 
Clockedoperator= (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...
 

Detailed Description

template<class Impl>
class FullO3CPU< Impl >

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.

Definition at line 98 of file cpu.hh.

Member Typedef Documentation

◆ CPUPolicy

template<class Impl>
typedef Impl::CPUPol FullO3CPU< Impl >::CPUPolicy

Definition at line 102 of file cpu.hh.

◆ DecodeStruct

template<class Impl>
typedef CPUPolicy::DecodeStruct FullO3CPU< Impl >::DecodeStruct

Definition at line 627 of file cpu.hh.

◆ DynInstPtr

template<class Impl>
typedef Impl::DynInstPtr FullO3CPU< Impl >::DynInstPtr

Definition at line 103 of file cpu.hh.

◆ FetchStruct

template<class Impl>
typedef CPUPolicy::FetchStruct FullO3CPU< Impl >::FetchStruct

Definition at line 625 of file cpu.hh.

◆ IEWStruct

template<class Impl>
typedef CPUPolicy::IEWStruct FullO3CPU< Impl >::IEWStruct

Definition at line 631 of file cpu.hh.

◆ ImplState

template<class Impl>
typedef O3ThreadState<Impl> FullO3CPU< Impl >::ImplState

Definition at line 111 of file cpu.hh.

◆ ListIt

template<class Impl>
typedef std::list<DynInstPtr>::iterator FullO3CPU< Impl >::ListIt

Definition at line 114 of file cpu.hh.

◆ LSQRequest

template<class Impl>
using FullO3CPU< Impl >::LSQRequest = typename LSQ<Impl>::LSQRequest

Definition at line 129 of file cpu.hh.

◆ O3CPU

template<class Impl>
typedef Impl::O3CPU FullO3CPU< Impl >::O3CPU

Definition at line 104 of file cpu.hh.

◆ RenameStruct

template<class Impl>
typedef CPUPolicy::RenameStruct FullO3CPU< Impl >::RenameStruct

Definition at line 629 of file cpu.hh.

◆ Thread

template<class Impl>
typedef O3ThreadState<Impl> FullO3CPU< Impl >::Thread

Definition at line 112 of file cpu.hh.

◆ TimeStruct

template<class Impl>
typedef CPUPolicy::TimeStruct FullO3CPU< Impl >::TimeStruct

Typedefs from the Impl to get the structs that each of the time buffers should use.

Definition at line 623 of file cpu.hh.

◆ VecElem

template<class Impl>
using FullO3CPU< Impl >::VecElem = TheISA::VecElem

Definition at line 106 of file cpu.hh.

◆ VecPredRegContainer

template<class Impl>
using FullO3CPU< Impl >::VecPredRegContainer = TheISA::VecPredRegContainer

Definition at line 109 of file cpu.hh.

◆ VecRegContainer

template<class Impl>
using FullO3CPU< Impl >::VecRegContainer = TheISA::VecRegContainer

Definition at line 107 of file cpu.hh.

Member Enumeration Documentation

◆ StageIdx

template<class Impl>
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 

Definition at line 612 of file cpu.hh.

◆ Status

template<class Impl>
enum FullO3CPU::Status
Enumerator
Running 
Idle 
Halted 
Blocked 
SwitchedOut 

Definition at line 119 of file cpu.hh.

Constructor & Destructor Documentation

◆ FullO3CPU()

template<class Impl >
FullO3CPU< Impl >::FullO3CPU ( DerivO3CPUParams *  params)

Constructs a CPU with the given parameters.

Definition at line 94 of file cpu.cc.

◆ ~FullO3CPU()

template<class Impl >
FullO3CPU< Impl >::~FullO3CPU ( )

Destructor.

Definition at line 377 of file cpu.cc.

Member Function Documentation

◆ activateContext()

template<class Impl >
void FullO3CPU< Impl >::activateContext ( ThreadID  tid)
overridevirtual

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().

◆ activateStage()

template<class Impl>
void FullO3CPU< Impl >::activateStage ( const StageIdx  idx)
inline

Changes a stage's status to active within the activity recorder.

Definition at line 660 of file cpu.hh.

◆ activateThread()

template<class Impl >
void FullO3CPU< Impl >::activateThread ( ThreadID  tid)

Add Thread to Active Threads List.

Definition at line 626 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::activateContext(), and FullO3CPU< O3CPUImpl >::drainResume().

◆ activityThisCycle()

template<class Impl>
void FullO3CPU< Impl >::activityThisCycle ( )
inline

Records that there was time buffer activity this cycle.

Definition at line 657 of file cpu.hh.

◆ addInst()

template<class Impl >
FullO3CPU< Impl >::ListIt FullO3CPU< Impl >::addInst ( const DynInstPtr inst)

Function to add instruction onto the head of the list of the instructions.

Used when new instructions are fetched.

Definition at line 1498 of file cpu.cc.

◆ addThreadToExitingList()

template<class Impl >
void FullO3CPU< Impl >::addThreadToExitingList ( ThreadID  tid)

Insert tid to the list of threads trying to exit.

Definition at line 1757 of file cpu.cc.

◆ cleanUpRemovedInsts()

template<class Impl >
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().

◆ commitDrained()

template<class Impl >
void FullO3CPU< Impl >::commitDrained ( ThreadID  tid)

Commit has reached a safe point to drain a thread.

Commit calls this method to inform the pipeline that it has reached a point where it is not executed microcode and is about to squash uncommitted instructions to fully drain the pipeline.

Definition at line 1078 of file cpu.cc.

◆ deactivateStage()

template<class Impl>
void FullO3CPU< Impl >::deactivateStage ( const StageIdx  idx)
inline

Changes a stage's status to inactive within the activity recorder.

Definition at line 664 of file cpu.hh.

◆ deactivateThread()

template<class Impl >
void FullO3CPU< Impl >::deactivateThread ( ThreadID  tid)

Remove Thread from Active Threads List.

Definition at line 644 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::haltContext(), and FullO3CPU< O3CPUImpl >::suspendContext().

◆ demapDataPage()

template<class Impl>
void FullO3CPU< Impl >::demapDataPage ( Addr  vaddr,
uint64_t  asn 
)
inline

Definition at line 211 of file cpu.hh.

◆ demapInstPage()

template<class Impl>
void FullO3CPU< Impl >::demapInstPage ( Addr  vaddr,
uint64_t  asn 
)
inline

Definition at line 206 of file cpu.hh.

◆ demapPage()

template<class Impl>
void FullO3CPU< Impl >::demapPage ( Addr  vaddr,
uint64_t  asn 
)
inline

Definition at line 200 of file cpu.hh.

◆ drain()

template<class Impl >
DrainState FullO3CPU< Impl >::drain ( )
overridevirtual

Starts draining the CPU's pipeline of all instructions in order to stop all memory accesses.

Implements Drainable.

Definition at line 948 of file cpu.cc.

◆ drainResume()

template<class Impl >
void FullO3CPU< Impl >::drainResume ( )
overridevirtual

Resumes execution after a drain.

Reimplemented from Drainable.

Definition at line 1085 of file cpu.cc.

◆ drainSanityCheck()

template<class Impl >
void FullO3CPU< Impl >::drainSanityCheck ( ) const
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().

◆ dumpInsts()

template<class Impl >
void FullO3CPU< Impl >::dumpInsts ( )

Debug function to print all instructions on the list.

Definition at line 1663 of file cpu.cc.

◆ exitThreads()

template<class Impl >
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().

◆ getAndIncrementInstSeq()

template<class Impl>
InstSeqNum FullO3CPU< Impl >::getAndIncrementInstSeq ( )
inline

Get the current instruction sequence number, and increment it.

Definition at line 314 of file cpu.hh.

◆ getDataPort()

template<class Impl>
Port& FullO3CPU< Impl >::getDataPort ( )
inlineoverridevirtual

Get the dcache port (used to find block size for translations).

Implements BaseCPU.

Definition at line 746 of file cpu.hh.

◆ getFreeTid()

template<class Impl >
ThreadID FullO3CPU< Impl >::getFreeTid ( )

Gets a free thread id.

Use if thread ids change across system.

Definition at line 1726 of file cpu.cc.

◆ getInstPort()

template<class Impl>
Port& FullO3CPU< Impl >::getInstPort ( )
inlineoverridevirtual

Used by the fetch unit to get a hold of the instruction port.

Implements BaseCPU.

Definition at line 739 of file cpu.hh.

◆ getInterrupts()

template<class Impl >
Fault FullO3CPU< Impl >::getInterrupts ( )

Returns the Fault for any valid interrupt.

Definition at line 880 of file cpu.cc.

◆ getWritableArchVecPredReg()

template<class Impl >
auto FullO3CPU< Impl >::getWritableArchVecPredReg ( int  reg_idx,
ThreadID  tid 
)

Definition at line 1371 of file cpu.cc.

◆ getWritableArchVecReg()

template<class Impl >
auto FullO3CPU< Impl >::getWritableArchVecReg ( int  reg_idx,
ThreadID  tid 
)

Read architectural vector register for modification.

Definition at line 1341 of file cpu.cc.

◆ getWritableVecPredReg()

template<class Impl >
auto FullO3CPU< Impl >::getWritableVecPredReg ( PhysRegIdPtr  reg_idx)

Definition at line 1243 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::getWritableArchVecPredReg().

◆ getWritableVecReg()

template<class Impl >
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().

◆ halt()

template<class Impl>
void FullO3CPU< Impl >::halt ( )
inline

Halts the CPU.

Definition at line 335 of file cpu.hh.

◆ haltContext()

template<class Impl >
void FullO3CPU< Impl >::haltContext ( ThreadID  tid)
overridevirtual

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().

◆ init()

template<class Impl >
void FullO3CPU< Impl >::init ( )
overridevirtual

Initialize the CPU.

Reimplemented from BaseCPU.

Definition at line 590 of file cpu.cc.

◆ insertThread()

template<class Impl >
void FullO3CPU< Impl >::insertThread ( ThreadID  tid)

Setup CPU to insert a thread's context.

Definition at line 765 of file cpu.cc.

◆ instAddr()

template<class Impl >
Addr FullO3CPU< Impl >::instAddr ( ThreadID  tid)

Reads the commit PC of a specific thread.

Definition at line 1469 of file cpu.cc.

◆ instDone()

template<class Impl >
void FullO3CPU< Impl >::instDone ( ThreadID  tid,
const DynInstPtr inst 
)

Function to tell the CPU that an instruction has completed.

Definition at line 1507 of file cpu.cc.

◆ isCpuDrained()

template<class Impl >
bool FullO3CPU< Impl >::isCpuDrained ( ) const
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().

◆ isDraining()

template<class Impl>
bool FullO3CPU< Impl >::isDraining ( ) const
inline

Is the CPU draining?

Definition at line 263 of file cpu.hh.

◆ isThreadExiting()

template<class Impl >
bool FullO3CPU< Impl >::isThreadExiting ( ThreadID  tid) const

Is the thread trying to exit?

Definition at line 1777 of file cpu.cc.

◆ microPC()

template<class Impl >
MicroPC FullO3CPU< Impl >::microPC ( ThreadID  tid)

Reads the commit micro PC of a specific thread.

Definition at line 1483 of file cpu.cc.

◆ nextInstAddr()

template<class Impl >
Addr FullO3CPU< Impl >::nextInstAddr ( ThreadID  tid)

Reads the next PC of a specific thread.

Definition at line 1476 of file cpu.cc.

◆ numActiveThreads()

template<class Impl>
int FullO3CPU< Impl >::numActiveThreads ( )
inline

Returns the Number of Active Threads in the CPU.

Definition at line 227 of file cpu.hh.

◆ pcState() [1/2]

template<class Impl >
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().

◆ pcState() [2/2]

template<class Impl >
TheISA::PCState FullO3CPU< Impl >::pcState ( ThreadID  tid)

Reads the commit PC state of a specific thread.

Definition at line 1455 of file cpu.cc.

◆ processInterrupts()

template<class Impl >
void FullO3CPU< Impl >::processInterrupts ( const Fault interrupt)

Processes any an interrupt fault.

Definition at line 888 of file cpu.cc.

◆ pushRequest()

template<class Impl>
Fault FullO3CPU< Impl >::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>() 
)
inline

CPU pushRequest function, forwards request to LSQ.

Definition at line 714 of file cpu.hh.

◆ read()

template<class Impl>
Fault FullO3CPU< Impl >::read ( LSQRequest req,
int  load_idx 
)
inline

CPU read function, forwards read to LSQ.

Definition at line 726 of file cpu.hh.

◆ readArchCCReg()

template<class Impl >
RegVal FullO3CPU< Impl >::readArchCCReg ( int  reg_idx,
ThreadID  tid 
)

Definition at line 1381 of file cpu.cc.

◆ readArchFloatReg()

template<class Impl >
RegVal FullO3CPU< Impl >::readArchFloatReg ( int  reg_idx,
ThreadID  tid 
)

Definition at line 1320 of file cpu.cc.

◆ readArchIntReg()

template<class Impl >
RegVal FullO3CPU< Impl >::readArchIntReg ( int  reg_idx,
ThreadID  tid 
)

Definition at line 1309 of file cpu.cc.

◆ readArchVecElem()

template<class Impl >
auto FullO3CPU< Impl >::readArchVecElem ( const RegIndex reg_idx,
const ElemIndex ldx,
ThreadID  tid 
) const

Definition at line 1351 of file cpu.cc.

◆ readArchVecLane()

template<class Impl>
template<typename VecElem >
VecLaneT<VecElem, true> FullO3CPU< Impl >::readArchVecLane ( int  reg_idx,
int  lId,
ThreadID  tid 
) const
inline

Read architectural vector register lane.

Definition at line 435 of file cpu.hh.

◆ readArchVecPredReg()

template<class Impl >
auto FullO3CPU< Impl >::readArchVecPredReg ( int  reg_idx,
ThreadID  tid 
) const

Definition at line 1361 of file cpu.cc.

◆ readArchVecReg()

template<class Impl >
auto FullO3CPU< Impl >::readArchVecReg ( int  reg_idx,
ThreadID  tid 
) const

Definition at line 1331 of file cpu.cc.

◆ readCCReg()

template<class Impl >
RegVal FullO3CPU< Impl >::readCCReg ( PhysRegIdPtr  phys_reg)

Definition at line 1252 of file cpu.cc.

◆ readFloatReg()

template<class Impl >
RegVal FullO3CPU< Impl >::readFloatReg ( PhysRegIdPtr  phys_reg)

Definition at line 1200 of file cpu.cc.

◆ readIntReg()

template<class Impl >
RegVal FullO3CPU< Impl >::readIntReg ( PhysRegIdPtr  phys_reg)

Definition at line 1192 of file cpu.cc.

◆ readMiscReg()

template<class Impl >
RegVal FullO3CPU< Impl >::readMiscReg ( int  misc_reg,
ThreadID  tid 
)

Reads a misc.

register, including any side effects the read might have as defined by the architecture.

Definition at line 1169 of file cpu.cc.

◆ readMiscRegNoEffect()

template<class Impl >
RegVal FullO3CPU< Impl >::readMiscRegNoEffect ( int  misc_reg,
ThreadID  tid 
) const

Register accessors.

Index refers to the physical register index. Reads a miscellaneous register.

Definition at line 1162 of file cpu.cc.

◆ readVecElem()

template<class Impl >
auto FullO3CPU< Impl >::readVecElem ( PhysRegIdPtr  reg_idx) const

Definition at line 1226 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::readArchVecElem().

◆ readVecLane() [1/2]

template<class Impl>
template<typename VecElem , int LaneIdx>
VecLaneT<VecElem, true> FullO3CPU< Impl >::readVecLane ( PhysRegIdPtr  phys_reg) const
inline

Read physical vector register lane.

Definition at line 378 of file cpu.hh.

◆ readVecLane() [2/2]

template<class Impl>
template<typename VecElem >
VecLaneT<VecElem, true> FullO3CPU< Impl >::readVecLane ( PhysRegIdPtr  phys_reg) const
inline

Read physical vector register lane.

Definition at line 389 of file cpu.hh.

◆ readVecPredReg()

template<class Impl >
auto FullO3CPU< Impl >::readVecPredReg ( PhysRegIdPtr  reg_idx) const

Definition at line 1234 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::readArchVecPredReg().

◆ readVecReg()

template<class Impl >
auto FullO3CPU< Impl >::readVecReg ( PhysRegIdPtr  reg_idx) const

Definition at line 1208 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::readArchVecReg().

◆ regProbePoints()

template<class Impl >
void FullO3CPU< Impl >::regProbePoints ( )
overridevirtual

Register probe points.

Reimplemented from BaseCPU.

Definition at line 383 of file cpu.cc.

◆ regStats()

template<class Impl >
void FullO3CPU< Impl >::regStats ( )
overridevirtual

Registers statistics.

Reimplemented from BaseO3CPU.

Definition at line 398 of file cpu.cc.

◆ removeFrontInst()

template<class Impl >
void FullO3CPU< Impl >::removeFrontInst ( const DynInstPtr inst)

Remove an instruction from the front end of the list.

There's no restriction on location of the instruction.

Definition at line 1528 of file cpu.cc.

◆ removeInstsNotInROB()

template<class Impl >
void FullO3CPU< Impl >::removeInstsNotInROB ( ThreadID  tid)

Remove all instructions that are not currently in the ROB.

There's also an option to not squash delay slot instructions.

Definition at line 1542 of file cpu.cc.

◆ removeInstsUntil()

template<class Impl >
void FullO3CPU< Impl >::removeInstsUntil ( const InstSeqNum seq_num,
ThreadID  tid 
)

Remove all instructions younger than the given sequence number.

Definition at line 1587 of file cpu.cc.

◆ removeThread()

template<class Impl >
void FullO3CPU< Impl >::removeThread ( ThreadID  tid)

Remove all of a thread's context from CPU.

Definition at line 817 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::haltContext().

◆ scheduleThreadExitEvent()

template<class Impl >
void FullO3CPU< Impl >::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.

Definition at line 1784 of file cpu.cc.

◆ scheduleTickEvent()

template<class Impl>
void FullO3CPU< Impl >::scheduleTickEvent ( Cycles  delay)
inlineprivate

Schedule tick event, regardless of its current state.

Definition at line 143 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::activateContext().

◆ serializeThread()

template<class Impl >
void FullO3CPU< Impl >::serializeThread ( CheckpointOut cp,
ThreadID  tid 
) const
overridevirtual

Serialize a single thread.

Parameters
cpThe stream to serialize to.
tidID of the current thread.

Reimplemented from BaseCPU.

Definition at line 934 of file cpu.cc.

◆ setArchCCReg()

template<class Impl >
void FullO3CPU< Impl >::setArchCCReg ( int  reg_idx,
RegVal  val,
ThreadID  tid 
)

Definition at line 1444 of file cpu.cc.

◆ setArchFloatReg()

template<class Impl >
void FullO3CPU< Impl >::setArchFloatReg ( int  reg_idx,
RegVal  val,
ThreadID  tid 
)

Definition at line 1403 of file cpu.cc.

◆ setArchIntReg()

template<class Impl >
void FullO3CPU< Impl >::setArchIntReg ( int  reg_idx,
RegVal  val,
ThreadID  tid 
)

Architectural register accessors.

Looks up in the commit rename table to obtain the true physical index of the architected register first, then accesses that physical register.

Definition at line 1392 of file cpu.cc.

◆ setArchVecElem()

template<class Impl >
void FullO3CPU< Impl >::setArchVecElem ( const RegIndex reg_idx,
const ElemIndex ldx,
const VecElem val,
ThreadID  tid 
)

Definition at line 1424 of file cpu.cc.

◆ setArchVecLane()

template<class Impl>
template<typename LD >
void FullO3CPU< Impl >::setArchVecLane ( int  reg_idx,
int  lId,
ThreadID  tid,
const LD &  val 
)
inline

Write a lane of the destination vector register.

Definition at line 446 of file cpu.hh.

◆ setArchVecPredReg()

template<class Impl >
void FullO3CPU< Impl >::setArchVecPredReg ( int  reg_idx,
const VecPredRegContainer val,
ThreadID  tid 
)

Definition at line 1434 of file cpu.cc.

◆ setArchVecReg()

template<class Impl >
void FullO3CPU< Impl >::setArchVecReg ( int  reg_idx,
const VecRegContainer val,
ThreadID  tid 
)

Definition at line 1414 of file cpu.cc.

◆ setCCReg()

template<class Impl >
void FullO3CPU< Impl >::setCCReg ( PhysRegIdPtr  phys_reg,
RegVal  val 
)

Definition at line 1301 of file cpu.cc.

◆ setFloatReg()

template<class Impl >
void FullO3CPU< Impl >::setFloatReg ( PhysRegIdPtr  phys_reg,
RegVal  val 
)

Definition at line 1268 of file cpu.cc.

◆ setIntReg()

template<class Impl >
void FullO3CPU< Impl >::setIntReg ( PhysRegIdPtr  phys_reg,
RegVal  val 
)

Definition at line 1260 of file cpu.cc.

◆ setMiscReg()

template<class Impl >
void FullO3CPU< Impl >::setMiscReg ( int  misc_reg,
RegVal  val,
ThreadID  tid 
)

Sets a misc.

register, including any side effects the write might have as defined by the architecture.

Definition at line 1184 of file cpu.cc.

◆ setMiscRegNoEffect()

template<class Impl >
void FullO3CPU< Impl >::setMiscRegNoEffect ( int  misc_reg,
RegVal  val,
ThreadID  tid 
)

Sets a miscellaneous register.

Definition at line 1177 of file cpu.cc.

◆ setVecElem()

template<class Impl >
void FullO3CPU< Impl >::setVecElem ( PhysRegIdPtr  reg_idx,
const VecElem val 
)

Definition at line 1284 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::setArchVecElem().

◆ setVecLane()

template<class Impl>
template<typename LD >
void FullO3CPU< Impl >::setVecLane ( PhysRegIdPtr  phys_reg,
const LD &  val 
)
inline

Write a lane of the destination vector register.

Definition at line 398 of file cpu.hh.

◆ setVecPredReg()

template<class Impl >
void FullO3CPU< Impl >::setVecPredReg ( PhysRegIdPtr  reg_idx,
const VecPredRegContainer val 
)

Definition at line 1292 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::setArchVecPredReg().

◆ setVecReg()

template<class Impl >
void FullO3CPU< Impl >::setVecReg ( PhysRegIdPtr  reg_idx,
const VecRegContainer val 
)

Definition at line 1276 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::setArchVecReg().

◆ squashFromTC()

template<class Impl >
void FullO3CPU< Impl >::squashFromTC ( ThreadID  tid)

Initiates a squash of all in-flight instructions for a given thread.

The source of the squash is an external update of state through the TC.

Definition at line 1490 of file cpu.cc.

◆ squashInstIt()

template<class Impl >
void FullO3CPU< Impl >::squashInstIt ( const ListIt instIt,
ThreadID  tid 
)
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().

◆ startup()

template<class Impl >
void FullO3CPU< Impl >::startup ( )
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().

◆ suspendContext()

template<class Impl >
void FullO3CPU< Impl >::suspendContext ( ThreadID  tid)
overridevirtual

Remove Thread from Active Threads List.

Reimplemented from BaseCPU.

Definition at line 730 of file cpu.cc.

◆ switchOut()

template<class Impl >
void FullO3CPU< Impl >::switchOut ( )
overridevirtual

Switches out this CPU.

Reimplemented from BaseCPU.

Definition at line 1115 of file cpu.cc.

◆ switchRenameMode()

template<class Impl >
void FullO3CPU< Impl >::switchRenameMode ( ThreadID  tid,
UnifiedFreeList freelist 
)

Check if a change in renaming is needed for vector registers.

The vecMode variable is updated and propagated to rename maps.

Parameters
tidThreadID
freelistlist of free registers

Definition at line 861 of file cpu.cc.

◆ syscall()

template<class Impl >
void FullO3CPU< Impl >::syscall ( ThreadID  tid,
Fault fault 
)

Executes a syscall.

Todo:
: Determine if this needs to be virtual.

Definition at line 914 of file cpu.cc.

◆ takeOverFrom()

template<class Impl >
void FullO3CPU< Impl >::takeOverFrom ( BaseCPU oldCPU)
overridevirtual

Takes over from another CPU.

Reimplemented from BaseCPU.

Definition at line 1130 of file cpu.cc.

◆ tcBase()

template<class Impl>
ThreadContext* FullO3CPU< Impl >::tcBase ( ThreadID  tid)
inline

◆ tick()

template<class Impl >
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().

◆ totalInsts()

template<class Impl >
Counter FullO3CPU< Impl >::totalInsts ( ) const
overridevirtual

Count the Total Instructions Committed in the CPU.

Implements BaseCPU.

Definition at line 665 of file cpu.cc.

◆ totalOps()

template<class Impl >
Counter FullO3CPU< Impl >::totalOps ( ) const
overridevirtual

Count the Total Ops (including micro ops) committed in the CPU.

Implements BaseCPU.

Definition at line 678 of file cpu.cc.

◆ trap()

template<class Impl >
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().

◆ tryDrain()

template<class Impl >
bool FullO3CPU< Impl >::tryDrain ( )
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.

Returns
False if a drain hasn't been requested or the CPU hasn't drained, true otherwise.

Definition at line 1011 of file cpu.cc.

Referenced by FullO3CPU< O3CPUImpl >::tick().

◆ unscheduleTickEvent()

template<class Impl>
void FullO3CPU< Impl >::unscheduleTickEvent ( )
inlineprivate

Unschedule tick event, regardless of its current state.

Definition at line 152 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::suspendContext().

◆ unserializeThread()

template<class Impl >
void FullO3CPU< Impl >::unserializeThread ( CheckpointIn cp,
ThreadID  tid 
)
overridevirtual

Unserialize one thread.

Parameters
cpThe checkpoint use.
tidID of the current thread.

Reimplemented from BaseCPU.

Definition at line 941 of file cpu.cc.

◆ updateThreadPriority()

template<class Impl >
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().

◆ vecRenameMode() [1/2]

template<class Impl>
Enums::VecRegRenameMode FullO3CPU< Impl >::vecRenameMode ( ) const
inline

Returns current vector renaming mode.

Definition at line 367 of file cpu.hh.

◆ vecRenameMode() [2/2]

template<class Impl>
void FullO3CPU< Impl >::vecRenameMode ( Enums::VecRegRenameMode  vec_mode)
inline

Sets the current vector renaming mode.

Definition at line 370 of file cpu.hh.

◆ verifyMemoryMode()

template<class Impl >
void FullO3CPU< Impl >::verifyMemoryMode ( ) const
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().

◆ wakeCPU()

template<class Impl >
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().

◆ wakeup()

template<class Impl >
void FullO3CPU< Impl >::wakeup ( ThreadID  tid)
overridevirtual

Implements BaseCPU.

Definition at line 1713 of file cpu.cc.

◆ write()

template<class Impl>
Fault FullO3CPU< Impl >::write ( LSQRequest req,
uint8_t *  data,
int  store_idx 
)
inline

CPU write function, forwards write to LSQ.

Definition at line 732 of file cpu.hh.

Friends And Related Function Documentation

◆ O3ThreadContext< Impl >

template<class Impl>
friend class O3ThreadContext< Impl >
friend

Definition at line 116 of file cpu.hh.

Member Data Documentation

◆ _status

template<class Impl>
Status FullO3CPU< Impl >::_status

◆ activeThreads

template<class Impl>
std::list<ThreadID> FullO3CPU< Impl >::activeThreads
protected

◆ activityRec

template<class Impl>
ActivityRecorder FullO3CPU< Impl >::activityRec
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().

◆ ccRegfileReads

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::ccRegfileReads

◆ ccRegfileWrites

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::ccRegfileWrites

◆ checker

template<class Impl>
Checker<Impl>* FullO3CPU< Impl >::checker

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().

◆ commit

template<class Impl>
CPUPolicy::Commit FullO3CPU< Impl >::commit
protected

◆ commitRenameMap

template<class Impl>
CPUPolicy::RenameMap FullO3CPU< Impl >::commitRenameMap[Impl::MaxThreads]
protected

◆ committedInsts

template<class Impl>
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().

◆ committedOps

template<class Impl>
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().

◆ cpi

template<class Impl>
Stats::Formula FullO3CPU< Impl >::cpi

Stat for the CPI per thread.

Definition at line 763 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::regStats().

◆ cpuWaitList

template<class Impl>
std::list<int> FullO3CPU< Impl >::cpuWaitList

Threads Scheduled to Enter CPU.

Definition at line 699 of file cpu.hh.

◆ decode

template<class Impl>
CPUPolicy::Decode FullO3CPU< Impl >::decode
protected

◆ decodeQueue

template<class Impl>
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().

◆ dtb

template<class Impl>
BaseTLB* FullO3CPU< Impl >::dtb

Definition at line 128 of file cpu.hh.

◆ exitingThreads

template<class Impl>
std::unordered_map<ThreadID, bool> FullO3CPU< Impl >::exitingThreads
protected

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().

◆ fetch

template<class Impl>
CPUPolicy::Fetch FullO3CPU< Impl >::fetch
protected

◆ fetchQueue

template<class Impl>
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().

◆ fpRegfileReads

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::fpRegfileReads

◆ fpRegfileWrites

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::fpRegfileWrites

◆ freeList

template<class Impl>
CPUPolicy::FreeList FullO3CPU< Impl >::freeList
protected

The free list.

Definition at line 581 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::insertThread().

◆ globalSeqNum

template<class Impl>
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().

◆ idleCycles

template<class Impl>
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().

◆ iew

template<class Impl>
CPUPolicy::IEW FullO3CPU< Impl >::iew
protected

◆ iewQueue

template<class Impl>
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().

◆ instcount

template<class Impl>
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().

◆ instList

template<class Impl>
std::list<DynInstPtr> FullO3CPU< Impl >::instList

◆ intRegfileReads

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::intRegfileReads

◆ intRegfileWrites

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::intRegfileWrites

◆ ipc

template<class Impl>
Stats::Formula FullO3CPU< Impl >::ipc

Stat for the IPC per thread.

Definition at line 767 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::regStats().

◆ isa

template<class Impl>
std::vector<TheISA::ISA *> FullO3CPU< Impl >::isa
protected

◆ itb

template<class Impl>
BaseTLB* FullO3CPU< Impl >::itb

Definition at line 127 of file cpu.hh.

◆ lastActivatedCycle

template<class Impl>
Tick FullO3CPU< Impl >::lastActivatedCycle

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().

◆ lastRunningCycle

template<class Impl>
Cycles FullO3CPU< Impl >::lastRunningCycle

◆ miscRegfileReads

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::miscRegfileReads

◆ miscRegfileWrites

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::miscRegfileWrites

Definition at line 788 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::regStats(), and FullO3CPU< O3CPUImpl >::setMiscReg().

◆ ppDataAccessComplete

template<class Impl>
ProbePointArg<std::pair<DynInstPtr, PacketPtr> >* FullO3CPU< Impl >::ppDataAccessComplete

Definition at line 195 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::regProbePoints().

◆ ppInstAccessComplete

template<class Impl>
ProbePointArg<PacketPtr>* FullO3CPU< Impl >::ppInstAccessComplete

Definition at line 194 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::regProbePoints().

◆ quiesceCycles

template<class Impl>
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().

◆ regFile

template<class Impl>
PhysRegFile FullO3CPU< Impl >::regFile
protected

◆ removeInstsThisCycle

template<class Impl>
bool FullO3CPU< Impl >::removeInstsThisCycle

◆ removeList

template<class Impl>
std::queue<ListIt> FullO3CPU< Impl >::removeList

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().

◆ rename

template<class Impl>
CPUPolicy::Rename FullO3CPU< Impl >::rename
protected

◆ renameMap

template<class Impl>
CPUPolicy::RenameMap FullO3CPU< Impl >::renameMap[Impl::MaxThreads]
protected

◆ renameQueue

template<class Impl>
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().

◆ rob

template<class Impl>
CPUPolicy::ROB FullO3CPU< Impl >::rob
protected

◆ scoreboard

template<class Impl>
Scoreboard FullO3CPU< Impl >::scoreboard
protected

Integer Register Scoreboard.

Definition at line 603 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::FullO3CPU(), and FullO3CPU< O3CPUImpl >::insertThread().

◆ system

template<class Impl>
System* FullO3CPU< Impl >::system

◆ thread

template<class Impl>
std::vector<Thread *> FullO3CPU< Impl >::thread

◆ threadExitEvent

template<class Impl>
EventFunctionWrapper FullO3CPU< Impl >::threadExitEvent
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().

◆ threadMap

template<class Impl>
std::map<ThreadID, unsigned> FullO3CPU< Impl >::threadMap

Mapping for system thread id to cpu id.

Definition at line 708 of file cpu.hh.

◆ tickEvent

template<class Impl>
EventFunctionWrapper FullO3CPU< Impl >::tickEvent
private

◆ tids

template<class Impl>
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

template<class Impl>
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().

◆ timesIdled

template<class Impl>
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().

◆ totalCpi

template<class Impl>
Stats::Formula FullO3CPU< Impl >::totalCpi

Stat for the total CPI.

Definition at line 765 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::regStats().

◆ totalIpc

template<class Impl>
Stats::Formula FullO3CPU< Impl >::totalIpc

Stat for the total IPC.

Definition at line 769 of file cpu.hh.

Referenced by FullO3CPU< O3CPUImpl >::regStats().

◆ vecMode

template<class Impl>
Enums::VecRegRenameMode FullO3CPU< Impl >::vecMode
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().

◆ vecPredRegfileReads

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::vecPredRegfileReads
mutable

◆ vecPredRegfileWrites

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::vecPredRegfileWrites

◆ vecRegfileReads

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::vecRegfileReads
mutable

◆ vecRegfileWrites

template<class Impl>
Stats::Scalar FullO3CPU< Impl >::vecRegfileWrites

The documentation for this class was generated from the following files:

Generated on Fri Feb 28 2020 16:27:11 for gem5 by doxygen 1.8.13