Class ImmutableReactiveMessageSenderSpec
java.lang.Object
org.apache.pulsar.reactive.client.api.ImmutableReactiveMessageSenderSpec
- All Implemented Interfaces:
ReactiveMessageSenderSpec
Immutable spec for a
ReactiveMessageSender
.-
Constructor Summary
ConstructorsConstructorDescriptionImmutableReactiveMessageSenderSpec
(String topicName, String producerName, Duration sendTimeout, Integer maxPendingMessages, Integer maxPendingMessagesAcrossPartitions, org.apache.pulsar.client.api.MessageRoutingMode messageRoutingMode, org.apache.pulsar.client.api.HashingScheme hashingScheme, org.apache.pulsar.client.api.ProducerCryptoFailureAction cryptoFailureAction, org.apache.pulsar.client.api.MessageRouter messageRouter, Duration batchingMaxPublishDelay, Integer roundRobinRouterBatchingPartitionSwitchFrequency, Integer batchingMaxMessages, Integer batchingMaxBytes, Boolean batchingEnabled, org.apache.pulsar.client.api.BatcherBuilder batcherBuilder, Boolean chunkingEnabled, org.apache.pulsar.client.api.CryptoKeyReader cryptoKeyReader, Set<String> encryptionKeys, org.apache.pulsar.client.api.CompressionType compressionType, Long initialSequenceId, Boolean autoUpdatePartitions, Duration autoUpdatePartitionsInterval, Boolean multiSchema, org.apache.pulsar.client.api.ProducerAccessMode accessMode, Boolean lazyStartPartitionedProducers, Map<String, String> properties) Constructs a ImmutableReactiveMessageConsumerSpec from anotherReactiveMessageConsumerSpec
. -
Method Summary
Modifier and TypeMethodDescriptionorg.apache.pulsar.client.api.ProducerAccessMode
Gets the type of access mode that the producer requires on the topic.Gets whether partitioned producer will automatically discover new partitions at runtime.Gets the interval of partitions updates if autoUpdatePartitions is enabled.org.apache.pulsar.client.api.BatcherBuilder
Gets the batcher builder of the producer.Gets whether automatic batching of messages is enabled for the producer.Gets the maximum number of bytes permitted in a batch.Gets the maximum number of messages permitted in a batch.Gets the time period within which the messages sent will be batched.Gets whether chunking of messages is enabled.org.apache.pulsar.client.api.CompressionType
Gets the compression type for the producer.org.apache.pulsar.client.api.ProducerCryptoFailureAction
Gets the action the producer will take in case of encryption failures.org.apache.pulsar.client.api.CryptoKeyReader
Gets the key reader to be used to encrypt the message payloads.Gets the public encryption key names, used by producer to encrypt the data key.org.apache.pulsar.client.api.HashingScheme
Gets the hashing function determining the partition where to publish a particular message on partitioned topics.Gets the baseline for the sequence ids for messages published by the producer.Gets whether producers register and connect immediately to the owner broker of each partition or start lazily on demand.Gets the maximum size of the queue holding the messages pending to receive an acknowledgment from the broker.Gets the maximum number of pending messages across all the partitions.org.apache.pulsar.client.api.MessageRouter
Gets the custom message router.org.apache.pulsar.client.api.MessageRoutingMode
Gets the message routing logic for producers on partitioned topics.Gets whether the multiple schema mode is enabled.Gets the name of the producer.Gets the properties of the producer.Gets the partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed message.Gets the send timeout.Gets the topic to publish on.
-
Constructor Details
-
ImmutableReactiveMessageSenderSpec
public ImmutableReactiveMessageSenderSpec(String topicName, String producerName, Duration sendTimeout, Integer maxPendingMessages, Integer maxPendingMessagesAcrossPartitions, org.apache.pulsar.client.api.MessageRoutingMode messageRoutingMode, org.apache.pulsar.client.api.HashingScheme hashingScheme, org.apache.pulsar.client.api.ProducerCryptoFailureAction cryptoFailureAction, org.apache.pulsar.client.api.MessageRouter messageRouter, Duration batchingMaxPublishDelay, Integer roundRobinRouterBatchingPartitionSwitchFrequency, Integer batchingMaxMessages, Integer batchingMaxBytes, Boolean batchingEnabled, org.apache.pulsar.client.api.BatcherBuilder batcherBuilder, Boolean chunkingEnabled, org.apache.pulsar.client.api.CryptoKeyReader cryptoKeyReader, Set<String> encryptionKeys, org.apache.pulsar.client.api.CompressionType compressionType, Long initialSequenceId, Boolean autoUpdatePartitions, Duration autoUpdatePartitionsInterval, Boolean multiSchema, org.apache.pulsar.client.api.ProducerAccessMode accessMode, Boolean lazyStartPartitionedProducers, Map<String, String> properties) -
ImmutableReactiveMessageSenderSpec
Constructs a ImmutableReactiveMessageConsumerSpec from anotherReactiveMessageConsumerSpec
.- Parameters:
senderSpec
- the spec to construct from
-
-
Method Details
-
getTopicName
Description copied from interface:ReactiveMessageSenderSpec
Gets the topic to publish on.- Specified by:
getTopicName
in interfaceReactiveMessageSenderSpec
- Returns:
- the topic
- See Also:
-
ProducerBuilder.topic(java.lang.String)
-
getProducerName
Description copied from interface:ReactiveMessageSenderSpec
Gets the name of the producer.- Specified by:
getProducerName
in interfaceReactiveMessageSenderSpec
- Returns:
- the producer name
- See Also:
-
ProducerBuilder.producerName(java.lang.String)
-
getSendTimeout
Description copied from interface:ReactiveMessageSenderSpec
Gets the send timeout.- Specified by:
getSendTimeout
in interfaceReactiveMessageSenderSpec
- Returns:
- the send timeout
- See Also:
-
ProducerBuilder.sendTimeout(int, java.util.concurrent.TimeUnit)
-
getMaxPendingMessages
Description copied from interface:ReactiveMessageSenderSpec
Gets the maximum size of the queue holding the messages pending to receive an acknowledgment from the broker.- Specified by:
getMaxPendingMessages
in interfaceReactiveMessageSenderSpec
- Returns:
- the maximum pending messages
- See Also:
-
ProducerBuilder.maxPendingMessages(int)
-
getMaxPendingMessagesAcrossPartitions
Description copied from interface:ReactiveMessageSenderSpec
Gets the maximum number of pending messages across all the partitions.- Specified by:
getMaxPendingMessagesAcrossPartitions
in interfaceReactiveMessageSenderSpec
- Returns:
- the maximum number of pending messages across all the partitions
- See Also:
-
ProducerBuilder.maxPendingMessagesAcrossPartitions(int)
-
getMessageRoutingMode
public org.apache.pulsar.client.api.MessageRoutingMode getMessageRoutingMode()Description copied from interface:ReactiveMessageSenderSpec
Gets the message routing logic for producers on partitioned topics.- Specified by:
getMessageRoutingMode
in interfaceReactiveMessageSenderSpec
- Returns:
- the message routing mode
- See Also:
-
ProducerBuilder.messageRoutingMode(org.apache.pulsar.client.api.MessageRoutingMode)
-
getHashingScheme
public org.apache.pulsar.client.api.HashingScheme getHashingScheme()Description copied from interface:ReactiveMessageSenderSpec
Gets the hashing function determining the partition where to publish a particular message on partitioned topics.- Specified by:
getHashingScheme
in interfaceReactiveMessageSenderSpec
- Returns:
- the hashing scheme
- See Also:
-
ProducerBuilder.hashingScheme(org.apache.pulsar.client.api.HashingScheme)
-
getCryptoFailureAction
public org.apache.pulsar.client.api.ProducerCryptoFailureAction getCryptoFailureAction()Description copied from interface:ReactiveMessageSenderSpec
Gets the action the producer will take in case of encryption failures.- Specified by:
getCryptoFailureAction
in interfaceReactiveMessageSenderSpec
- Returns:
- the action the producer will take in case of encryption failures
- See Also:
-
ProducerBuilder.cryptoFailureAction(org.apache.pulsar.client.api.ProducerCryptoFailureAction)
-
getMessageRouter
public org.apache.pulsar.client.api.MessageRouter getMessageRouter()Description copied from interface:ReactiveMessageSenderSpec
Gets the custom message router.- Specified by:
getMessageRouter
in interfaceReactiveMessageSenderSpec
- Returns:
- the message router
- See Also:
-
ProducerBuilder.messageRouter(org.apache.pulsar.client.api.MessageRouter)
-
getBatchingMaxPublishDelay
Description copied from interface:ReactiveMessageSenderSpec
Gets the time period within which the messages sent will be batched.- Specified by:
getBatchingMaxPublishDelay
in interfaceReactiveMessageSenderSpec
- Returns:
- the batch delay
- See Also:
-
ProducerBuilder.batchingMaxPublishDelay(long, java.util.concurrent.TimeUnit)
-
getRoundRobinRouterBatchingPartitionSwitchFrequency
Description copied from interface:ReactiveMessageSenderSpec
Gets the partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed message.- Specified by:
getRoundRobinRouterBatchingPartitionSwitchFrequency
in interfaceReactiveMessageSenderSpec
- Returns:
- the frequency of partition switch
- See Also:
-
ProducerBuilder.roundRobinRouterBatchingPartitionSwitchFrequency(int)
-
getBatchingMaxMessages
Description copied from interface:ReactiveMessageSenderSpec
Gets the maximum number of messages permitted in a batch.- Specified by:
getBatchingMaxMessages
in interfaceReactiveMessageSenderSpec
- Returns:
- the maximum number of messages in a batch
- See Also:
-
ProducerBuilder.batchingMaxMessages(int)
-
getBatchingMaxBytes
Description copied from interface:ReactiveMessageSenderSpec
Gets the maximum number of bytes permitted in a batch.- Specified by:
getBatchingMaxBytes
in interfaceReactiveMessageSenderSpec
- Returns:
- the maximum bytes of messages in a batch
- See Also:
-
ProducerBuilder.batchingMaxBytes(int)
-
getBatchingEnabled
Description copied from interface:ReactiveMessageSenderSpec
Gets whether automatic batching of messages is enabled for the producer.- Specified by:
getBatchingEnabled
in interfaceReactiveMessageSenderSpec
- Returns:
- true if batching is enabled
- See Also:
-
ProducerBuilder.enableBatching(boolean)
-
getBatcherBuilder
public org.apache.pulsar.client.api.BatcherBuilder getBatcherBuilder()Description copied from interface:ReactiveMessageSenderSpec
Gets the batcher builder of the producer.- Specified by:
getBatcherBuilder
in interfaceReactiveMessageSenderSpec
- Returns:
- the batcher builder
- See Also:
-
ProducerBuilder.batcherBuilder(org.apache.pulsar.client.api.BatcherBuilder)
-
getChunkingEnabled
Description copied from interface:ReactiveMessageSenderSpec
Gets whether chunking of messages is enabled.- Specified by:
getChunkingEnabled
in interfaceReactiveMessageSenderSpec
- Returns:
- true if message chunking is enabled
- See Also:
-
ProducerBuilder.enableChunking(boolean)
-
getCryptoKeyReader
public org.apache.pulsar.client.api.CryptoKeyReader getCryptoKeyReader()Description copied from interface:ReactiveMessageSenderSpec
Gets the key reader to be used to encrypt the message payloads.- Specified by:
getCryptoKeyReader
in interfaceReactiveMessageSenderSpec
- Returns:
- the key reader to be used to encrypt the message payloads
- See Also:
-
ProducerBuilder.cryptoKeyReader(org.apache.pulsar.client.api.CryptoKeyReader)
-
getEncryptionKeys
Description copied from interface:ReactiveMessageSenderSpec
Gets the public encryption key names, used by producer to encrypt the data key.- Specified by:
getEncryptionKeys
in interfaceReactiveMessageSenderSpec
- Returns:
- the public encryption key names
- See Also:
-
ProducerBuilder.addEncryptionKey(java.lang.String)
-
getCompressionType
public org.apache.pulsar.client.api.CompressionType getCompressionType()Description copied from interface:ReactiveMessageSenderSpec
Gets the compression type for the producer.- Specified by:
getCompressionType
in interfaceReactiveMessageSenderSpec
- Returns:
- the compression type
- See Also:
-
ProducerBuilder.compressionType(org.apache.pulsar.client.api.CompressionType)
-
getInitialSequenceId
Description copied from interface:ReactiveMessageSenderSpec
Gets the baseline for the sequence ids for messages published by the producer.- Specified by:
getInitialSequenceId
in interfaceReactiveMessageSenderSpec
- Returns:
- the initial sequence id
- See Also:
-
ProducerBuilder.initialSequenceId(long)
-
getAutoUpdatePartitions
Description copied from interface:ReactiveMessageSenderSpec
Gets whether partitioned producer will automatically discover new partitions at runtime.- Specified by:
getAutoUpdatePartitions
in interfaceReactiveMessageSenderSpec
- Returns:
- true if auto discovery of the partition configuration changes is enabled
- See Also:
-
ProducerBuilder.autoUpdatePartitions(boolean)
-
getAutoUpdatePartitionsInterval
Description copied from interface:ReactiveMessageSenderSpec
Gets the interval of partitions updates if autoUpdatePartitions is enabled.- Specified by:
getAutoUpdatePartitionsInterval
in interfaceReactiveMessageSenderSpec
- Returns:
- the interval of partitions updates
- See Also:
-
ProducerBuilder.autoUpdatePartitionsInterval(int, java.util.concurrent.TimeUnit)
-
getMultiSchema
Description copied from interface:ReactiveMessageSenderSpec
Gets whether the multiple schema mode is enabled.- Specified by:
getMultiSchema
in interfaceReactiveMessageSenderSpec
- Returns:
- true if the multiple schema mode is enabled
- See Also:
-
ProducerBuilder.enableMultiSchema(boolean)
-
getAccessMode
public org.apache.pulsar.client.api.ProducerAccessMode getAccessMode()Description copied from interface:ReactiveMessageSenderSpec
Gets the type of access mode that the producer requires on the topic.- Specified by:
getAccessMode
in interfaceReactiveMessageSenderSpec
- Returns:
- the access mode
- See Also:
-
ProducerBuilder.accessMode(org.apache.pulsar.client.api.ProducerAccessMode)
-
getLazyStartPartitionedProducers
Description copied from interface:ReactiveMessageSenderSpec
Gets whether producers register and connect immediately to the owner broker of each partition or start lazily on demand.- Specified by:
getLazyStartPartitionedProducers
in interfaceReactiveMessageSenderSpec
- Returns:
- true if lazy starting of partitioned producers is enabled
- See Also:
-
ProducerBuilder.enableLazyStartPartitionedProducers(boolean)
-
getProperties
Description copied from interface:ReactiveMessageSenderSpec
Gets the properties of the producer.- Specified by:
getProperties
in interfaceReactiveMessageSenderSpec
- Returns:
- the properties of the producer
- See Also:
-
ProducerBuilder.properties(java.util.Map<java.lang.String, java.lang.String>)
-