diff --git a/akka-core/src/main/scala/actor/ActiveObject.scala b/akka-core/src/main/scala/actor/ActiveObject.scala
index 9ec943cfc6..0780e355dd 100644
--- a/akka-core/src/main/scala/actor/ActiveObject.scala
+++ b/akka-core/src/main/scala/actor/ActiveObject.scala
@@ -66,23 +66,23 @@ final class ActiveObjectConfiguration {
}
/**
- * Holds RTTI (runtime type information) for the Active Object, f.e. current 'sender'
+ * Holds RTTI (runtime type information) for the Active Object, f.e. current 'sender'
* reference, the 'senderFuture' reference etc.
*
- * In order to make use of this context you have to create a member field in your
- * Active Object that has the type 'ActiveObjectContext', then an instance will
- * be injected for you to use.
+ * In order to make use of this context you have to create a member field in your
+ * Active Object that has the type 'ActiveObjectContext', then an instance will
+ * be injected for you to use.
*
- * This class does not contain static information but is updated by the runtime system
- * at runtime.
+ * This class does not contain static information but is updated by the runtime system
+ * at runtime.
*
- * Here is an example of usage:
+ * Here is an example of usage:
*
* class Ping {
- * // This context will be injected, holds RTTI (runtime type information)
- * // for the current message send
+ * // This context will be injected, holds RTTI (runtime type information)
+ * // for the current message send
* private ActiveObjectContext context = null;
- *
+ *
* public void hit(int count) {
* Pong pong = (Pong) context.getSender();
* pong.hit(count++)
@@ -100,19 +100,19 @@ final class ActiveObjectContext {
* Returns the current sender Active Object reference.
* Scala style getter.
*/
- def sender: AnyRef = {
+ def sender: AnyRef = {
if (_sender eq null) throw new IllegalStateException("Sender reference should not be null.")
else _sender
- }
+ }
/**
* Returns the current sender Active Object reference.
* Java style getter.
*/
- def getSender: AnyRef = {
+ def getSender: AnyRef = {
if (_sender eq null) throw new IllegalStateException("Sender reference should not be null.")
else _sender
- }
+ }
/**
* Returns the current sender future Active Object reference.
@@ -364,7 +364,7 @@ object ActiveObject extends Logging {
proxy.asInstanceOf[T]
}
- private[akka] def newInstance[T](intf: Class[T], target: AnyRef, actorRef: ActorRef,
+ private[akka] def newInstance[T](intf: Class[T], target: AnyRef, actorRef: ActorRef,
remoteAddress: Option[InetSocketAddress], timeout: Long): T = {
val context = injectActiveObjectContext(target)
val proxy = Proxy.newInstance(Array(intf), Array(target), false, false)
@@ -462,7 +462,7 @@ object ActiveObject extends Logging {
if (parent != null) injectActiveObjectContext0(activeObject, parent)
else {
log.warning(
- "Can't set 'ActiveObjectContext' for ActiveObject [%s] since no field of this type could be found.",
+ "Can't set 'ActiveObjectContext' for ActiveObject [%s] since no field of this type could be found.",
activeObject.getClass.getName)
None
}
@@ -522,7 +522,7 @@ private[akka] sealed class ActiveObjectAspect {
remoteAddress = init.remoteAddress
timeout = init.timeout
isInitialized = true
-
+
}
dispatch(joinPoint)
}
@@ -583,7 +583,7 @@ private[akka] sealed class ActiveObjectAspect {
} else future.result
private def isVoid(rtti: MethodRtti) = rtti.getMethod.getReturnType == java.lang.Void.TYPE
-
+
private def escapeArguments(args: Array[AnyRef]): Tuple2[Array[AnyRef], Boolean] = {
var isEscaped = false
val escapedArgs = for (arg <- args) yield {
@@ -606,11 +606,11 @@ private[akka] sealed class ActiveObjectAspect {
joinPoint: JoinPoint, isOneWay: Boolean, isVoid: Boolean, sender: AnyRef, senderFuture: CompletableFuture[Any]) {
override def toString: String = synchronized {
- "Invocation [joinPoint: " + joinPoint.toString +
- ", isOneWay: " + isOneWay +
+ "Invocation [joinPoint: " + joinPoint.toString +
+ ", isOneWay: " + isOneWay +
", isVoid: " + isVoid +
- ", sender: " + sender +
- ", senderFuture: " + senderFuture +
+ ", sender: " + sender +
+ ", senderFuture: " + senderFuture +
"]"
}
@@ -653,11 +653,11 @@ private[akka] class Dispatcher(transactionalRequired: Boolean, val callbacks: Op
private var postRestart: Option[Method] = None
private var initTxState: Option[Method] = None
private var context: Option[ActiveObjectContext] = None
-
+
def this(transactionalRequired: Boolean) = this(transactionalRequired,None)
private[actor] def initialize(targetClass: Class[_], targetInstance: AnyRef, ctx: Option[ActiveObjectContext]) = {
- if (transactionalRequired || targetClass.isAnnotationPresent(Annotations.transactionrequired))
+ if (transactionalRequired || targetClass.isAnnotationPresent(Annotations.transactionrequired))
self.makeTransactionRequired
self.id = targetClass.getName
target = Some(targetInstance)
@@ -705,7 +705,7 @@ private[akka] class Dispatcher(transactionalRequired: Boolean, val callbacks: Op
def receive = {
case Invocation(joinPoint, isOneWay, _, sender, senderFuture) =>
- context.foreach { ctx =>
+ context.foreach { ctx =>
if (sender ne null) ctx._sender = sender
if (senderFuture ne null) ctx._senderFuture = senderFuture
}
diff --git a/akka-core/src/main/scala/actor/Actor.scala b/akka-core/src/main/scala/actor/Actor.scala
index 120bea199d..3b7d62f97f 100644
--- a/akka-core/src/main/scala/actor/Actor.scala
+++ b/akka-core/src/main/scala/actor/Actor.scala
@@ -329,7 +329,7 @@ trait Actor extends Logging {
*
* self ! message
*
- * Here you also find most of the Actor API.
+ * Here you also find most of the Actor API.
*
* For example fields like:
*
@@ -384,7 +384,7 @@ trait Actor extends Logging {
* Is called when an Actor is started by invoking 'actor.start'.
*/
def init {}
-
+
/**
* User overridable callback.
*
diff --git a/akka-core/src/main/scala/actor/ActorRef.scala b/akka-core/src/main/scala/actor/ActorRef.scala
index 200997d1d2..682e85655c 100644
--- a/akka-core/src/main/scala/actor/ActorRef.scala
+++ b/akka-core/src/main/scala/actor/ActorRef.scala
@@ -222,7 +222,7 @@ trait ActorRef extends TransactionManagement {
* Is defined if the message was sent with sent with '!!' or '!!!', else None.
*/
def senderFuture: Option[CompletableFuture[Any]] = guard.withGuard { _senderFuture }
-
+
/**
* Is the actor being restarted?
*/
@@ -356,7 +356,7 @@ trait ActorRef extends TransactionManagement {
"\n\tYou have probably: " +
"\n\t\t1. Sent a message to an Actor from an instance that is NOT an Actor." +
"\n\t\t2. Invoked a method on an Active Object from an instance NOT an Active Object.")
-
+
/**
* Use reply_?(..) to reply with a message to the original sender of the message currently
* being processed.
@@ -1224,7 +1224,7 @@ private[akka] case class RemoteActorRef private[akka] (
extends ActorRef {
_uuid = uuuid
timeout = _timeout
-
+
start
lazy val remoteClient = RemoteClient.clientFor(hostname, port, loader)
diff --git a/akka-core/src/main/scala/remote/RemoteClient.scala b/akka-core/src/main/scala/remote/RemoteClient.scala
index f93c5dc345..15ed0409ed 100644
--- a/akka-core/src/main/scala/remote/RemoteClient.scala
+++ b/akka-core/src/main/scala/remote/RemoteClient.scala
@@ -82,19 +82,19 @@ object RemoteClient extends Logging {
private[akka] def actorFor(uuid: String, className: String, timeout: Long, hostname: String, port: Int, loader: Option[ClassLoader]): ActorRef =
RemoteActorRef(uuid, className, hostname, port, timeout, loader)
- def clientFor(hostname: String, port: Int): RemoteClient =
+ def clientFor(hostname: String, port: Int): RemoteClient =
clientFor(new InetSocketAddress(hostname, port), None)
- def clientFor(hostname: String, port: Int, loader: ClassLoader): RemoteClient =
+ def clientFor(hostname: String, port: Int, loader: ClassLoader): RemoteClient =
clientFor(new InetSocketAddress(hostname, port), Some(loader))
- def clientFor(address: InetSocketAddress): RemoteClient =
+ def clientFor(address: InetSocketAddress): RemoteClient =
clientFor(address, None)
- def clientFor(address: InetSocketAddress, loader: ClassLoader): RemoteClient =
+ def clientFor(address: InetSocketAddress, loader: ClassLoader): RemoteClient =
clientFor(address, Some(loader))
- private[akka] def clientFor(hostname: String, port: Int, loader: Option[ClassLoader]): RemoteClient =
+ private[akka] def clientFor(hostname: String, port: Int, loader: Option[ClassLoader]): RemoteClient =
clientFor(new InetSocketAddress(hostname, port), loader)
private[akka] def clientFor(address: InetSocketAddress, loader: Option[ClassLoader]): RemoteClient = synchronized {
@@ -330,7 +330,7 @@ class RemoteClientHandler(val name: String,
client.connection = bootstrap.connect(remoteAddress)
client.connection.awaitUninterruptibly // Wait until the connection attempt succeeds or fails.
if (!client.connection.isSuccess) {
- client.listeners.toArray.foreach(l =>
+ client.listeners.toArray.foreach(l =>
l.asInstanceOf[ActorRef] ! RemoteClientError(client.connection.getCause))
log.error(client.connection.getCause, "Reconnection to [%s] has failed", remoteAddress)
}
@@ -339,13 +339,13 @@ class RemoteClientHandler(val name: String,
}
override def channelConnected(ctx: ChannelHandlerContext, event: ChannelStateEvent) = {
- client.listeners.toArray.foreach(l =>
+ client.listeners.toArray.foreach(l =>
l.asInstanceOf[ActorRef] ! RemoteClientConnected(client.hostname, client.port))
log.debug("Remote client connected to [%s]", ctx.getChannel.getRemoteAddress)
}
override def channelDisconnected(ctx: ChannelHandlerContext, event: ChannelStateEvent) = {
- client.listeners.toArray.foreach(l =>
+ client.listeners.toArray.foreach(l =>
l.asInstanceOf[ActorRef] ! RemoteClientDisconnected(client.hostname, client.port))
log.debug("Remote client disconnected from [%s]", ctx.getChannel.getRemoteAddress)
}
diff --git a/akka-core/src/main/scala/remote/RemoteServer.scala b/akka-core/src/main/scala/remote/RemoteServer.scala
index 3b02a3a850..8f6cd40684 100644
--- a/akka-core/src/main/scala/remote/RemoteServer.scala
+++ b/akka-core/src/main/scala/remote/RemoteServer.scala
@@ -184,7 +184,7 @@ class RemoteServer extends Logging {
def start(_hostname: String, _port: Int): RemoteServer =
start(_hostname, _port, None)
- private def start(_hostname: String, _port: Int, loader: ClassLoader): RemoteServer =
+ private def start(_hostname: String, _port: Int, loader: ClassLoader): RemoteServer =
start(_hostname, _port, Some(loader))
private def start(_hostname: String, _port: Int, loader: Option[ClassLoader]): RemoteServer = synchronized {
diff --git a/akka-core/src/main/scala/routing/Listeners.scala b/akka-core/src/main/scala/routing/Listeners.scala
index 4bfc3f30b6..7563e0800b 100644
--- a/akka-core/src/main/scala/routing/Listeners.scala
+++ b/akka-core/src/main/scala/routing/Listeners.scala
@@ -13,7 +13,7 @@ case class Listen(listener: ActorRef) extends ListenerMessage
case class Deafen(listener: ActorRef) extends ListenerMessage
case class WithListeners(f: List[ActorRef] => Unit) extends ListenerMessage
-/**
+/**
* Listeners is a generic trait to implement listening capability on an Actor.
*
* Use the gossip(msg) method to have it sent to the listeners.
@@ -34,6 +34,6 @@ trait Listeners { self: Actor =>
}
protected def gossip(msg: Any) = listenersAsList foreach (_ ! msg)
-
+
private def listenersAsList: List[ActorRef] = listeners.toArray.toList.asInstanceOf[List[ActorRef]]
}
diff --git a/akka-core/src/main/scala/stm/Transaction.scala b/akka-core/src/main/scala/stm/Transaction.scala
index a7870cec93..439093dec6 100644
--- a/akka-core/src/main/scala/stm/Transaction.scala
+++ b/akka-core/src/main/scala/stm/Transaction.scala
@@ -282,10 +282,10 @@ object Transaction {
setTransaction(Some(tx))
mtx.registerLifecycleListener(new TransactionLifecycleListener() {
def notify(mtx: MultiverseTransaction, event: TransactionLifecycleEvent) = event.name match {
- case "postCommit" =>
+ case "postCommit" =>
log.trace("Committing transaction [%s]", mtx)
tx.commit
- case "postAbort" =>
+ case "postAbort" =>
log.trace("Aborting transaction [%s]", mtx)
tx.abort
case _ => {}
diff --git a/akka-core/src/test/scala/ActorPatternsTest.scala b/akka-core/src/test/scala/ActorPatternsTest.scala
index 028ea80ea3..0d4e9b6b08 100644
--- a/akka-core/src/test/scala/ActorPatternsTest.scala
+++ b/akka-core/src/test/scala/ActorPatternsTest.scala
@@ -43,7 +43,7 @@ class ActorPatternsTest extends junit.framework.TestCase with Suite with MustMat
b <- (d.!)
c <- (d.!)
} yield a + b + c
-
+
result.get must be(21)
for(a <- List(t1,t2,d)) a.stop
}
diff --git a/akka-core/src/test/scala/StmSpec.scala b/akka-core/src/test/scala/StmSpec.scala
index 58b9b6805f..17d4be32bd 100644
--- a/akka-core/src/test/scala/StmSpec.scala
+++ b/akka-core/src/test/scala/StmSpec.scala
@@ -95,7 +95,7 @@ class StmSpec extends
val size2: Int = (actor !! Size).getOrElse(fail("Could not get Vector::size"))
size2 should equal(3)
} catch {
- case e =>
+ case e =>
e.printStackTrace
fail(e.toString)
}
@@ -122,7 +122,7 @@ class StmSpec extends
val size4: Int = (actor !! Size).getOrElse(fail("Could not get size"))
size4 should equal(3)
} catch {
- case e =>
+ case e =>
fail(e.toString)
}
}
@@ -130,7 +130,7 @@ class StmSpec extends
/*
describe("Multiverse API") {
it("should blablabla") {
-
+
import org.multiverse.api.programmatic._
// import org.multiverse.api._
import org.multiverse.templates._
@@ -139,13 +139,13 @@ class StmSpec extends
import org.multiverse.api.{GlobalStmInstance, ThreadLocalTransaction, Transaction => MultiverseTransaction}
import org.multiverse.api.lifecycle.{TransactionLifecycleListener, TransactionLifecycleEvent}
import org.multiverse.commitbarriers._
-
+
def createRef[T]: ProgrammaticReference[T] = GlobalStmInstance
.getGlobalStmInstance
.getProgrammaticReferenceFactoryBuilder
.build
.atomicCreateReference(null.asInstanceOf[T])
-
+
val ref1 = Ref(0)//createRef[Int]
val ref2 = Ref(0)//createRef[Int]
@@ -185,13 +185,13 @@ class GlobalTransactionVectorTestActor extends Actor {
import se.scalablesolutions.akka.stm.Transaction.Global
private val vector: TransactionalVector[Int] = Global.atomic { TransactionalVector(1) }
-
+
def receive = {
- case Add(value) =>
+ case Add(value) =>
Global.atomic { vector + value}
self.reply(Success)
- case Size =>
+ case Size =>
val size = Global.atomic { vector.size }
self.reply(size)
}
@@ -200,12 +200,12 @@ class GlobalTransactionVectorTestActor extends Actor {
class NestedTransactorLevelOneActor extends Actor {
import GlobalTransactionVectorTestActor._
private val nested = actorOf[NestedTransactorLevelTwoActor].start
-
+
def receive = {
- case add @ Add(_) =>
+ case add @ Add(_) =>
self.reply((nested !! add).get)
- case Size =>
+ case Size =>
self.reply((nested !! Size).get)
case "HiLevelOne" => println("HiLevelOne")
@@ -216,15 +216,15 @@ class NestedTransactorLevelOneActor extends Actor {
class NestedTransactorLevelTwoActor extends Actor {
import GlobalTransactionVectorTestActor._
private val ref = Ref(0)
-
+
def receive = {
- case Add(value) =>
+ case Add(value) =>
ref.swap(value)
self.reply(Success)
- case Size =>
+ case Size =>
self.reply(ref.getOrElse(-1))
-
+
case "HiLevelTwo" => println("HiLevelTwo")
}
}
diff --git a/akka-http/src/main/scala/AkkaLoader.scala b/akka-http/src/main/scala/AkkaLoader.scala
index 431758e2c7..886c2c0688 100644
--- a/akka-http/src/main/scala/AkkaLoader.scala
+++ b/akka-http/src/main/scala/AkkaLoader.scala
@@ -47,29 +47,29 @@ class AkkaLoader extends Logging {
private def printBanner = {
log.info(
"""
- t
- t t t
- t t tt t
- tt t t tt t
- t ttttttt t ttt t
- t tt ttt t ttt t
- t t ttt t ttt t t
- tt t ttt ttt ttt t
- t t ttt ttt t tt t
- t ttt ttt t t
- tt ttt ttt t
- ttt ttt
- tttttttt ttt ttt ttt ttt tttttttt
- ttt tt ttt ttt ttt ttt ttt ttt
- ttt ttt ttt ttt ttt ttt ttt ttt
- ttt ttt ttt ttt ttt tt ttt ttt
- tttt ttttttttt tttttttt tttt
- ttttttttt ttt ttt ttt ttt ttttttttt
- ttt ttt ttt ttt ttt ttt ttt ttt
- ttt ttt ttt ttt ttt ttt ttt ttt
- ttt tt ttt ttt ttt ttt ttt ttt
+ t
+ t t t
+ t t tt t
+ tt t t tt t
+ t ttttttt t ttt t
+ t tt ttt t ttt t
+ t t ttt t ttt t t
+ tt t ttt ttt ttt t
+ t t ttt ttt t tt t
+ t ttt ttt t t
+ tt ttt ttt t
+ ttt ttt
tttttttt ttt ttt ttt ttt tttttttt
-
+ ttt tt ttt ttt ttt ttt ttt ttt
+ ttt ttt ttt ttt ttt ttt ttt ttt
+ ttt ttt ttt ttt ttt tt ttt ttt
+ tttt ttttttttt tttttttt tttt
+ ttttttttt ttt ttt ttt ttt ttttttttt
+ ttt ttt ttt ttt ttt ttt ttt ttt
+ ttt ttt ttt ttt ttt ttt ttt ttt
+ ttt tt ttt ttt ttt ttt ttt ttt
+ tttttttt ttt ttt ttt ttt tttttttt
+
==================================================
""")
log.info(" Running version %s", Config.VERSION)
diff --git a/akka-kernel/src/main/scala/EmbeddedAppServer.scala b/akka-kernel/src/main/scala/EmbeddedAppServer.scala
index 5d3001edbd..8d9982c7e2 100644
--- a/akka-kernel/src/main/scala/EmbeddedAppServer.scala
+++ b/akka-kernel/src/main/scala/EmbeddedAppServer.scala
@@ -50,14 +50,14 @@ trait EmbeddedAppServer extends Bootable with Logging {
Thread.currentThread.setContextClassLoader(applicationLoader.get)
super.init(sc)
}
- finally {
+ finally {
Thread.currentThread.setContextClassLoader(cl)
}
}
})
adapter.setContextPath(uri.getPath)
- adapter.addInitParameter("cometSupport",
+ adapter.addInitParameter("cometSupport",
"org.atmosphere.container.GrizzlyCometSupport")
adapter.addInitParameter("com.sun.jersey.config.property.resourceConfigClass",
"com.sun.jersey.api.core.PackagesResourceConfig")
diff --git a/akka-persistence/akka-persistence-cassandra/src/main/scala/CassandraStorageBackend.scala b/akka-persistence/akka-persistence-cassandra/src/main/scala/CassandraStorageBackend.scala
index b67a0e9256..f393f4a162 100644
--- a/akka-persistence/akka-persistence-cassandra/src/main/scala/CassandraStorageBackend.scala
+++ b/akka-persistence/akka-persistence-cassandra/src/main/scala/CassandraStorageBackend.scala
@@ -42,7 +42,7 @@ private[akka] object CassandraStorageBackend extends
case "ALL" => ConsistencyLevel.ALL
case "ANY" => ConsistencyLevel.ANY
case unknown => throw new IllegalArgumentException(
- "Cassandra consistency level [" + unknown + "] is not supported." +
+ "Cassandra consistency level [" + unknown + "] is not supported." +
"\n\tExpected one of [ZERO, ONE, QUORUM, DCQUORUM, DCQUORUMSYNC, ALL, ANY] in the akka.conf configuration file.")
}
}
@@ -105,9 +105,9 @@ private[akka] object CassandraStorageBackend extends
}
}
- def insertVectorStorageEntriesFor(name: String, elements: List[Array[Byte]]) =
+ def insertVectorStorageEntriesFor(name: String, elements: List[Array[Byte]]) =
elements.foreach(insertVectorStorageEntryFor(name, _))
-
+
def updateVectorStorageEntryFor(name: String, index: Int, elem: Array[Byte]) = {
val columnPath = new ColumnPath(VECTOR_COLUMN_PARENT.getColumn_family)
columnPath.setColumn(intToBytes(index))
diff --git a/akka-persistence/akka-persistence-cassandra/src/test/scala/CassandraPersistentActorSpec.scala b/akka-persistence/akka-persistence-cassandra/src/test/scala/CassandraPersistentActorSpec.scala
index 6746fca529..648dec2be3 100644
--- a/akka-persistence/akka-persistence-cassandra/src/test/scala/CassandraPersistentActorSpec.scala
+++ b/akka-persistence/akka-persistence-cassandra/src/test/scala/CassandraPersistentActorSpec.scala
@@ -171,4 +171,4 @@ object EmbeddedCassandraService {
def start: Unit = {}
}
-*/
\ No newline at end of file
+*/
diff --git a/akka-persistence/akka-persistence-common/src/main/scala/Storage.scala b/akka-persistence/akka-persistence-common/src/main/scala/Storage.scala
index bcfb2c1025..6a0eb9a8d8 100644
--- a/akka-persistence/akka-persistence-common/src/main/scala/Storage.scala
+++ b/akka-persistence/akka-persistence-common/src/main/scala/Storage.scala
@@ -30,7 +30,7 @@ class StorageException(message: String) extends RuntimeException(message)
*