Merge pull request #261 from jboner/wip-1662-remove-dead-imports-√
Wip 1662 remove dead imports √
This commit is contained in:
commit
d80a84ac03
59 changed files with 31 additions and 143 deletions
|
|
@ -8,7 +8,6 @@ import java.io.File
|
|||
import com.typesafe.config.Config
|
||||
import com.typesafe.config.ConfigFactory
|
||||
import com.typesafe.config.ConfigParseOptions
|
||||
import com.typesafe.config.ConfigResolveOptions
|
||||
|
||||
@deprecated("use ActorSystem instead", "2.0")
|
||||
object GlobalActorSystem extends ActorSystemImpl("GlobalSystem", OldConfigurationLoader.defaultConfig) {
|
||||
|
|
|
|||
|
|
@ -9,7 +9,6 @@ import akka.dispatch.Future
|
|||
import akka.dispatch.OldFuture
|
||||
import akka.util.Duration
|
||||
import java.util.concurrent.TimeUnit
|
||||
import java.net.InetSocketAddress
|
||||
import akka.migration.AskableActorRef
|
||||
|
||||
/**
|
||||
|
|
|
|||
|
|
@ -4,7 +4,6 @@
|
|||
package akka.dispatch
|
||||
|
||||
import java.util.concurrent.TimeoutException
|
||||
import akka.util.duration._
|
||||
import akka.AkkaException
|
||||
import akka.util.BoxedType
|
||||
import akka.util.Duration
|
||||
|
|
|
|||
|
|
@ -21,7 +21,7 @@ package object migration {
|
|||
implicit def actorRef2OldActorRef(actorRef: ActorRef) = new OldActorRef(actorRef)
|
||||
|
||||
class OldActorRef(actorRef: ActorRef) {
|
||||
@deprecated("Actors are automatically started when creatd, i.e. remove old call to start()", "2.0")
|
||||
@deprecated("Actors are automatically started when created, i.e. remove old call to start()", "2.0")
|
||||
def start(): ActorRef = actorRef
|
||||
|
||||
@deprecated("Stop with ActorSystem or ActorContext instead", "2.0")
|
||||
|
|
|
|||
|
|
@ -6,7 +6,6 @@ package akka.dispatch;
|
|||
|
||||
import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
|
||||
import java.util.concurrent.atomic.AtomicLongFieldUpdater;
|
||||
import java.util.concurrent.atomic.AtomicReferenceFieldUpdater;
|
||||
|
||||
abstract class AbstractMessageDispatcher {
|
||||
private volatile int _shutdownSchedule; // not initialized because this is faster: 0 == UNSCHEDULED
|
||||
|
|
|
|||
|
|
@ -4,20 +4,9 @@
|
|||
|
||||
package akka.actor
|
||||
|
||||
import akka.dispatch._
|
||||
import akka.routing._
|
||||
import akka.util.Duration
|
||||
import akka.japi.{ Creator, Procedure }
|
||||
import akka.serialization.{ Serializer, Serialization }
|
||||
import akka.event.Logging.Debug
|
||||
import akka.event.LogSource
|
||||
import akka.experimental
|
||||
import akka.AkkaException
|
||||
import scala.reflect.BeanProperty
|
||||
import scala.util.control.NoStackTrace
|
||||
import com.eaio.uuid.UUID
|
||||
import java.util.concurrent.TimeUnit
|
||||
import java.util.{ Collection ⇒ JCollection }
|
||||
import java.util.regex.Pattern
|
||||
|
||||
/**
|
||||
|
|
|
|||
|
|
@ -9,13 +9,10 @@ import akka.util._
|
|||
import scala.collection.immutable.Stack
|
||||
import java.lang.{ UnsupportedOperationException, IllegalStateException }
|
||||
import akka.serialization.Serialization
|
||||
import java.util.concurrent.TimeUnit
|
||||
import akka.event.EventStream
|
||||
import akka.event.DeathWatch
|
||||
import scala.annotation.tailrec
|
||||
import java.util.concurrent.{ ConcurrentHashMap, TimeoutException }
|
||||
import java.util.concurrent.{ ConcurrentHashMap }
|
||||
import akka.event.LoggingAdapter
|
||||
import java.util.concurrent.atomic.AtomicBoolean
|
||||
|
||||
/**
|
||||
* Immutable and serializable handle to an actor, which may or may not reside
|
||||
|
|
|
|||
|
|
@ -5,11 +5,10 @@
|
|||
package akka.actor
|
||||
|
||||
import java.util.concurrent.atomic.AtomicLong
|
||||
import akka.config.ConfigurationException
|
||||
import akka.dispatch._
|
||||
import akka.routing._
|
||||
import akka.AkkaException
|
||||
import akka.util.{ Duration, Switch, Helpers, Timeout }
|
||||
import akka.util.{ Switch, Helpers }
|
||||
import akka.event._
|
||||
|
||||
/**
|
||||
|
|
|
|||
|
|
@ -7,8 +7,6 @@ import akka.config.ConfigurationException
|
|||
import akka.event._
|
||||
import akka.dispatch._
|
||||
import akka.pattern.ask
|
||||
import akka.util.duration._
|
||||
import akka.util.Timeout._
|
||||
import org.jboss.netty.akka.util.HashedWheelTimer
|
||||
import java.util.concurrent.TimeUnit.MILLISECONDS
|
||||
import com.typesafe.config.Config
|
||||
|
|
|
|||
|
|
@ -4,12 +4,7 @@
|
|||
|
||||
package akka.actor
|
||||
|
||||
import collection.immutable.Seq
|
||||
import akka.event.Logging
|
||||
import akka.AkkaException
|
||||
import akka.config.ConfigurationException
|
||||
import akka.util.Duration
|
||||
import akka.event.EventStream
|
||||
import com.typesafe.config._
|
||||
import akka.routing._
|
||||
import java.util.concurrent.{ TimeUnit, ConcurrentHashMap }
|
||||
|
|
|
|||
|
|
@ -7,7 +7,6 @@ import akka.util._
|
|||
|
||||
import scala.collection.mutable
|
||||
import akka.event.Logging
|
||||
import akka.util.Duration._
|
||||
import akka.routing.{ Deafen, Listen, Listeners }
|
||||
|
||||
object FSM {
|
||||
|
|
|
|||
|
|
@ -4,7 +4,6 @@
|
|||
package akka.actor
|
||||
|
||||
import java.util.concurrent.TimeUnit
|
||||
import scala.annotation.tailrec
|
||||
import scala.collection.mutable.ArrayBuffer
|
||||
import scala.collection.JavaConversions._
|
||||
import java.lang.{ Iterable ⇒ JIterable }
|
||||
|
|
|
|||
|
|
@ -5,7 +5,6 @@ package akka.actor
|
|||
|
||||
import akka.dispatch._
|
||||
import akka.util.Duration
|
||||
import akka.util.duration._
|
||||
import java.util.concurrent.ConcurrentHashMap
|
||||
import akka.event.DeathWatch
|
||||
|
||||
|
|
|
|||
|
|
@ -6,7 +6,6 @@ package akka.actor
|
|||
|
||||
import akka.dispatch._
|
||||
import akka.japi.Creator
|
||||
import akka.util._
|
||||
import collection.immutable.Stack
|
||||
import akka.routing._
|
||||
|
||||
|
|
|
|||
|
|
@ -13,7 +13,7 @@
|
|||
package akka.actor
|
||||
|
||||
import akka.util.Duration
|
||||
import org.jboss.netty.akka.util.{ Timer, TimerTask, HashedWheelTimer, Timeout ⇒ HWTimeout }
|
||||
import org.jboss.netty.akka.util.{ TimerTask, HashedWheelTimer, Timeout ⇒ HWTimeout }
|
||||
import akka.event.LoggingAdapter
|
||||
import akka.dispatch.MessageDispatcher
|
||||
import java.io.Closeable
|
||||
|
|
|
|||
|
|
@ -6,9 +6,9 @@ package akka.actor
|
|||
|
||||
import akka.japi.{ Creator, Option ⇒ JOption }
|
||||
import java.lang.reflect.{ InvocationTargetException, Method, InvocationHandler, Proxy }
|
||||
import akka.util.{ Duration, Timeout }
|
||||
import akka.util.{ Timeout }
|
||||
import java.util.concurrent.atomic.{ AtomicReference ⇒ AtomVar }
|
||||
import akka.serialization.{ Serializer, Serialization, SerializationExtension }
|
||||
import akka.serialization.{ Serialization, SerializationExtension }
|
||||
import akka.dispatch._
|
||||
import java.util.concurrent.TimeoutException
|
||||
import java.lang.IllegalStateException
|
||||
|
|
|
|||
|
|
@ -4,8 +4,7 @@
|
|||
|
||||
package akka.actor
|
||||
|
||||
import akka.japi.{ Creator, Procedure }
|
||||
import akka.dispatch.{ MessageDispatcher, Promise }
|
||||
import akka.japi.{ Creator }
|
||||
|
||||
/**
|
||||
* Actor base trait that should be extended by or mixed to create an Actor with the semantics of the 'Actor Model':
|
||||
|
|
|
|||
|
|
@ -5,13 +5,9 @@
|
|||
package akka.dispatch
|
||||
|
||||
import util.DynamicVariable
|
||||
import akka.actor.{ ActorCell, Actor, IllegalActorStateException, ActorRef }
|
||||
import akka.actor.{ ActorCell, ActorRef }
|
||||
import java.util.concurrent.{ LinkedBlockingQueue, ConcurrentLinkedQueue, ConcurrentSkipListSet }
|
||||
import java.util.{ Comparator, Queue }
|
||||
import annotation.tailrec
|
||||
import akka.actor.ActorSystem
|
||||
import akka.event.EventStream
|
||||
import akka.actor.Scheduler
|
||||
import java.util.concurrent.atomic.AtomicBoolean
|
||||
import akka.util.Duration
|
||||
|
||||
|
|
|
|||
|
|
@ -9,12 +9,9 @@ import akka.util.{ Duration, ReflectiveAccess }
|
|||
import akka.actor.ActorSystem
|
||||
import akka.event.EventStream
|
||||
import akka.actor.Scheduler
|
||||
import akka.actor.ActorSystem.Settings
|
||||
import com.typesafe.config.Config
|
||||
import com.typesafe.config.ConfigFactory
|
||||
import akka.config.ConfigurationException
|
||||
import akka.event.Logging.Warning
|
||||
import akka.actor.Props
|
||||
import java.util.concurrent.{ ThreadFactory, TimeUnit, ConcurrentHashMap }
|
||||
|
||||
trait DispatcherPrerequisites {
|
||||
|
|
|
|||
|
|
@ -4,25 +4,22 @@
|
|||
|
||||
package akka.dispatch
|
||||
|
||||
import akka.AkkaException
|
||||
import akka.event.Logging.Error
|
||||
import akka.util.Timeout
|
||||
import scala.Option
|
||||
import akka.japi.{ Procedure, Function ⇒ JFunc, Option ⇒ JOption }
|
||||
import akka.japi.{ Function ⇒ JFunc, Option ⇒ JOption }
|
||||
|
||||
import scala.util.continuations._
|
||||
|
||||
import java.util.concurrent.TimeUnit.{ NANOSECONDS, MILLISECONDS }
|
||||
import java.util.concurrent.TimeUnit.NANOSECONDS
|
||||
import java.lang.{ Iterable ⇒ JIterable }
|
||||
import java.util.{ LinkedList ⇒ JLinkedList }
|
||||
|
||||
import scala.annotation.tailrec
|
||||
import scala.collection.mutable.Stack
|
||||
import akka.util.{ Switch, Duration, BoxedType }
|
||||
import java.util.concurrent.atomic.{ AtomicReferenceFieldUpdater, AtomicInteger, AtomicBoolean }
|
||||
import akka.util.{ Duration, BoxedType }
|
||||
import java.util.concurrent.atomic.{ AtomicReferenceFieldUpdater, AtomicInteger }
|
||||
import akka.dispatch.Await.CanAwait
|
||||
import java.util.concurrent._
|
||||
import akka.actor.ActorSystem
|
||||
|
||||
object Await {
|
||||
sealed trait CanAwait
|
||||
|
|
|
|||
|
|
@ -10,7 +10,6 @@ import akka.actor.{ ActorCell, ActorRef }
|
|||
import java.util.concurrent._
|
||||
import annotation.tailrec
|
||||
import akka.event.Logging.Error
|
||||
import com.typesafe.config.Config
|
||||
import akka.actor.ActorContext
|
||||
|
||||
class MessageQueueAppendFailedException(message: String, cause: Throwable = null) extends AkkaException(message, cause)
|
||||
|
|
|
|||
|
|
@ -4,13 +4,8 @@
|
|||
|
||||
package akka.dispatch
|
||||
|
||||
import java.util.concurrent.atomic.AtomicReference
|
||||
import akka.actor.ActorCell
|
||||
import akka.actor.ActorSystem
|
||||
import akka.event.EventStream
|
||||
import akka.actor.Scheduler
|
||||
import akka.util.Duration
|
||||
import java.util.concurrent.TimeUnit
|
||||
|
||||
/**
|
||||
* Dedicates a unique thread for each actor passed in as reference. Served through its messageQueue.
|
||||
|
|
|
|||
|
|
@ -6,7 +6,7 @@ package akka.dispatch
|
|||
|
||||
import java.util.concurrent.atomic.AtomicReference
|
||||
import scala.util.continuations._
|
||||
import scala.annotation.{ tailrec }
|
||||
import scala.annotation.tailrec
|
||||
import akka.util.Timeout
|
||||
|
||||
object PromiseStream {
|
||||
|
|
|
|||
|
|
@ -5,7 +5,7 @@
|
|||
package akka.dispatch
|
||||
|
||||
import java.util.Collection
|
||||
import java.util.concurrent.atomic.{ AtomicLong, AtomicInteger }
|
||||
import java.util.concurrent.atomic.AtomicLong
|
||||
import akka.util.Duration
|
||||
import java.util.concurrent._
|
||||
|
||||
|
|
|
|||
|
|
@ -3,8 +3,7 @@
|
|||
*/
|
||||
package akka.dispatch.japi
|
||||
|
||||
import akka.util.Timeout
|
||||
import akka.japi.{ Procedure2, Procedure, Function ⇒ JFunc, Option ⇒ JOption }
|
||||
import akka.japi.{ Procedure2, Procedure, Function ⇒ JFunc }
|
||||
|
||||
/* Java API */
|
||||
trait Future[+T] { self: akka.dispatch.Future[T] ⇒
|
||||
|
|
|
|||
|
|
@ -6,11 +6,6 @@ package akka.routing
|
|||
|
||||
import akka.actor._
|
||||
|
||||
import scala.annotation.tailrec
|
||||
|
||||
import java.util.concurrent.atomic.{ AtomicReference, AtomicInteger }
|
||||
import collection.JavaConverters
|
||||
|
||||
/**
|
||||
* An Iterable that also contains a version.
|
||||
*/
|
||||
|
|
|
|||
|
|
@ -4,11 +4,9 @@
|
|||
package akka.routing
|
||||
|
||||
import akka.actor._
|
||||
import akka.dispatch.{ Future, Promise }
|
||||
import java.util.concurrent.atomic.AtomicLong
|
||||
import java.util.concurrent.atomic.AtomicBoolean
|
||||
import java.util.concurrent.atomic.{ AtomicLong, AtomicBoolean }
|
||||
import java.util.concurrent.TimeUnit
|
||||
import akka.util.{ Duration, Timeout }
|
||||
import akka.util.Duration
|
||||
import akka.util.duration._
|
||||
import com.typesafe.config.Config
|
||||
import akka.config.ConfigurationException
|
||||
|
|
|
|||
|
|
@ -1,12 +1,11 @@
|
|||
package akka.util
|
||||
|
||||
import java.nio.ByteBuffer
|
||||
import java.nio.charset.Charset
|
||||
|
||||
import scala.collection.{ IndexedSeqOptimized, LinearSeq }
|
||||
import scala.collection.mutable.{ Builder, ArrayBuilder, WrappedArray }
|
||||
import scala.collection.IndexedSeqOptimized
|
||||
import scala.collection.mutable.{ Builder, WrappedArray }
|
||||
import scala.collection.immutable.{ IndexedSeq, VectorBuilder }
|
||||
import scala.collection.generic.{ CanBuildFrom, GenericCompanion }
|
||||
import scala.collection.generic.CanBuildFrom
|
||||
|
||||
object ByteString {
|
||||
|
||||
|
|
|
|||
|
|
@ -6,8 +6,7 @@ package akka.util
|
|||
|
||||
import java.util.concurrent.TimeUnit
|
||||
import TimeUnit._
|
||||
import java.lang.{ Long ⇒ JLong, Double ⇒ JDouble }
|
||||
import akka.actor.ActorSystem
|
||||
import java.lang.{ Double ⇒ JDouble }
|
||||
|
||||
class TimerException(message: String) extends RuntimeException(message)
|
||||
|
||||
|
|
|
|||
|
|
@ -3,7 +3,6 @@
|
|||
*/
|
||||
package akka.util
|
||||
|
||||
import java.io.{ PrintWriter, StringWriter }
|
||||
import java.util.Comparator
|
||||
import scala.annotation.tailrec
|
||||
import java.util.regex.Pattern
|
||||
|
|
|
|||
|
|
@ -4,7 +4,6 @@
|
|||
|
||||
package akka.util
|
||||
|
||||
import akka.actor._
|
||||
import java.lang.reflect.InvocationTargetException
|
||||
|
||||
object ReflectiveAccess {
|
||||
|
|
|
|||
|
|
@ -5,8 +5,6 @@ package akka.actor.mailbox
|
|||
|
||||
import com.surftools.BeanstalkClient._
|
||||
import com.surftools.BeanstalkClientImpl._
|
||||
import java.util.concurrent.TimeUnit.MILLISECONDS
|
||||
import akka.util.Duration
|
||||
import akka.AkkaException
|
||||
import akka.actor.ActorContext
|
||||
import akka.dispatch.Envelope
|
||||
|
|
|
|||
|
|
@ -3,14 +3,10 @@
|
|||
*/
|
||||
package akka.actor.mailbox
|
||||
|
||||
import akka.actor.ActorContext
|
||||
import akka.actor.ActorRef
|
||||
import akka.dispatch.Envelope
|
||||
import akka.dispatch.DefaultSystemMessageQueue
|
||||
import akka.dispatch.CustomMailbox
|
||||
import akka.actor.{ ActorContext, ActorRef }
|
||||
import akka.dispatch.{ Envelope, DefaultSystemMessageQueue, CustomMailbox }
|
||||
import akka.remote.MessageSerializer
|
||||
import akka.remote.RemoteProtocol.ActorRefProtocol
|
||||
import akka.remote.RemoteProtocol.RemoteMessageProtocol
|
||||
import akka.remote.RemoteProtocol.{ ActorRefProtocol, RemoteMessageProtocol }
|
||||
|
||||
private[akka] object DurableExecutableMailboxConfig {
|
||||
val Name = "[\\.\\/\\$\\s]".r
|
||||
|
|
|
|||
|
|
@ -14,10 +14,9 @@ import org.bson.BSONSerializer
|
|||
import org.bson.DefaultBSONDeserializer
|
||||
import org.bson.DefaultBSONSerializer
|
||||
|
||||
import akka.actor.SerializedActorRef
|
||||
import akka.remote.RemoteProtocol.MessageProtocol
|
||||
import akka.remote.MessageSerializer
|
||||
import akka.actor.{ ActorSystem, ActorSystemImpl, Props }
|
||||
import akka.actor.{ ActorSystem, ActorSystemImpl }
|
||||
|
||||
class BSONSerializableMailbox(system: ActorSystem) extends SerializableBSONObject[MongoDurableMessage] with Logging {
|
||||
|
||||
|
|
|
|||
|
|
@ -10,7 +10,7 @@ import org.bson.collection._
|
|||
import akka.actor.ActorContext
|
||||
import akka.event.Logging
|
||||
import akka.actor.ActorRef
|
||||
import akka.dispatch.{ Await, Promise, Envelope, DefaultPromise }
|
||||
import akka.dispatch.{ Await, Promise, Envelope }
|
||||
import java.util.concurrent.TimeoutException
|
||||
import akka.dispatch.MailboxType
|
||||
import com.typesafe.config.Config
|
||||
|
|
|
|||
|
|
@ -3,10 +3,7 @@
|
|||
*/
|
||||
package akka.actor.mailbox
|
||||
|
||||
import java.util.concurrent.TimeUnit.MILLISECONDS
|
||||
import akka.util.Duration
|
||||
import akka.AkkaException
|
||||
import org.I0Itec.zkclient.serialize._
|
||||
import akka.actor.ActorContext
|
||||
import akka.cluster.zookeeper.AkkaZkClient
|
||||
import akka.dispatch.Envelope
|
||||
|
|
|
|||
|
|
@ -7,7 +7,7 @@ package akka.kernel
|
|||
import akka.actor.ActorSystem
|
||||
import java.io.File
|
||||
import java.lang.Boolean.getBoolean
|
||||
import java.net.{ URL, URLClassLoader }
|
||||
import java.net.URLClassLoader
|
||||
import java.util.jar.JarFile
|
||||
import scala.collection.JavaConverters._
|
||||
|
||||
|
|
|
|||
|
|
@ -11,8 +11,6 @@ import scala.annotation.tailrec
|
|||
|
||||
import System.{ currentTimeMillis ⇒ newTimestamp }
|
||||
|
||||
import akka.actor.ActorSystem
|
||||
|
||||
/**
|
||||
* Implementation of 'The Phi Accrual Failure Detector' by Hayashibara et al. as defined in their paper:
|
||||
* [http://ddg.jaist.ac.jp/pub/HDY+04.pdf]
|
||||
|
|
|
|||
|
|
@ -9,7 +9,6 @@ import akka.actor.Status._
|
|||
import akka.event.Logging
|
||||
import akka.util.Duration
|
||||
import akka.config.ConfigurationException
|
||||
import akka.serialization.SerializationExtension
|
||||
|
||||
import java.util.concurrent.atomic.AtomicReference
|
||||
import java.util.concurrent.TimeUnit.SECONDS
|
||||
|
|
@ -19,7 +18,6 @@ import System.{ currentTimeMillis ⇒ newTimestamp }
|
|||
import scala.collection.immutable.Map
|
||||
import scala.annotation.tailrec
|
||||
|
||||
import com.google.protobuf.ByteString
|
||||
import java.util.concurrent.TimeoutException
|
||||
import akka.dispatch.Await
|
||||
import akka.pattern.ask
|
||||
|
|
|
|||
|
|
@ -5,9 +5,7 @@
|
|||
package akka.remote
|
||||
|
||||
import scala.collection.mutable
|
||||
import akka.actor.{ LocalActorRef, Actor, ActorRef, Props, newUuid }
|
||||
import akka.actor.Actor._
|
||||
import akka.actor.ActorSystemImpl
|
||||
import akka.actor.{ Actor, Props, ActorSystemImpl }
|
||||
|
||||
/**
|
||||
* Stream of all kinds of network events, remote failure and connection events, cluster failure and connection events etc.
|
||||
|
|
|
|||
|
|
@ -7,9 +7,7 @@ package akka.remote
|
|||
import akka.actor._
|
||||
import akka.event._
|
||||
import akka.util._
|
||||
import akka.util.duration._
|
||||
import akka.util.Helpers._
|
||||
import akka.serialization.{ JavaSerializer, Serialization, SerializationExtension }
|
||||
import akka.serialization.{ Serialization, SerializationExtension }
|
||||
import akka.dispatch.MessageDispatcher
|
||||
import akka.dispatch.SystemMessage
|
||||
import scala.annotation.tailrec
|
||||
|
|
|
|||
|
|
@ -6,16 +6,9 @@ package akka.remote
|
|||
|
||||
import akka.actor._
|
||||
import akka.dispatch._
|
||||
import akka.util.duration._
|
||||
import akka.util.Timeout
|
||||
import akka.config.ConfigurationException
|
||||
import akka.event.{ DeathWatch, Logging }
|
||||
import akka.serialization.Compression.LZF
|
||||
import com.google.protobuf.ByteString
|
||||
import akka.event.EventStream
|
||||
import akka.dispatch.Promise
|
||||
import akka.config.ConfigurationException
|
||||
import java.util.concurrent.{ TimeoutException }
|
||||
|
||||
/**
|
||||
* Remote ActorRefProvider. Starts up actor on remote node and creates a RemoteActorRef representing it.
|
||||
|
|
|
|||
|
|
@ -6,7 +6,6 @@ package akka.remote
|
|||
|
||||
import akka.actor._
|
||||
import akka.routing._
|
||||
import akka.actor.ActorSystem
|
||||
import akka.event.Logging
|
||||
|
||||
import scala.collection.immutable.Map
|
||||
|
|
|
|||
|
|
@ -7,13 +7,10 @@ package akka.remote
|
|||
import akka.actor._
|
||||
import akka.AkkaException
|
||||
import scala.reflect.BeanProperty
|
||||
import java.io.{ PrintWriter, PrintStream }
|
||||
import java.net.InetSocketAddress
|
||||
import java.net.URI
|
||||
import java.net.URISyntaxException
|
||||
import java.net.InetAddress
|
||||
import java.net.UnknownHostException
|
||||
import java.net.UnknownServiceException
|
||||
import akka.event.Logging
|
||||
|
||||
/**
|
||||
|
|
|
|||
|
|
@ -8,7 +8,6 @@ import akka.util.Duration
|
|||
import java.util.concurrent.TimeUnit.MILLISECONDS
|
||||
import java.net.InetAddress
|
||||
import akka.config.ConfigurationException
|
||||
import com.eaio.uuid.UUID
|
||||
import scala.collection.JavaConverters._
|
||||
|
||||
class RemoteSettings(val config: Config, val systemName: String) {
|
||||
|
|
|
|||
|
|
@ -4,7 +4,7 @@
|
|||
|
||||
package akka.remote.netty
|
||||
|
||||
import akka.actor.{ ActorRef, IllegalActorStateException, simpleName }
|
||||
import akka.actor.{ ActorRef, simpleName }
|
||||
import akka.remote._
|
||||
import RemoteProtocol._
|
||||
import akka.util._
|
||||
|
|
@ -25,7 +25,6 @@ import akka.actor.ActorSystemImpl
|
|||
import org.jboss.netty.handler.execution.{ ExecutionHandler, OrderedMemoryAwareThreadPoolExecutor }
|
||||
import java.util.concurrent._
|
||||
import locks.ReentrantReadWriteLock
|
||||
import akka.dispatch.MonitorableThreadFactory
|
||||
|
||||
class RemoteClientMessageBufferException(message: String, cause: Throwable = null) extends AkkaException(message, cause) {
|
||||
def this(msg: String) = this(msg, null)
|
||||
|
|
|
|||
|
|
@ -1,7 +1,5 @@
|
|||
package akka.remote
|
||||
|
||||
import akka.remote._
|
||||
import akka.routing._
|
||||
import akka.actor.{ Actor, Props }
|
||||
import akka.testkit._
|
||||
import akka.dispatch.Await
|
||||
|
|
|
|||
|
|
@ -1,10 +1,7 @@
|
|||
package akka.remote
|
||||
|
||||
import akka.actor.{ Actor, Props }
|
||||
import akka.remote._
|
||||
import akka.routing._
|
||||
import akka.testkit._
|
||||
import akka.util.duration._
|
||||
import akka.dispatch.Await
|
||||
import akka.pattern.ask
|
||||
|
||||
|
|
|
|||
|
|
@ -1,7 +1,6 @@
|
|||
package akka.remote
|
||||
|
||||
import akka.actor.{ Actor, Props }
|
||||
import akka.remote._
|
||||
import akka.routing._
|
||||
import akka.testkit.DefaultTimeout
|
||||
import akka.dispatch.Await
|
||||
|
|
|
|||
|
|
@ -1,7 +1,6 @@
|
|||
package akka.remote
|
||||
|
||||
import akka.actor.{ Actor, Props }
|
||||
import akka.remote._
|
||||
import akka.routing._
|
||||
import akka.testkit.DefaultTimeout
|
||||
import akka.dispatch.Await
|
||||
|
|
|
|||
|
|
@ -1,7 +1,6 @@
|
|||
package akka.remote
|
||||
|
||||
import akka.actor.{ Actor, Props }
|
||||
import akka.remote._
|
||||
import akka.routing._
|
||||
import akka.testkit._
|
||||
import akka.util.duration._
|
||||
|
|
|
|||
|
|
@ -11,7 +11,6 @@ import sbt.classpath.ClasspathUtilities
|
|||
import sbt.Project.Initialize
|
||||
import sbt.CommandSupport._
|
||||
import java.io.File
|
||||
import scala.collection.mutable.{ Set ⇒ MutableSet }
|
||||
|
||||
object AkkaKernelPlugin extends Plugin {
|
||||
|
||||
|
|
|
|||
|
|
@ -11,7 +11,6 @@ import scala.annotation.tailrec
|
|||
|
||||
import com.typesafe.config.Config
|
||||
|
||||
import CallingThreadDispatcher.Id
|
||||
import akka.actor.{ ExtensionIdProvider, ExtensionId, Extension, ExtendedActorSystem, ActorRef, ActorCell }
|
||||
import akka.dispatch.{ TaskInvocation, SystemMessage, Suspend, Resume, MessageDispatcherConfigurator, MessageDispatcher, Mailbox, Envelope, DispatcherPrerequisites, DefaultSystemMessageQueue }
|
||||
import akka.util.duration.intToDurationInt
|
||||
|
|
|
|||
|
|
@ -6,11 +6,7 @@ package akka.testkit
|
|||
|
||||
import akka.actor._
|
||||
import akka.util.{ ReflectiveAccess, Duration }
|
||||
import com.eaio.uuid.UUID
|
||||
import akka.actor.Props._
|
||||
import akka.actor.ActorSystem
|
||||
import java.util.concurrent.atomic.AtomicLong
|
||||
import akka.event.EventStream
|
||||
import scala.collection.immutable.Stack
|
||||
import akka.dispatch._
|
||||
import akka.pattern.ask
|
||||
|
|
|
|||
|
|
@ -3,13 +3,11 @@
|
|||
*/
|
||||
package akka.testkit
|
||||
|
||||
import scala.annotation.tailrec
|
||||
import scala.util.matching.Regex
|
||||
import akka.actor.{ DeadLetter, ActorSystem, Terminated }
|
||||
import akka.dispatch.{ SystemMessage, Terminate }
|
||||
import akka.event.Logging.{ Warning, LogEvent, InitializeLogger, Info, Error, Debug, LoggerInitialized }
|
||||
import akka.event.Logging
|
||||
import akka.testkit.TestEvent.{ UnMute, Mute }
|
||||
import akka.util.Duration
|
||||
|
||||
/**
|
||||
|
|
|
|||
|
|
@ -6,10 +6,7 @@ package akka.testkit
|
|||
|
||||
import akka.actor._
|
||||
import akka.util._
|
||||
import com.eaio.uuid.UUID
|
||||
import akka.actor.ActorSystem
|
||||
import akka.event.EventStream
|
||||
import akka.dispatch.{ DispatcherPrerequisites, Mailbox }
|
||||
import akka.dispatch.DispatcherPrerequisites
|
||||
|
||||
/**
|
||||
* This is a specialised form of the TestActorRef with support for querying and
|
||||
|
|
|
|||
|
|
@ -6,7 +6,6 @@ package akka.transactor
|
|||
|
||||
import akka.actor.{ UntypedActor, ActorRef }
|
||||
import scala.collection.JavaConversions._
|
||||
import scala.concurrent.stm.InTxn
|
||||
import java.util.{ Set ⇒ JSet }
|
||||
|
||||
/**
|
||||
|
|
|
|||
|
|
@ -8,7 +8,6 @@ import org.zeromq.{ ZMQ ⇒ JZMQ }
|
|||
import akka.actor._
|
||||
import akka.dispatch.{ Promise, Future }
|
||||
import akka.event.Logging
|
||||
import akka.util.duration._
|
||||
import annotation.tailrec
|
||||
import akka.util.Duration
|
||||
import java.util.concurrent.TimeUnit
|
||||
|
|
|
|||
|
|
@ -3,7 +3,6 @@
|
|||
*/
|
||||
package akka.zeromq
|
||||
|
||||
import akka.util.duration._
|
||||
import org.zeromq.{ ZMQ ⇒ JZMQ }
|
||||
import akka.actor._
|
||||
import akka.dispatch.{ Await }
|
||||
|
|
|
|||
Loading…
Add table
Add a link
Reference in a new issue