package proto
- Alphabetic
- Public
- Protected
Type Members
- final case class ConsumeEventIn(message: Message = akka.projection.grpc.internal.proto.ConsumeEventIn.Message.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ConsumeEventIn] with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class ConsumeEventOut(message: Message = akka.projection.grpc.internal.proto.ConsumeEventOut.Message.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ConsumeEventOut] with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class ConsumerEventAck(persistenceId: String = "", seqNr: Long = 0L, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ConsumerEventAck] with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class ConsumerEventInit(originId: String = "", streamId: String = "", fillSequenceNumberGaps: Boolean = false, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ConsumerEventInit] with Product with Serializable
must be the first event from the connecting producer, the producer must then not start emitting events until it sees a ConsumerEventStart
must be the first event from the connecting producer, the producer must then not start emitting events until it sees a ConsumerEventStart
- originId
unique producer identifier showing where the events came from/was produced
- streamId
the stream id of the type of entity the producer wants to push
- fillSequenceNumberGaps
if gaps in sequence numbers may exist and should be filled in
- Annotations
- @SerialVersionUID()
- final case class ConsumerEventStart(filter: Seq[FilterCriteria] = _root_.scala.Seq.empty, replicaInfo: Option[ReplicaInfo] = _root_.scala.None, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ConsumerEventStart] with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class ConsumerFilterStoreState(excludeTags: ByteString = _root_.com.google.protobuf.ByteString.EMPTY, includeTags: ByteString = _root_.com.google.protobuf.ByteString.EMPTY, excludeRegexEntityIds: ByteString = _root_.com.google.protobuf.ByteString.EMPTY, includeRegexEntityIds: ByteString = _root_.com.google.protobuf.ByteString.EMPTY, excludeEntityIds: ByteString = _root_.com.google.protobuf.ByteString.EMPTY, includeEntityOffsets: Option[SeqNrMap] = _root_.scala.None, includeTopics: ByteString = _root_.com.google.protobuf.ByteString.EMPTY, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ConsumerFilterStoreState] with Product with Serializable
- excludeTags
ORSet serialized with Akka's ReplicatedDataSerializer
- includeTags
ORSet serialized with Akka's ReplicatedDataSerializer
- excludeRegexEntityIds
ORSet serialized with Akka's ReplicatedDataSerializer
- includeRegexEntityIds
ORSet serialized with Akka's ReplicatedDataSerializer
- excludeEntityIds
ORSet serialized with Akka's ReplicatedDataSerializer
- includeTopics
ORSet serialized with Akka's ReplicatedDataSerializer
- Annotations
- @SerialVersionUID()
- final case class EntityIdOffset(entityId: String = "", seqNr: Long = 0L, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[EntityIdOffset] with Product with Serializable
- seqNr
If this is defined (> 0) events are replayed from the given sequence number (inclusive).
- Annotations
- @SerialVersionUID()
- final case class Event(persistenceId: String = "", seqNr: Long = 0L, slice: Int = 0, offset: Seq[Offset] = _root_.scala.Seq.empty, payload: Option[Any] = _root_.scala.None, source: String = "", metadata: Option[Any] = _root_.scala.None, tags: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[Event] with Product with Serializable
- payload
The event payload may be serialized as Protobuf message when the type_url prefix is
type.googleapis.com/
or with Akka serialization when the type_url prefixser.akka.io/
. For Akka serialization, the serializer id and manifest are encoded into a custom type_url schema. Note that the payload is empty for backtracking events, seesource
.- source
"" for ordinary events. "BT" for backtracking events. "PS" for PubSub events.
- Annotations
- @SerialVersionUID()
- trait EventConsumerService extends AnyRef
EventConsumerService runs on the consumer side and allows a producer to initiate/push events to the consumer.
EventConsumerService runs on the consumer side and allows a producer to initiate/push events to the consumer.
- Events are stored in the event journal on the producer side. 2. Producer side starts an Akka Projection which locally tracks its offset and as projection handler pushes events to a consuming EventConsumerService 3. Consumer stores events directly into a journal 4. Consumer side projections can run against the local journal
- Annotations
- @AkkaGrpcGenerated()
- trait EventConsumerServiceClient extends EventConsumerService with EventConsumerServiceClientPowerApi with AkkaGrpcClient
- Annotations
- @AkkaGrpcGenerated()
- trait EventConsumerServiceClientPowerApi extends AnyRef
- Annotations
- @AkkaGrpcGenerated()
- trait EventConsumerServicePowerApi extends AnyRef
- Annotations
- @AkkaGrpcGenerated()
- trait EventProducerService extends AnyRef
EventProducerService runs on the producer side and implements the producer side of the EventsBySlices query, which can be used with Akka Projection over gRPC.
EventProducerService runs on the producer side and implements the producer side of the EventsBySlices query, which can be used with Akka Projection over gRPC.
- Events are stored in the event journal on the producer side.
2. Consumer side starts an Akka Projection which locally reads its offset
from the Projection offset store.
3. Consumer side establishes a replication stream from the producer service
by sending the
InitReq
with the offset to start from. 4. Events are read from the journal on the producer side and emitted to the replication stream. 5. Consumer side processes the events in a Projection handler. 6. Offset is stored on the consumer side by the Projection offset store. 7. Producer continues to read new events from the journal and emit to the stream. The consumer can define event filters with theFilterCriteria
, which can be included in theInitReq
and also changed in runtime by sendingFilterReq
.
- Annotations
- @AkkaGrpcGenerated()
- Events are stored in the event journal on the producer side.
2. Consumer side starts an Akka Projection which locally reads its offset
from the Projection offset store.
3. Consumer side establishes a replication stream from the producer service
by sending the
- trait EventProducerServiceClient extends EventProducerService with EventProducerServiceClientPowerApi with AkkaGrpcClient
- Annotations
- @AkkaGrpcGenerated()
- trait EventProducerServiceClientPowerApi extends AnyRef
- Annotations
- @AkkaGrpcGenerated()
- trait EventProducerServicePowerApi extends AnyRef
- Annotations
- @AkkaGrpcGenerated()
- final case class EventTimestampRequest(streamId: String = "", persistenceId: String = "", seqNr: Long = 0L, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[EventTimestampRequest] with Product with Serializable
Retrieve the timestamp of a specific event.
Retrieve the timestamp of a specific event.
- Annotations
- @SerialVersionUID()
- final case class EventTimestampResponse(timestamp: Option[Timestamp] = _root_.scala.None, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[EventTimestampResponse] with Product with Serializable
Response to
EventTimestampRequest
.Response to
EventTimestampRequest
.- Annotations
- @SerialVersionUID()
- final case class ExcludeEntityIds(entityIds: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ExcludeEntityIds] with Product with Serializable
Exclude events for entities with the given entity ids, unless there is a matching include filter that overrides the exclude.
Exclude events for entities with the given entity ids, unless there is a matching include filter that overrides the exclude.
- Annotations
- @SerialVersionUID()
- final case class ExcludeRegexEntityIds(matching: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ExcludeRegexEntityIds] with Product with Serializable
Exclude events for entities with entity ids matching the given regular expressions, unless there is a matching include filter that overrides the exclude.
Exclude events for entities with entity ids matching the given regular expressions, unless there is a matching include filter that overrides the exclude.
- Annotations
- @SerialVersionUID()
- final case class ExcludeTags(tags: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ExcludeTags] with Product with Serializable
Exclude events with any of the given tags, unless there is a matching include filter that overrides the exclude.
Exclude events with any of the given tags, unless there is a matching include filter that overrides the exclude.
- Annotations
- @SerialVersionUID()
- final case class FilterCriteria(message: Message = akka.projection.grpc.internal.proto.FilterCriteria.Message.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[FilterCriteria] with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class FilterReq(criteria: Seq[FilterCriteria] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[FilterReq] with Product with Serializable
Add filter criteria to exclude and include events for matching entities.
Add filter criteria to exclude and include events for matching entities.
- Annotations
- @SerialVersionUID()
- final case class FilteredEvent(persistenceId: String = "", seqNr: Long = 0L, slice: Int = 0, offset: Seq[Offset] = _root_.scala.Seq.empty, source: String = "", unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[FilteredEvent] with Product with Serializable
Events that are filtered out are represented by this placeholder to be able to track sequence numbers without holes.
Events that are filtered out are represented by this placeholder to be able to track sequence numbers without holes.
- Annotations
- @SerialVersionUID()
- final case class IncludeEntityIds(entityIdOffset: Seq[EntityIdOffset] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[IncludeEntityIds] with Product with Serializable
Include events for entities with the given entity ids.
Include events for entities with the given entity ids. A matching include overrides a matching exclude.
For the given entity ids a
seq_nr
can be defined to replay all events for the entity from the sequence number (inclusive). Ifseq_nr
is 0 events will not be replayed.- Annotations
- @SerialVersionUID()
- final case class IncludeRegexEntityIds(matching: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[IncludeRegexEntityIds] with Product with Serializable
Include events for entities with entity ids matching the given regular expressions.
Include events for entities with entity ids matching the given regular expressions. A matching include overrides a matching exclude.
- Annotations
- @SerialVersionUID()
- final case class IncludeTags(tags: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[IncludeTags] with Product with Serializable
Include events with any of the given tags.
Include events with any of the given tags. A matching include overrides a matching exclude.
- Annotations
- @SerialVersionUID()
- final case class IncludeTopics(expression: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[IncludeTopics] with Product with Serializable
Include events with any of the given matching topics.
Include events with any of the given matching topics. A matching include overrides a matching exclude.
- expression
topic match expression according to MQTT specification, including wildcards
- Annotations
- @SerialVersionUID()
- final case class InitReq(streamId: String = "", sliceMin: Int = 0, sliceMax: Int = 0, offset: Seq[Offset] = _root_.scala.Seq.empty, filter: Seq[FilterCriteria] = _root_.scala.Seq.empty, replicaInfo: Option[ReplicaInfo] = _root_.scala.None, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[InitReq] with Product with Serializable
The first message must always be this InitReq to setup the stream.
The first message must always be this InitReq to setup the stream. It can only be used as the first message.
- streamId
the logical stream identifier, mapped to a specific internal entity type by the producer settings
- sliceMin
entities are partitioned by a deterministic slice (0-1023), a consumer would handle a slice range from slice_min to slice_max
- offset
start from this offset if empty, then NoOffset if single and no slice defined, then TimestampOffset if any and slice defined, then TimestampOffsetBySlice
- filter
consumer defined event filters
- Annotations
- @SerialVersionUID()
- final case class KeepAlive(unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[KeepAlive] with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class LoadEventRequest(streamId: String = "", persistenceId: String = "", seqNr: Long = 0L, replicaInfo: Option[ReplicaInfo] = _root_.scala.None, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[LoadEventRequest] with Product with Serializable
Lazy loading of a specific event.
Lazy loading of a specific event. Used when payload for a backtracking event is needed.
- streamId
the logical stream identifier, mapped to a specific internal entity type by the producer settings
- Annotations
- @SerialVersionUID()
- final case class LoadEventResponse(message: Message = akka.projection.grpc.internal.proto.LoadEventResponse.Message.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[LoadEventResponse] with Product with Serializable
Response to
LoadEventRequest
.Response to
LoadEventRequest
.- Annotations
- @SerialVersionUID()
- final case class Offset(timestamp: Option[Timestamp] = _root_.scala.None, seen: Seq[PersistenceIdSeqNr] = _root_.scala.Seq.empty, slice: Option[Int] = _root_.scala.None, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[Offset] with Product with Serializable
- seen
Events with these sequence numbers for this timestamp have already been processed and doesn't have to be emitted again. If empty it is assumed to be the persistence_id -> seq_nr of enclosing Event or FilteredEvent.
- slice
If defined then using offsets by slice.
- Annotations
- @SerialVersionUID()
- final case class PersistenceIdSeqNr(persistenceId: String = "", seqNr: Long = 0L, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[PersistenceIdSeqNr] with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class RemoveExcludeEntityIds(entityIds: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[RemoveExcludeEntityIds] with Product with Serializable
Remove a previously added
ExcludeEntityIds
.Remove a previously added
ExcludeEntityIds
.- Annotations
- @SerialVersionUID()
- final case class RemoveExcludeRegexEntityIds(matching: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[RemoveExcludeRegexEntityIds] with Product with Serializable
Remove a previously added
ExcludeRegexEntityIds
.Remove a previously added
ExcludeRegexEntityIds
.- Annotations
- @SerialVersionUID()
- final case class RemoveExcludeTags(tags: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[RemoveExcludeTags] with Product with Serializable
Remove a previously added
ExcludeTags
.Remove a previously added
ExcludeTags
.- Annotations
- @SerialVersionUID()
- final case class RemoveIncludeEntityIds(entityIds: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[RemoveIncludeEntityIds] with Product with Serializable
Remove a previously added
IncludeEntityIds
.Remove a previously added
IncludeEntityIds
.- Annotations
- @SerialVersionUID()
- final case class RemoveIncludeRegexEntityIds(matching: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[RemoveIncludeRegexEntityIds] with Product with Serializable
Remove a previously added
IncludeRegexEntityIds
.Remove a previously added
IncludeRegexEntityIds
.- Annotations
- @SerialVersionUID()
- final case class RemoveIncludeTags(tags: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[RemoveIncludeTags] with Product with Serializable
Remove a previously added
IncludeTags
.Remove a previously added
IncludeTags
.- Annotations
- @SerialVersionUID()
- final case class RemoveIncludeTopics(expression: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[RemoveIncludeTopics] with Product with Serializable
Remove a previously added
IncludeTopics
.Remove a previously added
IncludeTopics
.- Annotations
- @SerialVersionUID()
- final case class ReplayPersistenceId(fromPersistenceIdOffset: Option[PersistenceIdSeqNr] = _root_.scala.None, filterAfterSeqNr: Long = 0L, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ReplayPersistenceId] with Product with Serializable
- filterAfterSeqNr
apply filters for replayed events after this sequence number
- Annotations
- @SerialVersionUID()
- final case class ReplayReq(persistenceIdOffset: Seq[PersistenceIdSeqNr] = _root_.scala.Seq.empty, replayPersistenceIds: Seq[ReplayPersistenceId] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ReplayReq] with Product with Serializable
Replay events for given entities.
Replay events for given entities.
- persistenceIdOffset
deprecated in 1.5.3, use replay_persistence_ids
- Annotations
- @SerialVersionUID()
- final case class ReplicaInfo(replicaId: String = "", otherReplicaIds: Seq[String] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[ReplicaInfo] with Product with Serializable
Used for Replicated Event Sourcing to filter events based on origin.
Used for Replicated Event Sourcing to filter events based on origin. For edge topologies, like star topologies, an edge replica is not connected to all other replicas, but should be able to receive events indirectly via the replica that it is consuming from.
Events originating from other replicas that the consumer is connected to are excluded and emitted as FilteredEvent from the producer side, because the consumer will receive them directly from the other replica. Events originating from the consumer replica itself are excluded (break the cycle). Events originating from the producer replica are always included.
- replicaId
The replica id of the consumer
- otherReplicaIds
Other replicas that the consumer is connected to.
- Annotations
- @SerialVersionUID()
- final case class SeqNrMap(orsetKeys: ByteString = _root_.com.google.protobuf.ByteString.EMPTY, entries: Seq[Entry] = _root_.scala.Seq.empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[SeqNrMap] with Product with Serializable
- orsetKeys
ORSet serialized with Akka's ReplicatedDataSerializer
- Annotations
- @SerialVersionUID()
- final case class StreamIn(message: Message = akka.projection.grpc.internal.proto.StreamIn.Message.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[StreamIn] with Product with Serializable
- Annotations
- @SerialVersionUID()
- final case class StreamOut(message: Message = akka.projection.grpc.internal.proto.StreamOut.Message.Empty, unknownFields: UnknownFieldSet = _root_.scalapb.UnknownFieldSet.empty) extends GeneratedMessage with Updatable[StreamOut] with Product with Serializable
- Annotations
- @SerialVersionUID()
Value Members
- object ConsumeEventIn extends GeneratedMessageCompanion[ConsumeEventIn]
- object ConsumeEventOut extends GeneratedMessageCompanion[ConsumeEventOut]
- object ConsumerEventAck extends GeneratedMessageCompanion[ConsumerEventAck]
- object ConsumerEventInit extends GeneratedMessageCompanion[ConsumerEventInit]
- object ConsumerEventStart extends GeneratedMessageCompanion[ConsumerEventStart]
- object ConsumerFilterStoreState extends GeneratedMessageCompanion[ConsumerFilterStoreState]
- object ConsumerProto extends GeneratedFileObject
- object EntityIdOffset extends GeneratedMessageCompanion[EntityIdOffset]
- object Event extends GeneratedMessageCompanion[Event]
- object EventConsumerProto extends GeneratedFileObject
- object EventConsumerService extends ServiceDescription
- Annotations
- @AkkaGrpcGenerated()
- object EventConsumerServiceClient
- Annotations
- @AkkaGrpcGenerated()
- object EventConsumerServiceHandler
- Annotations
- @ApiMayChange() @AkkaGrpcGenerated()
- object EventConsumerServicePowerApiHandler
- Annotations
- @ApiMayChange() @AkkaGrpcGenerated()
- object EventProducerProto extends GeneratedFileObject
- object EventProducerService extends ServiceDescription
- Annotations
- @AkkaGrpcGenerated()
- object EventProducerServiceClient
- Annotations
- @AkkaGrpcGenerated()
- object EventProducerServiceHandler
- Annotations
- @ApiMayChange() @AkkaGrpcGenerated()
- object EventProducerServicePowerApiHandler
- Annotations
- @ApiMayChange() @AkkaGrpcGenerated()
- object EventTimestampRequest extends GeneratedMessageCompanion[EventTimestampRequest]
- object EventTimestampResponse extends GeneratedMessageCompanion[EventTimestampResponse]
- object ExcludeEntityIds extends GeneratedMessageCompanion[ExcludeEntityIds]
- object ExcludeRegexEntityIds extends GeneratedMessageCompanion[ExcludeRegexEntityIds]
- object ExcludeTags extends GeneratedMessageCompanion[ExcludeTags]
- object FilterCriteria extends GeneratedMessageCompanion[FilterCriteria]
- object FilterReq extends GeneratedMessageCompanion[FilterReq]
- object FilteredEvent extends GeneratedMessageCompanion[FilteredEvent]
- object IncludeEntityIds extends GeneratedMessageCompanion[IncludeEntityIds]
- object IncludeRegexEntityIds extends GeneratedMessageCompanion[IncludeRegexEntityIds]
- object IncludeTags extends GeneratedMessageCompanion[IncludeTags]
- object IncludeTopics extends GeneratedMessageCompanion[IncludeTopics]
- object InitReq extends GeneratedMessageCompanion[InitReq]
- object KeepAlive extends GeneratedMessageCompanion[KeepAlive]
- object LoadEventRequest extends GeneratedMessageCompanion[LoadEventRequest]
- object LoadEventResponse extends GeneratedMessageCompanion[LoadEventResponse]
- object Offset extends GeneratedMessageCompanion[Offset]
- object PersistenceIdSeqNr extends GeneratedMessageCompanion[PersistenceIdSeqNr]
- object RemoveExcludeEntityIds extends GeneratedMessageCompanion[RemoveExcludeEntityIds]
- object RemoveExcludeRegexEntityIds extends GeneratedMessageCompanion[RemoveExcludeRegexEntityIds]
- object RemoveExcludeTags extends GeneratedMessageCompanion[RemoveExcludeTags]
- object RemoveIncludeEntityIds extends GeneratedMessageCompanion[RemoveIncludeEntityIds]
- object RemoveIncludeRegexEntityIds extends GeneratedMessageCompanion[RemoveIncludeRegexEntityIds]
- object RemoveIncludeTags extends GeneratedMessageCompanion[RemoveIncludeTags]
- object RemoveIncludeTopics extends GeneratedMessageCompanion[RemoveIncludeTopics]
- object ReplayPersistenceId extends GeneratedMessageCompanion[ReplayPersistenceId]
- object ReplayReq extends GeneratedMessageCompanion[ReplayReq]
- object ReplicaInfo extends GeneratedMessageCompanion[ReplicaInfo]
- object SeqNrMap extends GeneratedMessageCompanion[SeqNrMap]
- object StreamIn extends GeneratedMessageCompanion[StreamIn]
- object StreamOut extends GeneratedMessageCompanion[StreamOut]