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

$

$minus$greater$() - Constructor for class akka.persistence.fsm.PersistentFSM.$minus$greater$
 

A

AbstractPersistentActor - Class in akka.persistence
Java API: an persistent actor - can be used to implement command or event sourcing.
AbstractPersistentActor() - Constructor for class akka.persistence.AbstractPersistentActor
 
AbstractPersistentActorWithAtLeastOnceDelivery - Class in akka.persistence
Java API compatible with lambda expressions
AbstractPersistentActorWithAtLeastOnceDelivery() - Constructor for class akka.persistence.AbstractPersistentActorWithAtLeastOnceDelivery
 
AbstractPersistentFSM<S extends PersistentFSM.FSMState,D,E> - Class in akka.persistence.fsm
Java API: compatible with lambda expressions
AbstractPersistentFSM() - Constructor for class akka.persistence.fsm.AbstractPersistentFSM
 
AbstractPersistentFSMBase<S,D,E> - Class in akka.persistence.fsm
Java API: compatible with lambda expressions
AbstractPersistentFSMBase() - Constructor for class akka.persistence.fsm.AbstractPersistentFSMBase
 
AbstractPersistentFSMBase$ - Class in akka.persistence.fsm
Java API: compatible with lambda expressions
AbstractPersistentFSMBase$() - Constructor for class akka.persistence.fsm.AbstractPersistentFSMBase$
 
AbstractPersistentLoggingFSM<S extends PersistentFSM.FSMState,D,E> - Class in akka.persistence.fsm
Java API: compatible with lambda expressions
AbstractPersistentLoggingFSM() - Constructor for class akka.persistence.fsm.AbstractPersistentLoggingFSM
 
AbstractPersistentView - Class in akka.persistence
Java API: compatible with lambda expressions (to be used with ReceiveBuilder)
AbstractPersistentView() - Constructor for class akka.persistence.AbstractPersistentView
 
actor() - Method in class akka.persistence.Persistence.PluginHolder
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.LoopMessageSuccess
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageRejected
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessages
 
actorInstanceId() - Method in class akka.persistence.JournalProtocol.WriteMessageSuccess
 
actorRef() - Method in class akka.persistence.fsm.PersistentFSM.SubscribeTransitionCallBack
 
actorRef() - Method in class akka.persistence.fsm.PersistentFSM.UnsubscribeTransitionCallBack
 
adapters() - Method in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
 
adapters() - Method in class akka.persistence.Persistence.PluginHolder
 
adaptersFor(String) - Method in class akka.persistence.Persistence
Returns an EventAdapters object which serves as a per-journal collection of bound event adapters.
adaptersFor(ActorRef) - Method in class akka.persistence.Persistence
INTERNAL API Looks up EventAdapters by journal plugin's ActorRef.
adaptFromJournal(PersistentRepr) - Method in interface akka.persistence.journal.WriteJournalBase
INTERNAL API
adaptToJournal(PersistentRepr) - Method in interface akka.persistence.journal.WriteJournalBase
INTERNAL API
add(PersistentRepr) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
addAllPayload(Iterable<? extends MessageFormats.PersistentMessage>) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
addAllPersistenceIdsSubscriber(ActorRef) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
addAllUnconfirmedDeliveries(Iterable<? extends MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery>) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addPayload(MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
addPayload(int, MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
addPayload(MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
addPayload(int, MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
addPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
addPayloadBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
addPersistenceIdSubscriber(ActorRef, String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
addTagSubscriber(ActorRef, String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
addToMessageBatch(PersistentRepr, Set<String>, org.iq80.leveldb.WriteBatch) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
addUnconfirmedDeliveries(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveries(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveriesBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
addUnconfirmedDeliveriesBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
advance() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
 
afterTransitionDo() - Method in class akka.persistence.fsm.PersistentFSM.State
 
akka.persistence - package akka.persistence
 
akka.persistence.fsm - package akka.persistence.fsm
 
akka.persistence.fsm.japi.pf - package akka.persistence.fsm.japi.pf
 
akka.persistence.journal - package akka.persistence.journal
 
akka.persistence.journal.inmem - package akka.persistence.journal.inmem
 
akka.persistence.journal.japi - package akka.persistence.journal.japi
 
akka.persistence.journal.leveldb - package akka.persistence.journal.leveldb
 
akka.persistence.serialization - package akka.persistence.serialization
 
akka.persistence.snapshot - package akka.persistence.snapshot
 
akka.persistence.snapshot.japi - package akka.persistence.snapshot.japi
 
akka.persistence.snapshot.local - package akka.persistence.snapshot.local
 
allPersistenceIds() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
allPersistenceIds() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.CurrentPersistenceIds
 
allPersistenceIdsSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
andThen(Function1<D, BoxedUnit>) - Method in class akka.persistence.fsm.PersistentFSM.State
Register a handler to be triggered after the state has been persisted successfully
anyEvent(FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on any type of event.
apply(PersistentRepr) - Method in class akka.persistence.AtomicWrite$
 
apply(PersistentRepr) - Static method in class akka.persistence.AtomicWrite
 
apply(Object) - Method in class akka.persistence.fsm.PersistentFSM.NullFunction$
 
apply(ExtendedActorSystem, Config) - Method in class akka.persistence.journal.EventAdapters$
 
apply(ExtendedActorSystem, Config) - Static method in class akka.persistence.journal.EventAdapters
 
apply(Seq<Object>) - Method in class akka.persistence.journal.EventSeq$
 
apply(Seq<Object>) - Static method in class akka.persistence.journal.EventSeq
 
apply(Object, long, String, String, boolean, ActorRef, String) - Method in class akka.persistence.PersistentRepr$
Plugin API.
applyEvent(E, D) - Method in interface akka.persistence.fsm.PersistentFSM
Override this handler to define the action on Domain Event
applying(Object...) - Method in class akka.persistence.fsm.PersistentFSM.State
Specify domain events to be applied when transitioning to the new state.
applying(Seq<E>) - Method in class akka.persistence.fsm.PersistentFSM.State
Specify domain events to be applied when transitioning to the new state.
applyState(PersistentFSM.State<S, D, E>) - Method in interface akka.persistence.fsm.PersistentFSM
Persist FSM State and FSM State Data
applyState(PersistentFSM.State<S, D, E>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
aroundPostRestart(Throwable) - Method in interface akka.persistence.Eventsourced
INTERNAL API.
aroundPostStop() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
INTERNAL API
aroundPostStop() - Method in interface akka.persistence.Eventsourced
INTERNAL API.
aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
INTERNAL API
aroundPreRestart(Throwable, Option<Object>) - Method in interface akka.persistence.Eventsourced
INTERNAL API.
aroundPreStart() - Method in interface akka.persistence.Eventsourced
INTERNAL API.
aroundPreStart() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
aroundPreStart() - Method in interface akka.persistence.PersistentView
INTERNAL API.
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
INTERNAL API
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Eventsourced
INTERNAL API.
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.PersistentView
INTERNAL API.
asyncDeleteMessagesTo(String, long) - Method in interface akka.persistence.journal.AsyncWriteJournal
Plugin API: asynchronously deletes all persistent messages up to toSequenceNr (inclusive).
asyncDeleteMessagesTo(String, long) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncDeleteMessagesTo(String, long) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
 
asyncDeleteMessagesTo(String, long) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
AsyncHandlerInvocation(Object, Function1<Object, BoxedUnit>) - Constructor for class akka.persistence.Eventsourced.AsyncHandlerInvocation
 
AsyncHandlerInvocation$() - Constructor for class akka.persistence.Eventsourced.AsyncHandlerInvocation$
 
asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.AsyncRecovery
Plugin API: asynchronously reads the highest stored sequence number for the given persistenceId.
asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncReadHighestSequenceNr(String, long) - Method in class akka.persistence.journal.japi.AsyncRecovery
 
asyncReadHighestSequenceNr(String, long) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
AsyncRecovery - Interface in akka.persistence.journal
Asynchronous message replay and sequence number recovery interface.
AsyncRecovery - Class in akka.persistence.journal.japi
Java API: asynchronous message replay and sequence number recovery interface.
AsyncRecovery() - Constructor for class akka.persistence.journal.japi.AsyncRecovery
 
asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.AsyncRecovery
Plugin API: asynchronously replays persistent messages.
asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in class akka.persistence.journal.japi.AsyncRecovery
 
asyncReplayMessages(String, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
asyncReplayTaggedMessages(String, long, long, long, Function1<LeveldbJournal.ReplayedTaggedMessage, BoxedUnit>) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
AsyncReplayTimeoutException - Exception in akka.persistence.journal
Thrown if replay inactivity exceeds a specified timeout.
AsyncReplayTimeoutException(String) - Constructor for exception akka.persistence.journal.AsyncReplayTimeoutException
 
AsyncWriteJournal - Interface in akka.persistence.journal
Abstract journal, optimized for asynchronous, non-blocking writes.
AsyncWriteJournal - Class in akka.persistence.journal.japi
Java API: abstract journal, optimized for asynchronous, non-blocking writes.
AsyncWriteJournal() - Constructor for class akka.persistence.journal.japi.AsyncWriteJournal
 
AsyncWriteJournal$ - Class in akka.persistence.journal
INTERNAL API.
AsyncWriteJournal$() - Constructor for class akka.persistence.journal.AsyncWriteJournal$
 
AsyncWriteJournal.Desequenced - Class in akka.persistence.journal
 
AsyncWriteJournal.Desequenced$ - Class in akka.persistence.journal
 
AsyncWriteJournal.Resequencer - Class in akka.persistence.journal
 
asyncWriteMessages(Seq<AtomicWrite>) - Method in interface akka.persistence.journal.AsyncWriteJournal
Plugin API: asynchronously writes a batch (Seq) of persistent messages to the journal.
asyncWriteMessages(Seq<AtomicWrite>) - Method in interface akka.persistence.journal.AsyncWriteProxy
 
asyncWriteMessages(Seq<AtomicWrite>) - Method in class akka.persistence.journal.japi.AsyncWriteJournal
 
asyncWriteMessages(Seq<AtomicWrite>) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
AsyncWriteProxy - Interface in akka.persistence.journal
INTERNAL API.
AsyncWriteProxy$ - Class in akka.persistence.journal
INTERNAL API.
AsyncWriteProxy$() - Constructor for class akka.persistence.journal.AsyncWriteProxy$
 
AsyncWriteProxy.InitTimeout$ - Class in akka.persistence.journal
 
AsyncWriteProxy.SetStore - Class in akka.persistence.journal
 
AsyncWriteProxy.SetStore$ - Class in akka.persistence.journal
 
AsyncWriteTarget - Class in akka.persistence.journal
INTERNAL API.
AsyncWriteTarget() - Constructor for class akka.persistence.journal.AsyncWriteTarget
 
AsyncWriteTarget$ - Class in akka.persistence.journal
INTERNAL API.
AsyncWriteTarget$() - Constructor for class akka.persistence.journal.AsyncWriteTarget$
 
AsyncWriteTarget.DeleteMessagesTo - Class in akka.persistence.journal
 
AsyncWriteTarget.DeleteMessagesTo$ - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplayFailure - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplayFailure$ - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplayMessages - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplayMessages$ - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplaySuccess - Class in akka.persistence.journal
 
AsyncWriteTarget.ReplaySuccess$ - Class in akka.persistence.journal
 
AsyncWriteTarget.WriteMessages - Class in akka.persistence.journal
 
AsyncWriteTarget.WriteMessages$ - Class in akka.persistence.journal
 
AtLeastOnceDelivery - Interface in akka.persistence
Mix-in this trait with your PersistentActor to send messages with at-least-once delivery semantics to destinations.
atLeastOnceDelivery() - Method in class akka.persistence.PersistenceSettings
 
atLeastOnceDelivery() - Constructor for class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
AtLeastOnceDelivery$ - Class in akka.persistence
 
AtLeastOnceDelivery$() - Constructor for class akka.persistence.AtLeastOnceDelivery$
 
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot - Class in akka.persistence
Snapshot of current AtLeastOnceDelivery state.
AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$ - Class in akka.persistence
 
AtLeastOnceDelivery.Internal$ - Class in akka.persistence
INTERNAL API
AtLeastOnceDelivery.Internal$.Delivery - Class in akka.persistence
 
AtLeastOnceDelivery.Internal$.RedeliveryTick - Class in akka.persistence
 
AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException - Exception in akka.persistence
 
AtLeastOnceDelivery.UnconfirmedDelivery - Class in akka.persistence
Information about a message that has not been confirmed.
AtLeastOnceDelivery.UnconfirmedDelivery$ - Class in akka.persistence
 
AtLeastOnceDelivery.UnconfirmedWarning - Class in akka.persistence
 
AtLeastOnceDelivery.UnconfirmedWarning$ - Class in akka.persistence
 
AtLeastOnceDeliveryLike - Interface in akka.persistence
 
AtLeastOnceDeliverySnapshot(long, Seq<AtLeastOnceDelivery.UnconfirmedDelivery>) - Constructor for class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
 
atLeastOnceDeliverySnapshot(MessageFormats.AtLeastOnceDeliverySnapshot) - Method in class akka.persistence.serialization.MessageSerializer
 
AtLeastOnceDeliverySnapshot$() - Constructor for class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$
 
atLeastOnceDeliverySnapshotBuilder(AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot) - Method in class akka.persistence.serialization.MessageSerializer
 
AtLeastOnceDeliverySnapshotClass() - Method in class akka.persistence.serialization.MessageSerializer
 
AtomicWrite - Class in akka.persistence
 
AtomicWrite(Seq<PersistentRepr>) - Constructor for class akka.persistence.AtomicWrite
 
AtomicWrite$ - Class in akka.persistence
 
AtomicWrite$() - Constructor for class akka.persistence.AtomicWrite$
 
AtomicWriteClass() - Method in class akka.persistence.serialization.MessageSerializer
 
attempt() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
autoUpdate() - Method in class akka.persistence.PersistenceSettings.view
 
autoUpdate() - Method in interface akka.persistence.PersistentView
If true, this view automatically updates itself with an interval specified by autoUpdateInterval.
autoUpdateInterval() - Method in class akka.persistence.PersistenceSettings.view
 
autoUpdateInterval() - Method in interface akka.persistence.PersistentView
The interval for automated updates.
autoUpdateReplayMax() - Method in class akka.persistence.PersistenceSettings.view
 
autoUpdateReplayMax() - Method in interface akka.persistence.PersistentView
The maximum number of messages to replay per update.
await() - Method in class akka.persistence.Update
 

B

breaker() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
breaker() - Method in interface akka.persistence.snapshot.SnapshotStore
 
buffer() - Method in class akka.persistence.journal.ReplayFilter
 
build() - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Build a PartialFunction from this builder.
build() - Method in class akka.persistence.fsm.japi.pf.FSMStopBuilder
Build a PartialFunction from this builder.
build() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
build() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
buildPartial() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 

C

cancel() - Method in class akka.persistence.fsm.PersistentFSM.Timer
 
cancelTimer(String) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
cause() - Method in class akka.persistence.DeleteMessagesFailure
 
cause() - Method in class akka.persistence.DeleteSnapshotFailure
 
cause() - Method in class akka.persistence.DeleteSnapshotsFailure
 
cause() - Method in class akka.persistence.fsm.PersistentFSM.Failure
 
cause() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayFailure
 
cause() - Method in class akka.persistence.JournalProtocol.ReplayMessagesFailure
 
cause() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
 
cause() - Method in class akka.persistence.JournalProtocol.WriteMessageRejected
 
cause() - Method in class akka.persistence.JournalProtocol.WriteMessagesFailed
 
cause() - Method in class akka.persistence.SaveSnapshotFailure
 
changeState(Eventsourced.State) - Method in interface akka.persistence.Eventsourced
 
changeState(PersistentView.State) - Method in interface akka.persistence.PersistentView
 
clear() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
clear() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
clearCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
required int64 currentDeliveryId = 1;
clearDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool deleted = 4;
clearDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required int64 deliveryId = 1;
clearDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
clearManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string manifest = 12;
clearPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
clearPayload() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
clearPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
clearPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required bytes payload = 2;
clearPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
optional bytes payloadManifest = 3;
clearPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
clearSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
clearSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int64 sequenceNr = 2;
clearSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required int32 serializerId = 1;
clearStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
required string stateIdentifier = 1;
clearTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
optional string timeout = 2;
clearUnconfirmedDeliveries() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
clearWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string writerUuid = 13;
clone() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
clone() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
CombinedReadEventAdapter(Seq<EventAdapter>) - Constructor for class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
 
CombinedReadEventAdapter$() - Constructor for class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter$
 
common() - Method in class akka.persistence.Eventsourced.ProcessingState
 
config() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
config() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
config() - Method in class akka.persistence.Persistence.PluginHolder
 
configFor(ActorRef) - Method in class akka.persistence.Persistence
INTERNAL API Looks up the plugin config by plugin's ActorRef.
configPath() - Method in class akka.persistence.journal.leveldb.LeveldbJournal
 
configPath() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
configPath() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
 
confirmDelivery(long) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
Call this method when a message has been confirmed by the destination, or to abort re-sending.
copy(S, D, Option<FiniteDuration>, Option<PersistentFSM.Reason>, List<Object>, boolean, Seq<E>, Function1<D, BoxedUnit>) - Method in class akka.persistence.fsm.PersistentFSM.State
Copy object and update values if needed.
counterFromBytes(byte[]) - Method in class akka.persistence.journal.leveldb.Key$
 
counterFromBytes(byte[]) - Static method in class akka.persistence.journal.leveldb.Key
 
counterKey(int) - Method in class akka.persistence.journal.leveldb.Key$
 
counterKey(int) - Static method in class akka.persistence.journal.leveldb.Key
 
counterToBytes(long) - Method in class akka.persistence.journal.leveldb.Key$
 
counterToBytes(long) - Static method in class akka.persistence.journal.leveldb.Key
 
create(Object...) - Method in class akka.persistence.journal.EventSeq$
Java API
create(Seq<Object>) - Method in class akka.persistence.journal.EventSeq$
Java API
create(Object...) - Static method in class akka.persistence.journal.EventSeq
Java API
create(Seq<Object>) - Static method in class akka.persistence.journal.EventSeq
Java API
create() - Method in class akka.persistence.PersistentRepr$
Java API, Plugin API.
create() - Method in class akka.persistence.Recovery$
Java API
create(long) - Method in class akka.persistence.Recovery$
Java API
create(SnapshotSelectionCriteria) - Method in class akka.persistence.Recovery$
Java API
create(SnapshotSelectionCriteria, long) - Method in class akka.persistence.Recovery$
Java API
create(SnapshotSelectionCriteria, long, long) - Method in class akka.persistence.Recovery$
Java API
create() - Static method in class akka.persistence.Recovery
Java API
create(long) - Static method in class akka.persistence.Recovery
Java API
create(SnapshotSelectionCriteria) - Static method in class akka.persistence.Recovery
Java API
create(SnapshotSelectionCriteria, long) - Static method in class akka.persistence.Recovery
Java API
create(SnapshotSelectionCriteria, long, long) - Static method in class akka.persistence.Recovery
Java API
create(SnapshotMetadata, Object) - Method in class akka.persistence.SelectedSnapshot$
Java API, Plugin API.
create(SnapshotMetadata, Object) - Static method in class akka.persistence.SelectedSnapshot
Java API, Plugin API.
create(long, long) - Method in class akka.persistence.SnapshotSelectionCriteria$
Java API.
create(long, long, long, long) - Method in class akka.persistence.SnapshotSelectionCriteria$
Java API.
create(long, long) - Static method in class akka.persistence.SnapshotSelectionCriteria
Java API.
create(long, long, long, long) - Static method in class akka.persistence.SnapshotSelectionCriteria
Java API.
create() - Method in class akka.persistence.Update$
Java API.
create(boolean) - Method in class akka.persistence.Update$
Java API.
create(boolean, long) - Method in class akka.persistence.Update$
Java API.
create() - Static method in class akka.persistence.Update
Java API.
create(boolean) - Static method in class akka.persistence.Update
Java API.
create(boolean, long) - Static method in class akka.persistence.Update
Java API.
createExtension(ExtendedActorSystem) - Method in class akka.persistence.Persistence$
 
createExtension(ExtendedActorSystem) - Static method in class akka.persistence.Persistence
 
criteria() - Method in class akka.persistence.DeleteSnapshotsFailure
 
criteria() - Method in class akka.persistence.DeleteSnapshotsSuccess
 
criteria() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshots
 
criteria() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshot
 
currentDeliveryId() - Method in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
 
CURRENTDELIVERYID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
CurrentPersistenceIds(Set<String>) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.CurrentPersistenceIds
 
CurrentPersistenceIds$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.CurrentPersistenceIds$
 
currentState() - Method in interface akka.persistence.Eventsourced
 
CurrentState(ActorRef, S, Option<FiniteDuration>) - Constructor for class akka.persistence.fsm.PersistentFSM.CurrentState
 
currentState() - Method in class akka.persistence.fsm.PersistentFSM.StopEvent
 
currentState() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
currentState() - Method in interface akka.persistence.PersistentView
 
CurrentState$() - Constructor for class akka.persistence.fsm.PersistentFSM.CurrentState$
 

D

data() - Method in class akka.persistence.serialization.Snapshot
 
debugEvent() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
 
debugEvent() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
defaultMaxUnconfirmedMessages() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
defaultRedeliverInterval() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
defaultRedeliveryBurstLimit() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
defaultWarnAfterNumberOfUnconfirmedAttempts() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
deferAsync(A, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Defer the handler execution until all pending handlers have been executed.
deferAsync(A, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
Defer the handler execution until all pending handlers have been executed.
deferAsync(A, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
Defer the handler execution until all pending handlers have been executed.
delete(String, long) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
deleteAsync(SnapshotMetadata) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
deleteAsync(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
deleteAsync(SnapshotMetadata) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
deleteAsync(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
deleteAsync(SnapshotMetadata) - Method in class akka.persistence.snapshot.NoSnapshotStore
 
deleteAsync(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.NoSnapshotStore
 
deleteAsync(SnapshotMetadata) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: deletes the snapshot identified by metadata.
deleteAsync(String, SnapshotSelectionCriteria) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: deletes all snapshots matching criteria.
deleted() - Method in class akka.persistence.PersistentImpl
 
deleted() - Method in interface akka.persistence.PersistentRepr
Not used in new records stored with Akka v2.4, but old records from v2.3 may have this as true if it was a non-permanent delete.
DELETED_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
deleteMessages(long) - Method in interface akka.persistence.Eventsourced
Permanently deletes all persistent messages with sequence numbers less than or equal toSequenceNr.
DeleteMessagesFailure - Class in akka.persistence
Reply message to a failed Eventsourced.deleteMessages(long) request.
DeleteMessagesFailure(Throwable, long) - Constructor for class akka.persistence.DeleteMessagesFailure
 
DeleteMessagesFailure$ - Class in akka.persistence
 
DeleteMessagesFailure$() - Constructor for class akka.persistence.DeleteMessagesFailure$
 
DeleteMessagesSuccess - Class in akka.persistence
Reply message to a successful Eventsourced.deleteMessages(long) request.
DeleteMessagesSuccess(long) - Constructor for class akka.persistence.DeleteMessagesSuccess
 
DeleteMessagesSuccess$ - Class in akka.persistence
 
DeleteMessagesSuccess$() - Constructor for class akka.persistence.DeleteMessagesSuccess$
 
DeleteMessagesTo(String, long) - Constructor for class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo
 
DeleteMessagesTo(String, long, ActorRef) - Constructor for class akka.persistence.JournalProtocol.DeleteMessagesTo
 
DeleteMessagesTo$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo$
 
DeleteMessagesTo$() - Constructor for class akka.persistence.JournalProtocol.DeleteMessagesTo$
 
DeleteSnapshot(SnapshotMetadata) - Constructor for class akka.persistence.SnapshotProtocol.DeleteSnapshot
 
deleteSnapshot(long) - Method in interface akka.persistence.Snapshotter
Deletes the snapshot identified by sequenceNr.
DeleteSnapshot$() - Constructor for class akka.persistence.SnapshotProtocol.DeleteSnapshot$
 
DeleteSnapshotFailure - Class in akka.persistence
Sent to a PersistentActor after failed deletion of a snapshot.
DeleteSnapshotFailure(SnapshotMetadata, Throwable) - Constructor for class akka.persistence.DeleteSnapshotFailure
 
DeleteSnapshotFailure$ - Class in akka.persistence
 
DeleteSnapshotFailure$() - Constructor for class akka.persistence.DeleteSnapshotFailure$
 
DeleteSnapshots(String, SnapshotSelectionCriteria) - Constructor for class akka.persistence.SnapshotProtocol.DeleteSnapshots
 
deleteSnapshots(SnapshotSelectionCriteria) - Method in interface akka.persistence.Snapshotter
Deletes all snapshots matching criteria.
DeleteSnapshots$() - Constructor for class akka.persistence.SnapshotProtocol.DeleteSnapshots$
 
DeleteSnapshotsFailure - Class in akka.persistence
Sent to a PersistentActor after failed deletion of a range of snapshots.
DeleteSnapshotsFailure(SnapshotSelectionCriteria, Throwable) - Constructor for class akka.persistence.DeleteSnapshotsFailure
 
DeleteSnapshotsFailure$ - Class in akka.persistence
 
DeleteSnapshotsFailure$() - Constructor for class akka.persistence.DeleteSnapshotsFailure$
 
DeleteSnapshotsSuccess - Class in akka.persistence
Sent to a PersistentActor after successful deletion of specified range of snapshots.
DeleteSnapshotsSuccess(SnapshotSelectionCriteria) - Constructor for class akka.persistence.DeleteSnapshotsSuccess
 
DeleteSnapshotsSuccess$ - Class in akka.persistence
 
DeleteSnapshotsSuccess$() - Constructor for class akka.persistence.DeleteSnapshotsSuccess$
 
DeleteSnapshotSuccess - Class in akka.persistence
Sent to a PersistentActor after successful deletion of a snapshot.
DeleteSnapshotSuccess(SnapshotMetadata) - Constructor for class akka.persistence.DeleteSnapshotSuccess
 
DeleteSnapshotSuccess$ - Class in akka.persistence
 
DeleteSnapshotSuccess$() - Constructor for class akka.persistence.DeleteSnapshotSuccess$
 
deletionKey(int, long) - Method in class akka.persistence.journal.leveldb.Key$
 
deletionKey(int, long) - Static method in class akka.persistence.journal.leveldb.Key
 
deliver(ActorPath, Function<Long, Object>) - Method in class akka.persistence.AbstractPersistentActorWithAtLeastOnceDelivery
Java API: Send the message created by the deliveryIdToMessage function to the destination actor.
deliver(ActorSelection, Function<Long, Object>) - Method in class akka.persistence.AbstractPersistentActorWithAtLeastOnceDelivery
Java API: Send the message created by the deliveryIdToMessage function to the destination actor.
deliver(ActorPath, Function1<Object, Object>) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
Scala API: Send the message created by the deliveryIdToMessage function to the destination actor.
deliver(ActorSelection, Function1<Object, Object>) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
Scala API: Send the message created by the deliveryIdToMessage function to the destination actor.
deliver(ActorPath, Function<Long, Object>) - Method in class akka.persistence.UntypedPersistentActorWithAtLeastOnceDelivery
Java API: Send the message created by the deliveryIdToMessage function to the destination actor.
deliver(ActorSelection, Function<Long, Object>) - Method in class akka.persistence.UntypedPersistentActorWithAtLeastOnceDelivery
Java API: Send the message created by the deliveryIdToMessage function to the destination actor.
Delivery(ActorPath, Object, long, int) - Constructor for class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
deliveryId() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
 
DELIVERYID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
deliverySequenceNr() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
Desequenced(Object, long, ActorRef, ActorRef) - Constructor for class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
Desequenced$() - Constructor for class akka.persistence.journal.AsyncWriteJournal.Desequenced$
 
deserialize(InputStream) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
destination() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
destination() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
 
DESTINATION_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
Disabled$() - Constructor for class akka.persistence.journal.ReplayFilter.Disabled$
 
domainEventClass() - Method in class akka.persistence.fsm.AbstractPersistentFSM
Domain event's Class Used for identifying domain events during recovery
domainEventClassTag() - Method in class akka.persistence.fsm.AbstractPersistentFSM
Adapter from Java Class to ClassTag
domainEventClassTag() - Method in interface akka.persistence.fsm.PersistentFSM
Enables to pass a ClassTag of a domain event base type from the implementing class
domainEvents() - Method in class akka.persistence.fsm.PersistentFSM.State
 
domainEventTag() - Method in interface akka.persistence.fsm.PersistentFSM
Domain event's ClassTag Used for identifying domain events during recovery
doPatch() - Method in class akka.persistence.serialization.SnapshotSerializer$
 
doPatch() - Static method in class akka.persistence.serialization.SnapshotSerializer
 

E

empty() - Method in class akka.persistence.journal.EventSeq$
Java API
empty() - Static method in class akka.persistence.journal.EventSeq
Java API
EmptyEventSeq - Interface in akka.persistence.journal
 
EmptyEventSeq$ - Class in akka.persistence.journal
 
EmptyEventSeq$() - Constructor for class akka.persistence.journal.EmptyEventSeq$
 
event(Class<P>, Class<Q>, FI.TypedPredicate2<P, Q>, FI.Apply2<P, Q, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on an event and data type and a predicate.
event(Class<P>, Class<Q>, FI.Apply2<P, Q, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on an event and data type.
event(Class<P>, FI.TypedPredicate2<P, D>, FI.Apply2<P, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the event type and predicate matches.
event(Class<P>, FI.Apply2<P, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the event type and predicate matches.
event(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if the predicate matches.
event(List<Object>, Class<Q>, FI.Apply2<Object, Q, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on the data type and if any of the event types in the list match or any of the event instances in the list compares equal.
event(List<Object>, FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if any of the event types in the list match or any of the event instances in the list compares equal.
Event(Object, D) - Constructor for class akka.persistence.fsm.PersistentFSM.Event
 
event() - Method in class akka.persistence.fsm.PersistentFSM.Event
 
event() - Method in class akka.persistence.fsm.PersistentFSM.LogEntry
 
Event() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
event() - Method in class akka.persistence.journal.SingleEventSeq
 
Event$() - Constructor for class akka.persistence.fsm.PersistentFSM.Event$
 
EventAdapter - Interface in akka.persistence.journal
EventAdapters - Class in akka.persistence.journal
EventAdapters serves as a per-journal collection of bound event adapters.
EventAdapters(ConcurrentHashMap<Class<?>, EventAdapter>, Seq<Tuple2<Class<?>, EventAdapter>>, LoggingAdapter) - Constructor for class akka.persistence.journal.EventAdapters
 
eventAdapters() - Method in interface akka.persistence.journal.WriteJournalBase
 
EventAdapters$ - Class in akka.persistence.journal
INTERNAL API
EventAdapters$() - Constructor for class akka.persistence.journal.EventAdapters$
 
EventAdapters.CombinedReadEventAdapter - Class in akka.persistence.journal
INTERNAL API
EventAdapters.CombinedReadEventAdapter$ - Class in akka.persistence.journal
 
EventAppended(String) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.EventAppended
 
EventAppended$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.EventAppended$
 
eventBatch() - Method in interface akka.persistence.Eventsourced
 
eventEquals(P, Class<Q>, FI.Apply2<P, Q, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches on the data type and if the event compares equal.
eventEquals(P, FI.Apply2<P, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
Add a case statement that matches if event compares equal.
events() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
 
events() - Method in class akka.persistence.journal.EmptyEventSeq$
 
events() - Method in class akka.persistence.journal.EventSeq
 
events() - Method in class akka.persistence.journal.EventsSeq
 
events() - Method in class akka.persistence.journal.SingleEventSeq
 
EventSeq - Class in akka.persistence.journal
 
EventSeq() - Constructor for class akka.persistence.journal.EventSeq
 
EventSeq$ - Class in akka.persistence.journal
 
EventSeq$() - Constructor for class akka.persistence.journal.EventSeq$
 
Eventsourced - Interface in akka.persistence
INTERNAL API.
Eventsourced$ - Class in akka.persistence
INTERNAL API
Eventsourced$() - Constructor for class akka.persistence.Eventsourced$
 
Eventsourced.AsyncHandlerInvocation - Class in akka.persistence
does not force the actor to stash commands; Originates from either `persistAsync` or `defer` calls
Eventsourced.AsyncHandlerInvocation$ - Class in akka.persistence
 
Eventsourced.PendingHandlerInvocation - Interface in akka.persistence
 
Eventsourced.ProcessingState - Class in akka.persistence
Common receive handler for processingCommands and persistingEvents
Eventsourced.StashingHandlerInvocation - Class in akka.persistence
forces actor to stash incoming commands until all these invocations are handled
Eventsourced.StashingHandlerInvocation$ - Class in akka.persistence
 
Eventsourced.State - Interface in akka.persistence
 
EventsSeq<E> - Class in akka.persistence.journal
 
EventsSeq(Seq<E>) - Constructor for class akka.persistence.journal.EventsSeq
 
EventsSeq$ - Class in akka.persistence.journal
 
EventsSeq$() - Constructor for class akka.persistence.journal.EventsSeq$
 
evt() - Method in class akka.persistence.Eventsourced.AsyncHandlerInvocation
 
evt() - Method in interface akka.persistence.Eventsourced.PendingHandlerInvocation
 
evt() - Method in class akka.persistence.Eventsourced.StashingHandlerInvocation
 
exec(Consumer<D>) - Method in class akka.persistence.fsm.AbstractPersistentFSM
Adapter from Java 8 Functional Interface to Scala Function
extension() - Method in interface akka.persistence.Eventsourced
 
extension() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
extension() - Method in interface akka.persistence.PersistentView
 
extension() - Method in interface akka.persistence.snapshot.SnapshotStore
 

F

fail(IllegalStateException) - Method in class akka.persistence.journal.ReplayFilter
 
Fail$() - Constructor for class akka.persistence.journal.ReplayFilter.Fail$
 
Failure(Object) - Constructor for class akka.persistence.fsm.PersistentFSM.Failure
 
Failure$() - Constructor for class akka.persistence.fsm.PersistentFSM.Failure$
 
flushBatch() - Method in interface akka.persistence.Eventsourced
 
flushJournalBatch() - Method in interface akka.persistence.Eventsourced
 
forMax(Duration) - Method in class akka.persistence.fsm.PersistentFSM.State
Modify state transition descriptor to include a state timeout for the next state.
from() - Method in class akka.persistence.fsm.PersistentFSM.Transition
 
fromBinary(byte[], Option<Class<?>>) - Method in class akka.persistence.serialization.MessageSerializer
Deserializes persistent messages.
fromBinary(byte[], Option<Class<?>>) - Method in class akka.persistence.serialization.SnapshotSerializer
Deserializes a Snapshot.
fromJournal(Object, String) - Method in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
 
fromJournal(Object, String) - Method in class akka.persistence.journal.IdentityEventAdapter$
 
fromJournal(Object, String) - Static method in class akka.persistence.journal.IdentityEventAdapter
 
fromJournal(Object, String) - Method in class akka.persistence.journal.NoopReadEventAdapter
 
fromJournal(Object, String) - Method in class akka.persistence.journal.NoopWriteEventAdapter
 
fromJournal(Object, String) - Method in interface akka.persistence.journal.ReadEventAdapter
Convert a event from its journal model to the applications domain model.
fromSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
fromSequenceNr() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages
 
fromSequenceNr() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
fromSnapshot() - Method in class akka.persistence.Recovery
 
fsmRef() - Method in class akka.persistence.fsm.PersistentFSM.CurrentState
 
fsmRef() - Method in class akka.persistence.fsm.PersistentFSM.Transition
 
FSMStateFunctionBuilder<S,D,E> - Class in akka.persistence.fsm.japi.pf
Builder used to create a partial function for FSM.whenUnhandled(scala.PartialFunction<akka.actor.FSM.Event<D>, akka.actor.FSM.State<S, D>>).
FSMStateFunctionBuilder() - Constructor for class akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder
 
FSMStopBuilder<S,D> - Class in akka.persistence.fsm.japi.pf
Builder used to create a partial function for FSM.onTermination(scala.PartialFunction<akka.actor.FSM.StopEvent<S, D>, scala.runtime.BoxedUnit>).
FSMStopBuilder() - Constructor for class akka.persistence.fsm.japi.pf.FSMStopBuilder
 
full() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
 

G

generation() - Method in class akka.persistence.fsm.PersistentFSM.TimeoutMarker
 
generation() - Method in class akka.persistence.fsm.PersistentFSM.Timer
 
generation() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
get(Class<?>) - Method in class akka.persistence.journal.EventAdapters
Finds the "most specific" matching adapter for the given class (i.e.
get(Class<?>) - Method in class akka.persistence.journal.IdentityEventAdapters$
 
get(Class<?>) - Static method in class akka.persistence.journal.IdentityEventAdapters
 
get(ActorSystem) - Method in class akka.persistence.Persistence$
Java API.
get(ActorSystem) - Static method in class akka.persistence.Persistence
Java API.
getCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
required int64 currentDeliveryId = 1;
getCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
required int64 currentDeliveryId = 1;
getCurrentDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
required int64 currentDeliveryId = 1;
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getDefaultInstance() - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
getDefaultInstanceForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
getDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool deleted = 4;
getDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional bool deleted = 4;
getDeleted() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional bool deleted = 4;
getDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required int64 deliveryId = 1;
getDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required int64 deliveryId = 1;
getDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required int64 deliveryId = 1;
getDeliverySnapshot() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
Full state of the AtLeastOnceDelivery.
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
getDescriptor() - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
getDescriptorForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
getDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
getDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required string destination = 2;
getDestination() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required string destination = 2;
getDestinationBytes() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
getDestinationBytes() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required string destination = 2;
getDestinationBytes() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required string destination = 2;
getInstance() - Method in class akka.persistence.RecoveryCompleted$
Java API: get the singleton instance
getInstance() - Static method in class akka.persistence.RecoveryCompleted
Java API: get the singleton instance
getLog() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
Retrieve current rolling log in oldest-first order.
getManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string manifest = 12;
getManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string manifest = 12;
getManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string manifest = 12;
getManifestBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string manifest = 12;
getManifestBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string manifest = 12;
getManifestBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string manifest = 12;
getMessage() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
Java API
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getParserForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
getPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required .PersistentPayload payload = 3;
getPayload() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required .PersistentPayload payload = 3;
getPayload(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
getPayload(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
repeated .PersistentMessage payload = 1;
getPayload(int) - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
repeated .PersistentMessage payload = 1;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .PersistentPayload payload = 1;
getPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .PersistentPayload payload = 1;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required bytes payload = 2;
getPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
required bytes payload = 2;
getPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
required bytes payload = 2;
getPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
getPayloadBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
getPayloadBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
getPayloadBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
getPayloadCount() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
getPayloadCount() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
repeated .PersistentMessage payload = 1;
getPayloadCount() - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
repeated .PersistentMessage payload = 1;
getPayloadList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
getPayloadList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
repeated .PersistentMessage payload = 1;
getPayloadList() - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
repeated .PersistentMessage payload = 1;
getPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
optional bytes payloadManifest = 3;
getPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
optional bytes payloadManifest = 3;
getPayloadManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
optional bytes payloadManifest = 3;
getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required .PersistentPayload payload = 3;
getPayloadOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required .PersistentPayload payload = 3;
getPayloadOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
getPayloadOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
repeated .PersistentMessage payload = 1;
getPayloadOrBuilder(int) - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
repeated .PersistentMessage payload = 1;
getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
getPayloadOrBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .PersistentPayload payload = 1;
getPayloadOrBuilder() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .PersistentPayload payload = 1;
getPayloadOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
getPayloadOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
repeated .PersistentMessage payload = 1;
getPayloadOrBuilderList() - Method in interface akka.persistence.serialization.MessageFormats.AtomicWriteOrBuilder
repeated .PersistentMessage payload = 1;
getPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
getPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string persistenceId = 3;
getPersistenceId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string persistenceId = 3;
getPersistenceIdBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
getPersistenceIdBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string persistenceId = 3;
getPersistenceIdBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string persistenceId = 3;
getSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
getSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string sender = 11;
getSender() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string sender = 11;
getSenderBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
getSenderBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string sender = 11;
getSenderBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string sender = 11;
getSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int64 sequenceNr = 2;
getSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional int64 sequenceNr = 2;
getSequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional int64 sequenceNr = 2;
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getSerializedSize() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
getSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required int32 serializerId = 1;
getSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
required int32 serializerId = 1;
getSerializerId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
required int32 serializerId = 1;
getStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
required string stateIdentifier = 1;
getStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
required string stateIdentifier = 1;
getStateIdentifier() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
required string stateIdentifier = 1;
getStateIdentifierBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
required string stateIdentifier = 1;
getStateIdentifierBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
required string stateIdentifier = 1;
getStateIdentifierBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
required string stateIdentifier = 1;
getTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
optional string timeout = 2;
getTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
optional string timeout = 2;
getTimeout() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
optional string timeout = 2;
getTimeoutBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
optional string timeout = 2;
getTimeoutBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
optional string timeout = 2;
getTimeoutBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
optional string timeout = 2;
getUnconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
Java API
getUnconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning
Java API
getUnconfirmedDeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveries(int) - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesCount() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesCount() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesCount() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesList() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilder(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilder(int) - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilderList() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnconfirmedDeliveriesOrBuilderList() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
getUnknownFields() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
getWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string writerUuid = 13;
getWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string writerUuid = 13;
getWriterUuid() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string writerUuid = 13;
getWriterUuidBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string writerUuid = 13;
getWriterUuidBytes() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string writerUuid = 13;
getWriterUuidBytes() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string writerUuid = 13;
goTo(S) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Produce transition to other state.

H

handleEvent() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
handleEventDefault() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
handler() - Method in class akka.persistence.Eventsourced.AsyncHandlerInvocation
 
handler() - Method in interface akka.persistence.Eventsourced.PendingHandlerInvocation
 
handler() - Method in class akka.persistence.Eventsourced.StashingHandlerInvocation
 
handleTransition(S, S) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
hasAllPersistenceIdsSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
hasCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
required int64 currentDeliveryId = 1;
hasCurrentDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
required int64 currentDeliveryId = 1;
hasCurrentDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder
required int64 currentDeliveryId = 1;
hasDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool deleted = 4;
hasDeleted() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional bool deleted = 4;
hasDeleted() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional bool deleted = 4;
hasDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required int64 deliveryId = 1;
hasDeliveryId() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required int64 deliveryId = 1;
hasDeliveryId() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required int64 deliveryId = 1;
hasDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
hasDestination() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required string destination = 2;
hasDestination() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required string destination = 2;
hasManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string manifest = 12;
hasManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string manifest = 12;
hasManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string manifest = 12;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
required .PersistentPayload payload = 3;
hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder
required .PersistentPayload payload = 3;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional .PersistentPayload payload = 1;
hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional .PersistentPayload payload = 1;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required bytes payload = 2;
hasPayload() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
required bytes payload = 2;
hasPayload() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
required bytes payload = 2;
hasPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
optional bytes payloadManifest = 3;
hasPayloadManifest() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
optional bytes payloadManifest = 3;
hasPayloadManifest() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
optional bytes payloadManifest = 3;
hasPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
hasPersistenceId() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string persistenceId = 3;
hasPersistenceId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string persistenceId = 3;
hasPersistenceIdSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
hasSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
hasSender() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string sender = 11;
hasSender() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string sender = 11;
hasSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int64 sequenceNr = 2;
hasSequenceNr() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional int64 sequenceNr = 2;
hasSequenceNr() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional int64 sequenceNr = 2;
hasSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required int32 serializerId = 1;
hasSerializerId() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
required int32 serializerId = 1;
hasSerializerId() - Method in interface akka.persistence.serialization.MessageFormats.PersistentPayloadOrBuilder
required int32 serializerId = 1;
hasStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
required string stateIdentifier = 1;
hasStateIdentifier() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
required string stateIdentifier = 1;
hasStateIdentifier() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
required string stateIdentifier = 1;
hasTagSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
hasTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
optional string timeout = 2;
hasTimeout() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
optional string timeout = 2;
hasTimeout() - Method in interface akka.persistence.serialization.MessageFormats.PersistentStateChangeEventOrBuilder
optional string timeout = 2;
hasWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string writerUuid = 13;
hasWriterUuid() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
optional string writerUuid = 13;
hasWriterUuid() - Method in interface akka.persistence.serialization.MessageFormats.PersistentMessageOrBuilder
optional string writerUuid = 13;
highestSequenceNr() - Method in class akka.persistence.AtomicWrite
 
highestSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplaySuccess
 
highestSequenceNr(String) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
highestSequenceNr() - Method in class akka.persistence.JournalProtocol.RecoverySuccess
 

I

identifier() - Method in interface akka.persistence.fsm.PersistentFSM.FSMState
 
IdentityEventAdapter - Class in akka.persistence.journal
No-op model adapter which passes through the incoming events as-is.
IdentityEventAdapter() - Constructor for class akka.persistence.journal.IdentityEventAdapter
 
IdentityEventAdapter$ - Class in akka.persistence.journal
No-op model adapter which passes through the incoming events as-is.
IdentityEventAdapter$() - Constructor for class akka.persistence.journal.IdentityEventAdapter$
 
IdentityEventAdapters - Class in akka.persistence.journal
 
IdentityEventAdapters() - Constructor for class akka.persistence.journal.IdentityEventAdapters
 
IdentityEventAdapters$ - Class in akka.persistence.journal
 
IdentityEventAdapters$() - Constructor for class akka.persistence.journal.IdentityEventAdapters$
 
idle() - Method in interface akka.persistence.PersistentView
When receiving an Update request, switches to replayStarted state and triggers an incremental message replay.
idMap() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
idMapLock() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
idOffset() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
ignoreRemainingReplay(Throwable) - Method in interface akka.persistence.PersistentView
Consumes remaining replayed messages and then throw the exception.
includeManifest() - Method in class akka.persistence.serialization.MessageSerializer
 
includeManifest() - Method in class akka.persistence.serialization.SnapshotSerializer
 
initialize() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
InitTimeout$() - Constructor for class akka.persistence.journal.AsyncWriteProxy.InitTimeout$
 
InmemJournal - Class in akka.persistence.journal.inmem
INTERNAL API.
InmemJournal() - Constructor for class akka.persistence.journal.inmem.InmemJournal
 
InmemMessages - Interface in akka.persistence.journal.inmem
INTERNAL API.
InmemStore - Class in akka.persistence.journal.inmem
INTERNAL API.
InmemStore() - Constructor for class akka.persistence.journal.inmem.InmemStore
 
instanceId() - Method in interface akka.persistence.Eventsourced
 
instantiateAdapter(String, ExtendedActorSystem) - Method in class akka.persistence.journal.EventAdapters$
 
instantiateAdapter(String, ExtendedActorSystem) - Static method in class akka.persistence.journal.EventAdapters
 
internal() - Method in class akka.persistence.PersistenceSettings
 
internal() - Constructor for class akka.persistence.PersistenceSettings.internal
 
Internal$() - Constructor for class akka.persistence.AtLeastOnceDelivery.Internal$
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
internalGetFieldAccessorTable() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
internalStash() - Method in interface akka.persistence.Eventsourced
 
internalStash() - Method in interface akka.persistence.PersistentView
 
isDefinedAt(Object) - Method in class akka.persistence.fsm.PersistentFSM.NullFunction$
 
isDeletionKey(Key) - Method in class akka.persistence.journal.leveldb.Key$
 
isDeletionKey(Key) - Static method in class akka.persistence.journal.leveldb.Key
 
isInitialized() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
isInitialized() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
isInitTimedOut() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
isMappingKey(Key) - Method in class akka.persistence.journal.leveldb.Key$
 
isMappingKey(Key) - Static method in class akka.persistence.journal.leveldb.Key
 
isNewPersistenceId(String) - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
isPersistent() - Method in interface akka.persistence.PersistentView
If true, the currently processed message was persisted (is sent from the Journal).
isReplayFilterEnabled() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
isStateTimerActive() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
isTimerActive(String) - Method in interface akka.persistence.fsm.PersistentFSMBase
 

J

journal() - Method in interface akka.persistence.Eventsourced
 
journal() - Method in interface akka.persistence.PersistentView
 
journalBatch() - Method in interface akka.persistence.Eventsourced
 
journalConfigFor(String) - Method in class akka.persistence.Persistence
INTERNAL API Returns the plugin config identified by pluginId.
journalFor(String) - Method in class akka.persistence.Persistence
INTERNAL API Returns a journal plugin actor identified by journalPluginId.
journalPluginId() - Method in interface akka.persistence.PersistenceIdentity
Configuration id of the journal plugin servicing this persistent actor or view.
JournalProtocol - Class in akka.persistence
INTERNAL API.
JournalProtocol() - Constructor for class akka.persistence.JournalProtocol
 
JournalProtocol$ - Class in akka.persistence
INTERNAL API.
JournalProtocol$() - Constructor for class akka.persistence.JournalProtocol$
 
JournalProtocol.DeleteMessagesTo - Class in akka.persistence
Request to delete all persistent messages with sequence numbers up to toSequenceNr (inclusive).
JournalProtocol.DeleteMessagesTo$ - Class in akka.persistence
 
JournalProtocol.LoopMessageSuccess - Class in akka.persistence
Reply message to a JournalProtocol.WriteMessages with a non-persistent message.
JournalProtocol.LoopMessageSuccess$ - Class in akka.persistence
 
JournalProtocol.Message - Interface in akka.persistence
Marker trait shared by internal journal messages.
JournalProtocol.RecoverySuccess - Class in akka.persistence
Reply message to a successful JournalProtocol.ReplayMessages request.
JournalProtocol.RecoverySuccess$ - Class in akka.persistence
 
JournalProtocol.ReplayedMessage - Class in akka.persistence
Reply message to a JournalProtocol.ReplayMessages request.
JournalProtocol.ReplayedMessage$ - Class in akka.persistence
 
JournalProtocol.ReplayMessages - Class in akka.persistence
Request to replay messages to persistentActor.
JournalProtocol.ReplayMessages$ - Class in akka.persistence
 
JournalProtocol.ReplayMessagesFailure - Class in akka.persistence
Reply message to a failed JournalProtocol.ReplayMessages request.
JournalProtocol.ReplayMessagesFailure$ - Class in akka.persistence
 
JournalProtocol.Request - Interface in akka.persistence
Internal journal command.
JournalProtocol.Response - Interface in akka.persistence
Internal journal acknowledgement.
JournalProtocol.WriteMessageFailure - Class in akka.persistence
Reply message to a failed JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessageFailure$ - Class in akka.persistence
 
JournalProtocol.WriteMessageRejected - Class in akka.persistence
Reply message to a rejected JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessageRejected$ - Class in akka.persistence
 
JournalProtocol.WriteMessages - Class in akka.persistence
Request to write messages.
JournalProtocol.WriteMessages$ - Class in akka.persistence
 
JournalProtocol.WriteMessagesFailed - Class in akka.persistence
Reply message to a failed JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessagesFailed$ - Class in akka.persistence
 
JournalProtocol.WriteMessagesSuccessful$ - Class in akka.persistence
Reply message to a successful JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessageSuccess - Class in akka.persistence
Reply message to a successful JournalProtocol.WriteMessages request.
JournalProtocol.WriteMessageSuccess$ - Class in akka.persistence
 

K

Key - Class in akka.persistence.journal.leveldb
LevelDB key.
Key(int, long, int) - Constructor for class akka.persistence.journal.leveldb.Key
 
key() - Method in class akka.persistence.serialization.SnapshotSerializer$
 
key() - Static method in class akka.persistence.serialization.SnapshotSerializer
 
Key$ - Class in akka.persistence.journal.leveldb
 
Key$() - Constructor for class akka.persistence.journal.leveldb.Key$
 
keyFromBytes(byte[]) - Method in class akka.persistence.journal.leveldb.Key$
 
keyFromBytes(byte[]) - Static method in class akka.persistence.journal.leveldb.Key
 
keyToBytes(Key) - Method in class akka.persistence.journal.leveldb.Key$
 
keyToBytes(Key) - Static method in class akka.persistence.journal.leveldb.Key
 

L

lastSequenceNr() - Method in interface akka.persistence.Eventsourced
Highest received sequence number so far or 0L if this actor hasn't replayed or stored any persistent events yet.
lastSequenceNr() - Method in interface akka.persistence.PersistentView
Highest received sequence number so far or 0L if this actor hasn't replayed any persistent events yet.
Latest() - Method in class akka.persistence.SnapshotSelectionCriteria$
The latest saved snapshot.
latest() - Method in class akka.persistence.SnapshotSelectionCriteria$
Java API.
Latest() - Static method in class akka.persistence.SnapshotSelectionCriteria
The latest saved snapshot.
latest() - Static method in class akka.persistence.SnapshotSelectionCriteria
Java API.
leveldb() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
leveldbDir() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
leveldbFactory() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
LeveldbIdMapping - Interface in akka.persistence.journal.leveldb
INTERNAL API.
LeveldbJournal - Class in akka.persistence.journal.leveldb
INTERNAL API.
LeveldbJournal() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal
 
LeveldbJournal$ - Class in akka.persistence.journal.leveldb
INTERNAL API.
LeveldbJournal$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal$
 
LeveldbJournal.CurrentPersistenceIds - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.CurrentPersistenceIds$ - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.EventAppended - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.EventAppended$ - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.PersistenceIdAdded - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.PersistenceIdAdded$ - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.ReplayedTaggedMessage - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.ReplayedTaggedMessage$ - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.ReplayTaggedMessages - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.ReplayTaggedMessages$ - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.SubscribeAllPersistenceIds$ - Class in akka.persistence.journal.leveldb
Subscribe the sender to current and new persistenceIds.
LeveldbJournal.SubscribePersistenceId - Class in akka.persistence.journal.leveldb
Subscribe the sender to changes (appended events) for a specific persistenceId.
LeveldbJournal.SubscribePersistenceId$ - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.SubscribeTag - Class in akka.persistence.journal.leveldb
Subscribe the sender to changes (appended events) for a specific tag.
LeveldbJournal.SubscribeTag$ - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.SubscriptionCommand - Interface in akka.persistence.journal.leveldb
 
LeveldbJournal.TaggedEventAppended - Class in akka.persistence.journal.leveldb
 
LeveldbJournal.TaggedEventAppended$ - Class in akka.persistence.journal.leveldb
 
leveldbOptions() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
leveldbReadOptions() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
LeveldbRecovery - Interface in akka.persistence.journal.leveldb
INTERNAL API.
leveldbSnapshot() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
LeveldbStore - Interface in akka.persistence.journal.leveldb
INTERNAL API.
leveldbWriteOptions() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
limit(long) - Method in class akka.persistence.SnapshotSelectionCriteria
INTERNAL API.
loadAsync(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
loadAsync(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
loadAsync(String, SnapshotSelectionCriteria) - Method in class akka.persistence.snapshot.NoSnapshotStore
 
loadAsync(String, SnapshotSelectionCriteria) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: asynchronously loads a snapshot.
LoadSnapshot(String, SnapshotSelectionCriteria, long) - Constructor for class akka.persistence.SnapshotProtocol.LoadSnapshot
 
loadSnapshot(String, SnapshotSelectionCriteria, long) - Method in interface akka.persistence.Snapshotter
Instructs the snapshot store to load the specified snapshot and send it via an SnapshotOffer to the running PersistentActor.
LoadSnapshot$() - Constructor for class akka.persistence.SnapshotProtocol.LoadSnapshot$
 
LoadSnapshotResult(Option<SelectedSnapshot>, long) - Constructor for class akka.persistence.SnapshotProtocol.LoadSnapshotResult
 
LoadSnapshotResult$() - Constructor for class akka.persistence.SnapshotProtocol.LoadSnapshotResult$
 
LocalSnapshotStore - Class in akka.persistence.snapshot.local
INTERNAL API
LocalSnapshotStore() - Constructor for class akka.persistence.snapshot.local.LocalSnapshotStore
 
log() - Method in interface akka.persistence.Eventsourced
 
logDepth() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
 
LogEntry(S, D, Object) - Constructor for class akka.persistence.fsm.PersistentFSM.LogEntry
 
LogEntry$() - Constructor for class akka.persistence.fsm.PersistentFSM.LogEntry$
 
LoggingPersistentFSM<S,D,E> - Interface in akka.persistence.fsm
Stackable trait for FSM which adds a rolling event log and debug logging capabilities (analogous to LoggingReceive).
logIssue(String) - Method in class akka.persistence.journal.ReplayFilter
 
logTermination(PersistentFSM.Reason) - Method in interface akka.persistence.fsm.PersistentFSMBase
By default PersistentFSM.Failure is logged at error level and other reason types are not logged.
lookup() - Method in class akka.persistence.Persistence$
 
lookup() - Static method in class akka.persistence.Persistence
 
LoopMessageSuccess(Object, int) - Constructor for class akka.persistence.JournalProtocol.LoopMessageSuccess
 
LoopMessageSuccess$() - Constructor for class akka.persistence.JournalProtocol.LoopMessageSuccess$
 
lowestSequenceNr() - Method in class akka.persistence.AtomicWrite
 

M

makeTransition(PersistentFSM.State<S, D, E>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
manifest(Object) - Method in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
 
manifest(Object) - Method in class akka.persistence.journal.IdentityEventAdapter$
 
manifest(Object) - Static method in class akka.persistence.journal.IdentityEventAdapter
 
manifest(Object) - Method in class akka.persistence.journal.NoopReadEventAdapter
 
manifest(Object) - Method in class akka.persistence.journal.NoopWriteEventAdapter
 
manifest(Object) - Method in interface akka.persistence.journal.WriteEventAdapter
Return the manifest (type hint) that will be provided in the fromJournal method.
manifest() - Method in class akka.persistence.PersistentImpl
 
manifest() - Method in interface akka.persistence.PersistentRepr
Returns the persistent payload's manifest if available
manifest() - Method in class akka.persistence.serialization.SnapshotHeader
 
MANIFEST_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
mappingId() - Method in class akka.persistence.journal.leveldb.Key
 
mappingKey(int) - Method in class akka.persistence.journal.leveldb.Key$
 
mappingKey(int) - Static method in class akka.persistence.journal.leveldb.Key
 
matchAnyEvent(FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchData(Class<DT>, FI.UnitApply<DT>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create a UnitPFBuilder with the first case statement set.
matchData(Class<DT>, FI.TypedPredicate<DT>, FI.UnitApply<DT>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create a UnitPFBuilder with the first case statement set.
matches(SnapshotMetadata) - Method in class akka.persistence.SnapshotSelectionCriteria
INTERNAL API.
matchEvent(Class<ET>, Class<DT>, FI.TypedPredicate2<ET, DT>, FI.Apply2<ET, DT, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, Class<DT>, FI.Apply2<ET, DT, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, FI.TypedPredicate2<ET, D>, FI.Apply2<ET, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(Class<ET>, FI.Apply2<ET, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(FI.TypedPredicate2<Object, D>, FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(List<Object>, Class<DT>, FI.Apply2<Object, DT, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchEvent(List<Object>, FI.Apply2<Object, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchEventEquals(Ev, Class<DT>, FI.Apply2<Ev, DT, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchEventEquals(Ev, FI.Apply2<Ev, D, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStateFunctionBuilder with the first case statement set.
matchState(S, S, FI.UnitApplyVoid) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMTransitionHandlerBuilder with the first case statement set.
matchState(S, S, FI.UnitApply2<S, S>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMTransitionHandlerBuilder with the first case statement set.
matchStop(PersistentFSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStopBuilder with the first case statement set.
matchStop(Class<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStopBuilder with the first case statement set.
matchStop(Class<RT>, FI.TypedPredicate<RT>, FI.UnitApply3<RT, S, D>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Create an FSMStopBuilder with the first case statement set.
max() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
max() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages
 
max() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
maxMessageBatchSize() - Method in interface akka.persistence.Eventsourced
 
maxSequenceNr() - Method in class akka.persistence.SnapshotSelectionCriteria
 
maxTimestamp() - Method in class akka.persistence.SnapshotSelectionCriteria
 
maxUnconfirmedMessages() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
Maximum number of unconfirmed messages that this actor is allowed to hold in memory.
maxUnconfirmedMessages() - Method in class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
MaxUnconfirmedMessagesExceededException(String) - Constructor for exception akka.persistence.AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException
 
mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
mergeFrom(MessageFormats.AtLeastOnceDeliverySnapshot) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
 
mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
mergeFrom(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
 
mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
mergeFrom(MessageFormats.AtomicWrite) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
 
mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
mergeFrom(MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
 
mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
mergeFrom(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
 
mergeFrom(Message) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
mergeFrom(MessageFormats.PersistentStateChangeEvent) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
 
mergePayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
mergePayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
message() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
message() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
 
message() - Method in class akka.persistence.JournalProtocol.LoopMessageSuccess
 
message() - Method in class akka.persistence.JournalProtocol.WriteMessageFailure
 
message() - Method in class akka.persistence.JournalProtocol.WriteMessageRejected
 
Message - Interface in akka.persistence.serialization
Marker trait for all protobuf-serializable messages in akka.persistence.
MessageFormats - Class in akka.persistence.serialization
 
MessageFormats.AtLeastOnceDeliverySnapshot - Class in akka.persistence.serialization
Protobuf type AtLeastOnceDeliverySnapshot
MessageFormats.AtLeastOnceDeliverySnapshot.Builder - Class in akka.persistence.serialization
Protobuf type AtLeastOnceDeliverySnapshot
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery - Class in akka.persistence.serialization
Protobuf type AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder - Class in akka.persistence.serialization
Protobuf type AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDeliveryOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.AtLeastOnceDeliverySnapshotOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.AtomicWrite - Class in akka.persistence.serialization
Protobuf type AtomicWrite
MessageFormats.AtomicWrite.Builder - Class in akka.persistence.serialization
Protobuf type AtomicWrite
MessageFormats.AtomicWriteOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.PersistentMessage - Class in akka.persistence.serialization
Protobuf type PersistentMessage
MessageFormats.PersistentMessage.Builder - Class in akka.persistence.serialization
Protobuf type PersistentMessage
MessageFormats.PersistentMessageOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.PersistentPayload - Class in akka.persistence.serialization
Protobuf type PersistentPayload
MessageFormats.PersistentPayload.Builder - Class in akka.persistence.serialization
Protobuf type PersistentPayload
MessageFormats.PersistentPayloadOrBuilder - Interface in akka.persistence.serialization
 
MessageFormats.PersistentStateChangeEvent - Class in akka.persistence.serialization
Protobuf type PersistentStateChangeEvent
MessageFormats.PersistentStateChangeEvent.Builder - Class in akka.persistence.serialization
Protobuf type PersistentStateChangeEvent
MessageFormats.PersistentStateChangeEventOrBuilder - Interface in akka.persistence.serialization
 
messages() - Method in class akka.persistence.journal.AsyncWriteTarget.WriteMessages
 
messages() - Method in interface akka.persistence.journal.inmem.InmemMessages
 
messages() - Method in class akka.persistence.JournalProtocol.WriteMessages
 
MessageSerializer - Class in akka.persistence.serialization
MessageSerializer(ExtendedActorSystem) - Constructor for class akka.persistence.serialization.MessageSerializer
 
metadata() - Method in class akka.persistence.DeleteSnapshotFailure
 
metadata() - Method in class akka.persistence.DeleteSnapshotSuccess
 
metadata() - Method in class akka.persistence.SaveSnapshotFailure
 
metadata() - Method in class akka.persistence.SaveSnapshotSuccess
 
metadata() - Method in class akka.persistence.SelectedSnapshot
 
metadata() - Method in class akka.persistence.SnapshotOffer
 
metadata() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshot
 
metadata() - Method in class akka.persistence.SnapshotProtocol.SaveSnapshot
 
minSequenceNr() - Method in class akka.persistence.SnapshotSelectionCriteria
 
minTimestamp() - Method in class akka.persistence.SnapshotSelectionCriteria
 
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.Internal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.AtomicWrite$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.DeleteMessagesFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.DeleteMessagesSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.DeleteSnapshotFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.DeleteSnapshotsFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.DeleteSnapshotsSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.DeleteSnapshotSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Eventsourced$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Eventsourced.AsyncHandlerInvocation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Eventsourced.StashingHandlerInvocation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.AbstractPersistentFSMBase$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.$minus$greater$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.CurrentState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Event$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Failure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.LogEntry$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Normal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.NullFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Shutdown$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.State$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.StateChangeEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.StateTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.StopEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.SubscribeTransitionCallBack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.TimeoutMarker$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Timer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.Transition$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.fsm.PersistentFSM.UnsubscribeTransitionCallBack$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteJournal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteJournal.Desequenced$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteProxy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteProxy.InitTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteProxy.SetStore$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplayFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.ReplaySuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.AsyncWriteTarget.WriteMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.EmptyEventSeq$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.EventAdapters$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.EventSeq$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.EventsSeq$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.IdentityEventAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.IdentityEventAdapters$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.Key$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.CurrentPersistenceIds$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.EventAppended$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.PersistenceIdAdded$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayedTaggedMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeAllPersistenceIds$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.SubscribePersistenceId$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeTag$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.LeveldbJournal.TaggedEventAppended$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.leveldb.SharedLeveldbJournal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.NoopReadEventAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.NoopWriteEventAdapter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter.Disabled$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter.Fail$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter.RepairByDiscardOld$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.ReplayFilter.Warn$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.SingleEventSeq$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.journal.Tagged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.DeleteMessagesTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.LoopMessageSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.RecoverySuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayedMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.ReplayMessagesFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessageFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessageRejected$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessagesFailed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessagesSuccessful$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.JournalProtocol.WriteMessageSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.NonPersistentRepr$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Persistence$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Persistence.PluginHolder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentImpl$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentRepr$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentView$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.PersistentView.ScheduledUpdate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Protocol$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Recovery$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.RecoveryCompleted$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SaveSnapshotFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SaveSnapshotSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SelectedSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.serialization.Snapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.serialization.SnapshotHeader$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.serialization.SnapshotSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotMetadata$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotOffer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.DeleteSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.DeleteSnapshots$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.LoadSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.LoadSnapshotResult$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotProtocol.SaveSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.SnapshotSelectionCriteria$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class akka.persistence.Update$
Static reference to the singleton instance of this Scala object.
msg() - Method in class akka.persistence.fsm.PersistentFSM.Timer
 
msg() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
 

N

name() - Method in class akka.persistence.fsm.PersistentFSM.Timer
 
nativeLeveldb() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
newBuilder(MessageFormats.AtLeastOnceDeliverySnapshot) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
newBuilder(MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
newBuilder(MessageFormats.AtomicWrite) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
newBuilder(MessageFormats.PersistentMessage) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
newBuilder(MessageFormats.PersistentPayload) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
newBuilder() - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
newBuilder(MessageFormats.PersistentStateChangeEvent) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
newBuilderForType() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
newPersistenceIdAdded(String) - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
newPersistenceIdAdded(String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
nextDeliverySequenceNr() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
nextSequenceNr() - Method in interface akka.persistence.Eventsourced
 
nextState() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
nextStateData() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
nextTagSequenceNr(String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
none() - Method in class akka.persistence.Recovery$
Convenience method for skipping recovery in PersistentActor.
none() - Static method in class akka.persistence.Recovery
Convenience method for skipping recovery in PersistentActor.
None() - Method in class akka.persistence.SnapshotSelectionCriteria$
No saved snapshot matches.
none() - Method in class akka.persistence.SnapshotSelectionCriteria$
Java API.
None() - Static method in class akka.persistence.SnapshotSelectionCriteria
No saved snapshot matches.
none() - Static method in class akka.persistence.SnapshotSelectionCriteria
Java API.
NonPersistentRepr - Class in akka.persistence
INTERNAL API Message which can be resequenced by the Journal, but will not be persisted.
NonPersistentRepr(Object, ActorRef) - Constructor for class akka.persistence.NonPersistentRepr
 
NonPersistentRepr$ - Class in akka.persistence
 
NonPersistentRepr$() - Constructor for class akka.persistence.NonPersistentRepr$
 
NoopReadEventAdapter - Class in akka.persistence.journal
INTERNAL API
NoopReadEventAdapter(WriteEventAdapter) - Constructor for class akka.persistence.journal.NoopReadEventAdapter
 
NoopReadEventAdapter$ - Class in akka.persistence.journal
 
NoopReadEventAdapter$() - Constructor for class akka.persistence.journal.NoopReadEventAdapter$
 
NoopWriteEventAdapter - Class in akka.persistence.journal
INTERNAL API
NoopWriteEventAdapter(ReadEventAdapter) - Constructor for class akka.persistence.journal.NoopWriteEventAdapter
 
NoopWriteEventAdapter$ - Class in akka.persistence.journal
 
NoopWriteEventAdapter$() - Constructor for class akka.persistence.journal.NoopWriteEventAdapter$
 
Normal() - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Default reason if calling stop().
Normal$() - Constructor for class akka.persistence.fsm.PersistentFSM.Normal$
 
NoSnapshotStore - Class in akka.persistence.snapshot
Used as default snapshot-store in case no other store was configured.
NoSnapshotStore() - Constructor for class akka.persistence.snapshot.NoSnapshotStore
 
NoSnapshotStore.NoSnapshotStoreException - Exception in akka.persistence.snapshot
 
NoSnapshotStoreException() - Constructor for exception akka.persistence.snapshot.NoSnapshotStore.NoSnapshotStoreException
 
notifies() - Method in class akka.persistence.fsm.PersistentFSM.State
 
notifyPersistenceIdChange(String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
notifyTagChange(String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
NullFunction() - Method in class akka.persistence.fsm.AbstractPersistentFSMBase$
A partial function value which does not match anything and can be used to &ldquo;reset&rdquo; whenUnhandled and onTermination handlers.
NullFunction() - Static method in class akka.persistence.fsm.AbstractPersistentFSMBase
A partial function value which does not match anything and can be used to &ldquo;reset&rdquo; whenUnhandled and onTermination handlers.
NullFunction$() - Constructor for class akka.persistence.fsm.PersistentFSM.NullFunction$
 
numberOfUnconfirmed() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
Number of messages that have not been confirmed yet.
numericId(String) - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
Get the mapped numeric id for the specified persistent actor id.

O

offset() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayedTaggedMessage
 
offset() - Method in class akka.persistence.serialization.SnapshotSerializer$
 
offset() - Static method in class akka.persistence.serialization.SnapshotSerializer
 
oldWriters() - Method in class akka.persistence.journal.ReplayFilter
 
onPersistFailure(Throwable, Object, long) - Method in interface akka.persistence.Eventsourced
Called when persist fails.
onPersistRejected(Throwable, Object, long) - Method in interface akka.persistence.Eventsourced
Called when the journal rejected persist of an event.
onReceive(Object) - Method in class akka.persistence.UntypedPersistentActor
 
onReceiveCommand(Object) - Method in class akka.persistence.UntypedPersistentActor
Java API: command handler.
onReceiveRecover(Object) - Method in class akka.persistence.UntypedPersistentActor
Java API: recovery handler that receives persisted events during recovery.
onRecoveryCompleted() - Method in interface akka.persistence.fsm.PersistentFSM
Override this handler to define the action on recovery completion
onRecoveryFailure(Throwable, Option<Object>) - Method in interface akka.persistence.Eventsourced
Called whenever a message replay fails.
onReplayError(Throwable) - Method in interface akka.persistence.PersistentView
Called whenever a message replay fails.
onReplaySuccess() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
onReplaySuccess() - Method in interface akka.persistence.Eventsourced
INTERNAL API.
onTermination(FSMStopBuilder<S, D>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Set handler which is called upon termination of this FSM actor.
onTermination(PartialFunction<PersistentFSM.StopEvent<S, D>, BoxedUnit>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
onTransition(FSMTransitionHandlerBuilder<S>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Add a handler which is called upon each state transition, i.e.
onTransition(FI.UnitApply2<S, S>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Add a handler which is called upon each state transition, i.e.
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
onWriteMessageComplete(boolean) - Method in class akka.persistence.Eventsourced.ProcessingState
 
ordering() - Method in class akka.persistence.SnapshotMetadata$
 
ordering() - Static method in class akka.persistence.SnapshotMetadata
 

P

parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseDelimitedFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseFrom(ByteString) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(byte[]) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
parseFrom(ByteString) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(byte[]) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
parseFrom(ByteString) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseFrom(byte[]) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseFrom(CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
parseFrom(ByteString) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(byte[]) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
parseFrom(ByteString) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(byte[]) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
parseFrom(ByteString) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseFrom(byte[]) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseFrom(InputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseFrom(CodedInputStream) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
PARSER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
payload() - Method in class akka.persistence.AtomicWrite
 
payload() - Method in class akka.persistence.journal.Tagged
 
payload() - Method in class akka.persistence.NonPersistentRepr
 
payload() - Method in interface akka.persistence.PersistentEnvelope
 
payload() - Method in class akka.persistence.PersistentImpl
 
payload() - Method in interface akka.persistence.PersistentRepr
This persistent message's payload.
PAYLOAD_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
PAYLOAD_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
PAYLOADMANIFEST_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
peekApplyHandler(Object) - Method in interface akka.persistence.Eventsourced
 
pendingInvocations() - Method in interface akka.persistence.Eventsourced
 
pendingStashingPersistInvocations() - Method in interface akka.persistence.Eventsourced
 
persist(A, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Java API: asynchronously persists event.
persist(Iterable<A>, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
 
persist(A, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
Asynchronously persists event.
persist(Seq<A>, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
 
persist(A, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
Java API: asynchronously persists event.
persist(Iterable<A>, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
 
persistAll(Iterable<A>, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Java API: asynchronously persists events in specified order.
persistAll(Seq<A>, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
Asynchronously persists events in specified order.
persistAll(Iterable<A>, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
Java API: asynchronously persists events in specified order.
persistAllAsync(Iterable<A>, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Java API: asynchronously persists events in specified order.
persistAllAsync(Seq<A>, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
Asynchronously persists events in specified order.
persistAllAsync(Iterable<A>, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
JAVA API: asynchronously persists events in specified order.
persistAsync(A, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
Java API: asynchronously persists event.
persistAsync(Iterable<A>, Procedure<A>) - Method in class akka.persistence.AbstractPersistentActor
 
persistAsync(A, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
Asynchronously persists event.
persistAsync(Seq<A>, Function1<A, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
 
persistAsync(A, Procedure<A>) - Method in class akka.persistence.UntypedPersistentActor
JAVA API: asynchronously persists event.
persistence() - Method in interface akka.persistence.journal.WriteJournalBase
 
Persistence - Class in akka.persistence
Persistence extension.
Persistence(ExtendedActorSystem) - Constructor for class akka.persistence.Persistence
 
Persistence$ - Class in akka.persistence
Persistence extension provider.
Persistence$() - Constructor for class akka.persistence.Persistence$
 
Persistence.PluginHolder - Class in akka.persistence
INTERNAL API.
Persistence.PluginHolder$ - Class in akka.persistence
 
persistenceId() - Method in class akka.persistence.AtomicWrite
 
persistenceId() - Method in class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo
 
persistenceId() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
persistenceId() - Method in class akka.persistence.journal.leveldb.Key
 
persistenceId() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.EventAppended
 
persistenceId() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.PersistenceIdAdded
 
persistenceId() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.SubscribePersistenceId
 
persistenceId() - Method in class akka.persistence.JournalProtocol.DeleteMessagesTo
 
persistenceId() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
persistenceId(ActorRef) - Method in class akka.persistence.Persistence
Creates a canonical persistent actor id from a persistent actor ref.
persistenceId() - Method in interface akka.persistence.PersistenceIdentity
Id of the persistent entity for which messages should be replayed.
persistenceId() - Method in class akka.persistence.PersistentImpl
 
persistenceId() - Method in interface akka.persistence.PersistentRepr
Persistent id that journals a persistent message
persistenceId() - Method in class akka.persistence.SnapshotMetadata
 
persistenceId() - Method in class akka.persistence.SnapshotProtocol.DeleteSnapshots
 
persistenceId() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshot
 
PERSISTENCEID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
PersistenceIdAdded(String) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.PersistenceIdAdded
 
PersistenceIdAdded$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.PersistenceIdAdded$
 
PersistenceIdentity - Interface in akka.persistence
Identification of PersistentActor or PersistentView.
persistenceIdSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
PersistenceRecovery - Interface in akka.persistence
 
PersistenceSettings - Class in akka.persistence
Persistence configuration.
PersistenceSettings(Config) - Constructor for class akka.persistence.PersistenceSettings
 
PersistenceSettings.atLeastOnceDelivery - Class in akka.persistence
 
PersistenceSettings.internal - Class in akka.persistence
INTERNAL API.
PersistenceSettings.view - Class in akka.persistence
 
persistent() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayedTaggedMessage
 
persistent() - Method in class akka.persistence.JournalProtocol.ReplayedMessage
 
persistent() - Method in class akka.persistence.JournalProtocol.WriteMessageSuccess
 
persistentActor() - Method in class akka.persistence.JournalProtocol.DeleteMessagesTo
 
persistentActor() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
persistentActor() - Method in class akka.persistence.JournalProtocol.WriteMessages
 
PersistentActor - Interface in akka.persistence
An persistent Actor - can be used to implement command or event sourcing.
PersistentEnvelope - Interface in akka.persistence
INTERNAL API
persistentFromBytes(byte[]) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
PersistentFSM<S extends PersistentFSM.FSMState,D,E> - Interface in akka.persistence.fsm
A FSM implementation with persistent state.
PersistentFSM$ - Class in akka.persistence.fsm
 
PersistentFSM$() - Constructor for class akka.persistence.fsm.PersistentFSM$
 
PersistentFSM.$minus$greater$ - Class in akka.persistence.fsm
This extractor is just convenience for matching a (S, S) pair, including a reminder what the new state is.
PersistentFSM.CurrentState<S> - Class in akka.persistence.fsm
Message type which is sent directly to the subscribed actor in FSM.SubscribeTransitionCallBack before sending any FSM.Transition messages.
PersistentFSM.CurrentState$ - Class in akka.persistence.fsm
 
PersistentFSM.Event<D> - Class in akka.persistence.fsm
All messages sent to the FSM will be wrapped inside an Event, which allows pattern matching to extract both state and data.
PersistentFSM.Event$ - Class in akka.persistence.fsm
 
PersistentFSM.Failure - Class in akka.persistence.fsm
Signifies that the FSM is shutting itself down because of an error, e.g.
PersistentFSM.Failure$ - Class in akka.persistence.fsm
 
PersistentFSM.FSMState - Interface in akka.persistence.fsm
FSMState base trait, makes possible for simple default serialization by conversion to String
PersistentFSM.LogEntry<S,D> - Class in akka.persistence.fsm
Log Entry of the LoggingFSM, can be obtained by calling getLog.
PersistentFSM.LogEntry$ - Class in akka.persistence.fsm
 
PersistentFSM.Normal$ - Class in akka.persistence.fsm
Default reason if calling stop().
PersistentFSM.NullFunction$ - Class in akka.persistence.fsm
A partial function value which does not match anything and can be used to &ldquo;reset&rdquo; whenUnhandled and onTermination handlers.
PersistentFSM.PersistentFsmEvent - Interface in akka.persistence.fsm
Base persistent event class
PersistentFSM.Reason - Interface in akka.persistence.fsm
Reason why this FSM is shutting down.
PersistentFSM.Shutdown$ - Class in akka.persistence.fsm
Reason given when someone was calling system.stop(fsm) from outside; also applies to Stop supervision directive.
PersistentFSM.State<S,D,E> - Class in akka.persistence.fsm
This captures all of the managed state of the FSM: the state name, the state data, possibly custom timeout, stop reason, replies accumulated while processing the last message, possibly domain event and handler to be executed after FSM moves to the new state (also triggered when staying in the same state)
PersistentFSM.State$ - Class in akka.persistence.fsm
 
PersistentFSM.StateChangeEvent - Class in akka.persistence.fsm
Persisted on state change
PersistentFSM.StateChangeEvent$ - Class in akka.persistence.fsm
 
PersistentFSM.StateTimeout$ - Class in akka.persistence.fsm
This case object is received in case of a state timeout.
PersistentFSM.StopEvent<S,D> - Class in akka.persistence.fsm
Case class representing the state of the FSM whithin the onTermination block.
PersistentFSM.StopEvent$ - Class in akka.persistence.fsm
 
PersistentFSM.SubscribeTransitionCallBack - Class in akka.persistence.fsm
Send this to an FSM to request first the PersistentFSM.CurrentState and then a series of PersistentFSM.Transition updates.
PersistentFSM.SubscribeTransitionCallBack$ - Class in akka.persistence.fsm
 
PersistentFSM.TimeoutMarker - Class in akka.persistence.fsm
INTERNAL API
PersistentFSM.TimeoutMarker$ - Class in akka.persistence.fsm
 
PersistentFSM.Timer - Class in akka.persistence.fsm
INTERNAL API
PersistentFSM.Timer$ - Class in akka.persistence.fsm
 
PersistentFSM.Transition<S> - Class in akka.persistence.fsm
Message type which is used to communicate transitions between states to all subscribed listeners (use FSM.SubscribeTransitionCallBack).
PersistentFSM.Transition$ - Class in akka.persistence.fsm
 
PersistentFSM.UnsubscribeTransitionCallBack - Class in akka.persistence.fsm
Unsubscribe from FSM.Transition notifications which was effected by sending the corresponding FSM.SubscribeTransitionCallBack.
PersistentFSM.UnsubscribeTransitionCallBack$ - Class in akka.persistence.fsm
 
PersistentFSMBase<S,D,E> - Interface in akka.persistence.fsm
Finite State Machine actor trait.
PersistentFSMBase.TransformHelper - Class in akka.persistence.fsm
 
PersistentImpl - Class in akka.persistence
INTERNAL API.
PersistentImpl(Object, long, String, String, boolean, ActorRef, String) - Constructor for class akka.persistence.PersistentImpl
 
PersistentImpl$ - Class in akka.persistence
 
PersistentImpl$() - Constructor for class akka.persistence.PersistentImpl$
 
PersistentImplClass() - Method in class akka.persistence.serialization.MessageSerializer
 
PersistentRepr - Interface in akka.persistence
Plugin API: representation of a persistent message in the journal plugin API.
PersistentRepr$ - Class in akka.persistence
 
PersistentRepr$() - Constructor for class akka.persistence.PersistentRepr$
 
PersistentReprClass() - Method in class akka.persistence.serialization.MessageSerializer
 
PersistentStateChangeEventClass() - Method in class akka.persistence.serialization.MessageSerializer
 
persistentToBytes(PersistentRepr) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
PersistentView - Interface in akka.persistence
A view replicates the persistent message stream of a PersistentActor.
PersistentView$ - Class in akka.persistence
INTERNAL API
PersistentView$() - Constructor for class akka.persistence.PersistentView$
 
PersistentView.ScheduledUpdate - Class in akka.persistence
 
PersistentView.ScheduledUpdate$ - Class in akka.persistence
 
PersistentView.State - Interface in akka.persistence
 
persistingEvents() - Method in interface akka.persistence.Eventsourced
Event persisting state.
PluginHolder(ActorRef, EventAdapters, Config) - Constructor for class akka.persistence.Persistence.PluginHolder
 
PluginHolder$() - Constructor for class akka.persistence.Persistence.PluginHolder$
 
pos() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
 
postStop() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
postStop() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
postStop() - Method in interface akka.persistence.PersistentView
 
preparePersistentBatch(Seq<PersistentEnvelope>) - Method in interface akka.persistence.journal.WriteJournalBase
 
preRestart(Throwable, Option<Object>) - Method in interface akka.persistence.PersistentView
 
preStart() - Method in class akka.persistence.journal.inmem.InmemJournal
 
preStart() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
preStart() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
preStart() - Method in interface akka.persistence.PersistentView
Triggers an initial recovery, starting form a snapshot, if any, and replaying at most autoUpdateReplayMax messages (following that snapshot).
preStart() - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
processEvent(PersistentFSM.Event<D>, Object) - Method in interface akka.persistence.fsm.LoggingPersistentFSM
 
processEvent(PersistentFSM.Event<D>, Object) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
processingCommands() - Method in interface akka.persistence.Eventsourced
Command processing state.
ProcessingState() - Constructor for class akka.persistence.Eventsourced.ProcessingState
 
processMsg(Object, Object) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
props(ActorRef, ReplayFilter.Mode, int, int) - Method in class akka.persistence.journal.ReplayFilter$
 
props(ActorRef, ReplayFilter.Mode, int, int) - Static method in class akka.persistence.journal.ReplayFilter
 
Protocol - Class in akka.persistence
INTERNAL API.
Protocol() - Constructor for class akka.persistence.Protocol
 
Protocol$ - Class in akka.persistence
INTERNAL API.
Protocol$() - Constructor for class akka.persistence.Protocol$
 
Protocol.Message - Interface in akka.persistence
INTERNAL API.
publish() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
publish() - Method in interface akka.persistence.snapshot.SnapshotStore
 
publishPluginCommands() - Method in class akka.persistence.PersistenceSettings.internal
 

R

read(String, long, long, long) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
ReadEventAdapter - Interface in akka.persistence.journal
Facility to convert from and to specialised data models, as may be required by specialized persistence Journals.
readHighestSequenceNr(int) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
readIdMap() - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
readIdMap(Map<String, Object>, org.iq80.leveldb.DBIterator) - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
reason() - Method in class akka.persistence.fsm.PersistentFSM.StopEvent
 
receive() - Method in class akka.persistence.AbstractPersistentActor
 
receive() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
receive() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
receive() - Method in class akka.persistence.journal.AsyncWriteJournal.Resequencer
 
receive() - Method in class akka.persistence.journal.inmem.InmemStore
 
receive() - Method in class akka.persistence.journal.leveldb.SharedLeveldbStore
 
receive() - Method in class akka.persistence.journal.ReplayFilter
 
receive() - Method in class akka.persistence.journal.ReplayMediator
 
receive() - Method in interface akka.persistence.PersistentActor
 
receive() - Method in interface akka.persistence.snapshot.SnapshotStore
 
receiveCommand() - Method in interface akka.persistence.Eventsourced
Command handler.
receiveCommand() - Method in interface akka.persistence.fsm.PersistentFSM
After recovery events are handled as in usual FSM actor
receiveCommand() - Method in class akka.persistence.UntypedPersistentActor
 
receivePluginInternal() - Method in interface akka.persistence.journal.AsyncWriteJournal
Plugin API
receivePluginInternal() - Method in class akka.persistence.journal.leveldb.LeveldbJournal
 
receivePluginInternal() - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
 
receivePluginInternal() - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
receivePluginInternal() - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API Allows plugin implementers to use f pipeTo self and handle additional messages for implementing advanced features
receiveRecover() - Method in interface akka.persistence.Eventsourced
Recovery handler that receives persisted events during recovery.
receiveRecover() - Method in interface akka.persistence.fsm.PersistentFSM
Discover the latest recorded state
receiveRecover() - Method in class akka.persistence.UntypedPersistentActor
 
receiveSnapshotStore() - Method in interface akka.persistence.snapshot.SnapshotStore
 
receiveWriteJournal() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
recovering(PartialFunction<Object, BoxedUnit>) - Method in interface akka.persistence.Eventsourced
Processes replayed messages, if any.
recovery() - Method in interface akka.persistence.PersistenceRecovery
Called when the persistent actor is started for the first time.
recovery() - Method in interface akka.persistence.PersistentView
 
Recovery - Class in akka.persistence
Recovery mode configuration object to be returned in PersistenceRecovery.recovery().
Recovery(SnapshotSelectionCriteria, long, long) - Constructor for class akka.persistence.Recovery
 
Recovery$ - Class in akka.persistence
 
Recovery$() - Constructor for class akka.persistence.Recovery$
 
RecoveryCompleted - Class in akka.persistence
 
RecoveryCompleted() - Constructor for class akka.persistence.RecoveryCompleted
 
RecoveryCompleted$ - Class in akka.persistence
Sent to a PersistentActor when the journal replay has been finished.
RecoveryCompleted$() - Constructor for class akka.persistence.RecoveryCompleted$
 
recoveryFinished() - Method in interface akka.persistence.Eventsourced
Returns true if this persistent actor has successfully finished recovery.
recoveryRunning() - Method in interface akka.persistence.Eventsourced
Returns true if this persistent actor is currently recovering.
recoveryRunning() - Method in interface akka.persistence.Eventsourced.State
 
recoveryRunning() - Method in interface akka.persistence.PersistentView.State
 
recoveryStarted(long) - Method in interface akka.persistence.Eventsourced
 
recoveryStarted(long) - Method in interface akka.persistence.PersistentView
 
RecoverySuccess(long) - Constructor for class akka.persistence.JournalProtocol.RecoverySuccess
 
RecoverySuccess$() - Constructor for class akka.persistence.JournalProtocol.RecoverySuccess$
 
redeliverInterval() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
Interval between redelivery attempts.
redeliverInterval() - Method in class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
redeliverOverdue() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
redeliverTask() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
redeliveryBurstLimit() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
Maximum number of unconfirmed messages that will be sent at each redelivery burst (burst frequency is half of the redelivery interval).
redeliveryBurstLimit() - Method in class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
RedeliveryTick() - Constructor for class akka.persistence.AtLeastOnceDelivery.Internal$.RedeliveryTick
 
ref() - Method in class akka.persistence.journal.AsyncWriteProxy.SetStore
 
register(S, PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>, Option<FiniteDuration>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
registerAllExtensions(ExtensionRegistry) - Static method in class akka.persistence.serialization.MessageFormats
 
removePayload(int) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
removeSubscriber(ActorRef) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
removeUnconfirmedDeliveries(int) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
RepairByDiscardOld$() - Constructor for class akka.persistence.journal.ReplayFilter.RepairByDiscardOld$
 
repeat() - Method in class akka.persistence.fsm.PersistentFSM.Timer
 
replacement() - Method in class akka.persistence.serialization.SnapshotSerializer$
 
replacement() - Static method in class akka.persistence.serialization.SnapshotSerializer
 
replayDispatcher() - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
replayDispatcherId() - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
ReplayedMessage(PersistentRepr) - Constructor for class akka.persistence.JournalProtocol.ReplayedMessage
 
ReplayedMessage$() - Constructor for class akka.persistence.JournalProtocol.ReplayedMessage$
 
ReplayedTaggedMessage(PersistentRepr, String, long) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.ReplayedTaggedMessage
 
ReplayedTaggedMessage$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.ReplayedTaggedMessage$
 
ReplayFailure(Throwable) - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplayFailure
 
ReplayFailure$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplayFailure$
 
ReplayFilter - Class in akka.persistence.journal
INTERNAL API
ReplayFilter(ActorRef, ReplayFilter.Mode, int, int) - Constructor for class akka.persistence.journal.ReplayFilter
 
ReplayFilter$ - Class in akka.persistence.journal
INTERNAL API
ReplayFilter$() - Constructor for class akka.persistence.journal.ReplayFilter$
 
ReplayFilter.Disabled$ - Class in akka.persistence.journal
 
ReplayFilter.Fail$ - Class in akka.persistence.journal
 
ReplayFilter.Mode - Interface in akka.persistence.journal
 
ReplayFilter.RepairByDiscardOld$ - Class in akka.persistence.journal
 
ReplayFilter.Warn$ - Class in akka.persistence.journal
 
replayFilterMaxOldWriters() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
replayFilterMode() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
replayFilterWindowSize() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
replayMax() - Method in class akka.persistence.PersistentView.ScheduledUpdate
 
replayMax() - Method in class akka.persistence.Recovery
 
replayMax() - Method in class akka.persistence.Update
 
ReplayMediator - Class in akka.persistence.journal
 
ReplayMediator(Function1<PersistentRepr, BoxedUnit>, Promise<BoxedUnit>, Duration) - Constructor for class akka.persistence.journal.ReplayMediator
 
ReplayMessages(String, long, long, long) - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
replayMessages(int, long, long, long, Function1<PersistentRepr, BoxedUnit>) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
ReplayMessages(long, long, long, String, ActorRef) - Constructor for class akka.persistence.JournalProtocol.ReplayMessages
 
ReplayMessages$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplayMessages$
 
ReplayMessages$() - Constructor for class akka.persistence.JournalProtocol.ReplayMessages$
 
ReplayMessagesFailure(Throwable) - Constructor for class akka.persistence.JournalProtocol.ReplayMessagesFailure
 
ReplayMessagesFailure$() - Constructor for class akka.persistence.JournalProtocol.ReplayMessagesFailure$
 
replayStarted(boolean) - Method in interface akka.persistence.PersistentView
Processes replayed messages, if any.
ReplaySuccess(long) - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplaySuccess
 
ReplaySuccess$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.ReplaySuccess$
 
ReplayTaggedMessages(long, long, long, String, ActorRef) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages
 
replayTaggedMessages(String, int, long, long, long, Function1<LeveldbJournal.ReplayedTaggedMessage, BoxedUnit>) - Method in interface akka.persistence.journal.leveldb.LeveldbRecovery
 
ReplayTaggedMessages$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages$
 
replies() - Method in class akka.persistence.fsm.PersistentFSM.State
 
replying(Object) - Method in class akka.persistence.fsm.PersistentFSM.State
Send reply to sender of the current message, if available.
replyTo() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages
 
resequencer() - Method in interface akka.persistence.journal.AsyncWriteJournal
 
Resequencer() - Constructor for class akka.persistence.journal.AsyncWriteJournal.Resequencer
 
resequencerCounter() - Method in interface akka.persistence.journal.AsyncWriteJournal
 

S

safeLongToInt(long) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
save(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
saveAsync(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.japi.SnapshotStore
 
saveAsync(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
saveAsync(SnapshotMetadata, Object) - Method in class akka.persistence.snapshot.NoSnapshotStore
 
saveAsync(SnapshotMetadata, Object) - Method in interface akka.persistence.snapshot.SnapshotStore
Plugin API: asynchronously saves a snapshot.
SaveSnapshot(SnapshotMetadata, Object) - Constructor for class akka.persistence.SnapshotProtocol.SaveSnapshot
 
saveSnapshot(Object) - Method in interface akka.persistence.Snapshotter
Saves a snapshot of this snapshotter's state.
SaveSnapshot$() - Constructor for class akka.persistence.SnapshotProtocol.SaveSnapshot$
 
SaveSnapshotFailure - Class in akka.persistence
Sent to a PersistentActor after failed saving of a snapshot.
SaveSnapshotFailure(SnapshotMetadata, Throwable) - Constructor for class akka.persistence.SaveSnapshotFailure
 
SaveSnapshotFailure$ - Class in akka.persistence
 
SaveSnapshotFailure$() - Constructor for class akka.persistence.SaveSnapshotFailure$
 
SaveSnapshotSuccess - Class in akka.persistence
Sent to a PersistentActor after successful saving of a snapshot.
SaveSnapshotSuccess(SnapshotMetadata) - Constructor for class akka.persistence.SaveSnapshotSuccess
 
SaveSnapshotSuccess$ - Class in akka.persistence
 
SaveSnapshotSuccess$() - Constructor for class akka.persistence.SaveSnapshotSuccess$
 
schedule(ActorRef, FiniteDuration) - Method in class akka.persistence.fsm.PersistentFSM.Timer
 
schedule() - Method in interface akka.persistence.PersistentView
 
ScheduledUpdate(long) - Constructor for class akka.persistence.PersistentView.ScheduledUpdate
 
ScheduledUpdate$() - Constructor for class akka.persistence.PersistentView.ScheduledUpdate$
 
SelectedSnapshot - Class in akka.persistence
Plugin API: a selected snapshot matching SnapshotSelectionCriteria.
SelectedSnapshot(SnapshotMetadata, Object) - Constructor for class akka.persistence.SelectedSnapshot
 
SelectedSnapshot$ - Class in akka.persistence
 
SelectedSnapshot$() - Constructor for class akka.persistence.SelectedSnapshot$
 
send(long, akka.persistence.AtLeastOnceDelivery.Internal.Delivery, long) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
sendBuffered() - Method in class akka.persistence.journal.ReplayFilter
 
sender() - Method in class akka.persistence.AtomicWrite
 
sender() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
sender() - Method in class akka.persistence.NonPersistentRepr
 
sender() - Method in interface akka.persistence.PersistentEnvelope
 
sender() - Method in class akka.persistence.PersistentImpl
 
sender() - Method in interface akka.persistence.PersistentRepr
Sender of this message.
SENDER_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
senderPersistentActor() - Method in interface akka.persistence.snapshot.SnapshotStore
Documents intent that the sender() is expected to be the PersistentActor
seqNo() - Method in class akka.persistence.journal.ReplayFilter
 
sequenceNr() - Method in interface akka.persistence.Eventsourced
 
sequenceNr() - Method in class akka.persistence.journal.leveldb.Key
 
sequenceNr() - Method in class akka.persistence.PersistentImpl
 
sequenceNr() - Method in interface akka.persistence.PersistentRepr
This persistent message's sequence number.
sequenceNr() - Method in class akka.persistence.SnapshotMetadata
 
SEQUENCENR_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
serialization() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
serialize(OutputStream, Snapshot) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
serializerId() - Method in class akka.persistence.serialization.SnapshotHeader
 
SERIALIZERID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
setCurrentDeliveryId(long) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
required int64 currentDeliveryId = 1;
setDeleted(boolean) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional bool deleted = 4;
setDeliveryId(long) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required int64 deliveryId = 1;
setDeliverySnapshot(AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot) - Method in interface akka.persistence.AtLeastOnceDeliveryLike
If snapshot from AtLeastOnceDeliveryLike.getDeliverySnapshot() was saved it will be received during recovery in a SnapshotOffer message and should be set with this method.
setDestination(String) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
setDestinationBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required string destination = 2;
setLastSequenceNr(long) - Method in interface akka.persistence.Eventsourced
 
setLastSequenceNr(long) - Method in interface akka.persistence.PersistentView
 
setManifest(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string manifest = 12;
setManifestBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string manifest = 12;
setPayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
setPayload(MessageFormats.PersistentPayload.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder
required .PersistentPayload payload = 3;
setPayload(int, MessageFormats.PersistentMessage) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
setPayload(int, MessageFormats.PersistentMessage.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite.Builder
repeated .PersistentMessage payload = 1;
setPayload(MessageFormats.PersistentPayload) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
setPayload(MessageFormats.PersistentPayload.Builder) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional .PersistentPayload payload = 1;
setPayload(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required bytes payload = 2;
setPayloadManifest(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
optional bytes payloadManifest = 3;
setPersistenceId(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
setPersistenceIdBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string persistenceId = 3;
setSender(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
setSenderBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string sender = 11;
setSequenceNr(long) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional int64 sequenceNr = 2;
setSerializerId(int) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload.Builder
required int32 serializerId = 1;
setStateIdentifier(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
required string stateIdentifier = 1;
setStateIdentifierBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
required string stateIdentifier = 1;
setStateTimeout(S, Option<FiniteDuration>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
SetStore(ActorRef) - Constructor for class akka.persistence.journal.AsyncWriteProxy.SetStore
 
setStore(ActorRef, ActorSystem) - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal$
Sets the shared LevelDB store for the given actor system.
setStore(ActorRef, ActorSystem) - Static method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
Sets the shared LevelDB store for the given actor system.
SetStore$() - Constructor for class akka.persistence.journal.AsyncWriteProxy.SetStore$
 
setTimeout(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
optional string timeout = 2;
setTimeoutBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent.Builder
optional string timeout = 2;
setTimer(String, Object, FiniteDuration) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Schedule named timer to deliver message after given delay, possibly repeating.
setTimer(String, Object, FiniteDuration, boolean) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
settings() - Method in class akka.persistence.Persistence
 
setUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
setUnconfirmedDeliveries(int, MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery.Builder) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.Builder
repeated .AtLeastOnceDeliverySnapshot.UnconfirmedDelivery unconfirmedDeliveries = 2;
setWriterUuid(String) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string writerUuid = 13;
setWriterUuidBytes(ByteString) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage.Builder
optional string writerUuid = 13;
SharedLeveldbJournal - Class in akka.persistence.journal.leveldb
INTERNAL API.
SharedLeveldbJournal() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbJournal
 
SharedLeveldbJournal$ - Class in akka.persistence.journal.leveldb
 
SharedLeveldbJournal$() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbJournal$
 
SharedLeveldbStore - Class in akka.persistence.journal.leveldb
A LevelDB store that can be shared by multiple actor systems.
SharedLeveldbStore() - Constructor for class akka.persistence.journal.leveldb.SharedLeveldbStore
 
Shutdown() - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Reason given when someone was calling system.stop(fsm) from outside; also applies to Stop supervision directive.
Shutdown$() - Constructor for class akka.persistence.fsm.PersistentFSM.Shutdown$
 
single(Object) - Method in class akka.persistence.journal.EventSeq$
Java API
single(Object) - Static method in class akka.persistence.journal.EventSeq
Java API
SingleEventSeq - Class in akka.persistence.journal
 
SingleEventSeq(Object) - Constructor for class akka.persistence.journal.SingleEventSeq
 
SingleEventSeq$ - Class in akka.persistence.journal
 
SingleEventSeq$() - Constructor for class akka.persistence.journal.SingleEventSeq$
 
size() - Method in class akka.persistence.AtomicWrite
 
size() - Method in class akka.persistence.NonPersistentRepr
 
size() - Method in interface akka.persistence.PersistentEnvelope
 
snapshot() - Method in class akka.persistence.SelectedSnapshot
 
Snapshot - Class in akka.persistence.serialization
Wrapper for snapshot data.
Snapshot(Object) - Constructor for class akka.persistence.serialization.Snapshot
 
snapshot() - Method in class akka.persistence.SnapshotOffer
 
snapshot() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshotResult
 
snapshot() - Method in class akka.persistence.SnapshotProtocol.SaveSnapshot
 
Snapshot$ - Class in akka.persistence.serialization
 
Snapshot$() - Constructor for class akka.persistence.serialization.Snapshot$
 
SnapshotHeader - Class in akka.persistence.serialization
INTERNAL API.
SnapshotHeader(int, Option<String>) - Constructor for class akka.persistence.serialization.SnapshotHeader
 
SnapshotHeader$ - Class in akka.persistence.serialization
 
SnapshotHeader$() - Constructor for class akka.persistence.serialization.SnapshotHeader$
 
SnapshotMetadata - Class in akka.persistence
Snapshot metadata.
SnapshotMetadata(String, long, long) - Constructor for class akka.persistence.SnapshotMetadata
 
SnapshotMetadata$ - Class in akka.persistence
 
SnapshotMetadata$() - Constructor for class akka.persistence.SnapshotMetadata$
 
SnapshotOffer - Class in akka.persistence
Offers a PersistentActor a previously saved snapshot during recovery.
SnapshotOffer(SnapshotMetadata, Object) - Constructor for class akka.persistence.SnapshotOffer
 
SnapshotOffer$ - Class in akka.persistence
 
SnapshotOffer$() - Constructor for class akka.persistence.SnapshotOffer$
 
snapshotPluginId() - Method in interface akka.persistence.PersistenceIdentity
Configuration id of the snapshot plugin servicing this persistent actor or view.
SnapshotProtocol - Class in akka.persistence
INTERNAL API.
SnapshotProtocol() - Constructor for class akka.persistence.SnapshotProtocol
 
SnapshotProtocol$ - Class in akka.persistence
INTERNAL API.
SnapshotProtocol$() - Constructor for class akka.persistence.SnapshotProtocol$
 
SnapshotProtocol.DeleteSnapshot - Class in akka.persistence
Instructs snapshot store to delete a snapshot.
SnapshotProtocol.DeleteSnapshot$ - Class in akka.persistence
 
SnapshotProtocol.DeleteSnapshots - Class in akka.persistence
Instructs snapshot store to delete all snapshots that match criteria.
SnapshotProtocol.DeleteSnapshots$ - Class in akka.persistence
 
SnapshotProtocol.LoadSnapshot - Class in akka.persistence
Instructs a snapshot store to load a snapshot.
SnapshotProtocol.LoadSnapshot$ - Class in akka.persistence
 
SnapshotProtocol.LoadSnapshotResult - Class in akka.persistence
Response message to a SnapshotProtocol.LoadSnapshot message.
SnapshotProtocol.LoadSnapshotResult$ - Class in akka.persistence
 
SnapshotProtocol.Message - Interface in akka.persistence
Marker trait shared by internal snapshot messages.
SnapshotProtocol.Request - Interface in akka.persistence
Internal snapshot command.
SnapshotProtocol.Response - Interface in akka.persistence
Internal snapshot acknowledgement.
SnapshotProtocol.SaveSnapshot - Class in akka.persistence
Instructs snapshot store to save a snapshot.
SnapshotProtocol.SaveSnapshot$ - Class in akka.persistence
 
SnapshotSelectionCriteria - Class in akka.persistence
Selection criteria for loading and deleting snapshots.
SnapshotSelectionCriteria(long, long, long, long) - Constructor for class akka.persistence.SnapshotSelectionCriteria
 
SnapshotSelectionCriteria$ - Class in akka.persistence
 
SnapshotSelectionCriteria$() - Constructor for class akka.persistence.SnapshotSelectionCriteria$
 
snapshotSequenceNr() - Method in interface akka.persistence.Eventsourced
Returns lastSequenceNr.
snapshotSequenceNr() - Method in interface akka.persistence.PersistentView
Returns lastSequenceNr.
snapshotSequenceNr() - Method in interface akka.persistence.Snapshotter
Sequence number to use when taking a snapshot.
SnapshotSerializer - Class in akka.persistence.serialization
Snapshot serializer.
SnapshotSerializer(ExtendedActorSystem) - Constructor for class akka.persistence.serialization.SnapshotSerializer
 
SnapshotSerializer$ - Class in akka.persistence.serialization
 
SnapshotSerializer$() - Constructor for class akka.persistence.serialization.SnapshotSerializer$
 
snapshotStore() - Method in interface akka.persistence.Eventsourced
 
snapshotStore() - Method in interface akka.persistence.PersistentView
 
SnapshotStore - Class in akka.persistence.snapshot.japi
Java API: abstract snapshot store.
SnapshotStore() - Constructor for class akka.persistence.snapshot.japi.SnapshotStore
 
SnapshotStore - Interface in akka.persistence.snapshot
Abstract snapshot store.
snapshotStore() - Method in interface akka.persistence.Snapshotter
Snapshot store plugin actor.
snapshotStoreFor(String) - Method in class akka.persistence.Persistence
INTERNAL API
Snapshotter - Interface in akka.persistence
Snapshot API on top of the internal snapshot protocol.
snapshotterId() - Method in interface akka.persistence.Eventsourced
Returns persistenceId.
snapshotterId() - Method in interface akka.persistence.PersistentView
Returns viewId.
snapshotterId() - Method in interface akka.persistence.Snapshotter
Snapshotter id.
snr() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
startRecovery(Recovery) - Method in interface akka.persistence.Eventsourced
 
startRecovery(Recovery) - Method in interface akka.persistence.PersistentView
 
startRedeliverTask() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
startWith(S, D) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Set initial state.
startWith(S, D, FiniteDuration) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Set initial state.
startWith(S, D, Option<FiniteDuration>) - Method in interface akka.persistence.fsm.PersistentFSMBase
Set initial state.
StashingHandlerInvocation(Object, Function1<Object, BoxedUnit>) - Constructor for class akka.persistence.Eventsourced.StashingHandlerInvocation
 
StashingHandlerInvocation$() - Constructor for class akka.persistence.Eventsourced.StashingHandlerInvocation$
 
state() - Method in class akka.persistence.fsm.PersistentFSM.CurrentState
 
State(S, D, Option<FiniteDuration>, Option<PersistentFSM.Reason>, List<Object>, Seq<E>, Function1<D, BoxedUnit>, boolean) - Constructor for class akka.persistence.fsm.PersistentFSM.State
 
State$() - Constructor for class akka.persistence.fsm.PersistentFSM.State$
 
stateChange(MessageFormats.PersistentStateChangeEvent) - Method in class akka.persistence.serialization.MessageSerializer
 
stateChangeBuilder(PersistentFSM.StateChangeEvent) - Method in class akka.persistence.serialization.MessageSerializer
 
StateChangeEvent(String, Option<FiniteDuration>) - Constructor for class akka.persistence.fsm.PersistentFSM.StateChangeEvent
 
StateChangeEvent$() - Constructor for class akka.persistence.fsm.PersistentFSM.StateChangeEvent$
 
stateData() - Method in class akka.persistence.fsm.PersistentFSM.Event
 
stateData() - Method in class akka.persistence.fsm.PersistentFSM.LogEntry
 
stateData() - Method in class akka.persistence.fsm.PersistentFSM.State
 
stateData() - Method in class akka.persistence.fsm.PersistentFSM.StopEvent
 
stateData() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
stateFunctions() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
stateIdentifier() - Method in class akka.persistence.fsm.PersistentFSM.StateChangeEvent
 
STATEIDENTIFIER_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
stateName() - Method in class akka.persistence.fsm.PersistentFSM.LogEntry
 
stateName() - Method in class akka.persistence.fsm.PersistentFSM.State
 
stateName() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
stateNames() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
stateReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.Eventsourced.State
 
stateReceive(PartialFunction<Object, BoxedUnit>, Object) - Method in interface akka.persistence.PersistentView.State
 
states() - Method in interface akka.persistence.fsm.LoggingPersistentFSM
 
statesMap() - Method in interface akka.persistence.fsm.PersistentFSM
Map from state identifier to state instance
StateTimeout() - Method in interface akka.persistence.fsm.PersistentFSMBase
This case object is received in case of a state timeout.
StateTimeout$() - Constructor for class akka.persistence.fsm.PersistentFSM.StateTimeout$
 
stateTimeouts() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
stay() - Method in interface akka.persistence.fsm.PersistentFSMBase
Produce "empty" transition descriptor.
stop(PersistentFSM.Reason, FI.UnitApply2<S, D>) - Method in class akka.persistence.fsm.japi.pf.FSMStopBuilder
Add a case statement that matches on an FSM.Reason.
stop(Class<P>, FI.UnitApply3<P, S, D>) - Method in class akka.persistence.fsm.japi.pf.FSMStopBuilder
Add a case statement that matches on a reason type.
stop(Class<P>, FI.TypedPredicate<P>, FI.UnitApply3<P, S, D>) - Method in class akka.persistence.fsm.japi.pf.FSMStopBuilder
Add a case statement that matches on a reason type and a predicate.
stop() - Method in interface akka.persistence.fsm.PersistentFSMBase
Produce change descriptor to stop this FSM actor with reason "Normal".
stop(PersistentFSM.Reason) - Method in interface akka.persistence.fsm.PersistentFSMBase
Produce change descriptor to stop this FSM actor including specified reason.
stop(PersistentFSM.Reason, D) - Method in interface akka.persistence.fsm.PersistentFSMBase
Produce change descriptor to stop this FSM actor including specified reason.
StopEvent(PersistentFSM.Reason, S, D) - Constructor for class akka.persistence.fsm.PersistentFSM.StopEvent
 
StopEvent() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
StopEvent$() - Constructor for class akka.persistence.fsm.PersistentFSM.StopEvent$
 
stopReason() - Method in class akka.persistence.fsm.PersistentFSM.State
 
store() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
storeNotInitialized() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
SubscribeAllPersistenceIds$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeAllPersistenceIds$
 
SubscribePersistenceId(String) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribePersistenceId
 
SubscribePersistenceId$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribePersistenceId$
 
SubscribeTag(String) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeTag
 
SubscribeTag$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeTag$
 
SubscribeTransitionCallBack(ActorRef) - Constructor for class akka.persistence.fsm.PersistentFSM.SubscribeTransitionCallBack
 
SubscribeTransitionCallBack$() - Constructor for class akka.persistence.fsm.PersistentFSM.SubscribeTransitionCallBack$
 
successUnit() - Method in class akka.persistence.journal.AsyncWriteJournal$
 
system() - Method in class akka.persistence.Persistence
 
system() - Method in class akka.persistence.serialization.MessageSerializer
 
system() - Method in class akka.persistence.serialization.SnapshotSerializer
 

T

tag() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayedTaggedMessage
 
tag() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages
 
tag() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.SubscribeTag
 
tag() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.TaggedEventAppended
 
tagAsPersistenceId(String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
Tagged - Class in akka.persistence.journal
The journal may support tagging of events that are used by the EventsByTag query and it may support specifying the tags via an EventAdapter that wraps the events in a Tagged with the given tags.
Tagged(Object, Set<String>) - Constructor for class akka.persistence.journal.Tagged
 
Tagged(Object, Set<String>) - Constructor for class akka.persistence.journal.Tagged
Java API
Tagged$ - Class in akka.persistence.journal
 
Tagged$() - Constructor for class akka.persistence.journal.Tagged$
 
TaggedEventAppended(String) - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.TaggedEventAppended
 
TaggedEventAppended$() - Constructor for class akka.persistence.journal.leveldb.LeveldbJournal.TaggedEventAppended$
 
tagNumericId(String) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
tagPersistenceIdPrefix() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
tags() - Method in class akka.persistence.journal.Tagged
 
tagSequenceNr() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
tagSubscribers() - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
target() - Method in class akka.persistence.journal.AsyncWriteJournal.Desequenced
 
terminate(PersistentFSM.State<S, D, E>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
terminateEvent() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
timeout() - Method in class akka.persistence.fsm.PersistentFSM.CurrentState
 
timeout() - Method in class akka.persistence.fsm.PersistentFSM.State
 
timeout() - Method in class akka.persistence.fsm.PersistentFSM.StateChangeEvent
 
timeout() - Method in class akka.persistence.fsm.PersistentFSM.Transition
 
timeout() - Method in interface akka.persistence.journal.AsyncWriteProxy
 
timeout() - Method in class akka.persistence.journal.inmem.InmemJournal
 
timeout() - Method in class akka.persistence.journal.leveldb.SharedLeveldbJournal
 
TIMEOUT_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
timeoutFuture() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
TimeoutMarker(long) - Constructor for class akka.persistence.fsm.PersistentFSM.TimeoutMarker
 
TimeoutMarker$() - Constructor for class akka.persistence.fsm.PersistentFSM.TimeoutMarker$
 
Timer(String, Object, boolean, int, ActorContext) - Constructor for class akka.persistence.fsm.PersistentFSM.Timer
 
Timer$() - Constructor for class akka.persistence.fsm.PersistentFSM.Timer$
 
timerGen() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
timers() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
timestamp() - Method in class akka.persistence.AtLeastOnceDelivery.Internal$.Delivery
 
timestamp() - Method in class akka.persistence.SnapshotMetadata
 
to() - Method in class akka.persistence.fsm.PersistentFSM.Transition
 
toBinary(Object) - Method in class akka.persistence.serialization.MessageSerializer
Serializes persistent messages.
toBinary(Object) - Method in class akka.persistence.serialization.SnapshotSerializer
Serializes a Snapshot.
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
toBuilder() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
toJournal(Object) - Method in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
 
toJournal(Object) - Method in class akka.persistence.journal.IdentityEventAdapter$
 
toJournal(Object) - Static method in class akka.persistence.journal.IdentityEventAdapter
 
toJournal(Object) - Method in class akka.persistence.journal.NoopReadEventAdapter
 
toJournal(Object) - Method in class akka.persistence.journal.NoopWriteEventAdapter
 
toJournal(Object) - Method in interface akka.persistence.journal.WriteEventAdapter
Convert domain event to journal event type.
toSequenceNr() - Method in class akka.persistence.DeleteMessagesFailure
 
toSequenceNr() - Method in class akka.persistence.DeleteMessagesSuccess
 
toSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.DeleteMessagesTo
 
toSequenceNr() - Method in class akka.persistence.journal.AsyncWriteTarget.ReplayMessages
 
toSequenceNr() - Method in class akka.persistence.journal.leveldb.LeveldbJournal.ReplayTaggedMessages
 
toSequenceNr() - Method in class akka.persistence.JournalProtocol.DeleteMessagesTo
 
toSequenceNr() - Method in class akka.persistence.JournalProtocol.ReplayMessages
 
toSequenceNr() - Method in class akka.persistence.Recovery
 
toSequenceNr() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshot
 
toSequenceNr() - Method in class akka.persistence.SnapshotProtocol.LoadSnapshotResult
 
toString() - Method in class akka.persistence.journal.EventAdapters.CombinedReadEventAdapter
 
toString() - Method in class akka.persistence.journal.EventAdapters
 
toString() - Method in class akka.persistence.journal.IdentityEventAdapters$
 
toString() - Static method in class akka.persistence.journal.IdentityEventAdapters
 
toString() - Method in class akka.persistence.journal.SingleEventSeq
 
total2pf(Function2<S, S, BoxedUnit>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
transform(PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
TransformHelper(PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>) - Constructor for class akka.persistence.fsm.PersistentFSMBase.TransformHelper
 
Transition(ActorRef, S, S, Option<FiniteDuration>) - Constructor for class akka.persistence.fsm.PersistentFSM.Transition
 
Transition$() - Constructor for class akka.persistence.fsm.PersistentFSM.Transition$
 
transitionEvent() - Method in interface akka.persistence.fsm.PersistentFSMBase
 
tryReceivePluginInternal(Object) - Method in interface akka.persistence.snapshot.SnapshotStore
 

U

unapply(Tuple2<S, S>) - Method in class akka.persistence.fsm.PersistentFSM.$minus$greater$
 
unapply(PersistentRepr) - Method in class akka.persistence.PersistentRepr$
extractor of payload and sequenceNr.
unconfirmed() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
 
unconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.AtLeastOnceDeliverySnapshot
 
unconfirmedDeliveries() - Method in class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning
 
UNCONFIRMEDDELIVERIES_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
UnconfirmedDelivery(long, ActorPath, Object) - Constructor for class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery
 
UnconfirmedDelivery$() - Constructor for class akka.persistence.AtLeastOnceDelivery.UnconfirmedDelivery$
 
UnconfirmedWarning(Seq<AtLeastOnceDelivery.UnconfirmedDelivery>) - Constructor for class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning
 
UnconfirmedWarning$() - Constructor for class akka.persistence.AtLeastOnceDelivery.UnconfirmedWarning$
 
Undefined() - Method in class akka.persistence.PersistentRepr$
Plugin API: value of an undefined persistenceId or manifest.
UndefinedId() - Method in class akka.persistence.PersistentRepr$
Plugin API: value of an undefined / identity event adapter.
unhandled(Object) - Method in interface akka.persistence.Eventsourced
 
unstashAll() - Method in interface akka.persistence.Eventsourced
 
unstashFilterPredicate() - Method in interface akka.persistence.Eventsourced
 
UnsubscribeTransitionCallBack(ActorRef) - Constructor for class akka.persistence.fsm.PersistentFSM.UnsubscribeTransitionCallBack
 
UnsubscribeTransitionCallBack$() - Constructor for class akka.persistence.fsm.PersistentFSM.UnsubscribeTransitionCallBack$
 
UntypedPersistentActor - Class in akka.persistence
Java API: an persistent actor - can be used to implement command or event sourcing.
UntypedPersistentActor() - Constructor for class akka.persistence.UntypedPersistentActor
 
UntypedPersistentActorWithAtLeastOnceDelivery - Class in akka.persistence
Java API: Use this class instead of UntypedPersistentActor to send messages with at-least-once delivery semantics to destinations.
UntypedPersistentActorWithAtLeastOnceDelivery() - Constructor for class akka.persistence.UntypedPersistentActorWithAtLeastOnceDelivery
 
UntypedPersistentView - Class in akka.persistence
Java API.
UntypedPersistentView() - Constructor for class akka.persistence.UntypedPersistentView
 
update(String, long, Function1<PersistentRepr, PersistentRepr>) - Method in interface akka.persistence.journal.inmem.InmemMessages
 
update(long, String, boolean, ActorRef, String) - Method in class akka.persistence.PersistentImpl
 
update(long, String, boolean, ActorRef, String) - Method in interface akka.persistence.PersistentRepr
Creates a new copy of this PersistentRepr.
Update - Class in akka.persistence
Instructs a PersistentView to update itself.
Update(boolean, long) - Constructor for class akka.persistence.Update
 
Update$ - Class in akka.persistence
 
Update$() - Constructor for class akka.persistence.Update$
 
updateLastSequenceNr(PersistentRepr) - Method in interface akka.persistence.Eventsourced
 
updateLastSequenceNr(PersistentRepr) - Method in interface akka.persistence.PersistentView
 
using(D) - Method in class akka.persistence.fsm.PersistentFSM.State
Modify state transition descriptor with new state data.
using(PartialFunction<PersistentFSM.State<S, D, E>, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.PersistentFSMBase.TransformHelper
 

V

view() - Method in class akka.persistence.PersistenceSettings
 
view() - Constructor for class akka.persistence.PersistenceSettings.view
 
viewId() - Method in interface akka.persistence.PersistentView
View id is used as identifier for snapshots performed by this PersistentView.
viewSettings() - Method in interface akka.persistence.PersistentView
 

W

Warn$() - Constructor for class akka.persistence.journal.ReplayFilter.Warn$
 
warnAfterNumberOfUnconfirmedAttempts() - Method in interface akka.persistence.AtLeastOnceDeliveryLike
After this number of delivery attempts a AtLeastOnceDelivery.UnconfirmedWarning message will be sent to self.
warnAfterNumberOfUnconfirmedAttempts() - Method in class akka.persistence.PersistenceSettings.atLeastOnceDelivery
 
when(S, PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FSMStateFunctionBuilder<S, D, E>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FiniteDuration, FSMStateFunctionBuilder<S, D, E>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Insert a new StateFunction at the end of the processing chain for the given state.
when(S, FiniteDuration, PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>) - Method in interface akka.persistence.fsm.PersistentFSMBase
Insert a new StateFunction at the end of the processing chain for the given state.
whenUnhandled(FSMStateFunctionBuilder<S, D, E>) - Method in class akka.persistence.fsm.AbstractPersistentFSMBase
Set handler which is called upon reception of unhandled messages.
whenUnhandled(PartialFunction<PersistentFSM.Event<D>, PersistentFSM.State<S, D, E>>) - Method in interface akka.persistence.fsm.PersistentFSMBase
 
withBatch(Function1<org.iq80.leveldb.WriteBatch, R>) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
withIterator(Function1<org.iq80.leveldb.DBIterator, R>) - Method in interface akka.persistence.journal.leveldb.LeveldbStore
 
withManifest(String) - Method in class akka.persistence.PersistentImpl
 
withManifest(String) - Method in interface akka.persistence.PersistentRepr
Creates a new persistent message with the specified manifest.
withNotification(boolean) - Method in class akka.persistence.fsm.PersistentFSM.State
 
withOutputStream(SnapshotMetadata, Function1<OutputStream, BoxedUnit>) - Method in class akka.persistence.snapshot.local.LocalSnapshotStore
 
withPayload(Object) - Method in class akka.persistence.PersistentImpl
 
withPayload(Object) - Method in interface akka.persistence.PersistentRepr
Creates a new persistent message with the specified payload.
withStopReason(PersistentFSM.Reason) - Method in class akka.persistence.fsm.PersistentFSM.State
INTERNAL API.
WriteEventAdapter - Interface in akka.persistence.journal
Facility to convert to specialised data models, as may be required by specialized persistence Journals.
writeIdMapping(String, int) - Method in interface akka.persistence.journal.leveldb.LeveldbIdMapping
 
writeInProgress() - Method in interface akka.persistence.Eventsourced
 
WriteJournalBase - Interface in akka.persistence.journal
 
WriteMessageFailure(PersistentRepr, Throwable, int) - Constructor for class akka.persistence.JournalProtocol.WriteMessageFailure
 
WriteMessageFailure$() - Constructor for class akka.persistence.JournalProtocol.WriteMessageFailure$
 
WriteMessageRejected(PersistentRepr, Throwable, int) - Constructor for class akka.persistence.JournalProtocol.WriteMessageRejected
 
WriteMessageRejected$() - Constructor for class akka.persistence.JournalProtocol.WriteMessageRejected$
 
WriteMessages(Seq<AtomicWrite>) - Constructor for class akka.persistence.journal.AsyncWriteTarget.WriteMessages
 
WriteMessages(Seq<PersistentEnvelope>, ActorRef, int) - Constructor for class akka.persistence.JournalProtocol.WriteMessages
 
WriteMessages$() - Constructor for class akka.persistence.journal.AsyncWriteTarget.WriteMessages$
 
WriteMessages$() - Constructor for class akka.persistence.JournalProtocol.WriteMessages$
 
WriteMessagesFailed(Throwable) - Constructor for class akka.persistence.JournalProtocol.WriteMessagesFailed
 
WriteMessagesFailed$() - Constructor for class akka.persistence.JournalProtocol.WriteMessagesFailed$
 
WriteMessagesSuccessful$() - Constructor for class akka.persistence.JournalProtocol.WriteMessagesSuccessful$
 
WriteMessageSuccess(PersistentRepr, int) - Constructor for class akka.persistence.JournalProtocol.WriteMessageSuccess
 
WriteMessageSuccess$() - Constructor for class akka.persistence.JournalProtocol.WriteMessageSuccess$
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
writeReplace() - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 
writerUuid() - Method in interface akka.persistence.Eventsourced
 
writerUuid() - Method in class akka.persistence.journal.ReplayFilter
 
writerUuid() - Method in class akka.persistence.PersistentImpl
 
writerUuid() - Method in interface akka.persistence.PersistentRepr
Unique identifier of the writing persistent actor.
WRITERUUID_FIELD_NUMBER - Static variable in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
writeTo(CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot.UnconfirmedDelivery
 
writeTo(CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.AtLeastOnceDeliverySnapshot
 
writeTo(CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.AtomicWrite
 
writeTo(CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.PersistentMessage
 
writeTo(CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.PersistentPayload
 
writeTo(CodedOutputStream) - Method in class akka.persistence.serialization.MessageFormats.PersistentStateChangeEvent
 

_

_lastSequenceNr() - Method in interface akka.persistence.Eventsourced
 
_lastSequenceNr() - Method in interface akka.persistence.PersistentView
 
$ A B C D E F G H I J K L M N O P R S T U V W _ 
Skip navigation links