diff --git a/akka-actor/src/main/scala/actor/Actor.scala b/akka-actor/src/main/scala/actor/Actor.scala index 0fe1e9766b..bbb51aff34 100644 --- a/akka-actor/src/main/scala/actor/Actor.scala +++ b/akka-actor/src/main/scala/actor/Actor.scala @@ -394,7 +394,7 @@ trait Actor extends Logging { /** * Changes tha Actor's behavior to become the new 'Receive' (PartialFunction[Any, Unit]) handler. - * Puts the behavior on top of the hotswap stack. + * Puts the behavior on top of the hotswap stack. */ def become(behavior: Receive): Unit = self.hotswap = self.hotswap.push(behavior) diff --git a/akka-actor/src/main/scala/actor/ActorRef.scala b/akka-actor/src/main/scala/actor/ActorRef.scala index b65fca33c1..a71679df60 100644 --- a/akka-actor/src/main/scala/actor/ActorRef.scala +++ b/akka-actor/src/main/scala/actor/ActorRef.scala @@ -805,7 +805,7 @@ class LocalActorRef private[akka] ( receiveTimeout = None cancelReceiveTimeout dispatcher.detach(this) - transactorConfig = transactorConfig.copy(factory = None) + transactorConfig = transactorConfig.copy(factory = None) _status = ActorRefInternals.SHUTDOWN actor.postStop ActorRegistry.unregister(this) @@ -1067,7 +1067,7 @@ class LocalActorRef private[akka] ( case Temporary => shutDownTemporaryActor(this) case _ => val failedActor = actorInstance.get - + // either permanent or none where default is permanent Actor.log.info("Restarting actor [%s] configured as PERMANENT.", id) Actor.log.debug("Restarting linked actors for actor [%s].", id) diff --git a/akka-actor/src/main/scala/actor/ActorRegistry.scala b/akka-actor/src/main/scala/actor/ActorRegistry.scala index f213021efd..6751ee9350 100644 --- a/akka-actor/src/main/scala/actor/ActorRegistry.scala +++ b/akka-actor/src/main/scala/actor/ActorRegistry.scala @@ -41,12 +41,12 @@ object ActorRegistry extends ListenerManagement { private val actorsById = new Index[String,ActorRef] private val remoteActorSets = Map[Address, RemoteActorSet]() private val guard = new ReadWriteGuard - + /** * Returns all actors in the system. */ def actors: Array[ActorRef] = filter(_ => true) - + /** * Returns the number of actors in the system. */ @@ -435,4 +435,4 @@ class Index[K <: AnyRef,V <: AnyRef : Manifest] { * Removes all keys and all values */ def clear = foreach { case (k,v) => remove(k,v) } -} \ No newline at end of file +} diff --git a/akka-actor/src/main/scala/actor/Supervisor.scala b/akka-actor/src/main/scala/actor/Supervisor.scala index cd1c85b019..1f30f1a9c8 100644 --- a/akka-actor/src/main/scala/actor/Supervisor.scala +++ b/akka-actor/src/main/scala/actor/Supervisor.scala @@ -80,7 +80,7 @@ case class SupervisorFactory(val config: SupervisorConfig) extends Logging { def newInstance: Supervisor = newInstanceFor(config) - def newInstanceFor(config: SupervisorConfig): Supervisor = { + def newInstanceFor(config: SupervisorConfig): Supervisor = { val supervisor = new Supervisor(config.restartStrategy) supervisor.configure(config) supervisor.start diff --git a/akka-actor/src/main/scala/config/Config.scala b/akka-actor/src/main/scala/config/Config.scala index b88a222279..0571449b67 100644 --- a/akka-actor/src/main/scala/config/Config.scala +++ b/akka-actor/src/main/scala/config/Config.scala @@ -55,7 +55,7 @@ object Config { case value => Some(value) } - (envConf orElse systemConf).map("akka." + _ + ".conf").getOrElse("akka.conf") + (envConf orElse systemConf).map("akka." + _ + ".conf").getOrElse("akka.conf") } if (System.getProperty("akka.config", "") != "") { @@ -74,8 +74,8 @@ object Config { val configFile = HOME.getOrElse(throwNoAkkaHomeException) + "/config/" + confName Configgy.configure(configFile) ConfigLogger.log.info( - "AKKA_HOME is defined as [%s], config loaded from [%s].", - HOME.getOrElse(throwNoAkkaHomeException), + "AKKA_HOME is defined as [%s], config loaded from [%s].", + HOME.getOrElse(throwNoAkkaHomeException), configFile) } catch { case e: ParseException => throw new ConfigurationException( @@ -106,7 +106,7 @@ object Config { CConfig.fromString("") // default empty config } } - + val CONFIG_VERSION = config.getString("akka.version", VERSION) if (VERSION != CONFIG_VERSION) throw new ConfigurationException( "Akka JAR version [" + VERSION + "] is different than the provided config version [" + CONFIG_VERSION + "]") @@ -115,9 +115,9 @@ object Config { val startTime = System.currentTimeMillis def uptime = (System.currentTimeMillis - startTime) / 1000 - + def throwNoAkkaHomeException = throw new ConfigurationException( - "Akka home is not defined. Either:" + + "Akka home is not defined. Either:" + "\n\t1. Define 'AKKA_HOME' environment variable pointing to the root of the Akka distribution." + "\n\t2. Add the '-Dakka.home=...' option pointing to the root of the Akka distribution.") } diff --git a/akka-actor/src/main/scala/config/SupervisionConfig.scala b/akka-actor/src/main/scala/config/SupervisionConfig.scala index b4ae9ddf51..9f5af03ddf 100644 --- a/akka-actor/src/main/scala/config/SupervisionConfig.scala +++ b/akka-actor/src/main/scala/config/SupervisionConfig.scala @@ -35,7 +35,7 @@ object Supervision { def this(actorRef: ActorRef, lifeCycle: LifeCycle) = this(actorRef, lifeCycle, None) } - + object Supervise { def apply(actorRef: ActorRef, lifeCycle: LifeCycle, remoteAddress: RemoteAddress) = new Supervise(actorRef, lifeCycle, remoteAddress) def apply(actorRef: ActorRef, lifeCycle: LifeCycle) = new Supervise(actorRef, lifeCycle, None) @@ -158,4 +158,4 @@ object Supervision { def this(target: Class[_], lifeCycle: LifeCycle, timeout: Long, transactionRequired: Boolean, dispatcher: MessageDispatcher, remoteAddress: RemoteAddress) = this(null: Class[_], target, lifeCycle, timeout, transactionRequired, dispatcher, remoteAddress) } -} \ No newline at end of file +} diff --git a/akka-actor/src/main/scala/dataflow/DataFlowVariable.scala b/akka-actor/src/main/scala/dataflow/DataFlowVariable.scala index 3d0dadad11..5b72503c43 100644 --- a/akka-actor/src/main/scala/dataflow/DataFlowVariable.scala +++ b/akka-actor/src/main/scala/dataflow/DataFlowVariable.scala @@ -143,7 +143,7 @@ object DataFlow { out ! Exit throw e } - + result.getOrElse(throw new DataFlowVariableException("Timed out (after " + timeoutMs + " milliseconds) while waiting for result")) } } diff --git a/akka-actor/src/main/scala/dispatch/Dispatchers.scala b/akka-actor/src/main/scala/dispatch/Dispatchers.scala index 925f856d3f..cb7f8fab94 100644 --- a/akka-actor/src/main/scala/dispatch/Dispatchers.scala +++ b/akka-actor/src/main/scala/dispatch/Dispatchers.scala @@ -94,7 +94,7 @@ object Dispatchers extends Logging { *

* E.g. each actor consumes its own thread. */ - def newThreadBasedDispatcher(actor: ActorRef, mailboxCapacity: Int, pushTimeOut: Duration) = + def newThreadBasedDispatcher(actor: ActorRef, mailboxCapacity: Int, pushTimeOut: Duration) = new ThreadBasedDispatcher(actor, mailboxCapacity, pushTimeOut) /** diff --git a/akka-actor/src/main/scala/dispatch/ExecutorBasedEventDrivenDispatcher.scala b/akka-actor/src/main/scala/dispatch/ExecutorBasedEventDrivenDispatcher.scala index 9ea0acb94c..83ff50427a 100644 --- a/akka-actor/src/main/scala/dispatch/ExecutorBasedEventDrivenDispatcher.scala +++ b/akka-actor/src/main/scala/dispatch/ExecutorBasedEventDrivenDispatcher.scala @@ -73,19 +73,19 @@ class ExecutorBasedEventDrivenDispatcher( val config: ThreadPoolConfig = ThreadPoolConfig()) extends MessageDispatcher { - def this(_name: String, throughput: Int, throughputDeadlineTime: Int, mailboxType: MailboxType) = + def this(_name: String, throughput: Int, throughputDeadlineTime: Int, mailboxType: MailboxType) = this(_name, throughput, throughputDeadlineTime, mailboxType,ThreadPoolConfig()) // Needed for Java API usage - def this(_name: String, throughput: Int, mailboxType: MailboxType) = + def this(_name: String, throughput: Int, mailboxType: MailboxType) = this(_name, throughput, Dispatchers.THROUGHPUT_DEADLINE_TIME_MILLIS, mailboxType) // Needed for Java API usage - def this(_name: String, throughput: Int) = + def this(_name: String, throughput: Int) = this(_name, throughput, Dispatchers.THROUGHPUT_DEADLINE_TIME_MILLIS, Dispatchers.MAILBOX_TYPE) // Needed for Java API usage def this(_name: String, _config: ThreadPoolConfig) = this(_name, Dispatchers.THROUGHPUT, Dispatchers.THROUGHPUT_DEADLINE_TIME_MILLIS, Dispatchers.MAILBOX_TYPE, _config) - def this(_name: String) = + def this(_name: String) = this(_name, Dispatchers.THROUGHPUT, Dispatchers.THROUGHPUT_DEADLINE_TIME_MILLIS, Dispatchers.MAILBOX_TYPE) // Needed for Java API usage val name = "akka:event-driven:dispatcher:" + _name @@ -111,7 +111,7 @@ class ExecutorBasedEventDrivenDispatcher( case UnboundedMailbox(blocking) => new DefaultUnboundedMessageQueue(blocking) with ExecutableMailbox { def dispatcher = ExecutorBasedEventDrivenDispatcher.this } - + case BoundedMailbox(blocking, capacity, pushTimeOut) => new DefaultBoundedMessageQueue(capacity, pushTimeOut, blocking) with ExecutableMailbox { def dispatcher = ExecutorBasedEventDrivenDispatcher.this @@ -175,7 +175,7 @@ class ExecutorBasedEventDrivenDispatcher( trait ExecutableMailbox extends Runnable { self: MessageQueue => def dispatcher: ExecutorBasedEventDrivenDispatcher - + final def run = { val reschedule = try { try { processMailbox() } catch { case ie: InterruptedException => true } diff --git a/akka-actor/src/main/scala/dispatch/ExecutorBasedEventDrivenWorkStealingDispatcher.scala b/akka-actor/src/main/scala/dispatch/ExecutorBasedEventDrivenWorkStealingDispatcher.scala index 306d59b865..69aa5d9365 100644 --- a/akka-actor/src/main/scala/dispatch/ExecutorBasedEventDrivenWorkStealingDispatcher.scala +++ b/akka-actor/src/main/scala/dispatch/ExecutorBasedEventDrivenWorkStealingDispatcher.scala @@ -41,7 +41,7 @@ class ExecutorBasedEventDrivenWorkStealingDispatcher( def this(_name: String) = this(_name, Dispatchers.MAILBOX_TYPE,ThreadPoolConfig()) //implicit def actorRef2actor(actorRef: ActorRef): Actor = actorRef.actor - + val mailboxType = Some(_mailboxType) val name = "akka:event-driven-work-stealing:dispatcher:" + _name diff --git a/akka-actor/src/main/scala/dispatch/HawtDispatcher.scala b/akka-actor/src/main/scala/dispatch/HawtDispatcher.scala index 211dca50be..1031ae4c9a 100644 --- a/akka-actor/src/main/scala/dispatch/HawtDispatcher.scala +++ b/akka-actor/src/main/scala/dispatch/HawtDispatcher.scala @@ -143,7 +143,7 @@ class HawtDispatcher(val aggregate: Boolean = true, val parent: DispatchQueue = import HawtDispatcher._ val mailboxType: Option[MailboxType] = None - + private[akka] def start { retainNonDaemon } private[akka] def shutdown { releaseNonDaemon } diff --git a/akka-actor/src/main/scala/dispatch/MailboxHandling.scala b/akka-actor/src/main/scala/dispatch/MailboxHandling.scala index 102bc19615..ff71b607ce 100644 --- a/akka-actor/src/main/scala/dispatch/MailboxHandling.scala +++ b/akka-actor/src/main/scala/dispatch/MailboxHandling.scala @@ -35,7 +35,7 @@ sealed trait MailboxType abstract class TransientMailboxType(val blocking: Boolean = false) extends MailboxType case class UnboundedMailbox(block: Boolean = false) extends TransientMailboxType(block) case class BoundedMailbox( - block: Boolean = false, + block: Boolean = false, val capacity: Int = { if (Dispatchers.MAILBOX_CAPACITY < 0) Int.MaxValue else Dispatchers.MAILBOX_CAPACITY }, val pushTimeOut: Duration = Dispatchers.MAILBOX_PUSH_TIME_OUT) extends TransientMailboxType(block) { if (capacity < 0) throw new IllegalArgumentException("The capacity for BoundedMailbox can not be negative") @@ -52,9 +52,9 @@ case class ZooKeeperBasedDurableMailbox(ser: EnterpriseModule.Serializer) extend case class AMQPBasedDurableMailbox(ser: EnterpriseModule.Serializer) extends DurableMailboxType(ser) case class JMSBasedDurableMailbox(ser: EnterpriseModule.Serializer) extends DurableMailboxType(ser) -class DefaultUnboundedMessageQueue(blockDequeue: Boolean) +class DefaultUnboundedMessageQueue(blockDequeue: Boolean) extends LinkedBlockingQueue[MessageInvocation] with MessageQueue { - + final def enqueue(handle: MessageInvocation) { this add handle } @@ -65,7 +65,7 @@ class DefaultUnboundedMessageQueue(blockDequeue: Boolean) } } -class DefaultBoundedMessageQueue(capacity: Int, pushTimeOut: Duration, blockDequeue: Boolean) +class DefaultBoundedMessageQueue(capacity: Int, pushTimeOut: Duration, blockDequeue: Boolean) extends LinkedBlockingQueue[MessageInvocation](capacity) with MessageQueue { final def enqueue(handle: MessageInvocation) { @@ -84,7 +84,7 @@ class DefaultBoundedMessageQueue(capacity: Int, pushTimeOut: Duration, blockDequ * @author Jonas Bonér */ trait MailboxFactory { - + val mailboxType: Option[MailboxType] /** @@ -105,4 +105,4 @@ trait MailboxFactory { * Creates and returns a durable mailbox for the given actor. */ private[akka] def createDurableMailbox(actorRef: ActorRef, mailboxType: DurableMailboxType): AnyRef -} \ No newline at end of file +} diff --git a/akka-actor/src/main/scala/dispatch/MessageHandling.scala b/akka-actor/src/main/scala/dispatch/MessageHandling.scala index 9978971377..f7eb0ca170 100644 --- a/akka-actor/src/main/scala/dispatch/MessageHandling.scala +++ b/akka-actor/src/main/scala/dispatch/MessageHandling.scala @@ -95,7 +95,7 @@ trait MessageDispatcher extends MailboxFactory with Logging { } } } - + private[akka] def unregister(actorRef: ActorRef) = { if (uuids remove actorRef.uuid) { actorRef.mailbox = null @@ -176,4 +176,4 @@ trait MessageDispatcher extends MailboxFactory with Logging { * Returns the size of the mailbox for the specified actor */ def mailboxSize(actorRef: ActorRef): Int -} \ No newline at end of file +} diff --git a/akka-actor/src/main/scala/dispatch/ThreadPoolBuilder.scala b/akka-actor/src/main/scala/dispatch/ThreadPoolBuilder.scala index 2f89cab81e..f6e92892d0 100644 --- a/akka-actor/src/main/scala/dispatch/ThreadPoolBuilder.scala +++ b/akka-actor/src/main/scala/dispatch/ThreadPoolBuilder.scala @@ -261,4 +261,4 @@ trait LazyExecutorService extends ExecutorServiceDelegate { class LazyExecutorServiceWrapper(executorFactory: => ExecutorService) extends LazyExecutorService { def createExecutor = executorFactory -} \ No newline at end of file +} diff --git a/akka-actor/src/main/scala/japi/JavaAPI.scala b/akka-actor/src/main/scala/japi/JavaAPI.scala index 9f79fb7fc3..f3dd89d91b 100644 --- a/akka-actor/src/main/scala/japi/JavaAPI.scala +++ b/akka-actor/src/main/scala/japi/JavaAPI.scala @@ -75,4 +75,4 @@ object Option { implicit def java2ScalaOption[A](o: Option[A]): scala.Option[A] = o.asScala implicit def scala2JavaOption[A](o: scala.Option[A]): Option[A] = option(o.get) -} \ No newline at end of file +} diff --git a/akka-actor/src/main/scala/routing/Iterators.scala b/akka-actor/src/main/scala/routing/Iterators.scala index 9b0d6b9742..c7a6f245c4 100644 --- a/akka-actor/src/main/scala/routing/Iterators.scala +++ b/akka-actor/src/main/scala/routing/Iterators.scala @@ -17,7 +17,7 @@ trait InfiniteIterator[T] extends Iterator[T] */ class CyclicIterator[T](items: List[T]) extends InfiniteIterator[T] { def this(items: java.util.List[T]) = this(items.toList) - + @volatile private[this] var current: List[T] = items def hasNext = items != Nil diff --git a/akka-actor/src/main/scala/routing/Routers.scala b/akka-actor/src/main/scala/routing/Routers.scala index 428141251b..e770159b2b 100644 --- a/akka-actor/src/main/scala/routing/Routers.scala +++ b/akka-actor/src/main/scala/routing/Routers.scala @@ -70,4 +70,4 @@ abstract class UntypedLoadBalancer extends UntypedDispatcher { else null override def isDefinedAt(msg: Any) = seq.exists( _.isDefinedAt(msg) ) -} \ No newline at end of file +} diff --git a/akka-actor/src/main/scala/stm/Transaction.scala b/akka-actor/src/main/scala/stm/Transaction.scala index c5531ea614..59a9d921e7 100644 --- a/akka-actor/src/main/scala/stm/Transaction.scala +++ b/akka-actor/src/main/scala/stm/Transaction.scala @@ -92,7 +92,7 @@ object Transaction { private[this] val persistentStateMap = new HashMap[String, Committable with Abortable] private[akka] val depth = new AtomicInteger(0) - val jta: Option[JtaModule.TransactionContainer] = + val jta: Option[JtaModule.TransactionContainer] = if (JTA_AWARE) Some(JtaModule.createTransactionContainer) else None diff --git a/akka-actor/src/main/scala/util/Address.scala b/akka-actor/src/main/scala/util/Address.scala index ee83896312..8ee1693553 100644 --- a/akka-actor/src/main/scala/util/Address.scala +++ b/akka-actor/src/main/scala/util/Address.scala @@ -20,4 +20,4 @@ class Address(val hostname: String, val port: Int) { that.asInstanceOf[Address].hostname == hostname && that.asInstanceOf[Address].port == port } -} \ No newline at end of file +} diff --git a/akka-actor/src/main/scala/util/Crypt.scala b/akka-actor/src/main/scala/util/Crypt.scala index 65f62f3f27..bccb291be5 100644 --- a/akka-actor/src/main/scala/util/Crypt.scala +++ b/akka-actor/src/main/scala/util/Crypt.scala @@ -18,8 +18,8 @@ object Crypt extends Logging { def md5(text: String): String = md5(unifyLineSeparator(text).getBytes("ASCII")) def md5(bytes: Array[Byte]): String = digest(bytes, MessageDigest.getInstance("MD5")) - - def sha1(text: String): String = sha1(unifyLineSeparator(text).getBytes("ASCII")) + + def sha1(text: String): String = sha1(unifyLineSeparator(text).getBytes("ASCII")) def sha1(bytes: Array[Byte]): String = digest(bytes, MessageDigest.getInstance("SHA1")) @@ -33,8 +33,8 @@ object Crypt extends Logging { def digest(bytes: Array[Byte], md: MessageDigest): String = { md.update(bytes) hexify(md.digest) - } - + } + def hexify(bytes: Array[Byte]): String = { val builder = new StringBuilder bytes.foreach { byte => builder.append(hex.charAt((byte & 0xF) >> 4)).append(hex.charAt(byte & 0xF)) } diff --git a/akka-actor/src/main/scala/util/Helpers.scala b/akka-actor/src/main/scala/util/Helpers.scala index e903f50556..25180a68d7 100644 --- a/akka-actor/src/main/scala/util/Helpers.scala +++ b/akka-actor/src/main/scala/util/Helpers.scala @@ -45,7 +45,7 @@ object Helpers extends Logging { log.warning(e, "Cannot narrow %s to expected type %s!", o, implicitly[Manifest[T]].erasure.getName) None } - + /** * Reference that can hold either a typed value or an exception. * @@ -61,13 +61,13 @@ object Helpers extends Logging { * * scala> res0() * res3: Int = 3 - * + * * scala> res0() = { println("Hello world"); 3} * Hello world * * scala> res0() * res5: Int = 3 - * + * * scala> res0() = error("Lets see what happens here...") * * scala> res0() @@ -80,15 +80,15 @@ object Helpers extends Logging { */ class ResultOrError[R](result: R){ private[this] var contents: Either[R, Throwable] = Left(result) - + def update(value: => R) = { - contents = try { - Left(value) - } catch { - case (error : Throwable) => Right(error) - } + contents = try { + Left(value) + } catch { + case (error : Throwable) => Right(error) + } } - + def apply() = contents match { case Left(result) => result case Right(error) => throw error.fillInStackTrace diff --git a/akka-actor/src/main/scala/util/LockUtil.scala b/akka-actor/src/main/scala/util/LockUtil.scala index 1a90377ff1..977383e9ff 100644 --- a/akka-actor/src/main/scala/util/LockUtil.scala +++ b/akka-actor/src/main/scala/util/LockUtil.scala @@ -86,7 +86,7 @@ class SimpleLock { } } else None } - + def ifPossibleApply[T,R](value: T)(function: (T) => R): Option[R] = { if (tryLock()) { try { diff --git a/akka-actor/src/main/scala/util/ReflectiveAccess.scala b/akka-actor/src/main/scala/util/ReflectiveAccess.scala index 9de57e5c4a..9f9c644dd3 100644 --- a/akka-actor/src/main/scala/util/ReflectiveAccess.scala +++ b/akka-actor/src/main/scala/util/ReflectiveAccess.scala @@ -208,10 +208,10 @@ object ReflectiveAccess extends Logging { def enqueue(message: MessageInvocation) def dequeue: MessageInvocation } - + type Serializer = { def toBinary(obj: AnyRef): Array[Byte] - def fromBinary(bytes: Array[Byte], clazz: Option[Class[_]]): AnyRef + def fromBinary(bytes: Array[Byte], clazz: Option[Class[_]]): AnyRef } lazy val isEnterpriseEnabled = clusterObjectInstance.isDefined @@ -219,7 +219,7 @@ object ReflectiveAccess extends Logging { val clusterObjectInstance: Option[AnyRef] = getObjectFor("akka.cluster.Cluster$") - val serializerClass: Option[Class[_]] = + val serializerClass: Option[Class[_]] = getClassFor("akka.serialization.Serializer") def ensureEnterpriseEnabled = if (!isEnterpriseEnabled) throw new ModuleNotAvailableException( diff --git a/akka-actor/src/test/scala/actor/actor/ActorFireForgetRequestReplySpec.scala b/akka-actor/src/test/scala/actor/actor/ActorFireForgetRequestReplySpec.scala index 2ad5c82fa5..0f9debe5b0 100644 --- a/akka-actor/src/test/scala/actor/actor/ActorFireForgetRequestReplySpec.scala +++ b/akka-actor/src/test/scala/actor/actor/ActorFireForgetRequestReplySpec.scala @@ -32,7 +32,7 @@ object ActorFireForgetRequestReplySpec { class SenderActor(replyActor: ActorRef) extends Actor { def receive = { - case "Init" => + case "Init" => replyActor ! "Send" case "Reply" => { state.s = "Reply" diff --git a/akka-actor/src/test/scala/actor/actor/ActorRefSpec.scala b/akka-actor/src/test/scala/actor/actor/ActorRefSpec.scala index dd620f6d7c..35922670f3 100644 --- a/akka-actor/src/test/scala/actor/actor/ActorRefSpec.scala +++ b/akka-actor/src/test/scala/actor/actor/ActorRefSpec.scala @@ -98,4 +98,4 @@ class ActorRefSpec extends serverRef.stop } } -} \ No newline at end of file +} diff --git a/akka-actor/src/test/scala/actor/actor/FSMActorSpec.scala b/akka-actor/src/test/scala/actor/actor/FSMActorSpec.scala index 78519122af..146c57759c 100644 --- a/akka-actor/src/test/scala/actor/actor/FSMActorSpec.scala +++ b/akka-actor/src/test/scala/actor/actor/FSMActorSpec.scala @@ -57,7 +57,7 @@ object FSMActorSpec { } startWith(Locked, CodeState("", code)) - + whenUnhandled { case Event(_, stateData) => { log.info("Unhandled") diff --git a/akka-actor/src/test/scala/actor/actor/HotSwapSpec.scala b/akka-actor/src/test/scala/actor/actor/HotSwapSpec.scala index 527bd544fb..5fc9e119a0 100644 --- a/akka-actor/src/test/scala/actor/actor/HotSwapSpec.scala +++ b/akka-actor/src/test/scala/actor/actor/HotSwapSpec.scala @@ -9,7 +9,7 @@ import java.util.concurrent.CyclicBarrier class HotSwapSpec extends WordSpec with MustMatchers { "An Actor" should { - + "be able to hotswap its behavior with HotSwap(..)" in { val barrier = new CyclicBarrier(2) @volatile var _log = "" @@ -17,7 +17,7 @@ class HotSwapSpec extends WordSpec with MustMatchers { def receive = { case _ => _log += "default" } }).start a ! HotSwap { - case _ => + case _ => _log += "swapped" barrier.await } @@ -31,17 +31,17 @@ class HotSwapSpec extends WordSpec with MustMatchers { @volatile var _log = "" val a = actorOf(new Actor { def receive = { - case "init" => + case "init" => _log += "init" barrier.await case "swap" => become({ - case _ => + case _ => _log += "swapped" barrier.await }) } }).start - + a ! "init" barrier.await _log must be ("init") @@ -72,7 +72,7 @@ class HotSwapSpec extends WordSpec with MustMatchers { barrier.reset _log = "" a ! HotSwap { - case "swapped" => + case "swapped" => _log += "swapped" barrier.await } @@ -104,21 +104,21 @@ class HotSwapSpec extends WordSpec with MustMatchers { @volatile var _log = "" val a = actorOf(new Actor { def receive = { - case "init" => + case "init" => _log += "init" barrier.await - case "swap" => + case "swap" => become({ - case "swapped" => + case "swapped" => _log += "swapped" barrier.await - case "revert" => + case "revert" => unbecome }) barrier.await } }).start - + a ! "init" barrier.await _log must be ("init") diff --git a/akka-actor/src/test/scala/actor/supervisor/RestartStrategySpec.scala b/akka-actor/src/test/scala/actor/supervisor/RestartStrategySpec.scala index 81937d7760..59bf800909 100644 --- a/akka-actor/src/test/scala/actor/supervisor/RestartStrategySpec.scala +++ b/akka-actor/src/test/scala/actor/supervisor/RestartStrategySpec.scala @@ -147,7 +147,7 @@ class RestartStrategySpec extends JUnitSuite { slave ! Ping slave ! Crash - + assert(secondRestartLatch.tryAwait(1, TimeUnit.SECONDS)) assert(secondPingLatch.tryAwait(1, TimeUnit.SECONDS)) @@ -224,7 +224,7 @@ class RestartStrategySpec extends JUnitSuite { val restartLatch,stopLatch,maxNoOfRestartsLatch = new StandardLatch val countDownLatch = new CountDownLatch(2) - + val boss = actorOf(new Actor{ self.faultHandler = OneForOneStrategy(List(classOf[Throwable]), None, Some(1000)) protected def receive = { @@ -238,7 +238,7 @@ class RestartStrategySpec extends JUnitSuite { case Ping => countDownLatch.countDown case Crash => throw new Exception("Crashing...") } - + override def postRestart(reason: Throwable) = { restartLatch.open } diff --git a/akka-actor/src/test/scala/dataflow/DataFlowSpec.scala b/akka-actor/src/test/scala/dataflow/DataFlowSpec.scala index a42ac353f2..f787060fc8 100644 --- a/akka-actor/src/test/scala/dataflow/DataFlowSpec.scala +++ b/akka-actor/src/test/scala/dataflow/DataFlowSpec.scala @@ -69,7 +69,7 @@ class DataFlowTest extends Spec with ShouldMatchers with BeforeAndAfterAll { result.get should equal (sum(0,ints(0,1000))) List(x,y,z).foreach(_.shutdown) } - + /*it("should be able to join streams") { import DataFlow._ ActorRegistry.shutdownAll @@ -95,7 +95,7 @@ class DataFlowTest extends Spec with ShouldMatchers with BeforeAndAfterAll { result.set(producer.map(x => x * x).foldLeft(0)(_ + _)) latch.countDown } - + latch.await(3,TimeUnit.SECONDS) should equal (true) result.get should equal (332833500) } @@ -131,7 +131,7 @@ class DataFlowTest extends Spec with ShouldMatchers with BeforeAndAfterAll { thread { ints(0, 1000, producer) } thread { sum(0, producer, consumer) } thread { recurseSum(consumer) } - + latch.await(15,TimeUnit.SECONDS) should equal (true) }*/ @@ -162,4 +162,4 @@ class DataFlowTest extends Spec with ShouldMatchers with BeforeAndAfterAll { latch.await(2,TimeUnit.SECONDS) should equal (true) }*/ } -} \ No newline at end of file +} diff --git a/akka-actor/src/test/scala/dispatch/ActorModelSpec.scala b/akka-actor/src/test/scala/dispatch/ActorModelSpec.scala index cdbc6e2ab4..bd0f359398 100644 --- a/akka-actor/src/test/scala/dispatch/ActorModelSpec.scala +++ b/akka-actor/src/test/scala/dispatch/ActorModelSpec.scala @@ -296,4 +296,4 @@ class HawtDispatcherModelTest extends ActorModelSpec { class ExecutorBasedEventDrivenWorkStealingDispatcherModelTest extends ActorModelSpec { def newInterceptedDispatcher = new ExecutorBasedEventDrivenWorkStealingDispatcher("foo") with MessageDispatcherInterceptor -} \ No newline at end of file +} diff --git a/akka-actor/src/test/scala/japi/JavaAPITest.scala b/akka-actor/src/test/scala/japi/JavaAPITest.scala index ebaa317115..30aa4f4499 100644 --- a/akka-actor/src/test/scala/japi/JavaAPITest.scala +++ b/akka-actor/src/test/scala/japi/JavaAPITest.scala @@ -2,4 +2,4 @@ package akka.japi import org.scalatest.junit.JUnitSuite -class JavaAPITest extends JavaAPITestBase with JUnitSuite \ No newline at end of file +class JavaAPITest extends JavaAPITestBase with JUnitSuite diff --git a/akka-amqp/src/main/java/akka/amqp/ExampleSessionJava.java b/akka-amqp/src/main/java/akka/amqp/ExampleSessionJava.java index 05ed2c3437..5764877c3c 100644 --- a/akka-amqp/src/main/java/akka/amqp/ExampleSessionJava.java +++ b/akka-amqp/src/main/java/akka/amqp/ExampleSessionJava.java @@ -214,7 +214,7 @@ public class ExampleSessionJava { scala.Option response = protobufRpcClient.call(RemoteProtocol.AddressProtocol.newBuilder().setHostname("localhost").setPort(4321).build()); - + System.out.println("### >> Got response: " + response); } } diff --git a/akka-amqp/src/main/scala/akka/amqp/AMQP.scala b/akka-amqp/src/main/scala/akka/amqp/AMQP.scala index 04c8753049..392ccc8d33 100644 --- a/akka-amqp/src/main/scala/akka/amqp/AMQP.scala +++ b/akka-amqp/src/main/scala/akka/amqp/AMQP.scala @@ -256,7 +256,7 @@ object AMQP { } // Needed for Java API usage def send(request: O, replyTo: String): Unit = { - send(request, Some(replyTo)) + send(request, Some(replyTo)) } def send(request: O, replyTo: Option[String] = None) = { @@ -311,7 +311,7 @@ object AMQP { def newStringConsumer(connection: ActorRef, handler: Procedure[String], exchangeName: String): ActorRef = { - newStringConsumer(connection, handler.apply _, Some(exchangeName)) + newStringConsumer(connection, handler.apply _, Some(exchangeName)) } // Needed for Java API usage @@ -328,7 +328,7 @@ object AMQP { exchangeName: String, routingKey: String, queueName: String): ActorRef = { - newStringConsumer(connection, handler.apply _, Some(exchangeName), Some(routingKey), Some(queueName)) + newStringConsumer(connection, handler.apply _, Some(exchangeName), Some(routingKey), Some(queueName)) } def newStringConsumer(connection: ActorRef, diff --git a/akka-amqp/src/main/scala/akka/amqp/rpc/RPC.scala b/akka-amqp/src/main/scala/akka/amqp/rpc/RPC.scala index d4e40c0e3d..4213c77f01 100644 --- a/akka-amqp/src/main/scala/akka/amqp/rpc/RPC.scala +++ b/akka-amqp/src/main/scala/akka/amqp/rpc/RPC.scala @@ -283,7 +283,7 @@ object RPC { def newStringRpcClient(connection: ActorRef, exchange: String): RpcClient[String, String] = { newStringRpcClient(connection, exchange, None) - } + } // Needed for Java API usage def newStringRpcClient(connection: ActorRef, diff --git a/akka-camel/src/main/scala/CamelContextLifecycle.scala b/akka-camel/src/main/scala/CamelContextLifecycle.scala index 69f513edfc..93375131d2 100644 --- a/akka-camel/src/main/scala/CamelContextLifecycle.scala +++ b/akka-camel/src/main/scala/CamelContextLifecycle.scala @@ -143,7 +143,7 @@ trait CamelContextLifecycle extends Logging { * Initializes this lifecycle object with the given CamelContext. For the passed * CamelContext, stream-caching is enabled. If applications want to disable stream- * caching they can do so after this method returned and prior to calling start. - * This method also registers a new TypedActorComponent at the passes CamelContext + * This method also registers a new TypedActorComponent at the passes CamelContext * under a name defined by TypedActorComponent.InternalSchema. */ def init(context: CamelContext) { diff --git a/akka-camel/src/main/scala/Consumer.scala b/akka-camel/src/main/scala/Consumer.scala index 8b5d7971dc..336b83e527 100644 --- a/akka-camel/src/main/scala/Consumer.scala +++ b/akka-camel/src/main/scala/Consumer.scala @@ -22,7 +22,7 @@ trait Consumer { self: Actor => /** * Determines whether two-way communications between an endpoint and this consumer actor * should be done in blocking or non-blocking mode (default is non-blocking). This method - * doesn't have any effect on one-way communications (they'll never block). + * doesn't have any effect on one-way communications (they'll never block). */ def blocking = false } diff --git a/akka-camel/src/main/scala/component/ActorComponent.scala b/akka-camel/src/main/scala/component/ActorComponent.scala index 81b5c49cff..c1f5cd56a1 100644 --- a/akka-camel/src/main/scala/component/ActorComponent.scala +++ b/akka-camel/src/main/scala/component/ActorComponent.scala @@ -112,7 +112,7 @@ class ActorEndpoint(uri: String, *

  • If the exchange pattern is out-capable and blocking is set to * false then the producer sends the message using the ! operator, together * with a callback handler. The callback handler is an ActorRef that can be - * used by the receiving actor to asynchronously reply to the route that is sending the + * used by the receiving actor to asynchronously reply to the route that is sending the * message.
  • *
  • If the exchange pattern is in-only then the producer sends the message using the * ! operator.
  • diff --git a/akka-http/src/main/scala/AkkaBroadcaster.scala b/akka-http/src/main/scala/AkkaBroadcaster.scala index 963058f052..fd0f76631a 100644 --- a/akka-http/src/main/scala/AkkaBroadcaster.scala +++ b/akka-http/src/main/scala/AkkaBroadcaster.scala @@ -37,4 +37,4 @@ class AkkaBroadcaster extends org.atmosphere.jersey.util.JerseySimpleBroadcaster protected override def broadcast(r: Resource, e : Event) { caster ! ((r,e)) } -} \ No newline at end of file +} diff --git a/akka-http/src/main/scala/DefaultAkkaLoader.scala b/akka-http/src/main/scala/DefaultAkkaLoader.scala index f7ab1f074b..b0bc3ad020 100644 --- a/akka-http/src/main/scala/DefaultAkkaLoader.scala +++ b/akka-http/src/main/scala/DefaultAkkaLoader.scala @@ -26,4 +26,4 @@ class DefaultAkkaLoader extends AkkaLoader { */ object Main extends DefaultAkkaLoader { def main(args: Array[String]) = boot -} \ No newline at end of file +} diff --git a/akka-http/src/main/scala/EmbeddedAppServer.scala b/akka-http/src/main/scala/EmbeddedAppServer.scala index db2b418ccb..ea68bf1106 100644 --- a/akka-http/src/main/scala/EmbeddedAppServer.scala +++ b/akka-http/src/main/scala/EmbeddedAppServer.scala @@ -33,14 +33,14 @@ trait EmbeddedAppServer extends Bootable with Logging { super.onLoad if (config.getBool("akka.rest.service", true)) { log.info("Attempting to start Akka REST service (Jersey)") - + System.setProperty("jetty.port",REST_PORT.toString) System.setProperty("jetty.host",REST_HOSTNAME) System.setProperty("jetty.home",HOME.getOrElse(throwNoAkkaHomeException) + "/deploy/root") val configuration = new XmlConfiguration( new File(HOME.getOrElse(throwNoAkkaHomeException) + "/config/microkernel-server.xml").toURI.toURL) - + server = Option(configuration.configure.asInstanceOf[Server]) map { s => //Set the correct classloader to our contexts applicationLoader foreach { loader => //We need to provide the correct classloader to the servlets diff --git a/akka-jta/src/test/scala/ReflectiveAccessSpec.scala b/akka-jta/src/test/scala/ReflectiveAccessSpec.scala index 4666098f80..1b13ef67b5 100644 --- a/akka-jta/src/test/scala/ReflectiveAccessSpec.scala +++ b/akka-jta/src/test/scala/ReflectiveAccessSpec.scala @@ -13,4 +13,4 @@ class ReflectiveAccessSpec extends JUnitSuite { ReflectiveAccess.JtaModule.ensureJtaEnabled assert(ReflectiveAccess.JtaModule.transactionContainerObjectInstance.isDefined) } -} \ No newline at end of file +} diff --git a/akka-kernel/src/main/scala/Kernel.scala b/akka-kernel/src/main/scala/Kernel.scala index 76d63728e6..342078913b 100644 --- a/akka-kernel/src/main/scala/Kernel.scala +++ b/akka-kernel/src/main/scala/Kernel.scala @@ -22,4 +22,4 @@ object Kernel extends DefaultAkkaLoader { case x: BootableRemoteActorService => x.startRemoteService case _ => }) -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-cassandra/src/test/scala/CassandraTicket343TestIntegration.scala b/akka-persistence/akka-persistence-cassandra/src/test/scala/CassandraTicket343TestIntegration.scala index d295e0a605..7a062f9c31 100644 --- a/akka-persistence/akka-persistence-cassandra/src/test/scala/CassandraTicket343TestIntegration.scala +++ b/akka-persistence/akka-persistence-cassandra/src/test/scala/CassandraTicket343TestIntegration.scala @@ -20,4 +20,4 @@ class CassandraTicket343TestIntegration extends Ticket343Test { def getMap: (String) => PersistentMap[Array[Byte], Array[Byte]] = CassandraStorage.getMap -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-common/src/main/scala/CommonStorageBackend.scala b/akka-persistence/akka-persistence-common/src/main/scala/CommonStorageBackend.scala index e7f16593a0..17502903f0 100644 --- a/akka-persistence/akka-persistence-common/src/main/scala/CommonStorageBackend.scala +++ b/akka-persistence/akka-persistence-common/src/main/scala/CommonStorageBackend.scala @@ -627,4 +627,4 @@ private[akka] trait CommonStorageBackend extends MapStorageBackend[Array[Byte], } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-common/src/test/scala/MapStorageBackendTest.scala b/akka-persistence/akka-persistence-common/src/test/scala/MapStorageBackendTest.scala index 602ee5f34b..51f3de40d0 100644 --- a/akka-persistence/akka-persistence-common/src/test/scala/MapStorageBackendTest.scala +++ b/akka-persistence/akka-persistence-common/src/test/scala/MapStorageBackendTest.scala @@ -158,4 +158,4 @@ trait MapStorageBackendTest extends Spec with ShouldMatchers with BeforeAndAfter } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-common/src/test/scala/QueueStorageBackendTest.scala b/akka-persistence/akka-persistence-common/src/test/scala/QueueStorageBackendTest.scala index 3f655ef434..767f29bc7e 100644 --- a/akka-persistence/akka-persistence-common/src/test/scala/QueueStorageBackendTest.scala +++ b/akka-persistence/akka-persistence-common/src/test/scala/QueueStorageBackendTest.scala @@ -120,4 +120,4 @@ trait QueueStorageBackendTest extends Spec with ShouldMatchers with BeforeAndAft } } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-common/src/test/scala/RefStorageBackendTest.scala b/akka-persistence/akka-persistence-common/src/test/scala/RefStorageBackendTest.scala index 9e20c76317..de9f38321d 100644 --- a/akka-persistence/akka-persistence-common/src/test/scala/RefStorageBackendTest.scala +++ b/akka-persistence/akka-persistence-common/src/test/scala/RefStorageBackendTest.scala @@ -49,4 +49,4 @@ trait RefStorageBackendTest extends Spec with ShouldMatchers with BeforeAndAfter } } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-common/src/test/scala/SortedSetStorageBackendTest.scala b/akka-persistence/akka-persistence-common/src/test/scala/SortedSetStorageBackendTest.scala index 9337aa935b..9c0eb7a50c 100644 --- a/akka-persistence/akka-persistence-common/src/test/scala/SortedSetStorageBackendTest.scala +++ b/akka-persistence/akka-persistence-common/src/test/scala/SortedSetStorageBackendTest.scala @@ -32,4 +32,4 @@ trait SortedSetStorageBackendTest extends Spec with ShouldMatchers with BeforeAn } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-common/src/test/scala/VectorStorageBackendTest.scala b/akka-persistence/akka-persistence-common/src/test/scala/VectorStorageBackendTest.scala index 8d732a866f..02c50689ff 100644 --- a/akka-persistence/akka-persistence-common/src/test/scala/VectorStorageBackendTest.scala +++ b/akka-persistence/akka-persistence-common/src/test/scala/VectorStorageBackendTest.scala @@ -180,4 +180,4 @@ trait VectorStorageBackendTest extends Spec with ShouldMatchers with BeforeAndAf } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-couchdb/src/main/scala/CouchDBStorage.scala b/akka-persistence/akka-persistence-couchdb/src/main/scala/CouchDBStorage.scala index 14a5917aca..83180a9b4a 100644 --- a/akka-persistence/akka-persistence-couchdb/src/main/scala/CouchDBStorage.scala +++ b/akka-persistence/akka-persistence-couchdb/src/main/scala/CouchDBStorage.scala @@ -23,7 +23,7 @@ object CouchDBStorage extends Storage { /** * Implements a persistent transactional map based on the CouchDB storage. * - * @author + * @author */ class CouchDBPersistentMap(id: String) extends PersistentMapBinary { val uuid = id @@ -34,7 +34,7 @@ class CouchDBPersistentMap(id: String) extends PersistentMapBinary { * Implements a persistent transactional vector based on the CouchDB * storage. * - * @author + * @author */ class CouchDBPersistentVector(id: String) extends PersistentVector[Array[Byte]] { val uuid = id @@ -44,4 +44,4 @@ class CouchDBPersistentVector(id: String) extends PersistentVector[Array[Byte]] class CouchDBPersistentRef(id: String) extends PersistentRef[Array[Byte]] { val uuid = id val storage = CouchDBStorageBackend -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-couchdb/src/main/scala/CouchDBStorageBackend.scala b/akka-persistence/akka-persistence-couchdb/src/main/scala/CouchDBStorageBackend.scala index 1515cb7210..780222535d 100644 --- a/akka-persistence/akka-persistence-couchdb/src/main/scala/CouchDBStorageBackend.scala +++ b/akka-persistence/akka-persistence-couchdb/src/main/scala/CouchDBStorageBackend.scala @@ -23,9 +23,9 @@ private [akka] object CouchDBStorageBackend extends RefStorageBackend[Array[Byte]] with Logging { - + import dispatch.json._ - + implicit object widgetWrites extends Writes[Map[String,Any]] { def writes(o: Map[String,Any]): JsValue = JsValue(o) } @@ -39,7 +39,7 @@ private [akka] object CouchDBStorageBackend extends val delete = new DeleteMethod(URL) client.executeMethod(delete) } - + def create() = { val client = new HttpClient() val put = new PutMethod(URL) @@ -48,16 +48,16 @@ private [akka] object CouchDBStorageBackend extends client.executeMethod(put) put.getResponseBodyAsString } - + private def storeMap(name: String, postfix: String, entries: List[(Array[Byte], Array[Byte])]) ={ var m = entries.map(e=>(new String(e._1) -> new String(e._2))).toMap + ("_id" -> (name + postfix)) val dataJson = JsonSerialization.tojson(m) postData(URL, dataJson.toString) } - + private def storeMap(name: String, postfix: String, entries: Map[String, Any]) ={ postData(URL, JsonSerialization.tojson(entries + ("_id" -> (name + postfix))).toString) - } + } private def getResponseForNameAsMap(name: String, postfix: String): Option[Map[String, Any]] = { getResponse(URL + name + postfix).flatMap(JSON.parseFull(_)).asInstanceOf[Option[Map[String, Any]]] @@ -65,43 +65,43 @@ private [akka] object CouchDBStorageBackend extends def insertMapStorageEntriesFor(name: String, entries: List[(Array[Byte], Array[Byte])]) ={ - val newDoc = getResponseForNameAsMap(name, "_map").getOrElse(Map[String, Any]()) ++ + val newDoc = getResponseForNameAsMap(name, "_map").getOrElse(Map[String, Any]()) ++ entries.map(e => (new String(e._1) -> new String(e._2))).toMap storeMap(name, "_map", newDoc) } - + def insertMapStorageEntryFor(name: String, key: Array[Byte], value: Array[Byte])={ insertMapStorageEntriesFor(name, List((key, value))) } - - + + def removeMapStorageFor(name: String) { lazy val url = URL + name + "_map" findDocRev(name + "_map").foreach(deleteData(url, _)) } - + def removeMapStorageFor(name: String, key: Array[Byte]): Unit = { lazy val sKey = new String(key) // if we can't find the map for name, then we don't need to delete it. getResponseForNameAsMap(name, "_map").foreach(doc => storeMap(name, "_map", doc - sKey)) } - + def getMapStorageEntryFor(name: String, key: Array[Byte]): Option[Array[Byte]] = { lazy val sKey = new String(key) getResponseForNameAsMap(name, "_map").flatMap(_.get(sKey)).asInstanceOf[Option[String]].map(_.getBytes) } - + def getMapStorageSizeFor(name: String): Int = getMapStorageFor(name).size - + def getMapStorageFor(name: String): List[(Array[Byte], Array[Byte])] = { val m = getResponseForNameAsMap(name, "_map").map(_ - ("_id", "_rev")).getOrElse(Map[String, Any]()) m.toList.map(e => (e._1.getBytes, e._2.asInstanceOf[String].getBytes)) } - + def getMapStorageRangeFor(name: String, start: Option[Array[Byte]], finish: Option[Array[Byte]], count: Int): List[(Array[Byte], Array[Byte])] = { val m = getResponseForNameAsMap(name, "_map").map(_ - ("_id", "_rev")).getOrElse(Map[String, Any]()) val keys = m.keys.toList.sortWith(_ < _) - + // if the supplied start is not defined, get the head of keys val s = start.map(new String(_)).getOrElse(keys.head) @@ -131,7 +131,7 @@ private [akka] object CouchDBStorageBackend extends storeMap(name, "_vector", m + ("vector" -> v.updated(index, new String(elem)))) } } - + def getVectorStorageEntryFor(name: String, index: Int): Array[Byte] ={ val v = getResponseForNameAsMap(name, "_vector").flatMap(_.get("vector")).getOrElse(List[String]()).asInstanceOf[List[String]] if (v.indices.contains(index)) @@ -139,7 +139,7 @@ private [akka] object CouchDBStorageBackend extends else Array[Byte]() } - + def getVectorStorageSizeFor(name: String): Int ={ getResponseForNameAsMap(name, "_vector").flatMap(_.get("vector")).map(_.asInstanceOf[List[String]].size).getOrElse(0) } @@ -151,12 +151,12 @@ private [akka] object CouchDBStorageBackend extends val c = if (count == 0) v.length else count v.slice(s, scala.math.min(s + c, f)).map(_.getBytes) } - + def insertRefStorageFor(name: String, element: Array[Byte]) ={ val newDoc = getResponseForNameAsMap(name, "_ref").getOrElse(Map[String, Any]()) + ("ref" -> new String(element)) storeMap(name, "_ref", newDoc) } - + def getRefStorageFor(name: String): Option[Array[Byte]] ={ getResponseForNameAsMap(name, "_ref").flatMap(_.get("ref")).map(_.asInstanceOf[String].getBytes) } @@ -171,7 +171,7 @@ private [akka] object CouchDBStorageBackend extends val delete = new DeleteMethod(url) delete.setRequestHeader("If-Match", rev) client.executeMethod(delete) - + val response = delete.getResponseBodyAsString() if (response != null) Some(response) @@ -191,7 +191,7 @@ private [akka] object CouchDBStorageBackend extends else None } - + private def getResponse(url: String): Option[String] = { val client = new HttpClient() val method = new GetMethod(url) diff --git a/akka-persistence/akka-persistence-couchdb/src/test/scala/CouchDBStorageBackendSpec.scala b/akka-persistence/akka-persistence-couchdb/src/test/scala/CouchDBStorageBackendSpec.scala index a28abd9601..c4a44666a5 100644 --- a/akka-persistence/akka-persistence-couchdb/src/test/scala/CouchDBStorageBackendSpec.scala +++ b/akka-persistence/akka-persistence-couchdb/src/test/scala/CouchDBStorageBackendSpec.scala @@ -15,14 +15,14 @@ import java.util.{Calendar, Date} @RunWith(classOf[JUnitRunner]) class CouchDBStorageBackendSpec extends Specification { - doBeforeSpec { + doBeforeSpec { CouchDBStorageBackend.create() } - + doAfterSpec { CouchDBStorageBackend.drop() } - + "CouchDBStorageBackend store and query in map" should { "enter 4 entries for transaction T-1" in { insertMapStorageEntryFor("T-1", "debasish.company".getBytes, "anshinsoft".getBytes) @@ -34,13 +34,13 @@ class CouchDBStorageBackendSpec extends Specification { new String(getMapStorageEntryFor("T-1", "debasish.language".getBytes).get) mustEqual("java") getMapStorageSizeFor("T-1") mustEqual(4) } - + "enter key/values for another transaction T-2" in { insertMapStorageEntryFor("T-2", "debasish.age".getBytes, "49".getBytes) insertMapStorageEntryFor("T-2", "debasish.spouse".getBytes, "paramita".getBytes) getMapStorageSizeFor("T-2") mustEqual(2) } - + "remove map storage for T-99" in { insertMapStorageEntryFor("T-99", "provider".getBytes, "googleapp".getBytes) insertMapStorageEntryFor("T-99", "quota".getBytes, "100mb".getBytes) @@ -67,7 +67,7 @@ class CouchDBStorageBackendSpec extends Specification { insertMapStorageEntryFor("T-11", "david".getBytes, toByteArray[Long](d / 2)) getMapStorageSizeFor("T-11") mustEqual(4) - fromByteArray[Long](getMapStorageEntryFor("T-11", "steve".getBytes).get) mustEqual(d) + fromByteArray[Long](getMapStorageEntryFor("T-11", "steve".getBytes).get) mustEqual(d) } } @@ -98,7 +98,7 @@ class CouchDBStorageBackendSpec extends Specification { getMapStorageRangeFor("T-5", Some("trade.account".getBytes), None, 0).map(e => (new String(e._1), new String(e._2))).size mustEqual(7) - + removeMapStorageFor("T-5") } } @@ -113,7 +113,7 @@ class CouchDBStorageBackendSpec extends Specification { getMapStorageSizeFor("T-31") mustEqual(1) fromByteArray[Name](getMapStorageEntryFor("T-31", "debasish".getBytes).getOrElse(Array[Byte]())) mustEqual(n) removeMapStorageFor("T-31") - } + } } "Store and query in vectors" should { @@ -135,7 +135,7 @@ class CouchDBStorageBackendSpec extends Specification { "write a Name object and fetch it properly" in { val dtb = Calendar.getInstance.getTime val n = Name(100, "debasish ghosh", "kolkata", dtb, Some(dtb)) - + insertVectorStorageEntryFor("T-31", toByteArray[Name](n)) getVectorStorageSizeFor("T-31") mustEqual(1) fromByteArray[Name](getVectorStorageEntryFor("T-31", 0)) mustEqual(n) @@ -159,21 +159,21 @@ class CouchDBStorageBackendSpec extends Specification { fromByteArray[Name](getRefStorageFor("T-4").get) mustEqual(n) } } - + "Mix the 3 different types storage with the same name" should { "work independently without inference each other" in { insertVectorStorageEntryFor("SameName", "v1".getBytes) insertMapStorageEntryFor("SameName", "vector".getBytes, "map_value_v".getBytes) insertVectorStorageEntryFor("SameName", "v2".getBytes) - insertMapStorageEntryFor("SameName", "ref".getBytes, "map_value_r".getBytes) + insertMapStorageEntryFor("SameName", "ref".getBytes, "map_value_r".getBytes) insertVectorStorageEntryFor("SameName", "v3".getBytes) insertRefStorageFor("SameName", "I am a ref!".getBytes) - + getMapStorageSizeFor("SameName") mustEqual(2) new String(getMapStorageEntryFor("SameName", "vector".getBytes).get) mustEqual("map_value_v") new String(getMapStorageEntryFor("SameName", "ref".getBytes).get) mustEqual("map_value_r") getVectorStorageSizeFor("SameName") mustEqual(3) - new String(getRefStorageFor("SameName").get) mustEqual("I am a ref!") + new String(getRefStorageFor("SameName").get) mustEqual("I am a ref!") } } } diff --git a/akka-persistence/akka-persistence-hbase/src/main/scala/HbaseStorageBackend.scala b/akka-persistence/akka-persistence-hbase/src/main/scala/HbaseStorageBackend.scala index d5b5aba154..2b33876ecf 100644 --- a/akka-persistence/akka-persistence-hbase/src/main/scala/HbaseStorageBackend.scala +++ b/akka-persistence/akka-persistence-hbase/src/main/scala/HbaseStorageBackend.scala @@ -39,7 +39,7 @@ private[akka] object HbaseStorageBackend extends MapStorageBackend[Array[Byte], CONFIGURATION.set("hbase.zookeeper.quorum", HBASE_ZOOKEEPER_QUORUM) init - + def init { val ADMIN = new HBaseAdmin(CONFIGURATION) @@ -50,14 +50,14 @@ private[akka] object HbaseStorageBackend extends MapStorageBackend[Array[Byte], ADMIN.enableTable(REF_TABLE_NAME) } REF_TABLE = new HTable(CONFIGURATION, REF_TABLE_NAME); - + if (!ADMIN.tableExists(VECTOR_TABLE_NAME)) { ADMIN.createTable(new HTableDescriptor(VECTOR_TABLE_NAME)) ADMIN.disableTable(VECTOR_TABLE_NAME) ADMIN.addColumn(VECTOR_TABLE_NAME, new HColumnDescriptor(VECTOR_ELEMENT_COLUMN_FAMILY_NAME)) ADMIN.enableTable(VECTOR_TABLE_NAME); } - VECTOR_TABLE = new HTable(CONFIGURATION, VECTOR_TABLE_NAME) + VECTOR_TABLE = new HTable(CONFIGURATION, VECTOR_TABLE_NAME) if (!ADMIN.tableExists(MAP_TABLE_NAME)) { ADMIN.createTable(new HTableDescriptor(MAP_TABLE_NAME)) @@ -65,9 +65,9 @@ private[akka] object HbaseStorageBackend extends MapStorageBackend[Array[Byte], ADMIN.addColumn(MAP_TABLE_NAME, new HColumnDescriptor(MAP_ELEMENT_COLUMN_FAMILY_NAME)) ADMIN.enableTable(MAP_TABLE_NAME); } - MAP_TABLE = new HTable(CONFIGURATION, MAP_TABLE_NAME) + MAP_TABLE = new HTable(CONFIGURATION, MAP_TABLE_NAME) } - + def drop { val ADMIN = new HBaseAdmin(CONFIGURATION) @@ -82,10 +82,10 @@ private[akka] object HbaseStorageBackend extends MapStorageBackend[Array[Byte], if (ADMIN.tableExists(MAP_TABLE_NAME)) { ADMIN.disableTable(MAP_TABLE_NAME) ADMIN.deleteTable(MAP_TABLE_NAME) - } + } init } - + // =============================================================== // For Ref // =============================================================== @@ -143,7 +143,7 @@ private[akka] object HbaseStorageBackend extends MapStorageBackend[Array[Byte], def getVectorStorageRangeFor(name: String, start: Option[Int], finish: Option[Int], count: Int): List[Array[Byte]] = { import scala.math._ - + val row = new Get(Bytes.toBytes(name)) val result = VECTOR_TABLE.get(row) val size = result.size @@ -156,7 +156,7 @@ private[akka] object HbaseStorageBackend extends MapStorageBackend[Array[Byte], e = finish.get - 1 } else { b = start.getOrElse(0) - e = finish.getOrElse(min(b + count - 1, size - 1)) + e = finish.getOrElse(min(b + count - 1, size - 1)) } for(i <- b to e) { val colnum = size - i - 1 @@ -168,7 +168,7 @@ private[akka] object HbaseStorageBackend extends MapStorageBackend[Array[Byte], def getVectorStorageSizeFor(name: String): Int = { val row = new Get(Bytes.toBytes(name)) val result = VECTOR_TABLE.get(row) - + if (result.isEmpty) 0 else @@ -190,7 +190,7 @@ private[akka] object HbaseStorageBackend extends MapStorageBackend[Array[Byte], def getMapStorageEntryFor(name: String, key: Array[Byte]): Option[Array[Byte]] = { val row = new Get(Bytes.toBytes(name)) val result = MAP_TABLE.get(row) - + Option(result.getValue(Bytes.toBytes(MAP_ELEMENT_COLUMN_FAMILY_NAME), key)) } diff --git a/akka-persistence/akka-persistence-hbase/src/test/scala/HbasePersistentActorSpecTestIntegration.scala b/akka-persistence/akka-persistence-hbase/src/test/scala/HbasePersistentActorSpecTestIntegration.scala index 71d06d37e6..8992ce71d7 100644 --- a/akka-persistence/akka-persistence-hbase/src/test/scala/HbasePersistentActorSpecTestIntegration.scala +++ b/akka-persistence/akka-persistence-hbase/src/test/scala/HbasePersistentActorSpecTestIntegration.scala @@ -83,7 +83,7 @@ class HbasePersistentActorSpecTestIntegration extends JUnitSuite with BeforeAndA override def beforeAll { testUtil.startMiniCluster } - + override def afterAll { testUtil.shutdownMiniCluster } @@ -92,7 +92,7 @@ class HbasePersistentActorSpecTestIntegration extends JUnitSuite with BeforeAndA def beforeEach { HbaseStorageBackend.drop } - + @After def afterEach { HbaseStorageBackend.drop diff --git a/akka-persistence/akka-persistence-hbase/src/test/scala/HbaseStorageSpecTestIntegration.scala b/akka-persistence/akka-persistence-hbase/src/test/scala/HbaseStorageSpecTestIntegration.scala index f19fbe9271..cd154476eb 100644 --- a/akka-persistence/akka-persistence-hbase/src/test/scala/HbaseStorageSpecTestIntegration.scala +++ b/akka-persistence/akka-persistence-hbase/src/test/scala/HbaseStorageSpecTestIntegration.scala @@ -8,17 +8,17 @@ import org.scalatest.BeforeAndAfterEach class HbaseStorageSpecTestIntegration extends Spec with ShouldMatchers with -BeforeAndAfterAll with +BeforeAndAfterAll with BeforeAndAfterEach { - + import org.apache.hadoop.hbase.HBaseTestingUtility - + val testUtil = new HBaseTestingUtility - + override def beforeAll { testUtil.startMiniCluster } - + override def afterAll { testUtil.shutdownMiniCluster } @@ -26,11 +26,11 @@ BeforeAndAfterEach { override def beforeEach { HbaseStorageBackend.drop } - + override def afterEach { HbaseStorageBackend.drop } - + describe("persistent maps") { it("should insert with single key and value") { import HbaseStorageBackend._ @@ -70,8 +70,8 @@ BeforeAndAfterEach { it("should do proper range queries") { import HbaseStorageBackend._ val l = List( - ("bjarne stroustrup", "c++"), - ("martin odersky", "scala"), + ("bjarne stroustrup", "c++"), + ("martin odersky", "scala"), ("james gosling", "java"), ("yukihiro matsumoto", "ruby"), ("slava pestov", "factor"), @@ -82,11 +82,11 @@ BeforeAndAfterEach { ("guido van rossum", "python"), ("james strachan", "groovy")) val rl = List( - ("james gosling", "java"), - ("james strachan", "groovy"), - ("larry wall", "perl"), - ("martin odersky", "scala"), - ("ola bini", "ioke"), ("rich hickey", "clojure"), + ("james gosling", "java"), + ("james strachan", "groovy"), + ("larry wall", "perl"), + ("martin odersky", "scala"), + ("ola bini", "ioke"), ("rich hickey", "clojure"), ("slava pestov", "factor")) insertMapStorageEntriesFor("t1", l.map { case (k, v) => (k.getBytes, v.getBytes) }) getMapStorageSizeFor("t1") should equal(l.size) @@ -166,7 +166,7 @@ BeforeAndAfterEach { describe("persistent refs") { it("should insert a ref") { import HbaseStorageBackend._ - + insertRefStorageFor("t1", "martin odersky".getBytes) new String(getRefStorageFor("t1").get) should equal("martin odersky") insertRefStorageFor("t1", "james gosling".getBytes) diff --git a/akka-persistence/akka-persistence-hbase/src/test/scala/HbaseTicket343SpecTestIntegration.scala b/akka-persistence/akka-persistence-hbase/src/test/scala/HbaseTicket343SpecTestIntegration.scala index 47fc87ee64..ee22bfaa21 100644 --- a/akka-persistence/akka-persistence-hbase/src/test/scala/HbaseTicket343SpecTestIntegration.scala +++ b/akka-persistence/akka-persistence-hbase/src/test/scala/HbaseTicket343SpecTestIntegration.scala @@ -80,7 +80,7 @@ object Storage { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) } - + ks2rem.foreach {k => fooMap -= k.getBytes }} @@ -94,7 +94,7 @@ object Storage { } self.reply(true) - case PUT_WITH_SLICE(kvs2add, from, cnt) => + case PUT_WITH_SLICE(kvs2add, from, cnt) => val v = atomic { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) @@ -103,7 +103,7 @@ object Storage { } self.reply(v: List[(Array[Byte], Array[Byte])]) - case PUT_REM_WITH_SLICE(kvs2add, ks2rem, from, cnt) => + case PUT_REM_WITH_SLICE(kvs2add, ks2rem, from, cnt) => val v = atomic { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) @@ -125,7 +125,7 @@ object Storage { def receive = { case VADD(v) => - val size = + val size = atomic { fooVector + v.getBytes fooVector length @@ -148,7 +148,7 @@ object Storage { self.reply(els) case VUPD_AND_ABORT(index, value) => - val l = + val l = atomic { fooVector.update(index, value.getBytes) // force fail @@ -173,13 +173,13 @@ import Storage._ class HbaseTicket343SpecTestIntegration extends Spec with ShouldMatchers with BeforeAndAfterAll with BeforeAndAfterEach { import org.apache.hadoop.hbase.HBaseTestingUtility - + val testUtil = new HBaseTestingUtility - + override def beforeAll { testUtil.startMiniCluster } - + override def afterAll { testUtil.shutdownMiniCluster } @@ -187,7 +187,7 @@ class HbaseTicket343SpecTestIntegration extends Spec with ShouldMatchers with Be override def beforeEach { HbaseStorageBackend.drop } - + override def afterEach { HbaseStorageBackend.drop } @@ -315,7 +315,7 @@ class HbaseTicket343SpecTestIntegration extends Spec with ShouldMatchers with Be (proc !! VADD("nilanjan")).getOrElse("VADD failed") should equal(4) evaluating { - (proc !! VUPD_AND_ABORT(0, "virat")).getOrElse("VUPD_AND_ABORT failed") + (proc !! VUPD_AND_ABORT(0, "virat")).getOrElse("VUPD_AND_ABORT failed") } should produce [Exception] // update aborts and hence values will remain unchanged diff --git a/akka-persistence/akka-persistence-mongo/src/main/scala/MongoStorageBackend.scala b/akka-persistence/akka-persistence-mongo/src/main/scala/MongoStorageBackend.scala index 47cc44fdc8..cab7237eb0 100644 --- a/akka-persistence/akka-persistence-mongo/src/main/scala/MongoStorageBackend.scala +++ b/akka-persistence/akka-persistence-mongo/src/main/scala/MongoStorageBackend.scala @@ -48,10 +48,10 @@ private[akka] object MongoStorageBackend extends db.safely { db => val q: DBObject = MongoDBObject(KEY -> name) coll.findOne(q) match { - case Some(dbo) => + case Some(dbo) => entries.foreach { case (k, v) => dbo += new String(k) -> v } db.safely { db => coll.update(q, dbo, true, false) } - case None => + case None => val builder = MongoDBObject.newBuilder builder += KEY -> name entries.foreach { case (k, v) => builder += new String(k) -> v } @@ -79,7 +79,7 @@ private[akka] object MongoStorageBackend extends } def getMapStorageEntryFor(name: String, key: Array[Byte]): Option[Array[Byte]] = queryFor(name) { (q, dbo) => - dbo.map { d => + dbo.map { d => d.getAs[Array[Byte]](new String(key)) }.getOrElse(None) } @@ -132,7 +132,7 @@ private[akka] object MongoStorageBackend extends db.safely { db => coll.findOne(q) match { // exists : need to update - case Some(dbo) => + case Some(dbo) => dbo -= KEY dbo -= "_id" val listBuilder = MongoDBList.newBuilder @@ -146,7 +146,7 @@ private[akka] object MongoStorageBackend extends coll.update(q, builder.result.asDBObject, true, false) // new : just add - case None => + case None => val listBuilder = MongoDBList.newBuilder listBuilder ++= elements @@ -166,7 +166,7 @@ private[akka] object MongoStorageBackend extends } def getVectorStorageEntryFor(name: String, index: Int): Array[Byte] = queryFor(name) { (q, dbo) => - dbo.map { d => + dbo.map { d => d(index.toString).asInstanceOf[Array[Byte]] }.getOrElse(Array.empty[Byte]) } @@ -207,12 +207,12 @@ private[akka] object MongoStorageBackend extends db.safely { db => coll.findOne(q) match { // exists : need to update - case Some(dbo) => + case Some(dbo) => dbo += ((REF, element)) coll.update(q, dbo, true, false) // not found : make one - case None => + case None => val builder = MongoDBObject.newBuilder builder += KEY -> name builder += REF -> element @@ -222,7 +222,7 @@ private[akka] object MongoStorageBackend extends } def getRefStorageFor(name: String): Option[Array[Byte]] = queryFor(name) { (q, dbo) => - dbo.map { d => + dbo.map { d => d.getAs[Array[Byte]](REF) }.getOrElse(None) } diff --git a/akka-persistence/akka-persistence-mongo/src/test/scala/MongoStorageSpec.scala b/akka-persistence/akka-persistence-mongo/src/test/scala/MongoStorageSpec.scala index a2b0a7aab5..482179455a 100644 --- a/akka-persistence/akka-persistence-mongo/src/test/scala/MongoStorageSpec.scala +++ b/akka-persistence/akka-persistence-mongo/src/test/scala/MongoStorageSpec.scala @@ -60,8 +60,8 @@ class MongoStorageSpec extends it("should do proper range queries") { import MongoStorageBackend._ val l = List( - ("bjarne stroustrup", "c++"), - ("martin odersky", "scala"), + ("bjarne stroustrup", "c++"), + ("martin odersky", "scala"), ("james gosling", "java"), ("yukihiro matsumoto", "ruby"), ("slava pestov", "factor"), diff --git a/akka-persistence/akka-persistence-mongo/src/test/scala/MongoTicket343Spec.scala b/akka-persistence/akka-persistence-mongo/src/test/scala/MongoTicket343Spec.scala index ef70719f4f..98cb9568b1 100644 --- a/akka-persistence/akka-persistence-mongo/src/test/scala/MongoTicket343Spec.scala +++ b/akka-persistence/akka-persistence-mongo/src/test/scala/MongoTicket343Spec.scala @@ -80,7 +80,7 @@ object Storage { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) } - + ks2rem.foreach {k => fooMap -= k.getBytes }} @@ -94,7 +94,7 @@ object Storage { } self.reply(true) - case PUT_WITH_SLICE(kvs2add, from, cnt) => + case PUT_WITH_SLICE(kvs2add, from, cnt) => val v = atomic { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) @@ -103,7 +103,7 @@ object Storage { } self.reply(v: List[(Array[Byte], Array[Byte])]) - case PUT_REM_WITH_SLICE(kvs2add, ks2rem, from, cnt) => + case PUT_REM_WITH_SLICE(kvs2add, ks2rem, from, cnt) => val v = atomic { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) @@ -125,7 +125,7 @@ object Storage { def receive = { case VADD(v) => - val size = + val size = atomic { fooVector + v.getBytes fooVector length @@ -148,7 +148,7 @@ object Storage { self.reply(els) case VUPD_AND_ABORT(index, value) => - val l = + val l = atomic { fooVector.update(index, value.getBytes) // force fail @@ -315,7 +315,7 @@ class MongoTicket343Spec extends (proc !! VADD("nilanjan")).getOrElse("VADD failed") should equal(4) evaluating { - (proc !! VUPD_AND_ABORT(0, "virat")).getOrElse("VUPD_AND_ABORT failed") + (proc !! VUPD_AND_ABORT(0, "virat")).getOrElse("VUPD_AND_ABORT failed") } should produce [Exception] // update aborts and hence values will remain unchanged diff --git a/akka-persistence/akka-persistence-redis/src/main/scala/RedisStorageBackend.scala b/akka-persistence/akka-persistence-redis/src/main/scala/RedisStorageBackend.scala index f255e469a2..af620c446c 100644 --- a/akka-persistence/akka-persistence-redis/src/main/scala/RedisStorageBackend.scala +++ b/akka-persistence/akka-persistence-redis/src/main/scala/RedisStorageBackend.scala @@ -32,7 +32,7 @@ object CommonsCodec { import CommonsCodec._ import CommonsCodec.Base64StringEncoder._ - + /** * A module for supporting Redis based persistence. *

    @@ -76,7 +76,7 @@ private [akka] object RedisStorageBackend extends /** * Map storage in Redis. *

    - * Maps are stored as key/value pairs in redis. + * Maps are stored as key/value pairs in redis. */ def insertMapStorageEntryFor(name: String, key: Array[Byte], value: Array[Byte]): Unit = withErrorHandling { insertMapStorageEntriesFor(name, List((key, value))) @@ -135,7 +135,7 @@ private [akka] object RedisStorageBackend extends def getMapStorageFor(name: String): List[(Array[Byte], Array[Byte])] = withErrorHandling { db.keys("%s:*".format(name)) - .map { keys => + .map { keys => keys.map(key => (makeKeyFromRedisKey(key.get)._2, stringToByteArray(db.get(key.get).get))).toList }.getOrElse { throw new NoSuchElementException(name + " not present") @@ -302,10 +302,10 @@ private [akka] object RedisStorageBackend extends // add item to sorted set identified by name def zadd(name: String, zscore: String, item: Array[Byte]): Boolean = withErrorHandling { db.zadd(name, zscore, byteArrayToString(item)) - .map { e => + .map { e => e match { case 1 => true - case _ => false + case _ => false } }.getOrElse(false) } @@ -313,10 +313,10 @@ private [akka] object RedisStorageBackend extends // remove item from sorted set identified by name def zrem(name: String, item: Array[Byte]): Boolean = withErrorHandling { db.zrem(name, byteArrayToString(item)) - .map { e => + .map { e => e match { case 1 => true - case _ => false + case _ => false } }.getOrElse(false) } @@ -331,7 +331,7 @@ private [akka] object RedisStorageBackend extends } def zrange(name: String, start: Int, end: Int): List[Array[Byte]] = withErrorHandling { - db.zrange(name, start.toString, end.toString, RedisClient.ASC, false) + db.zrange(name, start.toString, end.toString, RedisClient.ASC, false) .map(_.map(e => stringToByteArray(e.get))) .getOrElse { throw new NoSuchElementException(name + " not present") diff --git a/akka-persistence/akka-persistence-redis/src/test/scala/RedisTicket343Spec.scala b/akka-persistence/akka-persistence-redis/src/test/scala/RedisTicket343Spec.scala index d5accca626..76b07203bd 100644 --- a/akka-persistence/akka-persistence-redis/src/test/scala/RedisTicket343Spec.scala +++ b/akka-persistence/akka-persistence-redis/src/test/scala/RedisTicket343Spec.scala @@ -76,7 +76,7 @@ object Storage { } self.reply(v) - case MSET(kvs) => + case MSET(kvs) => atomic { kvs.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) @@ -84,13 +84,13 @@ object Storage { } self.reply(kvs.size) - case REMOVE_AFTER_PUT(kvs2add, ks2rem) => + case REMOVE_AFTER_PUT(kvs2add, ks2rem) => val v = atomic { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) } - + ks2rem.foreach {k => fooMap -= k.getBytes } @@ -98,7 +98,7 @@ object Storage { } self.reply(v) - case CLEAR_AFTER_PUT(kvs2add) => + case CLEAR_AFTER_PUT(kvs2add) => atomic { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) @@ -107,8 +107,8 @@ object Storage { } self.reply(true) - case PUT_WITH_SLICE(kvs2add, from, cnt) => - val v = + case PUT_WITH_SLICE(kvs2add, from, cnt) => + val v = atomic { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) @@ -117,8 +117,8 @@ object Storage { } self.reply(v: List[(Array[Byte], Array[Byte])]) - case PUT_REM_WITH_SLICE(kvs2add, ks2rem, from, cnt) => - val v = + case PUT_REM_WITH_SLICE(kvs2add, ks2rem, from, cnt) => + val v = atomic { kvs2add.foreach {kv => fooMap += (kv._1.getBytes, kv._2.getBytes) @@ -140,7 +140,7 @@ object Storage { def receive = { case VADD(v) => - val size = + val size = atomic { fooVector + v.getBytes fooVector length @@ -163,7 +163,7 @@ object Storage { self.reply(els) case VUPD_AND_ABORT(index, value) => - val l = + val l = atomic { fooVector.update(index, value.getBytes) // force fail @@ -347,7 +347,7 @@ class RedisTicket343Spec extends (proc !! VADD("nilanjan")).getOrElse("VADD failed") should equal(4) evaluating { - (proc !! VUPD_AND_ABORT(0, "virat")).getOrElse("VUPD_AND_ABORT failed") + (proc !! VUPD_AND_ABORT(0, "virat")).getOrElse("VUPD_AND_ABORT failed") } should produce [Exception] // update aborts and hence values will remain unchanged diff --git a/akka-persistence/akka-persistence-riak/src/main/scala/RiakStorageBackend.scala b/akka-persistence/akka-persistence-riak/src/main/scala/RiakStorageBackend.scala index 0967860851..d716cc0eec 100644 --- a/akka-persistence/akka-persistence-riak/src/main/scala/RiakStorageBackend.scala +++ b/akka-persistence/akka-persistence-riak/src/main/scala/RiakStorageBackend.scala @@ -120,4 +120,4 @@ private[akka] object RiakStorageBackend extends CommonStorageBackend { } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-riak/src/test/scala/RiakTicket343TestIntegration.scala b/akka-persistence/akka-persistence-riak/src/test/scala/RiakTicket343TestIntegration.scala index 3400f0bddb..ce9ead7f14 100644 --- a/akka-persistence/akka-persistence-riak/src/test/scala/RiakTicket343TestIntegration.scala +++ b/akka-persistence/akka-persistence-riak/src/test/scala/RiakTicket343TestIntegration.scala @@ -20,4 +20,4 @@ class RiakTicket343TestIntegration extends Ticket343Test { def getMap: (String) => PersistentMap[Array[Byte], Array[Byte]] = RiakStorage.getMap -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-voldemort/src/main/scala/VoldemortStorageBackend.scala b/akka-persistence/akka-persistence-voldemort/src/main/scala/VoldemortStorageBackend.scala index 87fd07cbe5..3f4e0436a0 100644 --- a/akka-persistence/akka-persistence-voldemort/src/main/scala/VoldemortStorageBackend.scala +++ b/akka-persistence/akka-persistence-voldemort/src/main/scala/VoldemortStorageBackend.scala @@ -142,4 +142,4 @@ private[akka] object VoldemortStorageBackend extends CommonStorageBackend { } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-voldemort/src/test/resources/config/stores.xml b/akka-persistence/akka-persistence-voldemort/src/test/resources/config/stores.xml index 99a0d1ebc6..5e1289190c 100644 --- a/akka-persistence/akka-persistence-voldemort/src/test/resources/config/stores.xml +++ b/akka-persistence/akka-persistence-voldemort/src/test/resources/config/stores.xml @@ -64,4 +64,4 @@ - \ No newline at end of file + diff --git a/akka-persistence/akka-persistence-voldemort/src/test/scala/EmbeddedVoldemort.scala b/akka-persistence/akka-persistence-voldemort/src/test/scala/EmbeddedVoldemort.scala index 867c9f8267..bd10420a5b 100644 --- a/akka-persistence/akka-persistence-voldemort/src/test/scala/EmbeddedVoldemort.scala +++ b/akka-persistence/akka-persistence-voldemort/src/test/scala/EmbeddedVoldemort.scala @@ -37,4 +37,4 @@ trait EmbeddedVoldemort extends BeforeAndAfterAll with Logging { override protected def afterAll(): Unit = { server.stop } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-voldemort/src/test/scala/VoldemortStorageBackendSuite.scala b/akka-persistence/akka-persistence-voldemort/src/test/scala/VoldemortStorageBackendSuite.scala index bd1116f56f..81b3844fd2 100644 --- a/akka-persistence/akka-persistence-voldemort/src/test/scala/VoldemortStorageBackendSuite.scala +++ b/akka-persistence/akka-persistence-voldemort/src/test/scala/VoldemortStorageBackendSuite.scala @@ -180,4 +180,4 @@ object VoldemortStorageBackendSuite { value.getBytes("UTF-8") } -} \ No newline at end of file +} diff --git a/akka-persistence/akka-persistence-voldemort/src/test/scala/VoldemortTicket343Test.scala b/akka-persistence/akka-persistence-voldemort/src/test/scala/VoldemortTicket343Test.scala index dce9d7452d..8a3cb1d0be 100644 --- a/akka-persistence/akka-persistence-voldemort/src/test/scala/VoldemortTicket343Test.scala +++ b/akka-persistence/akka-persistence-voldemort/src/test/scala/VoldemortTicket343Test.scala @@ -20,4 +20,4 @@ class VoldemortTicket343Test extends Ticket343Test with EmbeddedVoldemort { def getMap: (String) => PersistentMap[Array[Byte], Array[Byte]] = VoldemortStorage.getMap -} \ No newline at end of file +} diff --git a/akka-remote/src/main/java/akka/remote/protocol/RemoteProtocol.java b/akka-remote/src/main/java/akka/remote/protocol/RemoteProtocol.java index 1be793a2aa..cd7f1f0305 100644 --- a/akka-remote/src/main/java/akka/remote/protocol/RemoteProtocol.java +++ b/akka-remote/src/main/java/akka/remote/protocol/RemoteProtocol.java @@ -14,10 +14,10 @@ public final class RemoteProtocol { JAVA_ACTOR(1, 2), TYPED_ACTOR(2, 3), ; - - + + public final int getNumber() { return value; } - + public static ActorType valueOf(int value) { switch (value) { case 1: return SCALA_ACTOR; @@ -26,7 +26,7 @@ public final class RemoteProtocol { default: return null; } } - + public static com.google.protobuf.Internal.EnumLiteMap internalGetValueMap() { return internalValueMap; @@ -38,7 +38,7 @@ public final class RemoteProtocol { return ActorType.valueOf(number) ; } }; - + public final com.google.protobuf.Descriptors.EnumValueDescriptor getValueDescriptor() { return getDescriptor().getValues().get(index); @@ -51,9 +51,9 @@ public final class RemoteProtocol { getDescriptor() { return akka.remote.protocol.RemoteProtocol.getDescriptor().getEnumTypes().get(0); } - + private static final ActorType[] VALUES = { - SCALA_ACTOR, JAVA_ACTOR, TYPED_ACTOR, + SCALA_ACTOR, JAVA_ACTOR, TYPED_ACTOR, }; public static ActorType valueOf( com.google.protobuf.Descriptors.EnumValueDescriptor desc) { @@ -69,14 +69,14 @@ public final class RemoteProtocol { this.index = index; this.value = value; } - + static { akka.remote.protocol.RemoteProtocol.getDescriptor(); } - + // @@protoc_insertion_point(enum_scope:ActorType) } - + public enum SerializationSchemeType implements com.google.protobuf.ProtocolMessageEnum { JAVA(0, 1), @@ -85,10 +85,10 @@ public final class RemoteProtocol { JAVA_JSON(3, 4), PROTOBUF(4, 5), ; - - + + public final int getNumber() { return value; } - + public static SerializationSchemeType valueOf(int value) { switch (value) { case 1: return JAVA; @@ -99,7 +99,7 @@ public final class RemoteProtocol { default: return null; } } - + public static com.google.protobuf.Internal.EnumLiteMap internalGetValueMap() { return internalValueMap; @@ -111,7 +111,7 @@ public final class RemoteProtocol { return SerializationSchemeType.valueOf(number) ; } }; - + public final com.google.protobuf.Descriptors.EnumValueDescriptor getValueDescriptor() { return getDescriptor().getValues().get(index); @@ -124,9 +124,9 @@ public final class RemoteProtocol { getDescriptor() { return akka.remote.protocol.RemoteProtocol.getDescriptor().getEnumTypes().get(1); } - + private static final SerializationSchemeType[] VALUES = { - JAVA, SBINARY, SCALA_JSON, JAVA_JSON, PROTOBUF, + JAVA, SBINARY, SCALA_JSON, JAVA_JSON, PROTOBUF, }; public static SerializationSchemeType valueOf( com.google.protobuf.Descriptors.EnumValueDescriptor desc) { @@ -142,23 +142,23 @@ public final class RemoteProtocol { this.index = index; this.value = value; } - + static { akka.remote.protocol.RemoteProtocol.getDescriptor(); } - + // @@protoc_insertion_point(enum_scope:SerializationSchemeType) } - + public enum LifeCycleType implements com.google.protobuf.ProtocolMessageEnum { PERMANENT(0, 1), TEMPORARY(1, 2), ; - - + + public final int getNumber() { return value; } - + public static LifeCycleType valueOf(int value) { switch (value) { case 1: return PERMANENT; @@ -166,7 +166,7 @@ public final class RemoteProtocol { default: return null; } } - + public static com.google.protobuf.Internal.EnumLiteMap internalGetValueMap() { return internalValueMap; @@ -178,7 +178,7 @@ public final class RemoteProtocol { return LifeCycleType.valueOf(number) ; } }; - + public final com.google.protobuf.Descriptors.EnumValueDescriptor getValueDescriptor() { return getDescriptor().getValues().get(index); @@ -191,9 +191,9 @@ public final class RemoteProtocol { getDescriptor() { return akka.remote.protocol.RemoteProtocol.getDescriptor().getEnumTypes().get(2); } - + private static final LifeCycleType[] VALUES = { - PERMANENT, TEMPORARY, + PERMANENT, TEMPORARY, }; public static LifeCycleType valueOf( com.google.protobuf.Descriptors.EnumValueDescriptor desc) { @@ -209,14 +209,14 @@ public final class RemoteProtocol { this.index = index; this.value = value; } - + static { akka.remote.protocol.RemoteProtocol.getDescriptor(); } - + // @@protoc_insertion_point(enum_scope:LifeCycleType) } - + public static final class RemoteActorRefProtocol extends com.google.protobuf.GeneratedMessage { // Use RemoteActorRefProtocol.newBuilder() to construct. @@ -224,54 +224,54 @@ public final class RemoteProtocol { initFields(); } private RemoteActorRefProtocol(boolean noInit) {} - + private static final RemoteActorRefProtocol defaultInstance; public static RemoteActorRefProtocol getDefaultInstance() { return defaultInstance; } - + public RemoteActorRefProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_RemoteActorRefProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_RemoteActorRefProtocol_fieldAccessorTable; } - + // required string classOrServiceName = 1; public static final int CLASSORSERVICENAME_FIELD_NUMBER = 1; private boolean hasClassOrServiceName; private java.lang.String classOrServiceName_ = ""; public boolean hasClassOrServiceName() { return hasClassOrServiceName; } public java.lang.String getClassOrServiceName() { return classOrServiceName_; } - + // required string actorClassname = 2; public static final int ACTORCLASSNAME_FIELD_NUMBER = 2; private boolean hasActorClassname; private java.lang.String actorClassname_ = ""; public boolean hasActorClassname() { return hasActorClassname; } public java.lang.String getActorClassname() { return actorClassname_; } - + // required .AddressProtocol homeAddress = 3; public static final int HOMEADDRESS_FIELD_NUMBER = 3; private boolean hasHomeAddress; private akka.remote.protocol.RemoteProtocol.AddressProtocol homeAddress_; public boolean hasHomeAddress() { return hasHomeAddress; } public akka.remote.protocol.RemoteProtocol.AddressProtocol getHomeAddress() { return homeAddress_; } - + // optional uint64 timeout = 4; public static final int TIMEOUT_FIELD_NUMBER = 4; private boolean hasTimeout; private long timeout_ = 0L; public boolean hasTimeout() { return hasTimeout; } public long getTimeout() { return timeout_; } - + private void initFields() { homeAddress_ = akka.remote.protocol.RemoteProtocol.AddressProtocol.getDefaultInstance(); } @@ -282,7 +282,7 @@ public final class RemoteProtocol { if (!getHomeAddress().isInitialized()) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -300,12 +300,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasClassOrServiceName()) { size += com.google.protobuf.CodedOutputStream @@ -327,7 +327,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -394,31 +394,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -427,20 +427,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -450,7 +450,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -459,7 +459,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -469,7 +469,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol)other); @@ -478,7 +478,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol.getDefaultInstance()) return this; if (other.hasClassOrServiceName()) { @@ -496,7 +496,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -542,8 +542,8 @@ public final class RemoteProtocol { } } } - - + + // required string classOrServiceName = 1; public boolean hasClassOrServiceName() { return result.hasClassOrServiceName(); @@ -564,7 +564,7 @@ public final class RemoteProtocol { result.classOrServiceName_ = getDefaultInstance().getClassOrServiceName(); return this; } - + // required string actorClassname = 2; public boolean hasActorClassname() { return result.hasActorClassname(); @@ -585,7 +585,7 @@ public final class RemoteProtocol { result.actorClassname_ = getDefaultInstance().getActorClassname(); return this; } - + // required .AddressProtocol homeAddress = 3; public boolean hasHomeAddress() { return result.hasHomeAddress(); @@ -622,7 +622,7 @@ public final class RemoteProtocol { result.homeAddress_ = akka.remote.protocol.RemoteProtocol.AddressProtocol.getDefaultInstance(); return this; } - + // optional uint64 timeout = 4; public boolean hasTimeout() { return result.hasTimeout(); @@ -640,19 +640,19 @@ public final class RemoteProtocol { result.timeout_ = 0L; return this; } - + // @@protoc_insertion_point(builder_scope:RemoteActorRefProtocol) } - + static { defaultInstance = new RemoteActorRefProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:RemoteActorRefProtocol) } - + public static final class RemoteTypedActorRefProtocol extends com.google.protobuf.GeneratedMessage { // Use RemoteTypedActorRefProtocol.newBuilder() to construct. @@ -660,40 +660,40 @@ public final class RemoteProtocol { initFields(); } private RemoteTypedActorRefProtocol(boolean noInit) {} - + private static final RemoteTypedActorRefProtocol defaultInstance; public static RemoteTypedActorRefProtocol getDefaultInstance() { return defaultInstance; } - + public RemoteTypedActorRefProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_RemoteTypedActorRefProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_RemoteTypedActorRefProtocol_fieldAccessorTable; } - + // required .RemoteActorRefProtocol actorRef = 1; public static final int ACTORREF_FIELD_NUMBER = 1; private boolean hasActorRef; private akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol actorRef_; public boolean hasActorRef() { return hasActorRef; } public akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol getActorRef() { return actorRef_; } - + // required string interfaceName = 2; public static final int INTERFACENAME_FIELD_NUMBER = 2; private boolean hasInterfaceName; private java.lang.String interfaceName_ = ""; public boolean hasInterfaceName() { return hasInterfaceName; } public java.lang.String getInterfaceName() { return interfaceName_; } - + private void initFields() { actorRef_ = akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol.getDefaultInstance(); } @@ -703,7 +703,7 @@ public final class RemoteProtocol { if (!getActorRef().isInitialized()) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -715,12 +715,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasActorRef()) { size += com.google.protobuf.CodedOutputStream @@ -734,7 +734,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -801,31 +801,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -834,20 +834,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -857,7 +857,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -866,7 +866,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -876,7 +876,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol)other); @@ -885,7 +885,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.RemoteTypedActorRefProtocol.getDefaultInstance()) return this; if (other.hasActorRef()) { @@ -897,7 +897,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -935,8 +935,8 @@ public final class RemoteProtocol { } } } - - + + // required .RemoteActorRefProtocol actorRef = 1; public boolean hasActorRef() { return result.hasActorRef(); @@ -973,7 +973,7 @@ public final class RemoteProtocol { result.actorRef_ = akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol.getDefaultInstance(); return this; } - + // required string interfaceName = 2; public boolean hasInterfaceName() { return result.hasInterfaceName(); @@ -994,19 +994,19 @@ public final class RemoteProtocol { result.interfaceName_ = getDefaultInstance().getInterfaceName(); return this; } - + // @@protoc_insertion_point(builder_scope:RemoteTypedActorRefProtocol) } - + static { defaultInstance = new RemoteTypedActorRefProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:RemoteTypedActorRefProtocol) } - + public static final class SerializedActorRefProtocol extends com.google.protobuf.GeneratedMessage { // Use SerializedActorRefProtocol.newBuilder() to construct. @@ -1014,110 +1014,110 @@ public final class RemoteProtocol { initFields(); } private SerializedActorRefProtocol(boolean noInit) {} - + private static final SerializedActorRefProtocol defaultInstance; public static SerializedActorRefProtocol getDefaultInstance() { return defaultInstance; } - + public SerializedActorRefProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_SerializedActorRefProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_SerializedActorRefProtocol_fieldAccessorTable; } - + // required .UuidProtocol uuid = 1; public static final int UUID_FIELD_NUMBER = 1; private boolean hasUuid; private akka.remote.protocol.RemoteProtocol.UuidProtocol uuid_; public boolean hasUuid() { return hasUuid; } public akka.remote.protocol.RemoteProtocol.UuidProtocol getUuid() { return uuid_; } - + // required string id = 2; public static final int ID_FIELD_NUMBER = 2; private boolean hasId; private java.lang.String id_ = ""; public boolean hasId() { return hasId; } public java.lang.String getId() { return id_; } - + // required string actorClassname = 3; public static final int ACTORCLASSNAME_FIELD_NUMBER = 3; private boolean hasActorClassname; private java.lang.String actorClassname_ = ""; public boolean hasActorClassname() { return hasActorClassname; } public java.lang.String getActorClassname() { return actorClassname_; } - + // required .AddressProtocol originalAddress = 4; public static final int ORIGINALADDRESS_FIELD_NUMBER = 4; private boolean hasOriginalAddress; private akka.remote.protocol.RemoteProtocol.AddressProtocol originalAddress_; public boolean hasOriginalAddress() { return hasOriginalAddress; } public akka.remote.protocol.RemoteProtocol.AddressProtocol getOriginalAddress() { return originalAddress_; } - + // optional bytes actorInstance = 5; public static final int ACTORINSTANCE_FIELD_NUMBER = 5; private boolean hasActorInstance; private com.google.protobuf.ByteString actorInstance_ = com.google.protobuf.ByteString.EMPTY; public boolean hasActorInstance() { return hasActorInstance; } public com.google.protobuf.ByteString getActorInstance() { return actorInstance_; } - + // optional string serializerClassname = 6; public static final int SERIALIZERCLASSNAME_FIELD_NUMBER = 6; private boolean hasSerializerClassname; private java.lang.String serializerClassname_ = ""; public boolean hasSerializerClassname() { return hasSerializerClassname; } public java.lang.String getSerializerClassname() { return serializerClassname_; } - + // optional bool isTransactor = 7; public static final int ISTRANSACTOR_FIELD_NUMBER = 7; private boolean hasIsTransactor; private boolean isTransactor_ = false; public boolean hasIsTransactor() { return hasIsTransactor; } public boolean getIsTransactor() { return isTransactor_; } - + // optional uint64 timeout = 8; public static final int TIMEOUT_FIELD_NUMBER = 8; private boolean hasTimeout; private long timeout_ = 0L; public boolean hasTimeout() { return hasTimeout; } public long getTimeout() { return timeout_; } - + // optional uint64 receiveTimeout = 9; public static final int RECEIVETIMEOUT_FIELD_NUMBER = 9; private boolean hasReceiveTimeout; private long receiveTimeout_ = 0L; public boolean hasReceiveTimeout() { return hasReceiveTimeout; } public long getReceiveTimeout() { return receiveTimeout_; } - + // optional .LifeCycleProtocol lifeCycle = 10; public static final int LIFECYCLE_FIELD_NUMBER = 10; private boolean hasLifeCycle; private akka.remote.protocol.RemoteProtocol.LifeCycleProtocol lifeCycle_; public boolean hasLifeCycle() { return hasLifeCycle; } public akka.remote.protocol.RemoteProtocol.LifeCycleProtocol getLifeCycle() { return lifeCycle_; } - + // optional .RemoteActorRefProtocol supervisor = 11; public static final int SUPERVISOR_FIELD_NUMBER = 11; private boolean hasSupervisor; private akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol supervisor_; public boolean hasSupervisor() { return hasSupervisor; } public akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol getSupervisor() { return supervisor_; } - + // optional bytes hotswapStack = 12; public static final int HOTSWAPSTACK_FIELD_NUMBER = 12; private boolean hasHotswapStack; private com.google.protobuf.ByteString hotswapStack_ = com.google.protobuf.ByteString.EMPTY; public boolean hasHotswapStack() { return hasHotswapStack; } public com.google.protobuf.ByteString getHotswapStack() { return hotswapStack_; } - + // repeated .RemoteRequestProtocol messages = 13; public static final int MESSAGES_FIELD_NUMBER = 13; private java.util.List messages_ = @@ -1129,7 +1129,7 @@ public final class RemoteProtocol { public akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol getMessages(int index) { return messages_.get(index); } - + private void initFields() { uuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); originalAddress_ = akka.remote.protocol.RemoteProtocol.AddressProtocol.getDefaultInstance(); @@ -1154,7 +1154,7 @@ public final class RemoteProtocol { } return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -1199,12 +1199,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasUuid()) { size += com.google.protobuf.CodedOutputStream @@ -1262,7 +1262,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -1329,31 +1329,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -1362,20 +1362,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -1385,7 +1385,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -1394,7 +1394,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -1408,7 +1408,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol)other); @@ -1417,7 +1417,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol.getDefaultInstance()) return this; if (other.hasUuid()) { @@ -1465,7 +1465,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -1564,8 +1564,8 @@ public final class RemoteProtocol { } } } - - + + // required .UuidProtocol uuid = 1; public boolean hasUuid() { return result.hasUuid(); @@ -1602,7 +1602,7 @@ public final class RemoteProtocol { result.uuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); return this; } - + // required string id = 2; public boolean hasId() { return result.hasId(); @@ -1623,7 +1623,7 @@ public final class RemoteProtocol { result.id_ = getDefaultInstance().getId(); return this; } - + // required string actorClassname = 3; public boolean hasActorClassname() { return result.hasActorClassname(); @@ -1644,7 +1644,7 @@ public final class RemoteProtocol { result.actorClassname_ = getDefaultInstance().getActorClassname(); return this; } - + // required .AddressProtocol originalAddress = 4; public boolean hasOriginalAddress() { return result.hasOriginalAddress(); @@ -1681,7 +1681,7 @@ public final class RemoteProtocol { result.originalAddress_ = akka.remote.protocol.RemoteProtocol.AddressProtocol.getDefaultInstance(); return this; } - + // optional bytes actorInstance = 5; public boolean hasActorInstance() { return result.hasActorInstance(); @@ -1702,7 +1702,7 @@ public final class RemoteProtocol { result.actorInstance_ = getDefaultInstance().getActorInstance(); return this; } - + // optional string serializerClassname = 6; public boolean hasSerializerClassname() { return result.hasSerializerClassname(); @@ -1723,7 +1723,7 @@ public final class RemoteProtocol { result.serializerClassname_ = getDefaultInstance().getSerializerClassname(); return this; } - + // optional bool isTransactor = 7; public boolean hasIsTransactor() { return result.hasIsTransactor(); @@ -1741,7 +1741,7 @@ public final class RemoteProtocol { result.isTransactor_ = false; return this; } - + // optional uint64 timeout = 8; public boolean hasTimeout() { return result.hasTimeout(); @@ -1759,7 +1759,7 @@ public final class RemoteProtocol { result.timeout_ = 0L; return this; } - + // optional uint64 receiveTimeout = 9; public boolean hasReceiveTimeout() { return result.hasReceiveTimeout(); @@ -1777,7 +1777,7 @@ public final class RemoteProtocol { result.receiveTimeout_ = 0L; return this; } - + // optional .LifeCycleProtocol lifeCycle = 10; public boolean hasLifeCycle() { return result.hasLifeCycle(); @@ -1814,7 +1814,7 @@ public final class RemoteProtocol { result.lifeCycle_ = akka.remote.protocol.RemoteProtocol.LifeCycleProtocol.getDefaultInstance(); return this; } - + // optional .RemoteActorRefProtocol supervisor = 11; public boolean hasSupervisor() { return result.hasSupervisor(); @@ -1851,7 +1851,7 @@ public final class RemoteProtocol { result.supervisor_ = akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol.getDefaultInstance(); return this; } - + // optional bytes hotswapStack = 12; public boolean hasHotswapStack() { return result.hasHotswapStack(); @@ -1872,7 +1872,7 @@ public final class RemoteProtocol { result.hotswapStack_ = getDefaultInstance().getHotswapStack(); return this; } - + // repeated .RemoteRequestProtocol messages = 13; public java.util.List getMessagesList() { return java.util.Collections.unmodifiableList(result.messages_); @@ -1923,19 +1923,19 @@ public final class RemoteProtocol { result.messages_ = java.util.Collections.emptyList(); return this; } - + // @@protoc_insertion_point(builder_scope:SerializedActorRefProtocol) } - + static { defaultInstance = new SerializedActorRefProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:SerializedActorRefProtocol) } - + public static final class SerializedTypedActorRefProtocol extends com.google.protobuf.GeneratedMessage { // Use SerializedTypedActorRefProtocol.newBuilder() to construct. @@ -1943,40 +1943,40 @@ public final class RemoteProtocol { initFields(); } private SerializedTypedActorRefProtocol(boolean noInit) {} - + private static final SerializedTypedActorRefProtocol defaultInstance; public static SerializedTypedActorRefProtocol getDefaultInstance() { return defaultInstance; } - + public SerializedTypedActorRefProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_SerializedTypedActorRefProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_SerializedTypedActorRefProtocol_fieldAccessorTable; } - + // required .SerializedActorRefProtocol actorRef = 1; public static final int ACTORREF_FIELD_NUMBER = 1; private boolean hasActorRef; private akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol actorRef_; public boolean hasActorRef() { return hasActorRef; } public akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol getActorRef() { return actorRef_; } - + // required string interfaceName = 2; public static final int INTERFACENAME_FIELD_NUMBER = 2; private boolean hasInterfaceName; private java.lang.String interfaceName_ = ""; public boolean hasInterfaceName() { return hasInterfaceName; } public java.lang.String getInterfaceName() { return interfaceName_; } - + private void initFields() { actorRef_ = akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol.getDefaultInstance(); } @@ -1986,7 +1986,7 @@ public final class RemoteProtocol { if (!getActorRef().isInitialized()) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -1998,12 +1998,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasActorRef()) { size += com.google.protobuf.CodedOutputStream @@ -2017,7 +2017,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -2084,31 +2084,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -2117,20 +2117,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -2140,7 +2140,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -2149,7 +2149,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -2159,7 +2159,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol)other); @@ -2168,7 +2168,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.SerializedTypedActorRefProtocol.getDefaultInstance()) return this; if (other.hasActorRef()) { @@ -2180,7 +2180,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -2218,8 +2218,8 @@ public final class RemoteProtocol { } } } - - + + // required .SerializedActorRefProtocol actorRef = 1; public boolean hasActorRef() { return result.hasActorRef(); @@ -2256,7 +2256,7 @@ public final class RemoteProtocol { result.actorRef_ = akka.remote.protocol.RemoteProtocol.SerializedActorRefProtocol.getDefaultInstance(); return this; } - + // required string interfaceName = 2; public boolean hasInterfaceName() { return result.hasInterfaceName(); @@ -2277,19 +2277,19 @@ public final class RemoteProtocol { result.interfaceName_ = getDefaultInstance().getInterfaceName(); return this; } - + // @@protoc_insertion_point(builder_scope:SerializedTypedActorRefProtocol) } - + static { defaultInstance = new SerializedTypedActorRefProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:SerializedTypedActorRefProtocol) } - + public static final class MessageProtocol extends com.google.protobuf.GeneratedMessage { // Use MessageProtocol.newBuilder() to construct. @@ -2297,47 +2297,47 @@ public final class RemoteProtocol { initFields(); } private MessageProtocol(boolean noInit) {} - + private static final MessageProtocol defaultInstance; public static MessageProtocol getDefaultInstance() { return defaultInstance; } - + public MessageProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_MessageProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_MessageProtocol_fieldAccessorTable; } - + // required .SerializationSchemeType serializationScheme = 1; public static final int SERIALIZATIONSCHEME_FIELD_NUMBER = 1; private boolean hasSerializationScheme; private akka.remote.protocol.RemoteProtocol.SerializationSchemeType serializationScheme_; public boolean hasSerializationScheme() { return hasSerializationScheme; } public akka.remote.protocol.RemoteProtocol.SerializationSchemeType getSerializationScheme() { return serializationScheme_; } - + // required bytes message = 2; public static final int MESSAGE_FIELD_NUMBER = 2; private boolean hasMessage; private com.google.protobuf.ByteString message_ = com.google.protobuf.ByteString.EMPTY; public boolean hasMessage() { return hasMessage; } public com.google.protobuf.ByteString getMessage() { return message_; } - + // optional bytes messageManifest = 3; public static final int MESSAGEMANIFEST_FIELD_NUMBER = 3; private boolean hasMessageManifest; private com.google.protobuf.ByteString messageManifest_ = com.google.protobuf.ByteString.EMPTY; public boolean hasMessageManifest() { return hasMessageManifest; } public com.google.protobuf.ByteString getMessageManifest() { return messageManifest_; } - + private void initFields() { serializationScheme_ = akka.remote.protocol.RemoteProtocol.SerializationSchemeType.JAVA; } @@ -2346,7 +2346,7 @@ public final class RemoteProtocol { if (!hasMessage) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -2361,12 +2361,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasSerializationScheme()) { size += com.google.protobuf.CodedOutputStream @@ -2384,7 +2384,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.MessageProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -2451,31 +2451,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.MessageProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.MessageProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.MessageProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.MessageProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.MessageProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -2484,20 +2484,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.MessageProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.MessageProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.MessageProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.MessageProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -2507,7 +2507,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.MessageProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -2516,7 +2516,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.MessageProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -2526,7 +2526,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.MessageProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.MessageProtocol)other); @@ -2535,7 +2535,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.MessageProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.MessageProtocol.getDefaultInstance()) return this; if (other.hasSerializationScheme()) { @@ -2550,7 +2550,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -2593,8 +2593,8 @@ public final class RemoteProtocol { } } } - - + + // required .SerializationSchemeType serializationScheme = 1; public boolean hasSerializationScheme() { return result.hasSerializationScheme(); @@ -2615,7 +2615,7 @@ public final class RemoteProtocol { result.serializationScheme_ = akka.remote.protocol.RemoteProtocol.SerializationSchemeType.JAVA; return this; } - + // required bytes message = 2; public boolean hasMessage() { return result.hasMessage(); @@ -2636,7 +2636,7 @@ public final class RemoteProtocol { result.message_ = getDefaultInstance().getMessage(); return this; } - + // optional bytes messageManifest = 3; public boolean hasMessageManifest() { return result.hasMessageManifest(); @@ -2657,19 +2657,19 @@ public final class RemoteProtocol { result.messageManifest_ = getDefaultInstance().getMessageManifest(); return this; } - + // @@protoc_insertion_point(builder_scope:MessageProtocol) } - + static { defaultInstance = new MessageProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:MessageProtocol) } - + public static final class ActorInfoProtocol extends com.google.protobuf.GeneratedMessage { // Use ActorInfoProtocol.newBuilder() to construct. @@ -2677,68 +2677,68 @@ public final class RemoteProtocol { initFields(); } private ActorInfoProtocol(boolean noInit) {} - + private static final ActorInfoProtocol defaultInstance; public static ActorInfoProtocol getDefaultInstance() { return defaultInstance; } - + public ActorInfoProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_ActorInfoProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_ActorInfoProtocol_fieldAccessorTable; } - + // required .UuidProtocol uuid = 1; public static final int UUID_FIELD_NUMBER = 1; private boolean hasUuid; private akka.remote.protocol.RemoteProtocol.UuidProtocol uuid_; public boolean hasUuid() { return hasUuid; } public akka.remote.protocol.RemoteProtocol.UuidProtocol getUuid() { return uuid_; } - + // required string target = 2; public static final int TARGET_FIELD_NUMBER = 2; private boolean hasTarget; private java.lang.String target_ = ""; public boolean hasTarget() { return hasTarget; } public java.lang.String getTarget() { return target_; } - + // required uint64 timeout = 3; public static final int TIMEOUT_FIELD_NUMBER = 3; private boolean hasTimeout; private long timeout_ = 0L; public boolean hasTimeout() { return hasTimeout; } public long getTimeout() { return timeout_; } - + // required .ActorType actorType = 4; public static final int ACTORTYPE_FIELD_NUMBER = 4; private boolean hasActorType; private akka.remote.protocol.RemoteProtocol.ActorType actorType_; public boolean hasActorType() { return hasActorType; } public akka.remote.protocol.RemoteProtocol.ActorType getActorType() { return actorType_; } - + // optional .TypedActorInfoProtocol typedActorInfo = 5; public static final int TYPEDACTORINFO_FIELD_NUMBER = 5; private boolean hasTypedActorInfo; private akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol typedActorInfo_; public boolean hasTypedActorInfo() { return hasTypedActorInfo; } public akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol getTypedActorInfo() { return typedActorInfo_; } - + // optional string id = 6; public static final int ID_FIELD_NUMBER = 6; private boolean hasId; private java.lang.String id_ = ""; public boolean hasId() { return hasId; } public java.lang.String getId() { return id_; } - + private void initFields() { uuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); actorType_ = akka.remote.protocol.RemoteProtocol.ActorType.SCALA_ACTOR; @@ -2755,7 +2755,7 @@ public final class RemoteProtocol { } return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -2779,12 +2779,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasUuid()) { size += com.google.protobuf.CodedOutputStream @@ -2814,7 +2814,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.ActorInfoProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -2881,31 +2881,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.ActorInfoProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.ActorInfoProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.ActorInfoProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.ActorInfoProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.ActorInfoProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -2914,20 +2914,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.ActorInfoProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.ActorInfoProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.ActorInfoProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.ActorInfoProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -2937,7 +2937,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.ActorInfoProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -2946,7 +2946,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.ActorInfoProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -2956,7 +2956,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.ActorInfoProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.ActorInfoProtocol)other); @@ -2965,7 +2965,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.ActorInfoProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.ActorInfoProtocol.getDefaultInstance()) return this; if (other.hasUuid()) { @@ -2989,7 +2989,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -3054,8 +3054,8 @@ public final class RemoteProtocol { } } } - - + + // required .UuidProtocol uuid = 1; public boolean hasUuid() { return result.hasUuid(); @@ -3092,7 +3092,7 @@ public final class RemoteProtocol { result.uuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); return this; } - + // required string target = 2; public boolean hasTarget() { return result.hasTarget(); @@ -3113,7 +3113,7 @@ public final class RemoteProtocol { result.target_ = getDefaultInstance().getTarget(); return this; } - + // required uint64 timeout = 3; public boolean hasTimeout() { return result.hasTimeout(); @@ -3131,7 +3131,7 @@ public final class RemoteProtocol { result.timeout_ = 0L; return this; } - + // required .ActorType actorType = 4; public boolean hasActorType() { return result.hasActorType(); @@ -3152,7 +3152,7 @@ public final class RemoteProtocol { result.actorType_ = akka.remote.protocol.RemoteProtocol.ActorType.SCALA_ACTOR; return this; } - + // optional .TypedActorInfoProtocol typedActorInfo = 5; public boolean hasTypedActorInfo() { return result.hasTypedActorInfo(); @@ -3189,7 +3189,7 @@ public final class RemoteProtocol { result.typedActorInfo_ = akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol.getDefaultInstance(); return this; } - + // optional string id = 6; public boolean hasId() { return result.hasId(); @@ -3210,19 +3210,19 @@ public final class RemoteProtocol { result.id_ = getDefaultInstance().getId(); return this; } - + // @@protoc_insertion_point(builder_scope:ActorInfoProtocol) } - + static { defaultInstance = new ActorInfoProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:ActorInfoProtocol) } - + public static final class TypedActorInfoProtocol extends com.google.protobuf.GeneratedMessage { // Use TypedActorInfoProtocol.newBuilder() to construct. @@ -3230,40 +3230,40 @@ public final class RemoteProtocol { initFields(); } private TypedActorInfoProtocol(boolean noInit) {} - + private static final TypedActorInfoProtocol defaultInstance; public static TypedActorInfoProtocol getDefaultInstance() { return defaultInstance; } - + public TypedActorInfoProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_TypedActorInfoProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_TypedActorInfoProtocol_fieldAccessorTable; } - + // required string interface = 1; public static final int INTERFACE_FIELD_NUMBER = 1; private boolean hasInterface; private java.lang.String interface_ = ""; public boolean hasInterface() { return hasInterface; } public java.lang.String getInterface() { return interface_; } - + // required string method = 2; public static final int METHOD_FIELD_NUMBER = 2; private boolean hasMethod; private java.lang.String method_ = ""; public boolean hasMethod() { return hasMethod; } public java.lang.String getMethod() { return method_; } - + private void initFields() { } public final boolean isInitialized() { @@ -3271,7 +3271,7 @@ public final class RemoteProtocol { if (!hasMethod) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -3283,12 +3283,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasInterface()) { size += com.google.protobuf.CodedOutputStream @@ -3302,7 +3302,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -3369,31 +3369,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -3402,20 +3402,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -3425,7 +3425,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -3434,7 +3434,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -3444,7 +3444,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol)other); @@ -3453,7 +3453,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.TypedActorInfoProtocol.getDefaultInstance()) return this; if (other.hasInterface()) { @@ -3465,7 +3465,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -3498,8 +3498,8 @@ public final class RemoteProtocol { } } } - - + + // required string interface = 1; public boolean hasInterface() { return result.hasInterface(); @@ -3520,7 +3520,7 @@ public final class RemoteProtocol { result.interface_ = getDefaultInstance().getInterface(); return this; } - + // required string method = 2; public boolean hasMethod() { return result.hasMethod(); @@ -3541,19 +3541,19 @@ public final class RemoteProtocol { result.method_ = getDefaultInstance().getMethod(); return this; } - + // @@protoc_insertion_point(builder_scope:TypedActorInfoProtocol) } - + static { defaultInstance = new TypedActorInfoProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:TypedActorInfoProtocol) } - + public static final class RemoteRequestProtocol extends com.google.protobuf.GeneratedMessage { // Use RemoteRequestProtocol.newBuilder() to construct. @@ -3561,68 +3561,68 @@ public final class RemoteProtocol { initFields(); } private RemoteRequestProtocol(boolean noInit) {} - + private static final RemoteRequestProtocol defaultInstance; public static RemoteRequestProtocol getDefaultInstance() { return defaultInstance; } - + public RemoteRequestProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_RemoteRequestProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_RemoteRequestProtocol_fieldAccessorTable; } - + // required .UuidProtocol uuid = 1; public static final int UUID_FIELD_NUMBER = 1; private boolean hasUuid; private akka.remote.protocol.RemoteProtocol.UuidProtocol uuid_; public boolean hasUuid() { return hasUuid; } public akka.remote.protocol.RemoteProtocol.UuidProtocol getUuid() { return uuid_; } - + // required .MessageProtocol message = 2; public static final int MESSAGE_FIELD_NUMBER = 2; private boolean hasMessage; private akka.remote.protocol.RemoteProtocol.MessageProtocol message_; public boolean hasMessage() { return hasMessage; } public akka.remote.protocol.RemoteProtocol.MessageProtocol getMessage() { return message_; } - + // required .ActorInfoProtocol actorInfo = 3; public static final int ACTORINFO_FIELD_NUMBER = 3; private boolean hasActorInfo; private akka.remote.protocol.RemoteProtocol.ActorInfoProtocol actorInfo_; public boolean hasActorInfo() { return hasActorInfo; } public akka.remote.protocol.RemoteProtocol.ActorInfoProtocol getActorInfo() { return actorInfo_; } - + // required bool isOneWay = 4; public static final int ISONEWAY_FIELD_NUMBER = 4; private boolean hasIsOneWay; private boolean isOneWay_ = false; public boolean hasIsOneWay() { return hasIsOneWay; } public boolean getIsOneWay() { return isOneWay_; } - + // optional .UuidProtocol supervisorUuid = 5; public static final int SUPERVISORUUID_FIELD_NUMBER = 5; private boolean hasSupervisorUuid; private akka.remote.protocol.RemoteProtocol.UuidProtocol supervisorUuid_; public boolean hasSupervisorUuid() { return hasSupervisorUuid; } public akka.remote.protocol.RemoteProtocol.UuidProtocol getSupervisorUuid() { return supervisorUuid_; } - + // optional .RemoteActorRefProtocol sender = 6; public static final int SENDER_FIELD_NUMBER = 6; private boolean hasSender; private akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol sender_; public boolean hasSender() { return hasSender; } public akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol getSender() { return sender_; } - + // repeated .MetadataEntryProtocol metadata = 7; public static final int METADATA_FIELD_NUMBER = 7; private java.util.List metadata_ = @@ -3634,14 +3634,14 @@ public final class RemoteProtocol { public akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol getMetadata(int index) { return metadata_.get(index); } - + // optional string cookie = 8; public static final int COOKIE_FIELD_NUMBER = 8; private boolean hasCookie; private java.lang.String cookie_ = ""; public boolean hasCookie() { return hasCookie; } public java.lang.String getCookie() { return cookie_; } - + private void initFields() { uuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); message_ = akka.remote.protocol.RemoteProtocol.MessageProtocol.getDefaultInstance(); @@ -3668,7 +3668,7 @@ public final class RemoteProtocol { } return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -3698,12 +3698,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasUuid()) { size += com.google.protobuf.CodedOutputStream @@ -3741,7 +3741,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -3808,31 +3808,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -3841,20 +3841,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -3864,7 +3864,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -3873,7 +3873,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -3887,7 +3887,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol)other); @@ -3896,7 +3896,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.RemoteRequestProtocol.getDefaultInstance()) return this; if (other.hasUuid()) { @@ -3929,7 +3929,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -4013,8 +4013,8 @@ public final class RemoteProtocol { } } } - - + + // required .UuidProtocol uuid = 1; public boolean hasUuid() { return result.hasUuid(); @@ -4051,7 +4051,7 @@ public final class RemoteProtocol { result.uuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); return this; } - + // required .MessageProtocol message = 2; public boolean hasMessage() { return result.hasMessage(); @@ -4088,7 +4088,7 @@ public final class RemoteProtocol { result.message_ = akka.remote.protocol.RemoteProtocol.MessageProtocol.getDefaultInstance(); return this; } - + // required .ActorInfoProtocol actorInfo = 3; public boolean hasActorInfo() { return result.hasActorInfo(); @@ -4125,7 +4125,7 @@ public final class RemoteProtocol { result.actorInfo_ = akka.remote.protocol.RemoteProtocol.ActorInfoProtocol.getDefaultInstance(); return this; } - + // required bool isOneWay = 4; public boolean hasIsOneWay() { return result.hasIsOneWay(); @@ -4143,7 +4143,7 @@ public final class RemoteProtocol { result.isOneWay_ = false; return this; } - + // optional .UuidProtocol supervisorUuid = 5; public boolean hasSupervisorUuid() { return result.hasSupervisorUuid(); @@ -4180,7 +4180,7 @@ public final class RemoteProtocol { result.supervisorUuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); return this; } - + // optional .RemoteActorRefProtocol sender = 6; public boolean hasSender() { return result.hasSender(); @@ -4217,7 +4217,7 @@ public final class RemoteProtocol { result.sender_ = akka.remote.protocol.RemoteProtocol.RemoteActorRefProtocol.getDefaultInstance(); return this; } - + // repeated .MetadataEntryProtocol metadata = 7; public java.util.List getMetadataList() { return java.util.Collections.unmodifiableList(result.metadata_); @@ -4268,7 +4268,7 @@ public final class RemoteProtocol { result.metadata_ = java.util.Collections.emptyList(); return this; } - + // optional string cookie = 8; public boolean hasCookie() { return result.hasCookie(); @@ -4289,19 +4289,19 @@ public final class RemoteProtocol { result.cookie_ = getDefaultInstance().getCookie(); return this; } - + // @@protoc_insertion_point(builder_scope:RemoteRequestProtocol) } - + static { defaultInstance = new RemoteRequestProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:RemoteRequestProtocol) } - + public static final class RemoteReplyProtocol extends com.google.protobuf.GeneratedMessage { // Use RemoteReplyProtocol.newBuilder() to construct. @@ -4309,68 +4309,68 @@ public final class RemoteProtocol { initFields(); } private RemoteReplyProtocol(boolean noInit) {} - + private static final RemoteReplyProtocol defaultInstance; public static RemoteReplyProtocol getDefaultInstance() { return defaultInstance; } - + public RemoteReplyProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_RemoteReplyProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_RemoteReplyProtocol_fieldAccessorTable; } - + // required .UuidProtocol uuid = 1; public static final int UUID_FIELD_NUMBER = 1; private boolean hasUuid; private akka.remote.protocol.RemoteProtocol.UuidProtocol uuid_; public boolean hasUuid() { return hasUuid; } public akka.remote.protocol.RemoteProtocol.UuidProtocol getUuid() { return uuid_; } - + // optional .MessageProtocol message = 2; public static final int MESSAGE_FIELD_NUMBER = 2; private boolean hasMessage; private akka.remote.protocol.RemoteProtocol.MessageProtocol message_; public boolean hasMessage() { return hasMessage; } public akka.remote.protocol.RemoteProtocol.MessageProtocol getMessage() { return message_; } - + // optional .ExceptionProtocol exception = 3; public static final int EXCEPTION_FIELD_NUMBER = 3; private boolean hasException; private akka.remote.protocol.RemoteProtocol.ExceptionProtocol exception_; public boolean hasException() { return hasException; } public akka.remote.protocol.RemoteProtocol.ExceptionProtocol getException() { return exception_; } - + // optional .UuidProtocol supervisorUuid = 4; public static final int SUPERVISORUUID_FIELD_NUMBER = 4; private boolean hasSupervisorUuid; private akka.remote.protocol.RemoteProtocol.UuidProtocol supervisorUuid_; public boolean hasSupervisorUuid() { return hasSupervisorUuid; } public akka.remote.protocol.RemoteProtocol.UuidProtocol getSupervisorUuid() { return supervisorUuid_; } - + // required bool isActor = 5; public static final int ISACTOR_FIELD_NUMBER = 5; private boolean hasIsActor; private boolean isActor_ = false; public boolean hasIsActor() { return hasIsActor; } public boolean getIsActor() { return isActor_; } - + // required bool isSuccessful = 6; public static final int ISSUCCESSFUL_FIELD_NUMBER = 6; private boolean hasIsSuccessful; private boolean isSuccessful_ = false; public boolean hasIsSuccessful() { return hasIsSuccessful; } public boolean getIsSuccessful() { return isSuccessful_; } - + // repeated .MetadataEntryProtocol metadata = 7; public static final int METADATA_FIELD_NUMBER = 7; private java.util.List metadata_ = @@ -4382,14 +4382,14 @@ public final class RemoteProtocol { public akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol getMetadata(int index) { return metadata_.get(index); } - + // optional string cookie = 8; public static final int COOKIE_FIELD_NUMBER = 8; private boolean hasCookie; private java.lang.String cookie_ = ""; public boolean hasCookie() { return hasCookie; } public java.lang.String getCookie() { return cookie_; } - + private void initFields() { uuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); message_ = akka.remote.protocol.RemoteProtocol.MessageProtocol.getDefaultInstance(); @@ -4415,7 +4415,7 @@ public final class RemoteProtocol { } return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -4445,12 +4445,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasUuid()) { size += com.google.protobuf.CodedOutputStream @@ -4488,7 +4488,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -4555,31 +4555,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -4588,20 +4588,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -4611,7 +4611,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -4620,7 +4620,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -4634,7 +4634,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol)other); @@ -4643,7 +4643,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.RemoteReplyProtocol.getDefaultInstance()) return this; if (other.hasUuid()) { @@ -4676,7 +4676,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -4755,8 +4755,8 @@ public final class RemoteProtocol { } } } - - + + // required .UuidProtocol uuid = 1; public boolean hasUuid() { return result.hasUuid(); @@ -4793,7 +4793,7 @@ public final class RemoteProtocol { result.uuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); return this; } - + // optional .MessageProtocol message = 2; public boolean hasMessage() { return result.hasMessage(); @@ -4830,7 +4830,7 @@ public final class RemoteProtocol { result.message_ = akka.remote.protocol.RemoteProtocol.MessageProtocol.getDefaultInstance(); return this; } - + // optional .ExceptionProtocol exception = 3; public boolean hasException() { return result.hasException(); @@ -4867,7 +4867,7 @@ public final class RemoteProtocol { result.exception_ = akka.remote.protocol.RemoteProtocol.ExceptionProtocol.getDefaultInstance(); return this; } - + // optional .UuidProtocol supervisorUuid = 4; public boolean hasSupervisorUuid() { return result.hasSupervisorUuid(); @@ -4904,7 +4904,7 @@ public final class RemoteProtocol { result.supervisorUuid_ = akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); return this; } - + // required bool isActor = 5; public boolean hasIsActor() { return result.hasIsActor(); @@ -4922,7 +4922,7 @@ public final class RemoteProtocol { result.isActor_ = false; return this; } - + // required bool isSuccessful = 6; public boolean hasIsSuccessful() { return result.hasIsSuccessful(); @@ -4940,7 +4940,7 @@ public final class RemoteProtocol { result.isSuccessful_ = false; return this; } - + // repeated .MetadataEntryProtocol metadata = 7; public java.util.List getMetadataList() { return java.util.Collections.unmodifiableList(result.metadata_); @@ -4991,7 +4991,7 @@ public final class RemoteProtocol { result.metadata_ = java.util.Collections.emptyList(); return this; } - + // optional string cookie = 8; public boolean hasCookie() { return result.hasCookie(); @@ -5012,19 +5012,19 @@ public final class RemoteProtocol { result.cookie_ = getDefaultInstance().getCookie(); return this; } - + // @@protoc_insertion_point(builder_scope:RemoteReplyProtocol) } - + static { defaultInstance = new RemoteReplyProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:RemoteReplyProtocol) } - + public static final class UuidProtocol extends com.google.protobuf.GeneratedMessage { // Use UuidProtocol.newBuilder() to construct. @@ -5032,40 +5032,40 @@ public final class RemoteProtocol { initFields(); } private UuidProtocol(boolean noInit) {} - + private static final UuidProtocol defaultInstance; public static UuidProtocol getDefaultInstance() { return defaultInstance; } - + public UuidProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_UuidProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_UuidProtocol_fieldAccessorTable; } - + // required uint64 high = 1; public static final int HIGH_FIELD_NUMBER = 1; private boolean hasHigh; private long high_ = 0L; public boolean hasHigh() { return hasHigh; } public long getHigh() { return high_; } - + // required uint64 low = 2; public static final int LOW_FIELD_NUMBER = 2; private boolean hasLow; private long low_ = 0L; public boolean hasLow() { return hasLow; } public long getLow() { return low_; } - + private void initFields() { } public final boolean isInitialized() { @@ -5073,7 +5073,7 @@ public final class RemoteProtocol { if (!hasLow) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -5085,12 +5085,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasHigh()) { size += com.google.protobuf.CodedOutputStream @@ -5104,7 +5104,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.UuidProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -5171,31 +5171,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.UuidProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.UuidProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.UuidProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.UuidProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.UuidProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -5204,20 +5204,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.UuidProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.UuidProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.UuidProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -5227,7 +5227,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.UuidProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -5236,7 +5236,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.UuidProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -5246,7 +5246,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.UuidProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.UuidProtocol)other); @@ -5255,7 +5255,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.UuidProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.UuidProtocol.getDefaultInstance()) return this; if (other.hasHigh()) { @@ -5267,7 +5267,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -5300,8 +5300,8 @@ public final class RemoteProtocol { } } } - - + + // required uint64 high = 1; public boolean hasHigh() { return result.hasHigh(); @@ -5319,7 +5319,7 @@ public final class RemoteProtocol { result.high_ = 0L; return this; } - + // required uint64 low = 2; public boolean hasLow() { return result.hasLow(); @@ -5337,19 +5337,19 @@ public final class RemoteProtocol { result.low_ = 0L; return this; } - + // @@protoc_insertion_point(builder_scope:UuidProtocol) } - + static { defaultInstance = new UuidProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:UuidProtocol) } - + public static final class MetadataEntryProtocol extends com.google.protobuf.GeneratedMessage { // Use MetadataEntryProtocol.newBuilder() to construct. @@ -5357,40 +5357,40 @@ public final class RemoteProtocol { initFields(); } private MetadataEntryProtocol(boolean noInit) {} - + private static final MetadataEntryProtocol defaultInstance; public static MetadataEntryProtocol getDefaultInstance() { return defaultInstance; } - + public MetadataEntryProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_MetadataEntryProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_MetadataEntryProtocol_fieldAccessorTable; } - + // required string key = 1; public static final int KEY_FIELD_NUMBER = 1; private boolean hasKey; private java.lang.String key_ = ""; public boolean hasKey() { return hasKey; } public java.lang.String getKey() { return key_; } - + // required bytes value = 2; public static final int VALUE_FIELD_NUMBER = 2; private boolean hasValue; private com.google.protobuf.ByteString value_ = com.google.protobuf.ByteString.EMPTY; public boolean hasValue() { return hasValue; } public com.google.protobuf.ByteString getValue() { return value_; } - + private void initFields() { } public final boolean isInitialized() { @@ -5398,7 +5398,7 @@ public final class RemoteProtocol { if (!hasValue) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -5410,12 +5410,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasKey()) { size += com.google.protobuf.CodedOutputStream @@ -5429,7 +5429,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -5496,31 +5496,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -5529,20 +5529,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -5552,7 +5552,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -5561,7 +5561,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -5571,7 +5571,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol)other); @@ -5580,7 +5580,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.MetadataEntryProtocol.getDefaultInstance()) return this; if (other.hasKey()) { @@ -5592,7 +5592,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -5625,8 +5625,8 @@ public final class RemoteProtocol { } } } - - + + // required string key = 1; public boolean hasKey() { return result.hasKey(); @@ -5647,7 +5647,7 @@ public final class RemoteProtocol { result.key_ = getDefaultInstance().getKey(); return this; } - + // required bytes value = 2; public boolean hasValue() { return result.hasValue(); @@ -5668,19 +5668,19 @@ public final class RemoteProtocol { result.value_ = getDefaultInstance().getValue(); return this; } - + // @@protoc_insertion_point(builder_scope:MetadataEntryProtocol) } - + static { defaultInstance = new MetadataEntryProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:MetadataEntryProtocol) } - + public static final class LifeCycleProtocol extends com.google.protobuf.GeneratedMessage { // Use LifeCycleProtocol.newBuilder() to construct. @@ -5688,33 +5688,33 @@ public final class RemoteProtocol { initFields(); } private LifeCycleProtocol(boolean noInit) {} - + private static final LifeCycleProtocol defaultInstance; public static LifeCycleProtocol getDefaultInstance() { return defaultInstance; } - + public LifeCycleProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_LifeCycleProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_LifeCycleProtocol_fieldAccessorTable; } - + // required .LifeCycleType lifeCycle = 1; public static final int LIFECYCLE_FIELD_NUMBER = 1; private boolean hasLifeCycle; private akka.remote.protocol.RemoteProtocol.LifeCycleType lifeCycle_; public boolean hasLifeCycle() { return hasLifeCycle; } public akka.remote.protocol.RemoteProtocol.LifeCycleType getLifeCycle() { return lifeCycle_; } - + private void initFields() { lifeCycle_ = akka.remote.protocol.RemoteProtocol.LifeCycleType.PERMANENT; } @@ -5722,7 +5722,7 @@ public final class RemoteProtocol { if (!hasLifeCycle) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -5731,12 +5731,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasLifeCycle()) { size += com.google.protobuf.CodedOutputStream @@ -5746,7 +5746,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.LifeCycleProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -5813,31 +5813,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.LifeCycleProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.LifeCycleProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.LifeCycleProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.LifeCycleProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.LifeCycleProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -5846,20 +5846,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.LifeCycleProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.LifeCycleProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.LifeCycleProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.LifeCycleProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -5869,7 +5869,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.LifeCycleProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -5878,7 +5878,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.LifeCycleProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -5888,7 +5888,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.LifeCycleProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.LifeCycleProtocol)other); @@ -5897,7 +5897,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.LifeCycleProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.LifeCycleProtocol.getDefaultInstance()) return this; if (other.hasLifeCycle()) { @@ -5906,7 +5906,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -5941,8 +5941,8 @@ public final class RemoteProtocol { } } } - - + + // required .LifeCycleType lifeCycle = 1; public boolean hasLifeCycle() { return result.hasLifeCycle(); @@ -5963,19 +5963,19 @@ public final class RemoteProtocol { result.lifeCycle_ = akka.remote.protocol.RemoteProtocol.LifeCycleType.PERMANENT; return this; } - + // @@protoc_insertion_point(builder_scope:LifeCycleProtocol) } - + static { defaultInstance = new LifeCycleProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:LifeCycleProtocol) } - + public static final class AddressProtocol extends com.google.protobuf.GeneratedMessage { // Use AddressProtocol.newBuilder() to construct. @@ -5983,40 +5983,40 @@ public final class RemoteProtocol { initFields(); } private AddressProtocol(boolean noInit) {} - + private static final AddressProtocol defaultInstance; public static AddressProtocol getDefaultInstance() { return defaultInstance; } - + public AddressProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_AddressProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_AddressProtocol_fieldAccessorTable; } - + // required string hostname = 1; public static final int HOSTNAME_FIELD_NUMBER = 1; private boolean hasHostname; private java.lang.String hostname_ = ""; public boolean hasHostname() { return hasHostname; } public java.lang.String getHostname() { return hostname_; } - + // required uint32 port = 2; public static final int PORT_FIELD_NUMBER = 2; private boolean hasPort; private int port_ = 0; public boolean hasPort() { return hasPort; } public int getPort() { return port_; } - + private void initFields() { } public final boolean isInitialized() { @@ -6024,7 +6024,7 @@ public final class RemoteProtocol { if (!hasPort) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -6036,12 +6036,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasHostname()) { size += com.google.protobuf.CodedOutputStream @@ -6055,7 +6055,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.AddressProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -6122,31 +6122,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.AddressProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.AddressProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.AddressProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.AddressProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.AddressProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -6155,20 +6155,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.AddressProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.AddressProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.AddressProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.AddressProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -6178,7 +6178,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.AddressProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -6187,7 +6187,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.AddressProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -6197,7 +6197,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.AddressProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.AddressProtocol)other); @@ -6206,7 +6206,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.AddressProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.AddressProtocol.getDefaultInstance()) return this; if (other.hasHostname()) { @@ -6218,7 +6218,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -6251,8 +6251,8 @@ public final class RemoteProtocol { } } } - - + + // required string hostname = 1; public boolean hasHostname() { return result.hasHostname(); @@ -6273,7 +6273,7 @@ public final class RemoteProtocol { result.hostname_ = getDefaultInstance().getHostname(); return this; } - + // required uint32 port = 2; public boolean hasPort() { return result.hasPort(); @@ -6291,19 +6291,19 @@ public final class RemoteProtocol { result.port_ = 0; return this; } - + // @@protoc_insertion_point(builder_scope:AddressProtocol) } - + static { defaultInstance = new AddressProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:AddressProtocol) } - + public static final class ExceptionProtocol extends com.google.protobuf.GeneratedMessage { // Use ExceptionProtocol.newBuilder() to construct. @@ -6311,40 +6311,40 @@ public final class RemoteProtocol { initFields(); } private ExceptionProtocol(boolean noInit) {} - + private static final ExceptionProtocol defaultInstance; public static ExceptionProtocol getDefaultInstance() { return defaultInstance; } - + public ExceptionProtocol getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.remote.protocol.RemoteProtocol.internal_static_ExceptionProtocol_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.remote.protocol.RemoteProtocol.internal_static_ExceptionProtocol_fieldAccessorTable; } - + // required string classname = 1; public static final int CLASSNAME_FIELD_NUMBER = 1; private boolean hasClassname; private java.lang.String classname_ = ""; public boolean hasClassname() { return hasClassname; } public java.lang.String getClassname() { return classname_; } - + // required string message = 2; public static final int MESSAGE_FIELD_NUMBER = 2; private boolean hasMessage; private java.lang.String message_ = ""; public boolean hasMessage() { return hasMessage; } public java.lang.String getMessage() { return message_; } - + private void initFields() { } public final boolean isInitialized() { @@ -6352,7 +6352,7 @@ public final class RemoteProtocol { if (!hasMessage) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -6364,12 +6364,12 @@ public final class RemoteProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasClassname()) { size += com.google.protobuf.CodedOutputStream @@ -6383,7 +6383,7 @@ public final class RemoteProtocol { memoizedSerializedSize = size; return size; } - + public static akka.remote.protocol.RemoteProtocol.ExceptionProtocol parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -6450,31 +6450,31 @@ public final class RemoteProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.remote.protocol.RemoteProtocol.ExceptionProtocol prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.remote.protocol.RemoteProtocol.ExceptionProtocol result; - + // Construct using akka.remote.protocol.RemoteProtocol.ExceptionProtocol.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.remote.protocol.RemoteProtocol.ExceptionProtocol(); return builder; } - + protected akka.remote.protocol.RemoteProtocol.ExceptionProtocol internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -6483,20 +6483,20 @@ public final class RemoteProtocol { result = new akka.remote.protocol.RemoteProtocol.ExceptionProtocol(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.remote.protocol.RemoteProtocol.ExceptionProtocol.getDescriptor(); } - + public akka.remote.protocol.RemoteProtocol.ExceptionProtocol getDefaultInstanceForType() { return akka.remote.protocol.RemoteProtocol.ExceptionProtocol.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -6506,7 +6506,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + private akka.remote.protocol.RemoteProtocol.ExceptionProtocol buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -6515,7 +6515,7 @@ public final class RemoteProtocol { } return buildPartial(); } - + public akka.remote.protocol.RemoteProtocol.ExceptionProtocol buildPartial() { if (result == null) { throw new IllegalStateException( @@ -6525,7 +6525,7 @@ public final class RemoteProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.remote.protocol.RemoteProtocol.ExceptionProtocol) { return mergeFrom((akka.remote.protocol.RemoteProtocol.ExceptionProtocol)other); @@ -6534,7 +6534,7 @@ public final class RemoteProtocol { return this; } } - + public Builder mergeFrom(akka.remote.protocol.RemoteProtocol.ExceptionProtocol other) { if (other == akka.remote.protocol.RemoteProtocol.ExceptionProtocol.getDefaultInstance()) return this; if (other.hasClassname()) { @@ -6546,7 +6546,7 @@ public final class RemoteProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -6579,8 +6579,8 @@ public final class RemoteProtocol { } } } - - + + // required string classname = 1; public boolean hasClassname() { return result.hasClassname(); @@ -6601,7 +6601,7 @@ public final class RemoteProtocol { result.classname_ = getDefaultInstance().getClassname(); return this; } - + // required string message = 2; public boolean hasMessage() { return result.hasMessage(); @@ -6622,19 +6622,19 @@ public final class RemoteProtocol { result.message_ = getDefaultInstance().getMessage(); return this; } - + // @@protoc_insertion_point(builder_scope:ExceptionProtocol) } - + static { defaultInstance = new ExceptionProtocol(true); akka.remote.protocol.RemoteProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:ExceptionProtocol) } - + private static com.google.protobuf.Descriptors.Descriptor internal_static_RemoteActorRefProtocol_descriptor; private static @@ -6705,7 +6705,7 @@ public final class RemoteProtocol { private static com.google.protobuf.GeneratedMessage.FieldAccessorTable internal_static_ExceptionProtocol_fieldAccessorTable; - + public static com.google.protobuf.Descriptors.FileDescriptor getDescriptor() { return descriptor; @@ -6894,8 +6894,8 @@ public final class RemoteProtocol { new com.google.protobuf.Descriptors.FileDescriptor[] { }, assigner); } - + public static void internalForceInit() {} - + // @@protoc_insertion_point(outer_class_scope) } diff --git a/akka-remote/src/main/scala/remote/RemoteServer.scala b/akka-remote/src/main/scala/remote/RemoteServer.scala index dbb33ff50c..6d72a40a40 100644 --- a/akka-remote/src/main/scala/remote/RemoteServer.scala +++ b/akka-remote/src/main/scala/remote/RemoteServer.scala @@ -69,7 +69,7 @@ object RemoteNode extends RemoteServer object RemoteServer { val UUID_PREFIX = "uuid:" - val SECURE_COOKIE: Option[String] = { + val SECURE_COOKIE: Option[String] = { val cookie = config.getString("akka.remote.secure-cookie", "") if (cookie == "") None else Some(cookie) @@ -80,7 +80,7 @@ object RemoteServer { "Configuration option 'akka.remote.server.require-cookie' is turned on but no secure cookie is defined in 'akka.remote.secure-cookie'.") requireCookie } - + val UNTRUSTED_MODE = config.getBool("akka.remote.server.untrusted-mode", false) val HOSTNAME = config.getString("akka.remote.server.hostname", "localhost") val PORT = config.getInt("akka.remote.server.port", 2552) @@ -312,7 +312,7 @@ class RemoteServer extends Logging with ListenerManagement { def unregister(id: String):Unit = synchronized { if (_isRunning) { log.info("Unregistering server side remote actor with id [%s]", id) - if (id.startsWith(UUID_PREFIX)) actorsByUuid.remove(id.substring(UUID_PREFIX.length)) + if (id.startsWith(UUID_PREFIX)) actorsByUuid.remove(id.substring(UUID_PREFIX.length)) else { val actorRef = actors get id actorsByUuid.remove(actorRef.uuid, actorRef) @@ -477,11 +477,11 @@ class RemoteServerHandler( val actorInfo = request.getActorInfo log.debug("Dispatching to remote actor [%s:%s]", actorInfo.getTarget, actorInfo.getUuid) - val actorRef = + val actorRef = try { createActor(actorInfo).start } catch { - case e: SecurityException => + case e: SecurityException => channel.write(createErrorReplyMessage(e, request, true)) server.notifyListeners(RemoteServerError(e, server)) return @@ -493,10 +493,10 @@ class RemoteServerHandler( else None message match { // first match on system messages - case RemoteActorSystemMessage.Stop => + case RemoteActorSystemMessage.Stop => if (RemoteServer.UNTRUSTED_MODE) throw new SecurityException("Remote server is operating is untrusted mode, can not stop the actor") else actorRef.stop - case _: LifeCycleMessage if (RemoteServer.UNTRUSTED_MODE) => + case _: LifeCycleMessage if (RemoteServer.UNTRUSTED_MODE) => throw new SecurityException("Remote server is operating is untrusted mode, can not pass on a LifeCycleMessage to the remote actor") case _ => // then match on user defined messages @@ -613,7 +613,7 @@ class RemoteServerHandler( val timeout = actorInfo.getTimeout val actorRefOrNull = findActorByIdOrUuid(id, uuidFrom(uuid.getHigh,uuid.getLow).toString) - + if (actorRefOrNull eq null) { try { if (RemoteServer.UNTRUSTED_MODE) throw new SecurityException( @@ -687,10 +687,10 @@ class RemoteServerHandler( private def authenticateRemoteClient(request: RemoteRequestProtocol, ctx: ChannelHandlerContext) = { val attachment = ctx.getAttachment - if ((attachment ne null) && - attachment.isInstanceOf[String] && + if ((attachment ne null) && + attachment.isInstanceOf[String] && attachment.asInstanceOf[String] == CHANNEL_INIT) { // is first time around, channel initialization - ctx.setAttachment(null) + ctx.setAttachment(null) val clientAddress = ctx.getChannel.getRemoteAddress.toString if (!request.hasCookie) throw new SecurityException( "The remote client [" + clientAddress + "] does not have a secure cookie.") diff --git a/akka-remote/src/main/scala/serialization/Serializable.scala b/akka-remote/src/main/scala/serialization/Serializable.scala index 79c87f6300..ba46baef1b 100644 --- a/akka-remote/src/main/scala/serialization/Serializable.scala +++ b/akka-remote/src/main/scala/serialization/Serializable.scala @@ -93,7 +93,7 @@ object Serializable { * case class Address(street: String, city: String, zip: String) * extends ScalaJSON[Address] { * - * implicit val AddressFormat: Format[Address] = + * implicit val AddressFormat: Format[Address] = * asProduct3("street", "city", "zip")(Address)(Address.unapply(_).get) * * import dispatch.json._ @@ -113,9 +113,9 @@ object Serializable { * @author Jonas Bonér */ trait ScalaJSON[T] extends JSON { - def toJSON: String + def toJSON: String def fromJSON(js: String): T - def toBytes: Array[Byte] + def toBytes: Array[Byte] def fromBytes(bytes: Array[Byte]): T } } diff --git a/akka-remote/src/main/scala/serialization/SerializationProtocol.scala b/akka-remote/src/main/scala/serialization/SerializationProtocol.scala index a5873f4dc3..fbe89b282f 100644 --- a/akka-remote/src/main/scala/serialization/SerializationProtocol.scala +++ b/akka-remote/src/main/scala/serialization/SerializationProtocol.scala @@ -116,7 +116,7 @@ object ActorSerialization { if (serializeMailBox == true) { - val messages = + val messages = actorRef.mailbox match { case q: java.util.Queue[MessageInvocation] => val l = new scala.collection.mutable.ListBuffer[MessageInvocation] @@ -125,7 +125,7 @@ object ActorSerialization { l } - val requestProtocols = + val requestProtocols = messages.map(m => RemoteActorSerialization.createRemoteRequestProtocolBuilder( actorRef, @@ -172,7 +172,7 @@ object ActorSerialization { if (protocol.hasSupervisor) Some(RemoteActorSerialization.fromProtobufToRemoteActorRef(protocol.getSupervisor, loader)) else None - val hotswap = + val hotswap = if (serializer.isDefined && protocol.hasHotswapStack) serializer.get .fromBinary(protocol.getHotswapStack.toByteArray, Some(classOf[Stack[PartialFunction[Any, Unit]]])) .asInstanceOf[Stack[PartialFunction[Any, Unit]]] diff --git a/akka-remote/src/test/java/akka/actor/ProtobufProtocol.java b/akka-remote/src/test/java/akka/actor/ProtobufProtocol.java index 49d2e028c5..2af5cf564b 100644 --- a/akka-remote/src/test/java/akka/actor/ProtobufProtocol.java +++ b/akka-remote/src/test/java/akka/actor/ProtobufProtocol.java @@ -15,47 +15,47 @@ public final class ProtobufProtocol { initFields(); } private ProtobufPOJO(boolean noInit) {} - + private static final ProtobufPOJO defaultInstance; public static ProtobufPOJO getDefaultInstance() { return defaultInstance; } - + public ProtobufPOJO getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.actor.ProtobufProtocol.internal_static_akka_actor_ProtobufPOJO_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.actor.ProtobufProtocol.internal_static_akka_actor_ProtobufPOJO_fieldAccessorTable; } - + // required uint64 id = 1; public static final int ID_FIELD_NUMBER = 1; private boolean hasId; private long id_ = 0L; public boolean hasId() { return hasId; } public long getId() { return id_; } - + // required string name = 2; public static final int NAME_FIELD_NUMBER = 2; private boolean hasName; private java.lang.String name_ = ""; public boolean hasName() { return hasName; } public java.lang.String getName() { return name_; } - + // required bool status = 3; public static final int STATUS_FIELD_NUMBER = 3; private boolean hasStatus; private boolean status_ = false; public boolean hasStatus() { return hasStatus; } public boolean getStatus() { return status_; } - + private void initFields() { } public final boolean isInitialized() { @@ -64,7 +64,7 @@ public final class ProtobufProtocol { if (!hasStatus) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -79,12 +79,12 @@ public final class ProtobufProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasId()) { size += com.google.protobuf.CodedOutputStream @@ -102,7 +102,7 @@ public final class ProtobufProtocol { memoizedSerializedSize = size; return size; } - + public static akka.actor.ProtobufProtocol.ProtobufPOJO parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -169,31 +169,31 @@ public final class ProtobufProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.actor.ProtobufProtocol.ProtobufPOJO prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.actor.ProtobufProtocol.ProtobufPOJO result; - + // Construct using akka.actor.ProtobufProtocol.ProtobufPOJO.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.actor.ProtobufProtocol.ProtobufPOJO(); return builder; } - + protected akka.actor.ProtobufProtocol.ProtobufPOJO internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -202,20 +202,20 @@ public final class ProtobufProtocol { result = new akka.actor.ProtobufProtocol.ProtobufPOJO(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.actor.ProtobufProtocol.ProtobufPOJO.getDescriptor(); } - + public akka.actor.ProtobufProtocol.ProtobufPOJO getDefaultInstanceForType() { return akka.actor.ProtobufProtocol.ProtobufPOJO.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -225,7 +225,7 @@ public final class ProtobufProtocol { } return buildPartial(); } - + private akka.actor.ProtobufProtocol.ProtobufPOJO buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -234,7 +234,7 @@ public final class ProtobufProtocol { } return buildPartial(); } - + public akka.actor.ProtobufProtocol.ProtobufPOJO buildPartial() { if (result == null) { throw new IllegalStateException( @@ -244,7 +244,7 @@ public final class ProtobufProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.actor.ProtobufProtocol.ProtobufPOJO) { return mergeFrom((akka.actor.ProtobufProtocol.ProtobufPOJO)other); @@ -253,7 +253,7 @@ public final class ProtobufProtocol { return this; } } - + public Builder mergeFrom(akka.actor.ProtobufProtocol.ProtobufPOJO other) { if (other == akka.actor.ProtobufProtocol.ProtobufPOJO.getDefaultInstance()) return this; if (other.hasId()) { @@ -268,7 +268,7 @@ public final class ProtobufProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -305,8 +305,8 @@ public final class ProtobufProtocol { } } } - - + + // required uint64 id = 1; public boolean hasId() { return result.hasId(); @@ -324,7 +324,7 @@ public final class ProtobufProtocol { result.id_ = 0L; return this; } - + // required string name = 2; public boolean hasName() { return result.hasName(); @@ -345,7 +345,7 @@ public final class ProtobufProtocol { result.name_ = getDefaultInstance().getName(); return this; } - + // required bool status = 3; public boolean hasStatus() { return result.hasStatus(); @@ -363,19 +363,19 @@ public final class ProtobufProtocol { result.status_ = false; return this; } - + // @@protoc_insertion_point(builder_scope:akka.actor.ProtobufPOJO) } - + static { defaultInstance = new ProtobufPOJO(true); akka.actor.ProtobufProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:akka.actor.ProtobufPOJO) } - + public static final class Counter extends com.google.protobuf.GeneratedMessage { // Use Counter.newBuilder() to construct. @@ -383,40 +383,40 @@ public final class ProtobufProtocol { initFields(); } private Counter(boolean noInit) {} - + private static final Counter defaultInstance; public static Counter getDefaultInstance() { return defaultInstance; } - + public Counter getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.actor.ProtobufProtocol.internal_static_akka_actor_Counter_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.actor.ProtobufProtocol.internal_static_akka_actor_Counter_fieldAccessorTable; } - + // required uint32 count = 1; public static final int COUNT_FIELD_NUMBER = 1; private boolean hasCount; private int count_ = 0; public boolean hasCount() { return hasCount; } public int getCount() { return count_; } - + private void initFields() { } public final boolean isInitialized() { if (!hasCount) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -425,12 +425,12 @@ public final class ProtobufProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasCount()) { size += com.google.protobuf.CodedOutputStream @@ -440,7 +440,7 @@ public final class ProtobufProtocol { memoizedSerializedSize = size; return size; } - + public static akka.actor.ProtobufProtocol.Counter parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -507,31 +507,31 @@ public final class ProtobufProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.actor.ProtobufProtocol.Counter prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.actor.ProtobufProtocol.Counter result; - + // Construct using akka.actor.ProtobufProtocol.Counter.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.actor.ProtobufProtocol.Counter(); return builder; } - + protected akka.actor.ProtobufProtocol.Counter internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -540,20 +540,20 @@ public final class ProtobufProtocol { result = new akka.actor.ProtobufProtocol.Counter(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.actor.ProtobufProtocol.Counter.getDescriptor(); } - + public akka.actor.ProtobufProtocol.Counter getDefaultInstanceForType() { return akka.actor.ProtobufProtocol.Counter.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -563,7 +563,7 @@ public final class ProtobufProtocol { } return buildPartial(); } - + private akka.actor.ProtobufProtocol.Counter buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -572,7 +572,7 @@ public final class ProtobufProtocol { } return buildPartial(); } - + public akka.actor.ProtobufProtocol.Counter buildPartial() { if (result == null) { throw new IllegalStateException( @@ -582,7 +582,7 @@ public final class ProtobufProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.actor.ProtobufProtocol.Counter) { return mergeFrom((akka.actor.ProtobufProtocol.Counter)other); @@ -591,7 +591,7 @@ public final class ProtobufProtocol { return this; } } - + public Builder mergeFrom(akka.actor.ProtobufProtocol.Counter other) { if (other == akka.actor.ProtobufProtocol.Counter.getDefaultInstance()) return this; if (other.hasCount()) { @@ -600,7 +600,7 @@ public final class ProtobufProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -629,8 +629,8 @@ public final class ProtobufProtocol { } } } - - + + // required uint32 count = 1; public boolean hasCount() { return result.hasCount(); @@ -648,19 +648,19 @@ public final class ProtobufProtocol { result.count_ = 0; return this; } - + // @@protoc_insertion_point(builder_scope:akka.actor.Counter) } - + static { defaultInstance = new Counter(true); akka.actor.ProtobufProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:akka.actor.Counter) } - + public static final class DualCounter extends com.google.protobuf.GeneratedMessage { // Use DualCounter.newBuilder() to construct. @@ -668,40 +668,40 @@ public final class ProtobufProtocol { initFields(); } private DualCounter(boolean noInit) {} - + private static final DualCounter defaultInstance; public static DualCounter getDefaultInstance() { return defaultInstance; } - + public DualCounter getDefaultInstanceForType() { return defaultInstance; } - + public static final com.google.protobuf.Descriptors.Descriptor getDescriptor() { return akka.actor.ProtobufProtocol.internal_static_akka_actor_DualCounter_descriptor; } - + protected com.google.protobuf.GeneratedMessage.FieldAccessorTable internalGetFieldAccessorTable() { return akka.actor.ProtobufProtocol.internal_static_akka_actor_DualCounter_fieldAccessorTable; } - + // required uint32 count1 = 1; public static final int COUNT1_FIELD_NUMBER = 1; private boolean hasCount1; private int count1_ = 0; public boolean hasCount1() { return hasCount1; } public int getCount1() { return count1_; } - + // required uint32 count2 = 2; public static final int COUNT2_FIELD_NUMBER = 2; private boolean hasCount2; private int count2_ = 0; public boolean hasCount2() { return hasCount2; } public int getCount2() { return count2_; } - + private void initFields() { } public final boolean isInitialized() { @@ -709,7 +709,7 @@ public final class ProtobufProtocol { if (!hasCount2) return false; return true; } - + public void writeTo(com.google.protobuf.CodedOutputStream output) throws java.io.IOException { getSerializedSize(); @@ -721,12 +721,12 @@ public final class ProtobufProtocol { } getUnknownFields().writeTo(output); } - + private int memoizedSerializedSize = -1; public int getSerializedSize() { int size = memoizedSerializedSize; if (size != -1) return size; - + size = 0; if (hasCount1()) { size += com.google.protobuf.CodedOutputStream @@ -740,7 +740,7 @@ public final class ProtobufProtocol { memoizedSerializedSize = size; return size; } - + public static akka.actor.ProtobufProtocol.DualCounter parseFrom( com.google.protobuf.ByteString data) throws com.google.protobuf.InvalidProtocolBufferException { @@ -807,31 +807,31 @@ public final class ProtobufProtocol { return newBuilder().mergeFrom(input, extensionRegistry) .buildParsed(); } - + public static Builder newBuilder() { return Builder.create(); } public Builder newBuilderForType() { return newBuilder(); } public static Builder newBuilder(akka.actor.ProtobufProtocol.DualCounter prototype) { return newBuilder().mergeFrom(prototype); } public Builder toBuilder() { return newBuilder(this); } - + public static final class Builder extends com.google.protobuf.GeneratedMessage.Builder { private akka.actor.ProtobufProtocol.DualCounter result; - + // Construct using akka.actor.ProtobufProtocol.DualCounter.newBuilder() private Builder() {} - + private static Builder create() { Builder builder = new Builder(); builder.result = new akka.actor.ProtobufProtocol.DualCounter(); return builder; } - + protected akka.actor.ProtobufProtocol.DualCounter internalGetResult() { return result; } - + public Builder clear() { if (result == null) { throw new IllegalStateException( @@ -840,20 +840,20 @@ public final class ProtobufProtocol { result = new akka.actor.ProtobufProtocol.DualCounter(); return this; } - + public Builder clone() { return create().mergeFrom(result); } - + public com.google.protobuf.Descriptors.Descriptor getDescriptorForType() { return akka.actor.ProtobufProtocol.DualCounter.getDescriptor(); } - + public akka.actor.ProtobufProtocol.DualCounter getDefaultInstanceForType() { return akka.actor.ProtobufProtocol.DualCounter.getDefaultInstance(); } - + public boolean isInitialized() { return result.isInitialized(); } @@ -863,7 +863,7 @@ public final class ProtobufProtocol { } return buildPartial(); } - + private akka.actor.ProtobufProtocol.DualCounter buildParsed() throws com.google.protobuf.InvalidProtocolBufferException { if (!isInitialized()) { @@ -872,7 +872,7 @@ public final class ProtobufProtocol { } return buildPartial(); } - + public akka.actor.ProtobufProtocol.DualCounter buildPartial() { if (result == null) { throw new IllegalStateException( @@ -882,7 +882,7 @@ public final class ProtobufProtocol { result = null; return returnMe; } - + public Builder mergeFrom(com.google.protobuf.Message other) { if (other instanceof akka.actor.ProtobufProtocol.DualCounter) { return mergeFrom((akka.actor.ProtobufProtocol.DualCounter)other); @@ -891,7 +891,7 @@ public final class ProtobufProtocol { return this; } } - + public Builder mergeFrom(akka.actor.ProtobufProtocol.DualCounter other) { if (other == akka.actor.ProtobufProtocol.DualCounter.getDefaultInstance()) return this; if (other.hasCount1()) { @@ -903,7 +903,7 @@ public final class ProtobufProtocol { this.mergeUnknownFields(other.getUnknownFields()); return this; } - + public Builder mergeFrom( com.google.protobuf.CodedInputStream input, com.google.protobuf.ExtensionRegistryLite extensionRegistry) @@ -936,8 +936,8 @@ public final class ProtobufProtocol { } } } - - + + // required uint32 count1 = 1; public boolean hasCount1() { return result.hasCount1(); @@ -955,7 +955,7 @@ public final class ProtobufProtocol { result.count1_ = 0; return this; } - + // required uint32 count2 = 2; public boolean hasCount2() { return result.hasCount2(); @@ -973,19 +973,19 @@ public final class ProtobufProtocol { result.count2_ = 0; return this; } - + // @@protoc_insertion_point(builder_scope:akka.actor.DualCounter) } - + static { defaultInstance = new DualCounter(true); akka.actor.ProtobufProtocol.internalForceInit(); defaultInstance.initFields(); } - + // @@protoc_insertion_point(class_scope:akka.actor.DualCounter) } - + private static com.google.protobuf.Descriptors.Descriptor internal_static_akka_actor_ProtobufPOJO_descriptor; private static @@ -1001,7 +1001,7 @@ public final class ProtobufProtocol { private static com.google.protobuf.GeneratedMessage.FieldAccessorTable internal_static_akka_actor_DualCounter_fieldAccessorTable; - + public static com.google.protobuf.Descriptors.FileDescriptor getDescriptor() { return descriptor; @@ -1053,8 +1053,8 @@ public final class ProtobufProtocol { new com.google.protobuf.Descriptors.FileDescriptor[] { }, assigner); } - + public static void internalForceInit() {} - + // @@protoc_insertion_point(outer_class_scope) } diff --git a/akka-remote/src/test/scala/remote/ClientInitiatedRemoteActorSpec.scala b/akka-remote/src/test/scala/remote/ClientInitiatedRemoteActorSpec.scala index fb68efcb24..e2a2ef69f6 100644 --- a/akka-remote/src/test/scala/remote/ClientInitiatedRemoteActorSpec.scala +++ b/akka-remote/src/test/scala/remote/ClientInitiatedRemoteActorSpec.scala @@ -61,7 +61,7 @@ object ClientInitiatedRemoteActorSpec { var prefix = "default-" var count = 0 def receive = { - case "incrPrefix" => count += 1; prefix = "" + count + "-" + case "incrPrefix" => count += 1; prefix = "" + count + "-" case msg: String => self.reply(prefix + msg) } } diff --git a/akka-remote/src/test/scala/remote/RemoteAgentSpec.scala b/akka-remote/src/test/scala/remote/RemoteAgentSpec.scala index df82850d0d..183158a6dc 100644 --- a/akka-remote/src/test/scala/remote/RemoteAgentSpec.scala +++ b/akka-remote/src/test/scala/remote/RemoteAgentSpec.scala @@ -34,4 +34,4 @@ class RemoteAgentSpec extends JUnitSuite { assert(a() == 20, "Remote agent should be updated properly") a.close } -} \ No newline at end of file +} diff --git a/akka-remote/src/test/scala/remote/ServerInitiatedRemoteActorSpec.scala b/akka-remote/src/test/scala/remote/ServerInitiatedRemoteActorSpec.scala index c91b3745de..ef60732852 100644 --- a/akka-remote/src/test/scala/remote/ServerInitiatedRemoteActorSpec.scala +++ b/akka-remote/src/test/scala/remote/ServerInitiatedRemoteActorSpec.scala @@ -194,7 +194,7 @@ class ServerInitiatedRemoteActorSpec extends JUnitSuite { ref1.stop ref2 ! "OneWay" ref2.stop - + } @Test diff --git a/akka-remote/src/test/scala/serialization/ScalaJSONSerializableSpec.scala b/akka-remote/src/test/scala/serialization/ScalaJSONSerializableSpec.scala index 7ccfc0d9b6..435f94db1c 100644 --- a/akka-remote/src/test/scala/serialization/ScalaJSONSerializableSpec.scala +++ b/akka-remote/src/test/scala/serialization/ScalaJSONSerializableSpec.scala @@ -14,7 +14,7 @@ object Serializables { case class Shop(store: String, item: String, price: Int) extends ScalaJSON[Shop] { - implicit val ShopFormat: sjson.json.Format[Shop] = + implicit val ShopFormat: sjson.json.Format[Shop] = asProduct3("store", "item", "price")(Shop)(Shop.unapply(_).get) def toJSON: String = JsValue.toJson(tojson(this)) @@ -27,7 +27,7 @@ object Serializables { implicit val MyMessageFormat: sjson.json.Format[MyMessage] = asProduct2("id", "value")(MyMessage)(MyMessage.unapply(_).get) - case class MyJsonObject(val key: String, val map: Map[String, Int], + case class MyJsonObject(val key: String, val map: Map[String, Int], val standAloneInt: Int) extends ScalaJSON[MyJsonObject] { implicit val MyJsonObjectFormat: sjson.json.Format[MyJsonObject] = asProduct3("key", "map", "standAloneInt")(MyJsonObject)(MyJsonObject.unapply(_).get) diff --git a/akka-remote/src/test/scala/serialization/ScalaJSONSerializerSpec.scala b/akka-remote/src/test/scala/serialization/ScalaJSONSerializerSpec.scala index 45dc8d5090..f713f6035d 100644 --- a/akka-remote/src/test/scala/serialization/ScalaJSONSerializerSpec.scala +++ b/akka-remote/src/test/scala/serialization/ScalaJSONSerializerSpec.scala @@ -11,15 +11,15 @@ import akka.serialization.Serializer.ScalaJSON object Protocols { import sjson.json.DefaultProtocol._ case class Shop(store: String, item: String, price: Int) - implicit val ShopFormat: sjson.json.Format[Shop] = + implicit val ShopFormat: sjson.json.Format[Shop] = asProduct3("store", "item", "price")(Shop)(Shop.unapply(_).get) case class MyMessage(val id: String, val value: Tuple2[String, Int]) implicit val MyMessageFormat: sjson.json.Format[MyMessage] = asProduct2("id", "value")(MyMessage)(MyMessage.unapply(_).get) - case class MyJsonObject(val key: String, val map: Map[String, Int], - val standAloneInt: Int) + case class MyJsonObject(val key: String, val map: Map[String, Int], + val standAloneInt: Int) implicit val MyJsonObjectFormat: sjson.json.Format[MyJsonObject] = asProduct3("key", "map", "standAloneInt")(MyJsonObject)(MyJsonObject.unapply(_).get) } diff --git a/akka-remote/src/test/scala/serialization/SerializableTypeClassActorSpec.scala b/akka-remote/src/test/scala/serialization/SerializableTypeClassActorSpec.scala index 33e3a54cd0..7d5524bcd2 100644 --- a/akka-remote/src/test/scala/serialization/SerializableTypeClassActorSpec.scala +++ b/akka-remote/src/test/scala/serialization/SerializableTypeClassActorSpec.scala @@ -228,7 +228,7 @@ class MyActorWithDualCounter extends Actor { case "hello" => count = count + 1 self.reply("world " + count) - case "swap" => + case "swap" => become { case "hello" => self.reply("swapped") } } } diff --git a/akka-spring/src/main/scala/ActorBeanDefinitionParser.scala b/akka-spring/src/main/scala/ActorBeanDefinitionParser.scala index f0ca235615..2abb1024d8 100644 --- a/akka-spring/src/main/scala/ActorBeanDefinitionParser.scala +++ b/akka-spring/src/main/scala/ActorBeanDefinitionParser.scala @@ -90,4 +90,4 @@ class ConfigBeanDefinitionParser extends AbstractSingleBeanDefinitionParser with override def getBeanClass(element: Element): Class[_] = classOf[ConfiggyPropertyPlaceholderConfigurer] override def shouldGenerateId() = true -} \ No newline at end of file +} diff --git a/akka-spring/src/main/scala/ActorFactoryBean.scala b/akka-spring/src/main/scala/ActorFactoryBean.scala index c587f12609..d0fac73596 100644 --- a/akka-spring/src/main/scala/ActorFactoryBean.scala +++ b/akka-spring/src/main/scala/ActorFactoryBean.scala @@ -105,7 +105,7 @@ class ActorFactoryBean extends AbstractFactoryBean[AnyRef] with Logging with App if ((implementation eq null) || implementation == "") throw new AkkaBeansException( "The 'implementation' part of the 'akka:typed-actor' element in the Spring config file can't be null or empty string") - val typedActor: AnyRef = TypedActor.newInstance(interface.toClass, implementation.toClass, createConfig) + val typedActor: AnyRef = TypedActor.newInstance(interface.toClass, implementation.toClass, createConfig) if (isRemote && serverManaged) { val server = RemoteServer.getOrCreateServer(new InetSocketAddress(host, port.toInt)) if (serviceName.isEmpty) { diff --git a/akka-spring/src/main/scala/ConfiggyPropertyPlaceholderConfigurer.scala b/akka-spring/src/main/scala/ConfiggyPropertyPlaceholderConfigurer.scala index d6ac5e5d03..e32c331688 100644 --- a/akka-spring/src/main/scala/ConfiggyPropertyPlaceholderConfigurer.scala +++ b/akka-spring/src/main/scala/ConfiggyPropertyPlaceholderConfigurer.scala @@ -9,13 +9,13 @@ import net.lag.configgy.Configgy import java.util.Properties /** - * ConfiggyPropertyPlaceholderConfigurer. Property resource configurer for configgy files. + * ConfiggyPropertyPlaceholderConfigurer. Property resource configurer for configgy files. */ class ConfiggyPropertyPlaceholderConfigurer extends PropertyPlaceholderConfigurer { /** * Sets the akka properties as local properties, leaves the location empty. - * @param configgyResource akka.conf + * @param configgyResource akka.conf */ override def setLocation(configgyResource: Resource) { if (configgyResource eq null) throw new IllegalArgumentException("Property 'config' must be set") @@ -34,4 +34,4 @@ class ConfiggyPropertyPlaceholderConfigurer extends PropertyPlaceholderConfigure properties } -} \ No newline at end of file +} diff --git a/akka-spring/src/main/scala/DispatcherProperties.scala b/akka-spring/src/main/scala/DispatcherProperties.scala index b19309a1a8..8dd33602df 100644 --- a/akka-spring/src/main/scala/DispatcherProperties.scala +++ b/akka-spring/src/main/scala/DispatcherProperties.scala @@ -55,7 +55,7 @@ class ThreadPoolProperties { ", corePoolSize=" + corePoolSize + ", maxPoolSize=" + maxPoolSize + ", keepAlive=" + keepAlive + - ", policy=" + rejectionPolicy + + ", policy=" + rejectionPolicy + ", mailboxCapacity=" + mailboxCapacity + "]" } } diff --git a/akka-spring/src/test/scala/ConfiggyPropertyPlaceholderConfigurerSpec.scala b/akka-spring/src/test/scala/ConfiggyPropertyPlaceholderConfigurerSpec.scala index 852ca88ca5..0c61b18952 100644 --- a/akka-spring/src/test/scala/ConfiggyPropertyPlaceholderConfigurerSpec.scala +++ b/akka-spring/src/test/scala/ConfiggyPropertyPlaceholderConfigurerSpec.scala @@ -39,4 +39,4 @@ class ConfiggyPropertyPlaceholderConfigurerSpec extends FeatureSpec with ShouldM assert(actor1.timeout === 2000) } } -} \ No newline at end of file +} diff --git a/akka-spring/src/test/scala/TypedActorSpringFeatureTest.scala b/akka-spring/src/test/scala/TypedActorSpringFeatureTest.scala index 0f8a316653..faa307db0b 100644 --- a/akka-spring/src/test/scala/TypedActorSpringFeatureTest.scala +++ b/akka-spring/src/test/scala/TypedActorSpringFeatureTest.scala @@ -133,7 +133,7 @@ class TypedActorSpringFeatureTest extends FeatureSpec with ShouldMatchers with B myPojoProxy.oneWay("hello server-managed-remote-typed-actor 2") MyPojo.latch.await assert(MyPojo.lastOneWayMessage === "hello server-managed-remote-typed-actor 2") - } + } scenario("get a client proxy for server-managed-remote-typed-actor") { MyPojo.latch = new CountDownLatch(1) @@ -144,7 +144,7 @@ class TypedActorSpringFeatureTest extends FeatureSpec with ShouldMatchers with B assert(myPojoProxy.getFoo() === "foo") myPojoProxy.oneWay("hello") MyPojo.latch.await - } + } } diff --git a/akka-spring/src/test/scala/UntypedActorSpringFeatureTest.scala b/akka-spring/src/test/scala/UntypedActorSpringFeatureTest.scala index c2bbe7364d..3ae3f09b70 100644 --- a/akka-spring/src/test/scala/UntypedActorSpringFeatureTest.scala +++ b/akka-spring/src/test/scala/UntypedActorSpringFeatureTest.scala @@ -45,7 +45,7 @@ class UntypedActorSpringFeatureTest extends FeatureSpec with ShouldMatchers with } catch { case e => () } - } + } def getPingActorFromContext(config: String, id: String) : ActorRef = { diff --git a/akka-typed-actor/src/main/scala/actor/TypedActor.scala b/akka-typed-actor/src/main/scala/actor/TypedActor.scala index ba9115c22c..46ac719186 100644 --- a/akka-typed-actor/src/main/scala/actor/TypedActor.scala +++ b/akka-typed-actor/src/main/scala/actor/TypedActor.scala @@ -332,7 +332,7 @@ object TypedActorConfiguration { def apply(transactionRequired: Boolean) : TypedActorConfiguration = { if (transactionRequired) { new TypedActorConfiguration().makeTransactionRequired - } else new TypedActorConfiguration() + } else new TypedActorConfiguration() } } @@ -558,7 +558,7 @@ object TypedActor extends Logging { /** * Java API. - */ + */ def newRemoteInstance[T](intfClass: Class[T], factory: TypedActorFactory, hostname: String, port: Int) : T = newRemoteInstance(intfClass, factory.create, hostname, port) @@ -582,7 +582,7 @@ object TypedActor extends Logging { /** * Create a proxy for a RemoteActorRef representing a server managed remote typed actor. - * + * */ private[akka] def createProxyForRemoteActorRef[T](intfClass: Class[T], actorRef: ActorRef): T = { @@ -758,7 +758,7 @@ object TypedActor extends Logging { */ @Aspect("perInstance") private[akka] sealed class ServerManagedTypedActorAspect extends ActorAspect { - + @Around("execution(* *.*(..)) && this(akka.actor.ServerManagedTypedActor)") def invoke(joinPoint: JoinPoint): AnyRef = { if (!isInitialized) initialize(joinPoint) diff --git a/akka-typed-actor/src/test/scala/actor/typed-actor/TypedActorSpec.scala b/akka-typed-actor/src/test/scala/actor/typed-actor/TypedActorSpec.scala index 9a9eb795f6..40a18101cc 100644 --- a/akka-typed-actor/src/test/scala/actor/typed-actor/TypedActorSpec.scala +++ b/akka-typed-actor/src/test/scala/actor/typed-actor/TypedActorSpec.scala @@ -49,7 +49,7 @@ object TypedActorSpec { case msg: String => println("got " + msg) } } - + } diff --git a/config/akka-reference.conf b/config/akka-reference.conf index cfdd5887c6..5650b999bd 100644 --- a/config/akka-reference.conf +++ b/config/akka-reference.conf @@ -7,7 +7,7 @@ akka { version = "1.0-SNAPSHOT" # Akka version, checked against the runtime version of Akka. - + time-unit = "seconds" # Default timeout time unit for all timeout properties throughout the config # These boot classes are loaded (and created) automatically when the Akka Microkernel boots up @@ -54,7 +54,7 @@ akka { # # The following are only used for ExecutorBasedEventDriven # and only if mailbox-capacity > 0 - mailbox-push-timeout-time = 10 # Specifies the timeout to add a new message to a mailbox that is full - negative number means infinite timeout + mailbox-push-timeout-time = 10 # Specifies the timeout to add a new message to a mailbox that is full - negative number means infinite timeout # (in unit defined by the time-unit property) } } @@ -109,7 +109,7 @@ akka { } remote { - + secure-cookie = "050E0A0D0D06010A00000900040D060F0C09060B" # generate your own with '$AKKA_HOME/scripts/generate_secure_cookie.sh' or using 'Crypt.generateSecureCookie' compression-scheme = "zlib" # Options: "zlib" (lzf to come), leave out for no compression @@ -186,7 +186,7 @@ akka { vector = "Vectors" # Voldemort Store Used to Persist Vector Sizes. Use identity serializer for keys, identity serializer for values queue = "Queues" # Voldemort Store Used to Persist Vector Values. Use identity serializer for keys, identity serializer for values } - + client { # The KeyValue pairs under client are converted to java Properties and used to construct the Voldemort ClientConfig bootstrap_urls = "tcp://localhost:6666" # All Valid Voldemort Client properties are valid here, in string form } diff --git a/config/logback-test.xml b/config/logback-test.xml index f678c406ae..0a8d97ad51 100644 --- a/config/logback-test.xml +++ b/config/logback-test.xml @@ -16,10 +16,10 @@ - + - + diff --git a/config/microkernel-server.xml b/config/microkernel-server.xml index c9c97e5c95..987dd22943 100644 --- a/config/microkernel-server.xml +++ b/config/microkernel-server.xml @@ -63,7 +63,7 @@ --> - + @@ -94,4 +94,4 @@ true 1000 - + diff --git a/project/build/AkkaProject.scala b/project/build/AkkaProject.scala index d8a570a7a7..960d1ac892 100644 --- a/project/build/AkkaProject.scala +++ b/project/build/AkkaProject.scala @@ -515,7 +515,7 @@ class AkkaParentProject(info: ProjectInfo) extends DefaultProject(info) { class AkkaCamelProject(info: ProjectInfo) extends AkkaDefaultProject(info, distPath) { val camel_core = Dependencies.camel_core - + override def testOptions = createTestFilter( _.endsWith("Test")) } @@ -690,7 +690,7 @@ class AkkaParentProject(info: ProjectInfo) extends DefaultProject(info) { val atomikos_transactions_jta = Dependencies.atomikos_transactions_jta //val jta_1_1 = Dependencies.jta_1_1 //val atomikos_transactions_util = "com.atomikos" % "transactions-util" % "3.2.3" % "compile" - + //Testing val junit = Dependencies.junit val scalatest = Dependencies.scalatest @@ -767,7 +767,7 @@ class AkkaParentProject(info: ProjectInfo) extends DefaultProject(info) { val commons_fileupload = "commons-fileupload" % "commons-fileupload" % "1.2.1" % "compile" intransitive val jms_1_1 = "org.apache.geronimo.specs" % "geronimo-jms_1.1_spec" % "1.1.1" % "compile" intransitive val joda = "joda-time" % "joda-time" % "1.6" intransitive - + override def packageAction = task { val libs: Seq[Path] = managedClasspath(config("compile")).get.toSeq