in pulsar-client-tools/src/main/java/org/apache/pulsar/admin/cli/CmdTopics.java [98:278]
public CmdTopics(Supplier<PulsarAdmin> admin) {
super("topics", admin);
partitionedLookup = new PartitionedLookup();
deleteCmd = new DeleteCmd();
addCommand("list", new ListCmd());
addCommand("list-partitioned-topics", new PartitionedTopicListCmd());
addCommand("permissions", new Permissions());
addCommand("grant-permission", new GrantPermissions());
addCommand("revoke-permission", new RevokePermissions());
addCommand("lookup", new Lookup());
addCommand("partitioned-lookup", partitionedLookup);
addCommand("bundle-range", new GetBundleRange());
addCommand("delete", deleteCmd);
addCommand("truncate", new TruncateCmd());
addCommand("unload", new UnloadCmd());
addCommand("subscriptions", new ListSubscriptions());
addCommand("unsubscribe", new DeleteSubscription());
addCommand("create-subscription", new CreateSubscription());
addCommand("update-subscription-properties", new UpdateSubscriptionProperties());
addCommand("get-subscription-properties", new GetSubscriptionProperties());
addCommand("stats", new GetStats());
addCommand("stats-internal", new GetInternalStats());
addCommand("info-internal", new GetInternalInfo());
addCommand("partitioned-stats", new GetPartitionedStats());
addCommand("partitioned-stats-internal", new GetPartitionedStatsInternal());
addCommand("skip", new Skip());
addCommand("clear-backlog", new ClearBacklog());
addCommand("expire-messages", new ExpireMessages());
addCommand("expire-messages-all-subscriptions", new ExpireMessagesForAllSubscriptions());
addCommand("create-partitioned-topic", new CreatePartitionedCmd());
addCommand("create-missed-partitions", new CreateMissedPartitionsCmd());
addCommand("create", new CreateNonPartitionedCmd());
addCommand("update-partitioned-topic", new UpdatePartitionedCmd());
addCommand("get-partitioned-topic-metadata", new GetPartitionedTopicMetadataCmd());
addCommand("get-properties", new GetPropertiesCmd());
addCommand("update-properties", new UpdateProperties());
addCommand("remove-properties", new RemoveProperties());
addCommand("delete-partitioned-topic", new DeletePartitionedCmd());
addCommand("peek-messages", new PeekMessages());
addCommand("examine-messages", new ExamineMessages());
addCommand("get-message-by-id", new GetMessageById());
addCommand("get-message-id", new GetMessageId());
addCommand("reset-cursor", new ResetCursor());
addCommand("terminate", new Terminate());
addCommand("partitioned-terminate", new PartitionedTerminate());
addCommand("compact", new Compact());
addCommand("compaction-status", new CompactionStatusCmd());
addCommand("offload", new Offload());
addCommand("offload-status", new OffloadStatusCmd());
addCommand("last-message-id", new GetLastMessageId());
addCommand("get-backlog-quotas", new GetBacklogQuotaMap());
addCommand("set-backlog-quota", new SetBacklogQuota());
addCommand("remove-backlog-quota", new RemoveBacklogQuota());
addCommand("get-message-ttl", new GetMessageTTL());
addCommand("set-message-ttl", new SetMessageTTL());
addCommand("remove-message-ttl", new RemoveMessageTTL());
addCommand("get-retention", new GetRetention());
addCommand("set-retention", new SetRetention());
addCommand("remove-retention", new RemoveRetention());
//deprecated commands
addCommand("enable-deduplication", new EnableDeduplication());
addCommand("disable-deduplication", new DisableDeduplication());
addCommand("get-deduplication-enabled", new GetDeduplicationStatus());
addCommand("set-deduplication", new SetDeduplicationStatus());
addCommand("get-deduplication", new GetDeduplicationStatus());
addCommand("remove-deduplication", new RemoveDeduplicationStatus());
addCommand("get-deduplication-snapshot-interval", new GetDeduplicationSnapshotInterval());
addCommand("set-deduplication-snapshot-interval", new SetDeduplicationSnapshotInterval());
addCommand("remove-deduplication-snapshot-interval", new RemoveDeduplicationSnapshotInterval());
addCommand("get-delayed-delivery", new GetDelayedDelivery());
addCommand("set-delayed-delivery", new SetDelayedDelivery());
addCommand("remove-delayed-delivery", new RemoveDelayedDelivery());
addCommand("get-persistence", new GetPersistence());
addCommand("set-persistence", new SetPersistence());
addCommand("remove-persistence", new RemovePersistence());
addCommand("get-offload-policies", new GetOffloadPolicies());
addCommand("set-offload-policies", new SetOffloadPolicies());
addCommand("remove-offload-policies", new RemoveOffloadPolicies());
addCommand("get-dispatch-rate", new GetDispatchRate());
addCommand("set-dispatch-rate", new SetDispatchRate());
addCommand("remove-dispatch-rate", new RemoveDispatchRate());
addCommand("get-subscription-dispatch-rate", new GetSubscriptionDispatchRate());
addCommand("set-subscription-dispatch-rate", new SetSubscriptionDispatchRate());
addCommand("remove-subscription-dispatch-rate", new RemoveSubscriptionDispatchRate());
addCommand("get-replicator-dispatch-rate", new GetReplicatorDispatchRate());
addCommand("set-replicator-dispatch-rate", new SetReplicatorDispatchRate());
addCommand("remove-replicator-dispatch-rate", new RemoveReplicatorDispatchRate());
addCommand("get-compaction-threshold", new GetCompactionThreshold());
addCommand("set-compaction-threshold", new SetCompactionThreshold());
addCommand("remove-compaction-threshold", new RemoveCompactionThreshold());
//deprecated commands
addCommand("get-max-unacked-messages-on-consumer", new GetMaxUnackedMessagesOnConsumer());
addCommand("set-max-unacked-messages-on-consumer", new SetMaxUnackedMessagesOnConsumer());
addCommand("remove-max-unacked-messages-on-consumer", new RemoveMaxUnackedMessagesOnConsumer());
addCommand("get-max-unacked-messages-on-subscription", new GetMaxUnackedMessagesOnSubscription());
addCommand("set-max-unacked-messages-on-subscription", new SetMaxUnackedMessagesOnSubscription());
addCommand("remove-max-unacked-messages-on-subscription",
new RemoveMaxUnackedMessagesOnSubscription());
addCommand("get-max-unacked-messages-per-consumer", new GetMaxUnackedMessagesOnConsumer());
addCommand("set-max-unacked-messages-per-consumer", new SetMaxUnackedMessagesOnConsumer());
addCommand("remove-max-unacked-messages-per-consumer", new RemoveMaxUnackedMessagesOnConsumer());
addCommand("get-max-unacked-messages-per-subscription", new GetMaxUnackedMessagesOnSubscription());
addCommand("set-max-unacked-messages-per-subscription", new SetMaxUnackedMessagesOnSubscription());
addCommand("remove-max-unacked-messages-per-subscription",
new RemoveMaxUnackedMessagesOnSubscription());
addCommand("get-publish-rate", new GetPublishRate());
addCommand("set-publish-rate", new SetPublishRate());
addCommand("remove-publish-rate", new RemovePublishRate());
addCommand("set-subscription-types-enabled", new SetSubscriptionTypesEnabled());
addCommand("get-subscription-types-enabled", new GetSubscriptionTypesEnabled());
addCommand("remove-subscription-types-enabled", new RemoveSubscriptionTypesEnabled());
//deprecated commands
addCommand("get-maxProducers", new GetMaxProducers());
addCommand("set-maxProducers", new SetMaxProducers());
addCommand("remove-maxProducers", new RemoveMaxProducers());
addCommand("get-max-producers", new GetMaxProducers());
addCommand("set-max-producers", new SetMaxProducers());
addCommand("remove-max-producers", new RemoveMaxProducers());
addCommand("get-max-subscriptions", new GetMaxSubscriptionsPerTopic());
addCommand("set-max-subscriptions", new SetMaxSubscriptionsPerTopic());
addCommand("remove-max-subscriptions", new RemoveMaxSubscriptionsPerTopic());
addCommand("get-max-message-size", new GetMaxMessageSize());
addCommand("set-max-message-size", new SetMaxMessageSize());
addCommand("remove-max-message-size", new RemoveMaxMessageSize());
addCommand("get-max-consumers-per-subscription", new GetMaxConsumersPerSubscription());
addCommand("set-max-consumers-per-subscription", new SetMaxConsumersPerSubscription());
addCommand("remove-max-consumers-per-subscription", new RemoveMaxConsumersPerSubscription());
addCommand("get-inactive-topic-policies", new GetInactiveTopicPolicies());
addCommand("set-inactive-topic-policies", new SetInactiveTopicPolicies());
addCommand("remove-inactive-topic-policies", new RemoveInactiveTopicPolicies());
addCommand("get-max-consumers", new GetMaxConsumers());
addCommand("set-max-consumers", new SetMaxConsumers());
addCommand("remove-max-consumers", new RemoveMaxConsumers());
addCommand("get-subscribe-rate", new GetSubscribeRate());
addCommand("set-subscribe-rate", new SetSubscribeRate());
addCommand("remove-subscribe-rate", new RemoveSubscribeRate());
addCommand("set-replicated-subscription-status", new SetReplicatedSubscriptionStatus());
addCommand("get-replicated-subscription-status", new GetReplicatedSubscriptionStatus());
addCommand("get-backlog-size", new GetBacklogSizeByMessageId());
addCommand("analyze-backlog", new AnalyzeBacklog());
addCommand("get-replication-clusters", new GetReplicationClusters());
addCommand("set-replication-clusters", new SetReplicationClusters());
addCommand("remove-replication-clusters", new RemoveReplicationClusters());
addCommand("get-shadow-topics", new GetShadowTopics());
addCommand("set-shadow-topics", new SetShadowTopics());
addCommand("remove-shadow-topics", new RemoveShadowTopics());
addCommand("create-shadow-topic", new CreateShadowTopic());
addCommand("get-shadow-source", new GetShadowSource());
addCommand("get-schema-validation-enforce", new GetSchemaValidationEnforced());
addCommand("set-schema-validation-enforce", new SetSchemaValidationEnforced());
addCommand("trim-topic", new TrimTopic());
}