Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- absoluteExpiryTime(long) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the expiry time.
- add(UnsignedInteger) - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- add(Message) - Method in class com.rabbitmq.stream.impl.MessageBatch
- addData(byte[]) - Method in class com.rabbitmq.stream.codec.WrapperMessageBuilder
- addData(byte[]) - Method in interface com.rabbitmq.stream.MessageBuilder
-
Set binary data of the message.
- Address - Class in com.rabbitmq.stream
-
Utility class to represent a hostname and a port.
- Address(String, int) - Constructor for class com.rabbitmq.stream.Address
- addressResolver(AddressResolver) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
An
AddressResolver
to potentially change resolved node address to connect to. - addressResolver(AddressResolver) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- AddressResolver - Interface in com.rabbitmq.stream
-
API to potentially change resolved node address to connect to
- annotate(String, Object) - Method in interface com.rabbitmq.stream.Message
-
Add a message annotation to the message.
- ANONYMOUS - Static variable in class com.rabbitmq.stream.sasl.DefaultSaslConfiguration
- AnonymousSaslMechanism - Class in com.rabbitmq.stream.sasl
-
The
ANONYMOUS
SaslMechanism
. - AnonymousSaslMechanism() - Constructor for class com.rabbitmq.stream.sasl.AnonymousSaslMechanism
- applicationProperties() - Method in class com.rabbitmq.stream.codec.WrapperMessageBuilder
- applicationProperties() - Method in interface com.rabbitmq.stream.MessageBuilder
-
The builder to set application properties.
- argument(String, String) - Method in interface com.rabbitmq.stream.StreamCreator
-
Set an argument for the stream creation.
- AuthenticationFailureException - Exception Class in com.rabbitmq.stream
-
Exception to report a failed authentication attempt.
- AuthenticationFailureException(String) - Constructor for exception class com.rabbitmq.stream.AuthenticationFailureException
- AuthenticationFailureException(String, short) - Constructor for exception class com.rabbitmq.stream.AuthenticationFailureException
- autoTrackingStrategy() - Method in interface com.rabbitmq.stream.ConsumerBuilder
B
- B(long) - Static method in class com.rabbitmq.stream.ByteCapacity
- BackOffDelayPolicy - Interface in com.rabbitmq.stream
-
Contract to determine a delay between attempts of some task.
- BackOffDelayPolicy.FixedWithInitialDelayAndTimeoutBackOffPolicy - Class in com.rabbitmq.stream
- BackOffDelayPolicy.FixedWithInitialDelayBackOffPolicy - Class in com.rabbitmq.stream
- BALANCED - Enum constant in enum com.rabbitmq.stream.StreamCreator.LeaderLocator
-
The leader will be the node hosting the minimum number of stream leaders, if there are overall less than 1000 queues, or a random node, if there are overall more than 1000 queues.
- batchPublishingDelay(Duration) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
Period to send a batch of messages.
- batchSize(int) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
The maximum number of messages to accumulate before sending them to the broker.
- bigIntegerValue() - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- bindingKeys(String...) - Method in interface com.rabbitmq.stream.StreamCreator.SuperStreamConfiguration
-
The binding keys to use when declaring the super stream partitions.
- bootstrapCustomizer(Consumer<Bootstrap>) - Method in interface com.rabbitmq.stream.EnvironmentBuilder.NettyConfiguration
-
An extension point to customize Netty's
Bootstrap
s used to configure connections. - bootstrapCustomizer(Consumer<Bootstrap>) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- Broker(String, int) - Constructor for class com.rabbitmq.stream.impl.Client.Broker
- brokerVersion() - Method in class com.rabbitmq.stream.impl.Client
- build() - Method in class com.rabbitmq.stream.codec.WrapperMessageBuilder
- build() - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
Create the configured
Consumer
- build() - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Create the
Environment
instance. - build() - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- build() - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- build() - Method in interface com.rabbitmq.stream.MessageBuilder
-
Create the message.
- build() - Method in class com.rabbitmq.stream.observation.micrometer.MicrometerObservationCollectorBuilder
-
Create the Micrometer
ObservationCollector
. - build() - Method in interface com.rabbitmq.stream.ProducerBuilder
-
Create the
Producer
instance. - builder() - Method in interface com.rabbitmq.stream.ConsumerBuilder.AutoTrackingStrategy
-
Go back to the builder.
- builder() - Method in interface com.rabbitmq.stream.ConsumerBuilder.FilterConfiguration
-
Go back to the builder.
- builder() - Method in interface com.rabbitmq.stream.ConsumerBuilder.FlowConfiguration
-
Go back to the builder.
- builder() - Method in interface com.rabbitmq.stream.ConsumerBuilder.ManualTrackingStrategy
-
Go back to the builder.
- builder() - Static method in interface com.rabbitmq.stream.Environment
-
Create a builder to configure and create an
Environment
- byteBufAllocator(ByteBufAllocator) - Method in interface com.rabbitmq.stream.EnvironmentBuilder.NettyConfiguration
-
Netty's
ByteBuf
allocator. - byteBufAllocator(ByteBufAllocator) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- ByteCapacity - Class in com.rabbitmq.stream
-
API to easily configure byte capacities.
- byteValue() - Method in class com.rabbitmq.stream.amqp.UnsignedByte
C
- channelCustomizer(Consumer<Channel>) - Method in interface com.rabbitmq.stream.EnvironmentBuilder.NettyConfiguration
-
An extension point to customize Netty's
Channel
s used for connections. - channelCustomizer(Consumer<Channel>) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- checkInterval(Duration) - Method in interface com.rabbitmq.stream.ConsumerBuilder.ManualTrackingStrategy
-
Interval to check if the last requested stored offset has been actually stored.
- checksum(ByteBuf, long, long) - Method in interface com.rabbitmq.stream.ChunkChecksum
- chunk(int) - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- chunk(int) - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- chunk(int) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- chunk(int) - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
- chunkChecksum(ChunkChecksum) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The checksum strategy used for chunk checksum.
- chunkChecksum(ChunkChecksum) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- chunkChecksum(ChunkChecksum) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- ChunkChecksum - Interface in com.rabbitmq.stream
-
API to check the content of message chunks.
- ChunkChecksumValidationException - Exception Class in com.rabbitmq.stream
-
Indicate a checksum error for a chunk.
- ChunkChecksumValidationException(long, long) - Constructor for exception class com.rabbitmq.stream.ChunkChecksumValidationException
- chunkListener(Client.ChunkListener) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- chunkSize - Variable in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- Client - Class in com.rabbitmq.stream.impl
-
This is low-level client API to communicate with the broker.
- Client() - Constructor for class com.rabbitmq.stream.impl.Client
- Client(Client.ClientParameters) - Constructor for class com.rabbitmq.stream.impl.Client
- CLIENT_CLOSE - Enum constant in enum com.rabbitmq.stream.impl.Client.ShutdownContext.ShutdownReason
- CLIENT_LOCAL - Enum constant in enum com.rabbitmq.stream.StreamCreator.LeaderLocator
-
The stream leader will be on the node the client is connected to.
- Client.Broker - Class in com.rabbitmq.stream.impl
- Client.ChunkListener - Interface in com.rabbitmq.stream.impl
- Client.ClientParameters - Class in com.rabbitmq.stream.impl
- Client.ConsumerUpdateListener - Interface in com.rabbitmq.stream.impl
- Client.CreditNotification - Interface in com.rabbitmq.stream.impl
- Client.MessageIgnoredListener - Interface in com.rabbitmq.stream.impl
- Client.MessageListener - Interface in com.rabbitmq.stream.impl
- Client.MetadataListener - Interface in com.rabbitmq.stream.impl
- Client.OutboundEntityMappingCallback - Interface in com.rabbitmq.stream.impl
- Client.PublishConfirmListener - Interface in com.rabbitmq.stream.impl
- Client.PublishErrorListener - Interface in com.rabbitmq.stream.impl
- Client.QueryOffsetResponse - Class in com.rabbitmq.stream.impl
- Client.Response - Class in com.rabbitmq.stream.impl
- Client.ShutdownContext - Class in com.rabbitmq.stream.impl
- Client.ShutdownContext.ShutdownReason - Enum in com.rabbitmq.stream.impl
- Client.ShutdownListener - Interface in com.rabbitmq.stream.impl
- Client.StreamMetadata - Class in com.rabbitmq.stream.impl
- Client.StreamParametersBuilder - Class in com.rabbitmq.stream.impl
- ClientParameters() - Constructor for class com.rabbitmq.stream.impl.Client.ClientParameters
- clientProperties(Map<String, String>) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Custom client properties to add to default client properties.
- clientProperties(Map<String, String>) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- clientProperties(Map<String, String>) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- ClientProperties - Class in com.rabbitmq.stream.impl
- clientProperty(String, String) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Add a custom client properties to default client properties.
- clientProperty(String, String) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- clientProperty(String, String) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- close() - Method in interface com.rabbitmq.stream.Consumer
-
Close the consumer.
- close() - Method in interface com.rabbitmq.stream.Environment
-
Close the environment and its resources.
- close() - Method in class com.rabbitmq.stream.impl.Client
- close() - Method in interface com.rabbitmq.stream.Producer
-
Close the producer.
- closeConnection() - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- closeConnection() - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- closeConnection() - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- closeConnection() - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
- code() - Method in enum com.rabbitmq.stream.compression.Compression
- code() - Method in interface com.rabbitmq.stream.compression.CompressionCodec
-
Return the code for this type of codec.
- code() - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressGzipCompressionCodec
- code() - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressLz4CompressionCodec
- code() - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressSnappyCompressionCodec
- code() - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressZstdCompressionCodec
- code() - Method in class com.rabbitmq.stream.compression.CompressionUtils.GzipCompressionCodec
- code() - Method in class com.rabbitmq.stream.compression.CompressionUtils.Lz4JavaCompressionCodec
- code() - Method in class com.rabbitmq.stream.compression.CompressionUtils.XerialSnappyCompressionCodec
- code() - Method in class com.rabbitmq.stream.compression.CompressionUtils.ZstdJniCompressionCodec
- CODE_MESSAGE_ENQUEUEING_FAILED - Static variable in class com.rabbitmq.stream.Constants
- CODE_NO_ROUTE_FOUND - Static variable in class com.rabbitmq.stream.Constants
- CODE_PRODUCER_CLOSED - Static variable in class com.rabbitmq.stream.Constants
- CODE_PRODUCER_NOT_AVAILABLE - Static variable in class com.rabbitmq.stream.Constants
- CODE_PUBLISH_CONFIRM_TIMEOUT - Static variable in class com.rabbitmq.stream.Constants
- codec(Codec) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The AMQP 1.0 codec used to encode and decode AMQP 1.0 messages.
- codec(Codec) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- codec(Codec) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- Codec - Interface in com.rabbitmq.stream
-
Codec to encode and decode messages.
- Codec.EncodedMessage - Class in com.rabbitmq.stream
- com.rabbitmq.stream - package com.rabbitmq.stream
-
Main API for RabbitMQ Stream Java Client.
- com.rabbitmq.stream.amqp - package com.rabbitmq.stream.amqp
-
Classes for AMQP 1.0 support.
- com.rabbitmq.stream.codec - package com.rabbitmq.stream.codec
-
Implementations of AMQP 1.0
Codec
. - com.rabbitmq.stream.compression - package com.rabbitmq.stream.compression
-
Compression codec utilities to compress and decompress sub-entries.
- com.rabbitmq.stream.impl - package com.rabbitmq.stream.impl
-
Implementation-specific, non-public interfaces and classes of the RabbitMQ Stream Java Client.
- com.rabbitmq.stream.metrics - package com.rabbitmq.stream.metrics
-
Package for metrics collection utilities.
- com.rabbitmq.stream.observation.micrometer - package com.rabbitmq.stream.observation.micrometer
- com.rabbitmq.stream.sasl - package com.rabbitmq.stream.sasl
-
SASL API for the RabbitMQ Stream Java Client.
- COMMAND_CLOSE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_CONSUMER_UPDATE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_CREATE_STREAM - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_CREATE_SUPER_STREAM - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_CREDIT - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_DECLARE_PUBLISHER - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_DELETE_PUBLISHER - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_DELETE_STREAM - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_DELETE_SUPER_STREAM - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_DELIVER - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_EXCHANGE_COMMAND_VERSIONS - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_HEARTBEAT - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_METADATA - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_METADATA_UPDATE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_OPEN - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_PARTITIONS - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_PEER_PROPERTIES - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_PUBLISH - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_PUBLISH_CONFIRM - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_PUBLISH_ERROR - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_QUERY_OFFSET - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_QUERY_PUBLISHER_SEQUENCE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_ROUTE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_SASL_AUTHENTICATE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_SASL_HANDSHAKE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_STORE_OFFSET - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_STREAM_STATS - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_SUBSCRIBE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_TUNE - Static variable in class com.rabbitmq.stream.Constants
- COMMAND_UNSUBSCRIBE - Static variable in class com.rabbitmq.stream.Constants
- committedChunkId() - Method in interface com.rabbitmq.stream.MessageHandler.Context
-
The ID (offset) of the committed chunk (block of messages) in the stream.
- committedChunkId() - Method in interface com.rabbitmq.stream.StreamStats
-
The ID (offset) of the committed chunk (block of messages) in the stream.
- CommonsCompressCompressionCodecFactory - Class in com.rabbitmq.stream.compression
-
CompressionCodecFactory
creating codecs using Apache Commons Compress implementations. - CommonsCompressCompressionCodecFactory() - Constructor for class com.rabbitmq.stream.compression.CommonsCompressCompressionCodecFactory
- CommonsCompressGzipCompressionCodec() - Constructor for class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressGzipCompressionCodec
- CommonsCompressLz4CompressionCodec() - Constructor for class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressLz4CompressionCodec
- CommonsCompressSnappyCompressionCodec() - Constructor for class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressSnappyCompressionCodec
- CommonsCompressZstdCompressionCodec() - Constructor for class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressZstdCompressionCodec
- compareTo(UnsignedInteger) - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- compareTo(UnsignedLong) - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- compareTo(UnsignedShort) - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- compareTo(ByteCapacity) - Method in class com.rabbitmq.stream.ByteCapacity
- compareTo(UnsignedByte) - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- compress(OutputStream) - Method in interface com.rabbitmq.stream.compression.CompressionCodec
-
Creates an
OutputStream
to compress data. - compress(OutputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressGzipCompressionCodec
- compress(OutputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressLz4CompressionCodec
- compress(OutputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressSnappyCompressionCodec
- compress(OutputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressZstdCompressionCodec
- compress(OutputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.GzipCompressionCodec
- compress(OutputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.Lz4JavaCompressionCodec
- compress(OutputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.XerialSnappyCompressionCodec
- compress(OutputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.ZstdJniCompressionCodec
- compression(Compression) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
Compression algorithm to use to compress a batch of sub-entries.
- Compression - Enum in com.rabbitmq.stream.compression
-
Enum to define types of compression codecs.
- CompressionCodec - Interface in com.rabbitmq.stream.compression
-
Codec to compress and decompress sub-entries.
- compressionCodecFactory(CompressionCodecFactory) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Compression codec factory to use for compression in sub-entry batching.
- compressionCodecFactory(CompressionCodecFactory) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- compressionCodecFactory(CompressionCodecFactory) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- CompressionCodecFactory - Interface in com.rabbitmq.stream.compression
-
Factory to create
CompressionCodec
instances. - CompressionException - Exception Class in com.rabbitmq.stream.compression
-
Exception thrown when an error during compression/decompression occurs.
- CompressionException(String, Throwable) - Constructor for exception class com.rabbitmq.stream.compression.CompressionException
- CompressionUtils - Class in com.rabbitmq.stream.compression
-
Implementation of
CompressionCodec
s. - CompressionUtils.CommonsCompressGzipCompressionCodec - Class in com.rabbitmq.stream.compression
- CompressionUtils.CommonsCompressLz4CompressionCodec - Class in com.rabbitmq.stream.compression
- CompressionUtils.CommonsCompressSnappyCompressionCodec - Class in com.rabbitmq.stream.compression
- CompressionUtils.CommonsCompressZstdCompressionCodec - Class in com.rabbitmq.stream.compression
- CompressionUtils.GzipCompressionCodec - Class in com.rabbitmq.stream.compression
- CompressionUtils.Lz4JavaCompressionCodec - Class in com.rabbitmq.stream.compression
- CompressionUtils.XerialSnappyCompressionCodec - Class in com.rabbitmq.stream.compression
- CompressionUtils.ZstdJniCompressionCodec - Class in com.rabbitmq.stream.compression
- ConfirmationHandler - Interface in com.rabbitmq.stream
-
Callback API to confirm or fail a message.
- ConfirmationStatus - Class in com.rabbitmq.stream
-
The status to confirm or fail a message.
- ConfirmationStatus(Message, boolean, short) - Constructor for class com.rabbitmq.stream.ConfirmationStatus
- confirmTimeout(Duration) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
Time before the client calls the confirm callback to signal outstanding unconfirmed messages timed out.
- Constants - Class in com.rabbitmq.stream
-
Various constants (response codes, errors, etc)
- consume(long) - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- consume(long) - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- consume(long) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- consume(long) - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
- consumer() - Method in interface com.rabbitmq.stream.ConsumerUpdateListener.Context
-
The consumer instance.
- consumer() - Method in interface com.rabbitmq.stream.MessageHandler.Context
-
The consumer that receives the message.
- Consumer - Interface in com.rabbitmq.stream
-
API to consume messages from a RabbitMQ Stream.
- consumerBuilder() - Method in interface com.rabbitmq.stream.Environment
-
Create a
ConsumerBuilder
to configure and create aConsumer
- ConsumerBuilder - Interface in com.rabbitmq.stream
-
API to configure and create a
Consumer
. - ConsumerBuilder.AutoTrackingStrategy - Interface in com.rabbitmq.stream
-
Auto-tracking strategy.
- ConsumerBuilder.FilterConfiguration - Interface in com.rabbitmq.stream
-
Filter configuration.
- ConsumerBuilder.FlowConfiguration - Interface in com.rabbitmq.stream
-
Message flow configuration.
- ConsumerBuilder.ManualTrackingStrategy - Interface in com.rabbitmq.stream
-
Manual tracking strategy.
- ConsumerFlowStrategy - Interface in com.rabbitmq.stream
-
Contract to determine when a subscription provides credits to get more messages.
- ConsumerFlowStrategy.Context - Interface in com.rabbitmq.stream
-
Chunk context.
- ConsumerFlowStrategy.CreditOnChunkArrivalConsumerFlowStrategy - Class in com.rabbitmq.stream
-
Strategy that provides the specified number of initial credits and a credit on each new chunk.
- ConsumerFlowStrategy.MessageCountConsumerFlowStrategy - Class in com.rabbitmq.stream
-
Strategy that provides the specified number of initial credits and a credit when the specified ratio of the chunk messages are processed.
- ConsumerFlowStrategy.MessageProcessedCallback - Interface in com.rabbitmq.stream
-
Behavior for
MessageHandler.Context.processed()
calls. - consumerUpdateListener(ConsumerUpdateListener) - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
Set the listener for single active consumer updates.
- consumerUpdateListener(Client.ConsumerUpdateListener) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- ConsumerUpdateListener - Interface in com.rabbitmq.stream
-
An interface for reacting to status changes of single active consumers.
- ConsumerUpdateListener.Context - Interface in com.rabbitmq.stream
-
Information on the status change.
- consumerUpdateResponse(int, short, OffsetSpecification) - Method in class com.rabbitmq.stream.impl.Client
- contentEncoding(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the content encoding.
- contentType(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the content type.
- convertToQpidType(Object) - Method in class com.rabbitmq.stream.codec.QpidProtonCodec
- convertToSwiftMqType(Object) - Static method in class com.rabbitmq.stream.codec.SwiftMqCodec
- copy() - Method in interface com.rabbitmq.stream.Message
-
Create a copy of the message.
- correlationId(byte[]) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the correlation ID as an array of bytes.
- correlationId(long) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the correlation ID as a long.
- correlationId(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the correlation ID as a string.
- correlationId(UUID) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the correlation ID as an UUID.
- create() - Method in interface com.rabbitmq.stream.StreamCreator
-
Create the stream.
- create(String) - Method in class com.rabbitmq.stream.impl.Client
- create(String, Map<String, String>) - Method in class com.rabbitmq.stream.impl.Client
- createChunkCounter(MeterRegistry, String, Iterable<Tag>) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- createChunkSizeDistributionSummary(MeterRegistry, String, Iterable<Tag>) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- createMessage(byte[]) - Method in class com.rabbitmq.stream.codec.SwiftMqCodec
- createProperties(AMQPMessage) - Method in class com.rabbitmq.stream.codec.SwiftMqCodec
- createProperties(Message) - Static method in class com.rabbitmq.stream.codec.QpidProtonCodec
- creationTime(long) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the creation time.
- creator() - Method in interface com.rabbitmq.stream.StreamCreator.SuperStreamConfiguration
-
Go back to the creator.
- credentialsProvider(CredentialsProvider) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The
CredentialsProvider
to use. - credentialsProvider(CredentialsProvider) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- credentialsProvider(CredentialsProvider) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- CredentialsProvider - Interface in com.rabbitmq.stream.sasl
-
Marker interface for providing credentials.
- credit(byte, int) - Method in class com.rabbitmq.stream.impl.Client
- creditNotification(Client.CreditNotification) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- creditOnChunkArrival() - Static method in interface com.rabbitmq.stream.ConsumerFlowStrategy
-
Strategy that provides 1 initial credit and a credit on each new chunk.
- creditOnChunkArrival(int) - Static method in interface com.rabbitmq.stream.ConsumerFlowStrategy
-
Strategy that provides the specified number of initial credits and a credit on each new chunk.
- creditOnProcessedMessageCount(int, double) - Static method in interface com.rabbitmq.stream.ConsumerFlowStrategy
-
Strategy that provides the specified number of initial credits and a credit when the specified ratio of the chunk messages are processed.
- credits(int) - Method in interface com.rabbitmq.stream.ConsumerFlowStrategy.Context
-
Provide credits for the subscription.
- creditWhenHalfMessagesProcessed() - Static method in interface com.rabbitmq.stream.ConsumerFlowStrategy
-
Strategy that provides 1 initial credit and a credit when half of the chunk messages are processed.
- creditWhenHalfMessagesProcessed(int) - Static method in interface com.rabbitmq.stream.ConsumerFlowStrategy
-
Strategy that provides the specified number of initial credits and a credit when half of the chunk messages are processed.
- customProcessObservationConvention(ProcessObservationConvention) - Method in class com.rabbitmq.stream.observation.micrometer.MicrometerObservationCollectorBuilder
-
Custom convention for consuming.
- customPublishObservationConvention(PublishObservationConvention) - Method in class com.rabbitmq.stream.observation.micrometer.MicrometerObservationCollectorBuilder
-
Custom convention for publishing.
D
- declarePublisher(byte, String, String) - Method in class com.rabbitmq.stream.impl.Client
- decode(byte[]) - Method in interface com.rabbitmq.stream.Codec
- decode(byte[]) - Method in class com.rabbitmq.stream.codec.QpidProtonCodec
- decode(byte[]) - Method in class com.rabbitmq.stream.codec.SimpleCodec
- decode(byte[]) - Method in class com.rabbitmq.stream.codec.SwiftMqCodec
- decompress(InputStream) - Method in interface com.rabbitmq.stream.compression.CompressionCodec
-
Creates an
InputStream
to read decompressed data from. - decompress(InputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressGzipCompressionCodec
- decompress(InputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressLz4CompressionCodec
- decompress(InputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressSnappyCompressionCodec
- decompress(InputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressZstdCompressionCodec
- decompress(InputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.GzipCompressionCodec
- decompress(InputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.Lz4JavaCompressionCodec
- decompress(InputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.XerialSnappyCompressionCodec
- decompress(InputStream) - Method in class com.rabbitmq.stream.compression.CompressionUtils.ZstdJniCompressionCodec
- DEFAULT_CLIENT_PROPERTIES - Static variable in class com.rabbitmq.stream.impl.ClientProperties
- DEFAULT_PORT - Static variable in class com.rabbitmq.stream.impl.Client
- DEFAULT_TLS_PORT - Static variable in class com.rabbitmq.stream.impl.Client
- DefaultCompressionCodecFactory - Class in com.rabbitmq.stream.compression
-
CompressionCodecFactory
implementation using various compression libraries. - DefaultCompressionCodecFactory() - Constructor for class com.rabbitmq.stream.compression.DefaultCompressionCodecFactory
- defaultProcessObservationConvention(ProcessObservationConvention) - Method in class com.rabbitmq.stream.observation.micrometer.MicrometerObservationCollectorBuilder
-
Default convention for consuming.
- DefaultProcessObservationConvention - Class in com.rabbitmq.stream.observation.micrometer
-
Default
ProcessObservationConvention
. - DefaultProcessObservationConvention() - Constructor for class com.rabbitmq.stream.observation.micrometer.DefaultProcessObservationConvention
- defaultPublishObservationConvention(PublishObservationConvention) - Method in class com.rabbitmq.stream.observation.micrometer.MicrometerObservationCollectorBuilder
-
Default convention for publishing.
- DefaultPublishObservationConvention - Class in com.rabbitmq.stream.observation.micrometer
-
Default
PublishObservationConvention
. - DefaultPublishObservationConvention() - Constructor for class com.rabbitmq.stream.observation.micrometer.DefaultPublishObservationConvention
- DefaultSaslConfiguration - Class in com.rabbitmq.stream.sasl
-
SaslConfiguration
that supports our built-in mechanisms. - DefaultSaslConfiguration() - Constructor for class com.rabbitmq.stream.sasl.DefaultSaslConfiguration
- DefaultSaslConfiguration(String) - Constructor for class com.rabbitmq.stream.sasl.DefaultSaslConfiguration
- DefaultUsernamePasswordCredentialsProvider - Class in com.rabbitmq.stream.sasl
-
Default implementation of
UsernamePasswordCredentialsProvider
. - DefaultUsernamePasswordCredentialsProvider(String, String) - Constructor for class com.rabbitmq.stream.sasl.DefaultUsernamePasswordCredentialsProvider
- delay(int) - Method in interface com.rabbitmq.stream.BackOffDelayPolicy
-
Returns the delay to use for a given attempt.
- delay(int) - Method in class com.rabbitmq.stream.BackOffDelayPolicy.FixedWithInitialDelayAndTimeoutBackOffPolicy
- delay(int) - Method in class com.rabbitmq.stream.BackOffDelayPolicy.FixedWithInitialDelayBackOffPolicy
- delete(String) - Method in class com.rabbitmq.stream.impl.Client
- deletePublisher(byte) - Method in class com.rabbitmq.stream.impl.Client
- deleteStream(String) - Method in interface com.rabbitmq.stream.Environment
-
Delete a stream
- deleteSuperStream(String) - Method in interface com.rabbitmq.stream.Environment
-
Delete a super stream.
- dispatchingExecutorServiceFactory(ExecutorServiceFactory) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- doubleValue() - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- doubleValue() - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- doubleValue() - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- doubleValue() - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- DropwizardMetricsCollector - Class in com.rabbitmq.stream.metrics
- DropwizardMetricsCollector() - Constructor for class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- DropwizardMetricsCollector(MetricRegistry) - Constructor for class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- DropwizardMetricsCollector(MetricRegistry, String) - Constructor for class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
E
- encode(Message) - Method in interface com.rabbitmq.stream.Codec
- encode(Message) - Method in class com.rabbitmq.stream.codec.QpidProtonCodec
- encode(Message) - Method in class com.rabbitmq.stream.codec.SimpleCodec
- encode(Message) - Method in class com.rabbitmq.stream.codec.SwiftMqCodec
- EncodedMessage(int, byte[]) - Constructor for class com.rabbitmq.stream.Codec.EncodedMessage
- enqueueTimeout(Duration) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
Time before enqueueing of a message fail when the maximum number of unconfirmed is reached.
- entry(String, boolean) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, boolean) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, byte) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, byte) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, byte[]) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, byte[]) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, char) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, char) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, double) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, double) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, float) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, float) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, int) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, int) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, long) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, long) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, short) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, short) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, String) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, String) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entry(String, UUID) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entry(String, UUID) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entryDecimal128(String, BigDecimal) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entryDecimal128(String, BigDecimal) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entryDecimal32(String, BigDecimal) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entryDecimal32(String, BigDecimal) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entryDecimal64(String, BigDecimal) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entryDecimal64(String, BigDecimal) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entrySymbol(String, String) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entrySymbol(String, String) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entryTimestamp(String, long) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entryTimestamp(String, long) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entryUnsigned(String, byte) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entryUnsigned(String, byte) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entryUnsigned(String, int) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entryUnsigned(String, int) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entryUnsigned(String, long) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entryUnsigned(String, long) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- entryUnsigned(String, short) - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
- entryUnsigned(String, short) - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
- Environment - Interface in com.rabbitmq.stream
-
The
Environment
is the main entry point to a node or a cluster of nodes. - environmentBuilder() - Method in interface com.rabbitmq.stream.EnvironmentBuilder.NettyConfiguration
-
Go back to the environment builder
- environmentBuilder() - Method in interface com.rabbitmq.stream.EnvironmentBuilder.TlsConfiguration
-
Go back to the environment builder
- EnvironmentBuilder - Interface in com.rabbitmq.stream
-
API to configure and create an
Environment
. - EnvironmentBuilder.NettyConfiguration - Interface in com.rabbitmq.stream
-
Helper to configure Netty
- EnvironmentBuilder.TlsConfiguration - Interface in com.rabbitmq.stream
-
Helper to configure TLS.
- equals(Object) - Method in class com.rabbitmq.stream.Address
- equals(Object) - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- equals(Object) - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- equals(Object) - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- equals(Object) - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- equals(Object) - Method in class com.rabbitmq.stream.ByteCapacity
- equals(Object) - Method in class com.rabbitmq.stream.impl.Client.Broker
- equals(Object) - Method in class com.rabbitmq.stream.OffsetSpecification
- eventLoopGroup(EventLoopGroup) - Method in interface com.rabbitmq.stream.EnvironmentBuilder.NettyConfiguration
-
The
EventLoopGroup
instance to use. - eventLoopGroup(EventLoopGroup) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- executorServiceFactory(ExecutorServiceFactory) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- EXTERNAL - Static variable in class com.rabbitmq.stream.sasl.DefaultSaslConfiguration
- ExternalSaslMechanism - Class in com.rabbitmq.stream.sasl
-
The
EXTERNAL
SaslMechanism
. - ExternalSaslMechanism() - Constructor for class com.rabbitmq.stream.sasl.ExternalSaslMechanism
- extractBody(AMQPMessage) - Method in class com.rabbitmq.stream.codec.SwiftMqCodec
F
- filter() - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
Configure the filtering.
- filteringSupported() - Method in class com.rabbitmq.stream.impl.Client
- filterSize(int) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- filterSize(int) - Method in interface com.rabbitmq.stream.StreamCreator
-
Set the size of the stream chunk filters.
- filterValue(Function<Message, String>) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
Logic to extract a filter value from a message.
- first() - Static method in class com.rabbitmq.stream.OffsetSpecification
-
The first available offset in the stream.
- firstOffset() - Method in interface com.rabbitmq.stream.StreamStats
-
The first offset in the stream.
- fixed(Duration) - Static method in interface com.rabbitmq.stream.BackOffDelayPolicy
-
A policy with a constant delay.
- fixedWithInitialDelay(Duration, Duration) - Static method in interface com.rabbitmq.stream.BackOffDelayPolicy
-
A policy with a first delay and then a constant delay.
- fixedWithInitialDelay(Duration, Duration, Duration) - Static method in interface com.rabbitmq.stream.BackOffDelayPolicy
-
A policy with a first delay, then a constant delay until a timeout is reached.
- floatValue() - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- floatValue() - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- floatValue() - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- floatValue() - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- flow() - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
Configure flow of messages.
- flushInterval(Duration) - Method in interface com.rabbitmq.stream.ConsumerBuilder.AutoTrackingStrategy
-
Interval to check and stored the last received offset in case of inactivity.
- forceReplicaForConsumers(boolean) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Flag to force the connection to a stream replica for consumers.
- forceReplicaForConsumers(boolean) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- from(String) - Static method in class com.rabbitmq.stream.ByteCapacity
- from(String) - Static method in enum com.rabbitmq.stream.StreamCreator.LeaderLocator
G
- GB(long) - Static method in class com.rabbitmq.stream.ByteCapacity
- get(byte) - Static method in enum com.rabbitmq.stream.compression.Compression
- get(Compression) - Method in class com.rabbitmq.stream.compression.CommonsCompressCompressionCodecFactory
- get(Compression) - Method in interface com.rabbitmq.stream.compression.CompressionCodecFactory
-
Get a compression codec for a given type of compression.
- get(Compression) - Method in class com.rabbitmq.stream.compression.DefaultCompressionCodecFactory
- getAbsoluteExpiryTime() - Method in interface com.rabbitmq.stream.Properties
- getApplicationProperties() - Method in interface com.rabbitmq.stream.Message
-
Get the application properties of the message.
- getBody() - Method in interface com.rabbitmq.stream.Message
-
Get the message body.
- getBodyAsBinary() - Method in interface com.rabbitmq.stream.Message
-
Get the body of the message as an array of bytes.
- getCode() - Method in class com.rabbitmq.stream.ConfirmationStatus
-
The status code.
- getCode() - Method in exception class com.rabbitmq.stream.StreamException
- getComputed() - Method in exception class com.rabbitmq.stream.ChunkChecksumValidationException
- getContentEncoding() - Method in interface com.rabbitmq.stream.Properties
- getContentType() - Method in interface com.rabbitmq.stream.Properties
- getContextualName(ProcessContext) - Method in class com.rabbitmq.stream.observation.micrometer.DefaultProcessObservationConvention
- getContextualName(PublishContext) - Method in class com.rabbitmq.stream.observation.micrometer.DefaultPublishObservationConvention
- getCorrelationId() - Method in interface com.rabbitmq.stream.Properties
- getCorrelationIdAsBinary() - Method in interface com.rabbitmq.stream.Properties
- getCorrelationIdAsLong() - Method in interface com.rabbitmq.stream.Properties
- getCorrelationIdAsString() - Method in interface com.rabbitmq.stream.Properties
- getCorrelationIdAsUuid() - Method in interface com.rabbitmq.stream.Properties
- getCreationTime() - Method in interface com.rabbitmq.stream.Properties
- getData() - Method in class com.rabbitmq.stream.Codec.EncodedMessage
- getExpected() - Method in exception class com.rabbitmq.stream.ChunkChecksumValidationException
- getGroupId() - Method in interface com.rabbitmq.stream.Properties
- getGroupSequence() - Method in interface com.rabbitmq.stream.Properties
- getHighCardinalityKeyValues(ProcessContext) - Method in class com.rabbitmq.stream.observation.micrometer.DefaultProcessObservationConvention
- getHighCardinalityKeyValues(PublishContext) - Method in class com.rabbitmq.stream.observation.micrometer.DefaultPublishObservationConvention
- getHost() - Method in class com.rabbitmq.stream.impl.Client.Broker
- getLastPublishingId() - Method in interface com.rabbitmq.stream.Producer
-
Get the last publishing ID for a named producer.
- getLeader() - Method in class com.rabbitmq.stream.impl.Client.StreamMetadata
- getLowCardinalityKeyValues(ProcessContext) - Method in class com.rabbitmq.stream.observation.micrometer.DefaultProcessObservationConvention
- getLowCardinalityKeyValues(PublishContext) - Method in class com.rabbitmq.stream.observation.micrometer.DefaultPublishObservationConvention
- getMessage() - Method in class com.rabbitmq.stream.ConfirmationStatus
- getMessageAnnotations() - Method in interface com.rabbitmq.stream.Message
-
Get the message annotations of the message.
- getMessageId() - Method in interface com.rabbitmq.stream.Properties
- getMessageIdAsBinary() - Method in interface com.rabbitmq.stream.Properties
- getMessageIdAsLong() - Method in interface com.rabbitmq.stream.Properties
- getMessageIdAsString() - Method in interface com.rabbitmq.stream.Properties
- getMessageIdAsUuid() - Method in interface com.rabbitmq.stream.Properties
- getName() - Method in class com.rabbitmq.stream.observation.micrometer.DefaultProcessObservationConvention
- getName() - Method in class com.rabbitmq.stream.observation.micrometer.DefaultPublishObservationConvention
- getName() - Method in class com.rabbitmq.stream.sasl.AnonymousSaslMechanism
- getName() - Method in class com.rabbitmq.stream.sasl.ExternalSaslMechanism
- getName() - Method in class com.rabbitmq.stream.sasl.PlainSaslMechanism
- getName() - Method in interface com.rabbitmq.stream.sasl.SaslMechanism
-
The name of the SASL mechanism.
- getOffset() - Method in class com.rabbitmq.stream.impl.Client.QueryOffsetResponse
- getOffset() - Method in class com.rabbitmq.stream.OffsetSpecification
- getPassword() - Method in class com.rabbitmq.stream.sasl.DefaultUsernamePasswordCredentialsProvider
- getPassword() - Method in interface com.rabbitmq.stream.sasl.UsernamePasswordCredentialsProvider
-
The password
- getPayloadSizeBytes() - Method in class com.rabbitmq.stream.observation.micrometer.ProcessContext
- getPayloadSizeBytes() - Method in class com.rabbitmq.stream.observation.micrometer.PublishContext
- getPort() - Method in class com.rabbitmq.stream.impl.Client.Broker
- getProperties() - Method in interface com.rabbitmq.stream.Message
-
Get the properties of the message.
- getPublishingId() - Method in interface com.rabbitmq.stream.Message
-
Get the publishing ID for the message.
- getReplicas() - Method in class com.rabbitmq.stream.impl.Client.StreamMetadata
- getReplyTo() - Method in interface com.rabbitmq.stream.Properties
- getReplyToGroupId() - Method in interface com.rabbitmq.stream.Properties
- getResponseCode() - Method in class com.rabbitmq.stream.impl.Client.Response
- getResponseCode() - Method in class com.rabbitmq.stream.impl.Client.StreamMetadata
- getSaslMechanism(List<String>) - Method in class com.rabbitmq.stream.sasl.DefaultSaslConfiguration
- getSaslMechanism(List<String>) - Method in class com.rabbitmq.stream.sasl.JdkSaslConfiguration
- getSaslMechanism(List<String>) - Method in interface com.rabbitmq.stream.sasl.SaslConfiguration
-
Pick mechanism according to the ones passed in.
- getShutdownReason() - Method in class com.rabbitmq.stream.impl.Client.ShutdownContext
- getSize() - Method in class com.rabbitmq.stream.Codec.EncodedMessage
- getStream() - Method in class com.rabbitmq.stream.impl.Client.StreamMetadata
- getStream() - Method in class com.rabbitmq.stream.observation.micrometer.ProcessContext
- getStream() - Method in exception class com.rabbitmq.stream.StreamDoesNotExistException
- getSubject() - Method in interface com.rabbitmq.stream.Properties
- getTo() - Method in interface com.rabbitmq.stream.Properties
- getType() - Method in class com.rabbitmq.stream.OffsetSpecification
- getUserId() - Method in interface com.rabbitmq.stream.Properties
- getUsername() - Method in class com.rabbitmq.stream.sasl.DefaultUsernamePasswordCredentialsProvider
- getUsername() - Method in interface com.rabbitmq.stream.sasl.UsernamePasswordCredentialsProvider
-
The username
- groupId(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the group ID.
- groupSequence(long) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the group sequence.
- GZIP - Enum constant in enum com.rabbitmq.stream.compression.Compression
- GzipCompressionCodec() - Constructor for class com.rabbitmq.stream.compression.CompressionUtils.GzipCompressionCodec
H
- handle(byte, long) - Method in interface com.rabbitmq.stream.impl.Client.PublishConfirmListener
- handle(byte, long, long, long, Object, Message) - Method in interface com.rabbitmq.stream.impl.Client.MessageListener
- handle(byte, long, short) - Method in interface com.rabbitmq.stream.impl.Client.PublishErrorListener
- handle(byte, short) - Method in interface com.rabbitmq.stream.impl.Client.CreditNotification
- handle(long, Object) - Method in interface com.rabbitmq.stream.impl.Client.OutboundEntityMappingCallback
- handle(ConfirmationStatus) - Method in interface com.rabbitmq.stream.ConfirmationHandler
-
Callback to confirm or fail a message.
- handle(Client.ShutdownContext) - Method in interface com.rabbitmq.stream.impl.Client.ShutdownListener
- handle(Client, byte, boolean) - Method in interface com.rabbitmq.stream.impl.Client.ConsumerUpdateListener
- handle(Client, byte, long, long, long) - Method in interface com.rabbitmq.stream.impl.Client.ChunkListener
-
Callback when a chunk is received as part of a deliver operation.
- handle(MessageHandler.Context, Message) - Method in interface com.rabbitmq.stream.MessageHandler
-
Callback for an inbound message.
- handle(String, short) - Method in interface com.rabbitmq.stream.impl.Client.MetadataListener
- handleChallenge(byte[], CredentialsProvider) - Method in class com.rabbitmq.stream.sasl.AnonymousSaslMechanism
- handleChallenge(byte[], CredentialsProvider) - Method in class com.rabbitmq.stream.sasl.ExternalSaslMechanism
- handleChallenge(byte[], CredentialsProvider) - Method in class com.rabbitmq.stream.sasl.PlainSaslMechanism
- handleChallenge(byte[], CredentialsProvider) - Method in interface com.rabbitmq.stream.sasl.SaslMechanism
-
Handle a challenge from the server
- hash() - Method in interface com.rabbitmq.stream.ProducerBuilder.RoutingConfiguration
-
Enable the "hash" routing strategy (the default).
- hash(ToIntFunction<String>) - Method in interface com.rabbitmq.stream.ProducerBuilder.RoutingConfiguration
-
Enable the "hash" routing strategy with a specific hash algorithm.
- hashCode() - Method in class com.rabbitmq.stream.Address
- hashCode() - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- hashCode() - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- hashCode() - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- hashCode() - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- hashCode() - Method in class com.rabbitmq.stream.ByteCapacity
- hashCode() - Method in class com.rabbitmq.stream.impl.Client.Broker
- hashCode() - Method in class com.rabbitmq.stream.OffsetSpecification
- hasPublishingId() - Method in interface com.rabbitmq.stream.Message
-
Does this message has a publishing ID?
- HEARTBEAT_FAILURE - Enum constant in enum com.rabbitmq.stream.impl.Client.ShutdownContext.ShutdownReason
- host() - Method in class com.rabbitmq.stream.Address
- host(String) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The host to connect to.
- host(String) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- host(String) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- hostnameVerification() - Method in interface com.rabbitmq.stream.EnvironmentBuilder.TlsConfiguration
-
Enable hostname verification.
- hostnameVerification(boolean) - Method in interface com.rabbitmq.stream.EnvironmentBuilder.TlsConfiguration
-
Enable or disable hostname verification.
I
- id(String) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Informational ID for this environment instance.
- id(String) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- ignored(byte, long, long, long, Object) - Method in interface com.rabbitmq.stream.impl.Client.MessageIgnoredListener
- initialCredits() - Method in class com.rabbitmq.stream.ConsumerFlowStrategy.CreditOnChunkArrivalConsumerFlowStrategy
- initialCredits() - Method in interface com.rabbitmq.stream.ConsumerFlowStrategy
-
The initial number of credits for a subscription.
- initialCredits() - Method in class com.rabbitmq.stream.ConsumerFlowStrategy.MessageCountConsumerFlowStrategy
- initialCredits(int) - Method in interface com.rabbitmq.stream.ConsumerBuilder.FlowConfiguration
-
The number of initial credits for the subscription.
- initialMemberCount(int) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- initialMemberCount(int) - Method in interface com.rabbitmq.stream.StreamCreator
-
Set the number of initial members the stream should have.
- INSTANCE - Static variable in class com.rabbitmq.stream.sasl.AnonymousSaslMechanism
- INSTANCE - Static variable in class com.rabbitmq.stream.sasl.ExternalSaslMechanism
- INSTANCE - Static variable in class com.rabbitmq.stream.sasl.PlainSaslMechanism
- intValue() - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- intValue() - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- intValue() - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- intValue() - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- isActive() - Method in interface com.rabbitmq.stream.ConsumerUpdateListener.Context
-
Whether the consumer is active or not.
- isConfirmed() - Method in class com.rabbitmq.stream.ConfirmationStatus
-
Whether the message is confirmed or not.
- isNoop() - Method in interface com.rabbitmq.stream.ObservationCollector
-
Says whether the implementation does nothing or not.
- isOffset() - Method in class com.rabbitmq.stream.OffsetSpecification
- isOk() - Method in class com.rabbitmq.stream.impl.Client.Response
- isOpen() - Method in class com.rabbitmq.stream.impl.Client
- isResponseOk() - Method in class com.rabbitmq.stream.impl.Client.StreamMetadata
- isTimestamp() - Method in class com.rabbitmq.stream.OffsetSpecification
J
- JdkSaslConfiguration - Class in com.rabbitmq.stream.sasl
-
SaslConfiguration
using the JDK SASL support. - JdkSaslConfiguration(CredentialsProvider, Supplier<String>) - Constructor for class com.rabbitmq.stream.sasl.JdkSaslConfiguration
- JdkSaslConfiguration(CredentialsProvider, Supplier<String>, String[]) - Constructor for class com.rabbitmq.stream.sasl.JdkSaslConfiguration
K
- kB(long) - Static method in class com.rabbitmq.stream.ByteCapacity
- key() - Method in interface com.rabbitmq.stream.ProducerBuilder.RoutingConfiguration
-
Enable the "key" routing strategy.
L
- last() - Static method in class com.rabbitmq.stream.OffsetSpecification
-
The last chunk of messages in the stream.
- lazyInitialization(boolean) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
To delay the connection opening until necessary.
- lazyInitialization(boolean) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- leaderLocator(StreamCreator.LeaderLocator) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- leaderLocator(StreamCreator.LeaderLocator) - Method in interface com.rabbitmq.stream.StreamCreator
-
The
StreamCreator.LeaderLocator
strategy. - LEAST_LEADERS - Enum constant in enum com.rabbitmq.stream.StreamCreator.LeaderLocator
-
The stream leader will be on the node with the least number of stream leaders.
- localAddress() - Method in class com.rabbitmq.stream.impl.Client
- longValue() - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- longValue() - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- longValue() - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- longValue() - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- LZ4 - Enum constant in enum com.rabbitmq.stream.compression.Compression
- Lz4JavaCompressionCodec() - Constructor for class com.rabbitmq.stream.compression.CompressionUtils.Lz4JavaCompressionCodec
M
- manualTrackingStrategy() - Method in interface com.rabbitmq.stream.ConsumerBuilder
- matchUnfiltered() - Method in interface com.rabbitmq.stream.ConsumerBuilder.FilterConfiguration
-
Whether messages without a filter value should be sent as well.
- matchUnfiltered(boolean) - Method in interface com.rabbitmq.stream.ConsumerBuilder.FilterConfiguration
-
Whether messages without a filter value should be sent as well.
- MAX_SEGMENT_SIZE - Static variable in interface com.rabbitmq.stream.StreamCreator
-
Segment size is limited to 3 GB.
- MAX_VALUE - Static variable in class com.rabbitmq.stream.amqp.UnsignedInteger
- MAX_VALUE - Static variable in class com.rabbitmq.stream.amqp.UnsignedShort
- maxAge(Duration) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxAge(Duration) - Method in interface com.rabbitmq.stream.StreamCreator
-
The maximum age of a stream before it gets truncated.
- maxCompressedLength(int) - Method in interface com.rabbitmq.stream.compression.CompressionCodec
-
Provides the maximum compressed size from the source length.
- maxCompressedLength(int) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressGzipCompressionCodec
- maxCompressedLength(int) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressLz4CompressionCodec
- maxCompressedLength(int) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressSnappyCompressionCodec
- maxCompressedLength(int) - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressZstdCompressionCodec
- maxCompressedLength(int) - Method in class com.rabbitmq.stream.compression.CompressionUtils.GzipCompressionCodec
- maxCompressedLength(int) - Method in class com.rabbitmq.stream.compression.CompressionUtils.Lz4JavaCompressionCodec
- maxCompressedLength(int) - Method in class com.rabbitmq.stream.compression.CompressionUtils.XerialSnappyCompressionCodec
- maxCompressedLength(int) - Method in class com.rabbitmq.stream.compression.CompressionUtils.ZstdJniCompressionCodec
- maxConsumersByConnection(int) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The maximum number of consumers allocated to a single connection.
- maxConsumersByConnection(int) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- maxLengthBytes(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxLengthBytes(ByteCapacity) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxLengthBytes(ByteCapacity) - Method in interface com.rabbitmq.stream.StreamCreator
-
The maximum size of the stream before it gets truncated.
- maxLengthGb(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxLengthKb(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxLengthMb(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxLengthTb(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxProducersByConnection(int) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The maximum number of producers allocated to a single connection.
- maxProducersByConnection(int) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- maxSegmentSizeBytes(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxSegmentSizeBytes(ByteCapacity) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxSegmentSizeBytes(ByteCapacity) - Method in interface com.rabbitmq.stream.StreamCreator
-
The maximum size of each stream segments.
- maxSegmentSizeGb(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxSegmentSizeKb(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxSegmentSizeMb(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxSegmentSizeTb(long) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- maxTrackingConsumersByConnection(int) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The maximum number of tracking consumers allocated to a single connection.
- maxTrackingConsumersByConnection(int) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- maxUnconfirmedMessages(int) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
The maximum number of unconfirmed outbound messages.
- MB(long) - Static method in class com.rabbitmq.stream.ByteCapacity
- Message - Interface in com.rabbitmq.stream
-
API for outbound and inbound messages.
- messageAnnotations() - Method in class com.rabbitmq.stream.codec.WrapperMessageBuilder
- messageAnnotations() - Method in interface com.rabbitmq.stream.MessageBuilder
-
The builder to set message annotations.
- MessageBatch - Class in com.rabbitmq.stream.impl
- MessageBatch(Compression) - Constructor for class com.rabbitmq.stream.impl.MessageBatch
- MessageBatch(Compression, List<Message>) - Constructor for class com.rabbitmq.stream.impl.MessageBatch
- messageBuilder() - Method in interface com.rabbitmq.stream.Codec
- messageBuilder() - Method in class com.rabbitmq.stream.codec.QpidProtonCodec
- messageBuilder() - Method in class com.rabbitmq.stream.codec.SimpleCodec
- messageBuilder() - Method in class com.rabbitmq.stream.codec.SwiftMqCodec
- messageBuilder() - Method in class com.rabbitmq.stream.impl.Client
- messageBuilder() - Method in interface com.rabbitmq.stream.MessageBuilder.ApplicationPropertiesBuilder
-
Go back to the message builder
- messageBuilder() - Method in interface com.rabbitmq.stream.MessageBuilder.MessageAnnotationsBuilder
-
Go back to the message builder
- messageBuilder() - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Go back to the message builder.
- messageBuilder() - Method in interface com.rabbitmq.stream.Producer
-
Return a
MessageBuilder
to create aMessage
. - MessageBuilder - Interface in com.rabbitmq.stream
-
API to configure and create a
Message
. - MessageBuilder.ApplicationPropertiesBuilder - Interface in com.rabbitmq.stream
-
API to set application properties.
- MessageBuilder.MessageAnnotationsBuilder - Interface in com.rabbitmq.stream
-
API to set message annotations.
- MessageBuilder.PropertiesBuilder - Interface in com.rabbitmq.stream
-
API to set message properties.
- messageCount() - Method in interface com.rabbitmq.stream.ConsumerFlowStrategy.Context
-
The number of messages in the chunk.
- messageCountBeforeStorage(int) - Method in interface com.rabbitmq.stream.ConsumerBuilder.AutoTrackingStrategy
-
Number of messages before storing.
- messageHandler(MessageHandler) - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
The callback for inbound messages.
- MessageHandler - Interface in com.rabbitmq.stream
-
Callback API for inbound messages.
- MessageHandler.Context - Interface in com.rabbitmq.stream
-
Information about the message.
- messageId(byte[]) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the message ID as an array of bytes.
- messageId(long) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the message ID as long.
- messageId(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the message ID as a string.
- messageId(UUID) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the message ID as an UUID.
- messageIgnoredListener(Client.MessageIgnoredListener) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- messageListener(Client.MessageListener) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- MESSAGING_DESTINATION_NAME - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.HighCardinalityTags
-
The message destination name.
- MESSAGING_MESSAGE_PAYLOAD_SIZE_BYTES - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.HighCardinalityTags
- MESSAGING_OPERATION - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.LowCardinalityTags
-
A string identifying the kind of messaging operation.
- MESSAGING_SOURCE_NAME - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.HighCardinalityTags
-
The message destination name.
- MESSAGING_SYSTEM - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.LowCardinalityTags
-
A string identifying the messaging system.
- metadata(String...) - Method in class com.rabbitmq.stream.impl.Client
- metadataListener(Client.MetadataListener) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- metricsCollector(MetricsCollector) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Set up a
MetricsCollector
. - metricsCollector(MetricsCollector) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- metricsCollector(MetricsCollector) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- MetricsCollector - Interface in com.rabbitmq.stream.metrics
- MicrometerMetricsCollector - Class in com.rabbitmq.stream.metrics
- MicrometerMetricsCollector(MeterRegistry) - Constructor for class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- MicrometerMetricsCollector(MeterRegistry, String) - Constructor for class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- MicrometerMetricsCollector(MeterRegistry, String, Iterable<Tag>) - Constructor for class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- MicrometerMetricsCollector(MeterRegistry, String, String...) - Constructor for class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- MicrometerObservationCollectorBuilder - Class in com.rabbitmq.stream.observation.micrometer
-
Builder to configure and create Micrometer Observation implementation of
ObservationCollector
. - MicrometerObservationCollectorBuilder() - Constructor for class com.rabbitmq.stream.observation.micrometer.MicrometerObservationCollectorBuilder
N
- name(String) - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
The logical name of the
Consumer
. - name(String) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
The logical name of the producer.
- name(String) - Method in interface com.rabbitmq.stream.StreamCreator
-
The name of the (super) stream.
- NET_PROTOCOL_NAME - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.LowCardinalityTags
-
A string identifying the protocol (RabbitMQ Stream).
- NET_PROTOCOL_VERSION - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.LowCardinalityTags
-
A string identifying the protocol version (1.0).
- NET_SOCK_PEER_ADDR - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.HighCardinalityTags
- NET_SOCK_PEER_PORT - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.HighCardinalityTags
- netty() - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Helper to configure netty.
- netty() - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- next() - Static method in class com.rabbitmq.stream.OffsetSpecification
-
The next offset to be written, that is the end of the stream.
- NO_OP - Static variable in interface com.rabbitmq.stream.ChunkChecksum
- NO_OP - Static variable in interface com.rabbitmq.stream.ObservationCollector
- none() - Static method in class com.rabbitmq.stream.OffsetSpecification
-
When the offset specification is not relevant.
- NONE - Enum constant in enum com.rabbitmq.stream.compression.Compression
- NoOffsetException - Exception Class in com.rabbitmq.stream
- NoOffsetException(String) - Constructor for exception class com.rabbitmq.stream.NoOffsetException
- NoOpMetricsCollector - Class in com.rabbitmq.stream.metrics
- noTrackingStrategy() - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
Disable server-side offset tracking.
O
- observationCollector(ObservationCollector<?>) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Set up an
ObservationCollector
. - observationCollector(ObservationCollector<?>) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- ObservationCollector<T> - Interface in com.rabbitmq.stream
-
API to instrument operations in the stream client.
- offset() - Method in interface com.rabbitmq.stream.MessageHandler.Context
-
The offset of the message in the stream.
- offset(long) - Static method in class com.rabbitmq.stream.OffsetSpecification
-
A specific offset in the stream.
- offset(OffsetSpecification) - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
The offset to start consuming from.
- offsetSpecification() - Method in interface com.rabbitmq.stream.SubscriptionListener.SubscriptionContext
-
The offset specification computed by the library.
- offsetSpecification(OffsetSpecification) - Method in interface com.rabbitmq.stream.SubscriptionListener.SubscriptionContext
-
Set the offset specification to use for the subscription.
- OffsetSpecification - Class in com.rabbitmq.stream
-
API to specify an offset in a stream.
- ONE - Static variable in class com.rabbitmq.stream.amqp.UnsignedInteger
- openConnection() - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- openConnection() - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- openConnection() - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- openConnection() - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
P
- partitions() - Method in interface com.rabbitmq.stream.RoutingStrategy.Metadata
- partitions(int) - Method in interface com.rabbitmq.stream.StreamCreator.SuperStreamConfiguration
-
The number of partitions of the super stream.
- partitions(String) - Method in class com.rabbitmq.stream.impl.Client
- password(String) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The password to use.
- password(String) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- password(String) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- PLAIN - Static variable in class com.rabbitmq.stream.sasl.DefaultSaslConfiguration
- PlainSaslMechanism - Class in com.rabbitmq.stream.sasl
-
The
PLAIN
SaslMechanism
. - PlainSaslMechanism() - Constructor for class com.rabbitmq.stream.sasl.PlainSaslMechanism
- port() - Method in class com.rabbitmq.stream.Address
- port(int) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The port to use to connect.
- port(int) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- port(int) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- postFilter(Predicate<Message>) - Method in interface com.rabbitmq.stream.ConsumerBuilder.FilterConfiguration
-
Client-side filtering logic, occurring after the server-side filtering.
- prePublish(String, Message) - Method in interface com.rabbitmq.stream.ObservationCollector
-
Start observation.
- preSubscribe(SubscriptionListener.SubscriptionContext) - Method in interface com.rabbitmq.stream.SubscriptionListener
-
Callback called before the subscription is created.
- PROCESS_OBSERVATION - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation
-
Observation for processing a message.
- ProcessContext - Class in com.rabbitmq.stream.observation.micrometer
-
Observation.Context
for RabbitMQ Stream consuming. - processed() - Method in interface com.rabbitmq.stream.MessageHandler.Context
-
Mark the message as processed, potentially asking for more messages from the broker.
- processed(MessageHandler.Context) - Method in interface com.rabbitmq.stream.ConsumerFlowStrategy.MessageProcessedCallback
-
Method called when
MessageHandler.Context.processed()
is called. - ProcessObservationConvention - Interface in com.rabbitmq.stream.observation.micrometer
-
ObservationConvention
for RabbitMQ Stream consuming. - Producer - Interface in com.rabbitmq.stream
-
API to send messages to a RabbitMQ Stream.
- producerBuilder() - Method in interface com.rabbitmq.stream.Environment
-
Create a
ProducerBuilder
to configure and create aProducer
. - producerBuilder() - Method in interface com.rabbitmq.stream.ProducerBuilder.RoutingConfiguration
-
Go back to the producer builder.
- ProducerBuilder - Interface in com.rabbitmq.stream
-
API to create and configure a
Producer
. - ProducerBuilder.RoutingConfiguration - Interface in com.rabbitmq.stream
-
Routing configuration for super streams (partitioned streams).
- properties() - Method in class com.rabbitmq.stream.codec.WrapperMessageBuilder
- properties() - Method in interface com.rabbitmq.stream.MessageBuilder
-
The builder for
Properties
. - Properties - Interface in com.rabbitmq.stream
-
Message properties.
- publish(byte, List<Message>) - Method in class com.rabbitmq.stream.impl.Client
- publish(byte, List<Message>, Client.OutboundEntityMappingCallback) - Method in class com.rabbitmq.stream.impl.Client
- publish(byte, List<Message>, Client.OutboundEntityMappingCallback, ToLongFunction<Object>) - Method in class com.rabbitmq.stream.impl.Client
- publish(byte, List<Message>, ToLongFunction<Object>) - Method in class com.rabbitmq.stream.impl.Client
- publish(int) - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- publish(int) - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- publish(int) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- publish(int) - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
- PUBLISH_OBSERVATION - Enum constant in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation
-
Observation for publishing a message.
- publishBatches(byte, List<MessageBatch>) - Method in class com.rabbitmq.stream.impl.Client
- publishBatches(byte, List<MessageBatch>, Client.OutboundEntityMappingCallback) - Method in class com.rabbitmq.stream.impl.Client
- publishBatches(byte, List<MessageBatch>, Client.OutboundEntityMappingCallback, ToLongFunction<Object>) - Method in class com.rabbitmq.stream.impl.Client
- publishBatches(byte, List<MessageBatch>, ToLongFunction<Object>) - Method in class com.rabbitmq.stream.impl.Client
- publishConfirm(int) - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- publishConfirm(int) - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- publishConfirm(int) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- publishConfirm(int) - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
- publishConfirmListener(Client.PublishConfirmListener) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- PublishContext - Class in com.rabbitmq.stream.observation.micrometer
-
Observation.Context
for RabbitMQ Stream publishing. - published(T, Message) - Method in interface com.rabbitmq.stream.ObservationCollector
-
Callback when the message is about to be published.
- publishError(int) - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- publishError(int) - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- publishError(int) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- publishError(int) - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
- publishErrorListener(Client.PublishErrorListener) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- publishingId(long) - Method in class com.rabbitmq.stream.codec.WrapperMessageBuilder
- publishingId(long) - Method in interface com.rabbitmq.stream.MessageBuilder
-
Set the publishing ID (for de-duplication).
- PublishObservationConvention - Interface in com.rabbitmq.stream.observation.micrometer
-
ObservationConvention
for RabbitMQ Stream consuming. - put(String, String) - Method in class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
Q
- QpidProtonCodec - Class in com.rabbitmq.stream.codec
- QpidProtonCodec() - Constructor for class com.rabbitmq.stream.codec.QpidProtonCodec
- queryOffset(String, String) - Method in class com.rabbitmq.stream.impl.Client
- QueryOffsetResponse(short, long) - Constructor for class com.rabbitmq.stream.impl.Client.QueryOffsetResponse
- queryPublisherSequence(String, String) - Method in class com.rabbitmq.stream.impl.Client
- queryStreamStats(String) - Method in interface com.rabbitmq.stream.Environment
-
Query statistics on a stream.
R
- RANDOM - Enum constant in enum com.rabbitmq.stream.StreamCreator.LeaderLocator
-
The stream leader will be a random node of the cluster.
- readBytes(int) - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- readBytes(int) - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- readBytes(int) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- readBytes(int) - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
- recoveryBackOffDelayPolicy(BackOffDelayPolicy) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The
BackOffDelayPolicy
to use for connection recovery. - recoveryBackOffDelayPolicy(BackOffDelayPolicy) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- registry(ObservationRegistry) - Method in class com.rabbitmq.stream.observation.micrometer.MicrometerObservationCollectorBuilder
-
Set the
ObservationRegistry
to use. - remoteAddress() - Method in class com.rabbitmq.stream.impl.Client
- replyTo(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the reply to address.
- replyToGroupId(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the reply-to group ID.
- requestedHeartbeat(Duration) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The heartbeat to request.
- requestedHeartbeat(Duration) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- requestedHeartbeat(Duration) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- requestedMaxFrameSize(int) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The maximum frame size to request.
- requestedMaxFrameSize(int) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- requestedMaxFrameSize(int) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- resolve(Address) - Method in interface com.rabbitmq.stream.AddressResolver
-
Compute an address to connect to.
- Response(short) - Constructor for class com.rabbitmq.stream.impl.Client.Response
- RESPONSE_CODE_ACCESS_REFUSED - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_AUTHENTICATION_FAILURE - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_AUTHENTICATION_FAILURE_LOOPBACK - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_FRAME_TOO_LARGE - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_INTERNAL_ERROR - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_NO_OFFSET - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_OK - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_PRECONDITION_FAILED - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_PUBLISHER_DOES_NOT_EXIST - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_SASL_CANNOT_CHANGE_MECHANISM - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_SASL_CANNOT_CHANGE_USERNAME - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_SASL_CHALLENGE - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_SASL_ERROR - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_SASL_MECHANISM_NOT_SUPPORTED - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_STREAM_ALREADY_EXISTS - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_STREAM_DOES_NOT_EXIST - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_STREAM_NOT_AVAILABLE - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_SUBSCRIPTION_ID_ALREADY_EXISTS - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_SUBSCRIPTION_ID_DOES_NOT_EXIST - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_UNKNOWN_FRAME - Static variable in class com.rabbitmq.stream.Constants
- RESPONSE_CODE_VIRTUAL_HOST_ACCESS_FAILURE - Static variable in class com.rabbitmq.stream.Constants
- retryOnRecovery(boolean) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
Whether to republish unconfirmed messages after recovery.
- route(Message, RoutingStrategy.Metadata) - Method in interface com.rabbitmq.stream.RoutingStrategy
-
Where to route a message.
- route(String) - Method in interface com.rabbitmq.stream.RoutingStrategy.Metadata
- route(String, String) - Method in class com.rabbitmq.stream.impl.Client
- routing(Function<Message, String>) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
Configure the routing for super streams (partitioned streams).
- RoutingStrategy - Interface in com.rabbitmq.stream
-
Strategy to route outbound messages to appropriate streams.
- RoutingStrategy.Metadata - Interface in com.rabbitmq.stream
-
Metadata on the super stream.
- rpcTimeout(Duration) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Timeout for RPC calls.
- rpcTimeout(Duration) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- rpcTimeout(Duration) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
S
- saslConfiguration(SaslConfiguration) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The SASL configuration to use.
- saslConfiguration(SaslConfiguration) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- saslConfiguration(SaslConfiguration) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- SaslConfiguration - Interface in com.rabbitmq.stream.sasl
-
Contract to choose a
SaslMechanism
from the ones supported by the server. - SaslMechanism - Interface in com.rabbitmq.stream.sasl
-
Contract to handle SASL challenges sent by a SASL server.
- scheduledExecutorService(ScheduledExecutorService) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Set the
ScheduledExecutorService
used to: Schedule producers batch sending Handle connection recovery Handle topology update - scheduledExecutorService(ScheduledExecutorService) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- send(Message, ConfirmationHandler) - Method in interface com.rabbitmq.stream.Producer
-
Publish a message.
- SERVER_CLOSE - Enum constant in enum com.rabbitmq.stream.impl.Client.ShutdownContext.ShutdownReason
- shortValue() - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- shortValue() - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- shutdownListener(Client.ShutdownListener) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- SimpleCodec - Class in com.rabbitmq.stream.codec
- SimpleCodec() - Constructor for class com.rabbitmq.stream.codec.SimpleCodec
- singleActiveConsumer() - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
Declare the consumer as a single active consumer.
- SINGLETON - Static variable in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
- SNAPPY - Enum constant in enum com.rabbitmq.stream.compression.Compression
- sslContext(SslContext) - Method in interface com.rabbitmq.stream.EnvironmentBuilder.TlsConfiguration
-
Netty
SslContext
for TLS connections. - sslContext(SslContext) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- start(ConsumerFlowStrategy.Context) - Method in class com.rabbitmq.stream.ConsumerFlowStrategy.CreditOnChunkArrivalConsumerFlowStrategy
- start(ConsumerFlowStrategy.Context) - Method in class com.rabbitmq.stream.ConsumerFlowStrategy.MessageCountConsumerFlowStrategy
- start(ConsumerFlowStrategy.Context) - Method in interface com.rabbitmq.stream.ConsumerFlowStrategy
-
Return the behavior for
MessageHandler.Context.processed()
calls. - store(long) - Method in interface com.rabbitmq.stream.Consumer
-
Store the offset.
- storedOffset() - Method in interface com.rabbitmq.stream.Consumer
-
The stored offset for this named consumer on the configured stream.
- storeOffset() - Method in interface com.rabbitmq.stream.MessageHandler.Context
-
Shortcut to send a store order for the message offset.
- storeOffset(String, String, long) - Method in class com.rabbitmq.stream.impl.Client
- strategy(ConsumerFlowStrategy) - Method in interface com.rabbitmq.stream.ConsumerBuilder.FlowConfiguration
-
Flow strategy to use
- strategy(RoutingStrategy) - Method in interface com.rabbitmq.stream.ProducerBuilder.RoutingConfiguration
-
Set the routing strategy to use.
- stream() - Method in interface com.rabbitmq.stream.ConsumerUpdateListener.Context
-
The stream (partition in a super stream) involved.
- stream() - Method in interface com.rabbitmq.stream.MessageHandler.Context
-
The stream the message comes from.
- stream() - Method in class com.rabbitmq.stream.observation.micrometer.PublishContext
- stream() - Method in interface com.rabbitmq.stream.SubscriptionListener.SubscriptionContext
-
The stream involved.
- stream(String) - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
The stream to consume from.
- stream(String) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
The stream to send messages to.
- stream(String) - Method in interface com.rabbitmq.stream.StreamCreator
-
The name of the stream.
- streamCreator() - Method in interface com.rabbitmq.stream.Environment
-
Return a
StreamCreator
to configure and create a stream. - StreamCreator - Interface in com.rabbitmq.stream
-
API to configure and create a stream.
- StreamCreator.LeaderLocator - Enum in com.rabbitmq.stream
-
The leader locator strategy.
- StreamCreator.SuperStreamConfiguration - Interface in com.rabbitmq.stream
-
Super stream configuration.
- StreamDoesNotExistException - Exception Class in com.rabbitmq.stream
-
Exception to indicate a stream does not exist.
- StreamDoesNotExistException(String) - Constructor for exception class com.rabbitmq.stream.StreamDoesNotExistException
- StreamEnvironmentBuilder - Class in com.rabbitmq.stream.impl
- StreamEnvironmentBuilder() - Constructor for class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- StreamException - Exception Class in com.rabbitmq.stream
-
Generic stream exception.
- StreamException(String) - Constructor for exception class com.rabbitmq.stream.StreamException
- StreamException(String, short) - Constructor for exception class com.rabbitmq.stream.StreamException
- StreamException(String, Throwable) - Constructor for exception class com.rabbitmq.stream.StreamException
- StreamException(Throwable) - Constructor for exception class com.rabbitmq.stream.StreamException
- streamExists(String) - Method in interface com.rabbitmq.stream.Environment
-
Return whether a stream exists or not.
- StreamMetadata(String, short, Client.Broker, List<Client.Broker>) - Constructor for class com.rabbitmq.stream.impl.Client.StreamMetadata
- StreamNotAvailableException - Exception Class in com.rabbitmq.stream
-
Exception to indicate a stream is not available.
- StreamNotAvailableException(String) - Constructor for exception class com.rabbitmq.stream.StreamNotAvailableException
- StreamObservationDocumentation - Enum in com.rabbitmq.stream.observation.micrometer
-
ObservationDocumentation
for RabbitMQ Stream. - StreamObservationDocumentation.HighCardinalityTags - Enum in com.rabbitmq.stream.observation.micrometer
-
High cardinality tags.
- StreamObservationDocumentation.LowCardinalityTags - Enum in com.rabbitmq.stream.observation.micrometer
-
Low cardinality tags.
- StreamParametersBuilder() - Constructor for class com.rabbitmq.stream.impl.Client.StreamParametersBuilder
- StreamSaslException - Exception Class in com.rabbitmq.stream.sasl
- StreamSaslException(Throwable) - Constructor for exception class com.rabbitmq.stream.sasl.StreamSaslException
- StreamStats - Interface in com.rabbitmq.stream
-
Statistics on a stream.
- subEntrySize(int) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
The number of messages to put in a sub-entry of a publish frame.
- subject(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the subject.
- subscribe(byte, String, OffsetSpecification, int) - Method in class com.rabbitmq.stream.impl.Client
-
Subscribe to receive messages from a stream.
- subscribe(byte, String, OffsetSpecification, int, Map<String, String>) - Method in class com.rabbitmq.stream.impl.Client
-
Subscribe to receive messages from a stream.
- subscribe(MessageHandler) - Method in interface com.rabbitmq.stream.ObservationCollector
-
Decorate consumer registration.
- subscriptionListener(SubscriptionListener) - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
Callback on subscription.
- SubscriptionListener - Interface in com.rabbitmq.stream
-
Callback interface to customize a subscription.
- SubscriptionListener.SubscriptionContext - Interface in com.rabbitmq.stream
-
Context object for the subscription.
- subtract(UnsignedInteger) - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- superStream() - Method in interface com.rabbitmq.stream.StreamCreator
-
Configure the super stream to create.
- superStream(String) - Method in interface com.rabbitmq.stream.ConsumerBuilder
-
Set the consumer to consume from a super stream (partitioned stream).
- superStream(String) - Method in interface com.rabbitmq.stream.ProducerBuilder
-
The super stream to send messages to.
- supportsContext(Observation.Context) - Method in interface com.rabbitmq.stream.observation.micrometer.ProcessObservationConvention
- supportsContext(Observation.Context) - Method in interface com.rabbitmq.stream.observation.micrometer.PublishObservationConvention
- SwiftMqCodec - Class in com.rabbitmq.stream.codec
- SwiftMqCodec() - Constructor for class com.rabbitmq.stream.codec.SwiftMqCodec
- Symbol - Class in com.rabbitmq.stream.amqp
T
- TB(long) - Static method in class com.rabbitmq.stream.ByteCapacity
- TIMEOUT - Static variable in interface com.rabbitmq.stream.BackOffDelayPolicy
- timestamp() - Method in interface com.rabbitmq.stream.MessageHandler.Context
-
The timestamp of the message chunk.
- timestamp(long) - Static method in class com.rabbitmq.stream.OffsetSpecification
-
Offset of messages stored after the specified timestamp.
- tls() - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
Enable and configure TLS.
- tls() - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- tlsHostnameVerification(boolean) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- to(String) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the to address.
- toBytes() - Method in class com.rabbitmq.stream.ByteCapacity
- topologyUpdateBackOffDelayPolicy(BackOffDelayPolicy) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The
BackOffDelayPolicy
to use for topology recovery. - topologyUpdateBackOffDelayPolicy(BackOffDelayPolicy) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- toString() - Method in class com.rabbitmq.stream.Address
- toString() - Method in class com.rabbitmq.stream.amqp.Symbol
- toString() - Method in class com.rabbitmq.stream.amqp.UnsignedByte
- toString() - Method in class com.rabbitmq.stream.amqp.UnsignedInteger
- toString() - Method in class com.rabbitmq.stream.amqp.UnsignedLong
- toString() - Method in class com.rabbitmq.stream.amqp.UnsignedShort
- toString() - Method in class com.rabbitmq.stream.BackOffDelayPolicy.FixedWithInitialDelayAndTimeoutBackOffPolicy
- toString() - Method in class com.rabbitmq.stream.BackOffDelayPolicy.FixedWithInitialDelayBackOffPolicy
- toString() - Method in class com.rabbitmq.stream.ByteCapacity
- toString() - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressGzipCompressionCodec
- toString() - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressLz4CompressionCodec
- toString() - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressSnappyCompressionCodec
- toString() - Method in class com.rabbitmq.stream.compression.CompressionUtils.CommonsCompressZstdCompressionCodec
- toString() - Method in class com.rabbitmq.stream.compression.CompressionUtils.GzipCompressionCodec
- toString() - Method in class com.rabbitmq.stream.compression.CompressionUtils.Lz4JavaCompressionCodec
- toString() - Method in class com.rabbitmq.stream.compression.CompressionUtils.XerialSnappyCompressionCodec
- toString() - Method in class com.rabbitmq.stream.compression.CompressionUtils.ZstdJniCompressionCodec
- toString() - Method in class com.rabbitmq.stream.impl.Client.Broker
- toString() - Method in class com.rabbitmq.stream.impl.Client.Response
- toString() - Method in class com.rabbitmq.stream.impl.Client.StreamMetadata
- toString() - Method in class com.rabbitmq.stream.impl.Client
- toString() - Method in class com.rabbitmq.stream.OffsetSpecification
- trustEverything() - Method in interface com.rabbitmq.stream.EnvironmentBuilder.TlsConfiguration
-
Convenience method to set a
SslContext
that trusts all servers.
U
- UNKNOWN - Enum constant in enum com.rabbitmq.stream.impl.Client.ShutdownContext.ShutdownReason
- UnsignedByte - Class in com.rabbitmq.stream.amqp
-
This code is based on QPid Proton's
UnsignedByte
class. - UnsignedByte(byte) - Constructor for class com.rabbitmq.stream.amqp.UnsignedByte
- UnsignedInteger - Class in com.rabbitmq.stream.amqp
-
This code is based on QPid Proton's
UnsignedInteger
class. - UnsignedInteger(int) - Constructor for class com.rabbitmq.stream.amqp.UnsignedInteger
- UnsignedLong - Class in com.rabbitmq.stream.amqp
-
This code is based on QPid Proton's
UnsignedLong
class. - UnsignedLong(long) - Constructor for class com.rabbitmq.stream.amqp.UnsignedLong
- UnsignedShort - Class in com.rabbitmq.stream.amqp
-
This code is based on QPid Proton's
UnsignedShort
class. - UnsignedShort(short) - Constructor for class com.rabbitmq.stream.amqp.UnsignedShort
- unsubscribe(byte) - Method in class com.rabbitmq.stream.impl.Client
- update(ConsumerUpdateListener.Context) - Method in interface com.rabbitmq.stream.ConsumerUpdateListener
-
Callback when the consumer status change.
- uri(String) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The URI of a node to connect to.
- uri(String) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- uris(List<String>) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
A list of URIs of nodes of the same cluster to use to connect to.
- uris(List<String>) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- userId(byte[]) - Method in interface com.rabbitmq.stream.MessageBuilder.PropertiesBuilder
-
Set the user ID.
- username(String) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The username to use.
- username(String) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- username(String) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
- UsernamePasswordCredentialsProvider - Interface in com.rabbitmq.stream.sasl
-
Contract for credentials based on a username/password pair.
V
- value() - Method in enum com.rabbitmq.stream.StreamCreator.LeaderLocator
- valueOf(byte) - Static method in class com.rabbitmq.stream.amqp.UnsignedByte
- valueOf(int) - Static method in class com.rabbitmq.stream.amqp.UnsignedInteger
- valueOf(long) - Static method in class com.rabbitmq.stream.amqp.UnsignedInteger
- valueOf(long) - Static method in class com.rabbitmq.stream.amqp.UnsignedLong
- valueOf(short) - Static method in class com.rabbitmq.stream.amqp.UnsignedShort
- valueOf(String) - Static method in class com.rabbitmq.stream.amqp.Symbol
- valueOf(String) - Static method in class com.rabbitmq.stream.amqp.UnsignedByte
- valueOf(String) - Static method in class com.rabbitmq.stream.amqp.UnsignedInteger
- valueOf(String) - Static method in class com.rabbitmq.stream.amqp.UnsignedLong
- valueOf(String) - Static method in class com.rabbitmq.stream.amqp.UnsignedShort
- valueOf(String) - Static method in enum com.rabbitmq.stream.compression.Compression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.rabbitmq.stream.impl.Client.ShutdownContext.ShutdownReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.HighCardinalityTags
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.LowCardinalityTags
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.rabbitmq.stream.StreamCreator.LeaderLocator
-
Returns the enum constant of this type with the specified name.
- valueOf(BigInteger) - Static method in class com.rabbitmq.stream.amqp.UnsignedLong
- values() - Static method in enum com.rabbitmq.stream.compression.Compression
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.rabbitmq.stream.impl.Client.ShutdownContext.ShutdownReason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.HighCardinalityTags
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation.LowCardinalityTags
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.rabbitmq.stream.observation.micrometer.StreamObservationDocumentation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.rabbitmq.stream.StreamCreator.LeaderLocator
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values(String...) - Method in interface com.rabbitmq.stream.ConsumerBuilder.FilterConfiguration
-
Set the filter values.
- VERSION - Static variable in class com.rabbitmq.stream.impl.ClientProperties
- VERSION_1 - Static variable in class com.rabbitmq.stream.Constants
- VERSION_2 - Static variable in class com.rabbitmq.stream.Constants
- virtualHost(String) - Method in interface com.rabbitmq.stream.EnvironmentBuilder
-
The virtual host to connect to.
- virtualHost(String) - Method in class com.rabbitmq.stream.impl.Client.ClientParameters
- virtualHost(String) - Method in class com.rabbitmq.stream.impl.StreamEnvironmentBuilder
W
- WrapperMessageBuilder - Class in com.rabbitmq.stream.codec
- WrapperMessageBuilder() - Constructor for class com.rabbitmq.stream.codec.WrapperMessageBuilder
- writtenBytes(int) - Method in class com.rabbitmq.stream.metrics.DropwizardMetricsCollector
- writtenBytes(int) - Method in interface com.rabbitmq.stream.metrics.MetricsCollector
- writtenBytes(int) - Method in class com.rabbitmq.stream.metrics.MicrometerMetricsCollector
- writtenBytes(int) - Method in class com.rabbitmq.stream.metrics.NoOpMetricsCollector
X
- XerialSnappyCompressionCodec() - Constructor for class com.rabbitmq.stream.compression.CompressionUtils.XerialSnappyCompressionCodec
Z
- ZERO - Static variable in class com.rabbitmq.stream.amqp.UnsignedInteger
- ZERO - Static variable in class com.rabbitmq.stream.amqp.UnsignedLong
- ZSTD - Enum constant in enum com.rabbitmq.stream.compression.Compression
- ZstdJniCompressionCodec() - Constructor for class com.rabbitmq.stream.compression.CompressionUtils.ZstdJniCompressionCodec
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form