summaryrefslogtreecommitdiff
path: root/cask/actor
diff options
context:
space:
mode:
authorLi Haoyi <haoyi.sg@gmail.com>2019-11-03 17:33:31 +0800
committerLi Haoyi <haoyi.sg@gmail.com>2019-11-03 18:33:31 +0800
commitc95bf293dbe23fa6c5fd9e23b35a4e4ce34da415 (patch)
tree48006bcf854ef635f64da57dd23f59027af652ce /cask/actor
parent12a91e2b6c78cd347996663f56eadb9616834823 (diff)
downloadcask-c95bf293dbe23fa6c5fd9e23b35a4e4ce34da415.tar.gz
cask-c95bf293dbe23fa6c5fd9e23b35a4e4ce34da415.tar.bz2
cask-c95bf293dbe23fa6c5fd9e23b35a4e4ce34da415.zip
Flesh out `BatchActor.scala` into its own module, `cask.Actor`. Add the first unit test for an asynchronous logging actor
Diffstat (limited to 'cask/actor')
-rw-r--r--cask/actor/src/Actors.scala78
-rw-r--r--cask/actor/src/Context.scala190
-rw-r--r--cask/actor/test/src-jvm/JvmActorsTest.scala124
-rw-r--r--cask/actor/test/src/ActorsTest.scala17
4 files changed, 409 insertions, 0 deletions
diff --git a/cask/actor/src/Actors.scala b/cask/actor/src/Actors.scala
new file mode 100644
index 0000000..69a5289
--- /dev/null
+++ b/cask/actor/src/Actors.scala
@@ -0,0 +1,78 @@
+package cask.actor
+import collection.mutable
+
+abstract class BaseActor[T]()(implicit ac: Context) extends Actor[T]{
+ private val queue = new mutable.Queue[(T, Context.Token)]()
+
+ private var scheduled = false
+
+ def send(t: T)
+ (implicit fileName: sourcecode.FileName,
+ line: sourcecode.Line): Unit = synchronized{
+ val token = ac.reportSchedule(this, t, fileName, line)
+ queue.enqueue((t, token))
+ if (!scheduled){
+ scheduled = true
+ ac.execute(() => runWithItems())
+ }
+ }
+ def sendAsync(f: scala.concurrent.Future[T])
+ (implicit fileName: sourcecode.FileName,
+ line: sourcecode.Line) = {
+ f.onComplete{
+ case scala.util.Success(v) => this.send(v)
+ case scala.util.Failure(e) => ac.reportFailure(e)
+ }
+ }
+
+ def runBatch0(msgs: Seq[(T, Context.Token)]): Unit
+ private[this] def runWithItems(): Unit = {
+ val msgs = synchronized(queue.dequeueAll(_ => true))
+
+ runBatch0(msgs)
+
+ synchronized{
+ if (queue.nonEmpty) ac.execute(() => runWithItems())
+ else{
+ assert(scheduled)
+ scheduled = false
+ }
+ }
+ }
+}
+
+abstract class BatchActor[T]()(implicit ac: Context) extends BaseActor[T]{
+ def runBatch(msgs: Seq[T]): Unit
+ def runBatch0(msgs: Seq[(T, Context.Token)]): Unit = {
+ try {
+ msgs.foreach{case (m, token) => ac.reportRun(this, m, token)}
+ runBatch(msgs.map(_._1))
+ }
+ catch{case e: Throwable => ac.reportFailure(e)}
+ finally msgs.foreach{case (m, token) => ac.reportComplete(token)}
+
+ }
+}
+
+abstract class SimpleActor[T]()(implicit ac: Context) extends BaseActor[T]{
+ def run(msg: T): Unit
+ override def runBatch0(msgs: Seq[(T, Context.Token)]): Unit = {
+ for((msg, token) <- msgs) {
+ try {
+ ac.reportRun(this, msg, token)
+ run(msg)
+ }
+ catch{case e: Throwable => ac.reportFailure(e)}
+ finally ac.reportComplete(token)
+ }
+ }
+}
+
+abstract class StateMachineActor[T]()(implicit ac: Context) extends SimpleActor[T]() {
+ class State(val run: T => State)
+ protected[this] def initialState: State
+ protected[this] var state: State = initialState
+ def run(msg: T): Unit = {
+ state = state.run(msg)
+ }
+} \ No newline at end of file
diff --git a/cask/actor/src/Context.scala b/cask/actor/src/Context.scala
new file mode 100644
index 0000000..6b56f2e
--- /dev/null
+++ b/cask/actor/src/Context.scala
@@ -0,0 +1,190 @@
+package cask.actor
+import java.util.concurrent.{Executors, ThreadFactory, TimeUnit}
+
+import scala.concurrent.duration.Duration
+import scala.concurrent.{Await, CanAwait, ExecutionContext, Future, Promise}
+import scala.util.Try
+
+/**
+ * An extended `scala.concurrent.ExecutionContext`; provides the ability to
+ * schedule messages to be sent later, and hooks to track the current number of
+ * outstanding tasks or log the actor message sends for debugging purporses
+ */
+trait Context extends ExecutionContext {
+ def reportSchedule(): Context.Token = new Context.Token.Simple()
+
+ def reportSchedule(fileName: sourcecode.FileName,
+ line: sourcecode.Line): Context.Token = {
+ new Context.Token.Future(fileName, line)
+ }
+
+ def reportSchedule(a: Actor[_],
+ msg: Any,
+ fileName: sourcecode.FileName,
+ line: sourcecode.Line): Context.Token = {
+ new Context.Token.Send(a, msg, fileName, line)
+ }
+
+ def reportRun(a: Actor[_],
+ msg: Any,
+ token: Context.Token): Unit = ()
+
+ def reportComplete(token: Context.Token): Unit = ()
+
+ def scheduleMsg[T](a: Actor[T], msg: T, time: java.time.Duration)
+ (implicit fileName: sourcecode.FileName,
+ line: sourcecode.Line): Unit
+
+ def future[T](t: => T)
+ (implicit fileName: sourcecode.FileName,
+ line: sourcecode.Line): Future[T]
+
+ def execute(runnable: Runnable): Unit
+}
+
+object Context{
+ trait Token
+ object Token{
+ class Simple extends Token(){
+ override def toString = "token@" + Integer.toHexString(hashCode())
+ }
+
+ class Future(val fileName: sourcecode.FileName,
+ val line: sourcecode.Line) extends Token(){
+ override def toString =
+ "token@" + Integer.toHexString(hashCode()) + "@" +
+ fileName.value + ":" + line.value
+ }
+
+ class Send(val a: Actor[_],
+ val msg: Any,
+ val fileName: sourcecode.FileName,
+ val line: sourcecode.Line) extends Token(){
+ override def toString =
+ "token@" + Integer.toHexString(hashCode()) + "@" +
+ fileName.value + ":" + line.value
+ }
+ }
+
+ class Simple(ec: ExecutionContext, logEx: Throwable => Unit) extends Context.Impl {
+ def executionContext = ec
+ def reportFailure(t: Throwable) = logEx(t)
+ }
+
+ object Simple{
+ implicit val global: Simple = new Simple(scala.concurrent.ExecutionContext.Implicits.global, _.printStackTrace())
+ }
+
+ class Test(ec: ExecutionContext = scala.concurrent.ExecutionContext.global,
+ logEx: Throwable => Unit = _.printStackTrace()) extends Context.Impl {
+ private[this] val active = collection.mutable.Set.empty[Context.Token]
+ private[this] var promise = concurrent.Promise.successful[Unit](())
+
+ def executionContext = ec
+
+ def reportFailure(t: Throwable) = logEx(t)
+
+ def handleReportSchedule(token: Context.Token) = synchronized{
+ if (active.isEmpty) {
+ assert(promise.isCompleted)
+ promise = concurrent.Promise[Unit]
+ }
+ active.add(token)
+ token
+ }
+ override def reportSchedule() = {
+ handleReportSchedule(super.reportSchedule())
+ }
+ override def reportSchedule(fileName: sourcecode.FileName,
+ line: sourcecode.Line): Context.Token = {
+ handleReportSchedule(super.reportSchedule(fileName, line))
+ }
+
+ override def reportSchedule(a: Actor[_],
+ msg: Any,
+ fileName: sourcecode.FileName,
+ line: sourcecode.Line): Context.Token = {
+ handleReportSchedule(super.reportSchedule(a, msg, fileName, line))
+ }
+
+ override def reportComplete(token: Context.Token) = this.synchronized{
+ assert(active.remove(token))
+
+ if (active.isEmpty) promise.success(())
+ }
+
+ def waitForInactivity(timeout: Option[java.time.Duration] = None) = {
+ Await.result(
+ this.synchronized(promise).future,
+ timeout match{
+ case None => scala.concurrent.duration.Duration.Inf
+ case Some(t) => scala.concurrent.duration.Duration.fromNanos(t.toNanos)
+ }
+ )
+ }
+ }
+
+ trait Impl extends Context {
+ def executionContext: ExecutionContext
+
+ def execute(runnable: Runnable): Unit = {
+ val token = reportSchedule()
+ executionContext.execute(new Runnable {
+ def run(): Unit = {
+ try runnable.run()
+ finally reportComplete(token)
+ }
+ })
+ }
+
+ def future[T](t: => T)
+ (implicit fileName: sourcecode.FileName,
+ line: sourcecode.Line): Future[T] = {
+ val token = reportSchedule(fileName, line)
+ val p = Promise[T]
+ executionContext.execute(new Runnable {
+ def run(): Unit = {
+ p.complete(scala.util.Try(t))
+ reportComplete(token)
+ }
+ })
+ p.future
+ }
+
+ lazy val scheduler = Executors.newSingleThreadScheduledExecutor(
+ new ThreadFactory {
+ def newThread(r: Runnable): Thread = {
+ val t = new Thread(r, "ActorContext-Scheduler-Thread")
+ t.setDaemon(true)
+ t
+ }
+ }
+ )
+
+ def scheduleMsg[T](a: Actor[T],
+ msg: T, delay: java.time.Duration)
+ (implicit fileName: sourcecode.FileName,
+ line: sourcecode.Line) = {
+ val token = reportSchedule(a, msg, fileName, line)
+ scheduler.schedule[Unit](
+ () => {
+ a.send(msg)(fileName, line)
+ reportComplete(token)
+ },
+ delay.toMillis,
+ TimeUnit.MILLISECONDS
+ )
+ }
+ }
+
+}
+
+trait Actor[T]{
+ def send(t: T)
+ (implicit fileName: sourcecode.FileName,
+ line: sourcecode.Line): Unit
+
+ def sendAsync(f: scala.concurrent.Future[T])
+ (implicit fileName: sourcecode.FileName,
+ line: sourcecode.Line): Unit
+}
diff --git a/cask/actor/test/src-jvm/JvmActorsTest.scala b/cask/actor/test/src-jvm/JvmActorsTest.scala
new file mode 100644
index 0000000..9cfb0d5
--- /dev/null
+++ b/cask/actor/test/src-jvm/JvmActorsTest.scala
@@ -0,0 +1,124 @@
+package cask.actor
+
+import utest._
+object JvmActorsTest extends TestSuite{
+ def tests = Tests{
+ os.remove.all(os.pwd / "out" / "scratch")
+ test("lock"){
+ val rotateSize = 50
+ val logPath = os.pwd / "out" / "scratch" / "log.txt"
+ val oldPath = os.pwd / "out" / "scratch" / "log-old.txt"
+
+ var logSize = 0
+
+ def logLine(s: String): Unit = {
+ val newLogSize = logSize + s.length + 1
+ if (newLogSize <= rotateSize) logSize = newLogSize
+ else {
+ logSize = 0
+ os.move(logPath, oldPath, replaceExisting = true)
+ }
+
+ os.write.append(logPath, s + "\n", createFolders = true)
+ }
+
+ logLine("I am cow")
+ logLine("hear me moo")
+ logLine("I weight twice as much as you")
+ logLine("And I look good on the barbecue")
+ logLine("Yoghurt curds cream cheese and butter")
+ logLine("Comes from liquids from my udder")
+ logLine("I am cow, I am cow")
+ logLine("Hear me moo, moooo")
+
+ os.read(oldPath).trim() ==> "Yoghurt curds cream cheese and butter\nComes from liquids from my udder"
+ os.read(logPath).trim() ==> "I am cow, I am cow\nHear me moo, moooo"
+ }
+
+ test("actor"){
+ class Logger(log: os.Path, old: os.Path, rotateSize: Int)
+ (implicit ac: Context) extends SimpleActor[String]{
+ def run(s: String) = {
+ val newLogSize = logSize + s.length + 1
+ if (newLogSize <= rotateSize) logSize = newLogSize
+ else {
+ logSize = s.length
+ os.move(log, old, replaceExisting = true)
+ }
+ os.write.append(log, s + "\n", createFolders = true)
+ }
+ private var logSize = 0
+ }
+
+ implicit val ac = new Context.Test()
+
+ val logPath = os.pwd / "out" / "scratch" / "log.txt"
+ val oldPath = os.pwd / "out" / "scratch" / "log-old.txt"
+
+ val logger = new Logger(logPath, oldPath, rotateSize = 50)
+
+ logger.send("I am cow")
+ logger.send("hear me moo")
+ logger.send("I weight twice as much as you")
+ logger.send("And I look good on the barbecue")
+ logger.send("Yoghurt curds cream cheese and butter")
+ logger.send("Comes from liquids from my udder")
+ logger.send("I am cow, I am cow")
+ logger.send("Hear me moo, moooo")
+
+ ac.waitForInactivity()
+
+ os.read.lines(oldPath) ==> Seq("Comes from liquids from my udder")
+ os.read.lines(logPath) ==> Seq("I am cow, I am cow", "Hear me moo, moooo")
+ }
+
+ test("pipeline"){
+ class Writer(log: os.Path, old: os.Path, rotateSize: Int)
+ (implicit ac: Context) extends SimpleActor[String]{
+ def run(s: String) = {
+ val newLogSize = logSize + s.length + 1
+ if (newLogSize <= rotateSize) logSize = newLogSize
+ else {
+ logSize = s.length
+ os.move(log, old, replaceExisting = true)
+ }
+ os.write.append(log, s + "\n", createFolders = true)
+ }
+ private var logSize = 0
+ }
+
+ class Logger(dest: Actor[String])(implicit ac: Context) extends SimpleActor[String]{
+ def run(s: String) = dest.send(java.util.Base64.getEncoder.encodeToString(s.getBytes))
+ }
+
+ implicit val ac = new Context.Test()
+
+ val logPath = os.pwd / "out" / "scratch" / "log.txt"
+ val oldPath = os.pwd / "out" / "scratch" / "log-old.txt"
+
+ val writer = new Writer(logPath, oldPath, rotateSize = 50)
+ val logger = new Logger(writer)
+
+ logger.send("I am cow")
+ logger.send("hear me moo")
+ logger.send("I weight twice as much as you")
+ logger.send("And I look good on the barbecue")
+ logger.send("Yoghurt curds cream cheese and butter")
+ logger.send("Comes from liquids from my udder")
+ logger.send("I am cow, I am cow")
+ logger.send("Hear me moo, moooo")
+
+ ac.waitForInactivity()
+
+ os.read(oldPath) ==> "Q29tZXMgZnJvbSBsaXF1aWRzIGZyb20gbXkgdWRkZXI=\n"
+ os.read(logPath) ==> "SSBhbSBjb3csIEkgYW0gY293\nSGVhciBtZSBtb28sIG1vb29v\n"
+
+ def decodeFile(p: os.Path) = {
+ os.read.lines(p).map(s => new String(java.util.Base64.getDecoder.decode(s)))
+ }
+
+ decodeFile(oldPath) ==> Seq("Comes from liquids from my udder")
+ decodeFile(logPath) ==> Seq("I am cow, I am cow", "Hear me moo, moooo")
+ }
+ }
+} \ No newline at end of file
diff --git a/cask/actor/test/src/ActorsTest.scala b/cask/actor/test/src/ActorsTest.scala
new file mode 100644
index 0000000..2c81e5b
--- /dev/null
+++ b/cask/actor/test/src/ActorsTest.scala
@@ -0,0 +1,17 @@
+package cask.actor
+import utest._
+object ActorsTest extends TestSuite{
+ def tests = Tests{
+ test("hello"){
+ import Context.Simple.global
+
+ sealed trait Msg
+
+ object logger extends SimpleActor[Msg]{
+ def run(msg: Msg) = {
+
+ }
+ }
+ }
+ }
+} \ No newline at end of file