diff --git a/build.sbt b/build.sbt
index 8f2f78455b..db905d0f9f 100644
--- a/build.sbt
+++ b/build.sbt
@@ -47,6 +47,7 @@ lazy val `importer-portable` = project
.dependsOn(ts, scalajs, phases)
.enablePlugins(BuildInfoPlugin)
.settings(
+ libraryDependencies ++= List(Deps.bleepModel),
buildInfoPackage := "org.scalablytyped.converter.internal",
buildInfoKeys := Seq[BuildInfoKey](
"gitSha" -> "git rev-parse -1 HEAD".!!.split("\n").last.trim,
@@ -59,7 +60,7 @@ lazy val importer = project
.configure(baseSettings, optimize)
.settings(
libraryDependencies ++= Seq(
- Deps.bloop,
+ Deps.gigahorse,
Deps.coursier,
Deps.scalatest % Test,
),
diff --git a/cli/src/main/scala/org/scalablytyped/converter/cli/Main.scala b/cli/src/main/scala/org/scalablytyped/converter/cli/Main.scala
index a446a4dafa..5192450507 100644
--- a/cli/src/main/scala/org/scalablytyped/converter/cli/Main.scala
+++ b/cli/src/main/scala/org/scalablytyped/converter/cli/Main.scala
@@ -3,7 +3,7 @@ package org.scalablytyped.converter.cli
import com.olvind.logging.{stdout, storing, LogLevel, Logger}
import fansi.{Attr, Color, Str}
import org.scalablytyped.converter.internal.importer._
-import org.scalablytyped.converter.internal.importer.build.{BloopCompiler, PublishedSbtProject, SbtProject}
+import org.scalablytyped.converter.internal.importer.build.{BleepCompiler, ScalaProject}
import org.scalablytyped.converter.internal.importer.documentation.Npmjs
import org.scalablytyped.converter.internal.phases.PhaseListener.NoListener
import org.scalablytyped.converter.internal.phases.{PhaseRes, PhaseRunner, RecPhase}
@@ -248,12 +248,9 @@ object Main {
),
)
- val compiler = Await.result(
- BloopCompiler(logger.filter(LogLevel.debug).void, conversion.versions, failureCacheFolderOpt = None),
- Duration.Inf,
- )
+ val bleepCompiler = Await.result(BleepCompiler(logger.filter(LogLevel.debug).void), Duration.Inf)
- val Pipeline: RecPhase[LibTsSource, PublishedSbtProject] =
+ val Pipeline: RecPhase[LibTsSource, ScalaProject] =
RecPhase[LibTsSource]
.next(
new Phase1ReadTypescript(
@@ -285,10 +282,10 @@ object Main {
.next(
new Phase3Compile(
versions = conversion.versions,
- compiler = compiler,
+ bleepCompiler = bleepCompiler,
targetFolder = c.paths.out,
organization = conversion.organization,
- publishLocalFolder = constants.defaultLocalPublishFolder,
+ publishLocalTarget = PublishLocalTarget.DefaultIvy2,
metadataFetcher = Npmjs.No,
softWrites = true,
flavour = conversion.flavourImpl,
@@ -298,7 +295,7 @@ object Main {
"build",
)
- val results: Map[LibTsSource, PhaseRes[LibTsSource, PublishedSbtProject]] =
+ val results: Map[LibTsSource, PhaseRes[LibTsSource, ScalaProject]] =
sources
.map(source => source -> PhaseRunner(Pipeline, (_: LibTsSource) => logger.void, NoListener)(source))
.toMap
@@ -324,16 +321,16 @@ object Main {
System.exit(1)
} else {
- val allSuccesses: Map[LibTsSource, PublishedSbtProject] = {
- def go(source: LibTsSource, p: PublishedSbtProject): Map[LibTsSource, PublishedSbtProject] =
- Map(source -> p) ++ p.project.deps.flatMap { case (k, v) => go(k, v) }
+ val allSuccesses: Map[LibTsSource, ScalaProject] = {
+ def go(source: LibTsSource, p: ScalaProject): Map[LibTsSource, ScalaProject] =
+ Map(source -> p) ++ p.deps.flatMap { case (k, v) => go(k, v) }
results.collect { case (s, PhaseRes.Ok(res)) => go(s, res) }.reduceOption(_ ++ _).getOrElse(Map.empty)
}
- val short: Seq[SbtProject] =
+ val short: Seq[ScalaProject] =
results
- .collect { case (_, PhaseRes.Ok(res)) => res.project }
+ .collect { case (_, PhaseRes.Ok(res)) => res }
.toSeq
.filter(_.name != Name.std.unescaped)
.sortBy(_.name)
diff --git a/import-scalajs-definitions/src/main/scala/org/scalablytyped/converter/internal/scalajs/ImportScalaDefinitions.scala b/import-scalajs-definitions/src/main/scala/org/scalablytyped/converter/internal/scalajs/ImportScalaDefinitions.scala
index dd833c1dbc..3715d0dbff 100644
--- a/import-scalajs-definitions/src/main/scala/org/scalablytyped/converter/internal/scalajs/ImportScalaDefinitions.scala
+++ b/import-scalajs-definitions/src/main/scala/org/scalablytyped/converter/internal/scalajs/ImportScalaDefinitions.scala
@@ -1,18 +1,20 @@
package org.scalablytyped.converter.internal
package scalajs
-import java.util.regex.Pattern
-
import ammonite.ops._
-import bloop.io.AbsolutePath
import com.olvind.logging
-import org.scalablytyped.converter.internal.importer.build.BloopCompiler
+import coursier.Fetch
+import coursier.cache.{ArtifactError, FileCache}
+import coursier.core.{Dependency, Module}
+import coursier.error.{FetchError, ResolutionError}
+import coursier.util.Task
import org.scalablytyped.converter.internal.maps._
import org.scalablytyped.converter.internal.scalajs.transforms.Sorter
-import scala.concurrent.Await
+import java.util.regex.Pattern
import scala.concurrent.ExecutionContext.Implicits.global
import scala.concurrent.duration.Duration
+import scala.concurrent.{Await, Future}
import scala.reflect.NameTransformer
import scala.tools.scalap.scalax.rules.scalasig._
@@ -29,9 +31,37 @@ import scala.tools.scalap.scalax.rules.scalasig._
object ImportScalaDefinitions extends App {
private val defaultVersions: Versions = Versions(Versions.Scala213, Versions.ScalaJs1)
- val All: Array[AbsolutePath] = Await
+ val fileCache = FileCache[Task]().withChecksums(List(None))
+
+ def toCoursier(dep: Dep.Concrete): Dependency =
+ Dependency(
+ Module(coursier.Organization(dep.org), coursier.ModuleName(dep.mangledArtifact), Map.empty),
+ dep.version,
+ )
+
+ def resolve(deps: Dep.Concrete*): Future[Array[Path]] = {
+ def go(remainingAttempts: Int): Future[Array[Path]] =
+ Fetch[Task](fileCache)
+ .withDependencies(deps.map(toCoursier))
+ .io
+ .future()
+ .map(files => files.map(f => Path(f)).toArray)
+ .recoverWith {
+ case x: ResolutionError.CantDownloadModule
+ if remainingAttempts > 0 && x.perRepositoryErrors.exists(_.contains("concurrent download")) =>
+ go(remainingAttempts - 1)
+ case x: FetchError.DownloadingArtifacts if remainingAttempts > 0 && x.errors.exists {
+ case (_, artifactError) => artifactError.isInstanceOf[ArtifactError.Recoverable]
+ } =>
+ go(remainingAttempts - 1)
+ }
+
+ go(remainingAttempts = 3)
+ }
+
+ val All: Array[Path] = Await
.result(
- BloopCompiler.resolve(
+ resolve(
defaultVersions.scalajsReact.concrete(defaultVersions),
defaultVersions.scalaJsDom.concrete(defaultVersions),
defaultVersions.slinkyWeb.concrete(defaultVersions),
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/Phase3Compile.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/Phase3Compile.scala
index 857664af5a..afb7fc9369 100644
--- a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/Phase3Compile.scala
+++ b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/Phase3Compile.scala
@@ -1,14 +1,19 @@
package org.scalablytyped.converter.internal
package importer
+import bleep.model
import com.olvind.logging.{Formatter, Logger}
+import org.scalablytyped.converter.internal.importer.Phase3Compile.bleepBuildFile
import org.scalablytyped.converter.internal.importer.build._
+import org.scalablytyped.converter.internal.importer.cli.WrittenLine
import org.scalablytyped.converter.internal.importer.documentation.Npmjs
import org.scalablytyped.converter.internal.maps._
import org.scalablytyped.converter.internal.phases.{GetDeps, IsCircular, Phase, PhaseRes}
import org.scalablytyped.converter.internal.scalajs._
import org.scalablytyped.converter.internal.scalajs.flavours.FlavourImpl
+import java.nio.file.Paths
+import scala.collection.immutable.{SortedMap, SortedSet}
import java.time.ZonedDateTime
import scala.collection.immutable.SortedSet
import scala.concurrent.Await
@@ -20,16 +25,16 @@ import scala.util.Try
*/
class Phase3Compile(
versions: Versions,
- compiler: Compiler,
+ bleepCompiler: BleepCompiler,
targetFolder: os.Path,
organization: String,
- publishLocalFolder: os.Path,
+ publishLocalTarget: PublishLocalTarget,
metadataFetcher: Npmjs,
softWrites: Boolean,
flavour: FlavourImpl,
generateScalaJsBundlerFile: Boolean,
ensureSourceFilesWritten: Boolean,
-) extends Phase[LibTsSource, LibScalaJs, PublishedSbtProject] {
+) extends Phase[LibTsSource, LibScalaJs, ScalaProject] {
val ScalaFiles: PartialFunction[(os.RelPath, String), String] = {
case (path, value)
@@ -44,14 +49,14 @@ class Phase3Compile(
override def apply(
source: LibTsSource,
lib: LibScalaJs,
- getDeps: GetDeps[LibTsSource, PublishedSbtProject],
+ getDeps: GetDeps[LibTsSource, ScalaProject],
v4: IsCircular,
_logger: Logger[Unit],
- ): PhaseRes[LibTsSource, PublishedSbtProject] = {
+ ): PhaseRes[LibTsSource, ScalaProject] = {
val logger = _logger.withContext("flavour", flavour.toString)
getDeps(lib.dependencies.keys.map(x => x: LibTsSource).to[SortedSet]).flatMap {
- case PublishedSbtProject.Unpack(deps) =>
+ case ScalaProject.Unpack(deps: SortedMap[LibTsSource, ScalaProject]) =>
val scope = new TreeScope.Root(
libName = lib.scalaName,
_dependencies = lib.dependencies.map { case (_, lib) => lib.scalaName -> lib.packageTree },
@@ -69,33 +74,47 @@ class Phase3Compile(
if (generateScalaJsBundlerFile) ScalaJsBundlerDepFile(lib.source.libName, lib.libVersion)
else Empty
- val sbtLayout: SbtProjectLayout[os.RelPath, String] =
- ContentSbtProject(
- versions = versions,
- comments = lib.packageTree.comments,
- organization = organization,
- name = lib.libName,
- version = VersionHack.TemplateValue,
- localDeps = deps.toIArrayValues,
- deps = flavour.dependencies,
- scalaFiles = scalaFiles.map { case (relPath, content) => sourcesDir / relPath -> content },
- resources = resources.map { case (relPath, content) => resourcesDir / relPath -> content },
- metadataOpt = metadataOpt,
- declaredVersion = Some(lib.libVersion),
+ val allDeps: IArray[Dep] =
+ IArray.fromTraversable(flavour.dependencies) ++ IArray(versions.runtime) ++ deps.toIArrayValues.map(d =>
+ d.reference,
)
+ val bleepFile = bleepBuildFile(lib.libName, versions, allDeps, publishLocalTarget)
+ val sbtLayout: SbtProjectLayout[os.RelPath, String] = ContentSbtProject(
+ versions = versions,
+ comments = lib.packageTree.comments,
+ organization = organization,
+ name = lib.libName,
+ version = VersionHack.TemplateValue,
+ scalaFiles = scalaFiles.map { case (relPath, content) => sourcesDir / relPath -> content },
+ resources = resources.map { case (relPath, content) => resourcesDir / relPath -> content },
+ metadataOpt = metadataOpt,
+ declaredVersion = Some(lib.libVersion),
+ bleepBuildFile = bleepFile,
+ allDeps = allDeps,
+ )
+
val digest = Digest.of(sbtLayout.all.collect(ScalaFiles))
val finalVersion = lib.libVersion.version(digest)
val allFilesProperVersion = VersionHack.templateVersion(sbtLayout, finalVersion)
val reference = Dep.ScalaJs(organization, lib.libName, finalVersion).concrete(versions)
- val sbtProject = SbtProject(lib.libName, reference)(compilerPaths.baseDir, deps, metadataOpt)
+ val sbtProject = ScalaProject(lib.libName, reference)(compilerPaths.baseDir, deps, metadataOpt, bleepFile)
- val existing: IvyLayout[os.RelPath, os.Path] =
- IvyLayout.unit(reference).mapValues { case (relPath, _) => publishLocalFolder / relPath }
+ val (jarFile, existing) = {
+ publishLocalTarget match {
+ case PublishLocalTarget.DefaultIvy2 =>
+ val layout =
+ IvyLayout.unit(reference).mapValues { case (relPath, _) => publishLocalTarget.path / relPath }
+ (layout.jarFile._2, layout)
+ case PublishLocalTarget.InHomeFolder(_) =>
+ val layout =
+ MavenLayout.unit(reference).mapValues { case (relPath, _) => publishLocalTarget.path / relPath }
+ (layout.jarFile._2, layout)
+ }
+ }
- val jarFile = existing.jarFile._2
val lockFile = jarFile / os.up / ".lock"
FileLocking.withLock(lockFile.toNIO) { _ =>
@@ -105,11 +124,9 @@ class Phase3Compile(
if (existing.all.forall { case (_, file) => files.exists(file) }) {
logger.warn(s"Using cached build $jarFile")
- PhaseRes.Ok(PublishedSbtProject(sbtProject)(compilerPaths.classesDir, existing, None))
+ PhaseRes.Ok(sbtProject)
} else {
- files.deleteAll(compilerPaths.classesDir)
- os.makeDir.all(compilerPaths.classesDir)
if (!ensureSourceFilesWritten) {
files.sync(
allFilesProperVersion.all,
@@ -119,46 +136,125 @@ class Phase3Compile(
)
}
- val jarDeps: Set[Compiler.InternalDep] =
- deps.values.to[Set].map(x => Compiler.InternalDepJar(x.localIvyFiles.jarFile._2))
-
- if (files.exists(compilerPaths.resourcesDir))
- os.copy.over(from = compilerPaths.resourcesDir, to = compilerPaths.classesDir, replaceExisting = true)
-
logger.warn(s"Building $jarFile...")
val t0 = System.currentTimeMillis()
- val ret: PhaseRes[LibTsSource, PublishedSbtProject] =
- compiler.compile(lib.libName, digest, compilerPaths, jarDeps, flavour.dependencies) match {
- case Right(()) =>
- val writtenIvyFiles: IvyLayout[os.RelPath, os.Path] =
- ContentForPublish(
- v = versions,
- paths = compilerPaths,
- p = sbtProject,
- publication = ZonedDateTime.now(),
- externalDeps = flavour.dependencies,
- ).mapValues { (relPath, contents) =>
- val path = publishLocalFolder / relPath
- files.softWriteBytes(path, contents)
- path
- }
+ val ret: PhaseRes[LibTsSource, ScalaProject] = {
+ val cmd = {
+ List(
+ List(
+ bleepCompiler.path.toString,
+ "--debug",
+ "--dev",
+ "publish-local",
+ "--groupId",
+ organization,
+ "--version",
+ finalVersion,
+ ),
+ publishLocalTarget match {
+ case PublishLocalTarget.DefaultIvy2 => Nil
+ case inHome: PublishLocalTarget.InHomeFolder => List("--to", inHome.path.toString())
+ },
+ List(lib.libName),
+ ).flatten
+ }
+
+ cli(
+ "bleep publish-local",
+ compilerPaths.baseDir.toNIO,
+ cmd,
+ cliLogger = cli.CliLogger(logger),
+ ) match {
+ case Right(_) =>
val elapsed = System.currentTimeMillis - t0
logger.warn(s"Built $jarFile in $elapsed ms")
- PhaseRes.Ok(PublishedSbtProject(sbtProject)(compilerPaths.classesDir, writtenIvyFiles, None))
+ PhaseRes.Ok(sbtProject)
+ case Left(writtenLines) =>
+ val errors = writtenLines.combined
+ .collect {
+ case WrittenLine.StdErr(line) if line.contains("\uD83D\uDCD5") => line
+ case WrittenLine.StdOut(line) if line.contains("\uD83D\uDCD5") => line
+ }
+ .mkString("\n")
+ logger.error(errors)
+
+ PhaseRes.Failure(Map(source -> Right(s"Compilation failed: $errors")))
- case Left(err) =>
- logger.error(err)
- val firstError = err.split("\n").drop(1).headOption.getOrElse("")
- PhaseRes.Failure(Map(source -> Right(s"Compilation failed: $firstError")))
}
+ }
- files.deleteAll(compilerPaths.targetDir)
+ // ignore errors - the folder may not exist if everything failed above
+ Try(files.deleteAll(compilerPaths.baseDir / ".bleep"))
ret
}
}
}
}
+
+}
+
+object Phase3Compile {
+ def bleepBuildFile(
+ name: String,
+ versions: Versions,
+ allDeps: IArray[Dep],
+ publishLocalTarget: PublishLocalTarget,
+ ): model.BuildFile = {
+ def toBleep(dep: Dep.Concrete): model.Dep =
+ model.Dep.Java(dep.org, dep.mangledArtifact, dep.version)
+
+ model.BuildFile(
+ $schema = model.$schema,
+ $version = model.BleepVersion.current,
+ templates = model.JsonMap.empty,
+ scripts = model.JsonMap.empty,
+ resolvers = publishLocalTarget match {
+ case PublishLocalTarget.DefaultIvy2 => model.JsonList.empty
+ case PublishLocalTarget.InHomeFolder(relPath) =>
+ model.JsonList(List(model.Repository.MavenFolder(None, Paths.get(s"$${HOME_DIR}/$relPath"))))
+ },
+ projects = model.JsonMap(
+ Map(
+ model.ProjectName(name) -> model.Project(
+ `extends` = model.JsonSet.empty,
+ cross = model.JsonMap.empty,
+ folder = Some(bleep.RelPath.force(".")),
+ dependsOn = model.JsonSet.empty,
+ `source-layout` = None,
+ `sbt-scope` = Some("main"),
+ sources = model.JsonSet.empty,
+ resources = model.JsonSet.empty,
+ dependencies = model.JsonSet[model.Dep](allDeps.map(dep => toBleep(dep.concrete(versions))).toList: _*),
+ java = None,
+ scala = Some(
+ model.Scala(
+ version = Some(model.VersionScala(versions.scala.scalaVersion)),
+ options = model.Options.parse(versions.scalacOptions, None),
+ setup = None,
+ compilerPlugins = model.JsonSet.empty,
+ strict = None,
+ ),
+ ),
+ platform = Some(
+ model.Platform.Js(
+ model.VersionScalaJs(versions.scalaJs.scalaJsVersion),
+ jsMode = None,
+ jsKind = None,
+ jsEmitSourceMaps = None,
+ jsJsdom = None,
+ jsNodeVersion = None,
+ jsMainClass = None,
+ ),
+ ),
+ isTestProject = None,
+ testFrameworks = model.JsonSet.empty,
+ ),
+ ),
+ ),
+ jvm = Some(model.Jvm("graalvm-java17:22.3.0", None)),
+ )
+ }
}
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/PublishLocalTarget.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/PublishLocalTarget.scala
new file mode 100644
index 0000000000..b095e5b58f
--- /dev/null
+++ b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/PublishLocalTarget.scala
@@ -0,0 +1,16 @@
+package org.scalablytyped.converter.internal.importer
+
+import org.scalablytyped.converter.internal.constants
+
+sealed trait PublishLocalTarget {
+ def path: os.Path =
+ this match {
+ case PublishLocalTarget.DefaultIvy2 => constants.defaultLocalPublishFolder
+ case PublishLocalTarget.InHomeFolder(relPath) => os.Path(sys.props("user.home")) / relPath
+ }
+}
+
+object PublishLocalTarget {
+ case object DefaultIvy2 extends PublishLocalTarget
+ case class InHomeFolder(relPath: os.RelPath) extends PublishLocalTarget
+}
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/BleepCompiler.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/BleepCompiler.scala
new file mode 100644
index 0000000000..823d465207
--- /dev/null
+++ b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/BleepCompiler.scala
@@ -0,0 +1,31 @@
+package org.scalablytyped.converter.internal
+package importer
+package build
+
+import bleep.{model, BleepException, FetchBleepRelease}
+import com.olvind.logging.{Formatter, Logger}
+import coursier.cache.CacheLogger
+
+import java.nio.file.Path
+import scala.concurrent.{ExecutionContext, Future}
+
+object BleepCompiler {
+ implicit val PathFormatter: Formatter[os.Path] = x => x.toString()
+
+ def apply(
+ logger: Logger[Unit],
+ )(implicit ec: ExecutionContext): Future[BleepCompiler] =
+ Future[Either[BleepException, Path]] {
+ object cacheLogger extends CacheLogger {
+ override def downloadingArtifact(url: String): Unit = logger.withContext(url).info("downloading")
+ }
+ FetchBleepRelease(model.BleepVersion.current, cacheLogger, ec)
+ }.flatMap {
+ case Left(bleepException) =>
+ Future.failed(bleepException)
+ case Right(bleep) =>
+ Future.successful(BleepCompiler(bleep))
+ }
+}
+
+case class BleepCompiler(path: Path)
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/Compiler.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/Compiler.scala
deleted file mode 100644
index 6feb4b02a6..0000000000
--- a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/Compiler.scala
+++ /dev/null
@@ -1,21 +0,0 @@
-package org.scalablytyped.converter.internal
-package importer
-package build
-
-import org.scalablytyped.converter.internal.scalajs.Dep
-
-trait Compiler {
- def compile(
- name: String,
- digest: Digest,
- compilerPaths: CompilerPaths,
- deps: Set[Compiler.InternalDep],
- externalDeps: Set[Dep],
- ): Either[String, Unit]
-}
-
-object Compiler {
- sealed trait InternalDep
- case class InternalDepClassFiles(name: String, path: os.Path) extends InternalDep
- case class InternalDepJar(path: os.Path) extends InternalDep
-}
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/CompilerPaths.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/CompilerPaths.scala
index 80501056c3..a399e260ee 100644
--- a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/CompilerPaths.scala
+++ b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/CompilerPaths.scala
@@ -9,7 +9,6 @@ case class CompilerPaths private (
sourcesDir: os.Path,
resourcesDir: os.Path,
targetDir: os.Path,
- classesDir: os.Path,
)
object CompilerPaths {
@@ -21,7 +20,6 @@ object CompilerPaths {
sourcesDir = thisBaseDir / "src" / 'main / 'scala,
resourcesDir = thisBaseDir / "src" / 'main / 'resources,
targetDir = targetDir,
- classesDir = targetDir / s"scala-${v.scala.binVersion}" / 'classes,
)
}
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ContentForPublish.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ContentForPublish.scala
deleted file mode 100644
index 860c2bebc6..0000000000
--- a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ContentForPublish.scala
+++ /dev/null
@@ -1,129 +0,0 @@
-package org.scalablytyped.converter.internal
-package importer.build
-
-import java.io._
-import java.time.ZonedDateTime
-import java.time.format.DateTimeFormatter
-import java.util.jar.{JarEntry, JarOutputStream, Manifest}
-
-import org.scalablytyped.converter.internal.scalajs.{Dep, Versions}
-
-import scala.collection.mutable
-import scala.xml.Elem
-
-object ContentForPublish {
- def apply(
- v: Versions,
- paths: CompilerPaths,
- p: SbtProject,
- publication: ZonedDateTime,
- externalDeps: Set[Dep],
- ): IvyLayout[os.RelPath, Array[Byte]] =
- IvyLayout(
- p = p.reference,
- jarFile = createJar(publication)(paths.classesDir),
- sourceFile = createJar(publication)(paths.sourcesDir),
- ivyFile = fromXml(ivy(v, p, publication, externalDeps)),
- pomFile = fromXml(pom(v, p, externalDeps)),
- )
-
- private def fromXml(xml: Elem): Array[Byte] = {
- val prelude: String = """"""
- (prelude + xml).getBytes(constants.Utf8)
- }
-
- private def createManifest(): Manifest = {
- val m = new java.util.jar.Manifest()
- m.getMainAttributes.put(java.util.jar.Attributes.Name.MANIFEST_VERSION, "1.0")
- m.getMainAttributes.putValue("Created-By", "ScalablyTypedConverter")
- m
- }
-
- // adapted from mill
- def createJar(publication: ZonedDateTime)(fromFolders: os.Path*): Array[Byte] = {
- val seen = mutable.Set[os.RelPath](os.RelPath("META-INF") / "MANIFEST.MF")
- val baos = new ByteArrayOutputStream(1024 * 1024)
- val jar = new JarOutputStream(baos, createManifest())
-
- try {
- fromFolders.foreach { fromFolder =>
- os.walk(fromFolder).collect { case file if os.isFile(file) => file }.foreach { file =>
- val mapping = file.relativeTo(fromFolder)
- if (!seen(mapping)) {
- seen.add(mapping)
- val entry = new JarEntry(mapping.toString)
- entry.setTime(publication.toEpochSecond)
- jar.putNextEntry(entry)
- jar.write(os.read.bytes(file))
- jar.closeEntry()
- }
- }
- }
- } finally jar.close()
-
- baos.toByteArray
- }
-
- def ivy(v: Versions, p: SbtProject, publication: ZonedDateTime, externalDeps: Set[Dep]): Elem =
-
-
-
- {p.name}
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
- {v.scala.compiler.concrete(v).asIvy("scala-tool->default,optional(default)")}
- {v.scala.library.asIvy("scala-tool->default,optional(default);compile->default(compile)")}
- {v.scalaJsCompiler.toList.map(_.concrete(v).asIvy("plugin->default(compile)"))}
- {v.scalaJsLibrary.concrete(v).asIvy()}
- {v.scalaJsTestInterface.concrete(v).asIvy("test->default(compile)")}
- {v.runtime.concrete(v).asIvy()}
- {p.deps.map { case (_, d) => d.project.reference.asIvy() }}
- {externalDeps.map(d => d.concrete(v).asIvy())}
-
-
-
- def pom(v: Versions, p: SbtProject, externalDeps: Set[Dep]): Elem =
-
- 4.0.0
- {p.reference.org}
- {p.reference.mangledArtifact}
- jar
- {p.name}
- {p.reference.version}
- {p.name}
-
- {p.reference.org}
-
-
- {v.scala.library.concrete(v).asMaven}
- {v.scalaJsLibrary.concrete(v).asMaven}
- {v.scalaJsTestInterface.concrete(v).asMavenTest}
- {v.runtime.concrete(v).asMaven}
- {p.deps.map { case (_, d) => d.project.reference.asMaven }}
- {externalDeps.map(d => d.concrete(v).asMaven)}
-
-
-}
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ContentSbtProject.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ContentSbtProject.scala
index 421299bc0d..262e1093b6 100644
--- a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ContentSbtProject.scala
+++ b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ContentSbtProject.scala
@@ -2,6 +2,7 @@ package org.scalablytyped.converter.internal
package importer
package build
+import bleep.{model, yaml}
import org.scalablytyped.converter.internal.importer.documentation.{Npmjs, ProjectReadme}
import org.scalablytyped.converter.internal.scalajs.{Dep, Versions}
import org.scalablytyped.converter.internal.stringUtils.quote
@@ -13,18 +14,15 @@ object ContentSbtProject {
organization: String,
name: String,
version: String,
- localDeps: IArray[PublishedSbtProject],
- deps: Set[Dep],
scalaFiles: IArray[(os.RelPath, String)],
resources: IArray[(os.RelPath, String)],
metadataOpt: Option[Npmjs.Data],
declaredVersion: Option[LibraryVersion],
+ bleepBuildFile: model.BuildFile,
+ allDeps: IArray[Dep],
): SbtProjectLayout[os.RelPath, String] = {
val buildSbt = {
- val allDeps: IArray[Dep] = IArray.fromTraversable(deps) ++ IArray(versions.runtime) ++ localDeps.map(d =>
- d.project.reference,
- )
val depsString = allDeps.map(_.asSbt).distinct.sorted.mkString("Seq(\n ", ",\n ", ")")
s"""|organization := ${quote(organization)}
@@ -51,6 +49,7 @@ object ContentSbtProject {
os.RelPath("project") / "build.properties" -> s"sbt.version=${Versions.sbtVersion}",
os.RelPath("project") / "plugins.sbt" -> pluginsSbt,
readme,
+ os.RelPath("bleep.yaml") -> yaml.encodeShortened(bleepBuildFile),
scalaFiles,
resources,
)
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/SbtProject.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/SbtProject.scala
deleted file mode 100644
index b427588031..0000000000
--- a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/SbtProject.scala
+++ /dev/null
@@ -1,40 +0,0 @@
-package org.scalablytyped.converter.internal
-package importer
-package build
-
-import org.scalablytyped.converter.internal.importer.documentation.Npmjs
-import org.scalablytyped.converter.internal.scalajs.Dep
-
-import scala.collection.immutable.SortedMap
-
-case class SbtProject(name: String, reference: Dep.Concrete)(
- val baseDir: os.Path,
- val deps: Map[LibTsSource, PublishedSbtProject],
- val metadata: Option[Npmjs.Data],
-)
-
-case class PublishedSbtProject(project: SbtProject)(
- val classfileDir: os.Path,
- val localIvyFiles: IvyLayout[os.RelPath, os.Path],
- val publishedOpt: Option[Unit],
-)
-
-object PublishedSbtProject {
- object Unpack {
- def unapply(m: SortedMap[LibTsSource, PublishedSbtProject]): Some[SortedMap[LibTsSource, PublishedSbtProject]] =
- Some(apply(m))
-
- def apply(m: SortedMap[LibTsSource, PublishedSbtProject]): SortedMap[LibTsSource, PublishedSbtProject] = {
- val b = SortedMap.newBuilder[LibTsSource, PublishedSbtProject]
-
- def go(tuple: (LibTsSource, PublishedSbtProject)): Unit = {
- b += tuple
- tuple._2.project.deps.foreach(go)
- }
-
- m.foreach(go)
-
- b.result()
- }
- }
-}
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ScalaProject.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ScalaProject.scala
new file mode 100644
index 0000000000..5eb8b839ec
--- /dev/null
+++ b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/ScalaProject.scala
@@ -0,0 +1,36 @@
+package org.scalablytyped.converter.internal
+package importer
+package build
+
+import bleep.model
+import org.scalablytyped.converter.internal.importer.documentation.Npmjs
+import org.scalablytyped.converter.internal.scalajs.Dep
+
+import scala.collection.immutable.SortedMap
+
+case class ScalaProject(name: String, reference: Dep.Concrete)(
+ val baseDir: os.Path,
+ val deps: Map[LibTsSource, ScalaProject],
+ val metadata: Option[Npmjs.Data],
+ val bleepFile: model.BuildFile,
+)
+
+object ScalaProject {
+ object Unpack {
+ def unapply(m: SortedMap[LibTsSource, ScalaProject]): Some[SortedMap[LibTsSource, ScalaProject]] =
+ Some(apply(m))
+
+ def apply(m: SortedMap[LibTsSource, ScalaProject]): SortedMap[LibTsSource, ScalaProject] = {
+ val b = SortedMap.newBuilder[LibTsSource, ScalaProject]
+
+ def go(tuple: (LibTsSource, ScalaProject)): Unit = {
+ b += tuple
+ tuple._2.deps.foreach(go)
+ }
+
+ m.foreach(go)
+
+ b.result()
+ }
+ }
+}
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/layouts.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/layouts.scala
index 61681921b7..6fc7196a33 100644
--- a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/layouts.scala
+++ b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/build/layouts.scala
@@ -29,21 +29,23 @@ final case class SbtProjectLayout[F, V](
buildProperties: (F, V),
pluginsSbt: (F, V),
readmeMd: (F, V),
+ bleepYaml: (F, V),
sourcesDir: IArray[(F, V)],
resourcesDir: IArray[(F, V)],
) extends Layout[F, V] {
override type Self[f, v] = SbtProjectLayout[f, v]
override def all: IArray[(F, V)] =
- IArray(buildSbt, buildProperties, pluginsSbt, readmeMd) ++ sourcesDir ++ resourcesDir
+ IArray(buildSbt, buildProperties, pluginsSbt, readmeMd, bleepYaml) ++ sourcesDir ++ resourcesDir
override def map[FF, VV](f: (F, V) => (FF, VV)): SbtProjectLayout[FF, VV] =
this match {
- case SbtProjectLayout((_1k, _1v), (_2k, _2v), (_3k, _3v), (_4k, _4v), sources, resources) =>
+ case SbtProjectLayout((_1k, _1v), (_2k, _2v), (_3k, _3v), (_4k, _4v), (_5k, _5v), sources, resources) =>
SbtProjectLayout(
f(_1k, _1v),
f(_2k, _2v),
f(_3k, _3v),
f(_4k, _4v),
+ f(_5k, _5v),
sources.map { case (k, v) => f(k, v) },
resources.map { case (k, v) => f(k, v) },
)
@@ -86,6 +88,9 @@ final case class MavenLayout[F, V](jarFile: (F, V), sourceFile: (F, V), pomFile:
}
object MavenLayout {
+ def unit(p: Dep.Concrete): MavenLayout[os.RelPath, Unit] =
+ apply(p, (), (), ())
+
def apply[T](p: Dep.Concrete, jarFile: T, sourceFile: T, pomFile: T): MavenLayout[os.RelPath, T] = {
val org: os.RelPath =
p.org.split("\\.").foldLeft(os.RelPath(""))(_ / _)
diff --git a/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/cli.scala b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/cli.scala
new file mode 100644
index 0000000000..d7fe87351c
--- /dev/null
+++ b/importer-portable/src/main/scala/org/scalablytyped/converter/internal/importer/cli.scala
@@ -0,0 +1,93 @@
+package org.scalablytyped.converter.internal.importer
+
+import com.olvind.logging.Logger
+import sourcecode.{Enclosing, File, Line}
+
+import java.nio.file.Path
+import scala.sys.process.{BasicIO, Process, ProcessIO}
+
+// todo: replicated in bleep
+object cli {
+ sealed trait WrittenLine
+ object WrittenLine {
+ case class StdErr(line: String) extends WrittenLine
+ case class StdOut(line: String) extends WrittenLine
+ }
+
+ case class WrittenLines(combined: Array[WrittenLine]) {
+ def stdout: Array[String] = combined.collect { case WrittenLine.StdOut(line) => line }
+ def stderr: Array[String] = combined.collect { case WrittenLine.StdErr(line) => line }
+ }
+
+ sealed trait StdIn
+ object StdIn {
+ case object No extends StdIn
+ case object Attach extends StdIn
+ case class Provided(data: Array[Byte]) extends StdIn
+ }
+
+ case class CliLogger(logger: Logger[_])(implicit l: Line, f: File, e: Enclosing) {
+ def apply(writtenLine: WrittenLine): Unit =
+ writtenLine match {
+ case WrittenLine.StdErr(line) =>
+ logger.warn(line)(implicitly, l, f, e)
+ case WrittenLine.StdOut(line) =>
+ logger.info(line)(implicitly, l, f, e)
+ }
+ }
+
+ def apply(
+ action: String,
+ cwd: Path,
+ cmd: List[String],
+ cliLogger: CliLogger,
+ stdIn: StdIn = StdIn.No,
+ env: List[(String, String)] = Nil,
+ ): Either[WrittenLines, WrittenLines] = {
+ val process = Process {
+ val builder = new java.lang.ProcessBuilder(cmd: _*)
+ builder.directory(cwd.toFile)
+ builder.environment().clear()
+ env.foreach { case (k, v) => builder.environment.put(k, v) }
+ builder
+ }
+
+ val output = Array.newBuilder[WrittenLine]
+
+ val processIO = new ProcessIO(
+ writeInput = os =>
+ stdIn match {
+ case StdIn.No => ()
+ case StdIn.Attach => BasicIO.connectToIn(os)
+ case StdIn.Provided(data) =>
+ os.write(data)
+ os.close()
+ },
+ processOutput = BasicIO.processFully { line =>
+ val stdOut = WrittenLine.StdOut(line)
+ output += stdOut
+ cliLogger(stdOut)
+ },
+ processError = BasicIO.processFully { line =>
+ val stdErr = WrittenLine.StdErr(line)
+ output += stdErr
+ cliLogger(stdErr)
+ },
+ daemonizeThreads = false,
+ )
+
+ val exitCode = process.run(processIO).exitValue()
+
+ exitCode match {
+ case 0 => Right(WrittenLines(output.result()))
+ case n =>
+ cliLogger.logger
+ .withContext(action)
+ .withContext(cwd.toString)
+ .withContext(cmd)
+ .withContext(env)
+ .debug(s"Failed external command with error code $n")
+ Left(WrittenLines(output.result()))
+ }
+ }
+}
diff --git a/importer/src/main/scala/org/scalablytyped/converter/Main.scala b/importer/src/main/scala/org/scalablytyped/converter/Main.scala
index b58c15de3d..560241296a 100644
--- a/importer/src/main/scala/org/scalablytyped/converter/Main.scala
+++ b/importer/src/main/scala/org/scalablytyped/converter/Main.scala
@@ -2,10 +2,9 @@ package org.scalablytyped.converter
import java.nio.file.Path
import java.util.concurrent.ForkJoinPool
-
import org.scalablytyped.converter.internal.constants
import org.scalablytyped.converter.internal.constants.defaultCacheFolder
-import org.scalablytyped.converter.internal.importer.{withZipFs, Ci}
+import org.scalablytyped.converter.internal.importer.{withZipFs, Ci, PublishLocalTarget}
import scala.concurrent.ExecutionContext
@@ -31,7 +30,7 @@ object Main {
npmjs = npmjsPath,
parseCache = parseCacheOpt,
cacheFolder = defaultCacheFolder,
- publishLocalFolder = constants.defaultLocalPublishFolder,
+ publishLocalTarget = PublishLocalTarget.DefaultIvy2,
gitCache = defaultCacheFolder / "git",
)
val ci = new Ci(config, paths, pool, ec)
diff --git a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/Ci.scala b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/Ci.scala
index c029b6b2a4..cc79ecab9b 100644
--- a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/Ci.scala
+++ b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/Ci.scala
@@ -28,7 +28,7 @@ object Ci {
npmjs: Path,
parseCache: Option[Path],
cacheFolder: os.Path,
- publishLocalFolder: os.Path,
+ publishLocalTarget: PublishLocalTarget,
gitCache: os.Path,
)
@@ -199,12 +199,8 @@ class Ci(config: Ci.Config, paths: Ci.Paths, pool: ForkJoinPool, ec: ExecutionCo
} yield Bootstrap.forCi(externalsFolder, dtFolder, config.conversion, config.wantedLibs)
}
- val compilerF: Future[BloopCompiler] =
- BloopCompiler(
- logger = logger.filter(LogLevel.debug).void,
- v = config.conversion.versions,
- failureCacheFolderOpt = Some((paths.cacheFolder / 'compileFailures).toNIO),
- )(ec)
+ val compilerF: Future[BleepCompiler] =
+ BleepCompiler(logger = logger.filter(LogLevel.debug).void)(ec)
val dtFolderF: Future[InFolder] =
Future(
@@ -238,8 +234,8 @@ class Ci(config: Ci.Config, paths: Ci.Paths, pool: ForkJoinPool, ec: ExecutionCo
val localCleaningF = Future {
if (config.conserveSpace) {
- interfaceLogger.warn(s"Cleaning old artifacts in ${paths.publishLocalFolder}")
- LocalCleanup(paths.publishLocalFolder, config.conversion.organization, keepNum = 1)
+ interfaceLogger.warn(s"Cleaning old artifacts in ${paths.publishLocalTarget.path}")
+ LocalCleanup(paths.publishLocalTarget.path, config.conversion.organization, keepNum = 1)
}
}(ec)
@@ -256,7 +252,7 @@ class Ci(config: Ci.Config, paths: Ci.Paths, pool: ForkJoinPool, ec: ExecutionCo
val t0 = System.currentTimeMillis
- val Pipeline: RecPhase[LibTsSource, PublishedSbtProject] =
+ val Pipeline: RecPhase[LibTsSource, ScalaProject] =
RecPhase[LibTsSource]
.next(
new Phase1ReadTypescript(
@@ -288,10 +284,10 @@ class Ci(config: Ci.Config, paths: Ci.Paths, pool: ForkJoinPool, ec: ExecutionCo
.next(
new Phase3Compile(
versions = config.conversion.versions,
- compiler = compiler,
+ bleepCompiler = compiler,
targetFolder = targetFolder,
organization = config.conversion.organization,
- publishLocalFolder = paths.publishLocalFolder,
+ publishLocalTarget = paths.publishLocalTarget,
metadataFetcher = NpmjsFetcher(paths.npmjs)(ec),
softWrites = config.softWrites,
flavour = config.conversion.flavourImpl,
@@ -307,7 +303,7 @@ class Ci(config: Ci.Config, paths: Ci.Paths, pool: ForkJoinPool, ec: ExecutionCo
case Right(sources) => sources
}
- val results: Map[LibTsSource, PhaseRes[LibTsSource, PublishedSbtProject]] =
+ val results: Map[LibTsSource, PhaseRes[LibTsSource, ScalaProject]] =
Interface(config.debugMode) { listener =>
initial
.map(source => source -> PhaseRunner(Pipeline, logRegistry.get, listener)(source))
@@ -318,9 +314,9 @@ class Ci(config: Ci.Config, paths: Ci.Paths, pool: ForkJoinPool, ec: ExecutionCo
return Some(System.currentTimeMillis - t0)
}
- val successes: Map[LibTsSource, PublishedSbtProject] = {
- def go(source: LibTsSource, p: PublishedSbtProject): Map[LibTsSource, PublishedSbtProject] =
- Map(source -> p) ++ p.project.deps.flatMap { case (k, v) => go(k, v) }
+ val successes: Map[LibTsSource, ScalaProject] = {
+ def go(source: LibTsSource, p: ScalaProject): Map[LibTsSource, ScalaProject] =
+ Map(source -> p) ++ p.deps.flatMap { case (k, v) => go(k, v) }
results.collect { case (s, PhaseRes.Ok(res)) => go(s, res) }.reduceOption(_ ++ _).getOrElse(Map.empty)
}
@@ -377,7 +373,7 @@ target/
CommitChanges(
interfaceCmd,
summary,
- successes.values.map(_.project.baseDir).to[Vector],
+ successes.values.map(_.baseDir).to[Vector],
Vector(sbtProjectDir, readme, librariesByScore, librariesByName, librariesByDependents, gitIgnore, summaryFile),
formattedDiff,
)(targetFolder)
diff --git a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/Interface.scala b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/Interface.scala
index caeed88854..ab68fd7419 100644
--- a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/Interface.scala
+++ b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/Interface.scala
@@ -4,8 +4,8 @@ package importer
import org.scalablytyped.converter.internal.phases.PhaseListener
import org.scalablytyped.converter.internal.ts.TsIdentLibrary
import fansi.Color
-import monix.execution.atomic.AtomicBoolean
+import java.util.concurrent.atomic.AtomicBoolean
import scala.collection.mutable
import scala.util.Try
@@ -31,7 +31,7 @@ object Interface {
private def active = status.collect { case (lib, x: Started[LibTsSource]) => (lib, x) }
private def blocked = status.collect { case (lib, x: Blocked[LibTsSource]) => (lib, x) }
private def succeeded = status.collect { case (lib, x: Success[LibTsSource]) => lib -> x }
- private val hasExited = AtomicBoolean(false)
+ private val hasExited = new AtomicBoolean(false)
def finish(): Unit = {
require(blocked.isEmpty)
diff --git a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/build/BloopCompiler.scala b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/build/BloopCompiler.scala
deleted file mode 100644
index 74a640f27b..0000000000
--- a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/build/BloopCompiler.scala
+++ /dev/null
@@ -1,211 +0,0 @@
-package org.scalablytyped.converter.internal
-package importer
-package build
-
-import java.io.{ByteArrayOutputStream, PrintStream}
-import java.nio.file.{Files, Path}
-
-import bloop.Cli
-import bloop.cli.{CliOptions, Commands, CommonOptions, ExitStatus}
-import bloop.config.{Config => BloopConfig}
-import bloop.engine.NoPool
-import bloop.io.AbsolutePath
-import com.olvind.logging.{Formatter, Logger}
-import coursier.cache.{ArtifactError, FileCache}
-import coursier.error.{FetchError, ResolutionError}
-import coursier.util.Task
-import coursier.{Dependency, Fetch, Module}
-import org.scalablytyped.converter.internal.scalajs.{Dep, Versions}
-
-import scala.concurrent.duration._
-import scala.concurrent.{Await, ExecutionContext, Future}
-
-object BloopCompiler {
- implicit val AbsolutePathFormatter: Formatter[AbsolutePath] = x => x.syntax
-
- def toCoursier(dep: Dep.Concrete): Dependency =
- Dependency(
- Module(coursier.Organization(dep.org), coursier.ModuleName(dep.mangledArtifact)),
- dep.version,
- )
-
- // I've experienced `checksum not found` errors from coursier in test
- val fileCache = FileCache[Task]().withChecksums(List(None))
-
- def resolve(deps: Dep.Concrete*)(implicit ec: ExecutionContext): Future[Array[AbsolutePath]] = {
- def go(remainingAttempts: Int): Future[Array[AbsolutePath]] =
- Fetch[Task](fileCache)
- .withDependencies(deps.map(toCoursier))
- .io
- .future()
- .map(files => files.map(f => AbsolutePath(f)).toArray)
- .recoverWith {
- case x: ResolutionError.CantDownloadModule
- if remainingAttempts > 0 && x.perRepositoryErrors.exists(_.contains("concurrent download")) =>
- go(remainingAttempts - 1)
- case x: FetchError.DownloadingArtifacts if remainingAttempts > 0 && x.errors.exists {
- case (_, artifactError) => artifactError.isInstanceOf[ArtifactError.Recoverable]
- } =>
- go(remainingAttempts - 1)
- }
-
- go(remainingAttempts = 3)
- }
-
- def apply(
- logger: Logger[Unit],
- v: Versions,
- failureCacheFolderOpt: Option[Path],
- )(implicit ec: ExecutionContext): Future[BloopCompiler] = {
- val scalaCompilerF = resolve(v.scala.compiler.concrete(v))
- val globalClasspathBaseF = resolve(v.scalaJsLibrary.concrete(v), v.runtime.concrete(v))
- val scalaJsCompilerBaseF = resolve(v.scalaJsCompiler.toList.map(_.concrete(v)): _*)
-
- for {
- scalaCompiler <- scalaCompilerF
- globalClasspathBase <- globalClasspathBaseF
- scalaJsCompilerBase <- scalaJsCompilerBaseF
- } yield {
- logger.warn(s"Initializing scala compiler ${v.scala.scalaVersion} with scala.js ${v.scalaJs.scalaJsVersion}")
-
- val globalClasspath: Array[AbsolutePath] =
- scalaCompiler.collect { case path if path.toString.contains("scala-library") => path } ++ globalClasspathBase
-
- val scalaJsCompiler =
- scalaJsCompilerBase.collectFirst { case f if f.syntax.contains("scalajs-compiler") => f }
-
- logger.warn(globalClasspath)
- logger.warn(scalaJsCompiler.toString)
-
- new BloopCompiler(logger, failureCacheFolderOpt, v, globalClasspath, scalaCompiler, scalaJsCompiler)
- }
- }
-}
-
-class BloopCompiler private (
- logger: Logger[Unit],
- failureCacheFolderOpt: Option[Path],
- versions: Versions,
- globalClassPath: Array[AbsolutePath],
- scalaJars: Array[AbsolutePath],
- scalaJsCompiler: Option[AbsolutePath],
-) extends Compiler {
- override def compile(
- name: String,
- digest: Digest,
- compilerPaths: CompilerPaths,
- deps: Set[Compiler.InternalDep],
- externalDeps: Set[Dep],
- ): Either[String, Unit] = {
- val bloopFolder = compilerPaths.baseDir / ".bloop"
-
- val classPath = {
- val fromExternalDeps: Array[AbsolutePath] =
- Await.result(
- BloopCompiler.resolve(externalDeps.toArray.map(_.concrete(versions)): _*)(ExecutionContext.global),
- Duration.Inf,
- )
-
- val fromDependencyJars: Set[AbsolutePath] =
- deps.collect { case Compiler.InternalDepJar(jar) => AbsolutePath(jar.toIO) }
-
- val fromDependencyClassDirs: Set[AbsolutePath] =
- deps.collect { case Compiler.InternalDepClassFiles(_, path) => AbsolutePath(path.toIO) }
-
- (globalClassPath ++ fromExternalDeps ++ fromDependencyJars ++ fromDependencyClassDirs).map(_.underlying).toList
- }
-
- val classesDir = compilerPaths.classesDir
- val outDir = compilerPaths.baseDir / "target"
-
- val scalaJsOption: String =
- if (versions.scala.is3) "-scalajs"
- else scalaJsCompiler.map(scalaJsCompiler => "-Xplugin:" + scalaJsCompiler.syntax).get
-
- val projectFile = BloopConfig.File(
- "1.5.0",
- BloopConfig.Project(
- name = name,
- directory = compilerPaths.baseDir.toNIO,
- sources = List(compilerPaths.sourcesDir.toNIO),
- dependencies = deps.collect { case Compiler.InternalDepClassFiles(name, _) => name }.toList,
- classpath = classPath,
- out = outDir.toNIO,
- classesDir = compilerPaths.classesDir.toNIO,
- resources = None,
- scala = Some(
- BloopConfig.Scala(
- organization = versions.scala.scalaOrganization,
- name = "scala-compiler",
- version = versions.scala.scalaVersion,
- options = scalaJsOption :: versions.scalacOptions,
- jars = scalaJars.toList.map(_.underlying),
- analysis = None,
- setup = None,
- ),
- ),
- java = None,
- sbt = None,
- test = None,
- platform = None,
- resolution = None,
- workspaceDir = None,
- sourcesGlobs = None,
- sourceRoots = None,
- tags = None,
- sourceGenerators = None,
- ),
- )
- os.makeDir.all(bloopFolder)
- bloop.config.write(projectFile, (bloopFolder / (name + ".json")).toNIO)
-
- val outStream = new ByteArrayOutputStream
- val printStream = new PrintStream(outStream)
-
- val cacheFileOpt = failureCacheFolderOpt.map(_.resolve(name).resolve(digest.hexString))
-
- cacheFileOpt match {
- case Some(cacheFile) if Files.exists(cacheFile) =>
- Left(new String(Files.readAllBytes(cacheFile), constants.Utf8))
- case _ =>
- val status = Cli.run(
- bloop.engine.Run(
- Commands.Compile(
- projects = List(name),
- incremental = false,
- cliOptions = CliOptions(
- configDir = Some(bloopFolder.toNIO),
- common = CommonOptions(err = printStream, out = printStream),
- ),
- ),
- ),
- NoPool,
- )
-
- status match {
- case ExitStatus.Ok =>
- outStream.toString(constants.Utf8.name).linesIterator.filter(_.contains("[W]")).toVector match {
- case Vector() => ()
- case warnings => warnings.foreach(warning => logger.warn(warning))
- }
-
- /** bloop 1.4.3 apparently doesnt use `classesDir` as the path where it puts class files anymore.
- * Move them back to where we expect them
- */
- os.move.over(outDir / "bloop-bsp-clients-classes" / "classes-bloop-cli", classesDir)
-
- Right(())
- case other =>
- val msg = outStream.toString(constants.Utf8.name)
- /* save failure, but guard against flaky errors */
- (other, cacheFileOpt) match {
- case (ExitStatus.CompilationError, Some(cacheFile)) if !msg.contains("Unexpected error when compiling") =>
- files.writeBytes(cacheFile, msg.getBytes(constants.Utf8.name))
- case _ => ()
- }
-
- Left(msg)
- }
- }
- }
-}
diff --git a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/build/GenerateSbtPlugin.scala b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/build/GenerateSbtPlugin.scala
index c4270c65d5..813abc46a6 100644
--- a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/build/GenerateSbtPlugin.scala
+++ b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/build/GenerateSbtPlugin.scala
@@ -12,7 +12,7 @@ object GenerateSbtPlugin {
organization: String,
projectName: ProjectName,
projectDir: os.Path,
- projects: Set[PublishedSbtProject],
+ projects: Set[ScalaProject],
pluginVersion: String,
action: String,
): Unit = {
@@ -36,7 +36,7 @@ object GenerateSbtPlugin {
isDeprecated: Boolean,
organization: String,
projectName: ProjectName,
- projects: Set[PublishedSbtProject],
+ projects: Set[ScalaProject],
pluginVersion: String,
): IArray[(os.RelPath, String)] = {
@@ -58,7 +58,6 @@ object GenerateSbtPlugin {
val projectsByLetter =
projects
- .map(_.project)
.groupBy(_.name.head)
.to[Array]
.sortBy(_._1)
diff --git a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/documentation/TopLists.scala b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/documentation/TopLists.scala
index 7e248673d0..c18852dbc3 100644
--- a/importer/src/main/scala/org/scalablytyped/converter/internal/importer/documentation/TopLists.scala
+++ b/importer/src/main/scala/org/scalablytyped/converter/internal/importer/documentation/TopLists.scala
@@ -1,7 +1,7 @@
package org.scalablytyped.converter.internal
package importer.documentation
-import org.scalablytyped.converter.internal.importer.build.PublishedSbtProject
+import org.scalablytyped.converter.internal.importer.build.ScalaProject
object TopLists {
case class Lists(byScore: String, byName: String, byDependents: String)
@@ -22,20 +22,20 @@ object TopLists {
.filter(_.nonEmpty)
.getOrElse("-")
- def apply(successes: Set[PublishedSbtProject]): Lists = {
+ def apply(successes: Set[ScalaProject]): Lists = {
val withMetadata = successes.toArray.collect {
- case x if x.project.metadata.isDefined => x -> x.project.metadata.get
+ case x if x.metadata.isDefined => x -> x.metadata.get
}
- val byScoreRows = withMetadata.sortBy { case (p, m) => (-m.score.`final`, p.project.name) }.map {
+ val byScoreRows = withMetadata.sortBy { case (p, m) => (-m.score.`final`, p.name) }.map {
case (p, m) =>
- s"| ${m.score.`final`} | ${link(p.project.name, s"./${p.project.name.head}/${p.project.name}")} | ${desc(m)}"
+ s"| ${m.score.`final`} | ${link(p.name, s"./${p.name.head}/${p.name}")} | ${desc(m)}"
}
- val byNameRows = successes.toArray.sortBy { _.project.name }.map { x =>
- val nameLink = link(x.project.name, s"./${x.project.name.head}/${x.project.name}")
- val description = x.project.metadata.fold("-")(desc)
- val keywords = x.project.metadata
+ val byNameRows = successes.toArray.sortBy { _.name }.map { x =>
+ val nameLink = link(x.name, s"./${x.name.head}/${x.name}")
+ val description = x.metadata.fold("-")(desc)
+ val keywords = x.metadata
.flatMap(_.collected.metadata.keywords)
.map(_.mkString(", "))
.filter(_.nonEmpty)
@@ -44,10 +44,10 @@ object TopLists {
}
val byDependentsRows = withMetadata
- .sortBy { case (p, m) => (-m.evaluation.popularity.dependentsCount, p.project.name) }
+ .sortBy { case (p, m) => (-m.evaluation.popularity.dependentsCount, p.name) }
.map {
case (p, m) =>
- s"| ${m.evaluation.popularity.dependentsCount} | ${link(p.project.name, s"./${p.project.name.head}/${p.project.name}")} | ${desc(m)}"
+ s"| ${m.evaluation.popularity.dependentsCount} | ${link(p.name, s"./${p.name.head}/${p.name}")} | ${desc(m)}"
}
Lists(
diff --git a/importer/src/test/scala/org/scalablytyped/converter/internal/importer/ImporterHarness.scala b/importer/src/test/scala/org/scalablytyped/converter/internal/importer/ImporterHarness.scala
index 7628fae22d..e272f3f7fa 100644
--- a/importer/src/test/scala/org/scalablytyped/converter/internal/importer/ImporterHarness.scala
+++ b/importer/src/test/scala/org/scalablytyped/converter/internal/importer/ImporterHarness.scala
@@ -5,7 +5,7 @@ import ammonite.ops.{%, %%, ShelloutException}
import com.olvind.logging
import com.olvind.logging.{LogLevel, LogRegistry}
import org.scalablytyped.converter.Selection
-import org.scalablytyped.converter.internal.importer.build.{BloopCompiler, PublishedSbtProject}
+import org.scalablytyped.converter.internal.importer.build.{BleepCompiler, ScalaProject}
import org.scalablytyped.converter.internal.importer.documentation.Npmjs
import org.scalablytyped.converter.internal.maps._
import org.scalablytyped.converter.internal.phases.{PhaseListener, PhaseRes, PhaseRunner, RecPhase}
@@ -54,20 +54,17 @@ trait ImporterHarness extends AnyFunSuite {
def version: Versions
def mode: Mode
- private lazy val bloop = Await.result(
- BloopCompiler(testLogger, version, Some(failureCacheDir.toNIO))(ExecutionContext.Implicits.global),
- Duration.Inf,
- )
+ val bleepCompiler = Await.result(BleepCompiler(testLogger)(ExecutionContext.Implicits.global), Duration.Inf)
private def runImport(
source: InFolder,
targetFolder: os.Path,
pedantic: Boolean,
logRegistry: LogRegistry[LibTsSource, TsIdentLibrary, StringWriter],
- publishLocalFolder: os.Path,
+ publishLocalTarget: PublishLocalTarget.InHomeFolder,
flavour: FlavourImpl,
maybePrivateWithin: Option[Name],
- ): PhaseRes[LibTsSource, SortedMap[LibTsSource, PublishedSbtProject]] = {
+ ): PhaseRes[LibTsSource, SortedMap[LibTsSource, ScalaProject]] = {
val stdLibSource: LibTsSource.StdLibSource =
LibTsSource.StdLibSource(
InFolder(source.path),
@@ -79,7 +76,7 @@ trait ImporterHarness extends AnyFunSuite {
val ignored = Set.empty[TsIdentLibrary]
val resolver = new LibraryResolver(stdLibSource, allSources, ignored)
- val phase: RecPhase[LibTsSource, PublishedSbtProject] =
+ val phase: RecPhase[LibTsSource, ScalaProject] =
RecPhase[LibTsSource]
.next(
new Phase1ReadTypescript(
@@ -108,10 +105,10 @@ trait ImporterHarness extends AnyFunSuite {
.next(
new Phase3Compile(
versions = version,
- compiler = bloop,
+ bleepCompiler = bleepCompiler,
targetFolder = targetFolder,
organization = "org.scalablytyped",
- publishLocalFolder = publishLocalFolder,
+ publishLocalTarget = publishLocalTarget,
metadataFetcher = Npmjs.No,
softWrites = true,
flavour = flavour,
@@ -121,13 +118,13 @@ trait ImporterHarness extends AnyFunSuite {
"build",
)
- val results: SortedMap[LibTsSource, PhaseRes[LibTsSource, PublishedSbtProject]] =
+ val results: SortedMap[LibTsSource, PhaseRes[LibTsSource, ScalaProject]] =
allSources
.map(s => (s: LibTsSource) -> PhaseRunner(phase, logRegistry.get, PhaseListener.NoListener)(s))
.toMap
.toSorted
- PhaseRes.sequenceMap(results).map(PublishedSbtProject.Unpack.apply)
+ PhaseRes.sequenceMap(results).map(ScalaProject.Unpack.apply)
}
def findTestFolder(testName: String): InFolder = {
@@ -174,9 +171,10 @@ trait ImporterHarness extends AnyFunSuite {
_ => logging.appendable(new StringWriter()),
)
- val publishFolder = baseDir / "artifacts" / testName
+ val publishLocalTarget =
+ PublishLocalTarget.InHomeFolder(os.RelPath(".cache") / "scalablytyped" / "test-artifacts" / testName)
- runImport(source, targetFolder, pedantic, logRegistry, publishFolder, flavour, maybePrivateWithin) match {
+ runImport(source, targetFolder, pedantic, logRegistry, publishLocalTarget, flavour, maybePrivateWithin) match {
case PhaseRes.Ok(_) if run == Mode.RunDontStore => succeed
case PhaseRes.Ok(_) =>
implicit val wd = os.pwd
diff --git a/importer/src/test/scala/org/scalablytyped/converter/internal/importer/build/ContentForPublishTest.scala b/importer/src/test/scala/org/scalablytyped/converter/internal/importer/build/ContentForPublishTest.scala
deleted file mode 100644
index 87c46d64bf..0000000000
--- a/importer/src/test/scala/org/scalablytyped/converter/internal/importer/build/ContentForPublishTest.scala
+++ /dev/null
@@ -1,132 +0,0 @@
-package org.scalablytyped.converter.internal
-package importer
-package build
-
-import java.time.ZonedDateTime
-
-import org.scalablytyped.converter.internal.scalajs.{Dep, Versions}
-import org.scalablytyped.converter.internal.ts.TsIdent
-import org.scalatest.funsuite.AnyFunSuite
-import org.scalatest.matchers.should.Matchers
-
-class ContentForPublishTest extends AnyFunSuite with Matchers {
-
- val dummyPath = os.root / 'tmp
- val versions = Versions(Versions.Scala("2.13.8"), Versions.ScalaJs("1.10.0"))
- val project = SbtProject(
- name = "sbtprojectname",
- reference = Dep
- .ScalaJs(
- org = "sbtprojectorg",
- name = "sbtprojectartifactid",
- version = "sbtprojectversion",
- )
- .concrete(versions),
- )(
- dummyPath,
- Map(
- LibTsSource.FromFolder(InFolder(dummyPath), TsIdent.dummyLibrary) -> PublishedSbtProject(
- SbtProject(
- name = "depname",
- reference = Dep.ScalaJs(org = "deporg", name = "departifactid", version = "depversion").concrete(versions),
- )(dummyPath, Map(), None),
- )(null, null, None),
- ),
- None,
- )
-
- val publication = ZonedDateTime.of(2020, 12, 31, 23, 59, 59, 0, constants.TimeZone)
- val externalDeps = Set[Dep](Dep.ScalaJs("externaldeporg", "externaldepartifact", "externaldepversion"))
-
- test("ivy") {
- val xml = ContentForPublish.ivy(versions, project, publication, externalDeps)
- xml.toString should be(
- """
-
-
- sbtprojectname
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
- """.replace("\r\n", "\n"),
- )
- }
-
- test("pom") {
- val xml = ContentForPublish.pom(versions, project, externalDeps)
- xml.toString should be(
- """
- 4.0.0
- sbtprojectorg
- sbtprojectartifactid_sjs1_2.13
- jar
- sbtprojectname
- sbtprojectversion
- sbtprojectname
-
- sbtprojectorg
-
-
-
- org.scala-lang
- scala-library
- 2.13.8
-
-
- org.scala-js
- scalajs-library_2.13
- 1.10.0
-
-
- org.scala-js
- scalajs-test-interface_2.13
- 1.10.0
- test
-
-
- com.olvind
- scalablytyped-runtime_sjs1_2.13
- 2.4.2
-
-
- deporg
- departifactid_sjs1_2.13
- depversion
-
-
- externaldeporg
- externaldepartifact_sjs1_2.13
- externaldepversion
-
-
- """.replace("\r\n", "\n"),
- )
- }
-}
diff --git a/logging/src/main/scala/com/olvind/logging/Formatter.scala b/logging/src/main/scala/com/olvind/logging/Formatter.scala
index 83f2a59bcd..ca2d3b600c 100644
--- a/logging/src/main/scala/com/olvind/logging/Formatter.scala
+++ b/logging/src/main/scala/com/olvind/logging/Formatter.scala
@@ -87,7 +87,7 @@ object Formatter {
}
implicit val StrFormatter: Formatter[Str] = x => x
- implicit val StringFormatter: Formatter[String] = x => x
+ implicit val StringFormatter: Formatter[String] = Str.Strip(_)
implicit val IntFormatter: Formatter[Int] = _.toString
implicit val LongFormatter: Formatter[Long] = _.toString
implicit val UnitFormatter: Formatter[Unit] = _ => ""
diff --git a/project/Deps.scala b/project/Deps.scala
index e46ecefca1..324ab27f05 100644
--- a/project/Deps.scala
+++ b/project/Deps.scala
@@ -7,7 +7,8 @@ object Deps {
val sourcecode = "com.lihaoyi" %% "sourcecode" % "0.3.0"
val scalatest = "org.scalatest" %% "scalatest" % "3.2.14"
val fansi = "com.lihaoyi" %% "fansi" % "0.4.0"
- val bloop = "ch.epfl.scala" %% "bloop-frontend" % "1.5.4"
+ val bleepModel = "build.bleep" %% "bleep-model" % "0.0.1-M21"
+ val gigahorse = "com.eed3si9n" %% "gigahorse-okhttp" % "0.7.0"
val scalaXml = "org.scala-lang.modules" %% "scala-xml" % "2.1.0"
val scopt = "com.github.scopt" %% "scopt" % "4.1.0"
val awssdkS3 = "software.amazon.awssdk" % "s3" % "2.15.28"
diff --git a/sbt-converter/src/main/scala/org/scalablytyped/converter/internal/ImportTypings.scala b/sbt-converter/src/main/scala/org/scalablytyped/converter/internal/ImportTypings.scala
index e6959eefc8..e6f98d988e 100644
--- a/sbt-converter/src/main/scala/org/scalablytyped/converter/internal/ImportTypings.scala
+++ b/sbt-converter/src/main/scala/org/scalablytyped/converter/internal/ImportTypings.scala
@@ -2,11 +2,10 @@ package org.scalablytyped.converter
package internal
import java.nio.file.Path
-
import com.olvind.logging.Logger
import io.circe013.{Decoder, Encoder}
import org.scalablytyped.converter.internal.importer._
-import org.scalablytyped.converter.internal.importer.build.{Compiler, IvyLayout, PublishedSbtProject}
+import org.scalablytyped.converter.internal.importer.build.{BleepCompiler, IvyLayout, ScalaProject}
import org.scalablytyped.converter.internal.importer.documentation.Npmjs
import org.scalablytyped.converter.internal.maps._
import org.scalablytyped.converter.internal.phases.{PhaseListener, PhaseRes, PhaseRunner, RecPhase}
@@ -51,10 +50,10 @@ object ImportTypings {
input: Input,
logger: Logger[Unit],
parseCacheDirOpt: Option[Path],
- publishLocalFolder: os.Path,
+ publishLocalTarget: PublishLocalTarget,
fromFolder: InFolder,
targetFolder: os.Path,
- compiler: Compiler,
+ bleepCompiler: BleepCompiler,
): Either[Map[LibTsSource, Either[Throwable, String]], Output] = {
if (input.conversion.expandTypeMappings =/= EnabledTypeMappingExpansion.DefaultSelection) {
@@ -76,7 +75,7 @@ object ImportTypings {
val cachedParser = PersistingParser(parseCacheDirOpt, bootstrapped.inputFolders, logger)
- val Phases: RecPhase[LibTsSource, PublishedSbtProject] = RecPhase[LibTsSource]
+ val Phases: RecPhase[LibTsSource, ScalaProject] = RecPhase[LibTsSource]
.next(
new Phase1ReadTypescript(
resolve = bootstrapped.libraryResolver,
@@ -107,10 +106,10 @@ object ImportTypings {
.next(
new Phase3Compile(
versions = input.conversion.versions,
- compiler = compiler,
+ bleepCompiler = bleepCompiler,
targetFolder = targetFolder,
organization = input.conversion.organization,
- publishLocalFolder = publishLocalFolder,
+ publishLocalTarget = publishLocalTarget,
metadataFetcher = Npmjs.No,
softWrites = true,
flavour = input.conversion.flavourImpl,
@@ -120,15 +119,15 @@ object ImportTypings {
"build",
)
- val results: SortedMap[LibTsSource, PhaseRes[LibTsSource, PublishedSbtProject]] =
+ val results: SortedMap[LibTsSource, PhaseRes[LibTsSource, ScalaProject]] =
initial
.map(s => (s: LibTsSource) -> PhaseRunner(Phases, (_: LibTsSource) => logger, PhaseListener.NoListener)(s))
.toMap
.toSorted
val successes: Map[LibTsSource, Dep.Concrete] = {
- def go(source: LibTsSource, lib: PublishedSbtProject): Map[LibTsSource, Dep.Concrete] =
- Map(source -> lib.project.reference) ++ lib.project.deps.flatMap { case (k, v) => go(k, v) }
+ def go(source: LibTsSource, lib: ScalaProject): Map[LibTsSource, Dep.Concrete] =
+ Map(source -> lib.reference) ++ lib.deps.flatMap { case (k, v) => go(k, v) }
results.collect { case (s, PhaseRes.Ok(res)) => go(s, res) }.reduceOption(_ ++ _).getOrElse(Map.empty)
}
diff --git a/sbt-converter/src/main/scala/org/scalablytyped/converter/internal/ZincCompiler.scala b/sbt-converter/src/main/scala/org/scalablytyped/converter/internal/ZincCompiler.scala
deleted file mode 100644
index 95a041ab82..0000000000
--- a/sbt-converter/src/main/scala/org/scalablytyped/converter/internal/ZincCompiler.scala
+++ /dev/null
@@ -1,242 +0,0 @@
-package org.scalablytyped.converter
-package internal
-
-import java.io.File
-import java.net.URLClassLoader
-import java.time.Instant
-import java.util.Optional
-import java.util.function.Supplier
-
-import com.olvind.logging
-import com.olvind.logging.{LogLevel, Logger}
-import lmcoursier.{CoursierConfiguration, CoursierDependencyResolution}
-import org.scalablytyped.converter.internal.importer.build.{Compiler, CompilerPaths}
-import org.scalablytyped.converter.internal.scalajs.{Dep, Versions}
-import sbt._
-import sbt.coursierint.CoursierInputsTasks.credentialsTask
-import sbt.coursierint.CoursierRepositoriesTasks.coursierResolversTask
-import sbt.internal.inc.classpath.ClassLoaderCache
-import sbt.internal.inc.{AnalyzingCompiler, LoggedReporter, PlainVirtualFile, ScalaInstance, ZincLmUtil, ZincUtil}
-import sbt.librarymanagement.DependencyResolution
-import sbt.util.InterfaceUtil
-import xsbti.{CompileFailed, VirtualFile}
-import xsbti.compile.{CompileOrder => _, _}
-
-class ZincCompiler(inputs: Inputs, logger: Logger[Unit], resolve: Dep => Array[File]) extends Compiler {
- private lazy val incCompiler: IncrementalCompiler = ZincUtil.defaultIncrementalCompiler
-
- val sbtLogger = new ZincCompiler.WrapLogger(logger)
-
- def compile(
- name: String,
- digest: Digest,
- compilerPaths: CompilerPaths,
- deps: Set[Compiler.InternalDep],
- externalDeps: Set[Dep],
- ): Either[String, Unit] = {
-
- val cp: Array[VirtualFile] = {
- val fromInternal: Set[VirtualFile] = deps.collect {
- case Compiler.InternalDepJar(path) => PlainVirtualFile(path.toNIO)
- }
- val fromExternal: Set[VirtualFile] =
- externalDeps.map(resolve).flatten.map((f: File) => PlainVirtualFile(f.toPath))
-
- (inputs.options.classpath() ++ fromInternal ++ fromExternal).distinct
- }
-
- val updatedInputs = inputs
- .withOptions(
- inputs
- .options()
- .withClasspath(cp)
- .withSources(
- os.walk(compilerPaths.sourcesDir)
- .filter(_.last.endsWith(".scala"))
- .map(p => PlainVirtualFile(p.toNIO))
- .toArray,
- )
- .withClassesDirectory(files.existing(compilerPaths.classesDir).toNIO),
- )
-
- try {
- val result: CompileResult = incCompiler.compile(updatedInputs, sbtLogger)
- if (!result.hasModified) {
- throw new InterruptedException("Compilation result: false == result.hasModified")
- }
- Right(())
- } catch {
- case x: CompileFailed =>
- Left(s"$x: ${x.arguments.mkString(", ")} ${x.problems.mkString(", ")}")
- }
- }
-}
-
-object ZincCompiler {
- implicit class EnrichOption[T](val option: Option[T]) extends AnyVal {
- def toOptional: Optional[T] = InterfaceUtil.toOptional(option)
- }
-
- val task = Def.task {
- import Keys._
-
- val logger = WrapSbtLogger.task.value
- val sbtLogger = new ZincCompiler.WrapLogger(logger)
-
- val v = Versions(
- Versions.Scala(scalaVersion = (Compile / scalaVersion).value),
- Versions.ScalaJs(org.scalajs.sbtplugin.ScalaJSPlugin.autoImport.scalaJSVersion),
- )
-
- val resolver = DependencyResolution(
- new CoursierDependencyResolution(
- CoursierConfiguration()
- .withCredentials(credentialsTask.value.toVector)
- .withResolvers(coursierResolversTask.value.toVector),
- ),
- )
-
- def resolve(dep: Dep): Array[File] =
- resolver.retrieve(
- Utils.asModuleID(dep.concrete(v)),
- scalaModuleInfo.value,
- file("tmp"),
- sbtLogger,
- ) match {
- case Left(warning) => throw warning.resolveException
- case Right(resolved) => resolved.toArray
- }
-
- val scalaCompiler = resolve(v.scala.compiler)
- val scalaLibrary = resolve(v.scala.library)
- val runtime = resolve(v.scalaJsLibrary)
- val scalaJsCompiler = v.scalaJsCompiler.map(resolve).toList.flatten
- val allJars = scalaCompiler ++ runtime ++ scalaLibrary ++ scalaJsCompiler
-
- val st = state.value
- val g = BuildPaths.getGlobalBase(st)
- val zincDir = BuildPaths.getZincDirectory(st, g)
-
- val instance = mkScalaInstance(
- version = v.scala.scalaVersion,
- allJars = allJars,
- libraryJars = scalaLibrary.collect { case path if path.toString.contains("scala-library") => path },
- compilerJar = scalaCompiler.collectFirst { case f if f.getName.contains("-compiler") => f }.head,
- classLoaderCache = st.classLoaderCache,
- )
-
- val scalac: AnalyzingCompiler =
- v.scala.compilerBridge match {
- case Some(bridgeDep) =>
- new AnalyzingCompiler(
- instance,
- ZincCompilerUtil.constantBridgeProvider(instance, resolve(bridgeDep).head),
- classpathOptions.value,
- _ => (),
- None,
- )
- case None =>
- ZincLmUtil.scalaCompiler(
- scalaInstance = instance,
- classpathOptions = classpathOptions.value,
- globalLock = appConfiguration.value.provider.scalaProvider.launcher.globalLock,
- componentProvider = appConfiguration.value.provider.components,
- secondaryCacheDir = Option(zincDir),
- dependencyResolution = resolver,
- compilerBridgeSource = scalaCompilerBridgeSource.value,
- scalaJarsTarget = zincDir,
- classLoaderCache = None,
- log = sbtLogger,
- )
- }
-
- val compilers: Compilers =
- ZincUtil.compilers(
- instance = instance,
- classpathOptions = classpathOptions.value,
- javaHome = javaHome.value.map(_.toPath),
- scalac,
- )
-
- val converter = fileConverter.value
- val lookup = new PerClasspathEntryLookup {
- private val cachedAnalysisMap: File => Option[CompileAnalysis] =
- _ => None
- private val cachedPerEntryDefinesClassLookup: File => DefinesClass =
- Keys.classpathEntryDefinesClass.value
-
- override def analysis(classpathEntry: VirtualFile): Optional[CompileAnalysis] =
- cachedAnalysisMap(converter.toPath(classpathEntry).toFile).toOptional
- override def definesClass(classpathEntry: VirtualFile): DefinesClass =
- cachedPerEntryDefinesClassLookup(converter.toPath(classpathEntry).toFile)
- }
-
- val scalaJsOption: String = {
- if (v.scala.is3)
- "-scalajs"
- else
- scalaJsCompiler.collectFirst { case f if f.getName.contains("scalajs-compiler") => "-Xplugin:" + f }.get
- }
-
- val inputs = Inputs.of(
- compilers,
- CompileOptions
- .of()
- .withClasspath(allJars.map(f => PlainVirtualFile(f.asPath)))
- .withScalacOptions(Array(scalaJsOption) ++ v.scalacOptions)
- .withOrder(CompileOrder.ScalaThenJava),
- Setup.of(
- lookup,
- false,
- streams.value.cacheDirectory / (Compile / compileAnalysisFilename).value,
- compilerCache.value,
- IncOptions.of().withEnabled(false),
- new LoggedReporter(maxErrors.value, sbtLogger): xsbti.Reporter,
- Optional.empty[CompileProgress](),
- Array.empty[xsbti.T2[String, String]],
- ),
- PreviousResult.of(Optional.empty[CompileAnalysis](), Optional.empty[MiniSetup]()),
- )
-
- new ZincCompiler(inputs, logger, dep => resolve(dep))
- }
-
- def mkScalaInstance(
- version: String,
- allJars: Array[File],
- libraryJars: Array[File],
- compilerJar: File,
- classLoaderCache: ClassLoaderCache,
- ): ScalaInstance = {
- val allJarsDistinct = allJars.distinct
- val libraryLoader = classLoaderCache(libraryJars.toList)
- class ScalaLoader extends URLClassLoader(allJarsDistinct.map(_.toURI.toURL).toArray, libraryLoader)
- val fullLoader = classLoaderCache.cachedCustomClassloader(
- allJarsDistinct.toList,
- () => new ScalaLoader,
- )
- new ScalaInstance(
- version,
- fullLoader,
- libraryLoader,
- libraryJars,
- compilerJar,
- allJarsDistinct,
- Some(version),
- )
- }
-
- final class WrapLogger(val underlying: Logger[Unit]) extends xsbti.Logger {
- override def error(msg: Supplier[String]): Unit = underlying.error(msg.get())
-
- override def warn(msg: Supplier[String]): Unit = underlying.warn(msg.get())
-
- override def info(msg: Supplier[String]): Unit = underlying.info(msg.get())
-
- override def debug(msg: Supplier[String]): Unit = underlying.debug(msg.get())
-
- // trace? throwable? whaat
- override def trace(exception: Supplier[Throwable]): Unit =
- underlying.warn("traced exception from sbt", exception.get())
- }
-}
diff --git a/sbt-converter/src/main/scala/org/scalablytyped/converter/plugin/ScalablyTypedConverterExternalNpmPlugin.scala b/sbt-converter/src/main/scala/org/scalablytyped/converter/plugin/ScalablyTypedConverterExternalNpmPlugin.scala
index 504df60023..63083f52f0 100644
--- a/sbt-converter/src/main/scala/org/scalablytyped/converter/plugin/ScalablyTypedConverterExternalNpmPlugin.scala
+++ b/sbt-converter/src/main/scala/org/scalablytyped/converter/plugin/ScalablyTypedConverterExternalNpmPlugin.scala
@@ -1,20 +1,21 @@
package org.scalablytyped.converter.plugin
import _root_.io.circe013.syntax._
-import com.olvind.logging.{Formatter, LogLevel}
-import org.scalablytyped.converter.internal.RunCache.Present
+import com.olvind.logging.LogLevel
import org.scalablytyped.converter.internal._
-import org.scalablytyped.converter.internal.maps._
+import org.scalablytyped.converter.internal.RunCache.Present
+import org.scalablytyped.converter.internal.importer.PublishLocalTarget
+import org.scalablytyped.converter.internal.importer.build.BleepCompiler
import org.scalablytyped.converter.internal.ts.{PackageJson, TsIdentLibrary}
import org.scalajs.sbtplugin.ScalaJSPlugin
-import sbt.Keys._
import sbt._
+import sbt.Keys._
import scala.collection.immutable.SortedMap
-import scala.concurrent.ExecutionContext
+import scala.concurrent.duration.Duration
+import scala.concurrent.{Await, ExecutionContext}
object ScalablyTypedConverterExternalNpmPlugin extends AutoPlugin {
- private[plugin] val stInternalZincCompiler = taskKey[ZincCompiler]("Hijack compiler settings")
object autoImport {
val stImport = taskKey[ImportTypings.InOut]("Imports all the bundled npm and generates bindings")
@@ -70,10 +71,10 @@ object ScalablyTypedConverterExternalNpmPlugin extends AutoPlugin {
input = input,
logger = stLogger.filter(LogLevel.warn),
parseCacheDirOpt = Some(cacheDir.toPath.resolve("parse")),
- publishLocalFolder = publishLocalFolder,
+ publishLocalTarget = PublishLocalTarget.DefaultIvy2,
fromFolder = nodeModules,
targetFolder = outputDir / "sources",
- compiler = stInternalZincCompiler.value,
+ bleepCompiler = Await.result(BleepCompiler(stLogger)(ExecutionContext.Implicits.global), Duration.Inf),
) match {
case Right(output) =>
Json.persist[ImportTypings.InOut](runCacheKey.path(os.Path(cacheDir)))((input, output))
@@ -97,7 +98,6 @@ object ScalablyTypedConverterExternalNpmPlugin extends AutoPlugin {
stImport := stImportTask.value,
/* This is where we add our generated artifacts to the project for compilation */
allDependencies ++= stImport.value._2.moduleIds.toSeq,
- stInternalZincCompiler := ZincCompiler.task.value,
stPublishCache := RunCache.publishCacheTask(stImport).value,
)
}
diff --git a/sbt-converter/src/main/scala/org/scalablytyped/converter/plugin/ScalablyTypedConverterPlugin.scala b/sbt-converter/src/main/scala/org/scalablytyped/converter/plugin/ScalablyTypedConverterPlugin.scala
index d2c4c810dd..591fcdfe1f 100644
--- a/sbt-converter/src/main/scala/org/scalablytyped/converter/plugin/ScalablyTypedConverterPlugin.scala
+++ b/sbt-converter/src/main/scala/org/scalablytyped/converter/plugin/ScalablyTypedConverterPlugin.scala
@@ -3,19 +3,20 @@ package plugin
import _root_.io.circe013.syntax._
import com.olvind.logging.LogLevel
-import org.scalablytyped.converter.internal.RunCache.Present
import org.scalablytyped.converter.internal._
-import sbt.Keys._
+import org.scalablytyped.converter.internal.RunCache.Present
+import org.scalablytyped.converter.internal.importer.PublishLocalTarget
+import org.scalablytyped.converter.internal.importer.build.BleepCompiler
import sbt._
+import sbt.Keys._
import scalajsbundler.sbtplugin.ScalaJSBundlerPlugin
-import scala.concurrent.ExecutionContext
+import scala.concurrent.duration.Duration
+import scala.concurrent.{Await, ExecutionContext}
object ScalablyTypedConverterPlugin extends AutoPlugin {
override def requires = ScalablyTypedPluginBase && ScalaJSBundlerPlugin
- private[plugin] val stInternalZincCompiler = taskKey[ZincCompiler]("Hijack compiler settings")
-
object autoImport {
val stImport = taskKey[ImportTypings.InOut]("Imports all the bundled npm and generates bindings")
val stPublishCache = taskKey[Unit]("Publish all necessary files to cache")
@@ -64,10 +65,10 @@ object ScalablyTypedConverterPlugin extends AutoPlugin {
input = input,
logger = stLogger.filter(LogLevel.warn),
parseCacheDirOpt = Some(cacheDir.toNIO.resolve("parse")),
- publishLocalFolder = publishLocalFolder,
+ publishLocalTarget = PublishLocalTarget.DefaultIvy2,
fromFolder = fromFolder,
targetFolder = targetFolder,
- compiler = stInternalZincCompiler.value,
+ bleepCompiler = Await.result(BleepCompiler(stLogger)(ExecutionContext.Implicits.global), Duration.Inf),
) match {
case Right(output) =>
Json.persist[ImportTypings.InOut](runCacheKey.path(cacheDir))((input, output))
@@ -91,7 +92,6 @@ object ScalablyTypedConverterPlugin extends AutoPlugin {
/* This is where we add our generated artifacts to the project for compilation */
allDependencies ++= stImport.value._2.moduleIds.toSeq,
stImport := stImportTask.value,
- stInternalZincCompiler := ZincCompiler.task.value,
ScalaJsBundlerHack.adaptScalaJSBundlerPackageJson,
stPublishCache := RunCache.publishCacheTask(stImport).value,
)
diff --git a/scalajs/src/main/scala/org/scalablytyped/converter/internal/scalajs/Dep.scala b/scalajs/src/main/scala/org/scalablytyped/converter/internal/scalajs/Dep.scala
index a3acfedd7c..dfa5b326f8 100644
--- a/scalajs/src/main/scala/org/scalablytyped/converter/internal/scalajs/Dep.scala
+++ b/scalajs/src/main/scala/org/scalablytyped/converter/internal/scalajs/Dep.scala
@@ -3,8 +3,6 @@ package org.scalablytyped.converter.internal.scalajs
import io.circe013.{Decoder, Encoder}
import org.scalablytyped.converter.internal.stringUtils.quote
-import scala.xml.Elem
-
sealed trait Dep {
def org: String
def version: String
@@ -48,26 +46,6 @@ object Dep {
def asMangledSbt: String =
s"${quote(org)} % ${quote(mangledArtifact)} % ${quote(version)}"
-
- def asIvy(config: String = "compile->default(compile)"): Elem =
-
-
- // format: off
- def asMaven: Elem =
-
- {org}
- {mangledArtifact}
- {version}
-
-
- def asMavenTest: Elem =
-
- {org}
- {mangledArtifact}
- {version}
- test
-
- // format: on
}
object Concrete {
implicit val encodes: Encoder[Concrete] = io.circe013.generic.semiauto.deriveEncoder
diff --git a/scalajs/src/main/scala/org/scalablytyped/converter/internal/scalajs/Versions.scala b/scalajs/src/main/scala/org/scalablytyped/converter/internal/scalajs/Versions.scala
index 157eeb0fbc..3c871bf687 100644
--- a/scalajs/src/main/scala/org/scalablytyped/converter/internal/scalajs/Versions.scala
+++ b/scalajs/src/main/scala/org/scalablytyped/converter/internal/scalajs/Versions.scala
@@ -23,20 +23,11 @@ object Versions {
if (is3) Scala213.library
else Dep.Java(scalaOrganization, "scala-library", scalaVersion)
- val dottyLibrary: Option[Dep.Java] =
- if (is3) Some(Dep.Java(scalaOrganization, "scala3-library", scalaVersion))
- else None
-
val binVersion: String = scalaVersion match {
case Version("3", _, _) => s"3"
case Version("2", minor, _) => s"2.$minor"
case other => other
}
-
- val compilerBridge: Option[Dep.Java] =
- if (is3)
- Some(Dep.Java(scalaOrganization, "scala3-sbt-bridge", scalaVersion))
- else None
}
object Scala {
@@ -101,15 +92,6 @@ case class Versions(scala: Versions.Scala, scalaJs: Versions.ScalaJs) {
.Scala(scalaJs.scalaJsOrganization, "scalajs-library", scalaJs.scalaJsVersion)
.for3Use2_13(scala.is3)
- val scalaJsTestInterface: Dep =
- Dep
- .Scala(scalaJs.scalaJsOrganization, "scalajs-test-interface", scalaJs.scalaJsVersion)
- .for3Use2_13(scala.is3)
-
- val scalaJsCompiler: Option[Dep.ScalaFullVersion] =
- if (scala.is3) None
- else Some(Dep.ScalaFullVersion(scalaJs.scalaJsOrganization, "scalajs-compiler", scalaJs.scalaJsVersion))
-
val runtime = Dep.ScalaJs("com.olvind", "scalablytyped-runtime", "2.4.2")
val scalaJsDom = Dep.ScalaJs("org.scala-js", "scalajs-dom", "2.3.0")
val slinkyWeb = Dep.ScalaJs("me.shadaj", "slinky-web", "0.7.2")
diff --git a/tests/antd/check-3/a/antd/bleep.yaml b/tests/antd/check-3/a/antd/bleep.yaml
new file mode 100644
index 0000000000..74e118440e
--- /dev/null
+++ b/tests/antd/check-3/a/antd/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ antd:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/antd
+ type: maven-folder
diff --git a/tests/antd/check-3/r/rc-field-form/bleep.yaml b/tests/antd/check-3/r/rc-field-form/bleep.yaml
new file mode 100644
index 0000000000..f034f98fac
--- /dev/null
+++ b/tests/antd/check-3/r/rc-field-form/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ rc-field-form:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/antd
+ type: maven-folder
diff --git a/tests/augment-module/check-3/l/lodash/bleep.yaml b/tests/augment-module/check-3/l/lodash/bleep.yaml
new file mode 100644
index 0000000000..53334ed3ed
--- /dev/null
+++ b/tests/augment-module/check-3/l/lodash/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ lodash:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-7b3e8b
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/augment-module
+ type: maven-folder
diff --git a/tests/augment-module/check-3/l/lodash_dot_add/bleep.yaml b/tests/augment-module/check-3/l/lodash_dot_add/bleep.yaml
new file mode 100644
index 0000000000..0ebf611d38
--- /dev/null
+++ b/tests/augment-module/check-3/l/lodash_dot_add/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ lodash_dot_add:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/augment-module
+ type: maven-folder
diff --git a/tests/augment-module/check-3/s/std/bleep.yaml b/tests/augment-module/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..a8a76b2362
--- /dev/null
+++ b/tests/augment-module/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/augment-module
+ type: maven-folder
diff --git a/tests/aws-sdk/check-3/a/aws-sdk/bleep.yaml b/tests/aws-sdk/check-3/a/aws-sdk/bleep.yaml
new file mode 100644
index 0000000000..8af44cdefd
--- /dev/null
+++ b/tests/aws-sdk/check-3/a/aws-sdk/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ aws-sdk:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/aws-sdk
+ type: maven-folder
diff --git a/tests/babylon/check-3/b/babylon/bleep.yaml b/tests/babylon/check-3/b/babylon/bleep.yaml
new file mode 100644
index 0000000000..ea32ba87fb
--- /dev/null
+++ b/tests/babylon/check-3/b/babylon/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ babylon:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/babylon
+ type: maven-folder
diff --git a/tests/babylon/check-3/n/node/bleep.yaml b/tests/babylon/check-3/n/node/bleep.yaml
new file mode 100644
index 0000000000..f6a6fdafd4
--- /dev/null
+++ b/tests/babylon/check-3/n/node/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ node:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/babylon
+ type: maven-folder
diff --git a/tests/bigint/check-3/b/bigint/bleep.yaml b/tests/bigint/check-3/b/bigint/bleep.yaml
new file mode 100644
index 0000000000..f3793f177c
--- /dev/null
+++ b/tests/bigint/check-3/b/bigint/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ bigint:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-2d9f14
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/bigint
+ type: maven-folder
diff --git a/tests/bigint/check-3/s/std/bleep.yaml b/tests/bigint/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..2115296bdd
--- /dev/null
+++ b/tests/bigint/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/bigint
+ type: maven-folder
diff --git a/tests/chart.js/check-3/c/chart_dot_js/bleep.yaml b/tests/chart.js/check-3/c/chart_dot_js/bleep.yaml
new file mode 100644
index 0000000000..ffe6c03548
--- /dev/null
+++ b/tests/chart.js/check-3/c/chart_dot_js/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ chart_dot_js:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-c56b98
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/chart.js
+ type: maven-folder
diff --git a/tests/chart.js/check-3/s/std/bleep.yaml b/tests/chart.js/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..f5715a8c48
--- /dev/null
+++ b/tests/chart.js/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/chart.js
+ type: maven-folder
diff --git a/tests/cldrjs/check-3/c/cldrjs/bleep.yaml b/tests/cldrjs/check-3/c/cldrjs/bleep.yaml
new file mode 100644
index 0000000000..a38037c823
--- /dev/null
+++ b/tests/cldrjs/check-3/c/cldrjs/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ cldrjs:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-43cef5
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/cldrjs
+ type: maven-folder
diff --git a/tests/cldrjs/check-3/s/std/bleep.yaml b/tests/cldrjs/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..6465cc5943
--- /dev/null
+++ b/tests/cldrjs/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/cldrjs
+ type: maven-folder
diff --git a/tests/commander/check-3/c/commander/bleep.yaml b/tests/commander/check-3/c/commander/bleep.yaml
new file mode 100644
index 0000000000..5a5432bd45
--- /dev/null
+++ b/tests/commander/check-3/c/commander/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ commander:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:node_sjs1_3:0.0-unknown-654197
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-065f9f
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/commander
+ type: maven-folder
diff --git a/tests/commander/check-3/n/node/bleep.yaml b/tests/commander/check-3/n/node/bleep.yaml
new file mode 100644
index 0000000000..2ed8b46f95
--- /dev/null
+++ b/tests/commander/check-3/n/node/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ node:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/commander
+ type: maven-folder
diff --git a/tests/commander/check-3/s/std/bleep.yaml b/tests/commander/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..67f7bc44f3
--- /dev/null
+++ b/tests/commander/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/commander
+ type: maven-folder
diff --git a/tests/const-enum/check-3/c/const-enum/bleep.yaml b/tests/const-enum/check-3/c/const-enum/bleep.yaml
new file mode 100644
index 0000000000..5b224d22e5
--- /dev/null
+++ b/tests/const-enum/check-3/c/const-enum/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ const-enum:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/const-enum
+ type: maven-folder
diff --git a/tests/create-error/check-3/c/create-error/bleep.yaml b/tests/create-error/check-3/c/create-error/bleep.yaml
new file mode 100644
index 0000000000..ea724045bd
--- /dev/null
+++ b/tests/create-error/check-3/c/create-error/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ create-error:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-a78990
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/create-error
+ type: maven-folder
diff --git a/tests/create-error/check-3/s/std/bleep.yaml b/tests/create-error/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..073eb48b73
--- /dev/null
+++ b/tests/create-error/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/create-error
+ type: maven-folder
diff --git a/tests/defaulted-tparams/check-3/d/defaulted-tparams/bleep.yaml b/tests/defaulted-tparams/check-3/d/defaulted-tparams/bleep.yaml
new file mode 100644
index 0000000000..79bd0ef545
--- /dev/null
+++ b/tests/defaulted-tparams/check-3/d/defaulted-tparams/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ defaulted-tparams:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-6c3d33
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/defaulted-tparams
+ type: maven-folder
diff --git a/tests/defaulted-tparams/check-3/s/std/bleep.yaml b/tests/defaulted-tparams/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..334fe9ffae
--- /dev/null
+++ b/tests/defaulted-tparams/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/defaulted-tparams
+ type: maven-folder
diff --git a/tests/documentation/check-3/d/documentation/bleep.yaml b/tests/documentation/check-3/d/documentation/bleep.yaml
new file mode 100644
index 0000000000..a224a7ed17
--- /dev/null
+++ b/tests/documentation/check-3/d/documentation/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ documentation:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/documentation
+ type: maven-folder
diff --git a/tests/echarts/check-3/e/echarts/bleep.yaml b/tests/echarts/check-3/e/echarts/bleep.yaml
new file mode 100644
index 0000000000..6b9544f38b
--- /dev/null
+++ b/tests/echarts/check-3/e/echarts/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ echarts:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/echarts
+ type: maven-folder
diff --git a/tests/elasticsearch-js/check-3/e/elasticsearch-js/bleep.yaml b/tests/elasticsearch-js/check-3/e/elasticsearch-js/bleep.yaml
new file mode 100644
index 0000000000..e63bd12a4e
--- /dev/null
+++ b/tests/elasticsearch-js/check-3/e/elasticsearch-js/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ elasticsearch-js:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-3c461f
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/elasticsearch-js
+ type: maven-folder
diff --git a/tests/elasticsearch-js/check-3/s/std/bleep.yaml b/tests/elasticsearch-js/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..b0d0b1484a
--- /dev/null
+++ b/tests/elasticsearch-js/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/elasticsearch-js
+ type: maven-folder
diff --git a/tests/electron/check-3/e/electron/bleep.yaml b/tests/electron/check-3/e/electron/bleep.yaml
new file mode 100644
index 0000000000..acb8cafe8d
--- /dev/null
+++ b/tests/electron/check-3/e/electron/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ electron:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:node_sjs1_3:0.0-unknown-849fc0
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-515e78
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/electron
+ type: maven-folder
diff --git a/tests/electron/check-3/n/node/bleep.yaml b/tests/electron/check-3/n/node/bleep.yaml
new file mode 100644
index 0000000000..1d734cacb6
--- /dev/null
+++ b/tests/electron/check-3/n/node/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ node:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-515e78
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/electron
+ type: maven-folder
diff --git a/tests/electron/check-3/s/std/bleep.yaml b/tests/electron/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..6b5c2aab96
--- /dev/null
+++ b/tests/electron/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/electron
+ type: maven-folder
diff --git a/tests/expand-type-parameters/check-3/e/expand-type-parameters/bleep.yaml b/tests/expand-type-parameters/check-3/e/expand-type-parameters/bleep.yaml
new file mode 100644
index 0000000000..d61f714694
--- /dev/null
+++ b/tests/expand-type-parameters/check-3/e/expand-type-parameters/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ expand-type-parameters:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/expand-type-parameters
+ type: maven-folder
diff --git a/tests/export-as-namespace/check-3/a/angular-agility/bleep.yaml b/tests/export-as-namespace/check-3/a/angular-agility/bleep.yaml
new file mode 100644
index 0000000000..e3d65b2aaa
--- /dev/null
+++ b/tests/export-as-namespace/check-3/a/angular-agility/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ angular-agility:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:angular_sjs1_3:1.6-1d248f
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-badd07
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/export-as-namespace
+ type: maven-folder
diff --git a/tests/export-as-namespace/check-3/a/angular/bleep.yaml b/tests/export-as-namespace/check-3/a/angular/bleep.yaml
new file mode 100644
index 0000000000..4483d9f795
--- /dev/null
+++ b/tests/export-as-namespace/check-3/a/angular/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ angular:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-badd07
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/export-as-namespace
+ type: maven-folder
diff --git a/tests/export-as-namespace/check-3/s/std/bleep.yaml b/tests/export-as-namespace/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..4b6e0075c8
--- /dev/null
+++ b/tests/export-as-namespace/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/export-as-namespace
+ type: maven-folder
diff --git a/tests/firebase-admin/check-3/f/firebase-admin/bleep.yaml b/tests/firebase-admin/check-3/f/firebase-admin/bleep.yaml
new file mode 100644
index 0000000000..6d4847bcb6
--- /dev/null
+++ b/tests/firebase-admin/check-3/f/firebase-admin/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ firebase-admin:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:google-cloud__firestore_sjs1_3:2.2.3-ab3c78
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/firebase-admin
+ type: maven-folder
diff --git a/tests/firebase-admin/check-3/g/google-cloud__firestore/bleep.yaml b/tests/firebase-admin/check-3/g/google-cloud__firestore/bleep.yaml
new file mode 100644
index 0000000000..5e5ad75bff
--- /dev/null
+++ b/tests/firebase-admin/check-3/g/google-cloud__firestore/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ google-cloud__firestore:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/firebase-admin
+ type: maven-folder
diff --git a/tests/firebase/check-3/f/firebase/bleep.yaml b/tests/firebase/check-3/f/firebase/bleep.yaml
new file mode 100644
index 0000000000..94c70cd43f
--- /dev/null
+++ b/tests/firebase/check-3/f/firebase/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ firebase:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/firebase
+ type: maven-folder
diff --git a/tests/fp-ts/check-3/f/fp-ts/bleep.yaml b/tests/fp-ts/check-3/f/fp-ts/bleep.yaml
new file mode 100644
index 0000000000..8a75f2f621
--- /dev/null
+++ b/tests/fp-ts/check-3/f/fp-ts/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ fp-ts:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/fp-ts
+ type: maven-folder
diff --git a/tests/fullcalendar/check-3/f/fullcalendar/bleep.yaml b/tests/fullcalendar/check-3/f/fullcalendar/bleep.yaml
new file mode 100644
index 0000000000..3e30cb8aad
--- /dev/null
+++ b/tests/fullcalendar/check-3/f/fullcalendar/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ fullcalendar:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/fullcalendar
+ type: maven-folder
diff --git a/tests/insight/check-3/i/insight/bleep.yaml b/tests/insight/check-3/i/insight/bleep.yaml
new file mode 100644
index 0000000000..e02dd6a38f
--- /dev/null
+++ b/tests/insight/check-3/i/insight/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ insight:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/insight
+ type: maven-folder
diff --git a/tests/interface-package/check-3/i/interface-package/bleep.yaml b/tests/interface-package/check-3/i/interface-package/bleep.yaml
new file mode 100644
index 0000000000..ee9efaf63c
--- /dev/null
+++ b/tests/interface-package/check-3/i/interface-package/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ interface-package:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/interface-package
+ type: maven-folder
diff --git a/tests/keyof/check-3/k/keyof/bleep.yaml b/tests/keyof/check-3/k/keyof/bleep.yaml
new file mode 100644
index 0000000000..ab8b461072
--- /dev/null
+++ b/tests/keyof/check-3/k/keyof/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ keyof:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/keyof
+ type: maven-folder
diff --git a/tests/material-ui/check-japgolly-3/m/material-ui/bleep.yaml b/tests/material-ui/check-japgolly-3/m/material-ui/bleep.yaml
new file mode 100644
index 0000000000..fa1f97243d
--- /dev/null
+++ b/tests/material-ui/check-japgolly-3/m/material-ui/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ material-ui:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:0.0-unknown-d330f0
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-f14284
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/material-ui
+ type: maven-folder
diff --git a/tests/material-ui/check-japgolly-3/r/react/bleep.yaml b/tests/material-ui/check-japgolly-3/r/react/bleep.yaml
new file mode 100644
index 0000000000..ac4414e7a9
--- /dev/null
+++ b/tests/material-ui/check-japgolly-3/r/react/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-f14284
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/material-ui
+ type: maven-folder
diff --git a/tests/material-ui/check-japgolly-3/s/std/bleep.yaml b/tests/material-ui/check-japgolly-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..22445e89a7
--- /dev/null
+++ b/tests/material-ui/check-japgolly-3/s/std/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/material-ui
+ type: maven-folder
diff --git a/tests/material-ui/check-slinky-3/m/material-ui/bleep.yaml b/tests/material-ui/check-slinky-3/m/material-ui/bleep.yaml
new file mode 100644
index 0000000000..37bdecf9fe
--- /dev/null
+++ b/tests/material-ui/check-slinky-3/m/material-ui/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ material-ui:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:0.0-unknown-d0a3df
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-7e7520
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/material-ui
+ type: maven-folder
diff --git a/tests/material-ui/check-slinky-3/r/react/bleep.yaml b/tests/material-ui/check-slinky-3/r/react/bleep.yaml
new file mode 100644
index 0000000000..467a1ce6b3
--- /dev/null
+++ b/tests/material-ui/check-slinky-3/r/react/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-7e7520
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/material-ui
+ type: maven-folder
diff --git a/tests/material-ui/check-slinky-3/s/std/bleep.yaml b/tests/material-ui/check-slinky-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..bbff035ab0
--- /dev/null
+++ b/tests/material-ui/check-slinky-3/s/std/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/material-ui
+ type: maven-folder
diff --git a/tests/monaco-editor/check-3/m/monaco-editor/bleep.yaml b/tests/monaco-editor/check-3/m/monaco-editor/bleep.yaml
new file mode 100644
index 0000000000..95489a0088
--- /dev/null
+++ b/tests/monaco-editor/check-3/m/monaco-editor/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ monaco-editor:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-dc590b
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/monaco-editor
+ type: maven-folder
diff --git a/tests/monaco-editor/check-3/s/std/bleep.yaml b/tests/monaco-editor/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..2ffb57e7e4
--- /dev/null
+++ b/tests/monaco-editor/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/monaco-editor
+ type: maven-folder
diff --git a/tests/mongoose-simple-random/check-3/m/mongoose-simple-random/bleep.yaml b/tests/mongoose-simple-random/check-3/m/mongoose-simple-random/bleep.yaml
new file mode 100644
index 0000000000..c5c1216f8c
--- /dev/null
+++ b/tests/mongoose-simple-random/check-3/m/mongoose-simple-random/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ mongoose-simple-random:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:mongoose_sjs1_3:0.0-unknown-89e5f5
+ - org.scalablytyped:node_sjs1_3:0.0-unknown-654197
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-9918e1
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/mongoose-simple-random
+ type: maven-folder
diff --git a/tests/mongoose-simple-random/check-3/m/mongoose/bleep.yaml b/tests/mongoose-simple-random/check-3/m/mongoose/bleep.yaml
new file mode 100644
index 0000000000..47cd9036f8
--- /dev/null
+++ b/tests/mongoose-simple-random/check-3/m/mongoose/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ mongoose:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/mongoose-simple-random
+ type: maven-folder
diff --git a/tests/mongoose-simple-random/check-3/n/node/bleep.yaml b/tests/mongoose-simple-random/check-3/n/node/bleep.yaml
new file mode 100644
index 0000000000..329b170b66
--- /dev/null
+++ b/tests/mongoose-simple-random/check-3/n/node/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ node:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/mongoose-simple-random
+ type: maven-folder
diff --git a/tests/mongoose-simple-random/check-3/s/std/bleep.yaml b/tests/mongoose-simple-random/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..a0e21a9295
--- /dev/null
+++ b/tests/mongoose-simple-random/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/mongoose-simple-random
+ type: maven-folder
diff --git a/tests/numjs/check-3/n/ndarray/bleep.yaml b/tests/numjs/check-3/n/ndarray/bleep.yaml
new file mode 100644
index 0000000000..3a72dcdf6f
--- /dev/null
+++ b/tests/numjs/check-3/n/ndarray/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ ndarray:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-43cef5
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/numjs
+ type: maven-folder
diff --git a/tests/numjs/check-3/n/numjs/bleep.yaml b/tests/numjs/check-3/n/numjs/bleep.yaml
new file mode 100644
index 0000000000..83b543ef5e
--- /dev/null
+++ b/tests/numjs/check-3/n/numjs/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ numjs:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:ndarray_sjs1_3:0.0-unknown-47e2e3
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-43cef5
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/numjs
+ type: maven-folder
diff --git a/tests/numjs/check-3/s/std/bleep.yaml b/tests/numjs/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..5254752783
--- /dev/null
+++ b/tests/numjs/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/numjs
+ type: maven-folder
diff --git a/tests/pixi.js/check-3/e/eventemitter3/bleep.yaml b/tests/pixi.js/check-3/e/eventemitter3/bleep.yaml
new file mode 100644
index 0000000000..c9ca3f26d4
--- /dev/null
+++ b/tests/pixi.js/check-3/e/eventemitter3/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ eventemitter3:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/pixi.js
+ type: maven-folder
diff --git a/tests/pixi.js/check-3/p/pixi__utils/bleep.yaml b/tests/pixi.js/check-3/p/pixi__utils/bleep.yaml
new file mode 100644
index 0000000000..e0384f8a30
--- /dev/null
+++ b/tests/pixi.js/check-3/p/pixi__utils/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ pixi__utils:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:eventemitter3_sjs1_3:0.0-unknown-06649d
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/pixi.js
+ type: maven-folder
diff --git a/tests/pixi.js/check-3/p/pixi_dot_js/bleep.yaml b/tests/pixi.js/check-3/p/pixi_dot_js/bleep.yaml
new file mode 100644
index 0000000000..be2cdc5c23
--- /dev/null
+++ b/tests/pixi.js/check-3/p/pixi_dot_js/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ pixi_dot_js:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:eventemitter3_sjs1_3:0.0-unknown-06649d
+ - org.scalablytyped:pixi__utils_sjs1_3:0.0-unknown-d7dd2a
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/pixi.js
+ type: maven-folder
diff --git a/tests/prisma/check-3/p/prisma/bleep.yaml b/tests/prisma/check-3/p/prisma/bleep.yaml
new file mode 100644
index 0000000000..6e13e2a7ef
--- /dev/null
+++ b/tests/prisma/check-3/p/prisma/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ prisma:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-cbf303
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/prisma
+ type: maven-folder
diff --git a/tests/prisma/check-3/s/std/bleep.yaml b/tests/prisma/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..772e5d760a
--- /dev/null
+++ b/tests/prisma/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/prisma
+ type: maven-folder
diff --git a/tests/properties/check-3/p/properties/bleep.yaml b/tests/properties/check-3/p/properties/bleep.yaml
new file mode 100644
index 0000000000..5f25902565
--- /dev/null
+++ b/tests/properties/check-3/p/properties/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ properties:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/properties
+ type: maven-folder
diff --git a/tests/punchcard/check-3/p/punchcard/bleep.yaml b/tests/punchcard/check-3/p/punchcard/bleep.yaml
new file mode 100644
index 0000000000..0dde33fdfe
--- /dev/null
+++ b/tests/punchcard/check-3/p/punchcard/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ punchcard:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-0952dd
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/punchcard
+ type: maven-folder
diff --git a/tests/punchcard/check-3/s/std/bleep.yaml b/tests/punchcard/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..78ab37f2e4
--- /dev/null
+++ b/tests/punchcard/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/punchcard
+ type: maven-folder
diff --git a/tests/react-icons/check-3/r/react-icon-base/bleep.yaml b/tests/react-icons/check-3/r/react-icon-base/bleep.yaml
new file mode 100644
index 0000000000..aa6e3c83c7
--- /dev/null
+++ b/tests/react-icons/check-3/r/react-icon-base/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-icon-base:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:0.0-unknown-32226d
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-a639e4
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-icons
+ type: maven-folder
diff --git a/tests/react-icons/check-3/r/react-icons/bleep.yaml b/tests/react-icons/check-3/r/react-icons/bleep.yaml
new file mode 100644
index 0000000000..4ef6c927bb
--- /dev/null
+++ b/tests/react-icons/check-3/r/react-icons/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-icons:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react-icon-base_sjs1_3:2.1-16a3ce
+ - org.scalablytyped:react_sjs1_3:0.0-unknown-32226d
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-a639e4
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-icons
+ type: maven-folder
diff --git a/tests/react-icons/check-3/r/react/bleep.yaml b/tests/react-icons/check-3/r/react/bleep.yaml
new file mode 100644
index 0000000000..f92193b5d1
--- /dev/null
+++ b/tests/react-icons/check-3/r/react/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-a639e4
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-icons
+ type: maven-folder
diff --git a/tests/react-icons/check-3/s/std/bleep.yaml b/tests/react-icons/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..7f81cccd64
--- /dev/null
+++ b/tests/react-icons/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-icons
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/c/componentstest/bleep.yaml b/tests/react-integration-test/check-japgolly-3/c/componentstest/bleep.yaml
new file mode 100644
index 0000000000..4c5bcd853f
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/c/componentstest/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ componentstest:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/r/react-bootstrap/bleep.yaml b/tests/react-integration-test/check-japgolly-3/r/react-bootstrap/bleep.yaml
new file mode 100644
index 0000000000..d2720e4097
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/r/react-bootstrap/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-bootstrap:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/r/react-contextmenu/bleep.yaml b/tests/react-integration-test/check-japgolly-3/r/react-contextmenu/bleep.yaml
new file mode 100644
index 0000000000..6d8f25cf31
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/r/react-contextmenu/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-contextmenu:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/r/react-dropzone/bleep.yaml b/tests/react-integration-test/check-japgolly-3/r/react-dropzone/bleep.yaml
new file mode 100644
index 0000000000..dcdf93d30e
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/r/react-dropzone/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-dropzone:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/r/react-markdown/bleep.yaml b/tests/react-integration-test/check-japgolly-3/r/react-markdown/bleep.yaml
new file mode 100644
index 0000000000..dc755a1b6e
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/r/react-markdown/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-markdown:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/r/react-native/bleep.yaml b/tests/react-integration-test/check-japgolly-3/r/react-native/bleep.yaml
new file mode 100644
index 0000000000..c7dc66a459
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/r/react-native/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-native:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/r/react-select/bleep.yaml b/tests/react-integration-test/check-japgolly-3/r/react-select/bleep.yaml
new file mode 100644
index 0000000000..4a9937d163
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/r/react-select/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-select:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/r/react/bleep.yaml b/tests/react-integration-test/check-japgolly-3/r/react/bleep.yaml
new file mode 100644
index 0000000000..b56f356d54
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/r/react/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/s/semantic-ui-react/bleep.yaml b/tests/react-integration-test/check-japgolly-3/s/semantic-ui-react/bleep.yaml
new file mode 100644
index 0000000000..383ab33898
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/s/semantic-ui-react/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ semantic-ui-react:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/s/stardust-ui__react-component-event-listener/bleep.yaml b/tests/react-integration-test/check-japgolly-3/s/stardust-ui__react-component-event-listener/bleep.yaml
new file mode 100644
index 0000000000..c418b98324
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/s/stardust-ui__react-component-event-listener/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ stardust-ui__react-component-event-listener:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/s/stardust-ui__react-component-ref/bleep.yaml b/tests/react-integration-test/check-japgolly-3/s/stardust-ui__react-component-ref/bleep.yaml
new file mode 100644
index 0000000000..3b7baaa992
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/s/stardust-ui__react-component-ref/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ stardust-ui__react-component-ref:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-0ebacc
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-8b22f8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-japgolly-3/s/std/bleep.yaml b/tests/react-integration-test/check-japgolly-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..26ce330169
--- /dev/null
+++ b/tests/react-integration-test/check-japgolly-3/s/std/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/c/componentstest/bleep.yaml b/tests/react-integration-test/check-slinky-3/c/componentstest/bleep.yaml
new file mode 100644
index 0000000000..e44aa712fe
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/c/componentstest/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ componentstest:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/r/react-bootstrap/bleep.yaml b/tests/react-integration-test/check-slinky-3/r/react-bootstrap/bleep.yaml
new file mode 100644
index 0000000000..bab4cab0ba
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/r/react-bootstrap/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-bootstrap:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/r/react-contextmenu/bleep.yaml b/tests/react-integration-test/check-slinky-3/r/react-contextmenu/bleep.yaml
new file mode 100644
index 0000000000..45ce404c74
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/r/react-contextmenu/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-contextmenu:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/r/react-dropzone/bleep.yaml b/tests/react-integration-test/check-slinky-3/r/react-dropzone/bleep.yaml
new file mode 100644
index 0000000000..00865c4851
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/r/react-dropzone/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-dropzone:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/r/react-markdown/bleep.yaml b/tests/react-integration-test/check-slinky-3/r/react-markdown/bleep.yaml
new file mode 100644
index 0000000000..63cb1178bf
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/r/react-markdown/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-markdown:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/r/react-native/bleep.yaml b/tests/react-integration-test/check-slinky-3/r/react-native/bleep.yaml
new file mode 100644
index 0000000000..00a545a9b5
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/r/react-native/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-native:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/r/react-select/bleep.yaml b/tests/react-integration-test/check-slinky-3/r/react-select/bleep.yaml
new file mode 100644
index 0000000000..811e9724d1
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/r/react-select/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-select:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/r/react/bleep.yaml b/tests/react-integration-test/check-slinky-3/r/react/bleep.yaml
new file mode 100644
index 0000000000..cff77f1974
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/r/react/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/s/semantic-ui-react/bleep.yaml b/tests/react-integration-test/check-slinky-3/s/semantic-ui-react/bleep.yaml
new file mode 100644
index 0000000000..9c280d6d8e
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/s/semantic-ui-react/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ semantic-ui-react:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/s/stardust-ui__react-component-event-listener/bleep.yaml b/tests/react-integration-test/check-slinky-3/s/stardust-ui__react-component-event-listener/bleep.yaml
new file mode 100644
index 0000000000..4d44732963
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/s/stardust-ui__react-component-event-listener/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ stardust-ui__react-component-event-listener:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/s/stardust-ui__react-component-ref/bleep.yaml b/tests/react-integration-test/check-slinky-3/s/stardust-ui__react-component-ref/bleep.yaml
new file mode 100644
index 0000000000..f5535f82c9
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/s/stardust-ui__react-component-ref/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ stardust-ui__react-component-ref:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:16.9.2-6c1b12
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-d57ac3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-integration-test/check-slinky-3/s/std/bleep.yaml b/tests/react-integration-test/check-slinky-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..4556bbfd23
--- /dev/null
+++ b/tests/react-integration-test/check-slinky-3/s/std/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-integration-test
+ type: maven-folder
diff --git a/tests/react-transition-group/check-japgolly-3/r/react-transition-group/bleep.yaml b/tests/react-transition-group/check-japgolly-3/r/react-transition-group/bleep.yaml
new file mode 100644
index 0000000000..e1cc151bc4
--- /dev/null
+++ b/tests/react-transition-group/check-japgolly-3/r/react-transition-group/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-transition-group:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:0.0-unknown-ace288
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-3dbb8d
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-transition-group
+ type: maven-folder
diff --git a/tests/react-transition-group/check-japgolly-3/r/react/bleep.yaml b/tests/react-transition-group/check-japgolly-3/r/react/bleep.yaml
new file mode 100644
index 0000000000..8ba113814f
--- /dev/null
+++ b/tests/react-transition-group/check-japgolly-3/r/react/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-3dbb8d
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-transition-group
+ type: maven-folder
diff --git a/tests/react-transition-group/check-japgolly-3/s/std/bleep.yaml b/tests/react-transition-group/check-japgolly-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..901e95ac30
--- /dev/null
+++ b/tests/react-transition-group/check-japgolly-3/s/std/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies:
+ - com.github.japgolly.scalajs-react:core_sjs1_3:2.1.1
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-transition-group
+ type: maven-folder
diff --git a/tests/react-transition-group/check-slinky-3/r/react-transition-group/bleep.yaml b/tests/react-transition-group/check-slinky-3/r/react-transition-group/bleep.yaml
new file mode 100644
index 0000000000..5bfece86a5
--- /dev/null
+++ b/tests/react-transition-group/check-slinky-3/r/react-transition-group/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react-transition-group:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:react_sjs1_3:0.0-unknown-597d71
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-c9d4bb
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-transition-group
+ type: maven-folder
diff --git a/tests/react-transition-group/check-slinky-3/r/react/bleep.yaml b/tests/react-transition-group/check-slinky-3/r/react/bleep.yaml
new file mode 100644
index 0000000000..2f9b332c3e
--- /dev/null
+++ b/tests/react-transition-group/check-slinky-3/r/react/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-c9d4bb
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-transition-group
+ type: maven-folder
diff --git a/tests/react-transition-group/check-slinky-3/s/std/bleep.yaml b/tests/react-transition-group/check-slinky-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..0439a51fec
--- /dev/null
+++ b/tests/react-transition-group/check-slinky-3/s/std/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - me.shadaj:slinky-web_sjs1_3:0.7.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/react-transition-group
+ type: maven-folder
diff --git a/tests/recharts/check-3/r/recharts/bleep.yaml b/tests/recharts/check-3/r/recharts/bleep.yaml
new file mode 100644
index 0000000000..6992cd4cd6
--- /dev/null
+++ b/tests/recharts/check-3/r/recharts/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ recharts:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/recharts
+ type: maven-folder
diff --git a/tests/rxjs/check-3/r/rxjs/bleep.yaml b/tests/rxjs/check-3/r/rxjs/bleep.yaml
new file mode 100644
index 0000000000..65148657e5
--- /dev/null
+++ b/tests/rxjs/check-3/r/rxjs/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ rxjs:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/rxjs
+ type: maven-folder
diff --git a/tests/sax/check-3/n/node/bleep.yaml b/tests/sax/check-3/n/node/bleep.yaml
new file mode 100644
index 0000000000..ba02e0ec41
--- /dev/null
+++ b/tests/sax/check-3/n/node/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ node:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-6e4590
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/sax
+ type: maven-folder
diff --git a/tests/sax/check-3/s/sax/bleep.yaml b/tests/sax/check-3/s/sax/bleep.yaml
new file mode 100644
index 0000000000..7a8b2ebf71
--- /dev/null
+++ b/tests/sax/check-3/s/sax/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ sax:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:node_sjs1_3:9.6.x-19cff7
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-6e4590
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/sax
+ type: maven-folder
diff --git a/tests/sax/check-3/s/std/bleep.yaml b/tests/sax/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..d52c9a6197
--- /dev/null
+++ b/tests/sax/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/sax
+ type: maven-folder
diff --git a/tests/serve-static/check-3/e/express-serve-static-core/bleep.yaml b/tests/serve-static/check-3/e/express-serve-static-core/bleep.yaml
new file mode 100644
index 0000000000..09dd00e7f6
--- /dev/null
+++ b/tests/serve-static/check-3/e/express-serve-static-core/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ express-serve-static-core:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/serve-static
+ type: maven-folder
diff --git a/tests/serve-static/check-3/m/mime/bleep.yaml b/tests/serve-static/check-3/m/mime/bleep.yaml
new file mode 100644
index 0000000000..dffd2f800f
--- /dev/null
+++ b/tests/serve-static/check-3/m/mime/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ mime:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-43cef5
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/serve-static
+ type: maven-folder
diff --git a/tests/serve-static/check-3/s/serve-static/bleep.yaml b/tests/serve-static/check-3/s/serve-static/bleep.yaml
new file mode 100644
index 0000000000..dfa965afd0
--- /dev/null
+++ b/tests/serve-static/check-3/s/serve-static/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ serve-static:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:express-serve-static-core_sjs1_3:0.0-unknown-38d02c
+ - org.scalablytyped:mime_sjs1_3:2.0-ff6baa
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-43cef5
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/serve-static
+ type: maven-folder
diff --git a/tests/serve-static/check-3/s/std/bleep.yaml b/tests/serve-static/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..db021adbd2
--- /dev/null
+++ b/tests/serve-static/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/serve-static
+ type: maven-folder
diff --git a/tests/stylis/check-3/s/std/bleep.yaml b/tests/stylis/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..c7d075025c
--- /dev/null
+++ b/tests/stylis/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/stylis
+ type: maven-folder
diff --git a/tests/stylis/check-3/s/stylis/bleep.yaml b/tests/stylis/check-3/s/stylis/bleep.yaml
new file mode 100644
index 0000000000..7fce9449ab
--- /dev/null
+++ b/tests/stylis/check-3/s/stylis/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ stylis:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-43cef5
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/stylis
+ type: maven-folder
diff --git a/tests/swiz/check-3/s/std/bleep.yaml b/tests/swiz/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..08d46be8bb
--- /dev/null
+++ b/tests/swiz/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/swiz
+ type: maven-folder
diff --git a/tests/swiz/check-3/s/swiz/bleep.yaml b/tests/swiz/check-3/s/swiz/bleep.yaml
new file mode 100644
index 0000000000..5329e2b06b
--- /dev/null
+++ b/tests/swiz/check-3/s/swiz/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ swiz:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-43cef5
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/swiz
+ type: maven-folder
diff --git a/tests/tstl/check-3/t/tstl/bleep.yaml b/tests/tstl/check-3/t/tstl/bleep.yaml
new file mode 100644
index 0000000000..027bcb821e
--- /dev/null
+++ b/tests/tstl/check-3/t/tstl/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ tstl:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/tstl
+ type: maven-folder
diff --git a/tests/type-mappings/check-3/s/std/bleep.yaml b/tests/type-mappings/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..4fbe0e657d
--- /dev/null
+++ b/tests/type-mappings/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/type-mappings
+ type: maven-folder
diff --git a/tests/type-mappings/check-3/t/type-mappings/bleep.yaml b/tests/type-mappings/check-3/t/type-mappings/bleep.yaml
new file mode 100644
index 0000000000..6501d5dfb3
--- /dev/null
+++ b/tests/type-mappings/check-3/t/type-mappings/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ type-mappings:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-28b6e3
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/type-mappings
+ type: maven-folder
diff --git a/tests/typings-json/check-3/p/phaser/bleep.yaml b/tests/typings-json/check-3/p/phaser/bleep.yaml
new file mode 100644
index 0000000000..4710b9b299
--- /dev/null
+++ b/tests/typings-json/check-3/p/phaser/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ phaser:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-43cef5
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/typings-json
+ type: maven-folder
diff --git a/tests/typings-json/check-3/s/std/bleep.yaml b/tests/typings-json/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..4ce5da8cee
--- /dev/null
+++ b/tests/typings-json/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/typings-json
+ type: maven-folder
diff --git a/tests/union-to-inheritance/check-3/s/std/bleep.yaml b/tests/union-to-inheritance/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..91258513a3
--- /dev/null
+++ b/tests/union-to-inheritance/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/union-to-inheritance
+ type: maven-folder
diff --git a/tests/union-to-inheritance/check-3/u/union-to-inheritance/bleep.yaml b/tests/union-to-inheritance/check-3/u/union-to-inheritance/bleep.yaml
new file mode 100644
index 0000000000..bf3b6f6b69
--- /dev/null
+++ b/tests/union-to-inheritance/check-3/u/union-to-inheritance/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ union-to-inheritance:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-fb6f56
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/union-to-inheritance
+ type: maven-folder
diff --git a/tests/vfile/check-3/s/std/bleep.yaml b/tests/vfile/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..fd3fd22d58
--- /dev/null
+++ b/tests/vfile/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vfile
+ type: maven-folder
diff --git a/tests/vfile/check-3/v/vfile/bleep.yaml b/tests/vfile/check-3/v/vfile/bleep.yaml
new file mode 100644
index 0000000000..67a81a238d
--- /dev/null
+++ b/tests/vfile/check-3/v/vfile/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ vfile:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-805db8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vfile
+ type: maven-folder
diff --git a/tests/virtual-dom/check-3/v/virtual-dom/bleep.yaml b/tests/virtual-dom/check-3/v/virtual-dom/bleep.yaml
new file mode 100644
index 0000000000..637ab969a6
--- /dev/null
+++ b/tests/virtual-dom/check-3/v/virtual-dom/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ virtual-dom:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/virtual-dom
+ type: maven-folder
diff --git a/tests/void-elements/check-3/s/std/bleep.yaml b/tests/void-elements/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..edfae3ee71
--- /dev/null
+++ b/tests/void-elements/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/void-elements
+ type: maven-folder
diff --git a/tests/void-elements/check-3/v/void-elements/bleep.yaml b/tests/void-elements/check-3/v/void-elements/bleep.yaml
new file mode 100644
index 0000000000..3daee6fa41
--- /dev/null
+++ b/tests/void-elements/check-3/v/void-elements/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ void-elements:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-5c6000
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/void-elements
+ type: maven-folder
diff --git a/tests/vue/check-3/n/node/bleep.yaml b/tests/vue/check-3/n/node/bleep.yaml
new file mode 100644
index 0000000000..84c08b23e8
--- /dev/null
+++ b/tests/vue/check-3/n/node/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ node:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vue
+ type: maven-folder
diff --git a/tests/vue/check-3/s/std/bleep.yaml b/tests/vue/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..16f1ff5d1c
--- /dev/null
+++ b/tests/vue/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vue
+ type: maven-folder
diff --git a/tests/vue/check-3/s/storybook__vue/bleep.yaml b/tests/vue/check-3/s/storybook__vue/bleep.yaml
new file mode 100644
index 0000000000..0b141ab73c
--- /dev/null
+++ b/tests/vue/check-3/s/storybook__vue/bleep.yaml
@@ -0,0 +1,23 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ storybook__vue:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-b31d57
+ - org.scalablytyped:vue_sjs1_3:2.5.13-a432b8
+ - org.scalablytyped:webpack-env_sjs1_3:1.13-015d6e
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vue
+ type: maven-folder
diff --git a/tests/vue/check-3/v/vue-resource/bleep.yaml b/tests/vue/check-3/v/vue-resource/bleep.yaml
new file mode 100644
index 0000000000..31a824e285
--- /dev/null
+++ b/tests/vue/check-3/v/vue-resource/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ vue-resource:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-b31d57
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vue
+ type: maven-folder
diff --git a/tests/vue/check-3/v/vue-scrollto/bleep.yaml b/tests/vue/check-3/v/vue-scrollto/bleep.yaml
new file mode 100644
index 0000000000..62e9ea2f23
--- /dev/null
+++ b/tests/vue/check-3/v/vue-scrollto/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ vue-scrollto:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-b31d57
+ - org.scalablytyped:vue_sjs1_3:2.5.13-a432b8
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vue
+ type: maven-folder
diff --git a/tests/vue/check-3/v/vue/bleep.yaml b/tests/vue/check-3/v/vue/bleep.yaml
new file mode 100644
index 0000000000..d75c29d96d
--- /dev/null
+++ b/tests/vue/check-3/v/vue/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ vue:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-b31d57
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vue
+ type: maven-folder
diff --git a/tests/vue/check-3/w/webpack-env/bleep.yaml b/tests/vue/check-3/w/webpack-env/bleep.yaml
new file mode 100644
index 0000000000..3e6d0e7940
--- /dev/null
+++ b/tests/vue/check-3/w/webpack-env/bleep.yaml
@@ -0,0 +1,21 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ webpack-env:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-b31d57
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/vue
+ type: maven-folder
diff --git a/tests/winston/check-3/w/winston/bleep.yaml b/tests/winston/check-3/w/winston/bleep.yaml
new file mode 100644
index 0000000000..b946a31a43
--- /dev/null
+++ b/tests/winston/check-3/w/winston/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ winston:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/winston
+ type: maven-folder
diff --git a/tests/with-theme/check-3/r/react/bleep.yaml b/tests/with-theme/check-3/r/react/bleep.yaml
new file mode 100644
index 0000000000..c64e49b98b
--- /dev/null
+++ b/tests/with-theme/check-3/r/react/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ react:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/with-theme
+ type: maven-folder
diff --git a/tests/with-theme/check-3/s/std/bleep.yaml b/tests/with-theme/check-3/s/std/bleep.yaml
new file mode 100644
index 0000000000..a433792666
--- /dev/null
+++ b/tests/with-theme/check-3/s/std/bleep.yaml
@@ -0,0 +1,19 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ std:
+ dependencies: com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/with-theme
+ type: maven-folder
diff --git a/tests/with-theme/check-3/w/with-theme/bleep.yaml b/tests/with-theme/check-3/w/with-theme/bleep.yaml
new file mode 100644
index 0000000000..0ee0be16f2
--- /dev/null
+++ b/tests/with-theme/check-3/w/with-theme/bleep.yaml
@@ -0,0 +1,22 @@
+$schema: https://raw.githubusercontent.com/oyvindberg/bleep/master/schema.json
+$version: 0.0.1-M21
+jvm:
+ name: graalvm-java17:22.3.0
+projects:
+ with-theme:
+ dependencies:
+ - com.olvind:scalablytyped-runtime_sjs1_3:2.4.2
+ - org.scalablytyped:react_sjs1_3:0.0-unknown-f7710e
+ - org.scalablytyped:std_sjs1_3:0.0-unknown-61e39f
+ folder: ./
+ platform:
+ jsVersion: 1.11.0
+ name: js
+ sbt-scope: main
+ scala:
+ options: -encoding utf-8 -feature -language:existentials -language:higherKinds
+ -language:implicitConversions -no-indent -source:future
+ version: 3.2.0
+resolvers:
+ path: ${HOME_DIR}/.cache/scalablytyped/test-artifacts/with-theme
+ type: maven-folder