Skip navigation links
A B C D E F G H I K L M N O P Q R S T U V W _ 

A

AbstractChannel - Class in io.spine.server.transport
An abstract base for message channels.
AbstractChannel(ChannelId) - Constructor for class io.spine.server.transport.AbstractChannel
 
AbstractChannelObserver - Class in io.spine.server.integration
Base routines for the Subscriber.addObserver(StreamObserver) subscriber observers.
AbstractChannelObserver(BoundedContextName, Class<? extends Message>) - Constructor for class io.spine.server.integration.AbstractChannelObserver
 
AbstractColumnMapping<R> - Class in io.spine.server.entity.storage
The basic implementation of mapping rules for entity columns.
AbstractColumnMapping() - Constructor for class io.spine.server.entity.storage.AbstractColumnMapping
 
AbstractCommandDispatcher - Class in io.spine.server.command
The abstract base for non-aggregate classes that dispatch commands to their methods and post resulting events to EventBus.
AbstractCommandDispatcher() - Constructor for class io.spine.server.command.AbstractCommandDispatcher
 
AbstractCommander - Class in io.spine.server.command
The abstract base for classes that generate commands in response to incoming messages.
AbstractCommander() - Constructor for class io.spine.server.command.AbstractCommander
 
AbstractCommandHandler - Class in io.spine.server.command
The abstract base for non-aggregate classes that expose command handling methods and post their results to EventBus.
AbstractCommandHandler() - Constructor for class io.spine.server.command.AbstractCommandHandler
 
AbstractEntity<I,S extends io.spine.base.EntityState> - Class in io.spine.server.entity
Abstract base for entities.
AbstractEntity() - Constructor for class io.spine.server.entity.AbstractEntity
Creates a new instance with the zero version and cleared lifecycle flags.
AbstractEntity(I) - Constructor for class io.spine.server.entity.AbstractEntity
Creates new instance with the passed ID.
AbstractEntity(I, Function<I, S>) - Constructor for class io.spine.server.entity.AbstractEntity
Creates a new instance with the passed ID and default entity state obtained from the passed function.
AbstractEventReactor - Class in io.spine.server.event
An abstract base for all classes that may produce events in response to other events.
AbstractEventReactor() - Constructor for class io.spine.server.event.AbstractEventReactor
 
AbstractEventSubscriber - Class in io.spine.server.event
The abstract base for objects that can be subscribed to receive events from EventBus.
AbstractEventSubscriber() - Constructor for class io.spine.server.event.AbstractEventSubscriber
 
AbstractMessageEnvelope<I extends com.google.protobuf.Message,T,C extends com.google.protobuf.Message> - Class in io.spine.server.type
Abstract base for classes implementing MessageEnvelope.
AbstractMessageEnvelope(T) - Constructor for class io.spine.server.type.AbstractMessageEnvelope
 
AbstractStatefulReactor<I,S extends com.google.protobuf.Message,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.event
An abstract base for AbstractEventReactors which have state and require delivering the messages through an Inbox.
AbstractStatefulReactor(TypeUrl) - Constructor for class io.spine.server.event.AbstractStatefulReactor
Creates a new instance of the reactor and initializes the Inbox for it.
AbstractStorage<I,M extends com.google.protobuf.Message,R extends ReadRequest<I>> - Class in io.spine.server.storage
Abstract base for storages.
AbstractStorage(boolean) - Constructor for class io.spine.server.storage.AbstractStorage
 
AbstractTracer - Class in io.spine.server.trace
The implementation base for Tracers.
AbstractTracer(Signal<?, ?, ?>) - Constructor for class io.spine.server.trace.AbstractTracer
 
AbstractWorkRegistry - Class in io.spine.server.delivery
An implementation base for ShardedWorkRegistries based on a specific persistence mechanism.
AbstractWorkRegistry() - Constructor for class io.spine.server.delivery.AbstractWorkRegistry
 
activate(Subscription, SubscriptionCallback, StreamObserver<Response>) - Method in class io.spine.server.stand.Stand
Activates the subscription created via subscribe() method.
activate(Subscription, StreamObserver<SubscriptionUpdate>) - Method in class io.spine.server.SubscriptionService
 
activeEntityQueryParams(RecordStorage<?>) - Static method in class io.spine.server.entity.storage.QueryParameters
Creates a new QueryParameters instance which includes filters for column lifecycle flags to equal false.
actorContext() - Method in interface io.spine.server.type.SignalEnvelope
Obtains an actor context for the wrapped message.
add(Class<E>) - Method in class io.spine.server.BoundedContextBuilder
Adds the default repository for the passed entity class to the repository registration list.
add(Repository<?, ?>) - Method in class io.spine.server.BoundedContextBuilder
Adds the passed repository to the registration list which will be processed after the Bounded Context is created.
add(BoundedContext) - Method in class io.spine.server.CommandService.Builder
Adds the BoundedContext to the builder.
add(EventFilter) - Method in class io.spine.server.entity.CompositeEventFilter.Builder
Adds a filter to the built composite filter.
add(CompositeQueryParameter) - Method in class io.spine.server.entity.storage.QueryParameters.Builder
 
add(Class<M>, Class<R>, EventEnrichmentFn<M, R>) - Method in class io.spine.server.event.EventEnricher.Builder
Adds event enrichment function to the builder.
add(BoundedContext) - Method in class io.spine.server.QueryService.Builder
Adds the passed bounded context to be served by the query service.
add(BoundedContextBuilder) - Method in class io.spine.server.Server.Builder
Adds a builder for a BoundedContext to be added the server.
add(BoundedContext) - Method in class io.spine.server.SubscriptionService.Builder
Adds the context to be handled by the subscription service.
addAll(Iterable<CompositeQueryParameter>) - Method in class io.spine.server.entity.storage.QueryParameters.Builder
 
addCommandDispatcher(CommandDispatcher) - Method in class io.spine.server.BoundedContextBuilder
Adds the passed command dispatcher to the dispatcher registration list which will be processed after the Bounded Context is created.
addCommandEndpoint(InboxLabel, LazyEndpoint<I, CommandEnvelope>) - Method in class io.spine.server.delivery.Inbox.Builder
Adds an endpoint for commands which will be delivered through the Inbox and marks it with the certain label.
addCommandFilter(BusFilter<CommandEnvelope>) - Method in class io.spine.server.BoundedContextBuilder
Adds a filter for commands.
addCommandListener(Listener<CommandEnvelope>) - Method in class io.spine.server.BoundedContextBuilder
Adds a listener for commands posted to the CommandBus of the context being built.
addEventDispatcher(EventDispatcher) - Method in class io.spine.server.BoundedContextBuilder
Adds the passed event dispatcher to the dispatcher registration list which will be processed after the Bounded Context is created.
addEventEndpoint(InboxLabel, LazyEndpoint<I, EventEnvelope>) - Method in class io.spine.server.delivery.Inbox.Builder
Adds an endpoint for events which will be delivered through the Inbox and marks it with the certain label.
addEventFilter(BusFilter<EventEnvelope>) - Method in class io.spine.server.BoundedContextBuilder
Adds a filter for events.
addEventListener(Listener<EventEnvelope>) - Method in class io.spine.server.BoundedContextBuilder
Adds a listener of the events posted to the EventBus of the context being built.
addObserver(StreamObserver<ExternalMessage>) - Method in class io.spine.server.transport.Subscriber
Adds an observer to receive the subscription updates.
addService(BindableService) - Method in class io.spine.server.GrpcContainer.Builder
Adds a gRPC service to deploy within the container being built.
addShutdownHook() - Method in class io.spine.server.GrpcContainer
Makes the JVM shut down the service when it is shutting down itself.
afterInvoke(HandlerMethod<?, ?, ?, ?>) - Method in class io.spine.server.entity.AbstractEntity
 
afterInvoke(HandlerMethod<?, ?, ?, ?>) - Method in interface io.spine.server.log.HandlerLifecycle
A callback for a handler method invocation end.
Aggregate<I,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.aggregate
Abstract base for aggregates.
Aggregate() - Constructor for class io.spine.server.aggregate.Aggregate
Creates a new instance.
Aggregate(I) - Constructor for class io.spine.server.aggregate.Aggregate
Creates a new instance.
aggregateClass() - Method in class io.spine.server.aggregate.AggregateRepository
Obtains class information of aggregates managed by this repository.
AggregateField - Enum in io.spine.server.aggregate
A container for the storage fields specific for the AggregateStorage and its implementations.
AggregatePart<I,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>,R extends AggregateRoot<I>> - Class in io.spine.server.aggregate
A part of a larger aggregate.
AggregatePart(R) - Constructor for class io.spine.server.aggregate.AggregatePart
Creates a new instance of the aggregate part.
AggregatePart.GenericParameter - Enum in io.spine.server.aggregate
Enumeration of generic type parameters of this class.
AggregatePartRepository<I,A extends AggregatePart<I,?,?,R>,R extends AggregateRoot<I>> - Class in io.spine.server.aggregate
Common abstract base for repositories that manage AggregateParts.
AggregatePartRepository() - Constructor for class io.spine.server.aggregate.AggregatePartRepository
Creates a new instance.
AggregateRepository<I,A extends Aggregate<I,?,?>> - Class in io.spine.server.aggregate
The repository which manages instances of Aggregates.
AggregateRepository() - Constructor for class io.spine.server.aggregate.AggregateRepository
Creates a new instance.
AggregateRoot<I> - Class in io.spine.server.aggregate
A root object for a larger aggregate.
AggregateRoot(BoundedContext, I) - Constructor for class io.spine.server.aggregate.AggregateRoot
Creates a new instance.
AggregateRootDirectory - Interface in io.spine.server.aggregate
A mapping of aggregate roots to the associated parts.
aggregateStorage() - Method in class io.spine.server.aggregate.AggregateRepository
Returns the storage assigned to this aggregate.
AggregateStorage<I> - Class in io.spine.server.aggregate
An event-sourced storage of aggregate part events and snapshots.
AggregateStorage(boolean) - Constructor for class io.spine.server.aggregate.AggregateStorage
 
all() - Method in interface io.spine.server.tenant.TenantIndex
Obtains the set of all stored tenant IDs.
all() - Method in class io.spine.server.tenant.TenantRepository
 
allowAll() - Static method in interface io.spine.server.entity.EventFilter
Obtains an EventFilter which always returns the input event without any change.
allowEvents(Class<? extends EventMessage>...) - Static method in class io.spine.server.entity.EventWhiteList
Creates a new instance of EventWhiteList allowing events of the given types.
allRecords() - Method in class io.spine.server.delivery.AbstractWorkRegistry
Obtains all the session records associated with this registry.
and(Column, Filter) - Method in class io.spine.server.entity.storage.CompositeQueryParameter
Merges current instance with the given filter.
append(Event) - Method in interface io.spine.server.event.EventStore
Appends the passed event to the history of events.
append(Event) - Method in class io.spine.server.event.store.DefaultEventStore
 
appendAll(Iterable<Event>) - Method in interface io.spine.server.event.EventStore
Appends the passed events to the history of events.
appendAll(Iterable<Event>) - Method in class io.spine.server.event.store.DefaultEventStore
 
Apply - Annotation Type in io.spine.server.aggregate
Marks a method of an aggregate as one that modifies the state of the aggregate with data from the passed event.
apply(S) - Method in class io.spine.server.procman.migration.MarkPmArchived
 
apply(S) - Method in class io.spine.server.procman.migration.MarkPmDeleted
 
apply(S) - Method in class io.spine.server.procman.migration.RemovePmFromStorage
 
apply(S) - Method in class io.spine.server.procman.migration.UpdatePmColumns
 
apply(S) - Method in class io.spine.server.projection.migration.MarkProjectionArchived
 
apply(S) - Method in class io.spine.server.projection.migration.MarkProjectionDeleted
 
apply(S) - Method in class io.spine.server.projection.migration.RemoveProjectionFromStorage
 
apply(S) - Method in class io.spine.server.projection.migration.UpdateProjectionColumns
 
apply(CommandMessage, CommandContext) - Method in class io.spine.server.route.DefaultCommandRoute
 
apply(M, C) - Method in interface io.spine.server.route.Route
Obtains entity ID(s) from the passed message and its context.
apply() - Method in class io.spine.server.tenant.TenantAwareFunction0
 
apply(Empty) - Method in class io.spine.server.tenant.TenantAwareFunction0
 
applyMask(FieldMask, Collection<M>) - Static method in class io.spine.server.entity.FieldMasks
Applies the given FieldMask to given collection of Messages.
applyMask(FieldMask, M) - Static method in class io.spine.server.entity.FieldMasks
Applies the FieldMask to the given Message if the mask parameter is valid.
applyMigration(I, Migration<I, T, S>) - Method in class io.spine.server.entity.RecordBasedRepository
Applies a given Migration to an entity with the given ID.
applyMigration(Set<I>, Migration<I, T, S>) - Method in class io.spine.server.entity.RecordBasedRepository
Applies a Migration to several entities in batch.
asError() - Method in exception io.spine.server.aggregate.UnsupportedImportEventException
 
asError() - Method in exception io.spine.server.commandbus.CommandException
 
asError() - Method in exception io.spine.server.event.EventException
 
asError() - Method in exception io.spine.server.integration.UnsupportedExternalMessageException
 
asError() - Method in exception io.spine.server.stand.InvalidRequestException
 
asMessageOrigin() - Method in class io.spine.server.integration.ExternalMessageEnvelope
This method is not supported and always throws UnsupportedOperationException.
asMessageOrigin() - Method in interface io.spine.server.type.MessageEnvelope
Packs this message as an Origin of an event.
asMessageOrigin() - Method in interface io.spine.server.type.SignalEnvelope
 
asSession(ShardSessionRecord) - Method in class io.spine.server.delivery.AbstractWorkRegistry
Restores a ShardProcessingSession from the given session record.
Assign - Annotation Type in io.spine.server.command
Marks a method as command handler.
asThrowable() - Method in exception io.spine.server.aggregate.UnsupportedImportEventException
 
asThrowable() - Method in exception io.spine.server.commandbus.CommandException
 
asThrowable() - Method in exception io.spine.server.event.EventException
 
asThrowable() - Method in exception io.spine.server.integration.UnsupportedExternalMessageException
 
asThrowable() - Method in exception io.spine.server.stand.InvalidRequestException
 
at(Level) - Method in class io.spine.server.entity.AbstractEntity
Obtains a new fluent logging API at the given level.
at(Level) - Method in class io.spine.server.log.HandlerLog
Returns a fluent logging API appropriate for the specified log level.
at(Level) - Method in interface io.spine.server.log.LoggingEntity
Creates a FluentLogger.Api with the given level.
atPort(int) - Static method in class io.spine.server.GrpcContainer
Initiates creating a container exposed at the given port.
atPort(int) - Static method in class io.spine.server.Server
Initiates creating a server exposed at the passed port.
ATTR_COMMAND_TYPE_NAME - Static variable in exception io.spine.server.commandbus.CommandException
The name of the attribute of the command type reported in an error.
ATTR_EVENT_TYPE_NAME - Static variable in exception io.spine.server.event.EventException
 
attributeFilter() - Method in class io.spine.server.bus.DispatcherRegistry
Returns a filter allowing to tell whether the attributes of the envelope match the dispatcher requirements.
awaitTermination() - Method in class io.spine.server.GrpcContainer
Waits for the service to become terminated.
awaitTermination() - Method in class io.spine.server.Server
Waits for the server to become terminated.

B

BatchDeliveryListener<I> - Interface in io.spine.server.delivery
Listens to start and end of the Inbox batch delivery.
beforeInvoke(HandlerMethod<?, ?, ?, ?>) - Method in class io.spine.server.entity.AbstractEntity
 
beforeInvoke(HandlerMethod<?, ?, ?, ?>) - Method in interface io.spine.server.log.HandlerLifecycle
A callback for a handler method invocation start.
beginTransactionFor(P) - Method in class io.spine.server.procman.ProcessManagerRepository
 
BoundedContext - Class in io.spine.server
A logical and structural boundary of a model.
BoundedContextBuilder - Class in io.spine.server
A builder for producing BoundedContext instances.
build() - Method in class io.spine.server.aggregate.ImportBus.Builder
 
build() - Method in class io.spine.server.BoundedContextBuilder
Creates a new instance of BoundedContext with the set configurations.
build() - Method in class io.spine.server.commandbus.CommandBus.Builder
Builds an instance of CommandBus.
build() - Method in class io.spine.server.CommandService.Builder
Builds a new CommandService.
build() - Method in class io.spine.server.delivery.CatchUpProcessBuilder
Creates a new instance of CatchUpProcess.
build() - Method in class io.spine.server.delivery.DeliveryBuilder
 
build() - Method in class io.spine.server.delivery.Inbox.Builder
Creates an instance of Inbox and registers it in the server-wide Delivery.
build() - Method in class io.spine.server.enrich.EnricherBuilder
Creates a new Enricher.
build() - Method in class io.spine.server.entity.CompositeEventFilter.Builder
Creates a new instance of CompositeEventFilter.
build() - Method in class io.spine.server.entity.EventFieldFilter.Builder
Creates a new instance of EventFieldFilter.
build() - Method in class io.spine.server.entity.storage.QueryParameters.Builder
Creates a new instance of QueryParameters with the collected parameters.
build() - Method in class io.spine.server.event.EventBus.Builder
Builds an instance of EventBus.
build() - Method in class io.spine.server.event.EventEnricher.Builder
 
build() - Method in class io.spine.server.GrpcContainer.Builder
 
build() - Method in class io.spine.server.QueryService.Builder
Builds the QueryService.
build() - Method in class io.spine.server.Server.Builder
Creates a new instance of the server.
build() - Method in class io.spine.server.SubscriptionService.Builder
builder() - Method in class io.spine.server.aggregate.Aggregate
Obtains the instance of the state builder.
Builder() - Constructor for class io.spine.server.CommandService.Builder
 
builder() - Method in class io.spine.server.entity.TransactionalEntity
Obtains the instance of the state builder.
builder() - Method in class io.spine.server.event.AbstractStatefulReactor
Returns the current state as a ValidatingBuilder for the respective message.
Builder() - Constructor for class io.spine.server.event.EventEnricher.Builder
 
builder() - Method in class io.spine.server.procman.ProcessManager
Obtains the instance of the state builder.
builder() - Method in class io.spine.server.projection.Projection
Obtains the instance of the state builder.
Builder() - Constructor for class io.spine.server.QueryService.Builder
 
Builder() - Constructor for class io.spine.server.stand.Stand.Builder
 
Builder() - Constructor for class io.spine.server.SubscriptionService.Builder
 
BusBuilder.FieldCheck - Class in io.spine.server.bus
Verifies if required fields of a BusBuilder are set.
BusFilter<E extends MessageEnvelope<?,?,?>> - Interface in io.spine.server.bus
The filter for the messages posted to a bus.
byFirstMessageField(Class<I>) - Static method in interface io.spine.server.route.EventRoute
Creates an event route that obtains event producer ID from an EventContext and returns it as a sole element of the the immutable set.
byProducerId() - Static method in interface io.spine.server.route.EventRoute
Creates an event route that obtains event producer ID from an EventContext and returns it as a sole element of the immutable set.

C

callDispatchers(E) - Method in class io.spine.server.bus.MulticastBus
Call the dispatchers for the messageEnvelope.
callObservers(ExternalMessage) - Method in class io.spine.server.transport.Subscriber
 
cancel(Subscription, StreamObserver<Response>) - Method in class io.spine.server.stand.Stand
Cancels the Subscription.
cancel(Subscription, StreamObserver<Response>) - Method in class io.spine.server.SubscriptionService
 
canDispatch(E) - Method in interface io.spine.server.bus.MessageDispatcher
Checks if this dispatcher can dispatch the given message.
canDispatch(EventEnvelope) - Method in class io.spine.server.delivery.CatchUpProcess
Checks if this dispatcher can dispatch the given message.
canDispatch(EventEnvelope) - Method in class io.spine.server.event.AbstractEventSubscriber
 
canDispatch(EventEnvelope) - Method in class io.spine.server.projection.ProjectionRepository
 
catchUp(Timestamp, Set<I>) - Method in class io.spine.server.projection.ProjectionRepository
Repeats the dispatching of the events from the event log to the requested entities since the specified time.
catchUpAll(Timestamp) - Method in class io.spine.server.projection.ProjectionRepository
Starts the catch-up of all entities in this repository.
CatchUpAlreadyStartedException - Exception in io.spine.server.delivery
An exception telling that the projection catch-up cannot be started, since some of the requested entities are already catching up.
catchUpPageSize() - Method in class io.spine.server.delivery.DeliveryBuilder
Returns the value of the configured catch-up page size or Optional.empty() if no such value was configured.
CatchUpProcess<I> - Class in io.spine.server.delivery
A process that performs a projection catch-up.
CatchUpProcess.DispatchCatchingUp<I> - Interface in io.spine.server.delivery
A method object dispatching the event to catch-up.
CatchUpProcessBuilder<I> - Class in io.spine.server.delivery
A builder for CatchUpProcess.
CatchUpReadRequest - Class in io.spine.server.delivery
A request to read the state of CatchUp from the storage.
CatchUpSignal - Interface in io.spine.server.delivery
A marker interface for the signals controlling the execution of catch-up processes.
CatchUpStorage - Interface in io.spine.server.delivery
A storage for the state of the ongoing catch-up processes.
catchUpStorage() - Method in class io.spine.server.delivery.DeliveryBuilder
Returns the value of the configured CatchUpStorage or Optional.empty() if no such value was configured.
causedByRejection(Throwable) - Static method in class io.spine.server.command.Rejections
Tells whether or not the given throwable is caused by a ThrowableMessage.
ChannelHub<C extends MessageChannel> - Class in io.spine.server.transport
The hub of channels grouped in some logical way.
ChannelHub(TransportFactory) - Constructor for class io.spine.server.transport.ChannelHub
 
channelIdFor(TypeUrl) - Static method in interface io.spine.server.transport.MessageChannel
Converts the given message type into a ChannelId.
checkDispatcher(D) - Method in class io.spine.server.bus.DispatcherRegistry
Ensures that the passed dispatcher is valid.
checkEntityState(S) - Method in class io.spine.server.entity.AbstractEntity
Verifies the new entity state and returns ConstraintViolations, if any.
checkNotArchived() - Method in class io.spine.server.entity.AbstractEntity
Ensures that the entity is not marked as archived.
checkNotClosed() - Method in class io.spine.server.aggregate.AggregateStorage
Ensures the storage is not closed.
checkNotClosed(String) - Method in class io.spine.server.storage.AbstractStorage
Ensures the storage is not closed.
checkNotClosed() - Method in class io.spine.server.storage.AbstractStorage
Ensures the storage is not closed.
checkNotDeleted() - Method in class io.spine.server.entity.AbstractEntity
Ensures that the entity is not marked as deleted.
checkOpen() - Method in interface io.spine.server.Closeable
Ensures that the object is open.
checkSet(Object, Class<?>, String) - Static method in class io.spine.server.bus.BusBuilder.FieldCheck
 
checkStorage(S) - Static method in class io.spine.server.entity.Repository
Ensures that the storage is not null.
clearCache() - Method in class io.spine.server.tenant.TenantRepository
Clears the cache of known tenant IDs.
clearNode(ShardSessionRecord) - Method in class io.spine.server.delivery.AbstractWorkRegistry
Clears the value of ShardSessionRecord.worker and stores the session.
clearRecentHistory() - Method in class io.spine.server.aggregate.Aggregate
clearRecentHistory() - Method in class io.spine.server.entity.TransactionalEntity
close() - Method in class io.spine.server.aggregate.AggregateRepository
 
close() - Method in class io.spine.server.BoundedContext
Closes the BoundedContext performing all necessary clean-ups.
close() - Method in interface io.spine.server.bus.BusFilter
close() - Method in class io.spine.server.commandbus.CommandScheduler
 
close() - Method in class io.spine.server.entity.Repository
Closes the repository by closing the underlying storage.
close() - Method in class io.spine.server.integration.ThirdPartyContext
Closes this Context and clean up underlying resources.
close() - Method in class io.spine.server.procman.ProcessManagerRepository
 
close() - Method in class io.spine.server.projection.ProjectionRepository
 
close() - Method in class io.spine.server.ServerEnvironment
Releases resources associated with this instance.
close() - Method in class io.spine.server.stand.Stand
Closes the Stand performing necessary cleanups.
close() - Method in class io.spine.server.storage.AbstractStorage
Closes the storage.
close() - Method in class io.spine.server.storage.memory.InMemoryProjectionStorage
 
close() - Method in class io.spine.server.storage.memory.InMemoryStorageFactory
 
close() - Method in interface io.spine.server.storage.Storage
Closes the storage.
close() - Method in interface io.spine.server.tenant.TenantIndex
Closes the index for further read or write operations.
close() - Method in class io.spine.server.transport.ChannelHub
 
close() - Method in class io.spine.server.transport.memory.InMemoryPublisher
Does nothing as there are no resources to close in the in-memory implementation.
close() - Method in class io.spine.server.transport.memory.InMemoryTransportFactory
 
close() - Method in class io.spine.server.transport.Subscriber
 
Closeable - Interface in io.spine.server
Base interface for server-side objects that may hold resources that need to be released at the end of the lifecycle of the object.
closeStaleChannels() - Method in class io.spine.server.transport.ChannelHub
Closes the stale channels and removes those from the hub.
Column - Interface in io.spine.server.entity.storage
A column of the entity.
columnList() - Method in class io.spine.server.storage.RecordStorage
Obtains a list of columns of the managed Entity.
ColumnMapping<R> - Interface in io.spine.server.entity.storage
The value mapping rules of entity columns.
ColumnName - Class in io.spine.server.entity.storage
A name of the column in the storage.
columnNames() - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
Obtains the names of storage fields in the record.
ColumnTypeMapping<T,R> - Interface in io.spine.server.entity.storage
A persistence strategy of an entity column.
columnValue(ColumnName) - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
Obtains the value of the storage field by the specified column name.
columnValue(ColumnName, ColumnMapping<R>) - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
Obtains the value of the storage field by the specified column name.
Command - Annotation Type in io.spine.server.command
Marks a commanding method.
command() - Method in class io.spine.server.type.CommandEnvelope
Obtains the enclosed command object.
commandBus() - Method in class io.spine.server.BoundedContext
Obtains instance of CommandBus of this BoundedContext.
commandBus() - Method in class io.spine.server.commandbus.CommandScheduler
Obtains CommandBus associated with this scheduler.
CommandBus.Builder - Class in io.spine.server.commandbus
The Builder for CommandBus.
CommandClass - Class in io.spine.server.type
A value object for class type references.
commandClasses() - Method in class io.spine.server.procman.ProcessManagerRepository
Obtains a set of classes of commands handled by process managers of this repository.
CommandDispatcher - Interface in io.spine.server.commandbus
Delivers commands to their handlers.
commandDispatchers() - Method in class io.spine.server.BoundedContextBuilder
Obtains the list of command dispatchers added to the builder by the time of the call.
CommandEndpoint<I> - Interface in io.spine.server.delivery
An endpoint which accepts commands.
CommandEnvelope - Class in io.spine.server.type
The holder of a Command which provides convenient access to its properties.
Commander - Interface in io.spine.server.command
An interface common for objects that post one or more command in response to an incoming message.
CommandException - Exception in io.spine.server.commandbus
Abstract base for exceptions related to commands.
CommandException(String, Command, Error) - Constructor for exception io.spine.server.commandbus.CommandException
Creates a new instance.
CommandHandler - Interface in io.spine.server.command
A common interface for objects which declare one or more methods assigned to handle commands, producing events in response.
CommandHandlingEntity<I,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.command
An entity that handles commands.
CommandHandlingEntity() - Constructor for class io.spine.server.command.CommandHandlingEntity
 
CommandHandlingEntity(I) - Constructor for class io.spine.server.command.CommandHandlingEntity
Creates a new entity with the passed ID.
CommandPostingException - Exception in io.spine.server.commandbus
Exception that is thrown when a command could not be posted to a CommandBus.
CommandReceiver - Interface in io.spine.server.command
Common interface for all objects that receive commands in the end of the dispatching.
CommandRoute<I,M extends io.spine.base.CommandMessage> - Interface in io.spine.server.route
Obtains an ID of an entity which handles the command.
CommandRouting<I> - Class in io.spine.server.route
A routing schema used by a CommandDispatcher for delivering a command to its handler.
CommandScheduler - Class in io.spine.server.commandbus
Schedules commands delivering them to the target according to the scheduling options.
CommandScheduler() - Constructor for class io.spine.server.commandbus.CommandScheduler
 
CommandService - Class in io.spine.server
The CommandService allows client applications to post commands and receive updates from the application backend.
commandService() - Method in class io.spine.server.Server
Obtains the CommandService exposed by this server.
CommandService.Builder - Class in io.spine.server
The builder for a CommandService.
commandTypeAttribute(Message) - Static method in exception io.spine.server.commandbus.CommandException
Returns a map with a command type attribute.
complete() - Method in class io.spine.server.delivery.ShardProcessingSession
Completes this session and releases the picked shard, making it available for picking up.
CompositeEventFilter - Class in io.spine.server.entity
An EventFilter which composes several other filters.
CompositeEventFilter.Builder - Class in io.spine.server.entity
A builder for the CompositeEventFilter instances.
CompositeQueryParameter - Class in io.spine.server.entity.storage
A set of Filter instances joined by a logical composite operator.
configure(P) - Method in class io.spine.server.procman.ProcessManagerRepository
A callback method for configuring a recently created ProcessManager instance before it is returned by the repository as the result of creating a new process manager instance or finding existing one.
configureDeployment(Supplier<DeploymentType>) - Method in class io.spine.server.ServerEnvironment
Makes the ServerEnvironment.deploymentType() return the values from the provided supplier.
conjunct(Iterable<CompositeQueryParameter>) - Method in class io.spine.server.entity.storage.CompositeQueryParameter
Merges current instance with the given instances by the rules of conjunction.
ConnectionBuilder - Class in io.spine.server
Abstract base for builders of objects that depend on or expose server-side gRPC objects.
constructor() - Method in interface io.spine.server.entity.EntityFactory
Obtains the constructor used by the factory.
contains(BoundedContext) - Method in class io.spine.server.CommandService.Builder
Verifies if the passed BoundedContext was previously added to the builder.
contains(BoundedContext) - Method in class io.spine.server.QueryService.Builder
Tells if the builder already contains the passed bounded context.
contents() - Method in interface io.spine.server.delivery.Page
Obtains the messages of this page.
context() - Method in class io.spine.server.entity.Repository
Obtains the BoundedContext to which this repository belongs.
context() - Method in class io.spine.server.event.RejectionEnvelope
 
context() - Method in class io.spine.server.integration.ExternalMessageEnvelope
 
context() - Method in class io.spine.server.storage.memory.StorageSpec
Obtains the name of the context served by the storage.
context() - Method in class io.spine.server.type.CommandEnvelope
Obtains the command context.
context() - Method in class io.spine.server.type.EventEnvelope
Obtains the context of the event.
context() - Method in interface io.spine.server.type.MessageEnvelope
Obtains the context of the message.
contexts() - Method in class io.spine.server.SubscriptionService.Builder
Obtains the context added to the subscription service by the time of the call.
ContextSpec - Class in io.spine.server
Specification of a bounded context.
create(I) - Method in class io.spine.server.aggregate.AggregatePartRepository
 
create(I) - Method in class io.spine.server.aggregate.AggregateRepository
 
create(Object) - Method in class io.spine.server.entity.DefaultEntityFactory
 
create(Object) - Method in interface io.spine.server.entity.EntityFactory
Creates a new entity with the passed construction argument.
create(I) - Method in class io.spine.server.entity.RecordBasedRepository
 
create(I) - Method in class io.spine.server.entity.Repository
Create a new entity instance with its default state.
create(EntityRecord, Entity<?, ?>, RecordStorage<?>) - Static method in class io.spine.server.entity.storage.EntityRecordWithColumns
Creates a new record extracting the column values from the passed entity.
create(I) - Method in class io.spine.server.procman.ProcessManagerRepository
 
create(I) - Method in class io.spine.server.projection.ProjectionRepository
 
createAggregateStorage(ContextSpec, Class<? extends Aggregate<I, ?, ?>>) - Method in class io.spine.server.storage.memory.InMemoryStorageFactory
NOTE: the parameter is unused.
createAggregateStorage(ContextSpec, Class<? extends Aggregate<I, ?, ?>>) - Method in interface io.spine.server.storage.StorageFactory
Creates a new AggregateStorage.
createCatchUpStorage(boolean) - Method in class io.spine.server.storage.memory.InMemoryStorageFactory
 
createCatchUpStorage(boolean) - Method in interface io.spine.server.storage.StorageFactory
Creates a new CatchUpStorage.
createDefault() - Static method in interface io.spine.server.tenant.TenantIndex
Creates default implementation of TenantIndex for a multi-tenant context.
createEnrichment(M, C) - Method in class io.spine.server.enrich.Enricher
 
createEnrichment(M, C) - Method in interface io.spine.server.enrich.EnrichmentService
Creates an enrichment for the passed message.
createError(String, Command, CommandValidationError) - Static method in exception io.spine.server.commandbus.CommandException
 
createEvent(EventMessage, Version) - Method in class io.spine.server.event.EventFactory
Creates an event for the passed event message.
createEventStore(ContextSpec) - Method in interface io.spine.server.storage.StorageFactory
Creates a new EventStore.
createInboxStorage(boolean) - Method in class io.spine.server.storage.memory.InMemoryStorageFactory
 
createInboxStorage(boolean) - Method in interface io.spine.server.storage.StorageFactory
Creates a new InboxStorage.
createProjectionStorage(ContextSpec, Class<? extends Projection<I, ?, ?>>) - Method in class io.spine.server.storage.memory.InMemoryStorageFactory
 
createProjectionStorage(ContextSpec, Class<? extends Projection<I, ?, ?>>) - Method in interface io.spine.server.storage.StorageFactory
Creates a new ProjectionStorage.
createPublisher(ChannelId) - Method in class io.spine.server.transport.memory.InMemoryTransportFactory
 
createPublisher(ChannelId) - Method in interface io.spine.server.transport.TransportFactory
Creates a Publisher channel with the given ID.
createRecordStorage(ContextSpec, Class<? extends Entity<I, ?>>) - Method in class io.spine.server.storage.memory.InMemoryStorageFactory
 
createRecordStorage(ContextSpec, Class<? extends Entity<I, ?>>) - Method in interface io.spine.server.storage.StorageFactory
Creates a new RecordStorage.
createRejectionEvent(RejectionMessage, Version, RejectionEventContext) - Method in class io.spine.server.event.EventFactory
Creates a rejection event for the passed rejection message.
createStorage() - Method in class io.spine.server.aggregate.AggregateRepository
Creates aggregate storage for the repository.
createStorage() - Method in class io.spine.server.entity.RecordBasedRepository
 
createStorage() - Method in class io.spine.server.entity.Repository
Creates the storage for this repository.
createStorage() - Method in class io.spine.server.projection.ProjectionRepository
 
createStorage() - Method in class io.spine.server.tenant.TenantRepository
 
createSubscriber(ChannelId) - Method in class io.spine.server.transport.memory.InMemoryTransportFactory
 
createSubscriber(ChannelId) - Method in interface io.spine.server.transport.TransportFactory
Creates a Subscriber channel with the given ID.
currentWorkerFor(NodeId) - Method in class io.spine.server.delivery.AbstractWorkRegistry
Returns an identifier of the current worker that is now going to process the shard.

D

deadMessageHandler() - Method in class io.spine.server.aggregate.ImportBus
 
deduplicationWindow() - Method in class io.spine.server.delivery.DeliveryBuilder
Returns the value of the configured deduplication window or Optional.empty() if no such value was configured.
DefaultColumnMapping - Class in io.spine.server.entity.storage
A default column mapping which stores all values "as-is".
DefaultCommandRoute<I> - Class in io.spine.server.route
Obtains an ID of a command target entity from the first field of the command message.
DefaultEntityFactory<E extends Entity> - Class in io.spine.server.entity
Default implementation of entity factory which creates entities by invoking constructor which accepts entity ID.
DefaultEntityFactory(Class<E>) - Constructor for class io.spine.server.entity.DefaultEntityFactory
Creates new instance.
DefaultEventStore - Class in io.spine.server.event.store
Default implementation of EventStore.
DefaultEventStore() - Constructor for class io.spine.server.event.store.DefaultEventStore
Constructs new instance.
DefaultRecordBasedRepository<I,E extends AbstractEntity<I,S>,S extends io.spine.base.EntityState> - Class in io.spine.server.entity
Implementation of RecordBasedRepository that manages entities derived from AbstractEntity.
DefaultRecordBasedRepository() - Constructor for class io.spine.server.entity.DefaultRecordBasedRepository
Creates a new instance with the factory of entities of class specified as the <E> generic parameter, and with the default entity storage converter.
DefaultRepository - Interface in io.spine.server
The marker interface for the repositories which do not require creating a custom subclass of Repository.
defaultRoute() - Method in class io.spine.server.route.CommandRouting
 
defaultRoute() - Method in class io.spine.server.route.EventRouting
Obtains the default route used by the schema.
defaultState() - Method in class io.spine.server.entity.AbstractEntity
Obtains the default state of the entity.
delete(I) - Method in class io.spine.server.storage.memory.InMemoryProjectionStorage
 
delete(I) - Method in class io.spine.server.storage.memory.InMemoryRecordStorage
 
delete(I) - Method in class io.spine.server.storage.RecordStorage
Deletes the record with the passed ID.
deliveredCount() - Method in class io.spine.server.delivery.DeliveryStats
Returns the total number of messages delivered.
deliverMessagesFrom(ShardIndex) - Method in class io.spine.server.delivery.Delivery
Delivers the messages put into the shard with the passed index to their targets.
Delivery - Class in io.spine.server.delivery
Delivers the messages to the entities.
delivery() - Method in class io.spine.server.ServerEnvironment
Returns the delivery mechanism specific to this environment.
DeliveryBuilder - Class in io.spine.server.delivery
A builder for Delivery instances.
deliveryMonitor() - Method in class io.spine.server.delivery.DeliveryBuilder
Returns the value of the configured DeliveryMonitor or Optional.empty() if no such value was configured.
DeliveryMonitor - Class in io.spine.server.delivery
A controlling monitor of a Inbox Delivery process.
DeliveryMonitor() - Constructor for class io.spine.server.delivery.DeliveryMonitor
 
DeliveryStats - Class in io.spine.server.delivery
The statistics on delivering the messages from a certain shard.
DeliveryStrategy - Class in io.spine.server.delivery
Determines the index of a shard for the given identifier of an entity.
DeliveryStrategy() - Constructor for class io.spine.server.delivery.DeliveryStrategy
 
deploymentType() - Method in class io.spine.server.ServerEnvironment
The type of the environment application is deployed to.
determineIndex(Object, TypeUrl) - Method in class io.spine.server.delivery.DeliveryStrategy
 
discardEvents(Class<? extends EventMessage>...) - Static method in class io.spine.server.entity.EventBlackList
Creates a new instance of EventBlackList discarding events of the given types.
dispatch(CommandEnvelope) - Method in class io.spine.server.aggregate.AggregateRepository
Dispatches the passed command to an aggregate.
dispatch(EventEnvelope) - Method in class io.spine.server.aggregate.ImportBus
 
dispatch(E) - Method in interface io.spine.server.bus.MessageDispatcher
Dispatches the message contained in the passed envelope.
dispatch(CommandEnvelope) - Method in class io.spine.server.command.AbstractCommander
 
dispatch(CommandEnvelope) - Method in class io.spine.server.command.AbstractCommandHandler
Dispatches the command to the handler method and posts resulting events to the EventBus.
dispatch(EventEnvelope) - Method in class io.spine.server.entity.EventDispatchingRepository
Dispatches the event to the corresponding entities.
dispatch(EventEnvelope) - Method in class io.spine.server.event.AbstractEventReactor
 
dispatch(EventEnvelope) - Method in class io.spine.server.event.AbstractEventSubscriber
Dispatches the event to the handling method.
dispatch(EventEnvelope) - Method in class io.spine.server.event.AbstractStatefulReactor
 
dispatchCommand(CommandEnvelope) - Method in class io.spine.server.aggregate.Aggregate
Obtains a method for the passed command and invokes it.
dispatchCommand(CommandEnvelope) - Method in class io.spine.server.command.CommandHandlingEntity
Dispatches the passed command to appropriate handler.
dispatchCommand(CommandEnvelope) - Method in class io.spine.server.procman.ProcessManager
Dispatches the command to the handling method.
dispatchCommand(CommandEnvelope) - Method in class io.spine.server.procman.ProcessManagerRepository
Dispatches the command to a corresponding process manager.
dispatcherOf(E) - Method in class io.spine.server.bus.DispatcherRegistry
Obtains a single dispatcher (if available) for the passed message.
DispatcherRegistry<C extends io.spine.type.MessageClass<? extends com.google.protobuf.Message>,E extends MessageEnvelope<?,?,?>,D extends MessageDispatcher<C,E>> - Class in io.spine.server.bus
A registry of message dispatchers.
DispatcherRegistry() - Constructor for class io.spine.server.bus.DispatcherRegistry
 
dispatchersOf(C) - Method in class io.spine.server.bus.DispatcherRegistry
Obtains all the dispatchers for the passed message class.
dispatchesCommands() - Method in interface io.spine.server.commandbus.CommandDispatcher
Verifies if this instance dispatches at least one command.
dispatchesEvents() - Method in interface io.spine.server.event.EventDispatcher
Verifies if this instance dispatches at least one event.
dispatchesExternalEvents() - Method in interface io.spine.server.event.EventDispatcher
Verifies if this instance dispatches at least one external event.
dispatchEvent(EventEnvelope) - Method in class io.spine.server.aggregate.AggregateRepository
Dispatches event to one or more aggregates reacting on the event.
dispatchEvent(EventEnvelope) - Method in class io.spine.server.command.AbstractCommander
 
dispatchTo(I, Event) - Method in class io.spine.server.entity.EventDispatchingRepository
Dispatches the given event to an entity with the given ID.
dispatchTo(I, Event) - Method in class io.spine.server.procman.ProcessManagerRepository
Dispatches the given event to an entity with the given ID.
dispatchTo(I, Event) - Method in class io.spine.server.projection.ProjectionRepository
 
distinctAggregateIds() - Method in class io.spine.server.aggregate.AggregateStorage
Obtains distinct aggregate IDs from the stored event records.
doAdd(Class<S>, Class<T>, EnrichmentFn<S, C, T>) - Method in class io.spine.server.enrich.EnricherBuilder
Adds an enrichment function to the builder.
doBackward(EntityRecord) - Method in class io.spine.server.entity.StorageConverter
 
doForward(E) - Method in class io.spine.server.entity.StorageConverter
 
doLoadOrCreate(I) - Method in class io.spine.server.aggregate.AggregateRepository
 
domesticEventClasses() - Method in class io.spine.server.event.AbstractEventReactor
 
domesticEventClasses() - Method in class io.spine.server.event.AbstractEventSubscriber
 
domesticEventClasses() - Method in interface io.spine.server.event.EventDispatcher
Obtains classes of domestic events processed by this dispatcher.
domesticEventClasses() - Method in class io.spine.server.procman.ProcessManagerRepository
Obtains classes of domestic events to which the process managers managed by this repository react.
domesticEventClasses() - Method in class io.spine.server.projection.ProjectionRepository
 
domesticEvents() - Method in class io.spine.server.aggregate.AggregateRepository
 
domesticEvents() - Method in class io.spine.server.command.AbstractCommander
 
doNothing() - Method in interface io.spine.server.command.Commander
Obtains the DoNothing command message.
doNothing() - Static method in interface io.spine.server.GrpcContainer.ConfigureServer
Returns an instance which does nothing and returns the same ServerBuilder.
doSchedule(Command) - Method in class io.spine.server.commandbus.CommandScheduler
Schedules a command and delivers it to the target according to the scheduling options set to a context.
doSchedule(Command) - Method in class io.spine.server.commandbus.ExecutorCommandScheduler
 
doStore(A) - Method in class io.spine.server.aggregate.AggregateRepository
 

E

Either - Class in io.spine.server.tuple
Abstract base for values that can be one of the possible types.
Either(Message, int) - Constructor for class io.spine.server.tuple.Either
 
EitherOf2<A extends com.google.protobuf.Message,B extends com.google.protobuf.Message> - Class in io.spine.server.tuple
A value which can be one of two possible types.
EitherOf3<A extends com.google.protobuf.Message,B extends com.google.protobuf.Message,C extends com.google.protobuf.Message> - Class in io.spine.server.tuple
A value which can be one of three possible types.
EitherOf4<A extends com.google.protobuf.Message,B extends com.google.protobuf.Message,C extends com.google.protobuf.Message,D extends com.google.protobuf.Message> - Class in io.spine.server.tuple
A value which can be one of four possible types.
EitherOf5<A extends com.google.protobuf.Message,B extends com.google.protobuf.Message,C extends com.google.protobuf.Message,D extends com.google.protobuf.Message,E extends com.google.protobuf.Message> - Class in io.spine.server.tuple
A value which can be one of five possible types.
emittedEvent(EventMessage, ActorContext) - Method in class io.spine.server.integration.ThirdPartyContext
Emits an event from the third-party system.
emittedEvent(EventMessage, UserId) - Method in class io.spine.server.integration.ThirdPartyContext
Emits an event from the third-party system.
EmptyClass - Class in io.spine.server.type
The class of an Empty message.
emptySet() - Static method in class io.spine.server.type.EventClass
Returns an empty EventClass set.
enrich(E) - Method in class io.spine.server.enrich.Enricher
Enriches the passed message if it can be enriched.
EnrichableMessageEnvelope<I extends com.google.protobuf.Message,T,M extends com.google.protobuf.Message,C extends io.spine.core.EnrichableMessageContext,E extends EnrichableMessageEnvelope<I,T,M,C,E>> - Interface in io.spine.server.type
A common interface for enrichable message envelopes.
Enricher<M extends com.google.protobuf.Message,C extends io.spine.core.EnrichableMessageContext> - Class in io.spine.server.enrich
Enriches messages after they are stored, and before they are dispatched.
Enricher(EnricherBuilder<M, C, ?>) - Constructor for class io.spine.server.enrich.Enricher
Creates a new instance taking functions from the passed builder.
enricher() - Method in class io.spine.server.event.EventBus.Builder
Obtains Enricher assigned to the bus to be built.
EnricherBuilder<M extends com.google.protobuf.Message,C extends io.spine.core.EnrichableMessageContext,B extends EnricherBuilder<M,C,B>> - Class in io.spine.server.enrich
Allows to register enrichment functions used by the Enricher.
EnricherBuilder() - Constructor for class io.spine.server.enrich.EnricherBuilder
Creates new instance.
enrichEventsUsing(EventEnricher) - Method in class io.spine.server.BoundedContextBuilder
Sets a custom Enricher for events posted to the EventBus of the context being built.
EnrichmentFn<M extends com.google.protobuf.Message,C extends io.spine.core.EnrichableMessageContext,E extends com.google.protobuf.Message> - Interface in io.spine.server.enrich
Base interface for enrichment functions.
EnrichmentService<M extends com.google.protobuf.Message,C extends io.spine.core.EnrichableMessageContext> - Interface in io.spine.server.enrich
Creates enrichments for messages.
Entity<I,S extends io.spine.base.EntityState> - Interface in io.spine.server.entity
A server-side object with an identity.
Entity(TenantId) - Constructor for class io.spine.server.tenant.TenantRepository.Entity
 
Entity(TenantId, Function<TenantId, T>) - Constructor for class io.spine.server.tenant.TenantRepository.Entity
 
Entity.GenericParameter - Enum in io.spine.server.entity
Enumeration of generic type parameters of this interface.
entityClass() - Method in class io.spine.server.entity.Repository
Returns the class of entities managed by this repository.
entityFactory() - Method in class io.spine.server.entity.DefaultRecordBasedRepository
 
EntityFactory<E extends Entity> - Interface in io.spine.server.entity
Base interface for objects that can create entities.
entityFactory() - Method in class io.spine.server.entity.RecordBasedRepository
Obtains EntityFactory associated with this repository.
entityFactory() - Method in class io.spine.server.entity.StorageConverter
Obtains the entity factory used by the converter.
entityId() - Method in interface io.spine.server.entity.rejection.StandardRejection
Obtains the ID of the entity from the packed form.
EntityQuery<I> - Class in io.spine.server.entity.storage
A query to a RecordStorage for the records matching the given parameters.
EntityRecordWithColumns - Class in io.spine.server.entity.storage
A value of EntityRecord associated with the values of its columns.
entityStateType() - Method in class io.spine.server.entity.Repository
Obtains the TypeUrl for the state objects wrapped by entities managed by this repository.
entityStateType() - Method in class io.spine.server.entity.StorageConverter
Obtains the type URL of the state of entities which this converter builds.
entityStateUrl() - Method in class io.spine.server.storage.memory.StorageSpec
Obtains the URL of the entity state type.
EnvelopeValidator<E extends MessageEnvelope<?,?,?>> - Interface in io.spine.server.bus
An interface defining the validator for a MessageEnvelope.
equals(Object) - Method in class io.spine.server.command.AbstractCommandDispatcher
Indicates whether some other command handler is "equal to" this one.
equals(Object) - Method in class io.spine.server.ContextSpec
 
equals(Object) - Method in class io.spine.server.entity.AbstractEntity
 
equals(Object) - Method in class io.spine.server.entity.RecentHistory
 
equals(Object) - Method in class io.spine.server.entity.storage.CompositeQueryParameter
 
equals(Object) - Method in class io.spine.server.entity.storage.EntityQuery
 
equals(Object) - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
 
equals(Object) - Method in class io.spine.server.entity.storage.QueryParameters
 
equals(Object) - Method in class io.spine.server.entity.StorageConverter
 
equals(Object) - Method in class io.spine.server.integration.AbstractChannelObserver
 
equals(Object) - Method in class io.spine.server.storage.memory.StorageSpec
 
equals(Object) - Method in class io.spine.server.tuple.Either
 
equals(Object) - Method in class io.spine.server.tuple.Tuple
 
equals(Object) - Method in class io.spine.server.type.AbstractMessageEnvelope
 
error() - Method in exception io.spine.server.entity.InvalidEntityStateException
Returns an error occurred.
EventBlackList - Class in io.spine.server.entity
An EventFilter which allows any events except for the events of given types.
eventBus() - Method in class io.spine.server.aggregate.AggregateRepository
 
eventBus() - Method in class io.spine.server.BoundedContext
Obtains instance of EventBus of this BoundedContext.
eventBus() - Method in interface io.spine.server.entity.EventProducingRepository
Obtains the EventBus to which the repository posts.
eventBus() - Method in class io.spine.server.procman.ProcessManagerRepository
 
EventBus.Builder - Class in io.spine.server.event
The Builder for EventBus.
EventClass - Class in io.spine.server.type
A value object holding a class of events.
eventClasses() - Method in interface io.spine.server.event.EventDispatcher
Obtains classes of all events processed by this dispatcher.
EventContextField - Enum in io.spine.server.event.storage
Enumeration of storage fields required for storing EventContext.
EventDispatcher - Interface in io.spine.server.event
EventDispatcher delivers events to receiving objects.
eventDispatchers() - Method in class io.spine.server.BoundedContextBuilder
Obtains the list of event dispatchers added to the builder by the time of the call.
EventDispatchingRepository<I,E extends AbstractEntity<I,S>,S extends io.spine.base.EntityState> - Class in io.spine.server.entity
Abstract base for repositories that deliver events to entities they manage.
EventDispatchingRepository() - Constructor for class io.spine.server.entity.EventDispatchingRepository
 
EventEndpoint<I> - Interface in io.spine.server.delivery
An endpoint which accepts events.
eventEnricher() - Method in class io.spine.server.BoundedContextBuilder
Obtains EventEnricher assigned to the context to be built, or empty Optional if no enricher was assigned prior to this call.
EventEnricher - Class in io.spine.server.event
Enriches events after they are stored, and before they are dispatched.
EventEnricher.Builder - Class in io.spine.server.event
The builder for EventEnricher.
EventEnrichmentFn<M extends io.spine.base.EventMessage,E extends com.google.protobuf.Message> - Interface in io.spine.server.enrich
Base interface for event enrichment functions.
EventEnvelope - Class in io.spine.server.type
The holder of an Event which provides convenient access to its properties.
EventException - Exception in io.spine.server.event
A base for exceptions related to events.
EventException(String, EventMessage, Error) - Constructor for exception io.spine.server.event.EventException
Creates a new instance.
EventFactory - Class in io.spine.server.event
Produces events.
EventFactory(EventOrigin, Any) - Constructor for class io.spine.server.event.EventFactory
 
EventField - Enum in io.spine.server.event.storage
Enumeration of storage fields required for storing events.
EventFieldFilter - Class in io.spine.server.entity
An EventFilter which allows all the events but trims some of their message fields.
EventFieldFilter.Builder - Class in io.spine.server.entity
A builder for the EventFieldFilter instances.
EventFilter - Interface in io.spine.server.entity
A filter accepting Events posted by a Repository.
eventFilter() - Method in interface io.spine.server.entity.EventProducingRepository
Declared for mixing-in with Repository.eventFilter().
eventFilter() - Method in class io.spine.server.entity.Repository
Creates an EventFilter for this repository.
eventListener() - Method in class io.spine.server.stand.Stand
Obtains the bus listener which propagates all events and state updates to subscriptions.
EventProducer - Interface in io.spine.server
An object with identity which produces events.
EventProducingRepository - Interface in io.spine.server.entity
Operations common for repositories that can post to EventBus.
EventReactor - Interface in io.spine.server.event
A event reactor declares methods that receive events and may generate other events in response.
EventReceiver - Interface in io.spine.server.event
Common interface for objects receiving events.
EventRoute<I,M extends io.spine.base.EventMessage> - Interface in io.spine.server.route
Obtains a set of entity IDs for which to deliver an event.
EventRouting<I> - Class in io.spine.server.route
A routing schema used to deliver events.
events() - Method in class io.spine.server.aggregate.AggregateRepository
 
events() - Method in class io.spine.server.command.AbstractCommander
 
EventStore - Interface in io.spine.server.event
A store of all events in a Bounded Context.
EventSubscriber - Interface in io.spine.server.event
An event subscriber declares one or more methods subscribed to events.
eventTypeAttribute(Message) - Static method in exception io.spine.server.event.EventException
Returns a map with an event type attribute.
EventWhiteList - Class in io.spine.server.entity
An EventFilter which allows only events of given types.
execute(Query, StreamObserver<QueryResponse>) - Method in class io.spine.server.stand.Stand
Reads a particular set of items from the read-side of the application and feed the result into an instance.
execute(F) - Method in class io.spine.server.tenant.TenantAwareFunction
Returns the result of applying the function to the passed input.
execute() - Method in class io.spine.server.tenant.TenantAwareFunction0
 
execute() - Method in class io.spine.server.tenant.TenantAwareOperation
Executes the operation.
ExecutorCommandScheduler - Class in io.spine.server.commandbus
The command scheduler implementation which uses basic Java task scheduling features.
ExecutorCommandScheduler(ScheduledExecutorService) - Constructor for class io.spine.server.commandbus.ExecutorCommandScheduler
 
ExecutorCommandScheduler() - Constructor for class io.spine.server.commandbus.ExecutorCommandScheduler
 
exists(CommandMessage) - Static method in class io.spine.server.route.DefaultCommandRoute
Verifies of the passed command message potentially has a field with an entity ID.
expectedDefault(Message, Message) - Method in class io.spine.server.command.CommandHandlingEntity
Creates ValueMismatch for the case of discovering a non-default value when the default value was expected by a command.
expectedEmpty(String, String) - Method in class io.spine.server.command.CommandHandlingEntity
Creates ValueMismatch for the case of discovering a non-empty value, when an empty string was expected by a command.
expectedNotDefault(Message) - Method in class io.spine.server.command.CommandHandlingEntity
Creates a ValueMismatch for a command that wanted to clear a value, but discovered that the field already has the default value.
expectedNotDefault(Message, Message) - Method in class io.spine.server.command.CommandHandlingEntity
Creates a ValueMismatch for a command that wanted to change a field value, but discovered that the field has the default value.
expectedNotEmpty(String) - Method in class io.spine.server.command.CommandHandlingEntity
Creates a ValueMismatch for a command that wanted to clear a string value but discovered that the field is already empty.
exposedAggregateTypes() - Method in class io.spine.server.stand.Stand
Reads all Aggregate entity types exposed for reading by this instance of Stand.
exposedEventTypes() - Method in class io.spine.server.stand.Stand
Reads all event types produced by the repositories associated with this Stand.
exposedTypes() - Method in class io.spine.server.stand.Stand
Reads all Entity types exposed for reading by this instance of Stand.
externalEventClasses() - Method in class io.spine.server.event.AbstractEventReactor
 
externalEventClasses() - Method in class io.spine.server.event.AbstractEventSubscriber
 
externalEventClasses() - Method in interface io.spine.server.event.EventDispatcher
Obtains classes of external events processed by this dispatcher.
externalEventClasses() - Method in class io.spine.server.procman.ProcessManagerRepository
Obtains classes of external events to which the process managers managed by this repository react.
externalEventClasses() - Method in class io.spine.server.projection.ProjectionRepository
 
externalEvents() - Method in class io.spine.server.aggregate.AggregateRepository
 
externalEvents() - Method in class io.spine.server.command.AbstractCommander
 
ExternalMessageEnvelope - Class in io.spine.server.integration
An envelope for the messages produced outside of the current Bounded Context.

F

fieldMask() - Method in class io.spine.server.entity.StorageConverter
Obtains the field mask used by this converter to trim the state of entities before the state is injected into entities.
FieldMasks - Class in io.spine.server.entity
A utility class for creating instances of FieldMask and processing them against instances of Message.
filter(E) - Method in interface io.spine.server.bus.BusFilter
Accepts or rejects a passed message.
filter(CommandEnvelope) - Method in class io.spine.server.commandbus.CommandScheduler
 
filter(EventMessage) - Method in class io.spine.server.entity.CompositeEventFilter
 
filter(EventMessage) - Method in class io.spine.server.entity.EventBlackList
 
filter(EventMessage) - Method in class io.spine.server.entity.EventFieldFilter
 
filter(Collection<Event>) - Method in class io.spine.server.entity.EventFieldFilter
 
filter(EventMessage) - Method in interface io.spine.server.entity.EventFilter
Applies this filter to the given event.
filter(Collection<Event>) - Method in interface io.spine.server.entity.EventFilter
Applies this filter to the given Events in bulk.
filter(Collection<Event>) - Method in interface io.spine.server.entity.EventProducingRepository
Filters passed events using the EventProducingRepository.eventFilter() filter} of this repository.
filter(EventMessage) - Method in class io.spine.server.entity.EventWhiteList
 
filters() - Method in class io.spine.server.entity.storage.CompositeQueryParameter
Returns the joined entity column filters.
find(I) - Method in class io.spine.server.aggregate.AggregateRepository
Loads an aggregate by the passed ID.
find(ShardIndex) - Method in class io.spine.server.delivery.AbstractWorkRegistry
Looks for the session record by the given shard index.
find(I) - Method in class io.spine.server.entity.RecordBasedRepository
Finds an entity with the passed ID.
find(TargetFilters, ResponseFormat) - Method in class io.spine.server.entity.RecordBasedRepository
Finds the entities passing the given filters and applies the given FieldMask to the results.
find(I) - Method in class io.spine.server.entity.Repository
Finds an entity with the passed ID.
findActive(I) - Method in class io.spine.server.entity.RecordBasedRepository
Finds an entity with the passed ID even if the entity is active.
findConstructor() - Method in class io.spine.server.entity.DefaultEntityFactory
 
findOrCreate(I) - Method in class io.spine.server.entity.RecordBasedRepository
Loads an entity by the passed ID or creates a new one, if the entity was not found.
findOrCreate(I) - Method in class io.spine.server.procman.ProcessManagerRepository
Loads an entity by the passed ID or creates a new one, if the entity was not found.
findOrCreate(I) - Method in class io.spine.server.projection.ProjectionRepository
Loads an entity by the passed ID or creates a new one, if the entity was not found.
findPart(Class<? extends AggregateRoot<?>>, Class<? extends EntityState>) - Method in interface io.spine.server.aggregate.AggregateRootDirectory
Looks up an aggregate part repository by the type of the root and the type of the part state.
flushState() - Method in class io.spine.server.event.AbstractStatefulReactor
Immediately writes the changes made to the current builder to the storage.
forImport(ActorContext, Any) - Static method in class io.spine.server.event.EventFactory
Creates a new event factory for producing events to be imported into a Bounded Context.
forNumber(int) - Static method in class io.spine.server.delivery.UniformAcrossAllShards
Creates a strategy of uniform target distribution across shards, for a given shard number.
forwardingTo(StreamObserver<SubscriptionUpdate>) - Static method in interface io.spine.server.stand.SubscriptionCallback
Creates the callback which forwards to the passed observer.
from(EventEnvelope) - Static method in class io.spine.server.event.RejectionEnvelope
Creates a new RejectionEnvelope from the given event.
from(CommandEnvelope, Throwable) - Static method in class io.spine.server.event.RejectionEnvelope
Creates an instance of Rejection from the rejected command and a Throwable caused by the ThrowableMessage.
from(Class<? extends CommandMessage>) - Static method in class io.spine.server.type.CommandClass
Creates a new instance for the passed class value.
from(Class<? extends EventMessage>) - Static method in class io.spine.server.type.EventClass
Creates a new instance of the event class.
from(TypeUrl) - Static method in class io.spine.server.type.EventClass
Creates a new EventClass instance from the passed type URL.
from(Event) - Static method in class io.spine.server.type.EventClass
Creates a new EventClass from the given event.
fromThrowable(Class<? extends ThrowableMessage>) - Static method in class io.spine.server.type.EventClass
Obtains the class of the rejection by the class of corresponding throwable message.

G

get(Class<M>) - Method in class io.spine.server.route.CommandRouting
Obtains a route for the passed command class.
get(Class<M>) - Method in class io.spine.server.route.EventRouting
Obtains a route for the passed event class.
get(ChannelId) - Method in class io.spine.server.transport.ChannelHub
Obtains a channel from this hub by the given channel ID.
get(Either, int) - Static method in class io.spine.server.tuple.Either
 
get(int) - Method in class io.spine.server.tuple.Tuple
Obtains a value at the specified index.
getA() - Method in class io.spine.server.tuple.EitherOf2
Obtains the value of the first alternative.
getA() - Method in class io.spine.server.tuple.EitherOf3
Obtains the value of the first alternative.
getA() - Method in class io.spine.server.tuple.EitherOf4
Obtains the value of the first alternative.
getA() - Method in class io.spine.server.tuple.EitherOf5
Obtains the value of the first alternative.
getA() - Method in class io.spine.server.tuple.Pair
 
getA() - Method in class io.spine.server.tuple.Quartet
 
getA() - Method in class io.spine.server.tuple.Quintet
 
getA() - Method in class io.spine.server.tuple.Triplet
 
getB() - Method in class io.spine.server.tuple.EitherOf2
Obtains the value of the second alternative.
getB() - Method in class io.spine.server.tuple.EitherOf3
Obtains the value of the second alternative.
getB() - Method in class io.spine.server.tuple.EitherOf4
Obtains the value of the second alternative.
getB() - Method in class io.spine.server.tuple.EitherOf5
Obtains the value of the second alternative.
getB() - Method in class io.spine.server.tuple.Pair
 
getB() - Method in class io.spine.server.tuple.Quartet
 
getB() - Method in class io.spine.server.tuple.Quintet
 
getB() - Method in class io.spine.server.tuple.Triplet
 
getBoundedContextName() - Method in class io.spine.server.storage.memory.StorageSpec
Deprecated.
getC() - Method in class io.spine.server.tuple.EitherOf3
Obtains the value of the third alternative.
getC() - Method in class io.spine.server.tuple.EitherOf4
Obtains the value of the third alternative.
getC() - Method in class io.spine.server.tuple.EitherOf5
Obtains the value of the third alternative.
getC() - Method in class io.spine.server.tuple.Quartet
 
getC() - Method in class io.spine.server.tuple.Quintet
 
getC() - Method in class io.spine.server.tuple.Triplet
 
getCommand() - Method in exception io.spine.server.commandbus.CommandException
Returns a related command.
getCommandMessage() - Method in exception io.spine.server.commandbus.CommandPostingException
Obtains the command message of the command which could not be posted.
getContext() - Method in exception io.spine.server.commandbus.CommandPostingException
Obtains the context of the command which could not be posted.
getD() - Method in class io.spine.server.tuple.EitherOf4
Obtains the value of the third alternative.
getD() - Method in class io.spine.server.tuple.EitherOf5
Obtains the value of the third alternative.
getD() - Method in class io.spine.server.tuple.Quartet
 
getD() - Method in class io.spine.server.tuple.Quintet
 
getDispatcherForType(C) - Method in class io.spine.server.bus.DispatcherRegistry
Obtains a single dispatcher (if available) for the passed message.
getE() - Method in class io.spine.server.tuple.EitherOf5
 
getE() - Method in class io.spine.server.tuple.Quintet
 
getEntityId() - Method in interface io.spine.server.entity.rejection.StandardRejection
Obtains the packed version of ID of the entity which caused the rejection.
getEntityStateUrl() - Method in class io.spine.server.storage.memory.StorageSpec
Deprecated.
getEvent() - Method in class io.spine.server.event.RejectionEnvelope
 
getEventMessage() - Method in exception io.spine.server.event.EventException
Returns a related event message.
getId() - Method in interface io.spine.server.delivery.CatchUpSignal
Obtains the identifier of the CatchUp to which this signal relates.
getIdClass() - Method in class io.spine.server.storage.memory.StorageSpec
Deprecated.
getIds() - Method in class io.spine.server.entity.storage.EntityQuery
Obtains an immutable set of accepted ID values.
getLifecycleFlags() - Method in class io.spine.server.entity.AbstractEntity
 
getLifecycleFlags() - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
 
getLifecycleFlags() - Method in class io.spine.server.entity.TransactionalEntity
Obtains the current state of the entity lifecycle flags.
getLifecycleFlags() - Method in interface io.spine.server.entity.WithLifecycle
Obtains current lifecycle flags.
getMessage() - Method in exception io.spine.server.delivery.CatchUpAlreadyStartedException
 
getOrigin() - Method in class io.spine.server.event.RejectionEnvelope
Obtains the origin command.
getOriginMessage() - Method in class io.spine.server.event.RejectionEnvelope
Obtains the origin command message.
getParameters() - Method in class io.spine.server.entity.storage.EntityQuery
Obtains a Map of the Column metadata to the column required value.
getParameters() - Method in class io.spine.server.entity.storage.QueryParameters.Builder
 
getPort() - Method in class io.spine.server.GrpcContainer.Builder
Deprecated.
getRepository() - Method in class io.spine.server.delivery.CatchUpProcessBuilder
Obtains the projection repository for which the catch-up process is being built.
getRequest() - Method in exception io.spine.server.stand.InvalidRequestException
Obtains an original request which caused the error.
getRequest() - Method in exception io.spine.server.stand.InvalidSubscriptionException
 
getRequest() - Method in exception io.spine.server.stand.InvalidTopicException
 
getServices() - Method in class io.spine.server.GrpcContainer.Builder
Deprecated.
GrpcContainer - Class in io.spine.server
Wrapping container for gRPC server.
GrpcContainer.Builder - Class in io.spine.server
The builder for GrpcContainer allows to define a port and services exposed by the container.
GrpcContainer.ConfigureServer - Interface in io.spine.server
Allows to configure the gRPC's Server instance, on top of which this GrpcContainer will operate.

H

handle(EventEnvelope) - Method in class io.spine.server.event.AbstractEventSubscriber
Handles an event dispatched to this subscriber instance.
handle(ExternalMessage) - Method in class io.spine.server.integration.AbstractChannelObserver
Handles the message received via this channel.
HandlerLifecycle - Interface in io.spine.server.log
Callbacks for a HandlerMethod invocation.
HandlerLog - Class in io.spine.server.log
A log for handler methods.
HandlerLog(FluentLogger, HandlerMethod<?, ?, ?, ?>) - Constructor for class io.spine.server.log.HandlerLog
 
hasChannel(ChannelId) - Method in class io.spine.server.transport.ChannelHub
Checks if this channel hub contains a channel with a given ID.
hasColumn(ColumnName) - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
Determines if there is a column with the specified name among the storage fields.
hasColumns() - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
Determines if there are any columns associated with this record.
hasContext() - Method in class io.spine.server.entity.Repository
Verifies whether the repository is registered with a BoundedContext.
hasEntitiesOfType(Class<? extends Entity<?, ?>>) - Method in class io.spine.server.BoundedContext
Verifies if this Bounded Context contains entities of the passed class.
hasEntitiesWithState(Class<? extends EntityState>) - Method in class io.spine.server.BoundedContext
Verifies if this Bounded Context has entities with the state of the passed class.
hashCode() - Method in class io.spine.server.command.AbstractCommandDispatcher
 
hashCode() - Method in class io.spine.server.ContextSpec
 
hashCode() - Method in class io.spine.server.entity.AbstractEntity
 
hashCode() - Method in class io.spine.server.entity.RecentHistory
 
hashCode() - Method in class io.spine.server.entity.storage.CompositeQueryParameter
 
hashCode() - Method in class io.spine.server.entity.storage.EntityQuery
 
hashCode() - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
 
hashCode() - Method in class io.spine.server.entity.storage.QueryParameters
 
hashCode() - Method in class io.spine.server.entity.StorageConverter
 
hashCode() - Method in class io.spine.server.integration.AbstractChannelObserver
 
hashCode() - Method in class io.spine.server.storage.memory.StorageSpec
 
hashCode() - Method in class io.spine.server.tuple.Either
 
hashCode() - Method in class io.spine.server.tuple.Tuple
 
hashCode() - Method in class io.spine.server.type.AbstractMessageEnvelope
 
hasLifecycle() - Method in class io.spine.server.entity.storage.CompositeQueryParameter
Returns true if this parameter contains filters by the Entity lifecycle columns, false otherwise.
historyBackward() - Method in class io.spine.server.aggregate.Aggregate
Creates an iterator of the aggregate event history with reverse traversal.
historyBackward(AggregateReadRequest<I>) - Method in class io.spine.server.aggregate.AggregateStorage
Creates iterator of aggregate event history with the reverse traversal.
historyContains(Predicate<Event>) - Method in class io.spine.server.aggregate.Aggregate
Verifies if the aggregate history contains an event which satisfies the passed predicate.

I

id() - Method in class io.spine.server.aggregate.AggregateRoot
Obtains the aggregate ID.
id() - Method in class io.spine.server.command.AbstractCommandDispatcher
Obtains identity string of the dispatcher.
id() - Method in class io.spine.server.entity.AbstractEntity
 
id() - Method in interface io.spine.server.entity.Entity
Obtains the identifier of the entity.
id() - Method in class io.spine.server.entity.Migration
Returns the ID of an entity under migration.
id() - Method in class io.spine.server.event.RejectionEnvelope
 
id() - Method in class io.spine.server.integration.ExternalMessageEnvelope
 
id() - Method in class io.spine.server.transport.AbstractChannel
 
id() - Method in interface io.spine.server.transport.MessageChannel
Obtains the channel identifier.
id() - Method in class io.spine.server.type.CommandEnvelope
Obtains the command ID.
id() - Method in class io.spine.server.type.EventEnvelope
Obtains the event ID.
id() - Method in interface io.spine.server.type.MessageEnvelope
The ID of the message.
idAsString() - Method in class io.spine.server.entity.AbstractEntity
Obtains ID of the entity in the string form.
idAsString() - Method in interface io.spine.server.entity.Entity
Obtains string representation of the entity identifier.
idClass() - Method in class io.spine.server.entity.Repository
Returns the class of IDs used by this repository.
idClass() - Method in class io.spine.server.storage.memory.StorageSpec
Obtains the class of identifiers used by the storage.
identity() - Static method in interface io.spine.server.entity.storage.ColumnTypeMapping
 
ids() - Method in class io.spine.server.transport.ChannelHub
 
importableEvents() - Method in class io.spine.server.aggregate.AggregateRepository
Obtains classes of events that can be imported by aggregates of this repository.
ImportBus - Class in io.spine.server.aggregate
Dispatches events to repositories of aggregates that import these events.
importBus() - Method in class io.spine.server.BoundedContext
Obtains instance of ImportBus of this BoundedContext.
ImportBus.Builder - Class in io.spine.server.aggregate
The builder for ImportBus.
inapplicableTenantId(Command) - Static method in exception io.spine.server.commandbus.InvalidCommandException
Creates an exception for the command which specifies a tenant in a single-tenant context.
Inbox.Builder<I> - Class in io.spine.server.delivery
A builder of Inbox instances.
Inbox.CommandDestinations - Class in io.spine.server.delivery
The available destinations for the Commandss sent via this inbox.
Inbox.EventDestinations - Class in io.spine.server.delivery
The available destinations for the Events sent via this inbox.
InboxReadRequest - Class in io.spine.server.delivery
A request to read a certain InboxMessage by its ID.
InboxReadRequest(InboxMessageId) - Constructor for class io.spine.server.delivery.InboxReadRequest
 
inboxStorage() - Method in class io.spine.server.delivery.DeliveryBuilder
Returns the value of the configured InboxStorage or Optional.empty() if no such value was configured.
InboxStorage - Interface in io.spine.server.delivery
A contract for storages of Inbox messages.
include(BindableService) - Method in class io.spine.server.Server.Builder
Adds a gRPC service to the built server.
index() - Method in enum io.spine.server.aggregate.AggregatePart.GenericParameter
 
index() - Method in class io.spine.server.aggregate.AggregateStorage
Returns an iterator over identifiers of records in the storage.
index() - Method in enum io.spine.server.entity.Entity.GenericParameter
 
index() - Method in class io.spine.server.entity.Repository
Returns an iterator over the identifiers of all the entities managed by this repository.
index() - Method in class io.spine.server.storage.memory.InMemoryCatchUpStorage
 
index() - Method in class io.spine.server.storage.memory.InMemoryInboxStorage
 
index() - Method in class io.spine.server.storage.memory.InMemoryProjectionStorage
 
index() - Method in class io.spine.server.storage.memory.InMemoryRecordStorage
 
index() - Method in interface io.spine.server.storage.Storage
Returns an iterator over identifiers of records in the storage.
index() - Method in class io.spine.server.tuple.Either
Obtains a zero-based index of the value.
indexFor(Object, TypeUrl) - Method in class io.spine.server.delivery.DeliveryStrategy
Determines the shard index for the messages heading to the entity with the specified target identifier.
indexFor(Object, TypeUrl) - Method in class io.spine.server.delivery.UniformAcrossAllShards
 
init() - Method in class io.spine.server.BoundedContext
Performs post-creation initialization of the instance.
injectEnricher(EventEnricher) - Method in class io.spine.server.event.EventBus.Builder
Sets a custom Enricher for events posted to the EventBus which is being built.
injectServer(Server) - Method in class io.spine.server.GrpcContainer
Injects a server to this container.
injectState(E, S, EntityRecord) - Method in class io.spine.server.entity.StorageConverter
Derived classes must implement providing state injection into the passed entity.
InMemoryCatchUpStorage - Class in io.spine.server.storage.memory
An in-memory implementation of CatchUpStorage.
InMemoryCatchUpStorage(boolean) - Constructor for class io.spine.server.storage.memory.InMemoryCatchUpStorage
 
InMemoryInboxStorage - Class in io.spine.server.storage.memory
In-memory implementation of messages stored in Inbox.
InMemoryInboxStorage(boolean) - Constructor for class io.spine.server.storage.memory.InMemoryInboxStorage
 
InMemoryProjectionStorage<I> - Class in io.spine.server.storage.memory
The in-memory implementation of ProjectionStorage.
InMemoryPublisher - Class in io.spine.server.transport.memory
An in-memory implementation of the Publisher.
InMemoryRecordStorage<I> - Class in io.spine.server.storage.memory
Memory-based implementation of RecordStorage.
InMemoryStorageFactory - Class in io.spine.server.storage.memory
A factory for in-memory storages.
InMemoryTransportFactory - Class in io.spine.server.transport.memory
In-memory implementation of the TransportFactory.
InMemoryTransportFactory() - Constructor for class io.spine.server.transport.memory.InMemoryTransportFactory
Prevent direct instantiation from outside of the inheritance tree.
inProcess(String) - Static method in class io.spine.server.GrpcContainer
Initiates creating an in-process container exposed with the given server name.
inProcess(String) - Static method in class io.spine.server.Server
Initiates creating an in-process server exposed with the given name.
INSTANCE - Static variable in class io.spine.server.entity.storage.DefaultColumnMapping
 
instance() - Static method in class io.spine.server.ServerEnvironment
Returns a singleton instance.
instance() - Static method in class io.spine.server.type.EmptyClass
Return the single instance of the EmptyClass.
InvalidCommandException - Exception in io.spine.server.commandbus
The exception for reporting invalid commands.
InvalidEntityStateException - Exception in io.spine.server.entity
Signals that an entity state does not pass validation.
InvalidEventException - Exception in io.spine.server.event
The exception for reporting invalid events.
InvalidRequestException - Exception in io.spine.server.stand
A base class for exceptions fired in case an invalid request has been submitted to Stand.
InvalidSubscriptionException - Exception in io.spine.server.stand
An exception thrown in case an invalid or unsupported Subscription has been submitted to Stand.
InvalidSubscriptionException(String, Subscription, Error) - Constructor for exception io.spine.server.stand.InvalidSubscriptionException
Creates a new instance.
InvalidTopicException - Exception in io.spine.server.stand
An exception thrown in case an invalid or unsupported Topic has been submitted to Stand.
io.spine.server - package io.spine.server
This package provides classes and interfaces for backend part of the system.
io.spine.server.aggregate - package io.spine.server.aggregate
 
io.spine.server.bus - package io.spine.server.bus
This package contains classes and interfaces for abstract Bus.
io.spine.server.command - package io.spine.server.command
This package provides classes and interfaces related to command processing at the server side.
io.spine.server.commandbus - package io.spine.server.commandbus
This package provides classes and interfaces related to CommandBus and its configuration.
io.spine.server.delivery - package io.spine.server.delivery
This package is devoted to message delivery mechanism.
io.spine.server.enrich - package io.spine.server.enrich
This package contains classes and interfaces related to enrichment of events.
io.spine.server.entity - package io.spine.server.entity
This package contains classes and interfaces defining entity-oriented API and base functionality.
io.spine.server.entity.rejection - package io.spine.server.entity.rejection
This package contains classes and interfaces for rejections related to lifecycle of entities.
io.spine.server.entity.storage - package io.spine.server.entity.storage
This package contains classes and interfaces for working with entity storage representation.
io.spine.server.event - package io.spine.server.event
This package provides classes for server-side event processing.
io.spine.server.event.storage - package io.spine.server.event.storage
This package contains generated classes and interfaces for storing events.
io.spine.server.event.store - package io.spine.server.event.store
Provides default implementation of EventStore.
io.spine.server.integration - package io.spine.server.integration
This package contains classes and interfaces for communications between bounded contexts.
io.spine.server.log - package io.spine.server.log
Contains utilities which work with server-side logs.
io.spine.server.procman - package io.spine.server.procman
This package provides classes related to Process Managers.
io.spine.server.procman.migration - package io.spine.server.procman.migration
This package contains standard Spine migrations available for process managers.
io.spine.server.projection - package io.spine.server.projection
This package provides classes for working with event stream projections.
io.spine.server.projection.migration - package io.spine.server.projection.migration
This package contains standard Spine migrations available for projections.
io.spine.server.route - package io.spine.server.route
This package contains classes and interfaces for obtaining entity identifiers.
io.spine.server.stand - package io.spine.server.stand
This package provides classes for working with Stand.
io.spine.server.storage - package io.spine.server.storage
This package provides interfaces and base classes for storages.
io.spine.server.storage.memory - package io.spine.server.storage.memory
This package provides implementation of in-memory storages.
io.spine.server.tenant - package io.spine.server.tenant
This package contains classes and interfaces for supporting multi-tenancy.
io.spine.server.trace - package io.spine.server.trace
This package defines the Spine Trace API.
io.spine.server.transport - package io.spine.server.transport
This package contains classes and interfaces that connect Spine with the infrastructure of the outer world.
io.spine.server.transport.memory - package io.spine.server.transport.memory
This package provides implementation of in-memory TransportFactory routines.
io.spine.server.tuple - package io.spine.server.tuple
This package provides classes for return values from message-handling methods.
io.spine.server.type - package io.spine.server.type
Provides classes and interfaces for server-side type information.
isActive() - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
 
isActive() - Method in interface io.spine.server.entity.WithLifecycle
Verifies if any of the lifecycle attributes is set.
isArchived() - Method in class io.spine.server.entity.AbstractEntity
Tests whether the entity is marked as archived.
isArchived() - Method in class io.spine.server.entity.Migration
Returns true if the entity under migration is archived.
isArchived() - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
 
isArchived() - Method in interface io.spine.server.entity.WithLifecycle
Shows if current instance is marked as archived or not.
isClosed() - Method in class io.spine.server.storage.AbstractStorage
Tests whether the storage is closed.
isDeleted() - Method in class io.spine.server.entity.AbstractEntity
Tests whether the entity is marked as deleted.
isDeleted() - Method in class io.spine.server.entity.Migration
Returns true if the entity under migration is deleted.
isDeleted() - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
 
isDeleted() - Method in interface io.spine.server.entity.WithLifecycle
Shows if current instance is marked as deleted or not.
isEmpty() - Method in class io.spine.server.entity.RecentHistory
Returns true if there are no events in the recent history, false otherwise.
isEnrichmentEnabled() - Method in class io.spine.server.type.EventEnvelope
Verifies if the enrichment of the message is enabled.
isExternal() - Method in class io.spine.server.type.EventEnvelope
Returns true is the wrapped event is external, false otherwise.
isLifecycleAttributesSet() - Method in class io.spine.server.entity.storage.QueryParameters
Verifies whether this parameters include filters by the Entity lifecycle flags or not.
isLive(BindableService) - Method in class io.spine.server.GrpcContainer
Check if the given gRPC service has actually been deployed and is available for interaction within this container.
isMultitenant() - Method in class io.spine.server.BoundedContext
Returns true if the Bounded Context is designed to serve more than one tenant of the application, false otherwise.
isMultitenant() - Method in class io.spine.server.BoundedContextBuilder
 
isMultitenant() - Method in class io.spine.server.ContextSpec
Checks if the context is multitenant or not.
isMultitenant() - Method in class io.spine.server.storage.AbstractStorage
 
isMultitenant() - Method in interface io.spine.server.storage.Storage
Verifies whether the storage is multitenant.
isOpen() - Method in class io.spine.server.BoundedContext
 
isOpen() - Method in interface io.spine.server.Closeable
Tells if the object is still open.
isOpen() - Method in class io.spine.server.commandbus.CommandScheduler
 
isOpen() - Method in class io.spine.server.entity.Repository
Verifies if the repository is open.
isOpen() - Method in class io.spine.server.integration.ThirdPartyContext
 
isOpen() - Method in class io.spine.server.storage.AbstractStorage
Tests whether the storage is open.
isOpen() - Method in interface io.spine.server.storage.Storage
Verifies whether the storage is open.
isOpen() - Method in class io.spine.server.transport.memory.InMemoryTransportFactory
 
isRegistered() - Method in class io.spine.server.command.AbstractCommandDispatcher
 
isRegistered() - Method in class io.spine.server.entity.Repository
Tells if the repository is registered in a BoundedContext.
isRegistered() - Method in class io.spine.server.event.AbstractEventReactor
 
isRegistered() - Method in class io.spine.server.event.AbstractEventSubscriber
 
isRejection() - Method in class io.spine.server.type.EventEnvelope
Returns true if the wrapped event is a rejection, false otherwise.
isScheduledForDeployment(BindableService) - Method in class io.spine.server.GrpcContainer
Check if the given gRPC service is scheduled for the deployment in this container.
isShutdown() - Method in class io.spine.server.GrpcContainer
Returns true if the server is shut down or was not started at all, false otherwise.
isStale() - Method in class io.spine.server.transport.memory.InMemoryPublisher
Always returns false as publishers don't get stale.
isStale() - Method in interface io.spine.server.transport.MessageChannel
Allows to understand whether this channel is stale and can be closed.
isStale() - Method in class io.spine.server.transport.Subscriber
 
isTypeSupplier() - Method in class io.spine.server.event.store.DefaultEventStore
 
isTypeSupplier() - Method in class io.spine.server.tenant.TenantRepository
 
iterator() - Method in class io.spine.server.entity.RecentHistory
Creates a new iterator over the recent history items.
iterator(Predicate<E>) - Method in class io.spine.server.entity.RecordBasedRepository
 
iterator(Predicate<E>) - Method in class io.spine.server.entity.Repository
Returns an iterator over the entities managed by the repository that match the passed filter.
iterator() - Method in class io.spine.server.entity.storage.QueryParameters
Returns an iterator over the column filters.
iterator() - Method in class io.spine.server.tuple.Either
 
iterator() - Method in class io.spine.server.tuple.Tuple
 

K

keep(TenantId) - Method in interface io.spine.server.tenant.TenantIndex
Stores the passed tenant ID in the index.
keep(TenantId) - Method in class io.spine.server.tenant.TenantRepository
Stores the passed tenant ID in the index.

L

letPass() - Method in interface io.spine.server.bus.BusFilter
Lets the message pass the filter.
LifecycleFlagField - Enum in io.spine.server.storage
A container for the storage fields used to store the LifecycleFlags.
lifecycleFlags() - Method in interface io.spine.server.entity.WithLifecycle
Obtains current lifecycle flags.
lifecycleFlagsChanged() - Method in class io.spine.server.entity.AbstractEntity
 
lifecycleFlagsChanged() - Method in interface io.spine.server.entity.Entity
Tells whether lifecycle flags of the entity changed since its initialization.
Listener<E extends MessageEnvelope<?,?,?>> - Interface in io.spine.server.bus
A listener receives a message when it is posted to a Bus before it is processed by filters.
load(CatchUpId) - Method in class io.spine.server.delivery.CatchUpProcess
 
load(I) - Method in class io.spine.server.event.AbstractStatefulReactor
Loads the state from the storage by ID.
loadAll(ResponseFormat) - Method in class io.spine.server.entity.RecordBasedRepository
 
loadAll(Iterable<I>, FieldMask) - Method in class io.spine.server.entity.RecordBasedRepository
Loads all the entities in this repository with IDs, contained within the passed ids values.
local() - Static method in class io.spine.server.delivery.Delivery
Creates a new instance of Delivery suitable for local and development environment.
localAsync() - Static method in class io.spine.server.delivery.Delivery
Creates a new instance of Delivery for local and development environment.
LocalDispatchingObserver - Class in io.spine.server.delivery
An observer of changes to the shard contents, which triggers immediate delivery of the sharded messages.
LocalDispatchingObserver() - Constructor for class io.spine.server.delivery.LocalDispatchingObserver
Creates a new observer instance which performs the delivery synchronously.
LoggingEntity - Interface in io.spine.server.log
A Logging trait for entities.

M

markArchived() - Method in class io.spine.server.entity.Migration
Marks the entity under migration as archived.
markDeleted() - Method in class io.spine.server.entity.Migration
Marks the entity under migration as deleted.
MarkPmArchived<I,P extends ProcessManager<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.procman.migration
A migration operation that marks a ProcessManager as archived.
MarkPmArchived() - Constructor for class io.spine.server.procman.migration.MarkPmArchived
 
MarkPmDeleted<I,P extends ProcessManager<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.procman.migration
A migration operation that marks a ProcessManager as deleted.
MarkPmDeleted() - Constructor for class io.spine.server.procman.migration.MarkPmDeleted
 
MarkProjectionArchived<I,P extends Projection<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.projection.migration
A migration operation that marks a Projection as archived.
MarkProjectionArchived() - Constructor for class io.spine.server.projection.migration.MarkProjectionArchived
 
MarkProjectionDeleted<I,P extends Projection<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.projection.migration
A migration operation that marks a Projection as deleted.
MarkProjectionDeleted() - Constructor for class io.spine.server.projection.migration.MarkProjectionDeleted
 
message() - Method in class io.spine.server.event.RejectionEnvelope
 
message() - Method in class io.spine.server.integration.ExternalMessageEnvelope
Obtains an originally transferred message.
message() - Method in class io.spine.server.type.CommandEnvelope
Obtains the command message.
message() - Method in class io.spine.server.type.EventEnvelope
Obtains the event message.
message() - Method in interface io.spine.server.type.MessageEnvelope
Obtains the message.
MessageChannel - Interface in io.spine.server.transport
A channel dedicated to exchanging the messages.
messageClass() - Method in class io.spine.server.event.RejectionEnvelope
 
messageClass() - Method in class io.spine.server.integration.ExternalMessageEnvelope
Obtains a message class of an originally transferred message such as io.spine.sample.TaskCreated class.
messageClass() - Method in class io.spine.server.type.CommandEnvelope
Obtains the command class.
messageClass() - Method in class io.spine.server.type.EventEnvelope
Obtains the class of the event.
messageClass() - Method in interface io.spine.server.type.MessageEnvelope
Obtains the message class.
messageClasses() - Method in class io.spine.server.aggregate.AggregateRepository
 
messageClasses() - Method in interface io.spine.server.bus.MessageDispatcher
Obtains a set of message classes that can be processed by this dispatcher.
messageClasses() - Method in class io.spine.server.command.AbstractCommander
 
messageClasses() - Method in class io.spine.server.command.AbstractCommandHandler
 
messageClasses() - Method in class io.spine.server.event.AbstractEventReactor
 
messageClasses() - Method in class io.spine.server.event.AbstractEventSubscriber
 
messageClasses() - Method in class io.spine.server.procman.ProcessManagerRepository
Obtains a set of event classes to which process managers of this repository react.
messageClasses() - Method in class io.spine.server.projection.ProjectionRepository
 
MessageDispatcher<C extends io.spine.type.MessageClass,E extends MessageEnvelope> - Interface in io.spine.server.bus
A dispatcher of a message.
MessageEnvelope<I extends com.google.protobuf.Message,T,C extends com.google.protobuf.Message> - Interface in io.spine.server.type
A common interface for obtaining messages from wrapping objects.
messageFormat(String, Command) - Static method in exception io.spine.server.commandbus.CommandException
Builds a formatted string for the passed format and a command.
messageId() - Method in interface io.spine.server.type.SignalEnvelope
Obtains the message ID of the signal.
messageTypeName() - Method in class io.spine.server.type.CommandEnvelope
Obtains TypeName of the command message.
messageTypeName() - Method in class io.spine.server.type.EventEnvelope
Obtains the type of the event message.
Migration<I,E extends TransactionalEntity<I,S,?>,S extends io.spine.base.EntityState> - Class in io.spine.server.entity
A stored Entity transformation done to account for the domain model changes.
Migration() - Constructor for class io.spine.server.entity.Migration
 
missingTenantId(Command) - Static method in exception io.spine.server.commandbus.InvalidCommandException
Creates an exception for a command with missing tenant_id attribute in the CommandContext which is required in a multitenant application.
missingTxMessage() - Method in class io.spine.server.aggregate.Aggregate
Instructs to modify the state of an aggregate only within an event applier method.
missingTxMessage() - Method in class io.spine.server.entity.TransactionalEntity
Provides error message text for the case of not having an active transaction when a state modification call is made.
missingTxMessage() - Method in class io.spine.server.procman.ProcessManager
 
missingTxMessage() - Method in class io.spine.server.projection.Projection
 
Multicast<I,M extends com.google.protobuf.Message,C extends com.google.protobuf.Message> - Interface in io.spine.server.route
A route for a message to be delivered to several entities.
MulticastBus<M extends io.spine.core.Signal<?,?,?>,E extends SignalEnvelope<?,M,?>,C extends io.spine.type.MessageClass<? extends com.google.protobuf.Message>,D extends MessageDispatcher<C,E>> - Class in io.spine.server.bus
A Bus, which delivers a single message to multiple dispatchers.
MulticastBus(BusBuilder<?, M, E, C, D>) - Constructor for class io.spine.server.bus.MulticastBus
 
MulticastDispatcher<C extends io.spine.type.MessageClass,E extends MessageEnvelope> - Interface in io.spine.server.bus
Dispatches a message to several entities of the same type.
multitenant(String) - Static method in class io.spine.server.BoundedContext
Creates a new builder for a multitenant BoundedContext.
multitenant(String) - Static method in class io.spine.server.ContextSpec
Creates a spec of a multitenant context with the given name.
multitenant(String) - Static method in class io.spine.server.integration.ThirdPartyContext
Creates a new multitenant instance of ThirdPartyContext with the given name.

N

name() - Method in class io.spine.server.BoundedContext
Obtains an ID of the Bounded Context.
name() - Method in class io.spine.server.BoundedContextBuilder
Returns the name of the resulting context.
name() - Method in class io.spine.server.ContextSpec
Obtains the context name.
name() - Method in interface io.spine.server.entity.storage.Column
The name of the column in the storage.
name() - Method in interface io.spine.server.storage.StorageField
The field name.
newBuilder() - Static method in class io.spine.server.aggregate.ImportBus
Creates a builder for creating a new ImportBus.
newBuilder() - Static method in class io.spine.server.CommandService
Creates a new builder for CommandService.
newBuilder() - Static method in class io.spine.server.delivery.Delivery
Creates an instance of new Builder of Delivery.
newBuilder() - Static method in class io.spine.server.entity.CompositeEventFilter
Creates a new instance of Builder for CompositeEventFilter instances.
newBuilder() - Static method in class io.spine.server.entity.EventFieldFilter
Creates a new instance of Builder for EventFieldFilter instances.
newBuilder() - Static method in class io.spine.server.entity.storage.QueryParameters
 
newBuilder(QueryParameters) - Static method in class io.spine.server.entity.storage.QueryParameters
 
newBuilder() - Static method in class io.spine.server.event.EventEnricher
Creates a new builder.
newBuilder() - Static method in class io.spine.server.GrpcContainer
newBuilder() - Static method in class io.spine.server.QueryService
Creates a new builder for the service.
newBuilder() - Static method in class io.spine.server.Server
Deprecated.
newBuilder() - Static method in class io.spine.server.stand.Stand
 
newBuilder() - Static method in class io.spine.server.SubscriptionService
 
newCatchUpProcess(ProjectionRepository<I, ?, ?>) - Method in class io.spine.server.delivery.Delivery
Creates a new instance of the builder for CatchUpProcess.
newChannel(ChannelId) - Method in class io.spine.server.transport.ChannelHub
Creates a new channel under the specified ID.
newChannel(ChannelId) - Method in class io.spine.server.transport.PublisherHub
 
newChannel(ChannelId) - Method in class io.spine.server.transport.SubscriberHub
 
newCommandScheduler() - Method in class io.spine.server.ServerEnvironment
Obtains command scheduling mechanism used by CommandBus in this environment.
newestMessageToDeliver(ShardIndex) - Method in interface io.spine.server.delivery.InboxStorage
Finds the newest message to deliver in the given shard.
newestMessageToDeliver(ShardIndex) - Method in class io.spine.server.storage.memory.InMemoryInboxStorage
 
newInbox(TypeUrl) - Method in class io.spine.server.delivery.Delivery
Creates an instance of Inbox.Builder for the given entity type.
newInstance(Class<I>) - Static method in class io.spine.server.route.CommandRouting
Creates a new command routing.
newInstance(Class<I>) - Static method in class io.spine.server.route.DefaultCommandRoute
Creates a new instance.
newInstance(Class<I>) - Static method in class io.spine.server.route.StateUpdateRouting
Creates a new StateUpdateRouting.
newInstance() - Static method in class io.spine.server.storage.memory.InMemoryStorageFactory
Creates new instance of the factory which would serve the specified context.
newInstance() - Static method in class io.spine.server.transport.memory.InMemoryTransportFactory
Creates a new instance of InMemoryTransportFactory.
newInstance() - Static method in class io.spine.server.transport.memory.SingleThreadInMemTransportFactory
 
newRegistry() - Method in class io.spine.server.aggregate.ImportBus.Builder
 
newRegistry() - Method in class io.spine.server.commandbus.CommandBus.Builder
 
newRegistry() - Method in class io.spine.server.event.EventBus.Builder
 
newStateBuilderWith(CatchUpId) - Method in class io.spine.server.delivery.CatchUpProcess
 
newStateBuilderWith(I) - Method in class io.spine.server.event.AbstractStatefulReactor
Creates a new instance of the respective state ValidatingBuilder and sets the passed identifier to it.
newSubscriber(ChannelId) - Method in class io.spine.server.transport.memory.InMemoryTransportFactory
Creates a new instance of subscriber.
newSubscriber(ChannelId) - Method in class io.spine.server.transport.memory.SingleThreadInMemTransportFactory
 
next() - Method in interface io.spine.server.delivery.Page
Obtains the next page.
nodeId() - Method in class io.spine.server.ServerEnvironment
Obtains the identifier of the server node, on which this code is running at the moment.
noTargets() - Static method in interface io.spine.server.route.EventRoute
Returns the empty immutable set.
nothing() - Method in interface io.spine.server.EventProducer
Obtains the Nothing event message.

O

observer() - Method in class io.spine.server.event.EventBus.Builder
Obtains StreamObserver assigned to the bus.
observers() - Method in class io.spine.server.transport.Subscriber
Obtains current observers registered in this instance of Subscriber which receive the subscription updates.
of(Class<E>) - Static method in interface io.spine.server.DefaultRepository
Creates default repository for the passed entity class.
of(Class<T>) - Method in class io.spine.server.entity.storage.AbstractColumnMapping
 
of(Class<T>) - Method in interface io.spine.server.entity.storage.ColumnMapping
Obtains the mapping rules for the given type.
of(String) - Static method in class io.spine.server.entity.storage.ColumnName
 
of(StorageField) - Static method in class io.spine.server.entity.storage.ColumnName
 
of(FieldDeclaration) - Static method in class io.spine.server.entity.storage.ColumnName
 
of(EntityRecord) - Static method in class io.spine.server.entity.storage.EntityRecordWithColumns
Wraps a passed entity record.
of(EntityRecord, Map<ColumnName, Object>) - Static method in class io.spine.server.entity.storage.EntityRecordWithColumns
Creates a new instance from the passed record and storage fields.
of(ExternalMessage, Message) - Static method in class io.spine.server.integration.ExternalMessageEnvelope
Creates a new instance of ExternalMessageEnvelope from the ExternalMessage instance and the message transferred inside the ExternalMessage such as a io.spine.sample.TaskCreated event message.
of(BoundedContextName, TypeUrl, Class<I>) - Static method in class io.spine.server.storage.memory.StorageSpec
 
of(A, B) - Static method in class io.spine.server.tuple.Pair
Creates a new pair of values.
of(A, B, C, D) - Static method in class io.spine.server.tuple.Quartet
Creates a quartet with all values present.
of(A, B, C, D, E) - Static method in class io.spine.server.tuple.Quintet
Creates a quintet with all values present.
of(A, B, C) - Static method in class io.spine.server.tuple.Triplet
Creates new triplet with the passed values.
of(Message) - Static method in class io.spine.server.type.CommandClass
Creates a new instance for the class of the passed command.
of(Command) - Static method in class io.spine.server.type.CommandEnvelope
Creates an instance with the passed command.
of(Message) - Static method in class io.spine.server.type.EventClass
Creates a new instance of the event class by passed event instance.
of(Event) - Static method in class io.spine.server.type.EventEnvelope
Creates instance for the passed event.
ofBoolean() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of Boolean columns.
ofBoolean() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofByteString() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of ByteString columns.
ofByteString() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofDouble() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of Double columns.
ofDouble() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofEnum() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of Enum columns.
ofEnum() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofFloat() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of Float columns.
ofFloat() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofInteger() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of Integer columns.
ofInteger() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofLong() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of Long columns.
ofLong() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofMessage() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of Message columns.
ofMessage() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofNull() - Method in interface io.spine.server.entity.storage.ColumnMapping
Obtains the mapping rules of null.
ofNull() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
ofString() - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Returns the mapping rules of String columns.
ofString() - Method in class io.spine.server.entity.storage.DefaultColumnMapping
 
on(MessageEnvelope, Any) - Static method in class io.spine.server.event.EventFactory
Creates a new event factory for producing events in response to the passed message.
onCompleted() - Method in class io.spine.server.integration.AbstractChannelObserver
 
onConstraintViolations(Command, Iterable<ConstraintViolation>) - Static method in exception io.spine.server.commandbus.InvalidCommandException
Creates an exception instance for a command message, which has fields that violate validation constraint(s).
onConstraintViolations(EntityState, Iterable<ConstraintViolation>) - Static method in exception io.spine.server.entity.InvalidEntityStateException
Creates an exception instance for an entity state, which has fields that violate validation constraint(s).
onConstraintViolations(EventMessage, Iterable<ConstraintViolation>) - Static method in exception io.spine.server.event.InvalidEventException
Creates an exception instance for a event message which has fields that violate validation constraint(s).
onDeliveryCompleted(DeliveryStats) - Method in class io.spine.server.delivery.DeliveryMonitor
Called once some delivery process has completed and the corresponding shard has been released.
onDeliveryStarted(ShardIndex) - Method in class io.spine.server.delivery.DeliveryMonitor
 
onDispatched(SignalId) - Method in class io.spine.server.bus.MulticastBus
 
onDispatchingStarted(SignalId) - Method in class io.spine.server.bus.MulticastBus
 
onDuplicate(I, CommandEnvelope) - Method in interface io.spine.server.delivery.CommandEndpoint
 
onDuplicate(I, EventEnvelope) - Method in interface io.spine.server.delivery.EventEndpoint
 
onEnd(I) - Method in interface io.spine.server.delivery.BatchDeliveryListener
Invoked after the batch delivery to the target with the given ID is ended.
onError(SignalEnvelope<?, ?, ?>, Error) - Method in class io.spine.server.command.AbstractCommandDispatcher
 
onError(Throwable) - Method in class io.spine.server.integration.AbstractChannelObserver
 
onMessage(InboxMessage) - Method in class io.spine.server.delivery.LocalDispatchingObserver
 
onMessage(InboxMessage) - Method in interface io.spine.server.delivery.ShardObserver
A callback executed once the message was written into the shard.
onMessage(ExternalMessage) - Method in class io.spine.server.transport.Subscriber
Passes the given message to observers.
onNext(ExternalMessage) - Method in class io.spine.server.integration.AbstractChannelObserver
 
onRegistered() - Method in class io.spine.server.entity.Repository
The callback is invoked by a BoundedContext when adding the repository.
onRejection(SignalEnvelope<?, ?, ?>, Event) - Method in class io.spine.server.command.AbstractCommandDispatcher
 
onStart(I) - Method in interface io.spine.server.delivery.BatchDeliveryListener
Invoked before the batch delivery to the target with the given ID is started.
open() - Method in class io.spine.server.entity.Repository
Initializes the storage of the repository.
operator() - Method in class io.spine.server.entity.storage.CompositeQueryParameter
Obtains the composite operator.
originClass() - Method in class io.spine.server.type.EventEnvelope
Obtains the class of the origin message if available.
outerObject() - Method in class io.spine.server.type.AbstractMessageEnvelope
 
outerObject() - Method in interface io.spine.server.type.MessageEnvelope
Obtains the object which contains the message of interest.
outgoingEvents() - Method in class io.spine.server.aggregate.AggregateRepository
 
outgoingEvents() - Method in interface io.spine.server.entity.EventProducingRepository
Obtains classes of the events produced by entities of this repository.
outgoingEvents() - Method in class io.spine.server.procman.ProcessManagerRepository
 

P

Page<M> - Interface in io.spine.server.delivery
A page of messages obtained from a sharded storage in a read operation.
pageSize() - Method in class io.spine.server.delivery.DeliveryBuilder
Returns the value of the configured page size or Optional.empty() if no such value was configured.
Pair<A extends com.google.protobuf.Message,B> - Class in io.spine.server.tuple
A tuple with two elements.
partState(Class<P>) - Method in class io.spine.server.aggregate.AggregatePart
Obtains a state of another AggregatePart by its class.
partState(Class<S>) - Method in class io.spine.server.aggregate.AggregateRoot
Obtains a part state by its class.
perform(ProjectionRepository<I, ?, ?>, Event, Set<I>) - Method in interface io.spine.server.delivery.CatchUpProcess.DispatchCatchingUp
Dispatches the given event and optionally narrowing down the entities by the set of entity identifiers to dispatch the event to.
pickUp(ShardIndex, NodeId) - Method in class io.spine.server.delivery.AbstractWorkRegistry
 
pickUp(ShardIndex, NodeId) - Method in interface io.spine.server.delivery.ShardedWorkRegistry
Picks up the shard at a given index to process.
play(Iterable<Event>) - Method in class io.spine.server.aggregate.Aggregate
 
play(I, AggregateHistory) - Method in class io.spine.server.aggregate.AggregateRepository
Plays the given Aggregate history for an instance of Aggregate with the given ID.
play(Iterable<Event>) - Method in class io.spine.server.projection.Projection
 
port() - Method in class io.spine.server.ConnectionBuilder
Obtains the port of the connection, or empty Optional for in-process connection.
port() - Method in class io.spine.server.GrpcContainer
Obtains the port at which the container is exposed, or empty Optional if this is an in-process container.
port() - Method in class io.spine.server.Server
Deprecated.
please do not use
post(Command) - Method in class io.spine.server.commandbus.CommandScheduler
Delivers a scheduled command to a target.
post(Command, StreamObserver<Ack>) - Method in class io.spine.server.CommandService
 
postEvents(Iterable<Event>) - Method in class io.spine.server.command.AbstractCommandDispatcher
Posts passed events to EventBus.
postEvents(Collection<Event>) - Method in interface io.spine.server.entity.EventProducingRepository
Filters the passed events and posts the result to the EventBus.
postIfCommandRejected(SignalEnvelope<?, ?, ?>, Throwable) - Method in interface io.spine.server.entity.EventProducingRepository
If the passed signal is a command and the thrown cause is a rejection, posts the rejection to the associated EventBus.
processedBy(MessageId, EntityTypeName) - Method in interface io.spine.server.trace.Tracer
Marks the message to be processed by an entity with the given MessageId.
ProcessManager<I,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.procman
A central processing unit used to maintain the state of the business process and determine the next processing step based on intermediate results.
ProcessManager() - Constructor for class io.spine.server.procman.ProcessManager
Creates a new instance.
ProcessManager(I) - Constructor for class io.spine.server.procman.ProcessManager
Creates a new instance.
ProcessManagerMigration<I,P extends ProcessManager<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.procman
A Migration applied to a ProcessManager instance.
ProcessManagerMigration() - Constructor for class io.spine.server.procman.ProcessManagerMigration
 
ProcessManagerRepository<I,P extends ProcessManager<I,S,?>,S extends io.spine.base.EntityState> - Class in io.spine.server.procman
The abstract base for Process Managers repositories.
ProcessManagerRepository() - Constructor for class io.spine.server.procman.ProcessManagerRepository
 
producedEvents() - Method in class io.spine.server.command.AbstractCommander
Obtains classes of the events produced by this object.
producedEvents() - Method in class io.spine.server.command.AbstractCommandHandler
 
producedEvents() - Method in class io.spine.server.event.AbstractEventReactor
 
producedEvents() - Method in interface io.spine.server.EventProducer
Obtains classes of the events produced by this object.
producedEvents() - Method in class io.spine.server.procman.ProcessManager
 
producerId() - Method in class io.spine.server.command.AbstractCommandDispatcher
Obtains ID packed into Any for being used in generated events.
producerId() - Method in class io.spine.server.command.CommandHandlingEntity
 
producerId() - Method in class io.spine.server.event.AbstractEventReactor
Obtains the name of this reactor, packed to Any.
producerId() - Method in interface io.spine.server.EventProducer
The object identity packed into Any.
Projection<I,M extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<M>> - Class in io.spine.server.projection
Projection holds a structural representation of data extracted from a stream of events.
Projection() - Constructor for class io.spine.server.projection.Projection
Creates a new instance.
Projection(I) - Constructor for class io.spine.server.projection.Projection
Creates a new instance.
ProjectionMigration<I,P extends Projection<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.projection
A Migration applied to a ProcessManager instance.
ProjectionMigration() - Constructor for class io.spine.server.projection.ProjectionMigration
 
ProjectionRepository<I,P extends Projection<I,S,?>,S extends io.spine.base.EntityState> - Class in io.spine.server.projection
Abstract base for repositories managing Projections.
ProjectionRepository() - Constructor for class io.spine.server.projection.ProjectionRepository
 
projectionStateType() - Method in exception io.spine.server.delivery.CatchUpAlreadyStartedException
Returns the type URL of the projection for which the catch-up was requested.
ProjectionStorage<I> - Class in io.spine.server.projection
The storage used by projection repositories for keeping Projections and the timestamp of the last event processed by the projection repository.
ProjectionStorage(Class<? extends Projection<?, ?, ?>>, boolean) - Constructor for class io.spine.server.projection.ProjectionStorage
 
publish(Any, ExternalMessage) - Method in class io.spine.server.transport.memory.InMemoryPublisher
 
publish(Any, ExternalMessage) - Method in interface io.spine.server.transport.Publisher
Publishes a given ExternalMessage to the channel under a given ID.
Publisher - Interface in io.spine.server.transport
Publisher of messages of a specific type.
PublisherHub - Class in io.spine.server.transport
The hub of Publishers.
PublisherHub(TransportFactory) - Constructor for class io.spine.server.transport.PublisherHub
 
putMask(Class<? extends EventMessage>, FieldMask) - Method in class io.spine.server.entity.EventFieldFilter.Builder
Specifies the FieldMask for the given event type.

Q

Quartet<A extends com.google.protobuf.Message,B,C,D> - Class in io.spine.server.tuple
A tuple with four elements.
QueryParameters - Class in io.spine.server.entity.storage
The parameters of an EntityQuery.
QueryParameters.Builder - Class in io.spine.server.entity.storage
The builder for the QueryParameters.
QueryService - Class in io.spine.server
The QueryService provides a synchronous way to fetch read-side state from the server.
queryService() - Method in class io.spine.server.Server
Obtains the QueryService exposed by this server.
QueryService.Builder - Class in io.spine.server
The builder for a QueryService.
Quintet<A extends com.google.protobuf.Message,B,C,D,E> - Class in io.spine.server.tuple
A tuple of five elements.

R

React - Annotation Type in io.spine.server.event
Marks a method of an entity as one that may modify the state of the entity in response to some domain event.
read(AggregateReadRequest<I>) - Method in class io.spine.server.aggregate.AggregateStorage
Forms and returns an AggregateHistory based on the aggregate history.
read(EventStreamQuery, StreamObserver<Event>) - Method in interface io.spine.server.event.EventStore
Creates the stream with events matching the passed query.
read(EventStreamQuery, StreamObserver<Event>) - Method in class io.spine.server.event.store.DefaultEventStore
 
read(Query, StreamObserver<QueryResponse>) - Method in class io.spine.server.QueryService
Executes the passed query returning results to the passed observer.
read(CatchUpReadRequest) - Method in class io.spine.server.storage.memory.InMemoryCatchUpStorage
 
read(InboxReadRequest) - Method in class io.spine.server.storage.memory.InMemoryInboxStorage
 
read(RecordReadRequest<I>) - Method in class io.spine.server.storage.RecordStorage
Reads a record which matches the specified request.
read(RecordReadRequest<I>, FieldMask) - Method in class io.spine.server.storage.RecordStorage
Reads a record which matches the specified request and applies a FieldMask to it.
read(R) - Method in interface io.spine.server.storage.Storage
Reads a record from the storage by the specified request.
readAll() - Method in interface io.spine.server.delivery.CatchUpStorage
Returns an Iterable over all the stored catch-up processes.
readAll(ShardIndex, int) - Method in interface io.spine.server.delivery.InboxStorage
Reads the contents of the storage by the given shard index and returns the first page of the results.
readAll() - Method in class io.spine.server.storage.memory.InMemoryCatchUpStorage
 
readAll(ShardIndex, int) - Method in class io.spine.server.storage.memory.InMemoryInboxStorage
 
readAll(ResponseFormat) - Method in class io.spine.server.storage.RecordStorage
Reads all active items from the storage and apply FieldMask to each of the results.
readAll(EntityQuery<I>, ResponseFormat) - Method in class io.spine.server.storage.RecordStorage
Reads all the records matching the given EntityQuery and applies the given FieldMask to the resulting record states.
readAll(EntityQuery<I>) - Method in class io.spine.server.storage.RecordStorage
Reads all the records matching the given EntityQuery and applies the given FieldMask to the resulting record states.
readAllRecords(EntityQuery<I>, ResponseFormat) - Method in class io.spine.server.projection.ProjectionStorage
 
readAllRecords(ResponseFormat) - Method in class io.spine.server.storage.memory.InMemoryProjectionStorage
 
readAllRecords(ResponseFormat) - Method in class io.spine.server.storage.memory.InMemoryRecordStorage
 
readAllRecords(EntityQuery<I>, ResponseFormat) - Method in class io.spine.server.storage.memory.InMemoryRecordStorage
 
readAllRecords(ResponseFormat) - Method in class io.spine.server.storage.RecordStorage
Obtains an iterator for reading all records.
readAllRecords(EntityQuery<I>, ResponseFormat) - Method in class io.spine.server.storage.RecordStorage
Obtains an iterator for reading records matching the query, and applying the passed field mask to the results.
readByType(TypeUrl) - Method in interface io.spine.server.delivery.CatchUpStorage
Reads all the catch-up processes which update the projection of the specified type.
readByType(TypeUrl) - Method in class io.spine.server.storage.memory.InMemoryCatchUpStorage
 
readLifecycleFlags(I) - Method in class io.spine.server.storage.RecordStorage
 
readLifecycleFlags(I) - Method in interface io.spine.server.storage.StorageWithLifecycleFlags
Reads the lifecycle status for the entity with the passed ID.
readMultiple(Iterable<I>, FieldMask) - Method in class io.spine.server.storage.RecordStorage
Reads multiple active items from the storage and applies FieldMask to the results.
readMultipleRecords(Iterable<I>, FieldMask) - Method in class io.spine.server.storage.memory.InMemoryProjectionStorage
 
readMultipleRecords(Iterable<I>, FieldMask) - Method in class io.spine.server.storage.memory.InMemoryRecordStorage
 
readMultipleRecords(Iterable<I>, FieldMask) - Method in class io.spine.server.storage.RecordStorage
Obtains an iterator for reading multiple records by IDs, and applying the passed field mask to the results.
readRecord(I) - Method in class io.spine.server.projection.ProjectionStorage
 
readRecord(I) - Method in class io.spine.server.storage.memory.InMemoryRecordStorage
 
readRecord(I) - Method in class io.spine.server.storage.RecordStorage
Reads a record from the storage by the passed ID.
recentHistory() - Method in class io.spine.server.aggregate.Aggregate
Obtains recent history of events of this entity.
RecentHistory - Class in io.spine.server.entity
A copy of recent history of an event-sourced entity.
recentHistory() - Method in class io.spine.server.entity.TransactionalEntity
Obtains recent history of events of this entity.
record() - Method in class io.spine.server.entity.storage.EntityRecordWithColumns
Returns the enclosed entity record.
RecordBasedRepository<I,E extends Entity<I,S>,S extends io.spine.base.EntityState> - Class in io.spine.server.entity
The base class for repositories that store entities as records.
RecordBasedRepository() - Constructor for class io.spine.server.entity.RecordBasedRepository
Creates a new instance.
recordId() - Method in class io.spine.server.delivery.CatchUpReadRequest
 
recordId() - Method in class io.spine.server.delivery.InboxReadRequest
 
recordStorage() - Method in class io.spine.server.entity.RecordBasedRepository
Ensures that the repository has the storage.
recordStorage() - Method in class io.spine.server.projection.ProjectionRepository
Ensures that the repository has the storage.
recordStorage() - Method in class io.spine.server.projection.ProjectionStorage
Returns an entity storage implementation.
recordStorage() - Method in class io.spine.server.storage.memory.InMemoryProjectionStorage
 
RecordStorage<I> - Class in io.spine.server.storage
A storage keeping messages with identity.
RecordStorage(Class<? extends Entity<?, ?>>, boolean) - Constructor for class io.spine.server.storage.RecordStorage
Creates an instance of RecordStorage.
register(AggregatePartRepository<?, ?, ?>) - Method in interface io.spine.server.aggregate.AggregateRootDirectory
Associates the given aggregate part repository and the respective root type.
register(Repository<?, ?>) - Method in class io.spine.server.BoundedContext
Adds the passed repository to the context.
register(D) - Method in class io.spine.server.bus.DispatcherRegistry
 
registerCommandDispatcher(CommandDispatcher) - Method in class io.spine.server.BoundedContext
Registers the passed command dispatcher with the CommandBus.
registeredMessageClasses() - Method in class io.spine.server.bus.DispatcherRegistry
Obtains message classes from all registered dispatchers.
registerEventDispatcher(EventDispatcher) - Method in class io.spine.server.BoundedContext
Registering the passed event dispatcher with the buses of this context.
registerTypeSupplier(Repository<?, ?>) - Method in class io.spine.server.stand.Stand
Registers the passed Repository as an entity/event type supplier.
registerTypeSupplier(EventProducer) - Method in class io.spine.server.stand.Stand
Registers the passed EventProducer as the event type supplier.
registerWith(BoundedContext) - Method in class io.spine.server.aggregate.AggregatePartRepository
Initializes the repository during its registration with its context.
registerWith(BoundedContext) - Method in class io.spine.server.aggregate.AggregateRepository
Initializes the repository during its registration with its context.
registerWith(BoundedContext) - Method in class io.spine.server.command.AbstractCommandDispatcher
 
registerWith(BoundedContext) - Method in class io.spine.server.command.AbstractCommander
 
registerWith(BoundedContext) - Method in class io.spine.server.command.AbstractCommandHandler
 
registerWith(BoundedContext) - Method in class io.spine.server.entity.DefaultRecordBasedRepository
Initializes the repository by performing the validation of the entity class and creating the storage converter.
registerWith(BoundedContext) - Method in class io.spine.server.entity.EventDispatchingRepository
Registers itself as an event dispatcher with the parent BoundedContext.
registerWith(BoundedContext) - Method in class io.spine.server.event.AbstractEventReactor
 
registerWith(BoundedContext) - Method in class io.spine.server.event.AbstractEventSubscriber
 
registerWith(BoundedContext) - Method in class io.spine.server.event.store.DefaultEventStore
Initializes the instance by registering itself with the passed BoundedContext.
registerWith(BoundedContext) - Method in class io.spine.server.procman.ProcessManagerRepository
Registers itself as an event dispatcher with the parent BoundedContext.
registerWith(BoundedContext) - Method in class io.spine.server.projection.ProjectionRepository
Initializes the repository.
registerWith(BoundedContext) - Method in class io.spine.server.tenant.TenantRepository
 
registry() - Method in class io.spine.server.aggregate.ImportBus
 
reject(E) - Method in interface io.spine.server.bus.BusFilter
Rejects the message with the OK status.
reject(E, Error) - Method in interface io.spine.server.bus.BusFilter
Rejects the message with an Error status.
reject(E, ThrowableMessage) - Method in interface io.spine.server.bus.BusFilter
Rejects the message with a rejection status.
RejectionEnvelope - Class in io.spine.server.event
The holder of a rejection Event which provides convenient access to its properties.
Rejections - Class in io.spine.server.command
A set of utilities for working with rejections and ThrowableMessages.
releaseExpiredSessions(Duration) - Method in class io.spine.server.delivery.AbstractWorkRegistry
 
releaseExpiredSessions(Duration) - Method in interface io.spine.server.delivery.ShardedWorkRegistry
Clears up the recorded NodeIds from the session records if there was no activity for longer than passed inactivityPeriod.
remember(Iterable<Event>) - Method in class io.spine.server.entity.TransactionalEntity
Adds events to the recent history.
remove(Class<E>) - Method in class io.spine.server.BoundedContextBuilder
Removes the repository from the registration list by the passed entity class.
remove(Repository<?, ?>) - Method in class io.spine.server.BoundedContextBuilder
Removes the passed repository from the registration list.
remove(BoundedContext) - Method in class io.spine.server.CommandService.Builder
Removes the BoundedContext from the builder.
remove(Class<M>, Class<T>) - Method in class io.spine.server.enrich.EnricherBuilder
Removes the enrichment function for the passed event class.
remove(BoundedContext) - Method in class io.spine.server.QueryService.Builder
Excludes the passed bounded context from being served by the query service.
remove(BoundedContext) - Method in class io.spine.server.SubscriptionService.Builder
Removes the context from being handled by the subscription service.
removeAll(Iterable<InboxMessage>) - Method in interface io.spine.server.delivery.InboxStorage
Removes the passed messages from the storage.
removeAll(Iterable<InboxMessage>) - Method in class io.spine.server.storage.memory.InMemoryInboxStorage
 
removeCommandDispatcher(CommandDispatcher) - Method in class io.spine.server.BoundedContextBuilder
Removes the passed command dispatcher from the corresponding registration list.
removeEventDispatcher(EventDispatcher) - Method in class io.spine.server.BoundedContextBuilder
Removes the passed event dispatcher from the corresponding registration list.
removeFromStorage() - Method in class io.spine.server.entity.Migration
Configures the migration operation to delete the entity record from the storage.
removeObserver(StreamObserver<ExternalMessage>) - Method in class io.spine.server.transport.Subscriber
Removes an existing observer and disconnects it from this subscription channel.
RemovePmFromStorage<I,P extends ProcessManager<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.procman.migration
A migration operation that physically deletes the entity record from the storage.
RemovePmFromStorage() - Constructor for class io.spine.server.procman.migration.RemovePmFromStorage
 
RemoveProjectionFromStorage<I,P extends Projection<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.projection.migration
A migration operation that physically deletes the entity record from the storage.
RemoveProjectionFromStorage() - Constructor for class io.spine.server.projection.migration.RemoveProjectionFromStorage
 
removeService(ServerServiceDefinition) - Method in class io.spine.server.GrpcContainer.Builder
Removes the previously added gRPC service.
replaceDefault(CommandRoute<I, CommandMessage>) - Method in class io.spine.server.route.CommandRouting
Sets new default route in the schema.
replaceDefault(EventRoute<I, EventMessage>) - Method in class io.spine.server.route.EventRouting
Sets new default route in the schema.
repositories() - Method in class io.spine.server.BoundedContextBuilder
Obtains the list of repositories added to the builder by the time of the call.
Repository<I,E extends Entity<I,?>> - Class in io.spine.server.entity
Abstract base class for repositories.
Repository() - Constructor for class io.spine.server.entity.Repository
Creates the repository.
RepositoryCache.Load<I,E extends Entity<I,?>> - Interface in io.spine.server.entity
A function which loads an Entity by ID from its real repository.
RepositoryCache.Store<E extends Entity> - Interface in io.spine.server.entity
A function which stores the Entity to its real repository.
RepositoryLookup<I> - Interface in io.spine.server.delivery
A function that searches for the ProjectionRepository instance by the type URL of the state of the managed projection.
requestedIds() - Method in exception io.spine.server.delivery.CatchUpAlreadyStartedException
Returns the IDs of the targets which were asked to catch up.
reset() - Method in class io.spine.server.ServerEnvironment
This is test-only method required for cleaning of the server environment instance in tests.
route(EventEnvelope) - Method in class io.spine.server.delivery.CatchUpProcess
 
route(EventEnvelope) - Method in class io.spine.server.entity.EventDispatchingRepository
Determines the targets of the given event.
route(EventEnvelope) - Method in class io.spine.server.event.AbstractStatefulReactor
Selects the target to which the event should be dispatched.
route(Class<M>, CommandRoute<I, M>) - Method in class io.spine.server.route.CommandRouting
Sets a custom route for the passed command type.
route(Class<E>, EventRoute<I, ? super E>) - Method in class io.spine.server.route.EventRouting
Sets a custom route for the passed event type.
Route<M extends com.google.protobuf.Message,C extends com.google.protobuf.Message,R> - Interface in io.spine.server.route
Obtains one or more entity identifiers based on a message and its context.
route(Class<S>, StateUpdateRoute<I, S>) - Method in class io.spine.server.route.StateUpdateRouting
Sets a custom route for the passed entity state class.
routeStateUpdates(StateUpdateRouting<I>) - Method in class io.spine.server.route.EventRouting
Sets a custom routing schema for entity state updates.

S

schedule(Command) - Method in class io.spine.server.commandbus.CommandScheduler
Schedules a command and delivers it to the target according to the scheduling options.
scheduleCommandsUsing(Supplier<CommandScheduler>) - Method in class io.spine.server.ServerEnvironment
Assigns command scheduling mechanism used at this environment by all CommandBus instances.
self() - Method in class io.spine.server.aggregate.ImportBus.Builder
 
self() - Method in class io.spine.server.commandbus.CommandBus.Builder
 
self() - Method in class io.spine.server.event.EventBus.Builder
 
Server - Class in io.spine.server
Exposes one or more Bounded Contexts using CommandService, QueryService and SubscriptionService.
Server.Builder - Class in io.spine.server
The builder for the server.
ServerEnvironment - Class in io.spine.server
The server conditions and configuration under which the application operates.
ServerEnvironment.Fn<R> - Interface in io.spine.server
A function which accepts a class of EnvironmentType and returns a value configured in a ServerEnvironment.
ServerEnvironment.TypeConfigurator - Class in io.spine.server
Allows to configure values used by the ServerEnvironment for the given type.
serverName() - Method in class io.spine.server.ConnectionBuilder
Obtains the name of the in-process connection, or empty Optional if the connection is made via a port.
serverName() - Method in class io.spine.server.GrpcContainer
Obtains the name of the in-process server, or empty Optinal if the container is exposed at a port.
services() - Method in class io.spine.server.GrpcContainer.Builder
Obtains the services already added to the builder.
setAggregateRootDirectory(Supplier<AggregateRootDirectory>) - Method in class io.spine.server.BoundedContextBuilder
Sets the supplier of AggregateRootDirectory-s to use in the built context.
setArchived(boolean) - Method in class io.spine.server.entity.AbstractEntity
Sets archived status flag to the passed value.
setArchived(boolean) - Method in class io.spine.server.entity.TransactionalEntity
Sets archived status flag to the passed value.
setCatchUpPageSize(int) - Method in class io.spine.server.delivery.DeliveryBuilder
Sets the maximum number of events to read from an event store per single read operation during the catch-up.
setCatchUpStorage(CatchUpStorage) - Method in class io.spine.server.delivery.DeliveryBuilder
Sets the custom CatchUpStorage.
setDeduplicationWindow(Duration) - Method in class io.spine.server.delivery.DeliveryBuilder
Sets for how long the previously delivered messages should be kept in the Inbox to ensure the incoming messages aren't duplicates.
setDeleted(boolean) - Method in class io.spine.server.entity.AbstractEntity
Sets deleted status flag to the passed value.
setDeleted(boolean) - Method in class io.spine.server.entity.TransactionalEntity
Sets deleted status flag to the passed value.
setDispatchOp(CatchUpProcess.DispatchCatchingUp<I>) - Method in class io.spine.server.delivery.CatchUpProcessBuilder
Sets the way to dispatch the events during the catch-up.
setInboxStorage(InboxStorage) - Method in class io.spine.server.delivery.DeliveryBuilder
Sets the custom InboxStorage.
setInitialState(S, Version) - Method in class io.spine.server.entity.TransactionalEntity
Sets an initial state for the entity.
setMonitor(DeliveryMonitor) - Method in class io.spine.server.delivery.DeliveryBuilder
Sets the custom DeliveryMonitor.
setObserver(StreamObserver<Ack>) - Method in class io.spine.server.event.EventBus.Builder
Assigns the observer for the Bus.post(Signal, StreamObserver) operations.
setOf(Iterable<Class<? extends CommandMessage>>) - Static method in class io.spine.server.type.CommandClass
Creates a set of CommandClass from the passed set.
setOf(Class<? extends CommandMessage>...) - Static method in class io.spine.server.type.CommandClass
Creates a set of CommandClass from the passed classes.
setOf(Iterable<Class<? extends EventMessage>>) - Static method in class io.spine.server.type.EventClass
Creates a set of EventClass from the passed set.
setOf(Class<? extends EventMessage>...) - Static method in class io.spine.server.type.EventClass
Creates a set of EventClass from the passed classes.
setOf(Class<? extends EventMessage>) - Static method in class io.spine.server.type.EventClass
Creates a set with only one passed EventClass.
setPageSize(int) - Method in class io.spine.server.delivery.DeliveryBuilder
Sets the maximum amount of messages to deliver within a DeliveryStage.
setPort(int) - Method in class io.spine.server.GrpcContainer.Builder
Deprecated.
setPort(int) - Method in class io.spine.server.Server.Builder
Deprecated.
please use Server.atPort(int).
setSnapshotTrigger(int) - Method in class io.spine.server.aggregate.AggregateRepository
Changes the number of events between making aggregate snapshots to the passed value.
setStrategy(DeliveryStrategy) - Method in class io.spine.server.delivery.DeliveryBuilder
Sets strategy of assigning a shard index for a message that is delivered to a particular target.
setTenantIndex(TenantIndex) - Method in class io.spine.server.BoundedContextBuilder
 
setupCommandRouting(CommandRouting<I>) - Method in class io.spine.server.aggregate.AggregateRepository
A callback for derived classes to customize routing schema for commands.
setupCommandRouting(CommandRouting<I>) - Method in class io.spine.server.procman.ProcessManagerRepository
A callback for derived classes to customize routing schema for commands.
setupCustomMapping(ImmutableMap.Builder<Class<?>, ColumnTypeMapping<?, ? extends R>>) - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Allows to specify custom mapping rules.
setupEventRouting(EventRouting<I>) - Method in class io.spine.server.aggregate.AggregateRepository
A callback for derived classes to customize routing schema for events.
setupEventRouting(EventRouting<I>) - Method in class io.spine.server.entity.EventDispatchingRepository
A callback for derived repository classes to customize routing schema for events.
setupEventRouting(EventRouting<I>) - Method in class io.spine.server.procman.ProcessManagerRepository
Replaces default routing with the one which takes the target ID from the first field of an event message.
setupEventRouting(EventRouting<I>) - Method in class io.spine.server.projection.ProjectionRepository
 
setupImportRouting(EventRouting<I>) - Method in class io.spine.server.aggregate.AggregateRepository
A callback for derived classes to customize routing schema for importable events.
setupStateRouting(StateUpdateRouting<I>) - Method in class io.spine.server.projection.ProjectionRepository
A callback for derived repository classes to customize routing schema for delivering updated state to subscribed entities, if the default schema does not satisfy the routing needs.
setWorkRegistry(ShardedWorkRegistry) - Method in class io.spine.server.delivery.DeliveryBuilder
 
shardCount() - Method in class io.spine.server.delivery.DeliveryStrategy
Tells how many shards there are according to this strategy.
shardCount() - Method in class io.spine.server.delivery.UniformAcrossAllShards
 
ShardedWorkRegistry - Interface in io.spine.server.delivery
The registry of the shard indexes along with the identifiers of the nodes, which process the messages corresponding to each index.
shardIndex() - Method in class io.spine.server.delivery.DeliveryStats
Returns the index of the shard for which this statistics is calculated.
shardIndex() - Method in class io.spine.server.delivery.ShardProcessingSession
Returns the index of the shard, to which this session relates to.
ShardObserver - Interface in io.spine.server.delivery
An abstract base for observers of the updates made to the contents of shards.
ShardProcessingSession - Class in io.spine.server.delivery
The session of processing the messages, which reside in a shard.
ShardProcessingSession(ShardSessionRecord) - Constructor for class io.spine.server.delivery.ShardProcessingSession
 
shouldContinueAfter(DeliveryStage) - Method in class io.spine.server.delivery.DeliveryMonitor
Determines if the delivery execution should be continued after the given stage is completed.
shutdown() - Method in class io.spine.server.commandbus.CommandScheduler
Initiates an orderly shutdown in which previously scheduled commands will be delivered later, but no new commands will be accepted.
shutdown() - Method in class io.spine.server.commandbus.ExecutorCommandScheduler
 
shutdown() - Method in class io.spine.server.GrpcContainer
Initiates an orderly shutdown in which existing calls continue but new calls are rejected.
shutdown() - Method in class io.spine.server.Server
Initiates an orderly shutdown in which existing calls continue but new calls are rejected.
shutdownAndWait() - Method in class io.spine.server.Server
Initiates a forceful shutdown in which preexisting and new calls are rejected.
shutdownNowAndWait() - Method in class io.spine.server.GrpcContainer
Initiates a forceful shutdown in which preexisting and new calls are rejected.
signal() - Method in class io.spine.server.trace.AbstractTracer
 
signal() - Method in interface io.spine.server.trace.Tracer
Obtains the traced signal message.
SignalEnvelope<I extends io.spine.core.SignalId,T extends io.spine.core.Signal<I,?,C>,C extends io.spine.base.MessageContext> - Interface in io.spine.server.type
A common interface for envelopes of signal messages.
singleShard() - Static method in class io.spine.server.delivery.UniformAcrossAllShards
Returns a pre-defined strategy instance, which defines a single shard and puts all the targets into it.
singleTenant(String) - Static method in class io.spine.server.BoundedContext
Creates a new builder for a single tenant BoundedContext.
singleTenant(String) - Static method in class io.spine.server.ContextSpec
Creates a spec of a single tenant context with the given name.
singleTenant(String) - Static method in class io.spine.server.integration.ThirdPartyContext
Creates a new single-tenant instance of ThirdPartyContext with the given name.
singleTenant() - Static method in interface io.spine.server.tenant.TenantIndex
Obtains a TenantIndex to be used in single-tenant context.
SingleThreadInMemTransportFactory - Class in io.spine.server.transport.memory
The implementation of TransportFactory which uses single-thread subscribers.
SingleThreadInMemTransportFactory() - Constructor for class io.spine.server.transport.memory.SingleThreadInMemTransportFactory
 
size() - Method in interface io.spine.server.delivery.Page
Obtains the size of this page.
snapshotTrigger() - Method in class io.spine.server.aggregate.AggregateRepository
Returns the number of events until a next Snapshot is made.
spec() - Method in class io.spine.server.BoundedContext
Obtains specification of this context.
spec() - Method in class io.spine.server.BoundedContextBuilder
Obtains the context spec.
stand() - Method in class io.spine.server.BoundedContext
Obtains instance of Stand of this BoundedContext.
stand() - Method in class io.spine.server.projection.ProjectionRepository
Obtains the Stand from the BoundedContext of this repository.
Stand - Class in io.spine.server.stand
A bridge which connects QueryService and SubscriptionService with a Read-side of a Bounded Context.
Stand.Builder - Class in io.spine.server.stand
 
StandardRejection - Interface in io.spine.server.entity.rejection
Interface common for standard rejections which is used during routing.
start() - Method in class io.spine.server.GrpcContainer
Starts the service.
start(Executor) - Method in class io.spine.server.GrpcContainer
Starts the service on top of the given Executor.
start() - Method in class io.spine.server.Server
Starts the server.
startTransaction(P) - Method in class io.spine.server.procman.ProcessManagerMigration
 
startTransaction(P) - Method in class io.spine.server.projection.ProjectionMigration
 
state() - Method in class io.spine.server.entity.AbstractEntity
Obtains the state of the entity.
state() - Method in interface io.spine.server.entity.Entity
Obtains the state of the entity.
StateField - Enum in io.spine.server.storage
Storage fields for persisting entity state.
stateTypes(EntityOption.Visibility) - Method in class io.spine.server.BoundedContext
Obtains a set of entity type names by their visibility.
stateTypes() - Method in class io.spine.server.BoundedContext
Obtains the set of all entity type names.
StateUpdateRoute<I,M extends io.spine.base.EntityState> - Interface in io.spine.server.route
Obtains a set of entity IDs for which to deliver an entity state update.
StateUpdateRouting<I> - Class in io.spine.server.route
A routing schema used to deliver entity state updates.
storage() - Method in class io.spine.server.entity.Repository
Returns the storage assigned to this repository.
Storage<I,M extends com.google.protobuf.Message,R extends ReadRequest<I>> - Interface in io.spine.server.storage
The base interface for storages.
storageAssigned() - Method in class io.spine.server.entity.Repository
Returns true if the storage is assigned, false otherwise.
storageConverter() - Method in class io.spine.server.entity.DefaultRecordBasedRepository
 
storageConverter() - Method in class io.spine.server.entity.RecordBasedRepository
Obtains StorageConverter associated with this repository.
StorageConverter<I,E extends Entity<I,S>,S extends io.spine.base.EntityState> - Class in io.spine.server.entity
An abstract base for converters of entities into EntityRecord.
StorageConverter(TypeUrl, EntityFactory<E>, FieldMask) - Constructor for class io.spine.server.entity.StorageConverter
 
storageFactory() - Method in class io.spine.server.ServerEnvironment
Obtains the storage factory for the current environment.
StorageFactory - Interface in io.spine.server.storage
A factory for creating storages used by repositories EventStore and Stand.
StorageField - Interface in io.spine.server.storage
A marker interface for the enums representing the names of the fields used by the framework to store its data.
StorageSpec<I> - Class in io.spine.server.storage.memory
Attributes for accessing in-memory storage over in-process gRPC.
StorageWithLifecycleFlags<I,M extends com.google.protobuf.Message,R extends ReadRequest<I>> - Interface in io.spine.server.storage
A storage that allows to update lifecycle flags of entities.
store(A) - Method in class io.spine.server.aggregate.AggregateRepository
Stores the passed aggregate and commits its uncommitted events.
store(Iterable<Event>) - Method in class io.spine.server.aggregate.ImportBus
Updates the TenantIndex with the ID obtained from the passed events.
store(CatchUp) - Method in class io.spine.server.delivery.CatchUpProcess
 
store(E) - Method in class io.spine.server.entity.RecordBasedRepository
 
store(Collection<E>) - Method in class io.spine.server.entity.RecordBasedRepository
Stores Entities in bulk.
store(E) - Method in class io.spine.server.entity.Repository
Stores the passed object.
store(S) - Method in class io.spine.server.event.AbstractStatefulReactor
Stores the passed state in the storage.
store(P) - Method in class io.spine.server.procman.ProcessManagerRepository
 
store(P) - Method in class io.spine.server.projection.ProjectionRepository
 
strategy() - Method in class io.spine.server.delivery.DeliveryBuilder
Returns the value of the configured DeliveryStrategy or Optional.empty() if no such value was configured.
stream() - Method in class io.spine.server.entity.RecentHistory
Creates a new Stream of the recent history items.
subscribe(ShardObserver) - Method in class io.spine.server.delivery.Delivery
Subscribes to the updates of shard contents.
subscribe(Topic, StreamObserver<Subscription>) - Method in class io.spine.server.stand.Stand
Creates a subscription for the passed topic.
subscribe(Subscription) - Method in class io.spine.server.stand.Stand
Registers this inactive subscription is this Stand.
subscribe(Topic, StreamObserver<Subscription>) - Method in class io.spine.server.SubscriptionService
 
Subscriber - Class in io.spine.server.transport
Subscriber for messages of a specific type.
Subscriber(ChannelId) - Constructor for class io.spine.server.transport.Subscriber
 
SubscriberHub - Class in io.spine.server.transport
The hub of Subscribers.
SubscriberHub(TransportFactory) - Constructor for class io.spine.server.transport.SubscriberHub
 
SubscriptionCallback - Interface in io.spine.server.stand
Delivers the given subscription update to the read-side.
subscriptionService() - Method in class io.spine.server.Server
Obtains the SubscriptionService exposed by this server.
SubscriptionService - Class in io.spine.server
The SubscriptionService provides an asynchronous way to fetch read-side state from the server.
SubscriptionService.Builder - Class in io.spine.server
The builder for the SubscriptionService.
supports(Class<? extends EntityState>) - Method in class io.spine.server.route.StateUpdateRouting
Verifies if the passed state type can be routed by a custom route, or the message has a field matching the type of identifiers served by this routing.
systemNotSet() - Static method in class io.spine.server.bus.BusBuilder.FieldCheck
 
systemSettings() - Method in class io.spine.server.BoundedContextBuilder
Obtains the configuration of the System context.

T

targetType() - Method in interface io.spine.server.transport.MessageChannel
Obtains the type of the messages transferred through this channel.
TenantAwareFunction<F,T> - Class in io.spine.server.tenant
A function which is calculated in a tenant context.
TenantAwareFunction() - Constructor for class io.spine.server.tenant.TenantAwareFunction
 
TenantAwareFunction(TenantId) - Constructor for class io.spine.server.tenant.TenantAwareFunction
 
TenantAwareFunction0<T> - Class in io.spine.server.tenant
A tenant-aware function that takes no parameters.
TenantAwareFunction0() - Constructor for class io.spine.server.tenant.TenantAwareFunction0
 
TenantAwareFunction0(TenantId) - Constructor for class io.spine.server.tenant.TenantAwareFunction0
 
TenantAwareOperation - Class in io.spine.server.tenant
An abstract base for operations on a tenant data.
TenantAwareOperation() - Constructor for class io.spine.server.tenant.TenantAwareOperation
Creates an instance of an operation which uses the TenantId set in the execution context.
TenantAwareOperation(TenantId) - Constructor for class io.spine.server.tenant.TenantAwareOperation
Creates an instance of an operation for the tenant specified by the passed ID.
tenantId() - Method in class io.spine.server.event.RejectionEnvelope
 
tenantId() - Method in class io.spine.server.type.CommandEnvelope
Obtains the tenant ID of the command.
tenantId() - Method in class io.spine.server.type.EventEnvelope
Obtains tenant ID of the event.
tenantId() - Method in interface io.spine.server.type.SignalEnvelope
Obtains ID of the tenant in which context the actor works.
tenantIndex() - Method in class io.spine.server.BoundedContextBuilder
Obtains TenantIndex implementation associated with the Bounded Context.
TenantIndex - Interface in io.spine.server.tenant
The index of tenant IDs in a multi-tenant application.
tenantIndexNotSet() - Static method in class io.spine.server.bus.BusBuilder.FieldCheck
 
TenantRepository<T extends io.spine.base.EntityState,E extends TenantRepository.Entity<T>> - Class in io.spine.server.tenant
Abstract base for repositories storing information about tenants.
TenantRepository() - Constructor for class io.spine.server.tenant.TenantRepository
 
TenantRepository.Entity<T extends io.spine.base.EntityState> - Class in io.spine.server.tenant
Stores data associated with a tenant ID.
ThirdPartyContext - Class in io.spine.server.integration
An external non-Spine based upstream system.
thisClass() - Method in class io.spine.server.aggregate.Aggregate
Obtains model class for this aggregate.
thisClass() - Method in class io.spine.server.aggregate.AggregatePart
Obtains model class for this aggregate part.
thisClass() - Method in class io.spine.server.procman.ProcessManager
 
thisClass() - Method in class io.spine.server.projection.Projection
 
toCatchUp(I) - Method in class io.spine.server.delivery.Inbox.EventDestinations
Sends to the catch-up handler of the entity with the specified ID.
toEnriched(EnrichmentService<M, C>) - Method in interface io.spine.server.type.EnrichableMessageEnvelope
Creates a copy with the envelope adding enrichments to the context of the message.
toEnriched(EnrichmentService<EventMessage, EventContext>) - Method in class io.spine.server.type.EventEnvelope
 
toEntity(EntityRecord) - Method in class io.spine.server.entity.RecordBasedRepository
Converts the passed record into an entity.
toEntity(EntityRecord) - Method in class io.spine.server.procman.ProcessManagerRepository
Creates and configures an instance of the process manager by the passed record.
toEnvelope(Event) - Method in class io.spine.server.aggregate.ImportBus
 
toEventEnvelope() - Method in class io.spine.server.integration.ExternalMessageEnvelope
Converts this instance to an envelope of the external event.
toHandler(I) - Method in class io.spine.server.delivery.Inbox.CommandDestinations
Sends to the command handling method of the entity with the specified ID.
toImporter(I) - Method in class io.spine.server.delivery.Inbox.EventDestinations
Sends to the event-importing handler of the entity with the specified ID.
toModelClass(Class<A>) - Method in class io.spine.server.aggregate.AggregateRepository
 
toReactor(I) - Method in class io.spine.server.delivery.Inbox.EventDestinations
Sends to the reacting handler of the entity with the specified ID.
toSingleTenant() - Method in class io.spine.server.ContextSpec
Returns a single-tenant version of this instance, if it is multitenant, or this instance if it is single-tenant.
toString() - Method in class io.spine.server.BoundedContext
Returns the name of this Bounded Context.
toString() - Method in class io.spine.server.ContextSpec
 
toString() - Method in class io.spine.server.entity.AbstractEntity
 
toString() - Method in class io.spine.server.entity.RecentHistory
 
toString() - Method in class io.spine.server.entity.storage.CompositeQueryParameter
 
toString() - Method in class io.spine.server.entity.storage.EntityQuery
 
toString() - Method in class io.spine.server.entity.storage.QueryParameters
 
toString() - Method in class io.spine.server.storage.memory.StorageSpec
 
toString() - Method in class io.spine.server.type.AbstractMessageEnvelope
 
toString() - Method in class io.spine.server.type.EmptyClass
 
toSubscriber(I) - Method in class io.spine.server.delivery.Inbox.EventDestinations
Sends to the event-subscribing handler of the entity with the specified ID.
trace(ContextSpec, Signal<?, ?, ?>) - Method in interface io.spine.server.trace.TracerFactory
Creates a new instance of Tracer for the given signal.
Tracer - Interface in io.spine.server.trace
A tracer of a single signal.
TracerFactory - Interface in io.spine.server.trace
A factory of Tracers of signal messages.
tracing() - Method in class io.spine.server.ServerEnvironment
Obtains the TracerFactory associated with the current environment, if it was set.
TransactionalEntity<I,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.entity
A base for entities, perform transactions events.
TransactionalEntity() - Constructor for class io.spine.server.entity.TransactionalEntity
Creates a new instance.
TransactionalEntity(I) - Constructor for class io.spine.server.entity.TransactionalEntity
Creates a new instance.
transportFactory() - Method in class io.spine.server.ServerEnvironment
Obtains the transport factory for the current environment.
TransportFactory - Interface in io.spine.server.transport
A factory for creating channel-based transport for Message inter-exchange between the current deployment component and other application parts.
Triplet<A extends com.google.protobuf.Message,B,C> - Class in io.spine.server.tuple
A tuple with three elements.
truncate(int) - Method in class io.spine.server.aggregate.AggregateStorage
Drops all records which occur before the Nth snapshot for each entity.
truncate(int, Timestamp) - Method in class io.spine.server.aggregate.AggregateStorage
Drops all records older than date but not newer than the Nth snapshot for each entity.
Tuple - Class in io.spine.server.tuple
Abstract base for tuple classes.
Tuple(Object...) - Constructor for class io.spine.server.tuple.Tuple
Creates a new instance with the passed values.
tx() - Method in class io.spine.server.entity.TransactionalEntity
Obtains the transaction used for modifying the entity.
tx() - Method in class io.spine.server.procman.ProcessManager
Obtains the transaction used for modifying the entity.
type() - Method in interface io.spine.server.entity.storage.Column
The type of the column.
type() - Method in class io.spine.server.ServerEnvironment
Obtains the type of the current server environment.
typeUrl() - Method in class io.spine.server.type.EventEnvelope
Obtains the type URL of the event message.

U

unCache(TenantId) - Method in class io.spine.server.tenant.TenantRepository
Removes the passed value from the in-memory cache of known tenant IDs.
unexpectedValue(Message, Message, Message) - Method in class io.spine.server.command.CommandHandlingEntity
Creates ValueMismatch for the case of discovering a value different than by a command.
unexpectedValue(String, String, String) - Method in class io.spine.server.command.CommandHandlingEntity
Creates ValueMismatch for the case of discovering a value different than expected by a command.
unicast(Class<E>, Function<E, I>) - Method in class io.spine.server.route.EventRouting
Sets a custom route for the passed event type by obtaining the target entity ID from the passed function.
unicast(Class<E>, BiFunction<E, EventContext, I>) - Method in class io.spine.server.route.EventRouting
Sets a custom route for the passed event type by obtaining the target entity ID from the passed function over event message and its context.
Unicast<I,M extends com.google.protobuf.Message,C extends com.google.protobuf.Message> - Interface in io.spine.server.route
A route for a message to be delivered to one entity.
UnicastDispatcher<C extends io.spine.type.MessageClass,E extends MessageEnvelope> - Interface in io.spine.server.bus
Dispatches a message to one entity.
UniformAcrossAllShards - Class in io.spine.server.delivery
The strategy of splitting the entities into a number of shards uniformly.
unknownTenantError(Message, String) - Static method in exception io.spine.server.commandbus.InvalidCommandException
Creates an error for a command with missing tenant_id attribute in the CommandContext which is required in a multitenant application.
unregister(D) - Method in class io.spine.server.bus.DispatcherRegistry
 
unregisterAll() - Method in class io.spine.server.bus.DispatcherRegistry
Unregisters all dispatchers.
UnsupportedCommandException - Exception in io.spine.server.commandbus
Exception that is thrown when unsupported command is obtained or in case there is no class for given Protobuf command message.
UnsupportedCommandException(Command) - Constructor for exception io.spine.server.commandbus.UnsupportedCommandException
 
UnsupportedEventException - Exception in io.spine.server.event
Exception that is thrown when unsupported event is obtained or if there is no class for the given Protobuf event message.
UnsupportedEventException(EventMessage) - Constructor for exception io.spine.server.event.UnsupportedEventException
 
UnsupportedExternalMessageException - Exception in io.spine.server.integration
Exception that is thrown when unsupported external message is obtained or in case there is no class for the given Protobuf event message.
UnsupportedExternalMessageException(Message) - Constructor for exception io.spine.server.integration.UnsupportedExternalMessageException
 
UnsupportedImportEventException - Exception in io.spine.server.aggregate
Thrown when there are no aggregates that accept an event message for import.
unsupportedType(Class<?>) - Method in class io.spine.server.entity.storage.AbstractColumnMapping
Throws an exception about an unsupported column type.
updateBuilder(EntityRecord.Builder, E) - Method in class io.spine.server.entity.StorageConverter
Derived classes may override to additionally tune the passed entity builder.
UpdatePmColumns<I,P extends ProcessManager<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.procman.migration
A migration operation that does the update of interface-based columns of a ProcessManager.
UpdatePmColumns() - Constructor for class io.spine.server.procman.migration.UpdatePmColumns
 
UpdateProjectionColumns<I,P extends Projection<I,S,B>,S extends io.spine.base.EntityState,B extends io.spine.protobuf.ValidatingBuilder<S>> - Class in io.spine.server.projection.migration
A migration operation that does the update of interface-based columns of a Projection.
UpdateProjectionColumns() - Constructor for class io.spine.server.projection.migration.UpdateProjectionColumns
 
use(Delivery) - Method in class io.spine.server.ServerEnvironment.TypeConfigurator
Assigns the specified Delivery for the selected environment.
use(TracerFactory) - Method in class io.spine.server.ServerEnvironment.TypeConfigurator
Assigns TracerFactory for the selected environment.
use(TransportFactory) - Method in class io.spine.server.ServerEnvironment.TypeConfigurator
Assigns the specified transport factory for the selected environment.
use(StorageFactory) - Method in class io.spine.server.ServerEnvironment.TypeConfigurator
Assigns the specified StorageFactory for the selected environment.
useDelivery(ServerEnvironment.Fn<Delivery>) - Method in class io.spine.server.ServerEnvironment.TypeConfigurator
Assigns a Delivery obtained from the passed function.
useStorageFactory(ServerEnvironment.Fn<StorageFactory>) - Method in class io.spine.server.ServerEnvironment.TypeConfigurator
Assigns a StorageFactory obtained from the passed function.
useTracerFactory(ServerEnvironment.Fn<TracerFactory>) - Method in class io.spine.server.ServerEnvironment.TypeConfigurator
Lazily uses the TracerFactory obtained from the passed function.
useTransportFactory(ServerEnvironment.Fn<TransportFactory>) - Method in class io.spine.server.ServerEnvironment.TypeConfigurator
Assigns a TransportFactory obtained from the passed function.

V

validate(E) - Method in interface io.spine.server.bus.EnvelopeValidator
Validates the given MessageEnvelope by some specific rules.
validator() - Method in class io.spine.server.aggregate.ImportBus
 
value() - Method in class io.spine.server.tuple.Either
Obtains the stored value.
valueOf(String) - Static method in enum io.spine.server.aggregate.AggregateField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.spine.server.aggregate.AggregatePart.GenericParameter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.spine.server.entity.Entity.GenericParameter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.spine.server.event.storage.EventContextField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.spine.server.event.storage.EventField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.spine.server.storage.LifecycleFlagField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.spine.server.storage.StateField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.spine.server.storage.VersionField
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.spine.server.aggregate.AggregateField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.spine.server.aggregate.AggregatePart.GenericParameter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.spine.server.entity.Entity.GenericParameter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.spine.server.event.storage.EventContextField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.spine.server.event.storage.EventField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.spine.server.storage.LifecycleFlagField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.spine.server.storage.StateField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.spine.server.storage.VersionField
Returns an array containing the constants of this enum type, in the order they are declared.
version() - Method in class io.spine.server.command.AbstractCommander
The version of the object to be put into events.
version() - Method in class io.spine.server.command.AbstractCommandHandler
Always returns empty version.
version() - Method in class io.spine.server.entity.AbstractEntity
Obtains the version of the entity.
version() - Method in interface io.spine.server.entity.Entity
Obtains the version of the entity.
version() - Method in class io.spine.server.entity.Migration
Returns the version of entity under migration.
version() - Method in class io.spine.server.event.AbstractEventReactor
Returns a zero version.
version() - Method in interface io.spine.server.EventProducer
The version of the object to be put into events.
VersionField - Enum in io.spine.server.storage
Fields used to store version information of an entity.
versionNumber() - Method in class io.spine.server.aggregate.Aggregate
Obtains the version number of the entity.
versionNumber() - Method in class io.spine.server.entity.AbstractEntity
Obtains the version number of the entity.

W

when(Class<? extends EnvironmentType>) - Static method in class io.spine.server.ServerEnvironment
Starts flowing API chain for configuring ServerEnvironment for the passed type.
whenModified() - Method in class io.spine.server.entity.AbstractEntity
Obtains timestamp of the entity version.
withA(A) - Static method in class io.spine.server.tuple.EitherOf2
Creates a new instance with <A> value.
withA(A) - Static method in class io.spine.server.tuple.EitherOf3
Creates a new instance with <A> value.
withA(A) - Static method in class io.spine.server.tuple.EitherOf4
Creates a new instance with <A> value.
withA(A) - Static method in class io.spine.server.tuple.EitherOf5
Creates a new instance with <A> value.
withB(B) - Static method in class io.spine.server.tuple.EitherOf2
Creates a new instance with <B> value.
withB(B) - Static method in class io.spine.server.tuple.EitherOf3
Creates a new instance with <B> value.
withB(B) - Static method in class io.spine.server.tuple.EitherOf4
Creates a new instance with <B> value.
withB(B) - Static method in class io.spine.server.tuple.EitherOf5
Creates a new instance with <B> value.
withBatchListener(BatchDeliveryListener<I>) - Method in class io.spine.server.delivery.Inbox.Builder
Allows to specify the listener of the starting and ending batch dispatching operations.
withC(C) - Static method in class io.spine.server.tuple.EitherOf3
Creates a new instance with <C> value.
withC(C) - Static method in class io.spine.server.tuple.EitherOf4
Creates a new instance with <C> value.
withC(C) - Static method in class io.spine.server.tuple.EitherOf5
Creates a new instance with <C> value.
withD(D) - Static method in class io.spine.server.tuple.EitherOf4
Creates a new instance with <C> value.
withD(D) - Static method in class io.spine.server.tuple.EitherOf5
Creates a new instance with <D> value.
withDefault(EventRoute<I, EventMessage>) - Static method in class io.spine.server.route.EventRouting
Creates a new event routing with the passed default route.
withDefaultByProducerId() - Static method in class io.spine.server.route.EventRouting
Creates a new event routing with the default one by event producer ID.
withE(E) - Static method in class io.spine.server.tuple.EitherOf5
Creates a new instance with <E> value.
withEither(A, B) - Static method in class io.spine.server.tuple.Pair
Creates a pair with the second element of a type descending from Either.
withFieldMask(FieldMask) - Method in class io.spine.server.entity.StorageConverter
Creates a copy of this converter modified with the passed filed mask.
withId(I) - Static method in interface io.spine.server.route.EventRoute
Creates an immutable singleton set with the passed ID.
WithLifecycle - Interface in io.spine.server.entity
Something with LifecycleFlags.
withNullable(A, B) - Static method in class io.spine.server.tuple.Pair
Creates a pair with optionally present second value.
withNullable(A, B, C, D) - Static method in class io.spine.server.tuple.Quartet
Creates a quartet with one optional value.
withNullable(A, B, C, D, E) - Static method in class io.spine.server.tuple.Quintet
Creates a quintet with one optional value.
withNullable(A, B, C) - Static method in class io.spine.server.tuple.Triplet
Creates a triplet with the last element optional.
withNullable2(A, B, C, D) - Static method in class io.spine.server.tuple.Quartet
Creates a quartet with two optional values.
withNullable2(A, B, C, D, E) - Static method in class io.spine.server.tuple.Quintet
Creates a quintet with two optional values.
withNullable2(A, B, C) - Static method in class io.spine.server.tuple.Triplet
Creates a new triplet with optional second and third elements.
withNullable3(A, B, C, D) - Static method in class io.spine.server.tuple.Quartet
Creates a quartet with three optional values.
withNullable3(A, B, C, D, E) - Static method in class io.spine.server.tuple.Quintet
Creates a quintet with three optional values.
withNullable4(A, B, C, D, E) - Static method in class io.spine.server.tuple.Quintet
Creates a quintet with four optional values.
withOptional(A, Optional<B>) - Static method in class io.spine.server.tuple.Pair
Creates a pair with optionally present second value.
withServer(GrpcContainer.ConfigureServer) - Method in class io.spine.server.GrpcContainer.Builder
Sets an additional configuration action for the gRPC Server instance, created for this GrpcContainer to run on top of.
withSingle(BoundedContext) - Static method in class io.spine.server.CommandService
Builds the service with a single Bounded Context.
withSingle(BoundedContext) - Static method in class io.spine.server.QueryService
Builds the service with a single Bounded Context.
withSingle(BoundedContext) - Static method in class io.spine.server.SubscriptionService
Builds the service with a single Bounded Context.
workRegistry() - Method in class io.spine.server.delivery.DeliveryBuilder
Returns the value of the configured ShardedWorkRegistry or Optional.empty() if no such value was configured.
write(I, AggregateHistory) - Method in class io.spine.server.aggregate.AggregateStorage
Writes events into the storage.
write(ShardSessionRecord) - Method in class io.spine.server.delivery.AbstractWorkRegistry
Stores the given session.
write(CatchUp) - Method in interface io.spine.server.delivery.CatchUpStorage
Writes a message to the storage.
write(InboxMessage) - Method in interface io.spine.server.delivery.InboxStorage
Writes a message to the storage.
write(CatchUp) - Method in class io.spine.server.storage.memory.InMemoryCatchUpStorage
 
write(CatchUpId, CatchUp) - Method in class io.spine.server.storage.memory.InMemoryCatchUpStorage
 
write(InboxMessage) - Method in class io.spine.server.storage.memory.InMemoryInboxStorage
 
write(InboxMessageId, InboxMessage) - Method in class io.spine.server.storage.memory.InMemoryInboxStorage
 
write(I, EntityRecordWithColumns) - Method in class io.spine.server.storage.RecordStorage
Writes a record and its columns into the storage.
write(I, EntityRecord) - Method in class io.spine.server.storage.RecordStorage
 
write(Map<I, EntityRecordWithColumns>) - Method in class io.spine.server.storage.RecordStorage
Writes a bulk of records into the storage.
write(I, M) - Method in interface io.spine.server.storage.Storage
Writes a record into the storage.
writeAll(Iterable<InboxMessage>) - Method in interface io.spine.server.delivery.InboxStorage
Writes several messages to the storage.
writeAll(Iterable<InboxMessage>) - Method in class io.spine.server.storage.memory.InMemoryInboxStorage
 
writeLifecycleFlags(I, LifecycleFlags) - Method in class io.spine.server.storage.RecordStorage
 
writeLifecycleFlags(I, LifecycleFlags) - Method in interface io.spine.server.storage.StorageWithLifecycleFlags
Writes the lifecycle status for the entity with the passed ID.
writeRecord(I, AggregateEventRecord) - Method in class io.spine.server.aggregate.AggregateStorage
Writes the passed record into the storage.
writeRecord(I, EntityRecordWithColumns) - Method in class io.spine.server.projection.ProjectionStorage
 
writeRecord(I, EntityRecordWithColumns) - Method in class io.spine.server.storage.memory.InMemoryRecordStorage
 
writeRecord(I, EntityRecordWithColumns) - Method in class io.spine.server.storage.RecordStorage
Writes a record and the associated column values into the storage.
writeRecords(Map<I, EntityRecordWithColumns>) - Method in class io.spine.server.projection.ProjectionStorage
 
writeRecords(Map<I, EntityRecordWithColumns>) - Method in class io.spine.server.storage.memory.InMemoryRecordStorage
 
writeRecords(Map<I, EntityRecordWithColumns>) - Method in class io.spine.server.storage.RecordStorage
Writes a bulk of records into the storage.

_

_config() - Method in interface io.spine.server.log.LoggingEntity
 
_fine() - Method in interface io.spine.server.log.LoggingEntity
 
_finer() - Method in interface io.spine.server.log.LoggingEntity
 
_finest() - Method in interface io.spine.server.log.LoggingEntity
 
_info() - Method in interface io.spine.server.log.LoggingEntity
 
_severe() - Method in interface io.spine.server.log.LoggingEntity
 
_warn() - Method in interface io.spine.server.log.LoggingEntity
 
A B C D E F G H I K L M N O P Q R S T U V W _ 
Skip navigation links