Go to the documentation of this file.
   42 #ifndef __CPU_O3_LSQ_HH__ 
   43 #define __CPU_O3_LSQ_HH__ 
   59 #include "enums/SMTQueuePolicy.hh" 
  306                 const Addr& 
addr, 
const uint32_t& size,
 
  351             assert(reason == Flag::LSQEntryFreed || reason == Flag::Discarded);
 
  384             request()->setContext(context_id);
 
  441                     pkt->senderState = 
st;
 
  528             return flags.
isSet(Flag::TranslationStarted) &&
 
  595             assert(!
flags.
isSet(Flag::WritebackScheduled));
 
  596             flags.
set(Flag::WritebackScheduled);
 
  613             flags.
set(Flag::TranslationSquashed);
 
  626         virtual std::string 
name()
 const { 
return "LSQRequest"; }
 
  666                        std::move(amo_op)) {}
 
  678         virtual std::string 
name()
 const { 
return "SingleDataRequest"; }
 
  706         virtual std::string 
name()
 const { 
return "HtmCmdRequest"; }
 
  750                 uint64_t* res=
nullptr) :
 
  783         virtual std::string 
name()
 const { 
return "SplitDataRequest"; }
 
  787     LSQ(
CPU *cpu_ptr, 
IEW *iew_ptr, 
const O3CPUParams ¶ms);
 
  790     std::string 
name() 
const;
 
  967     Fault read(LSQRequest* req, 
int load_idx);
 
 1037         if (pol == SMTQueuePolicy::Dynamic) {
 
 1039         } 
else if (pol == SMTQueuePolicy::Partitioned) {
 
 1042         } 
else if (pol == SMTQueuePolicy::Threshold) {
 
 1046             return SMTThreshold;
 
 1078 #endif // __CPU_O3_LSQ_HH__ 
  
void release(Flag reason)
Release the LSQRequest.
unsigned LQEntries
Total Size of LQ Entries.
DynInstPtr inst
Instruction which initiated the access to memory.
AtomicOpFunctorPtr _amo_op
SMTQueuePolicy lsqPolicy
The LSQ policy for SMT mode.
virtual bool isSnooping() const
As this CPU requires snooping to maintain the load store queue change the behaviour from the base CPU...
bool isComplete()
Completes a packet and returns whether the access is finished.
void insertStore(const DynInstPtr &store_inst)
Inserts a store into the LSQ.
Memory operation metadata.
virtual void initiateTranslation()
void commitLoads(InstSeqNum &youngest_inst, ThreadID tid)
Commits loads up until the given sequence number for a specific thread.
int numStoresToWB(ThreadID tid)
Returns the number of stores a specific thread has to write back.
virtual void complete()=0
bool cacheBlocked() const
Is D-cache blocked?
virtual void recvFunctionalSnoop(PacketPtr pkt)
Receive a functional snoop request packet from the peer.
bool isTranslationComplete()
std::vector< bool > _byteEnable
SplitDataRequest(LSQUnit *port, const DynInstPtr &inst, bool isLoad, const Addr &addr, const uint32_t &size, const Request::Flags &flags_, PacketDataPtr data=nullptr, uint64_t *res=nullptr)
unsigned numFreeEntries(ThreadID tid)
Returns the number of free entries for a specific thread.
virtual std::string name() const
ThreadID numThreads
Number of Threads.
void taskId(const uint32_t &v)
void dumpInsts() const
Debugging function to print out all instructions.
virtual ~SplitDataRequest()
int getCount()
Returns the number of instructions in all of the queues.
virtual void buildPackets()
void writebackStores()
Attempts to write back stores until all cache ports are used or the interface becomes blocked.
void setActiveThreads(std::list< ThreadID > *at_ptr)
Sets the pointer to the list of active threads.
Fault read(LSQRequest *req, int load_idx)
Executes a read operation, using the load specified at the load index.
bool lqEmpty() const
Returns if all of the LQs are empty.
@ Discarded
Request discarded.
void set(Type mask)
Set all flag's bits matching the given mask.
bool _cacheBlocked
D-cache is blocked.
virtual void buildPackets()
bool needWB
Whether or not the instruction will need to writeback.
void install()
Install the request in the LQ/SQ.
virtual void initiateTranslation()
void setState(const State &newState)
void clear()
Clear all flag's bits.
virtual Cycles handleLocalAccess(gem5::ThreadContext *thread, PacketPtr pkt)
Memory mapped IPR accesses.
DcachePort class for the load/store queue.
virtual bool isCacheBlockHit(Addr blockAddr, Addr cacheBlockMask)=0
Test if the request accesses a particular cache line.
bool isMemAccessRequired()
InstSeqNum getStoreHeadSeqNum(ThreadID tid)
Returns the sequence number of the head of the store queue.
virtual void buildPackets()=0
int numLoads()
Returns the total number of loads in the load queue.
virtual bool isCacheBlockHit(Addr blockAddr, Addr cacheBlockMask)
Caches may probe into the load-store queue to enforce memory ordering guarantees.
bool cachePortAvailable(bool is_load) const
Is any store port available to use?
LSQRequest * _request
The senderState needs to know the LSQRequest who owns it.
uint8_t outstanding
Number of outstanding packets to complete.
const RequestPtr request(int idx=0) const
bool squashed() const override
This function is used by the page table walker to determine if it should translate the a pending requ...
const DynInstPtr & instruction()
void recvTimingSnoopReq(PacketPtr pkt)
virtual void sendPacketToCache()=0
@ LSQEntryFreed
LSQ resources freed.
int getStoreHead(ThreadID tid)
Returns the head index of the store queue.
virtual PacketPtr mainPacket()
virtual std::string name() const
Addr getVaddr(int idx=0) const
virtual void sendPacketToCache()
std::string name() const
Returns the name of the LSQ.
virtual ~LSQRequest()
Destructor.
DcachePort dcachePort
Data port.
virtual void recvTimingSnoopReq(PacketPtr pkt)
Receive a timing snoop request from the peer.
bool isEmpty() const
Returns if the LSQ is empty (both LQ and SQ are empty).
DcachePort(LSQ *_lsq, CPU *_cpu)
Default constructor.
std::list< ThreadID > * activeThreads
List of Active Threads in System.
virtual bool recvTimingResp(PacketPtr pkt)
@ IsAtomic
True if this is an atomic request.
virtual void sendPacketToCache()
void setVirt(Addr vaddr, unsigned size, Request::Flags flags_, RequestorID requestor_id, Addr pc)
Set up virtual request.
bool isStalled()
Returns if the LSQ is stalled due to a memory operation that must be replayed.
Fault executeStore(const DynInstPtr &inst)
Executes a store.
LSQSenderState(LSQRequest *request, bool is_load)
Default constructor.
int cacheStorePorts
The number of cache ports available each cycle (stores only).
bool sqFull()
Returns if any of the SQs are full.
void resetHtmStartsStops(ThreadID tid)
A RequestPort is a specialisation of a Port, which implements the default protocol for the three diff...
bool violation()
Returns whether or not there was a memory ordering violation.
Cycles is a wrapper class for representing cycle counts, i.e.
void completeDataAccess(PacketPtr pkt)
int numHtmStarts(ThreadID tid) const
SingleDataRequest(LSQUnit *port, const DynInstPtr &inst, bool isLoad, const Addr &addr, const uint32_t &size, const Request::Flags &flags_, PacketDataPtr data=nullptr, uint64_t *res=nullptr, AtomicOpFunctorPtr amo_op=nullptr)
int numStores()
Returns the total number of stores in the store queue.
virtual bool recvTimingResp(PacketPtr pkt)=0
Class that implements the actual LQ and SQ for each specific thread.
HtmCmdRequest(LSQUnit *port, const DynInstPtr &inst, const Request::Flags &flags_)
unsigned SQEntries
Total Size of SQ Entries.
void tick()
Ticks the LSQ.
O3CPU class, has each of the stages (fetch through commit) within it, as well as all of the time buff...
void packetSent()
Update the status to reflect that a packet was sent.
Fault write(LSQRequest *req, uint8_t *data, int store_idx)
Executes a store operation, using the store specified at the store index.
unsigned maxSQEntries
Max SQ Size - Used to Enforce Sharing Policies.
ThreadContext is the external interface to all thread state for anything outside of the CPU.
bool isTranslationBlocked()
void discard()
The request is discarded (e.g.
std::shared_ptr< FaultBase > Fault
bool isSet(Type mask) const
Verifies whether any bit matching the given mask is set.
bool isDrained() const
Has the LSQ drained?
bool isSplit
Whether or not this access is split in two.
void discardSenderState()
Mark senderState as discarded.
std::vector< PacketPtr > _packets
IEW * iewStage
The IEW stage pointer.
virtual std::string name() const
A Packet is used to encapsulate a transfer between two objects in the memory system (e....
uint32_t _entryIdx
LQ/SQ entry idx.
void packetNotSent()
Update the status to reflect that a packet was not sent.
IEW handles both single threaded and SMT IEW (issue/execute/writeback).
std::shared_ptr< Request > RequestPtr
PacketPtr packet(int idx=0)
uint64_t getLatestHtmUid(ThreadID tid) const
uint32_t _numOutstandingPackets
bool willWB()
Returns if the LSQ will write back to memory this cycle.
unsigned numFreeLoadEntries()
Returns the number of free load entries.
void cachePortBusy(bool is_load)
Another store port is in use.
virtual void recvReqRetry()
Handles doing a retry of the previous send.
virtual std::string name() const
bool isReleased()
Test if the LSQRequest has been released, i.e.
RequestPtr request(int idx=0)
A virtual base opaque structure used to hold state associated with the packet (e.g....
void senderState(LSQSenderState *st)
virtual PacketPtr mainPacket()
bool pktToSend
Whether or not there is a packet that needs sending.
void setLastRetiredHtmUid(ThreadID tid, uint64_t htmUid)
uint64_t Addr
Address type This will probably be moved somewhere else in the near future.
const Request::Flags _flags
virtual bool isCacheBlockHit(Addr blockAddr, Addr cacheBlockMask)
Test if the request accesses a particular cache line.
int entryAmount(ThreadID num_threads)
Number of entries needed for the given amount of threads.
DynInstPtr getMemDepViolator(ThreadID tid)
Gets the instruction that caused the memory ordering violation.
@ TranslationFinished
True if there are un-replied outbound translations.
void squash(const InstSeqNum &squashed_num, ThreadID tid)
Squash instructions from a thread until the specified sequence number.
bool sqEmpty() const
Returns if all of the SQs are empty.
void drainSanityCheck() const
Perform sanity checks after a drain.
virtual ~SingleDataRequest()
static uint32_t maxLSQAllocation(SMTQueuePolicy pol, uint32_t entries, uint32_t numThreads, uint32_t SMTThreshold)
Auxiliary function to calculate per-thread max LSQ allocation limit.
const LSQSenderState * senderState() const
PacketPtr pendingPacket
A second packet from a split store that needs sending.
virtual bool recvTimingResp(PacketPtr pkt)
void recvReqRetry()
Retry the previous send that failed.
Flags< FlagsStorage > FlagsType
virtual Cycles handleLocalAccess(gem5::ThreadContext *thread, PacketPtr pkt)
Memory mapped IPR accesses.
virtual void initiateTranslation()
bool isLoad
Whether or not it is a load.
void writebackScheduled()
void insertLoad(const DynInstPtr &load_inst)
Inserts a load into the LSQ.
Derived class to hold any sender state the LSQ needs.
LSQRequest(LSQUnit *port, const DynInstPtr &inst, bool isLoad)
CPU * cpu
The CPU pointer.
virtual RequestPtr mainRequest()
bool hasStoresToWB()
Returns whether or not there are any stores to write back to memory.
Overload hash function for BasicBlockRange type.
int getLoadHead(ThreadID tid)
Returns the head index of the load queue for a specific thread.
virtual void finish(const Fault &fault, const RequestPtr &req, gem5::ThreadContext *tc, BaseMMU::Mode mode)
std::vector< RequestPtr > _requests
unsigned maxLQEntries
Max LQ Size - Used to Enforce Sharing Policies.
virtual RequestPtr mainRequest()
void markDelayed() override
Signal that the translation has been delayed due to a hw page table walk.
InstSeqNum getLoadHeadSeqNum(ThreadID tid)
Returns the sequence number of the head of the load queue.
@ TranslationSquashed
Ownership tracking flags.
virtual void finish(const Fault &fault, const RequestPtr &req, gem5::ThreadContext *tc, BaseMMU::Mode mode)
int ContextID
Globally unique thread context ID.
PacketPtr mainPkt
The main packet from a split load, used during writeback.
unsigned numFreeStoreEntries()
Returns the number of free store entries.
bool isAnyOutstandingRequest()
Test if there is any in-flight translation or mem access request.
virtual void initiateTranslation()=0
int usedStorePorts
The number of used cache ports in this cycle by stores.
LSQ(CPU *cpu_ptr, IEW *iew_ptr, const O3CPUParams ¶ms)
Constructs an LSQ with the given parameters.
virtual Cycles handleLocalAccess(gem5::ThreadContext *thread, PacketPtr pkt)=0
Memory mapped IPR accesses.
virtual void finish(const Fault &fault, const RequestPtr &req, gem5::ThreadContext *tc, BaseMMU::Mode mode)
Fault pushRequest(const DynInstPtr &inst, bool isLoad, uint8_t *data, unsigned int size, Addr addr, Request::Flags flags, uint64_t *res, AtomicOpFunctorPtr amo_op, const std::vector< bool > &byte_enable)
uint32_t numTranslatedFragments
virtual bool recvTimingResp(PacketPtr pkt)
Timing version of receive.
RequestPort & getDataPort()
@ WritebackScheduled
Store written back.
void takeOverFrom()
Takes over execution from another CPU's thread.
void commitStores(InstSeqNum &youngest_inst, ThreadID tid)
Commits stores up until the given sequence number for a specific thread.
bool deleted
Has the request been deleted? LSQ entries can be squashed before the response comes back.
std::unique_ptr< AtomicOpFunctor > AtomicOpFunctorPtr
Reference material can be found at the JEDEC website: UFS standard http://www.jedec....
@ WbStore
True if this is a store/atomic that writes registers (SC).
bool lqFull()
Returns if any of the LQs are full.
@ TranslationStarted
True if any translation has been sent to TLB.
int numHtmStops(ThreadID tid) const
void setContext(const ContextID &context_id)
Convenience getters/setters.
void sendFragmentToTranslation(int i)
std::vector< Fault > _fault
void addRequest(Addr addr, unsigned size, const std::vector< bool > &byte_enable)
Helper function used to add a (sub)request, given its address addr, size size and byte-enable mask by...
Fault executeLoad(const DynInstPtr &inst)
Executes a load.
uint32_t numInTranslationFragments
int usedLoadPorts
The number of used cache ports in this cycle by loads.
std::vector< LSQUnit > thread
The LSQ units for individual threads.
bool isFull()
Returns if the LSQ is full (either LQ or SQ is full).
uint32_t numReceivedPackets
int16_t ThreadID
Thread index/ID type.
bool recvTimingResp(PacketPtr pkt)
Handles writing back and completing the load or store that has returned from memory.
LSQSenderState * _senderState
int cacheLoadPorts
The number of cache ports available each cycle (loads only).
void freeLSQEntry()
The LSQ entry is cleared.
Generated on Tue Sep 21 2021 12:25:01 for gem5 by  doxygen 1.8.17