Interface TopicPolicies


public interface TopicPolicies
Admin interface for topic policies management.
  • Method Details

    • getBacklogQuotaMap

      Get backlog quota map for a topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException.NotFoundException - Topic does not exist
      PulsarAdminException - 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 name
      backlogQuota - the new BacklogQuota
      backlogQuotaType -
      Throws:
      PulsarAdminException.NotFoundException - Topic does not exist
      PulsarAdminException - Unexpected error
    • setBacklogQuota

      default void setBacklogQuota(String topic, BacklogQuota backlogQuota) throws PulsarAdminException
      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 name
      backlogQuotaType -
      Throws:
      PulsarAdminException.NotFoundException - Topic does not exist
      PulsarAdminException - Unexpected error
    • removeBacklogQuota

      default void removeBacklogQuota(String topic) throws PulsarAdminException
      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

      DelayedDeliveryPolicies getDelayedDeliveryPolicy(String topic) throws PulsarAdminException
      Get the delayed delivery policy for a specified topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getDelayedDeliveryPolicyAsync

      CompletableFuture<DelayedDeliveryPolicies> getDelayedDeliveryPolicyAsync(String topic)
      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

      CompletableFuture<Void> removeDelayedDeliveryPolicyAsync(String topic)
      Remove the delayed delivery policy for a specified topic asynchronously.
      Parameters:
      topic -
      Returns:
    • removeDelayedDeliveryPolicy

      void removeDelayedDeliveryPolicy(String topic) throws PulsarAdminException
      Remove the delayed delivery policy for a specified topic.
      Parameters:
      topic -
      Throws:
      PulsarAdminException
    • setMessageTTL

      void setMessageTTL(String topic, int messageTTLInSecond) throws PulsarAdminException
      Set message TTL for a topic.
      Parameters:
      topic - Topic name
      messageTTLInSecond - Message TTL in second.
      Throws:
      NotAuthorizedException - Don't have admin permission
      PulsarAdminException.NotFoundException - Topic does not exist
      PulsarAdminException - Unexpected error
    • getMessageTTL

      Integer getMessageTTL(String topic) throws PulsarAdminException
      Get message TTL for a topic.
      Parameters:
      topic -
      Returns:
      Message TTL in second.
      Throws:
      NotAuthorizedException - Don't have admin permission
      PulsarAdminException.NotFoundException - Topic does not exist
      PulsarAdminException - Unexpected error
    • getMessageTTL

      Integer getMessageTTL(String topic, boolean applied) throws PulsarAdminException
      Get message TTL applied for a topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • removeMessageTTL

      void removeMessageTTL(String topic) throws PulsarAdminException
      Remove message TTL for a topic.
      Parameters:
      topic -
      Throws:
      NotAuthorizedException - Don't have admin permission
      PulsarAdminException.NotFoundException - Topic does not exist
      PulsarAdminException - Unexpected error
    • setRetention

      void setRetention(String topic, RetentionPolicies retention) throws PulsarAdminException
      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 permission
      PulsarAdminException.NotFoundException - Topic does not exist
      ConflictException - Concurrent modification
      PulsarAdminException - Unexpected error
    • setRetentionAsync

      CompletableFuture<Void> setRetentionAsync(String topic, RetentionPolicies retention)
      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

      RetentionPolicies getRetention(String topic) throws PulsarAdminException
      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 permission
      PulsarAdminException.NotFoundException - Topic does not exist
      ConflictException - Concurrent modification
      PulsarAdminException - Unexpected error
    • getRetentionAsync

      CompletableFuture<RetentionPolicies> getRetentionAsync(String topic)
      Get the retention configuration for a topic asynchronously.

      Get the retention configuration for a topic.

      Parameters:
      topic - Topic name
    • getRetention

      RetentionPolicies getRetention(String topic, boolean applied) throws PulsarAdminException
      Get the applied retention configuration for a topic.
      Parameters:
      topic -
      applied -
      Returns:
      Throws:
      PulsarAdminException
    • getRetentionAsync

      CompletableFuture<RetentionPolicies> getRetentionAsync(String topic, boolean applied)
      Get the applied retention configuration for a topic asynchronously.
      Parameters:
      topic -
      applied -
      Returns:
    • removeRetention

      void removeRetention(String topic) throws PulsarAdminException
      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 permission
      PulsarAdminException.NotFoundException - Topic does not exist
      ConflictException - Concurrent modification
      PulsarAdminException - Unexpected error
    • removeRetentionAsync

      CompletableFuture<Void> removeRetentionAsync(String topic)
      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

      Integer getMaxUnackedMessagesOnConsumer(String topic) throws PulsarAdminException
      Get max unacked messages on a consumer of a topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getMaxUnackedMessagesOnConsumerAsync

      CompletableFuture<Integer> getMaxUnackedMessagesOnConsumerAsync(String topic)
      get max unacked messages on consumer of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • getMaxUnackedMessagesOnConsumer

      Integer getMaxUnackedMessagesOnConsumer(String topic, boolean applied) throws PulsarAdminException
      get applied max unacked messages on consumer of a topic.
      Parameters:
      topic -
      applied -
      Returns:
      Throws:
      PulsarAdminException
    • getMaxUnackedMessagesOnConsumerAsync

      CompletableFuture<Integer> getMaxUnackedMessagesOnConsumerAsync(String topic, boolean applied)
      get applied max unacked messages on consumer of a topic asynchronously.
      Parameters:
      topic -
      applied -
      Returns:
    • setMaxUnackedMessagesOnConsumer

      void setMaxUnackedMessagesOnConsumer(String topic, int maxNum) throws PulsarAdminException
      set max unacked messages on consumer of a topic.
      Parameters:
      topic -
      maxNum -
      Throws:
      PulsarAdminException
    • setMaxUnackedMessagesOnConsumerAsync

      CompletableFuture<Void> setMaxUnackedMessagesOnConsumerAsync(String topic, int maxNum)
      set max unacked messages on consumer of a topic asynchronously.
      Parameters:
      topic -
      maxNum -
      Returns:
    • removeMaxUnackedMessagesOnConsumer

      void removeMaxUnackedMessagesOnConsumer(String topic) throws PulsarAdminException
      remove max unacked messages on consumer of a topic.
      Parameters:
      topic -
      Throws:
      PulsarAdminException
    • removeMaxUnackedMessagesOnConsumerAsync

      CompletableFuture<Void> removeMaxUnackedMessagesOnConsumerAsync(String topic)
      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

      InactiveTopicPolicies getInactiveTopicPolicies(String topic) throws PulsarAdminException
      get inactive topic policies of a topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getInactiveTopicPoliciesAsync

      CompletableFuture<InactiveTopicPolicies> getInactiveTopicPoliciesAsync(String topic)
      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

      void removeInactiveTopicPolicies(String topic) throws PulsarAdminException
      remove inactive topic policies of a topic.
      Parameters:
      topic -
      Throws:
      PulsarAdminException
    • removeInactiveTopicPoliciesAsync

      CompletableFuture<Void> removeInactiveTopicPoliciesAsync(String topic)
      remove inactive topic policies of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • getOffloadPolicies

      OffloadPolicies getOffloadPolicies(String topic) throws PulsarAdminException
      get offload policies of a topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getOffloadPoliciesAsync

      CompletableFuture<OffloadPolicies> getOffloadPoliciesAsync(String topic)
      get offload policies of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • getOffloadPolicies

      OffloadPolicies getOffloadPolicies(String topic, boolean applied) throws PulsarAdminException
      get applied offload policies of a topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getOffloadPoliciesAsync

      CompletableFuture<OffloadPolicies> getOffloadPoliciesAsync(String topic, boolean applied)
      get applied offload policies of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • setOffloadPolicies

      void setOffloadPolicies(String topic, OffloadPolicies offloadPolicies) throws PulsarAdminException
      set offload policies of a topic.
      Parameters:
      topic -
      offloadPolicies -
      Throws:
      PulsarAdminException
    • setOffloadPoliciesAsync

      CompletableFuture<Void> setOffloadPoliciesAsync(String topic, OffloadPolicies offloadPolicies)
      set offload policies of a topic asynchronously.
      Parameters:
      topic -
      offloadPolicies -
      Returns:
    • removeOffloadPolicies

      void removeOffloadPolicies(String topic) throws PulsarAdminException
      remove offload policies of a topic.
      Parameters:
      topic -
      Throws:
      PulsarAdminException
    • removeOffloadPoliciesAsync

      CompletableFuture<Void> removeOffloadPoliciesAsync(String topic)
      remove offload policies of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • getMaxUnackedMessagesOnSubscription

      Integer getMaxUnackedMessagesOnSubscription(String topic) throws PulsarAdminException
      get max unacked messages on subscription of a topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getMaxUnackedMessagesOnSubscriptionAsync

      CompletableFuture<Integer> getMaxUnackedMessagesOnSubscriptionAsync(String topic)
      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

      CompletableFuture<Integer> getMaxUnackedMessagesOnSubscriptionAsync(String topic, boolean applied)
      get max unacked messages on subscription of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • setMaxUnackedMessagesOnSubscription

      void setMaxUnackedMessagesOnSubscription(String topic, int maxNum) throws PulsarAdminException
      set max unacked messages on subscription of a topic.
      Parameters:
      topic -
      maxNum -
      Throws:
      PulsarAdminException
    • setMaxUnackedMessagesOnSubscriptionAsync

      CompletableFuture<Void> setMaxUnackedMessagesOnSubscriptionAsync(String topic, int maxNum)
      set max unacked messages on subscription of a topic asynchronously.
      Parameters:
      topic -
      maxNum -
      Returns:
    • removeMaxUnackedMessagesOnSubscription

      void removeMaxUnackedMessagesOnSubscription(String topic) throws PulsarAdminException
      remove max unacked messages on subscription of a topic.
      Parameters:
      topic -
      Throws:
      PulsarAdminException
    • removeMaxUnackedMessagesOnSubscriptionAsync

      CompletableFuture<Void> removeMaxUnackedMessagesOnSubscriptionAsync(String topic)
      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 name
      persistencePolicies - Configuration of bookkeeper persistence policies
      Throws:
      PulsarAdminException - Unexpected error
    • setPersistenceAsync

      CompletableFuture<Void> setPersistenceAsync(String topic, PersistencePolicies persistencePolicies)
      Set the configuration of persistence policies for specified topic asynchronously.
      Parameters:
      topic - Topic name
      persistencePolicies - Configuration of bookkeeper persistence policies
    • getPersistence

      PersistencePolicies getPersistence(String topic) throws PulsarAdminException
      Get the configuration of persistence policies for specified topic.
      Parameters:
      topic - Topic name
      Returns:
      Configuration of bookkeeper persistence policies
      Throws:
      PulsarAdminException - Unexpected error
    • getPersistenceAsync

      CompletableFuture<PersistencePolicies> getPersistenceAsync(String topic)
      Get the configuration of persistence policies for specified topic asynchronously.
      Parameters:
      topic - Topic name
    • getPersistence

      PersistencePolicies getPersistence(String topic, boolean applied) throws PulsarAdminException
      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

      CompletableFuture<PersistencePolicies> getPersistenceAsync(String topic, boolean applied)
      Get the applied configuration of persistence policies for specified topic asynchronously.
      Parameters:
      topic - Topic name
    • removePersistence

      void removePersistence(String topic) throws PulsarAdminException
      Remove the configuration of persistence policies for specified topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removePersistenceAsync

      CompletableFuture<Void> removePersistenceAsync(String topic)
      Remove the configuration of persistence policies for specified topic asynchronously.
      Parameters:
      topic - Topic name
    • getDeduplicationStatus

      Boolean getDeduplicationStatus(String topic) throws PulsarAdminException
      get deduplication enabled of a topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getDeduplicationStatusAsync

      CompletableFuture<Boolean> getDeduplicationStatusAsync(String topic)
      get deduplication enabled of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • getDeduplicationStatus

      Boolean getDeduplicationStatus(String topic, boolean applied) throws PulsarAdminException
      get applied deduplication enabled of a topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getDeduplicationStatusAsync

      CompletableFuture<Boolean> getDeduplicationStatusAsync(String topic, boolean applied)
      get applied deduplication enabled of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • setDeduplicationStatus

      void setDeduplicationStatus(String topic, boolean enabled) throws PulsarAdminException
      set deduplication enabled of a topic.
      Parameters:
      topic -
      enabled -
      Throws:
      PulsarAdminException
    • setDeduplicationStatusAsync

      CompletableFuture<Void> setDeduplicationStatusAsync(String topic, boolean enabled)
      set deduplication enabled of a topic asynchronously.
      Parameters:
      topic -
      enabled -
      Returns:
    • removeDeduplicationStatus

      void removeDeduplicationStatus(String topic) throws PulsarAdminException
      remove deduplication enabled of a topic.
      Parameters:
      topic -
      Throws:
      PulsarAdminException
    • removeDeduplicationStatusAsync

      CompletableFuture<Void> removeDeduplicationStatusAsync(String topic)
      remove deduplication enabled of a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • setDispatchRate

      void setDispatchRate(String topic, DispatchRate dispatchRate) throws PulsarAdminException
      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

      CompletableFuture<Void> setDispatchRateAsync(String topic, DispatchRate dispatchRate)
      Set message-dispatch-rate asynchronously.

      topic can dispatch this many messages per second

      Parameters:
      topic -
      dispatchRate - number of messages per second
    • getDispatchRate

      DispatchRate getDispatchRate(String topic) throws PulsarAdminException
      Get message-dispatch-rate (topic can dispatch this many messages per second).
      Parameters:
      topic -
      Throws:
      PulsarAdminException - Unexpected error
    • getDispatchRateAsync

      CompletableFuture<DispatchRate> getDispatchRateAsync(String topic)
      Get message-dispatch-rate asynchronously.

      Topic can dispatch this many messages per second.

      Parameters:
      topic -
    • getDispatchRate

      DispatchRate getDispatchRate(String topic, boolean applied) throws PulsarAdminException
      Get applied message-dispatch-rate (topic can dispatch this many messages per second).
      Parameters:
      topic -
      Throws:
      PulsarAdminException - Unexpected error
    • getDispatchRateAsync

      CompletableFuture<DispatchRate> getDispatchRateAsync(String topic, boolean applied)
      Get applied message-dispatch-rate asynchronously.

      Topic can dispatch this many messages per second.

      Parameters:
      topic -
    • removeDispatchRate

      void removeDispatchRate(String topic) throws PulsarAdminException
      Remove message-dispatch-rate.

      Remove topic message dispatch rate

      Parameters:
      topic -
      Throws:
      PulsarAdminException - unexpected error
    • removeDispatchRateAsync

      CompletableFuture<Void> removeDispatchRateAsync(String topic) throws PulsarAdminException
      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

      CompletableFuture<Void> setSubscriptionDispatchRateAsync(String topic, DispatchRate dispatchRate)
      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

      DispatchRate getSubscriptionDispatchRate(String topic, boolean applied) throws PulsarAdminException
      Get applied subscription-message-dispatch-rate.

      Subscriptions of this topic can dispatch this many messages per second.

      Parameters:
      topic -
      Throws:
      PulsarAdminException - Unexpected error
    • getSubscriptionDispatchRateAsync

      CompletableFuture<DispatchRate> getSubscriptionDispatchRateAsync(String topic, boolean applied)
      Get applied subscription-message-dispatch-rate asynchronously.

      Subscriptions in this topic can dispatch this many messages per second.

      Parameters:
      topic -
    • getSubscriptionDispatchRate

      DispatchRate getSubscriptionDispatchRate(String topic) throws PulsarAdminException
      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

      CompletableFuture<DispatchRate> getSubscriptionDispatchRateAsync(String topic)
      Get subscription-message-dispatch-rate asynchronously.

      Subscriptions of this topic can dispatch this many messages per second.

      Parameters:
      topic -
    • removeSubscriptionDispatchRate

      void removeSubscriptionDispatchRate(String topic) throws PulsarAdminException
      Remove subscription-message-dispatch-rate for a topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removeSubscriptionDispatchRateAsync

      CompletableFuture<Void> removeSubscriptionDispatchRateAsync(String topic)
      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)
    • 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)
    • 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)
    • removeSubscriptionDispatchRate

      void removeSubscriptionDispatchRate(String topic, String subscriptionName) throws PulsarAdminException
      Remove subscription level dispatch rate limiter setting for a specific subscription.
      Throws:
      PulsarAdminException
    • removeSubscriptionDispatchRateAsync

      CompletableFuture<Void> removeSubscriptionDispatchRateAsync(String topic, String subscriptionName)
    • setReplicatorDispatchRate

      void setReplicatorDispatchRate(String topic, DispatchRate dispatchRate) throws PulsarAdminException
      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

      CompletableFuture<Void> setReplicatorDispatchRateAsync(String topic, DispatchRate dispatchRate)
      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

      DispatchRate getReplicatorDispatchRate(String topic) throws PulsarAdminException
      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

      CompletableFuture<DispatchRate> getReplicatorDispatchRateAsync(String topic)
      Get replicatorDispatchRate asynchronously.

      Replicator dispatch rate under this topic can dispatch this many messages per second.

      Parameters:
      topic -
    • getReplicatorDispatchRate

      DispatchRate getReplicatorDispatchRate(String topic, boolean applied) throws PulsarAdminException
      Get applied replicatorDispatchRate for the topic.
      Parameters:
      topic -
      applied -
      Returns:
      Throws:
      PulsarAdminException
    • getReplicatorDispatchRateAsync

      CompletableFuture<DispatchRate> getReplicatorDispatchRateAsync(String topic, boolean applied)
      Get applied replicatorDispatchRate asynchronously.
      Parameters:
      topic -
      applied -
      Returns:
    • removeReplicatorDispatchRate

      void removeReplicatorDispatchRate(String topic) throws PulsarAdminException
      Remove replicatorDispatchRate for a topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removeReplicatorDispatchRateAsync

      CompletableFuture<Void> removeReplicatorDispatchRateAsync(String topic)
      Remove replicatorDispatchRate for a topic asynchronously.
      Parameters:
      topic - Topic name
    • getCompactionThreshold

      Long getCompactionThreshold(String topic) throws PulsarAdminException
      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 permission
      PulsarAdminException.NotFoundException - Namespace does not exist
      PulsarAdminException - Unexpected error
    • getCompactionThresholdAsync

      CompletableFuture<Long> getCompactionThresholdAsync(String topic)
      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

      Long getCompactionThreshold(String topic, boolean applied) throws PulsarAdminException
      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 permission
      PulsarAdminException.NotFoundException - Namespace does not exist
      PulsarAdminException - Unexpected error
    • getCompactionThresholdAsync

      CompletableFuture<Long> getCompactionThresholdAsync(String topic, boolean applied)
      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

      void setCompactionThreshold(String topic, long compactionThreshold) throws PulsarAdminException
      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 name
      compactionThreshold - maximum number of backlog bytes before compaction is triggered
      Throws:
      NotAuthorizedException - Don't have admin permission
      PulsarAdminException.NotFoundException - Namespace does not exist
      PulsarAdminException - Unexpected error
    • setCompactionThresholdAsync

      CompletableFuture<Void> setCompactionThresholdAsync(String topic, long compactionThreshold)
      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 name
      compactionThreshold - maximum number of backlog bytes before compaction is triggered
    • removeCompactionThreshold

      void removeCompactionThreshold(String topic) throws PulsarAdminException
      Remove the compactionThreshold for a topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removeCompactionThresholdAsync

      CompletableFuture<Void> removeCompactionThresholdAsync(String topic)
      Remove the compactionThreshold for a topic asynchronously.
      Parameters:
      topic - Topic name
    • setPublishRate

      void setPublishRate(String topic, PublishRate publishMsgRate) throws PulsarAdminException
      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

      CompletableFuture<Void> setPublishRateAsync(String topic, PublishRate publishMsgRate)
      Set message-publish-rate (topics can publish this many messages per second) asynchronously.
      Parameters:
      topic -
      publishMsgRate - number of messages per second
    • getPublishRate

      PublishRate getPublishRate(String topic) throws PulsarAdminException
      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

      CompletableFuture<PublishRate> getPublishRateAsync(String topic)
      Get message-publish-rate (topics can publish this many messages per second) asynchronously.
      Parameters:
      topic -
      Returns:
      number of messages per second
    • removePublishRate

      void removePublishRate(String topic) throws PulsarAdminException
      Remove message-publish-rate.

      Remove topic message publish rate

      Parameters:
      topic -
      Throws:
      PulsarAdminException - unexpected error
    • removePublishRateAsync

      CompletableFuture<Void> removePublishRateAsync(String topic) throws PulsarAdminException
      Remove message-publish-rate asynchronously.

      Remove topic message publish rate

      Parameters:
      topic -
      Throws:
      PulsarAdminException - unexpected error
    • getMaxConsumersPerSubscription

      Integer getMaxConsumersPerSubscription(String topic) throws PulsarAdminException
      Get the maxConsumersPerSubscription for a topic.

      Response example:

       0
       
      Parameters:
      topic - Topic name
      Throws:
      NotAuthorizedException - Don't have admin permission
      PulsarAdminException.NotFoundException - Namespace does not exist
      PulsarAdminException - Unexpected error
    • getMaxConsumersPerSubscriptionAsync

      CompletableFuture<Integer> getMaxConsumersPerSubscriptionAsync(String topic)
      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 name
      maxConsumersPerSubscription - maxConsumersPerSubscription value for a namespace
      Throws:
      NotAuthorizedException - Don't have admin permission
      PulsarAdminException.NotFoundException - Namespace does not exist
      PulsarAdminException - Unexpected error
    • setMaxConsumersPerSubscriptionAsync

      CompletableFuture<Void> setMaxConsumersPerSubscriptionAsync(String topic, int maxConsumersPerSubscription)
      Set maxConsumersPerSubscription for a topic asynchronously.

      Request example:

       10
       
      Parameters:
      topic - Topic name
      maxConsumersPerSubscription - maxConsumersPerSubscription value for a namespace
    • removeMaxConsumersPerSubscription

      void removeMaxConsumersPerSubscription(String topic) throws PulsarAdminException
      Remove the maxConsumersPerSubscription for a topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxConsumersPerSubscriptionAsync

      CompletableFuture<Void> removeMaxConsumersPerSubscriptionAsync(String topic)
      Remove the maxConsumersPerSubscription for a topic asynchronously.
      Parameters:
      topic - Topic name
    • getMaxProducers

      Integer getMaxProducers(String topic) throws PulsarAdminException
      Get the max number of producer for specified topic.
      Parameters:
      topic - Topic name
      Returns:
      Configuration of bookkeeper persistence policies
      Throws:
      PulsarAdminException - Unexpected error
    • getMaxProducersAsync

      CompletableFuture<Integer> getMaxProducersAsync(String topic)
      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

      Integer getMaxProducers(String topic, boolean applied) throws PulsarAdminException
      Get the max number of producer applied for specified topic.
      Parameters:
      topic -
      applied -
      Returns:
      Throws:
      PulsarAdminException
    • getMaxProducersAsync

      CompletableFuture<Integer> getMaxProducersAsync(String topic, boolean applied)
      Get the max number of producer applied for specified topic asynchronously.
      Parameters:
      topic -
      applied -
      Returns:
    • setMaxProducers

      void setMaxProducers(String topic, int maxProducers) throws PulsarAdminException
      Set the max number of producer for specified topic.
      Parameters:
      topic - Topic name
      maxProducers - Max number of producer
      Throws:
      PulsarAdminException - Unexpected error
    • setMaxProducersAsync

      CompletableFuture<Void> setMaxProducersAsync(String topic, int maxProducers)
      Set the max number of producer for specified topic asynchronously.
      Parameters:
      topic - Topic name
      maxProducers - Max number of producer
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxProducers

      void removeMaxProducers(String topic) throws PulsarAdminException
      Remove the max number of producer for specified topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxProducersAsync

      CompletableFuture<Void> removeMaxProducersAsync(String topic)
      Remove the max number of producer for specified topic asynchronously.
      Parameters:
      topic - Topic name
    • getMaxSubscriptionsPerTopic

      Integer getMaxSubscriptionsPerTopic(String topic) throws PulsarAdminException
      Get the max number of subscriptions for specified topic.
      Parameters:
      topic - Topic name
      Returns:
      Configuration of bookkeeper persistence policies
      Throws:
      PulsarAdminException - Unexpected error
    • getMaxSubscriptionsPerTopicAsync

      CompletableFuture<Integer> getMaxSubscriptionsPerTopicAsync(String topic)
      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 name
      maxSubscriptionsPerTopic - 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 name
      maxSubscriptionsPerTopic - Max number of subscriptions
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxSubscriptionsPerTopic

      void removeMaxSubscriptionsPerTopic(String topic) throws PulsarAdminException
      Remove the max number of subscriptions for specified topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxSubscriptionsPerTopicAsync

      CompletableFuture<Void> removeMaxSubscriptionsPerTopicAsync(String topic)
      Remove the max number of subscriptions for specified topic asynchronously.
      Parameters:
      topic - Topic name
    • getMaxMessageSize

      Integer getMaxMessageSize(String topic) throws PulsarAdminException
      Get the max message size for specified topic.
      Parameters:
      topic - Topic name
      Returns:
      Configuration of bookkeeper persistence policies
      Throws:
      PulsarAdminException - Unexpected error
    • getMaxMessageSizeAsync

      CompletableFuture<Integer> getMaxMessageSizeAsync(String topic)
      Get the max message size for specified topic asynchronously.
      Parameters:
      topic - Topic name
      Returns:
      Configuration of bookkeeper persistence policies
      Throws:
      PulsarAdminException - Unexpected error
    • setMaxMessageSize

      void setMaxMessageSize(String topic, int maxMessageSize) throws PulsarAdminException
      Set the max message size for specified topic.
      Parameters:
      topic - Topic name
      maxMessageSize - Max message size of producer
      Throws:
      PulsarAdminException - Unexpected error
    • setMaxMessageSizeAsync

      CompletableFuture<Void> setMaxMessageSizeAsync(String topic, int maxMessageSize)
      Set the max message size for specified topic asynchronously.0 disables.
      Parameters:
      topic - Topic name
      maxMessageSize - Max message size of topic
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxMessageSize

      void removeMaxMessageSize(String topic) throws PulsarAdminException
      Remove the max message size for specified topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxMessageSizeAsync

      CompletableFuture<Void> removeMaxMessageSizeAsync(String topic)
      Remove the max message size for specified topic asynchronously.
      Parameters:
      topic - Topic name
    • getMaxConsumers

      Integer getMaxConsumers(String topic) throws PulsarAdminException
      Get the max number of consumer for specified topic.
      Parameters:
      topic - Topic name
      Returns:
      Configuration of bookkeeper persistence policies
      Throws:
      PulsarAdminException - Unexpected error
    • getMaxConsumersAsync

      CompletableFuture<Integer> getMaxConsumersAsync(String topic)
      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

      Integer getMaxConsumers(String topic, boolean applied) throws PulsarAdminException
      Get the max number of consumer applied for specified topic.
      Parameters:
      topic -
      applied -
      Returns:
      Throws:
      PulsarAdminException
    • getMaxConsumersAsync

      CompletableFuture<Integer> getMaxConsumersAsync(String topic, boolean applied)
      Get the max number of consumer applied for specified topic asynchronously.
      Parameters:
      topic -
      applied -
      Returns:
    • setMaxConsumers

      void setMaxConsumers(String topic, int maxConsumers) throws PulsarAdminException
      Set the max number of consumer for specified topic.
      Parameters:
      topic - Topic name
      maxConsumers - Max number of consumer
      Throws:
      PulsarAdminException - Unexpected error
    • setMaxConsumersAsync

      CompletableFuture<Void> setMaxConsumersAsync(String topic, int maxConsumers)
      Set the max number of consumer for specified topic asynchronously.
      Parameters:
      topic - Topic name
      maxConsumers - Max number of consumer
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxConsumers

      void removeMaxConsumers(String topic) throws PulsarAdminException
      Remove the max number of consumer for specified topic.
      Parameters:
      topic - Topic name
      Throws:
      PulsarAdminException - Unexpected error
    • removeMaxConsumersAsync

      CompletableFuture<Void> removeMaxConsumersAsync(String topic)
      Remove the max number of consumer for specified topic asynchronously.
      Parameters:
      topic - Topic name
    • getDeduplicationSnapshotInterval

      Integer getDeduplicationSnapshotInterval(String topic) throws PulsarAdminException
      Get the deduplication snapshot interval for specified topic.
      Parameters:
      topic -
      Returns:
      Throws:
      PulsarAdminException
    • getDeduplicationSnapshotIntervalAsync

      CompletableFuture<Integer> getDeduplicationSnapshotIntervalAsync(String topic)
      Get the deduplication snapshot interval for specified topic asynchronously.
      Parameters:
      topic -
      Returns:
    • setDeduplicationSnapshotInterval

      void setDeduplicationSnapshotInterval(String topic, int interval) throws PulsarAdminException
      Set the deduplication snapshot interval for specified topic.
      Parameters:
      topic -
      interval -
      Throws:
      PulsarAdminException
    • setDeduplicationSnapshotIntervalAsync

      CompletableFuture<Void> setDeduplicationSnapshotIntervalAsync(String topic, int interval)
      Set the deduplication snapshot interval for specified topic asynchronously.
      Parameters:
      topic -
      interval -
      Returns:
    • removeDeduplicationSnapshotInterval

      void removeDeduplicationSnapshotInterval(String topic) throws PulsarAdminException
      Remove the deduplication snapshot interval for specified topic.
      Parameters:
      topic -
      Throws:
      PulsarAdminException
    • removeDeduplicationSnapshotIntervalAsync

      CompletableFuture<Void> removeDeduplicationSnapshotIntervalAsync(String topic)
      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

      void removeSubscriptionTypesEnabled(String topic) throws PulsarAdminException
      Remove subscription types enabled for a topic.
      Parameters:
      topic -
      Throws:
      PulsarAdminException
    • removeSubscriptionTypesEnabledAsync

      CompletableFuture<Void> removeSubscriptionTypesEnabledAsync(String topic)
      Remove subscription types enabled for a topic asynchronously.
      Parameters:
      topic -
      Returns:
    • setSubscribeRate

      void setSubscribeRate(String topic, SubscribeRate subscribeRate) throws PulsarAdminException
      Set topic-subscribe-rate (topic will limit by subscribeRate).
      Parameters:
      topic -
      subscribeRate - consumer subscribe limit by this subscribeRate
      Throws:
      PulsarAdminException - Unexpected error
    • setSubscribeRateAsync

      CompletableFuture<Void> setSubscribeRateAsync(String topic, SubscribeRate subscribeRate)
      Set topic-subscribe-rate (topics will limit by subscribeRate) asynchronously.
      Parameters:
      topic -
      subscribeRate - consumer subscribe limit by this subscribeRate
    • getSubscribeRate

      SubscribeRate getSubscribeRate(String topic) throws PulsarAdminException
      Get topic-subscribe-rate (topics allow subscribe times per consumer in a period).
      Parameters:
      topic -
      Throws:
      PulsarAdminException - Unexpected error
    • getSubscribeRateAsync

      CompletableFuture<SubscribeRate> getSubscribeRateAsync(String topic)
      Get topic-subscribe-rate asynchronously.

      Topic allow subscribe times per consumer in a period.

      Parameters:
      topic -
    • getSubscribeRate

      SubscribeRate getSubscribeRate(String topic, boolean applied) throws PulsarAdminException
      Get applied topic-subscribe-rate (topics allow subscribe times per consumer in a period).
      Parameters:
      topic -
      Throws:
      PulsarAdminException - Unexpected error
    • getSubscribeRateAsync

      CompletableFuture<SubscribeRate> getSubscribeRateAsync(String topic, boolean applied)
      Get applied topic-subscribe-rate asynchronously.
      Parameters:
      topic -
    • removeSubscribeRate

      void removeSubscribeRate(String topic) throws PulsarAdminException
      Remove topic-subscribe-rate.

      Remove topic subscribe rate

      Parameters:
      topic -
      Throws:
      PulsarAdminException - unexpected error
    • removeSubscribeRateAsync

      CompletableFuture<Void> removeSubscribeRateAsync(String topic) throws PulsarAdminException
      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 interested
      applied - 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 interested
      applied - 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 set
      strategy - 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 set
      strategy - The schema compatibility strategy
    • removeSchemaCompatibilityStrategy

      void removeSchemaCompatibilityStrategy(String topic) throws PulsarAdminException
      Remove schema compatibility strategy on a topic.
      Parameters:
      topic - The topic in whose policy should be removed
      Throws:
      PulsarAdminException
    • removeSchemaCompatibilityStrategyAsync

      CompletableFuture<Void> removeSchemaCompatibilityStrategyAsync(String topic)
      Remove schema compatibility strategy on a topic asynchronously.
      Parameters:
      topic - The topic in whose policy should be removed