| Constructor and Description | 
|---|
DefaultAMQPMessageConverter(Serializer serializer)
Initializes the AMQPMessageConverter with the given  
serializer, using a PackageRoutingKeyResolver and requesting durable dispatching. | 
DefaultAMQPMessageConverter(Serializer serializer,
                           RoutingKeyResolver routingKeyResolver,
                           boolean durable)
Initializes the AMQPMessageConverter with the given  
serializer, routingKeyResolver and
 requesting durable dispatching when durable is true. | 
| Constructor and Description | 
|---|
EventMessageReader(DataInputStream input,
                  Serializer serializer)
Creates a new EventMessageReader that reads the data from the given  
input and deserializes payload
 and meta data using the given serializer. | 
EventMessageWriter(DataOutput output,
                  Serializer serializer)
Creates a new EventMessageWriter writing data to the specified underlying  
output. | 
JavaSerializationAMQPMessageConverter(Serializer serializer)
Initializes the AMQPMessageConverter with the given  
serializer, using a PackageRoutingKeyResolver and requesting durable dispatching. | 
JavaSerializationAMQPMessageConverter(Serializer serializer,
                                     RoutingKeyResolver routingKeyResolver,
                                     boolean durable)
Initializes the AMQPMessageConverter with the given  
serializer, routingKeyResolver and
 requesting durable dispatching when durable is true. | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SpringAMQPPublisher.setSerializer(Serializer serializer)
Sets the serializer to serialize messages with when sending them to the Exchange. 
 | 
| Constructor and Description | 
|---|
SpringAMQPMessageSource(Serializer serializer)
Initializes an SpringAMQPMessageSource with  
DefaultAMQPMessageConverter using given serializer. | 
| Modifier and Type | Method and Description | 
|---|---|
Serializer | 
AxonAutoConfiguration.eventSerializer(Serializer messageSerializer,
               Serializer generalSerializer,
               RevisionResolver revisionResolver)  | 
Serializer | 
AxonAutoConfiguration.messageSerializer(Serializer genericSerializer,
                 RevisionResolver revisionResolver)  | 
Serializer | 
AxonAutoConfiguration.serializer(RevisionResolver revisionResolver)  | 
| Modifier and Type | Method and Description | 
|---|---|
AMQPMessageConverter | 
AMQPAutoConfiguration.amqpMessageConverter(Serializer eventSerializer,
                    RoutingKeyResolver routingKeyResolver)  | 
Serializer | 
AxonAutoConfiguration.eventSerializer(Serializer messageSerializer,
               Serializer generalSerializer,
               RevisionResolver revisionResolver)  | 
EventStorageEngine | 
JpaAutoConfiguration.eventStorageEngine(Serializer serializer,
                  PersistenceExceptionResolver persistenceExceptionResolver,
                  Serializer eventSerializer,
                  AxonConfiguration configuration,
                  EntityManagerProvider entityManagerProvider,
                  TransactionManager transactionManager)  | 
JGroupsConnectorFactoryBean | 
JGroupsAutoConfiguration.jgroupsConnectorFactoryBean(Serializer messageSerializer,
                           CommandBus localSegment,
                           RoutingStrategy routingStrategy,
                           ConsistentHashChangeListener consistentHashChangeListener)  | 
Serializer | 
AxonAutoConfiguration.messageSerializer(Serializer genericSerializer,
                 RevisionResolver revisionResolver)  | 
JpaSagaStore | 
JpaAutoConfiguration.sagaStore(Serializer serializer,
         EntityManagerProvider entityManagerProvider)  | 
SpringHttpCommandBusConnector | 
SpringCloudAutoConfiguration.springHttpCommandBusConnector(CommandBus localSegment,
                             org.springframework.web.client.RestTemplate restTemplate,
                             Serializer serializer)  | 
TokenStore | 
JpaAutoConfiguration.tokenStore(Serializer serializer,
          EntityManagerProvider entityManagerProvider)  | 
| Modifier and Type | Method and Description | 
|---|---|
Serializer | 
DisruptorConfiguration.getSerializer()
Returns the serializer to perform pre-serialization with, or  
null if no pre-serialization should be
 done. | 
| Modifier and Type | Method and Description | 
|---|---|
DisruptorConfiguration | 
DisruptorConfiguration.setSerializer(Serializer newSerializer)
Returns the serializer to perform pre-serialization with, or  
null if no pre-serialization should be
 done. | 
| Modifier and Type | Method and Description | 
|---|---|
CommandMessage<?> | 
DispatchMessage.getCommandMessage(Serializer serializer)
Returns the CommandMessage wrapped in this Message. 
 | 
Throwable | 
ReplyMessage.getError(Serializer serializer)
Returns the error of the command processing. 
 | 
Object | 
ReplyMessage.getReturnValue(Serializer serializer)
Returns the returnValue of the command processing. 
 | 
| Constructor and Description | 
|---|
DispatchMessage(CommandMessage<?> commandMessage,
               Serializer serializer,
               boolean expectReply)
Initialized a DispatchMessage for the given  
commandMessage, which uses the given
 serializer to deserialize its contents. | 
ReplyMessage(String commandIdentifier,
            boolean success,
            Object returnValue,
            Serializer serializer)
Initializes a ReplyMessage containing a reply to the command with given {commandIdentifier} and given
  
returnValue. | 
| Modifier and Type | Method and Description | 
|---|---|
protected Serializer | 
DefaultConfigurer.defaultSerializer(Configuration config)
Provides the default Serializer implementation. 
 | 
Serializer | 
Configuration.eventSerializer()
Returns the  
Serializer defined in this Configuration to be used for serializing Event Message payload
 and their metadata. | 
Serializer | 
Configuration.messageSerializer()
Returns the  
Serializer defined in this Configuration to be used for serializing Message payloads and
 metadata. | 
default Serializer | 
Configuration.serializer()
Returns the serializer defined in this Configuration 
 | 
| Modifier and Type | Method and Description | 
|---|---|
Configurer | 
DefaultConfigurer.configureEventSerializer(Function<Configuration,Serializer> eventSerializerBuilder)  | 
Configurer | 
Configurer.configureEventSerializer(Function<Configuration,Serializer> eventSerializerBuilder)
Configures the given event Serializer to use in this configuration. 
 | 
Configurer | 
DefaultConfigurer.configureMessageSerializer(Function<Configuration,Serializer> messageSerializerBuilder)  | 
Configurer | 
Configurer.configureMessageSerializer(Function<Configuration,Serializer> messageSerializerBuilder)
Configures the given event Serializer to use in this configuration. 
 | 
default Configurer | 
Configurer.configureSerializer(Function<Configuration,Serializer> serializerBuilder)
Configures the given Serializer to use in this configuration. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
JdbcSagaStore.setSerializer(Serializer serializer)
Sets the Serializer instance to serialize Sagas with. 
 | 
| Constructor and Description | 
|---|
JdbcSagaStore(ConnectionProvider connectionProvider,
             SagaSqlSchema sqldef,
             Serializer serializer)
Initializes a Saga Repository, using given  
connectionProvider to obtain connections to the
 database, and given sqldef to execute SQL statements and serializer to serialize
 Sagas. | 
| Modifier and Type | Method and Description | 
|---|---|
protected AbstractSagaEntry<?> | 
JpaSagaStore.createSagaEntry(Object saga,
               String sagaIdentifier,
               Serializer serializer)
Intended for clients to override. 
 | 
| Constructor and Description | 
|---|
AbstractSagaEntry(Object saga,
                 String sagaIdentifier,
                 Serializer serializer,
                 Class<T> contentType)
Constructs a new SagaEntry for the given  
saga. | 
JpaSagaStore(Serializer serializer,
            EntityManagerProvider entityManagerProvider)
Initializes a Saga Repository with the given  
serializer and entityManagerProvider. | 
SagaEntry(T saga,
         String sagaIdentifier,
         Serializer serializer)
Constructs a new SagaEntry for the given  
saga. | 
| Modifier and Type | Method and Description | 
|---|---|
TrackingToken | 
AbstractTokenEntry.getToken(Serializer serializer)
Returns the token, deserializing it with given  
serializer | 
void | 
GenericTokenEntry.updateToken(TrackingToken token,
           Serializer serializer)  | 
abstract void | 
AbstractTokenEntry.updateToken(TrackingToken token,
           Serializer serializer)
Update this entry with the given  
token, serializing it using given serializer. | 
protected void | 
AbstractTokenEntry.updateToken(TrackingToken token,
           Serializer serializer,
           Class<T> contentType)
Update the token data to the given  
token, using given serializer to serialize it to the given
 contentType. | 
| Constructor and Description | 
|---|
AbstractTokenEntry(TrackingToken token,
                  Serializer serializer,
                  Class<T> contentType)
Initializes a new token entry for given  
token, process and segment. | 
GenericTokenEntry(TrackingToken token,
                 Serializer serializer,
                 Class<T> contentType,
                 String processorName,
                 int segment)
Initializes a new token entry for given  
token, process and segment. | 
| Constructor and Description | 
|---|
JdbcTokenStore(ConnectionProvider connectionProvider,
              Serializer serializer)
Initialize the JpaTokenStore with given resources. 
 | 
JdbcTokenStore(ConnectionProvider connectionProvider,
              Serializer serializer,
              TokenSchema schema,
              TemporalAmount claimTimeout,
              String nodeId,
              Class<?> contentType)
Initialize the JpaTokenStore with given resources. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TokenEntry.updateToken(TrackingToken token,
           Serializer serializer)  | 
| Constructor and Description | 
|---|
JpaTokenStore(EntityManagerProvider entityManagerProvider,
             Serializer serializer)
Initializes a token store with given  
entityManagerProvider and serializer. | 
JpaTokenStore(EntityManagerProvider entityManagerProvider,
             Serializer serializer,
             TemporalAmount claimTimeout,
             String nodeId)
Initialize the JpaTokenStore with given resources. 
 | 
TokenEntry(String processorName,
          int segment,
          TrackingToken token,
          Serializer serializer)
Initializes a new token entry for given  
token, processorName and segment. | 
| Modifier and Type | Method and Description | 
|---|---|
Serializer | 
AbstractEventStorageEngine.getEventSerializer()
Get the serializer used by this storage engine when storing and retrieving events. 
 | 
Serializer | 
AbstractEventStorageEngine.getSerializer()
Get the serializer used by this storage engine when storing and retrieving snapshots. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected abstract void | 
AbstractEventStorageEngine.appendEvents(List<? extends EventMessage<?>> events,
            Serializer serializer)
Append given  
events to the backing database. | 
protected abstract void | 
AbstractEventStorageEngine.storeSnapshot(DomainEventMessage<?> snapshot,
             Serializer serializer)
Store the given  
snapshot of an Aggregate. | 
static DomainEventStream | 
EventUtils.upcastAndDeserializeDomainEvents(Stream<? extends DomainEventData<?>> eventEntryStream,
                                Serializer serializer,
                                EventUpcaster upcasterChain,
                                boolean skipUnknownTypes)
Upcasts and deserializes the given  
eventEntryStream using the given serializer and
 upcasterChain. | 
static Stream<TrackedEventMessage<?>> | 
EventUtils.upcastAndDeserializeTrackedEvents(Stream<? extends TrackedEventData<?>> eventEntryStream,
                                 Serializer serializer,
                                 EventUpcaster upcasterChain,
                                 boolean skipUnknownTypes)
Upcasts and deserializes the given  
eventEntryStream using the given serializer and
 upcasterChain. | 
| Constructor and Description | 
|---|
AbstractDomainEventEntry(DomainEventMessage<?> eventMessage,
                        Serializer serializer,
                        Class<T> contentType)
Construct a new event entry from a published domain event message to enable storing the event or sending it to a
 remote location. 
 | 
AbstractEventEntry(EventMessage<?> eventMessage,
                  Serializer serializer,
                  Class<T> contentType)
Construct a new event entry from a published event message to enable storing the event or sending it to a remote
 location. 
 | 
AbstractEventStorageEngine(Serializer serializer,
                          EventUpcaster upcasterChain,
                          PersistenceExceptionResolver persistenceExceptionResolver)
Deprecated. 
 
The constructor which supplies an additional  
Serializer for
 events should be used. | 
AbstractEventStorageEngine(Serializer serializer,
                          EventUpcaster upcasterChain,
                          PersistenceExceptionResolver persistenceExceptionResolver,
                          Serializer eventSerializer)
Initializes an EventStorageEngine with given  
serializer, upcasterChain and persistenceExceptionResolver. | 
AbstractSequencedDomainEventEntry(DomainEventMessage<?> eventMessage,
                                 Serializer serializer,
                                 Class<T> contentType)
Construct a new default domain event entry from a published domain event message to enable storing the event or
 sending it to a remote location. 
 | 
AbstractSnapshotEventEntry(DomainEventMessage<?> eventMessage,
                          Serializer serializer,
                          Class<T> contentType)
Construct a new event entry from a published domain event message to enable storing the event or sending it to a
 remote location. 
 | 
BatchingEventStorageEngine(Serializer serializer,
                          EventUpcaster upcasterChain,
                          PersistenceExceptionResolver persistenceExceptionResolver,
                          Serializer eventSerializer,
                          Integer batchSize)
Initializes an EventStorageEngine with given  
serializer, upcasterChain, persistenceExceptionResolver, eventSerializer and batchSize. | 
| Modifier and Type | Method and Description | 
|---|---|
protected void | 
JdbcEventStorageEngine.appendEvents(List<? extends EventMessage<?>> events,
            Serializer serializer)  | 
protected PreparedStatement | 
JdbcEventStorageEngine.appendSnapshot(Connection connection,
              DomainEventMessage<?> snapshot,
              Serializer serializer)
Creates a statement to append the given  
snapshot to the event storage using given connection to
 the database. | 
protected void | 
JdbcEventStorageEngine.storeSnapshot(DomainEventMessage<?> snapshot,
             Serializer serializer)  | 
| Constructor and Description | 
|---|
JdbcEventStorageEngine(Serializer serializer,
                      EventUpcaster upcasterChain,
                      PersistenceExceptionResolver persistenceExceptionResolver,
                      ConnectionProvider connectionProvider,
                      TransactionManager transactionManager)
Initializes an EventStorageEngine that uses JDBC to store and load events using the default  
EventSchema. | 
JdbcEventStorageEngine(Serializer serializer,
                      EventUpcaster upcasterChain,
                      PersistenceExceptionResolver persistenceExceptionResolver,
                      Serializer eventSerializer,
                      ConnectionProvider connectionProvider,
                      TransactionManager transactionManager)
Initializes an EventStorageEngine that uses JDBC to store and load events using the default  
EventSchema. | 
JdbcEventStorageEngine(Serializer serializer,
                      EventUpcaster upcasterChain,
                      PersistenceExceptionResolver persistenceExceptionResolver,
                      Serializer eventSerializer,
                      Integer batchSize,
                      ConnectionProvider connectionProvider,
                      TransactionManager transactionManager,
                      Class<?> dataType,
                      EventSchema schema,
                      Integer maxGapOffset,
                      Long lowestGlobalSequence)
Initializes an EventStorageEngine that uses JDBC to store and load events. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected void | 
JpaEventStorageEngine.appendEvents(List<? extends EventMessage<?>> events,
            Serializer serializer)  | 
protected Object | 
JpaEventStorageEngine.createEventEntity(EventMessage<?> eventMessage,
                 Serializer serializer)
Returns a Jpa event entity for given  
eventMessage. | 
protected Object | 
JpaEventStorageEngine.createSnapshotEntity(DomainEventMessage<?> snapshot,
                    Serializer serializer)
Returns a Jpa snapshot entity for given  
snapshot of an aggregate. | 
protected void | 
JpaEventStorageEngine.storeSnapshot(DomainEventMessage<?> snapshot,
             Serializer serializer)  | 
| Constructor and Description | 
|---|
DomainEventEntry(DomainEventMessage<?> eventMessage,
                Serializer serializer)
Construct a new default domain event entry from a published domain event message to enable storing the event or
 sending it to a remote location. 
 | 
JpaEventStorageEngine(Serializer serializer,
                     EventUpcaster upcasterChain,
                     DataSource dataSource,
                     EntityManagerProvider entityManagerProvider,
                     TransactionManager transactionManager)
Initializes an EventStorageEngine that uses JPA to store and load events. 
 | 
JpaEventStorageEngine(Serializer serializer,
                     EventUpcaster upcasterChain,
                     DataSource dataSource,
                     Serializer eventSerializer,
                     EntityManagerProvider entityManagerProvider,
                     TransactionManager transactionManager)
Initializes an EventStorageEngine that uses JPA to store and load events. 
 | 
JpaEventStorageEngine(Serializer serializer,
                     EventUpcaster upcasterChain,
                     PersistenceExceptionResolver persistenceExceptionResolver,
                     EntityManagerProvider entityManagerProvider,
                     TransactionManager transactionManager)
Initializes an EventStorageEngine that uses JPA to store and load events. 
 | 
JpaEventStorageEngine(Serializer serializer,
                     EventUpcaster upcasterChain,
                     PersistenceExceptionResolver persistenceExceptionResolver,
                     Serializer eventSerializer,
                     EntityManagerProvider entityManagerProvider,
                     TransactionManager transactionManager)
Initializes an EventStorageEngine that uses JPA to store and load events. 
 | 
JpaEventStorageEngine(Serializer serializer,
                     EventUpcaster upcasterChain,
                     PersistenceExceptionResolver persistenceExceptionResolver,
                     Serializer eventSerializer,
                     Integer batchSize,
                     EntityManagerProvider entityManagerProvider,
                     TransactionManager transactionManager,
                     Long lowestGlobalSequence,
                     Integer maxGapOffset,
                     boolean explicitFlush)
Initializes an EventStorageEngine that uses JPA to store and load events. 
 | 
SnapshotEventEntry(DomainEventMessage<?> eventMessage,
                  Serializer serializer)
Construct a new default snapshot event entry from an aggregate. 
 | 
| Constructor and Description | 
|---|
JGroupsConnector(CommandBus localSegment,
                org.jgroups.JChannel channel,
                String clusterName,
                Serializer serializer)
Initialize the connector using the given  
localSegment to handle commands on the local node, and the given
 channel to connect between nodes. | 
JGroupsConnector(CommandBus localSegment,
                org.jgroups.JChannel channel,
                String clusterName,
                Serializer serializer,
                RoutingStrategy routingStrategy)
Initialize the connector using the given  
localSegment to handle commands on the local node, and the given
 channel to connect between nodes. | 
JGroupsConnector(CommandBus localSegment,
                org.jgroups.JChannel channel,
                String clusterName,
                Serializer serializer,
                RoutingStrategy routingStrategy,
                ConsistentHashChangeListener consistentHashChangeListener)
Initialize the connector using the given  
localSegment to handle commands on the local node, and the given
 channel to connect between nodes. | 
JGroupsDispatchMessage(CommandMessage<?> commandMessage,
                      Serializer serializer,
                      boolean expectReply)
Initialize a JGroupsDispatchMessage for the given  
commandMessage, to be serialized using given
 serializer. | 
JGroupsReplyMessage(String commandIdentifier,
                   boolean success,
                   Object returnValue,
                   Serializer serializer)
Initializes a JGroupsReplyMessage containing a reply to the command with given {commandIdentifier} and given
  
returnValue. | 
| Modifier and Type | Method and Description | 
|---|---|
<S> SerializedObject<S> | 
MessageDecorator.serializeMetaData(Serializer serializer,
                 Class<S> expectedRepresentation)  | 
<S> SerializedObject<S> | 
MessageDecorator.serializePayload(Serializer serializer,
                Class<S> expectedRepresentation)  | 
| Modifier and Type | Method and Description | 
|---|---|
T | 
SagaEntry.getSaga(Serializer serializer)
Returns the Saga instance stored in this entry. 
 | 
| Constructor and Description | 
|---|
MongoSagaStore(MongoTemplate mongoTemplate,
              Serializer serializer)
Initializes the Repository, using given  
mongoTemplate to access the collections containing the
 stored Saga instances, serializing Saga instances using the given serializer. | 
SagaEntry(String identifier,
         T saga,
         Set<AssociationValue> associationValues,
         Serializer serializer)
Constructs a new SagaEntry for the given  
saga. | 
| Modifier and Type | Method and Description | 
|---|---|
protected void | 
MongoEventStorageEngine.appendEvents(List<? extends EventMessage<?>> events,
            Serializer serializer)  | 
void | 
StorageStrategy.appendEvents(com.mongodb.client.MongoCollection<org.bson.Document> eventCollection,
            List<? extends EventMessage<?>> events,
            Serializer serializer)
Appends the given list of  
events to the given eventCollection. | 
void | 
AbstractMongoEventStorageStrategy.appendEvents(com.mongodb.client.MongoCollection<org.bson.Document> eventCollection,
            List<? extends EventMessage<?>> events,
            Serializer serializer)  | 
void | 
StorageStrategy.appendSnapshot(com.mongodb.client.MongoCollection<org.bson.Document> snapshotCollection,
              DomainEventMessage<?> snapshot,
              Serializer serializer)
Append the given aggregate  
snapshot to the snapshotCollection. | 
void | 
AbstractMongoEventStorageStrategy.appendSnapshot(com.mongodb.client.MongoCollection<org.bson.Document> snapshotCollection,
              DomainEventMessage<?> snapshot,
              Serializer serializer)  | 
protected abstract Stream<org.bson.Document> | 
AbstractMongoEventStorageStrategy.createEventDocuments(List<? extends EventMessage<?>> events,
                    Serializer serializer)
Returns a stream of Mongo documents that represent the given batch of events. 
 | 
protected abstract org.bson.Document | 
AbstractMongoEventStorageStrategy.createSnapshotDocument(DomainEventMessage<?> snapshot,
                      Serializer serializer)
Returns a Mongo document for given snapshot event. 
 | 
protected void | 
MongoEventStorageEngine.storeSnapshot(DomainEventMessage<?> snapshot,
             Serializer serializer)  | 
| Constructor and Description | 
|---|
MongoEventStorageEngine(Serializer serializer,
                       EventUpcaster upcasterChain,
                       Integer batchSize,
                       MongoTemplate template,
                       StorageStrategy storageStrategy)
Initializes an EventStorageEngine that uses Mongo to store and load events. 
 | 
MongoEventStorageEngine(Serializer serializer,
                       EventUpcaster upcasterChain,
                       MongoTemplate template,
                       StorageStrategy storageStrategy)
Initializes an EventStorageEngine that uses Mongo to store and load events. 
 | 
MongoEventStorageEngine(Serializer serializer,
                       EventUpcaster upcasterChain,
                       PersistenceExceptionResolver persistenceExceptionResolver,
                       Serializer eventSerializer,
                       Integer batchSize,
                       MongoTemplate template,
                       StorageStrategy storageStrategy)
Initializes an EventStorageEngine that uses Mongo to store and load events. 
 | 
MongoEventStorageEngine(Serializer serializer,
                       EventUpcaster upcasterChain,
                       Serializer eventSerializer,
                       Integer batchSize,
                       MongoTemplate template,
                       StorageStrategy storageStrategy)
Initializes an EventStorageEngine that uses Mongo to store and load events. 
 | 
MongoEventStorageEngine(Serializer serializer,
                       EventUpcaster upcasterChain,
                       Serializer eventSerializer,
                       MongoTemplate template,
                       StorageStrategy storageStrategy)
Initializes an EventStorageEngine that uses Mongo to store and load events. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected Stream<org.bson.Document> | 
DocumentPerCommitStorageStrategy.createEventDocuments(List<? extends EventMessage<?>> events,
                    Serializer serializer)  | 
protected org.bson.Document | 
DocumentPerCommitStorageStrategy.createSnapshotDocument(DomainEventMessage<?> snapshot,
                      Serializer serializer)  | 
| Constructor and Description | 
|---|
CommitEntry(List<? extends DomainEventMessage<?>> events,
           Serializer serializer)
Constructor used to create a new event entry to store in Mongo. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected Stream<org.bson.Document> | 
DocumentPerEventStorageStrategy.createEventDocuments(List<? extends EventMessage<?>> events,
                    Serializer serializer)  | 
protected org.bson.Document | 
DocumentPerEventStorageStrategy.createSnapshotDocument(DomainEventMessage<?> snapshot,
                      Serializer serializer)  | 
| Constructor and Description | 
|---|
EventEntry(DomainEventMessage<?> event,
          Serializer serializer)
Constructor used to create a new event entry to store in Mongo. 
 | 
| Constructor and Description | 
|---|
MongoTokenStore(MongoTemplate mongoTemplate,
               Serializer serializer)
Creates a MongoTokenStore with a default claim timeout of 10 seconds, a default owner identifier and a default
 content type. 
 | 
MongoTokenStore(MongoTemplate mongoTemplate,
               Serializer serializer,
               TemporalAmount claimTimeout,
               String nodeId,
               Class<?> contentType)
Creates a MongoTokenStore by using the given values. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DBObjectXStreamSerializer
XStream based serializer implementation that serializes objects into a Binary JSON structure. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractXStreamSerializer
Abstract implementation for XStream based serializers. 
 | 
class  | 
JavaSerializer
Serializer implementation that uses Java serialization to serialize and deserialize object instances. 
 | 
class  | 
MessageSerializer
Wrapper around a serializer that provides  
SerializationAware support. | 
| Modifier and Type | Method and Description | 
|---|---|
Serializer | 
LazyDeserializingObject.getSerializer()
Returns the serializer to deserialize this object 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static <T> SerializedObject<T> | 
MessageSerializer.serializeMetaData(Message<?> message,
                 Serializer serializer,
                 Class<T> expectedRepresentation)
Utility method that serializes the meta data of the given  
message using given
 serializer and expectedRepresentation. | 
<R> SerializedObject<R> | 
SerializedMessage.serializeMetaData(Serializer serializer,
                 Class<R> expectedRepresentation)  | 
<T> SerializedObject<T> | 
SerializedObjectHolder.serializeMetaData(Serializer serializer,
                 Class<T> expectedRepresentation)  | 
<T> SerializedObject<T> | 
SerializationAware.serializeMetaData(Serializer serializer,
                 Class<T> expectedRepresentation)
Serialize the meta data of this message using given  
serializer, using given
 expectedRepresentation. | 
static <T> SerializedObject<T> | 
MessageSerializer.serializePayload(Message<?> message,
                Serializer serializer,
                Class<T> expectedRepresentation)
Utility method that serializes the payload of the given  
message using given serializer
 and expectedRepresentation. | 
<R> SerializedObject<R> | 
SerializedMessage.serializePayload(Serializer serializer,
                Class<R> expectedRepresentation)  | 
<T> SerializedObject<T> | 
SerializedObjectHolder.serializePayload(Serializer serializer,
                Class<T> expectedRepresentation)  | 
<T> SerializedObject<T> | 
SerializationAware.serializePayload(Serializer serializer,
                Class<T> expectedRepresentation)
Serialize the payload of this message using given  
serializer, using given
 expectedRepresentation. | 
| Constructor and Description | 
|---|
LazyDeserializingObject(SerializedObject<?> serializedObject,
                       Serializer serializer)
Creates an instance which will deserialize given  
serializedObject upon request. | 
LazyDeserializingObject(Supplier<SerializedObject<?>> serializedObjectSupplier,
                       SerializedType serializedType,
                       Serializer serializer)
Creates an instance which will get the supplied SerializedObject and deserialize it upon request. 
 | 
MessageSerializer(Serializer serializer)
Initializes the MessageSerializer as a wrapper around the given serializer. 
 | 
SerializedMessage(String identifier,
                 SerializedObject<?> serializedPayload,
                 SerializedObject<?> serializedMetaData,
                 Serializer serializer)
Initializes a  
SerializedMessage with given identifier from the given serialized payload and
 metadata. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
JacksonSerializer
Serializer implementation that uses Jackson to serialize objects into a JSON format. 
 | 
| Constructor and Description | 
|---|
InitialEventRepresentation(EventData<?> eventData,
                          Serializer serializer)
Initializes an  
InitialEventRepresentation from the given eventData. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
XStreamSerializer
Serializer that uses XStream to serialize and deserialize arbitrary objects. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected JGroupsConnector | 
JGroupsConnectorFactoryBean.instantiateConnector(CommandBus localSegment,
                    org.jgroups.JChannel channel,
                    String clusterName,
                    Serializer serializer,
                    RoutingStrategy routingStrategy)  | 
void | 
JGroupsConnectorFactoryBean.setSerializer(Serializer serializer)
Sets the serializer used to serialize events before they are dispatched to the destination. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
Serializer | 
AxonConfiguration.eventSerializer()  | 
Serializer | 
AxonConfiguration.messageSerializer()  | 
| Modifier and Type | Method and Description | 
|---|---|
Predicate<? super CommandMessage<?>> | 
MessageRoutingInformation.getCommandFilter(Serializer serializer)  | 
CommandMessage<C> | 
SpringHttpDispatchMessage.getCommandMessage(Serializer serializer)  | 
R | 
SpringHttpReplyMessage.getReturnValue(Serializer serializer)  | 
| Constructor and Description | 
|---|
MessageRoutingInformation(int loadFactor,
                         Predicate<? super CommandMessage<?>> commandFilter,
                         Serializer serializer)  | 
SpringHttpCommandBusConnector(CommandBus localCommandBus,
                             org.springframework.web.client.RestOperations restOperations,
                             Serializer serializer)  | 
SpringHttpDispatchMessage(CommandMessage<?> commandMessage,
                         Serializer serializer,
                         boolean expectReply)
Initialize a SpringHttpDispatchMessage for the given  
commandMessage, to be serialized using given
 serializer. | 
SpringHttpReplyMessage(String commandIdentifier,
                      boolean success,
                      Object returnValue,
                      Serializer serializer)
Initializes a SpringHttpReplyMessage containing a reply to the command with given {commandIdentifier} and given
  
returnValue. | 
Copyright © 2010–2018. All rights reserved.