Packages

p

eventstore

package eventstore

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. eventstore
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. trait AbstractPersistentSubscriptionActor[T] extends Actor with ActorLogging
  2. trait AbstractSubscriptionActor[T] extends Actor with ActorLogging
  3. class AccessDeniedException extends EsException
    Annotations
    @SerialVersionUID()
  4. type ByteString = akka.util.ByteString
  5. class CannotEstablishConnectionException extends EsException
    Annotations
    @SerialVersionUID()
  6. sealed trait ClassTags[O, I] extends AnyRef
  7. class CommandNotExpectedException extends EsException
    Annotations
    @SerialVersionUID()
  8. sealed trait ConsumerStrategy extends AnyRef
  9. case class Content(value: ByteString = ByteString.empty, contentType: ContentType = ContentType.Binary) extends Product with Serializable
    Annotations
    @SerialVersionUID()
  10. sealed trait ContentType extends AnyRef
  11. sealed trait CreatePersistentSubscriptionError extends RuntimeException with SystemError
  12. sealed trait DeletePersistentSubscriptionError extends RuntimeException with SystemError
  13. case class DeleteResult(logPosition: Position) extends Product with Serializable

    Result type returned after deleting a stream.

    Result type returned after deleting a stream.

    logPosition

    The position of the write in the log

    Annotations
    @SerialVersionUID()
  14. case class DeleteStream(streamId: Id, expectedVersion: Existing = ExpectedVersion.Any, hard: Boolean = false, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  15. case class DeleteStreamCompleted(position: Option[Exact] = None) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  16. class EsConnection extends AnyRef

    Maintains a full duplex connection to the EventStore

    Maintains a full duplex connection to the EventStore

    All operations are handled in a full async manner. Many threads can use an EsConnection at the same time or a single thread can make many asynchronous requests. To get the most performance out of the connection it is generally recommended to use it in this way.

  17. abstract class EsException extends RuntimeException with NoStackTrace
  18. implicit final class EsInt extends AnyVal
  19. implicit final class EsString extends AnyVal
  20. trait EsTransaction extends AnyRef
  21. case class EsTransactionForActor(transactionId: Long, actor: ActorRef)(implicit timeout: Timeout) extends EsTransaction with Product with Serializable
  22. sealed trait Event extends Ordered[Event]
  23. case class EventData(eventType: String, eventId: Uuid = randomUuid, data: Content = Content.Empty, metadata: Content = Content.Empty) extends Product with Serializable
    Annotations
    @SerialVersionUID()
  24. case class EventNotFoundException(streamId: Id, number: EventNumber) extends EsException with Product with Serializable
    Annotations
    @SerialVersionUID()
  25. sealed trait EventNumber extends Ordered[EventNumber]
  26. case class EventRecord(streamId: Id, number: Exact, data: EventData, created: Option[DateTime] = None) extends Event with Product with Serializable
    Annotations
    @SerialVersionUID()
  27. class EventStoreExtension extends Extension
  28. sealed trait EventStream extends AnyRef
  29. sealed trait ExpectedVersion extends AnyRef
  30. case class HttpSettings(uri: Uri = Uri("http://127.0.0.1:2113")) extends Product with Serializable
  31. case class IdentifyClient(version: Int, connectionName: Option[String]) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  32. sealed trait In extends Message
  33. sealed trait InOut extends In with Out
  34. case class IndexedEvent(event: Event, position: Exact) extends Ordered[IndexedEvent] with Product with Serializable
    Annotations
    @SerialVersionUID()
  35. class InvalidOperationException extends EsException
    Annotations
    @SerialVersionUID()
  36. sealed trait Message extends AnyRef
  37. case class NonMetadataEventException(event: Event) extends EsException with Product with Serializable
    Annotations
    @SerialVersionUID()
  38. case class NotAuthenticatedException(pack: PackOut) extends EsException with Product with Serializable
    Annotations
    @SerialVersionUID()
  39. case class NotHandled(reason: Reason) extends RuntimeException with ServerError with Product with Serializable
    Annotations
    @SerialVersionUID()
  40. sealed trait OperationError extends RuntimeException with ServerError
  41. case class OperationTimeoutException extends EsException with Product with Serializable

    OperationTimeoutException

    OperationTimeoutException

    Annotations
    @SerialVersionUID()
  42. sealed trait Out extends Message with OutLike
  43. sealed trait OutLike extends AnyRef
  44. sealed trait OverflowStrategy extends AnyRef
  45. class PersistentSubscriptionActor extends AbstractPersistentSubscriptionActor[Event] with FSM[State, Data]
  46. case class PersistentSubscriptionSettings(resolveLinkTos: Boolean = false, startFrom: EventNumber = EventNumber.Last, extraStatistics: Boolean = false, messageTimeout: FiniteDuration = 30.seconds, maxRetryCount: Int = 500, liveBufferSize: Int = 500, readBatchSize: Int = 10, historyBufferSize: Int = 20, checkPointAfter: FiniteDuration = 2.seconds, minCheckPointCount: Int = 10, maxCheckPointCount: Int = 1000, maxSubscriberCount: Int = 0, consumerStrategy: ConsumerStrategy = ConsumerStrategy.RoundRobin) extends Product with Serializable

    Represents the settings for persistent subscription

    Represents the settings for persistent subscription

    You can use eventstore.j.PersistentSubscriptionSettingsBuilder) from Java

    resolveLinkTos

    Whether to resolve LinkTo events automatically

    startFrom

    Where the subscription should start from, EventNumber

    extraStatistics

    Whether or not in depth latency statistics should be tracked on this subscription.

    messageTimeout

    The amount of time after which a message should be considered to be timedout and retried.

    maxRetryCount

    The maximum number of retries (due to timeout) before a message get considered to be parked

    liveBufferSize

    The size of the buffer listening to live messages as they happen

    readBatchSize

    The number of events read at a time when paging in history

    historyBufferSize

    The number of events to cache when paging through history

    checkPointAfter

    The amount of time to try to checkpoint after

    minCheckPointCount

    The minimum number of messages to checkpoint

    maxCheckPointCount

    maximum number of messages to checkpoint if this number is a reached a checkpoint will be forced.

    maxSubscriberCount

    The maximum number of subscribers allowed.

    consumerStrategy

    The ConsumerStrategy to use for distributing events to client consumers.

    Annotations
    @SerialVersionUID()
  47. sealed trait Position extends Ordered[Position]
  48. case class ProjectionDetails(name: String, effectiveName: String, version: Int, epoch: Int, status: ProjectionStatus, stateReason: String, mode: ProjectionMode, writesInProgress: Int, readsInProgress: Int, progress: Double, bufferedEvents: Int) extends Product with Serializable
  49. class ProjectionException extends EsException
    Annotations
    @SerialVersionUID()
  50. class ProjectionsClient extends ProjectionsUrls

    A client allowing to create, get the status and delete an existing projection.

  51. trait ProjectionsUrls extends AnyRef

    The API miss documentation so I used the C# client as a starting point See : https://github.com/EventStore/EventStore/blob/release-v3.9.0/src/EventStore.ClientAPI/Projections/ProjectionsClient.cs

    The API miss documentation so I used the C# client as a starting point See : https://github.com/EventStore/EventStore/blob/release-v3.9.0/src/EventStore.ClientAPI/Projections/ProjectionsClient.cs

    Attributes
    protected[this]
  52. case class ReadAllEvents(fromPosition: Position = Position.First, maxCount: Int = Settings.Default.readBatchSize, direction: ReadDirection = ReadDirection.Forward, resolveLinkTos: Boolean = Settings.Default.resolveLinkTos, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  53. case class ReadAllEventsCompleted(events: List[IndexedEvent], position: Exact, nextPosition: Exact, direction: ReadDirection) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  54. sealed trait ReadAllEventsError extends RuntimeException with ServerError
  55. sealed trait ReadDirection extends AnyRef
  56. case class ReadEvent(streamId: Id, eventNumber: EventNumber = EventNumber.First, resolveLinkTos: Boolean = Settings.Default.resolveLinkTos, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  57. case class ReadEventCompleted(event: Event) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  58. sealed trait ReadEventError extends RuntimeException with ServerError
  59. case class ReadStreamEvents(streamId: Id, fromNumber: EventNumber = EventNumber.First, maxCount: Int = Settings.Default.readBatchSize, direction: ReadDirection = ReadDirection.Forward, resolveLinkTos: Boolean = Settings.Default.resolveLinkTos, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  60. case class ReadStreamEventsCompleted(events: List[Event], nextEventNumber: EventNumber, lastEventNumber: Exact, endOfStream: Boolean, lastCommitPosition: Long, direction: ReadDirection) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  61. sealed trait ReadStreamEventsError extends RuntimeException with ServerError
  62. case class ResolvedEvent(linkedEvent: EventRecord, linkEvent: EventRecord) extends Event with Product with Serializable
    Annotations
    @SerialVersionUID()
  63. class RetriesLimitReachedException extends EsException
    Annotations
    @SerialVersionUID()
  64. implicit final class RichPartialFunction extends AnyVal
  65. case class ScavengeDatabaseCompleted(totalTime: FiniteDuration, totalSpaceSaved: Long) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  66. sealed trait ScavengeError extends RuntimeException with SystemError
  67. class ScavengeFailedException extends EsException
    Annotations
    @SerialVersionUID()
  68. sealed trait ServerError extends RuntimeException with SystemError
  69. class ServerErrorException extends EsException
    Annotations
    @SerialVersionUID()
  70. case class Settings(address: InetSocketAddress = "127.0.0.1" :: 1113, connectionTimeout: FiniteDuration = 1.second, maxReconnections: Int = 100, reconnectionDelayMin: FiniteDuration = 250.millis, reconnectionDelayMax: FiniteDuration = 10.seconds, defaultCredentials: Option[UserCredentials] = Some(UserCredentials.DefaultAdmin), heartbeatInterval: FiniteDuration = 500.millis, heartbeatTimeout: FiniteDuration = 5.seconds, operationMaxRetries: Int = 10, operationTimeout: FiniteDuration = 30.seconds, resolveLinkTos: Boolean = false, requireMaster: Boolean = true, readBatchSize: Int = 500, bufferSize: Int = 100000, bufferOverflowStrategy: OverflowStrategy = OverflowStrategy.Fail, cluster: Option[ClusterSettings] = None, http: HttpSettings = HttpSettings(), serializationParallelism: Int = 8, serializationOrdered: Boolean = true, connectionName: Option[String] = Some("jvm-client")) extends Product with Serializable

    address

    IP & port of Event Store

    connectionTimeout

    The desired connection timeout

    maxReconnections

    Maximum number of reconnections before backing off, -1 to reconnect forever

    reconnectionDelayMin

    Delay before first reconnection

    reconnectionDelayMax

    Maximum delay on reconnections

    defaultCredentials

    The UserCredentials to use for operations where other UserCredentials are not explicitly supplied.

    heartbeatInterval

    The interval at which to send heartbeat messages.

    heartbeatTimeout

    The interval after which an unacknowledged heartbeat will cause the connection to be considered faulted and disconnect.

    operationMaxRetries

    The maximum number of operation retries

    operationTimeout

    The amount of time before an operation is considered to have timed out

    resolveLinkTos

    Whether to resolve LinkTo events automatically

    requireMaster

    Whether or not to require Event Store to refuse serving read or write request if it is not master

    readBatchSize

    Number of events to be retrieved by client as single message

    bufferSize

    The size of the buffer in element count

    bufferOverflowStrategy

    Strategy that is used when elements cannot fit inside the buffer

    http

    Url to access eventstore though the Http API

    serializationParallelism

    The number of serialization/deserialization functions to be run in parallel

    serializationOrdered

    Serialization done asynchronously and these futures may complete in any order, but results will be used with preserved order if set to true

    connectionName

    Client identifier used to show a friendly name of client in Event Store.

    Annotations
    @SerialVersionUID()
  71. class StreamDeletedException extends EsException
    Annotations
    @SerialVersionUID()
  72. case class StreamEventAppeared(event: IndexedEvent) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  73. case class StreamNotFoundException(streamId: Id) extends EsException with Product with Serializable
    Annotations
    @SerialVersionUID()
  74. class StreamSubscriptionActor extends AbstractSubscriptionActor[Event]
  75. sealed trait SubscribeCompleted extends In
  76. case class SubscribeTo(stream: EventStream, resolveLinkTos: Boolean = Settings.Default.resolveLinkTos) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  77. case class SubscribeToAllCompleted(lastCommit: Long) extends SubscribeCompleted with Product with Serializable
    Annotations
    @SerialVersionUID()
  78. case class SubscribeToStreamCompleted(lastCommit: Long, lastEventNumber: Option[Exact] = None) extends SubscribeCompleted with Product with Serializable
    Annotations
    @SerialVersionUID()
  79. class SubscriptionActor extends AbstractSubscriptionActor[IndexedEvent]
  80. sealed trait SubscriptionDropped extends RuntimeException with ServerError
  81. trait SubscriptionObserver[T] extends AnyRef
  82. class SubscriptionObserverActor[T] extends Actor
  83. trait SystemError extends RuntimeException with NoStackTrace with Serializable
  84. class TransactionActor extends Actor with ActorLogging
  85. case class TransactionCommit(transactionId: Long, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  86. case class TransactionCommitCompleted(transactionId: Long, numbersRange: Option[Range] = None, position: Option[Exact] = None) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  87. case class TransactionStart(streamId: Id, expectedVersion: ExpectedVersion = ExpectedVersion.Any, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  88. case class TransactionStartCompleted(transactionId: Long) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  89. case class TransactionWrite(transactionId: Long, events: List[EventData], requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  90. case class TransactionWriteCompleted(transactionId: Long) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  91. sealed trait UpdatePersistentSubscriptionError extends RuntimeException with SystemError
  92. case class UserCredentials(login: String, password: String) extends Product with Serializable
    Annotations
    @SerialVersionUID()
  93. type Uuid = UUID
  94. case class WithCredentials(out: Out, credentials: UserCredentials) extends OutLike with Product with Serializable
    Annotations
    @SerialVersionUID()
  95. case class WriteEvents(streamId: Id, events: List[EventData], expectedVersion: ExpectedVersion = ExpectedVersion.Any, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  96. case class WriteEventsCompleted(numbersRange: Option[Range] = None, position: Option[Exact] = None) extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  97. case class WriteResult(nextExpectedVersion: Exact, logPosition: Position) extends Product with Serializable

    Result type returned after writing to a stream.

    Result type returned after writing to a stream.

    nextExpectedVersion

    The next expected version for the stream.

    logPosition

    The position of the write in the log

    Annotations
    @SerialVersionUID()
  98. class WrongExpectedVersionException extends EsException
    Annotations
    @SerialVersionUID()

Value Members

  1. val ByteString: akka.util.ByteString.type
  2. val MaxBatchSize: Int
  3. def randomUuid: Uuid
  4. object AllStreamsPublisher
  5. object Authenticate extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  6. object Authenticated extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  7. object BadRequest extends RuntimeException with ServerError with Product with Serializable
    Annotations
    @SerialVersionUID()
  8. object ClassTags
  9. object ClientIdentified extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  10. object ConsumerStrategy

    System supported consumer strategies for use with persistent subscriptions.

  11. object Content extends Serializable
  12. object ContentType
  13. object CreatePersistentSubscriptionError extends Serializable
  14. object DeletePersistentSubscriptionError extends Serializable
  15. object EsConnection
  16. object EsTransaction
  17. object Event
  18. object EventData extends Serializable
  19. object EventNumber
  20. object EventRecord extends Serializable
  21. object EventStoreExtension extends ExtensionId[EventStoreExtension] with ExtensionIdProvider
  22. object EventStream
  23. object ExpectedVersion
  24. object HttpSettings extends Serializable
  25. object InvalidTransactionException extends EsException with Product with Serializable
    Annotations
    @SerialVersionUID()
  26. object LiveProcessingStarted extends Product with Serializable
    Annotations
    @SerialVersionUID()
  27. object NotAuthenticated extends RuntimeException with ServerError with Product with Serializable
    Annotations
    @SerialVersionUID()
  28. object NotHandled extends Serializable
  29. object OperationError extends Serializable
  30. object OperationTimedOut extends RuntimeException with SystemError with Product with Serializable
    Annotations
    @SerialVersionUID()
  31. object OverflowStrategy
  32. object PersistentSubscription
  33. object PersistentSubscriptionActor
  34. object PersistentSubscriptionSettings extends Serializable
  35. object Ping extends InOut with Product with Serializable
    Annotations
    @SerialVersionUID()
  36. object Pong extends InOut with Product with Serializable
    Annotations
    @SerialVersionUID()
  37. object Position
  38. object ProjectionDetails extends Serializable
  39. object ProjectionsClient
  40. object ReadAllEventsError extends Serializable
  41. object ReadDirection
  42. object ReadEvent extends Serializable
  43. object ReadEventError extends Serializable
  44. object ReadStreamEventsError extends Serializable
  45. object ScavengeDatabase extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  46. object ScavengeError extends Serializable
  47. object ScavengeInProgressException extends EsException with Product with Serializable
    Annotations
    @SerialVersionUID()
  48. object Settings extends Serializable
  49. object StreamPublisher
  50. object StreamSubscriptionActor
  51. object SubscriptionActor
  52. object SubscriptionDropped extends Serializable
  53. object SubscriptionObserverActor
  54. object SystemEventType
  55. object TransactionActor
  56. object Unsubscribe extends Out with Product with Serializable
    Annotations
    @SerialVersionUID()
  57. object Unsubscribed extends In with Product with Serializable
    Annotations
    @SerialVersionUID()
  58. object UpdatePersistentSubscriptionError extends Serializable
  59. object UserCredentials extends Serializable
  60. object WriteEvents extends Serializable
  61. object WriteResult extends Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped