58#include "debug/Activity.hh" 
   59#include "debug/Drain.hh" 
   60#include "debug/Fetch.hh" 
   61#include "debug/O3CPU.hh" 
   62#include "debug/O3PipeView.hh" 
   64#include "params/BaseO3CPU.hh" 
  104        fatal(
"numThreads (%d) is larger than compiled limit (%d),\n" 
  105              "\tincrease MaxThreads in src/cpu/o3/limits.hh\n",
 
  108        fatal(
"fetchWidth (%d) is larger than compiled limit (%d),\n" 
  109             "\tincrease MaxWidth in src/cpu/o3/limits.hh\n",
 
  112        fatal(
"fetch buffer size (%u bytes) is greater than the cache " 
  115        fatal(
"cache block (%u bytes) is not a multiple of the " 
  121        pc[
i].reset(params.isa[0]->newPCState());
 
  137        decoder[tid] = params.decoder[tid];
 
 
  161             "Number of branches that fetch has predicted taken"),
 
  163             "Number of cycles fetch has run and was not squashing or " 
  166             "Number of cycles fetch has spent squashing"),
 
  168             "Number of cycles fetch has spent waiting for tlb"),
 
  170             "Number of cycles fetch was idle"),
 
  172             "Number of cycles fetch has spent blocked"),
 
  174             "Number of cycles fetch has spent waiting on interrupts, or bad " 
  175             "addresses, or out of MSHRs"),
 
  177             "Number of cycles fetch has spent waiting on pipes to drain"),
 
  179             "Number of stall cycles due to no active thread to fetch from"),
 
  181             "Number of stall cycles due to pending traps"),
 
  183             "Number of stall cycles due to pending quiesce instructions"),
 
  185             "Number of stall cycles due to full MSHR"),
 
  187             "Number of cache lines fetched"),
 
  189             "Number of outstanding Icache misses that were squashed"),
 
  191             "Number of outstanding ITLB misses that were squashed"),
 
  193             "Number of instructions fetched each cycle (Total)"),
 
  195             "Ratio of cycles fetch was idle",
 
 
  281    stalls[tid].decode = 
false;
 
  282    stalls[tid].drain = 
false;
 
  291    for (
int i = -
cpu->fetchQueue.getPast();
 
 
  317        stalls[tid].decode = 
false;
 
  318        stalls[tid].drain = 
false;
 
 
  337    DPRINTF(
Fetch, 
"[tid:%i] Waking up from cache miss.\n", tid);
 
  338    assert(!
cpu->switchedOut());
 
  356    DPRINTF(Activity, 
"[tid:%i] Activating fetch due to cache completion\n",
 
  368    pkt->
req->setAccessLatency();
 
  369    cpu->ppInstAccessComplete->notify(pkt);
 
 
  434    assert(
cpu->getInstPort().isConnected());
 
 
  442    assert(
cpu->isDraining());
 
  443    assert(!
stalls[tid].drain);
 
  444    DPRINTF(Drain, 
"%i: Thread drained.\n", tid);
 
 
  461        DPRINTF(Activity, 
"Activating stage.\n");
 
 
  473        DPRINTF(Activity, 
"Deactivating stage.\n");
 
 
  499    if (!inst->isControl()) {
 
  500        inst->staticInst->advancePC(next_pc);
 
  501        inst->setPredTarg(next_pc);
 
  502        inst->setPredTaken(
false);
 
  507    predict_taken = 
branchPred->predict(inst->staticInst, inst->seqNum,
 
  512                "predicted to be taken to %s\n",
 
  513                tid, inst->seqNum, inst->pcState().instAddr(), next_pc);
 
  516                "predicted to be not taken\n",
 
  517                tid, inst->seqNum, inst->pcState().instAddr());
 
  521            "predicted to go to %s\n",
 
  522            tid, inst->seqNum, inst->pcState().instAddr(), next_pc);
 
  523    inst->setPredTarg(next_pc);
 
  524    inst->setPredTaken(predict_taken);
 
  526    cpu->fetchStats[tid]->numBranches++;
 
  532    return predict_taken;
 
 
  540    assert(!
cpu->switchedOut());
 
  545        DPRINTF(
Fetch, 
"[tid:%i] Can't fetch cache line, cache blocked\n",
 
  553        DPRINTF(
Fetch, 
"[tid:%i] Can't fetch cache line, interrupt pending\n",
 
  561    DPRINTF(
Fetch, 
"[tid:%i] Fetching cache line %#x for addr %#x\n",
 
  562            tid, fetchBufferBlockPC, 
vaddr);
 
  567    RequestPtr mem_req = std::make_shared<Request>(
 
  570        cpu->thread[tid]->contextId());
 
  572    mem_req->taskId(
cpu->taskId());
 
  579    cpu->mmu->translateTiming(mem_req, 
cpu->thread[tid]->getTC(),
 
 
  587    ThreadID tid = 
cpu->contextToThread(mem_req->contextId());
 
  588    Addr fetchBufferBlockPC = mem_req->getVaddr();
 
  590    assert(!
cpu->switchedOut());
 
  596        mem_req->getVaddr() != 
memReq[tid]->getVaddr()) {
 
  597        DPRINTF(
Fetch, 
"[tid:%i] Ignoring itlb completed after squash\n",
 
  609        if (!
cpu->system->isMemAddr(mem_req->getPaddr())) {
 
  610            warn(
"Address %#x is outside of physical memory, stopping fetch\n",
 
  611                    mem_req->getPaddr());
 
  639            DPRINTF(Activity, 
"[tid:%i] Activity: Waiting on I-cache " 
  659                "[tid:%i] Got back req with addr %#x but expected %#x\n",
 
  660                tid, mem_req->getVaddr(), 
memReq[tid]->getVaddr());
 
  669        DPRINTF(
Fetch, 
"[tid:%i] Translation faulted, building noop.\n", tid);
 
  672                fetch_pc, fetch_pc, 
false);
 
  673        instruction->setNotAnInst();
 
  675        instruction->setPredTarg(fetch_pc);
 
  676        instruction->fault = fault;
 
  679        DPRINTF(Activity, 
"Activity this cycle.\n");
 
  680        cpu->activityThisCycle();
 
  684        DPRINTF(
Fetch, 
"[tid:%i] Blocked, need to handle the trap.\n", tid);
 
  685        DPRINTF(
Fetch, 
"[tid:%i] fault (%s) detected @ PC %s.\n",
 
  686                tid, fault->name(), *
pc[tid]);
 
 
  695    DPRINTF(
Fetch, 
"[tid:%i] Squashing, setting PC to: %s.\n",
 
  698    set(
pc[tid], new_pc);
 
  700    if (squashInst && squashInst->pcState().instAddr() == new_pc.
instAddr() &&
 
  701        !squashInst->isLastMicroop())
 
  702        macroop[tid] = squashInst->macroop;
 
  709        DPRINTF(
Fetch, 
"[tid:%i] Squashing outstanding Icache miss.\n",
 
  713        DPRINTF(
Fetch, 
"[tid:%i] Squashing outstanding ITLB miss.\n",
 
 
  747    DPRINTF(
Fetch, 
"[tid:%i] Squashing from decode.\n", tid);
 
  753    cpu->removeInstsUntil(seq_num, tid);
 
 
  759    bool ret_val = 
false;
 
  762        assert(
cpu->isDraining());
 
 
  780                DPRINTF(Activity, 
"[tid:%i] Activating stage.\n",tid);
 
  783                    DPRINTF(Activity, 
"[tid:%i] Activating fetch due to cache" 
  796        DPRINTF(Activity, 
"Deactivating stage.\n");
 
 
  813    cpu->removeInstsNotInROB(tid);
 
 
  819    bool status_change = 
false;
 
  831        status_change =  status_change || updated_status;
 
  837        if (
fromCommit->commitInfo[0].interruptPending) {
 
  841        if (
fromCommit->commitInfo[0].clearInterrupt) {
 
  849        fetch(status_change);
 
  869    unsigned insts_to_decode = 0;
 
  870    unsigned available_insts = 0;
 
  873        if (!
stalls[tid].decode) {
 
  880    std::advance(tid_itr,
 
  883    while (available_insts != 0 && insts_to_decode < 
decodeWidth) {
 
  888            DPRINTF(
Fetch, 
"[tid:%i] [sn:%llu] Sending instruction to decode " 
  889                    "from fetch queue. Fetch queue size: %i.\n",
 
  906        DPRINTF(Activity, 
"Activity this cycle.\n");
 
  907        cpu->activityThisCycle();
 
 
  919        stalls[tid].decode = 
true;
 
  923        assert(
stalls[tid].decode);
 
  925        stalls[tid].decode = 
false;
 
  931        DPRINTF(
Fetch, 
"[tid:%i] Squashing instructions due to squash " 
  932                "from commit.\n",tid);
 
  941        if (
fromCommit->commitInfo[tid].mispredictInst &&
 
  942            fromCommit->commitInfo[tid].mispredictInst->isControl()) {
 
  945                    fromCommit->commitInfo[tid].branchTaken, tid);
 
  952    } 
else if (
fromCommit->commitInfo[tid].doneSeqNum) {
 
  960        DPRINTF(
Fetch, 
"[tid:%i] Squashing instructions due to squash " 
  961                "from decode.\n",tid);
 
  964        if (
fromDecode->decodeInfo[tid].branchMispredict) {
 
  967                    fromDecode->decodeInfo[tid].branchTaken, tid);
 
 1003        DPRINTF(
Fetch, 
"[tid:%i] Done squashing, switching to running.\n",
 
 
 1030            arrays, staticInst, curMacroop, this_pc, next_pc, seq, 
cpu);
 
 1031    instruction->setTid(tid);
 
 1033    instruction->setThreadState(
cpu->thread[tid]);
 
 1035    DPRINTF(
Fetch, 
"[tid:%i] Instruction PC %s created [sn:%lli].\n",
 
 1039            instruction->staticInst->disassemble(this_pc.
instAddr()));
 
 1043        instruction->traceData =
 
 1044            cpu->getTracer()->getInstRecord(
curTick(), 
cpu->tcBase(tid),
 
 1045                    instruction->staticInst, this_pc, curMacroop);
 
 1048    instruction->traceData = NULL;
 
 1052    instruction->setInstListIt(
cpu->addInst(instruction));
 
 1059    DPRINTF(
Fetch, 
"[tid:%i] Fetch queue entry created (%i/%i).\n",
 
 
 1077    assert(!
cpu->switchedOut());
 
 1090    DPRINTF(
Fetch, 
"Attempting to fetch from [tid:%i]\n", tid);
 
 1104        DPRINTF(
Fetch, 
"[tid:%i] Icache miss is complete.\n", tid);
 
 1107        status_change = 
true;
 
 1118            DPRINTF(
Fetch, 
"[tid:%i] Attempting to translate and read " 
 1119                    "instruction, starting at PC %s.\n", tid, this_pc);
 
 1124                cpu->fetchStats[tid]->icacheStallCycles++;
 
 1152    std::unique_ptr<PCStateBase> next_pc(this_pc.
clone());
 
 1161    DPRINTF(
Fetch, 
"[tid:%i] Adding instructions to queue to " 
 1166    bool predictedBranch = 
false;
 
 1169    bool quiesce = 
false;
 
 1175    const Addr pc_mask = dec_ptr->pcMask();
 
 1181           && !predictedBranch && !quiesce) {
 
 1185        bool needMem = !inRom && !curMacroop && !dec_ptr->instReady();
 
 1186        fetchAddr = (this_pc.
instAddr() + pcOffset) & pc_mask;
 
 1196            if (blkOffset >= numInsts) {
 
 1202            memcpy(dec_ptr->moreBytesPtr(),
 
 1204            decoder[tid]->moreBytes(this_pc, fetchAddr);
 
 1206            if (dec_ptr->needMoreBytes()) {
 
 1216            if (!(curMacroop || inRom)) {
 
 1217                if (dec_ptr->instReady()) {
 
 1218                    staticInst = dec_ptr->decode(this_pc);
 
 1221                    cpu->fetchStats[tid]->numInsts++;
 
 1224                        curMacroop = staticInst;
 
 1237            bool newMacro = 
false;
 
 1238            if (curMacroop || inRom) {
 
 1240                    staticInst = dec_ptr->fetchRomMicroop(
 
 1241                            this_pc.
microPC(), curMacroop);
 
 1249                    tid, staticInst, curMacroop, this_pc, *next_pc, 
true);
 
 1255            if (debug::O3PipeView) {
 
 1256                instruction->fetchTick = 
curTick();
 
 1260            set(next_pc, this_pc);
 
 1266            if (predictedBranch) {
 
 1267                DPRINTF(
Fetch, 
"Branch detected with PC = %s\n", this_pc);
 
 1270            newMacro |= this_pc.
instAddr() != next_pc->instAddr();
 
 1273            set(this_pc, *next_pc);
 
 1277                fetchAddr = this_pc.
instAddr() & pc_mask;
 
 1283            if (instruction->isQuiesce()) {
 
 1285                        "Quiesce instruction encountered, halting fetch!\n");
 
 1287                status_change = 
true;
 
 1291        } 
while ((curMacroop || dec_ptr->instReady()) &&
 
 1300    if (predictedBranch) {
 
 1301        DPRINTF(
Fetch, 
"[tid:%i] Done fetching, predicted branch " 
 1302                "instruction encountered.\n", tid);
 
 1304        DPRINTF(
Fetch, 
"[tid:%i] Done fetching, reached fetch bandwidth " 
 1305                "for this cycle.\n", tid);
 
 1307        DPRINTF(
Fetch, 
"[tid:%i] Done fetching, reached the end of the" 
 1308                "fetch buffer.\n", tid);
 
 1320    fetchAddr = (this_pc.
instAddr() + pcOffset) & pc_mask;
 
 
 1365          case SMTFetchPolicy::RoundRobin:
 
 1367          case SMTFetchPolicy::IQCount:
 
 1369          case SMTFetchPolicy::LSQCount:
 
 1371          case SMTFetchPolicy::Branch:
 
 
 1403    while (pri_iter != end) {
 
 1404        high_pri = *pri_iter;
 
 
 1428    std::priority_queue<unsigned, std::vector<unsigned>,
 
 1429                        std::greater<unsigned> > PQ;
 
 1430    std::map<unsigned, ThreadID> threadMap;
 
 1441    while (!PQ.empty()) {
 
 1442        ThreadID high_pri = threadMap[PQ.top()];
 
 
 1460    std::priority_queue<unsigned, std::vector<unsigned>,
 
 1461                        std::greater<unsigned> > PQ;
 
 1462    std::map<unsigned, ThreadID> threadMap;
 
 1465        unsigned ldstqCount = 
fromIEW->iewInfo[tid].ldstqCount;
 
 1469        PQ.push(ldstqCount);
 
 1470        threadMap[ldstqCount] = tid;
 
 1473    while (!PQ.empty()) {
 
 1474        ThreadID high_pri = threadMap[PQ.top()];
 
 
 1490    panic(
"Branch Count Fetch policy unimplemented\n");
 
 
 1516        DPRINTF(
Fetch, 
"[tid:%i] Issuing a pipelined I-cache access, " 
 1517                "starting at PC %s.\n", tid, this_pc);
 
 
 1526    DPRINTF(
Fetch,
"There are no more threads available to fetch from.\n");
 
 1543        cpu->fetchStats[tid]->icacheStallCycles++;
 
 1544        DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting cache response!\n",
 
 1548        DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting ITLB walk to " 
 1552        DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting for a pending trap!\n",
 
 1556        DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting for a pending quiesce " 
 1557                "instruction!\n", tid);
 
 1560        DPRINTF(
Fetch, 
"[tid:%i] Fetch is waiting for an I-cache retry!\n",
 
 1563            DPRINTF(
Fetch, 
"[tid:%i] Fetch predicted non-executable address\n",
 
 1566        DPRINTF(
Fetch, 
"[tid:%i] Unexpected fetch stall reason " 
 
 1575    DPRINTF(O3CPU, 
"Fetch unit received timing\n");
 
 1577    assert(pkt->
req->isUncacheable() ||
 
 1579    fetch->processCacheCompletion(pkt);
 
 
 1587    fetch->recvReqRetry();
 
 
Defines global host-dependent types: Counter, Tick, and (indirectly) {int,uint}{8,...
Cycles is a wrapper class for representing cycle counts, i.e.
virtual bool branching() const =0
MicroPC microPC() const
Returns the current micropc.
Addr instAddr() const
Returns the memory address of the instruction this PC points to.
virtual PCStateBase * clone() const =0
A Packet is used to encapsulate a transfer between two objects in the memory system (e....
RequestPtr req
A pointer to the original request.
const T * getConstPtr() const
void dataDynamic(T *p)
Set the data pointer to a value that should have delete [] called on it.
bool cacheResponding() const
ProbePointArg generates a point for the class of Arg.
RequestPort(const std::string &name, SimObject *_owner, PortID id=InvalidPortID)
Request port.
@ INST_FETCH
The request was an instruction fetch.
uint8_t numSrcRegs() const
Number of source registers.
virtual StaticInstPtr fetchMicroop(MicroPC upc) const
Return the microop that goes with a particular micropc.
uint8_t numDestRegs() const
Number of destination registers.
bool isLastMicroop() const
O3CPU class, has each of the stages (fetch through commit) within it, as well as all of the time buff...
Fetch * fetch
Pointer to fetch.
virtual bool recvTimingResp(PacketPtr pkt)
Timing version of receive.
IcachePort(Fetch *_fetch, CPU *_cpu)
Default constructor.
virtual void recvReqRetry()
Handles doing a retry of a failed fetch.
gem5::o3::Fetch::FetchStatGroup fetchStats
bool wroteToTimeBuffer
Variable that tracks if fetch has written to the time buffer this cycle.
void deactivateThread(ThreadID tid)
For priority-based fetch policies, need to keep update priorityList.
FetchStatus
Overall fetch status.
std::list< ThreadID > * activeThreads
List of Active Threads.
TimeBuffer< TimeStruct >::wire fromCommit
Wire to get commit's information from backwards time buffer.
Cycles renameToFetchDelay
Rename to fetch delay.
StaticInstPtr macroop[MaxThreads]
void fetch(bool &status_change)
Does the actual fetching of instructions and passing them on to the next stage.
void takeOverFrom()
Takes over from another CPU's thread.
uint8_t * fetchBuffer[MaxThreads]
The fetch data that is being fetched and buffered.
void doSquash(const PCStateBase &new_pc, const DynInstPtr squashInst, ThreadID tid)
Squashes a specific thread and resets the PC.
TimeBuffer< FetchStruct >::wire toDecode
Wire used to write any information heading to decode.
void setActiveThreads(std::list< ThreadID > *at_ptr)
Sets pointer to list of active threads.
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...
ThreadStatus fetchStatus[MaxThreads]
Per-thread status.
ThreadID numThreads
Number of threads.
TimeBuffer< TimeStruct >::wire fromDecode
Wire to get decode's information from backwards time buffer.
ProbePointArg< DynInstPtr > * ppFetch
Probe points.
TimeBuffer< TimeStruct >::wire fromRename
Wire to get rename's information from backwards time buffer.
void squash(const PCStateBase &new_pc, const InstSeqNum seq_num, DynInstPtr squashInst, ThreadID tid)
Squashes a specific thread and resets the PC.
void squashFromDecode(const PCStateBase &new_pc, const DynInstPtr squashInst, const InstSeqNum seq_num, ThreadID tid)
Squashes a specific thread and resets the PC.
FetchStatus updateFetchStatus()
Updates overall fetch stage status; to be called at the end of each cycle.
ThreadID getFetchingThread()
Returns the appropriate thread to fetch, given the fetch policy.
bool fetchBufferValid[MaxThreads]
Whether or not the fetch buffer data is valid.
void startupStage()
Initialize stage.
void pipelineIcacheAccesses(ThreadID tid)
Pipeline the next I-cache access to the current one.
std::string name() const
Returns the name of fetch.
void wakeFromQuiesce()
Tells fetch to wake up from a quiesce instruction.
void switchToActive()
Changes the status of this stage to active, and indicates this to the CPU.
void switchToInactive()
Changes the status of this stage to inactive, and indicates this to the CPU.
int numInst
Tracks how many instructions has been fetched this cycle.
bool fetchCacheLine(Addr vaddr, ThreadID tid, Addr pc)
Fetches the cache line that contains the fetch PC.
Cycles decodeToFetchDelay
Decode to fetch delay.
bool issuePipelinedIfetch[MaxThreads]
Set to true if a pipelined I-cache request should be issued.
Addr fetchBufferAlignPC(Addr addr)
Align a PC to the start of a fetch buffer block.
FetchStatus _status
Fetch status.
bool delayedCommit[MaxThreads]
Can the fetch stage redirect from an interrupt on this instruction?
ThreadID threadFetched
Thread ID being fetched.
SMTFetchPolicy fetchPolicy
Fetch policy.
Addr cacheBlkSize
Cache block size.
branch_prediction::BPredUnit * branchPred
BPredUnit.
void drainSanityCheck() const
Perform sanity checks after a drain.
unsigned fetchWidth
The width of fetch in instructions.
unsigned fetchQueueSize
The size of the fetch queue in micro-ops.
InstDecoder * decoder[MaxThreads]
The decoder.
TimeBuffer< TimeStruct >::wire fromIEW
Wire to get iew's information from backwards time buffer.
void regProbePoints()
Registers probes.
bool checkSignalsAndUpdate(ThreadID tid)
Checks all input signals and updates the status as necessary.
bool checkStall(ThreadID tid) const
Checks if a thread is stalled.
IcachePort icachePort
Instruction port.
void setTimeBuffer(TimeBuffer< TimeStruct > *time_buffer)
Sets the main backwards communication time buffer pointer.
void processCacheCompletion(PacketPtr pkt)
Processes cache completion event.
ThreadID iqCount()
Returns the appropriate thread to fetch using the IQ count policy.
Addr fetchBufferMask
Mask to align a fetch address to a fetch buffer boundary.
void recvReqRetry()
Handles retrying the fetch access.
bool checkInterrupt(Addr pc)
Check if an interrupt is pending and that we need to handle.
Cycles iewToFetchDelay
IEW to fetch delay.
void resetStage()
Reset this pipeline stage.
Fetch(CPU *_cpu, const BaseO3CPUParams ¶ms)
Fetch constructor.
void drainStall(ThreadID tid)
Stall the fetch stage after reaching a safe drain point.
Counter lastIcacheStall[MaxThreads]
Icache stall statistics.
int instSize
Size of instructions.
ProbePointArg< RequestPtr > * ppFetchRequestSent
To probe when a fetch request is successfully sent.
Cycles commitToFetchDelay
Commit to fetch delay.
RequestPtr memReq[MaxThreads]
Memory request used to access cache.
TimeBuffer< TimeStruct > * timeBuffer
Time buffer interface.
void profileStall(ThreadID tid)
Profile the reasons of fetch stall.
ThreadID roundRobin()
Returns the appropriate thread to fetch using a round robin policy.
Addr fetchBufferPC[MaxThreads]
The PC of the first instruction loaded into the fetch buffer.
void drainResume()
Resume after a drain.
void clearStates(ThreadID tid)
Clear all thread-specific states.
void finishTranslation(const Fault &fault, const RequestPtr &mem_req)
bool interruptPending
Checks if there is an interrupt pending.
std::unique_ptr< PCStateBase > pc[MaxThreads]
ThreadID lsqCount()
Returns the appropriate thread to fetch using the LSQ count policy.
Stalls stalls[MaxThreads]
Tracks which stages are telling fetch to stall.
DynInstPtr buildInst(ThreadID tid, StaticInstPtr staticInst, StaticInstPtr curMacroop, const PCStateBase &this_pc, const PCStateBase &next_pc, bool trace)
bool isDrained() const
Has the stage drained?
Addr fetchOffset[MaxThreads]
std::deque< DynInstPtr > fetchQueue[MaxThreads]
Queue of fetched instructions.
PacketPtr retryPkt
The packet that is waiting to be retried.
std::list< ThreadID > priorityList
List that has the threads organized by priority.
FinishTranslationEvent finishTranslationEvent
Event used to delay fault generation of translation faults.
ThreadID retryTid
The thread that is waiting on the cache to tell fetch to retry.
void tick()
Ticks the fetch stage, processing all inputs signals and fetching as many instructions as possible.
ThreadID numFetchingThreads
Number of threads that are actively fetching.
unsigned fetchBufferSize
The size of the fetch buffer in bytes.
void setFetchQueue(TimeBuffer< FetchStruct > *fq_ptr)
Sets pointer to time buffer used to communicate to the next stage.
CPU * cpu
Pointer to the O3CPU.
unsigned decodeWidth
The width of decode in instructions.
bool cacheBlocked
Is the cache blocked?
ThreadID branchCount()
Returns the appropriate thread to fetch using the branch count policy.
#define ADD_STAT(n,...)
Convenience macro to add a stat to a statistics group.
#define panic(...)
This implements a cprintf based panic() function.
#define fatal(...)
This implements a cprintf based fatal() function.
static constexpr int MaxThreads
void removeCommThreadInsts(ThreadID tid, CommStruct &comm_struct)
Remove instructions belonging to given thread from the given comm struct's instruction array.
RefCountingPtr< DynInst > DynInstPtr
static constexpr int MaxWidth
const FlagsType pdf
Print the percent of the total that this entry represents.
Copyright (c) 2024 Arm Limited All rights reserved.
std::shared_ptr< FaultBase > Fault
int16_t ThreadID
Thread index/ID type.
std::shared_ptr< Request > RequestPtr
const ThreadID InvalidThreadID
Tick curTick()
The universal simulation clock.
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.
RefCountingPtr< StaticInst > StaticInstPtr
static bool isRomMicroPC(MicroPC upc)
StaticInstPtr nopStaticInstPtr
Pointer to a statically allocated generic "nop" instruction object.
constexpr decltype(nullptr) NoFault
Declaration of the Packet class.
Struct that defines the information passed from fetch to decode.
statistics::Scalar icacheSquashes
Total number of outstanding icache accesses that were dropped due to a squash.
statistics::Scalar pendingDrainCycles
Total number of cycles spent in waiting for drains.
statistics::Scalar cacheLines
Stat for total number of fetched cache lines.
statistics::Scalar blockedCycles
Total number of cycles spent blocked.
statistics::Scalar idleCycles
Stat for total number of cycles spent blocked due to other stages in the pipeline.
statistics::Scalar predictedBranches
Stat for total number of predicted branches.
statistics::Scalar noActiveThreadStallCycles
Total number of stall cycles caused by no active threads to run.
statistics::Scalar pendingQuiesceStallCycles
Total number of stall cycles caused by pending quiesce instructions.
statistics::Scalar icacheWaitRetryStallCycles
Total number of stall cycles caused by I-cache wait retrys.
statistics::Scalar pendingTrapStallCycles
Total number of stall cycles caused by pending traps.
statistics::Scalar cycles
Stat for total number of cycles spent fetching.
statistics::Scalar miscStallCycles
Total number of cycles spent in any other state.
statistics::Scalar tlbCycles
Stat for total number of cycles spent waiting for translation.
statistics::Scalar squashCycles
Stat for total number of cycles spent squashing.
FetchStatGroup(CPU *cpu, Fetch *fetch)
statistics::Formula idleRate
Rate of how often fetch was idle.
statistics::Scalar tlbSquashes
Total number of outstanding tlb accesses that were dropped due to a squash.
statistics::Distribution nisnDist
Distribution of number of instructions fetched each cycle.