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

spring.pulsar.client.auth-params

Authentication parameter(s) as a JSON encoded string.

spring.pulsar.client.auth-plugin-class-name

Fully qualified class name of the authentication plugin.

spring.pulsar.client.authentication.*

Authentication parameter(s) as a map of parameter names to parameter values.

spring.pulsar.client.connection-timeout

Duration to wait for a connection to a broker to be established.

10s

spring.pulsar.client.dns-lookup-bind-address

DNS lookup bind address.

spring.pulsar.client.dns-lookup-bind-port

DNS lookup bind port.

0

spring.pulsar.client.enable-busy-wait

Enables spin-waiting on executors and IO threads in order to reduce latency during context switches.

false

spring.pulsar.client.enable-transaction

Enables transactions. To use this, start the transactionCoordinatorClient with the pulsar client.

false

spring.pulsar.client.initial-backoff-interval

Initial backoff interval.

100ms

spring.pulsar.client.keep-alive-interval

Keep alive interval for broker-client connection.

30s

spring.pulsar.client.listener-name

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.

spring.pulsar.client.lookup-timeout

Client lookup timeout.

-1ms

spring.pulsar.client.max-backoff-interval

Maximum backoff interval.

30s

spring.pulsar.client.max-concurrent-lookup-request

Number of concurrent lookup-requests allowed to send on each broker-connection to prevent overload on broker.

5000

spring.pulsar.client.max-lookup-redirects

Maximum number of times a lookup-request to a broker will be redirected.

20

spring.pulsar.client.max-lookup-request

Number of max lookup-requests allowed on each broker-connection to prevent overload on broker.

50000

spring.pulsar.client.max-number-of-rejected-request-per-connection

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.

50

spring.pulsar.client.memory-limit

Limit of direct memory that will be allocated by the client.

64MB

spring.pulsar.client.num-connections-per-broker

Maximum number of connections that the client will open to a single broker.

1

spring.pulsar.client.num-io-threads

Number of threads to be used for handling connections to brokers.

1

spring.pulsar.client.num-listener-threads

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.

1

spring.pulsar.client.operation-timeout

Client operation timeout.

30s

spring.pulsar.client.proxy-protocol

Protocol of proxy service. proxyServiceUrl and proxyProtocol must be mutually inclusive.

spring.pulsar.client.proxy-service-url

URL of proxy service. proxyServiceUrl and proxyProtocol must be mutually inclusive.

spring.pulsar.client.request-timeout

Maximum duration for completing a request.

1m

spring.pulsar.client.service-url

Pulsar service URL in the format '(pulsar|pulsar+ssl)://<host>:<port>'.

pulsar://localhost:6650

spring.pulsar.client.socks5-proxy-address

SOCKS5 proxy address.

spring.pulsar.client.socks5-proxy-password

SOCKS5 proxy password.

spring.pulsar.client.socks5-proxy-username

SOCKS5 proxy username.

spring.pulsar.client.ssl-provider

Name of the security provider used for SSL connections.

spring.pulsar.client.stats-interval

Interval between each stat info.

60s

spring.pulsar.client.tls-allow-insecure-connection

Whether the client accepts untrusted TLS certificates from the broker.

false

spring.pulsar.client.tls-ciphers

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.

spring.pulsar.client.tls-hostname-verification-enable

Whether the hostname is validated when the proxy creates a TLS connection with brokers.

false

spring.pulsar.client.tls-protocols

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.

spring.pulsar.client.tls-trust-certs-file-path

Path to the trusted TLS certificate file.

spring.pulsar.client.tls-trust-store-password

Store password for the key store file.

spring.pulsar.client.tls-trust-store-path

Location of the trust store file.

spring.pulsar.client.tls-trust-store-type

File format of the trust store file.

spring.pulsar.client.use-key-store-tls

Enable KeyStore instead of PEM type configuration if TLS is enabled.

false

spring.pulsar.client.use-tcp-no-delay

Whether to use TCP no-delay flag on the connection, to disable Nagle algorithm.

true

spring.pulsar.client.use-tls

Whether to use TLS encryption on the connection.

false

Pulsar Producer Properties

Name Description Default Value

spring.pulsar.producer.auto-update-partitions

Whether partitioned producer automatically discover new partitions at runtime.

true

spring.pulsar.producer.auto-update-partitions-interval

Interval of partitions discovery updates.

1m

spring.pulsar.producer.batching-enabled

Whether to automatically batch messages.

true

spring.pulsar.producer.batching-max-bytes

Maximum number of bytes permitted in a batch.

128KB

spring.pulsar.producer.batching-max-messages

Maximum number of messages to be batched.

1000

spring.pulsar.producer.batching-max-publish-delay

Time period within which the messages sent will be batched.

1ms

spring.pulsar.producer.batching-partition-switch-frequency-by-publish-delay

Partition switch frequency while batching of messages is enabled and using round-robin routing mode for non-keyed message.

10

spring.pulsar.producer.block-if-queue-full

Whether the "send" and "sendAsync" methods should block if the outgoing message queue is full.

false

spring.pulsar.producer.cache.enabled

Whether to enable caching in the PulsarProducerFactory.

true

spring.pulsar.producer.chunking-enabled

Whether to split large-size messages into multiple chunks.

false

spring.pulsar.producer.compression-type

Message compression type.

spring.pulsar.producer.crypto-failure-action

Action the producer will take in case of encryption failure.

spring.pulsar.producer.encryption-keys

Names of the public encryption keys to use when encrypting data.

spring.pulsar.producer.hashing-scheme

Message hashing scheme to choose the partition to which the message is published.

spring.pulsar.producer.initial-sequence-id

Baseline for the sequence ids for messages published by the producer.

spring.pulsar.producer.lazy-start-partitioned-producers

Whether producers in Shared mode register and connect immediately to the owner broker of each partition or start lazily on demand.

false

spring.pulsar.producer.max-pending-messages

Maximum number of pending messages for the producer.

1000

spring.pulsar.producer.max-pending-messages-across-partitions

Maximum number of pending messages across all the partitions.

50000

spring.pulsar.producer.message-routing-mode

Message routing mode for a partitioned producer.

spring.pulsar.producer.multi-schema

Whether the multiple schema mode is enabled.

true

spring.pulsar.producer.producer-access-mode

Type of access to the topic the producer requires.

spring.pulsar.producer.producer-name

Name for the producer. If not assigned, a unique name is generated.

spring.pulsar.producer.properties.*

Map of properties to add to the producer.

spring.pulsar.producer.send-timeout

Time before a message has to be acknowledged by the broker.

30s

spring.pulsar.producer.topic-name

Topic the producer will publish to.

spring.pulsar.template.observations-enabled

Whether to record observations for send operations when the Observations API is available.

true

Pulsar Consumer Properties

Name Description Default Value

spring.pulsar.consumer.ack-receipt-enabled

Whether an acknowledgement receipt is enabled.

false

spring.pulsar.consumer.ack-timeout

Timeout for unacked messages to be redelivered.

0

spring.pulsar.consumer.acknowledgements-group-time

Time to group acknowledgements before sending them to the broker.

100ms

spring.pulsar.consumer.auto-ack-oldest-chunked-message-on-queue-full

Whether to automatically drop outstanding un-acked messages if the queue is full.

true

spring.pulsar.consumer.auto-update-partitions

Whether the consumer auto-subscribes for partition increase. This is only for partitioned consumers.

true

spring.pulsar.consumer.auto-update-partitions-interval

Interval of partitions discovery updates.

1m

spring.pulsar.consumer.batch-index-ack-enabled

Whether the batch index acknowledgment is enabled.

false

spring.pulsar.consumer.consumer-name

Consumer name to identify a particular consumer from the topic stats.

spring.pulsar.consumer.crypto-failure-action

Action the consumer will take in case of decryption failure.

spring.pulsar.consumer.dead-letter-policy.dead-letter-topic

spring.pulsar.consumer.dead-letter-policy.initial-subscription-name

spring.pulsar.consumer.dead-letter-policy.max-redeliver-count

spring.pulsar.consumer.dead-letter-policy.retry-letter-topic

spring.pulsar.consumer.expire-time-of-incomplete-chunked-message

Time to expire incomplete chunks if the consumer won't be able to receive all chunks before.

1m

spring.pulsar.consumer.max-pending-chunked-message

Maximum number of chunked messages to be kept in memory.

10

spring.pulsar.consumer.max-total-receiver-queue-size-across-partitions

Maximum number of messages that a consumer can be pushed at once from a broker across all partitions.

50000

spring.pulsar.consumer.negative-ack-redelivery-delay

Delay before re-delivering messages that have failed to be processed.

1m

spring.pulsar.consumer.pattern-auto-discovery-period

Auto-discovery period for topics when topic pattern is used in minutes.

1

spring.pulsar.consumer.pool-messages

Whether pooling of messages and the underlying data buffers is enabled.

false

spring.pulsar.consumer.priority-level

Priority level for shared subscription consumers.

0

spring.pulsar.consumer.properties

Map of properties to add to the consumer.

spring.pulsar.consumer.read-compacted

Whether to read messages from the compacted topic rather than the full message backlog.

false

spring.pulsar.consumer.receiver-queue-size

Number of messages that can be accumulated before the consumer calls "receive".

1000

spring.pulsar.consumer.regex-subscription-mode

Determines which topics the consumer should be subscribed to when using pattern subscriptions.

spring.pulsar.consumer.replicate-subscription-state

Whether to replicate subscription state.

false

spring.pulsar.consumer.reset-include-head

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)}}.

false

spring.pulsar.consumer.retry-enable

Whether to auto retry messages.

false

spring.pulsar.consumer.start-paused

Whether to start the consumer in a paused state.

false

spring.pulsar.consumer.subscription-initial-position

Position where to initialize a newly created subscription.

spring.pulsar.consumer.subscription-mode

Subscription mode to be used when subscribing to the topic.

spring.pulsar.consumer.subscription-name

Subscription name for the consumer.

spring.pulsar.consumer.subscription-properties.*

Map of properties to add to the subscription.

spring.pulsar.consumer.subscription-type

Subscription type to be used when subscribing to a topic.

spring.pulsar.consumer.tick-duration

Precision for the ack timeout messages tracker.

1s

spring.pulsar.consumer.topics

Comma-separated list of topics the consumer subscribes to.

spring.pulsar.consumer.topics-pattern

Pattern for topics the consumer subscribes to.

spring.pulsar.listener.ack-mode

AckMode for acknowledgements. Allowed values are RECORD, BATCH, MANUAL.

spring.pulsar.listener.batch-timeout

Duration to wait for enough message to fill a batch request before timing out.

100ms

spring.pulsar.listener.max-num-bytes

Max size in a single batch request.

10MB

spring.pulsar.listener.max-num-messages

Max number of messages in a single batch request.

-1

spring.pulsar.listener.observations-enabled

Whether to record observations for receive operations when the Observations API is available.

true

spring.pulsar.listener.schema-type

SchemaType of the consumed messages.

Pulsar Reader Properties

Name Description Default Value

spring.pulsar.reader.read-compacted

Whether to read messages from a compacted topic rather than a full message backlog of a topic.

spring.pulsar.reader.reader-name

Reader name.

spring.pulsar.reader.receiver-queue-size

Size of a consumer's receiver queue.

spring.pulsar.reader.reset-include-head

Whether the first message to be returned is the one specified by messageId.

spring.pulsar.reader.subscription-name

Subscription name.

spring.pulsar.reader.subscription-role-prefix

Prefix of subscription role.

spring.pulsar.reader.topic-names

Topic names.

Pulsar Defaults Properties

Name Description Default Value

spring.pulsar.defaults.type-mappings

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

spring.pulsar.function.enabled

Whether to enable function support.

true

spring.pulsar.function.fail-fast

Whether to stop processing further function creates/updates when a failure occurs.

true

spring.pulsar.function.propagate-failures

Whether to throw an exception if any failure is encountered during server startup while creating/updating functions.

true

spring.pulsar.function.propagate-stop-failures

Whether to throw an exception if any failure is encountered during server shutdown while enforcing stop policy on functions.

false

Pulsar Administration Properties

Name Description Default Value

spring.pulsar.administration.auth-params

Authentication parameter(s) as a JSON encoded string.

spring.pulsar.administration.auth-plugin-class-name

Fully qualified class name of the authentication plugin.

spring.pulsar.administration.authentication.*

Authentication parameter(s) as a map of parameter names to parameter values.

spring.pulsar.administration.auto-cert-refresh-time

Certificates auto refresh time if Pulsar admin uses tls authentication.

5m

spring.pulsar.administration.connection-timeout

Duration to wait for a connection to server to be established.

1m

spring.pulsar.administration.read-timeout

Server response read time out for any request.

1m

spring.pulsar.administration.request-timeout

Server request time out for any request.

5m

spring.pulsar.administration.service-url

Pulsar web URL for the admin endpoint in the format '(http|https)://<host>:<port>'.

http://localhost:8080

spring.pulsar.administration.ssl-provider

Name of the security provider used for SSL connections.

spring.pulsar.administration.tls-allow-insecure-connection

Whether the client accepts untrusted TLS certificates from the broker.

false

spring.pulsar.administration.tls-ciphers

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.

spring.pulsar.administration.tls-hostname-verification-enable

Whether the hostname is validated when the proxy creates a TLS connection with brokers.

false

spring.pulsar.administration.tls-protocols

List of SSL protocols used to generate the SSLContext. Allowed values in recent JVMs are TLS, TLSv1.3, TLSv1.2 and TLSv1.1.

spring.pulsar.administration.tls-trust-certs-file-path

Path to the trusted TLS certificate file.

spring.pulsar.administration.tls-trust-store-password

Store password for the key store file.

spring.pulsar.administration.tls-trust-store-path

Location of the trust store file.

spring.pulsar.administration.tls-trust-store-type

File format of the trust store file.

spring.pulsar.administration.use-key-store-tls

Enable KeyStore instead of PEM type configuration if TLS is enabled.

false

Pulsar Reactive Sender Properties

Name Description Default Value

spring.pulsar.reactive.sender.auto-update-partitions

Whether partitioned producer automatically discover new partitions at runtime.

true

spring.pulsar.reactive.sender.auto-update-partitions-interval

Interval of partitions discovery updates.

1m

spring.pulsar.reactive.sender.batching-enabled

Whether to automatically batch messages.

true

spring.pulsar.reactive.sender.batching-max-bytes

Maximum number of bytes permitted in a batch.

128KB

spring.pulsar.reactive.sender.batching-max-messages

Maximum number of messages to be batched.

1000

spring.pulsar.reactive.sender.batching-max-publish-delay

Time period within which the messages sent will be batched.

1ms

spring.pulsar.reactive.sender.cache.enabled

Whether to enable caching in the ReactivePulsarSenderFactory.

true

spring.pulsar.reactive.sender.cache.expire-after-access

Time period to expire unused entries in the cache.

1m

spring.pulsar.reactive.sender.cache.initial-capacity

Initial size of cache.

50

spring.pulsar.reactive.sender.cache.maximum-size

Maximum size of cache (entries).

1000

spring.pulsar.reactive.sender.chunking-enabled

Whether to split large-size messages into multiple chunks.

false

spring.pulsar.reactive.sender.compression-type

Message compression type.

spring.pulsar.reactive.sender.crypto-failure-action

Action the producer will take in case of encryption failure.

spring.pulsar.reactive.sender.encryption-keys

Names of the public encryption keys to use when encrypting data.

spring.pulsar.reactive.sender.hashing-scheme

Message hashing scheme to choose the partition to which the message is published.

spring.pulsar.reactive.sender.initial-sequence-id

Baseline for the sequence ids for messages published by the producer.

spring.pulsar.reactive.sender.lazy-start-partitioned-producers

Whether producers in Shared mode register and connect immediately to the owner broker of each partition or start lazily on demand.

false

spring.pulsar.reactive.sender.max-pending-messages

Maximum number of pending messages for the producer.

1000

spring.pulsar.reactive.sender.max-pending-messages-across-partitions

Maximum number of pending messages across all the partitions.

50000

spring.pulsar.reactive.sender.message-routing-mode

Message routing mode for a partitioned producer.

spring.pulsar.reactive.sender.multi-schema

Whether the multiple schema mode is enabled.

true

spring.pulsar.reactive.sender.producer-access-mode

Type of access to the topic the producer requires.

spring.pulsar.reactive.sender.producer-name

Name for the producer. If not assigned, a unique name is generated.

spring.pulsar.reactive.sender.properties.*

Map of properties to add to the producer.

spring.pulsar.reactive.sender.round-robin-router-batching-partition-switch-frequency

spring.pulsar.reactive.sender.send-timeout

Time before a message has to be acknowledged by the broker.

30s

spring.pulsar.reactive.sender.topic-name

Topic the producer will publish to.

Pulsar Reactive Consumer Properties

Name Description Default Value

spring.pulsar.reactive.consumer.ack-timeout

Timeout for unacked messages to be redelivered.

0

spring.pulsar.reactive.consumer.ack-timeout-tick-time

Precision for the ack timeout messages tracker.

1s

spring.pulsar.reactive.consumer.acknowledge-asynchronously

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.

true

spring.pulsar.reactive.consumer.acknowledge-scheduler-type

Type of acknowledge scheduler.

spring.pulsar.reactive.consumer.acknowledgements-group-time

Time to group acknowledgements before sending them to the broker.

100ms

spring.pulsar.reactive.consumer.auto-ack-oldest-chunked-message-on-queue-full

Whether to automatically drop outstanding un-acked messages if the queue is full.

true

spring.pulsar.reactive.consumer.auto-update-partitions

Whether the consumer auto-subscribes for partition increase. This is only for partitioned consumers.

true

spring.pulsar.reactive.consumer.auto-update-partitions-interval

1m

spring.pulsar.reactive.consumer.batch-index-ack-enabled

Whether batch index acknowledgement is enabled.

false

spring.pulsar.reactive.consumer.consumer-name

Consumer name to identify a particular consumer from the topic stats.

spring.pulsar.reactive.consumer.crypto-failure-action

Action the consumer will take in case of decryption failure.

spring.pulsar.reactive.consumer.dead-letter-policy.dead-letter-topic

spring.pulsar.reactive.consumer.dead-letter-policy.initial-subscription-name

spring.pulsar.reactive.consumer.dead-letter-policy.max-redeliver-count

spring.pulsar.reactive.consumer.dead-letter-policy.retry-letter-topic

spring.pulsar.reactive.consumer.expire-time-of-incomplete-chunked-message

Time to expire incomplete chunks if the consumer won't be able to receive all chunks before in milliseconds.

1m

spring.pulsar.reactive.consumer.max-pending-chunked-message

Maximum number of chunked messages to be kept in memory.

10

spring.pulsar.reactive.consumer.max-total-receiver-queue-size-across-partitions

Maximum number of messages that a consumer can be pushed at once from a broker across all partitions.

50000

spring.pulsar.reactive.consumer.negative-ack-redelivery-delay

Delay before re-delivering messages that have failed to be processed.

1m

spring.pulsar.reactive.consumer.priority-level

Priority level for shared subscription consumers.

0

spring.pulsar.reactive.consumer.properties

Map of properties to add to the consumer.

spring.pulsar.reactive.consumer.read-compacted

Whether to read messages from the compacted topic rather than the full message backlog.

false

spring.pulsar.reactive.consumer.receiver-queue-size

Number of messages that can be accumulated before the consumer calls "receive".

1000

spring.pulsar.reactive.consumer.replicate-subscription-state

Whether to replicate subscription state.

false

spring.pulsar.reactive.consumer.retry-letter-topic-enable

Whether the retry letter topic is enabled.

false

spring.pulsar.reactive.consumer.subscription-initial-position

Position where to initialize a newly created subscription.

spring.pulsar.reactive.consumer.subscription-mode

Subscription mode to be used when subscribing to the topic.

spring.pulsar.reactive.consumer.subscription-name

Subscription name for the consumer.

spring.pulsar.reactive.consumer.subscription-properties

Map of properties to add to the subscription.

spring.pulsar.reactive.consumer.subscription-type

Subscription type to be used when subscribing to a topic.

spring.pulsar.reactive.consumer.topics

Comma-separated list of topics the consumer subscribes to.

spring.pulsar.reactive.consumer.topics-pattern

Pattern for topics the consumer subscribes to.

spring.pulsar.reactive.consumer.topics-pattern-auto-discovery-period

Auto-discovery period for topics when topic pattern is used.

1m

spring.pulsar.reactive.consumer.topics-pattern-subscription-mode

Determines which topics the consumer should be subscribed to when using pattern subscriptions.

spring.pulsar.reactive.listener.handling-timeout

Duration to wait before the message handling times out.

2m

spring.pulsar.reactive.listener.schema-type

SchemaType of the consumed messages.

spring.pulsar.reactive.listener.use-key-ordered-processing

Whether per-key message ordering should be maintained when concurrent processing is used.

false

Pulsar Binder Properties

Name Description Default Value

spring.cloud.stream.pulsar.binder.consumer.ack-receipt-enabled

spring.cloud.stream.pulsar.binder.consumer.ack-timeout

spring.cloud.stream.pulsar.binder.consumer.acknowledgements-group-time

spring.cloud.stream.pulsar.binder.consumer.auto-ack-oldest-chunked-message-on-queue-full

spring.cloud.stream.pulsar.binder.consumer.auto-update-partitions

spring.cloud.stream.pulsar.binder.consumer.auto-update-partitions-interval

spring.cloud.stream.pulsar.binder.consumer.batch-index-ack-enabled

spring.cloud.stream.pulsar.binder.consumer.consumer-name

spring.cloud.stream.pulsar.binder.consumer.crypto-failure-action

spring.cloud.stream.pulsar.binder.consumer.dead-letter-policy.dead-letter-topic

spring.cloud.stream.pulsar.binder.consumer.dead-letter-policy.initial-subscription-name

spring.cloud.stream.pulsar.binder.consumer.dead-letter-policy.max-redeliver-count

spring.cloud.stream.pulsar.binder.consumer.dead-letter-policy.retry-letter-topic

spring.cloud.stream.pulsar.binder.consumer.expire-time-of-incomplete-chunked-message

spring.cloud.stream.pulsar.binder.consumer.max-pending-chunked-message

spring.cloud.stream.pulsar.binder.consumer.max-total-receiver-queue-size-across-partitions

spring.cloud.stream.pulsar.binder.consumer.negative-ack-redelivery-delay

spring.cloud.stream.pulsar.binder.consumer.pattern-auto-discovery-period

spring.cloud.stream.pulsar.binder.consumer.pool-messages

spring.cloud.stream.pulsar.binder.consumer.priority-level

spring.cloud.stream.pulsar.binder.consumer.properties

spring.cloud.stream.pulsar.binder.consumer.read-compacted

spring.cloud.stream.pulsar.binder.consumer.receiver-queue-size

spring.cloud.stream.pulsar.binder.consumer.regex-subscription-mode

spring.cloud.stream.pulsar.binder.consumer.replicate-subscription-state

spring.cloud.stream.pulsar.binder.consumer.reset-include-head

spring.cloud.stream.pulsar.binder.consumer.retry-enable

spring.cloud.stream.pulsar.binder.consumer.start-paused

spring.cloud.stream.pulsar.binder.consumer.subscription-initial-position

spring.cloud.stream.pulsar.binder.consumer.subscription-mode

spring.cloud.stream.pulsar.binder.consumer.subscription-name

spring.cloud.stream.pulsar.binder.consumer.subscription-properties.*

spring.cloud.stream.pulsar.binder.consumer.subscription-type

spring.cloud.stream.pulsar.binder.consumer.tick-duration

spring.cloud.stream.pulsar.binder.consumer.topics

spring.cloud.stream.pulsar.binder.consumer.topics-pattern

spring.cloud.stream.pulsar.binder.partition-count

Number of topic partitions.

spring.cloud.stream.pulsar.binder.producer.auto-update-partitions

spring.cloud.stream.pulsar.binder.producer.auto-update-partitions-interval

spring.cloud.stream.pulsar.binder.producer.batching-enabled

spring.cloud.stream.pulsar.binder.producer.batching-max-bytes

spring.cloud.stream.pulsar.binder.producer.batching-max-messages

spring.cloud.stream.pulsar.binder.producer.batching-max-publish-delay

spring.cloud.stream.pulsar.binder.producer.batching-partition-switch-frequency-by-publish-delay

spring.cloud.stream.pulsar.binder.producer.block-if-queue-full

spring.cloud.stream.pulsar.binder.producer.chunking-enabled

spring.cloud.stream.pulsar.binder.producer.compression-type

spring.cloud.stream.pulsar.binder.producer.crypto-failure-action

spring.cloud.stream.pulsar.binder.producer.encryption-keys

spring.cloud.stream.pulsar.binder.producer.hashing-scheme

spring.cloud.stream.pulsar.binder.producer.initial-sequence-id

spring.cloud.stream.pulsar.binder.producer.lazy-start-partitioned-producers

spring.cloud.stream.pulsar.binder.producer.max-pending-messages

spring.cloud.stream.pulsar.binder.producer.max-pending-messages-across-partitions

spring.cloud.stream.pulsar.binder.producer.message-routing-mode

spring.cloud.stream.pulsar.binder.producer.multi-schema

spring.cloud.stream.pulsar.binder.producer.producer-access-mode

spring.cloud.stream.pulsar.binder.producer.producer-name

spring.cloud.stream.pulsar.binder.producer.properties.*

spring.cloud.stream.pulsar.binder.producer.send-timeout

spring.cloud.stream.pulsar.binder.producer.topic-name

Pulsar Binding Properties

Name Description Default Value

spring.cloud.stream.pulsar.bindings.*

Properties per individual binding name (e.g. 'mySink-in-0'). Replace the '*' ' with the name of your binding.

spring.cloud.stream.pulsar.bindings.*.consumer.ack-receipt-enabled

spring.cloud.stream.pulsar.bindings.*.consumer.ack-timeout

spring.cloud.stream.pulsar.bindings.*.consumer.acknowledgements-group-time

spring.cloud.stream.pulsar.bindings.*.consumer.auto-ack-oldest-chunked-message-on-queue-full

spring.cloud.stream.pulsar.bindings.*.consumer.auto-update-partitions

spring.cloud.stream.pulsar.bindings.*.consumer.auto-update-partitions-interval

spring.cloud.stream.pulsar.bindings.*.consumer.batch-index-ack-enabled

spring.cloud.stream.pulsar.bindings.*.consumer.consumer-name

spring.cloud.stream.pulsar.bindings.*.consumer.crypto-failure-action

spring.cloud.stream.pulsar.bindings.*.consumer.dead-letter-policy.dead-letter-topic

spring.cloud.stream.pulsar.bindings.*.consumer.dead-letter-policy.initial-subscription-name

spring.cloud.stream.pulsar.bindings.*.consumer.dead-letter-policy.max-redeliver-count

spring.cloud.stream.pulsar.bindings.*.consumer.dead-letter-policy.retry-letter-topic

spring.cloud.stream.pulsar.bindings.*.consumer.expire-time-of-incomplete-chunked-message

spring.cloud.stream.pulsar.bindings.*.consumer.max-pending-chunked-message

spring.cloud.stream.pulsar.bindings.*.consumer.max-total-receiver-queue-size-across-partitions

spring.cloud.stream.pulsar.bindings.*.consumer.message-key-type

Pulsar message key type for this binding (only used when schema type is {@code }KEY_VALUE}).

spring.cloud.stream.pulsar.bindings.*.consumer.message-type

Pulsar message type for this binding.

spring.cloud.stream.pulsar.bindings.*.consumer.negative-ack-redelivery-delay

spring.cloud.stream.pulsar.bindings.*.consumer.partition-count

Number of topic partitions.

spring.cloud.stream.pulsar.bindings.*.consumer.pattern-auto-discovery-period

spring.cloud.stream.pulsar.bindings.*.consumer.pool-messages

spring.cloud.stream.pulsar.bindings.*.consumer.priority-level

spring.cloud.stream.pulsar.bindings.*.consumer.properties

spring.cloud.stream.pulsar.bindings.*.consumer.read-compacted

spring.cloud.stream.pulsar.bindings.*.consumer.receiver-queue-size

spring.cloud.stream.pulsar.bindings.*.consumer.regex-subscription-mode

spring.cloud.stream.pulsar.bindings.*.consumer.replicate-subscription-state

spring.cloud.stream.pulsar.bindings.*.consumer.reset-include-head

spring.cloud.stream.pulsar.bindings.*.consumer.retry-enable

spring.cloud.stream.pulsar.bindings.*.consumer.schema-type

Pulsar {@link SchemaType} for this binding.

spring.cloud.stream.pulsar.bindings.*.consumer.start-paused

spring.cloud.stream.pulsar.bindings.*.consumer.subscription-initial-position

spring.cloud.stream.pulsar.bindings.*.consumer.subscription-mode

spring.cloud.stream.pulsar.bindings.*.consumer.subscription-name

spring.cloud.stream.pulsar.bindings.*.consumer.subscription-properties

spring.cloud.stream.pulsar.bindings.*.consumer.subscription-type

spring.cloud.stream.pulsar.bindings.*.consumer.tick-duration

spring.cloud.stream.pulsar.bindings.*.consumer.topics

spring.cloud.stream.pulsar.bindings.*.consumer.topics-pattern

spring.cloud.stream.pulsar.bindings.*.producer.auto-update-partitions

spring.cloud.stream.pulsar.bindings.*.producer.auto-update-partitions-interval

spring.cloud.stream.pulsar.bindings.*.producer.batching-enabled

spring.cloud.stream.pulsar.bindings.*.producer.batching-max-bytes

spring.cloud.stream.pulsar.bindings.*.producer.batching-max-messages

spring.cloud.stream.pulsar.bindings.*.producer.batching-max-publish-delay

spring.cloud.stream.pulsar.bindings.*.producer.batching-partition-switch-frequency-by-publish-delay

spring.cloud.stream.pulsar.bindings.*.producer.block-if-queue-full

spring.cloud.stream.pulsar.bindings.*.producer.chunking-enabled

spring.cloud.stream.pulsar.bindings.*.producer.compression-type

spring.cloud.stream.pulsar.bindings.*.producer.crypto-failure-action

spring.cloud.stream.pulsar.bindings.*.producer.encryption-keys

spring.cloud.stream.pulsar.bindings.*.producer.hashing-scheme

spring.cloud.stream.pulsar.bindings.*.producer.initial-sequence-id

spring.cloud.stream.pulsar.bindings.*.producer.lazy-start-partitioned-producers

spring.cloud.stream.pulsar.bindings.*.producer.max-pending-messages

spring.cloud.stream.pulsar.bindings.*.producer.max-pending-messages-across-partitions

spring.cloud.stream.pulsar.bindings.*.producer.message-key-type

Pulsar message key type for this binding (only used when schema type is {@code }KEY_VALUE}).

spring.cloud.stream.pulsar.bindings.*.producer.message-routing-mode

spring.cloud.stream.pulsar.bindings.*.producer.message-type

Pulsar message type for this binding.

spring.cloud.stream.pulsar.bindings.*.producer.multi-schema

spring.cloud.stream.pulsar.bindings.*.producer.partition-count

Number of topic partitions.

spring.cloud.stream.pulsar.bindings.*.producer.producer-access-mode

spring.cloud.stream.pulsar.bindings.*.producer.producer-name

spring.cloud.stream.pulsar.bindings.*.producer.properties

spring.cloud.stream.pulsar.bindings.*.producer.schema-type

Pulsar {@link SchemaType} for this binding.

spring.cloud.stream.pulsar.bindings.*.producer.send-timeout

spring.cloud.stream.pulsar.bindings.*.producer.topic-name