Package org.apache.pulsar.client.admin
Interface TopicPolicies
public interface TopicPolicies
Admin interface for topic policies management.
-
Method Summary
Modifier and TypeMethodDescriptiongetBacklogQuotaMap
(String topic) Get backlog quota map for a topic.getBacklogQuotaMap
(String topic, boolean applied) Get applied backlog quota map for a topic.getCompactionThreshold
(String topic) Get the compactionThreshold for a topic.getCompactionThreshold
(String topic, boolean applied) Get the compactionThreshold for a topic.Get the compactionThreshold for a topic asynchronously.getCompactionThresholdAsync
(String topic, boolean applied) Get the compactionThreshold for a topic asynchronously.Get the deduplication snapshot interval for specified topic.Get the deduplication snapshot interval for specified topic asynchronously.getDeduplicationStatus
(String topic) get deduplication enabled of a topic.getDeduplicationStatus
(String topic, boolean applied) get applied deduplication enabled of a topic.get deduplication enabled of a topic asynchronously.getDeduplicationStatusAsync
(String topic, boolean applied) get applied deduplication enabled of a topic asynchronously.getDelayedDeliveryPolicy
(String topic) Get the delayed delivery policy for a specified topic.getDelayedDeliveryPolicy
(String topic, boolean applied) Get the delayed delivery policy applied for a specified topic.Get the delayed delivery policy for a specified topic asynchronously.getDelayedDeliveryPolicyAsync
(String topic, boolean applied) Get the delayed delivery policy applied for a specified topic asynchronously.getDispatchRate
(String topic) Get message-dispatch-rate (topic can dispatch this many messages per second).getDispatchRate
(String topic, boolean applied) Get applied message-dispatch-rate (topic can dispatch this many messages per second).getDispatchRateAsync
(String topic) Get message-dispatch-rate asynchronously.getDispatchRateAsync
(String topic, boolean applied) Get applied message-dispatch-rate asynchronously.getInactiveTopicPolicies
(String topic) get inactive topic policies of a topic.getInactiveTopicPolicies
(String topic, boolean applied) Get inactive topic policies applied for a topic.get inactive topic policies of a topic asynchronously.getInactiveTopicPoliciesAsync
(String topic, boolean applied) Get inactive topic policies applied for a topic asynchronously.getMaxConsumers
(String topic) Get the max number of consumer for specified topic.getMaxConsumers
(String topic, boolean applied) Get the max number of consumer applied for specified topic.getMaxConsumersAsync
(String topic) Get the max number of consumer for specified topic asynchronously.getMaxConsumersAsync
(String topic, boolean applied) Get the max number of consumer applied for specified topic asynchronously.Get the maxConsumersPerSubscription for a topic.Get the maxConsumersPerSubscription for a topic asynchronously.getMaxMessageSize
(String topic) Get the max message size for specified topic.getMaxMessageSizeAsync
(String topic) Get the max message size for specified topic asynchronously.getMaxProducers
(String topic) Get the max number of producer for specified topic.getMaxProducers
(String topic, boolean applied) Get the max number of producer applied for specified topic.getMaxProducersAsync
(String topic) Get the max number of producer for specified topic asynchronously.getMaxProducersAsync
(String topic, boolean applied) Get the max number of producer applied for specified topic asynchronously.Get the max number of subscriptions for specified topic.Get the max number of subscriptions for specified topic asynchronously.Get max unacked messages on a consumer of a topic.getMaxUnackedMessagesOnConsumer
(String topic, boolean applied) get applied max unacked messages on consumer of a topic.get max unacked messages on consumer of a topic asynchronously.getMaxUnackedMessagesOnConsumerAsync
(String topic, boolean applied) get applied max unacked messages on consumer of a topic asynchronously.get max unacked messages on subscription of a topic.getMaxUnackedMessagesOnSubscription
(String topic, boolean applied) get max unacked messages on subscription of a topic.get max unacked messages on subscription of a topic asynchronously.getMaxUnackedMessagesOnSubscriptionAsync
(String topic, boolean applied) get max unacked messages on subscription of a topic asynchronously.getMessageTTL
(String topic) Get message TTL for a topic.getMessageTTL
(String topic, boolean applied) Get message TTL applied for a topic.getOffloadPolicies
(String topic) get offload policies of a topic.getOffloadPolicies
(String topic, boolean applied) get applied offload policies of a topic.getOffloadPoliciesAsync
(String topic) get offload policies of a topic asynchronously.getOffloadPoliciesAsync
(String topic, boolean applied) get applied offload policies of a topic asynchronously.getPersistence
(String topic) Get the configuration of persistence policies for specified topic.getPersistence
(String topic, boolean applied) Get the applied configuration of persistence policies for specified topic.getPersistenceAsync
(String topic) Get the configuration of persistence policies for specified topic asynchronously.getPersistenceAsync
(String topic, boolean applied) Get the applied configuration of persistence policies for specified topic asynchronously.getPublishRate
(String topic) Get message-publish-rate (topics can publish this many messages per second).getPublishRateAsync
(String topic) Get message-publish-rate (topics can publish this many messages per second) asynchronously.getReplicatorDispatchRate
(String topic) Get replicatorDispatchRate for the topic.getReplicatorDispatchRate
(String topic, boolean applied) Get applied replicatorDispatchRate for the topic.Get replicatorDispatchRate asynchronously.getReplicatorDispatchRateAsync
(String topic, boolean applied) Get applied replicatorDispatchRate asynchronously.getRetention
(String topic) Get the retention configuration for a topic.getRetention
(String topic, boolean applied) Get the applied retention configuration for a topic.getRetentionAsync
(String topic) Get the retention configuration for a topic asynchronously.getRetentionAsync
(String topic, boolean applied) Get the applied retention configuration for a topic asynchronously.getSchemaCompatibilityStrategy
(String topic, boolean applied) Get schema compatibility strategy on a topic.getSchemaCompatibilityStrategyAsync
(String topic, boolean applied) Get schema compatibility strategy on a topic asynchronously.getSubscribeRate
(String topic) Get topic-subscribe-rate (topics allow subscribe times per consumer in a period).getSubscribeRate
(String topic, boolean applied) Get applied topic-subscribe-rate (topics allow subscribe times per consumer in a period).getSubscribeRateAsync
(String topic) Get topic-subscribe-rate asynchronously.getSubscribeRateAsync
(String topic, boolean applied) Get applied topic-subscribe-rate asynchronously.Get subscription-message-dispatch-rate for the topic.getSubscriptionDispatchRate
(String topic, boolean applied) Get applied subscription-message-dispatch-rate.getSubscriptionDispatchRate
(String topic, String subscriptionName) Get subscription level dispatch rate limiter setting for a specific subscription.getSubscriptionDispatchRate
(String topic, String subscriptionName, boolean applied) If applied is true, get dispatch rate limiter for a specific subscription.Get subscription-message-dispatch-rate asynchronously.getSubscriptionDispatchRateAsync
(String topic, boolean applied) Get applied subscription-message-dispatch-rate asynchronously.getSubscriptionDispatchRateAsync
(String topic, String subscriptionName) Async version ofgetSubscriptionDispatchRate(String, String)
.getSubscriptionDispatchRateAsync
(String topic, String subscriptionName, boolean applied) Async version ofgetSubscriptionDispatchRate(String, String, boolean)
.Set<org.apache.pulsar.client.api.SubscriptionType>
Get is enable sub types.CompletableFuture<Set<org.apache.pulsar.client.api.SubscriptionType>>
Get is enable sub types asynchronously.default void
removeBacklogQuota
(String topic) void
removeBacklogQuota
(String topic, BacklogQuota.BacklogQuotaType backlogQuotaType) Remove a backlog quota policy from a topic.void
removeCompactionThreshold
(String topic) Remove the compactionThreshold for a topic.Remove the compactionThreshold for a topic asynchronously.void
Remove the deduplication snapshot interval for specified topic.Remove the deduplication snapshot interval for specified topic asynchronously.void
removeDeduplicationStatus
(String topic) remove deduplication enabled of a topic.remove deduplication enabled of a topic asynchronously.void
Remove the delayed delivery policy for a specified topic.Remove the delayed delivery policy for a specified topic asynchronously.void
removeDispatchRate
(String topic) Remove message-dispatch-rate.removeDispatchRateAsync
(String topic) Remove message-dispatch-rate asynchronously.void
remove inactive topic policies of a topic.remove inactive topic policies of a topic asynchronously.void
removeMaxConsumers
(String topic) Remove the max number of consumer for specified topic.removeMaxConsumersAsync
(String topic) Remove the max number of consumer for specified topic asynchronously.void
Remove the maxConsumersPerSubscription for a topic.Remove the maxConsumersPerSubscription for a topic asynchronously.void
removeMaxMessageSize
(String topic) Remove the max message size for specified topic.removeMaxMessageSizeAsync
(String topic) Remove the max message size for specified topic asynchronously.void
removeMaxProducers
(String topic) Remove the max number of producer for specified topic.removeMaxProducersAsync
(String topic) Remove the max number of producer for specified topic asynchronously.void
Remove the max number of subscriptions for specified topic.Remove the max number of subscriptions for specified topic asynchronously.void
remove max unacked messages on consumer of a topic.remove max unacked messages on consumer of a topic asynchronously.void
remove max unacked messages on subscription of a topic.remove max unacked messages on subscription of a topic asynchronously.void
removeMessageTTL
(String topic) Remove message TTL for a topic.void
removeOffloadPolicies
(String topic) remove offload policies of a topic.removeOffloadPoliciesAsync
(String topic) remove offload policies of a topic asynchronously.void
removePersistence
(String topic) Remove the configuration of persistence policies for specified topic.removePersistenceAsync
(String topic) Remove the configuration of persistence policies for specified topic asynchronously.void
removePublishRate
(String topic) Remove message-publish-rate.removePublishRateAsync
(String topic) Remove message-publish-rate asynchronously.void
Remove replicatorDispatchRate for a topic.Remove replicatorDispatchRate for a topic asynchronously.void
removeRetention
(String topic) Remove the retention configuration for all the topics on a topic.removeRetentionAsync
(String topic) Remove the retention configuration for all the topics on a topic asynchronously.void
Remove schema compatibility strategy on a topic.Remove schema compatibility strategy on a topic asynchronously.void
removeSubscribeRate
(String topic) Remove topic-subscribe-rate.removeSubscribeRateAsync
(String topic) Remove topic-subscribe-rate asynchronously.void
Remove subscription-message-dispatch-rate for a topic.void
removeSubscriptionDispatchRate
(String topic, String subscriptionName) Remove subscription level dispatch rate limiter setting for a specific subscription.Remove subscription-message-dispatch-rate for a topic asynchronously.removeSubscriptionDispatchRateAsync
(String topic, String subscriptionName) Async version ofremoveSubscriptionDispatchRate(String, String)
.void
Remove subscription types enabled for a topic.Remove subscription types enabled for a topic asynchronously.default void
setBacklogQuota
(String topic, BacklogQuota backlogQuota) void
setBacklogQuota
(String topic, BacklogQuota backlogQuota, BacklogQuota.BacklogQuotaType backlogQuotaType) Set a backlog quota for a topic.void
setCompactionThreshold
(String topic, long compactionThreshold) Set the compactionThreshold for a topic.setCompactionThresholdAsync
(String topic, long compactionThreshold) Set the compactionThreshold for a topic asynchronously.void
setDeduplicationSnapshotInterval
(String topic, int interval) Set the deduplication snapshot interval for specified topic.setDeduplicationSnapshotIntervalAsync
(String topic, int interval) Set the deduplication snapshot interval for specified topic asynchronously.void
setDeduplicationStatus
(String topic, boolean enabled) set deduplication enabled of a topic.setDeduplicationStatusAsync
(String topic, boolean enabled) set deduplication enabled of a topic asynchronously.void
setDelayedDeliveryPolicy
(String topic, DelayedDeliveryPolicies delayedDeliveryPolicies) Set the delayed delivery policy for a specified topic.setDelayedDeliveryPolicyAsync
(String topic, DelayedDeliveryPolicies delayedDeliveryPolicies) Set the delayed delivery policy for a specified topic asynchronously.void
setDispatchRate
(String topic, DispatchRate dispatchRate) Set message-dispatch-rate (topic can dispatch this many messages per second).setDispatchRateAsync
(String topic, DispatchRate dispatchRate) Set message-dispatch-rate asynchronously.void
setInactiveTopicPolicies
(String topic, InactiveTopicPolicies inactiveTopicPolicies) set inactive topic policies of a topic.setInactiveTopicPoliciesAsync
(String topic, InactiveTopicPolicies inactiveTopicPolicies) set inactive topic policies of a topic asynchronously.void
setMaxConsumers
(String topic, int maxConsumers) Set the max number of consumer for specified topic.setMaxConsumersAsync
(String topic, int maxConsumers) Set the max number of consumer for specified topic asynchronously.void
setMaxConsumersPerSubscription
(String topic, int maxConsumersPerSubscription) Set maxConsumersPerSubscription for a topic.setMaxConsumersPerSubscriptionAsync
(String topic, int maxConsumersPerSubscription) Set maxConsumersPerSubscription for a topic asynchronously.void
setMaxMessageSize
(String topic, int maxMessageSize) Set the max message size for specified topic.setMaxMessageSizeAsync
(String topic, int maxMessageSize) Set the max message size for specified topic asynchronously.0 disables.void
setMaxProducers
(String topic, int maxProducers) Set the max number of producer for specified topic.setMaxProducersAsync
(String topic, int maxProducers) Set the max number of producer for specified topic asynchronously.void
setMaxSubscriptionsPerTopic
(String topic, int maxSubscriptionsPerTopic) Set the max number of subscriptions for specified topic.setMaxSubscriptionsPerTopicAsync
(String topic, int maxSubscriptionsPerTopic) Set the max number of subscriptions for specified topic asynchronously.void
setMaxUnackedMessagesOnConsumer
(String topic, int maxNum) set max unacked messages on consumer of a topic.setMaxUnackedMessagesOnConsumerAsync
(String topic, int maxNum) set max unacked messages on consumer of a topic asynchronously.void
setMaxUnackedMessagesOnSubscription
(String topic, int maxNum) set max unacked messages on subscription of a topic.setMaxUnackedMessagesOnSubscriptionAsync
(String topic, int maxNum) set max unacked messages on subscription of a topic asynchronously.void
setMessageTTL
(String topic, int messageTTLInSecond) Set message TTL for a topic.void
setOffloadPolicies
(String topic, OffloadPolicies offloadPolicies) set offload policies of a topic.setOffloadPoliciesAsync
(String topic, OffloadPolicies offloadPolicies) set offload policies of a topic asynchronously.void
setPersistence
(String topic, PersistencePolicies persistencePolicies) Set the configuration of persistence policies for specified topic.setPersistenceAsync
(String topic, PersistencePolicies persistencePolicies) Set the configuration of persistence policies for specified topic asynchronously.void
setPublishRate
(String topic, PublishRate publishMsgRate) Set message-publish-rate (topics can publish this many messages per second).setPublishRateAsync
(String topic, PublishRate publishMsgRate) Set message-publish-rate (topics can publish this many messages per second) asynchronously.void
setReplicatorDispatchRate
(String topic, DispatchRate dispatchRate) Set replicatorDispatchRate for the topic.setReplicatorDispatchRateAsync
(String topic, DispatchRate dispatchRate) Set replicatorDispatchRate for the topic asynchronously.void
setRetention
(String topic, RetentionPolicies retention) Set the retention configuration on a topic.setRetentionAsync
(String topic, RetentionPolicies retention) Set the retention configuration for all the topics on a topic asynchronously.void
setSchemaCompatibilityStrategy
(String topic, SchemaCompatibilityStrategy strategy) Set schema compatibility strategy on a topic.setSchemaCompatibilityStrategyAsync
(String topic, SchemaCompatibilityStrategy strategy) Set schema compatibility strategy on a topic asynchronously.void
setSubscribeRate
(String topic, SubscribeRate subscribeRate) Set topic-subscribe-rate (topic will limit by subscribeRate).setSubscribeRateAsync
(String topic, SubscribeRate subscribeRate) Set topic-subscribe-rate (topics will limit by subscribeRate) asynchronously.void
setSubscriptionDispatchRate
(String topic, String subscriptionName, DispatchRate dispatchRate) Set dispatch rate limiter for a specific subscription.void
setSubscriptionDispatchRate
(String topic, DispatchRate dispatchRate) Set subscription-message-dispatch-rate for the topic.setSubscriptionDispatchRateAsync
(String topic, String subscriptionName, DispatchRate dispatchRate) Async version ofsetSubscriptionDispatchRate(String, String, DispatchRate)
.setSubscriptionDispatchRateAsync
(String topic, DispatchRate dispatchRate) Set subscription-message-dispatch-rate for the topic asynchronously.void
setSubscriptionTypesEnabled
(String topic, Set<org.apache.pulsar.client.api.SubscriptionType> subscriptionTypesEnabled) Set is enable sub types.setSubscriptionTypesEnabledAsync
(String topic, Set<org.apache.pulsar.client.api.SubscriptionType> subscriptionTypesEnabled) Set is enable sub types asynchronously.
-
Method Details
-
getBacklogQuotaMap
Map<BacklogQuota.BacklogQuotaType,BacklogQuota> getBacklogQuotaMap(String topic) throws PulsarAdminException Get backlog quota map for a topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException.NotFoundException
- Topic does not existPulsarAdminException
- Unexpected error
-
getBacklogQuotaMap
Map<BacklogQuota.BacklogQuotaType,BacklogQuota> getBacklogQuotaMap(String topic, boolean applied) throws PulsarAdminException Get applied backlog quota map for a topic.- Parameters:
topic
-applied
-- Returns:
- Throws:
PulsarAdminException
-
setBacklogQuota
void setBacklogQuota(String topic, BacklogQuota backlogQuota, BacklogQuota.BacklogQuotaType backlogQuotaType) throws PulsarAdminException Set a backlog quota for a topic.- Parameters:
topic
- Topic namebacklogQuota
- the new BacklogQuotabacklogQuotaType
-- Throws:
PulsarAdminException.NotFoundException
- Topic does not existPulsarAdminException
- Unexpected error
-
setBacklogQuota
- Throws:
PulsarAdminException
-
removeBacklogQuota
void removeBacklogQuota(String topic, BacklogQuota.BacklogQuotaType backlogQuotaType) throws PulsarAdminException Remove a backlog quota policy from a topic. The namespace backlog policy falls back to the default.- Parameters:
topic
- Topic namebacklogQuotaType
-- Throws:
PulsarAdminException.NotFoundException
- Topic does not existPulsarAdminException
- Unexpected error
-
removeBacklogQuota
- Throws:
PulsarAdminException
-
getDelayedDeliveryPolicy
DelayedDeliveryPolicies getDelayedDeliveryPolicy(String topic, boolean applied) throws PulsarAdminException Get the delayed delivery policy applied for a specified topic.- Parameters:
topic
-applied
-- Returns:
- Throws:
PulsarAdminException
-
getDelayedDeliveryPolicyAsync
CompletableFuture<DelayedDeliveryPolicies> getDelayedDeliveryPolicyAsync(String topic, boolean applied) Get the delayed delivery policy applied for a specified topic asynchronously.- Parameters:
topic
-applied
-- Returns:
-
getDelayedDeliveryPolicy
Get the delayed delivery policy for a specified topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getDelayedDeliveryPolicyAsync
Get the delayed delivery policy for a specified topic asynchronously.- Parameters:
topic
-- Returns:
-
setDelayedDeliveryPolicy
void setDelayedDeliveryPolicy(String topic, DelayedDeliveryPolicies delayedDeliveryPolicies) throws PulsarAdminException Set the delayed delivery policy for a specified topic.- Parameters:
topic
-delayedDeliveryPolicies
-- Throws:
PulsarAdminException
-
setDelayedDeliveryPolicyAsync
CompletableFuture<Void> setDelayedDeliveryPolicyAsync(String topic, DelayedDeliveryPolicies delayedDeliveryPolicies) Set the delayed delivery policy for a specified topic asynchronously.- Parameters:
topic
-delayedDeliveryPolicies
-- Returns:
-
removeDelayedDeliveryPolicyAsync
Remove the delayed delivery policy for a specified topic asynchronously.- Parameters:
topic
-- Returns:
-
removeDelayedDeliveryPolicy
Remove the delayed delivery policy for a specified topic.- Parameters:
topic
-- Throws:
PulsarAdminException
-
setMessageTTL
Set message TTL for a topic.- Parameters:
topic
- Topic namemessageTTLInSecond
- Message TTL in second.- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Topic does not existPulsarAdminException
- Unexpected error
-
getMessageTTL
Get message TTL for a topic.- Parameters:
topic
-- Returns:
- Message TTL in second.
- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Topic does not existPulsarAdminException
- Unexpected error
-
getMessageTTL
Get message TTL applied for a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
removeMessageTTL
Remove message TTL for a topic.- Parameters:
topic
-- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Topic does not existPulsarAdminException
- Unexpected error
-
setRetention
Set the retention configuration on a topic. Set the retention configuration on a topic. This operation requires Pulsar super-user access. Request parameter example:{ "retentionTimeInMinutes" : 60, // how long to retain messages "retentionSizeInMB" : 1024, // retention backlog limit }
- Parameters:
topic
- Topic name- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Topic does not existConflictException
- Concurrent modificationPulsarAdminException
- Unexpected error
-
setRetentionAsync
Set the retention configuration for all the topics on a topic asynchronously. Set the retention configuration on a topic. This operation requires Pulsar super-user access. Request parameter example:{ "retentionTimeInMinutes" : 60, // how long to retain messages "retentionSizeInMB" : 1024, // retention backlog limit }
- Parameters:
topic
- Topic name
-
getRetention
Get the retention configuration for a topic. Get the retention configuration for a topic. Response example:{ "retentionTimeInMinutes" : 60, // how long to retain messages "retentionSizeInMB" : 1024, // retention backlog limit }
- Parameters:
topic
- Topic name- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Topic does not existConflictException
- Concurrent modificationPulsarAdminException
- Unexpected error
-
getRetentionAsync
Get the retention configuration for a topic asynchronously. Get the retention configuration for a topic.- Parameters:
topic
- Topic name
-
getRetention
Get the applied retention configuration for a topic.- Parameters:
topic
-applied
-- Returns:
- Throws:
PulsarAdminException
-
getRetentionAsync
Get the applied retention configuration for a topic asynchronously.- Parameters:
topic
-applied
-- Returns:
-
removeRetention
Remove the retention configuration for all the topics on a topic. Remove the retention configuration on a topic. This operation requires Pulsar super-user access. Request parameter example:- Parameters:
topic
- Topic name- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Topic does not existConflictException
- Concurrent modificationPulsarAdminException
- Unexpected error
-
removeRetentionAsync
Remove the retention configuration for all the topics on a topic asynchronously. Remove the retention configuration on a topic. This operation requires Pulsar super-user access. Request parameter example:{ "retentionTimeInMinutes" : 60, // how long to retain messages "retentionSizeInMB" : 1024, // retention backlog limit }
- Parameters:
topic
- Topic name
-
getMaxUnackedMessagesOnConsumer
Get max unacked messages on a consumer of a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getMaxUnackedMessagesOnConsumerAsync
get max unacked messages on consumer of a topic asynchronously.- Parameters:
topic
-- Returns:
-
getMaxUnackedMessagesOnConsumer
get applied max unacked messages on consumer of a topic.- Parameters:
topic
-applied
-- Returns:
- Throws:
PulsarAdminException
-
getMaxUnackedMessagesOnConsumerAsync
get applied max unacked messages on consumer of a topic asynchronously.- Parameters:
topic
-applied
-- Returns:
-
setMaxUnackedMessagesOnConsumer
set max unacked messages on consumer of a topic.- Parameters:
topic
-maxNum
-- Throws:
PulsarAdminException
-
setMaxUnackedMessagesOnConsumerAsync
set max unacked messages on consumer of a topic asynchronously.- Parameters:
topic
-maxNum
-- Returns:
-
removeMaxUnackedMessagesOnConsumer
remove max unacked messages on consumer of a topic.- Parameters:
topic
-- Throws:
PulsarAdminException
-
removeMaxUnackedMessagesOnConsumerAsync
remove max unacked messages on consumer of a topic asynchronously.- Parameters:
topic
-- Returns:
-
getInactiveTopicPolicies
InactiveTopicPolicies getInactiveTopicPolicies(String topic, boolean applied) throws PulsarAdminException Get inactive topic policies applied for a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getInactiveTopicPoliciesAsync
CompletableFuture<InactiveTopicPolicies> getInactiveTopicPoliciesAsync(String topic, boolean applied) Get inactive topic policies applied for a topic asynchronously.- Parameters:
topic
-applied
-- Returns:
-
getInactiveTopicPolicies
get inactive topic policies of a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getInactiveTopicPoliciesAsync
get inactive topic policies of a topic asynchronously.- Parameters:
topic
-- Returns:
-
setInactiveTopicPolicies
void setInactiveTopicPolicies(String topic, InactiveTopicPolicies inactiveTopicPolicies) throws PulsarAdminException set inactive topic policies of a topic.- Parameters:
topic
-inactiveTopicPolicies
-- Throws:
PulsarAdminException
-
setInactiveTopicPoliciesAsync
CompletableFuture<Void> setInactiveTopicPoliciesAsync(String topic, InactiveTopicPolicies inactiveTopicPolicies) set inactive topic policies of a topic asynchronously.- Parameters:
topic
-inactiveTopicPolicies
-- Returns:
-
removeInactiveTopicPolicies
remove inactive topic policies of a topic.- Parameters:
topic
-- Throws:
PulsarAdminException
-
removeInactiveTopicPoliciesAsync
remove inactive topic policies of a topic asynchronously.- Parameters:
topic
-- Returns:
-
getOffloadPolicies
get offload policies of a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getOffloadPoliciesAsync
get offload policies of a topic asynchronously.- Parameters:
topic
-- Returns:
-
getOffloadPolicies
get applied offload policies of a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getOffloadPoliciesAsync
get applied offload policies of a topic asynchronously.- Parameters:
topic
-- Returns:
-
setOffloadPolicies
set offload policies of a topic.- Parameters:
topic
-offloadPolicies
-- Throws:
PulsarAdminException
-
setOffloadPoliciesAsync
set offload policies of a topic asynchronously.- Parameters:
topic
-offloadPolicies
-- Returns:
-
removeOffloadPolicies
remove offload policies of a topic.- Parameters:
topic
-- Throws:
PulsarAdminException
-
removeOffloadPoliciesAsync
remove offload policies of a topic asynchronously.- Parameters:
topic
-- Returns:
-
getMaxUnackedMessagesOnSubscription
get max unacked messages on subscription of a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getMaxUnackedMessagesOnSubscriptionAsync
get max unacked messages on subscription of a topic asynchronously.- Parameters:
topic
-- Returns:
-
getMaxUnackedMessagesOnSubscription
Integer getMaxUnackedMessagesOnSubscription(String topic, boolean applied) throws PulsarAdminException get max unacked messages on subscription of a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getMaxUnackedMessagesOnSubscriptionAsync
get max unacked messages on subscription of a topic asynchronously.- Parameters:
topic
-- Returns:
-
setMaxUnackedMessagesOnSubscription
set max unacked messages on subscription of a topic.- Parameters:
topic
-maxNum
-- Throws:
PulsarAdminException
-
setMaxUnackedMessagesOnSubscriptionAsync
set max unacked messages on subscription of a topic asynchronously.- Parameters:
topic
-maxNum
-- Returns:
-
removeMaxUnackedMessagesOnSubscription
remove max unacked messages on subscription of a topic.- Parameters:
topic
-- Throws:
PulsarAdminException
-
removeMaxUnackedMessagesOnSubscriptionAsync
remove max unacked messages on subscription of a topic asynchronously.- Parameters:
topic
-- Returns:
-
setPersistence
void setPersistence(String topic, PersistencePolicies persistencePolicies) throws PulsarAdminException Set the configuration of persistence policies for specified topic.- Parameters:
topic
- Topic namepersistencePolicies
- Configuration of bookkeeper persistence policies- Throws:
PulsarAdminException
- Unexpected error
-
setPersistenceAsync
Set the configuration of persistence policies for specified topic asynchronously.- Parameters:
topic
- Topic namepersistencePolicies
- Configuration of bookkeeper persistence policies
-
getPersistence
Get the configuration of persistence policies for specified topic.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
getPersistenceAsync
Get the configuration of persistence policies for specified topic asynchronously.- Parameters:
topic
- Topic name
-
getPersistence
Get the applied configuration of persistence policies for specified topic.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
getPersistenceAsync
Get the applied configuration of persistence policies for specified topic asynchronously.- Parameters:
topic
- Topic name
-
removePersistence
Remove the configuration of persistence policies for specified topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removePersistenceAsync
Remove the configuration of persistence policies for specified topic asynchronously.- Parameters:
topic
- Topic name
-
getDeduplicationStatus
get deduplication enabled of a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getDeduplicationStatusAsync
get deduplication enabled of a topic asynchronously.- Parameters:
topic
-- Returns:
-
getDeduplicationStatus
get applied deduplication enabled of a topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getDeduplicationStatusAsync
get applied deduplication enabled of a topic asynchronously.- Parameters:
topic
-- Returns:
-
setDeduplicationStatus
set deduplication enabled of a topic.- Parameters:
topic
-enabled
-- Throws:
PulsarAdminException
-
setDeduplicationStatusAsync
set deduplication enabled of a topic asynchronously.- Parameters:
topic
-enabled
-- Returns:
-
removeDeduplicationStatus
remove deduplication enabled of a topic.- Parameters:
topic
-- Throws:
PulsarAdminException
-
removeDeduplicationStatusAsync
remove deduplication enabled of a topic asynchronously.- Parameters:
topic
-- Returns:
-
setDispatchRate
Set message-dispatch-rate (topic can dispatch this many messages per second).- Parameters:
topic
-dispatchRate
- number of messages per second- Throws:
PulsarAdminException
- Unexpected error
-
setDispatchRateAsync
Set message-dispatch-rate asynchronously. topic can dispatch this many messages per second- Parameters:
topic
-dispatchRate
- number of messages per second
-
getDispatchRate
Get message-dispatch-rate (topic can dispatch this many messages per second).- Parameters:
topic
-- Throws:
PulsarAdminException
- Unexpected error
-
getDispatchRateAsync
Get message-dispatch-rate asynchronously. Topic can dispatch this many messages per second.- Parameters:
topic
-
-
getDispatchRate
Get applied message-dispatch-rate (topic can dispatch this many messages per second).- Parameters:
topic
-- Throws:
PulsarAdminException
- Unexpected error
-
getDispatchRateAsync
Get applied message-dispatch-rate asynchronously. Topic can dispatch this many messages per second.- Parameters:
topic
-
-
removeDispatchRate
Remove message-dispatch-rate. Remove topic message dispatch rate- Parameters:
topic
-- Throws:
PulsarAdminException
- unexpected error
-
removeDispatchRateAsync
Remove message-dispatch-rate asynchronously. Remove topic message dispatch rate- Parameters:
topic
-- Throws:
PulsarAdminException
- unexpected error
-
setSubscriptionDispatchRate
void setSubscriptionDispatchRate(String topic, DispatchRate dispatchRate) throws PulsarAdminException Set subscription-message-dispatch-rate for the topic. Subscriptions of this topic can dispatch this many messages per second- Parameters:
topic
-dispatchRate
- number of messages per second- Throws:
PulsarAdminException
- Unexpected error
-
setSubscriptionDispatchRateAsync
Set subscription-message-dispatch-rate for the topic asynchronously. Subscriptions of this topic can dispatch this many messages per second.- Parameters:
topic
-dispatchRate
- number of messages per second
-
getSubscriptionDispatchRate
Get applied subscription-message-dispatch-rate. Subscriptions of this topic can dispatch this many messages per second.- Parameters:
topic
-- Throws:
PulsarAdminException
- Unexpected error
-
getSubscriptionDispatchRateAsync
Get applied subscription-message-dispatch-rate asynchronously. Subscriptions in this topic can dispatch this many messages per second.- Parameters:
topic
-
-
getSubscriptionDispatchRate
Get subscription-message-dispatch-rate for the topic. Subscriptions of this topic can dispatch this many messages per second.- Parameters:
topic
-- Throws:
PulsarAdminException
- Unexpected error
-
getSubscriptionDispatchRateAsync
Get subscription-message-dispatch-rate asynchronously. Subscriptions of this topic can dispatch this many messages per second.- Parameters:
topic
-
-
removeSubscriptionDispatchRate
Remove subscription-message-dispatch-rate for a topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removeSubscriptionDispatchRateAsync
Remove subscription-message-dispatch-rate for a topic asynchronously.- Parameters:
topic
- Topic name
-
setSubscriptionDispatchRate
void setSubscriptionDispatchRate(String topic, String subscriptionName, DispatchRate dispatchRate) throws PulsarAdminException Set dispatch rate limiter for a specific subscription.- Throws:
PulsarAdminException
-
setSubscriptionDispatchRateAsync
CompletableFuture<Void> setSubscriptionDispatchRateAsync(String topic, String subscriptionName, DispatchRate dispatchRate) Async version ofsetSubscriptionDispatchRate(String, String, DispatchRate)
. -
getSubscriptionDispatchRate
DispatchRate getSubscriptionDispatchRate(String topic, String subscriptionName, boolean applied) throws PulsarAdminException If applied is true, get dispatch rate limiter for a specific subscription. Or else, return subscription level setting.- Throws:
PulsarAdminException
-
getSubscriptionDispatchRateAsync
CompletableFuture<DispatchRate> getSubscriptionDispatchRateAsync(String topic, String subscriptionName, boolean applied) Async version ofgetSubscriptionDispatchRate(String, String, boolean)
. -
getSubscriptionDispatchRate
DispatchRate getSubscriptionDispatchRate(String topic, String subscriptionName) throws PulsarAdminException Get subscription level dispatch rate limiter setting for a specific subscription.- Throws:
PulsarAdminException
-
getSubscriptionDispatchRateAsync
CompletableFuture<DispatchRate> getSubscriptionDispatchRateAsync(String topic, String subscriptionName) Async version ofgetSubscriptionDispatchRate(String, String)
. -
removeSubscriptionDispatchRate
void removeSubscriptionDispatchRate(String topic, String subscriptionName) throws PulsarAdminException Remove subscription level dispatch rate limiter setting for a specific subscription.- Throws:
PulsarAdminException
-
removeSubscriptionDispatchRateAsync
Async version ofremoveSubscriptionDispatchRate(String, String)
. -
setReplicatorDispatchRate
Set replicatorDispatchRate for the topic. Replicator dispatch rate under this topic can dispatch this many messages per second- Parameters:
topic
-dispatchRate
- number of messages per second- Throws:
PulsarAdminException
- Unexpected error
-
setReplicatorDispatchRateAsync
Set replicatorDispatchRate for the topic asynchronously. Replicator dispatch rate under this topic can dispatch this many messages per second.- Parameters:
topic
-dispatchRate
- number of messages per second
-
getReplicatorDispatchRate
Get replicatorDispatchRate for the topic. Replicator dispatch rate under this topic can dispatch this many messages per second.- Parameters:
topic
-- Throws:
PulsarAdminException
- Unexpected error
-
getReplicatorDispatchRateAsync
Get replicatorDispatchRate asynchronously. Replicator dispatch rate under this topic can dispatch this many messages per second.- Parameters:
topic
-
-
getReplicatorDispatchRate
Get applied replicatorDispatchRate for the topic.- Parameters:
topic
-applied
-- Returns:
- Throws:
PulsarAdminException
-
getReplicatorDispatchRateAsync
Get applied replicatorDispatchRate asynchronously.- Parameters:
topic
-applied
-- Returns:
-
removeReplicatorDispatchRate
Remove replicatorDispatchRate for a topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removeReplicatorDispatchRateAsync
Remove replicatorDispatchRate for a topic asynchronously.- Parameters:
topic
- Topic name
-
getCompactionThreshold
Get the compactionThreshold for a topic. The maximum number of bytes can have before compaction is triggered. 0 disables. Response example:10000000
- Parameters:
topic
- Topic name- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Namespace does not existPulsarAdminException
- Unexpected error
-
getCompactionThresholdAsync
Get the compactionThreshold for a topic asynchronously. The maximum number of bytes can have before compaction is triggered. 0 disables. Response example:10000000
- Parameters:
topic
- Topic name
-
getCompactionThreshold
Get the compactionThreshold for a topic. The maximum number of bytes can have before compaction is triggered. 0 disables.- Parameters:
topic
- Topic name- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Namespace does not existPulsarAdminException
- Unexpected error
-
getCompactionThresholdAsync
Get the compactionThreshold for a topic asynchronously. The maximum number of bytes can have before compaction is triggered. 0 disables.- Parameters:
topic
- Topic name
-
setCompactionThreshold
Set the compactionThreshold for a topic. The maximum number of bytes can have before compaction is triggered. 0 disables. Request example:10000000
- Parameters:
topic
- Topic namecompactionThreshold
- maximum number of backlog bytes before compaction is triggered- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Namespace does not existPulsarAdminException
- Unexpected error
-
setCompactionThresholdAsync
Set the compactionThreshold for a topic asynchronously. The maximum number of bytes can have before compaction is triggered. 0 disables. Request example:10000000
- Parameters:
topic
- Topic namecompactionThreshold
- maximum number of backlog bytes before compaction is triggered
-
removeCompactionThreshold
Remove the compactionThreshold for a topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removeCompactionThresholdAsync
Remove the compactionThreshold for a topic asynchronously.- Parameters:
topic
- Topic name
-
setPublishRate
Set message-publish-rate (topics can publish this many messages per second).- Parameters:
topic
-publishMsgRate
- number of messages per second- Throws:
PulsarAdminException
- Unexpected error
-
setPublishRateAsync
Set message-publish-rate (topics can publish this many messages per second) asynchronously.- Parameters:
topic
-publishMsgRate
- number of messages per second
-
getPublishRate
Get message-publish-rate (topics can publish this many messages per second).- Parameters:
topic
-- Returns:
- number of messages per second
- Throws:
PulsarAdminException
- Unexpected error
-
getPublishRateAsync
Get message-publish-rate (topics can publish this many messages per second) asynchronously.- Parameters:
topic
-- Returns:
- number of messages per second
-
removePublishRate
Remove message-publish-rate. Remove topic message publish rate- Parameters:
topic
-- Throws:
PulsarAdminException
- unexpected error
-
removePublishRateAsync
Remove message-publish-rate asynchronously. Remove topic message publish rate- Parameters:
topic
-- Throws:
PulsarAdminException
- unexpected error
-
getMaxConsumersPerSubscription
Get the maxConsumersPerSubscription for a topic. Response example:0
- Parameters:
topic
- Topic name- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Namespace does not existPulsarAdminException
- Unexpected error
-
getMaxConsumersPerSubscriptionAsync
Get the maxConsumersPerSubscription for a topic asynchronously. Response example:0
- Parameters:
topic
- Topic name
-
setMaxConsumersPerSubscription
void setMaxConsumersPerSubscription(String topic, int maxConsumersPerSubscription) throws PulsarAdminException Set maxConsumersPerSubscription for a topic. Request example:10
- Parameters:
topic
- Topic namemaxConsumersPerSubscription
- maxConsumersPerSubscription value for a namespace- Throws:
NotAuthorizedException
- Don't have admin permissionPulsarAdminException.NotFoundException
- Namespace does not existPulsarAdminException
- Unexpected error
-
setMaxConsumersPerSubscriptionAsync
CompletableFuture<Void> setMaxConsumersPerSubscriptionAsync(String topic, int maxConsumersPerSubscription) Set maxConsumersPerSubscription for a topic asynchronously. Request example:10
- Parameters:
topic
- Topic namemaxConsumersPerSubscription
- maxConsumersPerSubscription value for a namespace
-
removeMaxConsumersPerSubscription
Remove the maxConsumersPerSubscription for a topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxConsumersPerSubscriptionAsync
Remove the maxConsumersPerSubscription for a topic asynchronously.- Parameters:
topic
- Topic name
-
getMaxProducers
Get the max number of producer for specified topic.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
getMaxProducersAsync
Get the max number of producer for specified topic asynchronously.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
getMaxProducers
Get the max number of producer applied for specified topic.- Parameters:
topic
-applied
-- Returns:
- Throws:
PulsarAdminException
-
getMaxProducersAsync
Get the max number of producer applied for specified topic asynchronously.- Parameters:
topic
-applied
-- Returns:
-
setMaxProducers
Set the max number of producer for specified topic.- Parameters:
topic
- Topic namemaxProducers
- Max number of producer- Throws:
PulsarAdminException
- Unexpected error
-
setMaxProducersAsync
Set the max number of producer for specified topic asynchronously.- Parameters:
topic
- Topic namemaxProducers
- Max number of producer- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxProducers
Remove the max number of producer for specified topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxProducersAsync
Remove the max number of producer for specified topic asynchronously.- Parameters:
topic
- Topic name
-
getMaxSubscriptionsPerTopic
Get the max number of subscriptions for specified topic.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
getMaxSubscriptionsPerTopicAsync
Get the max number of subscriptions for specified topic asynchronously.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
setMaxSubscriptionsPerTopic
void setMaxSubscriptionsPerTopic(String topic, int maxSubscriptionsPerTopic) throws PulsarAdminException Set the max number of subscriptions for specified topic.- Parameters:
topic
- Topic namemaxSubscriptionsPerTopic
- Max number of subscriptions- Throws:
PulsarAdminException
- Unexpected error
-
setMaxSubscriptionsPerTopicAsync
CompletableFuture<Void> setMaxSubscriptionsPerTopicAsync(String topic, int maxSubscriptionsPerTopic) Set the max number of subscriptions for specified topic asynchronously.- Parameters:
topic
- Topic namemaxSubscriptionsPerTopic
- Max number of subscriptions- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxSubscriptionsPerTopic
Remove the max number of subscriptions for specified topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxSubscriptionsPerTopicAsync
Remove the max number of subscriptions for specified topic asynchronously.- Parameters:
topic
- Topic name
-
getMaxMessageSize
Get the max message size for specified topic.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
getMaxMessageSizeAsync
Get the max message size for specified topic asynchronously.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
setMaxMessageSize
Set the max message size for specified topic.- Parameters:
topic
- Topic namemaxMessageSize
- Max message size of producer- Throws:
PulsarAdminException
- Unexpected error
-
setMaxMessageSizeAsync
Set the max message size for specified topic asynchronously.0 disables.- Parameters:
topic
- Topic namemaxMessageSize
- Max message size of topic- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxMessageSize
Remove the max message size for specified topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxMessageSizeAsync
Remove the max message size for specified topic asynchronously.- Parameters:
topic
- Topic name
-
getMaxConsumers
Get the max number of consumer for specified topic.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
getMaxConsumersAsync
Get the max number of consumer for specified topic asynchronously.- Parameters:
topic
- Topic name- Returns:
- Configuration of bookkeeper persistence policies
- Throws:
PulsarAdminException
- Unexpected error
-
getMaxConsumers
Get the max number of consumer applied for specified topic.- Parameters:
topic
-applied
-- Returns:
- Throws:
PulsarAdminException
-
getMaxConsumersAsync
Get the max number of consumer applied for specified topic asynchronously.- Parameters:
topic
-applied
-- Returns:
-
setMaxConsumers
Set the max number of consumer for specified topic.- Parameters:
topic
- Topic namemaxConsumers
- Max number of consumer- Throws:
PulsarAdminException
- Unexpected error
-
setMaxConsumersAsync
Set the max number of consumer for specified topic asynchronously.- Parameters:
topic
- Topic namemaxConsumers
- Max number of consumer- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxConsumers
Remove the max number of consumer for specified topic.- Parameters:
topic
- Topic name- Throws:
PulsarAdminException
- Unexpected error
-
removeMaxConsumersAsync
Remove the max number of consumer for specified topic asynchronously.- Parameters:
topic
- Topic name
-
getDeduplicationSnapshotInterval
Get the deduplication snapshot interval for specified topic.- Parameters:
topic
-- Returns:
- Throws:
PulsarAdminException
-
getDeduplicationSnapshotIntervalAsync
Get the deduplication snapshot interval for specified topic asynchronously.- Parameters:
topic
-- Returns:
-
setDeduplicationSnapshotInterval
Set the deduplication snapshot interval for specified topic.- Parameters:
topic
-interval
-- Throws:
PulsarAdminException
-
setDeduplicationSnapshotIntervalAsync
Set the deduplication snapshot interval for specified topic asynchronously.- Parameters:
topic
-interval
-- Returns:
-
removeDeduplicationSnapshotInterval
Remove the deduplication snapshot interval for specified topic.- Parameters:
topic
-- Throws:
PulsarAdminException
-
removeDeduplicationSnapshotIntervalAsync
Remove the deduplication snapshot interval for specified topic asynchronously.- Parameters:
topic
-- Returns:
-
setSubscriptionTypesEnabled
void setSubscriptionTypesEnabled(String topic, Set<org.apache.pulsar.client.api.SubscriptionType> subscriptionTypesEnabled) throws PulsarAdminException Set is enable sub types.- Parameters:
topic
-subscriptionTypesEnabled
- is enable subTypes- Throws:
PulsarAdminException
- Unexpected error
-
setSubscriptionTypesEnabledAsync
CompletableFuture<Void> setSubscriptionTypesEnabledAsync(String topic, Set<org.apache.pulsar.client.api.SubscriptionType> subscriptionTypesEnabled) Set is enable sub types asynchronously.- Parameters:
topic
-subscriptionTypesEnabled
- is enable subTypes
-
getSubscriptionTypesEnabled
Set<org.apache.pulsar.client.api.SubscriptionType> getSubscriptionTypesEnabled(String topic) throws PulsarAdminException Get is enable sub types.- Parameters:
topic
- is topic for get is enable sub types- Returns:
- set of enable sub types
- Throws:
PulsarAdminException
- Unexpected error
-
getSubscriptionTypesEnabledAsync
CompletableFuture<Set<org.apache.pulsar.client.api.SubscriptionType>> getSubscriptionTypesEnabledAsync(String topic) Get is enable sub types asynchronously.- Parameters:
topic
- is topic for get is enable sub types
-
removeSubscriptionTypesEnabled
Remove subscription types enabled for a topic.- Parameters:
topic
-- Throws:
PulsarAdminException
-
removeSubscriptionTypesEnabledAsync
Remove subscription types enabled for a topic asynchronously.- Parameters:
topic
-- Returns:
-
setSubscribeRate
Set topic-subscribe-rate (topic will limit by subscribeRate).- Parameters:
topic
-subscribeRate
- consumer subscribe limit by this subscribeRate- Throws:
PulsarAdminException
- Unexpected error
-
setSubscribeRateAsync
Set topic-subscribe-rate (topics will limit by subscribeRate) asynchronously.- Parameters:
topic
-subscribeRate
- consumer subscribe limit by this subscribeRate
-
getSubscribeRate
Get topic-subscribe-rate (topics allow subscribe times per consumer in a period).- Parameters:
topic
-- Throws:
PulsarAdminException
- Unexpected error
-
getSubscribeRateAsync
Get topic-subscribe-rate asynchronously. Topic allow subscribe times per consumer in a period.- Parameters:
topic
-
-
getSubscribeRate
Get applied topic-subscribe-rate (topics allow subscribe times per consumer in a period).- Parameters:
topic
-- Throws:
PulsarAdminException
- Unexpected error
-
getSubscribeRateAsync
Get applied topic-subscribe-rate asynchronously.- Parameters:
topic
-
-
removeSubscribeRate
Remove topic-subscribe-rate. Remove topic subscribe rate- Parameters:
topic
-- Throws:
PulsarAdminException
- unexpected error
-
removeSubscribeRateAsync
Remove topic-subscribe-rate asynchronously. Remove topic subscribe rate- Parameters:
topic
-- Throws:
PulsarAdminException
- unexpected error
-
getSchemaCompatibilityStrategy
SchemaCompatibilityStrategy getSchemaCompatibilityStrategy(String topic, boolean applied) throws PulsarAdminException Get schema compatibility strategy on a topic.- Parameters:
topic
- The topic in whose policy we are interestedapplied
- Get the current applied schema compatibility strategy- Throws:
PulsarAdminException
-
getSchemaCompatibilityStrategyAsync
CompletableFuture<SchemaCompatibilityStrategy> getSchemaCompatibilityStrategyAsync(String topic, boolean applied) Get schema compatibility strategy on a topic asynchronously.- Parameters:
topic
- The topic in whose policy we are interestedapplied
- Get the current applied schema compatibility strategy
-
setSchemaCompatibilityStrategy
void setSchemaCompatibilityStrategy(String topic, SchemaCompatibilityStrategy strategy) throws PulsarAdminException Set schema compatibility strategy on a topic.- Parameters:
topic
- The topic in whose policy should be setstrategy
- The schema compatibility strategy- Throws:
PulsarAdminException
-
setSchemaCompatibilityStrategyAsync
CompletableFuture<Void> setSchemaCompatibilityStrategyAsync(String topic, SchemaCompatibilityStrategy strategy) Set schema compatibility strategy on a topic asynchronously.- Parameters:
topic
- The topic in whose policy should be setstrategy
- The schema compatibility strategy
-
removeSchemaCompatibilityStrategy
Remove schema compatibility strategy on a topic.- Parameters:
topic
- The topic in whose policy should be removed- Throws:
PulsarAdminException
-
removeSchemaCompatibilityStrategyAsync
Remove schema compatibility strategy on a topic asynchronously.- Parameters:
topic
- The topic in whose policy should be removed
-