Go to the documentation of this file.
53 #include "config/the_isa.hh"
60 #include "debug/Activity.hh"
61 #include "debug/Drain.hh"
62 #include "debug/Fetch.hh"
63 #include "debug/O3CPU.hh"
64 #include "debug/O3PipeView.hh"
66 #include "params/O3CPU.hh"
106 fatal(
"numThreads (%d) is larger than compiled limit (%d),\n"
107 "\tincrease MaxThreads in src/cpu/o3/limits.hh\n",
110 fatal(
"fetchWidth (%d) is larger than compiled limit (%d),\n"
111 "\tincrease MaxWidth in src/cpu/o3/limits.hh\n",
114 fatal(
"fetch buffer size (%u bytes) is greater than the cache "
117 fatal(
"cache block (%u bytes) is not a multiple of the "
139 decoder[tid] =
new TheISA::Decoder(
140 dynamic_cast<TheISA::ISA *
>(params.isa[tid]));
162 : statistics::
Group(cpu,
"fetch"),
163 ADD_STAT(icacheStallCycles, statistics::units::Cycle::get(),
164 "Number of cycles fetch is stalled on an Icache miss"),
165 ADD_STAT(insts, statistics::units::Count::get(),
166 "Number of instructions fetch has processed"),
167 ADD_STAT(branches, statistics::units::Count::get(),
168 "Number of branches that fetch encountered"),
169 ADD_STAT(predictedBranches, statistics::units::Count::get(),
170 "Number of branches that fetch has predicted taken"),
171 ADD_STAT(cycles, statistics::units::Cycle::get(),
172 "Number of cycles fetch has run and was not squashing or "
174 ADD_STAT(squashCycles, statistics::units::Cycle::get(),
175 "Number of cycles fetch has spent squashing"),
176 ADD_STAT(tlbCycles, statistics::units::Cycle::get(),
177 "Number of cycles fetch has spent waiting for tlb"),
178 ADD_STAT(idleCycles, statistics::units::Cycle::get(),
179 "Number of cycles fetch was idle"),
180 ADD_STAT(blockedCycles, statistics::units::Cycle::get(),
181 "Number of cycles fetch has spent blocked"),
182 ADD_STAT(miscStallCycles, statistics::units::Cycle::get(),
183 "Number of cycles fetch has spent waiting on interrupts, or bad "
184 "addresses, or out of MSHRs"),
185 ADD_STAT(pendingDrainCycles, statistics::units::Cycle::get(),
186 "Number of cycles fetch has spent waiting on pipes to drain"),
187 ADD_STAT(noActiveThreadStallCycles, statistics::units::Cycle::get(),
188 "Number of stall cycles due to no active thread to fetch from"),
189 ADD_STAT(pendingTrapStallCycles, statistics::units::Cycle::get(),
190 "Number of stall cycles due to pending traps"),
191 ADD_STAT(pendingQuiesceStallCycles, statistics::units::Cycle::get(),
192 "Number of stall cycles due to pending quiesce instructions"),
193 ADD_STAT(icacheWaitRetryStallCycles, statistics::units::Cycle::get(),
194 "Number of stall cycles due to full MSHR"),
195 ADD_STAT(cacheLines, statistics::units::Count::get(),
196 "Number of cache lines fetched"),
197 ADD_STAT(icacheSquashes, statistics::units::Count::get(),
198 "Number of outstanding Icache misses that were squashed"),
199 ADD_STAT(tlbSquashes, statistics::units::Count::get(),
200 "Number of outstanding ITLB misses that were squashed"),
201 ADD_STAT(nisnDist, statistics::units::Count::get(),
202 "Number of instructions fetched each cycle (Total)"),
203 ADD_STAT(idleRate, statistics::units::Ratio::get(),
204 "Ratio of cycles fetch was idle",
205 idleCycles / cpu->baseStats.numCycles),
206 ADD_STAT(branchRate, statistics::units::Ratio::get(),
207 "Number of branch fetches per cycle",
208 branches / cpu->baseStats.numCycles),
209 ADD_STAT(rate, statistics::units::Rate<
210 statistics::units::Count, statistics::units::Cycle>::get(),
211 "Number of inst fetches per cycle",
212 insts / cpu->baseStats.numCycles)
356 DPRINTF(
Fetch,
"[tid:%i] Waking up from cache miss.\n", tid);
375 DPRINTF(Activity,
"[tid:%i] Activating fetch due to cache completion\n",
387 pkt->
req->setAccessLatency();
462 assert(!
stalls[tid].drain);
463 DPRINTF(Drain,
"%i: Thread drained.\n", tid);
480 DPRINTF(Activity,
"Activating stage.\n");
492 DPRINTF(Activity,
"Deactivating stage.\n");
518 if (!inst->isControl()) {
519 inst->staticInst->advancePC(nextPC);
520 inst->setPredTarg(nextPC);
521 inst->setPredTaken(
false);
531 "predicted to be taken to %s\n",
532 tid, inst->seqNum, inst->pcState().instAddr(), nextPC);
535 "predicted to be not taken\n",
536 tid, inst->seqNum, inst->pcState().instAddr());
540 "predicted to go to %s\n",
541 tid, inst->seqNum, inst->pcState().instAddr(), nextPC);
542 inst->setPredTarg(nextPC);
543 inst->setPredTaken(predict_taken);
551 return predict_taken;
564 DPRINTF(
Fetch,
"[tid:%i] Can't fetch cache line, cache blocked\n",
572 DPRINTF(
Fetch,
"[tid:%i] Can't fetch cache line, interrupt pending\n",
580 DPRINTF(
Fetch,
"[tid:%i] Fetching cache line %#x for addr %#x\n",
581 tid, fetchBufferBlockPC,
vaddr);
586 RequestPtr mem_req = std::make_shared<Request>(
607 Addr fetchBufferBlockPC = mem_req->getVaddr();
615 mem_req->getVaddr() !=
memReq[tid]->getVaddr()) {
616 DPRINTF(
Fetch,
"[tid:%i] Ignoring itlb completed after squash\n",
629 warn(
"Address %#x is outside of physical memory, stopping fetch\n",
630 mem_req->getPaddr());
658 DPRINTF(Activity,
"[tid:%i] Activity: Waiting on I-cache "
678 "[tid:%i] Got back req with addr %#x but expected %#x\n",
679 tid, mem_req->getVaddr(),
memReq[tid]->getVaddr());
688 DPRINTF(
Fetch,
"[tid:%i] Translation faulted, building noop.\n", tid);
691 fetchPC, fetchPC,
false);
692 instruction->setNotAnInst();
694 instruction->setPredTarg(fetchPC);
695 instruction->fault = fault;
698 DPRINTF(Activity,
"Activity this cycle.\n");
703 DPRINTF(
Fetch,
"[tid:%i] Blocked, need to handle the trap.\n", tid);
704 DPRINTF(
Fetch,
"[tid:%i] fault (%s) detected @ PC %s.\n",
705 tid, fault->
name(),
pc[tid]);
714 DPRINTF(
Fetch,
"[tid:%i] Squashing, setting PC to: %s.\n",
719 if (squashInst && squashInst->pcState().instAddr() == newPC.instAddr())
720 macroop[tid] = squashInst->macroop;
727 DPRINTF(
Fetch,
"[tid:%i] Squashing outstanding Icache miss.\n",
731 DPRINTF(
Fetch,
"[tid:%i] Squashing outstanding ITLB miss.\n",
765 DPRINTF(
Fetch,
"[tid:%i] Squashing from decode.\n", tid);
777 bool ret_val =
false;
795 while (threads != end) {
803 DPRINTF(Activity,
"[tid:%i] Activating stage.\n",tid);
806 DPRINTF(Activity,
"[tid:%i] Activating fetch due to cache"
819 DPRINTF(Activity,
"Deactivating stage.\n");
844 bool status_change =
false;
852 while (threads != end) {
858 status_change = status_change || updated_status;
864 if (
fromCommit->commitInfo[0].interruptPending) {
868 if (
fromCommit->commitInfo[0].clearInterrupt) {
876 fetch(status_change);
896 unsigned insts_to_decode = 0;
897 unsigned available_insts = 0;
900 if (!
stalls[tid].decode) {
907 std::advance(tid_itr,
910 while (available_insts != 0 && insts_to_decode <
decodeWidth) {
915 DPRINTF(
Fetch,
"[tid:%i] [sn:%llu] Sending instruction to decode "
916 "from fetch queue. Fetch queue size: %i.\n",
933 DPRINTF(Activity,
"Activity this cycle.\n");
950 assert(
stalls[tid].decode);
958 DPRINTF(
Fetch,
"[tid:%i] Squashing instructions due to squash "
959 "from commit.\n",tid);
968 if (
fromCommit->commitInfo[tid].mispredictInst &&
969 fromCommit->commitInfo[tid].mispredictInst->isControl()) {
980 }
else if (
fromCommit->commitInfo[tid].doneSeqNum) {
988 DPRINTF(
Fetch,
"[tid:%i] Squashing instructions due to squash "
989 "from decode.\n",tid);
992 if (
fromDecode->decodeInfo[tid].branchMispredict) {
1032 DPRINTF(
Fetch,
"[tid:%i] Done squashing, switching to running.\n",
1055 new DynInst(staticInst, curMacroop, thisPC, nextPC, seq,
cpu);
1056 instruction->setTid(tid);
1058 instruction->setThreadState(
cpu->
thread[tid]);
1060 DPRINTF(
Fetch,
"[tid:%i] Instruction PC %#x (%d) created "
1061 "[sn:%lli].\n", tid, thisPC.instAddr(),
1062 thisPC.microPC(), seq);
1065 instruction->staticInst->
1066 disassemble(thisPC.instAddr()));
1070 instruction->traceData =
1072 instruction->staticInst, thisPC, curMacroop);
1075 instruction->traceData = NULL;
1079 instruction->setInstListIt(
cpu->
addInst(instruction));
1086 DPRINTF(
Fetch,
"[tid:%i] Fetch queue entry created (%i/%i).\n",
1117 DPRINTF(
Fetch,
"Attempting to fetch from [tid:%i]\n", tid);
1123 Addr fetchAddr = (thisPC.instAddr() + pcOffset) &
decoder[tid]->pcMask();
1131 DPRINTF(
Fetch,
"[tid:%i] Icache miss is complete.\n", tid);
1134 status_change =
true;
1145 DPRINTF(
Fetch,
"[tid:%i] Attempting to translate and read "
1146 "instruction, starting at PC %s.\n", tid, thisPC);
1186 DPRINTF(
Fetch,
"[tid:%i] Adding instructions to queue to "
1191 bool predictedBranch =
false;
1200 const Addr pc_mask = dec_ptr->pcMask();
1206 && !predictedBranch && !
quiesce) {
1210 bool needMem = !inRom && !curMacroop && !dec_ptr->instReady();
1211 fetchAddr = (thisPC.instAddr() + pcOffset) & pc_mask;
1221 if (blkOffset >= numInsts) {
1227 memcpy(dec_ptr->moreBytesPtr(),
1229 decoder[tid]->moreBytes(thisPC, fetchAddr);
1231 if (dec_ptr->needMoreBytes()) {
1241 if (!(curMacroop || inRom)) {
1242 if (dec_ptr->instReady()) {
1243 staticInst = dec_ptr->decode(thisPC);
1249 curMacroop = staticInst;
1262 bool newMacro =
false;
1263 if (curMacroop || inRom) {
1265 staticInst = dec_ptr->fetchRomMicroop(
1266 thisPC.microPC(), curMacroop);
1268 staticInst = curMacroop->
fetchMicroop(thisPC.microPC());
1274 buildInst(tid, staticInst, curMacroop, thisPC, nextPC,
true);
1280 if (debug::O3PipeView) {
1281 instruction->fetchTick =
curTick();
1289 predictedBranch |= thisPC.branching();
1292 if (predictedBranch) {
1293 DPRINTF(
Fetch,
"Branch detected with PC = %s\n", thisPC);
1296 newMacro |= thisPC.instAddr() != nextPC.instAddr();
1303 fetchAddr = thisPC.instAddr() & pc_mask;
1309 if (instruction->isQuiesce()) {
1311 "Quiesce instruction encountered, halting fetch!\n");
1313 status_change =
true;
1317 }
while ((curMacroop || dec_ptr->instReady()) &&
1326 if (predictedBranch) {
1327 DPRINTF(
Fetch,
"[tid:%i] Done fetching, predicted branch "
1328 "instruction encountered.\n", tid);
1330 DPRINTF(
Fetch,
"[tid:%i] Done fetching, reached fetch bandwidth "
1331 "for this cycle.\n", tid);
1333 DPRINTF(
Fetch,
"[tid:%i] Done fetching, reached the end of the"
1334 "fetch buffer.\n", tid);
1348 fetchAddr = (thisPC.instAddr() + pcOffset) & pc_mask;
1393 case SMTFetchPolicy::RoundRobin:
1395 case SMTFetchPolicy::IQCount:
1397 case SMTFetchPolicy::LSQCount:
1399 case SMTFetchPolicy::Branch:
1431 while (pri_iter != end) {
1432 high_pri = *pri_iter;
1456 std::priority_queue<unsigned, std::vector<unsigned>,
1457 std::greater<unsigned> > PQ;
1458 std::map<unsigned, ThreadID> threadMap;
1463 while (threads != end) {
1473 while (!PQ.empty()) {
1474 ThreadID high_pri = threadMap[PQ.top()];
1492 std::priority_queue<unsigned, std::vector<unsigned>,
1493 std::greater<unsigned> > PQ;
1494 std::map<unsigned, ThreadID> threadMap;
1499 while (threads != end) {
1501 unsigned ldstqCount =
fromIEW->iewInfo[tid].ldstqCount;
1505 PQ.push(ldstqCount);
1506 threadMap[ldstqCount] = tid;
1509 while (!PQ.empty()) {
1510 ThreadID high_pri = threadMap[PQ.top()];
1526 panic(
"Branch Count Fetch policy unimplemented\n");
1545 Addr fetchAddr = (thisPC.instAddr() + pcOffset) &
decoder[tid]->pcMask();
1552 DPRINTF(
Fetch,
"[tid:%i] Issuing a pipelined I-cache access, "
1553 "starting at PC %s.\n", tid, thisPC);
1562 DPRINTF(
Fetch,
"There are no more threads available to fetch from.\n");
1580 DPRINTF(
Fetch,
"[tid:%i] Fetch is waiting cache response!\n",
1584 DPRINTF(
Fetch,
"[tid:%i] Fetch is waiting ITLB walk to "
1588 DPRINTF(
Fetch,
"[tid:%i] Fetch is waiting for a pending trap!\n",
1592 DPRINTF(
Fetch,
"[tid:%i] Fetch is waiting for a pending quiesce "
1593 "instruction!\n", tid);
1596 DPRINTF(
Fetch,
"[tid:%i] Fetch is waiting for an I-cache retry!\n",
1599 DPRINTF(
Fetch,
"[tid:%i] Fetch predicted non-executable address\n",
1602 DPRINTF(
Fetch,
"[tid:%i] Unexpected fetch stall reason "
1611 DPRINTF(O3CPU,
"Fetch unit received timing\n");
1613 assert(pkt->
req->isUncacheable() ||
1615 fetch->processCacheCompletion(pkt);
1623 fetch->recvReqRetry();
Tick curTick()
The universal simulation clock.
#define fatal(...)
This implements a cprintf based fatal() function.
statistics::Scalar pendingQuiesceStallCycles
Total number of stall cycles caused by pending quiesce instructions.
FetchStatus
Overall fetch status.
void update(const InstSeqNum &done_sn, ThreadID tid)
Tells the branch predictor to commit any updates until the given sequence number.
ThreadID numFetchingThreads
Number of threads that are actively fetching.
FetchStatus _status
Fetch status.
bool fetchCacheLine(Addr vaddr, ThreadID tid, Addr pc)
Fetches the cache line that contains the fetch PC.
void switchToInactive()
Changes the status of this stage to inactive, and indicates this to the CPU.
void notify(const Arg &arg)
called at the ProbePoint call site, passes arg to each listener.
constexpr decltype(nullptr) NoFault
bool switchedOut() const
Determine if the CPU is switched out.
statistics::Scalar insts
Stat for total number of fetched instructions.
bool sendTimingReq(PacketPtr pkt)
Attempt to send a timing request to the responder port by calling its corresponding receive function.
void removeInstsUntil(const InstSeqNum &seq_num, ThreadID tid)
Remove all instructions younger than the given sequence number.
statistics::Scalar blockedCycles
Total number of cycles spent blocked.
uint8_t * fetchBuffer[MaxThreads]
The fetch data that is being fetched and buffered.
statistics::Scalar pendingDrainCycles
Total number of cycles spent in waiting for drains.
statistics::Scalar miscStallCycles
Total number of cycles spent in any other state.
void profileStall(ThreadID tid)
Profile the reasons of fetch stall.
bool lookupAndUpdateNextPC(const DynInstPtr &inst, TheISA::PCState &pc)
Looks up in the branch predictor to see if the next PC should be either next PC+=MachInst or a branch...
void pipelineIcacheAccesses(ThreadID tid)
Pipeline the next I-cache access to the current one.
static bool isRomMicroPC(MicroPC upc)
virtual void recvReqRetry()
Handles doing a retry of a failed fetch.
RequestPtr req
A pointer to the original request.
branch_prediction::BPredUnit * branchPred
BPredUnit.
void drainStall(ThreadID tid)
Stall the fetch stage after reaching a safe drain point.
bool checkInterrupt(Addr pc)
Check if an interrupt is pending and that we need to handle.
PacketPtr retryPkt
The packet that is waiting to be retried.
Cycles iewToFetchDelay
IEW to fetch delay.
void wakeFromQuiesce()
Tells fetch to wake up from a quiesce instruction.
std::string name() const
Returns the name of fetch.
void processCacheCompletion(PacketPtr pkt)
Processes cache completion event.
bool cacheResponding() const
InstSeqNum getAndIncrementInstSeq()
Get the current instruction sequence number, and increment it.
void setActiveThreads(std::list< ThreadID > *at_ptr)
Sets pointer to list of active threads.
void squashFromDecode(const TheISA::PCState &newPC, const DynInstPtr squashInst, const InstSeqNum seq_num, ThreadID tid)
Squashes a specific thread and resets the PC.
statistics::Distribution nisnDist
Distribution of number of instructions fetched each cycle.
Fetch(CPU *_cpu, const O3CPUParams ¶ms)
Fetch constructor.
bool delayedCommit[MaxThreads]
Can the fetch stage redirect from an interrupt on this instruction?
statistics::Scalar cacheLines
Stat for total number of fetched cache lines.
void schedule(Event &event, Tick when)
unsigned fetchWidth
The width of fetch in instructions.
void clearStates(ThreadID tid)
Clear all thread-specific states.
Fetch class handles both single threaded and SMT fetch.
void quiesce(ThreadContext *tc)
int numInst
Tracks how many instructions has been fetched this cycle.
ThreadID retryTid
The thread that is waiting on the cache to tell fetch to retry.
bool isDrained() const
Has the stage drained?
StaticInstPtr macroop[MaxThreads]
ThreadID getFetchingThread()
Returns the appropriate thread to fetch, given the fetch policy.
void sample(const U &v, int n=1)
Add a value to the distribtion n times.
gem5::o3::Fetch::FetchStatGroup fetchStats
statistics::Scalar idleCycles
Stat for total number of cycles spent blocked due to other stages in the pipeline.
ProbePointArg< PacketPtr > * ppInstAccessComplete
statistics::Scalar pendingTrapStallCycles
Total number of stall cycles caused by pending traps.
ProbePointArg< RequestPtr > * ppFetchRequestSent
To probe when a fetch request is successfully sent.
A RequestPort is a specialisation of a Port, which implements the default protocol for the three diff...
void setFault(Fault _fault)
statistics::Scalar tlbCycles
Stat for total number of cycles spent waiting for translation.
virtual StaticInstPtr fetchMicroop(MicroPC upc) const
Return the microop that goes with a particular micropc.
Cycles is a wrapper class for representing cycle counts, i.e.
void deactivateStage(const StageIdx idx)
Changes a stage's status to inactive within the activity recorder.
statistics::Scalar icacheStallCycles
Stat for total number of cycles stalled due to an icache miss.
const FlagsType pdf
Print the percent of the total that this entry represents.
void drainSanityCheck() const
Perform sanity checks after a drain.
Counter lastIcacheStall[MaxThreads]
Icache stall statistics.
void drainResume()
Resume after a drain.
TimeBuffer< TimeStruct >::wire fromDecode
Wire to get decode's information from backwards time buffer.
unsigned fetchBufferSize
The size of the fetch buffer in bytes.
statistics::Scalar tlbSquashes
Total number of outstanding tlb accesses that were dropped due to a squash.
TheISA::PCState pc[MaxThreads]
uint32_t taskId() const
Get cpu task id.
std::list< ThreadID > priorityList
List that has the threads organized by priority.
TimeBuffer< TimeStruct >::wire fromIEW
Wire to get iew's information from backwards time buffer.
Cycles commitToFetchDelay
Commit to fetch delay.
O3CPU class, has each of the stages (fetch through commit) within it, as well as all of the time buff...
void fetch(bool &status_change)
Does the actual fetching of instructions and passing them on to the next stage.
std::enable_if_t< std::is_integral< T >::value, T > random()
Use the SFINAE idiom to choose an implementation based on whether the type is integral or floating po...
Port & getInstPort() override
Used by the fetch unit to get a hold of the instruction port.
Distribution & init(Counter min, Counter max, Counter bkt)
Set the parameters of this distribution.
statistics::Scalar branches
Total number of fetched branches.
bool isMemAddr(Addr addr) const
Check if a physical address is within a range of a memory that is part of the global address map.
virtual std::string name() const
std::shared_ptr< FaultBase > Fault
bool checkStall(ThreadID tid) const
Checks if a thread is stalled.
FinishTranslationEvent finishTranslationEvent
Event used to delay fault generation of translation faults.
Stalls stalls[MaxThreads]
Tracks which stages are telling fetch to stall.
bool wroteToTimeBuffer
Variable that tracks if fetch has written to the time buffer this cycle.
void recvReqRetry()
Handles retrying the fetch access.
ThreadID roundRobin()
Returns the appropriate thread to fetch using a round robin policy.
Addr fetchBufferAlignPC(Addr addr)
Align a PC to the start of a fetch buffer block.
#define ADD_STAT(n,...)
Convenience macro to add a stat to a statistics group.
A Packet is used to encapsulate a transfer between two objects in the memory system (e....
ThreadID lsqCount()
Returns the appropriate thread to fetch using the LSQ count policy.
GenericISA::DelaySlotPCState< 4 > PCState
ProbePointArg< PacketInfo > Packet
Packet probe point.
void setTimeBuffer(TimeBuffer< TimeStruct > *time_buffer)
Sets the main backwards communication time buffer pointer.
RequestorID instRequestorId() const
Reads this CPU's unique instruction requestor ID.
std::shared_ptr< Request > RequestPtr
@ INST_FETCH
The request was an instruction fetch.
void setReq(const RequestPtr &_req)
const T * getConstPtr() const
void activateStage(const StageIdx idx)
Changes a stage's status to active within the activity recorder.
gem5::ThreadContext * tcBase(ThreadID tid)
Returns a pointer to a thread context.
bool fetchBufferValid[MaxThreads]
Whether or not the fetch buffer data is valid.
ThreadID threadFetched
Thread ID being fetched.
std::vector< ThreadState * > thread
Pointers to all of the threads in the CPU.
void deactivateThread(ThreadID tid)
For priority-based fetch policies, need to keep update priorityList.
void drainSanityCheck() const
Perform sanity checks after a drain.
const ThreadID InvalidThreadID
void wakeCPU()
Wakes the CPU, rescheduling the CPU if it's not already active.
CPU * cpu
Pointer to the O3CPU.
statistics::Scalar cycles
Stat for total number of cycles spent fetching.
bool isConnected() const
Is this port currently connected to a peer?
static constexpr int MaxWidth
statistics::Scalar squashCycles
Stat for total number of cycles spent squashing.
void switchToActive()
Changes the status of this stage to active, and indicates this to the CPU.
ThreadID contextToThread(ContextID cid)
Convert ContextID to threadID.
virtual InstRecord * getInstRecord(Tick when, ThreadContext *tc, const StaticInstPtr staticInst, TheISA::PCState pc, const StaticInstPtr macroStaticInst=NULL)=0
statistics::Formula rate
Number of instruction fetched per cycle.
int instSize
Size of instructions.
void squash(const InstSeqNum &squashed_sn, ThreadID tid)
Squashes all outstanding updates until a given sequence number.
TimeBuffer< TimeStruct > * timeBuffer
Time buffer interface.
std::deque< DynInstPtr > fetchQueue[MaxThreads]
Queue of fetched instructions.
void tick()
Ticks the fetch stage, processing all inputs signals and fetching as many instructions as possible.
bool interruptPending
Checks if there is an interrupt pending.
uint64_t Addr
Address type This will probably be moved somewhere else in the near future.
statistics::Scalar icacheSquashes
Total number of outstanding icache accesses that were dropped due to a squash.
statistics::Formula branchRate
Number of branch fetches per cycle.
const std::string & name()
bool isLastMicroop() const
void resetStage()
Reset this pipeline stage.
FetchStatus updateFetchStatus()
Updates overall fetch stage status; to be called at the end of each cycle.
void translateTiming(const RequestPtr &req, ThreadContext *tc, Translation *translation, Mode mode)
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...
bool cacheBlocked
Is the cache blocked? If so no threads can access it.
DynInstPtr buildInst(ThreadID tid, StaticInstPtr staticInst, StaticInstPtr curMacroop, TheISA::PCState thisPC, TheISA::PCState nextPC, bool trace)
void squash(const TheISA::PCState &newPC, const InstSeqNum seq_num, DynInstPtr squashInst, ThreadID tid)
Squashes a specific thread and resets the PC.
Cycles decodeToFetchDelay
Decode to fetch delay.
bool checkSignalsAndUpdate(ThreadID tid)
Checks all input signals and updates the status as necessary.
Trace::InstTracer * getTracer()
Provide access to the tracer pointer.
void startupStage()
Initialize stage.
ProbePointArg generates a point for the class of Arg.
System * system
Pointer to the system.
bool FullSystem
The FullSystem variable can be used to determine the current mode of simulation.
ProbeManager * getProbeManager()
Get the probe manager for this object.
unsigned decodeWidth
The width of decode in instructions.
static constexpr int MaxThreads
ProbePointArg< DynInstPtr > * ppFetch
Probe points.
void activityThisCycle()
Records that there was time buffer activity this cycle.
void removeInstsNotInROB(ThreadID tid)
Remove all instructions that are not currently in the ROB.
TimeBuffer< FetchStruct >::wire toDecode
Wire used to write any information heading to decode.
ThreadID iqCount()
Returns the appropriate thread to fetch using the IQ count policy.
StaticInstPtr nopStaticInstPtr
Pointer to a statically allocated generic "nop" instruction object.
Derived & prereq(const Stat &prereq)
Set the prerequisite stat and marks this stat to print at the end of simulation.
statistics::Scalar noActiveThreadStallCycles
Total number of stall cycles caused by no active threads to run.
bool issuePipelinedIfetch[MaxThreads]
Set to true if a pipelined I-cache request should be issued.
SMTFetchPolicy fetchPolicy
Fetch policy.
TimeBuffer< TimeStruct >::wire fromRename
Wire to get rename's information from backwards time buffer.
void takeOverFrom()
Takes over from another CPU's thread.
void doSquash(const TheISA::PCState &newPC, const DynInstPtr squashInst, ThreadID tid)
Squashes a specific thread and resets the PC.
ListIt addInst(const DynInstPtr &inst)
Function to add instruction onto the head of the list of the instructions.
void dataDynamic(T *p)
Set the data pointer to a value that should have delete [] called on it.
std::list< ThreadID > * activeThreads
List of Active Threads.
Addr fetchBufferPC[MaxThreads]
The PC of the first instruction loaded into the fetch buffer.
bool isDraining() const
Is the CPU draining?
TimeBuffer< TimeStruct >::wire fromCommit
Wire to get commit's information from backwards time buffer.
void finishTranslation(const Fault &fault, const RequestPtr &mem_req)
Addr fetchBufferMask
Mask to align a fetch address to a fetch buffer boundary.
IcachePort(Fetch *_fetch, CPU *_cpu)
Default constructor.
statistics::Scalar icacheWaitRetryStallCycles
Total number of stall cycles caused by I-cache wait retrys.
void regProbePoints()
Registers probes.
IcachePort icachePort
Instruction port.
Derived & flags(Flags _flags)
Set the flags and marks this stat to print at the end of simulation.
void setFetchQueue(TimeBuffer< FetchStruct > *fq_ptr)
Sets pointer to time buffer used to communicate to the next stage.
unsigned fetchQueueSize
The size of the fetch queue in micro-ops.
void pcState(const TheISA::PCState &newPCState, ThreadID tid)
Sets the commit PC state of a specific thread.
Reference material can be found at the JEDEC website: UFS standard http://www.jedec....
ThreadID branchCount()
Returns the appropriate thread to fetch using the branch count policy.
const FlagsType total
Print the total.
Addr fetchOffset[MaxThreads]
statistics::Formula idleRate
Rate of how often fetch was idle.
statistics::Scalar predictedBranches
Stat for total number of predicted branches.
RequestPtr memReq[MaxThreads]
Memory request used to access cache.
ThreadID numThreads
Number of threads.
unsigned int cacheBlkSize
Cache block size.
FetchStatGroup(CPU *cpu, Fetch *fetch)
ThreadStatus fetchStatus[MaxThreads]
Per-thread status.
Cycles renameToFetchDelay
Rename to fetch delay.
bool predict(const StaticInstPtr &inst, const InstSeqNum &seqNum, TheISA::PCState &pc, ThreadID tid)
Predicts whether or not the instruction is a taken branch, and the target of the branch if it is take...
TheISA::Decoder * decoder[MaxThreads]
The decoder.
bool scheduled() const
Determine if the current event is scheduled.
int16_t ThreadID
Thread index/ID type.
#define panic(...)
This implements a cprintf based panic() function.
virtual bool recvTimingResp(PacketPtr pkt)
Timing version of receive.
Generated on Tue Sep 7 2021 14:53:44 for gem5 by doxygen 1.8.17