Class/Object

it.agilelab.bigdata.wasp.consumers.spark.streaming.actor.master

SparkConsumersStreamingMasterGuardian

Related Docs: object SparkConsumersStreamingMasterGuardian | package master

Permalink

class SparkConsumersStreamingMasterGuardian extends FSM[State, Data] with LoggingFSM[State, Data] with DatabaseOperations with Stash with Logging with PipeToSupport with RetrySupport

Linear Supertypes
RetrySupport, PipeToSupport, Logging, Stash, RequiresMessageQueue[DequeBasedMessageQueueSemantics], UnrestrictedStash, StashSupport, DatabaseOperations, LoggingFSM[master.State, Data], FSM[master.State, Data], ActorLogging, Listeners, Actor, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SparkConsumersStreamingMasterGuardian
  2. RetrySupport
  3. PipeToSupport
  4. Logging
  5. Stash
  6. RequiresMessageQueue
  7. UnrestrictedStash
  8. StashSupport
  9. DatabaseOperations
  10. LoggingFSM
  11. FSM
  12. ActorLogging
  13. Listeners
  14. Actor
  15. AnyRef
  16. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SparkConsumersStreamingMasterGuardian(pipegraphBL: PipegraphBL, watchdogCreator: ChildCreator, collaboratorName: String, retryInterval: FiniteDuration, unschedulableCheckInterval: FiniteDuration, debugActor: Option[ActorRef], initialSchedulingStrategy: SchedulingStrategy)

    Permalink

Type Members

  1. type Event = akka.actor.FSM.Event[Data]

    Permalink
    Definition Classes
    FSM
  2. final class PipeableCompletionStage[T] extends AnyRef

    Permalink
    Definition Classes
    PipeToSupport
  3. final class PipeableFuture[T] extends AnyRef

    Permalink
    Definition Classes
    PipeToSupport
  4. type Receive = PartialFunction[Any, Unit]

    Permalink
    Definition Classes
    Actor
  5. trait Recoverable[F[_]] extends AnyRef

    Permalink
    Definition Classes
    RetrySupport
  6. type State = akka.actor.FSM.State[master.State, Data]

    Permalink
    Definition Classes
    FSM
  7. type StateFunction = PartialFunction[Event, State]

    Permalink
    Definition Classes
    FSM
  8. type StopEvent = akka.actor.FSM.StopEvent[master.State, Data]

    Permalink
    Definition Classes
    FSM
  9. type Timeout = Option[FiniteDuration]

    Permalink
    Definition Classes
    FSM
  10. final class TransformHelper extends AnyRef

    Permalink
    Definition Classes
    FSM
  11. type TransitionHandler = PartialFunction[(master.State, master.State), Unit]

    Permalink
    Definition Classes
    FSM

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. val ->: akka.actor.FSM.->.type

    Permalink
    Definition Classes
    FSM
  4. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  5. val Event: akka.actor.FSM.Event.type

    Permalink
    Definition Classes
    FSM
  6. val StateTimeout: akka.actor.FSM.StateTimeout.type

    Permalink
    Definition Classes
    FSM
  7. val StopEvent: akka.actor.FSM.StopEvent.type

    Permalink
    Definition Classes
    FSM
  8. def aroundPostRestart(reason: Throwable): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
  9. def aroundPostStop(): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
  10. def aroundPreRestart(reason: Throwable, message: Option[Any]): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
  11. def aroundPreStart(): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
  12. def aroundReceive(receive: akka.actor.Actor.Receive, msg: Any): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
  13. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  14. final def cancelTimer(name: String): Unit

    Permalink
    Definition Classes
    FSM
  15. def checkThatModelDoesNotContainLegacyOrRTComponents(model: PipegraphModel): Try[PipegraphModel]

    Permalink

    Preprocessing method that checks that currently not supported components are not used.

    Preprocessing method that checks that currently not supported components are not used.

    model

    The pipegraph model to check

    returns

    The checked pipegraphmodel

    Definition Classes
    DatabaseOperations
  16. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  17. val cluster: Cluster

    Permalink
  18. implicit val context: ActorContext

    Permalink
    Definition Classes
    Actor
  19. def createInstanceOf(model: PipegraphModel): Try[PipegraphInstanceModel]

    Permalink

    Creates an instance of the specified model.

    Creates an instance of the specified model.

    model

    The model to instantiate

    returns

    A Try containing the instance model or an exception

    Definition Classes
    DatabaseOperations
  20. def createInstanceOf(modelName: String): Try[PipegraphInstanceModel]

    Permalink
    Definition Classes
    DatabaseOperations
  21. implicit val ec: ExecutionContext

    Permalink
  22. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  23. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  24. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  25. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  26. def getLog: IndexedSeq[LogEntry[master.State, Data]]

    Permalink
    Attributes
    protected
    Definition Classes
    LoggingFSM
  27. def gossip(msg: Any)(implicit sender: ActorRef): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Listeners
  28. final def goto(nextStateName: master.State): State

    Permalink
    Definition Classes
    FSM
  29. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  30. def identifyCollaboratorOnMember(m: Member): Future[ActorRef]

    Permalink
  31. def identifyPeerActor(peer: String): Future[ActorRef]

    Permalink
  32. final def initialize(): Unit

    Permalink
    Definition Classes
    FSM
  33. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  34. final def isTimerActive(name: String): Boolean

    Permalink
    Definition Classes
    FSM
  35. def listenerManagement: akka.actor.Actor.Receive

    Permalink
    Attributes
    protected
    Definition Classes
    Listeners
  36. val listeners: Set[ActorRef]

    Permalink
    Attributes
    protected
    Definition Classes
    Listeners
  37. def log: LoggingAdapter

    Permalink
    Definition Classes
    ActorLogging
  38. def logDepth: Int

    Permalink
    Definition Classes
    LoggingFSM
  39. def logTermination(reason: Reason): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    FSM
  40. val logger: WaspLogger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  41. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  42. final def nextStateData: Data

    Permalink
    Definition Classes
    FSM
  43. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  44. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  45. final def onTermination(terminationHandler: PartialFunction[StopEvent, Unit]): Unit

    Permalink
    Definition Classes
    FSM
  46. final def onTransition(transitionHandler: TransitionHandler): Unit

    Permalink
    Definition Classes
    FSM
  47. implicit def pipe[T](future: Future[T])(implicit executionContext: ExecutionContext): PipeableFuture[T]

    Permalink
    Definition Classes
    PipeToSupport
  48. implicit def pipeCompletionStage[T](future: CompletionStage[T])(implicit executionContext: ExecutionContext): PipeableCompletionStage[T]

    Permalink
    Definition Classes
    PipeToSupport
  49. val pipegraphBL: PipegraphBL

    Permalink
    Attributes
    protected
  50. def postRestart(reason: Throwable): Unit

    Permalink
    Definition Classes
    Actor
    Annotations
    @throws( classOf[java.lang.Exception] )
  51. def postStop(): Unit

    Permalink
    Definition Classes
    UnrestrictedStash → Actor
  52. def preRestart(reason: Throwable, message: Option[Any]): Unit

    Permalink
    Definition Classes
    UnrestrictedStash → Actor
  53. def preStart(): Unit

    Permalink
    Definition Classes
    Actor
    Annotations
    @throws( classOf[java.lang.Exception] )
  54. def receive: Receive

    Permalink
    Definition Classes
    FSM → Actor
  55. implicit def recoverableFuture(implicit ec: ExecutionContext): Recoverable[Future]

    Permalink
    Definition Classes
    RetrySupport
  56. implicit def recoverableTry: Recoverable[Try]

    Permalink
    Definition Classes
    RetrySupport
  57. def resetStatesWhileRecoveringAndReturnPending(knownMembers: Set[Collaborator]): Try[(Seq[(PipegraphModel, PipegraphInstanceModel)], Seq[(PipegraphModel, PipegraphInstanceModel)])]

    Permalink
    Definition Classes
    DatabaseOperations
  58. def retrievePipegraph(name: String): Try[PipegraphModel]

    Permalink

    Retrieves PipegraphModels with specified name from the db.

    Retrieves PipegraphModels with specified name from the db.

    if no PipegraphModel exist with name failure is returned

    returns

    A Try containing the PipegraphModels or an exception

    Definition Classes
    DatabaseOperations
  59. def retrievePipegraphAndUpdateInstanceToProcessing(pipegraphInstanceModel: PipegraphInstanceModel): Try[(PipegraphModel, PipegraphInstanceModel)]

    Permalink
    Definition Classes
    DatabaseOperations
  60. def retrievePipegraphInstances(status: PipegraphStatus*): Try[Seq[PipegraphInstanceModel]]

    Permalink

    Retrieves PipegraphInstanceModels with specified statuses

    Retrieves PipegraphInstanceModels with specified statuses

    status

    the status of the PipegraphInstanceModel that should be retrieved

    returns

    A Try containing the PipegraphInstanceModels or an exception

    Definition Classes
    DatabaseOperations
  61. def retrievePipegraphInstancesAndPipegraphs(status: PipegraphStatus*): Try[Seq[(PipegraphModel, PipegraphInstanceModel)]]

    Permalink
    Definition Classes
    DatabaseOperations
  62. def retrieveSystemPipegraphs(): Try[Seq[PipegraphModel]]

    Permalink

    Retrieves PipegraphModels that are marked as system

    Retrieves PipegraphModels that are marked as system

    returns

    A Try containing the PipegraphModels or an exception

    Definition Classes
    DatabaseOperations
  63. def retry[F[_], A](retryable: () ⇒ F[A])(implicit arg0: Recoverable[F]): A

    Permalink
  64. def retry[F[_], A](retryInterval: FiniteDuration)(retryable: () ⇒ F[A])(implicit arg0: Recoverable[F]): A

    Permalink
    Definition Classes
    RetrySupport
  65. var schedulingStrategy: SchedulingStrategy

    Permalink
  66. implicit final val self: ActorRef

    Permalink
    Definition Classes
    Actor
  67. final def sender(): ActorRef

    Permalink
    Definition Classes
    Actor
  68. final def setStateTimeout(state: master.State, timeout: Timeout): Unit

    Permalink
    Definition Classes
    FSM
  69. final def setTimer(name: String, msg: Any, timeout: FiniteDuration, repeat: Boolean): Unit

    Permalink
    Definition Classes
    FSM
  70. final def startWith(stateName: master.State, stateData: Data, timeout: Timeout): Unit

    Permalink
    Definition Classes
    FSM
  71. def stash(): Unit

    Permalink
    Definition Classes
    StashSupport
  72. final def stateData: Data

    Permalink
    Definition Classes
    FSM
  73. final def stateName: master.State

    Permalink
    Definition Classes
    FSM
  74. final def stay(): State

    Permalink
    Definition Classes
    FSM
  75. final def stop(reason: Reason, stateData: Data): State

    Permalink
    Definition Classes
    FSM
  76. final def stop(reason: Reason): State

    Permalink
    Definition Classes
    FSM
  77. final def stop(): State

    Permalink
    Definition Classes
    FSM
  78. def supervisorStrategy: SupervisorStrategy

    Permalink
    Definition Classes
    Actor
  79. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  80. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  81. implicit final def total2pf(transitionHandler: (master.State, master.State) ⇒ Unit): TransitionHandler

    Permalink
    Definition Classes
    FSM
  82. final def transform(func: StateFunction): TransformHelper

    Permalink
    Definition Classes
    FSM
  83. def unhandled(message: Any): Unit

    Permalink
    Definition Classes
    Actor
  84. def unstashAll(): Unit

    Permalink
    Definition Classes
    StashSupport
  85. def updateToStatus(jobInstance: PipegraphInstanceModel, targetStatus: PipegraphStatus, maybeError: Option[Throwable] = None): Try[PipegraphInstanceModel]

    Permalink

    Updates the status of the supplied instance to the target status.

    Updates the status of the supplied instance to the target status.

    jobInstance

    The instance to update

    targetStatus

    The target status

    maybeError

    Maybe an error to persist on the database

    returns

    A try containing the updated PipegraphInstanceModel or an exception.

    Definition Classes
    DatabaseOperations
  86. def updateToStatus(pipegraphInstances: Seq[(PipegraphModel, PipegraphInstanceModel)], targetStatus: PipegraphStatus): Try[Seq[(PipegraphModel, PipegraphInstanceModel)]]

    Permalink

    Updates the status of the supplied instances to the target status.

    Updates the status of the supplied instances to the target status.

    pipegraphInstances

    The instances to update

    targetStatus

    The target status

    returns

    A try containing the updated PipegraphInstanceModel or an exception.

    Definition Classes
    DatabaseOperations
  87. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  88. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  89. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  90. val watchdogCreator: ChildCreator

    Permalink
    Attributes
    protected
  91. final def when(stateName: master.State, stateTimeout: FiniteDuration)(stateFunction: StateFunction): Unit

    Permalink
    Definition Classes
    FSM
  92. final def whenUnhandled(stateFunction: StateFunction): Unit

    Permalink
    Definition Classes
    FSM

Inherited from RetrySupport

Inherited from PipeToSupport

Inherited from Logging

Inherited from Stash

Inherited from RequiresMessageQueue[DequeBasedMessageQueueSemantics]

Inherited from UnrestrictedStash

Inherited from StashSupport

Inherited from DatabaseOperations

Inherited from LoggingFSM[master.State, Data]

Inherited from FSM[master.State, Data]

Inherited from ActorLogging

Inherited from Listeners

Inherited from Actor

Inherited from AnyRef

Inherited from Any

Ungrouped