@Path(value="/persistent") @Produces(value="application/json") public class PersistentTopics extends PersistentTopicsBase
namespaceName, PARTITIONED_TOPIC_PATH_ZNODE, topicName
httpRequest, NOT_IMPLEMENTED, servletContext, uri
Constructor and Description |
---|
PersistentTopics() |
Modifier and Type | Method and Description |
---|---|
void |
compact(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
LongRunningProcessStatus |
compactionStatus(String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
void |
createMissedPartitions(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
createNonPartitionedTopic(String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
void |
createPartitionedTopic(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
int numPartitions) |
void |
createSubscription(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String topic,
String encodedSubName,
boolean authoritative,
MessageIdImpl messageId,
boolean replicated) |
void |
deleteDeduplicationSnapshotInterval(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
deleteDelayedDeliveryPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
deleteInactiveTopicPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
deleteMaxUnackedMessagesOnConsumer(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
deleteMaxUnackedMessagesOnSubscription(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
deletePartitionedTopic(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
boolean force,
boolean authoritative,
boolean deleteSchema) |
void |
deleteSubscription(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
String encodedSubName,
boolean force,
boolean authoritative) |
void |
deleteTopic(String tenant,
String namespace,
String encodedTopic,
boolean force,
boolean authoritative,
boolean deleteSchema) |
javax.ws.rs.core.Response |
examineMessage(String tenant,
String namespace,
String encodedTopic,
String initialPosition,
long messagePosition,
boolean authoritative) |
void |
expireMessagesForAllSubscriptions(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
int expireTimeInSeconds,
boolean authoritative) |
void |
expireTopicMessages(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
String encodedSubName,
boolean authoritative,
ResetCursorData resetCursorData) |
void |
expireTopicMessages(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
String encodedSubName,
int expireTimeInSeconds,
boolean authoritative) |
org.apache.pulsar.common.policies.data.PersistentOfflineTopicStats |
getBacklog(String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
Map<org.apache.pulsar.common.policies.data.BacklogQuota.BacklogQuotaType,org.apache.pulsar.common.policies.data.BacklogQuota> |
getBacklogQuotaMap(String tenant,
String namespace,
String encodedTopic) |
void |
getCompactionThreshold(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getDeduplicationEnabled(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getDeduplicationSnapshotInterval(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getDelayedDeliveryPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getDispatchRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getInactiveTopicPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
org.apache.pulsar.common.policies.data.PersistentTopicInternalStats |
getInternalStats(String tenant,
String namespace,
String encodedTopic,
boolean authoritative,
boolean metadata) |
void |
getLastMessageId(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
void |
getList(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace) |
void |
getManagedLedgerInfo(String tenant,
String namespace,
boolean authoritative,
String encodedTopic,
javax.ws.rs.container.AsyncResponse asyncResponse) |
void |
getMaxConsumers(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getMaxConsumersPerSubscription(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getMaxMessageSize(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getMaxProducers(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getMaxSubscriptionsPerTopic(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getMaxUnackedMessagesOnConsumer(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getMaxUnackedMessagesOnSubscription(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getMessageById(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
long ledgerId,
long entryId,
boolean authoritative) |
int |
getMessageTTL(String tenant,
String namespace,
String encodedTopic) |
void |
getOffloadPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
org.apache.pulsar.common.partition.PartitionedTopicMetadata |
getPartitionedMetadata(String tenant,
String namespace,
String encodedTopic,
boolean authoritative,
boolean checkAllowAutoCreation) |
void |
getPartitionedStats(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
boolean perPartition,
boolean authoritative,
boolean getPreciseBacklog,
boolean subscriptionBacklogSize) |
void |
getPartitionedStatsInternal(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
List<String> |
getPartitionedTopicList(String tenant,
String namespace) |
Map<String,Set<org.apache.pulsar.common.policies.data.AuthAction>> |
getPermissionsOnTopic(String tenant,
String namespace,
String encodedTopic) |
void |
getPersistence(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getPublishRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getRetention(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
org.apache.pulsar.common.policies.data.TopicStats |
getStats(String tenant,
String namespace,
String encodedTopic,
boolean authoritative,
boolean getPreciseBacklog,
boolean subscriptionBacklogSize) |
void |
getSubscribeRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getSubscriptionDispatchRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
getSubscriptions(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
void |
grantPermissionsOnTopic(String tenant,
String namespace,
String encodedTopic,
String role,
Set<org.apache.pulsar.common.policies.data.AuthAction> actions) |
OffloadProcessStatus |
offloadStatus(String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
javax.ws.rs.core.Response |
peekNthMessage(String tenant,
String namespace,
String encodedTopic,
String encodedSubName,
int messagePosition,
boolean authoritative) |
void |
removeBacklogQuota(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.BacklogQuota.BacklogQuotaType backlogQuotaType) |
void |
removeCompactionThreshold(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeDeduplicationEnabled(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeDispatchRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeMaxConsumers(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeMaxConsumersPerSubscription(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeMaxMessageSize(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeMaxProducers(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeMaxSubscriptionsPerTopic(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeMessageTTL(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeOffloadPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removePersistence(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removePublishRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeRetention(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeSubscribeRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
removeSubscriptionDispatchRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic) |
void |
resetCursor(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
String encodedSubName,
long timestamp,
boolean authoritative) |
void |
resetCursorOnPosition(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
String encodedSubName,
boolean authoritative,
ResetCursorData resetCursorData) |
void |
revokePermissionsOnTopic(String tenant,
String namespace,
String encodedTopic,
String role) |
void |
setBacklogQuota(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.BacklogQuota.BacklogQuotaType backlogQuotaType,
org.apache.pulsar.common.policies.data.BacklogQuota backlogQuota) |
void |
setCompactionThreshold(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
long compactionThreshold) |
void |
setDeduplicationEnabled(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
Boolean enabled) |
void |
setDeduplicationSnapshotInterval(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
Integer interval) |
void |
setDelayedDeliveryPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.DelayedDeliveryPolicies deliveryPolicies) |
void |
setDispatchRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.DispatchRate dispatchRate) |
void |
setInactiveTopicPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.InactiveTopicPolicies inactiveTopicPolicies) |
void |
setMaxConsumers(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
int maxConsumers) |
void |
setMaxConsumersPerSubscription(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
int maxConsumersPerSubscription) |
void |
setMaxMessageSize(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
int maxMessageSize) |
void |
setMaxProducers(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
int maxProducers) |
void |
setMaxSubscriptionsPerTopic(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
int maxSubscriptionsPerTopic) |
void |
setMaxUnackedMessagesOnConsumer(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
Integer maxUnackedNum) |
void |
setMaxUnackedMessagesOnSubscription(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
Integer maxUnackedNum) |
void |
setMessageTTL(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
int messageTTL) |
void |
setOffloadPolicies(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.OffloadPolicies offloadPolicies) |
void |
setPersistence(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.PersistencePolicies persistencePolicies) |
void |
setPublishRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.PublishRate publishRate) |
void |
setRetention(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.RetentionPolicies retention) |
void |
setSubscribeRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.SubscribeRate subscribeRate) |
void |
setSubscriptionDispatchRate(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
org.apache.pulsar.common.policies.data.DispatchRate dispatchRate) |
void |
skipAllMessages(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
String encodedSubName,
boolean authoritative) |
void |
skipMessages(String tenant,
String namespace,
String encodedTopic,
String encodedSubName,
int numMessages,
boolean authoritative) |
org.apache.pulsar.client.api.MessageId |
terminate(String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
void |
terminatePartitionedTopic(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
void |
triggerOffload(String tenant,
String namespace,
String encodedTopic,
boolean authoritative,
MessageIdImpl messageId) |
void |
unloadTopic(javax.ws.rs.container.AsyncResponse asyncResponse,
String tenant,
String namespace,
String encodedTopic,
boolean authoritative) |
void |
updatePartitionedTopic(String tenant,
String namespace,
String encodedTopic,
boolean updateLocalTopicOnly,
boolean authoritative,
int numPartitions)
It updates number of partitions of an existing non-global partitioned topic.
|
getPartitionedTopicMetadata, internalCompactionStatus, internalCreateMissedPartitions, internalCreateNonPartitionedTopic, internalCreateSubscription, internalDeletePartitionedTopic, internalDeleteSubscription, internalDeleteSubscription, internalDeleteSubscriptionForcefully, internalDeleteTopic, internalDeleteTopic, internalDeleteTopicForcefully, internalExamineMessage, internalExpireMessagesByPosition, internalExpireMessagesByTimestamp, internalExpireMessagesForAllSubscriptions, internalGetBacklog, internalGetCompactionThreshold, internalGetDispatchRate, internalGetInternalStats, internalGetLastMessageId, internalGetList, internalGetManagedLedgerInfo, internalGetManagedLedgerInfoForNonPartitionedTopic, internalGetMaxConsumers, internalGetMaxConsumersPerSubscription, internalGetMaxMessageSize, internalGetMaxProducers, internalGetMaxSubscriptionsPerTopic, internalGetMessageById, internalGetPartitionedMetadata, internalGetPartitionedStats, internalGetPartitionedStatsInternal, internalGetPartitionedTopicList, internalGetPermissionsOnTopic, internalGetPersistence, internalGetPublishRate, internalGetRetention, internalGetStats, internalGetSubscribeRate, internalGetSubscriptionDispatchRate, internalGetSubscriptions, internalGrantPermissionsOnTopic, internalOffloadStatus, internalPeekNthMessage, internalRemoveBacklogQuota, internalRemoveCompactionThreshold, internalRemoveDispatchRate, internalRemoveMaxConsumers, internalRemoveMaxConsumersPerSubscription, internalRemoveMaxProducers, internalRemovePersistence, internalRemovePublishRate, internalRemoveRetention, internalRemoveSubscribeRate, internalRemoveSubscriptionDispatchRate, internalResetCursor, internalResetCursorOnPosition, internalRevokePermissionsOnTopic, internalSetBacklogQuota, internalSetCompactionThreshold, internalSetDeduplicationEnabled, internalSetDeduplicationSnapshotInterval, internalSetDelayedDeliveryPolicies, internalSetDispatchRate, internalSetInactiveTopicPolicies, internalSetMaxConsumers, internalSetMaxConsumersPerSubscription, internalSetMaxMessageSize, internalSetMaxProducers, internalSetMaxSubscriptionsPerTopic, internalSetMaxUnackedMessagesOnConsumer, internalSetMaxUnackedMessagesOnSubscription, internalSetMessageTTL, internalSetOffloadPolicies, internalSetPersistence, internalSetPublishRate, internalSetRetention, internalSetSubscribeRate, internalSetSubscriptionDispatchRate, internalSkipAllMessages, internalSkipMessages, internalTerminate, internalTerminatePartitionedTopic, internalTriggerCompaction, internalTriggerCompactionNonPartitionedTopic, internalTriggerOffload, internalUnloadTopic, internalUpdatePartitionedTopic, preValidation, unsafeGetPartitionedTopicMetadataAsync, validateAdminAccessForSubscriber, validateAdminAndClientPermission, validateAdminOperationOnTopic, validateReadOperationOnTopic, validateWriteOperationOnTopic
checkArgument, checkBacklogQuota, checkNotNull, checkNotNull, checkTopicExistsAsync, checkTopicLevelPolicyEnable, clusters, clustersCache, clustersListCache, dispatchRate, domain, failureDomainCache, failureDomainListCache, fetchPartitionedTopicMetadata, fetchPartitionedTopicMetadataCheckAllowAutoCreation, getListOfNamespaces, getNamespacePolicies, getNamespacePolicies, getNamespacePoliciesAsync, getNamespaceReplicatedClusters, getPartitionedTopicList, getPartitionedTopicMetadata, getPartitionedTopicMetadataAsync, getTopicPolicies, globalZk, globalZkCache, internalCreatePartitionedTopic, isLeaderBroker, isNamespaceReplicated, jsonMapper, localCacheService, localPoliciesCache, localZk, localZkCache, managedLedgerListCache, mergeNamespaceWithDefaults, namespaceBacklogQuota, namespaceIsolationPoliciesCache, policiesCache, resumeAsyncResponseExceptionally, setServletContext, subscribeRate, subscriptionDispatchRate, tenantsCache, tryCreatePartitionsAsync, validateAdminAccessForTenant, validateBrokerName, validateBundleOwnership, validateClusterExists, validateGlobalNamespaceOwnership, validateNamespaceName, validateNamespaceName, validateNamespaceOwnershipWithBundles, validatePartitionedTopicMetadata, validatePartitionedTopicName, validatePersistencePolicies, validatePoliciesReadOnlyAccess, validateSuperUserAccess, validateTopicExistedAndCheckAllowAutoCreation, validateTopicName, validateTopicName, zkCreate, zkCreateOptimistic, zkCreateOptimisticAsync, zkPathExists, zkSync
checkAuthorization, checkConnect, checkLocalOrGetPeerReplicationCluster, clientAppId, clientAuthData, config, getClusterDataIfDifferentCluster, hasSuperUserAccess, isBundleOwnedByAnyBroker, isClientAuthenticated, isLeaderBroker, isRequestHttps, joinPath, originalPrincipal, path, pulsar, setPulsar, splitPath, validateAdminAccessForTenant, validateBundleOwnership, validateClusterForTenant, validateClusterOwnership, validateGlobalNamespaceOwnership, validateNamespaceBundleOwnership, validateNamespaceBundleRange, validateNamespaceOperation, validateNamespacePolicyOperation, validateTenantOperation, validateTopicOwnership
@GET @Path(value="/{tenant}/{namespace}") public void getList(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace)
@GET @Path(value="/{tenant}/{namespace}/partitioned") public List<String> getPartitionedTopicList(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace)
@GET @Path(value="/{tenant}/{namespace}/{topic}/permissions") public Map<String,Set<org.apache.pulsar.common.policies.data.AuthAction>> getPermissionsOnTopic(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/permissions/{role}") public void grantPermissionsOnTopic(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="role") String role, Set<org.apache.pulsar.common.policies.data.AuthAction> actions)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/permissions/{role}") public void revokePermissionsOnTopic(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="role") String role)
@PUT @Path(value="/{tenant}/{namespace}/{topic}/partitions") public void createPartitionedTopic(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, int numPartitions)
@PUT @Path(value="/{tenant}/{namespace}/{topic}") public void createNonPartitionedTopic(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="/{tenant}/{namespace}/{topic}/offloadPolicies") public void getOffloadPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/offloadPolicies") public void setOffloadPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.OffloadPolicies offloadPolicies)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/offloadPolicies") public void removeOffloadPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/maxUnackedMessagesOnConsumer") public void getMaxUnackedMessagesOnConsumer(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/maxUnackedMessagesOnConsumer") public void setMaxUnackedMessagesOnConsumer(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, Integer maxUnackedNum)
@GET @Path(value="/{tenant}/{namespace}/{topic}/deduplicationSnapshotInterval") public void getDeduplicationSnapshotInterval(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/deduplicationSnapshotInterval") public void setDeduplicationSnapshotInterval(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, Integer interval)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/deduplicationSnapshotInterval") public void deleteDeduplicationSnapshotInterval(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/maxUnackedMessagesOnConsumer") public void deleteMaxUnackedMessagesOnConsumer(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/inactiveTopicPolicies") public void getInactiveTopicPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/inactiveTopicPolicies") public void setInactiveTopicPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.InactiveTopicPolicies inactiveTopicPolicies)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/inactiveTopicPolicies") public void deleteInactiveTopicPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/maxUnackedMessagesOnSubscription") public void getMaxUnackedMessagesOnSubscription(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/maxUnackedMessagesOnSubscription") public void setMaxUnackedMessagesOnSubscription(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, Integer maxUnackedNum)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/maxUnackedMessagesOnSubscription") public void deleteMaxUnackedMessagesOnSubscription(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/delayedDelivery") public void getDelayedDeliveryPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/delayedDelivery") public void setDelayedDeliveryPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.DelayedDeliveryPolicies deliveryPolicies)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/delayedDelivery") public void deleteDelayedDeliveryPolicies(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/partitions") public void updatePartitionedTopic(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="updateLocalTopicOnly") @DefaultValue(value="false") boolean updateLocalTopicOnly, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, int numPartitions)
tenant
- namespace
- encodedTopic
- numPartitions
- @POST @Path(value="/{tenant}/{namespace}/{topic}/createMissedPartitions") public void createMissedPartitions(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/partitions") public org.apache.pulsar.common.partition.PartitionedTopicMetadata getPartitionedMetadata(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, @QueryParam(value="checkAllowAutoCreation") @DefaultValue(value="false") boolean checkAllowAutoCreation)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/partitions") public void deletePartitionedTopic(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="force") @DefaultValue(value="false") boolean force, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, @QueryParam(value="deleteSchema") @DefaultValue(value="false") boolean deleteSchema)
@PUT @Path(value="/{tenant}/{namespace}/{topic}/unload") public void unloadTopic(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}") public void deleteTopic(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="force") @DefaultValue(value="false") boolean force, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, @QueryParam(value="deleteSchema") @DefaultValue(value="false") boolean deleteSchema)
@GET @Path(value="/{tenant}/{namespace}/{topic}/subscriptions") public void getSubscriptions(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="{tenant}/{namespace}/{topic}/stats") public org.apache.pulsar.common.policies.data.TopicStats getStats(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, @QueryParam(value="getPreciseBacklog") @DefaultValue(value="false") boolean getPreciseBacklog, @QueryParam(value="subscriptionBacklogSize") @DefaultValue(value="false") boolean subscriptionBacklogSize)
@GET @Path(value="{tenant}/{namespace}/{topic}/internalStats") public org.apache.pulsar.common.policies.data.PersistentTopicInternalStats getInternalStats(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, @QueryParam(value="metadata") @DefaultValue(value="false") boolean metadata)
@GET @Path(value="{tenant}/{namespace}/{topic}/internal-info") public void getManagedLedgerInfo(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, @PathParam(value="topic") @Encoded String encodedTopic, @Suspended javax.ws.rs.container.AsyncResponse asyncResponse)
@GET @Path(value="{tenant}/{namespace}/{topic}/partitioned-stats") public void getPartitionedStats(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="perPartition") @DefaultValue(value="true") boolean perPartition, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, @QueryParam(value="getPreciseBacklog") @DefaultValue(value="false") boolean getPreciseBacklog, @QueryParam(value="subscriptionBacklogSize") @DefaultValue(value="false") boolean subscriptionBacklogSize)
@GET @Path(value="{tenant}/{namespace}/{topic}/partitioned-internalStats") public void getPartitionedStatsInternal(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subName}") public void deleteSubscription(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="subName") String encodedSubName, @QueryParam(value="force") @DefaultValue(value="false") boolean force, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@POST @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subName}/skip_all") public void skipAllMessages(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="subName") String encodedSubName, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@POST @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subName}/skip/{numMessages}") public void skipMessages(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="subName") String encodedSubName, @PathParam(value="numMessages") int numMessages, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@POST @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subName}/expireMessages/{expireTimeInSeconds}") public void expireTopicMessages(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="subName") String encodedSubName, @PathParam(value="expireTimeInSeconds") int expireTimeInSeconds, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@POST @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subName}/expireMessages") public void expireTopicMessages(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="subName") String encodedSubName, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, ResetCursorData resetCursorData)
@POST @Path(value="/{tenant}/{namespace}/{topic}/all_subscription/expireMessages/{expireTimeInSeconds}") public void expireMessagesForAllSubscriptions(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="expireTimeInSeconds") int expireTimeInSeconds, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@PUT @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subscriptionName}") public void createSubscription(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String topic, @PathParam(value="subscriptionName") String encodedSubName, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, MessageIdImpl messageId, @QueryParam(value="replicated") boolean replicated)
@POST @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subName}/resetcursor/{timestamp}") public void resetCursor(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="subName") String encodedSubName, @PathParam(value="timestamp") long timestamp, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@POST @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subName}/resetcursor") public void resetCursorOnPosition(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="subName") String encodedSubName, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, ResetCursorData resetCursorData)
@GET @Path(value="/{tenant}/{namespace}/{topic}/subscription/{subName}/position/{messagePosition}") public javax.ws.rs.core.Response peekNthMessage(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="subName") String encodedSubName, @PathParam(value="messagePosition") int messagePosition, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="/{tenant}/{namespace}/{topic}/examinemessage") public javax.ws.rs.core.Response examineMessage(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="initialPosition") String initialPosition, @QueryParam(value="messagePosition") long messagePosition, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="/{tenant}/{namespace}/{topic}/ledger/{ledgerId}/entry/{entryId}") public void getMessageById(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @PathParam(value="ledgerId") long ledgerId, @PathParam(value="entryId") long entryId, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="{tenant}/{namespace}/{topic}/backlog") public org.apache.pulsar.common.policies.data.PersistentOfflineTopicStats getBacklog(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="/{tenant}/{namespace}/{topic}/backlogQuotaMap") public Map<org.apache.pulsar.common.policies.data.BacklogQuota.BacklogQuotaType,org.apache.pulsar.common.policies.data.BacklogQuota> getBacklogQuotaMap(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/backlogQuota") public void setBacklogQuota(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="backlogQuotaType") org.apache.pulsar.common.policies.data.BacklogQuota.BacklogQuotaType backlogQuotaType, org.apache.pulsar.common.policies.data.BacklogQuota backlogQuota)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/backlogQuota") public void removeBacklogQuota(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="backlogQuotaType") org.apache.pulsar.common.policies.data.BacklogQuota.BacklogQuotaType backlogQuotaType)
@GET @Path(value="/{tenant}/{namespace}/{topic}/messageTTL") public int getMessageTTL(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/messageTTL") public void setMessageTTL(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="messageTTL") int messageTTL)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/messageTTL") public void removeMessageTTL(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/deduplicationEnabled") public void getDeduplicationEnabled(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/deduplicationEnabled") public void setDeduplicationEnabled(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, Boolean enabled)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/deduplicationEnabled") public void removeDeduplicationEnabled(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/retention") public void getRetention(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/retention") public void setRetention(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.RetentionPolicies retention)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/retention") public void removeRetention(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/persistence") public void getPersistence(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/persistence") public void setPersistence(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.PersistencePolicies persistencePolicies)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/persistence") public void removePersistence(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/maxSubscriptionsPerTopic") public void getMaxSubscriptionsPerTopic(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/maxSubscriptionsPerTopic") public void setMaxSubscriptionsPerTopic(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, int maxSubscriptionsPerTopic)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/maxSubscriptionsPerTopic") public void removeMaxSubscriptionsPerTopic(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/maxProducers") public void getMaxProducers(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/maxProducers") public void setMaxProducers(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, int maxProducers)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/maxProducers") public void removeMaxProducers(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/maxConsumers") public void getMaxConsumers(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/maxConsumers") public void setMaxConsumers(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, int maxConsumers)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/maxConsumers") public void removeMaxConsumers(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/maxMessageSize") public void getMaxMessageSize(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/maxMessageSize") public void setMaxMessageSize(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, int maxMessageSize)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/maxMessageSize") public void removeMaxMessageSize(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/terminate") public org.apache.pulsar.client.api.MessageId terminate(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@POST @Path(value="/{tenant}/{namespace}/{topic}/terminate/partitions") public void terminatePartitionedTopic(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@PUT @Path(value="/{tenant}/{namespace}/{topic}/compaction") public void compact(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="/{tenant}/{namespace}/{topic}/compaction") public LongRunningProcessStatus compactionStatus(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@PUT @Path(value="/{tenant}/{namespace}/{topic}/offload") public void triggerOffload(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative, MessageIdImpl messageId)
@GET @Path(value="/{tenant}/{namespace}/{topic}/offload") public OffloadProcessStatus offloadStatus(@PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="/{tenant}/{namespace}/{topic}/lastMessageId") public void getLastMessageId(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, @QueryParam(value="authoritative") @DefaultValue(value="false") boolean authoritative)
@GET @Path(value="/{tenant}/{namespace}/{topic}/dispatchRate") public void getDispatchRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/dispatchRate") public void setDispatchRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.DispatchRate dispatchRate)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/dispatchRate") public void removeDispatchRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/subscriptionDispatchRate") public void getSubscriptionDispatchRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/subscriptionDispatchRate") public void setSubscriptionDispatchRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.DispatchRate dispatchRate)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/subscriptionDispatchRate") public void removeSubscriptionDispatchRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/compactionThreshold") public void getCompactionThreshold(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/compactionThreshold") public void setCompactionThreshold(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, long compactionThreshold)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/compactionThreshold") public void removeCompactionThreshold(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/maxConsumersPerSubscription") public void getMaxConsumersPerSubscription(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/maxConsumersPerSubscription") public void setMaxConsumersPerSubscription(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, int maxConsumersPerSubscription)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/maxConsumersPerSubscription") public void removeMaxConsumersPerSubscription(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/publishRate") public void getPublishRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/publishRate") public void setPublishRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.PublishRate publishRate)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/publishRate") public void removePublishRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@GET @Path(value="/{tenant}/{namespace}/{topic}/subscribeRate") public void getSubscribeRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
@POST @Path(value="/{tenant}/{namespace}/{topic}/subscribeRate") public void setSubscribeRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic, org.apache.pulsar.common.policies.data.SubscribeRate subscribeRate)
@DELETE @Path(value="/{tenant}/{namespace}/{topic}/subscribeRate") public void removeSubscribeRate(@Suspended javax.ws.rs.container.AsyncResponse asyncResponse, @PathParam(value="tenant") String tenant, @PathParam(value="namespace") String namespace, @PathParam(value="topic") @Encoded String encodedTopic)
Copyright © 2017–2021 Apache Software Foundation. All rights reserved.