Go to the documentation of this file.
55 #include "debug/Cache.hh"
56 #include "debug/CacheTags.hh"
57 #include "debug/CacheVerbose.hh"
58 #include "enums/Clusivity.hh"
64 #include "params/Cache.hh"
74 assert(
p.replacement_policy);
79 bool deferred_response,
bool pending_downgrade)
116 if (!deferred_response) {
165 if (pkt->
req->isUncacheable()) {
169 "Should never see a write in a read-only cache %s\n",
176 if (old_blk && old_blk->
isValid()) {
192 while (!writebacks.empty()) {
227 writebacks.pop_front();
234 while (!writebacks.empty()) {
257 writebacks.pop_front();
277 if (!forwardAsSnoop) {
284 DPRINTF(
Cache,
"Got prefetch response from above for addr "
308 DPRINTF(
Cache,
"packet promoted from Write to WriteLineReq\n");
318 assert(!pkt->
req->isUncacheable());
327 if (pkt->
req->isUncacheable()) {
332 assert(!blk || !blk->
isValid());
367 assert(pkt->
req->hasPaddr());
368 assert(!pkt->
req->isUncacheable());
378 RequestPtr req = std::make_shared<Request>(pkt->
req->getPaddr(),
380 pkt->
req->getFlags(),
381 pkt->
req->requestorId());
384 assert(
pf->matchAddr(pkt));
413 DPRINTF(
Cache,
"Cache above responding to %s: not responding\n",
479 bool is_whole_line_write)
const
484 bool blkValid = blk && blk->
isValid();
486 if (cpu_pkt->
req->isUncacheable() ||
501 const bool useUpgrades =
true;
503 if (is_whole_line_write) {
509 }
else if (blkValid && useUpgrades) {
512 assert(needsWritable);
542 if (cpu_pkt->
hasSharers() && !needsWritable) {
548 DPRINTF(
Cache,
"%s: passing hasSharers from %s to %s\n",
569 (pkt->
req->isUncacheable() && pkt->
isWrite())) {
575 assert(!(pkt->
req->isUncacheable() && pkt->
isWrite()) ||
586 bool is_forward = (bus_pkt ==
nullptr);
597 const std::string old_state = blk ? blk->
print() :
"";
604 DPRINTF(
Cache,
"%s: Receive response: %s for %s\n", __func__,
605 bus_pkt->
print(), old_state);
624 blk =
handleFill(bus_pkt, blk, writebacks, allocate);
626 is_invalidate =
false;
628 }
else if (bus_pkt->
isRead() ||
645 if (is_invalidate && blk && blk->
isValid()) {
660 assert(!pkt->
req->isCacheInvalidate());
661 DPRINTF(
Cache,
"Cache above responding to %s: not responding\n",
690 const bool is_error = pkt->
isError();
697 for (
auto &target: targets) {
698 Packet *tgt_pkt = target.pkt;
699 switch (target.source) {
701 Tick completion_time;
731 "read-only cache %s\n",
name());
765 int transfer_offset =
767 if (transfer_offset < 0) {
778 assert(!tgt_pkt->
req->isUncacheable());
783 completion_time - target.recvTime;
794 tgt_pkt->
req->setExtraData(0);
796 if (is_invalidate && blk && blk->
isValid()) {
875 pkt->
req->isCacheMaintenance() ||
881 panic(
"Illegal target->source enum %d\n", target.source);
940 bool already_copied,
bool pending_inval)
978 DPRINTF(CacheVerbose,
"%s: created response: %s tick: %lu\n", __func__,
979 pkt->
print(), forward_time);
985 bool is_deferred,
bool pending_inval)
987 DPRINTF(CacheVerbose,
"%s: for %s\n", __func__, pkt->
print());
989 assert(!(is_deferred && !is_timing));
991 assert(!(pending_inval && !is_deferred));
1004 "%s got an invalidating uncacheable snoop request %s",
1007 uint32_t snoop_delay = 0;
1018 Packet snoopPkt(pkt,
true,
true);
1056 bool respond =
false;
1057 bool blk_valid = blk && blk->
isValid();
1060 DPRINTF(CacheVerbose,
"%s: packet (snoop) %s found block: %s\n",
1065 writebacks.push_back(wb_pkt);
1078 }
else if (!blk_valid) {
1079 DPRINTF(CacheVerbose,
"%s: snoop miss for %s\n", __func__,
1095 DPRINTF(
Cache,
"%s: snoop hit for %s, old state is %s\n", __func__,
1108 "Should never have a dirty block in a read-only cache %s\n",
1117 DPRINTF(
Cache,
"Found addr %#llx in upper level cache for snoop %s "
1123 if (pkt->
isRead() && !invalidate) {
1125 assert(!needs_writable);
1133 if (!pkt->
req->isUncacheable()) {
1163 "%s is passing a Modified line through %s, "
1164 "but keeping the block",
name(), pkt->
print());
1183 if (!respond && is_deferred) {
1190 if (blk_valid && invalidate) {
1202 DPRINTF(CacheVerbose,
"%s: for %s\n", __func__, pkt->
print());
1226 DPRINTF(
Cache,
"Setting block cached for %s from lower cache on "
1227 "mshr hit\n", pkt->
print());
1235 DPRINTF(
Cache,
"Deferring snoop on in-service MSHR to blk %#llx (%s)."
1236 "mshrs: %s\n", blk_addr, is_secure ?
"s" :
"ns",
1240 warn(
"allocating bonus target for snoop");
1247 DPRINTF(
Cache,
"Snoop hit in writeback to addr %#llx (%s)\n",
1248 pkt->
getAddr(), is_secure ?
"s" :
"ns");
1264 DPRINTF(
Cache,
"%s: Squashing %s from lower cache on writequeue "
1265 "hit\n", __func__, pkt->
print());
1279 if (!pkt->
req->isUncacheable() && pkt->
isRead() && !invalidate) {
1288 if (have_writable) {
1309 uint32_t snoop_delay =
handleSnoop(pkt, blk,
true,
false,
false);
1326 uint32_t snoop_delay =
handleSnoop(pkt, blk,
false,
false,
false);
1341 Packet snoop_pkt(pkt,
true,
false);
1378 Packet snoop_pkt(tgt_pkt,
true,
false);
1405 bool pending_modified_resp = !snoop_pkt.
hasSharers();
1415 DPRINTF(
Cache,
"Block present, prefetch squashed by cache. "
1416 "Deallocating mshr target %#x.\n",
Addr getBlockAddr(unsigned int blk_size) const
void print(std::ostream &os, int verbosity=0, const std::string &prefix="") const override
Prints the contents of this MSHR for debugging.
Miss Status and handling Register.
bool sendTimingReq(PacketPtr pkt)
Attempt to send a timing request to the responder port by calling its corresponding receive function.
virtual void handleTimingReqMiss(PacketPtr pkt, CacheBlk *blk, Tick forward_time, Tick request_time)=0
void invalidateBlock(CacheBlk *blk)
Invalidate a cache block.
Cycles handleAtomicReqMiss(PacketPtr pkt, CacheBlk *&blk, PacketList &writebacks) override
Handle a request in atomic mode that missed in this cache.
Addr getOffset(unsigned int blk_size) const
virtual bool access(PacketPtr pkt, CacheBlk *&blk, Cycles &lat, PacketList &writebacks)
Does all the processing necessary to perform the provided request.
bool forwardSnoops
Do we forward snoops from mem side port through to cpu side port?
const PacketPtr pkt
Pending request packet.
WriteQueue writeBuffer
Write/writeback buffer.
void setData(const uint8_t *p)
Copy data into the packet from the provided pointer.
bool sendMSHRQueuePacket(MSHR *mshr) override
Take an MSHR, turn it into a suitable downstream packet, and send it out.
virtual void recvTimingResp(PacketPtr pkt)
Handles a response (cache line fill/write ack) from the bus.
RequestPtr req
A pointer to the original request.
bool isForward
True if the entry is just a simple forward from an upper level.
Cycles getDecompressionLatency(const CacheBlk *blk)
Get the decompression latency if the block is compressed.
Tick sendAtomic(PacketPtr pkt)
Send an atomic request packet, where the data is moved and the state is updated in zero time,...
statistics::Vector mshrUncacheable
Number of misses that miss in the MSHRs, per command and thread.
bool hasPostInvalidate() const
@ SECURE
The request targets the secure memory space.
void markInService(MSHR *mshr, bool pending_modified_resp)
Mark a request as in service (sent downstream in the memory system), effectively making this MSHR the...
void setCacheResponding()
Snoop flags.
bool cacheResponding() const
Target * getTarget() override
Returns a reference to the first target.
void copyError(Packet *pkt)
void clearCoherenceBits(unsigned bits)
Clear the corresponding coherence bits.
void clearBlocked(BlockedCause cause)
Marks the cache as unblocked for the given cause.
Tick recvAtomic(PacketPtr pkt) override
Performs the access specified by the request.
A queue entry is holding packets that will be serviced as soon as resources are available.
PacketPtr evictBlock(CacheBlk *blk) override
Evict a cache block.
void recvTimingSnoopReq(PacketPtr pkt) override
Snoops bus transactions to maintain coherence.
void makeAtomicResponse()
void setDataFromBlock(const uint8_t *blk_data, int blkSize)
Copy data into the packet from the provided block pointer, which is aligned to the given block size.
std::unique_ptr< Packet > pendingDelete
Upstream caches need this packet until true is returned, so hold it for deletion until a subsequent c...
@ WritableBit
write permission
uint32_t headerDelay
The extra delay from seeing the packet until the header is transmitted.
void handleTimingReqMiss(PacketPtr pkt, CacheBlk *blk, Tick forward_time, Tick request_time) override
uint32_t handleSnoop(PacketPtr pkt, CacheBlk *blk, bool is_timing, bool is_deferred, bool pending_inval)
Perform an upward snoop if needed, and update the block state (possibly invalidating the block).
bool isUncacheable() const
void setSatisfied()
Set when a request hits in a cache and the cache is not going to respond.
Addr blkAddr
Block aligned address.
uint32_t snoopDelay
Keep track of the extra delay incurred by snooping upwards before sending a request down the memory s...
void setPrefetched()
Marks this blocks as a recently prefetched block.
Cycles is a wrapper class for representing cycle counts, i.e.
WriteAllocator *const writeAllocator
The writeAllocator drive optimizations for streaming writes.
bool inRange(Addr addr) const
Determine if an address is in the ranges covered by this cache.
Tick recvAtomicSnoop(PacketPtr pkt) override
Snoop for the provided request in the cache and return the estimated time taken.
bool mustCheckAbove() const
Does the request need to check for cached copies of the same block in the memory hierarchy above.
uint32_t payloadDelay
The extra pipelining delay from seeing the packet until the end of payload is transmitted by the comp...
uint64_t order
Increasing order number assigned to each incoming request.
uint32_t getTaskId() const
Get the task id associated to this block.
RequestorID maxRequestors()
Get the number of requestors registered in the system.
BaseTags * tags
Tag and data Storage.
bool allocate() const
Should writes allocate?
bool needsWritable() const
void allocateWriteBuffer(PacketPtr pkt, Tick time)
virtual std::string name() const
void print(std::ostream &o, int verbosity=0, const std::string &prefix="") const
gem5::BaseCache::CacheStats stats
Cache(const CacheParams &p)
Instantiates a basic cache object.
A Packet is used to encapsulate a transfer between two objects in the memory system (e....
virtual bool sendMSHRQueuePacket(MSHR *mshr)
Take an MSHR, turn it into a suitable downstream packet, and send it out.
PacketPtr writecleanBlk(CacheBlk *blk, Request::Flags dest, PacketId id)
Create a writeclean request for the given block.
ProbePointArg< PacketInfo > Packet
Packet probe point.
const unsigned blkSize
Block size of this cache.
uint64_t Tick
Tick count type.
Addr regenerateBlkAddr(CacheBlk *blk)
Regenerate block address using tags.
void handleTimingReqHit(PacketPtr pkt, CacheBlk *blk, Tick request_time) override
bool isSecure
True if the entry targets the secure memory space.
virtual Tick recvAtomic(PacketPtr pkt)
Performs the access specified by the request.
std::shared_ptr< Request > RequestPtr
const T * getConstPtr() const
void setCoherenceBits(unsigned bits)
Sets the corresponding coherence bits.
bool matchAddr(const Addr addr, const bool is_secure) const
Check if packet corresponds to a given address and address space.
void setExpressSnoop()
The express snoop flag is used for two purposes.
@ wbRequestorId
This requestor id is used for writeback requests by the caches.
std::string print() const override
Pretty-print tag, set and way, and interpret state bits to readable form including mapping to a MOESI...
void promoteWholeLineWrites(PacketPtr pkt)
Turn line-sized writes into WriteInvalidate transactions.
Entry * findMatch(Addr blk_addr, bool is_secure, bool ignore_uncacheable=true) const
Find the first entry that matches the provided address.
statistics::Vector missLatency
Total number of cycles per thread/command spent waiting for a miss.
void sendTimingSnoopReq(PacketPtr pkt)
Attempt to send a timing snoop request packet to the request port by calling its corresponding receiv...
bool allocOnFill(MemCmd cmd) const
Determine whether we should allocate on a fill or not.
std::unordered_set< RequestPtr > outstandingSnoop
Store the outstanding requests that we are expecting snoop responses from so we can determine which s...
void setResponderHadWritable()
On responding to a snoop request (which only happens for Modified or Owned lines),...
MemCmd cmd
The command field of the packet.
bool forceDeallocateTarget(MSHR *mshr)
Deallocate top target, possibly freeing the MSHR.
void serviceMSHRTargets(MSHR *mshr, const PacketPtr pkt, CacheBlk *blk) override
Service non-deferred MSHR targets using the received response.
bool responderHadWritable() const
bool needsResponse() const
bool wasWholeLineWrite
Track if we sent this as a whole line write or not.
uint64_t Addr
Address type This will probably be moved somewhere else in the near future.
SenderState * senderState
This packet's sender state.
@ DirtyBit
dirty (modified)
Tick clockEdge(Cycles cycles=Cycles(0)) const
Determine the tick when a cycle begins, by default the current one, but the argument also enables the...
virtual void recvTimingReq(PacketPtr pkt)
Performs the access specified by the request.
A coherent cache that can be arranged in flexible topologies.
uint8_t * data
Contains a copy of the data in this block for easy access.
PacketPtr cleanEvictBlk(CacheBlk *blk)
Create a CleanEvict request for the given block.
PacketPtr createMissPacket(PacketPtr cpu_pkt, CacheBlk *blk, bool needs_writable, bool is_whole_line_write) const override
Create an appropriate downstream bus request packet.
void maintainClusivity(bool from_cache, CacheBlk *blk)
Maintain the clusivity of this cache by potentially invalidating a block.
const bool isReadOnly
Is this cache read only, for example the instruction cache, or table-walker cache.
void setHasSharers()
On fills, the hasSharers flag is used by the caches in combination with the cacheResponding flag,...
const enums::Clusivity clusivity
Clusivity with respect to the upstream cache, determining if we fill into both this cache and the cac...
#define panic_if(cond,...)
Conditional panic macro that checks the supplied condition and only panics if the condition is true a...
void makeTimingResponse()
void doWritebacks(PacketList &writebacks, Tick forward_time) override
Insert writebacks into the write buffer.
const bool doFastWrites
This cache should allocate a block on a line-sized write miss.
void recvTimingSnoopResp(PacketPtr pkt) override
Handle a snoop response.
void allocate()
Allocate memory for the packet.
bool isSWPrefetch() const
CacheCmdStats & cmdStats(const PacketPtr p)
void satisfyRequest(PacketPtr pkt, CacheBlk *blk, bool deferred_response=false, bool pending_downgrade=false) override
Perform any necessary updates to the block and perform any data exchange between the packet and the b...
int getNumTargets() const
Returns the current number of allocated targets.
virtual void handleTimingReqHit(PacketPtr pkt, CacheBlk *blk, Tick request_time)
virtual PacketPtr evictBlock(CacheBlk *blk)=0
Evict a cache block.
bool handleSnoop(PacketPtr target, Counter order)
System * system
System we are currently operating in.
MSHRQueue mshrQueue
Miss status registers.
bool access(PacketPtr pkt, CacheBlk *&blk, Cycles &lat, PacketList &writebacks) override
Does all the processing necessary to perform the provided request.
const bool writebackClean
Determine if clean lines should be written back or not.
bool isSecure() const
Check if this block holds data from the secure memory space.
bool isSet(unsigned bits) const
Checks the given coherence bits are set.
const Cycles lookupLatency
The latency of tag lookup of a cache.
int getNumTargets() const
Returns the current number of allocated targets.
MSHR * allocateMissBuffer(PacketPtr pkt, Tick time, bool sched_send=true)
TargetList extractServiceableTargets(PacketPtr pkt)
Extracts the subset of the targets that can be serviced given a received response.
Tick sendAtomicSnoop(PacketPtr pkt)
Send an atomic snoop request packet, where the data is moved and the state is updated in zero time,...
void schedTimingSnoopResp(PacketPtr pkt, Tick when)
Schedule the sending of a timing snoop response.
Cycles ticksToCycles(Tick t) const
#define gem5_assert(cond,...)
The assert macro will function like a normal assert, but will use panic instead of straight abort().
bool isMaskedWrite() const
void copyResponderFlags(const PacketPtr pkt)
Copy the reponse flags from an input packet to this packet.
const int numTarget
The number of targets for each MSHR.
void schedTimingResp(PacketPtr pkt, Tick when)
Schedule the sending of a timing response.
bool isCachedAbove(PacketPtr pkt, bool is_timing=true)
Send up a snoop request and find cached copies.
Reference material can be found at the JEDEC website: UFS standard http://www.jedec....
void doWritebacksAtomic(PacketList &writebacks) override
Send writebacks down the memory hierarchy in atomic mode.
const Cycles forwardLatency
This is the forward latency of the cache.
bool hasPostDowngrade() const
QueueEntry::Target * getTarget() override
Returns a reference to the first target.
bool isBlockCached() const
CacheBlk * handleFill(PacketPtr pkt, CacheBlk *blk, PacketList &writebacks, bool allocate)
Handle a fill operation caused by a received packet.
bool isWholeLineWrite(unsigned blk_size)
void doTimingSupplyResponse(PacketPtr req_pkt, const uint8_t *blk_data, bool already_copied, bool pending_inval)
PacketPtr writebackBlk(CacheBlk *blk)
Create a writeback request for the given block.
virtual bool isValid() const
Checks if the entry is valid.
bool isInvalidate() const
#define panic(...)
This implements a cprintf based panic() function.
virtual void satisfyRequest(PacketPtr pkt, CacheBlk *blk, bool deferred_response=false, bool pending_downgrade=false)
Perform any necessary updates to the block and perform any data exchange between the packet and the b...
void recvTimingReq(PacketPtr pkt) override
Performs the access specified by the request.
const Cycles responseLatency
The latency of sending reponse to its upper level cache/core on a linefill.
compression::Base * compressor
Compression method being used.
Generated on Tue Dec 21 2021 11:34:31 for gem5 by doxygen 1.8.17