package msg

Ordering
  1. Alphabetic
Visibility
  1. Public
  2. Protected

Type Members

  1. final case class AppendEntries(shardId: NormalizedShardId, term: Term, leader: MemberIndex, prevLogIndex: LogEntryIndex, prevLogTerm: Term, entries: Seq[LogEntry] = _root_.scala.Seq.empty, leaderCommit: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  2. final case class AppendEntriesFailed(term: Term, sender: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  3. final case class AppendEntriesSucceeded(term: Term, lastLogIndex: LogEntryIndex, sender: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  4. final case class AppendedEntries(term: Term, logEntries: Seq[LogEntry] = _root_.scala.Seq.empty, prevLogIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  5. final case class AppendedEvent(event: EntityEvent, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  6. final case class BegunNewTerm(term: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  7. final case class Command(command: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  8. final case class CommitLogStoreInternalEvent(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable

    Empty

    Empty

    Annotations
    @SerialVersionUID()
  9. final case class CommitLogStoreSave(shardId: NormalizedShardId, index: LogEntryIndex, committedEvent: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  10. final case class CompactionCompleted(memberIndex: MemberIndex, shardId: NormalizedShardId, snapshotLastLogTerm: Term, snapshotLastLogIndex: LogEntryIndex, entityIds: Seq[NormalizedEntityId] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  11. final case class DetectedNewTerm(term: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  12. final case class EntityEvent(event: Payload, entityId: Option[NormalizedEntityId] = _root_.scala.None, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  13. final case class EntitySnapshot(metadata: EntitySnapshotMetadata, state: EntityState, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  14. final case class EntitySnapshotMetadata(entityId: NormalizedEntityId, logEntryIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  15. final case class EntityState(underlying: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  16. final case class ForwardedCommand(command: Command, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  17. final case class InstallSnapshot(shardId: NormalizedShardId, term: Term, srcMemberIndex: MemberIndex, srcLatestSnapshotLastLogTerm: Term, srcLatestSnapshotLastLogLogIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  18. final case class InstallSnapshotSucceeded(shardId: NormalizedShardId, term: Term, dstLatestSnapshotLastLogLogIndex: LogEntryIndex, sender: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  19. final case class LogEntry(index: LogEntryIndex, event: EntityEvent, term: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  20. final case class LogEntryIndex(underlying: Long, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  21. final case class MemberIndex(role: String, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  22. final case class NoOffset(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable

    empty

    empty

    Annotations
    @SerialVersionUID()
  23. final case class NoOp(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable

    Empty

    Empty

    Annotations
    @SerialVersionUID()
  24. final case class NormalizedEntityId(underlying: String, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  25. final case class NormalizedShardId(underlying: String, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  26. final case class Offset(underlying: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  27. final case class Payload(enclosedMessage: ByteString, serializerId: Int, messageManifest: Option[ByteString] = _root_.scala.None, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  28. final case class PersistentState(currentTerm: Term, replicatedLog: ReplicatedLog, lastSnapshotStatus: SnapshotStatus, votedFor: Option[MemberIndex] = _root_.scala.None, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  29. final case class ReplicatedLog(entries: Seq[LogEntry] = _root_.scala.Seq.empty, ancestorLastTerm: Term, ancestorLastIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  30. final case class ReplicationEnvelope(entityId: String, message: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  31. final case class RequestVote(shardId: NormalizedShardId, term: Term, candidate: MemberIndex, lastLogIndex: LogEntryIndex, lastLogTerm: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  32. final case class RequestVoteAccepted(term: Term, sender: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  33. final case class RequestVoteDenied(term: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  34. final case class Sequence(value: Long, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  35. final case class SnapshotStatus(snapshotLastTerm: Term, snapshotLastLogIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  36. final case class SnapshotSyncCompleted(snapshotLastLogTerm: Term, snapshotLastLogIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  37. final case class SuspendEntity(shardId: NormalizedShardId, entityId: NormalizedEntityId, stopMessage: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  38. final case class SyncCompleted(offset: Offset, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  39. final case class SyncProgress(offset: Offset, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  40. final case class Term(term: Long, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  41. final case class TimeBasedUUID(mostSigBits: Long, leastSigBits: Long, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  42. final case class TryCreateEntity(shardId: NormalizedShardId, entityId: NormalizedEntityId, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()
  43. final case class Voted(term: Term, candidate: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
    Annotations
    @SerialVersionUID()

Value Members

  1. object AppendEntries extends GeneratedMessageCompanion[AppendEntries] with Serializable
  2. object AppendEntriesFailed extends GeneratedMessageCompanion[AppendEntriesFailed] with Serializable
  3. object AppendEntriesSucceeded extends GeneratedMessageCompanion[AppendEntriesSucceeded] with Serializable
  4. object AppendedEntries extends GeneratedMessageCompanion[AppendedEntries] with Serializable
  5. object AppendedEvent extends GeneratedMessageCompanion[AppendedEvent] with Serializable
  6. object BegunNewTerm extends GeneratedMessageCompanion[BegunNewTerm] with Serializable
  7. object ClusterReplicationProto extends GeneratedFileObject
  8. object Command extends GeneratedMessageCompanion[Command] with Serializable
  9. object CommitLogStoreInternalEvent extends GeneratedMessageCompanion[CommitLogStoreInternalEvent] with Serializable
  10. object CommitLogStoreSave extends GeneratedMessageCompanion[CommitLogStoreSave] with Serializable
  11. object CompactionCompleted extends GeneratedMessageCompanion[CompactionCompleted] with Serializable
  12. object DetectedNewTerm extends GeneratedMessageCompanion[DetectedNewTerm] with Serializable
  13. object EntityEvent extends GeneratedMessageCompanion[EntityEvent] with Serializable
  14. object EntitySnapshot extends GeneratedMessageCompanion[EntitySnapshot] with Serializable
  15. object EntitySnapshotMetadata extends GeneratedMessageCompanion[EntitySnapshotMetadata] with Serializable
  16. object EntityState extends GeneratedMessageCompanion[EntityState] with Serializable
  17. object ForwardedCommand extends GeneratedMessageCompanion[ForwardedCommand] with Serializable
  18. object InstallSnapshot extends GeneratedMessageCompanion[InstallSnapshot] with Serializable
  19. object InstallSnapshotSucceeded extends GeneratedMessageCompanion[InstallSnapshotSucceeded] with Serializable
  20. object LogEntry extends GeneratedMessageCompanion[LogEntry] with Serializable
  21. object LogEntryIndex extends GeneratedMessageCompanion[LogEntryIndex] with Serializable
  22. object MemberIndex extends GeneratedMessageCompanion[MemberIndex] with Serializable
  23. object NoOffset extends GeneratedMessageCompanion[NoOffset] with Serializable
  24. object NoOp extends GeneratedMessageCompanion[NoOp] with Serializable
  25. object NormalizedEntityId extends GeneratedMessageCompanion[NormalizedEntityId] with Serializable
  26. object NormalizedShardId extends GeneratedMessageCompanion[NormalizedShardId] with Serializable
  27. object Offset extends GeneratedMessageCompanion[Offset] with Serializable
  28. object Payload extends GeneratedMessageCompanion[Payload] with Serializable
  29. object PersistentState extends GeneratedMessageCompanion[PersistentState] with Serializable
  30. object ReplicatedLog extends GeneratedMessageCompanion[ReplicatedLog] with Serializable
  31. object ReplicationEnvelope extends GeneratedMessageCompanion[ReplicationEnvelope] with Serializable
  32. object RequestVote extends GeneratedMessageCompanion[RequestVote] with Serializable
  33. object RequestVoteAccepted extends GeneratedMessageCompanion[RequestVoteAccepted] with Serializable
  34. object RequestVoteDenied extends GeneratedMessageCompanion[RequestVoteDenied] with Serializable
  35. object Sequence extends GeneratedMessageCompanion[Sequence] with Serializable
  36. object SnapshotStatus extends GeneratedMessageCompanion[SnapshotStatus] with Serializable
  37. object SnapshotSyncCompleted extends GeneratedMessageCompanion[SnapshotSyncCompleted] with Serializable
  38. object SuspendEntity extends GeneratedMessageCompanion[SuspendEntity] with Serializable
  39. object SyncCompleted extends GeneratedMessageCompanion[SyncCompleted] with Serializable
  40. object SyncProgress extends GeneratedMessageCompanion[SyncProgress] with Serializable
  41. object Term extends GeneratedMessageCompanion[Term] with Serializable
  42. object TimeBasedUUID extends GeneratedMessageCompanion[TimeBasedUUID] with Serializable
  43. object TryCreateEntity extends GeneratedMessageCompanion[TryCreateEntity] with Serializable
  44. object Voted extends GeneratedMessageCompanion[Voted] with Serializable

Ungrouped