package scala.tools.nsc
import java.io.{ File, FileOutputStream, PrintWriter, IOException, FileNotFoundException }
import java.nio.charset.{ Charset, CharsetDecoder, IllegalCharsetNameException, UnsupportedCharsetException }
import compat.Platform.currentTime
import scala.tools.util.Profiling
import scala.collection.{ mutable, immutable }
import io.{ SourceReader, AbstractFile, Path }
import reporters.{ Reporter, ConsoleReporter }
import util.{ Exceptional, ClassPath, SourceFile, Statistics, BatchSourceFile, ScriptSourceFile, ShowPickled, returning }
import reflect.generic.{ PickleBuffer, PickleFormat }
import settings.{ AestheticSettings }
import symtab.{ Flags, SymbolTable, SymbolLoaders, SymbolTrackers }
import symtab.classfile.Pickler
import dependencies.DependencyAnalysis
import plugins.Plugins
import ast._
import ast.parser._
import typechecker._
import transform._
import backend.icode.{ ICodes, GenICode, ICodeCheckers }
import backend.{ ScalaPrimitives, Platform, MSILPlatform, JavaPlatform }
import backend.jvm.GenJVM
import backend.opt.{ Inliners, ClosureElimination, DeadCodeElimination }
import backend.icode.analysis._
class Global(var settings: Settings, var reporter: Reporter) extends SymbolTable
with CompilationUnits
with Plugins
with PhaseAssembly
{
def this(reporter: Reporter) =
this(new Settings(err => reporter.error(null, err)), reporter)
def this(settings: Settings) =
this(settings, new ConsoleReporter(settings))
type ThisPlatform = Platform[_] { val global: Global.this.type }
lazy val platform: ThisPlatform =
if (forMSIL) new { val global: Global.this.type = Global.this } with MSILPlatform
else new { val global: Global.this.type = Global.this } with JavaPlatform
def classPath: ClassPath[_] = platform.classPath
def rootLoader: LazyType = platform.rootLoader
object gen extends {
val global: Global.this.type = Global.this
} with TreeGen {
def mkAttributedCast(tree: Tree, pt: Type): Tree =
typer.typed(mkCast(tree, pt))
}
object constfold extends {
val global: Global.this.type = Global.this
} with ConstantFolder
object icodes extends {
val global: Global.this.type = Global.this
} with ICodes
object scalaPrimitives extends {
val global: Global.this.type = Global.this
} with ScalaPrimitives
object overridingPairs extends {
val global: Global.this.type = Global.this
} with OverridingPairs
object analysis extends {
val global: Global.this.type = Global.this
} with TypeFlowAnalysis
object copyPropagation extends {
val global: Global.this.type = Global.this
} with CopyPropagation
object statistics extends {
val global: Global.this.type = Global.this
} with Statistics
object nodePrinters extends {
val global: Global.this.type = Global.this
} with NodePrinters {
infolevel = InfoLevel.Verbose
}
object treeBrowsers extends {
val global: Global.this.type = Global.this
} with TreeBrowsers
val nodeToString = nodePrinters.nodeToString
val treeBrowser = treeBrowsers.create()
def signalDone(context: analyzer.Context, old: Tree, result: Tree) {}
def signalParseProgress(pos: Position) {}
def registerContext(c: analyzer.Context) {}
def registerTopLevelSym(sym: Symbol) {}
def error(msg: String) = globalError(msg)
def globalError(msg: String) = reporter.error(NoPosition, msg)
def inform(msg: String) = reporter.info(NoPosition, msg, true)
def warning(msg: String) =
if (opt.fatalWarnings) globalError(msg)
else reporter.warning(NoPosition, msg)
private def elapsedMessage(msg: String, start: Long) =
msg + " in " + (currentTime - start) + "ms"
def informComplete(msg: String): Unit = reporter.withoutTruncating(inform(msg))
def informProgress(msg: String) = if (opt.verbose) inform("[" + msg + "]")
def inform[T](msg: String, value: T): T = returning(value)(x => inform(msg + x))
def informTime(msg: String, start: Long) = informProgress(elapsedMessage(msg, start))
def logError(msg: String, t: Throwable): Unit = ()
@inline final def log(msg: => AnyRef): Unit =
if (settings.log containsPhase globalPhase)
inform("[log " + phase + "] " + msg)
def logThrowable(t: Throwable): Unit = globalError(throwableAsString(t))
def throwableAsString(t: Throwable): String =
if (opt.richExes) Exceptional(t).force().context()
else util.stackTraceString(t)
private val reader: SourceReader = {
val defaultEncoding = Properties.sourceEncoding
val defaultReader = Properties.sourceReader
def loadCharset(name: String) =
try Some(Charset.forName(name))
catch {
case _: IllegalCharsetNameException =>
globalError("illegal charset name '" + name + "'")
None
case _: UnsupportedCharsetException =>
globalError("unsupported charset '" + name + "'")
None
}
val charset = opt.encoding flatMap loadCharset getOrElse {
settings.encoding.value = defaultEncoding
Charset.forName(defaultEncoding)
}
def loadReader(name: String): Option[SourceReader] = {
def ccon = Class.forName(name).getConstructor(classOf[CharsetDecoder], classOf[Reporter])
try Some(ccon.newInstance(charset.newDecoder(), reporter).asInstanceOf[SourceReader])
catch { case x =>
globalError("exception while trying to instantiate source reader '" + name + "'")
None
}
}
opt.sourceReader flatMap loadReader getOrElse {
new SourceReader(charset.newDecoder(), reporter)
}
}
if (!dependencyAnalysis.off)
dependencyAnalysis.loadDependencyAnalysis()
if (opt.verbose || opt.logClasspath) {
informComplete("[search path for source files: " + classPath.sourcepaths.mkString(",") + "]")
informComplete("[search path for class files: " + classPath.asClasspathString + "]")
}
object opt extends AestheticSettings {
def settings = Global.this.settings
def isActive(ph: Settings#PhasesSetting) = ph containsPhase globalPhase
def wasActive(ph: Settings#PhasesSetting) = ph containsPhase globalPhase.prev
private def splitClassAndPhase(str: String, term: Boolean): Name = {
def mkName(s: String) = if (term) newTermName(s) else newTypeName(s)
(str indexOf '@') match {
case -1 => mkName(str)
case idx =>
val phasePart = str drop (idx + 1)
settings.Yshow.tryToSetColon(phasePart split ',' toList)
mkName(str take idx)
}
}
def checkPhase = wasActive(settings.check)
def logPhase = isActive(settings.log)
def writeICode = settings.writeICode.value
def browsePhase = isActive(settings.browse)
def echoFilenames = opt.debug && (opt.verbose || currentRun.size < 5)
def noShow = settings.Yshow.isDefault
def printLate = settings.printLate.value
def printPhase = isActive(settings.Xprint)
def showNames = List(showClass, showObject).flatten
def showPhase = isActive(settings.Yshow)
def showSymbols = settings.Yshowsyms.value
def showTrees = settings.Xshowtrees.value
val showClass = optSetting[String](settings.Xshowcls) map (x => splitClassAndPhase(x, false))
val showObject = optSetting[String](settings.Xshowobj) map (x => splitClassAndPhase(x, true))
def profCPUPhase = isActive(settings.Yprofile) && !profileAll
def profileAll = settings.Yprofile.doAllPhases
def profileAny = !settings.Yprofile.isDefault || !settings.YprofileMem.isDefault
def profileClass = settings.YprofileClass.value
def profileMem = settings.YprofileMem.value
def timings = sys.props contains "scala.timings"
def inferDebug = (sys.props contains "scalac.debug.infer") || settings.Yinferdebug.value
def typerDebug = (sys.props contains "scalac.debug.typer") || settings.Ytyperdebug.value
}
def isScriptRun = opt.script.isDefined
def getSourceFile(f: AbstractFile): BatchSourceFile =
if (isScriptRun) ScriptSourceFile(f, reader read f)
else new BatchSourceFile(f, reader read f)
def getSourceFile(name: String): SourceFile = {
val f = AbstractFile.getFile(name)
if (f eq null) throw new FileNotFoundException(
"source file '" + name + "' could not be found")
getSourceFile(f)
}
lazy val loaders = new SymbolLoaders {
val global: Global.this.type = Global.this
}
var globalPhase: Phase = NoPhase
val MaxPhases = 64
val phaseWithId: Array[Phase] = Array.fill(MaxPhases)(NoPhase)
abstract class GlobalPhase(prev: Phase) extends Phase(prev) {
phaseWithId(id) = this
def run() {
echoPhaseSummary(this)
currentRun.units foreach applyPhase
}
def apply(unit: CompilationUnit): Unit
private val isErased = prev.name == "erasure" || prev.erasedTypes
override def erasedTypes: Boolean = isErased
private val isFlat = prev.name == "flatten" || prev.flatClasses
override def flatClasses: Boolean = isFlat
private val isSpecialized = prev.name == "specialize" || prev.specialized
override def specialized: Boolean = isSpecialized
private val isRefChecked = prev.name == "refchecks" || prev.refChecked
override def refChecked: Boolean = isRefChecked
def cancelled(unit: CompilationUnit) = {
val maxJavaPhase = if (createJavadoc) currentRun.typerPhase.id else currentRun.namerPhase.id
reporter.cancelled || unit.isJava && this.id > maxJavaPhase
}
final def applyPhase(unit: CompilationUnit) {
if (opt.echoFilenames)
inform("[running phase " + name + " on " + unit + "]")
val unit0 = currentRun.currentUnit
try {
currentRun.currentUnit = unit
if (!cancelled(unit)) {
currentRun.informUnitStarting(this, unit)
apply(unit)
}
currentRun.advanceUnit
} finally {
currentRun.currentUnit = unit0
}
}
}
var printTypings = opt.typerDebug
var printInfers = opt.inferDebug
object syntaxAnalyzer extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]()
val runsRightAfter = None
} with SyntaxAnalyzer
object analyzer extends {
val global: Global.this.type = Global.this
} with Analyzer
object superAccessors extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("typer")
val runsRightAfter = None
} with SuperAccessors
object pickler extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("superaccessors")
val runsRightAfter = None
} with Pickler
object refchecks extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("pickler")
val runsRightAfter = None
} with RefChecks
object liftcode extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("refchecks")
val runsRightAfter = None
} with LiftCode
object uncurry extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("refchecks", "liftcode")
val runsRightAfter = None
} with UnCurry
object tailCalls extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("uncurry")
val runsRightAfter = None
} with TailCalls
object explicitOuter extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("tailcalls")
val runsRightAfter = None
} with ExplicitOuter
object specializeTypes extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("")
val runsRightAfter = Some("tailcalls")
} with SpecializeTypes
object erasure extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("explicitouter")
val runsRightAfter = Some("explicitouter")
} with Erasure
object lazyVals extends {
final val FLAGS_PER_WORD = 32
val global: Global.this.type = Global.this
val runsAfter = List[String]("erasure")
val runsRightAfter = None
} with LazyVals
object lambdaLift extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("lazyvals")
val runsRightAfter = None
} with LambdaLift
object constructors extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("lambdalift")
val runsRightAfter = None
} with Constructors
object flatten extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("constructors")
val runsRightAfter = None
} with Flatten
object mixer extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("flatten", "constructors")
val runsRightAfter = None
} with Mixin
object cleanup extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("mixin")
val runsRightAfter = None
} with CleanUp
object genicode extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("cleanup")
val runsRightAfter = None
} with GenICode
object inliner extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("icode")
val runsRightAfter = None
} with Inliners
object closureElimination extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("inliner")
val runsRightAfter = None
} with ClosureElimination
object deadCode extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("closelim")
val runsRightAfter = None
} with DeadCodeElimination
object genJVM extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]("dce")
val runsRightAfter = None
} with GenJVM
object dependencyAnalysis extends {
val global: Global.this.type = Global.this
val runsAfter = List("jvm")
val runsRightAfter = None
} with DependencyAnalysis
object terminal extends {
val global: Global.this.type = Global.this
val phaseName = "terminal"
val runsAfter = List[String]("jvm", "msil")
val runsRightAfter = None
} with SubComponent {
private var cache: Option[GlobalPhase] = None
def reset(): Unit = cache = None
def newPhase(prev: Phase): GlobalPhase =
cache getOrElse returning(new TerminalPhase(prev))(x => cache = Some(x))
class TerminalPhase(prev: Phase) extends GlobalPhase(prev) {
def name = "terminal"
def apply(unit: CompilationUnit) {}
}
}
object sampleTransform extends {
val global: Global.this.type = Global.this
val runsAfter = List[String]()
val runsRightAfter = None
} with SampleTransform
object treeChecker extends {
val global: Global.this.type = Global.this
} with TreeCheckers
object icodeCheckers extends {
val global: Global.this.type = Global.this
} with ICodeCheckers
object icodeChecker extends icodeCheckers.ICodeChecker()
object typer extends analyzer.Typer(
analyzer.NoContext.make(EmptyTree, Global.this.definitions.RootClass, new Scope)
)
protected def computeInternalPhases() {
val phs = List(
syntaxAnalyzer -> "parse source into ASTs, perform simple desugaring",
analyzer.namerFactory -> "resolve names, attach symbols to named trees",
analyzer.packageObjects -> "load package objects",
analyzer.typerFactory -> "the meat and potatoes: type the trees",
superAccessors -> "add super accessors in traits and nested classes",
pickler -> "serialize symbol tables",
refchecks -> "reference/override checking, translate nested objects",
uncurry -> "uncurry, translate function values to anonymous classes",
tailCalls -> "replace tail calls by jumps",
specializeTypes -> "@specialized-driven class and method specialization",
explicitOuter -> "this refs to outer pointers, translate patterns",
erasure -> "erase types, add interfaces for traits",
lazyVals -> "allocate bitmaps, translate lazy vals into lazified defs",
lambdaLift -> "move nested functions to top level",
constructors -> "move field definitions into constructors",
mixer -> "mixin composition",
cleanup -> "platform-specific cleanups, generate reflective calls",
genicode -> "generate portable intermediate code",
inliner -> "optimization: do inlining",
closureElimination -> "optimization: eliminate uncalled closures",
deadCode -> "optimization: eliminate dead code",
terminal -> "The last phase in the compiler chain"
)
phs foreach (addToPhasesSet _).tupled
}
private val otherPhaseDescriptions = Map(
"flatten" -> "eliminate inner classes",
"liftcode" -> "reify trees",
"jvm" -> "generate JVM bytecode"
) withDefaultValue ""
protected def computePlatformPhases() = platform.platformPhases foreach { sub =>
addToPhasesSet(sub, otherPhaseDescriptions(sub.phaseName))
}
protected def computePhaseDescriptors: List[SubComponent] = {
computeInternalPhases()
computePlatformPhases()
computePluginPhases()
buildCompilerFromPhasesSet()
}
lazy val phaseDescriptors: List[SubComponent] = computePhaseDescriptors
protected lazy val phasesSet = new mutable.HashSet[SubComponent]
protected lazy val phasesDescMap = new mutable.HashMap[SubComponent, String] withDefaultValue ""
private lazy val phaseTimings = new Phase.TimingModel
protected def addToPhasesSet(sub: SubComponent, descr: String) {
phasesSet += sub
phasesDescMap(sub) = descr
}
lazy val phaseNames = {
new Run
phaseDescriptors map (_.phaseName)
}
def phaseDescriptions: String = {
val width = phaseNames map (_.length) max
val fmt = "%" + width + "s %2s %s\n"
val line1 = fmt.format("phase name", "id", "description")
val line2 = fmt.format("----------", "--", "-----------")
val descs = phaseDescriptors.zipWithIndex map {
case (ph, idx) => fmt.format(ph.phaseName, idx + 1, phasesDescMap(ph))
}
line1 :: line2 :: descs mkString
}
private var curRun: Run = null
private var curRunId = 0
private [nsc] def dropRun() {
curRun = null
}
def currentRun: Run = curRun
override def currentRunId = curRunId
def echoPhaseSummary(ph: Phase) = {
if (opt.debug && !opt.echoFilenames)
inform("[running phase " + ph.name + " on " + currentRun.size + " compilation units]")
}
class Run {
var isDefined = false
private var terminalPhase: Phase = NoPhase
private lazy val stopPhaseSetting = {
val result = phaseDescriptors sliding 2 collectFirst {
case xs if xs exists (settings.stopBefore contains _.phaseName) => if (settings.stopBefore contains xs.head.phaseName) xs.head else xs.last
case xs if settings.stopAfter contains xs.head.phaseName => xs.last
}
if (result exists (_.phaseName == "parser"))
globalError("Cannot stop before parser phase.")
result
}
protected def stopPhase(name: String) = stopPhaseSetting exists (_.phaseName == name)
protected def skipPhase(name: String) = settings.skip contains name
private val firstPhase = {
curRunId += 1
curRun = this
val parserPhase: Phase = syntaxAnalyzer.newPhase(NoPhase)
phase = parserPhase
definitions.init
terminal.reset
val lastPhase = phaseDescriptors.tail .
takeWhile (pd => !stopPhase(pd.phaseName)) .
filterNot (pd => skipPhase(pd.phaseName)) .
foldLeft (parserPhase) ((chain, ph) => ph newPhase chain)
terminalPhase =
if (lastPhase.name == "terminal") lastPhase
else terminal newPhase lastPhase
parserPhase
}
var currentUnit: CompilationUnit = _
var deprecationWarnings: Int = 0
var uncheckedWarnings: Int = 0
def progress(current: Int, total: Int) {}
def informUnitStarting(phase: Phase, unit: CompilationUnit) { }
def advancePhase() {
unitc = 0
phasec += 1
refreshProgress
}
def advanceUnit() {
unitc += 1
refreshProgress
}
def cancel() { reporter.cancelled = true }
private var phasec: Int = 0
private var unitc: Int = 0
private def currentProgress = (phasec * size) + unitc
private def totalProgress = (phaseDescriptors.size - 1) * size
private def refreshProgress() = if (size > 0) progress(currentProgress, totalProgress)
def phaseNamed(name: String): Phase = {
var p: Phase = firstPhase
while (p.next != p && p.name != name) p = p.next
if (p.name != name) NoPhase else p
}
val parserPhase = phaseNamed("parser")
val namerPhase = phaseNamed("namer")
val typerPhase = phaseNamed("typer")
val picklerPhase = phaseNamed("pickler")
val refchecksPhase = phaseNamed("refchecks")
val uncurryPhase = phaseNamed("uncurry")
val explicitouterPhase = phaseNamed("explicitouter")
val erasurePhase = phaseNamed("erasure")
val flattenPhase = phaseNamed("flatten")
val mixinPhase = phaseNamed("mixin")
val cleanupPhase = phaseNamed("cleanup")
val icodePhase = phaseNamed("icode")
val jvmPhase = phaseNamed("jvm")
def runIsAt(ph: Phase) = globalPhase.id == ph.id
def runIsPast(ph: Phase) = globalPhase.id > ph.id
isDefined = true
private val unitbuf = new mutable.ListBuffer[CompilationUnit]
val compiledFiles = new mutable.HashSet[String]
private var _unitbufSize = 0
def size = _unitbufSize
private def addUnit(unit: CompilationUnit) {
unitbuf += unit
_unitbufSize += 1
compiledFiles += unit.source.file.path
}
private def checkDeprecatedSettings(unit: CompilationUnit) {
settings.userSetSettings filter (_.isDeprecated) foreach { s =>
unit.deprecationWarning(NoPosition, s.name + " is deprecated: " + s.deprecationMessage.get)
}
}
def units: Iterator[CompilationUnit] = unitbuf.iterator
val symSource = new mutable.HashMap[Symbol, AbstractFile]
val symData = new mutable.HashMap[Symbol, PickleBuffer]
def registerPickle(sym: Symbol): Unit = {
if (opt.showPhase && (opt.showNames exists (x => findNamedMember(x.toTypeName, sym) != NoSymbol))) {
symData get sym foreach { pickle =>
ShowPickled.show("\n<<-- " + sym.fullName + " -->>\n", pickle, false)
}
}
}
def compiles(sym: Symbol): Boolean =
if (sym == NoSymbol) false
else if (symSource.isDefinedAt(sym)) true
else if (!sym.owner.isPackageClass) compiles(sym.toplevelClass)
else if (sym.isModuleClass) compiles(sym.sourceModule)
else false
def canRedefine(sym: Symbol) = !compiles(sym)
protected def runCheckers() {
val toCheck = globalPhase.prev
val canCheck = toCheck.checkable
val fmt = if (canCheck) "[Now checking: %s]" else "[Not checkable: %s]"
inform(fmt format toCheck.name)
if (canCheck) {
phase = globalPhase
if (globalPhase.id >= icodePhase.id) icodeChecker.checkICodes
else treeChecker.checkTrees
}
}
private def showMembers() =
opt.showNames foreach (x => showDef(x, opt.declsOnly, globalPhase))
lazy val profiler = Class.forName(opt.profileClass).newInstance().asInstanceOf[Profiling]
object trackerFactory extends SymbolTrackers {
val global: Global.this.type = Global.this
lazy val trackers = currentRun.units.toList map (x => SymbolTracker(x))
def snapshot() = {
inform("\n[[symbol layout at end of " + phase + "]]")
atPhase(phase.next) {
trackers foreach { t =>
t.snapshot()
inform(t.show("Heading from " + phase.prev.name + " to " + phase.name))
}
}
}
}
def reportCompileErrors() {
if (reporter.hasErrors) {
for ((sym, file) <- symSource.iterator) {
sym.reset(new loaders.SourcefileLoader(file))
if (sym.isTerm)
sym.moduleClass reset loaders.moduleClassLoader
}
}
else {
def warn(count: Int, what: String, option: Settings#BooleanSetting) = (
if (option.isDefault && count > 0)
warning("there were %d %s warnings; re-run with %s for details".format(count, what, option.name))
)
warn(deprecationWarnings, "deprecation", settings.deprecation)
warn(uncheckedWarnings, "unchecked", settings.unchecked)
}
}
def compileSources(_sources: List[SourceFile]) {
val depSources = dependencyAnalysis calculateFiles _sources.distinct
val sources = coreClassesFirst(depSources)
if (reporter.hasErrors)
return
if (sources.isEmpty) {
checkDeprecatedSettings(new CompilationUnit(new BatchSourceFile("<no file>", "")))
reportCompileErrors()
return
}
val startTime = currentTime
reporter.reset();
{
val first :: rest = sources
val unit = new CompilationUnit(first)
addUnit(unit)
checkDeprecatedSettings(unit)
for (source <- rest)
addUnit(new CompilationUnit(source))
}
globalPhase = firstPhase
if (opt.profileAll) {
inform("starting CPU profiling on compilation run")
profiler.startProfiling()
}
while (globalPhase != terminalPhase && !reporter.hasErrors) {
val startTime = currentTime
phase = globalPhase
if (opt.profCPUPhase) {
inform("starting CPU profiling on phase " + globalPhase.name)
profiler profile globalPhase.run
}
else globalPhase.run
if (opt.profileAny)
profiler.advanceGeneration(globalPhase.name)
informTime(globalPhase.description, startTime)
phaseTimings(globalPhase) = currentTime - startTime
if (opt.writeICode && (runIsAt(icodePhase) || opt.printPhase && runIsPast(icodePhase)))
writeICode()
if (opt.printPhase || opt.printLate && runIsAt(cleanupPhase)) {
if (opt.showTrees) nodePrinters.printAll()
else printAllUnits()
}
if (opt.showSymbols)
trackerFactory.snapshot()
if (opt.showPhase)
showMembers()
if (opt.browsePhase)
treeBrowser browse (phase.name, units)
globalPhase = globalPhase.next
if (opt.checkPhase)
runCheckers()
if (opt.printStats)
statistics.print(phase)
advancePhase
}
if (opt.profileAll)
profiler.stopProfiling()
if (opt.timings)
inform(phaseTimings.formatted)
if (opt.noShow)
showMembers()
reportCompileErrors()
symSource.keys foreach (x => resetPackageClass(x.owner))
informTime("total", startTime)
if (opt.profileMem) {
inform("Saving heap snapshot, this could take a while...")
System.gc()
profiler.captureSnapshot()
inform("...done saving heap snapshot.")
specializeTypes.printSpecStats()
}
if (!dependencyAnalysis.off)
dependencyAnalysis.saveDependencyAnalysis()
}
def compileFiles(files: List[AbstractFile]) {
try compileSources(files map getSourceFile)
catch { case ex: IOException => globalError(ex.getMessage()) }
}
def compile(filenames: List[String]) {
try {
val sources: List[SourceFile] =
if (isScriptRun && filenames.size > 1) returning(Nil)(_ => globalError("can only compile one script at a time"))
else filenames map getSourceFile
compileSources(sources)
}
catch { case ex: IOException => globalError(ex.getMessage()) }
}
def compileLate(file: AbstractFile) {
if (!compiledFiles(file.path))
compileLate(new CompilationUnit(getSourceFile(file)))
}
def compileLate(unit: CompilationUnit) {
def stop(ph: Phase) = ph == null || ph.id >= (globalPhase.id max typerPhase.id)
def loop(ph: Phase) {
if (stop(ph)) refreshProgress
else {
atPhase(ph)(ph.asInstanceOf[GlobalPhase] applyPhase unit)
loop(ph.next match {
case `ph` => null
case x => x
})
}
}
addUnit(unit)
loop(firstPhase)
}
def compileSourceFor(context : analyzer.Context, name : Name) = false
def compileSourceFor(qual : Tree, name : Name) = false
private def resetPackageClass(pclazz: Symbol) {
atPhase(firstPhase) {
pclazz.setInfo(atPhase(typerPhase)(pclazz.info))
}
if (!pclazz.isRoot) resetPackageClass(pclazz.owner)
}
private def coreClassesFirst(files: List[SourceFile]) = {
val goLast = 4
def rank(f: SourceFile) = {
if (f.file.container.name != "scala") goLast
else f.file.name match {
case "ScalaObject.scala" => 1
case "LowPriorityImplicits.scala" => 2
case "StandardEmbeddings.scala" => 2
case "EmbeddedControls.scala" => 2
case "Predef.scala" => 3
case _ => goLast
}
}
files sortBy rank
}
}
def printAllUnits() {
print("[[syntax trees at end of " + phase + "]]")
atPhase(phase.next) { currentRun.units foreach treePrinter.print }
}
private def findMemberFromRoot(fullName: Name): Symbol = {
val segs = nme.segments(fullName.toString, fullName.isTermName)
if (segs.isEmpty) NoSymbol
else findNamedMember(segs.tail, definitions.RootClass.info member segs.head)
}
private def findNamedMember(fullName: Name, root: Symbol): Symbol = {
val segs = nme.segments(fullName.toString, fullName.isTermName)
if (segs.isEmpty || segs.head != root.simpleName) NoSymbol
else findNamedMember(segs.tail, root)
}
private def findNamedMember(segs: List[Name], root: Symbol): Symbol =
if (segs.isEmpty) root
else findNamedMember(segs.tail, root.info member segs.head)
def showDef(fullName: Name, declsOnly: Boolean, ph: Phase) = {
val boringOwners = Set(definitions.AnyClass, definitions.AnyRefClass, definitions.ObjectClass)
def phased[T](body: => T): T = afterPhase(ph)(body)
def boringMember(sym: Symbol) = boringOwners(sym.owner)
def symString(sym: Symbol) = if (sym.isTerm) sym.defString else sym.toString
def members(sym: Symbol) = phased(sym.info.members filterNot boringMember map symString)
def decls(sym: Symbol) = phased(sym.info.decls.toList map symString)
def bases(sym: Symbol) = phased(sym.info.baseClasses map (x => x.kindString + " " + x.fullName))
val syms = findMemberFromRoot(fullName) match {
case NoSymbol => phased(currentRun.symSource.keys map (sym => findNamedMember(fullName, sym)) filterNot (_ == NoSymbol) toList)
case sym => List(sym)
}
syms foreach { sym =>
val name = "\n<<-- %s %s after phase '%s' -->>".format(sym.kindString, sym.fullName, ph.name)
val baseClasses = bases(sym).mkString("Base classes:\n ", "\n ", "")
val contents =
if (declsOnly) decls(sym).mkString("Declarations:\n ", "\n ", "")
else members(sym).mkString("Members (excluding Any/AnyRef unless overridden):\n ", "\n ", "")
inform(List(name, baseClasses, contents) mkString "\n\n")
}
}
def getFile(clazz: Symbol, suffix: String): File = {
val outDir = Path(
settings.outputDirs.outputDirFor(clazz.sourceFile).path match {
case "" => "."
case path => path
}
)
val segments = clazz.fullName split '.'
val dir = segments.init.foldLeft(outDir)(_ / _).createDirectory()
new File(dir.path, segments.last + suffix)
}
private def writeICode() {
val printer = new icodes.TextPrinter(null, icodes.linearizer)
icodes.classes.values.foreach((cls) => {
val suffix = if (cls.symbol.hasModuleFlag) "$.icode" else ".icode"
var file = getFile(cls.symbol, suffix)
try {
val stream = new FileOutputStream(file)
printer.setWriter(new PrintWriter(stream, true))
printer.printClass(cls)
informProgress("wrote " + file)
} catch {
case ex: IOException =>
if (opt.debug) ex.printStackTrace()
globalError("could not write file " + file)
}
})
}
def forJVM = opt.jvm
def forMSIL = opt.msil
def forInteractive = onlyPresentation
def forScaladoc = onlyPresentation
def createJavadoc = false
@deprecated("Use forInteractive or forScaladoc, depending on what you're after", "2.9.0")
def onlyPresentation = false
}