Go to the documentation of this file.
   40 #include "arch/locked_mem.hh" 
   41 #include "arch/registers.hh" 
   42 #include "arch/utility.hh" 
   48 #include "debug/Activity.hh" 
   49 #include "debug/Branch.hh" 
   50 #include "debug/Drain.hh" 
   51 #include "debug/ExecFaulting.hh" 
   52 #include "debug/MinorExecute.hh" 
   53 #include "debug/MinorInterrupt.hh" 
   54 #include "debug/MinorMem.hh" 
   55 #include "debug/MinorTrace.hh" 
   56 #include "debug/PCEvent.hh" 
   63     const MinorCPUParams ¶ms,
 
   70     issueLimit(params.executeIssueLimit),
 
   71     memoryIssueLimit(params.executeMemoryIssueLimit),
 
   72     commitLimit(params.executeCommitLimit),
 
   73     memoryCommitLimit(params.executeMemoryCommitLimit),
 
   74     processMoreThanOneInput(params.executeCycleInput),
 
   75     fuDescriptions(*params.executeFuncUnits),
 
   76     numFuncUnits(fuDescriptions.funcUnits.size()),
 
   77     setTraceTimeOnCommit(params.executeSetTraceTimeOnCommit),
 
   78     setTraceTimeOnIssue(params.executeSetTraceTimeOnIssue),
 
   79     allowEarlyMemIssue(params.executeAllowEarlyMemoryIssue),
 
   80     noCostFUIndex(fuDescriptions.funcUnits.size() + 1),
 
   81     lsq(name_ + 
".lsq", name_ + 
".dcache_port",
 
   83         params.executeMaxAccessesInMemory,
 
   84         params.executeMemoryWidth,
 
   85         params.executeLSQRequestsQueueSize,
 
   86         params.executeLSQTransfersQueueSize,
 
   87         params.executeLSQStoreBufferSize,
 
   88         params.executeLSQMaxStoreBufferStoresPerCycle),
 
   95         fatal(
"%s: executeCommitLimit must be >= 1 (%d)\n", name_,
 
  100         fatal(
"%s: executeCommitLimit must be >= 1 (%d)\n", name_,
 
  105         fatal(
"%s: executeMemoryIssueLimit must be >= 1 (%d)\n", name_,
 
  110         fatal(
"%s: executeMemoryCommitLimit (%d) must be <=" 
  111             " executeCommitLimit (%d)\n",
 
  115     if (params.executeInputBufferSize < 1) {
 
  116         fatal(
"%s: executeInputBufferSize must be >= 1 (%d)\n", name_,
 
  117         params.executeInputBufferSize);
 
  120     if (params.executeInputBufferSize < 1) {
 
  121         fatal(
"%s: executeInputBufferSize must be >= 1 (%d)\n", name_,
 
  122         params.executeInputBufferSize);
 
  128     unsigned int total_slots = 0;
 
  132         std::ostringstream fu_name;
 
  138         total_slots += fu_description->
opLat;
 
  140         fu_name << name_ << 
".fu." << 
i;
 
  148     for (
int op_class = No_OpClass + 1; op_class < 
Num_OpClasses; op_class++) {
 
  149         bool found_fu = 
false;
 
  150         unsigned int fu_index = 0;
 
  155                 static_cast<OpClass
>(op_class)))
 
  163             warn(
"No functional unit for OpClass %s\n",
 
  164                 Enums::OpClassStrings[op_class]);
 
  169     for (
ThreadID tid = 0; tid < params.numThreads; tid++) {
 
  175                 name_ + 
".inputBuffer" + tid_str, 
"insts",
 
  176                 params.executeInputBufferSize));
 
  184             name_ + 
".inFlightInsts" + tid_str, 
"insts", total_slots);
 
  188             name_ + 
".inFUMemInsts" + tid_str, 
"insts", total_slots);
 
  225         inst->isLastOpInInst() &&
 
  226         (inst->staticInst->isSerializeAfter() ||
 
  227          inst->staticInst->isSquashAfter());
 
  229     DPRINTF(Branch, 
"tryToBranch before: %s after: %s%s\n",
 
  230         pc_before, target, (force_branch ? 
" (forcing)" : 
""));
 
  233     bool must_branch = pc_before != target ||
 
  245         DPRINTF(Branch, 
"Advancing current PC from: %s to: %s\n",
 
  249     if (inst->predictedTaken && !force_branch) {
 
  254             DPRINTF(Branch, 
"Predicted a branch from 0x%x to 0x%x but" 
  255                 " none happened inst: %s\n",
 
  256                 inst->pc.instAddr(), inst->predictedTarget.instAddr(), *inst);
 
  259         } 
else if (inst->predictedTarget == target) {
 
  264             DPRINTF(Branch, 
"Predicted a branch from 0x%x to 0x%x correctly" 
  266                 inst->pc.instAddr(), inst->predictedTarget.instAddr(), *inst);
 
  271             DPRINTF(Branch, 
"Predicted a branch from 0x%x to 0x%x" 
  272                     " but got the wrong target (actual: 0x%x) inst: %s\n",
 
  273                     inst->pc.instAddr(), inst->predictedTarget.instAddr(),
 
  274                     target.instAddr(), *inst);
 
  278     } 
else if (must_branch) {
 
  280         DPRINTF(Branch, 
"Unpredicted branch from 0x%x to 0x%x inst: %s\n",
 
  281             inst->pc.instAddr(), target.instAddr(), *inst);
 
  310             (inst->isBubble() ? 
executeInfo[tid].lastPredictionSeqNum
 
  311                 : inst->id.predictionSeqNum),
 
  314         DPRINTF(Branch, 
"Branch data signalled: %s\n", branch);
 
  322     ThreadID thread_id = inst->id.threadId;
 
  329     bool is_load = inst->staticInst->isLoad();
 
  330     bool is_store = inst->staticInst->isStore();
 
  331     bool is_atomic = inst->staticInst->isAtomic();
 
  332     bool is_prefetch = inst->staticInst->isDataPrefetch();
 
  336     bool use_context_predicate = 
true;
 
  338     if (inst->translationFault != 
NoFault) {
 
  340         DPRINTF(MinorMem, 
"Completing fault from DTLB access: %s\n",
 
  341             inst->translationFault->name());
 
  343         if (inst->staticInst->isPrefetch()) {
 
  344             DPRINTF(MinorMem, 
"Not taking fault on prefetch: %s\n",
 
  345                 inst->translationFault->name());
 
  350             fault = inst->translationFault;
 
  352             fault->invoke(thread, inst->staticInst);
 
  354     } 
else if (!packet) {
 
  355         DPRINTF(MinorMem, 
"Completing failed request inst: %s\n",
 
  357         use_context_predicate = 
false;
 
  359             inst->staticInst->completeAcc(
nullptr, &context, inst->traceData);
 
  360     } 
else if (packet->
isError()) {
 
  361         DPRINTF(MinorMem, 
"Trying to commit error response: %s\n",
 
  364         fatal(
"Received error response packet for inst: %s\n", *inst);
 
  365     } 
else if (is_store || is_load || is_prefetch || is_atomic) {
 
  368         DPRINTF(MinorMem, 
"Memory response inst: %s addr: 0x%x size: %d\n",
 
  371         if (is_load && packet->
getSize() > 0) {
 
  372             DPRINTF(MinorMem, 
"Memory data[0]: 0x%x\n",
 
  373                 static_cast<unsigned int>(packet->
getConstPtr<uint8_t>()[0]));
 
  377         fault = inst->staticInst->completeAcc(packet, &context,
 
  382             DPRINTF(MinorMem, 
"Fault in memory completeAcc: %s\n",
 
  384             fault->invoke(thread, inst->staticInst);
 
  392         fatal(
"There should only ever be reads, " 
  393             "writes or faults at this point\n");
 
  398     if (inst->traceData) {
 
  399         inst->traceData->setPredicate((use_context_predicate ?
 
  418     DPRINTF(MinorInterrupt, 
"Considering interrupt status from PC: %s\n",
 
  430         DPRINTF(MinorInterrupt, 
"Invoking interrupt: %s to PC: %s\n",
 
  445     bool &passed_predicate, 
Fault &fault)
 
  450     passed_predicate = 
false;
 
  463         DPRINTF(MinorExecute, 
"Initiating memRef inst: %s\n", *inst);
 
  465         Fault init_fault = inst->staticInst->initiateAcc(&context,
 
  470                 assert(inst->translationFault != 
NoFault);
 
  476                 inst->translationFault = 
NoFault;
 
  481             DPRINTF(MinorExecute, 
"Fault on memory inst: %s" 
  482                 " initiateAcc: %s\n", *inst, init_fault->name());
 
  488                 DPRINTF(MinorMem, 
"No memory access for inst: %s\n", *inst);
 
  495                 inst->traceData->setPredicate(passed_predicate);
 
  521     unsigned int ret = 
index + 1;
 
  523     if (ret == cycle_size)
 
  536         ret = cycle_size - 1;
 
  552     unsigned int fu_index = 0;
 
  561     unsigned num_insts_issued = 0;
 
  564     unsigned num_mem_insts_issued = 0;
 
  568     unsigned num_insts_discarded = 0;
 
  572         Fault fault = inst->fault;
 
  573         bool discarded = 
false;
 
  574         bool issued_mem_ref = 
false;
 
  576         if (inst->isBubble()) {
 
  582             DPRINTF(MinorExecute, 
"Discarding inst: %s from suspended" 
  587         } 
else if (inst->id.streamSeqNum != thread.
streamSeqNum) {
 
  588             DPRINTF(MinorExecute, 
"Discarding inst: %s as its stream" 
  589                 " state was unexpected, expected: %d\n",
 
  606                 DPRINTF(MinorExecute, 
"Trying to issue inst: %s to FU: %d\n",
 
  613                 bool fu_is_capable = (!inst->isFault() ?
 
  614                     fu->provides(inst->staticInst->opClass()) : 
true);
 
  616                 if (inst->isNoCostInst()) {
 
  631                     inst->extraCommitDelay = 
Cycles(0);
 
  632                     inst->extraCommitDelayExpr = NULL;
 
  641                 } 
else if (!fu_is_capable || 
fu->alreadyPushed()) {
 
  643                     if (!fu_is_capable) {
 
  644                         DPRINTF(MinorExecute, 
"Can't issue as FU: %d isn't" 
  645                             " capable\n", fu_index);
 
  647                         DPRINTF(MinorExecute, 
"Can't issue as FU: %d is" 
  648                             " already busy\n", fu_index);
 
  650                 } 
else if (
fu->stalled) {
 
  651                     DPRINTF(MinorExecute, 
"Can't issue inst: %s into FU: %d," 
  654                 } 
else if (!
fu->canInsert()) {
 
  655                     DPRINTF(MinorExecute, 
"Can't issue inst: %s to busy FU" 
  656                         " for another: %d cycles\n",
 
  657                         *inst, 
fu->cyclesBeforeInsert());
 
  660                         fu->findTiming(inst->staticInst) : NULL);
 
  667                         &(
fu->cantForwardFromFUIndices);
 
  670                         DPRINTF(MinorExecute, 
"Can't issue inst: %s as extra" 
  671                             " decoding is suppressing it\n",
 
  673                     } 
else if (!
scoreboard[thread_id].canInstIssue(inst,
 
  674                         src_latencies, cant_forward_from_fu_indices,
 
  677                         DPRINTF(MinorExecute, 
"Can't issue inst: %s yet\n",
 
  681                         DPRINTF(MinorExecute, 
"Issuing inst: %s" 
  682                             " into FU %d\n", *inst,
 
  686                         TimingExpr *extra_dest_retire_lat_expr = NULL;
 
  692                             extra_dest_retire_lat =
 
  694                             extra_dest_retire_lat_expr =
 
  700                         issued_mem_ref = inst->isMemRef();
 
  705                         inst->fuIndex = fu_index;
 
  706                         inst->extraCommitDelay = extra_dest_retire_lat;
 
  707                         inst->extraCommitDelayExpr =
 
  708                             extra_dest_retire_lat_expr;
 
  710                         if (issued_mem_ref) {
 
  715                                 inst->instToWaitFor =
 
  716                                     scoreboard[thread_id].execSeqNumToWaitFor(inst,
 
  722                                     DPRINTF(MinorExecute, 
"A barrier will" 
  723                                         " cause a delay in mem ref issue of" 
  724                                         " inst: %s until after inst" 
  725                                         " %d(exec)\n", *inst,
 
  728                                     inst->instToWaitFor =
 
  731                                     DPRINTF(MinorExecute, 
"Memory ref inst:" 
  732                                         " %s must wait for inst %d(exec)" 
  734                                         *inst, inst->instToWaitFor);
 
  737                                 inst->canEarlyIssue = 
true;
 
  741                             DPRINTF(MinorExecute, 
"Pushing mem inst: %s\n",
 
  755                             fu->description.opLat +
 
  756                             extra_dest_retire_lat +
 
  759                             issued_mem_ref && extra_assumed_lat == 
Cycles(0));
 
  773                 DPRINTF(MinorExecute, 
"Didn't issue inst: %s\n", *inst);
 
  779             if (
DTRACE(MinorTrace) && !inst->isBubble())
 
  780                 inst->minorTraceInst(*
this);
 
  783             if (!discarded && inst->isInst() &&
 
  784                 inst->staticInst->isFullMemBarrier())
 
  786                 DPRINTF(MinorMem, 
"Issuing memory barrier inst: %s\n", *inst);
 
  791                 inst->traceData->setWhen(
curTick());
 
  795                 num_mem_insts_issued++;
 
  798                 num_insts_discarded++;
 
  799             } 
else if (!inst->isBubble()) {
 
  803                     DPRINTF(MinorExecute, 
"Reached inst issue limit\n");
 
  807             DPRINTF(MinorExecute, 
"Stepping to next inst inputIndex: %d\n",
 
  819                 DPRINTF(MinorExecute, 
"Wrapping\n");
 
  830     return num_insts_issued;
 
  837     unsigned int num_pc_event_checks = 0;
 
  843         cpu.
threads[thread_id]->pcEventQueue.service(oldPC, thread);
 
  844         num_pc_event_checks++;
 
  845     } 
while (oldPC != thread->
instAddr());
 
  847     if (num_pc_event_checks > 1) {
 
  852     return num_pc_event_checks > 1;
 
  858     assert(!inst->isFault());
 
  864     if (!inst->staticInst->isMicroop() || inst->staticInst->isLastMicroop())
 
  877                                [inst->staticInst->opClass()]++;
 
  881         inst->traceData->setCPSeq(thread->
numOp);
 
  889     bool &completed_mem_issue)
 
  891     ThreadID thread_id = inst->id.threadId;
 
  894     bool completed_inst = 
true;
 
  902         panic(
"We should never hit the case where we try to commit from a " 
  903               "suspended thread as the streamSeqNum should not match");
 
  904     } 
else if (inst->isFault()) {
 
  907         DPRINTF(MinorExecute, 
"Fault inst reached Execute: %s\n",
 
  908             inst->fault->name());
 
  911         inst->fault->invoke(thread, NULL);
 
  914     } 
else if (inst->staticInst->isMemRef()) {
 
  927         bool predicate_passed = 
false;
 
  929             predicate_passed, fault);
 
  931         if (completed_mem_inst && fault != 
NoFault) {
 
  932             if (early_memory_issue) {
 
  933                 DPRINTF(MinorExecute, 
"Fault in early executing inst: %s\n",
 
  937                 inst->canEarlyIssue = 
false;
 
  940                 completed_inst = 
false;
 
  942                 DPRINTF(MinorExecute, 
"Fault in execute: %s\n",
 
  944                 fault->invoke(thread, NULL);
 
  947                 completed_inst = 
true;
 
  950             completed_inst = completed_mem_inst;
 
  952         completed_mem_issue = completed_inst;
 
  953     } 
else if (inst->isInst() && inst->staticInst->isFullMemBarrier() &&
 
  956         DPRINTF(MinorExecute, 
"Can't commit data barrier inst: %s yet as" 
  957             " there isn't space in the store buffer\n", *inst);
 
  959         completed_inst = 
false;
 
  960     } 
else if (inst->isInst() && inst->staticInst->isQuiesce()
 
  964         completed_inst = 
false;
 
  968         DPRINTF(MinorExecute, 
"Committing inst: %s\n", *inst);
 
  970         fault = inst->staticInst->execute(&context,
 
  980             if (inst->traceData) {
 
  981                 if (
DTRACE(ExecFaulting)) {
 
  982                     inst->traceData->setFaulting(
true);
 
  984                     delete inst->traceData;
 
  985                     inst->traceData = NULL;
 
  989             DPRINTF(MinorExecute, 
"Fault in execute of inst: %s fault: %s\n",
 
  990                 *inst, fault->name());
 
  991             fault->invoke(thread, inst->staticInst);
 
  998     if (completed_inst) {
 
 1002         executeInfo[thread_id].lastPredictionSeqNum = inst->id.predictionSeqNum;
 
 1005         if (!inst->isFault() &&
 
 1013             assert(resume_pc.microPC() == 0);
 
 1015             DPRINTF(MinorInterrupt, 
"Suspending thread: %d from Execute" 
 1016                 " inst: %s\n", thread_id, *inst);
 
 1025     return completed_inst;
 
 1063     bool completed_inst = 
true;
 
 1066     unsigned int num_insts_committed = 0;
 
 1070     unsigned int num_mem_refs_committed = 0;
 
 1072     if (only_commit_microops && !ex_info.
inFlightInsts->empty()) {
 
 1073         DPRINTF(MinorInterrupt, 
"Only commit microops %s %d\n",
 
 1085         if (only_commit_microops) {
 
 1086             DPRINTF(MinorInterrupt, 
"Committing tail of insts before" 
 1094             head_inflight_inst->
inst->id.execSeqNum;
 
 1101         bool committed_inst = 
false;
 
 1102         bool discard_inst = 
false;
 
 1103         bool completed_mem_ref = 
false;
 
 1104         bool issued_mem_ref = 
false;
 
 1105         bool early_memory_issue = 
false;
 
 1108         completed_inst = 
false;
 
 1120         DPRINTF(MinorExecute, 
"Trying to commit canCommitInsts: %d\n",
 
 1130         } 
else if (mem_response &&
 
 1134             discard_inst = inst->id.streamSeqNum !=
 
 1137             DPRINTF(MinorExecute, 
"Trying to commit mem response: %s\n",
 
 1142                 DPRINTF(MinorExecute, 
"Discarding mem inst: %s as its" 
 1143                     " stream state was unexpected, expected: %d\n",
 
 1149                 committed_inst = 
true;
 
 1152             completed_mem_ref = 
true;
 
 1153             completed_inst = 
true;
 
 1154         } 
else if (can_commit_insts) {
 
 1159             bool try_to_commit = 
false;
 
 1171                 DPRINTF(MinorExecute, 
"Trying to commit from mem FUs\n");
 
 1180                 if (!fu_inst->isBubble() &&
 
 1182                     fu_inst->canEarlyIssue &&
 
 1184                     head_exec_seq_num > fu_inst->instToWaitFor)
 
 1186                     DPRINTF(MinorExecute, 
"Issuing mem ref early" 
 1187                         " inst: %s instToWaitFor: %d\n",
 
 1188                         *(fu_inst), fu_inst->instToWaitFor);
 
 1191                     try_to_commit = 
true;
 
 1192                     early_memory_issue = 
true;
 
 1193                     completed_inst = 
true;
 
 1198             if (!completed_inst && inst->isNoCostInst()) {
 
 1199                 DPRINTF(MinorExecute, 
"Committing no cost inst: %s", *inst);
 
 1201                 try_to_commit = 
true;
 
 1202                 completed_inst = 
true;
 
 1207             if (!completed_inst && !inst->inLSQ) {
 
 1208                 DPRINTF(MinorExecute, 
"Trying to commit from FUs\n");
 
 1217                 if (fu_inst.
inst->isBubble()) {
 
 1219                     completed_inst = 
false;
 
 1220                 } 
else if (fu_inst_seq_num != head_exec_seq_num) {
 
 1226                 } 
else if (fu_inst.
inst->id == inst->id)  {
 
 1230                     try_to_commit = 
true;
 
 1231                     completed_inst = 
true;
 
 1235             if (try_to_commit) {
 
 1236                 discard_inst = inst->id.streamSeqNum !=
 
 1241                 if (!discard_inst) {
 
 1247                     if (inst->extraCommitDelayExpr) {
 
 1248                         DPRINTF(MinorExecute, 
"Evaluating expression for" 
 1249                             " extra commit delay inst: %s\n", *inst);
 
 1256                         uint64_t extra_delay = inst->extraCommitDelayExpr->
 
 1259                         DPRINTF(MinorExecute, 
"Extra commit delay expr" 
 1260                             " result: %d\n", extra_delay);
 
 1262                         if (extra_delay < 128) {
 
 1263                             inst->extraCommitDelay += 
Cycles(extra_delay);
 
 1265                             DPRINTF(MinorExecute, 
"Extra commit delay was" 
 1266                                 " very long: %d\n", extra_delay);
 
 1268                         inst->extraCommitDelayExpr = NULL;
 
 1273                     if (inst->extraCommitDelay != 
Cycles(0)) {
 
 1275                             inst->extraCommitDelay;
 
 1276                         inst->extraCommitDelay = 
Cycles(0);
 
 1281                     if (!inst->isFault() && inst->isMemRef() &&
 
 1283                             inst->id.execSeqNum &&
 
 1286                         DPRINTF(MinorExecute, 
"Not committing inst: %s yet" 
 1287                             " as there are incomplete barriers in flight\n",
 
 1289                         completed_inst = 
false;
 
 1290                     } 
else if (inst->minimumCommitCycle > now) {
 
 1291                         DPRINTF(MinorExecute, 
"Not committing inst: %s yet" 
 1292                             " as it wants to be stalled for %d more cycles\n",
 
 1293                             *inst, inst->minimumCommitCycle - now);
 
 1294                         completed_inst = 
false;
 
 1297                             early_memory_issue, branch, fault,
 
 1298                             committed_inst, issued_mem_ref);
 
 1302                     completed_inst = 
true;
 
 1305                 if (completed_inst) {
 
 1311                         DPRINTF(MinorExecute, 
"Unstalling %d for inst %s\n", inst->fuIndex, inst->id);
 
 1312                         funcUnits[inst->fuIndex]->stalled = 
false;
 
 1317             DPRINTF(MinorExecute, 
"No instructions to commit\n");
 
 1318             completed_inst = 
false;
 
 1322         assert(!(discard_inst && !completed_inst));
 
 1327             DPRINTF(MinorExecute, 
"Discarding inst: %s as its stream" 
 1328                 " state was unexpected, expected: %d\n",
 
 1336         if (issued_mem_ref) {
 
 1343         if (completed_inst && inst->isMemRef()) {
 
 1353         if (completed_inst && !(issued_mem_ref && fault == 
NoFault)) {
 
 1355             DPRINTF(MinorExecute, 
"Completed inst: %s\n", *inst);
 
 1359                 inst->isLastOpInInst();
 
 1370             if (inst->isInst() && inst->staticInst->isFullMemBarrier()) {
 
 1371                 DPRINTF(MinorMem, 
"Completing memory barrier" 
 1372                     " inst: %s committed: %d\n", *inst, committed_inst);
 
 1376             scoreboard[thread_id].clearInstDests(inst, inst->isMemRef());
 
 1380         if (committed_inst) {
 
 1381             bool is_no_cost_inst = inst->isNoCostInst();
 
 1385             if (
DTRACE(MinorTrace) && !is_no_cost_inst)
 
 1388             if (!is_no_cost_inst)
 
 1389                 num_insts_committed++;
 
 1392                 DPRINTF(MinorExecute, 
"Reached inst commit limit\n");
 
 1396             if (inst->traceData) {
 
 1398                     inst->traceData->setWhen(
curTick());
 
 1399                 inst->traceData->dump();
 
 1402             if (completed_mem_ref)
 
 1403                 num_mem_refs_committed++;
 
 1406                 DPRINTF(MinorExecute, 
"Reached mem ref commit limit\n");
 
 1414     return executeInfo[thread_id].lastCommitWasEndOfMacroop &&
 
 1421     if (!
inp.outputWire->isBubble())
 
 1426     unsigned int num_issued = 0;
 
 1433     bool interrupted = 
false;
 
 1442         DPRINTF(MinorInterrupt, 
"Execute skipping a cycle to allow old" 
 1443             " branch to complete\n");
 
 1450             DPRINTF(MinorExecute, 
"Attempting to commit [tid:%d]\n",
 
 1457                     commit(commit_tid, 
true, 
false, branch);
 
 1468                     commit(commit_tid, 
false, 
true, branch);
 
 1473                 DPRINTF(MinorExecute, 
"Committing micro-ops for interrupt[tid:%d]\n",
 
 1475                 bool only_commit_microops = interrupted &&
 
 1477                 commit(commit_tid, only_commit_microops, 
false, branch);
 
 1494             DPRINTF(MinorExecute, 
"Attempting to issue [tid:%d]\n",
 
 1496             num_issued = 
issue(issue_tid);
 
 1504     bool can_issue_next = 
false;
 
 1510             unsigned int input_index = 
executeInfo[tid].inputIndex;
 
 1512             if (inst->isFault()) {
 
 1513                 can_issue_next = 
true;
 
 1514             } 
else if (!inst->isBubble()) {
 
 1515                 next_issuable_insts.push_back(inst);
 
 1520     bool becoming_stalled = 
true;
 
 1530         if (
fu->occupancy !=0 && !
fu->stalled)
 
 1531             becoming_stalled = 
false;
 
 1537         for (
auto inst : next_issuable_insts) {
 
 1538             if (!
fu->stalled && 
fu->provides(inst->staticInst->opClass()) &&
 
 1539                 scoreboard[inst->id.threadId].canInstIssue(inst,
 
 1542                 can_issue_next = 
true;
 
 1548     bool head_inst_might_commit = 
false;
 
 1552         if (!info.inFlightInsts->empty()) {
 
 1553             const QueuedInst &head_inst = info.inFlightInsts->front();
 
 1555             if (head_inst.
inst->isNoCostInst()) {
 
 1556                 head_inst_might_commit = 
true;
 
 1560                      fu->front().inst->id == head_inst.
inst->id) ||
 
 1563                     head_inst_might_commit = 
true;
 
 1570     DPRINTF(Activity, 
"Need to tick num issued insts: %s%s%s%s%s%s\n",
 
 1571        (num_issued != 0 ? 
" (issued some insts)" : 
""),
 
 1572        (becoming_stalled ? 
"(becoming stalled)" : 
"(not becoming stalled)"),
 
 1573        (can_issue_next ? 
" (can issued next inst)" : 
""),
 
 1574        (head_inst_might_commit ? 
"(head inst might commit)" : 
""),
 
 1576        (interrupted ? 
" (interrupted)" : 
""));
 
 1580        !becoming_stalled || 
 
 1582        head_inst_might_commit || 
 
 1586     if (!need_to_tick) {
 
 1587         DPRINTF(Activity, 
"The next cycle might be skippable as there are no" 
 1588             " advanceable FUs\n");
 
 1600     if (!
inp.outputWire->isBubble())
 
 1612         bool thread_interrupted = 
false;
 
 1619             interrupted = interrupted || thread_interrupted;
 
 1621             DPRINTF(MinorInterrupt, 
"No interrupt controller\n");
 
 1623         DPRINTF(MinorInterrupt, 
"[tid:%d] thread_interrupted?=%d isInbetweenInsts?=%d\n",
 
 1653     std::ostringstream insts;
 
 1654     std::ostringstream stalled;
 
 1656     executeInfo[0].instsBeingCommitted.reportData(insts);
 
 1665         stalled << (
funcUnits[
i]->stalled ? 
'1' : 
'E');
 
 1671     MINORTRACE(
"insts=%s inputIndex=%d streamSeqNum=%d" 
 1672         " stalled=%s drainState=%d isInbetweenInsts=%d\n",
 
 1689       case Enums::SingleThreaded:
 
 1691       case Enums::RoundRobin:
 
 1698           panic(
"Invalid thread policy");
 
 1701     for (
auto tid : priority_list) {
 
 1704         if (can_commit_insts) {
 
 1708             can_commit_insts = can_commit_insts &&
 
 1712                 bool can_transfer_mem_inst = 
false;
 
 1718                     can_transfer_mem_inst =
 
 1719                         !fu_inst->isBubble() &&
 
 1720                          fu_inst->id.threadId == tid &&
 
 1722                          fu_inst->canEarlyIssue &&
 
 1723                          inst->id.execSeqNum > fu_inst->instToWaitFor;
 
 1727                 if (can_commit_insts && !can_transfer_mem_inst &&
 
 1731                     can_execute_fu_inst = !fu_inst.
inst->isBubble() &&
 
 1732                         fu_inst.
inst->id == inst->id;
 
 1735                 can_commit_insts = can_commit_insts &&
 
 1736                     (can_transfer_mem_inst || can_execute_fu_inst);
 
 1741         if (can_commit_insts) {
 
 1756       case Enums::SingleThreaded:
 
 1758       case Enums::RoundRobin:
 
 1765           panic(
"Invalid thread scheduling policy.");
 
 1768     for (
auto tid : priority_list) {
 
 1781     DPRINTF(Drain, 
"MinorExecute drainResume\n");
 
 1795           os << 
"NotDraining";
 
 1798           os << 
"DrainCurrentInst";
 
 1801           os << 
"DrainHaltFetch";
 
 1804           os << 
"DrainAllInsts";
 
 1807           os << 
"Drain-" << 
static_cast<int>(state);
 
 1817     DPRINTF(Drain, 
"setDrainState[%d]: %s\n", thread_id, state);
 
 1824     DPRINTF(Drain, 
"MinorExecute drain\n");
 
 1872     return inst->id.streamSeqNum == 
executeInfo[inst->id.threadId].streamSeqNum;
 
 1880     if (!
executeInfo[inst->id.threadId].inFlightInsts->empty())
 
 1881         ret = 
executeInfo[inst->id.threadId].inFlightInsts->front().inst->id == inst->id;
 
  
Queue< QueuedInst, ReportTraitsAdaptor< QueuedInst > > * inFUMemInsts
Memory ref instructions still in the FUs.
const ThreadID InvalidThreadID
static const OpClass Num_OpClasses
Stats::Scalar numInsts
Stat for number instructions committed.
MinorCPU::MinorCPUPort & getDcachePort()
Return the raw-bindable port.
#define fatal(...)
This implements a cprintf based fatal() function.
std::vector< InputBuffer< ForwardInstData > > inputBuffer
std::vector< Cycles > srcRegsRelativeLats
Cycle offsets from the scoreboard delivery times of register values for each of this instruction's so...
bool isInterrupted(ThreadID thread_id) const
Has an interrupt been raised.
void popResponse(LSQRequestPtr response)
Sanity check and pop the head response.
Latch< BranchData >::Input out
Input port carrying stream changes to Fetch1.
void wakeupOnEvent(unsigned int stage_id)
Interface for stages to signal that they have become active after a callback or eventq event where th...
Forward flowing data between Fetch2,Decode,Execute carrying a packet of instructions of a width appro...
bool tryPCEvents(ThreadID thread_id)
Try to act on PC-related events.
void minorTrace() const
Report buffer states from 'slot' 'from' to 'to'.
Object to gather the visible context for evaluation.
Extra timing capability to allow individual ops to have their source register dependency latencies tw...
bool lastCommitWasEndOfMacroop
The last commit was the end of a full instruction so an interrupt can safely happen.
bool isStreamChange() const
As static isStreamChange but on this branch data.
void pushFailedRequest(MinorDynInstPtr inst)
Push a predicate failed-representing request into the queues just to maintain commit order.
bool processMoreThanOneInput
If true, more than one input line can be processed each cycle if there is room to execute more instru...
int16_t ThreadID
Thread index/ID type.
ThreadID checkInterrupts(BranchData &branch, bool &interrupted)
Check all threads for possible interrupts.
Minor::MinorActivityRecorder * activityRecorder
Activity recording for pipeline.
MinorFUPool & fuDescriptions
Descriptions of the functional units we want to generate.
const std::string to_string(sc_enc enc)
LSQ lsq
Dcache port to pass on to the CPU.
bool hasInterrupt(ThreadID thread_id)
Checks if a specific thread has an interrupt.
bool instIsRightStream(MinorDynInstPtr inst)
Does the given instruction have the right stream sequence number to be committed?
bool accessesInFlight() const
Are there any accesses other than normal cached loads in the memory system or having received respons...
bool isInbetweenInsts(ThreadID thread_id) const
Are we between instructions? Can we be interrupted?
Enums::ThreadPolicy threadPolicy
Thread Scheduling Policy (RoundRobin, Random, etc)
void step()
Step checks the queues to see if their are issuable transfers which were not otherwise picked up by t...
#define MINORTRACE(...)
DPRINTFN for MinorTrace reporting.
Minor::MinorStats stats
Processor-specific statistics.
std::vector< MinorFU * > funcUnits
bool FullSystem
The FullSystem variable can be used to determine the current mode of simulation.
bool suppress
If true, instructions matching this mask/match should not be issued in this FU.
virtual ThreadContext * getContext(int tn)
Given a thread num get tho thread context for it.
ThreadID interruptPriority
InstSeqNum streamSeqNum
Source of sequence number for instuction streams.
std::vector< Scoreboard > scoreboard
Scoreboard of instruction dependencies.
static bool isStreamChange(const BranchData::Reason reason)
Is a request with this reason actually a request to change the PC rather than a bubble or branch pred...
bool executeMemRefInst(MinorDynInstPtr inst, BranchData &branch, bool &failed_predicate, Fault &fault)
Execute a memory reference instruction.
@ BadlyPredictedBranchTarget
unsigned int cyclicIndexDec(unsigned int index, unsigned int cycle_size)
Decrement a cyclic buffer index for indices [0, cycle_size-1].
void advancePC(PCState &pc, const StaticInstPtr &inst)
bool isDrained()
After thread suspension, has Execute been drained of in-flight instructions and memory accesses.
bool commitInst(MinorDynInstPtr inst, bool early_memory_issue, BranchData &branch, Fault &fault, bool &committed, bool &completed_mem_issue)
Commit a single instruction.
@ CorrectlyPredictedBranch
Latch< ForwardInstData >::Output inp
Input port carrying instructions from Decode.
Cycles opLat
Delay from issuing the operation, to it reaching the end of the associated pipeline.
unsigned int inputIndex
Index that we've completed upto in getInput data.
The SimpleThread object provides a combination of the ThreadState object and the ThreadContext interf...
std::vector< Minor::MinorThread * > threads
These are thread state-representing objects for this CPU.
std::vector< ExecuteThreadInfo > executeInfo
bool canRequest()
Is their space in the request queue to be able to push a request by issuing an isMemRef instruction.
...ReportTraits are trait classes with the same functionality as ReportIF, but with elements explicit...
InstSeqNum lastPredictionSeqNum
A prediction number for use where one isn't available from an instruction.
Cycles extraAssumedLat
Extra delay that results should show in the scoreboard after leaving the pipeline.
MinorCPU::MinorCPUPort & getDcachePort()
Returns the DcachePort owned by this Execute to pass upwards.
void completeMemBarrierInst(MinorDynInstPtr inst, bool committed)
Complete a barrier instruction.
ThreadContext is the external interface to all thread state for anything outside of the CPU.
Counter numOp
Number of ops (including micro ops) committed.
static MinorDynInstPtr bubble()
There is a single bubble inst.
MinorCPU is an in-order CPU model with four fixed pipeline stages:
DrainState
Stage cycle-by-cycle state.
Wrapper for a queue type to act as a pipeline stage input queue.
Stats::Scalar numDiscardedOps
Number of ops discarded before committing.
void handleMemResponse(MinorDynInstPtr inst, LSQ::LSQRequestPtr response, BranchData &branch, Fault &fault)
Handle extracting mem ref responses from the memory queues and completing the associated instructions...
bool needsToBeSentToStoreBuffer()
This request, once processed by the requests/transfers queues, will need to go to the store buffer.
std::shared_ptr< FaultBase > Fault
unsigned int width() const
Number of instructions carried by this object.
void evaluate()
Pass on input/buffer data to the output if you can.
unsigned int drain()
Like the drain interface on SimObject.
bool isBubble() const
BubbleIF interface.
void serviceEvents(Tick when)
process all events up to the given timestamp.
bool setTraceTimeOnIssue
Modify instruction trace times on issue.
Counter numInst
Number of instructions committed.
bool canPushIntoStoreBuffer() const
Must check this before trying to insert into the store buffer.
Cycles curCycle() const
Determine the current cycle, corresponding to a tick aligned to a clock edge.
unsigned int issueLimit
Number of instructions that can be issued per cycle.
bool needsToTick()
May need to be ticked next cycle as one of the queues contains an actionable transfers or address tra...
void updateBranchData(ThreadID tid, BranchData::Reason reason, MinorDynInstPtr inst, const TheISA::PCState &target, BranchData &branch)
Actually create a branch to communicate to Fetch1/Fetch2 and, if that is a stream-changing branch upd...
const ForwardInstData * getInput(ThreadID tid)
Get a piece of data to work on from the inputBuffer, or 0 if there is no data.
unsigned int cyclicIndexInc(unsigned int index, unsigned int cycle_size)
Increment a cyclic buffer index for indices [0, cycle_size-1].
Provide a non-protected base class for Minor's Ports as derived classes are created by Fetch1 and Exe...
MinorDynInstPtr insts[MAX_FORWARD_INSTS]
Array of carried insts, ref counted.
void popInput(ThreadID tid)
Pop an element off the input buffer, if there are any.
unsigned int memoryCommitLimit
Number of memory instructions that can be committed per cycle.
void commit(ThreadID thread_id, bool only_commit_microops, bool discard, BranchData &branch)
Try and commit instructions from the ends of the functional unit pipelines.
bool readMemAccPredicate() const override
MinorCPU & cpu
Pointer back to the containing CPU.
Queue< QueuedInst, ReportTraitsAdaptor< QueuedInst > > * inFlightInsts
In-order instructions either in FUs or the LSQ.
constexpr decltype(nullptr) NoFault
virtual Status status() const =0
void setDrainState(ThreadID thread_id, DrainState state)
Set the drain state (with useful debugging messages)
uint64_t Addr
Address type This will probably be moved somewhere else in the near future.
void tryToBranch(MinorDynInstPtr inst, Fault fault, BranchData &branch)
Generate Branch data based (into branch) on an observed (or not) change in PC while executing an inst...
bool allowEarlyMemIssue
Allow mem refs to leave their FUs before reaching the head of the in flight insts queue if their depe...
virtual Fault getInterrupt()=0
bool setTraceTimeOnCommit
Modify instruction trace times on commit.
Stats::Scalar numOps
Stat for number ops (including micro ops) committed.
virtual TheISA::PCState pcState() const =0
unsigned int issue(ThreadID thread_id)
Try and issue instructions from the inputBuffer.
EventQueue comInstEventQueue
An instruction-based event queue.
Forward data betwen Execute and Fetch1 carrying change-of-address/stream information.
virtual void updateIntrInfo()=0
ForwardInstData instsBeingCommitted
Structure for reporting insts currently being processed/retired for MinorTrace.
Stats::Scalar numOps
Number of simulated insts and microops.
std::ostream & operator<<(std::ostream &os, const InstId &id)
Print this id in the usual slash-separated format expected by MinorTrace.
void doInstCommitAccounting(MinorDynInstPtr inst)
Do the stats handling and instruction count and PC event events related to the new instruction/op cou...
bool instIsHeadInst(MinorDynInstPtr inst)
Returns true if the given instruction is at the head of the inFlightInsts instruction queue.
@ Suspended
Temporarily inactive.
void issuedMemBarrierInst(MinorDynInstPtr inst)
A memory barrier instruction has been issued, remember its execSeqNum that we can avoid issuing memor...
bool readPredicate() const override
ExecContext bears the exec_context interface for Minor.
GenericISA::DelaySlotPCState< MachInst > PCState
void activity()
Records that there is activity this cycle.
std::vector< ThreadID > roundRobinPriority(ThreadID priority)
Thread scheduling utility functions.
unsigned int commitLimit
Number of instructions that can be committed per cycle.
ThreadID getCommittingThread()
Use the current threading policy to determine the next thread to decode from.
unsigned int memoryIssueLimit
Number of memory ops that can be issued per cycle.
A functional unit configured from a MinorFU object.
void sendStoreToStoreBuffer(LSQRequestPtr request)
A store has been committed, please move it to the store buffer.
A functional unit that can execute any of opClasses operations with a single op(eration)Lat(ency) and...
A Packet is used to encapsulate a transfer between two objects in the memory system (e....
Execute(const std::string &name_, MinorCPU &cpu_, const MinorCPUParams ¶ms, Latch< ForwardInstData >::Output inp_, Latch< BranchData >::Input out_)
Cycles extraCommitLat
Extra latency that the instruction should spend at the end of the pipeline.
static BranchData bubble()
BubbleIF interface.
A scoreboard of register dependencies including, for each register: The number of in-flight instructi...
ThreadID numThreads
Number of threads we're actually simulating (<= SMT_MAX_THREADS).
InstSeqNum getLastMemBarrier(ThreadID thread_id) const
Get the execSeqNum of the last issued memory barrier.
Cycles is a wrapper class for representing cycle counts, i.e.
std::vector< FUPipeline * > funcUnits
The execution functional units.
Container class to box instructions in the FUs to make those queues have correct bubble behaviour whe...
std::vector< ThreadID > randomPriority()
unsigned int numFuncUnits
Number of functional units to produce.
Tick curTick()
The universal simulation clock.
TimingExpr * extraCommitLatExpr
bool takeInterrupt(ThreadID thread_id, BranchData &branch)
Act on an interrupt.
bool isDrained()
Is there nothing left in the LSQ.
DrainState drainState
State progression for draining NotDraining -> ...
Stats::Scalar numInsts
Number of simulated instructions.
virtual void probeInstCommit(const StaticInstPtr &inst, Addr pc)
Helper method to trigger PMU probes for a committed instruction.
bool checkInterrupts(ThreadID tid) const
virtual Addr instAddr() const =0
Stats::Scalar numFetchSuspends
Number of times fetch was asked to suspend by Execute.
const T * getConstPtr() const
BaseInterrupts * getInterruptController(ThreadID tid)
LSQRequestPtr findResponse(MinorDynInstPtr inst)
Returns a response if it's at the head of the transfers queue and it's either complete or can be sent...
Stats::Vector2d committedInstType
Number of instructions by type (OpClass)
ThreadState::ThreadStateStats threadStats
Derived SenderState to carry data access info.
ThreadID getIssuingThread()
unsigned int noCostFUIndex
The FU index of the non-existent costless FU for instructions which pass the MinorDynInst::isNoCostIn...
#define panic(...)
This implements a cprintf based panic() function.
Generated on Tue Jun 22 2021 15:28:26 for gem5 by  doxygen 1.8.17