Interface Transactions


public interface Transactions
  • Method Details

    • getCoordinatorStatsByIdAsync

      CompletableFuture<TransactionCoordinatorStats> getCoordinatorStatsByIdAsync(int coordinatorId)
      Get transaction metadataStore stats.
      Parameters:
      coordinatorId - the id which get transaction coordinator
      Returns:
      the future of transaction metadata store stats.
    • getCoordinatorStatsById

      TransactionCoordinatorStats getCoordinatorStatsById(int coordinatorId) throws PulsarAdminException
      Get transaction metadataStore stats.
      Parameters:
      coordinatorId - the id which get transaction coordinator
      Returns:
      the transaction metadata store stats.
      Throws:
      PulsarAdminException
    • getCoordinatorStatsAsync

      Get transaction metadataStore stats.
      Returns:
      the map future of transaction metadata store stats.
    • getCoordinatorStats

      Get transaction metadataStore stats.
      Returns:
      the map of transaction metadata store stats.
      Throws:
      PulsarAdminException
    • getTransactionInBufferStatsAsync

      CompletableFuture<TransactionInBufferStats> getTransactionInBufferStatsAsync(org.apache.pulsar.client.api.transaction.TxnID txnID, String topic)
      Get transaction in buffer stats.
      Parameters:
      txnID - the txnId
      topic - the produce topic
      Returns:
      the future stats of transaction in buffer.
    • getTransactionInBufferStats

      TransactionInBufferStats getTransactionInBufferStats(org.apache.pulsar.client.api.transaction.TxnID txnID, String topic) throws PulsarAdminException
      Get transaction in buffer stats.
      Parameters:
      txnID - the txnId
      topic - the produce topic
      Returns:
      the stats of transaction in buffer.
      Throws:
      PulsarAdminException
    • getTransactionInPendingAckStatsAsync

      CompletableFuture<TransactionInPendingAckStats> getTransactionInPendingAckStatsAsync(org.apache.pulsar.client.api.transaction.TxnID txnID, String topic, String subName)
      Get transaction in pending ack stats.
      Parameters:
      txnID - the txnId
      topic - the ack topic
      subName - the subscription name of this transaction ack
      Returns:
      the future stats of transaction in pending ack.
    • getTransactionInPendingAckStats

      TransactionInPendingAckStats getTransactionInPendingAckStats(org.apache.pulsar.client.api.transaction.TxnID txnID, String topic, String subName) throws PulsarAdminException
      Get transaction in pending ack stats.
      Parameters:
      txnID - the txnId
      topic - the ack topic
      subName - the subscription name of this transaction ack
      Returns:
      the stats of transaction in pending ack.
      Throws:
      PulsarAdminException
    • getTransactionMetadataAsync

      CompletableFuture<TransactionMetadata> getTransactionMetadataAsync(org.apache.pulsar.client.api.transaction.TxnID txnID)
      Get transaction metadata.
      Parameters:
      txnID - the ID of this transaction
      Returns:
      the future metadata of this transaction.
    • getTransactionMetadata

      TransactionMetadata getTransactionMetadata(org.apache.pulsar.client.api.transaction.TxnID txnID) throws PulsarAdminException
      Get transaction metadata.
      Parameters:
      txnID - the ID of this transaction
      Returns:
      the metadata of this transaction.
      Throws:
      PulsarAdminException
    • getTransactionBufferStatsAsync

      CompletableFuture<TransactionBufferStats> getTransactionBufferStatsAsync(String topic, boolean lowWaterMarks)
      Get transaction buffer stats.
      Parameters:
      topic - the topic of getting transaction buffer stats
      lowWaterMarks - Whether to get information about lowWaterMarks stored in transaction pending ack.
      Returns:
      the future stats of transaction buffer in topic.
    • getTransactionBufferStatsAsync

      default CompletableFuture<TransactionBufferStats> getTransactionBufferStatsAsync(String topic)
      Get transaction buffer stats.
      Parameters:
      topic - the topic of getting transaction buffer stats
      Returns:
      the future stats of transaction buffer in topic.
    • getTransactionBufferStats

      TransactionBufferStats getTransactionBufferStats(String topic, boolean lowWaterMarks) throws PulsarAdminException
      Get transaction buffer stats.
      Parameters:
      topic - the topic of getting transaction buffer stats
      lowWaterMarks - Whether to get information about lowWaterMarks stored in transaction buffer.
      Returns:
      the stats of transaction buffer in topic.
      Throws:
      PulsarAdminException
    • getTransactionBufferStats

      default TransactionBufferStats getTransactionBufferStats(String topic) throws PulsarAdminException
      Get transaction buffer stats.
      Parameters:
      topic - the topic of getting transaction buffer stats
      Returns:
      the stats of transaction buffer in topic.
      Throws:
      PulsarAdminException
    • getPendingAckStatsAsync

      CompletableFuture<TransactionPendingAckStats> getPendingAckStatsAsync(String topic, String subName, boolean lowWaterMarks)
      Get transaction pending ack stats.
      Parameters:
      topic - the topic of this transaction pending ack stats
      subName - the subscription name of this transaction pending ack stats
      lowWaterMarks - Whether to get information about lowWaterMarks stored in transaction pending ack.
      Returns:
      the stats of transaction pending ack.
    • getPendingAckStatsAsync

      default CompletableFuture<TransactionPendingAckStats> getPendingAckStatsAsync(String topic, String subName)
      Get transaction pending ack stats.
      Parameters:
      topic - the topic of this transaction pending ack stats
      subName - the subscription name of this transaction pending ack stats
      Returns:
      the stats of transaction pending ack.
    • getPendingAckStats

      TransactionPendingAckStats getPendingAckStats(String topic, String subName, boolean lowWaterMarks) throws PulsarAdminException
      Get transaction pending ack stats.
      Parameters:
      topic - the topic of this transaction pending ack stats
      subName - the subscription name of this transaction pending ack stats
      lowWaterMarks - Whether to get information about lowWaterMarks stored in transaction pending ack.
      Returns:
      the stats of transaction pending ack.
      Throws:
      PulsarAdminException
    • getPendingAckStats

      default TransactionPendingAckStats getPendingAckStats(String topic, String subName) throws PulsarAdminException
      Get transaction pending ack stats.
      Parameters:
      topic - the topic of this transaction pending ack stats
      subName - the subscription name of this transaction pending ack stats
      Returns:
      the stats of transaction pending ack.
      Throws:
      PulsarAdminException
    • getSlowTransactionsByCoordinatorIdAsync

      CompletableFuture<Map<String,TransactionMetadata>> getSlowTransactionsByCoordinatorIdAsync(Integer coordinatorId, long timeout, TimeUnit timeUnit)
      Get slow transactions by coordinator id.
      Parameters:
      coordinatorId - the coordinator id of getting slow transaction status.
      timeout - the timeout
      timeUnit - the timeout timeUnit
      Returns:
      the future metadata of slow transactions.
    • getSlowTransactionsByCoordinatorId

      Map<String,TransactionMetadata> getSlowTransactionsByCoordinatorId(Integer coordinatorId, long timeout, TimeUnit timeUnit) throws PulsarAdminException
      Get slow transactions by coordinator id.
      Parameters:
      coordinatorId - the coordinator id of getting slow transaction status.
      timeout - the timeout
      timeUnit - the timeout timeUnit
      Returns:
      the metadata of slow transactions.
      Throws:
      PulsarAdminException
    • getSlowTransactionsAsync

      CompletableFuture<Map<String,TransactionMetadata>> getSlowTransactionsAsync(long timeout, TimeUnit timeUnit)
      Get slow transactions.
      Parameters:
      timeout - the timeout
      timeUnit - the timeout timeUnit
      Returns:
      the future metadata of slow transactions.
    • getSlowTransactions

      Map<String,TransactionMetadata> getSlowTransactions(long timeout, TimeUnit timeUnit) throws PulsarAdminException
      Get slow transactions.
      Parameters:
      timeout - the timeout
      timeUnit - the timeout timeUnit
      Returns:
      the metadata of slow transactions.
      Throws:
      PulsarAdminException
    • getCoordinatorInternalStatsAsync

      CompletableFuture<TransactionCoordinatorInternalStats> getCoordinatorInternalStatsAsync(int coordinatorId, boolean metadata)
      Get transaction coordinator internal stats.
      Parameters:
      coordinatorId - the coordinator ID
      metadata - is get ledger metadata
      Returns:
      the future internal stats of this coordinator
    • getCoordinatorInternalStats

      TransactionCoordinatorInternalStats getCoordinatorInternalStats(int coordinatorId, boolean metadata) throws PulsarAdminException
      Get transaction coordinator internal stats.
      Parameters:
      coordinatorId - the coordinator ID
      metadata - whether to obtain ledger metadata
      Returns:
      the internal stats of this coordinator
      Throws:
      PulsarAdminException
    • getPendingAckInternalStatsAsync

      CompletableFuture<TransactionPendingAckInternalStats> getPendingAckInternalStatsAsync(String topic, String subName, boolean metadata)
      Get pending ack internal stats.
      Parameters:
      topic - the topic of get pending ack internal stats
      subName - the subscription name of this pending ack
      metadata - whether to obtain ledger metadata
      Returns:
      the future internal stats of pending ack
    • getPendingAckInternalStats

      TransactionPendingAckInternalStats getPendingAckInternalStats(String topic, String subName, boolean metadata) throws PulsarAdminException
      Get pending ack internal stats.
      Parameters:
      topic - the topic of get pending ack internal stats
      subName - the subscription name of this pending ack
      metadata - whether to obtain ledger metadata
      Returns:
      the internal stats of pending ack
      Throws:
      PulsarAdminException
    • scaleTransactionCoordinators

      void scaleTransactionCoordinators(int replicas) throws PulsarAdminException
      Sets the scale of the transaction coordinators. And currently, we can only support scale-up.
      Parameters:
      replicas - the new transaction coordinators size.
      Throws:
      PulsarAdminException
    • scaleTransactionCoordinatorsAsync

      CompletableFuture<Void> scaleTransactionCoordinatorsAsync(int replicas)
      Asynchronously sets the size of the transaction coordinators. And currently, we can only support scale-up.
      Parameters:
      replicas - the new transaction coordinators size.
      Returns:
      a future that can be used to track when the transaction coordinator number is updated.
    • getPositionStatsInPendingAck

      PositionInPendingAckStats getPositionStatsInPendingAck(String topic, String subName, Long ledgerId, Long entryId, Integer batchIndex) throws PulsarAdminException
      Get the position stats in transaction pending ack.
      Parameters:
      topic - the topic of checking position in pending ack state
      subName - the subscription name of this pending ack
      ledgerId - the ledger id of the message position.
      entryId - the entry id of the message position.
      batchIndex - the batch index of the message position, `null` means not batch message.
      Returns:
      PositionInPendingAckStats a state identified whether the position state.
      Throws:
      PulsarAdminException
    • getPositionStatsInPendingAckAsync

      CompletableFuture<PositionInPendingAckStats> getPositionStatsInPendingAckAsync(String topic, String subName, Long ledgerId, Long entryId, Integer batchIndex)
      Get the position stats in transaction pending ack.
      Parameters:
      topic - the topic of checking position in pending ack state
      subName - the subscription name of this pending ack
      ledgerId - the ledger id of the message position.
      entryId - the entry id of the message position.
      batchIndex - the batch index of the message position, `null` means not batch message.
      Returns:
      PositionInPendingAckStats a state identified whether the position state.