§Persistent Entity
Event Sourcing and CQRS is a recommended introduction to this section.
A PersistentEntity has a stable entity identifier, with which it can be accessed from the service implementation or other places. The state of an entity is persistent (durable) using Event Sourcing. We represent all state changes as events and those immutable facts are appended to an event log. To recreate the current state of an entity when it is started we replay these events.
A persistent entity corresponds to an Aggregate Root in Domain-Driven Design terms. Each instance has a stable identifier and for a given id there will only be one instance of the entity. Lagom takes care of distributing those instances across the cluster of the service. If you know the identifier you can send messages, so called commands, to the entity.
The persistent entity is also a transaction boundary. Invariants can be maintained within one entity but not across several entities.
If you are familiar with JPA it is worth noting that a PersistentEntity can be used for similar things as a JPA @Entity but several aspects are rather different. For example, a JPA @Entity is loaded from the database from wherever it is needed, i.e. there may be many Java object instances with the same entity identifier. In contrast, there is only one instance of PersistentEntity with a given identifier. With JPA you typically only store current state and the history of how the state was reached is not captured.
You interact with a PersistentEntity by sending command messages to it. Commands are processed sequentially, one at a time, for a specific entity instance. A command may result in state changes that are persisted as events, representing the effect of the command. The current state is not stored for every change, since it can be derived from the events. These events are only ever appended to storage, nothing is ever mutated, which allows for very high transaction rates and efficient replication.
The entities are automatically distributed across the nodes in the cluster of the service. Each entity runs only at one place, and messages can be sent to the entity without requiring the sender to know the location of the entity. If a node is stopped the entities running on that node will be started on another node when a message is sent to it next time. When new nodes are added to the cluster some existing entities are rebalanced to the new nodes to spread the load.
An entity is kept alive, holding its current state in memory, as long as it is used. When it has not been used for a while it will automatically be passivated to free up resources.
When an entity is started it replays the stored events to restore the current state. This can be either the full history of changes or starting from a snapshot which will reduce recovery times.
§Choosing a database
Lagom is compatible with the following databases:
For instructions on configuring your project to use Cassandra, see Using Cassandra for Persistent Entities. If instead you want to use one of the relational databases listed above, see Using a Relational Database for Persistent Entities on how to configure your project. If you wish to use Couchbase, proceed to the Lagom section of the Akka Persistence Couchbase site for all the details.
To see how to combine Cassandra for write-side persistence and JPA for a read-side view, see the Mixed Persistence Service sample.
Lagom provides out of the box support for running Cassandra in a development environment - developers do not need to install, configure or manage Cassandra at all themselves when using Lagom, which makes for great developer velocity, and it means gone are the days where developers spend days setting up their development environment before they can start to be productive on a project.
§PersistentEntity Stub
This is how a PersistentEntity class looks like before filling in the implementation details:
import com.lightbend.lagom.javadsl.persistence.PersistentEntity;
public class Post1 extends PersistentEntity<BlogCommand, BlogEvent, BlogState> {
  @Override
  public Behavior initialBehavior(Optional<BlogState> snapshotState) {
    BehaviorBuilder b = newBehaviorBuilder(snapshotState.orElse(BlogState.EMPTY));
    // TODO define command and event handlers
    return b.build();
  }
}The three type parameters of the extended PersistentEntity class define:
- Command- the super class/interface of the commands
- Event- the super class/interface of the events
- State- the class of the state
initialBehavior is an abstract method that your concrete subclass must implement. It returns the Behavior of the entity. Use newBehaviorBuilder to create a mutable builder for defining the behavior. The behavior consists of current state and functions to process incoming commands and persisted events as described in the following sections.
§Command Handlers
The functions that process incoming commands are registered in the Behavior using setCommandHandler of the BehaviorBuilder.
// Command handlers are invoked for incoming messages (commands).
// A command handler must "return" the events to be persisted (if any).
b.setCommandHandler(
    AddPost.class,
    (AddPost cmd, CommandContext<AddPostDone> ctx) -> {
      final PostAdded postAdded = new PostAdded(entityId(), cmd.getContent());
      return ctx.thenPersist(
          postAdded,
          (PostAdded evt) ->
              // After persist is done additional side effects can be performed
              ctx.reply(new AddPostDone(entityId())));
    });You should define one command handler for each command class that the entity can receive.
A command handler returns a Persist directive that defines what event or events, if any, to persist. Use the thenPersist, thenPersistAll or done methods of the context that is passed to the command handler function to create the Persist directive.
- thenPersistwill persist one single event
- thenPersistAllwill persist several events atomically, i.e. all events
 are stored or none of them are stored if there is an error
- doneno events are to be persisted
External side effects can be performed after successful persist in the afterPersist function. In the above example a reply is sent with the ctx.reply method.
The command can be validated before persisting state changes. Use ctx.invalidCommand or ctx.commandFailed to reject an invalid command.
b.setCommandHandler(
    AddPost.class,
    (AddPost cmd, CommandContext<AddPostDone> ctx) -> {
      if (cmd.getContent().getTitle() == null || cmd.getContent().getTitle().equals("")) {
        ctx.invalidCommand("Title must be defined");
        return ctx.done();
      }A PersistentEntity may also process commands that do not change application state, such as query commands or commands that are not valid in the entity’s current state (such as a bid placed after the auction closed). Such command handlers are registered using setReadOnlyCommandHandler of the BehaviorBuilder. Replies are sent with the reply method of the context that is passed to the command handler function.
The setReadOnlyCommandHandler is simply a convenience function that avoids you having to return no events followed by a side effect.
b.setReadOnlyCommandHandler(GetPost.class, (cmd, ctx) -> ctx.reply(state().getContent().get()));The commands must be immutable to avoid concurrency issues that may occur from changing a command instance that has been sent.
The section Immutable Objects describes how to define immutable command classes.
§Event Handlers
When an event has been persisted successfully the current state is updated by applying the event to the current state. The functions for updating the state are registered with the setEventHandler method of the BehaviorBuilder.
// Event handlers are used both when persisting new events
// and when replaying events.
b.setEventHandler(PostAdded.class, evt -> new BlogState(Optional.of(evt.getContent()), false));You should define one event handler for each event class that the entity can persist.
The event handler returns the new state. The state must be immutable, so you return a new instance of the state. Current state can be accessed from the event handler with the state method of the PersistentEntity. The same event handlers are also used when the entity is started up to recover its state from the stored events.
The events must be immutable to avoid concurrency issues that may occur from changing an event instance that is about to be persisted.
The section Immutable Objects describes how to define immutable event classes.
§Replies
Each command must define what type of message to use as reply to the command by implementing the PersistentEntity.ReplyType interface.
final class AddPost implements BlogCommand, PersistentEntity.ReplyType<AddPostDone> {
  private final PostContent content;
  @JsonCreator
  public AddPost(PostContent content) {
    this.content = content;
  }
  public PostContent getContent() {
    return content;
  }
  @Override
  public boolean equals(Object o) {
    if (this == o) return true;
    if (o == null || getClass() != o.getClass()) return false;
    AddPost addPost = (AddPost) o;
    return content.equals(addPost.content);
  }
  @Override
  public int hashCode() {
    return content.hashCode();
  }
}You send the reply message using the reply method of the context that is passed to the command handler function.
Typically the reply will be an acknowledgment that the entity processed the command successfully, i.e. you send it after persist.
b.setCommandHandler(
    ChangeBody.class,
    (cmd, ctx) ->
        ctx.thenPersist(
            new BodyChanged(entityId(), cmd.getBody()), evt -> ctx.reply(Done.getInstance())));For convenience you may use the akka.Done as acknowledgment message.
It can also be a reply to a read-only query command.
b.setReadOnlyCommandHandler(GetPost.class, (cmd, ctx) -> ctx.reply(state().getContent().get()));You can use ctx.invalidCommand to reject an invalid command, which will fail the CompletionStage with PersistentEntity.InvalidCommandException on the sender side.
You can send a negative acknowledgment with ctx.commandFailed, which will fail the CompletionStage on the sender side with the given exception.
If persisting the events fails a negative acknowledgment is automatically sent, which will fail the CompletionStage on the sender side with PersistentEntity.PersistException.
If the PersistentEntity receives a command for which there is no registered command handler a negative acknowledgment is automatically sent, which will fail the CompletionStage on the sender side with PersistentEntity.UnhandledCommandException.
If you don’t reply to a command the CompletionStage on the sender side will be completed with a akka.pattern.AskTimeoutException after a timeout.
§Changing Behavior
The event handlers are typically only updating the state, but they may also change the behavior of the entity in the sense that new functions for processing commands and events may be defined. This is useful when implementing finite state machine (FSM) like entities. Event handlers that change the behavior are registered with the setEventHandlerChangingBehavior of the BehaviorBuilder. Such an event handler returns the new Behavior instead of just returning the new state.
b.setEventHandlerChangingBehavior(
    PostAdded.class,
    evt -> becomePostAdded(new BlogState(Optional.of(evt.getContent()), false)));private Behavior becomePostAdded(BlogState newState) {
  BehaviorBuilder b = newBehaviorBuilder(newState);
  b.setReadOnlyCommandHandler(GetPost.class, (cmd, ctx) -> ctx.reply(state().getContent().get()));
  b.setCommandHandler(
      ChangeBody.class,
      (cmd, ctx) ->
          ctx.thenPersist(
              new BodyChanged(entityId(), cmd.getBody()), evt -> ctx.reply(Done.getInstance())));
  b.setEventHandler(BodyChanged.class, evt -> state().withBody(evt.getBody()));
  return b.build();
}In the above example we are creating a completely new Behavior with newBehaviorBuilder. It is also possible to start with current Behavior and modify it. You can access current behavior with the behavior method of the PersistentEntity and then use the builder method of the Behavior.
§Snapshots
When the entity is started the state is recovered by replaying stored events. To reduce this recovery time the entity may start the recovery from a snapshot of the state and then only replaying the events that were stored after the snapshot.
Such snapshots are automatically saved after a configured number of persisted events. The snapshot if any is passed as a parameter to the initialBehavior method and you should use that state as the state of the returned Behavior.
One thing to keep in mind is that if you are using event handlers that change the behavior (setEventHandlerChangingBehavior) you must also restore corresponding Behavior from the snapshot state that is passed as a parameter to the initialBehavior method.
@Override
public Behavior initialBehavior(Optional<BlogState> snapshotState) {
  if (snapshotState.isPresent() && !snapshotState.get().isEmpty()) {
    // behavior after snapshot must be restored by initialBehavior
    // if we have a non-empty BlogState we know that the initial
    // AddPost has been performed
    return becomePostAdded(snapshotState.get());
  } else {
    // behavior when no snapshot is used
    BehaviorBuilder b = newBehaviorBuilder(BlogState.EMPTY);
    // TODO define command and event handlers
    return b.build();
  }
}The state must be immutable to avoid concurrency issues that may occur from changing a state instance that is about to be saved as snapshot.
The section Immutable Objects describes how to define immutable state classes.
§Usage from Service Implementation
To access an entity from a service implementation you first need to inject the PersistentEntityRegistry and at startup (in the constructor) register the class that implements the PersistentEntity.
In the service method you retrieve a PersistentEntityRef for a given entity identifier from the registry. Then you can send the command to the entity using the ask method of the PersistentEntityRef. ask returns a CompletionStage with the reply message.
import com.lightbend.lagom.javadsl.persistence.PersistentEntityRef;
import javax.inject.Inject;
import com.lightbend.lagom.javadsl.persistence.PersistentEntityRegistry;
import com.lightbend.lagom.javadsl.api.*;
public class BlogServiceImpl implements BlogService {
  private final PersistentEntityRegistry persistentEntities;
  @Inject
  public BlogServiceImpl(PersistentEntityRegistry persistentEntities) {
    this.persistentEntities = persistentEntities;
    persistentEntities.register(Post.class);
  }
  @Override
  public ServiceCall<BlogCommand.AddPost, String> addPost(String id) {
    return request -> {
      PersistentEntityRef<BlogCommand> ref = persistentEntities.refFor(Post.class, id);
      return ref.ask(request).thenApply(ack -> "OK");
    };
  }
}In this example we are using the command AddPost also as the request parameter of the service method, but you can of course use another type for the external API of the service.
The commands are sent as messages to the entity that may be running on a different node. If that node is not available due to network issues, JVM crash or similar the messages may be lost until the problem has been detected and the entities have been migrated to another node. In such situations the ask will time out and the CompletionStage will be completed with akka.pattern.AskTimeoutException.
Note that the AskTimeoutException is not a guarantee that the command was not processed. For example, the command might have been processed but the reply message was lost.
§Serialization
JSON is the recommended format the persisted events and state. The Serialization section describes how to add Jackson serialization support to such classes and also how to evolve the classes, which is especially important for the persistent state and events, since you must be able to deserialize old objects that were stored.
§Unit Testing
For unit testing of the entity you can use the PersistentEntityTestDriver, which will run the PersistentEntity without using a database. You can verify that it emits expected events and side-effects in response to incoming commands.
import static org.junit.Assert.assertEquals;
import java.util.Collections;
import java.util.Optional;
import com.lightbend.lagom.javadsl.persistence.PersistentEntity.InvalidCommandException;
import com.lightbend.lagom.javadsl.testkit.PersistentEntityTestDriver;
import com.lightbend.lagom.javadsl.testkit.PersistentEntityTestDriver.Outcome;
import org.junit.AfterClass;
import org.junit.BeforeClass;
import org.junit.Test;
import akka.Done;
import akka.actor.ActorSystem;
import akka.testkit.javadsl.TestKit;
public class PostTest {
  static ActorSystem system;
  @BeforeClass
  public static void setup() {
    system = ActorSystem.create();
  }
  @AfterClass
  public static void teardown() {
    TestKit.shutdownActorSystem(system);
    system = null;
  }
  @Test
  public void testAddPost() {
    PersistentEntityTestDriver<BlogCommand, BlogEvent, BlogState> driver =
        new PersistentEntityTestDriver<>(system, new Post(), "post-1");
    PostContent content = new PostContent("Title", "Body");
    Outcome<BlogEvent, BlogState> outcome = driver.run(new AddPost(content));
    assertEquals(new PostAdded("post-1", content), outcome.events().get(0));
    assertEquals(1, outcome.events().size());
    assertEquals(false, outcome.state().isPublished());
    assertEquals(Optional.of(content), outcome.state().getContent());
    assertEquals(new AddPostDone("post-1"), outcome.getReplies().get(0));
    assertEquals(Collections.emptyList(), outcome.issues());
  }
  @Test
  public void testInvalidTitle() {
    PersistentEntityTestDriver<BlogCommand, BlogEvent, BlogState> driver =
        new PersistentEntityTestDriver<>(system, new Post(), "post-1");
    Outcome<BlogEvent, BlogState> outcome = driver.run(new AddPost(new PostContent("", "Body")));
    assertEquals(InvalidCommandException.class, outcome.getReplies().get(0).getClass());
    assertEquals(0, outcome.events().size());
    assertEquals(Collections.emptyList(), outcome.issues());
  }
  @Test
  public void testChangeBody() {
    PersistentEntityTestDriver<BlogCommand, BlogEvent, BlogState> driver =
        new PersistentEntityTestDriver<>(system, new Post(), "post-1");
    driver.run(new AddPost(new PostContent("Title", "Body")));
    Outcome<BlogEvent, BlogState> outcome =
        driver.run(new ChangeBody("New body 1"), new ChangeBody("New body 2"));
    assertEquals(new BodyChanged("post-1", "New body 1"), outcome.events().get(0));
    assertEquals(new BodyChanged("post-1", "New body 2"), outcome.events().get(1));
    assertEquals(2, outcome.events().size());
    assertEquals(false, outcome.state().isPublished());
    assertEquals("New body 2", outcome.state().getContent().get().getBody());
    assertEquals(Done.getInstance(), outcome.getReplies().get(0));
    assertEquals(Done.getInstance(), outcome.getReplies().get(1));
    assertEquals(2, outcome.getReplies().size());
    assertEquals(Collections.emptyList(), outcome.issues());
  }
}run may be invoked multiple times to divide the sequence of commands into manageable steps. The Outcome contains the events and side-effects of the last run, but the state is not reset between different runs.
Note that it also verifies that all commands, events, replies and state are serializable, and reports any such problems in the issues of the Outcome.
To use this feature add the following in your project’s build.
In Maven:
<dependency>
    <groupId>com.lightbend.lagom</groupId>
    <artifactId>lagom-javadsl-testkit_${scala.binary.version}</artifactId>
    <version>${lagom.version}</version>
    <scope>test</scope>
</dependency>
In sbt:
libraryDependencies += lagomJavadslTestKit§Full Example
import com.lightbend.lagom.javadsl.persistence.PersistentEntity;
import java.util.Optional;
import akka.Done;
public class Post extends PersistentEntity<BlogCommand, BlogEvent, BlogState> {
  @Override
  public Behavior initialBehavior(Optional<BlogState> snapshotState) {
    if (snapshotState.isPresent() && !snapshotState.get().isEmpty()) {
      // behavior after snapshot must be restored by initialBehavior
      return becomePostAdded(snapshotState.get());
    } else {
      // Behavior consist of a State and defined event handlers and command handlers.
      BehaviorBuilder b = newBehaviorBuilder(BlogState.EMPTY);
      // Command handlers are invoked for incoming messages (commands).
      // A command handler must "return" the events to be persisted (if any).
      b.setCommandHandler(
          AddPost.class,
          (AddPost cmd, CommandContext<AddPostDone> ctx) -> {
            if (cmd.getContent().getTitle() == null || cmd.getContent().getTitle().equals("")) {
              ctx.invalidCommand("Title must be defined");
              return ctx.done();
            }
            final PostAdded postAdded = new PostAdded(entityId(), cmd.getContent());
            return ctx.thenPersist(
                postAdded,
                (PostAdded evt) ->
                    // After persist is done additional side effects can be performed
                    ctx.reply(new AddPostDone(entityId())));
          });
      // Event handlers are used both when persisting new events and when replaying
      // events.
      b.setEventHandlerChangingBehavior(
          PostAdded.class,
          evt -> becomePostAdded(new BlogState(Optional.of(evt.getContent()), false)));
      return b.build();
    }
  }
  // Behavior can be changed in the event handlers.
  private Behavior becomePostAdded(BlogState newState) {
    BehaviorBuilder b = newBehaviorBuilder(newState);
    b.setCommandHandler(
        ChangeBody.class,
        (cmd, ctx) ->
            ctx.thenPersist(
                new BodyChanged(entityId(), cmd.getBody()), evt -> ctx.reply(Done.getInstance())));
    b.setEventHandler(BodyChanged.class, evt -> state().withBody(evt.getBody()));
    return b.build();
  }
}import com.fasterxml.jackson.annotation.JsonCreator;
import com.lightbend.lagom.javadsl.persistence.PersistentEntity;
import com.lightbend.lagom.serialization.Jsonable;
import akka.Done;
public interface BlogCommand extends Jsonable {
  // #AddPost
  final class AddPost implements BlogCommand, PersistentEntity.ReplyType<AddPostDone> {
    private final PostContent content;
    @JsonCreator
    public AddPost(PostContent content) {
      this.content = content;
    }
    public PostContent getContent() {
      return content;
    }
    @Override
    public boolean equals(Object o) {
      if (this == o) return true;
      if (o == null || getClass() != o.getClass()) return false;
      AddPost addPost = (AddPost) o;
      return content.equals(addPost.content);
    }
    @Override
    public int hashCode() {
      return content.hashCode();
    }
  }
  // #AddPost
  final class AddPostDone implements Jsonable {
    private final String postId;
    @JsonCreator
    public AddPostDone(String postId) {
      this.postId = postId;
    }
    public String getPostId() {
      return postId;
    }
    @Override
    public boolean equals(Object o) {
      if (this == o) return true;
      if (o == null || getClass() != o.getClass()) return false;
      AddPostDone that = (AddPostDone) o;
      return postId.equals(that.postId);
    }
    @Override
    public int hashCode() {
      return postId.hashCode();
    }
  }
  enum GetPost implements BlogCommand, PersistentEntity.ReplyType<PostContent> {
    INSTANCE
  }
  final class ChangeBody implements BlogCommand, PersistentEntity.ReplyType<Done> {
    private final String body;
    @JsonCreator
    public ChangeBody(String body) {
      this.body = body;
    }
    public String getBody() {
      return body;
    }
    @Override
    public boolean equals(Object o) {
      if (this == o) return true;
      if (o == null || getClass() != o.getClass()) return false;
      ChangeBody that = (ChangeBody) o;
      return body.equals(that.body);
    }
    @Override
    public int hashCode() {
      return body.hashCode();
    }
  }
  enum Publish implements BlogCommand, PersistentEntity.ReplyType<Done> {
    INSTANCE
  }
}import com.fasterxml.jackson.annotation.JsonCreator;
import com.lightbend.lagom.javadsl.persistence.AggregateEvent;
import com.lightbend.lagom.javadsl.persistence.AggregateEventShards;
import com.lightbend.lagom.javadsl.persistence.AggregateEventTag;
import com.lightbend.lagom.serialization.Jsonable;
import org.pcollections.PSequence;
// #sharded-tags
interface BlogEvent extends Jsonable, AggregateEvent<BlogEvent> {
  // will produce tags with shard numbers from 0 to 9
  int NUM_SHARDS = 10;
  AggregateEventShards<BlogEvent> TAG = AggregateEventTag.sharded(BlogEvent.class, NUM_SHARDS);
  @Override
  default AggregateEventShards<BlogEvent> aggregateTag() {
    return TAG;
  }
  // #sharded-tags
  final class PostAdded implements BlogEvent {
    private final String postId;
    private final PostContent content;
    @JsonCreator
    public PostAdded(String postId, PostContent content) {
      this.postId = postId;
      this.content = content;
    }
    public String getPostId() {
      return postId;
    }
    public PostContent getContent() {
      return content;
    }
    @Override
    public boolean equals(Object o) {
      if (this == o) return true;
      if (o == null || getClass() != o.getClass()) return false;
      PostAdded postAdded = (PostAdded) o;
      if (!postId.equals(postAdded.postId)) return false;
      return content.equals(postAdded.content);
    }
    @Override
    public int hashCode() {
      int result = postId.hashCode();
      result = 31 * result + content.hashCode();
      return result;
    }
  }
  final class BodyChanged implements BlogEvent {
    private final String postId;
    private final String body;
    @JsonCreator
    public BodyChanged(String postId, String body) {
      this.postId = postId;
      this.body = body;
    }
    public String getPostId() {
      return postId;
    }
    public String getBody() {
      return body;
    }
    @Override
    public boolean equals(Object o) {
      if (this == o) return true;
      if (o == null || getClass() != o.getClass()) return false;
      BodyChanged that = (BodyChanged) o;
      if (!postId.equals(that.postId)) return false;
      return body.equals(that.body);
    }
    @Override
    public int hashCode() {
      int result = postId.hashCode();
      result = 31 * result + body.hashCode();
      return result;
    }
  }
  final class PostPublished implements BlogEvent {
    private final String postId;
    @JsonCreator
    public PostPublished(String postId) {
      this.postId = postId;
    }
    public String getPostId() {
      return postId;
    }
    @Override
    public boolean equals(Object o) {
      if (this == o) return true;
      if (o == null || getClass() != o.getClass()) return false;
      PostPublished that = (PostPublished) o;
      return postId.equals(that.postId);
    }
    @Override
    public int hashCode() {
      return postId.hashCode();
    }
  }
}public final class BlogState implements Jsonable {
  public static final BlogState EMPTY = new BlogState(Optional.empty(), false);
  private final Optional<PostContent> content;
  private final boolean published;
  @JsonCreator
  public BlogState(Optional<PostContent> content, boolean published) {
    this.content = content;
    this.published = published;
  }
  public BlogState withBody(String body) {
    if (isEmpty()) throw new IllegalStateException("Can't set body without content");
    PostContent c = content.get();
    return new BlogState(Optional.of(new PostContent(c.getTitle(), body)), published);
  }
  @JsonIgnore
  public boolean isEmpty() {
    return !content.isPresent();
  }
  public Optional<PostContent> getContent() {
    return content;
  }
  public boolean isPublished() {
    return published;
  }
  @Override
  public boolean equals(Object o) {
    if (this == o) return true;
    if (o == null || getClass() != o.getClass()) return false;
    BlogState blogState = (BlogState) o;
    if (published != blogState.published) return false;
    return content.equals(blogState.content);
  }
  @Override
  public int hashCode() {
    int result = content.hashCode();
    result = 31 * result + (published ? 1 : 0);
    return result;
  }
}§Refactoring Consideration
If you change the class name of a PersistentEntity you have to override entityTypeName and retain the original name because this name is part of the key of the store data (it is part of the persistenceId of the underlying PersistentActor). By default the entityTypeName is using the short class name of the concrete PersistentEntity class.
§Configuration
The default configuration should be good starting point, and the following settings may later be amended to customize the behavior if needed. The following is a listing of the non database specific settings for Lagom persistence:
lagom.persistence {
  # As a rule of thumb, the number of shards should be a factor ten greater
  # than the planned maximum number of cluster nodes. Less shards than number
  # of nodes will result in that some nodes will not host any shards. Too many
  # shards will result in less efficient management of the shards, e.g.
  # rebalancing overhead, and increased latency because the coordinator is
  # involved in the routing of the first message for each shard. The value
  # must be the same on all nodes in a running cluster. It can be changed
  # after stopping all nodes in the cluster.
  max-number-of-shards = 100
  # Persistent entities saves snapshots after this number of persistent
  # events. Snapshots are used to reduce recovery times.
  # It may be configured to "off" to disable snapshots.
  snapshot-after = 100
  # A persistent entity is passivated automatically if it does not receive
  # any messages during this timeout. Passivation is performed to reduce
  # memory consumption. Objects referenced by the entity can be garbage
  # collected after passivation. Next message will activate the entity
  # again, which will recover its state from persistent storage. Set to 0
  # to disable passivation - this should only be done when the number of
  # entities is bounded and their state, sharded across the cluster, will
  # fit in memory.
  passivate-after-idle-timeout = 120s
  # Specifies that entities run on cluster nodes with a specific role.
  # If the role is not specified (or empty) all nodes in the cluster are used.
  # The entities can still be accessed from other nodes.
  run-entities-on-role = ""
  # Default timeout for PersistentEntityRef.ask replies.
  ask-timeout = 5s
  dispatcher {
    type = Dispatcher
    executor = "thread-pool-executor"
    thread-pool-executor {
      fixed-pool-size = 16
    }
    throughput = 1
  }
}§Underlying Implementation
Each PersistentEntity instance is executed by a PersistentActor that is managed by Akka Cluster Sharding.
§Execution details (advanced)
If you’ve read all the sections above you are familiar with all the pieces conforming a Persistent Entity but there are few details worth explaining more extensively. As stated above:
Commands are processed sequentially, one at a time, for a specific entity instance.
This needs a deeper explanation to understand the guarantees provided by Lagom. When a command is received, the following occurs:
- a command handler is selected, if none is found an UnhandledCommandExceptionis thrown
- the command handler is invoked for the command, one or more events may be emitted (to process a command that emits no events, setReadOnlyCommandHandlermust be used)
- events are applied to the appropriate event Handler (this can cause Behaviorchanges so defining the command handler on a behavior doesn’t require all event handlers to be supported on that behavior)
- if applying the events didn’t cause any exception, events are persisted atomically and in the same order they were emitted on the command handler
- if there’s an afterPersist, then it is invoked (only once)
- if the snapshotting threshold is exceeded, a snapshot is generated and stored
- finally, the command processing completes and a new command may be processed.
If you are familiar with Akka Persistence this process is slightly different in few places:
- new commands are not processed until events are stored, the Effectcompleted and the snapshot updated (if necessary). Akka provides the same behavior and alsoasyncalternatives that cause new commands to be processed even before all event handlers have completed.
- saving snapshots is an operation run under the covers at least every lagom.persistence.snapshot-afterevents (see Configuration above) but “storing events atomically” takes precedence. Imagine we want a snapshot every 100 events and we already have 99 events, if the next command emits 3 events the snapshot will only be stored after event number 102 because events[100, 101, 102]will be stored atomically and only after it’ll be possible to create a snapshot.