From a455f9df6aade4e47bbd8c45a288087ff7716985 Mon Sep 17 00:00:00 2001 From: Shengquan Ni <13672781+shengquan-ni@users.noreply.github.com> Date: Fri, 25 Oct 2024 15:06:28 -0700 Subject: [PATCH 1/4] update --- ...ControllerAsyncRPCHandlerInitializer.scala | 3 - .../controller/ControllerEvent.scala | 6 - .../promisehandlers/ModifyLogicHandler.scala | 53 ---- .../promisehandlers/PauseHandler.scala | 24 +- .../promisehandlers/ReconfigureHandler.scala | 35 --- .../RetryWorkflowHandler.scala | 38 --- .../DataProcessorRPCHandlerInitializer.scala | 3 - .../ControlCommandConvertUtils.scala | 3 - .../QueryCurrentInputTupleHandler.scala | 18 -- .../ShutdownDPThreadHandler.scala | 27 -- .../UpdateExecutorHandler.scala | 67 ----- .../OperatorCurrentTuplesUpdateEvent.scala | 25 -- .../event/TexeraWebSocketEvent.scala | 1 - .../web/service/ExecutionConsoleService.scala | 21 -- .../ExecutionReconfigurationService.scala | 47 ++-- .../FriesReconfigurationAlgorithm.scala | 35 ++- .../partitionings/Partitioning.scala | 116 ++++---- .../controlcommands/ConsoleMessage.scala | 21 +- .../controlcommands/ConsoleMessageType.scala | 2 +- .../controlcommands/ControlCommandV2.scala | 252 +++++++++--------- .../ControlcommandsProto.scala | 5 +- .../worker/controlcommands/LinkOrdinal.scala | 21 +- .../controlreturns/ControlException.scala | 17 +- .../controlreturns/ControlReturnV2.scala | 17 +- .../CurrentInputTupleInfo.scala | 2 +- .../controlreturns/EvaluatedValue.scala | 19 +- .../worker/controlreturns/TypedValue.scala | 17 +- .../statistics/PortTupleCountMapping.scala | 21 +- .../worker/statistics/StatisticsProto.scala | 7 +- .../worker/statistics/WorkerMetrics.scala | 21 +- .../worker/statistics/WorkerState.scala | 2 +- .../worker/statistics/WorkerStatistics.scala | 21 +- .../common/actormessage/ActorCommand.scala | 36 +-- .../actormessage/PythonActorMessage.scala | 21 +- .../ambermessage/ControlPayloadV2.scala | 59 ++-- .../ambermessage/PythonControlMessage.scala | 25 +- .../ambermessage/PythonDataHeader.scala | 21 +- .../ActorVirtualIdentity.scala | 17 +- .../virtualidentity/ChannelIdentity.scala | 25 +- .../ChannelMarkerIdentity.scala | 17 +- .../virtualidentity/ExecutionIdentity.scala | 17 +- .../virtualidentity/OperatorIdentity.scala | 17 +- .../virtualidentity/PhysicalOpIdentity.scala | 21 +- .../virtualidentity/WorkflowIdentity.scala | 17 +- .../engine/common/workflow/InputPort.scala | 23 +- .../engine/common/workflow/OutputPort.scala | 21 +- .../engine/common/workflow/PhysicalLink.scala | 33 +-- .../engine/common/workflow/PortIdentity.scala | 17 +- .../BreakpointFault.scala | 36 +-- .../EvaluatedValueList.scala | 19 +- .../ExecutionBreakpointStore.scala | 36 +-- .../ExecutionConsoleStore.scala | 36 +-- .../ExecutionMetadataStore.scala | 23 +- .../ExecutionStatsStore.scala | 38 +-- .../workflowruntimestate/FatalErrorType.scala | 2 +- .../OperatorBreakpoints.scala | 19 +- .../OperatorConsole.scala | 38 +-- .../OperatorMetrics.scala | 21 +- .../OperatorStatistics.scala | 21 +- .../OperatorWorkerMapping.scala | 19 +- .../WorkflowAggregatedState.scala | 2 +- .../WorkflowFatalError.scala | 21 +- .../WorkflowruntimestateProto.scala | 11 +- 63 files changed, 718 insertions(+), 978 deletions(-) delete mode 100644 core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/ModifyLogicHandler.scala delete mode 100644 core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/ReconfigureHandler.scala delete mode 100644 core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/RetryWorkflowHandler.scala delete mode 100644 core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/QueryCurrentInputTupleHandler.scala delete mode 100644 core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/ShutdownDPThreadHandler.scala delete mode 100644 core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/UpdateExecutorHandler.scala delete mode 100644 core/amber/src/main/scala/edu/uci/ics/texera/web/model/websocket/event/OperatorCurrentTuplesUpdateEvent.scala diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala index 6ecd8d7181e..c4d93193e0b 100644 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala +++ b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala @@ -11,15 +11,12 @@ class ControllerAsyncRPCHandlerInitializer( with AmberLogging with LinkWorkersHandler with WorkerExecutionCompletedHandler - with WorkerStateUpdatedHandler with PauseHandler with QueryWorkerStatisticsHandler with ResumeHandler with StartWorkflowHandler with PortCompletedHandler with ConsoleMessageHandler - with RetryWorkflowHandler - with ModifyLogicHandler with EvaluatePythonExpressionHandler with DebugCommandHandler with TakeGlobalCheckpointHandler diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerEvent.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerEvent.scala index 170405d2816..0d6ad9871c7 100644 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerEvent.scala +++ b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerEvent.scala @@ -1,6 +1,5 @@ package edu.uci.ics.amber.engine.architecture.controller -import edu.uci.ics.amber.engine.common.model.tuple.Tuple import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand import edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity import edu.uci.ics.amber.engine.common.workflowruntimestate.{ @@ -16,11 +15,6 @@ object ControllerEvent { operatorMetrics: Map[String, OperatorMetrics] ) extends ControlCommand[Unit] - case class ReportCurrentProcessingTuple( - operatorID: String, - tuple: Array[(Tuple, ActorVirtualIdentity)] - ) extends ControlCommand[Unit] - case class WorkerAssignmentUpdate(workerMapping: Map[String, Seq[String]]) extends ControlCommand[Unit] diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/ModifyLogicHandler.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/ModifyLogicHandler.scala deleted file mode 100644 index 31603ac97e4..00000000000 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/ModifyLogicHandler.scala +++ /dev/null @@ -1,53 +0,0 @@ -package edu.uci.ics.amber.engine.architecture.controller.promisehandlers - -import com.twitter.util.Future -import edu.uci.ics.amber.engine.architecture.controller.ControllerAsyncRPCHandlerInitializer -import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ConsoleMessageHandler.ConsoleMessageTriggered -import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ModifyLogicHandler.ModifyLogic -import edu.uci.ics.amber.engine.architecture.pythonworker.promisehandlers.UpdatePythonExecutorHandler.UpdatePythonExecutor -import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.UpdateExecutorHandler.UpdateExecutor -import edu.uci.ics.amber.engine.common.model.PhysicalOp -import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand -import edu.uci.ics.amber.error.ErrorUtils.mkConsoleMessage -import edu.uci.ics.texera.workflow.common.operators.StateTransferFunc - -object ModifyLogicHandler { - - final case class ModifyLogic(newOp: PhysicalOp, stateTransferFunc: Option[StateTransferFunc]) - extends ControlCommand[Unit] -} - -/** retry the execution of the entire workflow - * - * possible sender: controller, client - */ -trait ModifyLogicHandler { - this: ControllerAsyncRPCHandlerInitializer => - - registerHandler[ModifyLogic, Unit] { (msg, sender) => - { - val operator = cp.workflowScheduler.physicalPlan.getOperator(msg.newOp.id) - val opExecution = cp.workflowExecution.getRunningRegionExecutions - .map(_.getOperatorExecution(msg.newOp.id)) - .head - val workerCommand = if (operator.isPythonBased) { - UpdatePythonExecutor( - msg.newOp.getPythonCode, - isSource = operator.isSourceOperator - ) - } else { - UpdateExecutor(msg.newOp, msg.stateTransferFunc) - } - Future - .collect(opExecution.getWorkerIds.map { worker => - send(workerCommand, worker).onFailure((err: Throwable) => { - logger.error("Failure when performing reconfiguration", err) - // report error to frontend - val errorEvt = ConsoleMessageTriggered(mkConsoleMessage(actorId, err)) - sendToClient(errorEvt) - }) - }.toSeq) - .unit - } - } -} diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/PauseHandler.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/PauseHandler.scala index 6ac1ddf749f..cc72278b276 100644 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/PauseHandler.scala +++ b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/PauseHandler.scala @@ -3,19 +3,13 @@ package edu.uci.ics.amber.engine.architecture.controller.promisehandlers import com.twitter.util.Future import edu.uci.ics.amber.engine.architecture.controller.ControllerEvent.{ ExecutionStateUpdate, - ExecutionStatsUpdate, - ReportCurrentProcessingTuple + ExecutionStatsUpdate } import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.PauseHandler.PauseWorkflow import edu.uci.ics.amber.engine.architecture.controller.ControllerAsyncRPCHandlerInitializer import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.PauseHandler.PauseWorker -import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.QueryCurrentInputTupleHandler.QueryCurrentInputTuple import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.QueryStatisticsHandler.QueryStatistics -import edu.uci.ics.amber.engine.common.model.tuple.Tuple import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand -import edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity - -import scala.collection.mutable object PauseHandler { @@ -38,9 +32,6 @@ trait PauseHandler { .flatMap(_.getAllOperatorExecutions) .map { case (physicalOpId, opExecution) => - // create a buffer for the current input tuple - // since we need to show them on the frontend - val buffer = mutable.ArrayBuffer[(Tuple, ActorVirtualIdentity)]() Future .collect( opExecution.getWorkerIds @@ -52,22 +43,13 @@ trait PauseHandler { send(PauseWorker(), worker).flatMap { state => workerExecution.setState(state) send(QueryStatistics(), worker) - .join(send(QueryCurrentInputTuple(), worker)) // get the stats and current input tuple from the worker - .map { - case (metrics, tuple) => - workerExecution.setStats(metrics.workerStatistics) - buffer.append((tuple, worker)) + .map { metrics => + workerExecution.setStats(metrics.workerStatistics) } } }.toSeq ) - .map { _ => - // for each paused operator, send the input tuple - sendToClient( - ReportCurrentProcessingTuple(physicalOpId.logicalOpId.id, buffer.toArray) - ) - } } .toSeq ) diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/ReconfigureHandler.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/ReconfigureHandler.scala deleted file mode 100644 index d907e4947c4..00000000000 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/ReconfigureHandler.scala +++ /dev/null @@ -1,35 +0,0 @@ -package edu.uci.ics.amber.engine.architecture.controller.promisehandlers - -import edu.uci.ics.amber.engine.architecture.controller.ControllerAsyncRPCHandlerInitializer -import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ReconfigureHandler.Reconfigure -import edu.uci.ics.amber.engine.common.model.PhysicalOp -import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand -import edu.uci.ics.amber.engine.common.virtualidentity.util.SELF -import edu.uci.ics.texera.web.service.FriesReconfigurationAlgorithm -import edu.uci.ics.texera.workflow.common.operators.StateTransferFunc - -object ReconfigureHandler { - - final case class Reconfigure( - reconfigurations: List[(PhysicalOp, Option[StateTransferFunc])], - reconfigurationId: String - ) extends ControlCommand[Unit] - -} - -trait ReconfigureHandler { - this: ControllerAsyncRPCHandlerInitializer => - - registerHandler[Reconfigure, Unit] { (msg, sender) => - { - val epochMarkers = FriesReconfigurationAlgorithm.scheduleReconfigurations( - cp.workflowExecutionCoordinator, - msg.reconfigurations, - msg.reconfigurationId - ) - epochMarkers.foreach(epoch => { - send(epoch, SELF) - }) - } - } -} diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/RetryWorkflowHandler.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/RetryWorkflowHandler.scala deleted file mode 100644 index 256b96fcd8c..00000000000 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/RetryWorkflowHandler.scala +++ /dev/null @@ -1,38 +0,0 @@ -package edu.uci.ics.amber.engine.architecture.controller.promisehandlers - -import com.twitter.util.Future -import edu.uci.ics.amber.engine.architecture.controller.ControllerAsyncRPCHandlerInitializer -import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ResumeHandler.ResumeWorkflow -import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.RetryWorkflowHandler.RetryWorkflow -import edu.uci.ics.amber.engine.architecture.pythonworker.promisehandlers.ReplayCurrentTupleHandler.ReplayCurrentTuple -import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand -import edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity -import edu.uci.ics.amber.engine.common.virtualidentity.util.CONTROLLER - -object RetryWorkflowHandler { - final case class RetryWorkflow(workers: Seq[ActorVirtualIdentity]) extends ControlCommand[Unit] -} - -/** retry the execution of the entire workflow - * - * possible sender: controller, client - */ -trait RetryWorkflowHandler { - this: ControllerAsyncRPCHandlerInitializer => - - registerHandler { (msg: RetryWorkflow, sender) => - { - // if it is a PythonWorker, prepare for retry - // retry message has no effect on completed workers - Future - .collect( - msg.workers - .map(worker => send(ReplayCurrentTuple(), worker)) - ) - .unit - - // resume all workers - execute(ResumeWorkflow(), CONTROLLER) - } - } -} diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/DataProcessorRPCHandlerInitializer.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/DataProcessorRPCHandlerInitializer.scala index 5286139ea09..fb11c047076 100644 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/DataProcessorRPCHandlerInitializer.scala +++ b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/DataProcessorRPCHandlerInitializer.scala @@ -12,15 +12,12 @@ class DataProcessorRPCHandlerInitializer(val dp: DataProcessor) with OpenExecutorHandler with PauseHandler with AddPartitioningHandler - with QueryCurrentInputTupleHandler with QueryStatisticsHandler with ResumeHandler with StartHandler with AssignPortHandler with AddInputChannelHandler - with ShutdownDPThreadHandler with FlushNetworkBufferHandler - with UpdateExecutorHandler with RetrieveStateHandler with PrepareCheckpointHandler with FinalizeCheckpointHandler { diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandConvertUtils.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandConvertUtils.scala index c0352215680..119daaea666 100644 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandConvertUtils.scala +++ b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandConvertUtils.scala @@ -17,7 +17,6 @@ import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.AddPartition import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.AssignPortHandler.AssignPort import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.OpenExecutorHandler.OpenExecutor import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.PauseHandler.PauseWorker -import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.QueryCurrentInputTupleHandler.QueryCurrentInputTuple import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.QueryStatisticsHandler.QueryStatistics import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.ResumeHandler.ResumeWorker import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.StartHandler.StartWorker @@ -48,8 +47,6 @@ object ControlCommandConvertUtils { AddInputChannelV2(channelId, portId) case QueryStatistics() => QueryStatisticsV2() - case QueryCurrentInputTuple() => - QueryCurrentInputTupleV2() case InitializeExecutor(_, opExecInitInfo, isSource) => val (code, language) = opExecInitInfo.asInstanceOf[OpExecInitInfoWithCode].codeGen(0, 0) InitializeExecutorV2( diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/QueryCurrentInputTupleHandler.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/QueryCurrentInputTupleHandler.scala deleted file mode 100644 index 804574a2704..00000000000 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/QueryCurrentInputTupleHandler.scala +++ /dev/null @@ -1,18 +0,0 @@ -package edu.uci.ics.amber.engine.architecture.worker.promisehandlers - -import edu.uci.ics.amber.engine.architecture.worker.DataProcessorRPCHandlerInitializer -import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.QueryCurrentInputTupleHandler.QueryCurrentInputTuple -import edu.uci.ics.amber.engine.common.model.tuple.Tuple -import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand - -object QueryCurrentInputTupleHandler { - final case class QueryCurrentInputTuple() extends ControlCommand[Tuple] -} - -trait QueryCurrentInputTupleHandler { - this: DataProcessorRPCHandlerInitializer => - - registerHandler { (msg: QueryCurrentInputTuple, sender) => - dp.inputManager.getCurrentTuple - } -} diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/ShutdownDPThreadHandler.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/ShutdownDPThreadHandler.scala deleted file mode 100644 index 52f54c1e7ba..00000000000 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/ShutdownDPThreadHandler.scala +++ /dev/null @@ -1,27 +0,0 @@ -package edu.uci.ics.amber.engine.architecture.worker.promisehandlers - -import edu.uci.ics.amber.engine.architecture.worker.{DataProcessorRPCHandlerInitializer} -import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.ShutdownDPThreadHandler.ShutdownDPThread -import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand - -import java.util.concurrent.CompletableFuture - -object ShutdownDPThreadHandler { - final case class ShutdownDPThread() extends ControlCommand[Unit] { - @transient - val completed = new CompletableFuture[Unit]() - } -} - -trait ShutdownDPThreadHandler { - this: DataProcessorRPCHandlerInitializer => - - registerHandler { (msg: ShutdownDPThread, sender) => - { - msg.completed.complete(()) - throw new InterruptedException() // actively interrupt itself - () - } - } - -} diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/UpdateExecutorHandler.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/UpdateExecutorHandler.scala deleted file mode 100644 index e1be72728cc..00000000000 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/worker/promisehandlers/UpdateExecutorHandler.scala +++ /dev/null @@ -1,67 +0,0 @@ -package edu.uci.ics.amber.engine.architecture.worker.promisehandlers - -import edu.uci.ics.amber.engine.architecture.deploysemantics.layer.{ - OpExecInitInfoWithCode, - OpExecInitInfoWithFunc -} -import edu.uci.ics.amber.engine.architecture.worker.DataProcessorRPCHandlerInitializer -import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.UpdateExecutorHandler.{ - UpdateExecutor, - UpdateExecutorCompleted, - UpdateMultipleExecutors -} -import edu.uci.ics.amber.engine.common.VirtualIdentityUtils -import edu.uci.ics.amber.engine.common.model.PhysicalOp -import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand -import edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity -import edu.uci.ics.texera.workflow.common.operators.StateTransferFunc - -object UpdateExecutorHandler { - case class UpdateExecutor( - physicalOp: PhysicalOp, - stateTransferFunc: Option[StateTransferFunc] - ) extends ControlCommand[Unit] - - case class UpdateMultipleExecutors(executorsToUpdate: List[UpdateExecutor]) - extends ControlCommand[Unit] - - case class UpdateExecutorCompleted(workerId: ActorVirtualIdentity) extends ControlCommand[Unit] -} - -/** Get queue and other resource usage of this worker - * - * possible sender: controller(by ControllerInitiateMonitoring) - */ -trait UpdateExecutorHandler { - this: DataProcessorRPCHandlerInitializer => - - registerHandler { (msg: UpdateExecutor, _) => - performUpdateExecutor(msg) - sendToClient(UpdateExecutorCompleted(this.actorId)) - } - - registerHandler { (msg: UpdateMultipleExecutors, _) => - msg.executorsToUpdate - .find(_.physicalOp.id == VirtualIdentityUtils.getPhysicalOpId(actorId)) - .foreach { executorToUpdate => - performUpdateExecutor(executorToUpdate) - sendToClient(UpdateExecutorCompleted(this.actorId)) - } - } - - private def performUpdateExecutor(updateExecutor: UpdateExecutor): Unit = { - val oldOpExecState = dp.executor - dp.executor = updateExecutor.physicalOp.opExecInitInfo match { - case OpExecInitInfoWithCode(codeGen) => - ??? // TODO: compile and load java/scala operator here - case OpExecInitInfoWithFunc(opGen) => - opGen(VirtualIdentityUtils.getWorkerIndex(actorId), 1) - } - - if (updateExecutor.stateTransferFunc.nonEmpty) { - updateExecutor.stateTransferFunc.get.apply(oldOpExecState, dp.executor) - } - dp.executor.open() - } - -} diff --git a/core/amber/src/main/scala/edu/uci/ics/texera/web/model/websocket/event/OperatorCurrentTuplesUpdateEvent.scala b/core/amber/src/main/scala/edu/uci/ics/texera/web/model/websocket/event/OperatorCurrentTuplesUpdateEvent.scala deleted file mode 100644 index 82b3f6b1b6f..00000000000 --- a/core/amber/src/main/scala/edu/uci/ics/texera/web/model/websocket/event/OperatorCurrentTuplesUpdateEvent.scala +++ /dev/null @@ -1,25 +0,0 @@ -package edu.uci.ics.texera.web.model.websocket.event - -import edu.uci.ics.amber.engine.architecture.controller.ControllerEvent.ReportCurrentProcessingTuple -import edu.uci.ics.texera.web.model.websocket.event.OperatorCurrentTuplesUpdateEvent.WorkerTuples - -object OperatorCurrentTuplesUpdateEvent { - def apply(report: ReportCurrentProcessingTuple): OperatorCurrentTuplesUpdateEvent = { - val workerTuples = report.tuple - .map(p => { - val workerName = p._2.toString; - if (p._1 == null) { - WorkerTuples(workerName, List.empty) - } else { - WorkerTuples(workerName, p._1.getFields.map(v => v.toString).toList) - } - }) - .filter(tuples => tuples.tuple != null && tuples.tuple.nonEmpty) - .toList - OperatorCurrentTuplesUpdateEvent(report.operatorID, workerTuples) - } - case class WorkerTuples(workerID: String, tuple: List[String]) -} - -case class OperatorCurrentTuplesUpdateEvent(operatorID: String, tuples: List[WorkerTuples]) - extends TexeraWebSocketEvent diff --git a/core/amber/src/main/scala/edu/uci/ics/texera/web/model/websocket/event/TexeraWebSocketEvent.scala b/core/amber/src/main/scala/edu/uci/ics/texera/web/model/websocket/event/TexeraWebSocketEvent.scala index 4b0e7600a43..5d21d02c5c6 100644 --- a/core/amber/src/main/scala/edu/uci/ics/texera/web/model/websocket/event/TexeraWebSocketEvent.scala +++ b/core/amber/src/main/scala/edu/uci/ics/texera/web/model/websocket/event/TexeraWebSocketEvent.scala @@ -15,7 +15,6 @@ import edu.uci.ics.texera.web.model.websocket.response.{HeartBeatResponse, Modif new Type(value = classOf[OperatorStatisticsUpdateEvent]), new Type(value = classOf[WebResultUpdateEvent]), new Type(value = classOf[ConsoleUpdateEvent]), - new Type(value = classOf[OperatorCurrentTuplesUpdateEvent]), new Type(value = classOf[CacheStatusUpdateEvent]), new Type(value = classOf[PaginatedResultEvent]), new Type(value = classOf[PythonExpressionEvaluateResponse]), diff --git a/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionConsoleService.scala b/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionConsoleService.scala index c1823f646be..e348b4d2f99 100644 --- a/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionConsoleService.scala +++ b/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionConsoleService.scala @@ -5,7 +5,6 @@ import com.twitter.util.{Await, Duration} import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ConsoleMessageHandler.ConsoleMessageTriggered import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.EvaluatePythonExpressionHandler.EvaluatePythonExpression import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.DebugCommandHandler.DebugCommand -import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.RetryWorkflowHandler.RetryWorkflow import edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage import edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessageType.COMMAND import edu.uci.ics.amber.engine.common.{AmberConfig, VirtualIdentityUtils} @@ -13,18 +12,12 @@ import edu.uci.ics.amber.engine.common.client.AmberClient import edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity import edu.uci.ics.texera.web.model.websocket.event.TexeraWebSocketEvent import edu.uci.ics.texera.web.model.websocket.event.python.ConsoleUpdateEvent -import edu.uci.ics.texera.web.model.websocket.request.RetryRequest import edu.uci.ics.texera.web.model.websocket.request.python.{ DebugCommandRequest, PythonExpressionEvaluateRequest } import edu.uci.ics.texera.web.model.websocket.response.python.PythonExpressionEvaluateResponse import edu.uci.ics.texera.web.storage.ExecutionStateStore -import edu.uci.ics.texera.web.storage.ExecutionStateStore.updateWorkflowState -import edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowAggregatedState.{ - RESUMING, - RUNNING -} import edu.uci.ics.amber.engine.common.workflowruntimestate.{ EvaluatedValueList, ExecutionConsoleStore, @@ -107,20 +100,6 @@ class ExecutionConsoleService( } } - //Receive retry request - addSubscription(wsInput.subscribe((req: RetryRequest, uidOpt) => { - stateStore.metadataStore.updateState(metadataStore => - updateWorkflowState(RESUMING, metadataStore) - ) - client.sendAsyncWithCallback[Unit]( - RetryWorkflow(req.workers.map(x => ActorVirtualIdentity(x))), - _ => - stateStore.metadataStore.updateState(metadataStore => - updateWorkflowState(RUNNING, metadataStore) - ) - ) - })) - //Receive evaluate python expression addSubscription(wsInput.subscribe((req: PythonExpressionEvaluateRequest, uidOpt) => { val result = Await.result( diff --git a/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionReconfigurationService.scala b/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionReconfigurationService.scala index 0a3a11487c1..fe3d2fb3006 100644 --- a/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionReconfigurationService.scala +++ b/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionReconfigurationService.scala @@ -1,10 +1,6 @@ package edu.uci.ics.texera.web.service import edu.uci.ics.amber.engine.architecture.controller.Workflow -import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ReconfigureHandler.Reconfigure -import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ModifyLogicHandler.ModifyLogic -import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.UpdateExecutorHandler.UpdateExecutorCompleted -import edu.uci.ics.amber.engine.common.AmberConfig import edu.uci.ics.amber.engine.common.client.AmberClient import edu.uci.ics.texera.web.SubscriptionManager import edu.uci.ics.texera.web.model.websocket.event.TexeraWebSocketEvent @@ -13,9 +9,8 @@ import edu.uci.ics.texera.web.model.websocket.response.{ ModifyLogicCompletedEvent, ModifyLogicResponse } -import edu.uci.ics.texera.web.storage.{ExecutionReconfigurationStore, ExecutionStateStore} +import edu.uci.ics.texera.web.storage.ExecutionStateStore -import java.util.UUID import scala.util.{Failure, Success} class ExecutionReconfigurationService( @@ -25,11 +20,11 @@ class ExecutionReconfigurationService( ) extends SubscriptionManager { // monitors notification from the engine that a reconfiguration on a worker is completed - client.registerCallback[UpdateExecutorCompleted]((evt: UpdateExecutorCompleted) => { - stateStore.reconfigurationStore.updateState(old => { - old.copy(completedReconfigurations = old.completedReconfigurations + evt.workerId) - }) - }) +// client.registerCallback[UpdateExecutorCompleted]((evt: UpdateExecutorCompleted) => { +// stateStore.reconfigurationStore.updateState(old => { +// old.copy(completedReconfigurations = old.completedReconfigurations + evt.workerId) +// }) +// }) // monitors the reconfiguration state (completed workers) change, // notifies the frontend when all workers of an operator complete reconfiguration @@ -92,20 +87,20 @@ class ExecutionReconfigurationService( if (reconfigurations.isEmpty) { return } - - // schedule all pending reconfigurations to the engine - val reconfigurationId = UUID.randomUUID().toString - if (!AmberConfig.enableTransactionalReconfiguration) { - reconfigurations.foreach(reconfig => { - client.sendAsync(ModifyLogic(reconfig._1, reconfig._2)) - }) - } else { - client.sendAsync(Reconfigure(reconfigurations, reconfigurationId)) - - // clear all un-scheduled reconfigurations, start a new reconfiguration ID - stateStore.reconfigurationStore.updateState(_ => - ExecutionReconfigurationStore(Some(reconfigurationId)) - ) - } + throw new RuntimeException("reconfiguration is tentatively disabled.") +// // schedule all pending reconfigurations to the engine +// val reconfigurationId = UUID.randomUUID().toString +// if (!AmberConfig.enableTransactionalReconfiguration) { +// reconfigurations.foreach(reconfig => { +// client.sendAsync(ModifyLogic(reconfig._1, reconfig._2)) +// }) +// } else { +// client.sendAsync(Reconfigure(reconfigurations, reconfigurationId)) +// +// // clear all un-scheduled reconfigurations, start a new reconfiguration ID +// stateStore.reconfigurationStore.updateState(_ => +// ExecutionReconfigurationStore(Some(reconfigurationId)) +// ) +// } } } diff --git a/core/amber/src/main/scala/edu/uci/ics/texera/web/service/FriesReconfigurationAlgorithm.scala b/core/amber/src/main/scala/edu/uci/ics/texera/web/service/FriesReconfigurationAlgorithm.scala index f4b31bb2f14..8af2641e40a 100644 --- a/core/amber/src/main/scala/edu/uci/ics/texera/web/service/FriesReconfigurationAlgorithm.scala +++ b/core/amber/src/main/scala/edu/uci/ics/texera/web/service/FriesReconfigurationAlgorithm.scala @@ -2,13 +2,8 @@ package edu.uci.ics.texera.web.service import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ChannelMarkerHandler.PropagateChannelMarker import edu.uci.ics.amber.engine.architecture.scheduling.{Region, WorkflowExecutionCoordinator} -import edu.uci.ics.amber.engine.architecture.worker.promisehandlers.UpdateExecutorHandler.{ - UpdateExecutor, - UpdateMultipleExecutors -} -import edu.uci.ics.amber.engine.common.ambermessage.RequireAlignment import edu.uci.ics.amber.engine.common.model.{PhysicalOp, PhysicalPlan} -import edu.uci.ics.amber.engine.common.virtualidentity.{ChannelMarkerIdentity, PhysicalOpIdentity} +import edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity import edu.uci.ics.texera.workflow.common.operators.StateTransferFunc import org.jgrapht.alg.connectivity.ConnectivityInspector @@ -93,22 +88,22 @@ object FriesReconfigurationAlgorithm { val componentPlan = mcsPlan.getSubPlan(componentSet) // generate the reconfiguration command for this component - val reconfigCommand = UpdateMultipleExecutors( - reconfigurations - .filter(o => component.contains(o._1.id)) - .map(o => UpdateExecutor(o._1, o._2)) - ) +// val reconfigCommand = UpdateMultipleExecutors( +// reconfigurations +// .filter(o => component.contains(o._1.id)) +// .map(o => UpdateExecutor(o._1, o._2)) +// ) // find the source operators of the component - val sources = componentSet.intersect(mcsPlan.getSourceOperatorIds) - epochMarkers += PropagateChannelMarker( - sources, - ChannelMarkerIdentity(epochMarkerId), - RequireAlignment, - componentPlan, - reconfigurations.map(_._1.id).toSet, - reconfigCommand - ) +// val sources = componentSet.intersect(mcsPlan.getSourceOperatorIds) +// epochMarkers += PropagateChannelMarker( +// sources, +// ChannelMarkerIdentity(epochMarkerId), +// RequireAlignment, +// componentPlan, +// reconfigurations.map(_._1.id).toSet, +// reconfigCommand +// ) }) epochMarkers.toList diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/sendsemantics/partitionings/Partitioning.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/sendsemantics/partitionings/Partitioning.scala index 219a232353b..704d15fc3c1 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/sendsemantics/partitionings/Partitioning.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/sendsemantics/partitionings/Partitioning.scala @@ -43,8 +43,8 @@ final case class PartitioningMessage( sealedValue: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage.SealedValue ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PartitioningMessage] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 if (sealedValue.oneToOnePartitioning.isDefined) { val __value = sealedValue.oneToOnePartitioning.get @@ -69,12 +69,13 @@ final case class PartitioningMessage( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { sealedValue.oneToOnePartitioning.foreach { __v => @@ -140,7 +141,7 @@ final case class PartitioningMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage + def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage def toPartitioning: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.PartitioningTypeMapper.toCustom(this) // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.Partitioning]) } @@ -289,8 +290,8 @@ final case class OneToOnePartitioning( channels: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[OneToOnePartitioning] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -306,12 +307,13 @@ final case class OneToOnePartitioning( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -329,7 +331,7 @@ final case class OneToOnePartitioning( } def withBatchSize(__v: _root_.scala.Int): OneToOnePartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): OneToOnePartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): OneToOnePartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): OneToOnePartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): OneToOnePartitioning = copy(channels = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -349,7 +351,7 @@ final case class OneToOnePartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.OneToOnePartitioning + def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.OneToOnePartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.OneToOnePartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.OneToOnePartitioning]) } @@ -421,8 +423,8 @@ final case class RoundRobinPartitioning( channels: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[RoundRobinPartitioning] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -438,12 +440,13 @@ final case class RoundRobinPartitioning( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -461,7 +464,7 @@ final case class RoundRobinPartitioning( } def withBatchSize(__v: _root_.scala.Int): RoundRobinPartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): RoundRobinPartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): RoundRobinPartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): RoundRobinPartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): RoundRobinPartitioning = copy(channels = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -481,7 +484,7 @@ final case class RoundRobinPartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RoundRobinPartitioning + def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RoundRobinPartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RoundRobinPartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.RoundRobinPartitioning]) } @@ -554,8 +557,8 @@ final case class HashBasedShufflePartitioning( hashAttributeNames: _root_.scala.Seq[_root_.scala.Predef.String] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[HashBasedShufflePartitioning] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -575,12 +578,13 @@ final case class HashBasedShufflePartitioning( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -602,11 +606,11 @@ final case class HashBasedShufflePartitioning( } def withBatchSize(__v: _root_.scala.Int): HashBasedShufflePartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): HashBasedShufflePartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): HashBasedShufflePartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): HashBasedShufflePartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): HashBasedShufflePartitioning = copy(channels = __v) def clearHashAttributeNames = copy(hashAttributeNames = _root_.scala.Seq.empty) - def addHashAttributeNames(__vs: _root_.scala.Predef.String*): HashBasedShufflePartitioning = addAllHashAttributeNames(__vs) + def addHashAttributeNames(__vs: _root_.scala.Predef.String *): HashBasedShufflePartitioning = addAllHashAttributeNames(__vs) def addAllHashAttributeNames(__vs: Iterable[_root_.scala.Predef.String]): HashBasedShufflePartitioning = copy(hashAttributeNames = hashAttributeNames ++ __vs) def withHashAttributeNames(__v: _root_.scala.Seq[_root_.scala.Predef.String]): HashBasedShufflePartitioning = copy(hashAttributeNames = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -628,7 +632,7 @@ final case class HashBasedShufflePartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.HashBasedShufflePartitioning + def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.HashBasedShufflePartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.HashBasedShufflePartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.HashBasedShufflePartitioning]) } @@ -713,8 +717,8 @@ final case class RangeBasedShufflePartitioning( rangeMax: _root_.scala.Long ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[RangeBasedShufflePartitioning] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -748,12 +752,13 @@ final case class RangeBasedShufflePartitioning( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -787,11 +792,11 @@ final case class RangeBasedShufflePartitioning( } def withBatchSize(__v: _root_.scala.Int): RangeBasedShufflePartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): RangeBasedShufflePartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): RangeBasedShufflePartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): RangeBasedShufflePartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): RangeBasedShufflePartitioning = copy(channels = __v) def clearRangeAttributeNames = copy(rangeAttributeNames = _root_.scala.Seq.empty) - def addRangeAttributeNames(__vs: _root_.scala.Predef.String*): RangeBasedShufflePartitioning = addAllRangeAttributeNames(__vs) + def addRangeAttributeNames(__vs: _root_.scala.Predef.String *): RangeBasedShufflePartitioning = addAllRangeAttributeNames(__vs) def addAllRangeAttributeNames(__vs: Iterable[_root_.scala.Predef.String]): RangeBasedShufflePartitioning = copy(rangeAttributeNames = rangeAttributeNames ++ __vs) def withRangeAttributeNames(__v: _root_.scala.Seq[_root_.scala.Predef.String]): RangeBasedShufflePartitioning = copy(rangeAttributeNames = __v) def withRangeMin(__v: _root_.scala.Long): RangeBasedShufflePartitioning = copy(rangeMin = __v) @@ -825,7 +830,7 @@ final case class RangeBasedShufflePartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RangeBasedShufflePartitioning + def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RangeBasedShufflePartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RangeBasedShufflePartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.RangeBasedShufflePartitioning]) } @@ -927,8 +932,8 @@ final case class BroadcastPartitioning( channels: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[BroadcastPartitioning] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -944,12 +949,13 @@ final case class BroadcastPartitioning( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -967,7 +973,7 @@ final case class BroadcastPartitioning( } def withBatchSize(__v: _root_.scala.Int): BroadcastPartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): BroadcastPartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): BroadcastPartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): BroadcastPartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): BroadcastPartitioning = copy(channels = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -987,7 +993,7 @@ final case class BroadcastPartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.BroadcastPartitioning + def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.BroadcastPartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.BroadcastPartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.BroadcastPartitioning]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessage.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessage.scala index 72c44619a9a..c212263a9c2 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessage.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessage.scala @@ -15,8 +15,8 @@ final case class ConsoleMessage( message: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ConsoleMessage] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -28,7 +28,7 @@ final case class ConsoleMessage( { val __value = timestamp - if (__value != com.google.protobuf.timestamp.Timestamp.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -63,12 +63,13 @@ final case class ConsoleMessage( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -79,7 +80,7 @@ final case class ConsoleMessage( }; { val __v = timestamp - if (__v != com.google.protobuf.timestamp.Timestamp.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -156,7 +157,7 @@ final case class ConsoleMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ConsoleMessage]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessageType.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessageType.scala index dbd62bedf62..54ac513d22c 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessageType.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessageType.scala @@ -18,6 +18,7 @@ sealed abstract class ConsoleMessageType(val value: _root_.scala.Int) extends _r object ConsoleMessageType extends _root_.scalapb.GeneratedEnumCompanion[ConsoleMessageType] { sealed trait Recognized extends ConsoleMessageType implicit def enumCompanion: _root_.scalapb.GeneratedEnumCompanion[ConsoleMessageType] = this + @SerialVersionUID(0L) case object PRINT extends ConsoleMessageType(0) with ConsoleMessageType.Recognized { val index = 0 @@ -48,7 +49,6 @@ object ConsoleMessageType extends _root_.scalapb.GeneratedEnumCompanion[ConsoleM @SerialVersionUID(0L) final case class Unrecognized(unrecognizedValue: _root_.scala.Int) extends ConsoleMessageType(unrecognizedValue) with _root_.scalapb.UnrecognizedEnum - lazy val values = scala.collection.immutable.Seq(PRINT, ERROR, COMMAND, DEBUGGER) def fromValue(__value: _root_.scala.Int): ConsoleMessageType = __value match { case 0 => PRINT diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandV2.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandV2.scala index 1333742daf0..79499755eae 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandV2.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandV2.scala @@ -71,8 +71,8 @@ final case class ControlCommandV2Message( sealedValue: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message.SealedValue ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ControlCommandV2Message] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 if (sealedValue.startWorker.isDefined) { val __value = sealedValue.startWorker.get @@ -153,12 +153,13 @@ final case class ControlCommandV2Message( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { sealedValue.startWorker.foreach { __v => @@ -364,7 +365,7 @@ final case class ControlCommandV2Message( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message def toControlCommandV2: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2 = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.ControlCommandV2TypeMapper.toCustom(this) // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ControlCommandV2]) } @@ -726,7 +727,7 @@ final case class StartWorkerV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.StartWorkerV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.StartWorkerV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.StartWorkerV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.StartWorkerV2]) } @@ -775,7 +776,7 @@ final case class PauseWorkerV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PauseWorkerV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.PauseWorkerV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PauseWorkerV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.PauseWorkerV2]) } @@ -824,7 +825,7 @@ final case class ResumeWorkerV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ResumeWorkerV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ResumeWorkerV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ResumeWorkerV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ResumeWorkerV2]) } @@ -871,13 +872,13 @@ final case class AssignPortV2( schema: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, _root_.scala.Predef.String] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[AssignPortV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = portId - if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -895,17 +896,18 @@ final case class AssignPortV2( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = portId - if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -927,7 +929,7 @@ final case class AssignPortV2( def withPortId(__v: edu.uci.ics.amber.engine.common.workflow.PortIdentity): AssignPortV2 = copy(portId = __v) def withInput(__v: _root_.scala.Boolean): AssignPortV2 = copy(input = __v) def clearSchema = copy(schema = _root_.scala.collection.immutable.Map.empty) - def addSchema(__vs: (_root_.scala.Predef.String, _root_.scala.Predef.String)*): AssignPortV2 = addAllSchema(__vs) + def addSchema(__vs: (_root_.scala.Predef.String, _root_.scala.Predef.String) *): AssignPortV2 = addAllSchema(__vs) def addAllSchema(__vs: Iterable[(_root_.scala.Predef.String, _root_.scala.Predef.String)]): AssignPortV2 = copy(schema = schema ++ __vs) def withSchema(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, _root_.scala.Predef.String]): AssignPortV2 = copy(schema = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -952,7 +954,7 @@ final case class AssignPortV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.AssignPortV2]) } @@ -1018,8 +1020,8 @@ object AssignPortV2 extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amber. value: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[SchemaEntry] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -1038,12 +1040,13 @@ object AssignPortV2 extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amber. __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -1081,7 +1084,7 @@ object AssignPortV2 extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amber. } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2.SchemaEntry + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2.SchemaEntry.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2.SchemaEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.AssignPortV2.SchemaEntry]) } @@ -1172,37 +1175,38 @@ final case class AddPartitioningV2( partitioning: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[AddPartitioningV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = tag - if (__value != edu.uci.ics.amber.engine.common.workflow.PhysicalLink.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2._typemapper_partitioning.toBase(partitioning) - if (__value != edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = tag - if (__v != edu.uci.ics.amber.engine.common.workflow.PhysicalLink.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1210,7 +1214,7 @@ final case class AddPartitioningV2( }; { val __v = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2._typemapper_partitioning.toBase(partitioning) - if (__v != edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1239,7 +1243,7 @@ final case class AddPartitioningV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.AddPartitioningV2]) } @@ -1314,37 +1318,38 @@ final case class AddInputChannelV2( portId: edu.uci.ics.amber.engine.common.workflow.PortIdentity ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[AddInputChannelV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = channelId - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = portId - if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = channelId - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1352,7 +1357,7 @@ final case class AddInputChannelV2( }; { val __v = portId - if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1381,7 +1386,7 @@ final case class AddInputChannelV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddInputChannelV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddInputChannelV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddInputChannelV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.AddInputChannelV2]) } @@ -1457,7 +1462,7 @@ final case class QueryStatisticsV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryStatisticsV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryStatisticsV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryStatisticsV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.QueryStatisticsV2]) } @@ -1506,7 +1511,7 @@ final case class QueryCurrentInputTupleV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryCurrentInputTupleV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryCurrentInputTupleV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryCurrentInputTupleV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.QueryCurrentInputTupleV2]) } @@ -1555,7 +1560,7 @@ final case class OpenExecutorV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.OpenExecutorV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.OpenExecutorV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.OpenExecutorV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.OpenExecutorV2]) } @@ -1601,13 +1606,13 @@ final case class PortCompletedV2( input: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[PortCompletedV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = portId - if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -1621,17 +1626,18 @@ final case class PortCompletedV2( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = portId - if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1666,7 +1672,7 @@ final case class PortCompletedV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PortCompletedV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.PortCompletedV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PortCompletedV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.PortCompletedV2]) } @@ -1737,8 +1743,8 @@ final case class SchedulerTimeSlotEventV2( timeSlotExpired: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[SchedulerTimeSlotEventV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -1750,12 +1756,13 @@ final case class SchedulerTimeSlotEventV2( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -1781,7 +1788,7 @@ final case class SchedulerTimeSlotEventV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.SchedulerTimeSlotEventV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.SchedulerTimeSlotEventV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.SchedulerTimeSlotEventV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.SchedulerTimeSlotEventV2]) } @@ -1838,8 +1845,8 @@ final case class InitializeExecutorV2( isSource: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[InitializeExecutorV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -1865,12 +1872,13 @@ final case class InitializeExecutorV2( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -1920,7 +1928,7 @@ final case class InitializeExecutorV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.InitializeExecutorV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.InitializeExecutorV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.InitializeExecutorV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.InitializeExecutorV2]) } @@ -1996,8 +2004,8 @@ final case class UpdateExecutorV2( isSource: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[UpdateExecutorV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -2016,12 +2024,13 @@ final case class UpdateExecutorV2( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -2059,7 +2068,7 @@ final case class UpdateExecutorV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.UpdateExecutorV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.UpdateExecutorV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.UpdateExecutorV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.UpdateExecutorV2]) } @@ -2124,30 +2133,31 @@ final case class PythonConsoleMessageV2( message: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[PythonConsoleMessageV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = message - if (__value != edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = message - if (__v != edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -2170,7 +2180,7 @@ final case class PythonConsoleMessageV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PythonConsoleMessageV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.PythonConsoleMessageV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PythonConsoleMessageV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.PythonConsoleMessageV2]) } @@ -2235,7 +2245,7 @@ final case class ReplayCurrentTupleV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ReplayCurrentTupleV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ReplayCurrentTupleV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ReplayCurrentTupleV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ReplayCurrentTupleV2]) } @@ -2280,8 +2290,8 @@ final case class EvaluateExpressionV2( expression: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[EvaluateExpressionV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -2293,12 +2303,13 @@ final case class EvaluateExpressionV2( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -2324,7 +2335,7 @@ final case class EvaluateExpressionV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.EvaluateExpressionV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.EvaluateExpressionV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.EvaluateExpressionV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.EvaluateExpressionV2]) } @@ -2379,8 +2390,8 @@ final case class WorkerDebugCommandV2( cmd: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[WorkerDebugCommandV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -2392,12 +2403,13 @@ final case class WorkerDebugCommandV2( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -2423,7 +2435,7 @@ final case class WorkerDebugCommandV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerDebugCommandV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerDebugCommandV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerDebugCommandV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.WorkerDebugCommandV2]) } @@ -2482,7 +2494,7 @@ final case class WorkerExecutionCompletedV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerExecutionCompletedV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerExecutionCompletedV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerExecutionCompletedV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.WorkerExecutionCompletedV2]) } @@ -2531,7 +2543,7 @@ final case class NoOpV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.NoOpV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.NoOpV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.NoOpV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.NoOpV2]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlcommandsProto.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlcommandsProto.scala index d2c71617e83..273ceb5655f 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlcommandsProto.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlcommandsProto.scala @@ -108,8 +108,9 @@ object ControlcommandsProto extends _root_.scalapb.GeneratedFileObject { XBsZXRlZBhlIAEoCzJILmVkdS51Y2kuaWNzLmFtYmVyLmVuZ2luZS5hcmNoaXRlY3R1cmUud29ya2VyLldvcmtlckV4ZWN1dGlvb kNvbXBsZXRlZFYyQh3iPxoSGHdvcmtlckV4ZWN1dGlvbkNvbXBsZXRlZEgAUhh3b3JrZXJFeGVjdXRpb25Db21wbGV0ZWQSVwoFb m9fb3AYj04gASgLMjQuZWR1LnVjaS5pY3MuYW1iZXIuZW5naW5lLmFyY2hpdGVjdHVyZS53b3JrZXIuTm9PcFYyQgniPwYSBG5vT - 3BIAFIEbm9PcEIOCgxzZWFsZWRfdmFsdWUqRQoSQ29uc29sZU1lc3NhZ2VUeXBlEgkKBVBSSU5UEAASCQoFRVJST1IQARILCgdDT - 01NQU5EEAISDAoIREVCVUdHRVIQA0IJ4j8GSABYAHgBYgZwcm90bzM=""" + 3BIAFIEbm9PcEIOCgxzZWFsZWRfdmFsdWUqegoSQ29uc29sZU1lc3NhZ2VUeXBlEhUKBVBSSU5UEAAaCuI/BxIFUFJJTlQSFQoFR + VJST1IQARoK4j8HEgVFUlJPUhIZCgdDT01NQU5EEAIaDOI/CRIHQ09NTUFORBIbCghERUJVR0dFUhADGg3iPwoSCERFQlVHR0VSQ + gniPwZIAFgAeAFiBnByb3RvMw==""" ).mkString) lazy val scalaDescriptor: _root_.scalapb.descriptors.FileDescriptor = { val scalaProto = com.google.protobuf.descriptor.FileDescriptorProto.parseFrom(ProtoBytes) diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/LinkOrdinal.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/LinkOrdinal.scala index a4d35e4b32b..5100ef4067a 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/LinkOrdinal.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/LinkOrdinal.scala @@ -11,13 +11,13 @@ final case class LinkOrdinal( portOrdinal: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[LinkOrdinal] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = link - if (__value != edu.uci.ics.amber.engine.common.workflow.PhysicalLink.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -31,17 +31,18 @@ final case class LinkOrdinal( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = link - if (__v != edu.uci.ics.amber.engine.common.workflow.PhysicalLink.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -76,7 +77,7 @@ final case class LinkOrdinal( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.LinkOrdinal + def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.LinkOrdinal.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.LinkOrdinal // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.LinkOrdinal]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlException.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlException.scala index 2663cb2b113..ea646de6306 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlException.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlException.scala @@ -10,8 +10,8 @@ final case class ControlException( msg: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ControlException] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -23,12 +23,13 @@ final case class ControlException( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -54,7 +55,7 @@ final case class ControlException( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlException + def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlException.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlException // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ControlException]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlReturnV2.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlReturnV2.scala index 2b772db787f..e1219f24715 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlReturnV2.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlReturnV2.scala @@ -10,8 +10,8 @@ final case class ControlReturnV2( value: edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2.Value ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ControlReturnV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 if (value.controlException.isDefined) { val __value = value.controlException.get @@ -36,12 +36,13 @@ final case class ControlReturnV2( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { value.controlException.foreach { __v => @@ -105,7 +106,7 @@ final case class ControlReturnV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2 + def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ControlReturnV2]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/CurrentInputTupleInfo.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/CurrentInputTupleInfo.scala index d35580c38f5..1efec257a3d 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/CurrentInputTupleInfo.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/CurrentInputTupleInfo.scala @@ -14,7 +14,7 @@ final case class CurrentInputTupleInfo( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.CurrentInputTupleInfo + def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.CurrentInputTupleInfo.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.CurrentInputTupleInfo // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.CurrentInputTupleInfo]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/EvaluatedValue.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/EvaluatedValue.scala index 48f844d2d06..efa427e0914 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/EvaluatedValue.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/EvaluatedValue.scala @@ -11,8 +11,8 @@ final case class EvaluatedValue( attributes: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue] ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[EvaluatedValue] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 if (value.isDefined) { val __value = value.get @@ -25,12 +25,13 @@ final case class EvaluatedValue( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { value.foreach { __v => @@ -50,7 +51,7 @@ final case class EvaluatedValue( def clearValue: EvaluatedValue = copy(value = _root_.scala.None) def withValue(__v: edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue): EvaluatedValue = copy(value = Option(__v)) def clearAttributes = copy(attributes = _root_.scala.Seq.empty) - def addAttributes(__vs: edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue*): EvaluatedValue = addAllAttributes(__vs) + def addAttributes(__vs: edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue *): EvaluatedValue = addAllAttributes(__vs) def addAllAttributes(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue]): EvaluatedValue = copy(attributes = attributes ++ __vs) def withAttributes(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue]): EvaluatedValue = copy(attributes = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -67,7 +68,7 @@ final case class EvaluatedValue( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue + def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.EvaluatedValue]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/TypedValue.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/TypedValue.scala index 388be4a87bf..7e94957bd0e 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/TypedValue.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/TypedValue.scala @@ -14,8 +14,8 @@ final case class TypedValue( expandable: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[TypedValue] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -55,12 +55,13 @@ final case class TypedValue( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -134,7 +135,7 @@ final case class TypedValue( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue + def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.TypedValue]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/PortTupleCountMapping.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/PortTupleCountMapping.scala index fa56edca692..3895efd6186 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/PortTupleCountMapping.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/PortTupleCountMapping.scala @@ -11,13 +11,13 @@ final case class PortTupleCountMapping( tupleCount: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PortTupleCountMapping] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = portId - if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -31,17 +31,18 @@ final case class PortTupleCountMapping( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = portId - if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -76,7 +77,7 @@ final case class PortTupleCountMapping( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping + def companion: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping.type = edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.PortTupleCountMapping]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/StatisticsProto.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/StatisticsProto.scala index d3641aa2e22..fccb81a1c69 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/StatisticsProto.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/StatisticsProto.scala @@ -32,9 +32,10 @@ object StatisticsProto extends _root_.scalapb.GeneratedFileObject { hIIaWRsZVRpbWVSCGlkbGVUaW1lIooCCg1Xb3JrZXJNZXRyaWNzEnEKDHdvcmtlcl9zdGF0ZRgBIAEoDjI5LmVkdS51Y2kuaWNzL mFtYmVyLmVuZ2luZS5hcmNoaXRlY3R1cmUud29ya2VyLldvcmtlclN0YXRlQhPiPxASC3dvcmtlclN0YXRl8AEBUgt3b3JrZXJTd GF0ZRKFAQoRd29ya2VyX3N0YXRpc3RpY3MYAiABKAsyPi5lZHUudWNpLmljcy5hbWJlci5lbmdpbmUuYXJjaGl0ZWN0dXJlLndvc - mtlci5Xb3JrZXJTdGF0aXN0aWNzQhjiPxUSEHdvcmtlclN0YXRpc3RpY3PwAQFSEHdvcmtlclN0YXRpc3RpY3MqUwoLV29ya2VyU - 3RhdGUSEQoNVU5JTklUSUFMSVpFRBAAEgkKBVJFQURZEAESCwoHUlVOTklORxACEgoKBlBBVVNFRBADEg0KCUNPTVBMRVRFRBAEQ - gniPwZIAFgAeAFiBnByb3RvMw==""" + mtlci5Xb3JrZXJTdGF0aXN0aWNzQhjiPxUSEHdvcmtlclN0YXRpc3RpY3PwAQFSEHdvcmtlclN0YXRpc3RpY3MqngEKC1dvcmtlc + lN0YXRlEiUKDVVOSU5JVElBTElaRUQQABoS4j8PEg1VTklOSVRJQUxJWkVEEhUKBVJFQURZEAEaCuI/BxIFUkVBRFkSGQoHUlVOT + klORxACGgziPwkSB1JVTk5JTkcSFwoGUEFVU0VEEAMaC+I/CBIGUEFVU0VEEh0KCUNPTVBMRVRFRBAEGg7iPwsSCUNPTVBMRVRFR + EIJ4j8GSABYAHgBYgZwcm90bzM=""" ).mkString) lazy val scalaDescriptor: _root_.scalapb.descriptors.FileDescriptor = { val scalaProto = com.google.protobuf.descriptor.FileDescriptorProto.parseFrom(ProtoBytes) diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerMetrics.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerMetrics.scala index ff9b953816b..80da6c8ca52 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerMetrics.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerMetrics.scala @@ -11,8 +11,8 @@ final case class WorkerMetrics( workerStatistics: edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[WorkerMetrics] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -24,19 +24,20 @@ final case class WorkerMetrics( { val __value = workerStatistics - if (__value != edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -47,7 +48,7 @@ final case class WorkerMetrics( }; { val __v = workerStatistics - if (__v != edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -76,7 +77,7 @@ final case class WorkerMetrics( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerMetrics + def companion: edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerMetrics.type = edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerMetrics // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.WorkerMetrics]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerState.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerState.scala index 8fa537dff62..0a4d506f505 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerState.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerState.scala @@ -19,6 +19,7 @@ sealed abstract class WorkerState(val value: _root_.scala.Int) extends _root_.sc object WorkerState extends _root_.scalapb.GeneratedEnumCompanion[WorkerState] { sealed trait Recognized extends WorkerState implicit def enumCompanion: _root_.scalapb.GeneratedEnumCompanion[WorkerState] = this + @SerialVersionUID(0L) case object UNINITIALIZED extends WorkerState(0) with WorkerState.Recognized { val index = 0 @@ -56,7 +57,6 @@ object WorkerState extends _root_.scalapb.GeneratedEnumCompanion[WorkerState] { @SerialVersionUID(0L) final case class Unrecognized(unrecognizedValue: _root_.scala.Int) extends WorkerState(unrecognizedValue) with _root_.scalapb.UnrecognizedEnum - lazy val values = scala.collection.immutable.Seq(UNINITIALIZED, READY, RUNNING, PAUSED, COMPLETED) def fromValue(__value: _root_.scala.Int): WorkerState = __value match { case 0 => UNINITIALIZED diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerStatistics.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerStatistics.scala index f90c3c166ff..63c2de8b30d 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerStatistics.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerStatistics.scala @@ -14,8 +14,8 @@ final case class WorkerStatistics( idleTime: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[WorkerStatistics] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 inputTupleCount.foreach { __item => val __value = __item @@ -49,12 +49,13 @@ final case class WorkerStatistics( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { inputTupleCount.foreach { __v => @@ -89,11 +90,11 @@ final case class WorkerStatistics( }; } def clearInputTupleCount = copy(inputTupleCount = _root_.scala.Seq.empty) - def addInputTupleCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping*): WorkerStatistics = addAllInputTupleCount(__vs) + def addInputTupleCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping *): WorkerStatistics = addAllInputTupleCount(__vs) def addAllInputTupleCount(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): WorkerStatistics = copy(inputTupleCount = inputTupleCount ++ __vs) def withInputTupleCount(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): WorkerStatistics = copy(inputTupleCount = __v) def clearOutputTupleCount = copy(outputTupleCount = _root_.scala.Seq.empty) - def addOutputTupleCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping*): WorkerStatistics = addAllOutputTupleCount(__vs) + def addOutputTupleCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping *): WorkerStatistics = addAllOutputTupleCount(__vs) def addAllOutputTupleCount(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): WorkerStatistics = copy(outputTupleCount = outputTupleCount ++ __vs) def withOutputTupleCount(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): WorkerStatistics = copy(outputTupleCount = __v) def withDataProcessingTime(__v: _root_.scala.Long): WorkerStatistics = copy(dataProcessingTime = __v) @@ -128,7 +129,7 @@ final case class WorkerStatistics( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics + def companion: edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics.type = edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.WorkerStatistics]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/ActorCommand.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/ActorCommand.scala index db9e024e44e..53f0368a9a0 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/ActorCommand.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/ActorCommand.scala @@ -37,8 +37,8 @@ final case class ActorCommandMessage( sealedValue: edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage.SealedValue ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ActorCommandMessage] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 if (sealedValue.backpressure.isDefined) { val __value = sealedValue.backpressure.get @@ -51,12 +51,13 @@ final case class ActorCommandMessage( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { sealedValue.backpressure.foreach { __v => @@ -92,7 +93,7 @@ final case class ActorCommandMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage + def companion: edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage.type = edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage def toActorCommand: edu.uci.ics.amber.engine.common.actormessage.ActorCommand = edu.uci.ics.amber.engine.common.actormessage.ActorCommand.ActorCommandTypeMapper.toCustom(this) // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ActorCommand]) } @@ -195,8 +196,8 @@ final case class Backpressure( enableBackpressure: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.common.actormessage.ActorCommand.NonEmpty with scalapb.lenses.Updatable[Backpressure] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -208,12 +209,13 @@ final case class Backpressure( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -239,7 +241,7 @@ final case class Backpressure( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.actormessage.Backpressure + def companion: edu.uci.ics.amber.engine.common.actormessage.Backpressure.type = edu.uci.ics.amber.engine.common.actormessage.Backpressure // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.Backpressure]) } @@ -298,7 +300,7 @@ final case class CreditUpdate( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.actormessage.CreditUpdate + def companion: edu.uci.ics.amber.engine.common.actormessage.CreditUpdate.type = edu.uci.ics.amber.engine.common.actormessage.CreditUpdate // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.CreditUpdate]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/PythonActorMessage.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/PythonActorMessage.scala index 7a4d99136c2..9d4b717d432 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/PythonActorMessage.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/PythonActorMessage.scala @@ -10,30 +10,31 @@ final case class PythonActorMessage( payload: edu.uci.ics.amber.engine.common.actormessage.ActorCommand ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PythonActorMessage] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage._typemapper_payload.toBase(payload) - if (__value != edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage._typemapper_payload.toBase(payload) - if (__v != edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -56,7 +57,7 @@ final case class PythonActorMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage + def companion: edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage.type = edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PythonActorMessage]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/ControlPayloadV2.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/ControlPayloadV2.scala index 1e6a9c304ed..8fa604cf407 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/ControlPayloadV2.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/ControlPayloadV2.scala @@ -37,8 +37,8 @@ final case class ControlPayloadV2Message( sealedValue: edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message.SealedValue ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ControlPayloadV2Message] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 if (sealedValue.controlInvocation.isDefined) { val __value = sealedValue.controlInvocation.get @@ -51,12 +51,13 @@ final case class ControlPayloadV2Message( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { sealedValue.controlInvocation.foreach { __v => @@ -92,7 +93,7 @@ final case class ControlPayloadV2Message( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message + def companion: edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message.type = edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message def toControlPayloadV2: edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2 = edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2.ControlPayloadV2TypeMapper.toCustom(this) // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ControlPayloadV2]) } @@ -196,8 +197,8 @@ final case class ControlInvocationV2( command: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2 ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2.NonEmpty with scalapb.lenses.Updatable[ControlInvocationV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -209,19 +210,20 @@ final case class ControlInvocationV2( { val __value = edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2._typemapper_command.toBase(command) - if (__value != edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -232,7 +234,7 @@ final case class ControlInvocationV2( }; { val __v = edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2._typemapper_command.toBase(command) - if (__v != edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -261,7 +263,7 @@ final case class ControlInvocationV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2 + def companion: edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2.type = edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ControlInvocationV2]) } @@ -335,8 +337,8 @@ final case class ReturnInvocationV2( controlReturn: edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2 ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2.NonEmpty with scalapb.lenses.Updatable[ReturnInvocationV2] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -348,19 +350,20 @@ final case class ReturnInvocationV2( { val __value = controlReturn - if (__value != edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -371,7 +374,7 @@ final case class ReturnInvocationV2( }; { val __v = controlReturn - if (__v != edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -400,7 +403,7 @@ final case class ReturnInvocationV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.ambermessage.ReturnInvocationV2 + def companion: edu.uci.ics.amber.engine.common.ambermessage.ReturnInvocationV2.type = edu.uci.ics.amber.engine.common.ambermessage.ReturnInvocationV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ReturnInvocationV2]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonControlMessage.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonControlMessage.scala index 331051cadba..7cd342b7bae 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonControlMessage.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonControlMessage.scala @@ -11,37 +11,38 @@ final case class PythonControlMessage( payload: edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2 ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PythonControlMessage] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = tag - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage._typemapper_payload.toBase(payload) - if (__value != edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = tag - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -49,7 +50,7 @@ final case class PythonControlMessage( }; { val __v = edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage._typemapper_payload.toBase(payload) - if (__v != edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -78,7 +79,7 @@ final case class PythonControlMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage + def companion: edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage.type = edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PythonControlMessage]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonDataHeader.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonDataHeader.scala index 03d33ecf93a..4a25ce1475e 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonDataHeader.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonDataHeader.scala @@ -11,13 +11,13 @@ final case class PythonDataHeader( payloadType: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PythonDataHeader] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = tag - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -31,17 +31,18 @@ final case class PythonDataHeader( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = tag - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -76,7 +77,7 @@ final case class PythonDataHeader( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.ambermessage.PythonDataHeader + def companion: edu.uci.ics.amber.engine.common.ambermessage.PythonDataHeader.type = edu.uci.ics.amber.engine.common.ambermessage.PythonDataHeader // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PythonDataHeader]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ActorVirtualIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ActorVirtualIdentity.scala index c8db20851ef..51bce383b66 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ActorVirtualIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ActorVirtualIdentity.scala @@ -10,8 +10,8 @@ final case class ActorVirtualIdentity( name: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ActorVirtualIdentity] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -23,12 +23,13 @@ final case class ActorVirtualIdentity( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -54,7 +55,7 @@ final case class ActorVirtualIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity + def companion: edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ActorVirtualIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelIdentity.scala index 8297da89498..f5c72494569 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelIdentity.scala @@ -12,20 +12,20 @@ final case class ChannelIdentity( isControl: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ChannelIdentity] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = fromWorkerId - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = toWorkerId - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -39,17 +39,18 @@ final case class ChannelIdentity( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = fromWorkerId - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -57,7 +58,7 @@ final case class ChannelIdentity( }; { val __v = toWorkerId - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -98,7 +99,7 @@ final case class ChannelIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity + def companion: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ChannelIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelMarkerIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelMarkerIdentity.scala index f9cce189278..4972ec96149 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelMarkerIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelMarkerIdentity.scala @@ -10,8 +10,8 @@ final case class ChannelMarkerIdentity( id: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ChannelMarkerIdentity] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -23,12 +23,13 @@ final case class ChannelMarkerIdentity( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -54,7 +55,7 @@ final case class ChannelMarkerIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.virtualidentity.ChannelMarkerIdentity + def companion: edu.uci.ics.amber.engine.common.virtualidentity.ChannelMarkerIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.ChannelMarkerIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ChannelMarkerIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ExecutionIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ExecutionIdentity.scala index cbb5fc226ca..d74e8cf99c2 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ExecutionIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ExecutionIdentity.scala @@ -10,8 +10,8 @@ final case class ExecutionIdentity( id: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionIdentity] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -23,12 +23,13 @@ final case class ExecutionIdentity( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -54,7 +55,7 @@ final case class ExecutionIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity + def companion: edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/OperatorIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/OperatorIdentity.scala index b1b79dd7884..e553d797887 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/OperatorIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/OperatorIdentity.scala @@ -10,8 +10,8 @@ final case class OperatorIdentity( id: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorIdentity] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -23,12 +23,13 @@ final case class OperatorIdentity( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -54,7 +55,7 @@ final case class OperatorIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity + def companion: edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/PhysicalOpIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/PhysicalOpIdentity.scala index 3075b6e8cda..3cf496f210b 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/PhysicalOpIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/PhysicalOpIdentity.scala @@ -11,13 +11,13 @@ final case class PhysicalOpIdentity( layerName: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PhysicalOpIdentity] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = logicalOpId - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -31,17 +31,18 @@ final case class PhysicalOpIdentity( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = logicalOpId - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -76,7 +77,7 @@ final case class PhysicalOpIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity + def companion: edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PhysicalOpIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/WorkflowIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/WorkflowIdentity.scala index a625c7ff256..5e69915365a 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/WorkflowIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/WorkflowIdentity.scala @@ -10,8 +10,8 @@ final case class WorkflowIdentity( id: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[WorkflowIdentity] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -23,12 +23,13 @@ final case class WorkflowIdentity( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -54,7 +55,7 @@ final case class WorkflowIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.virtualidentity.WorkflowIdentity + def companion: edu.uci.ics.amber.engine.common.virtualidentity.WorkflowIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.WorkflowIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.WorkflowIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/InputPort.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/InputPort.scala index 023c20ed716..6d5791b4999 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/InputPort.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/InputPort.scala @@ -13,13 +13,13 @@ final case class InputPort( dependencies: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflow.PortIdentity] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[InputPort] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = id - if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -44,17 +44,18 @@ final case class InputPort( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = id - if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -83,7 +84,7 @@ final case class InputPort( def withDisplayName(__v: _root_.scala.Predef.String): InputPort = copy(displayName = __v) def withAllowMultiLinks(__v: _root_.scala.Boolean): InputPort = copy(allowMultiLinks = __v) def clearDependencies = copy(dependencies = _root_.scala.Seq.empty) - def addDependencies(__vs: edu.uci.ics.amber.engine.common.workflow.PortIdentity*): InputPort = addAllDependencies(__vs) + def addDependencies(__vs: edu.uci.ics.amber.engine.common.workflow.PortIdentity *): InputPort = addAllDependencies(__vs) def addAllDependencies(__vs: Iterable[edu.uci.ics.amber.engine.common.workflow.PortIdentity]): InputPort = copy(dependencies = dependencies ++ __vs) def withDependencies(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflow.PortIdentity]): InputPort = copy(dependencies = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -113,7 +114,7 @@ final case class InputPort( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflow.InputPort + def companion: edu.uci.ics.amber.engine.common.workflow.InputPort.type = edu.uci.ics.amber.engine.common.workflow.InputPort // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.InputPort]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/OutputPort.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/OutputPort.scala index 6a495c698b3..7823ecb0af6 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/OutputPort.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/OutputPort.scala @@ -12,13 +12,13 @@ final case class OutputPort( blocking: _root_.scala.Boolean = false ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OutputPort] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = id - if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -39,17 +39,18 @@ final case class OutputPort( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = id - if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -96,7 +97,7 @@ final case class OutputPort( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflow.OutputPort + def companion: edu.uci.ics.amber.engine.common.workflow.OutputPort.type = edu.uci.ics.amber.engine.common.workflow.OutputPort // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OutputPort]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PhysicalLink.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PhysicalLink.scala index 747e58691a1..651ef332562 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PhysicalLink.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PhysicalLink.scala @@ -13,51 +13,52 @@ final case class PhysicalLink( toPortId: edu.uci.ics.amber.engine.common.workflow.PortIdentity = edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PhysicalLink] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { val __value = fromOpId - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = fromPortId - if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = toOpId - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = toPortId - if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = fromOpId - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -65,7 +66,7 @@ final case class PhysicalLink( }; { val __v = fromPortId - if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -73,7 +74,7 @@ final case class PhysicalLink( }; { val __v = toOpId - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(3, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -81,7 +82,7 @@ final case class PhysicalLink( }; { val __v = toPortId - if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(4, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -122,7 +123,7 @@ final case class PhysicalLink( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflow.PhysicalLink + def companion: edu.uci.ics.amber.engine.common.workflow.PhysicalLink.type = edu.uci.ics.amber.engine.common.workflow.PhysicalLink // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PhysicalLink]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PortIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PortIdentity.scala index 7d27211281d..e8f98bb680d 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PortIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PortIdentity.scala @@ -11,8 +11,8 @@ final case class PortIdentity( internal: _root_.scala.Boolean = false ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PortIdentity] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -31,12 +31,13 @@ final case class PortIdentity( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -74,7 +75,7 @@ final case class PortIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflow.PortIdentity + def companion: edu.uci.ics.amber.engine.common.workflow.PortIdentity.type = edu.uci.ics.amber.engine.common.workflow.PortIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PortIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/BreakpointFault.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/BreakpointFault.scala index 26f4d36082e..5c50e98935f 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/BreakpointFault.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/BreakpointFault.scala @@ -11,8 +11,8 @@ final case class BreakpointFault( faultedTuple: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.BreakpointTuple] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[BreakpointFault] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -28,12 +28,13 @@ final case class BreakpointFault( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -70,7 +71,7 @@ final case class BreakpointFault( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.type = edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.BreakpointFault]) } @@ -130,8 +131,8 @@ object BreakpointFault extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb tuple: _root_.scala.Seq[_root_.scala.Predef.String] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[BreakpointTuple] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -154,12 +155,13 @@ object BreakpointFault extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -182,7 +184,7 @@ object BreakpointFault extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb def withId(__v: _root_.scala.Long): BreakpointTuple = copy(id = __v) def withIsInput(__v: _root_.scala.Boolean): BreakpointTuple = copy(isInput = __v) def clearTuple = copy(tuple = _root_.scala.Seq.empty) - def addTuple(__vs: _root_.scala.Predef.String*): BreakpointTuple = addAllTuple(__vs) + def addTuple(__vs: _root_.scala.Predef.String *): BreakpointTuple = addAllTuple(__vs) def addAllTuple(__vs: Iterable[_root_.scala.Predef.String]): BreakpointTuple = copy(tuple = tuple ++ __vs) def withTuple(__v: _root_.scala.Seq[_root_.scala.Predef.String]): BreakpointTuple = copy(tuple = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -207,7 +209,7 @@ object BreakpointFault extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.BreakpointTuple + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.BreakpointTuple.type = edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.BreakpointTuple // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.BreakpointFault.BreakpointTuple]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/EvaluatedValueList.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/EvaluatedValueList.scala index 05e7737f95e..ad98ad6a8b0 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/EvaluatedValueList.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/EvaluatedValueList.scala @@ -10,8 +10,8 @@ final case class EvaluatedValueList( values: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[EvaluatedValueList] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 values.foreach { __item => val __value = __item @@ -20,12 +20,13 @@ final case class EvaluatedValueList( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { values.foreach { __v => @@ -36,7 +37,7 @@ final case class EvaluatedValueList( }; } def clearValues = copy(values = _root_.scala.Seq.empty) - def addValues(__vs: edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue*): EvaluatedValueList = addAllValues(__vs) + def addValues(__vs: edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue *): EvaluatedValueList = addAllValues(__vs) def addAllValues(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue]): EvaluatedValueList = copy(values = values ++ __vs) def withValues(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue]): EvaluatedValueList = copy(values = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -51,7 +52,7 @@ final case class EvaluatedValueList( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList.type = edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.EvaluatedValueList]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionBreakpointStore.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionBreakpointStore.scala index f20f8ae7e75..80e7324bca8 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionBreakpointStore.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionBreakpointStore.scala @@ -10,8 +10,8 @@ final case class ExecutionBreakpointStore( operatorInfo: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints] = _root_.scala.collection.immutable.Map.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionBreakpointStore] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 operatorInfo.foreach { __item => val __value = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore._typemapper_operatorInfo.toBase(__item) @@ -20,12 +20,13 @@ final case class ExecutionBreakpointStore( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { operatorInfo.foreach { __v => @@ -36,7 +37,7 @@ final case class ExecutionBreakpointStore( }; } def clearOperatorInfo = copy(operatorInfo = _root_.scala.collection.immutable.Map.empty) - def addOperatorInfo(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints)*): ExecutionBreakpointStore = addAllOperatorInfo(__vs) + def addOperatorInfo(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints) *): ExecutionBreakpointStore = addAllOperatorInfo(__vs) def addAllOperatorInfo(__vs: Iterable[(_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints)]): ExecutionBreakpointStore = copy(operatorInfo = operatorInfo ++ __vs) def withOperatorInfo(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints]): ExecutionBreakpointStore = copy(operatorInfo = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -51,7 +52,7 @@ final case class ExecutionBreakpointStore( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionBreakpointStore]) } @@ -104,8 +105,8 @@ object ExecutionBreakpointStore extends scalapb.GeneratedMessageCompanion[edu.uc value: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorInfoEntry] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -121,12 +122,13 @@ object ExecutionBreakpointStore extends scalapb.GeneratedMessageCompanion[edu.uc __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -163,7 +165,7 @@ object ExecutionBreakpointStore extends scalapb.GeneratedMessageCompanion[edu.uc } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore.OperatorInfoEntry + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore.OperatorInfoEntry.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore.OperatorInfoEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionBreakpointStore.OperatorInfoEntry]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionConsoleStore.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionConsoleStore.scala index c6c54a195dd..92c20334161 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionConsoleStore.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionConsoleStore.scala @@ -10,8 +10,8 @@ final case class ExecutionConsoleStore( operatorConsole: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole] = _root_.scala.collection.immutable.Map.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionConsoleStore] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 operatorConsole.foreach { __item => val __value = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore._typemapper_operatorConsole.toBase(__item) @@ -20,12 +20,13 @@ final case class ExecutionConsoleStore( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { operatorConsole.foreach { __v => @@ -36,7 +37,7 @@ final case class ExecutionConsoleStore( }; } def clearOperatorConsole = copy(operatorConsole = _root_.scala.collection.immutable.Map.empty) - def addOperatorConsole(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole)*): ExecutionConsoleStore = addAllOperatorConsole(__vs) + def addOperatorConsole(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole) *): ExecutionConsoleStore = addAllOperatorConsole(__vs) def addAllOperatorConsole(__vs: Iterable[(_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole)]): ExecutionConsoleStore = copy(operatorConsole = operatorConsole ++ __vs) def withOperatorConsole(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole]): ExecutionConsoleStore = copy(operatorConsole = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -51,7 +52,7 @@ final case class ExecutionConsoleStore( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionConsoleStore]) } @@ -104,8 +105,8 @@ object ExecutionConsoleStore extends scalapb.GeneratedMessageCompanion[edu.uci.i value: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorConsoleEntry] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -121,12 +122,13 @@ object ExecutionConsoleStore extends scalapb.GeneratedMessageCompanion[edu.uci.i __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -163,7 +165,7 @@ object ExecutionConsoleStore extends scalapb.GeneratedMessageCompanion[edu.uci.i } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore.OperatorConsoleEntry + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore.OperatorConsoleEntry.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore.OperatorConsoleEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionConsoleStore.OperatorConsoleEntry]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionMetadataStore.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionMetadataStore.scala index 3c397d55884..0b561891d5c 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionMetadataStore.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionMetadataStore.scala @@ -13,8 +13,8 @@ final case class ExecutionMetadataStore( isRecovering: _root_.scala.Boolean = false ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionMetadataStore] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -30,7 +30,7 @@ final case class ExecutionMetadataStore( { val __value = executionId - if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -44,12 +44,13 @@ final case class ExecutionMetadataStore( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -66,7 +67,7 @@ final case class ExecutionMetadataStore( }; { val __v = executionId - if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(3, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -81,7 +82,7 @@ final case class ExecutionMetadataStore( } def withState(__v: edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowAggregatedState): ExecutionMetadataStore = copy(state = __v) def clearFatalErrors = copy(fatalErrors = _root_.scala.Seq.empty) - def addFatalErrors(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError*): ExecutionMetadataStore = addAllFatalErrors(__vs) + def addFatalErrors(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError *): ExecutionMetadataStore = addAllFatalErrors(__vs) def addAllFatalErrors(__vs: Iterable[edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError]): ExecutionMetadataStore = copy(fatalErrors = fatalErrors ++ __vs) def withFatalErrors(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError]): ExecutionMetadataStore = copy(fatalErrors = __v) def withExecutionId(__v: edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity): ExecutionMetadataStore = copy(executionId = __v) @@ -113,7 +114,7 @@ final case class ExecutionMetadataStore( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionMetadataStore + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionMetadataStore.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionMetadataStore // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionMetadataStore]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionStatsStore.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionStatsStore.scala index bb3dbb30049..c9827aebd1c 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionStatsStore.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionStatsStore.scala @@ -13,8 +13,8 @@ final case class ExecutionStatsStore( operatorWorkerMapping: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionStatsStore] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -41,12 +41,13 @@ final case class ExecutionStatsStore( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -77,11 +78,11 @@ final case class ExecutionStatsStore( def withStartTimeStamp(__v: _root_.scala.Long): ExecutionStatsStore = copy(startTimeStamp = __v) def withEndTimeStamp(__v: _root_.scala.Long): ExecutionStatsStore = copy(endTimeStamp = __v) def clearOperatorInfo = copy(operatorInfo = _root_.scala.collection.immutable.Map.empty) - def addOperatorInfo(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics)*): ExecutionStatsStore = addAllOperatorInfo(__vs) + def addOperatorInfo(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics) *): ExecutionStatsStore = addAllOperatorInfo(__vs) def addAllOperatorInfo(__vs: Iterable[(_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics)]): ExecutionStatsStore = copy(operatorInfo = operatorInfo ++ __vs) def withOperatorInfo(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics]): ExecutionStatsStore = copy(operatorInfo = __v) def clearOperatorWorkerMapping = copy(operatorWorkerMapping = _root_.scala.Seq.empty) - def addOperatorWorkerMapping(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping*): ExecutionStatsStore = addAllOperatorWorkerMapping(__vs) + def addOperatorWorkerMapping(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping *): ExecutionStatsStore = addAllOperatorWorkerMapping(__vs) def addAllOperatorWorkerMapping(__vs: Iterable[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping]): ExecutionStatsStore = copy(operatorWorkerMapping = operatorWorkerMapping ++ __vs) def withOperatorWorkerMapping(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping]): ExecutionStatsStore = copy(operatorWorkerMapping = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -108,7 +109,7 @@ final case class ExecutionStatsStore( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionStatsStore]) } @@ -180,8 +181,8 @@ object ExecutionStatsStore extends scalapb.GeneratedMessageCompanion[edu.uci.ics value: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorInfoEntry] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -197,12 +198,13 @@ object ExecutionStatsStore extends scalapb.GeneratedMessageCompanion[edu.uci.ics __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -239,7 +241,7 @@ object ExecutionStatsStore extends scalapb.GeneratedMessageCompanion[edu.uci.ics } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore.OperatorInfoEntry + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore.OperatorInfoEntry.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore.OperatorInfoEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionStatsStore.OperatorInfoEntry]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/FatalErrorType.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/FatalErrorType.scala index 5470ffb9857..fe34ee6210e 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/FatalErrorType.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/FatalErrorType.scala @@ -16,6 +16,7 @@ sealed abstract class FatalErrorType(val value: _root_.scala.Int) extends _root_ object FatalErrorType extends _root_.scalapb.GeneratedEnumCompanion[FatalErrorType] { sealed trait Recognized extends FatalErrorType implicit def enumCompanion: _root_.scalapb.GeneratedEnumCompanion[FatalErrorType] = this + @SerialVersionUID(0L) case object COMPILATION_ERROR extends FatalErrorType(0) with FatalErrorType.Recognized { val index = 0 @@ -32,7 +33,6 @@ object FatalErrorType extends _root_.scalapb.GeneratedEnumCompanion[FatalErrorTy @SerialVersionUID(0L) final case class Unrecognized(unrecognizedValue: _root_.scala.Int) extends FatalErrorType(unrecognizedValue) with _root_.scalapb.UnrecognizedEnum - lazy val values = scala.collection.immutable.Seq(COMPILATION_ERROR, EXECUTION_FAILURE) def fromValue(__value: _root_.scala.Int): FatalErrorType = __value match { case 0 => COMPILATION_ERROR diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorBreakpoints.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorBreakpoints.scala index 35d1c32ac85..a88ff9f2081 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorBreakpoints.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorBreakpoints.scala @@ -10,8 +10,8 @@ final case class OperatorBreakpoints( unresolvedBreakpoints: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorBreakpoints] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 unresolvedBreakpoints.foreach { __item => val __value = __item @@ -20,12 +20,13 @@ final case class OperatorBreakpoints( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { unresolvedBreakpoints.foreach { __v => @@ -36,7 +37,7 @@ final case class OperatorBreakpoints( }; } def clearUnresolvedBreakpoints = copy(unresolvedBreakpoints = _root_.scala.Seq.empty) - def addUnresolvedBreakpoints(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault*): OperatorBreakpoints = addAllUnresolvedBreakpoints(__vs) + def addUnresolvedBreakpoints(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault *): OperatorBreakpoints = addAllUnresolvedBreakpoints(__vs) def addAllUnresolvedBreakpoints(__vs: Iterable[edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault]): OperatorBreakpoints = copy(unresolvedBreakpoints = unresolvedBreakpoints ++ __vs) def withUnresolvedBreakpoints(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault]): OperatorBreakpoints = copy(unresolvedBreakpoints = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -51,7 +52,7 @@ final case class OperatorBreakpoints( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorBreakpoints]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorConsole.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorConsole.scala index fd87777a374..a1d98ddf5a0 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorConsole.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorConsole.scala @@ -11,8 +11,8 @@ final case class OperatorConsole( evaluateExprResults: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList] = _root_.scala.collection.immutable.Map.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorConsole] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 consoleMessages.foreach { __item => val __value = __item @@ -25,12 +25,13 @@ final case class OperatorConsole( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { consoleMessages.foreach { __v => @@ -47,11 +48,11 @@ final case class OperatorConsole( }; } def clearConsoleMessages = copy(consoleMessages = _root_.scala.Seq.empty) - def addConsoleMessages(__vs: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage*): OperatorConsole = addAllConsoleMessages(__vs) + def addConsoleMessages(__vs: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage *): OperatorConsole = addAllConsoleMessages(__vs) def addAllConsoleMessages(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage]): OperatorConsole = copy(consoleMessages = consoleMessages ++ __vs) def withConsoleMessages(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage]): OperatorConsole = copy(consoleMessages = __v) def clearEvaluateExprResults = copy(evaluateExprResults = _root_.scala.collection.immutable.Map.empty) - def addEvaluateExprResults(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList)*): OperatorConsole = addAllEvaluateExprResults(__vs) + def addEvaluateExprResults(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList) *): OperatorConsole = addAllEvaluateExprResults(__vs) def addAllEvaluateExprResults(__vs: Iterable[(_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList)]): OperatorConsole = copy(evaluateExprResults = evaluateExprResults ++ __vs) def withEvaluateExprResults(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList]): OperatorConsole = copy(evaluateExprResults = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -68,7 +69,7 @@ final case class OperatorConsole( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorConsole]) } @@ -128,8 +129,8 @@ object OperatorConsole extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb value: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[EvaluateExprResultsEntry] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -145,12 +146,13 @@ object OperatorConsole extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -187,7 +189,7 @@ object OperatorConsole extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole.EvaluateExprResultsEntry + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole.EvaluateExprResultsEntry.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole.EvaluateExprResultsEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorConsole.EvaluateExprResultsEntry]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorMetrics.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorMetrics.scala index 32e8c2317df..a7d8aa04873 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorMetrics.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorMetrics.scala @@ -11,8 +11,8 @@ final case class OperatorMetrics( operatorStatistics: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics.defaultInstance ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorMetrics] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -24,19 +24,20 @@ final case class OperatorMetrics( { val __value = operatorStatistics - if (__value != edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -47,7 +48,7 @@ final case class OperatorMetrics( }; { val __v = operatorStatistics - if (__v != edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -76,7 +77,7 @@ final case class OperatorMetrics( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorMetrics]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorStatistics.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorStatistics.scala index ac9916e52b0..fcaa8bde7f3 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorStatistics.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorStatistics.scala @@ -15,8 +15,8 @@ final case class OperatorStatistics( idleTime: _root_.scala.Long = 0L ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorStatistics] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 inputCount.foreach { __item => val __value = __item @@ -57,12 +57,13 @@ final case class OperatorStatistics( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { inputCount.foreach { __v => @@ -103,11 +104,11 @@ final case class OperatorStatistics( }; } def clearInputCount = copy(inputCount = _root_.scala.Seq.empty) - def addInputCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping*): OperatorStatistics = addAllInputCount(__vs) + def addInputCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping *): OperatorStatistics = addAllInputCount(__vs) def addAllInputCount(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): OperatorStatistics = copy(inputCount = inputCount ++ __vs) def withInputCount(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): OperatorStatistics = copy(inputCount = __v) def clearOutputCount = copy(outputCount = _root_.scala.Seq.empty) - def addOutputCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping*): OperatorStatistics = addAllOutputCount(__vs) + def addOutputCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping *): OperatorStatistics = addAllOutputCount(__vs) def addAllOutputCount(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): OperatorStatistics = copy(outputCount = outputCount ++ __vs) def withOutputCount(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): OperatorStatistics = copy(outputCount = __v) def withNumWorkers(__v: _root_.scala.Int): OperatorStatistics = copy(numWorkers = __v) @@ -148,7 +149,7 @@ final case class OperatorStatistics( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorStatistics]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorWorkerMapping.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorWorkerMapping.scala index 3b4c7076147..346ba1263ca 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorWorkerMapping.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorWorkerMapping.scala @@ -11,8 +11,8 @@ final case class OperatorWorkerMapping( workerIds: _root_.scala.Seq[_root_.scala.Predef.String] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorWorkerMapping] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -28,12 +28,13 @@ final case class OperatorWorkerMapping( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -49,7 +50,7 @@ final case class OperatorWorkerMapping( } def withOperatorId(__v: _root_.scala.Predef.String): OperatorWorkerMapping = copy(operatorId = __v) def clearWorkerIds = copy(workerIds = _root_.scala.Seq.empty) - def addWorkerIds(__vs: _root_.scala.Predef.String*): OperatorWorkerMapping = addAllWorkerIds(__vs) + def addWorkerIds(__vs: _root_.scala.Predef.String *): OperatorWorkerMapping = addAllWorkerIds(__vs) def addAllWorkerIds(__vs: Iterable[_root_.scala.Predef.String]): OperatorWorkerMapping = copy(workerIds = workerIds ++ __vs) def withWorkerIds(__v: _root_.scala.Seq[_root_.scala.Predef.String]): OperatorWorkerMapping = copy(workerIds = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -69,7 +70,7 @@ final case class OperatorWorkerMapping( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorWorkerMapping]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowAggregatedState.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowAggregatedState.scala index acd2f9cfa08..617cf1778ee 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowAggregatedState.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowAggregatedState.scala @@ -24,6 +24,7 @@ sealed abstract class WorkflowAggregatedState(val value: _root_.scala.Int) exten object WorkflowAggregatedState extends _root_.scalapb.GeneratedEnumCompanion[WorkflowAggregatedState] { sealed trait Recognized extends WorkflowAggregatedState implicit def enumCompanion: _root_.scalapb.GeneratedEnumCompanion[WorkflowAggregatedState] = this + @SerialVersionUID(0L) case object UNINITIALIZED extends WorkflowAggregatedState(0) with WorkflowAggregatedState.Recognized { val index = 0 @@ -96,7 +97,6 @@ object WorkflowAggregatedState extends _root_.scalapb.GeneratedEnumCompanion[Wor @SerialVersionUID(0L) final case class Unrecognized(unrecognizedValue: _root_.scala.Int) extends WorkflowAggregatedState(unrecognizedValue) with _root_.scalapb.UnrecognizedEnum - lazy val values = scala.collection.immutable.Seq(UNINITIALIZED, READY, RUNNING, PAUSING, PAUSED, RESUMING, COMPLETED, FAILED, UNKNOWN, KILLED) def fromValue(__value: _root_.scala.Int): WorkflowAggregatedState = __value match { case 0 => UNINITIALIZED diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowFatalError.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowFatalError.scala index 4f840574f76..42b43c4d93b 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowFatalError.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowFatalError.scala @@ -15,8 +15,8 @@ final case class WorkflowFatalError( workerId: _root_.scala.Predef.String = "" ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[WorkflowFatalError] { @transient - private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 - private[this] def __computeSerializedValue(): _root_.scala.Int = { + private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 + private[this] def __computeSerializedSize(): _root_.scala.Int = { var __size = 0 { @@ -28,7 +28,7 @@ final case class WorkflowFatalError( { val __value = timestamp - if (__value != com.google.protobuf.timestamp.Timestamp.defaultInstance) { + if (__value.serializedSize != 0) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -63,12 +63,13 @@ final case class WorkflowFatalError( __size } override def serializedSize: _root_.scala.Int = { - var read = __serializedSizeCachedValue - if (read == 0) { - read = __computeSerializedValue() - __serializedSizeCachedValue = read + var __size = __serializedSizeMemoized + if (__size == 0) { + __size = __computeSerializedSize() + 1 + __serializedSizeMemoized = __size } - read + __size - 1 + } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -79,7 +80,7 @@ final case class WorkflowFatalError( }; { val __v = timestamp - if (__v != com.google.protobuf.timestamp.Timestamp.defaultInstance) { + if (__v.serializedSize != 0) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -156,7 +157,7 @@ final case class WorkflowFatalError( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError + def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError.type = edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.WorkflowFatalError]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowruntimestateProto.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowruntimestateProto.scala index 0472dee23ff..1c86d6baf58 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowruntimestateProto.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowruntimestateProto.scala @@ -87,10 +87,13 @@ object WorkflowruntimestateProto extends _root_.scalapb.GeneratedFileObject { XRlUgVzdGF0ZRJoCgxmYXRhbF9lcnJvcnMYAiADKAsyMy5lZHUudWNpLmljcy5hbWJlci5lbmdpbmUuY29tbW9uLldvcmtmbG93R mF0YWxFcnJvckIQ4j8NEgtmYXRhbEVycm9yc1ILZmF0YWxFcnJvcnMSaQoLZXhlY3V0aW9uSWQYAyABKAsyMi5lZHUudWNpLmljc y5hbWJlci5lbmdpbmUuY29tbW9uLkV4ZWN1dGlvbklkZW50aXR5QhPiPxASC2V4ZWN1dGlvbklk8AEBUgtleGVjdXRpb25JZBI2C - g1pc19yZWNvdmVyaW5nGAQgASgIQhHiPw4SDGlzUmVjb3ZlcmluZ1IMaXNSZWNvdmVyaW5nKj4KDkZhdGFsRXJyb3JUeXBlEhUKE - UNPTVBJTEFUSU9OX0VSUk9SEAASFQoRRVhFQ1VUSU9OX0ZBSUxVUkUQASqfAQoXV29ya2Zsb3dBZ2dyZWdhdGVkU3RhdGUSEQoNV - U5JTklUSUFMSVpFRBAAEgkKBVJFQURZEAESCwoHUlVOTklORxACEgsKB1BBVVNJTkcQAxIKCgZQQVVTRUQQBBIMCghSRVNVTUlOR - xAFEg0KCUNPTVBMRVRFRBAGEgoKBkZBSUxFRBAHEgsKB1VOS05PV04QCBIKCgZLSUxMRUQQCUIJ4j8GSABYAHgAYgZwcm90bzM=""" + g1pc19yZWNvdmVyaW5nGAQgASgIQhHiPw4SDGlzUmVjb3ZlcmluZ1IMaXNSZWNvdmVyaW5nKm4KDkZhdGFsRXJyb3JUeXBlEi0KE + UNPTVBJTEFUSU9OX0VSUk9SEAAaFuI/ExIRQ09NUElMQVRJT05fRVJST1ISLQoRRVhFQ1VUSU9OX0ZBSUxVUkUQARoW4j8TEhFFW + EVDVVRJT05fRkFJTFVSRSqvAgoXV29ya2Zsb3dBZ2dyZWdhdGVkU3RhdGUSJQoNVU5JTklUSUFMSVpFRBAAGhLiPw8SDVVOSU5JV + ElBTElaRUQSFQoFUkVBRFkQARoK4j8HEgVSRUFEWRIZCgdSVU5OSU5HEAIaDOI/CRIHUlVOTklORxIZCgdQQVVTSU5HEAMaDOI/C + RIHUEFVU0lORxIXCgZQQVVTRUQQBBoL4j8IEgZQQVVTRUQSGwoIUkVTVU1JTkcQBRoN4j8KEghSRVNVTUlORxIdCglDT01QTEVUR + UQQBhoO4j8LEglDT01QTEVURUQSFwoGRkFJTEVEEAcaC+I/CBIGRkFJTEVEEhkKB1VOS05PV04QCBoM4j8JEgdVTktOT1dOEhcKB + ktJTExFRBAJGgviPwgSBktJTExFREIJ4j8GSABYAHgAYgZwcm90bzM=""" ).mkString) lazy val scalaDescriptor: _root_.scalapb.descriptors.FileDescriptor = { val scalaProto = com.google.protobuf.descriptor.FileDescriptorProto.parseFrom(ProtoBytes) From ea875d74067dab901b697af2d2581f427271e7cb Mon Sep 17 00:00:00 2001 From: Shengquan Ni <13672781+shengquan-ni@users.noreply.github.com> Date: Fri, 25 Oct 2024 15:10:11 -0700 Subject: [PATCH 2/4] Update ControllerAsyncRPCHandlerInitializer.scala --- .../controller/ControllerAsyncRPCHandlerInitializer.scala | 1 + 1 file changed, 1 insertion(+) diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala index c4d93193e0b..dc333a11fb7 100644 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala +++ b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala @@ -11,6 +11,7 @@ class ControllerAsyncRPCHandlerInitializer( with AmberLogging with LinkWorkersHandler with WorkerExecutionCompletedHandler + with WorkerStateUpdatedHandler with PauseHandler with QueryWorkerStatisticsHandler with ResumeHandler From d520f429c9829248d7751404b2884adb67c542f5 Mon Sep 17 00:00:00 2001 From: Shengquan Ni <13672781+shengquan-ni@users.noreply.github.com> Date: Fri, 25 Oct 2024 15:13:29 -0700 Subject: [PATCH 3/4] update --- .../partitionings/Partitioning.scala | 116 ++++---- .../controlcommands/ConsoleMessage.scala | 21 +- .../controlcommands/ConsoleMessageType.scala | 2 +- .../controlcommands/ControlCommandV2.scala | 252 +++++++++--------- .../ControlcommandsProto.scala | 5 +- .../worker/controlcommands/LinkOrdinal.scala | 21 +- .../controlreturns/ControlException.scala | 17 +- .../controlreturns/ControlReturnV2.scala | 17 +- .../CurrentInputTupleInfo.scala | 2 +- .../controlreturns/EvaluatedValue.scala | 19 +- .../worker/controlreturns/TypedValue.scala | 17 +- .../statistics/PortTupleCountMapping.scala | 21 +- .../worker/statistics/StatisticsProto.scala | 7 +- .../worker/statistics/WorkerMetrics.scala | 21 +- .../worker/statistics/WorkerState.scala | 2 +- .../worker/statistics/WorkerStatistics.scala | 21 +- .../common/actormessage/ActorCommand.scala | 36 ++- .../actormessage/PythonActorMessage.scala | 21 +- .../ambermessage/ControlPayloadV2.scala | 59 ++-- .../ambermessage/PythonControlMessage.scala | 25 +- .../ambermessage/PythonDataHeader.scala | 21 +- .../ActorVirtualIdentity.scala | 17 +- .../virtualidentity/ChannelIdentity.scala | 25 +- .../ChannelMarkerIdentity.scala | 17 +- .../virtualidentity/ExecutionIdentity.scala | 17 +- .../virtualidentity/OperatorIdentity.scala | 17 +- .../virtualidentity/PhysicalOpIdentity.scala | 21 +- .../virtualidentity/WorkflowIdentity.scala | 17 +- .../engine/common/workflow/InputPort.scala | 23 +- .../engine/common/workflow/OutputPort.scala | 21 +- .../engine/common/workflow/PhysicalLink.scala | 33 ++- .../engine/common/workflow/PortIdentity.scala | 17 +- .../BreakpointFault.scala | 36 ++- .../EvaluatedValueList.scala | 19 +- .../ExecutionBreakpointStore.scala | 36 ++- .../ExecutionConsoleStore.scala | 36 ++- .../ExecutionMetadataStore.scala | 23 +- .../ExecutionStatsStore.scala | 38 ++- .../workflowruntimestate/FatalErrorType.scala | 2 +- .../OperatorBreakpoints.scala | 19 +- .../OperatorConsole.scala | 38 ++- .../OperatorMetrics.scala | 21 +- .../OperatorStatistics.scala | 21 +- .../OperatorWorkerMapping.scala | 19 +- .../WorkflowAggregatedState.scala | 2 +- .../WorkflowFatalError.scala | 21 +- .../WorkflowruntimestateProto.scala | 11 +- 47 files changed, 611 insertions(+), 679 deletions(-) diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/sendsemantics/partitionings/Partitioning.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/sendsemantics/partitionings/Partitioning.scala index 704d15fc3c1..219a232353b 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/sendsemantics/partitionings/Partitioning.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/sendsemantics/partitionings/Partitioning.scala @@ -43,8 +43,8 @@ final case class PartitioningMessage( sealedValue: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage.SealedValue ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PartitioningMessage] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 if (sealedValue.oneToOnePartitioning.isDefined) { val __value = sealedValue.oneToOnePartitioning.get @@ -69,13 +69,12 @@ final case class PartitioningMessage( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { sealedValue.oneToOnePartitioning.foreach { __v => @@ -141,7 +140,7 @@ final case class PartitioningMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage + def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage def toPartitioning: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.PartitioningTypeMapper.toCustom(this) // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.Partitioning]) } @@ -290,8 +289,8 @@ final case class OneToOnePartitioning( channels: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[OneToOnePartitioning] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -307,13 +306,12 @@ final case class OneToOnePartitioning( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -331,7 +329,7 @@ final case class OneToOnePartitioning( } def withBatchSize(__v: _root_.scala.Int): OneToOnePartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): OneToOnePartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): OneToOnePartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): OneToOnePartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): OneToOnePartitioning = copy(channels = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -351,7 +349,7 @@ final case class OneToOnePartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.OneToOnePartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.OneToOnePartitioning + def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.OneToOnePartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.OneToOnePartitioning]) } @@ -423,8 +421,8 @@ final case class RoundRobinPartitioning( channels: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[RoundRobinPartitioning] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -440,13 +438,12 @@ final case class RoundRobinPartitioning( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -464,7 +461,7 @@ final case class RoundRobinPartitioning( } def withBatchSize(__v: _root_.scala.Int): RoundRobinPartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): RoundRobinPartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): RoundRobinPartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): RoundRobinPartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): RoundRobinPartitioning = copy(channels = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -484,7 +481,7 @@ final case class RoundRobinPartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RoundRobinPartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RoundRobinPartitioning + def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RoundRobinPartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.RoundRobinPartitioning]) } @@ -557,8 +554,8 @@ final case class HashBasedShufflePartitioning( hashAttributeNames: _root_.scala.Seq[_root_.scala.Predef.String] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[HashBasedShufflePartitioning] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -578,13 +575,12 @@ final case class HashBasedShufflePartitioning( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -606,11 +602,11 @@ final case class HashBasedShufflePartitioning( } def withBatchSize(__v: _root_.scala.Int): HashBasedShufflePartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): HashBasedShufflePartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): HashBasedShufflePartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): HashBasedShufflePartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): HashBasedShufflePartitioning = copy(channels = __v) def clearHashAttributeNames = copy(hashAttributeNames = _root_.scala.Seq.empty) - def addHashAttributeNames(__vs: _root_.scala.Predef.String *): HashBasedShufflePartitioning = addAllHashAttributeNames(__vs) + def addHashAttributeNames(__vs: _root_.scala.Predef.String*): HashBasedShufflePartitioning = addAllHashAttributeNames(__vs) def addAllHashAttributeNames(__vs: Iterable[_root_.scala.Predef.String]): HashBasedShufflePartitioning = copy(hashAttributeNames = hashAttributeNames ++ __vs) def withHashAttributeNames(__v: _root_.scala.Seq[_root_.scala.Predef.String]): HashBasedShufflePartitioning = copy(hashAttributeNames = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -632,7 +628,7 @@ final case class HashBasedShufflePartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.HashBasedShufflePartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.HashBasedShufflePartitioning + def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.HashBasedShufflePartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.HashBasedShufflePartitioning]) } @@ -717,8 +713,8 @@ final case class RangeBasedShufflePartitioning( rangeMax: _root_.scala.Long ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[RangeBasedShufflePartitioning] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -752,13 +748,12 @@ final case class RangeBasedShufflePartitioning( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -792,11 +787,11 @@ final case class RangeBasedShufflePartitioning( } def withBatchSize(__v: _root_.scala.Int): RangeBasedShufflePartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): RangeBasedShufflePartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): RangeBasedShufflePartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): RangeBasedShufflePartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): RangeBasedShufflePartitioning = copy(channels = __v) def clearRangeAttributeNames = copy(rangeAttributeNames = _root_.scala.Seq.empty) - def addRangeAttributeNames(__vs: _root_.scala.Predef.String *): RangeBasedShufflePartitioning = addAllRangeAttributeNames(__vs) + def addRangeAttributeNames(__vs: _root_.scala.Predef.String*): RangeBasedShufflePartitioning = addAllRangeAttributeNames(__vs) def addAllRangeAttributeNames(__vs: Iterable[_root_.scala.Predef.String]): RangeBasedShufflePartitioning = copy(rangeAttributeNames = rangeAttributeNames ++ __vs) def withRangeAttributeNames(__v: _root_.scala.Seq[_root_.scala.Predef.String]): RangeBasedShufflePartitioning = copy(rangeAttributeNames = __v) def withRangeMin(__v: _root_.scala.Long): RangeBasedShufflePartitioning = copy(rangeMin = __v) @@ -830,7 +825,7 @@ final case class RangeBasedShufflePartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RangeBasedShufflePartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RangeBasedShufflePartitioning + def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.RangeBasedShufflePartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.RangeBasedShufflePartitioning]) } @@ -932,8 +927,8 @@ final case class BroadcastPartitioning( channels: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning.NonEmpty with scalapb.lenses.Updatable[BroadcastPartitioning] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -949,13 +944,12 @@ final case class BroadcastPartitioning( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -973,7 +967,7 @@ final case class BroadcastPartitioning( } def withBatchSize(__v: _root_.scala.Int): BroadcastPartitioning = copy(batchSize = __v) def clearChannels = copy(channels = _root_.scala.Seq.empty) - def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity *): BroadcastPartitioning = addAllChannels(__vs) + def addChannels(__vs: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity*): BroadcastPartitioning = addAllChannels(__vs) def addAllChannels(__vs: Iterable[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): BroadcastPartitioning = copy(channels = channels ++ __vs) def withChannels(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity]): BroadcastPartitioning = copy(channels = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -993,7 +987,7 @@ final case class BroadcastPartitioning( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.BroadcastPartitioning.type = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.BroadcastPartitioning + def companion = edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.BroadcastPartitioning // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.sendsemantics.BroadcastPartitioning]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessage.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessage.scala index c212263a9c2..72c44619a9a 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessage.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessage.scala @@ -15,8 +15,8 @@ final case class ConsoleMessage( message: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ConsoleMessage] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -28,7 +28,7 @@ final case class ConsoleMessage( { val __value = timestamp - if (__value.serializedSize != 0) { + if (__value != com.google.protobuf.timestamp.Timestamp.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -63,13 +63,12 @@ final case class ConsoleMessage( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -80,7 +79,7 @@ final case class ConsoleMessage( }; { val __v = timestamp - if (__v.serializedSize != 0) { + if (__v != com.google.protobuf.timestamp.Timestamp.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -157,7 +156,7 @@ final case class ConsoleMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ConsoleMessage]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessageType.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessageType.scala index 54ac513d22c..dbd62bedf62 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessageType.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ConsoleMessageType.scala @@ -18,7 +18,6 @@ sealed abstract class ConsoleMessageType(val value: _root_.scala.Int) extends _r object ConsoleMessageType extends _root_.scalapb.GeneratedEnumCompanion[ConsoleMessageType] { sealed trait Recognized extends ConsoleMessageType implicit def enumCompanion: _root_.scalapb.GeneratedEnumCompanion[ConsoleMessageType] = this - @SerialVersionUID(0L) case object PRINT extends ConsoleMessageType(0) with ConsoleMessageType.Recognized { val index = 0 @@ -49,6 +48,7 @@ object ConsoleMessageType extends _root_.scalapb.GeneratedEnumCompanion[ConsoleM @SerialVersionUID(0L) final case class Unrecognized(unrecognizedValue: _root_.scala.Int) extends ConsoleMessageType(unrecognizedValue) with _root_.scalapb.UnrecognizedEnum + lazy val values = scala.collection.immutable.Seq(PRINT, ERROR, COMMAND, DEBUGGER) def fromValue(__value: _root_.scala.Int): ConsoleMessageType = __value match { case 0 => PRINT diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandV2.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandV2.scala index 79499755eae..1333742daf0 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandV2.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlCommandV2.scala @@ -71,8 +71,8 @@ final case class ControlCommandV2Message( sealedValue: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message.SealedValue ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ControlCommandV2Message] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 if (sealedValue.startWorker.isDefined) { val __value = sealedValue.startWorker.get @@ -153,13 +153,12 @@ final case class ControlCommandV2Message( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { sealedValue.startWorker.foreach { __v => @@ -365,7 +364,7 @@ final case class ControlCommandV2Message( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message def toControlCommandV2: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2 = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.ControlCommandV2TypeMapper.toCustom(this) // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ControlCommandV2]) } @@ -727,7 +726,7 @@ final case class StartWorkerV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.StartWorkerV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.StartWorkerV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.StartWorkerV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.StartWorkerV2]) } @@ -776,7 +775,7 @@ final case class PauseWorkerV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.PauseWorkerV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PauseWorkerV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PauseWorkerV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.PauseWorkerV2]) } @@ -825,7 +824,7 @@ final case class ResumeWorkerV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ResumeWorkerV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ResumeWorkerV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ResumeWorkerV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ResumeWorkerV2]) } @@ -872,13 +871,13 @@ final case class AssignPortV2( schema: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, _root_.scala.Predef.String] ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[AssignPortV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = portId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -896,18 +895,17 @@ final case class AssignPortV2( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = portId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -929,7 +927,7 @@ final case class AssignPortV2( def withPortId(__v: edu.uci.ics.amber.engine.common.workflow.PortIdentity): AssignPortV2 = copy(portId = __v) def withInput(__v: _root_.scala.Boolean): AssignPortV2 = copy(input = __v) def clearSchema = copy(schema = _root_.scala.collection.immutable.Map.empty) - def addSchema(__vs: (_root_.scala.Predef.String, _root_.scala.Predef.String) *): AssignPortV2 = addAllSchema(__vs) + def addSchema(__vs: (_root_.scala.Predef.String, _root_.scala.Predef.String)*): AssignPortV2 = addAllSchema(__vs) def addAllSchema(__vs: Iterable[(_root_.scala.Predef.String, _root_.scala.Predef.String)]): AssignPortV2 = copy(schema = schema ++ __vs) def withSchema(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, _root_.scala.Predef.String]): AssignPortV2 = copy(schema = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -954,7 +952,7 @@ final case class AssignPortV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.AssignPortV2]) } @@ -1020,8 +1018,8 @@ object AssignPortV2 extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amber. value: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[SchemaEntry] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -1040,13 +1038,12 @@ object AssignPortV2 extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amber. __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -1084,7 +1081,7 @@ object AssignPortV2 extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amber. } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2.SchemaEntry.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2.SchemaEntry + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AssignPortV2.SchemaEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.AssignPortV2.SchemaEntry]) } @@ -1175,38 +1172,37 @@ final case class AddPartitioningV2( partitioning: edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.Partitioning ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[AddPartitioningV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = tag - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PhysicalLink.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2._typemapper_partitioning.toBase(partitioning) - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = tag - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PhysicalLink.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1214,7 +1210,7 @@ final case class AddPartitioningV2( }; { val __v = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2._typemapper_partitioning.toBase(partitioning) - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.architecture.sendsemantics.partitionings.PartitioningMessage.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1243,7 +1239,7 @@ final case class AddPartitioningV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddPartitioningV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.AddPartitioningV2]) } @@ -1318,38 +1314,37 @@ final case class AddInputChannelV2( portId: edu.uci.ics.amber.engine.common.workflow.PortIdentity ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[AddInputChannelV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = channelId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = portId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = channelId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1357,7 +1352,7 @@ final case class AddInputChannelV2( }; { val __v = portId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1386,7 +1381,7 @@ final case class AddInputChannelV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddInputChannelV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddInputChannelV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.AddInputChannelV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.AddInputChannelV2]) } @@ -1462,7 +1457,7 @@ final case class QueryStatisticsV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryStatisticsV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryStatisticsV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryStatisticsV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.QueryStatisticsV2]) } @@ -1511,7 +1506,7 @@ final case class QueryCurrentInputTupleV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryCurrentInputTupleV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryCurrentInputTupleV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.QueryCurrentInputTupleV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.QueryCurrentInputTupleV2]) } @@ -1560,7 +1555,7 @@ final case class OpenExecutorV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.OpenExecutorV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.OpenExecutorV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.OpenExecutorV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.OpenExecutorV2]) } @@ -1606,13 +1601,13 @@ final case class PortCompletedV2( input: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[PortCompletedV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = portId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -1626,18 +1621,17 @@ final case class PortCompletedV2( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = portId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -1672,7 +1666,7 @@ final case class PortCompletedV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.PortCompletedV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PortCompletedV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PortCompletedV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.PortCompletedV2]) } @@ -1743,8 +1737,8 @@ final case class SchedulerTimeSlotEventV2( timeSlotExpired: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[SchedulerTimeSlotEventV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -1756,13 +1750,12 @@ final case class SchedulerTimeSlotEventV2( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -1788,7 +1781,7 @@ final case class SchedulerTimeSlotEventV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.SchedulerTimeSlotEventV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.SchedulerTimeSlotEventV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.SchedulerTimeSlotEventV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.SchedulerTimeSlotEventV2]) } @@ -1845,8 +1838,8 @@ final case class InitializeExecutorV2( isSource: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[InitializeExecutorV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -1872,13 +1865,12 @@ final case class InitializeExecutorV2( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -1928,7 +1920,7 @@ final case class InitializeExecutorV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.InitializeExecutorV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.InitializeExecutorV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.InitializeExecutorV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.InitializeExecutorV2]) } @@ -2004,8 +1996,8 @@ final case class UpdateExecutorV2( isSource: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[UpdateExecutorV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -2024,13 +2016,12 @@ final case class UpdateExecutorV2( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -2068,7 +2059,7 @@ final case class UpdateExecutorV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.UpdateExecutorV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.UpdateExecutorV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.UpdateExecutorV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.UpdateExecutorV2]) } @@ -2133,31 +2124,30 @@ final case class PythonConsoleMessageV2( message: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[PythonConsoleMessageV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = message - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = message - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -2180,7 +2170,7 @@ final case class PythonConsoleMessageV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.PythonConsoleMessageV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PythonConsoleMessageV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.PythonConsoleMessageV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.PythonConsoleMessageV2]) } @@ -2245,7 +2235,7 @@ final case class ReplayCurrentTupleV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ReplayCurrentTupleV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ReplayCurrentTupleV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.ReplayCurrentTupleV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ReplayCurrentTupleV2]) } @@ -2290,8 +2280,8 @@ final case class EvaluateExpressionV2( expression: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[EvaluateExpressionV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -2303,13 +2293,12 @@ final case class EvaluateExpressionV2( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -2335,7 +2324,7 @@ final case class EvaluateExpressionV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.EvaluateExpressionV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.EvaluateExpressionV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.EvaluateExpressionV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.EvaluateExpressionV2]) } @@ -2390,8 +2379,8 @@ final case class WorkerDebugCommandV2( cmd: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2.NonEmpty with scalapb.lenses.Updatable[WorkerDebugCommandV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -2403,13 +2392,12 @@ final case class WorkerDebugCommandV2( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -2435,7 +2423,7 @@ final case class WorkerDebugCommandV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerDebugCommandV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerDebugCommandV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerDebugCommandV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.WorkerDebugCommandV2]) } @@ -2494,7 +2482,7 @@ final case class WorkerExecutionCompletedV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerExecutionCompletedV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerExecutionCompletedV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.WorkerExecutionCompletedV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.WorkerExecutionCompletedV2]) } @@ -2543,7 +2531,7 @@ final case class NoOpV2( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.NoOpV2.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.NoOpV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.NoOpV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.NoOpV2]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlcommandsProto.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlcommandsProto.scala index 273ceb5655f..d2c71617e83 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlcommandsProto.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/ControlcommandsProto.scala @@ -108,9 +108,8 @@ object ControlcommandsProto extends _root_.scalapb.GeneratedFileObject { XBsZXRlZBhlIAEoCzJILmVkdS51Y2kuaWNzLmFtYmVyLmVuZ2luZS5hcmNoaXRlY3R1cmUud29ya2VyLldvcmtlckV4ZWN1dGlvb kNvbXBsZXRlZFYyQh3iPxoSGHdvcmtlckV4ZWN1dGlvbkNvbXBsZXRlZEgAUhh3b3JrZXJFeGVjdXRpb25Db21wbGV0ZWQSVwoFb m9fb3AYj04gASgLMjQuZWR1LnVjaS5pY3MuYW1iZXIuZW5naW5lLmFyY2hpdGVjdHVyZS53b3JrZXIuTm9PcFYyQgniPwYSBG5vT - 3BIAFIEbm9PcEIOCgxzZWFsZWRfdmFsdWUqegoSQ29uc29sZU1lc3NhZ2VUeXBlEhUKBVBSSU5UEAAaCuI/BxIFUFJJTlQSFQoFR - VJST1IQARoK4j8HEgVFUlJPUhIZCgdDT01NQU5EEAIaDOI/CRIHQ09NTUFORBIbCghERUJVR0dFUhADGg3iPwoSCERFQlVHR0VSQ - gniPwZIAFgAeAFiBnByb3RvMw==""" + 3BIAFIEbm9PcEIOCgxzZWFsZWRfdmFsdWUqRQoSQ29uc29sZU1lc3NhZ2VUeXBlEgkKBVBSSU5UEAASCQoFRVJST1IQARILCgdDT + 01NQU5EEAISDAoIREVCVUdHRVIQA0IJ4j8GSABYAHgBYgZwcm90bzM=""" ).mkString) lazy val scalaDescriptor: _root_.scalapb.descriptors.FileDescriptor = { val scalaProto = com.google.protobuf.descriptor.FileDescriptorProto.parseFrom(ProtoBytes) diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/LinkOrdinal.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/LinkOrdinal.scala index 5100ef4067a..a4d35e4b32b 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/LinkOrdinal.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlcommands/LinkOrdinal.scala @@ -11,13 +11,13 @@ final case class LinkOrdinal( portOrdinal: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[LinkOrdinal] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = link - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PhysicalLink.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -31,18 +31,17 @@ final case class LinkOrdinal( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = link - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PhysicalLink.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -77,7 +76,7 @@ final case class LinkOrdinal( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlcommands.LinkOrdinal.type = edu.uci.ics.amber.engine.architecture.worker.controlcommands.LinkOrdinal + def companion = edu.uci.ics.amber.engine.architecture.worker.controlcommands.LinkOrdinal // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.LinkOrdinal]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlException.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlException.scala index ea646de6306..2663cb2b113 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlException.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlException.scala @@ -10,8 +10,8 @@ final case class ControlException( msg: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ControlException] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -23,13 +23,12 @@ final case class ControlException( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -55,7 +54,7 @@ final case class ControlException( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlException.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlException + def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlException // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ControlException]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlReturnV2.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlReturnV2.scala index e1219f24715..2b772db787f 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlReturnV2.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/ControlReturnV2.scala @@ -10,8 +10,8 @@ final case class ControlReturnV2( value: edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2.Value ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ControlReturnV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 if (value.controlException.isDefined) { val __value = value.controlException.get @@ -36,13 +36,12 @@ final case class ControlReturnV2( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { value.controlException.foreach { __v => @@ -106,7 +105,7 @@ final case class ControlReturnV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2 + def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.ControlReturnV2]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/CurrentInputTupleInfo.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/CurrentInputTupleInfo.scala index 1efec257a3d..d35580c38f5 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/CurrentInputTupleInfo.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/CurrentInputTupleInfo.scala @@ -14,7 +14,7 @@ final case class CurrentInputTupleInfo( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.CurrentInputTupleInfo.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.CurrentInputTupleInfo + def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.CurrentInputTupleInfo // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.CurrentInputTupleInfo]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/EvaluatedValue.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/EvaluatedValue.scala index efa427e0914..48f844d2d06 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/EvaluatedValue.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/EvaluatedValue.scala @@ -11,8 +11,8 @@ final case class EvaluatedValue( attributes: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue] ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[EvaluatedValue] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 if (value.isDefined) { val __value = value.get @@ -25,13 +25,12 @@ final case class EvaluatedValue( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { value.foreach { __v => @@ -51,7 +50,7 @@ final case class EvaluatedValue( def clearValue: EvaluatedValue = copy(value = _root_.scala.None) def withValue(__v: edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue): EvaluatedValue = copy(value = Option(__v)) def clearAttributes = copy(attributes = _root_.scala.Seq.empty) - def addAttributes(__vs: edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue *): EvaluatedValue = addAllAttributes(__vs) + def addAttributes(__vs: edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue*): EvaluatedValue = addAllAttributes(__vs) def addAllAttributes(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue]): EvaluatedValue = copy(attributes = attributes ++ __vs) def withAttributes(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue]): EvaluatedValue = copy(attributes = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -68,7 +67,7 @@ final case class EvaluatedValue( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue + def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.EvaluatedValue]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/TypedValue.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/TypedValue.scala index 7e94957bd0e..388be4a87bf 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/TypedValue.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/controlreturns/TypedValue.scala @@ -14,8 +14,8 @@ final case class TypedValue( expandable: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[TypedValue] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -55,13 +55,12 @@ final case class TypedValue( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -135,7 +134,7 @@ final case class TypedValue( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue.type = edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue + def companion = edu.uci.ics.amber.engine.architecture.worker.controlreturns.TypedValue // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.TypedValue]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/PortTupleCountMapping.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/PortTupleCountMapping.scala index 3895efd6186..fa56edca692 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/PortTupleCountMapping.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/PortTupleCountMapping.scala @@ -11,13 +11,13 @@ final case class PortTupleCountMapping( tupleCount: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PortTupleCountMapping] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = portId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -31,18 +31,17 @@ final case class PortTupleCountMapping( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = portId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -77,7 +76,7 @@ final case class PortTupleCountMapping( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping.type = edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping + def companion = edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.PortTupleCountMapping]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/StatisticsProto.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/StatisticsProto.scala index fccb81a1c69..d3641aa2e22 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/StatisticsProto.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/StatisticsProto.scala @@ -32,10 +32,9 @@ object StatisticsProto extends _root_.scalapb.GeneratedFileObject { hIIaWRsZVRpbWVSCGlkbGVUaW1lIooCCg1Xb3JrZXJNZXRyaWNzEnEKDHdvcmtlcl9zdGF0ZRgBIAEoDjI5LmVkdS51Y2kuaWNzL mFtYmVyLmVuZ2luZS5hcmNoaXRlY3R1cmUud29ya2VyLldvcmtlclN0YXRlQhPiPxASC3dvcmtlclN0YXRl8AEBUgt3b3JrZXJTd GF0ZRKFAQoRd29ya2VyX3N0YXRpc3RpY3MYAiABKAsyPi5lZHUudWNpLmljcy5hbWJlci5lbmdpbmUuYXJjaGl0ZWN0dXJlLndvc - mtlci5Xb3JrZXJTdGF0aXN0aWNzQhjiPxUSEHdvcmtlclN0YXRpc3RpY3PwAQFSEHdvcmtlclN0YXRpc3RpY3MqngEKC1dvcmtlc - lN0YXRlEiUKDVVOSU5JVElBTElaRUQQABoS4j8PEg1VTklOSVRJQUxJWkVEEhUKBVJFQURZEAEaCuI/BxIFUkVBRFkSGQoHUlVOT - klORxACGgziPwkSB1JVTk5JTkcSFwoGUEFVU0VEEAMaC+I/CBIGUEFVU0VEEh0KCUNPTVBMRVRFRBAEGg7iPwsSCUNPTVBMRVRFR - EIJ4j8GSABYAHgBYgZwcm90bzM=""" + mtlci5Xb3JrZXJTdGF0aXN0aWNzQhjiPxUSEHdvcmtlclN0YXRpc3RpY3PwAQFSEHdvcmtlclN0YXRpc3RpY3MqUwoLV29ya2VyU + 3RhdGUSEQoNVU5JTklUSUFMSVpFRBAAEgkKBVJFQURZEAESCwoHUlVOTklORxACEgoKBlBBVVNFRBADEg0KCUNPTVBMRVRFRBAEQ + gniPwZIAFgAeAFiBnByb3RvMw==""" ).mkString) lazy val scalaDescriptor: _root_.scalapb.descriptors.FileDescriptor = { val scalaProto = com.google.protobuf.descriptor.FileDescriptorProto.parseFrom(ProtoBytes) diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerMetrics.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerMetrics.scala index 80da6c8ca52..ff9b953816b 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerMetrics.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerMetrics.scala @@ -11,8 +11,8 @@ final case class WorkerMetrics( workerStatistics: edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[WorkerMetrics] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -24,20 +24,19 @@ final case class WorkerMetrics( { val __value = workerStatistics - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -48,7 +47,7 @@ final case class WorkerMetrics( }; { val __v = workerStatistics - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -77,7 +76,7 @@ final case class WorkerMetrics( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerMetrics.type = edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerMetrics + def companion = edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerMetrics // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.WorkerMetrics]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerState.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerState.scala index 0a4d506f505..8fa537dff62 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerState.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerState.scala @@ -19,7 +19,6 @@ sealed abstract class WorkerState(val value: _root_.scala.Int) extends _root_.sc object WorkerState extends _root_.scalapb.GeneratedEnumCompanion[WorkerState] { sealed trait Recognized extends WorkerState implicit def enumCompanion: _root_.scalapb.GeneratedEnumCompanion[WorkerState] = this - @SerialVersionUID(0L) case object UNINITIALIZED extends WorkerState(0) with WorkerState.Recognized { val index = 0 @@ -57,6 +56,7 @@ object WorkerState extends _root_.scalapb.GeneratedEnumCompanion[WorkerState] { @SerialVersionUID(0L) final case class Unrecognized(unrecognizedValue: _root_.scala.Int) extends WorkerState(unrecognizedValue) with _root_.scalapb.UnrecognizedEnum + lazy val values = scala.collection.immutable.Seq(UNINITIALIZED, READY, RUNNING, PAUSED, COMPLETED) def fromValue(__value: _root_.scala.Int): WorkerState = __value match { case 0 => UNINITIALIZED diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerStatistics.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerStatistics.scala index 63c2de8b30d..f90c3c166ff 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerStatistics.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/architecture/worker/statistics/WorkerStatistics.scala @@ -14,8 +14,8 @@ final case class WorkerStatistics( idleTime: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[WorkerStatistics] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 inputTupleCount.foreach { __item => val __value = __item @@ -49,13 +49,12 @@ final case class WorkerStatistics( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { inputTupleCount.foreach { __v => @@ -90,11 +89,11 @@ final case class WorkerStatistics( }; } def clearInputTupleCount = copy(inputTupleCount = _root_.scala.Seq.empty) - def addInputTupleCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping *): WorkerStatistics = addAllInputTupleCount(__vs) + def addInputTupleCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping*): WorkerStatistics = addAllInputTupleCount(__vs) def addAllInputTupleCount(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): WorkerStatistics = copy(inputTupleCount = inputTupleCount ++ __vs) def withInputTupleCount(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): WorkerStatistics = copy(inputTupleCount = __v) def clearOutputTupleCount = copy(outputTupleCount = _root_.scala.Seq.empty) - def addOutputTupleCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping *): WorkerStatistics = addAllOutputTupleCount(__vs) + def addOutputTupleCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping*): WorkerStatistics = addAllOutputTupleCount(__vs) def addAllOutputTupleCount(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): WorkerStatistics = copy(outputTupleCount = outputTupleCount ++ __vs) def withOutputTupleCount(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): WorkerStatistics = copy(outputTupleCount = __v) def withDataProcessingTime(__v: _root_.scala.Long): WorkerStatistics = copy(dataProcessingTime = __v) @@ -129,7 +128,7 @@ final case class WorkerStatistics( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics.type = edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics + def companion = edu.uci.ics.amber.engine.architecture.worker.statistics.WorkerStatistics // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.architecture.worker.WorkerStatistics]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/ActorCommand.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/ActorCommand.scala index 53f0368a9a0..db9e024e44e 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/ActorCommand.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/ActorCommand.scala @@ -37,8 +37,8 @@ final case class ActorCommandMessage( sealedValue: edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage.SealedValue ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ActorCommandMessage] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 if (sealedValue.backpressure.isDefined) { val __value = sealedValue.backpressure.get @@ -51,13 +51,12 @@ final case class ActorCommandMessage( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { sealedValue.backpressure.foreach { __v => @@ -93,7 +92,7 @@ final case class ActorCommandMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage.type = edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage + def companion = edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage def toActorCommand: edu.uci.ics.amber.engine.common.actormessage.ActorCommand = edu.uci.ics.amber.engine.common.actormessage.ActorCommand.ActorCommandTypeMapper.toCustom(this) // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ActorCommand]) } @@ -196,8 +195,8 @@ final case class Backpressure( enableBackpressure: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.common.actormessage.ActorCommand.NonEmpty with scalapb.lenses.Updatable[Backpressure] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -209,13 +208,12 @@ final case class Backpressure( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -241,7 +239,7 @@ final case class Backpressure( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.actormessage.Backpressure.type = edu.uci.ics.amber.engine.common.actormessage.Backpressure + def companion = edu.uci.ics.amber.engine.common.actormessage.Backpressure // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.Backpressure]) } @@ -300,7 +298,7 @@ final case class CreditUpdate( def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = throw new MatchError(__fieldNumber) def getField(__field: _root_.scalapb.descriptors.FieldDescriptor): _root_.scalapb.descriptors.PValue = throw new MatchError(__field) def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.actormessage.CreditUpdate.type = edu.uci.ics.amber.engine.common.actormessage.CreditUpdate + def companion = edu.uci.ics.amber.engine.common.actormessage.CreditUpdate // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.CreditUpdate]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/PythonActorMessage.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/PythonActorMessage.scala index 9d4b717d432..7a4d99136c2 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/PythonActorMessage.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/actormessage/PythonActorMessage.scala @@ -10,31 +10,30 @@ final case class PythonActorMessage( payload: edu.uci.ics.amber.engine.common.actormessage.ActorCommand ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PythonActorMessage] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage._typemapper_payload.toBase(payload) - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage._typemapper_payload.toBase(payload) - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.actormessage.ActorCommandMessage.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -57,7 +56,7 @@ final case class PythonActorMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage.type = edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage + def companion = edu.uci.ics.amber.engine.common.actormessage.PythonActorMessage // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PythonActorMessage]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/ControlPayloadV2.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/ControlPayloadV2.scala index 8fa604cf407..1e6a9c304ed 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/ControlPayloadV2.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/ControlPayloadV2.scala @@ -37,8 +37,8 @@ final case class ControlPayloadV2Message( sealedValue: edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message.SealedValue ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ControlPayloadV2Message] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 if (sealedValue.controlInvocation.isDefined) { val __value = sealedValue.controlInvocation.get @@ -51,13 +51,12 @@ final case class ControlPayloadV2Message( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { sealedValue.controlInvocation.foreach { __v => @@ -93,7 +92,7 @@ final case class ControlPayloadV2Message( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message.type = edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message + def companion = edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message def toControlPayloadV2: edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2 = edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2.ControlPayloadV2TypeMapper.toCustom(this) // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ControlPayloadV2]) } @@ -197,8 +196,8 @@ final case class ControlInvocationV2( command: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2 ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2.NonEmpty with scalapb.lenses.Updatable[ControlInvocationV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -210,20 +209,19 @@ final case class ControlInvocationV2( { val __value = edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2._typemapper_command.toBase(command) - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -234,7 +232,7 @@ final case class ControlInvocationV2( }; { val __v = edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2._typemapper_command.toBase(command) - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.architecture.worker.controlcommands.ControlCommandV2Message.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -263,7 +261,7 @@ final case class ControlInvocationV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2.type = edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2 + def companion = edu.uci.ics.amber.engine.common.ambermessage.ControlInvocationV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ControlInvocationV2]) } @@ -337,8 +335,8 @@ final case class ReturnInvocationV2( controlReturn: edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2 ) extends scalapb.GeneratedMessage with edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2.NonEmpty with scalapb.lenses.Updatable[ReturnInvocationV2] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -350,20 +348,19 @@ final case class ReturnInvocationV2( { val __value = controlReturn - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -374,7 +371,7 @@ final case class ReturnInvocationV2( }; { val __v = controlReturn - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.architecture.worker.controlreturns.ControlReturnV2.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -403,7 +400,7 @@ final case class ReturnInvocationV2( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.ambermessage.ReturnInvocationV2.type = edu.uci.ics.amber.engine.common.ambermessage.ReturnInvocationV2 + def companion = edu.uci.ics.amber.engine.common.ambermessage.ReturnInvocationV2 // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ReturnInvocationV2]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonControlMessage.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonControlMessage.scala index 7cd342b7bae..331051cadba 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonControlMessage.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonControlMessage.scala @@ -11,38 +11,37 @@ final case class PythonControlMessage( payload: edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2 ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PythonControlMessage] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = tag - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage._typemapper_payload.toBase(payload) - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = tag - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -50,7 +49,7 @@ final case class PythonControlMessage( }; { val __v = edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage._typemapper_payload.toBase(payload) - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.ambermessage.ControlPayloadV2Message.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -79,7 +78,7 @@ final case class PythonControlMessage( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage.type = edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage + def companion = edu.uci.ics.amber.engine.common.ambermessage.PythonControlMessage // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PythonControlMessage]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonDataHeader.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonDataHeader.scala index 4a25ce1475e..03d33ecf93a 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonDataHeader.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/ambermessage/PythonDataHeader.scala @@ -11,13 +11,13 @@ final case class PythonDataHeader( payloadType: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PythonDataHeader] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = tag - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -31,18 +31,17 @@ final case class PythonDataHeader( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = tag - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -77,7 +76,7 @@ final case class PythonDataHeader( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.ambermessage.PythonDataHeader.type = edu.uci.ics.amber.engine.common.ambermessage.PythonDataHeader + def companion = edu.uci.ics.amber.engine.common.ambermessage.PythonDataHeader // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PythonDataHeader]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ActorVirtualIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ActorVirtualIdentity.scala index 51bce383b66..c8db20851ef 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ActorVirtualIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ActorVirtualIdentity.scala @@ -10,8 +10,8 @@ final case class ActorVirtualIdentity( name: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ActorVirtualIdentity] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -23,13 +23,12 @@ final case class ActorVirtualIdentity( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -55,7 +54,7 @@ final case class ActorVirtualIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity + def companion = edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ActorVirtualIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelIdentity.scala index f5c72494569..8297da89498 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelIdentity.scala @@ -12,20 +12,20 @@ final case class ChannelIdentity( isControl: _root_.scala.Boolean ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ChannelIdentity] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = fromWorkerId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = toWorkerId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -39,18 +39,17 @@ final case class ChannelIdentity( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = fromWorkerId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -58,7 +57,7 @@ final case class ChannelIdentity( }; { val __v = toWorkerId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -99,7 +98,7 @@ final case class ChannelIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity + def companion = edu.uci.ics.amber.engine.common.virtualidentity.ChannelIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ChannelIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelMarkerIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelMarkerIdentity.scala index 4972ec96149..f9cce189278 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelMarkerIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ChannelMarkerIdentity.scala @@ -10,8 +10,8 @@ final case class ChannelMarkerIdentity( id: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ChannelMarkerIdentity] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -23,13 +23,12 @@ final case class ChannelMarkerIdentity( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -55,7 +54,7 @@ final case class ChannelMarkerIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.virtualidentity.ChannelMarkerIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.ChannelMarkerIdentity + def companion = edu.uci.ics.amber.engine.common.virtualidentity.ChannelMarkerIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ChannelMarkerIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ExecutionIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ExecutionIdentity.scala index d74e8cf99c2..cbb5fc226ca 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ExecutionIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/ExecutionIdentity.scala @@ -10,8 +10,8 @@ final case class ExecutionIdentity( id: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionIdentity] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -23,13 +23,12 @@ final case class ExecutionIdentity( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -55,7 +54,7 @@ final case class ExecutionIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity + def companion = edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/OperatorIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/OperatorIdentity.scala index e553d797887..b1b79dd7884 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/OperatorIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/OperatorIdentity.scala @@ -10,8 +10,8 @@ final case class OperatorIdentity( id: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorIdentity] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -23,13 +23,12 @@ final case class OperatorIdentity( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -55,7 +54,7 @@ final case class OperatorIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity + def companion = edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/PhysicalOpIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/PhysicalOpIdentity.scala index 3cf496f210b..3075b6e8cda 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/PhysicalOpIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/PhysicalOpIdentity.scala @@ -11,13 +11,13 @@ final case class PhysicalOpIdentity( layerName: _root_.scala.Predef.String ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PhysicalOpIdentity] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = logicalOpId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -31,18 +31,17 @@ final case class PhysicalOpIdentity( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = logicalOpId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.OperatorIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -77,7 +76,7 @@ final case class PhysicalOpIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity + def companion = edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PhysicalOpIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/WorkflowIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/WorkflowIdentity.scala index 5e69915365a..a625c7ff256 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/WorkflowIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/virtualidentity/WorkflowIdentity.scala @@ -10,8 +10,8 @@ final case class WorkflowIdentity( id: _root_.scala.Long ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[WorkflowIdentity] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -23,13 +23,12 @@ final case class WorkflowIdentity( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -55,7 +54,7 @@ final case class WorkflowIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.virtualidentity.WorkflowIdentity.type = edu.uci.ics.amber.engine.common.virtualidentity.WorkflowIdentity + def companion = edu.uci.ics.amber.engine.common.virtualidentity.WorkflowIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.WorkflowIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/InputPort.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/InputPort.scala index 6d5791b4999..023c20ed716 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/InputPort.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/InputPort.scala @@ -13,13 +13,13 @@ final case class InputPort( dependencies: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflow.PortIdentity] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[InputPort] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = id - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -44,18 +44,17 @@ final case class InputPort( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = id - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -84,7 +83,7 @@ final case class InputPort( def withDisplayName(__v: _root_.scala.Predef.String): InputPort = copy(displayName = __v) def withAllowMultiLinks(__v: _root_.scala.Boolean): InputPort = copy(allowMultiLinks = __v) def clearDependencies = copy(dependencies = _root_.scala.Seq.empty) - def addDependencies(__vs: edu.uci.ics.amber.engine.common.workflow.PortIdentity *): InputPort = addAllDependencies(__vs) + def addDependencies(__vs: edu.uci.ics.amber.engine.common.workflow.PortIdentity*): InputPort = addAllDependencies(__vs) def addAllDependencies(__vs: Iterable[edu.uci.ics.amber.engine.common.workflow.PortIdentity]): InputPort = copy(dependencies = dependencies ++ __vs) def withDependencies(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflow.PortIdentity]): InputPort = copy(dependencies = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -114,7 +113,7 @@ final case class InputPort( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflow.InputPort.type = edu.uci.ics.amber.engine.common.workflow.InputPort + def companion = edu.uci.ics.amber.engine.common.workflow.InputPort // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.InputPort]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/OutputPort.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/OutputPort.scala index 7823ecb0af6..6a495c698b3 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/OutputPort.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/OutputPort.scala @@ -12,13 +12,13 @@ final case class OutputPort( blocking: _root_.scala.Boolean = false ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OutputPort] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = id - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -39,18 +39,17 @@ final case class OutputPort( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = id - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -97,7 +96,7 @@ final case class OutputPort( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflow.OutputPort.type = edu.uci.ics.amber.engine.common.workflow.OutputPort + def companion = edu.uci.ics.amber.engine.common.workflow.OutputPort // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OutputPort]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PhysicalLink.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PhysicalLink.scala index 651ef332562..747e58691a1 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PhysicalLink.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PhysicalLink.scala @@ -13,52 +13,51 @@ final case class PhysicalLink( toPortId: edu.uci.ics.amber.engine.common.workflow.PortIdentity = edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PhysicalLink] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { val __value = fromOpId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = fromPortId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = toOpId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; { val __value = toPortId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { val __v = fromOpId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.defaultInstance) { _output__.writeTag(1, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -66,7 +65,7 @@ final case class PhysicalLink( }; { val __v = fromPortId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -74,7 +73,7 @@ final case class PhysicalLink( }; { val __v = toOpId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.PhysicalOpIdentity.defaultInstance) { _output__.writeTag(3, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -82,7 +81,7 @@ final case class PhysicalLink( }; { val __v = toPortId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflow.PortIdentity.defaultInstance) { _output__.writeTag(4, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -123,7 +122,7 @@ final case class PhysicalLink( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflow.PhysicalLink.type = edu.uci.ics.amber.engine.common.workflow.PhysicalLink + def companion = edu.uci.ics.amber.engine.common.workflow.PhysicalLink // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PhysicalLink]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PortIdentity.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PortIdentity.scala index e8f98bb680d..7d27211281d 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PortIdentity.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflow/PortIdentity.scala @@ -11,8 +11,8 @@ final case class PortIdentity( internal: _root_.scala.Boolean = false ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[PortIdentity] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -31,13 +31,12 @@ final case class PortIdentity( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -75,7 +74,7 @@ final case class PortIdentity( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflow.PortIdentity.type = edu.uci.ics.amber.engine.common.workflow.PortIdentity + def companion = edu.uci.ics.amber.engine.common.workflow.PortIdentity // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.PortIdentity]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/BreakpointFault.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/BreakpointFault.scala index 5c50e98935f..26f4d36082e 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/BreakpointFault.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/BreakpointFault.scala @@ -11,8 +11,8 @@ final case class BreakpointFault( faultedTuple: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.BreakpointTuple] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[BreakpointFault] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -28,13 +28,12 @@ final case class BreakpointFault( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -71,7 +70,7 @@ final case class BreakpointFault( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.type = edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.BreakpointFault]) } @@ -131,8 +130,8 @@ object BreakpointFault extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb tuple: _root_.scala.Seq[_root_.scala.Predef.String] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[BreakpointTuple] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -155,13 +154,12 @@ object BreakpointFault extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -184,7 +182,7 @@ object BreakpointFault extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb def withId(__v: _root_.scala.Long): BreakpointTuple = copy(id = __v) def withIsInput(__v: _root_.scala.Boolean): BreakpointTuple = copy(isInput = __v) def clearTuple = copy(tuple = _root_.scala.Seq.empty) - def addTuple(__vs: _root_.scala.Predef.String *): BreakpointTuple = addAllTuple(__vs) + def addTuple(__vs: _root_.scala.Predef.String*): BreakpointTuple = addAllTuple(__vs) def addAllTuple(__vs: Iterable[_root_.scala.Predef.String]): BreakpointTuple = copy(tuple = tuple ++ __vs) def withTuple(__v: _root_.scala.Seq[_root_.scala.Predef.String]): BreakpointTuple = copy(tuple = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -209,7 +207,7 @@ object BreakpointFault extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.BreakpointTuple.type = edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.BreakpointTuple + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault.BreakpointTuple // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.BreakpointFault.BreakpointTuple]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/EvaluatedValueList.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/EvaluatedValueList.scala index ad98ad6a8b0..05e7737f95e 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/EvaluatedValueList.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/EvaluatedValueList.scala @@ -10,8 +10,8 @@ final case class EvaluatedValueList( values: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[EvaluatedValueList] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 values.foreach { __item => val __value = __item @@ -20,13 +20,12 @@ final case class EvaluatedValueList( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { values.foreach { __v => @@ -37,7 +36,7 @@ final case class EvaluatedValueList( }; } def clearValues = copy(values = _root_.scala.Seq.empty) - def addValues(__vs: edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue *): EvaluatedValueList = addAllValues(__vs) + def addValues(__vs: edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue*): EvaluatedValueList = addAllValues(__vs) def addAllValues(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue]): EvaluatedValueList = copy(values = values ++ __vs) def withValues(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlreturns.EvaluatedValue]): EvaluatedValueList = copy(values = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -52,7 +51,7 @@ final case class EvaluatedValueList( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList.type = edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.EvaluatedValueList]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionBreakpointStore.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionBreakpointStore.scala index 80e7324bca8..f20f8ae7e75 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionBreakpointStore.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionBreakpointStore.scala @@ -10,8 +10,8 @@ final case class ExecutionBreakpointStore( operatorInfo: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints] = _root_.scala.collection.immutable.Map.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionBreakpointStore] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 operatorInfo.foreach { __item => val __value = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore._typemapper_operatorInfo.toBase(__item) @@ -20,13 +20,12 @@ final case class ExecutionBreakpointStore( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { operatorInfo.foreach { __v => @@ -37,7 +36,7 @@ final case class ExecutionBreakpointStore( }; } def clearOperatorInfo = copy(operatorInfo = _root_.scala.collection.immutable.Map.empty) - def addOperatorInfo(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints) *): ExecutionBreakpointStore = addAllOperatorInfo(__vs) + def addOperatorInfo(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints)*): ExecutionBreakpointStore = addAllOperatorInfo(__vs) def addAllOperatorInfo(__vs: Iterable[(_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints)]): ExecutionBreakpointStore = copy(operatorInfo = operatorInfo ++ __vs) def withOperatorInfo(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints]): ExecutionBreakpointStore = copy(operatorInfo = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -52,7 +51,7 @@ final case class ExecutionBreakpointStore( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionBreakpointStore]) } @@ -105,8 +104,8 @@ object ExecutionBreakpointStore extends scalapb.GeneratedMessageCompanion[edu.uc value: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorInfoEntry] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -122,13 +121,12 @@ object ExecutionBreakpointStore extends scalapb.GeneratedMessageCompanion[edu.uc __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -165,7 +163,7 @@ object ExecutionBreakpointStore extends scalapb.GeneratedMessageCompanion[edu.uc } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore.OperatorInfoEntry.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore.OperatorInfoEntry + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionBreakpointStore.OperatorInfoEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionBreakpointStore.OperatorInfoEntry]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionConsoleStore.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionConsoleStore.scala index 92c20334161..c6c54a195dd 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionConsoleStore.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionConsoleStore.scala @@ -10,8 +10,8 @@ final case class ExecutionConsoleStore( operatorConsole: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole] = _root_.scala.collection.immutable.Map.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionConsoleStore] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 operatorConsole.foreach { __item => val __value = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore._typemapper_operatorConsole.toBase(__item) @@ -20,13 +20,12 @@ final case class ExecutionConsoleStore( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { operatorConsole.foreach { __v => @@ -37,7 +36,7 @@ final case class ExecutionConsoleStore( }; } def clearOperatorConsole = copy(operatorConsole = _root_.scala.collection.immutable.Map.empty) - def addOperatorConsole(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole) *): ExecutionConsoleStore = addAllOperatorConsole(__vs) + def addOperatorConsole(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole)*): ExecutionConsoleStore = addAllOperatorConsole(__vs) def addAllOperatorConsole(__vs: Iterable[(_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole)]): ExecutionConsoleStore = copy(operatorConsole = operatorConsole ++ __vs) def withOperatorConsole(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole]): ExecutionConsoleStore = copy(operatorConsole = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -52,7 +51,7 @@ final case class ExecutionConsoleStore( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionConsoleStore]) } @@ -105,8 +104,8 @@ object ExecutionConsoleStore extends scalapb.GeneratedMessageCompanion[edu.uci.i value: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorConsoleEntry] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -122,13 +121,12 @@ object ExecutionConsoleStore extends scalapb.GeneratedMessageCompanion[edu.uci.i __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -165,7 +163,7 @@ object ExecutionConsoleStore extends scalapb.GeneratedMessageCompanion[edu.uci.i } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore.OperatorConsoleEntry.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore.OperatorConsoleEntry + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionConsoleStore.OperatorConsoleEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionConsoleStore.OperatorConsoleEntry]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionMetadataStore.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionMetadataStore.scala index 0b561891d5c..3c397d55884 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionMetadataStore.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionMetadataStore.scala @@ -13,8 +13,8 @@ final case class ExecutionMetadataStore( isRecovering: _root_.scala.Boolean = false ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionMetadataStore] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -30,7 +30,7 @@ final case class ExecutionMetadataStore( { val __value = executionId - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -44,13 +44,12 @@ final case class ExecutionMetadataStore( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -67,7 +66,7 @@ final case class ExecutionMetadataStore( }; { val __v = executionId - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity.defaultInstance) { _output__.writeTag(3, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -82,7 +81,7 @@ final case class ExecutionMetadataStore( } def withState(__v: edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowAggregatedState): ExecutionMetadataStore = copy(state = __v) def clearFatalErrors = copy(fatalErrors = _root_.scala.Seq.empty) - def addFatalErrors(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError *): ExecutionMetadataStore = addAllFatalErrors(__vs) + def addFatalErrors(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError*): ExecutionMetadataStore = addAllFatalErrors(__vs) def addAllFatalErrors(__vs: Iterable[edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError]): ExecutionMetadataStore = copy(fatalErrors = fatalErrors ++ __vs) def withFatalErrors(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError]): ExecutionMetadataStore = copy(fatalErrors = __v) def withExecutionId(__v: edu.uci.ics.amber.engine.common.virtualidentity.ExecutionIdentity): ExecutionMetadataStore = copy(executionId = __v) @@ -114,7 +113,7 @@ final case class ExecutionMetadataStore( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionMetadataStore.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionMetadataStore + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionMetadataStore // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionMetadataStore]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionStatsStore.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionStatsStore.scala index c9827aebd1c..bb3dbb30049 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionStatsStore.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/ExecutionStatsStore.scala @@ -13,8 +13,8 @@ final case class ExecutionStatsStore( operatorWorkerMapping: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[ExecutionStatsStore] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -41,13 +41,12 @@ final case class ExecutionStatsStore( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -78,11 +77,11 @@ final case class ExecutionStatsStore( def withStartTimeStamp(__v: _root_.scala.Long): ExecutionStatsStore = copy(startTimeStamp = __v) def withEndTimeStamp(__v: _root_.scala.Long): ExecutionStatsStore = copy(endTimeStamp = __v) def clearOperatorInfo = copy(operatorInfo = _root_.scala.collection.immutable.Map.empty) - def addOperatorInfo(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics) *): ExecutionStatsStore = addAllOperatorInfo(__vs) + def addOperatorInfo(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics)*): ExecutionStatsStore = addAllOperatorInfo(__vs) def addAllOperatorInfo(__vs: Iterable[(_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics)]): ExecutionStatsStore = copy(operatorInfo = operatorInfo ++ __vs) def withOperatorInfo(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics]): ExecutionStatsStore = copy(operatorInfo = __v) def clearOperatorWorkerMapping = copy(operatorWorkerMapping = _root_.scala.Seq.empty) - def addOperatorWorkerMapping(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping *): ExecutionStatsStore = addAllOperatorWorkerMapping(__vs) + def addOperatorWorkerMapping(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping*): ExecutionStatsStore = addAllOperatorWorkerMapping(__vs) def addAllOperatorWorkerMapping(__vs: Iterable[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping]): ExecutionStatsStore = copy(operatorWorkerMapping = operatorWorkerMapping ++ __vs) def withOperatorWorkerMapping(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping]): ExecutionStatsStore = copy(operatorWorkerMapping = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -109,7 +108,7 @@ final case class ExecutionStatsStore( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionStatsStore]) } @@ -181,8 +180,8 @@ object ExecutionStatsStore extends scalapb.GeneratedMessageCompanion[edu.uci.ics value: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorInfoEntry] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -198,13 +197,12 @@ object ExecutionStatsStore extends scalapb.GeneratedMessageCompanion[edu.uci.ics __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -241,7 +239,7 @@ object ExecutionStatsStore extends scalapb.GeneratedMessageCompanion[edu.uci.ics } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore.OperatorInfoEntry.type = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore.OperatorInfoEntry + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.ExecutionStatsStore.OperatorInfoEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.ExecutionStatsStore.OperatorInfoEntry]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/FatalErrorType.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/FatalErrorType.scala index fe34ee6210e..5470ffb9857 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/FatalErrorType.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/FatalErrorType.scala @@ -16,7 +16,6 @@ sealed abstract class FatalErrorType(val value: _root_.scala.Int) extends _root_ object FatalErrorType extends _root_.scalapb.GeneratedEnumCompanion[FatalErrorType] { sealed trait Recognized extends FatalErrorType implicit def enumCompanion: _root_.scalapb.GeneratedEnumCompanion[FatalErrorType] = this - @SerialVersionUID(0L) case object COMPILATION_ERROR extends FatalErrorType(0) with FatalErrorType.Recognized { val index = 0 @@ -33,6 +32,7 @@ object FatalErrorType extends _root_.scalapb.GeneratedEnumCompanion[FatalErrorTy @SerialVersionUID(0L) final case class Unrecognized(unrecognizedValue: _root_.scala.Int) extends FatalErrorType(unrecognizedValue) with _root_.scalapb.UnrecognizedEnum + lazy val values = scala.collection.immutable.Seq(COMPILATION_ERROR, EXECUTION_FAILURE) def fromValue(__value: _root_.scala.Int): FatalErrorType = __value match { case 0 => COMPILATION_ERROR diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorBreakpoints.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorBreakpoints.scala index a88ff9f2081..35d1c32ac85 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorBreakpoints.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorBreakpoints.scala @@ -10,8 +10,8 @@ final case class OperatorBreakpoints( unresolvedBreakpoints: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorBreakpoints] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 unresolvedBreakpoints.foreach { __item => val __value = __item @@ -20,13 +20,12 @@ final case class OperatorBreakpoints( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { unresolvedBreakpoints.foreach { __v => @@ -37,7 +36,7 @@ final case class OperatorBreakpoints( }; } def clearUnresolvedBreakpoints = copy(unresolvedBreakpoints = _root_.scala.Seq.empty) - def addUnresolvedBreakpoints(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault *): OperatorBreakpoints = addAllUnresolvedBreakpoints(__vs) + def addUnresolvedBreakpoints(__vs: edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault*): OperatorBreakpoints = addAllUnresolvedBreakpoints(__vs) def addAllUnresolvedBreakpoints(__vs: Iterable[edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault]): OperatorBreakpoints = copy(unresolvedBreakpoints = unresolvedBreakpoints ++ __vs) def withUnresolvedBreakpoints(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.common.workflowruntimestate.BreakpointFault]): OperatorBreakpoints = copy(unresolvedBreakpoints = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -52,7 +51,7 @@ final case class OperatorBreakpoints( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorBreakpoints // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorBreakpoints]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorConsole.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorConsole.scala index a1d98ddf5a0..fd87777a374 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorConsole.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorConsole.scala @@ -11,8 +11,8 @@ final case class OperatorConsole( evaluateExprResults: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList] = _root_.scala.collection.immutable.Map.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorConsole] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 consoleMessages.foreach { __item => val __value = __item @@ -25,13 +25,12 @@ final case class OperatorConsole( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { consoleMessages.foreach { __v => @@ -48,11 +47,11 @@ final case class OperatorConsole( }; } def clearConsoleMessages = copy(consoleMessages = _root_.scala.Seq.empty) - def addConsoleMessages(__vs: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage *): OperatorConsole = addAllConsoleMessages(__vs) + def addConsoleMessages(__vs: edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage*): OperatorConsole = addAllConsoleMessages(__vs) def addAllConsoleMessages(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage]): OperatorConsole = copy(consoleMessages = consoleMessages ++ __vs) def withConsoleMessages(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage]): OperatorConsole = copy(consoleMessages = __v) def clearEvaluateExprResults = copy(evaluateExprResults = _root_.scala.collection.immutable.Map.empty) - def addEvaluateExprResults(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList) *): OperatorConsole = addAllEvaluateExprResults(__vs) + def addEvaluateExprResults(__vs: (_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList)*): OperatorConsole = addAllEvaluateExprResults(__vs) def addAllEvaluateExprResults(__vs: Iterable[(_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList)]): OperatorConsole = copy(evaluateExprResults = evaluateExprResults ++ __vs) def withEvaluateExprResults(__v: _root_.scala.collection.immutable.Map[_root_.scala.Predef.String, edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList]): OperatorConsole = copy(evaluateExprResults = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -69,7 +68,7 @@ final case class OperatorConsole( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorConsole]) } @@ -129,8 +128,8 @@ object OperatorConsole extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb value: _root_.scala.Option[edu.uci.ics.amber.engine.common.workflowruntimestate.EvaluatedValueList] = _root_.scala.None ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[EvaluateExprResultsEntry] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -146,13 +145,12 @@ object OperatorConsole extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -189,7 +187,7 @@ object OperatorConsole extends scalapb.GeneratedMessageCompanion[edu.uci.ics.amb } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole.EvaluateExprResultsEntry.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole.EvaluateExprResultsEntry + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorConsole.EvaluateExprResultsEntry // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorConsole.EvaluateExprResultsEntry]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorMetrics.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorMetrics.scala index a7d8aa04873..32e8c2317df 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorMetrics.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorMetrics.scala @@ -11,8 +11,8 @@ final case class OperatorMetrics( operatorStatistics: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics.defaultInstance ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorMetrics] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -24,20 +24,19 @@ final case class OperatorMetrics( { val __value = operatorStatistics - if (__value.serializedSize != 0) { + if (__value != edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -48,7 +47,7 @@ final case class OperatorMetrics( }; { val __v = operatorStatistics - if (__v.serializedSize != 0) { + if (__v != edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -77,7 +76,7 @@ final case class OperatorMetrics( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorMetrics // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorMetrics]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorStatistics.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorStatistics.scala index fcaa8bde7f3..ac9916e52b0 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorStatistics.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorStatistics.scala @@ -15,8 +15,8 @@ final case class OperatorStatistics( idleTime: _root_.scala.Long = 0L ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorStatistics] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 inputCount.foreach { __item => val __value = __item @@ -57,13 +57,12 @@ final case class OperatorStatistics( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { inputCount.foreach { __v => @@ -104,11 +103,11 @@ final case class OperatorStatistics( }; } def clearInputCount = copy(inputCount = _root_.scala.Seq.empty) - def addInputCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping *): OperatorStatistics = addAllInputCount(__vs) + def addInputCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping*): OperatorStatistics = addAllInputCount(__vs) def addAllInputCount(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): OperatorStatistics = copy(inputCount = inputCount ++ __vs) def withInputCount(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): OperatorStatistics = copy(inputCount = __v) def clearOutputCount = copy(outputCount = _root_.scala.Seq.empty) - def addOutputCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping *): OperatorStatistics = addAllOutputCount(__vs) + def addOutputCount(__vs: edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping*): OperatorStatistics = addAllOutputCount(__vs) def addAllOutputCount(__vs: Iterable[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): OperatorStatistics = copy(outputCount = outputCount ++ __vs) def withOutputCount(__v: _root_.scala.Seq[edu.uci.ics.amber.engine.architecture.worker.statistics.PortTupleCountMapping]): OperatorStatistics = copy(outputCount = __v) def withNumWorkers(__v: _root_.scala.Int): OperatorStatistics = copy(numWorkers = __v) @@ -149,7 +148,7 @@ final case class OperatorStatistics( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorStatistics // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorStatistics]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorWorkerMapping.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorWorkerMapping.scala index 346ba1263ca..3b4c7076147 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorWorkerMapping.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/OperatorWorkerMapping.scala @@ -11,8 +11,8 @@ final case class OperatorWorkerMapping( workerIds: _root_.scala.Seq[_root_.scala.Predef.String] = _root_.scala.Seq.empty ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[OperatorWorkerMapping] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -28,13 +28,12 @@ final case class OperatorWorkerMapping( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -50,7 +49,7 @@ final case class OperatorWorkerMapping( } def withOperatorId(__v: _root_.scala.Predef.String): OperatorWorkerMapping = copy(operatorId = __v) def clearWorkerIds = copy(workerIds = _root_.scala.Seq.empty) - def addWorkerIds(__vs: _root_.scala.Predef.String *): OperatorWorkerMapping = addAllWorkerIds(__vs) + def addWorkerIds(__vs: _root_.scala.Predef.String*): OperatorWorkerMapping = addAllWorkerIds(__vs) def addAllWorkerIds(__vs: Iterable[_root_.scala.Predef.String]): OperatorWorkerMapping = copy(workerIds = workerIds ++ __vs) def withWorkerIds(__v: _root_.scala.Seq[_root_.scala.Predef.String]): OperatorWorkerMapping = copy(workerIds = __v) def getFieldByNumber(__fieldNumber: _root_.scala.Int): _root_.scala.Any = { @@ -70,7 +69,7 @@ final case class OperatorWorkerMapping( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping.type = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.OperatorWorkerMapping // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.OperatorWorkerMapping]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowAggregatedState.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowAggregatedState.scala index 617cf1778ee..acd2f9cfa08 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowAggregatedState.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowAggregatedState.scala @@ -24,7 +24,6 @@ sealed abstract class WorkflowAggregatedState(val value: _root_.scala.Int) exten object WorkflowAggregatedState extends _root_.scalapb.GeneratedEnumCompanion[WorkflowAggregatedState] { sealed trait Recognized extends WorkflowAggregatedState implicit def enumCompanion: _root_.scalapb.GeneratedEnumCompanion[WorkflowAggregatedState] = this - @SerialVersionUID(0L) case object UNINITIALIZED extends WorkflowAggregatedState(0) with WorkflowAggregatedState.Recognized { val index = 0 @@ -97,6 +96,7 @@ object WorkflowAggregatedState extends _root_.scalapb.GeneratedEnumCompanion[Wor @SerialVersionUID(0L) final case class Unrecognized(unrecognizedValue: _root_.scala.Int) extends WorkflowAggregatedState(unrecognizedValue) with _root_.scalapb.UnrecognizedEnum + lazy val values = scala.collection.immutable.Seq(UNINITIALIZED, READY, RUNNING, PAUSING, PAUSED, RESUMING, COMPLETED, FAILED, UNKNOWN, KILLED) def fromValue(__value: _root_.scala.Int): WorkflowAggregatedState = __value match { case 0 => UNINITIALIZED diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowFatalError.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowFatalError.scala index 42b43c4d93b..4f840574f76 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowFatalError.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowFatalError.scala @@ -15,8 +15,8 @@ final case class WorkflowFatalError( workerId: _root_.scala.Predef.String = "" ) extends scalapb.GeneratedMessage with scalapb.lenses.Updatable[WorkflowFatalError] { @transient - private[this] var __serializedSizeMemoized: _root_.scala.Int = 0 - private[this] def __computeSerializedSize(): _root_.scala.Int = { + private[this] var __serializedSizeCachedValue: _root_.scala.Int = 0 + private[this] def __computeSerializedValue(): _root_.scala.Int = { var __size = 0 { @@ -28,7 +28,7 @@ final case class WorkflowFatalError( { val __value = timestamp - if (__value.serializedSize != 0) { + if (__value != com.google.protobuf.timestamp.Timestamp.defaultInstance) { __size += 1 + _root_.com.google.protobuf.CodedOutputStream.computeUInt32SizeNoTag(__value.serializedSize) + __value.serializedSize } }; @@ -63,13 +63,12 @@ final case class WorkflowFatalError( __size } override def serializedSize: _root_.scala.Int = { - var __size = __serializedSizeMemoized - if (__size == 0) { - __size = __computeSerializedSize() + 1 - __serializedSizeMemoized = __size + var read = __serializedSizeCachedValue + if (read == 0) { + read = __computeSerializedValue() + __serializedSizeCachedValue = read } - __size - 1 - + read } def writeTo(`_output__`: _root_.com.google.protobuf.CodedOutputStream): _root_.scala.Unit = { { @@ -80,7 +79,7 @@ final case class WorkflowFatalError( }; { val __v = timestamp - if (__v.serializedSize != 0) { + if (__v != com.google.protobuf.timestamp.Timestamp.defaultInstance) { _output__.writeTag(2, 2) _output__.writeUInt32NoTag(__v.serializedSize) __v.writeTo(_output__) @@ -157,7 +156,7 @@ final case class WorkflowFatalError( } } def toProtoString: _root_.scala.Predef.String = _root_.scalapb.TextFormat.printToSingleLineUnicodeString(this) - def companion: edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError.type = edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError + def companion = edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowFatalError // @@protoc_insertion_point(GeneratedMessage[edu.uci.ics.amber.engine.common.WorkflowFatalError]) } diff --git a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowruntimestateProto.scala b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowruntimestateProto.scala index 1c86d6baf58..0472dee23ff 100644 --- a/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowruntimestateProto.scala +++ b/core/amber/src/main/scalapb/edu/uci/ics/amber/engine/common/workflowruntimestate/WorkflowruntimestateProto.scala @@ -87,13 +87,10 @@ object WorkflowruntimestateProto extends _root_.scalapb.GeneratedFileObject { XRlUgVzdGF0ZRJoCgxmYXRhbF9lcnJvcnMYAiADKAsyMy5lZHUudWNpLmljcy5hbWJlci5lbmdpbmUuY29tbW9uLldvcmtmbG93R mF0YWxFcnJvckIQ4j8NEgtmYXRhbEVycm9yc1ILZmF0YWxFcnJvcnMSaQoLZXhlY3V0aW9uSWQYAyABKAsyMi5lZHUudWNpLmljc y5hbWJlci5lbmdpbmUuY29tbW9uLkV4ZWN1dGlvbklkZW50aXR5QhPiPxASC2V4ZWN1dGlvbklk8AEBUgtleGVjdXRpb25JZBI2C - g1pc19yZWNvdmVyaW5nGAQgASgIQhHiPw4SDGlzUmVjb3ZlcmluZ1IMaXNSZWNvdmVyaW5nKm4KDkZhdGFsRXJyb3JUeXBlEi0KE - UNPTVBJTEFUSU9OX0VSUk9SEAAaFuI/ExIRQ09NUElMQVRJT05fRVJST1ISLQoRRVhFQ1VUSU9OX0ZBSUxVUkUQARoW4j8TEhFFW - EVDVVRJT05fRkFJTFVSRSqvAgoXV29ya2Zsb3dBZ2dyZWdhdGVkU3RhdGUSJQoNVU5JTklUSUFMSVpFRBAAGhLiPw8SDVVOSU5JV - ElBTElaRUQSFQoFUkVBRFkQARoK4j8HEgVSRUFEWRIZCgdSVU5OSU5HEAIaDOI/CRIHUlVOTklORxIZCgdQQVVTSU5HEAMaDOI/C - RIHUEFVU0lORxIXCgZQQVVTRUQQBBoL4j8IEgZQQVVTRUQSGwoIUkVTVU1JTkcQBRoN4j8KEghSRVNVTUlORxIdCglDT01QTEVUR - UQQBhoO4j8LEglDT01QTEVURUQSFwoGRkFJTEVEEAcaC+I/CBIGRkFJTEVEEhkKB1VOS05PV04QCBoM4j8JEgdVTktOT1dOEhcKB - ktJTExFRBAJGgviPwgSBktJTExFREIJ4j8GSABYAHgAYgZwcm90bzM=""" + g1pc19yZWNvdmVyaW5nGAQgASgIQhHiPw4SDGlzUmVjb3ZlcmluZ1IMaXNSZWNvdmVyaW5nKj4KDkZhdGFsRXJyb3JUeXBlEhUKE + UNPTVBJTEFUSU9OX0VSUk9SEAASFQoRRVhFQ1VUSU9OX0ZBSUxVUkUQASqfAQoXV29ya2Zsb3dBZ2dyZWdhdGVkU3RhdGUSEQoNV + U5JTklUSUFMSVpFRBAAEgkKBVJFQURZEAESCwoHUlVOTklORxACEgsKB1BBVVNJTkcQAxIKCgZQQVVTRUQQBBIMCghSRVNVTUlOR + xAFEg0KCUNPTVBMRVRFRBAGEgoKBkZBSUxFRBAHEgsKB1VOS05PV04QCBIKCgZLSUxMRUQQCUIJ4j8GSABYAHgAYgZwcm90bzM=""" ).mkString) lazy val scalaDescriptor: _root_.scalapb.descriptors.FileDescriptor = { val scalaProto = com.google.protobuf.descriptor.FileDescriptorProto.parseFrom(ProtoBytes) From 0ad320a8eb51e156da91b6db5053fffb705822dc Mon Sep 17 00:00:00 2001 From: Shengquan Ni <13672781+shengquan-ni@users.noreply.github.com> Date: Fri, 25 Oct 2024 15:18:44 -0700 Subject: [PATCH 4/4] update --- ...ControllerAsyncRPCHandlerInitializer.scala | 1 + .../RetryWorkflowHandler.scala | 38 +++++++++++++++++++ .../web/service/ExecutionConsoleService.scala | 21 ++++++++++ 3 files changed, 60 insertions(+) create mode 100644 core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/RetryWorkflowHandler.scala diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala index dc333a11fb7..6eac0f9681a 100644 --- a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala +++ b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/ControllerAsyncRPCHandlerInitializer.scala @@ -18,6 +18,7 @@ class ControllerAsyncRPCHandlerInitializer( with StartWorkflowHandler with PortCompletedHandler with ConsoleMessageHandler + with RetryWorkflowHandler with EvaluatePythonExpressionHandler with DebugCommandHandler with TakeGlobalCheckpointHandler diff --git a/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/RetryWorkflowHandler.scala b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/RetryWorkflowHandler.scala new file mode 100644 index 00000000000..256b96fcd8c --- /dev/null +++ b/core/amber/src/main/scala/edu/uci/ics/amber/engine/architecture/controller/promisehandlers/RetryWorkflowHandler.scala @@ -0,0 +1,38 @@ +package edu.uci.ics.amber.engine.architecture.controller.promisehandlers + +import com.twitter.util.Future +import edu.uci.ics.amber.engine.architecture.controller.ControllerAsyncRPCHandlerInitializer +import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ResumeHandler.ResumeWorkflow +import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.RetryWorkflowHandler.RetryWorkflow +import edu.uci.ics.amber.engine.architecture.pythonworker.promisehandlers.ReplayCurrentTupleHandler.ReplayCurrentTuple +import edu.uci.ics.amber.engine.common.rpc.AsyncRPCServer.ControlCommand +import edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity +import edu.uci.ics.amber.engine.common.virtualidentity.util.CONTROLLER + +object RetryWorkflowHandler { + final case class RetryWorkflow(workers: Seq[ActorVirtualIdentity]) extends ControlCommand[Unit] +} + +/** retry the execution of the entire workflow + * + * possible sender: controller, client + */ +trait RetryWorkflowHandler { + this: ControllerAsyncRPCHandlerInitializer => + + registerHandler { (msg: RetryWorkflow, sender) => + { + // if it is a PythonWorker, prepare for retry + // retry message has no effect on completed workers + Future + .collect( + msg.workers + .map(worker => send(ReplayCurrentTuple(), worker)) + ) + .unit + + // resume all workers + execute(ResumeWorkflow(), CONTROLLER) + } + } +} diff --git a/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionConsoleService.scala b/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionConsoleService.scala index e348b4d2f99..947154622b5 100644 --- a/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionConsoleService.scala +++ b/core/amber/src/main/scala/edu/uci/ics/texera/web/service/ExecutionConsoleService.scala @@ -5,11 +5,16 @@ import com.twitter.util.{Await, Duration} import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.ConsoleMessageHandler.ConsoleMessageTriggered import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.EvaluatePythonExpressionHandler.EvaluatePythonExpression import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.DebugCommandHandler.DebugCommand +import edu.uci.ics.amber.engine.architecture.controller.promisehandlers.RetryWorkflowHandler.RetryWorkflow import edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessage import edu.uci.ics.amber.engine.architecture.worker.controlcommands.ConsoleMessageType.COMMAND import edu.uci.ics.amber.engine.common.{AmberConfig, VirtualIdentityUtils} import edu.uci.ics.amber.engine.common.client.AmberClient import edu.uci.ics.amber.engine.common.virtualidentity.ActorVirtualIdentity +import edu.uci.ics.amber.engine.common.workflowruntimestate.WorkflowAggregatedState.{ + RESUMING, + RUNNING +} import edu.uci.ics.texera.web.model.websocket.event.TexeraWebSocketEvent import edu.uci.ics.texera.web.model.websocket.event.python.ConsoleUpdateEvent import edu.uci.ics.texera.web.model.websocket.request.python.{ @@ -23,6 +28,8 @@ import edu.uci.ics.amber.engine.common.workflowruntimestate.{ ExecutionConsoleStore, OperatorConsole } +import edu.uci.ics.texera.web.model.websocket.request.RetryRequest +import edu.uci.ics.texera.web.storage.ExecutionStateStore.updateWorkflowState import edu.uci.ics.texera.web.{SubscriptionManager, WebsocketInput} import java.time.Instant @@ -100,6 +107,20 @@ class ExecutionConsoleService( } } + //Receive retry request + addSubscription(wsInput.subscribe((req: RetryRequest, uidOpt) => { + stateStore.metadataStore.updateState(metadataStore => + updateWorkflowState(RESUMING, metadataStore) + ) + client.sendAsyncWithCallback[Unit]( + RetryWorkflow(req.workers.map(x => ActorVirtualIdentity(x))), + _ => + stateStore.metadataStore.updateState(metadataStore => + updateWorkflowState(RUNNING, metadataStore) + ) + ) + })) + //Receive evaluate python expression addSubscription(wsInput.subscribe((req: PythonExpressionEvaluateRequest, uidOpt) => { val result = Await.result(