53#include "debug/Activity.hh"
54#include "debug/Drain.hh"
55#include "debug/O3CPU.hh"
56#include "debug/Quiesce.hh"
57#include "enums/MemoryMode.hh"
75 tickEvent([this]{
tick(); },
"O3CPU tick",
77 threadExitEvent([
this]{ exitThreads(); },
"O3CPU exit threads",
82 removeInstsThisCycle(
false),
89 regFile(params.numPhysIntRegs,
90 params.numPhysFloatRegs,
91 params.numPhysVecRegs,
92 params.numPhysVecPredRegs,
93 params.numPhysMatRegs,
95 params.isa[0]->regClasses()),
97 freeList(
name() +
".freelist", ®File),
101 scoreboard(
name() +
".scoreboard", regFile.totalNumPhysRegs()),
103 isa(numThreads, NULL),
105 timeBuffer(params.backComSize, params.forwardComSize),
106 fetchQueue(params.backComSize, params.forwardComSize),
107 decodeQueue(params.backComSize, params.forwardComSize),
108 renameQueue(params.backComSize, params.forwardComSize),
109 iewQueue(params.backComSize, params.forwardComSize),
110 activityRec(
name(), NumStages,
111 params.backComSize + params.forwardComSize,
116 lastRunningCycle(curCycle()),
120 "SMT is not supported in O3 in full system mode currently.");
123 "More workload items (%d) than threads (%d) on CPU %s.",
124 params.workload.size(), params.numThreads,
name());
126 if (!params.switched_out) {
129 _status = SwitchedOut;
132 if (params.checker) {
133 BaseCPU *temp_checker = params.checker;
134 checker =
dynamic_cast<Checker<DynInstPtr> *
>(temp_checker);
135 checker->setIcachePort(&fetch.getInstPort());
136 checker->setSystem(params.system);
142 thread.resize(numThreads);
143 tids.resize(numThreads);
151 fetch.setActiveThreads(&activeThreads);
152 decode.setActiveThreads(&activeThreads);
153 rename.setActiveThreads(&activeThreads);
154 iew.setActiveThreads(&activeThreads);
155 commit.setActiveThreads(&activeThreads);
158 fetch.setTimeBuffer(&timeBuffer);
159 decode.setTimeBuffer(&timeBuffer);
160 rename.setTimeBuffer(&timeBuffer);
161 iew.setTimeBuffer(&timeBuffer);
162 commit.setTimeBuffer(&timeBuffer);
165 fetch.setFetchQueue(&fetchQueue);
166 decode.setFetchQueue(&fetchQueue);
167 commit.setFetchQueue(&fetchQueue);
168 decode.setDecodeQueue(&decodeQueue);
169 rename.setDecodeQueue(&decodeQueue);
170 rename.setRenameQueue(&renameQueue);
171 iew.setRenameQueue(&renameQueue);
172 iew.setIEWQueue(&iewQueue);
173 commit.setIEWQueue(&iewQueue);
174 commit.setRenameQueue(&renameQueue);
176 commit.setIEWStage(&iew);
177 rename.setIEWStage(&iew);
178 rename.setCommitStage(&commit);
184 active_threads = params.workload.size();
187 panic(
"Workload Size too large. Increase the 'MaxThreads' "
188 "constant in cpu/o3/limits.hh or edit your workload size.");
194 const auto ®Classes = params.isa[0]->regClasses();
197 numThreads * regClasses.at(
IntRegClass)->numRegs() &&
199 "Not enough physical registers, consider increasing "
204 "Not enough physical registers, consider increasing "
205 "numPhysFloatRegs\n");
207 numThreads * regClasses.at(
VecRegClass)->numRegs() &&
209 "Not enough physical registers, consider increasing "
211 panic_if(params.numPhysVecPredRegs <=
214 "Not enough physical registers, consider increasing "
215 "numPhysVecPredRegs\n");
217 numThreads * regClasses.at(
MatRegClass)->numRegs() &&
219 "Not enough physical registers, consider increasing "
222 numThreads * regClasses.at(
CCRegClass)->numRegs() &&
224 "Not enough physical registers, consider increasing "
230 params.numPhysCCRegs != 0,
231 "Non-zero number of physical CC regs specified, even though\n"
232 " ISA does not use them.");
234 rename.setScoreboard(&scoreboard);
235 iew.setScoreboard(&scoreboard);
238 for (
ThreadID tid = 0; tid < numThreads; tid++) {
239 isa[tid] = params.isa[tid];
240 commitRenameMap[tid].init(regClasses, ®File, &freeList);
241 renameMap[tid].init(regClasses, ®File, &freeList);
246 for (
ThreadID tid = 0; tid < active_threads; tid++) {
249 for (
auto &
id: *regClasses.
at(
type)) {
253 renameMap[tid].setEntry(
id, phys_reg);
254 commitRenameMap[tid].setEntry(
id, phys_reg);
259 rename.setRenameMap(renameMap);
260 commit.setRenameMap(commitRenameMap);
261 rename.setFreeList(&freeList);
266 lastActivatedCycle = 0;
268 DPRINTF(O3CPU,
"Creating O3CPU object.\n");
271 thread.resize(numThreads);
273 for (
ThreadID tid = 0; tid < numThreads; ++tid) {
276 assert(numThreads == 1);
277 thread[tid] =
new ThreadState(
this, 0, NULL);
279 if (tid < params.workload.size()) {
280 DPRINTF(O3CPU,
"Workload[%i] process is %#x", tid,
282 thread[tid] =
new ThreadState(
this, tid, params.workload[tid]);
286 Process* dummy_proc = NULL;
288 thread[tid] =
new ThreadState(
this, tid, dummy_proc);
295 auto *o3_tc =
new ThreadContext;
301 if (params.checker) {
302 tc =
new CheckerThreadContext<ThreadContext>(o3_tc, checker);
306 o3_tc->thread = thread[tid];
309 thread[tid]->tc = tc;
312 threadContexts.push_back(tc);
316 if (!params.switched_out && interrupts.empty()) {
317 fatal(
"O3CPU %s has no interrupt controller.\n"
318 "Ensure createInterruptController() is called.\n",
name());
340 : statistics::
Group(cpu),
341 ADD_STAT(timesIdled, statistics::units::Count::get(),
342 "Number of times that the entire CPU went into an idle state "
343 "and unscheduled itself"),
344 ADD_STAT(idleCycles, statistics::units::Cycle::get(),
345 "Total number of cycles that the CPU has spent unscheduled due "
347 ADD_STAT(quiesceCycles, statistics::units::Cycle::get(),
348 "Total number of cycles that CPU has spent quiesced or waiting "
365 DPRINTF(O3CPU,
"\n\nO3CPU: Ticking main, O3CPU.\n");
401 DPRINTF(O3CPU,
"Switched out!\n");
410 DPRINTF(O3CPU,
"Scheduling next tick!\n");
428 thread[tid]->noSquashFromTC =
true;
433 thread[tid]->noSquashFromTC =
false;
456 DPRINTF(O3CPU,
"[tid:%i] Calling activate thread.\n", tid);
460 DPRINTF(O3CPU,
"[tid:%i] Adding to active threads list\n", tid);
477 DPRINTF(O3CPU,
"[tid:%i] Calling deactivate thread.\n", tid);
481 DPRINTF(O3CPU,
"[tid:%i] Removing from active threads list\n",
555 DPRINTF(O3CPU,
"[tid:%i] Suspending Thread Context.\n", tid);
567 DPRINTF(Quiesce,
"Suspending Context\n");
576 DPRINTF(O3CPU,
"[tid:%i] Halt Context called. Deallocating\n", tid);
597 DPRINTF(O3CPU,
"[tid:%i] Initializing thread into CPU");
607 const auto ®Classes =
isa[tid]->regClasses();
611 for (
auto &
id: *regClasses.at(
type)) {
635 DPRINTF(O3CPU,
"[tid:%i] Removing thread context from CPU.\n", tid);
703 DPRINTF(O3CPU,
"Interrupt %s being handled\n", interrupt->name());
704 trap(interrupt, 0,
nullptr);
717 thread[tid]->serialize(cp);
723 thread[tid]->unserialize(cp);
736 DPRINTF(Drain,
"Draining...\n");
752 DPRINTF(Drain,
"Currently suspended so activate %i \n",
763 DPRINTF(Drain,
"CPU not drained\n");
767 DPRINTF(Drain,
"CPU is already drained\n");
797 DPRINTF(Drain,
"CPU done draining, processing drain event\n");
820 DPRINTF(Drain,
"Main CPU structures not drained.\n");
825 DPRINTF(Drain,
"Fetch not drained.\n");
830 DPRINTF(Drain,
"Decode not drained.\n");
835 DPRINTF(Drain,
"Rename not drained.\n");
840 DPRINTF(Drain,
"IEW not drained.\n");
845 DPRINTF(Drain,
"Commit not drained.\n");
860 DPRINTF(Drain,
"Resuming...\n");
869 DPRINTF(Drain,
"Activating thread: %i\n",
i);
886 DPRINTF(O3CPU,
"Switching out\n");
910 auto *oldO3CPU =
dynamic_cast<CPU *
>(oldCPU);
922 fatal(
"The O3 CPU requires the memory system to be in "
930 return isa[tid]->readMiscRegNoEffect(misc_reg);
937 return isa[tid]->readMiscReg(misc_reg);
943 isa[tid]->setMiscRegNoEffect(misc_reg,
val);
950 isa[tid]->setMiscReg(misc_reg,
val);
1128 thread[tid]->noSquashFromTC =
true;
1144 if (!inst->isMicroop() || inst->isLastMicroop()) {
1146 thread[tid]->threadStats.numInsts++;
1150 thread[tid]->comInstEventQueue.serviceEvents(
thread[tid]->numInst);
1153 thread[tid]->threadStats.numOps++;
1162 DPRINTF(O3CPU,
"Removing committed instruction [tid:%i] PC %s "
1164 inst->threadNumber, inst->pcState(), inst->seqNum);
1175 DPRINTF(O3CPU,
"Thread %i: Deleting instructions from instruction"
1180 bool rob_empty =
false;
1185 DPRINTF(O3CPU,
"ROB is empty, squashing all insts.\n");
1190 DPRINTF(O3CPU,
"ROB is not empty, squashing insts not in ROB.\n");
1201 while (inst_it != end_it) {
1227 DPRINTF(O3CPU,
"Deleting instructions from instruction "
1228 "list that are from [tid:%i] and above [sn:%lli] (end=%lli).\n",
1229 tid, seq_num, (*inst_iter)->seqNum);
1231 while ((*inst_iter)->seqNum > seq_num) {
1233 bool break_loop = (inst_iter ==
instList.begin());
1247 if ((*instIt)->threadNumber == tid) {
1248 DPRINTF(O3CPU,
"Squashing instruction, "
1249 "[tid:%i] [sn:%lli] PC %s\n",
1250 (*instIt)->threadNumber,
1252 (*instIt)->pcState());
1255 (*instIt)->setSquashed();
1268 DPRINTF(O3CPU,
"Removing instruction, "
1269 "[tid:%i] [sn:%lli] PC %s\n",
1295 cprintf(
"Dumping Instruction List\n");
1297 while (inst_list_it !=
instList.end()) {
1298 cprintf(
"Instruction:%i\nPC:%#x\n[tid:%i]\n[sn:%lli]\nIssued:%i\n"
1300 num, (*inst_list_it)->pcState().instAddr(),
1301 (*inst_list_it)->threadNumber,
1302 (*inst_list_it)->seqNum, (*inst_list_it)->isIssued(),
1303 (*inst_list_it)->isSquashed());
1319 DPRINTF(Activity,
"CPU already running.\n");
1323 DPRINTF(Activity,
"Waking up CPU\n");
1344 DPRINTF(Quiesce,
"Suspended Processor woken\n");
1369 unsigned high_thread = *list_begin;
1380 DPRINTF(O3CPU,
"Thread %d is inserted to exitingThreads list\n", tid);
1432 bool readyToExit = it->second;
1435 DPRINTF(O3CPU,
"Exiting thread %d\n", thread_id);
1463 req->setContext(
thread[tid]->contextId());
1464 req->setHtmAbortCause(cause);
1466 assert(req->isHTMAbort());
1469 uint8_t *memData =
new uint8_t[8];
1476 panic(
"HTM abort signal was not sent to the memory subsystem.");
void advance()
Advances the activity buffer, decrementing the activityCount if active communication just left the ti...
void reset()
Clears the time buffer and the activity count.
void activity()
Records that there is activity this cycle.
bool active()
Returns if the CPU should be active.
void init() override
init() is called after all C++ SimObjects have been created and all ports are connected.
void updateCycleCounters(CPUState state)
base method keeping track of cycle progression
void schedulePowerGatingEvent()
std::vector< std::unique_ptr< CommitCPUStats > > commitStats
void regProbePoints() override
Register probe points for this object.
uint32_t taskId() const
Get cpu task id.
virtual void suspendContext(ThreadID thread_num)
Notify the CPU that the indicated context is now suspended.
gem5::BaseCPU::BaseCPUStats baseStats
ThreadID numThreads
Number of threads we're actually simulating (<= SMT_MAX_THREADS).
void deschedulePowerGatingEvent()
std::vector< std::unique_ptr< ExecuteCPUStats > > executeStats
std::vector< BaseInterrupts * > interrupts
void startup() override
startup() is the final initialization call before simulation.
virtual void switchOut()
Prepare for another CPU to take over execution.
virtual void takeOverFrom(BaseCPU *cpu)
Load the state of a CPU from the previous CPU object, invoked on all new CPUs that are about to be sw...
std::vector< ThreadContext * > threadContexts
bool switchedOut() const
Determine if the CPU is switched out.
virtual void probeInstCommit(const StaticInstPtr &inst, Addr pc)
Helper method to trigger PMU probes for a committed instruction.
RequestorID _dataRequestorId
data side request id that must be placed in all requests
virtual void activateContext(ThreadID thread_num)
Notify the CPU that the indicated context is now active.
void switchOut()
Prepare for another CPU to take over execution.
Cycles curCycle() const
Determine the current cycle, corresponding to a tick aligned to a clock edge.
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...
Tick nextCycle() const
Based on the clock of the object, determine the start tick of the first cycle that is at least one cy...
Cycles is a wrapper class for representing cycle counts, i.e.
A Packet is used to encapsulate a transfer between two objects in the memory system (e....
void dataStatic(T *p)
Set the data pointer to the following value that should not be freed.
static PacketPtr createRead(const RequestPtr &req)
Constructor-like methods that return Packets based on Request objects.
void setHtmTransactional(uint64_t val)
Stipulates that this packet/request originates in the CPU executing in transactional mode,...
constexpr RegClassType classValue() const
ProbePointArg generates a point for the class of Arg.
Register ID: describe an architectural register with its class and index.
RegId flatten(const BaseISA &isa) const
bool sendTimingReq(PacketPtr pkt)
Attempt to send a timing request to the responder port by calling its corresponding receive function.
@ STRICT_ORDER
The request is required to be strictly ordered by CPU models and is non-speculative.
@ PHYSICAL
The virtual address is also the physical address.
@ HTM_ABORT
The request aborts a HTM transaction.
bool isTimingMode() const
Is the system in timing mode?
ThreadContext is the external interface to all thread state for anything outside of the CPU.
virtual void setStatus(Status new_status)=0
@ Halted
Permanently shut down.
@ Suspended
Temporarily inactive.
virtual const PCStateBase & pcState() const =0
O3CPU class, has each of the stages (fetch through commit) within it, as well as all of the time buff...
std::vector< BaseISA * > isa
void instDone(ThreadID tid, const DynInstPtr &inst)
Function to tell the CPU that an instruction has completed.
IEW iew
The issue/execute/writeback stages.
gem5::Checker< DynInstPtr > * checker
Pointer to the checker, which can dynamically verify instruction results at run time.
void dumpInsts()
Debug function to print all instructions on the list.
void drainSanityCheck() const
Perform sanity checks after a drain.
void htmSendAbortSignal(ThreadID tid, uint64_t htm_uid, HtmFailureFaultCause cause) override
This function is used to instruct the memory subsystem that a transaction should be aborted and the s...
std::list< DynInstPtr > instList
List of all the instructions in flight.
RegVal getReg(PhysRegIdPtr phys_reg, ThreadID tid)
ListIt addInst(const DynInstPtr &inst)
Function to add instruction onto the head of the list of the instructions.
void setArchReg(const RegId ®, RegVal val, ThreadID tid)
ROB rob
The re-order buffer.
InstSeqNum globalSeqNum
The global sequence number counter.
void haltContext(ThreadID tid) override
Remove Thread from Active Threads List && Remove Thread Context from CPU.
TimeBuffer< DecodeStruct > decodeQueue
The decode stage's instruction queue.
EventFunctionWrapper tickEvent
The tick event used for scheduling CPU ticks.
void serializeThread(CheckpointOut &cp, ThreadID tid) const override
Serialize a single thread.
void startup() override
startup() is the final initialization call before simulation.
void drainResume() override
Resumes execution after a drain.
Rename rename
The dispatch stage.
void regProbePoints() override
Register probe points.
void deactivateThread(ThreadID tid)
Remove Thread from Active Threads List.
Counter totalInsts() const override
Count the Total Instructions Committed in the CPU.
void trap(const Fault &fault, ThreadID tid, const StaticInstPtr &inst)
Traps to handle given fault.
CPU(const BaseO3CPUParams ¶ms)
Constructs a CPU with the given parameters.
ProbePointArg< PacketPtr > * ppInstAccessComplete
void exitThreads()
Terminate all threads that are ready to exit.
ThreadID getFreeTid()
Gets a free thread id.
std::vector< ThreadState * > thread
Pointers to all of the threads in the CPU.
void tick()
Ticks CPU, calling tick() on each stage, and checking the overall activity to see if the CPU should d...
void removeThread(ThreadID tid)
Remove all of a thread's context from CPU.
void commitDrained(ThreadID tid)
Commit has reached a safe point to drain a thread.
void unscheduleTickEvent()
Unschedule tick event, regardless of its current state.
gem5::o3::CPU::CPUStats cpuStats
UnifiedFreeList freeList
The free list.
Status _status
Overall CPU status.
std::list< DynInstPtr >::iterator ListIt
void activateContext(ThreadID tid) override
Add Thread to Active Threads List.
virtual void wakeup(ThreadID tid) override
bool removeInstsThisCycle
Records if instructions need to be removed this cycle due to being retired or squashed.
void setMiscReg(int misc_reg, RegVal val, ThreadID tid)
Sets a misc.
std::vector< ThreadID > tids
Available thread ids in the cpu.
ProbePointArg< std::pair< DynInstPtr, PacketPtr > > * ppDataAccessComplete
PerThreadUnifiedRenameMap commitRenameMap
The commit rename map.
void setMiscRegNoEffect(int misc_reg, RegVal val, ThreadID tid)
Sets a miscellaneous register.
void removeInstsUntil(const InstSeqNum &seq_num, ThreadID tid)
Remove all instructions younger than the given sequence number.
std::queue< ListIt > removeList
List of all the instructions that will be removed at the end of this cycle.
TimeBuffer< FetchStruct > fetchQueue
The fetch stage's instruction queue.
void cleanUpRemovedInsts()
Cleans up all instructions on the remove list.
Commit commit
The commit stage.
void suspendContext(ThreadID tid) override
Remove Thread from Active Threads List.
void unserializeThread(CheckpointIn &cp, ThreadID tid) override
Unserialize one thread.
void removeInstsNotInROB(ThreadID tid)
Remove all instructions that are not currently in the ROB.
void takeOverFrom(BaseCPU *oldCPU) override
Takes over from another CPU.
void switchOut() override
Switches out this CPU.
PhysRegFile regFile
The register file.
Cycles lastRunningCycle
The cycle that the CPU was last running, used for statistics.
bool tryDrain()
Check if the pipeline has drained and signal drain done.
ActivityRecorder activityRec
The activity recorder; used to tell if the CPU has any activity remaining or if it can go to idle and...
void processInterrupts(const Fault &interrupt)
Processes any an interrupt fault.
void squashFromTC(ThreadID tid)
Initiates a squash of all in-flight instructions for a given thread.
TimeBuffer< TimeStruct > timeBuffer
The main time buffer to do backwards communication.
Tick lastActivatedCycle
The cycle that the CPU was last activated by a new thread.
void squashInstIt(const ListIt &instIt, ThreadID tid)
Removes the instruction pointed to by the iterator.
System * system
Pointer to the system.
Decode decode
The decode stage.
void verifyMemoryMode() const override
Verify that the system is in a memory mode supported by the CPU.
RegVal getArchReg(const RegId ®, ThreadID tid)
Architectural register accessors.
TimeBuffer< IEWStruct > iewQueue
The IEW stage's instruction queue.
EventFunctionWrapper threadExitEvent
The exit event used for terminating all ready-to-exit threads.
DrainState drain() override
Starts draining the CPU's pipeline of all instructions in order to stop all memory accesses.
std::list< ThreadID > activeThreads
Active Threads List.
PerThreadUnifiedRenameMap renameMap
The rename map.
Fault getInterrupts()
Returns the Fault for any valid interrupt.
void scheduleTickEvent(Cycles delay)
Schedule tick event, regardless of its current state.
RegVal readMiscRegNoEffect(int misc_reg, ThreadID tid) const
Register accessors.
bool isCpuDrained() const
Check if a system is in a drained state.
Fetch fetch
The fetch stage.
void addThreadToExitingList(ThreadID tid)
Insert tid to the list of threads trying to exit.
void pcState(const PCStateBase &new_pc_state, ThreadID tid)
Sets the commit PC state of a specific thread.
void scheduleThreadExitEvent(ThreadID tid)
If a thread is trying to exit and its corresponding trap event has been completed,...
void updateThreadPriority()
Update The Order In Which We Process Threads.
void setReg(PhysRegIdPtr phys_reg, RegVal val, ThreadID tid)
bool isThreadExiting(ThreadID tid) const
Is the thread trying to exit?
void removeFrontInst(const DynInstPtr &inst)
Remove an instruction from the front end of the list.
void * getWritableArchReg(const RegId ®, ThreadID tid)
RegVal readMiscReg(int misc_reg, ThreadID tid)
Reads a misc.
void init() override
Initialize the CPU.
void activateThread(ThreadID tid)
Add Thread to Active Threads List.
gem5::ThreadContext * tcBase(ThreadID tid)
Returns a pointer to a thread context.
Scoreboard scoreboard
Integer Register Scoreboard.
void * getWritableReg(PhysRegIdPtr phys_reg, ThreadID tid)
std::unordered_map< ThreadID, bool > exitingThreads
This is a list of threads that are trying to exit.
Counter totalOps() const override
Count the Total Ops (including micro ops) committed in the CPU.
void wakeCPU()
Wakes the CPU, rescheduling the CPU if it's not already active.
void insertThread(ThreadID tid)
Setup CPU to insert a thread's context.
TimeBuffer< RenameStruct > renameQueue
The rename stage's instruction queue.
void startupStage()
Initializes stage by sending back the number of free entries.
bool executingHtmTransaction(ThreadID) const
Is the CPU currently processing a HTM transaction?
void deactivateThread(ThreadID tid)
Deschedules a thread from scheduling.
void tick()
Ticks the commit stage, which tries to commit instructions.
const PCStateBase & pcState(ThreadID tid)
Reads the PC of a specific thread.
void resetHtmStartsStops(ThreadID)
void drainSanityCheck() const
Perform sanity checks after a drain.
void takeOverFrom()
Takes over from another CPU's thread.
void clearStates(ThreadID tid)
Clear all thread-specific states.
void drainResume()
Resumes execution after draining.
void drain()
Initializes the draining of commit.
void generateTCEvent(ThreadID tid)
Records that commit needs to initiate a squash due to an external state update through the TC.
void regProbePoints()
Registers probes.
void setThreads(std::vector< ThreadState * > &threads)
Sets the list of threads.
bool isDrained() const
Has the stage drained?
void takeOverFrom()
Takes over from another CPU's thread.
bool isDrained() const
Has the stage drained?
void clearStates(ThreadID tid)
Clear all thread-specific states.
void drainSanityCheck() const
Perform sanity checks after a drain.
void tick()
Ticks decode, processing all input signals and decoding as many instructions as possible.
void deactivateThread(ThreadID tid)
For priority-based fetch policies, need to keep update priorityList.
void takeOverFrom()
Takes over from another CPU's thread.
void startupStage()
Initialize stage.
void wakeFromQuiesce()
Tells fetch to wake up from a quiesce instruction.
void drainSanityCheck() const
Perform sanity checks after a drain.
void regProbePoints()
Registers probes.
void drainStall(ThreadID tid)
Stall the fetch stage after reaching a safe drain point.
void drainResume()
Resume after a drain.
void clearStates(ThreadID tid)
Clear all thread-specific states.
bool isDrained() const
Has the stage drained?
void tick()
Ticks the fetch stage, processing all inputs signals and fetching as many instructions as possible.
void takeOverFrom()
Takes over from another CPU's thread.
void clearStates(ThreadID tid)
Clear all thread-specific states.
void startupStage()
Initializes stage; sends back the number of free IQ and LSQ entries.
void drainSanityCheck() const
Perform sanity checks after a drain.
bool isDrained() const
Has the stage drained?
InstructionQueue instQueue
Instruction queue.
void tick()
Ticks IEW stage, causing Dispatch, the IQ, the LSQ, Execute, and Writeback to run for one cycle.
LSQ ldstQueue
Load / store queue.
void regProbePoints()
Registers probes.
unsigned getCount(ThreadID tid)
Returns the number of used entries for a thread.
RequestPort & getDataPort()
int getCount()
Returns the number of instructions in all of the queues.
void resetHtmStartsStops(ThreadID tid)
RegVal getReg(PhysRegIdPtr phys_reg) const
void * getWritableReg(PhysRegIdPtr phys_reg)
void setReg(PhysRegIdPtr phys_reg, RegVal val)
void resetEntries()
Re-adjust ROB partitioning.
DynInstPtr readTailInst(ThreadID tid)
Returns pointer to the tail instruction within the ROB.
bool isEmpty() const
Returns if the ROB is empty.
void startupStage()
Initializes variables for the stage.
void tick()
Ticks rename, which processes all input signals and attempts to rename as many instructions as possib...
void drainSanityCheck() const
Perform sanity checks after a drain.
void takeOverFrom()
Takes over from another CPU's thread.
void regProbePoints()
Registers probes.
bool isDrained() const
Has the stage drained?
void clearStates(ThreadID tid)
Clear all thread-specific states.
void setReg(PhysRegIdPtr phys_reg)
Sets the register as ready.
PhysRegIdPtr getReg(RegClassType type)
Gets a free register of type type.
Derived & prereq(const Stat &prereq)
Set the prerequisite stat and marks this stat to print at the end of simulation.
#define ADD_STAT(n,...)
Convenience macro to add a stat to a statistics group.
void signalDrainDone() const
Signal that an object is drained.
DrainState drainState() const
Return the current drain state of an object.
DrainState
Object drain/handover states.
@ Draining
Draining buffers pending serialization/handover.
@ Running
Running normally.
@ Drained
Buffers drained, ready for serialization/handover.
void deschedule(Event &event)
bool scheduled() const
Determine if the current event is scheduled.
void schedule(Event &event, Tick when)
static const Priority CPU_Tick_Pri
CPU ticks must come after other associated CPU events (such as writebacks).
static const Priority CPU_Exit_Pri
If we want to exit a thread in a CPU, it comes after CPU_Tick_Pri.
#define panic(...)
This implements a cprintf based panic() function.
#define fatal_if(cond,...)
Conditional fatal macro that checks the supplied condition and only causes a fatal error if the condi...
#define fatal(...)
This implements a cprintf based fatal() function.
#define panic_if(cond,...)
Conditional panic macro that checks the supplied condition and only panics if the condition is true a...
ProbeManager * getProbeManager()
Get the probe manager for this object.
#define warn_if(cond,...)
Conditional warning macro that checks the supplied condition and only prints a warning if the conditi...
static constexpr int MaxThreads
const FlagsType total
Print the total.
double Counter
All counters are of 64-bit values.
Copyright (c) 2024 - Pranith Kumar Copyright (c) 2020 Inria All rights reserved.
std::shared_ptr< FaultBase > Fault
int16_t ThreadID
Thread index/ID type.
std::shared_ptr< Request > RequestPtr
const ThreadID InvalidThreadID
void cprintf(const char *format, const Args &...args)
Tick curTick()
The universal simulation clock.
std::ostream CheckpointOut
uint64_t Addr
Address type This will probably be moved somewhere else in the near future.
bool FullSystem
The FullSystem variable can be used to determine the current mode of simulation.
constexpr decltype(nullptr) NoFault
RegClassType
Enumerate the classes of registers.
@ MatRegClass
Matrix Register.
@ FloatRegClass
Floating-point register.
@ CCRegClass
Condition-code register.
@ VecRegClass
Vector Register.
@ IntRegClass
Integer register.
@ VecElemClass
Vector Register Native Elem lane.
statistics::Scalar numCycles
statistics::Scalar timesIdled
Stat for total number of times the CPU is descheduled.
statistics::Scalar quiesceCycles
Stat for total number of cycles the CPU spends descheduled due to a quiesce operation or waiting for ...
statistics::Scalar idleCycles
Stat for total number of cycles the CPU spends descheduled.
const std::string & name()