Sequencer.cc revision 12749:223c83ed9979
1/*
2 * Copyright (c) 1999-2008 Mark D. Hill and David A. Wood
3 * All rights reserved.
4 *
5 * Redistribution and use in source and binary forms, with or without
6 * modification, are permitted provided that the following conditions are
7 * met: redistributions of source code must retain the above copyright
8 * notice, this list of conditions and the following disclaimer;
9 * redistributions in binary form must reproduce the above copyright
10 * notice, this list of conditions and the following disclaimer in the
11 * documentation and/or other materials provided with the distribution;
12 * neither the name of the copyright holders nor the names of its
13 * contributors may be used to endorse or promote products derived from
14 * this software without specific prior written permission.
15 *
16 * THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS
17 * "AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT
18 * LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR
19 * A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT
20 * OWNER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
21 * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
22 * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE,
23 * DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY
24 * THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT
25 * (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE
26 * OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
27 */
28
29#include "mem/ruby/system/Sequencer.hh"
30
31#include "arch/x86/ldstflags.hh"
32#include "base/logging.hh"
33#include "base/str.hh"
34#include "cpu/testers/rubytest/RubyTester.hh"
35#include "debug/MemoryAccess.hh"
36#include "debug/ProtocolTrace.hh"
37#include "debug/RubySequencer.hh"
38#include "debug/RubyStats.hh"
39#include "mem/packet.hh"
40#include "mem/protocol/PrefetchBit.hh"
41#include "mem/protocol/RubyAccessMode.hh"
42#include "mem/ruby/profiler/Profiler.hh"
43#include "mem/ruby/slicc_interface/RubyRequest.hh"
44#include "mem/ruby/system/RubySystem.hh"
45#include "sim/system.hh"
46
47using namespace std;
48
49Sequencer *
50RubySequencerParams::create()
51{
52    return new Sequencer(this);
53}
54
55Sequencer::Sequencer(const Params *p)
56    : RubyPort(p), m_IncompleteTimes(MachineType_NUM),
57      deadlockCheckEvent([this]{ wakeup(); }, "Sequencer deadlock check")
58{
59    m_outstanding_count = 0;
60
61    m_instCache_ptr = p->icache;
62    m_dataCache_ptr = p->dcache;
63    m_data_cache_hit_latency = p->dcache_hit_latency;
64    m_inst_cache_hit_latency = p->icache_hit_latency;
65    m_max_outstanding_requests = p->max_outstanding_requests;
66    m_deadlock_threshold = p->deadlock_threshold;
67
68    m_coreId = p->coreid; // for tracking the two CorePair sequencers
69    assert(m_max_outstanding_requests > 0);
70    assert(m_deadlock_threshold > 0);
71    assert(m_instCache_ptr != NULL);
72    assert(m_dataCache_ptr != NULL);
73    assert(m_data_cache_hit_latency > 0);
74    assert(m_inst_cache_hit_latency > 0);
75
76    m_runningGarnetStandalone = p->garnet_standalone;
77}
78
79Sequencer::~Sequencer()
80{
81}
82
83void
84Sequencer::wakeup()
85{
86    assert(drainState() != DrainState::Draining);
87
88    // Check for deadlock of any of the requests
89    Cycles current_time = curCycle();
90
91    // Check across all outstanding requests
92    int total_outstanding = 0;
93
94    RequestTable::iterator read = m_readRequestTable.begin();
95    RequestTable::iterator read_end = m_readRequestTable.end();
96    for (; read != read_end; ++read) {
97        SequencerRequest* request = read->second;
98        if (current_time - request->issue_time < m_deadlock_threshold)
99            continue;
100
101        panic("Possible Deadlock detected. Aborting!\n"
102              "version: %d request.paddr: 0x%x m_readRequestTable: %d "
103              "current time: %u issue_time: %d difference: %d\n", m_version,
104              request->pkt->getAddr(), m_readRequestTable.size(),
105              current_time * clockPeriod(), request->issue_time * clockPeriod(),
106              (current_time * clockPeriod()) - (request->issue_time * clockPeriod()));
107    }
108
109    RequestTable::iterator write = m_writeRequestTable.begin();
110    RequestTable::iterator write_end = m_writeRequestTable.end();
111    for (; write != write_end; ++write) {
112        SequencerRequest* request = write->second;
113        if (current_time - request->issue_time < m_deadlock_threshold)
114            continue;
115
116        panic("Possible Deadlock detected. Aborting!\n"
117              "version: %d request.paddr: 0x%x m_writeRequestTable: %d "
118              "current time: %u issue_time: %d difference: %d\n", m_version,
119              request->pkt->getAddr(), m_writeRequestTable.size(),
120              current_time * clockPeriod(), request->issue_time * clockPeriod(),
121              (current_time * clockPeriod()) - (request->issue_time * clockPeriod()));
122    }
123
124    total_outstanding += m_writeRequestTable.size();
125    total_outstanding += m_readRequestTable.size();
126
127    assert(m_outstanding_count == total_outstanding);
128
129    if (m_outstanding_count > 0) {
130        // If there are still outstanding requests, keep checking
131        schedule(deadlockCheckEvent, clockEdge(m_deadlock_threshold));
132    }
133}
134
135void Sequencer::resetStats()
136{
137    m_latencyHist.reset();
138    m_hitLatencyHist.reset();
139    m_missLatencyHist.reset();
140    for (int i = 0; i < RubyRequestType_NUM; i++) {
141        m_typeLatencyHist[i]->reset();
142        m_hitTypeLatencyHist[i]->reset();
143        m_missTypeLatencyHist[i]->reset();
144        for (int j = 0; j < MachineType_NUM; j++) {
145            m_hitTypeMachLatencyHist[i][j]->reset();
146            m_missTypeMachLatencyHist[i][j]->reset();
147        }
148    }
149
150    for (int i = 0; i < MachineType_NUM; i++) {
151        m_missMachLatencyHist[i]->reset();
152        m_hitMachLatencyHist[i]->reset();
153
154        m_IssueToInitialDelayHist[i]->reset();
155        m_InitialToForwardDelayHist[i]->reset();
156        m_ForwardToFirstResponseDelayHist[i]->reset();
157        m_FirstResponseToCompletionDelayHist[i]->reset();
158
159        m_IncompleteTimes[i] = 0;
160    }
161}
162
163// Insert the request on the correct request table.  Return true if
164// the entry was already present.
165RequestStatus
166Sequencer::insertRequest(PacketPtr pkt, RubyRequestType request_type)
167{
168    assert(m_outstanding_count ==
169        (m_writeRequestTable.size() + m_readRequestTable.size()));
170
171    // See if we should schedule a deadlock check
172    if (!deadlockCheckEvent.scheduled() &&
173        drainState() != DrainState::Draining) {
174        schedule(deadlockCheckEvent, clockEdge(m_deadlock_threshold));
175    }
176
177    Addr line_addr = makeLineAddress(pkt->getAddr());
178
179    // Check if the line is blocked for a Locked_RMW
180    if (m_controller->isBlocked(line_addr) &&
181        (request_type != RubyRequestType_Locked_RMW_Write)) {
182        // Return that this request's cache line address aliases with
183        // a prior request that locked the cache line. The request cannot
184        // proceed until the cache line is unlocked by a Locked_RMW_Write
185        return RequestStatus_Aliased;
186    }
187
188    // Create a default entry, mapping the address to NULL, the cast is
189    // there to make gcc 4.4 happy
190    RequestTable::value_type default_entry(line_addr,
191                                           (SequencerRequest*) NULL);
192
193    if ((request_type == RubyRequestType_ST) ||
194        (request_type == RubyRequestType_RMW_Read) ||
195        (request_type == RubyRequestType_RMW_Write) ||
196        (request_type == RubyRequestType_Load_Linked) ||
197        (request_type == RubyRequestType_Store_Conditional) ||
198        (request_type == RubyRequestType_Locked_RMW_Read) ||
199        (request_type == RubyRequestType_Locked_RMW_Write) ||
200        (request_type == RubyRequestType_FLUSH)) {
201
202        // Check if there is any outstanding read request for the same
203        // cache line.
204        if (m_readRequestTable.count(line_addr) > 0) {
205            m_store_waiting_on_load++;
206            return RequestStatus_Aliased;
207        }
208
209        pair<RequestTable::iterator, bool> r =
210            m_writeRequestTable.insert(default_entry);
211        if (r.second) {
212            RequestTable::iterator i = r.first;
213            i->second = new SequencerRequest(pkt, request_type, curCycle());
214            m_outstanding_count++;
215        } else {
216          // There is an outstanding write request for the cache line
217          m_store_waiting_on_store++;
218          return RequestStatus_Aliased;
219        }
220    } else {
221        // Check if there is any outstanding write request for the same
222        // cache line.
223        if (m_writeRequestTable.count(line_addr) > 0) {
224            m_load_waiting_on_store++;
225            return RequestStatus_Aliased;
226        }
227
228        pair<RequestTable::iterator, bool> r =
229            m_readRequestTable.insert(default_entry);
230
231        if (r.second) {
232            RequestTable::iterator i = r.first;
233            i->second = new SequencerRequest(pkt, request_type, curCycle());
234            m_outstanding_count++;
235        } else {
236            // There is an outstanding read request for the cache line
237            m_load_waiting_on_load++;
238            return RequestStatus_Aliased;
239        }
240    }
241
242    m_outstandReqHist.sample(m_outstanding_count);
243    assert(m_outstanding_count ==
244        (m_writeRequestTable.size() + m_readRequestTable.size()));
245
246    return RequestStatus_Ready;
247}
248
249void
250Sequencer::markRemoved()
251{
252    m_outstanding_count--;
253    assert(m_outstanding_count ==
254           m_writeRequestTable.size() + m_readRequestTable.size());
255}
256
257void
258Sequencer::invalidateSC(Addr address)
259{
260    AbstractCacheEntry *e = m_dataCache_ptr->lookup(address);
261    // The controller has lost the coherence permissions, hence the lock
262    // on the cache line maintained by the cache should be cleared.
263    if (e && e->isLocked(m_version)) {
264        e->clearLocked();
265    }
266}
267
268bool
269Sequencer::handleLlsc(Addr address, SequencerRequest* request)
270{
271    AbstractCacheEntry *e = m_dataCache_ptr->lookup(address);
272    if (!e)
273        return true;
274
275    // The success flag indicates whether the LLSC operation was successful.
276    // LL ops will always succeed, but SC may fail if the cache line is no
277    // longer locked.
278    bool success = true;
279    if (request->m_type == RubyRequestType_Store_Conditional) {
280        if (!e->isLocked(m_version)) {
281            //
282            // For failed SC requests, indicate the failure to the cpu by
283            // setting the extra data to zero.
284            //
285            request->pkt->req->setExtraData(0);
286            success = false;
287        } else {
288            //
289            // For successful SC requests, indicate the success to the cpu by
290            // setting the extra data to one.
291            //
292            request->pkt->req->setExtraData(1);
293        }
294        //
295        // Independent of success, all SC operations must clear the lock
296        //
297        e->clearLocked();
298    } else if (request->m_type == RubyRequestType_Load_Linked) {
299        //
300        // Note: To fully follow Alpha LLSC semantics, should the LL clear any
301        // previously locked cache lines?
302        //
303        e->setLocked(m_version);
304    } else if (e->isLocked(m_version)) {
305        //
306        // Normal writes should clear the locked address
307        //
308        e->clearLocked();
309    }
310    return success;
311}
312
313void
314Sequencer::recordMissLatency(const Cycles cycles, const RubyRequestType type,
315                             const MachineType respondingMach,
316                             bool isExternalHit, Cycles issuedTime,
317                             Cycles initialRequestTime,
318                             Cycles forwardRequestTime,
319                             Cycles firstResponseTime, Cycles completionTime)
320{
321    m_latencyHist.sample(cycles);
322    m_typeLatencyHist[type]->sample(cycles);
323
324    if (isExternalHit) {
325        m_missLatencyHist.sample(cycles);
326        m_missTypeLatencyHist[type]->sample(cycles);
327
328        if (respondingMach != MachineType_NUM) {
329            m_missMachLatencyHist[respondingMach]->sample(cycles);
330            m_missTypeMachLatencyHist[type][respondingMach]->sample(cycles);
331
332            if ((issuedTime <= initialRequestTime) &&
333                (initialRequestTime <= forwardRequestTime) &&
334                (forwardRequestTime <= firstResponseTime) &&
335                (firstResponseTime <= completionTime)) {
336
337                m_IssueToInitialDelayHist[respondingMach]->sample(
338                    initialRequestTime - issuedTime);
339                m_InitialToForwardDelayHist[respondingMach]->sample(
340                    forwardRequestTime - initialRequestTime);
341                m_ForwardToFirstResponseDelayHist[respondingMach]->sample(
342                    firstResponseTime - forwardRequestTime);
343                m_FirstResponseToCompletionDelayHist[respondingMach]->sample(
344                    completionTime - firstResponseTime);
345            } else {
346                m_IncompleteTimes[respondingMach]++;
347            }
348        }
349    } else {
350        m_hitLatencyHist.sample(cycles);
351        m_hitTypeLatencyHist[type]->sample(cycles);
352
353        if (respondingMach != MachineType_NUM) {
354            m_hitMachLatencyHist[respondingMach]->sample(cycles);
355            m_hitTypeMachLatencyHist[type][respondingMach]->sample(cycles);
356        }
357    }
358}
359
360void
361Sequencer::writeCallback(Addr address, DataBlock& data,
362                         const bool externalHit, const MachineType mach,
363                         const Cycles initialRequestTime,
364                         const Cycles forwardRequestTime,
365                         const Cycles firstResponseTime)
366{
367    assert(address == makeLineAddress(address));
368    assert(m_writeRequestTable.count(makeLineAddress(address)));
369
370    RequestTable::iterator i = m_writeRequestTable.find(address);
371    assert(i != m_writeRequestTable.end());
372    SequencerRequest* request = i->second;
373
374    m_writeRequestTable.erase(i);
375    markRemoved();
376
377    assert((request->m_type == RubyRequestType_ST) ||
378           (request->m_type == RubyRequestType_ATOMIC) ||
379           (request->m_type == RubyRequestType_RMW_Read) ||
380           (request->m_type == RubyRequestType_RMW_Write) ||
381           (request->m_type == RubyRequestType_Load_Linked) ||
382           (request->m_type == RubyRequestType_Store_Conditional) ||
383           (request->m_type == RubyRequestType_Locked_RMW_Read) ||
384           (request->m_type == RubyRequestType_Locked_RMW_Write) ||
385           (request->m_type == RubyRequestType_FLUSH));
386
387    //
388    // For Alpha, properly handle LL, SC, and write requests with respect to
389    // locked cache blocks.
390    //
391    // Not valid for Garnet_standalone protocl
392    //
393    bool success = true;
394    if (!m_runningGarnetStandalone)
395        success = handleLlsc(address, request);
396
397    // Handle SLICC block_on behavior for Locked_RMW accesses. NOTE: the
398    // address variable here is assumed to be a line address, so when
399    // blocking buffers, must check line addresses.
400    if (request->m_type == RubyRequestType_Locked_RMW_Read) {
401        // blockOnQueue blocks all first-level cache controller queues
402        // waiting on memory accesses for the specified address that go to
403        // the specified queue. In this case, a Locked_RMW_Write must go to
404        // the mandatory_q before unblocking the first-level controller.
405        // This will block standard loads, stores, ifetches, etc.
406        m_controller->blockOnQueue(address, m_mandatory_q_ptr);
407    } else if (request->m_type == RubyRequestType_Locked_RMW_Write) {
408        m_controller->unblock(address);
409    }
410
411    hitCallback(request, data, success, mach, externalHit,
412                initialRequestTime, forwardRequestTime, firstResponseTime);
413}
414
415void
416Sequencer::readCallback(Addr address, DataBlock& data,
417                        bool externalHit, const MachineType mach,
418                        Cycles initialRequestTime,
419                        Cycles forwardRequestTime,
420                        Cycles firstResponseTime)
421{
422    assert(address == makeLineAddress(address));
423    assert(m_readRequestTable.count(makeLineAddress(address)));
424
425    RequestTable::iterator i = m_readRequestTable.find(address);
426    assert(i != m_readRequestTable.end());
427    SequencerRequest* request = i->second;
428
429    m_readRequestTable.erase(i);
430    markRemoved();
431
432    assert((request->m_type == RubyRequestType_LD) ||
433           (request->m_type == RubyRequestType_IFETCH));
434
435    hitCallback(request, data, true, mach, externalHit,
436                initialRequestTime, forwardRequestTime, firstResponseTime);
437}
438
439void
440Sequencer::hitCallback(SequencerRequest* srequest, DataBlock& data,
441                       bool llscSuccess,
442                       const MachineType mach, const bool externalHit,
443                       const Cycles initialRequestTime,
444                       const Cycles forwardRequestTime,
445                       const Cycles firstResponseTime)
446{
447    warn_once("Replacement policy updates recently became the responsibility "
448              "of SLICC state machines. Make sure to setMRU() near callbacks "
449              "in .sm files!");
450
451    PacketPtr pkt = srequest->pkt;
452    Addr request_address(pkt->getAddr());
453    RubyRequestType type = srequest->m_type;
454    Cycles issued_time = srequest->issue_time;
455
456    assert(curCycle() >= issued_time);
457    Cycles total_latency = curCycle() - issued_time;
458
459    // Profile the latency for all demand accesses.
460    recordMissLatency(total_latency, type, mach, externalHit, issued_time,
461                      initialRequestTime, forwardRequestTime,
462                      firstResponseTime, curCycle());
463
464    DPRINTFR(ProtocolTrace, "%15s %3s %10s%20s %6s>%-6s %#x %d cycles\n",
465             curTick(), m_version, "Seq",
466             llscSuccess ? "Done" : "SC_Failed", "", "",
467             printAddress(request_address), total_latency);
468
469    // update the data unless it is a non-data-carrying flush
470    if (RubySystem::getWarmupEnabled()) {
471        data.setData(pkt->getConstPtr<uint8_t>(),
472                     getOffset(request_address), pkt->getSize());
473    } else if (!pkt->isFlush()) {
474        if ((type == RubyRequestType_LD) ||
475            (type == RubyRequestType_IFETCH) ||
476            (type == RubyRequestType_RMW_Read) ||
477            (type == RubyRequestType_Locked_RMW_Read) ||
478            (type == RubyRequestType_Load_Linked)) {
479            memcpy(pkt->getPtr<uint8_t>(),
480                   data.getData(getOffset(request_address), pkt->getSize()),
481                   pkt->getSize());
482            DPRINTF(RubySequencer, "read data %s\n", data);
483        } else if (pkt->req->isSwap()) {
484            std::vector<uint8_t> overwrite_val(pkt->getSize());
485            memcpy(&overwrite_val[0], pkt->getConstPtr<uint8_t>(),
486                   pkt->getSize());
487            memcpy(pkt->getPtr<uint8_t>(),
488                   data.getData(getOffset(request_address), pkt->getSize()),
489                   pkt->getSize());
490            data.setData(&overwrite_val[0],
491                         getOffset(request_address), pkt->getSize());
492            DPRINTF(RubySequencer, "swap data %s\n", data);
493        } else if (type != RubyRequestType_Store_Conditional || llscSuccess) {
494            // Types of stores set the actual data here, apart from
495            // failed Store Conditional requests
496            data.setData(pkt->getConstPtr<uint8_t>(),
497                         getOffset(request_address), pkt->getSize());
498            DPRINTF(RubySequencer, "set data %s\n", data);
499        }
500    }
501
502    // If using the RubyTester, update the RubyTester sender state's
503    // subBlock with the recieved data.  The tester will later access
504    // this state.
505    if (m_usingRubyTester) {
506        DPRINTF(RubySequencer, "hitCallback %s 0x%x using RubyTester\n",
507                pkt->cmdString(), pkt->getAddr());
508        RubyTester::SenderState* testerSenderState =
509            pkt->findNextSenderState<RubyTester::SenderState>();
510        assert(testerSenderState);
511        testerSenderState->subBlock.mergeFrom(data);
512    }
513
514    delete srequest;
515
516    RubySystem *rs = m_ruby_system;
517    if (RubySystem::getWarmupEnabled()) {
518        assert(pkt->req);
519        delete pkt;
520        rs->m_cache_recorder->enqueueNextFetchRequest();
521    } else if (RubySystem::getCooldownEnabled()) {
522        delete pkt;
523        rs->m_cache_recorder->enqueueNextFlushRequest();
524    } else {
525        ruby_hit_callback(pkt);
526        testDrainComplete();
527    }
528}
529
530bool
531Sequencer::empty() const
532{
533    return m_writeRequestTable.empty() && m_readRequestTable.empty();
534}
535
536RequestStatus
537Sequencer::makeRequest(PacketPtr pkt)
538{
539    if (m_outstanding_count >= m_max_outstanding_requests) {
540        return RequestStatus_BufferFull;
541    }
542
543    RubyRequestType primary_type = RubyRequestType_NULL;
544    RubyRequestType secondary_type = RubyRequestType_NULL;
545
546    if (pkt->isLLSC()) {
547        //
548        // Alpha LL/SC instructions need to be handled carefully by the cache
549        // coherence protocol to ensure they follow the proper semantics. In
550        // particular, by identifying the operations as atomic, the protocol
551        // should understand that migratory sharing optimizations should not
552        // be performed (i.e. a load between the LL and SC should not steal
553        // away exclusive permission).
554        //
555        if (pkt->isWrite()) {
556            DPRINTF(RubySequencer, "Issuing SC\n");
557            primary_type = RubyRequestType_Store_Conditional;
558        } else {
559            DPRINTF(RubySequencer, "Issuing LL\n");
560            assert(pkt->isRead());
561            primary_type = RubyRequestType_Load_Linked;
562        }
563        secondary_type = RubyRequestType_ATOMIC;
564    } else if (pkt->req->isLockedRMW()) {
565        //
566        // x86 locked instructions are translated to store cache coherence
567        // requests because these requests should always be treated as read
568        // exclusive operations and should leverage any migratory sharing
569        // optimization built into the protocol.
570        //
571        if (pkt->isWrite()) {
572            DPRINTF(RubySequencer, "Issuing Locked RMW Write\n");
573            primary_type = RubyRequestType_Locked_RMW_Write;
574        } else {
575            DPRINTF(RubySequencer, "Issuing Locked RMW Read\n");
576            assert(pkt->isRead());
577            primary_type = RubyRequestType_Locked_RMW_Read;
578        }
579        secondary_type = RubyRequestType_ST;
580    } else {
581        //
582        // To support SwapReq, we need to check isWrite() first: a SwapReq
583        // should always be treated like a write, but since a SwapReq implies
584        // both isWrite() and isRead() are true, check isWrite() first here.
585        //
586        if (pkt->isWrite()) {
587            //
588            // Note: M5 packets do not differentiate ST from RMW_Write
589            //
590            primary_type = secondary_type = RubyRequestType_ST;
591        } else if (pkt->isRead()) {
592            if (pkt->req->isInstFetch()) {
593                primary_type = secondary_type = RubyRequestType_IFETCH;
594            } else {
595                bool storeCheck = false;
596                // only X86 need the store check
597                if (system->getArch() == Arch::X86ISA) {
598                    uint32_t flags = pkt->req->getFlags();
599                    storeCheck = flags &
600                        (X86ISA::StoreCheck << X86ISA::FlagShift);
601                }
602                if (storeCheck) {
603                    primary_type = RubyRequestType_RMW_Read;
604                    secondary_type = RubyRequestType_ST;
605                } else {
606                    primary_type = secondary_type = RubyRequestType_LD;
607                }
608            }
609        } else if (pkt->isFlush()) {
610          primary_type = secondary_type = RubyRequestType_FLUSH;
611        } else {
612            panic("Unsupported ruby packet type\n");
613        }
614    }
615
616    RequestStatus status = insertRequest(pkt, primary_type);
617    if (status != RequestStatus_Ready)
618        return status;
619
620    issueRequest(pkt, secondary_type);
621
622    // TODO: issue hardware prefetches here
623    return RequestStatus_Issued;
624}
625
626void
627Sequencer::issueRequest(PacketPtr pkt, RubyRequestType secondary_type)
628{
629    assert(pkt != NULL);
630    ContextID proc_id = pkt->req->hasContextId() ?
631        pkt->req->contextId() : InvalidContextID;
632
633    ContextID core_id = coreId();
634
635    // If valid, copy the pc to the ruby request
636    Addr pc = 0;
637    if (pkt->req->hasPC()) {
638        pc = pkt->req->getPC();
639    }
640
641    // check if the packet has data as for example prefetch and flush
642    // requests do not
643    std::shared_ptr<RubyRequest> msg =
644        std::make_shared<RubyRequest>(clockEdge(), pkt->getAddr(),
645                                      pkt->isFlush() ?
646                                      nullptr : pkt->getPtr<uint8_t>(),
647                                      pkt->getSize(), pc, secondary_type,
648                                      RubyAccessMode_Supervisor, pkt,
649                                      PrefetchBit_No, proc_id, core_id);
650
651    DPRINTFR(ProtocolTrace, "%15s %3s %10s%20s %6s>%-6s %#x %s\n",
652            curTick(), m_version, "Seq", "Begin", "", "",
653            printAddress(msg->getPhysicalAddress()),
654            RubyRequestType_to_string(secondary_type));
655
656    // The Sequencer currently assesses instruction and data cache hit latency
657    // for the top-level caches at the beginning of a memory access.
658    // TODO: Eventually, this latency should be moved to represent the actual
659    // cache access latency portion of the memory access. This will require
660    // changing cache controller protocol files to assess the latency on the
661    // access response path.
662    Cycles latency(0);  // Initialize to zero to catch misconfigured latency
663    if (secondary_type == RubyRequestType_IFETCH)
664        latency = m_inst_cache_hit_latency;
665    else
666        latency = m_data_cache_hit_latency;
667
668    // Send the message to the cache controller
669    assert(latency > 0);
670
671    assert(m_mandatory_q_ptr != NULL);
672    m_mandatory_q_ptr->enqueue(msg, clockEdge(), cyclesToTicks(latency));
673}
674
675template <class KEY, class VALUE>
676std::ostream &
677operator<<(ostream &out, const std::unordered_map<KEY, VALUE> &map)
678{
679    auto i = map.begin();
680    auto end = map.end();
681
682    out << "[";
683    for (; i != end; ++i)
684        out << " " << i->first << "=" << i->second;
685    out << " ]";
686
687    return out;
688}
689
690void
691Sequencer::print(ostream& out) const
692{
693    out << "[Sequencer: " << m_version
694        << ", outstanding requests: " << m_outstanding_count
695        << ", read request table: " << m_readRequestTable
696        << ", write request table: " << m_writeRequestTable
697        << "]";
698}
699
700// this can be called from setState whenever coherence permissions are
701// upgraded when invoked, coherence violations will be checked for the
702// given block
703void
704Sequencer::checkCoherence(Addr addr)
705{
706#ifdef CHECK_COHERENCE
707    m_ruby_system->checkGlobalCoherenceInvariant(addr);
708#endif
709}
710
711void
712Sequencer::recordRequestType(SequencerRequestType requestType) {
713    DPRINTF(RubyStats, "Recorded statistic: %s\n",
714            SequencerRequestType_to_string(requestType));
715}
716
717
718void
719Sequencer::evictionCallback(Addr address)
720{
721    ruby_eviction_callback(address);
722}
723
724void
725Sequencer::regStats()
726{
727    RubyPort::regStats();
728
729    m_store_waiting_on_load
730        .name(name() + ".store_waiting_on_load")
731        .desc("Number of times a store aliased with a pending load")
732        .flags(Stats::nozero);
733    m_store_waiting_on_store
734        .name(name() + ".store_waiting_on_store")
735        .desc("Number of times a store aliased with a pending store")
736        .flags(Stats::nozero);
737    m_load_waiting_on_load
738        .name(name() + ".load_waiting_on_load")
739        .desc("Number of times a load aliased with a pending load")
740        .flags(Stats::nozero);
741    m_load_waiting_on_store
742        .name(name() + ".load_waiting_on_store")
743        .desc("Number of times a load aliased with a pending store")
744        .flags(Stats::nozero);
745
746    // These statistical variables are not for display.
747    // The profiler will collate these across different
748    // sequencers and display those collated statistics.
749    m_outstandReqHist.init(10);
750    m_latencyHist.init(10);
751    m_hitLatencyHist.init(10);
752    m_missLatencyHist.init(10);
753
754    for (int i = 0; i < RubyRequestType_NUM; i++) {
755        m_typeLatencyHist.push_back(new Stats::Histogram());
756        m_typeLatencyHist[i]->init(10);
757
758        m_hitTypeLatencyHist.push_back(new Stats::Histogram());
759        m_hitTypeLatencyHist[i]->init(10);
760
761        m_missTypeLatencyHist.push_back(new Stats::Histogram());
762        m_missTypeLatencyHist[i]->init(10);
763    }
764
765    for (int i = 0; i < MachineType_NUM; i++) {
766        m_hitMachLatencyHist.push_back(new Stats::Histogram());
767        m_hitMachLatencyHist[i]->init(10);
768
769        m_missMachLatencyHist.push_back(new Stats::Histogram());
770        m_missMachLatencyHist[i]->init(10);
771
772        m_IssueToInitialDelayHist.push_back(new Stats::Histogram());
773        m_IssueToInitialDelayHist[i]->init(10);
774
775        m_InitialToForwardDelayHist.push_back(new Stats::Histogram());
776        m_InitialToForwardDelayHist[i]->init(10);
777
778        m_ForwardToFirstResponseDelayHist.push_back(new Stats::Histogram());
779        m_ForwardToFirstResponseDelayHist[i]->init(10);
780
781        m_FirstResponseToCompletionDelayHist.push_back(new Stats::Histogram());
782        m_FirstResponseToCompletionDelayHist[i]->init(10);
783    }
784
785    for (int i = 0; i < RubyRequestType_NUM; i++) {
786        m_hitTypeMachLatencyHist.push_back(std::vector<Stats::Histogram *>());
787        m_missTypeMachLatencyHist.push_back(std::vector<Stats::Histogram *>());
788
789        for (int j = 0; j < MachineType_NUM; j++) {
790            m_hitTypeMachLatencyHist[i].push_back(new Stats::Histogram());
791            m_hitTypeMachLatencyHist[i][j]->init(10);
792
793            m_missTypeMachLatencyHist[i].push_back(new Stats::Histogram());
794            m_missTypeMachLatencyHist[i][j]->init(10);
795        }
796    }
797}
798