pekko/akka-actor/src/main/scala/akka/actor/Scheduler.scala

147 lines
5.4 KiB
Scala
Raw Normal View History

2009-08-17 20:46:05 +02:00
/*
* Copyright 2007 WorldWide Conferencing, LLC
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at http://www.apache.org/licenses/LICENSE-2.0
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
2010-05-21 08:18:56 +02:00
*
* Rework of David Pollak's ActorPing class in the Lift Project
* which is licensed under the Apache 2 License.
2009-08-17 20:46:05 +02:00
*/
package akka.actor
2009-08-17 18:42:41 +02:00
import scala.collection.JavaConversions
2009-08-17 18:42:41 +02:00
import java.util.concurrent._
2009-09-07 18:41:45 +02:00
import akka.event.EventHandler
import akka.AkkaException
import atomic.AtomicLong
2009-08-17 18:42:41 +02:00
2011-02-28 22:54:32 +01:00
object Scheduler {
import Actor._
2010-05-21 20:08:49 +02:00
case class SchedulerException(msg: String, e: Throwable) extends AkkaException(msg, e)
2010-05-21 08:18:56 +02:00
@volatile
private var service = Executors.newSingleThreadScheduledExecutor(SchedulerThreadFactory)
2010-08-06 17:13:31 +02:00
/**
* Schedules to send the specified message to the receiver after initialDelay and then repeated after delay.
* The returned java.util.concurrent.ScheduledFuture can be used to cancel the
* send of the message.
*/
2010-08-06 17:13:31 +02:00
def schedule(receiver: ActorRef, message: AnyRef, initialDelay: Long, delay: Long, timeUnit: TimeUnit): ScheduledFuture[AnyRef] = {
2009-08-17 18:42:41 +02:00
try {
2010-08-06 17:13:31 +02:00
service.scheduleAtFixedRate(
2010-05-21 20:08:49 +02:00
new Runnable { def run = receiver ! message },
2010-05-21 08:18:56 +02:00
initialDelay, delay, timeUnit).asInstanceOf[ScheduledFuture[AnyRef]]
2009-08-17 18:42:41 +02:00
} catch {
case e: Exception
val error = SchedulerException(message + " could not be scheduled on " + receiver, e)
EventHandler.error(error, this, "%s @ %s".format(receiver, message))
throw error
2009-08-17 18:42:41 +02:00
}
}
/**
* Schedules to run specified function to the receiver after initialDelay and then repeated after delay,
* avoid blocking operations since this is executed in the schedulers thread.
* The returned java.util.concurrent.ScheduledFuture can be used to cancel the
* execution of the function.
*/
def schedule(f: () Unit, initialDelay: Long, delay: Long, timeUnit: TimeUnit): ScheduledFuture[AnyRef] =
schedule(new Runnable { def run = f() }, initialDelay, delay, timeUnit)
/**
* Schedules to run specified runnable to the receiver after initialDelay and then repeated after delay,
* avoid blocking operations since this is executed in the schedulers thread.
* The returned java.util.concurrent.ScheduledFuture can be used to cancel the
* execution of the runnable.
*/
def schedule(runnable: Runnable, initialDelay: Long, delay: Long, timeUnit: TimeUnit): ScheduledFuture[AnyRef] = {
try {
service.scheduleAtFixedRate(runnable, initialDelay, delay, timeUnit).asInstanceOf[ScheduledFuture[AnyRef]]
} catch {
case e: Exception
val error = SchedulerException("Failed to schedule a Runnable", e)
EventHandler.error(error, this, error.getMessage)
throw error
}
}
/**
* Schedules to send the specified message to the receiver after delay.
* The returned java.util.concurrent.ScheduledFuture can be used to cancel the
* send of the message.
*/
2010-08-06 17:13:31 +02:00
def scheduleOnce(receiver: ActorRef, message: AnyRef, delay: Long, timeUnit: TimeUnit): ScheduledFuture[AnyRef] = {
try {
2010-08-06 17:13:31 +02:00
service.schedule(
new Runnable { def run = receiver ! message },
delay, timeUnit).asInstanceOf[ScheduledFuture[AnyRef]]
} catch {
case e: Exception
val error = SchedulerException(message + " could not be scheduleOnce'd on " + receiver, e)
EventHandler.error(e, this, receiver + " @ " + message)
throw error
}
}
/**
* Schedules a function to be run after delay,
* avoid blocking operations since the runnable is executed in the schedulers thread.
* The returned java.util.concurrent.ScheduledFuture can be used to cancel the
* execution of the function.
*/
def scheduleOnce(f: () Unit, delay: Long, timeUnit: TimeUnit): ScheduledFuture[AnyRef] =
scheduleOnce(new Runnable { def run = f() }, delay, timeUnit)
/**
* Schedules a runnable to be run after delay,
* avoid blocking operations since the runnable is executed in the schedulers thread.
* The returned java.util.concurrent.ScheduledFuture can be used to cancel the
* execution of the runnable.
*/
def scheduleOnce(runnable: Runnable, delay: Long, timeUnit: TimeUnit): ScheduledFuture[AnyRef] = {
try {
service.schedule(runnable, delay, timeUnit).asInstanceOf[ScheduledFuture[AnyRef]]
} catch {
case e: Exception
val error = SchedulerException("Failed to scheduleOnce a Runnable", e)
EventHandler.error(e, this, error.getMessage)
throw error
}
}
def shutdown() {
synchronized {
service.shutdown()
}
2009-08-17 18:42:41 +02:00
}
def restart() {
synchronized {
shutdown()
service = Executors.newSingleThreadScheduledExecutor(SchedulerThreadFactory)
}
2010-05-21 08:18:56 +02:00
}
}
2009-08-17 18:42:41 +02:00
private object SchedulerThreadFactory extends ThreadFactory {
private val count = new AtomicLong(0)
2009-08-17 18:42:41 +02:00
val threadFactory = Executors.defaultThreadFactory()
2009-08-17 20:46:05 +02:00
2009-08-17 18:42:41 +02:00
def newThread(r: Runnable): Thread = {
val thread = threadFactory.newThread(r)
thread.setName("akka:scheduler-" + count.incrementAndGet())
2009-08-17 18:42:41 +02:00
thread.setDaemon(true)
thread
}
}