Package com.rabbitmq.stream
Main API for RabbitMQ Stream Java Client.
-
Interface Summary Interface Description AddressResolver API to potentially change resolved node address to connect toBackOffDelayPolicy Contract to determine a delay between attempts of some task.ChunkChecksum API to check the content of message chunks.Codec Codec to encode and decode messages.ConfirmationHandler Callback API to confirm or fail a message.Consumer API to consume messages from a RabbitMQ Stream.ConsumerBuilder API to configure and create aConsumer
.ConsumerBuilder.AutoTrackingStrategy Auto-tracking strategy.ConsumerBuilder.FilterConfiguration Filter configuration.ConsumerBuilder.FlowConfiguration Message flow configuration.ConsumerBuilder.ManualTrackingStrategy Manual tracking strategy.ConsumerFlowStrategy Contract to determine when a subscription provides credits to get more messages.ConsumerFlowStrategy.Context Chunk context.ConsumerFlowStrategy.MessageProcessedCallback Behavior forMessageHandler.Context.processed()
calls.ConsumerUpdateListener An interface for reacting to status changes of single active consumers.ConsumerUpdateListener.Context Information on the status change.Environment TheEnvironment
is the main entry point to a node or a cluster of nodes.EnvironmentBuilder API to configure and create anEnvironment
.EnvironmentBuilder.NettyConfiguration Helper to configure NettyEnvironmentBuilder.TlsConfiguration Helper to configure TLS.Message API for outbound and inbound messages.MessageBuilder API to configure and create aMessage
.MessageBuilder.ApplicationPropertiesBuilder API to set application properties.MessageBuilder.MessageAnnotationsBuilder API to set message annotations.MessageBuilder.PropertiesBuilder API to set message properties.MessageHandler Callback API for inbound messages.MessageHandler.Context Information about the message.ObservationCollector<T> API to instrument operations in the stream client.Producer API to send messages to a RabbitMQ Stream.ProducerBuilder API to create and configure aProducer
.ProducerBuilder.RoutingConfiguration Routing configuration for super streams (partitioned streams).Properties Message properties.RoutingStrategy Strategy to route outbound messages to appropriate streams.RoutingStrategy.Metadata Metadata on the super stream.StreamCreator API to configure and create a stream.StreamCreator.SuperStreamConfiguration Super stream configuration.StreamStats Statistics on a stream.SubscriptionListener Callback interface to customize a subscription.SubscriptionListener.SubscriptionContext Context object for the subscription. -
Class Summary Class Description Address Utility class to represent a hostname and a port.BackOffDelayPolicy.FixedWithInitialDelayAndTimeoutBackOffPolicy BackOffDelayPolicy.FixedWithInitialDelayBackOffPolicy ByteCapacity API to easily configure byte capacities.Codec.EncodedMessage ConfirmationStatus The status to confirm or fail a message.Constants Various constants (response codes, errors, etc)ConsumerFlowStrategy.CreditOnChunkArrivalConsumerFlowStrategy Strategy that provides the specified number of initial credits and a credit on each new chunk.ConsumerFlowStrategy.MessageCountConsumerFlowStrategy Strategy that provides the specified number of initial credits and a credit when the specified ratio of the chunk messages are processed.OffsetSpecification API to specify an offset in a stream. -
Enum Summary Enum Description StreamCreator.LeaderLocator The leader locator strategy. -
Exception Summary Exception Description AuthenticationFailureException Exception to report a failed authentication attempt.ChunkChecksumValidationException Indicate a checksum error for a chunk.NoOffsetException StreamDoesNotExistException Exception to indicate a stream does not exist.StreamException Generic stream exception.StreamNotAvailableException Exception to indicate a stream is not available.