@PublicEvolving public final class PulsarSourceOptions extends Object
PulsarSourceBuilder.setConfig(ConfigOption, Object)
. The PulsarOptions
is also required
for pulsar source.for shared configure options.
public static final String SOURCE_CONFIG_PREFIX
public static final String CONSUMER_CONFIG_PREFIX
public static final ConfigOption<Long> PULSAR_PARTITION_DISCOVERY_INTERVAL_MS
public static final ConfigOption<Boolean> PULSAR_ENABLE_AUTO_ACKNOWLEDGE_MESSAGE
public static final ConfigOption<Long> PULSAR_AUTO_COMMIT_CURSOR_INTERVAL
public static final ConfigOption<Long> PULSAR_READ_TRANSACTION_TIMEOUT
@Deprecated public static final ConfigOption<Long> PULSAR_TRANSACTION_TIMEOUT_MILLIS
PULSAR_READ_TRANSACTION_TIMEOUT
instead. This would be removed in
the next release.public static final ConfigOption<Long> PULSAR_MAX_FETCH_TIME
public static final ConfigOption<Integer> PULSAR_MAX_FETCH_RECORDS
public static final ConfigOption<CursorVerification> PULSAR_VERIFY_INITIAL_OFFSETS
public static final ConfigOption<String> PULSAR_SUBSCRIPTION_NAME
public static final ConfigOption<org.apache.pulsar.client.api.SubscriptionType> PULSAR_SUBSCRIPTION_TYPE
public static final ConfigOption<org.apache.pulsar.client.api.SubscriptionMode> PULSAR_SUBSCRIPTION_MODE
public static final ConfigOption<Integer> PULSAR_RECEIVER_QUEUE_SIZE
public static final ConfigOption<Long> PULSAR_ACKNOWLEDGEMENTS_GROUP_TIME_MICROS
public static final ConfigOption<Long> PULSAR_NEGATIVE_ACK_REDELIVERY_DELAY_MICROS
public static final ConfigOption<Integer> PULSAR_MAX_TOTAL_RECEIVER_QUEUE_SIZE_ACROSS_PARTITIONS
public static final ConfigOption<String> PULSAR_CONSUMER_NAME
public static final ConfigOption<Long> PULSAR_ACK_TIMEOUT_MILLIS
public static final ConfigOption<Long> PULSAR_TICK_DURATION_MILLIS
public static final ConfigOption<Integer> PULSAR_PRIORITY_LEVEL
public static final ConfigOption<Integer> PULSAR_MAX_PENDING_CHUNKED_MESSAGE
public static final ConfigOption<Boolean> PULSAR_AUTO_ACK_OLDEST_CHUNKED_MESSAGE_ON_QUEUE_FULL
public static final ConfigOption<Long> PULSAR_EXPIRE_TIME_OF_INCOMPLETE_CHUNKED_MESSAGE_MILLIS
public static final ConfigOption<org.apache.pulsar.client.api.ConsumerCryptoFailureAction> PULSAR_CRYPTO_FAILURE_ACTION
public static final ConfigOption<Map<String,String>> PULSAR_CONSUMER_PROPERTIES
public static final ConfigOption<Boolean> PULSAR_READ_COMPACTED
@Deprecated public static final ConfigOption<org.apache.pulsar.client.api.SubscriptionInitialPosition> PULSAR_SUBSCRIPTION_INITIAL_POSITION
StartCursor
, no need to use it anymore.
Pulsar didn't support this config option before 1.10.1, so we have to remove this config
option.public static final ConfigOption<Integer> PULSAR_MAX_REDELIVER_COUNT
By default, some messages are probably redelivered many times, even to the extent that it never stops.
By using the dead letter mechanism, messages have the max redelivery count. When exceeding the maximum number of redeliveries, messages are sent to the Dead Letter Topic and acknowledged automatically.
You can enable the dead letter mechanism by setting deadLetterPolicy.
Example pulsar.consumer.deadLetterPolicy.maxRedeliverCount = 10
Default dead
letter topic name is {TopicName}-{Subscription}-DLQ.
To set a custom dead letter topic name:
pulsar.consumer.deadLetterPolicy.maxRedeliverCount = 10
pulsar.consumer.deadLetterPolicy.deadLetterTopic = your-topic-name
When specifying the dead letter policy while not specifying ackTimeoutMillis, you can set the ack timeout to 30000 millisecond.
public static final ConfigOption<String> PULSAR_RETRY_LETTER_TOPIC
public static final ConfigOption<String> PULSAR_DEAD_LETTER_TOPIC
public static final ConfigOption<Boolean> PULSAR_RETRY_ENABLE
public static final ConfigOption<Integer> PULSAR_AUTO_UPDATE_PARTITIONS_INTERVAL_SECONDS
public static final ConfigOption<Boolean> PULSAR_REPLICATE_SUBSCRIPTION_STATE
public static final ConfigOption<Boolean> PULSAR_ACK_RECEIPT_ENABLED
public static final ConfigOption<Boolean> PULSAR_POOL_MESSAGES
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.