Go to the documentation of this file.
51 #include "config/the_isa.hh"
60 #include "debug/Activity.hh"
61 #include "debug/Commit.hh"
62 #include "debug/CommitRate.hh"
63 #include "debug/Drain.hh"
64 #include "debug/ExecFaulting.hh"
65 #include "debug/HtmCpu.hh"
66 #include "debug/O3PipeView.hh"
67 #include "params/O3CPU.hh"
86 : commitPolicy(params.smtCommitPolicy),
88 iewToCommitDelay(params.iewToCommitDelay),
89 commitToIEWDelay(params.commitToIEWDelay),
90 renameToROBDelay(params.renameToROBDelay),
91 fetchToCommitDelay(params.commitToFetchDelay),
92 renameWidth(params.renameWidth),
93 commitWidth(params.commitWidth),
94 numThreads(params.numThreads),
97 trapLatency(params.trapLatency),
98 canHandleInterrupts(true),
99 avoidQuiesceLiveLock(false),
103 fatal(
"commitWidth (%d) is larger than compiled limit (%d),\n"
104 "\tincrease MaxWidth in src/cpu/o3/limits.hh\n",
150 : statistics::
Group(cpu,
"commit"),
151 ADD_STAT(commitSquashedInsts, statistics::units::Count::get(),
152 "The number of squashed insts skipped by commit"),
153 ADD_STAT(commitNonSpecStalls, statistics::units::Count::get(),
154 "The number of times commit has been forced to stall to "
155 "communicate backwards"),
156 ADD_STAT(branchMispredicts, statistics::units::Count::get(),
157 "The number of times a branch was mispredicted"),
158 ADD_STAT(numCommittedDist, statistics::units::Count::get(),
159 "Number of insts commited each cycle"),
160 ADD_STAT(instsCommitted, statistics::units::Count::get(),
161 "Number of instructions committed"),
162 ADD_STAT(opsCommitted, statistics::units::Count::get(),
163 "Number of ops (including micro ops) committed"),
164 ADD_STAT(memRefs, statistics::units::Count::get(),
165 "Number of memory references committed"),
166 ADD_STAT(loads, statistics::units::Count::get(),
"Number of loads committed"),
167 ADD_STAT(amos, statistics::units::Count::get(),
168 "Number of atomic instructions committed"),
169 ADD_STAT(membars, statistics::units::Count::get(),
170 "Number of memory barriers committed"),
171 ADD_STAT(branches, statistics::units::Count::get(),
172 "Number of branches committed"),
173 ADD_STAT(vectorInstructions, statistics::units::Count::get(),
174 "Number of committed Vector instructions."),
175 ADD_STAT(floating, statistics::units::Count::get(),
176 "Number of committed floating point instructions."),
177 ADD_STAT(integer, statistics::units::Count::get(),
178 "Number of committed integer instructions."),
179 ADD_STAT(functionCalls, statistics::units::Count::get(),
180 "Number of function calls committed."),
181 ADD_STAT(committedInstType, statistics::units::Count::get(),
182 "Class of committed instruction"),
183 ADD_STAT(commitEligibleSamples, statistics::units::Cycle::get(),
184 "number cycles where commit BW limit reached")
186 using namespace statistics;
321 toIEW->commitInfo[tid].usedROB =
true;
323 toIEW->commitInfo[tid].emptyROB =
true;
367 panic(
"cannot drain partially through a HTM transaction");
452 while (threads != end) {
465 DPRINTF(Activity,
"Deactivating stage.\n");
468 DPRINTF(Activity,
"Activating stage.\n");
481 while (threads != end) {
501 DPRINTF(
Commit,
"Generating trap event for [tid:%i]\n", tid);
507 Cycles latency = std::dynamic_pointer_cast<SyscallRetryFault>(inst_fault) ?
511 if (inst_fault !=
nullptr &&
512 std::dynamic_pointer_cast<GenericHtmFailureFault>(inst_fault)) {
520 thread[tid]->trapPending =
true;
527 DPRINTF(
Commit,
"Generating TC squash event for [tid:%i]\n", tid);
551 toIEW->commitInfo[tid].doneSeqNum = squashed_inst;
555 toIEW->commitInfo[tid].squash =
true;
559 toIEW->commitInfo[tid].robSquashing =
true;
561 toIEW->commitInfo[tid].mispredictInst = NULL;
562 toIEW->commitInfo[tid].squashInst = NULL;
564 toIEW->commitInfo[tid].pc =
pc[tid];
572 DPRINTF(
Commit,
"Squashing from trap, restarting at PC %s\n",
pc[tid]);
574 thread[tid]->trapPending =
false;
575 thread[tid]->noSquashFromTC =
false;
591 thread[tid]->noSquashFromTC =
false;
592 assert(!
thread[tid]->trapPending);
604 "restarting at PC %s\n",
pc[tid]);
620 DPRINTF(
Commit,
"Executing squash after for [tid:%i] inst [sn:%llu]\n",
621 tid, head_inst->seqNum);
642 while (threads != end) {
655 " insts this cycle.\n", tid);
657 toIEW->commitInfo[tid].robSquashing =
true;
669 while (threads != end) {
679 DPRINTF(
Commit,
"[tid:%i] Instruction [sn:%llu] PC %s is head of"
680 " ROB and ready to commit\n",
681 tid, inst->seqNum, inst->
pcState());
688 DPRINTF(
Commit,
"[tid:%i] Can't commit, Instruction [sn:%llu] PC "
689 "%s is head of ROB and not ready\n",
690 tid, inst->seqNum, inst->pcState());
693 DPRINTF(
Commit,
"[tid:%i] ROB has %d insts & %d free entries.\n",
699 DPRINTF(Activity,
"Activity This Cycle.\n");
711 DPRINTF(
Commit,
"Pending interrupt is cleared by requestor before "
712 "it got handled. Restart fetching from the orig path.\n");
713 toIEW->commitInfo[0].clearInterrupt =
true;
727 toIEW->commitInfo[0].clearInterrupt =
true;
729 assert(!
thread[0]->noSquashFromTC);
730 thread[0]->noSquashFromTC =
true;
741 thread[0]->noSquashFromTC =
false;
753 "flight, ROB is %sempty\n",
780 toIEW->commitInfo[0].interruptPending =
true;
798 int num_squashing_threads = 0;
800 while (threads != end) {
832 if (
fromIEW->mispredictInst[tid]) {
834 "[tid:%i] Squashing due to branch mispred "
835 "PC:%#x [sn:%llu]\n",
837 fromIEW->mispredictInst[tid]->instAddr(),
841 "[tid:%i] Squashing due to order violation [sn:%llu]\n",
842 tid,
fromIEW->squashedSeqNum[tid]);
847 fromIEW->pc[tid].nextInstAddr());
855 if (
fromIEW->includeSquashInst[tid]) {
866 toIEW->commitInfo[tid].doneSeqNum = squashed_inst;
868 toIEW->commitInfo[tid].squash =
true;
872 toIEW->commitInfo[tid].robSquashing =
true;
874 toIEW->commitInfo[tid].mispredictInst =
876 toIEW->commitInfo[tid].branchTaken =
878 toIEW->commitInfo[tid].squashInst =
880 if (
toIEW->commitInfo[tid].mispredictInst) {
881 if (
toIEW->commitInfo[tid].mispredictInst->isUncondCtrl()) {
882 toIEW->commitInfo[tid].branchTaken =
true;
884 ++
stats.branchMispredicts;
891 num_squashing_threads++;
897 if (num_squashing_threads) {
912 while (threads != end) {
916 toIEW->commitInfo[tid].usedROB =
true;
936 toIEW->commitInfo[tid].usedROB =
true;
937 toIEW->commitInfo[tid].emptyROB =
true;
957 DPRINTF(
Commit,
"Trying to commit instructions in the ROB.\n");
959 unsigned num_committed = 0;
978 toIEW->commitInfo[0].clearInterrupt =
true;
993 ThreadID tid = head_inst->threadNumber;
995 assert(tid == commit_thread);
998 "Trying to commit head instruction, [tid:%i] [sn:%llu]\n",
999 tid, head_inst->seqNum);
1003 if (head_inst->isSquashed()) {
1010 ++
stats.commitSquashedInsts;
1017 pc[tid] = head_inst->pcState();
1020 bool commit_success =
commitHead(head_inst, num_committed);
1022 if (commit_success) {
1024 stats.committedInstType[tid][head_inst->opClass()]++;
1030 if (head_inst->isHtmStart())
1034 if (head_inst->inHtmTransactionalState()) {
1041 if (head_inst->isHtmStop())
1047 toIEW->commitInfo[tid].doneSeqNum = head_inst->seqNum;
1054 assert(!head_inst->isStoreConditional() ||
1055 head_inst->isCompleted() ||
1056 !head_inst->readPredicate());
1059 head_inst->updateMiscRegs();
1069 head_inst->staticInst->advancePC(
pc[tid]);
1076 if (head_inst->isSquashAfter())
1081 !
thread[tid]->trapPending) {
1085 DPRINTF(Drain,
"Draining: %i:%s\n", tid,
pc[tid]);
1092 bool onInstBoundary = !head_inst->isMicroop() ||
1093 head_inst->isLastMicroop() ||
1094 !head_inst->isDelayedCommit();
1096 if (onInstBoundary) {
1101 assert(!
thread[tid]->noSquashFromTC &&
1102 !
thread[tid]->trapPending);
1104 oldpc =
pc[tid].instAddr();
1105 thread[tid]->pcEventQueue.service(
1106 oldpc,
thread[tid]->getTC());
1111 "PC skip function event, stopping commit\n");
1129 "[tid:%i] [sn:%llu].\n",
1130 head_inst->pcState(), tid ,head_inst->seqNum);
1136 DPRINTF(CommitRate,
"%i\n", num_committed);
1137 stats.numCommittedDist.sample(num_committed);
1140 stats.commitEligibleSamples++;
1149 ThreadID tid = head_inst->threadNumber;
1153 if (!head_inst->isExecuted()) {
1156 assert(head_inst->isNonSpeculative() || head_inst->isStoreConditional()
1157 || head_inst->isReadBarrier() || head_inst->isWriteBarrier()
1158 || head_inst->isAtomic()
1159 || (head_inst->isLoad() && head_inst->strictlyOrdered()));
1162 "Encountered a barrier or non-speculative "
1163 "instruction [tid:%i] [sn:%llu] "
1164 "at the head of the ROB, PC %s.\n",
1165 tid, head_inst->seqNum, head_inst->pcState());
1169 "[tid:%i] [sn:%llu] "
1170 "Waiting for all stores to writeback.\n",
1171 tid, head_inst->seqNum);
1175 toIEW->commitInfo[tid].nonSpecSeqNum = head_inst->seqNum;
1179 head_inst->clearCanCommit();
1181 if (head_inst->isLoad() && head_inst->strictlyOrdered()) {
1183 "Strictly ordered load, PC %s.\n",
1184 tid, head_inst->seqNum, head_inst->pcState());
1185 toIEW->commitInfo[tid].strictlyOrdered =
true;
1186 toIEW->commitInfo[tid].strictlyOrderedLoad = head_inst;
1188 ++
stats.commitNonSpecStalls;
1195 Fault inst_fault = head_inst->getFault();
1200 if (inst_fault !=
NoFault && head_inst->inHtmTransactionalState()) {
1202 if (!std::dynamic_pointer_cast<GenericHtmFailureFault>(inst_fault)) {
1203 DPRINTF(HtmCpu,
"%s - fault (%s) encountered within transaction"
1204 " - converting to GenericHtmFailureFault\n",
1205 head_inst->staticInst->getName(), inst_fault->name());
1206 inst_fault = std::make_shared<GenericHtmFailureFault>(
1207 head_inst->getHtmTransactionUid(),
1215 if (!head_inst->isStore() && inst_fault ==
NoFault) {
1216 head_inst->setCompleted();
1220 DPRINTF(
Commit,
"Inst [tid:%i] [sn:%llu] PC %s has a fault\n",
1221 tid, head_inst->seqNum, head_inst->pcState());
1225 "[tid:%i] [sn:%llu] "
1226 "Stores outstanding, fault must wait.\n",
1227 tid, head_inst->seqNum);
1231 head_inst->setCompleted();
1240 assert(!
thread[tid]->noSquashFromTC);
1244 thread[tid]->noSquashFromTC =
true;
1254 head_inst->staticInst);
1257 thread[tid]->noSquashFromTC =
false;
1262 "[tid:%i] [sn:%llu] Committing instruction with fault\n",
1263 tid, head_inst->seqNum);
1264 if (head_inst->traceData) {
1267 if (debug::ExecFaulting
1268 &&
dynamic_cast<ReExec*
>(inst_fault.get()) ==
nullptr) {
1270 head_inst->traceData->setFaulting(
true);
1271 head_inst->traceData->setFetchSeq(head_inst->seqNum);
1272 head_inst->traceData->setCPSeq(
thread[tid]->numOp);
1273 head_inst->traceData->dump();
1275 delete head_inst->traceData;
1276 head_inst->traceData = NULL;
1287 "[tid:%i] [sn:%llu] Committing instruction with PC %s\n",
1288 tid, head_inst->seqNum, head_inst->pcState());
1289 if (head_inst->traceData) {
1290 head_inst->traceData->setFetchSeq(head_inst->seqNum);
1291 head_inst->traceData->setCPSeq(
thread[tid]->numOp);
1292 head_inst->traceData->dump();
1293 delete head_inst->traceData;
1294 head_inst->traceData = NULL;
1296 if (head_inst->isReturn()) {
1298 "[tid:%i] [sn:%llu] Return Instruction Committed PC %s \n",
1299 tid, head_inst->seqNum, head_inst->pcState());
1303 for (
int i = 0;
i < head_inst->numDestRegs();
i++) {
1305 head_inst->regs.renamedDestIdx(
i));
1310 if (head_inst->isHtmStart())
1317 if (debug::O3PipeView) {
1318 head_inst->commitTick =
curTick() - head_inst->fetchTick;
1323 if (head_inst->isStore() || head_inst->isAtomic())
1333 DPRINTF(
Commit,
"Getting instructions from Rename stage.\n");
1338 for (
int inst_num = 0; inst_num < insts_to_process; ++inst_num) {
1342 if (!inst->isSquashed() &&
1347 DPRINTF(
Commit,
"[tid:%i] [sn:%llu] Inserting PC %s into ROB.\n",
1348 tid, inst->seqNum, inst->pcState());
1357 "Instruction PC %s was squashed, skipping.\n",
1358 tid, inst->seqNum, inst->pcState());
1368 for (
int inst_num = 0; inst_num <
fromIEW->size; ++inst_num) {
1369 assert(
fromIEW->insts[inst_num]);
1370 if (!
fromIEW->insts[inst_num]->isSquashed()) {
1373 fromIEW->insts[inst_num]->threadNumber,
1374 fromIEW->insts[inst_num]->pcState(),
1375 fromIEW->insts[inst_num]->seqNum);
1378 fromIEW->insts[inst_num]->setCanCommit();
1388 if (!inst->isMicroop() || inst->isLastMicroop())
1389 stats.instsCommitted[tid]++;
1390 stats.opsCommitted[tid]++;
1394 if (!inst->isNop() && !inst->isInstPrefetch()) {
1401 if (inst->isControl())
1402 stats.branches[tid]++;
1407 if (inst->isMemRef()) {
1408 stats.memRefs[tid]++;
1410 if (inst->isLoad()) {
1414 if (inst->isAtomic()) {
1419 if (inst->isFullMemBarrier()) {
1420 stats.membars[tid]++;
1424 if (inst->isInteger())
1425 stats.integer[tid]++;
1428 if (inst->isFloating())
1429 stats.floating[tid]++;
1431 if (inst->isVector())
1432 stats.vectorInstructions[tid]++;
1436 stats.functionCalls[tid]++;
1450 case CommitPolicy::RoundRobin:
1453 case CommitPolicy::OldestReady:
1479 while (pri_iter != end) {
1503 unsigned oldest = 0;
1504 unsigned oldest_seq_num = 0;
1510 while (threads != end) {
1524 oldest_seq_num = head_inst->seqNum;
1526 }
else if (head_inst->seqNum < oldest_seq_num) {
1528 oldest_seq_num = head_inst->seqNum;
bool drainPending
Is a drain pending? Commit is looking for an instruction boundary while there are no pending interrup...
void setActiveThreads(std::list< ThreadID > *at_ptr)
Sets pointer to list of active threads.
UnifiedRenameMap * renameMap[MaxThreads]
Rename map interface.
void setROB(ROB *rob_ptr)
Sets pointer to the ROB.
Tick curTick()
The universal simulation clock.
#define fatal(...)
This implements a cprintf based fatal() function.
const Cycles fetchToCommitDelay
void doSquash(ThreadID tid)
Executes the squash, marking squashed instructions.
void takeOverFrom()
Takes over from another CPU's thread.
statistics::Vector instsCommitted
Total number of instructions committed.
constexpr decltype(nullptr) NoFault
void squashFromTC(ThreadID tid)
Handles squashing due to an TC write.
void squash(InstSeqNum squash_num, ThreadID tid)
Squashes all instructions younger than the given sequence number for the specific thread.
void regProbePoints()
Registers probes.
Commit(CPU *_cpu, const O3CPUParams ¶ms)
Construct a Commit with the given parameters.
statistics::Vector loads
Stat for the total number of committed loads.
const unsigned renameWidth
Rename width, in instructions.
void setIEWQueue(TimeBuffer< IEWStruct > *iq_ptr)
Sets the pointer to the queue coming from IEW.
statistics::Distribution numCommittedDist
Distribution of the number of committed instructions each cycle.
void drain()
Initializes the draining of commit.
statistics::Vector2d committedInstType
Committed instructions by instruction type (OpClass)
TheISA::PCState pc[MaxThreads]
The commit PC state of each thread.
TimeBuffer< RenameStruct > * renameQueue
Rename instruction queue interface, for ROB.
ProbePointArg< DynInstPtr > * ppSquash
To probe when an instruction is squashed.
DynInstPtr squashAfterInst[MaxThreads]
Instruction passed to squashAfter().
Derived & init(size_type _x, size_type _y)
void setThreads(std::vector< ThreadState * > &threads)
Sets the list of threads.
TimeBuffer< TimeStruct > * timeBuffer
Time buffer interface.
TimeBuffer< IEWStruct >::wire fromIEW
Wire to read information from IEW queue.
void processInterrupts(const Fault &interrupt)
Processes any an interrupt fault.
Fault getInterrupts()
Returns the Fault for any valid interrupt.
std::list< ThreadID > priority_list
Priority List used for Commit Policy.
bool wroteToTimeBuffer
Records that commit has written to the time buffer this cycle.
void insertInst(const DynInstPtr &inst)
Function to insert an instruction into the ROB.
bool changedROBEntries()
Returns if any of the threads have the number of ROB entries changed on this cycle.
void startupStage()
Initializes stage by sending back the number of free entries.
void drainSanityCheck() const
Perform sanity checks after a drain.
void setRenameMap(UnifiedRenameMap rm_ptr[MaxThreads])
Sets pointer to the commited state rename map.
void commitInsts()
Commits as many instructions as possible.
ProbePointArg< DynInstPtr > * ppCommit
Probe Points.
bool isDoneSquashing(ThreadID tid) const
Reads the PC of the oldest head instruction.
void schedule(Event &event, Tick when)
std::list< DynInstPtr > instList
List of all the instructions in flight.
void squashFromSquashAfter(ThreadID tid)
Handles a squash from a squashAfter() request.
unsigned numFreeEntries()
Returns the number of total free entries in the ROB.
void setRenameQueue(TimeBuffer< RenameStruct > *rq_ptr)
Sets the pointer to the queue coming from rename.
bool committedStores[MaxThreads]
Records if there were any stores committed this cycle.
void generateTrapEvent(ThreadID tid, Fault inst_fault)
Generates an event to schedule a squash due to a trap.
void deactivateThread(ThreadID tid)
Deschedules a thread from scheduling.
void resetEntries()
Re-adjust ROB partitioning.
const FlagsType dist
Print the distribution.
size_t numROBFreeEntries(ThreadID tid)
Returns the number of free ROB entries for a specific thread.
gem5::Checker< DynInstPtr > * checker
Pointer to the checker, which can dynamically verify instruction results at run time.
Cycles is a wrapper class for representing cycle counts, i.e.
int htmStarts[MaxThreads]
unsigned getMaxEntries(ThreadID tid)
Returns the maximum number of entries for a specific thread.
void deactivateStage(const StageIdx idx)
Changes a stage's status to inactive within the activity recorder.
std::string name() const
Returns the name of the Commit.
statistics::Scalar branchMispredicts
Stat for the total number of branch mispredicts that caused a squash.
IEW * iewStage
The pointer to the IEW stage.
const FlagsType pdf
Print the percent of the total that this entry represents.
ThreadID numThreads
Number of threads we're actually simulating (<= SMT_MAX_THREADS).
std::list< ThreadID > * activeThreads
Pointer to the list of active threads.
bool changedROBNumEntries[MaxThreads]
Records if the number of ROB entries has changed this cycle.
TimeBuffer< IEWStruct > * iewQueue
IEW instruction queue interface.
const StaticInstPtr nullStaticInstPtr
Statically allocated null StaticInstPtr.
void generateTCEvent(ThreadID tid)
Records that commit needs to initiate a squash due to an external state update through the TC.
const Cycles renameToROBDelay
Rename to ROB delay.
void squashAll(ThreadID tid)
Squashes all in flight instructions.
statistics::Vector floating
Total number of floating point instructions.
O3CPU class, has each of the stages (fetch through commit) within it, as well as all of the time buff...
Distribution & init(Counter min, Counter max, Counter bkt)
Set the parameters of this distribution.
Commit handles single threaded and SMT commit.
void propagateInterrupt()
Get fetch redirecting so we can handle an interrupt.
virtual std::string name() const
std::shared_ptr< FaultBase > Fault
void processTrapEvent(ThreadID tid)
Mark the thread as processing a trap.
bool isDrained() const
Has the stage drained?
ThreadStatus commitStatus[MaxThreads]
Per-thread status.
#define ADD_STAT(n,...)
Convenience macro to add a stat to a statistics group.
ThreadID roundRobin()
Returns the thread ID to use based on a round robin policy.
Addr microPC(ThreadID tid)
Reads the micro PC of a specific thread.
void getInsts()
Gets instructions from rename and inserts them into the ROB.
const DynInstPtr & readHeadInst(ThreadID tid)
Returns pointer to the head instruction within the ROB.
bool avoidQuiesceLiveLock
Have we had an interrupt pending and then seen it de-asserted because of a masking change?...
void scheduleThreadExitEvent(ThreadID tid)
If a thread is trying to exit and its corresponding trap event has been completed,...
IEW handles both single threaded and SMT IEW (issue/execute/writeback).
bool commitHead(const DynInstPtr &head_inst, unsigned inst_num)
Tries to commit the head ROB instruction passed in.
void activateStage(const StageIdx idx)
Changes a stage's status to active within the activity recorder.
TimeBuffer< TimeStruct >::wire toIEW
Wire to write information heading to previous stages.
void resetHtmStartsStops(ThreadID)
void squashAfter(ThreadID tid, const DynInstPtr &head_inst)
Handle squashing from instruction with SquashAfter set.
ThreadID oldestReady()
Returns the thread ID to use based on an oldest instruction policy.
void setActiveThreads(std::list< ThreadID > *at_ptr)
Sets pointer to the list of active threads.
statistics::Scalar commitSquashedInsts
Stat for the total number of squashed instructions discarded by commit.
const unsigned commitWidth
Commit width, in instructions.
void clearStates(ThreadID tid)
Clear all thread-specific states.
const ThreadID InvalidThreadID
static constexpr int MaxWidth
std::vector< ThreadState * > thread
Vector of all of the threads.
CPU * cpu
Pointer to O3CPU.
bool isHeadReady(ThreadID tid)
Is the oldest instruction across all threads ready.
bool checkEmptyROB[MaxThreads]
Records if commit should check if the ROB is truly empty (see commit_impl.hh).
uint64_t Addr
Address type This will probably be moved somewhere else in the near future.
statistics::Vector integer
Total number of integer instructions.
Addr instAddr(ThreadID tid)
Returns the PC of a specific thread.
TimeBuffer< FetchStruct >::wire fromFetch
statistics::Vector vectorInstructions
Total number of vector instructions.
void updateComInstStats(const DynInstPtr &inst)
Updates commit stats based on this instruction.
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...
ThreadID getCommittingThread()
Gets the thread to commit, based on the SMT policy.
ProbePointArg generates a point for the class of Arg.
void commit()
Handles any squashes that are sent from IEW, and adds instructions to the ROB and tries to commit ins...
bool FullSystem
The FullSystem variable can be used to determine the current mode of simulation.
unsigned getThreadEntries(ThreadID tid)
Returns the number of entries being used by a specific thread.
void setLastRetiredHtmUid(ThreadID tid, uint64_t htmUid)
ProbeManager * getProbeManager()
Get the probe manager for this object.
static constexpr int MaxThreads
void activityThisCycle()
Records that there was time buffer activity this cycle.
statistics::Vector amos
Stat for the total number of committed atomics.
void drainResume()
Resumes execution after draining.
DynInstPtr findInst(ThreadID tid, InstSeqNum squash_inst)
Returns a pointer to the instruction with the given sequence if it is in the ROB.
bool executingHtmTransaction(ThreadID) const
Is the CPU currently processing a HTM transaction?
void traceFunctions(Addr pc)
Derived & prereq(const Stat &prereq)
Set the prerequisite stat and marks this stat to print at the end of simulation.
void commitDrained(ThreadID tid)
Commit has reached a safe point to drain a thread.
void trap(const Fault &fault, ThreadID tid, const StaticInstPtr &inst)
Traps to handle given fault.
Fault interrupt
The interrupt fault.
bool checkInterrupts(ThreadID tid) const
InstSeqNum lastCommitedSeqNum[MaxThreads]
The sequence number of the last commited instruction.
bool isEmpty() const
Returns if the ROB is empty.
void setFetchQueue(TimeBuffer< FetchStruct > *fq_ptr)
bool trapSquash[MaxThreads]
Records if a thread has to squash this cycle due to a trap.
bool isThreadExiting(ThreadID tid) const
Is the thread trying to exit?
CommitPolicy commitPolicy
Commit policy used in SMT mode.
bool trapInFlight[MaxThreads]
Records if there is a trap currently in flight.
CommitStatus _status
Overall commit status.
Cycles syscallRetryLatency
TheISA::PCState pcState(ThreadID tid)
Reads the PC of a specific thread.
statistics::Vector memRefs
Stat for the total number of committed memory references.
CommitStatus _nextStatus
Next commit status, to be set at the end of the cycle.
std::vector< Info * > stats
Derived & ysubnames(const char **names)
statistics::Vector opsCommitted
Total number of ops (including micro ops) committed.
void retireHead(ThreadID tid)
Retires the head instruction, removing it from the ROB.
CommitStats(CPU *cpu, Commit *commit)
statistics::Scalar commitNonSpecStalls
Stat for the total number of times commit has had to stall due to a non-speculative instruction reach...
void tick()
Ticks the commit stage, which tries to commit instructions.
Derived & flags(Flags _flags)
Set the flags and marks this stat to print at the end of simulation.
ProbePointArg< DynInstPtr > * ppCommitStall
static const Priority CPU_Tick_Pri
CPU ticks must come after other associated CPU events (such as writebacks).
InstSeqNum youngestSeqNum[MaxThreads]
The sequence number of the youngest valid instruction in the ROB.
statistics::Vector functionCalls
Total number of function calls.
bool hasStoresToWB()
Returns if the LSQ has any stores to writeback.
Reference material can be found at the JEDEC website: UFS standard http://www.jedec....
int countInsts()
This is more of a debugging function than anything.
const ThreadID numThreads
Number of Active Threads.
const FlagsType total
Print the total.
Derived & init(size_type size)
Set this vector to have the given size.
void markCompletedInsts()
Marks completed instructions using information sent from IEW.
bool drainImminent
Is a drain imminent? Commit has found an instruction boundary while no interrupts were present or in ...
void updateStatus()
Updates the overall status of commit with the nextStatus, and tell the CPU if commit is active/inacti...
void setTimeBuffer(TimeBuffer< TimeStruct > *tb_ptr)
Sets the main time buffer pointer, used for backwards communication.
void clearInterrupts(ThreadID tid)
void squashFromTrap(ThreadID tid)
Handles squashing due to a trap.
const Cycles trapLatency
The latency to handle a trap.
bool canHandleInterrupts
True if last committed microop can be followed by an interrupt.
void handleInterrupt()
Handles processing an interrupt.
void setIEWStage(IEW *iew_stage)
Sets the pointer to the IEW stage.
TimeBuffer< RenameStruct >::wire fromRename
Wire to read information from rename queue.
statistics::Vector branches
Total number of committed branches.
void drainSanityCheck() const
Perform sanity checks after a drain.
void instDone(ThreadID tid, const DynInstPtr &inst)
Function to tell the CPU that an instruction has completed.
int16_t ThreadID
Thread index/ID type.
void takeOverFrom()
Takes over another CPU's thread.
statistics::Vector membars
Total number of committed memory barriers.
#define panic(...)
This implements a cprintf based panic() function.
void setEntry(const RegId &arch_reg, PhysRegIdPtr phys_reg)
Update rename map with a specific mapping.
Unified register rename map for all classes of registers.
const Cycles iewToCommitDelay
IEW to Commit delay.
TimeBuffer< TimeStruct >::wire robInfoFromIEW
Wire to read information from IEW (for ROB).
TimeBuffer< FetchStruct > * fetchQueue
bool tcSquash[MaxThreads]
Records if a thread has to squash this cycle due to an XC write.
Generated on Wed Jul 28 2021 12:10:24 for gem5 by doxygen 1.8.17