package msg
Ordering
- Alphabetic
Visibility
- Public
- Protected
Type Members
- 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()
- final case class AppendEntriesFailed(term: Term, sender: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class AppendEntriesSucceeded(term: Term, lastLogIndex: LogEntryIndex, sender: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- 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()
- final case class AppendedEvent(event: EntityEvent, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class BegunNewTerm(term: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class Command(command: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class CommitLogStoreInternalEvent(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
Empty
Empty
- Annotations
- @SerialVersionUID()
- final case class CommitLogStoreSave(shardId: NormalizedShardId, index: LogEntryIndex, committedEvent: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- 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()
- final case class DetectedNewTerm(term: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- 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()
- final case class EntitySnapshot(metadata: EntitySnapshotMetadata, state: EntityState, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class EntitySnapshotMetadata(entityId: NormalizedEntityId, logEntryIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class EntityState(underlying: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class ForwardedCommand(command: Command, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- 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()
- 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()
- final case class LogEntry(index: LogEntryIndex, event: EntityEvent, term: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class LogEntryIndex(underlying: Long, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class MemberIndex(role: String, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class NoOffset(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
empty
empty
- Annotations
- @SerialVersionUID()
- final case class NoOp(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
Empty
Empty
- Annotations
- @SerialVersionUID()
- final case class NormalizedEntityId(underlying: String, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class NormalizedShardId(underlying: String, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class Offset(underlying: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- 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()
- 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()
- 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()
- final case class ReplicationEnvelope(entityId: String, message: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- 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()
- final case class RequestVoteAccepted(term: Term, sender: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class RequestVoteDenied(term: Term, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class Sequence(value: Long, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class SnapshotStatus(snapshotLastTerm: Term, snapshotLastLogIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class SnapshotSyncCompleted(snapshotLastLogTerm: Term, snapshotLastLogIndex: LogEntryIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class SuspendEntity(shardId: NormalizedShardId, entityId: NormalizedEntityId, stopMessage: Payload, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class SyncCompleted(offset: Offset, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class SyncProgress(offset: Offset, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class Term(term: Long, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class TimeBasedUUID(mostSigBits: Long, leastSigBits: Long, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class TryCreateEntity(shardId: NormalizedShardId, entityId: NormalizedEntityId, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class Voted(term: Term, candidate: MemberIndex, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Product with Serializable
- Annotations
- @SerialVersionUID()
Value Members
- object AppendEntries extends GeneratedMessageCompanion[AppendEntries] with Serializable
- object AppendEntriesFailed extends GeneratedMessageCompanion[AppendEntriesFailed] with Serializable
- object AppendEntriesSucceeded extends GeneratedMessageCompanion[AppendEntriesSucceeded] with Serializable
- object AppendedEntries extends GeneratedMessageCompanion[AppendedEntries] with Serializable
- object AppendedEvent extends GeneratedMessageCompanion[AppendedEvent] with Serializable
- object BegunNewTerm extends GeneratedMessageCompanion[BegunNewTerm] with Serializable
- object ClusterReplicationProto extends GeneratedFileObject
- object Command extends GeneratedMessageCompanion[Command] with Serializable
- object CommitLogStoreInternalEvent extends GeneratedMessageCompanion[CommitLogStoreInternalEvent] with Serializable
- object CommitLogStoreSave extends GeneratedMessageCompanion[CommitLogStoreSave] with Serializable
- object CompactionCompleted extends GeneratedMessageCompanion[CompactionCompleted] with Serializable
- object DetectedNewTerm extends GeneratedMessageCompanion[DetectedNewTerm] with Serializable
- object EntityEvent extends GeneratedMessageCompanion[EntityEvent] with Serializable
- object EntitySnapshot extends GeneratedMessageCompanion[EntitySnapshot] with Serializable
- object EntitySnapshotMetadata extends GeneratedMessageCompanion[EntitySnapshotMetadata] with Serializable
- object EntityState extends GeneratedMessageCompanion[EntityState] with Serializable
- object ForwardedCommand extends GeneratedMessageCompanion[ForwardedCommand] with Serializable
- object InstallSnapshot extends GeneratedMessageCompanion[InstallSnapshot] with Serializable
- object InstallSnapshotSucceeded extends GeneratedMessageCompanion[InstallSnapshotSucceeded] with Serializable
- object LogEntry extends GeneratedMessageCompanion[LogEntry] with Serializable
- object LogEntryIndex extends GeneratedMessageCompanion[LogEntryIndex] with Serializable
- object MemberIndex extends GeneratedMessageCompanion[MemberIndex] with Serializable
- object NoOffset extends GeneratedMessageCompanion[NoOffset] with Serializable
- object NoOp extends GeneratedMessageCompanion[NoOp] with Serializable
- object NormalizedEntityId extends GeneratedMessageCompanion[NormalizedEntityId] with Serializable
- object NormalizedShardId extends GeneratedMessageCompanion[NormalizedShardId] with Serializable
- object Offset extends GeneratedMessageCompanion[Offset] with Serializable
- object Payload extends GeneratedMessageCompanion[Payload] with Serializable
- object PersistentState extends GeneratedMessageCompanion[PersistentState] with Serializable
- object ReplicatedLog extends GeneratedMessageCompanion[ReplicatedLog] with Serializable
- object ReplicationEnvelope extends GeneratedMessageCompanion[ReplicationEnvelope] with Serializable
- object RequestVote extends GeneratedMessageCompanion[RequestVote] with Serializable
- object RequestVoteAccepted extends GeneratedMessageCompanion[RequestVoteAccepted] with Serializable
- object RequestVoteDenied extends GeneratedMessageCompanion[RequestVoteDenied] with Serializable
- object Sequence extends GeneratedMessageCompanion[Sequence] with Serializable
- object SnapshotStatus extends GeneratedMessageCompanion[SnapshotStatus] with Serializable
- object SnapshotSyncCompleted extends GeneratedMessageCompanion[SnapshotSyncCompleted] with Serializable
- object SuspendEntity extends GeneratedMessageCompanion[SuspendEntity] with Serializable
- object SyncCompleted extends GeneratedMessageCompanion[SyncCompleted] with Serializable
- object SyncProgress extends GeneratedMessageCompanion[SyncProgress] with Serializable
- object Term extends GeneratedMessageCompanion[Term] with Serializable
- object TimeBasedUUID extends GeneratedMessageCompanion[TimeBasedUUID] with Serializable
- object TryCreateEntity extends GeneratedMessageCompanion[TryCreateEntity] with Serializable
- object Voted extends GeneratedMessageCompanion[Voted] with Serializable