Merge remote-tracking branch 'origin/master' into unittest-config
This commit is contained in:
		
							
								
								
									
										166
									
								
								src/main/scala/coreplex/BaseCoreplex.scala
									
									
									
									
									
										Normal file
									
								
							
							
						
						
									
										166
									
								
								src/main/scala/coreplex/BaseCoreplex.scala
									
									
									
									
									
										Normal file
									
								
							@@ -0,0 +1,166 @@
 | 
				
			|||||||
 | 
					package coreplex
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					import Chisel._
 | 
				
			||||||
 | 
					import cde.{Parameters, Field}
 | 
				
			||||||
 | 
					import junctions._
 | 
				
			||||||
 | 
					import uncore.tilelink._
 | 
				
			||||||
 | 
					import uncore.tilelink2._
 | 
				
			||||||
 | 
					import uncore.coherence._
 | 
				
			||||||
 | 
					import uncore.agents._
 | 
				
			||||||
 | 
					import uncore.devices._
 | 
				
			||||||
 | 
					import uncore.util._
 | 
				
			||||||
 | 
					import uncore.converters._
 | 
				
			||||||
 | 
					import rocket._
 | 
				
			||||||
 | 
					import rocket.Util._
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					/** Number of memory channels */
 | 
				
			||||||
 | 
					case object NMemoryChannels extends Field[Int]
 | 
				
			||||||
 | 
					/** Number of banks per memory channel */
 | 
				
			||||||
 | 
					case object NBanksPerMemoryChannel extends Field[Int]
 | 
				
			||||||
 | 
					/** Least significant bit of address used for bank partitioning */
 | 
				
			||||||
 | 
					case object BankIdLSB extends Field[Int]
 | 
				
			||||||
 | 
					/** Function for building some kind of coherence manager agent */
 | 
				
			||||||
 | 
					case object BuildL2CoherenceManager extends Field[(Int, Parameters) => CoherenceAgent]
 | 
				
			||||||
 | 
					/** Function for building some kind of tile connected to a reset signal */
 | 
				
			||||||
 | 
					case object BuildTiles extends Field[Seq[(Bool, Parameters) => Tile]]
 | 
				
			||||||
 | 
					/** The file to read the BootROM contents from */
 | 
				
			||||||
 | 
					case object BootROMFile extends Field[String]
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					trait HasCoreplexParameters {
 | 
				
			||||||
 | 
					  implicit val p: Parameters
 | 
				
			||||||
 | 
					  lazy val nBanksPerMemChannel = p(NBanksPerMemoryChannel)
 | 
				
			||||||
 | 
					  lazy val lsb = p(BankIdLSB)
 | 
				
			||||||
 | 
					  lazy val innerParams = p.alterPartial({ case TLId => "L1toL2" })
 | 
				
			||||||
 | 
					  lazy val outermostParams = p.alterPartial({ case TLId => "Outermost" })
 | 
				
			||||||
 | 
					  lazy val outermostMMIOParams = p.alterPartial({ case TLId => "MMIO_Outermost" })
 | 
				
			||||||
 | 
					  lazy val globalAddrMap = p(rocketchip.GlobalAddrMap)
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					case class CoreplexConfig(
 | 
				
			||||||
 | 
					    nTiles: Int,
 | 
				
			||||||
 | 
					    nExtInterrupts: Int,
 | 
				
			||||||
 | 
					    nSlaves: Int,
 | 
				
			||||||
 | 
					    nMemChannels: Int,
 | 
				
			||||||
 | 
					    hasSupervisor: Boolean)
 | 
				
			||||||
 | 
					{
 | 
				
			||||||
 | 
					  val plicKey = PLICConfig(nTiles, hasSupervisor, nExtInterrupts, 0)
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					abstract class BaseCoreplex(c: CoreplexConfig)(implicit p: Parameters) extends LazyModule
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					abstract class BaseCoreplexBundle(val c: CoreplexConfig)(implicit val p: Parameters) extends Bundle with HasCoreplexParameters {
 | 
				
			||||||
 | 
					  val master = new Bundle {
 | 
				
			||||||
 | 
					    val mem = Vec(c.nMemChannels, new ClientUncachedTileLinkIO()(outermostParams))
 | 
				
			||||||
 | 
					    val mmio = new ClientUncachedTileLinkIO()(outermostMMIOParams)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					  val slave = Vec(c.nSlaves, new ClientUncachedTileLinkIO()(innerParams)).flip
 | 
				
			||||||
 | 
					  val interrupts = Vec(c.nExtInterrupts, Bool()).asInput
 | 
				
			||||||
 | 
					  val debug = new DebugBusIO()(p).flip
 | 
				
			||||||
 | 
					  val clint = Vec(c.nTiles, new CoreplexLocalInterrupts).asInput
 | 
				
			||||||
 | 
					  val resetVector = UInt(INPUT, p(XLen))
 | 
				
			||||||
 | 
					  val success = Bool(OUTPUT) // used for testing
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					abstract class BaseCoreplexModule[+L <: BaseCoreplex, +B <: BaseCoreplexBundle](
 | 
				
			||||||
 | 
					    c: CoreplexConfig, l: L, b: => B)(implicit val p: Parameters) extends LazyModuleImp(l) with HasCoreplexParameters {
 | 
				
			||||||
 | 
					  val outer: L = l
 | 
				
			||||||
 | 
					  val io: B = b
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  // Build a set of Tiles
 | 
				
			||||||
 | 
					  val tiles = p(BuildTiles) map { _(reset, p) }
 | 
				
			||||||
 | 
					  val uncoreTileIOs = (tiles zipWithIndex) map { case (tile, i) => Wire(tile.io) }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  val nCachedPorts = tiles.map(tile => tile.io.cached.size).reduce(_ + _)
 | 
				
			||||||
 | 
					  val nUncachedPorts = tiles.map(tile => tile.io.uncached.size).reduce(_ + _)
 | 
				
			||||||
 | 
					  val nBanks = c.nMemChannels * nBanksPerMemChannel
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  // Build an uncore backing the Tiles
 | 
				
			||||||
 | 
					  buildUncore(p.alterPartial({
 | 
				
			||||||
 | 
					    case HastiId => "TL"
 | 
				
			||||||
 | 
					    case TLId => "L1toL2"
 | 
				
			||||||
 | 
					    case NCachedTileLinkPorts => nCachedPorts
 | 
				
			||||||
 | 
					    case NUncachedTileLinkPorts => nUncachedPorts
 | 
				
			||||||
 | 
					  }))
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  def buildUncore(implicit p: Parameters) = {
 | 
				
			||||||
 | 
					    // Create a simple L1toL2 NoC between the tiles and the banks of outer memory
 | 
				
			||||||
 | 
					    // Cached ports are first in client list, making sharerToClientId just an indentity function
 | 
				
			||||||
 | 
					    // addrToBank is sed to hash physical addresses (of cache blocks) to banks (and thereby memory channels)
 | 
				
			||||||
 | 
					    def sharerToClientId(sharerId: UInt) = sharerId
 | 
				
			||||||
 | 
					    def addrToBank(addr: UInt): UInt = if (nBanks == 0) UInt(0) else {
 | 
				
			||||||
 | 
					      val isMemory = globalAddrMap.isInRegion("mem", addr << log2Up(p(CacheBlockBytes)))
 | 
				
			||||||
 | 
					      Mux(isMemory, addr.extract(lsb + log2Ceil(nBanks) - 1, lsb), UInt(nBanks))
 | 
				
			||||||
 | 
					    }
 | 
				
			||||||
 | 
					    val l1tol2net = Module(new PortedTileLinkCrossbar(addrToBank, sharerToClientId))
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    // Create point(s) of coherence serialization
 | 
				
			||||||
 | 
					    val managerEndpoints = List.tabulate(nBanks){id => p(BuildL2CoherenceManager)(id, p)}
 | 
				
			||||||
 | 
					    managerEndpoints.flatMap(_.incoherent).foreach(_ := Bool(false))
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    val mmioManager = Module(new MMIOTileLinkManager()(p.alterPartial({
 | 
				
			||||||
 | 
					        case TLId => "L1toL2"
 | 
				
			||||||
 | 
					        case InnerTLId => "L1toL2"
 | 
				
			||||||
 | 
					        case OuterTLId => "L2toMMIO"
 | 
				
			||||||
 | 
					      })))
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    // Wire the tiles to the TileLink client ports of the L1toL2 network,
 | 
				
			||||||
 | 
					    // and coherence manager(s) to the other side
 | 
				
			||||||
 | 
					    l1tol2net.io.clients_cached <> uncoreTileIOs.map(_.cached).flatten
 | 
				
			||||||
 | 
					    l1tol2net.io.clients_uncached <> uncoreTileIOs.map(_.uncached).flatten ++ io.slave
 | 
				
			||||||
 | 
					    l1tol2net.io.managers <> managerEndpoints.map(_.innerTL) :+ mmioManager.io.inner
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    // Create a converter between TileLinkIO and MemIO for each channel
 | 
				
			||||||
 | 
					    val mem_ic = Module(new TileLinkMemoryInterconnect(nBanksPerMemChannel, c.nMemChannels)(outermostParams))
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    val outerTLParams = p.alterPartial({ case TLId => "L2toMC" })
 | 
				
			||||||
 | 
					    val backendBuffering = TileLinkDepths(0,0,0,0,0)
 | 
				
			||||||
 | 
					    for ((bank, icPort) <- managerEndpoints zip mem_ic.io.in) {
 | 
				
			||||||
 | 
					      val unwrap = Module(new ClientTileLinkIOUnwrapper()(outerTLParams))
 | 
				
			||||||
 | 
					      unwrap.io.in <> TileLinkEnqueuer(bank.outerTL, backendBuffering)(outerTLParams)
 | 
				
			||||||
 | 
					      TileLinkWidthAdapter(icPort, unwrap.io.out)
 | 
				
			||||||
 | 
					    }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    io.master.mem <> mem_ic.io.out
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    buildMMIONetwork(TileLinkEnqueuer(mmioManager.io.outer, 1))(
 | 
				
			||||||
 | 
					        p.alterPartial({case TLId => "L2toMMIO"}))
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  def buildMMIONetwork(mmio: ClientUncachedTileLinkIO)(implicit p: Parameters) = {
 | 
				
			||||||
 | 
					    val ioAddrMap = globalAddrMap.subMap("io")
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    val cBus = Module(new TileLinkRecursiveInterconnect(1, ioAddrMap))
 | 
				
			||||||
 | 
					    cBus.io.in.head <> mmio
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    val plic = Module(new PLIC(c.plicKey))
 | 
				
			||||||
 | 
					    plic.io.tl <> cBus.port("cbus:plic")
 | 
				
			||||||
 | 
					    for (i <- 0 until io.interrupts.size) {
 | 
				
			||||||
 | 
					      val gateway = Module(new LevelGateway)
 | 
				
			||||||
 | 
					      gateway.io.interrupt := io.interrupts(i)
 | 
				
			||||||
 | 
					      plic.io.devices(i) <> gateway.io.plic
 | 
				
			||||||
 | 
					    }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    val debugModule = Module(new DebugModule)
 | 
				
			||||||
 | 
					    debugModule.io.tl <> cBus.port("cbus:debug")
 | 
				
			||||||
 | 
					    debugModule.io.db <> io.debug
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    // connect coreplex-internal interrupts to tiles
 | 
				
			||||||
 | 
					    for ((tile, i) <- (uncoreTileIOs zipWithIndex)) {
 | 
				
			||||||
 | 
					      tile.interrupts := io.clint(i)
 | 
				
			||||||
 | 
					      tile.interrupts.meip := plic.io.harts(plic.cfg.context(i, 'M'))
 | 
				
			||||||
 | 
					      tile.interrupts.seip.foreach(_ := plic.io.harts(plic.cfg.context(i, 'S')))
 | 
				
			||||||
 | 
					      tile.interrupts.debug := debugModule.io.debugInterrupts(i)
 | 
				
			||||||
 | 
					      tile.hartid := i
 | 
				
			||||||
 | 
					      tile.resetVector := io.resetVector
 | 
				
			||||||
 | 
					    }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    val tileSlavePorts = (0 until c.nTiles) map (i => s"cbus:dmem$i") filter (ioAddrMap contains _)
 | 
				
			||||||
 | 
					    for ((t, m) <- (uncoreTileIOs.map(_.slave).flatten) zip (tileSlavePorts map (cBus port _)))
 | 
				
			||||||
 | 
					      t <> m
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    io.master.mmio <> cBus.port("pbus")
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  // Coreplex doesn't know when to stop running
 | 
				
			||||||
 | 
					  io.success := Bool(false)
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
@@ -4,165 +4,81 @@ import Chisel._
 | 
				
			|||||||
import cde.{Parameters, Field}
 | 
					import cde.{Parameters, Field}
 | 
				
			||||||
import junctions._
 | 
					import junctions._
 | 
				
			||||||
import uncore.tilelink._
 | 
					import uncore.tilelink._
 | 
				
			||||||
import uncore.coherence._
 | 
					 | 
				
			||||||
import uncore.agents._
 | 
					 | 
				
			||||||
import uncore.devices._
 | 
					 | 
				
			||||||
import uncore.util._
 | 
					import uncore.util._
 | 
				
			||||||
import uncore.converters._
 | 
					 | 
				
			||||||
import rocket._
 | 
					import rocket._
 | 
				
			||||||
import rocket.Util._
 | 
					 | 
				
			||||||
 | 
					
 | 
				
			||||||
/** Number of memory channels */
 | 
					trait DirectConnection {
 | 
				
			||||||
case object NMemoryChannels extends Field[Int]
 | 
					  val tiles: Seq[Tile]
 | 
				
			||||||
/** Number of banks per memory channel */
 | 
					  val uncoreTileIOs: Seq[TileIO]
 | 
				
			||||||
case object NBanksPerMemoryChannel extends Field[Int]
 | 
					 | 
				
			||||||
/** Least significant bit of address used for bank partitioning */
 | 
					 | 
				
			||||||
case object BankIdLSB extends Field[Int]
 | 
					 | 
				
			||||||
/** Function for building some kind of coherence manager agent */
 | 
					 | 
				
			||||||
case object BuildL2CoherenceManager extends Field[(Int, Parameters) => CoherenceAgent]
 | 
					 | 
				
			||||||
/** Function for building some kind of tile connected to a reset signal */
 | 
					 | 
				
			||||||
case object BuildTiles extends Field[Seq[(Bool, Parameters) => Tile]]
 | 
					 | 
				
			||||||
/** The file to read the BootROM contents from */
 | 
					 | 
				
			||||||
case object BootROMFile extends Field[String]
 | 
					 | 
				
			||||||
 | 
					
 | 
				
			||||||
trait HasCoreplexParameters {
 | 
					  val tlBuffering = TileLinkDepths(1,1,2,2,0)
 | 
				
			||||||
  implicit val p: Parameters
 | 
					  val ultBuffering = UncachedTileLinkDepths(1,2)
 | 
				
			||||||
  lazy val nBanksPerMemChannel = p(NBanksPerMemoryChannel)
 | 
					 | 
				
			||||||
  lazy val lsb = p(BankIdLSB)
 | 
					 | 
				
			||||||
  lazy val innerParams = p.alterPartial({ case TLId => "L1toL2" })
 | 
					 | 
				
			||||||
  lazy val outermostParams = p.alterPartial({ case TLId => "Outermost" })
 | 
					 | 
				
			||||||
  lazy val outermostMMIOParams = p.alterPartial({ case TLId => "MMIO_Outermost" })
 | 
					 | 
				
			||||||
  lazy val globalAddrMap = p(rocketchip.GlobalAddrMap)
 | 
					 | 
				
			||||||
}
 | 
					 | 
				
			||||||
 | 
					
 | 
				
			||||||
case class CoreplexConfig(
 | 
					  (tiles zip uncoreTileIOs) foreach { case (tile, uncore) =>
 | 
				
			||||||
    nTiles: Int,
 | 
					    (uncore.cached zip tile.io.cached) foreach { case (u, t) => u <> TileLinkEnqueuer(t, tlBuffering)(t.p) }
 | 
				
			||||||
    nExtInterrupts: Int,
 | 
					    (uncore.uncached zip tile.io.uncached) foreach { case (u, t) => u <> TileLinkEnqueuer(t, ultBuffering)(t.p) }
 | 
				
			||||||
    nSlaves: Int,
 | 
					    tile.io.slave.foreach { _ <> TileLinkEnqueuer(uncore.slave.get, 1)(uncore.slave.get.p) }
 | 
				
			||||||
    nMemChannels: Int,
 | 
					 | 
				
			||||||
    hasSupervisor: Boolean,
 | 
					 | 
				
			||||||
    hasExtMMIOPort: Boolean)
 | 
					 | 
				
			||||||
{
 | 
					 | 
				
			||||||
  val plicKey = PLICConfig(nTiles, hasSupervisor, nExtInterrupts, 0)
 | 
					 | 
				
			||||||
}
 | 
					 | 
				
			||||||
 | 
					
 | 
				
			||||||
abstract class Coreplex(implicit val p: Parameters, implicit val c: CoreplexConfig) extends Module
 | 
					    tile.io.interrupts <> uncore.interrupts
 | 
				
			||||||
    with HasCoreplexParameters {
 | 
					 | 
				
			||||||
  class CoreplexIO(implicit val p: Parameters, implicit val c: CoreplexConfig) extends Bundle {
 | 
					 | 
				
			||||||
    val master = new Bundle {
 | 
					 | 
				
			||||||
      val mem = Vec(c.nMemChannels, new ClientUncachedTileLinkIO()(outermostParams))
 | 
					 | 
				
			||||||
      val mmio = c.hasExtMMIOPort.option(new ClientUncachedTileLinkIO()(outermostMMIOParams))
 | 
					 | 
				
			||||||
    }
 | 
					 | 
				
			||||||
    val slave = Vec(c.nSlaves, new ClientUncachedTileLinkIO()(innerParams)).flip
 | 
					 | 
				
			||||||
    val interrupts = Vec(c.nExtInterrupts, Bool()).asInput
 | 
					 | 
				
			||||||
    val debug = new DebugBusIO()(p).flip
 | 
					 | 
				
			||||||
    val clint = Vec(c.nTiles, new CoreplexLocalInterrupts).asInput
 | 
					 | 
				
			||||||
    val success = Bool(OUTPUT)
 | 
					 | 
				
			||||||
    val resetVector = UInt(INPUT, p(XLen))
 | 
					 | 
				
			||||||
  }
 | 
					 | 
				
			||||||
 | 
					
 | 
				
			||||||
  val io = new CoreplexIO
 | 
					    tile.io.hartid := uncore.hartid
 | 
				
			||||||
}
 | 
					    tile.io.resetVector := uncore.resetVector
 | 
				
			||||||
 | 
					 | 
				
			||||||
class DefaultCoreplex(tp: Parameters, tc: CoreplexConfig) extends Coreplex()(tp, tc) {
 | 
					 | 
				
			||||||
  // Coreplex doesn't know when to stop running
 | 
					 | 
				
			||||||
  io.success := Bool(false)
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
  // Build a set of Tiles
 | 
					 | 
				
			||||||
  val tileResets = Wire(Vec(tc.nTiles, Bool()))
 | 
					 | 
				
			||||||
  val tileList = p(BuildTiles).zip(tileResets).map {
 | 
					 | 
				
			||||||
    case (tile, rst) => tile(rst, p)
 | 
					 | 
				
			||||||
  }
 | 
					 | 
				
			||||||
  val nCachedPorts = tileList.map(tile => tile.io.cached.size).reduce(_ + _)
 | 
					 | 
				
			||||||
  val nUncachedPorts = tileList.map(tile => tile.io.uncached.size).reduce(_ + _)
 | 
					 | 
				
			||||||
  val nBanks = tc.nMemChannels * nBanksPerMemChannel
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
  // Build an uncore backing the Tiles
 | 
					 | 
				
			||||||
  buildUncore(p.alterPartial({
 | 
					 | 
				
			||||||
    case HastiId => "TL"
 | 
					 | 
				
			||||||
    case TLId => "L1toL2"
 | 
					 | 
				
			||||||
    case NCachedTileLinkPorts => nCachedPorts
 | 
					 | 
				
			||||||
    case NUncachedTileLinkPorts => nUncachedPorts
 | 
					 | 
				
			||||||
  }))
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
  def buildUncore(implicit p: Parameters) = {
 | 
					 | 
				
			||||||
    // Create a simple L1toL2 NoC between the tiles and the banks of outer memory
 | 
					 | 
				
			||||||
    // Cached ports are first in client list, making sharerToClientId just an indentity function
 | 
					 | 
				
			||||||
    // addrToBank is sed to hash physical addresses (of cache blocks) to banks (and thereby memory channels)
 | 
					 | 
				
			||||||
    def sharerToClientId(sharerId: UInt) = sharerId
 | 
					 | 
				
			||||||
    def addrToBank(addr: UInt): UInt = if (nBanks == 0) UInt(0) else {
 | 
					 | 
				
			||||||
      val isMemory = globalAddrMap.isInRegion("mem", addr << log2Up(p(CacheBlockBytes)))
 | 
					 | 
				
			||||||
      Mux(isMemory, addr.extract(lsb + log2Ceil(nBanks) - 1, lsb), UInt(nBanks))
 | 
					 | 
				
			||||||
    }
 | 
					 | 
				
			||||||
    val preBuffering = TileLinkDepths(1,1,2,2,0)
 | 
					 | 
				
			||||||
    val l1tol2net = Module(new PortedTileLinkCrossbar(addrToBank, sharerToClientId, preBuffering))
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    // Create point(s) of coherence serialization
 | 
					 | 
				
			||||||
    val managerEndpoints = List.tabulate(nBanks){id => p(BuildL2CoherenceManager)(id, p)}
 | 
					 | 
				
			||||||
    managerEndpoints.flatMap(_.incoherent).foreach(_ := Bool(false))
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    val mmioManager = Module(new MMIOTileLinkManager()(p.alterPartial({
 | 
					 | 
				
			||||||
        case TLId => "L1toL2"
 | 
					 | 
				
			||||||
        case InnerTLId => "L1toL2"
 | 
					 | 
				
			||||||
        case OuterTLId => "L2toMMIO"
 | 
					 | 
				
			||||||
      })))
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    // Wire the tiles to the TileLink client ports of the L1toL2 network,
 | 
					 | 
				
			||||||
    // and coherence manager(s) to the other side
 | 
					 | 
				
			||||||
    l1tol2net.io.clients_cached <> tileList.map(_.io.cached).flatten
 | 
					 | 
				
			||||||
    l1tol2net.io.clients_uncached <> tileList.map(_.io.uncached).flatten ++ io.slave
 | 
					 | 
				
			||||||
    l1tol2net.io.managers <> managerEndpoints.map(_.innerTL) :+ mmioManager.io.inner
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    // Create a converter between TileLinkIO and MemIO for each channel
 | 
					 | 
				
			||||||
    val mem_ic = Module(new TileLinkMemoryInterconnect(nBanksPerMemChannel, tc.nMemChannels)(outermostParams))
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    val outerTLParams = p.alterPartial({ case TLId => "L2toMC" })
 | 
					 | 
				
			||||||
    val backendBuffering = TileLinkDepths(0,0,0,0,0)
 | 
					 | 
				
			||||||
    for ((bank, icPort) <- managerEndpoints zip mem_ic.io.in) {
 | 
					 | 
				
			||||||
      val unwrap = Module(new ClientTileLinkIOUnwrapper()(outerTLParams))
 | 
					 | 
				
			||||||
      unwrap.io.in <> TileLinkEnqueuer(bank.outerTL, backendBuffering)(outerTLParams)
 | 
					 | 
				
			||||||
      TileLinkWidthAdapter(icPort, unwrap.io.out)
 | 
					 | 
				
			||||||
    }
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    io.master.mem <> mem_ic.io.out
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    buildMMIONetwork(TileLinkEnqueuer(mmioManager.io.outer, 1))(
 | 
					 | 
				
			||||||
        p.alterPartial({case TLId => "L2toMMIO"}))
 | 
					 | 
				
			||||||
  }
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
  def buildMMIONetwork(mmio: ClientUncachedTileLinkIO)(implicit p: Parameters) = {
 | 
					 | 
				
			||||||
    val ioAddrMap = globalAddrMap.subMap("io")
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    val mmioNetwork = Module(new TileLinkRecursiveInterconnect(1, ioAddrMap))
 | 
					 | 
				
			||||||
    mmioNetwork.io.in.head <> mmio
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    val plic = Module(new PLIC(c.plicKey))
 | 
					 | 
				
			||||||
    plic.io.tl <> mmioNetwork.port("int:plic")
 | 
					 | 
				
			||||||
    for (i <- 0 until io.interrupts.size) {
 | 
					 | 
				
			||||||
      val gateway = Module(new LevelGateway)
 | 
					 | 
				
			||||||
      gateway.io.interrupt := io.interrupts(i)
 | 
					 | 
				
			||||||
      plic.io.devices(i) <> gateway.io.plic
 | 
					 | 
				
			||||||
    }
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    val debugModule = Module(new DebugModule)
 | 
					 | 
				
			||||||
    debugModule.io.tl <> mmioNetwork.port("int:debug")
 | 
					 | 
				
			||||||
    debugModule.io.db <> io.debug
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    // connect coreplex-internal interrupts to tiles
 | 
					 | 
				
			||||||
    for (((tile, tileReset), i) <- (tileList zip tileResets) zipWithIndex) {
 | 
					 | 
				
			||||||
      tileReset := reset // TODO should tiles be reset separately from coreplex?
 | 
					 | 
				
			||||||
      tile.io.interrupts := io.clint(i)
 | 
					 | 
				
			||||||
      tile.io.interrupts.meip := plic.io.harts(plic.cfg.context(i, 'M'))
 | 
					 | 
				
			||||||
      tile.io.interrupts.seip.foreach(_ := plic.io.harts(plic.cfg.context(i, 'S')))
 | 
					 | 
				
			||||||
      tile.io.interrupts.debug := debugModule.io.debugInterrupts(i)
 | 
					 | 
				
			||||||
      tile.io.hartid := i
 | 
					 | 
				
			||||||
      tile.io.resetVector := io.resetVector
 | 
					 | 
				
			||||||
    }
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    val tileSlavePorts = (0 until tc.nTiles) map (i => s"int:dmem$i") filter (ioAddrMap contains _)
 | 
					 | 
				
			||||||
    for ((t, m) <- (tileList.map(_.io.slave).flatten) zip (tileSlavePorts map (mmioNetwork port _)))
 | 
					 | 
				
			||||||
      t <> TileLinkEnqueuer(m, 1)
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
    io.master.mmio.foreach { _ <> mmioNetwork.port("ext") }
 | 
					 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class DefaultCoreplex(c: CoreplexConfig)(implicit p: Parameters) extends BaseCoreplex(c)(p) {
 | 
				
			||||||
 | 
					  override lazy val module = Module(new DefaultCoreplexModule(c, this, new DefaultCoreplexBundle(c)(p))(p))
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class DefaultCoreplexBundle(c: CoreplexConfig)(implicit p: Parameters) extends BaseCoreplexBundle(c)(p)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class DefaultCoreplexModule[+L <: DefaultCoreplex, +B <: DefaultCoreplexBundle](
 | 
				
			||||||
 | 
					    c: CoreplexConfig, l: L, b: => B)(implicit p: Parameters) extends BaseCoreplexModule(c, l, b)(p)
 | 
				
			||||||
 | 
					    with DirectConnection
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					/////
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					trait TileClockResetBundle {
 | 
				
			||||||
 | 
					  val c: CoreplexConfig
 | 
				
			||||||
 | 
					  val tcrs = Vec(c.nTiles, new Bundle {
 | 
				
			||||||
 | 
					    val clock = Clock(INPUT)
 | 
				
			||||||
 | 
					    val reset = Bool(INPUT)
 | 
				
			||||||
 | 
					  })
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					trait AsyncConnection {
 | 
				
			||||||
 | 
					  val io: TileClockResetBundle
 | 
				
			||||||
 | 
					  val tiles: Seq[Tile]
 | 
				
			||||||
 | 
					  val uncoreTileIOs: Seq[TileIO]
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  (tiles, uncoreTileIOs, io.tcrs).zipped foreach { case (tile, uncore, tcr) =>
 | 
				
			||||||
 | 
					    tile.clock := tcr.clock
 | 
				
			||||||
 | 
					    tile.reset := tcr.reset
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    (uncore.cached zip tile.io.cached) foreach { case (u, t) => u <> AsyncTileLinkFrom(tcr.clock, tcr.reset, t) }
 | 
				
			||||||
 | 
					    (uncore.uncached zip tile.io.uncached) foreach { case (u, t) => u <> AsyncUTileLinkFrom(tcr.clock, tcr.reset, t) }
 | 
				
			||||||
 | 
					    tile.io.slave.foreach { _ <> AsyncUTileLinkTo(tcr.clock, tcr.reset, uncore.slave.get)}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    val ti = tile.io.interrupts
 | 
				
			||||||
 | 
					    val ui = uncore.interrupts
 | 
				
			||||||
 | 
					    ti.debug := LevelSyncTo(tcr.clock, ui.debug)
 | 
				
			||||||
 | 
					    ti.mtip := LevelSyncTo(tcr.clock, ui.mtip)
 | 
				
			||||||
 | 
					    ti.msip := LevelSyncTo(tcr.clock, ui.msip)
 | 
				
			||||||
 | 
					    ti.meip := LevelSyncTo(tcr.clock, ui.meip)
 | 
				
			||||||
 | 
					    ti.seip.foreach { _ := LevelSyncTo(tcr.clock, ui.seip.get) }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    tile.io.hartid := uncore.hartid
 | 
				
			||||||
 | 
					    tile.io.resetVector := uncore.resetVector
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class MultiClockCoreplex(c: CoreplexConfig)(implicit p: Parameters) extends BaseCoreplex(c)(p) {
 | 
				
			||||||
 | 
					  override lazy val module = Module(new MultiClockCoreplexModule(c, this, new MultiClockCoreplexBundle(c)(p))(p))
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class MultiClockCoreplexBundle(c: CoreplexConfig)(implicit p: Parameters) extends BaseCoreplexBundle(c)(p)
 | 
				
			||||||
 | 
					    with TileClockResetBundle
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class MultiClockCoreplexModule[+L <: MultiClockCoreplex, +B <: MultiClockCoreplexBundle](
 | 
				
			||||||
 | 
					    c: CoreplexConfig, l: L, b: => B)(implicit p: Parameters) extends BaseCoreplexModule(c, l, b)(p)
 | 
				
			||||||
 | 
					    with AsyncConnection
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -69,7 +69,7 @@ class BusMasterTest(implicit p: Parameters) extends GroundTest()(p)
 | 
				
			|||||||
       s_req_check :: s_resp_check :: s_done :: Nil) = Enum(Bits(), 8)
 | 
					       s_req_check :: s_resp_check :: s_done :: Nil) = Enum(Bits(), 8)
 | 
				
			||||||
  val state = Reg(init = s_idle)
 | 
					  val state = Reg(init = s_idle)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  val busMasterBlock = addrMap("io:ext:busmaster").start >> p(CacheBlockOffsetBits)
 | 
					  val busMasterBlock = addrMap("io:pbus:busmaster").start >> p(CacheBlockOffsetBits)
 | 
				
			||||||
  val start_acq = Put(
 | 
					  val start_acq = Put(
 | 
				
			||||||
    client_xact_id = UInt(0),
 | 
					    client_xact_id = UInt(0),
 | 
				
			||||||
    addr_block = UInt(busMasterBlock),
 | 
					    addr_block = UInt(busMasterBlock),
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -81,7 +81,7 @@ class PCIeMockupTestConfig extends Config(
 | 
				
			|||||||
class WithGroundTest extends Config(
 | 
					class WithGroundTest extends Config(
 | 
				
			||||||
  (pname, site, here) => pname match {
 | 
					  (pname, site, here) => pname match {
 | 
				
			||||||
    case BuildCoreplex =>
 | 
					    case BuildCoreplex =>
 | 
				
			||||||
      (p: Parameters, c: CoreplexConfig) => Module(new GroundTestCoreplex(p, c))
 | 
					      (c: CoreplexConfig, p: Parameters) => uncore.tilelink2.LazyModule(new GroundTestCoreplex(c)(p)).module
 | 
				
			||||||
    case TLKey("L1toL2") => {
 | 
					    case TLKey("L1toL2") => {
 | 
				
			||||||
      val useMEI = site(NTiles) <= 1 && site(NCachedTileLinkPorts) <= 1
 | 
					      val useMEI = site(NTiles) <= 1 && site(NCachedTileLinkPorts) <= 1
 | 
				
			||||||
      TileLinkParameters(
 | 
					      TileLinkParameters(
 | 
				
			||||||
@@ -128,7 +128,7 @@ class WithComparator extends Config(
 | 
				
			|||||||
    case BuildGroundTest =>
 | 
					    case BuildGroundTest =>
 | 
				
			||||||
      (p: Parameters) => Module(new ComparatorCore()(p))
 | 
					      (p: Parameters) => Module(new ComparatorCore()(p))
 | 
				
			||||||
    case ComparatorKey => ComparatorParameters(
 | 
					    case ComparatorKey => ComparatorParameters(
 | 
				
			||||||
      targets    = Seq("mem", "io:ext:TL2:testram").map(name =>
 | 
					      targets    = Seq("mem", "io:pbus:TL2:testram").map(name =>
 | 
				
			||||||
                    site(GlobalAddrMap)(name).start.longValue),
 | 
					                    site(GlobalAddrMap)(name).start.longValue),
 | 
				
			||||||
      width      = 8,
 | 
					      width      = 8,
 | 
				
			||||||
      operations = 1000,
 | 
					      operations = 1000,
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -2,8 +2,15 @@ package groundtest
 | 
				
			|||||||
 | 
					
 | 
				
			||||||
import Chisel._
 | 
					import Chisel._
 | 
				
			||||||
import cde.{Parameters}
 | 
					import cde.{Parameters}
 | 
				
			||||||
import coreplex.{CoreplexConfig, DefaultCoreplex}
 | 
					import coreplex._
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class GroundTestCoreplex(tp: Parameters, tc: CoreplexConfig) extends DefaultCoreplex(tp, tc) {
 | 
					class GroundTestCoreplex(c: CoreplexConfig)(implicit p: Parameters) extends BaseCoreplex(c)(p) {
 | 
				
			||||||
  io.success := tileList.flatMap(_.io.elements get "success").map(_.asInstanceOf[Bool]).reduce(_&&_)
 | 
					  override lazy val module = Module(new GroundTestCoreplexModule(c, this, new GroundTestCoreplexBundle(c)(p))(p))
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class GroundTestCoreplexBundle(c: CoreplexConfig)(implicit p: Parameters) extends BaseCoreplexBundle(c)(p)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class GroundTestCoreplexModule[+L <: GroundTestCoreplex, +B <: GroundTestCoreplexBundle](
 | 
				
			||||||
 | 
					    c: CoreplexConfig, l: L, b: => B)(implicit p: Parameters) extends BaseCoreplexModule(c, l, b)(p) with DirectConnection {
 | 
				
			||||||
 | 
					  io.success := tiles.flatMap(_.io.elements get "success").map(_.asInstanceOf[Bool]).reduce(_&&_)
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -72,7 +72,7 @@ class IOGetAfterPutBlockRegression(implicit p: Parameters) extends Regression()(
 | 
				
			|||||||
  io.mem.grant.ready := Bool(true)
 | 
					  io.mem.grant.ready := Bool(true)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  io.cache.req.valid := !get_sent && started
 | 
					  io.cache.req.valid := !get_sent && started
 | 
				
			||||||
  io.cache.req.bits.addr := UInt(addrMap("io:ext:TL2:bootrom").start)
 | 
					  io.cache.req.bits.addr := UInt(addrMap("io:pbus:TL2:bootrom").start)
 | 
				
			||||||
  io.cache.req.bits.typ := UInt(log2Ceil(32 / 8))
 | 
					  io.cache.req.bits.typ := UInt(log2Ceil(32 / 8))
 | 
				
			||||||
  io.cache.req.bits.cmd := M_XRD
 | 
					  io.cache.req.bits.cmd := M_XRD
 | 
				
			||||||
  io.cache.req.bits.tag := UInt(0)
 | 
					  io.cache.req.bits.tag := UInt(0)
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -101,7 +101,7 @@ class GroundTestTile(resetSignal: Bool)
 | 
				
			|||||||
                    extends Tile(resetSignal = resetSignal)(p)
 | 
					                    extends Tile(resetSignal = resetSignal)(p)
 | 
				
			||||||
                    with HasGroundTestParameters {
 | 
					                    with HasGroundTestParameters {
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  override val io = new TileIO {
 | 
					  override val io = new TileIO(bc) {
 | 
				
			||||||
    val success = Bool(OUTPUT)
 | 
					    val success = Bool(OUTPUT)
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -85,3 +85,50 @@ object AsyncIrrevocableFrom
 | 
				
			|||||||
    PostQueueIrrevocablize(AsyncDecoupledFrom(from_clock, from_reset, from_source, depth, sync))
 | 
					    PostQueueIrrevocablize(AsyncDecoupledFrom(from_clock, from_reset, from_source, depth, sync))
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					/**
 | 
				
			||||||
 | 
					 * This helper object synchronizes a level-sensitive signal from one
 | 
				
			||||||
 | 
					 * clock domain to another.
 | 
				
			||||||
 | 
					 */
 | 
				
			||||||
 | 
					object LevelSyncCrossing {
 | 
				
			||||||
 | 
					  class SynchronizerBackend(sync: Int, _clock: Clock) extends Module(Some(_clock)) {
 | 
				
			||||||
 | 
					    val io = new Bundle {
 | 
				
			||||||
 | 
					      val in = Bool(INPUT)
 | 
				
			||||||
 | 
					      val out = Bool(OUTPUT)
 | 
				
			||||||
 | 
					    }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    io.out := ShiftRegister(io.in, sync)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  class SynchronizerFrontend(_clock: Clock) extends Module(Some(_clock)) {
 | 
				
			||||||
 | 
					    val io = new Bundle {
 | 
				
			||||||
 | 
					      val in = Bool(INPUT)
 | 
				
			||||||
 | 
					      val out = Bool(OUTPUT)
 | 
				
			||||||
 | 
					    }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    io.out := RegNext(io.in)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  def apply(from_clock: Clock, to_clock: Clock, in: Bool, sync: Int = 2): Bool = {
 | 
				
			||||||
 | 
					    val front = Module(new SynchronizerFrontend(from_clock))
 | 
				
			||||||
 | 
					    val back = Module(new SynchronizerBackend(sync, to_clock))
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    front.io.in := in
 | 
				
			||||||
 | 
					    back.io.in := front.io.out
 | 
				
			||||||
 | 
					    back.io.out
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					object LevelSyncTo {
 | 
				
			||||||
 | 
					  def apply(to_clock: Clock, in: Bool, sync: Int = 2): Bool = {
 | 
				
			||||||
 | 
					    val scope = AsyncScope()
 | 
				
			||||||
 | 
					    LevelSyncCrossing(scope.clock, to_clock, in, sync)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					object LevelSyncFrom {
 | 
				
			||||||
 | 
					  def apply(from_clock: Clock, in: Bool, sync: Int = 2): Bool = {
 | 
				
			||||||
 | 
					    val scope = AsyncScope()
 | 
				
			||||||
 | 
					    LevelSyncCrossing(from_clock, scope.clock, in, sync)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -119,7 +119,7 @@ class DCache(implicit p: Parameters) extends L1HellaCacheModule()(p) {
 | 
				
			|||||||
      require(nWays == 1)
 | 
					      require(nWays == 1)
 | 
				
			||||||
      metaWriteArb.io.out.ready := true
 | 
					      metaWriteArb.io.out.ready := true
 | 
				
			||||||
      metaReadArb.io.out.ready := !metaWriteArb.io.out.valid
 | 
					      metaReadArb.io.out.ready := !metaWriteArb.io.out.valid
 | 
				
			||||||
      val inScratchpad = addrMap(s"io:int:dmem${tileId}").containsAddress(s1_paddr)
 | 
					      val inScratchpad = addrMap(s"io:cbus:dmem${tileId}").containsAddress(s1_paddr)
 | 
				
			||||||
      val hitState = Mux(inScratchpad, ClientMetadata.onReset.onHit(M_XWR), ClientMetadata.onReset)
 | 
					      val hitState = Mux(inScratchpad, ClientMetadata.onReset.onHit(M_XWR), ClientMetadata.onReset)
 | 
				
			||||||
      (inScratchpad, hitState, L1Metadata(UInt(0), ClientMetadata.onReset))
 | 
					      (inScratchpad, hitState, L1Metadata(UInt(0), ClientMetadata.onReset))
 | 
				
			||||||
    } else {
 | 
					    } else {
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -22,22 +22,35 @@ case class RoccParameters(
 | 
				
			|||||||
  nPTWPorts : Int = 0,
 | 
					  nPTWPorts : Int = 0,
 | 
				
			||||||
  useFPU: Boolean = false)
 | 
					  useFPU: Boolean = false)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					case class TileBundleConfig(
 | 
				
			||||||
 | 
					  nCachedTileLinkPorts: Int,
 | 
				
			||||||
 | 
					  nUncachedTileLinkPorts: Int,
 | 
				
			||||||
 | 
					  xLen: Int,
 | 
				
			||||||
 | 
					  hasSlavePort: Boolean)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class TileIO(c: TileBundleConfig)(implicit p: Parameters) extends Bundle {
 | 
				
			||||||
 | 
					  val cached = Vec(c.nCachedTileLinkPorts, new ClientTileLinkIO)
 | 
				
			||||||
 | 
					  val uncached = Vec(c.nUncachedTileLinkPorts, new ClientUncachedTileLinkIO)
 | 
				
			||||||
 | 
					  val hartid = UInt(INPUT, c.xLen)
 | 
				
			||||||
 | 
					  val interrupts = new TileInterrupts().asInput
 | 
				
			||||||
 | 
					  val slave = c.hasSlavePort.option(new ClientUncachedTileLinkIO().flip)
 | 
				
			||||||
 | 
					  val resetVector = UInt(INPUT, c.xLen)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  override def cloneType = new TileIO(c).asInstanceOf[this.type]
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
abstract class Tile(clockSignal: Clock = null, resetSignal: Bool = null)
 | 
					abstract class Tile(clockSignal: Clock = null, resetSignal: Bool = null)
 | 
				
			||||||
    (implicit p: Parameters) extends Module(Option(clockSignal), Option(resetSignal)) {
 | 
					    (implicit p: Parameters) extends Module(Option(clockSignal), Option(resetSignal)) {
 | 
				
			||||||
  val nCachedTileLinkPorts = p(NCachedTileLinkPorts)
 | 
					  val nCachedTileLinkPorts = p(NCachedTileLinkPorts)
 | 
				
			||||||
  val nUncachedTileLinkPorts = p(NUncachedTileLinkPorts)
 | 
					  val nUncachedTileLinkPorts = p(NUncachedTileLinkPorts)
 | 
				
			||||||
  val dcacheParams = p.alterPartial({ case CacheName => "L1D" })
 | 
					  val dcacheParams = p.alterPartial({ case CacheName => "L1D" })
 | 
				
			||||||
 | 
					  val bc = TileBundleConfig(
 | 
				
			||||||
 | 
					    nCachedTileLinkPorts = nCachedTileLinkPorts,
 | 
				
			||||||
 | 
					    nUncachedTileLinkPorts = nUncachedTileLinkPorts,
 | 
				
			||||||
 | 
					    xLen = p(XLen),
 | 
				
			||||||
 | 
					    hasSlavePort = p(DataScratchpadSize) > 0)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  class TileIO extends Bundle {
 | 
					  val io = new TileIO(bc)
 | 
				
			||||||
    val cached = Vec(nCachedTileLinkPorts, new ClientTileLinkIO)
 | 
					 | 
				
			||||||
    val uncached = Vec(nUncachedTileLinkPorts, new ClientUncachedTileLinkIO)
 | 
					 | 
				
			||||||
    val hartid = UInt(INPUT, p(XLen))
 | 
					 | 
				
			||||||
    val interrupts = new TileInterrupts().asInput
 | 
					 | 
				
			||||||
    val slave = (p(DataScratchpadSize) > 0).option(new ClientUncachedTileLinkIO().flip)
 | 
					 | 
				
			||||||
    val resetVector = UInt(INPUT, p(XLen))
 | 
					 | 
				
			||||||
  }
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
  val io = new TileIO
 | 
					 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class RocketTile(clockSignal: Clock = null, resetSignal: Bool = null)
 | 
					class RocketTile(clockSignal: Clock = null, resetSignal: Bool = null)
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -18,7 +18,7 @@ case object GlobalAddrMap extends Field[AddrMap]
 | 
				
			|||||||
case object ConfigString extends Field[String]
 | 
					case object ConfigString extends Field[String]
 | 
				
			||||||
case object NCoreplexExtClients extends Field[Int]
 | 
					case object NCoreplexExtClients extends Field[Int]
 | 
				
			||||||
/** Function for building Coreplex */
 | 
					/** Function for building Coreplex */
 | 
				
			||||||
case object BuildCoreplex extends Field[(Parameters, CoreplexConfig) => Coreplex]
 | 
					case object BuildCoreplex extends Field[(CoreplexConfig, Parameters) => BaseCoreplexModule[BaseCoreplex, BaseCoreplexBundle]]
 | 
				
			||||||
 | 
					
 | 
				
			||||||
/** Base Top with no Periphery */
 | 
					/** Base Top with no Periphery */
 | 
				
			||||||
abstract class BaseTop(q: Parameters) extends LazyModule {
 | 
					abstract class BaseTop(q: Parameters) extends LazyModule {
 | 
				
			||||||
@@ -36,8 +36,7 @@ abstract class BaseTop(q: Parameters) extends LazyModule {
 | 
				
			|||||||
    nExtInterrupts = pInterrupts.sum,
 | 
					    nExtInterrupts = pInterrupts.sum,
 | 
				
			||||||
    nSlaves = pBusMasters.sum,
 | 
					    nSlaves = pBusMasters.sum,
 | 
				
			||||||
    nMemChannels = q(NMemoryChannels),
 | 
					    nMemChannels = q(NMemoryChannels),
 | 
				
			||||||
    hasSupervisor = q(UseVM),
 | 
					    hasSupervisor = q(UseVM)
 | 
				
			||||||
    hasExtMMIOPort = true
 | 
					 | 
				
			||||||
  )
 | 
					  )
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  lazy val genGlobalAddrMap = GenerateGlobalAddrMap(q, pDevices.get, peripheryManagers)
 | 
					  lazy val genGlobalAddrMap = GenerateGlobalAddrMap(q, pDevices.get, peripheryManagers)
 | 
				
			||||||
@@ -53,21 +52,23 @@ abstract class BaseTop(q: Parameters) extends LazyModule {
 | 
				
			|||||||
  peripheryBus.node := TLBuffer(TLWidthWidget(TLHintHandler(legacy.node), legacy.tlDataBytes))
 | 
					  peripheryBus.node := TLBuffer(TLWidthWidget(TLHintHandler(legacy.node), legacy.tlDataBytes))
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class BaseTopBundle(val p: Parameters, val c: Coreplex) extends ParameterizedBundle()(p) {
 | 
					abstract class BaseTopBundle(val p: Parameters) extends Bundle {
 | 
				
			||||||
  val success = Bool(OUTPUT)
 | 
					  val success = Bool(OUTPUT)
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
abstract class BaseTopModule[+L <: BaseTop, +B <: BaseTopBundle](val p: Parameters, l: L, b: Coreplex => B) extends LazyModuleImp(l) {
 | 
					abstract class BaseTopModule[+L <: BaseTop, +B <: BaseTopBundle](
 | 
				
			||||||
 | 
					    val p: Parameters, l: L, b: => B) extends LazyModuleImp(l) {
 | 
				
			||||||
  val outer: L = l
 | 
					  val outer: L = l
 | 
				
			||||||
 | 
					  val io: B = b
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  val coreplex = p(BuildCoreplex)(p, outer.c)
 | 
					  val coreplex = p(BuildCoreplex)(outer.c, p)
 | 
				
			||||||
  val io: B = b(coreplex)
 | 
					  val coreplexIO = coreplex.io
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  val mmioNetwork =
 | 
					  val pBus =
 | 
				
			||||||
    Module(new TileLinkRecursiveInterconnect(1, p(GlobalAddrMap).subMap("io:ext"))(
 | 
					    Module(new TileLinkRecursiveInterconnect(1, p(GlobalAddrMap).subMap("io:pbus"))(
 | 
				
			||||||
      p.alterPartial({ case TLId => "L2toMMIO" })))
 | 
					      p.alterPartial({ case TLId => "L2toMMIO" })))
 | 
				
			||||||
  mmioNetwork.io.in.head <> coreplex.io.master.mmio.get
 | 
					  pBus.io.in.head <> coreplexIO.master.mmio
 | 
				
			||||||
  outer.legacy.module.io.legacy <> mmioNetwork.port("TL2")
 | 
					  outer.legacy.module.io.legacy <> pBus.port("TL2")
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  println("Generated Address Map")
 | 
					  println("Generated Address Map")
 | 
				
			||||||
  for (entry <- p(GlobalAddrMap).flatten) {
 | 
					  for (entry <- p(GlobalAddrMap).flatten) {
 | 
				
			||||||
@@ -86,5 +87,5 @@ abstract class BaseTopModule[+L <: BaseTop, +B <: BaseTopBundle](val p: Paramete
 | 
				
			|||||||
  println(p(ConfigString))
 | 
					  println(p(ConfigString))
 | 
				
			||||||
  ConfigStringOutput.contents = Some(p(ConfigString))
 | 
					  ConfigStringOutput.contents = Some(p(ConfigString))
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  io.success := coreplex.io.success
 | 
					  io.success := coreplexIO.success
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -40,7 +40,7 @@ class BasePlatformConfig extends Config(
 | 
				
			|||||||
            idBits = Dump("MEM_ID_BITS", site(MIFTagBits)))
 | 
					            idBits = Dump("MEM_ID_BITS", site(MIFTagBits)))
 | 
				
			||||||
        }
 | 
					        }
 | 
				
			||||||
        case BuildCoreplex =>
 | 
					        case BuildCoreplex =>
 | 
				
			||||||
          (p: Parameters, c: CoreplexConfig) => Module(new DefaultCoreplex(p, c))
 | 
					          (c: CoreplexConfig, p: Parameters) => uncore.tilelink2.LazyModule(new DefaultCoreplex(c)(p)).module
 | 
				
			||||||
        case NExtTopInterrupts => 2
 | 
					        case NExtTopInterrupts => 2
 | 
				
			||||||
        // Note that PLIC asserts that this is > 0.
 | 
					        // Note that PLIC asserts that this is > 0.
 | 
				
			||||||
        case AsyncDebugBus => false
 | 
					        case AsyncDebugBus => false
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -4,33 +4,66 @@ package rocketchip
 | 
				
			|||||||
 | 
					
 | 
				
			||||||
import Chisel._
 | 
					import Chisel._
 | 
				
			||||||
import cde.{Parameters, Field}
 | 
					import cde.{Parameters, Field}
 | 
				
			||||||
import coreplex.Coreplex
 | 
					import junctions._
 | 
				
			||||||
 | 
					import coreplex._
 | 
				
			||||||
import rocketchip._
 | 
					import rocketchip._
 | 
				
			||||||
 | 
					
 | 
				
			||||||
/** Example Top with Periphery */
 | 
					/** Example Top with Periphery */
 | 
				
			||||||
class ExampleTop(q: Parameters) extends BaseTop(q)
 | 
					class ExampleTop(q: Parameters) extends BaseTop(q)
 | 
				
			||||||
    with PeripheryBootROM with PeripheryDebug with PeripheryExtInterrupts with PeripheryCoreplexLocalInterrupter
 | 
					    with PeripheryBootROM
 | 
				
			||||||
    with PeripheryMasterMem with PeripheryMasterMMIO with PeripherySlave {
 | 
					    with PeripheryDebug
 | 
				
			||||||
  override lazy val module = Module(new ExampleTopModule(p, this, new ExampleTopBundle(p, _)))
 | 
					    with PeripheryExtInterrupts
 | 
				
			||||||
 | 
					    with PeripheryCoreplexLocalInterrupter
 | 
				
			||||||
 | 
					    with PeripheryMasterMem
 | 
				
			||||||
 | 
					    with PeripheryMasterMMIO
 | 
				
			||||||
 | 
					    with PeripherySlave {
 | 
				
			||||||
 | 
					  override lazy val module = Module(new ExampleTopModule(p, this, new ExampleTopBundle(p)))
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class ExampleTopBundle(p: Parameters, c: Coreplex) extends BaseTopBundle(p, c)
 | 
					class ExampleTopBundle(p: Parameters) extends BaseTopBundle(p)
 | 
				
			||||||
    with PeripheryBootROMBundle with PeripheryDebugBundle with PeripheryExtInterruptsBundle with PeripheryCoreplexLocalInterrupterBundle
 | 
					    with PeripheryBootROMBundle
 | 
				
			||||||
    with PeripheryMasterMemBundle with PeripheryMasterMMIOBundle with PeripherySlaveBundle
 | 
					    with PeripheryDebugBundle
 | 
				
			||||||
 | 
					    with PeripheryExtInterruptsBundle
 | 
				
			||||||
 | 
					    with PeripheryCoreplexLocalInterrupterBundle
 | 
				
			||||||
 | 
					    with PeripheryMasterMemBundle
 | 
				
			||||||
 | 
					    with PeripheryMasterMMIOBundle
 | 
				
			||||||
 | 
					    with PeripherySlaveBundle
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class ExampleTopModule[+L <: ExampleTop, +B <: ExampleTopBundle](p: Parameters, l: L, b: Coreplex => B) extends BaseTopModule(p, l, b)
 | 
					class ExampleTopModule[+L <: ExampleTop, +B <: ExampleTopBundle](p: Parameters, l: L, b: => B) extends BaseTopModule(p, l, b)
 | 
				
			||||||
    with PeripheryBootROMModule with PeripheryDebugModule with PeripheryExtInterruptsModule with PeripheryCoreplexLocalInterrupterModule
 | 
					    with PeripheryBootROMModule
 | 
				
			||||||
    with PeripheryMasterMemModule with PeripheryMasterMMIOModule with PeripherySlaveModule
 | 
					    with PeripheryDebugModule
 | 
				
			||||||
 | 
					    with PeripheryExtInterruptsModule
 | 
				
			||||||
 | 
					    with PeripheryCoreplexLocalInterrupterModule
 | 
				
			||||||
 | 
					    with PeripheryMasterMemModule
 | 
				
			||||||
 | 
					    with PeripheryMasterMMIOModule
 | 
				
			||||||
 | 
					    with PeripherySlaveModule
 | 
				
			||||||
    with HardwiredResetVector
 | 
					    with HardwiredResetVector
 | 
				
			||||||
 | 
					
 | 
				
			||||||
/** Example Top with TestRAM */
 | 
					/** Example Top with TestRAM */
 | 
				
			||||||
class ExampleTopWithTestRAM(q: Parameters) extends ExampleTop(q)
 | 
					class ExampleTopWithTestRAM(q: Parameters) extends ExampleTop(q)
 | 
				
			||||||
    with PeripheryTestRAM {
 | 
					    with PeripheryTestRAM {
 | 
				
			||||||
  override lazy val module = Module(new ExampleTopWithTestRAMModule(p, this, new ExampleTopWithTestRAMBundle(p, _)))
 | 
					  override lazy val module = Module(new ExampleTopWithTestRAMModule(p, this, new ExampleTopWithTestRAMBundle(p)))
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class ExampleTopWithTestRAMBundle(p: Parameters, c: Coreplex) extends ExampleTopBundle(p, c)
 | 
					class ExampleTopWithTestRAMBundle(p: Parameters) extends ExampleTopBundle(p)
 | 
				
			||||||
    with PeripheryTestRAMBundle
 | 
					    with PeripheryTestRAMBundle
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class ExampleTopWithTestRAMModule[+L <: ExampleTopWithTestRAM, +B <: ExampleTopWithTestRAMBundle](p: Parameters, l: L, b: Coreplex => B) extends ExampleTopModule(p, l, b)
 | 
					class ExampleTopWithTestRAMModule[+L <: ExampleTopWithTestRAM, +B <: ExampleTopWithTestRAMBundle](p: Parameters, l: L, b: => B) extends ExampleTopModule(p, l, b)
 | 
				
			||||||
    with PeripheryTestRAMModule
 | 
					    with PeripheryTestRAMModule
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					/** Example Top with Multi Clock */
 | 
				
			||||||
 | 
					class ExampleMultiClockTop(q: Parameters) extends ExampleTop(q)
 | 
				
			||||||
 | 
					    with PeripheryTestRAM {
 | 
				
			||||||
 | 
					  override lazy val module = Module(new ExampleMultiClockTopModule(p, this, new ExampleMultiClockTopBundle(p)))
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class ExampleMultiClockTopBundle(p: Parameters) extends ExampleTopBundle(p)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					class ExampleMultiClockTopModule[+L <: ExampleMultiClockTop, +B <: ExampleMultiClockTopBundle](p: Parameters, l: L, b: => B) extends ExampleTopModule(p, l, b) {
 | 
				
			||||||
 | 
					  val multiClockCoreplexIO = coreplexIO.asInstanceOf[MultiClockCoreplexBundle]
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  multiClockCoreplexIO.tcrs foreach { tcr =>
 | 
				
			||||||
 | 
					    tcr.clock := clock
 | 
				
			||||||
 | 
					    tcr.reset := reset
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -101,16 +101,16 @@ trait PeripheryDebugModule {
 | 
				
			|||||||
  implicit val p: Parameters
 | 
					  implicit val p: Parameters
 | 
				
			||||||
  val outer: PeripheryDebug
 | 
					  val outer: PeripheryDebug
 | 
				
			||||||
  val io: PeripheryDebugBundle
 | 
					  val io: PeripheryDebugBundle
 | 
				
			||||||
  val coreplex: Coreplex
 | 
					  val coreplexIO: BaseCoreplexBundle
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  if (p(IncludeJtagDTM)) {
 | 
					  if (p(IncludeJtagDTM)) {
 | 
				
			||||||
    // JtagDTMWithSync is a wrapper which
 | 
					    // JtagDTMWithSync is a wrapper which
 | 
				
			||||||
    // handles the synchronization as well.
 | 
					    // handles the synchronization as well.
 | 
				
			||||||
    val dtm = Module (new JtagDTMWithSync()(p))
 | 
					    val dtm = Module (new JtagDTMWithSync()(p))
 | 
				
			||||||
    dtm.io.jtag <> io.jtag.get
 | 
					    dtm.io.jtag <> io.jtag.get
 | 
				
			||||||
    coreplex.io.debug <> dtm.io.debug
 | 
					    coreplexIO.debug <> dtm.io.debug
 | 
				
			||||||
  } else {
 | 
					  } else {
 | 
				
			||||||
    coreplex.io.debug <>
 | 
					    coreplexIO.debug <>
 | 
				
			||||||
      (if (p(AsyncDebugBus)) AsyncDebugBusFrom(io.debug_clk.get, io.debug_rst.get, io.debug.get)
 | 
					      (if (p(AsyncDebugBus)) AsyncDebugBusFrom(io.debug_clk.get, io.debug_rst.get, io.debug.get)
 | 
				
			||||||
      else io.debug.get)
 | 
					      else io.debug.get)
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
@@ -134,12 +134,12 @@ trait PeripheryExtInterruptsModule {
 | 
				
			|||||||
  implicit val p: Parameters
 | 
					  implicit val p: Parameters
 | 
				
			||||||
  val outer: PeripheryExtInterrupts
 | 
					  val outer: PeripheryExtInterrupts
 | 
				
			||||||
  val io: PeripheryExtInterruptsBundle
 | 
					  val io: PeripheryExtInterruptsBundle
 | 
				
			||||||
  val coreplex: Coreplex
 | 
					  val coreplexIO: BaseCoreplexBundle
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  {
 | 
					  {
 | 
				
			||||||
    val r = outer.pInterrupts.range("ext")
 | 
					    val r = outer.pInterrupts.range("ext")
 | 
				
			||||||
    ((r._1 until r._2) zipWithIndex) foreach { case (c, i) =>
 | 
					    ((r._1 until r._2) zipWithIndex) foreach { case (c, i) =>
 | 
				
			||||||
      coreplex.io.interrupts(c) := io.interrupts(i)
 | 
					      coreplexIO.interrupts(c) := io.interrupts(i)
 | 
				
			||||||
    }
 | 
					    }
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
@@ -163,10 +163,10 @@ trait PeripheryMasterMemModule extends HasPeripheryParameters {
 | 
				
			|||||||
  implicit val p: Parameters
 | 
					  implicit val p: Parameters
 | 
				
			||||||
  val outer: PeripheryMasterMem
 | 
					  val outer: PeripheryMasterMem
 | 
				
			||||||
  val io: PeripheryMasterMemBundle
 | 
					  val io: PeripheryMasterMemBundle
 | 
				
			||||||
  val coreplex: Coreplex
 | 
					  val coreplexIO: BaseCoreplexBundle
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  // Abuse the fact that zip takes the shorter of the two lists
 | 
					  // Abuse the fact that zip takes the shorter of the two lists
 | 
				
			||||||
  ((io.mem_axi zip coreplex.io.master.mem) zipWithIndex) foreach { case ((axi, mem), idx) =>
 | 
					  ((io.mem_axi zip coreplexIO.master.mem) zipWithIndex) foreach { case ((axi, mem), idx) =>
 | 
				
			||||||
    val axi_sync = PeripheryUtils.convertTLtoAXI(mem)(outermostParams)
 | 
					    val axi_sync = PeripheryUtils.convertTLtoAXI(mem)(outermostParams)
 | 
				
			||||||
    axi_sync.ar.bits.cache := CACHE_NORMAL_NOCACHE_BUF
 | 
					    axi_sync.ar.bits.cache := CACHE_NORMAL_NOCACHE_BUF
 | 
				
			||||||
    axi_sync.aw.bits.cache := CACHE_NORMAL_NOCACHE_BUF
 | 
					    axi_sync.aw.bits.cache := CACHE_NORMAL_NOCACHE_BUF
 | 
				
			||||||
@@ -176,11 +176,11 @@ trait PeripheryMasterMemModule extends HasPeripheryParameters {
 | 
				
			|||||||
    )
 | 
					    )
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  (io.mem_ahb zip coreplex.io.master.mem) foreach { case (ahb, mem) =>
 | 
					  (io.mem_ahb zip coreplexIO.master.mem) foreach { case (ahb, mem) =>
 | 
				
			||||||
    ahb <> PeripheryUtils.convertTLtoAHB(mem, atomics = false)(outermostParams)
 | 
					    ahb <> PeripheryUtils.convertTLtoAHB(mem, atomics = false)(outermostParams)
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  (io.mem_tl zip coreplex.io.master.mem) foreach { case (tl, mem) =>
 | 
					  (io.mem_tl zip coreplexIO.master.mem) foreach { case (tl, mem) =>
 | 
				
			||||||
    tl <> TileLinkEnqueuer(mem, 2)(outermostParams)
 | 
					    tl <> TileLinkEnqueuer(mem, 2)(outermostParams)
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
@@ -204,10 +204,10 @@ trait PeripheryMasterMMIOModule extends HasPeripheryParameters {
 | 
				
			|||||||
  implicit val p: Parameters
 | 
					  implicit val p: Parameters
 | 
				
			||||||
  val outer: PeripheryMasterMMIO
 | 
					  val outer: PeripheryMasterMMIO
 | 
				
			||||||
  val io: PeripheryMasterMMIOBundle
 | 
					  val io: PeripheryMasterMMIOBundle
 | 
				
			||||||
  val mmioNetwork: TileLinkRecursiveInterconnect
 | 
					  val pBus: TileLinkRecursiveInterconnect
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  val mmio_ports = p(ExtMMIOPorts) map { port =>
 | 
					  val mmio_ports = p(ExtMMIOPorts) map { port =>
 | 
				
			||||||
    TileLinkWidthAdapter(mmioNetwork.port(port.name), "MMIO_Outermost")
 | 
					    TileLinkWidthAdapter(pBus.port(port.name), "MMIO_Outermost")
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  val mmio_axi_start = 0
 | 
					  val mmio_axi_start = 0
 | 
				
			||||||
@@ -258,7 +258,7 @@ trait PeripherySlaveModule extends HasPeripheryParameters {
 | 
				
			|||||||
  implicit val p: Parameters
 | 
					  implicit val p: Parameters
 | 
				
			||||||
  val outer: PeripherySlave
 | 
					  val outer: PeripherySlave
 | 
				
			||||||
  val io: PeripherySlaveBundle
 | 
					  val io: PeripherySlaveBundle
 | 
				
			||||||
  val coreplex: Coreplex
 | 
					  val coreplexIO: BaseCoreplexBundle
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  if (p(NExtBusAXIChannels) > 0) {
 | 
					  if (p(NExtBusAXIChannels) > 0) {
 | 
				
			||||||
    val arb = Module(new NastiArbiter(p(NExtBusAXIChannels)))
 | 
					    val arb = Module(new NastiArbiter(p(NExtBusAXIChannels)))
 | 
				
			||||||
@@ -273,7 +273,7 @@ trait PeripherySlaveModule extends HasPeripheryParameters {
 | 
				
			|||||||
 | 
					
 | 
				
			||||||
    val r = outer.pBusMasters.range("ext")
 | 
					    val r = outer.pBusMasters.range("ext")
 | 
				
			||||||
    require(r._2 - r._1 == 1, "RangeManager should return 1 slot")
 | 
					    require(r._2 - r._1 == 1, "RangeManager should return 1 slot")
 | 
				
			||||||
    coreplex.io.slave(r._1) <> conv.io.tl
 | 
					    coreplexIO.slave(r._1) <> conv.io.tl
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
@@ -299,10 +299,10 @@ trait PeripheryCoreplexLocalInterrupterModule extends HasPeripheryParameters {
 | 
				
			|||||||
  implicit val p: Parameters
 | 
					  implicit val p: Parameters
 | 
				
			||||||
  val outer: PeripheryCoreplexLocalInterrupter
 | 
					  val outer: PeripheryCoreplexLocalInterrupter
 | 
				
			||||||
  val io: PeripheryCoreplexLocalInterrupterBundle
 | 
					  val io: PeripheryCoreplexLocalInterrupterBundle
 | 
				
			||||||
  val coreplex: Coreplex
 | 
					  val coreplexIO: BaseCoreplexBundle
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  outer.clint.module.io.rtcTick := Counter(p(RTCPeriod)).inc()
 | 
					  outer.clint.module.io.rtcTick := Counter(p(RTCPeriod)).inc()
 | 
				
			||||||
  coreplex.io.clint <> outer.clint.module.io.tiles
 | 
					  coreplexIO.clint <> outer.clint.module.io.tiles
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
/////
 | 
					/////
 | 
				
			||||||
@@ -371,6 +371,6 @@ trait PeripheryTestBusMasterModule {
 | 
				
			|||||||
/////
 | 
					/////
 | 
				
			||||||
 | 
					
 | 
				
			||||||
trait HardwiredResetVector {
 | 
					trait HardwiredResetVector {
 | 
				
			||||||
  val coreplex: Coreplex
 | 
					  val coreplexIO: BaseCoreplexBundle
 | 
				
			||||||
  coreplex.io.resetVector := UInt(0x1000) // boot ROM
 | 
					  coreplexIO.resetVector := UInt(0x1000) // boot ROM
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -53,7 +53,7 @@ class GlobalVariable[T] {
 | 
				
			|||||||
 | 
					
 | 
				
			||||||
object GenerateGlobalAddrMap {
 | 
					object GenerateGlobalAddrMap {
 | 
				
			||||||
  def apply(p: Parameters, pDevicesEntries: Seq[AddrMapEntry], peripheryManagers: Seq[TLManagerParameters]) = {
 | 
					  def apply(p: Parameters, pDevicesEntries: Seq[AddrMapEntry], peripheryManagers: Seq[TLManagerParameters]) = {
 | 
				
			||||||
    lazy val intIOAddrMap: AddrMap = {
 | 
					    lazy val cBusIOAddrMap: AddrMap = {
 | 
				
			||||||
      val entries = collection.mutable.ArrayBuffer[AddrMapEntry]()
 | 
					      val entries = collection.mutable.ArrayBuffer[AddrMapEntry]()
 | 
				
			||||||
      entries += AddrMapEntry("debug", MemSize(4096, MemAttr(AddrMapProt.RWX)))
 | 
					      entries += AddrMapEntry("debug", MemSize(4096, MemAttr(AddrMapProt.RWX)))
 | 
				
			||||||
      entries += AddrMapEntry("plic", MemRange(0x40000000, 0x4000000, MemAttr(AddrMapProt.RW)))
 | 
					      entries += AddrMapEntry("plic", MemRange(0x40000000, 0x4000000, MemAttr(AddrMapProt.RW)))
 | 
				
			||||||
@@ -84,15 +84,15 @@ object GenerateGlobalAddrMap {
 | 
				
			|||||||
    }.flatten
 | 
					    }.flatten
 | 
				
			||||||
 | 
					
 | 
				
			||||||
    lazy val tl2AddrMap = new AddrMap(tl2Devices, collapse = true)
 | 
					    lazy val tl2AddrMap = new AddrMap(tl2Devices, collapse = true)
 | 
				
			||||||
    lazy val extIOAddrMap = new AddrMap(AddrMapEntry("TL2", tl2AddrMap) +: (p(ExtMMIOPorts) ++ pDevicesEntries), collapse = true)
 | 
					    lazy val pBusIOAddrMap = new AddrMap(AddrMapEntry("TL2", tl2AddrMap) +: (p(ExtMMIOPorts) ++ pDevicesEntries), collapse = true)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
    val memBase = 0x80000000L
 | 
					    val memBase = 0x80000000L
 | 
				
			||||||
    val memSize = p(ExtMemSize)
 | 
					    val memSize = p(ExtMemSize)
 | 
				
			||||||
    Dump("MEM_BASE", memBase)
 | 
					    Dump("MEM_BASE", memBase)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
    val intern = AddrMapEntry("int", intIOAddrMap)
 | 
					    val cBus = AddrMapEntry("cbus", cBusIOAddrMap)
 | 
				
			||||||
    val extern = AddrMapEntry("ext", extIOAddrMap)
 | 
					    val pBus = AddrMapEntry("pbus", pBusIOAddrMap)
 | 
				
			||||||
    val io = AddrMapEntry("io", AddrMap((intern +: (!extIOAddrMap.isEmpty).option(extern).toSeq):_*))
 | 
					    val io = AddrMapEntry("io", AddrMap((cBus +: (!pBusIOAddrMap.isEmpty).option(pBus).toSeq):_*))
 | 
				
			||||||
    val mem = AddrMapEntry("mem", MemRange(memBase, memSize, MemAttr(AddrMapProt.RWX, true)))
 | 
					    val mem = AddrMapEntry("mem", MemRange(memBase, memSize, MemAttr(AddrMapProt.RWX, true)))
 | 
				
			||||||
    AddrMap((io +: (p(NMemoryChannels) > 0).option(mem).toSeq):_*)
 | 
					    AddrMap((io +: (p(NMemoryChannels) > 0).option(mem).toSeq):_*)
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
@@ -101,8 +101,8 @@ object GenerateGlobalAddrMap {
 | 
				
			|||||||
object GenerateConfigString {
 | 
					object GenerateConfigString {
 | 
				
			||||||
  def apply(p: Parameters, c: CoreplexConfig, pDevicesEntries: Seq[AddrMapEntry], peripheryManagers: Seq[TLManagerParameters]) = {
 | 
					  def apply(p: Parameters, c: CoreplexConfig, pDevicesEntries: Seq[AddrMapEntry], peripheryManagers: Seq[TLManagerParameters]) = {
 | 
				
			||||||
    val addrMap = p(GlobalAddrMap)
 | 
					    val addrMap = p(GlobalAddrMap)
 | 
				
			||||||
    val plicAddr = addrMap("io:int:plic").start
 | 
					    val plicAddr = addrMap("io:cbus:plic").start
 | 
				
			||||||
    val clint = CoreplexLocalInterrupterConfig(0, addrMap("io:ext:TL2:clint").start)
 | 
					    val clint = CoreplexLocalInterrupterConfig(0, addrMap("io:pbus:TL2:clint").start)
 | 
				
			||||||
    val xLen = p(XLen)
 | 
					    val xLen = p(XLen)
 | 
				
			||||||
    val res = new StringBuilder
 | 
					    val res = new StringBuilder
 | 
				
			||||||
    res append  "plic {\n"
 | 
					    res append  "plic {\n"
 | 
				
			||||||
@@ -155,7 +155,7 @@ object GenerateConfigString {
 | 
				
			|||||||
    }
 | 
					    }
 | 
				
			||||||
    res append  "};\n"
 | 
					    res append  "};\n"
 | 
				
			||||||
    pDevicesEntries foreach { entry =>
 | 
					    pDevicesEntries foreach { entry =>
 | 
				
			||||||
      val region = addrMap("io:ext:" + entry.name)
 | 
					      val region = addrMap("io:pbus:" + entry.name)
 | 
				
			||||||
      res append s"${entry.name} {\n"
 | 
					      res append s"${entry.name} {\n"
 | 
				
			||||||
      res append s"  addr 0x${region.start.toString(16)};\n"
 | 
					      res append s"  addr 0x${region.start.toString(16)};\n"
 | 
				
			||||||
      res append s"  size 0x${region.size.toString(16)}; \n"
 | 
					      res append s"  size 0x${region.size.toString(16)}; \n"
 | 
				
			||||||
 
 | 
				
			|||||||
							
								
								
									
										53
									
								
								src/main/scala/uncore/tilelink/Crossing.scala
									
									
									
									
									
										Normal file
									
								
							
							
						
						
									
										53
									
								
								src/main/scala/uncore/tilelink/Crossing.scala
									
									
									
									
									
										Normal file
									
								
							@@ -0,0 +1,53 @@
 | 
				
			|||||||
 | 
					package uncore.tilelink
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					import Chisel._
 | 
				
			||||||
 | 
					import junctions._
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					object AsyncClientUncachedTileLinkCrossing {
 | 
				
			||||||
 | 
					  def apply(from_clock: Clock, from_reset: Bool, from_source: ClientUncachedTileLinkIO, to_clock: Clock, to_reset: Bool, depth: Int = 8, sync: Int = 3): ClientUncachedTileLinkIO = {
 | 
				
			||||||
 | 
					    val to_sink = Wire(new ClientUncachedTileLinkIO()(from_source.p))
 | 
				
			||||||
 | 
					    to_sink.acquire <> AsyncDecoupledCrossing(from_clock, from_reset, from_source.acquire, to_clock, to_reset, depth, sync)
 | 
				
			||||||
 | 
					    from_source.grant <> AsyncDecoupledCrossing(to_clock, to_reset, to_sink.grant, from_clock, from_reset, depth, sync)
 | 
				
			||||||
 | 
					    to_sink
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					object AsyncClientTileLinkCrossing {
 | 
				
			||||||
 | 
					  def apply(from_clock: Clock, from_reset: Bool, from_source: ClientTileLinkIO, to_clock: Clock, to_reset: Bool, depth: Int = 8, sync: Int = 3): ClientTileLinkIO = {
 | 
				
			||||||
 | 
					    val to_sink = Wire(new ClientTileLinkIO()(from_source.p))
 | 
				
			||||||
 | 
					    to_sink.acquire <> AsyncDecoupledCrossing(from_clock, from_reset, from_source.acquire, to_clock, to_reset, depth, sync)
 | 
				
			||||||
 | 
					    to_sink.release <> AsyncDecoupledCrossing(from_clock, from_reset, from_source.release, to_clock, to_reset, depth, sync)
 | 
				
			||||||
 | 
					    to_sink.finish <> AsyncDecoupledCrossing(from_clock, from_reset, from_source.finish, to_clock, to_reset, depth, sync)
 | 
				
			||||||
 | 
					    from_source.grant <> AsyncDecoupledCrossing(to_clock, to_reset, to_sink.grant, from_clock, from_reset, depth, sync)
 | 
				
			||||||
 | 
					    from_source.probe <> AsyncDecoupledCrossing(to_clock, to_reset, to_sink.probe, from_clock, from_reset, depth, sync)
 | 
				
			||||||
 | 
					    to_sink
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					object AsyncUTileLinkTo {
 | 
				
			||||||
 | 
					  def apply(to_clock: Clock, to_reset: Bool, source: ClientUncachedTileLinkIO, depth: Int = 8, sync: Int = 3): ClientUncachedTileLinkIO = {
 | 
				
			||||||
 | 
					    val scope = AsyncScope()
 | 
				
			||||||
 | 
					    AsyncClientUncachedTileLinkCrossing(scope.clock, scope.reset, source, to_clock, to_reset, depth, sync)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					object AsyncUTileLinkFrom {
 | 
				
			||||||
 | 
					  def apply(from_clock: Clock, from_reset: Bool, from_source: ClientUncachedTileLinkIO, depth: Int = 8, sync: Int = 3): ClientUncachedTileLinkIO = {
 | 
				
			||||||
 | 
					    val scope = AsyncScope()
 | 
				
			||||||
 | 
					    AsyncClientUncachedTileLinkCrossing(from_clock, from_reset, from_source, scope.clock, scope.reset, depth, sync)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					object AsyncTileLinkTo {
 | 
				
			||||||
 | 
					  def apply(to_clock: Clock, to_reset: Bool, source: ClientTileLinkIO, depth: Int = 8, sync: Int = 3): ClientTileLinkIO = {
 | 
				
			||||||
 | 
					    val scope = AsyncScope()
 | 
				
			||||||
 | 
					    AsyncClientTileLinkCrossing(scope.clock, scope.reset, source, to_clock, to_reset, depth, sync)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					object AsyncTileLinkFrom {
 | 
				
			||||||
 | 
					  def apply(from_clock: Clock, from_reset: Bool, from_source: ClientTileLinkIO, depth: Int = 8, sync: Int = 3): ClientTileLinkIO = {
 | 
				
			||||||
 | 
					    val scope = AsyncScope()
 | 
				
			||||||
 | 
					    AsyncClientTileLinkCrossing(from_clock, from_reset, from_source, scope.clock, scope.reset, depth, sync)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
@@ -168,6 +168,7 @@ class TLFragmenter(minSize: Int, maxSize: Int, alwaysMin: Boolean = false) exten
 | 
				
			|||||||
    out.d.ready := in.d.ready || drop
 | 
					    out.d.ready := in.d.ready || drop
 | 
				
			||||||
    in.d.valid  := out.d.valid && !drop
 | 
					    in.d.valid  := out.d.valid && !drop
 | 
				
			||||||
    in.d.bits   := out.d.bits // pass most stuff unchanged
 | 
					    in.d.bits   := out.d.bits // pass most stuff unchanged
 | 
				
			||||||
 | 
					    in.d.bits.addr_lo := out.d.bits.addr_lo & ~dsizeOH1
 | 
				
			||||||
    in.d.bits.source := out.d.bits.source >> fragmentBits
 | 
					    in.d.bits.source := out.d.bits.source >> fragmentBits
 | 
				
			||||||
    in.d.bits.size   := Mux(dFirst, dFirst_size, dOrig)
 | 
					    in.d.bits.size   := Mux(dFirst, dFirst_size, dOrig)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -4,6 +4,7 @@ package uncore.tilelink2
 | 
				
			|||||||
import Chisel._
 | 
					import Chisel._
 | 
				
			||||||
import chisel3.util.LFSR16
 | 
					import chisel3.util.LFSR16
 | 
				
			||||||
import unittest._
 | 
					import unittest._
 | 
				
			||||||
 | 
					import util.Pow2ClockDivider
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class IDMapGenerator(numIds: Int) extends Module {
 | 
					class IDMapGenerator(numIds: Int) extends Module {
 | 
				
			||||||
  val w = log2Up(numIds)
 | 
					  val w = log2Up(numIds)
 | 
				
			||||||
@@ -208,15 +209,6 @@ class TLFuzzer(
 | 
				
			|||||||
  }
 | 
					  }
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class ClockDivider extends BlackBox {
 | 
					 | 
				
			||||||
  val io = new Bundle {
 | 
					 | 
				
			||||||
    val clock_in  = Clock(INPUT)
 | 
					 | 
				
			||||||
    val reset_in  = Bool(INPUT)
 | 
					 | 
				
			||||||
    val clock_out = Clock(OUTPUT)
 | 
					 | 
				
			||||||
    val reset_out = Bool(OUTPUT)
 | 
					 | 
				
			||||||
  }
 | 
					 | 
				
			||||||
}
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
class TLFuzzRAM extends LazyModule
 | 
					class TLFuzzRAM extends LazyModule
 | 
				
			||||||
{
 | 
					{
 | 
				
			||||||
  val model = LazyModule(new TLRAMModel)
 | 
					  val model = LazyModule(new TLRAMModel)
 | 
				
			||||||
@@ -240,17 +232,14 @@ class TLFuzzRAM extends LazyModule
 | 
				
			|||||||
    io.finished := fuzz.module.io.finished
 | 
					    io.finished := fuzz.module.io.finished
 | 
				
			||||||
 | 
					
 | 
				
			||||||
    // Shove the RAM into another clock domain
 | 
					    // Shove the RAM into another clock domain
 | 
				
			||||||
    val clocks = Module(new ClockDivider)
 | 
					    val clocks = Module(new Pow2ClockDivider(2))
 | 
				
			||||||
    ram.module.clock := clocks.io.clock_out
 | 
					    ram.module.clock := clocks.io.clock_out
 | 
				
			||||||
    ram.module.reset := clocks.io.reset_out
 | 
					 | 
				
			||||||
    clocks.io.clock_in := clock
 | 
					 | 
				
			||||||
    clocks.io.reset_in := reset
 | 
					 | 
				
			||||||
 | 
					
 | 
				
			||||||
    // ... and safely cross TL2 into it
 | 
					    // ... and safely cross TL2 into it
 | 
				
			||||||
    cross.module.io.in_clock := clock
 | 
					    cross.module.io.in_clock := clock
 | 
				
			||||||
    cross.module.io.in_reset := reset
 | 
					    cross.module.io.in_reset := reset
 | 
				
			||||||
    cross.module.io.out_clock := clocks.io.clock_out
 | 
					    cross.module.io.out_clock := clocks.io.clock_out
 | 
				
			||||||
    cross.module.io.out_reset := clocks.io.reset_out
 | 
					    cross.module.io.out_reset := reset
 | 
				
			||||||
  }
 | 
					  }
 | 
				
			||||||
}
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -3,6 +3,7 @@
 | 
				
			|||||||
package uncore.tilelink2
 | 
					package uncore.tilelink2
 | 
				
			||||||
 | 
					
 | 
				
			||||||
import Chisel._
 | 
					import Chisel._
 | 
				
			||||||
 | 
					import util.Pow2ClockDivider
 | 
				
			||||||
 | 
					
 | 
				
			||||||
object LFSR16Seed
 | 
					object LFSR16Seed
 | 
				
			||||||
{
 | 
					{
 | 
				
			||||||
@@ -225,9 +226,7 @@ trait RRTest1Bundle
 | 
				
			|||||||
 | 
					
 | 
				
			||||||
trait RRTest1Module extends Module with HasRegMap
 | 
					trait RRTest1Module extends Module with HasRegMap
 | 
				
			||||||
{
 | 
					{
 | 
				
			||||||
  val clocks = Module(new ClockDivider)
 | 
					  val clocks = Module(new Pow2ClockDivider(2))
 | 
				
			||||||
  clocks.io.clock_in := clock
 | 
					 | 
				
			||||||
  clocks.io.reset_in := reset
 | 
					 | 
				
			||||||
 | 
					
 | 
				
			||||||
  def x(bits: Int) = {
 | 
					  def x(bits: Int) = {
 | 
				
			||||||
    val field = UInt(width = bits)
 | 
					    val field = UInt(width = bits)
 | 
				
			||||||
@@ -237,7 +236,7 @@ trait RRTest1Module extends Module with HasRegMap
 | 
				
			|||||||
    readCross.io.master_reset := reset
 | 
					    readCross.io.master_reset := reset
 | 
				
			||||||
    readCross.io.master_allow := Bool(true)
 | 
					    readCross.io.master_allow := Bool(true)
 | 
				
			||||||
    readCross.io.slave_clock := clocks.io.clock_out
 | 
					    readCross.io.slave_clock := clocks.io.clock_out
 | 
				
			||||||
    readCross.io.slave_reset := clocks.io.reset_out
 | 
					    readCross.io.slave_reset := reset
 | 
				
			||||||
    readCross.io.slave_allow := Bool(true)
 | 
					    readCross.io.slave_allow := Bool(true)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
    val writeCross = Module(new RegisterWriteCrossing(field))
 | 
					    val writeCross = Module(new RegisterWriteCrossing(field))
 | 
				
			||||||
@@ -245,7 +244,7 @@ trait RRTest1Module extends Module with HasRegMap
 | 
				
			|||||||
    writeCross.io.master_reset := reset
 | 
					    writeCross.io.master_reset := reset
 | 
				
			||||||
    writeCross.io.master_allow := Bool(true)
 | 
					    writeCross.io.master_allow := Bool(true)
 | 
				
			||||||
    writeCross.io.slave_clock := clocks.io.clock_out
 | 
					    writeCross.io.slave_clock := clocks.io.clock_out
 | 
				
			||||||
    writeCross.io.slave_reset := clocks.io.reset_out
 | 
					    writeCross.io.slave_reset := reset
 | 
				
			||||||
    writeCross.io.slave_allow := Bool(true)
 | 
					    writeCross.io.slave_allow := Bool(true)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
    readCross.io.slave_register := writeCross.io.slave_register
 | 
					    readCross.io.slave_register := writeCross.io.slave_register
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -32,4 +32,3 @@ class WithUncoreUnitTests extends Config(
 | 
				
			|||||||
)
 | 
					)
 | 
				
			||||||
 | 
					
 | 
				
			||||||
class UncoreUnitTestConfig extends Config(new WithUncoreUnitTests ++ new BaseConfig)
 | 
					class UncoreUnitTestConfig extends Config(new WithUncoreUnitTests ++ new BaseConfig)
 | 
				
			||||||
 | 
					 | 
				
			||||||
 
 | 
				
			|||||||
							
								
								
									
										36
									
								
								src/main/scala/util/ClockDivider.scala
									
									
									
									
									
										Normal file
									
								
							
							
						
						
									
										36
									
								
								src/main/scala/util/ClockDivider.scala
									
									
									
									
									
										Normal file
									
								
							@@ -0,0 +1,36 @@
 | 
				
			|||||||
 | 
					package util
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					import Chisel._
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					/** Divide the clock by 2 */
 | 
				
			||||||
 | 
					class ClockDivider2 extends Module {
 | 
				
			||||||
 | 
					  val io = new Bundle {
 | 
				
			||||||
 | 
					    val clock_out = Clock(OUTPUT)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  val clock_reg = Reg(Bool())
 | 
				
			||||||
 | 
					  clock_reg := !clock_reg
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  io.clock_out := clock_reg.asClock
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					/** Divide the clock by power of 2 times.
 | 
				
			||||||
 | 
					 *  @param pow2 divides the clock 2 ^ pow2 times
 | 
				
			||||||
 | 
					 *  WARNING: This is meant for simulation use only. */
 | 
				
			||||||
 | 
					class Pow2ClockDivider(pow2: Int) extends Module {
 | 
				
			||||||
 | 
					  val io = new Bundle {
 | 
				
			||||||
 | 
					    val clock_out = Clock(OUTPUT)
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					  if (pow2 == 0) {
 | 
				
			||||||
 | 
					    io.clock_out := clock
 | 
				
			||||||
 | 
					  } else {
 | 
				
			||||||
 | 
					    val dividers = Seq.fill(pow2) { Module(new ClockDivider2) }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    dividers.init.zip(dividers.tail).map { case (last, next) =>
 | 
				
			||||||
 | 
					      next.clock := last.io.clock_out
 | 
				
			||||||
 | 
					    }
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					    io.clock_out := dividers.last.io.clock_out
 | 
				
			||||||
 | 
					  }
 | 
				
			||||||
 | 
					}
 | 
				
			||||||
@@ -9,7 +9,6 @@ bb_vsrcs = $(base_dir)/vsrc/DebugTransportModuleJtag.v \
 | 
				
			|||||||
	$(base_dir)/vsrc/AsyncMailbox.v \
 | 
						$(base_dir)/vsrc/AsyncMailbox.v \
 | 
				
			||||||
	$(base_dir)/vsrc/AsyncResetReg.v \
 | 
						$(base_dir)/vsrc/AsyncResetReg.v \
 | 
				
			||||||
	$(base_dir)/vsrc/AsyncSetReg.v \
 | 
						$(base_dir)/vsrc/AsyncSetReg.v \
 | 
				
			||||||
	$(base_dir)/vsrc/ClockDivider.v \
 | 
					 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					
 | 
				
			||||||
sim_vsrcs = \
 | 
					sim_vsrcs = \
 | 
				
			||||||
 
 | 
				
			|||||||
@@ -1,19 +0,0 @@
 | 
				
			|||||||
// You can't divide clocks in Chisel
 | 
					 | 
				
			||||||
module ClockDivider(
 | 
					 | 
				
			||||||
  input  clock_in,
 | 
					 | 
				
			||||||
  input  reset_in,
 | 
					 | 
				
			||||||
  output clock_out,
 | 
					 | 
				
			||||||
  output reset_out
 | 
					 | 
				
			||||||
);
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
  reg [2:0] shift = 3'b001;
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
  always @(posedge clock_in)
 | 
					 | 
				
			||||||
  begin
 | 
					 | 
				
			||||||
    shift <= {shift[0], shift[2:1]};
 | 
					 | 
				
			||||||
  end
 | 
					 | 
				
			||||||
  
 | 
					 | 
				
			||||||
  assign reset_out = reset_in;
 | 
					 | 
				
			||||||
  assign clock_out = shift[0];
 | 
					 | 
				
			||||||
 | 
					 | 
				
			||||||
endmodule
 | 
					 | 
				
			||||||
@@ -1,12 +1,16 @@
 | 
				
			|||||||
// See LICENSE for license details.
 | 
					// See LICENSE for license details.
 | 
				
			||||||
 | 
					
 | 
				
			||||||
 | 
					`ifndef RESET_DELAY
 | 
				
			||||||
 | 
					 `define RESET_DELAY 777.7
 | 
				
			||||||
 | 
					`endif
 | 
				
			||||||
 | 
					
 | 
				
			||||||
module TestDriver;
 | 
					module TestDriver;
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  reg clock = 1'b0;
 | 
					  reg clock = 1'b0;
 | 
				
			||||||
  reg reset = 1'b1;
 | 
					  reg reset = 1'b1;
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  always #(`CLOCK_PERIOD/2.0) clock = ~clock;
 | 
					  always #(`CLOCK_PERIOD/2.0) clock = ~clock;
 | 
				
			||||||
  initial #777.7 reset = 0;
 | 
					  initial #(`RESET_DELAY) reset = 0;
 | 
				
			||||||
 | 
					
 | 
				
			||||||
  // Read input arguments and initialize
 | 
					  // Read input arguments and initialize
 | 
				
			||||||
  reg verbose = 1'b0;
 | 
					  reg verbose = 1'b0;
 | 
				
			||||||
 
 | 
				
			|||||||
		Reference in New Issue
	
	Block a user