You can specify various properties inside your application.properties file, inside your application.yml file, or as command line switches.
This appendix provides a list of Spring Pulsar properties and references to the underlying classes that consume them.
| Spring Boot provides various conversion mechanisms with advanced value formatting. See the properties conversion section for more detail. |
Pulsar Client Properties
| Name | Description | Default Value |
|---|---|---|
Authentication parameter(s) as a JSON encoded string. |
||
Fully qualified class name of the authentication plugin. |
||
Authentication parameter(s) as a map of parameter names to parameter values. |
||
Duration to wait for a connection to a broker to be established. |
|
|
DNS lookup bind address. |
||
DNS lookup bind port. |
|
|
Enables spin-waiting on executors and IO threads in order to reduce latency during context switches. |
|
|
Enables transactions. To use this, start the transactionCoordinatorClient with the pulsar client. |
|
|
Initial backoff interval. |
|
|
Keep alive interval for broker-client connection. |
|
|
Listener name for lookup. Clients can use listenerName to choose one of the listeners as the service URL to create a connection to the broker. To use this, "advertisedListeners" must be enabled on the broker. |
||
Client lookup timeout. |
|
|
Maximum backoff interval. |
|
|
Number of concurrent lookup-requests allowed to send on each broker-connection to prevent overload on broker. |
|
|
Maximum number of times a lookup-request to a broker will be redirected. |
|
|
Number of max lookup-requests allowed on each broker-connection to prevent overload on broker. |
|
|
|
Maximum number of broker-rejected requests in a certain timeframe, after which the current connection is closed and a new connection is created by the client. |
|
Limit of direct memory that will be allocated by the client. |
|
|
Maximum number of connections that the client will open to a single broker. |
|
|
Number of threads to be used for handling connections to brokers. |
|
|
Number of threads to be used for message listeners. The listener thread pool is shared across all the consumers and readers that are using a "listener" model to get messages. For a given consumer, the listener will always be invoked from the same thread, to ensure ordering. |
|
|
Client operation timeout. |
|
|
Protocol of proxy service. proxyServiceUrl and proxyProtocol must be mutually inclusive. |
||
URL of proxy service. proxyServiceUrl and proxyProtocol must be mutually inclusive. |
||
Maximum duration for completing a request. |
|
|
Pulsar service URL in the format '(pulsar|pulsar+ssl)://<host>:<port>'. |
|
|
SOCKS5 proxy address. |
||
SOCKS5 proxy password. |
||
SOCKS5 proxy username. |
||
Name of the security provider used for SSL connections. |
||
Interval between each stat info. |
|
|
Whether the client accepts untrusted TLS certificates from the broker. |
|
|
Comma-separated list of cipher suites. This is a named combination of authentication, encryption, MAC and key exchange algorithm used to negotiate the security settings for a network connection using TLS or SSL network protocol. By default, all the available cipher suites are supported. |
||
Whether the hostname is validated when the proxy creates a TLS connection with brokers. |
|
|
Comma-separated list of SSL protocols used to generate the SSLContext. Allowed values in recent JVMs are TLS, TLSv1.3, TLSv1.2 and TLSv1.1. |
||
Path to the trusted TLS certificate file. |
||
Store password for the key store file. |
||
Location of the trust store file. |
||
File format of the trust store file. |
||
Enable KeyStore instead of PEM type configuration if TLS is enabled. |
|
|
Whether to use TCP no-delay flag on the connection, to disable Nagle algorithm. |
|
|
Whether to use TLS encryption on the connection. |
|
Pulsar Producer Properties
| Name | Description | Default Value |
|---|---|---|
Whether partitioned producer automatically discover new partitions at runtime. |
|
|
Interval of partitions discovery updates. |
|
|
Whether to automatically batch messages. |
|
|
Maximum number of bytes permitted in a batch. |
|
|
Maximum number of messages to be batched. |
|
|
Time period within which the messages sent will be batched. |
|
|
|
Partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed message. |
|
Whether the "send" and "sendAsync" methods should block if the outgoing message queue is full. |
|
|
Whether to enable caching in the PulsarProducerFactory. |
|
|
Whether to split large-size messages into multiple chunks. |
|
|
Message compression type. |
||
Action the producer will take in case of encryption failure. |
||
Names of the public encryption keys to use when encrypting data. |
||
Message hashing scheme to choose the partition to which the message is published. |
||
Baseline for the sequence ids for messages published by the producer. |
||
Whether producers in Shared mode register and connect immediately to the owner broker of each partition or start lazily on demand. |
|
|
Maximum number of pending messages for the producer. |
|
|
|
Maximum number of pending messages across all the partitions. |
|
Message routing mode for a partitioned producer. |
||
Whether the multiple schema mode is enabled. |
|
|
Type of access to the topic the producer requires. |
||
Name for the producer. If not assigned, a unique name is generated. |
||
Map of properties to add to the producer. |
||
Time before a message has to be acknowledged by the broker. |
|
|
Topic the producer will publish to. |
||
Whether to record observations for send operations when the Observations API is available. |
|
Pulsar Consumer Properties
| Name | Description | Default Value |
|---|---|---|
Whether an acknowledgement receipt is enabled. |
|
|
Timeout for unacked messages to be redelivered. |
|
|
Time to group acknowledgements before sending them to the broker. |
|
|
|
Whether to automatically drop outstanding un-acked messages if the queue is full. |
|
Whether the consumer auto-subscribes for partition increase. This is only for partitioned consumers. |
|
|
Interval of partitions discovery updates. |
|
|
Whether the batch index acknowledgment is enabled. |
|
|
Consumer name to identify a particular consumer from the topic stats. |
||
Action the consumer will take in case of decryption failure. |
||
|
||
|
||
|
||
|
Time to expire incomplete chunks if the consumer won't be able to receive all chunks before. |
|
Maximum number of chunked messages to be kept in memory. |
|
|
|
Maximum number of messages that a consumer can be pushed at once from a broker across all partitions. |
|
Delay before re-delivering messages that have failed to be processed. |
|
|
Auto-discovery period for topics when topic pattern is used in minutes. |
|
|
Whether pooling of messages and the underlying data buffers is enabled. |
|
|
Priority level for shared subscription consumers. |
|
|
Map of properties to add to the consumer. |
||
Whether to read messages from the compacted topic rather than the full message backlog. |
|
|
Number of messages that can be accumulated before the consumer calls "receive". |
|
|
Determines which topics the consumer should be subscribed to when using pattern subscriptions. |
||
Whether to replicate subscription state. |
|
|
Whether to include the given position of any reset operation like {@link org.apache.pulsar.client.api.Consumer#seek(long) or {@link ConsumerConfigProperties#seek(MessageId)}}. |
|
|
Whether to auto retry messages. |
|
|
Whether to start the consumer in a paused state. |
|
|
Position where to initialize a newly created subscription. |
||
Subscription mode to be used when subscribing to the topic. |
||
Subscription name for the consumer. |
||
Map of properties to add to the subscription. |
||
Subscription type to be used when subscribing to a topic. |
||
Precision for the ack timeout messages tracker. |
|
|
Comma-separated list of topics the consumer subscribes to. |
||
Pattern for topics the consumer subscribes to. |
||
AckMode for acknowledgements. Allowed values are RECORD, BATCH, MANUAL. |
||
Duration to wait for enough message to fill a batch request before timing out. |
|
|
Max size in a single batch request. |
|
|
Max number of messages in a single batch request. |
|
|
Whether to record observations for receive operations when the Observations API is available. |
|
|
SchemaType of the consumed messages. |
Pulsar Reader Properties
| Name | Description | Default Value |
|---|---|---|
Whether to read messages from a compacted topic rather than a full message backlog of a topic. |
||
Reader name. |
||
Size of a consumer's receiver queue. |
||
Whether the first message to be returned is the one specified by messageId. |
||
Subscription name. |
||
Prefix of subscription role. |
||
Topic names. |
Pulsar Defaults Properties
| Name | Description | Default Value |
|---|---|---|
List of mappings from message type to topic name and schema info to use as a defaults when a topic name and/or schema is not explicitly specified when producing or consuming messages of the mapped type. |
Pulsar Function Properties
| Name | Description | Default Value |
|---|---|---|
Whether to enable function support. |
|
|
Whether to stop processing further function creates/updates when a failure occurs. |
|
|
Whether to throw an exception if any failure is encountered during server startup while creating/updating functions. |
|
|
Whether to throw an exception if any failure is encountered during server shutdown while enforcing stop policy on functions. |
|
Pulsar Administration Properties
| Name | Description | Default Value |
|---|---|---|
Authentication parameter(s) as a JSON encoded string. |
||
Fully qualified class name of the authentication plugin. |
||
Authentication parameter(s) as a map of parameter names to parameter values. |
||
Certificates auto refresh time if Pulsar admin uses tls authentication. |
|
|
Duration to wait for a connection to server to be established. |
|
|
Server response read time out for any request. |
|
|
Server request time out for any request. |
|
|
Pulsar web URL for the admin endpoint in the format '(http|https)://<host>:<port>'. |
|
|
Name of the security provider used for SSL connections. |
||
Whether the client accepts untrusted TLS certificates from the broker. |
|
|
List of cipher suites. This is a named combination of authentication, encryption, MAC and key exchange algorithm used to negotiate the security settings for a network connection using TLS or SSL network protocol. By default, all the available cipher suites are supported. |
||
|
Whether the hostname is validated when the proxy creates a TLS connection with brokers. |
|
List of SSL protocols used to generate the SSLContext. Allowed values in recent JVMs are TLS, TLSv1.3, TLSv1.2 and TLSv1.1. |
||
Path to the trusted TLS certificate file. |
||
Store password for the key store file. |
||
Location of the trust store file. |
||
File format of the trust store file. |
||
Enable KeyStore instead of PEM type configuration if TLS is enabled. |
|
Pulsar Reactive Sender Properties
| Name | Description | Default Value |
|---|---|---|
Whether partitioned producer automatically discover new partitions at runtime. |
|
|
|
Interval of partitions discovery updates. |
|
Whether to automatically batch messages. |
|
|
Maximum number of bytes permitted in a batch. |
|
|
Maximum number of messages to be batched. |
|
|
Time period within which the messages sent will be batched. |
|
|
Whether to enable caching in the ReactivePulsarSenderFactory. |
|
|
Time period to expire unused entries in the cache. |
|
|
Initial size of cache. |
|
|
Maximum size of cache (entries). |
|
|
Whether to split large-size messages into multiple chunks. |
|
|
Message compression type. |
||
Action the producer will take in case of encryption failure. |
||
Names of the public encryption keys to use when encrypting data. |
||
Message hashing scheme to choose the partition to which the message is published. |
||
Baseline for the sequence ids for messages published by the producer. |
||
|
Whether producers in Shared mode register and connect immediately to the owner broker of each partition or start lazily on demand. |
|
Maximum number of pending messages for the producer. |
|
|
|
Maximum number of pending messages across all the partitions. |
|
Message routing mode for a partitioned producer. |
||
Whether the multiple schema mode is enabled. |
|
|
Type of access to the topic the producer requires. |
||
Name for the producer. If not assigned, a unique name is generated. |
||
Map of properties to add to the producer. |
||
|
||
Time before a message has to be acknowledged by the broker. |
|
|
Topic the producer will publish to. |
Pulsar Reactive Consumer Properties
| Name | Description | Default Value |
|---|---|---|
Timeout for unacked messages to be redelivered. |
|
|
Precision for the ack timeout messages tracker. |
|
|
When set to true, ignores the acknowledge operation completion and makes it asynchronous from the message consuming processing to improve performance by allowing the acknowledges and message processing to interleave. Defaults to true. |
|
|
Type of acknowledge scheduler. |
||
Time to group acknowledgements before sending them to the broker. |
|
|
|
Whether to automatically drop outstanding un-acked messages if the queue is full. |
|
Whether the consumer auto-subscribes for partition increase. This is only for partitioned consumers. |
|
|
|
|
|
Whether batch index acknowledgement is enabled. |
|
|
Consumer name to identify a particular consumer from the topic stats. |
||
Action the consumer will take in case of decryption failure. |
||
|
||
|
||
|
||
|
||
|
Time to expire incomplete chunks if the consumer won't be able to receive all chunks before in milliseconds. |
|
Maximum number of chunked messages to be kept in memory. |
|
|
|
Maximum number of messages that a consumer can be pushed at once from a broker across all partitions. |
|
|
Delay before re-delivering messages that have failed to be processed. |
|
Priority level for shared subscription consumers. |
|
|
Map of properties to add to the consumer. |
||
Whether to read messages from the compacted topic rather than the full message backlog. |
|
|
Number of messages that can be accumulated before the consumer calls "receive". |
|
|
|
Whether to replicate subscription state. |
|
Whether the retry letter topic is enabled. |
|
|
|
Position where to initialize a newly created subscription. |
|
Subscription mode to be used when subscribing to the topic. |
||
Subscription name for the consumer. |
||
Map of properties to add to the subscription. |
||
Subscription type to be used when subscribing to a topic. |
||
Comma-separated list of topics the consumer subscribes to. |
||
Pattern for topics the consumer subscribes to. |
||
|
Auto-discovery period for topics when topic pattern is used. |
|
|
Determines which topics the consumer should be subscribed to when using pattern subscriptions. |
|
Duration to wait before the message handling times out. |
|
|
SchemaType of the consumed messages. |
||
Whether per-key message ordering should be maintained when concurrent processing is used. |
|
Pulsar Reactive Reader Properties
| Name | Description | Default Value |
|---|---|---|
|
||