Package

eventstore

Permalink

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

    Permalink
  2. trait AbstractSubscriptionActor[T] extends Actor with ActorLogging

    Permalink
  3. class AccessDeniedException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()
  4. type ByteString = akka.util.ByteString

    Permalink
  5. class CannotEstablishConnectionException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()
  6. sealed trait ClassTags[O, I] extends AnyRef

    Permalink
  7. class CommandNotExpectedException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()
  8. sealed trait ConsumerStrategy extends AnyRef

    Permalink
  9. case class Content(value: ByteString = ByteString.empty, contentType: ContentType = ContentType.Binary) extends Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  10. sealed trait ContentType extends AnyRef

    Permalink
  11. sealed trait CreatePersistentSubscriptionError extends RuntimeException with SystemError

    Permalink
  12. sealed trait DeletePersistentSubscriptionError extends RuntimeException with SystemError

    Permalink
  13. case class DeleteResult(logPosition: Position) extends Product with Serializable

    Permalink

    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

    Permalink
    Annotations
    @SerialVersionUID()
  15. case class DeleteStreamCompleted(position: Option[Exact] = None) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  16. class EsConnection extends AnyRef

    Permalink

    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

    Permalink
  18. implicit final class EsInt extends AnyVal

    Permalink
  19. implicit final class EsString extends AnyVal

    Permalink
  20. trait EsTransaction extends AnyRef

    Permalink
  21. case class EsTransactionForActor(transactionId: Long, actor: ActorRef)(implicit timeout: Timeout) extends EsTransaction with Product with Serializable

    Permalink
  22. sealed trait Event extends Ordered[Event]

    Permalink
  23. case class EventData(eventType: String, eventId: Uuid = randomUuid, data: Content = Content.Empty, metadata: Content = Content.Empty) extends Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  24. case class EventNotFoundException(streamId: Id, number: EventNumber) extends EsException with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  25. sealed trait EventNumber extends Ordered[EventNumber]

    Permalink
  26. case class EventRecord(streamId: Id, number: Exact, data: EventData, created: Option[DateTime] = None) extends Event with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  27. class EventStoreExtension extends Extension

    Permalink
  28. sealed trait EventStream extends AnyRef

    Permalink
  29. sealed trait ExpectedVersion extends AnyRef

    Permalink
  30. case class HttpSettings(uri: Uri = Uri("http://127.0.0.1:2113")) extends Product with Serializable

    Permalink
  31. case class IdentifyClient(version: Int, connectionName: Option[String]) extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  32. sealed trait In extends Message

    Permalink
  33. sealed trait InOut extends In with Out

    Permalink
  34. case class IndexedEvent(event: Event, position: Exact) extends Ordered[IndexedEvent] with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  35. class InvalidOperationException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()
  36. sealed trait Message extends AnyRef

    Permalink
  37. case class NonMetadataEventException(event: Event) extends EsException with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  38. case class NotAuthenticatedException(pack: PackOut) extends EsException with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  39. case class NotHandled(reason: Reason) extends RuntimeException with ServerError with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  40. sealed trait OperationError extends RuntimeException with ServerError

    Permalink
  41. case class OperationTimeoutException extends EsException with Product with Serializable

    Permalink

    OperationTimeoutException

    OperationTimeoutException

    Annotations
    @SerialVersionUID()
  42. sealed trait Out extends Message with OutLike

    Permalink
  43. sealed trait OutLike extends AnyRef

    Permalink
  44. sealed trait OverflowStrategy extends AnyRef

    Permalink
  45. class PersistentSubscriptionActor extends AbstractPersistentSubscriptionActor[Event] with FSM[State, Data]

    Permalink
  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

    Permalink

    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]

    Permalink
  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

    Permalink
  49. class ProjectionException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()
  50. class ProjectionsClient extends ProjectionsUrls

    Permalink

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

  51. trait ProjectionsUrls extends AnyRef

    Permalink

    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

    Permalink
    Annotations
    @SerialVersionUID()
  53. case class ReadAllEventsCompleted(events: List[IndexedEvent], position: Exact, nextPosition: Exact, direction: ReadDirection) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  54. sealed trait ReadAllEventsError extends RuntimeException with ServerError

    Permalink
  55. sealed trait ReadDirection extends AnyRef

    Permalink
  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

    Permalink
    Annotations
    @SerialVersionUID()
  57. case class ReadEventCompleted(event: Event) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  58. sealed trait ReadEventError extends RuntimeException with ServerError

    Permalink
  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

    Permalink
    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

    Permalink
    Annotations
    @SerialVersionUID()
  61. sealed trait ReadStreamEventsError extends RuntimeException with ServerError

    Permalink
  62. case class ResolvedEvent(linkedEvent: EventRecord, linkEvent: EventRecord) extends Event with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  63. class RetriesLimitReachedException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()
  64. implicit final class RichPartialFunction extends AnyVal

    Permalink
  65. case class ScavengeDatabaseResponse(scavengeId: Option[String]) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  66. sealed trait ScavengeError extends RuntimeException with SystemError

    Permalink
  67. sealed trait ServerError extends RuntimeException with SystemError

    Permalink
  68. class ServerErrorException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()
  69. 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

    Permalink

    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()
  70. class StreamDeletedException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()
  71. case class StreamEventAppeared(event: IndexedEvent) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  72. case class StreamNotFoundException(streamId: Id) extends EsException with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  73. class StreamSubscriptionActor extends AbstractSubscriptionActor[Event]

    Permalink
  74. sealed trait SubscribeCompleted extends In

    Permalink
  75. case class SubscribeTo(stream: EventStream, resolveLinkTos: Boolean = Settings.Default.resolveLinkTos) extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  76. case class SubscribeToAllCompleted(lastCommit: Long) extends SubscribeCompleted with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  77. case class SubscribeToStreamCompleted(lastCommit: Long, lastEventNumber: Option[Exact] = None) extends SubscribeCompleted with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  78. class SubscriptionActor extends AbstractSubscriptionActor[IndexedEvent]

    Permalink
  79. sealed trait SubscriptionDropped extends RuntimeException with ServerError

    Permalink
  80. trait SubscriptionObserver[T] extends AnyRef

    Permalink
  81. class SubscriptionObserverActor[T] extends Actor

    Permalink
  82. trait SystemError extends RuntimeException with NoStackTrace with Serializable

    Permalink
  83. class TransactionActor extends Actor with ActorLogging

    Permalink
  84. case class TransactionCommit(transactionId: Long, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  85. case class TransactionCommitCompleted(transactionId: Long, numbersRange: Option[Range] = None, position: Option[Exact] = None) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  86. case class TransactionStart(streamId: Id, expectedVersion: ExpectedVersion = ExpectedVersion.Any, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  87. case class TransactionStartCompleted(transactionId: Long) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  88. case class TransactionWrite(transactionId: Long, events: List[EventData], requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  89. case class TransactionWriteCompleted(transactionId: Long) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  90. sealed trait UpdatePersistentSubscriptionError extends RuntimeException with SystemError

    Permalink
  91. case class UserCredentials(login: String, password: String) extends Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  92. type Uuid = UUID

    Permalink
  93. case class WithCredentials(out: Out, credentials: UserCredentials) extends OutLike with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  94. case class WriteEvents(streamId: Id, events: List[EventData], expectedVersion: ExpectedVersion = ExpectedVersion.Any, requireMaster: Boolean = Settings.Default.requireMaster) extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  95. case class WriteEventsCompleted(numbersRange: Option[Range] = None, position: Option[Exact] = None) extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  96. case class WriteResult(nextExpectedVersion: Exact, logPosition: Position) extends Product with Serializable

    Permalink

    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()
  97. class WrongExpectedVersionException extends EsException

    Permalink
    Annotations
    @SerialVersionUID()

Value Members

  1. object Authenticate extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  2. object Authenticated extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  3. object BadRequest extends RuntimeException with ServerError with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  4. val ByteString: akka.util.ByteString.type

    Permalink
  5. object ClassTags

    Permalink
  6. object ClientIdentified extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  7. object ConsumerStrategy

    Permalink

    System supported consumer strategies for use with persistent subscriptions.

  8. object Content extends Serializable

    Permalink
  9. object ContentType

    Permalink
  10. object CreatePersistentSubscriptionError extends Serializable

    Permalink
  11. object DeletePersistentSubscriptionError extends Serializable

    Permalink
  12. object EsConnection

    Permalink
  13. object EsTransaction

    Permalink
  14. object Event

    Permalink
  15. object EventData extends Serializable

    Permalink
  16. object EventNumber

    Permalink
  17. object EventRecord extends Serializable

    Permalink
  18. object EventStoreExtension extends ExtensionId[EventStoreExtension] with ExtensionIdProvider

    Permalink
  19. object EventStream

    Permalink
  20. object ExpectedVersion

    Permalink
  21. object HttpSettings extends Serializable

    Permalink
  22. object InvalidTransactionException extends EsException with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  23. object LiveProcessingStarted extends Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  24. val MaxBatchSize: Int

    Permalink
  25. object NotAuthenticated extends RuntimeException with ServerError with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  26. object NotHandled extends Serializable

    Permalink
  27. object OperationError extends Serializable

    Permalink
  28. object OperationTimedOut extends RuntimeException with SystemError with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  29. object OverflowStrategy

    Permalink
  30. object PersistentSubscription

    Permalink
  31. object PersistentSubscriptionActor

    Permalink
  32. object PersistentSubscriptionSettings extends Serializable

    Permalink
  33. object Ping extends InOut with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  34. object Pong extends InOut with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  35. object Position

    Permalink
  36. object ProjectionDetails extends Serializable

    Permalink
  37. object ProjectionsClient

    Permalink
  38. object ReadAllEventsError extends Serializable

    Permalink
  39. object ReadDirection

    Permalink
  40. object ReadEvent extends Serializable

    Permalink
  41. object ReadEventError extends Serializable

    Permalink
  42. object ReadStreamEventsError extends Serializable

    Permalink
  43. object ScavengeDatabase extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  44. object ScavengeError extends Serializable

    Permalink
  45. object ScavengeInProgressException extends EsException with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  46. object ScavengeUnauthorizedException extends EsException with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  47. object Settings extends Serializable

    Permalink
  48. object SourceStageLogic

    Permalink
  49. object StreamSubscriptionActor

    Permalink
  50. object SubscriptionActor

    Permalink
  51. object SubscriptionDropped extends Serializable

    Permalink
  52. object SubscriptionObserverActor

    Permalink
  53. object SystemEventType

    Permalink
  54. object TransactionActor

    Permalink
  55. object Unsubscribe extends Out with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  56. object Unsubscribed extends In with Product with Serializable

    Permalink
    Annotations
    @SerialVersionUID()
  57. object UpdatePersistentSubscriptionError extends Serializable

    Permalink
  58. object UserCredentials extends Serializable

    Permalink
  59. object WriteEvents extends Serializable

    Permalink
  60. object WriteResult extends Serializable

    Permalink
  61. package cluster

    Permalink
  62. package examples

    Permalink
  63. package j

    Permalink
  64. package operations

    Permalink
  65. package proto

    Permalink
  66. def randomUuid: Uuid

    Permalink
  67. package tcp

    Permalink
  68. package util

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped