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 " 
  123         pc[
i].reset(params.isa[0]->newPCState());
 
  139         decoder[tid] = params.decoder[tid];
 
  161     : statistics::
Group(cpu, 
"fetch"),
 
  162     ADD_STAT(icacheStallCycles, statistics::units::Cycle::get(),
 
  163              "Number of cycles fetch is stalled on an Icache miss"),
 
  164     ADD_STAT(insts, statistics::units::Count::get(),
 
  165              "Number of instructions fetch has processed"),
 
  166     ADD_STAT(branches, statistics::units::Count::get(),
 
  167              "Number of branches that fetch encountered"),
 
  168     ADD_STAT(predictedBranches, statistics::units::Count::get(),
 
  169              "Number of branches that fetch has predicted taken"),
 
  170     ADD_STAT(cycles, statistics::units::Cycle::get(),
 
  171              "Number of cycles fetch has run and was not squashing or " 
  173     ADD_STAT(squashCycles, statistics::units::Cycle::get(),
 
  174              "Number of cycles fetch has spent squashing"),
 
  175     ADD_STAT(tlbCycles, statistics::units::Cycle::get(),
 
  176              "Number of cycles fetch has spent waiting for tlb"),
 
  177     ADD_STAT(idleCycles, statistics::units::Cycle::get(),
 
  178              "Number of cycles fetch was idle"),
 
  179     ADD_STAT(blockedCycles, statistics::units::Cycle::get(),
 
  180              "Number of cycles fetch has spent blocked"),
 
  181     ADD_STAT(miscStallCycles, statistics::units::Cycle::get(),
 
  182              "Number of cycles fetch has spent waiting on interrupts, or bad " 
  183              "addresses, or out of MSHRs"),
 
  184     ADD_STAT(pendingDrainCycles, statistics::units::Cycle::get(),
 
  185              "Number of cycles fetch has spent waiting on pipes to drain"),
 
  186     ADD_STAT(noActiveThreadStallCycles, statistics::units::Cycle::get(),
 
  187              "Number of stall cycles due to no active thread to fetch from"),
 
  188     ADD_STAT(pendingTrapStallCycles, statistics::units::Cycle::get(),
 
  189              "Number of stall cycles due to pending traps"),
 
  190     ADD_STAT(pendingQuiesceStallCycles, statistics::units::Cycle::get(),
 
  191              "Number of stall cycles due to pending quiesce instructions"),
 
  192     ADD_STAT(icacheWaitRetryStallCycles, statistics::units::Cycle::get(),
 
  193              "Number of stall cycles due to full MSHR"),
 
  194     ADD_STAT(cacheLines, statistics::units::Count::get(),
 
  195              "Number of cache lines fetched"),
 
  196     ADD_STAT(icacheSquashes, statistics::units::Count::get(),
 
  197              "Number of outstanding Icache misses that were squashed"),
 
  198     ADD_STAT(tlbSquashes, statistics::units::Count::get(),
 
  199              "Number of outstanding ITLB misses that were squashed"),
 
  200     ADD_STAT(nisnDist, statistics::units::Count::get(),
 
  201              "Number of instructions fetched each cycle (Total)"),
 
  202     ADD_STAT(idleRate, statistics::units::Ratio::get(),
 
  203              "Ratio of cycles fetch was idle",
 
  204              idleCycles / cpu->baseStats.numCycles),
 
  205     ADD_STAT(branchRate, statistics::units::Ratio::get(),
 
  206              "Number of branch fetches per cycle",
 
  207              branches / cpu->baseStats.numCycles),
 
  208     ADD_STAT(rate, statistics::units::Rate<
 
  209                     statistics::units::Count, statistics::units::Cycle>::get(),
 
  210              "Number of inst fetches per cycle",
 
  211              insts / cpu->baseStats.numCycles)
 
  355     DPRINTF(
Fetch, 
"[tid:%i] Waking up from cache miss.\n", tid);
 
  356     assert(!
cpu->switchedOut());
 
  374     DPRINTF(Activity, 
"[tid:%i] Activating fetch due to cache completion\n",
 
  386     pkt->
req->setAccessLatency();
 
  461     assert(!
stalls[tid].drain);
 
  462     DPRINTF(Drain, 
"%i: Thread drained.\n", tid);
 
  479         DPRINTF(Activity, 
"Activating stage.\n");
 
  491         DPRINTF(Activity, 
"Deactivating stage.\n");
 
  517     if (!inst->isControl()) {
 
  518         inst->staticInst->advancePC(next_pc);
 
  519         inst->setPredTarg(next_pc);
 
  520         inst->setPredTaken(
false);
 
  530                 "predicted to be taken to %s\n",
 
  531                 tid, inst->seqNum, inst->pcState().instAddr(), next_pc);
 
  534                 "predicted to be not taken\n",
 
  535                 tid, inst->seqNum, inst->pcState().instAddr());
 
  539             "predicted to go to %s\n",
 
  540             tid, inst->seqNum, inst->pcState().instAddr(), next_pc);
 
  541     inst->setPredTarg(next_pc);
 
  542     inst->setPredTaken(predict_taken);
 
  550     return predict_taken;
 
  558     assert(!
cpu->switchedOut());
 
  563         DPRINTF(
Fetch, 
"[tid:%i] Can't fetch cache line, cache blocked\n",
 
  571         DPRINTF(
Fetch, 
"[tid:%i] Can't fetch cache line, interrupt pending\n",
 
  579     DPRINTF(
Fetch, 
"[tid:%i] Fetching cache line %#x for addr %#x\n",
 
  580             tid, fetchBufferBlockPC, 
vaddr);
 
  585     RequestPtr mem_req = std::make_shared<Request>(
 
  590     mem_req->taskId(
cpu->taskId());
 
  605     ThreadID tid = 
cpu->contextToThread(mem_req->contextId());
 
  606     Addr fetchBufferBlockPC = mem_req->getVaddr();
 
  608     assert(!
cpu->switchedOut());
 
  614         mem_req->getVaddr() != 
memReq[tid]->getVaddr()) {
 
  615         DPRINTF(
Fetch, 
"[tid:%i] Ignoring itlb completed after squash\n",
 
  628             warn(
"Address %#x is outside of physical memory, stopping fetch\n",
 
  629                     mem_req->getPaddr());
 
  657             DPRINTF(Activity, 
"[tid:%i] Activity: Waiting on I-cache " 
  677                 "[tid:%i] Got back req with addr %#x but expected %#x\n",
 
  678                 tid, mem_req->getVaddr(), 
memReq[tid]->getVaddr());
 
  687         DPRINTF(
Fetch, 
"[tid:%i] Translation faulted, building noop.\n", tid);
 
  690                 fetch_pc, fetch_pc, 
false);
 
  691         instruction->setNotAnInst();
 
  693         instruction->setPredTarg(fetch_pc);
 
  694         instruction->fault = fault;
 
  697         DPRINTF(Activity, 
"Activity this cycle.\n");
 
  702         DPRINTF(
Fetch, 
"[tid:%i] Blocked, need to handle the trap.\n", tid);
 
  703         DPRINTF(
Fetch, 
"[tid:%i] fault (%s) detected @ PC %s.\n",
 
  704                 tid, fault->
name(), *
pc[tid]);
 
  713     DPRINTF(
Fetch, 
"[tid:%i] Squashing, setting PC to: %s.\n",
 
  716     set(
pc[tid], new_pc);
 
  718     if (squashInst && squashInst->pcState().instAddr() == new_pc.
instAddr())
 
  719         macroop[tid] = squashInst->macroop;
 
  726         DPRINTF(
Fetch, 
"[tid:%i] Squashing outstanding Icache miss.\n",
 
  730         DPRINTF(
Fetch, 
"[tid:%i] Squashing outstanding ITLB miss.\n",
 
  764     DPRINTF(
Fetch, 
"[tid:%i] Squashing from decode.\n", tid);
 
  776     bool ret_val = 
false;
 
  794     while (threads != end) {
 
  802                 DPRINTF(Activity, 
"[tid:%i] Activating stage.\n",tid);
 
  805                     DPRINTF(Activity, 
"[tid:%i] Activating fetch due to cache" 
  818         DPRINTF(Activity, 
"Deactivating stage.\n");
 
  843     bool status_change = 
false;
 
  851     while (threads != end) {
 
  857         status_change =  status_change || updated_status;
 
  863         if (
fromCommit->commitInfo[0].interruptPending) {
 
  867         if (
fromCommit->commitInfo[0].clearInterrupt) {
 
  875         fetch(status_change);
 
  895     unsigned insts_to_decode = 0;
 
  896     unsigned available_insts = 0;
 
  899         if (!
stalls[tid].decode) {
 
  906     std::advance(tid_itr,
 
  909     while (available_insts != 0 && insts_to_decode < 
decodeWidth) {
 
  914             DPRINTF(
Fetch, 
"[tid:%i] [sn:%llu] Sending instruction to decode " 
  915                     "from fetch queue. Fetch queue size: %i.\n",
 
  932         DPRINTF(Activity, 
"Activity this cycle.\n");
 
  949         assert(
stalls[tid].decode);
 
  957         DPRINTF(
Fetch, 
"[tid:%i] Squashing instructions due to squash " 
  958                 "from commit.\n",tid);
 
  967         if (
fromCommit->commitInfo[tid].mispredictInst &&
 
  968             fromCommit->commitInfo[tid].mispredictInst->isControl()) {
 
  971                     fromCommit->commitInfo[tid].branchTaken, tid);
 
  978     } 
else if (
fromCommit->commitInfo[tid].doneSeqNum) {
 
  986         DPRINTF(
Fetch, 
"[tid:%i] Squashing instructions due to squash " 
  987                 "from decode.\n",tid);
 
  990         if (
fromDecode->decodeInfo[tid].branchMispredict) {
 
  993                     fromDecode->decodeInfo[tid].branchTaken, tid);
 
 1029         DPRINTF(
Fetch, 
"[tid:%i] Done squashing, switching to running.\n",
 
 1056             arrays, staticInst, curMacroop, this_pc, next_pc, seq, 
cpu);
 
 1057     instruction->setTid(tid);
 
 1059     instruction->setThreadState(
cpu->
thread[tid]);
 
 1061     DPRINTF(
Fetch, 
"[tid:%i] Instruction PC %s created [sn:%lli].\n",
 
 1065             instruction->staticInst->disassemble(this_pc.
instAddr()));
 
 1069         instruction->traceData =
 
 1071                     instruction->staticInst, this_pc, curMacroop);
 
 1074     instruction->traceData = NULL;
 
 1078     instruction->setInstListIt(
cpu->
addInst(instruction));
 
 1085     DPRINTF(
Fetch, 
"[tid:%i] Fetch queue entry created (%i/%i).\n",
 
 1103     assert(!
cpu->switchedOut());
 
 1116     DPRINTF(
Fetch, 
"Attempting to fetch from [tid:%i]\n", tid);
 
 1130         DPRINTF(
Fetch, 
"[tid:%i] Icache miss is complete.\n", tid);
 
 1133         status_change = 
true;
 
 1144             DPRINTF(
Fetch, 
"[tid:%i] Attempting to translate and read " 
 1145                     "instruction, starting at PC %s.\n", tid, this_pc);
 
 1177     std::unique_ptr<PCStateBase> next_pc(this_pc.
clone());
 
 1186     DPRINTF(
Fetch, 
"[tid:%i] Adding instructions to queue to " 
 1191     bool predictedBranch = 
false;
 
 1206            && !predictedBranch && !
quiesce) {
 
 1210         bool needMem = !inRom && !curMacroop && !dec_ptr->instReady();
 
 1211         fetchAddr = (this_pc.
instAddr() + pcOffset) & pc_mask;
 
 1221             if (blkOffset >= numInsts) {
 
 1227             memcpy(dec_ptr->moreBytesPtr(),
 
 1231             if (dec_ptr->needMoreBytes()) {
 
 1241             if (!(curMacroop || inRom)) {
 
 1242                 if (dec_ptr->instReady()) {
 
 1243                     staticInst = dec_ptr->decode(this_pc);
 
 1249                         curMacroop = staticInst;
 
 1262             bool newMacro = 
false;
 
 1263             if (curMacroop || inRom) {
 
 1265                     staticInst = dec_ptr->fetchRomMicroop(
 
 1266                             this_pc.
microPC(), curMacroop);
 
 1274                     tid, staticInst, curMacroop, this_pc, *next_pc, 
true);
 
 1280             if (debug::O3PipeView) {
 
 1281                 instruction->fetchTick = 
curTick();
 
 1285             set(next_pc, this_pc);
 
 1291             if (predictedBranch) {
 
 1292                 DPRINTF(
Fetch, 
"Branch detected with PC = %s\n", this_pc);
 
 1295             newMacro |= this_pc.
instAddr() != next_pc->instAddr();
 
 1298             set(this_pc, *next_pc);
 
 1302                 fetchAddr = this_pc.
instAddr() & pc_mask;
 
 1308             if (instruction->isQuiesce()) {
 
 1310                         "Quiesce instruction encountered, halting fetch!\n");
 
 1312                 status_change = 
true;
 
 1316         } 
while ((curMacroop || dec_ptr->instReady()) &&
 
 1325     if (predictedBranch) {
 
 1326         DPRINTF(
Fetch, 
"[tid:%i] Done fetching, predicted branch " 
 1327                 "instruction encountered.\n", tid);
 
 1329         DPRINTF(
Fetch, 
"[tid:%i] Done fetching, reached fetch bandwidth " 
 1330                 "for this cycle.\n", tid);
 
 1332         DPRINTF(
Fetch, 
"[tid:%i] Done fetching, reached the end of the" 
 1333                 "fetch buffer.\n", tid);
 
 1345     fetchAddr = (this_pc.
instAddr() + pcOffset) & pc_mask;
 
 1390           case SMTFetchPolicy::RoundRobin:
 
 1392           case SMTFetchPolicy::IQCount:
 
 1394           case SMTFetchPolicy::LSQCount:
 
 1396           case SMTFetchPolicy::Branch:
 
 1428     while (pri_iter != end) {
 
 1429         high_pri = *pri_iter;
 
 1453     std::priority_queue<unsigned, std::vector<unsigned>,
 
 1454                         std::greater<unsigned> > PQ;
 
 1455     std::map<unsigned, ThreadID> threadMap;
 
 1460     while (threads != end) {
 
 1470     while (!PQ.empty()) {
 
 1471         ThreadID high_pri = threadMap[PQ.top()];
 
 1489     std::priority_queue<unsigned, std::vector<unsigned>,
 
 1490                         std::greater<unsigned> > PQ;
 
 1491     std::map<unsigned, ThreadID> threadMap;
 
 1496     while (threads != end) {
 
 1498         unsigned ldstqCount = 
fromIEW->iewInfo[tid].ldstqCount;
 
 1502         PQ.push(ldstqCount);
 
 1503         threadMap[ldstqCount] = tid;
 
 1506     while (!PQ.empty()) {
 
 1507         ThreadID high_pri = threadMap[PQ.top()];
 
 1523     panic(
"Branch Count Fetch policy unimplemented\n");
 
 1549         DPRINTF(
Fetch, 
"[tid:%i] Issuing a pipelined I-cache access, " 
 1550                 "starting at PC %s.\n", tid, this_pc);
 
 1559     DPRINTF(
Fetch,
"There are no more threads available to fetch from.\n");
 
 1577         DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting cache response!\n",
 
 1581         DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting ITLB walk to " 
 1585         DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting for a pending trap!\n",
 
 1589         DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting for a pending quiesce " 
 1590                 "instruction!\n", tid);
 
 1593         DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting for an I-cache retry!\n",
 
 1596             DPRINTF(
Fetch, 
"[tid:%i] Fetch predicted non-executable address\n",
 
 1599         DPRINTF(
Fetch, 
"[tid:%i] Unexpected fetch stall reason " 
 1608     DPRINTF(O3CPU, 
"Fetch unit received timing\n");
 
 1610     assert(pkt->
req->isUncacheable() ||
 
 1612     fetch->processCacheCompletion(pkt);
 
 1620     fetch->recvReqRetry();
 
  
virtual void moreBytes(const PCStateBase &pc, Addr fetchPC)=0
Feed data to the decoder.
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.
bool lookupAndUpdateNextPC(const DynInstPtr &inst, PCStateBase &pc)
Looks up in the branch predictor to see if the next PC should be either next PC+=MachInst or a branch...
FetchStatus _status
Fetch status.
Addr instAddr() const
Returns the memory address of the instruction this PC points to.
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.
bool predict(const StaticInstPtr &inst, const InstSeqNum &seqNum, PCStateBase &pc, ThreadID tid)
Predicts whether or not the instruction is a taken branch, and the target of the branch if it is take...
void notify(const Arg &arg)
called at the ProbePoint call site, passes arg to each listener.
constexpr decltype(nullptr) NoFault
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.
std::unique_ptr< PCStateBase > pc[MaxThreads]
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.
@ INST_FETCH
The request was an instruction fetch.
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.
void squash(const PCStateBase &new_pc, const InstSeqNum seq_num, DynInstPtr squashInst, ThreadID tid)
Squashes a specific thread and resets the PC.
statistics::Scalar miscStallCycles
Total number of cycles spent in any other state.
void profileStall(ThreadID tid)
Profile the reasons of fetch stall.
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.
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.
int8_t numSrcRegs() const
Number of source registers.
MicroPC microPC() const
Returns the current micropc.
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
InstDecoder * decoder[MaxThreads]
The decoder.
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.
std::enable_if_t< std::is_integral_v< T >, T > random()
Use the SFINAE idiom to choose an implementation based on whether the type is integral or floating po...
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.
virtual bool branching() const =0
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.
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.
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.
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.
void squashFromDecode(const PCStateBase &new_pc, const DynInstPtr squashInst, const InstSeqNum seq_num, ThreadID tid)
Squashes a specific thread and resets the PC.
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.
ProbePointArg< PacketInfo > Packet
Packet probe point.
void pcState(const PCStateBase &new_pc_state, ThreadID tid)
Sets the commit PC state of a specific thread.
void setTimeBuffer(TimeBuffer< TimeStruct > *time_buffer)
Sets the main backwards communication time buffer pointer.
std::shared_ptr< Request > RequestPtr
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.
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.
virtual void translateTiming(const RequestPtr &req, ThreadContext *tc, Translation *translation, Mode mode)
bool cacheBlocked
Is the cache blocked? If so no threads can access it.
Cycles decodeToFetchDelay
Decode to fetch delay.
bool checkSignalsAndUpdate(ThreadID tid)
Checks all input signals and updates the status as necessary.
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.
size_t moreBytesSize() const
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.
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.
int8_t numDestRegs() const
Number of destination registers.
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.
DynInstPtr buildInst(ThreadID tid, StaticInstPtr staticInst, StaticInstPtr curMacroop, const PCStateBase &this_pc, const PCStateBase &next_pc, bool trace)
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.
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.
void doSquash(const PCStateBase &new_pc, const DynInstPtr squashInst, ThreadID tid)
Squashes a specific thread and resets the PC.
ThreadID numThreads
Number of threads.
unsigned int cacheBlkSize
Cache block size.
FetchStatGroup(CPU *cpu, Fetch *fetch)
ThreadStatus fetchStatus[MaxThreads]
Per-thread status.
virtual PCStateBase * clone() const =0
Cycles renameToFetchDelay
Rename to fetch delay.
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 Wed May 4 2022 12:13:53 for gem5 by  doxygen 1.8.17