Interface ActiveMQServerControl


public interface ActiveMQServerControl
An ActiveMQServerControl is used to manage ActiveMQ Artemis servers.
  • Field Details

  • Method Details

    • getName

      String getName()
      Returns this server's name.
    • getCurrentTimeMillis

      long getCurrentTimeMillis()
    • getVersion

      String getVersion()
      Returns this server's version.
    • isActive

      boolean isActive()
    • getConnectionCount

      int getConnectionCount()
      Returns the number of clients connected to this server.
    • getTotalConnectionCount

      long getTotalConnectionCount()
      Returns the number of clients which have connected to this server since it was started.
    • getTotalMessageCount

      long getTotalMessageCount()
      Returns the number of messages in all queues currently on the server.
    • getTotalMessagesAdded

      long getTotalMessagesAdded()
      Returns the number of messages sent to all queues currently on the server since they were created.
    • getTotalMessagesAcknowledged

      long getTotalMessagesAcknowledged()
      Returns the number of messages acknowledged from all the queues currently on this server since they were created.
    • getTotalConsumerCount

      long getTotalConsumerCount()
      Returns the number of consumers on all the queues currently on this server.
    • isStarted

      boolean isStarted()
      Return whether this server is started.
    • getIncomingInterceptorClassNames

      String[] getIncomingInterceptorClassNames()
      Returns the list of interceptors used by this server for incoming messages.
      See Also:
    • getOutgoingInterceptorClassNames

      String[] getOutgoingInterceptorClassNames()
      Returns the list of interceptors used by this server for outgoing messages.
      See Also:
    • getBrokerPluginClassNames

      String[] getBrokerPluginClassNames()
    • isClustered

      boolean isClustered()
      Returns whether this server is clustered.
    • getScheduledThreadPoolMaxSize

      int getScheduledThreadPoolMaxSize()
      Returns the maximum number of threads in the scheduled thread pool.
    • getThreadPoolMaxSize

      int getThreadPoolMaxSize()
      Returns the maximum number of threads in the thread pool.
    • getSecurityInvalidationInterval

      long getSecurityInvalidationInterval()
      Returns the interval time (in milliseconds) to invalidate security credentials.
    • isSecurityEnabled

      boolean isSecurityEnabled()
      Returns whether security is enabled for this server.
    • getBindingsDirectory

      String getBindingsDirectory()
      Returns the file system directory used to store bindings.
    • getJournalDirectory

      String getJournalDirectory()
      Returns the file system directory used to store journal log.
    • getJournalType

      String getJournalType()
      Returns the type of journal used by this server (either NIO or ASYNCIO).
    • isJournalSyncTransactional

      boolean isJournalSyncTransactional()
      Returns whether the journal is synchronized when receiving transactional data.
    • isJournalSyncNonTransactional

      boolean isJournalSyncNonTransactional()
      Returns whether the journal is synchronized when receiving non-transactional data.
    • getJournalFileSize

      int getJournalFileSize()
      Returns the size (in bytes) of each journal files.
    • getJournalMinFiles

      int getJournalMinFiles()
      Returns the number of journal files to pre-create.
    • getJournalMaxIO

      int getJournalMaxIO()
      Returns the maximum number of write requests that can be in the AIO queue at any given time.
    • getJournalBufferSize

      int getJournalBufferSize()
      Returns the size of the internal buffer on the journal.
    • getJournalPoolFiles

      int getJournalPoolFiles()
      Number of files that would be acceptable to keep on a pool
    • getJournalBufferTimeout

      int getJournalBufferTimeout()
      Returns the timeout (in nanoseconds) used to flush internal buffers on the journal.
    • setFailoverOnServerShutdown

      void setFailoverOnServerShutdown(boolean failoverOnServerShutdown) throws Exception
      do any clients failover on a server shutdown
      Throws:
      Exception
    • isFailoverOnServerShutdown

      boolean isFailoverOnServerShutdown()
      returns if clients failover on a server shutdown
    • getJournalCompactMinFiles

      int getJournalCompactMinFiles()
      Returns the minimal number of journal files before compacting.
    • getJournalCompactPercentage

      int getJournalCompactPercentage()
      Return the percentage of live data before compacting the journal.
    • isPersistenceEnabled

      boolean isPersistenceEnabled()
      Returns whether this server is using persistence and store data.
    • isCreateBindingsDir

      boolean isCreateBindingsDir()
      Returns whether the bindings directory is created on this server startup.
    • isCreateJournalDir

      boolean isCreateJournalDir()
      Returns whether the journal directory is created on this server startup.
    • isMessageCounterEnabled

      boolean isMessageCounterEnabled()
      Returns whether message counter is enabled for this server.
    • getMessageCounterMaxDayCount

      int getMessageCounterMaxDayCount()
      Returns the maximum number of days kept in memory for message counter.
    • setMessageCounterMaxDayCount

      void setMessageCounterMaxDayCount(int count) throws Exception
      Sets the maximum number of days kept in memory for message counter.
      Parameters:
      count - value must be greater than 0
      Throws:
      Exception
    • getMessageCounterSamplePeriod

      long getMessageCounterSamplePeriod()
      Returns the sample period (in milliseconds) to take message counter snapshot.
    • setMessageCounterSamplePeriod

      void setMessageCounterSamplePeriod(long newPeriod) throws Exception
      Sets the sample period to take message counter snapshot.
      Parameters:
      newPeriod - value must be greater than 1000ms
      Throws:
      Exception
    • isBackup

      boolean isBackup()
      Returns true if this server is a backup, false if it is a primary server.
      If a backup server has been activated, returns false.
    • isSharedStore

      boolean isSharedStore()
      Returns whether this server shares its data store with a corresponding primary or backup server.
    • getPagingDirectory

      String getPagingDirectory()
      Returns the file system directory used to store paging files.
    • isPersistDeliveryCountBeforeDelivery

      boolean isPersistDeliveryCountBeforeDelivery()
      Returns whether delivery count is persisted before messages are delivered to the consumers.
    • getConnectionTTLOverride

      long getConnectionTTLOverride()
      Returns the connection time to live.
      This value overrides the connection time to live sent by the client.
    • getManagementAddress

      String getManagementAddress()
      Returns the management address of this server.
      Clients can send management messages to this address to manage this server.
    • getNodeID

      String getNodeID()
      Returns the node ID of this server.
      Clients can send management messages to this address to manage this server.
    • getActivationSequence

      long getActivationSequence()
      Returns the current activation sequence number of this server.
      When replicated, peers may coordinate activation with this monotonic sequence
    • getManagementNotificationAddress

      String getManagementNotificationAddress()
      Returns the management notification address of this server.
      Clients can bind queues to this address to receive management notifications emitted by this server.
    • getIDCacheSize

      int getIDCacheSize()
      Returns the size of the cache for pre-creating message IDs.
    • isPersistIDCache

      boolean isPersistIDCache()
      Returns whether message ID cache is persisted.
    • getLargeMessagesDirectory

      String getLargeMessagesDirectory()
      Returns the file system directory used to store large messages.
    • isWildcardRoutingEnabled

      boolean isWildcardRoutingEnabled()
      Returns whether wildcard routing is supported by this server.
    • getTransactionTimeout

      long getTransactionTimeout()
      Returns the timeout (in milliseconds) after which transactions is removed from the resource manager after it was created.
    • getTransactionTimeoutScanPeriod

      long getTransactionTimeoutScanPeriod()
      Returns the frequency (in milliseconds) to scan transactions to detect which transactions have timed out.
    • getMessageExpiryScanPeriod

      long getMessageExpiryScanPeriod()
      Returns the frequency (in milliseconds) to scan messages to detect which messages have expired.
    • getMessageExpiryThreadPriority

      @Deprecated long getMessageExpiryThreadPriority()
      Deprecated.
      Returns the priority of the thread used to scan message expiration.
    • isAsyncConnectionExecutionEnabled

      boolean isAsyncConnectionExecutionEnabled()
      Returns whether code coming from connection is executed asynchronously or not.
    • getConnectors

      Object[] getConnectors() throws Exception
      Returns the connectors configured for this server.
      Throws:
      Exception
    • getConnectorsAsJSON

      String getConnectorsAsJSON() throws Exception
      Returns the connectors configured for this server using JSON serialization.
      Throws:
      Exception
    • getAcceptors

      Object[] getAcceptors() throws Exception
      Returns the acceptors configured for this server.
      Throws:
      Exception
    • getAcceptorsAsJSON

      String getAcceptorsAsJSON() throws Exception
      Returns the acceptors configured for this server using JSON serialization.
      Throws:
      Exception
    • getAddressCount

      int getAddressCount()
      Returns the number of addresses created on this server.
    • getAddressNames

      String[] getAddressNames()
      Returns the names of the addresses created on this server.
    • getQueueCount

      int getQueueCount()
      Returns the number of queues created on this server.
    • getQueueNames

      String[] getQueueNames()
      Returns the names of the queues created on this server.
    • getUptime

      String getUptime()
      Returns the uptime of this server.
    • getUptimeMillis

      long getUptimeMillis()
      Returns the uptime of this server.
    • isReplicaSync

      boolean isReplicaSync()
      Returns whether the initial replication synchronization process with the backup server is complete; applicable for either the primary or backup server.
    • getDiskScanPeriod

      int getDiskScanPeriod()
      Returns how often the server checks for disk space usage.
    • getMaxDiskUsage

      int getMaxDiskUsage()
      Returns the disk use max limit.
    • getGlobalMaxSize

      long getGlobalMaxSize()
      Returns the global max bytes limit for in-memory messages.
    • getAddressMemoryUsage

      long getAddressMemoryUsage()
      Returns the memory used by all the addresses on broker for in-memory messages
    • getDiskStoreUsage

      double getDiskStoreUsage()
      Returns the percentage of total disk store use
    • getAddressMemoryUsagePercentage

      int getAddressMemoryUsagePercentage()
      Returns the memory used by all the addresses on broker as a percentage of the global-max-size
    • getHAPolicy

      String getHAPolicy()
    • getAuthenticationCacheSize

      long getAuthenticationCacheSize()
      Returns the runtime size of the authentication cache
    • getAuthorizationCacheSize

      long getAuthorizationCacheSize()
      Returns the runtime size of the authorization cache
    • getStatus

      String getStatus()
    • freezeReplication

      boolean freezeReplication() throws Exception
      Throws:
      Exception
    • createAddress

      String createAddress(String name, String routingTypes) throws Exception
      Throws:
      Exception
    • updateAddress

      String updateAddress(String name, String routingTypes) throws Exception
      Throws:
      Exception
    • deleteAddress

      void deleteAddress(String name) throws Exception
      Throws:
      Exception
    • deleteAddress

      void deleteAddress(String name, boolean force) throws Exception
      Throws:
      Exception
    • createQueue

      @Deprecated void createQueue(String address, String name) throws Exception
      Deprecated.
      Create a durable queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      name - name of the queue
      Throws:
      Exception
    • createQueue

      @Deprecated void createQueue(String address, String name, String routingType) throws Exception
      Deprecated.
      Create a durable queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      name - name of the queue
      routingType - The routing type used for this address, MULTICAST or ANYCAST
      Throws:
      Exception
    • createQueue

      @Deprecated void createQueue(String address, String name, boolean durable) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      name - name of the queue
      durable - whether the queue is durable
      Throws:
      Exception
    • createQueue

      @Deprecated void createQueue(String address, String name, boolean durable, String routingType) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      name - name of the queue
      durable - whether the queue is durable
      routingType - The routing type used for this address, MULTICAST or ANYCAST
      Throws:
      Exception
    • createQueue

      @Deprecated void createQueue(String address, String name, String filter, boolean durable) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      name - name of the queue
      filter - of the queue
      durable - whether the queue is durable
      Throws:
      Exception
    • createQueue

      @Deprecated void createQueue(String address, String name, String filter, boolean durable, String routingType) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      name - name of the queue
      filter - of the queue
      durable - whether the queue is durable
      routingType - The routing type used for this address, MULTICAST or ANYCAST
      Throws:
      Exception
    • createQueue

      @Deprecated String createQueue(String address, String routingType, String name, String filterStr, boolean durable, int maxConsumers, boolean purgeOnNoConsumers, boolean exclusive, boolean groupRebalance, int groupBuckets, boolean lastValue, String lastValueKey, boolean nonDestructive, int consumersBeforeDispatch, long delayBeforeDispatch, boolean autoCreateAddress) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      name - name of the queue
      filterStr - filter of the queue
      durable - is the queue durable?
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      lastValue - use last-value semantics
      consumersBeforeDispatch - number of consumers needed before dispatch can start
      delayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not met
      autoCreateAddress - create an address with default values should a matching address not be found
      Returns:
      a textual summary of the queue
      Throws:
      Exception
    • createQueue

      @Deprecated String createQueue(String address, String routingType, String name, String filterStr, boolean durable, int maxConsumers, boolean purgeOnNoConsumers, boolean exclusive, boolean groupRebalance, int groupBuckets, boolean lastValue, String lastValueKey, boolean nonDestructive, int consumersBeforeDispatch, long delayBeforeDispatch, boolean autoDelete, long autoDeleteDelay, long autoDeleteMessageCount, boolean autoCreateAddress) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      name - name of the queue
      filterStr - filter of the queue
      durable - is the queue durable?
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      lastValue - use last-value semantics
      consumersBeforeDispatch - number of consumers needed before dispatch can start
      delayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not met
      autoCreateAddress - create an address with default values should a matching address not be found
      Returns:
      a textual summary of the queue
      Throws:
      Exception
    • createQueue

      @Deprecated String createQueue(String address, String routingType, String name, String filterStr, boolean durable, int maxConsumers, boolean purgeOnNoConsumers, boolean exclusive, boolean groupRebalance, int groupBuckets, String groupFirstKey, boolean lastValue, String lastValueKey, boolean nonDestructive, int consumersBeforeDispatch, long delayBeforeDispatch, boolean autoDelete, long autoDeleteDelay, long autoDeleteMessageCount, boolean autoCreateAddress) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      name - name of the queue
      filterStr - filter of the queue
      durable - is the queue durable?
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      lastValue - use last-value semantics
      consumersBeforeDispatch - number of consumers needed before dispatch can start
      delayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not met
      autoCreateAddress - create an address with default values should a matching address not be found
      Returns:
      a textual summary of the queue
      Throws:
      Exception
    • createQueue

      @Deprecated String createQueue(String address, String routingType, String name, String filterStr, boolean durable, int maxConsumers, boolean purgeOnNoConsumers, boolean exclusive, boolean groupRebalance, int groupBuckets, String groupFirstKey, boolean lastValue, String lastValueKey, boolean nonDestructive, int consumersBeforeDispatch, long delayBeforeDispatch, boolean autoDelete, long autoDeleteDelay, long autoDeleteMessageCount, boolean autoCreateAddress, long ringSize) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      name - name of the queue
      filterStr - filter of the queue
      durable - is the queue durable?
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      lastValue - use last-value semantics
      consumersBeforeDispatch - number of consumers needed before dispatch can start
      delayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not met
      autoCreateAddress - create an address with default values should a matching address not be found
      ringSize - the size this queue should maintain according to ring semantics
      Returns:
      a textual summary of the queue
      Throws:
      Exception
    • createQueue

      @Deprecated String createQueue(String address, String routingType, String name, String filterStr, boolean durable, int maxConsumers, boolean purgeOnNoConsumers, boolean autoCreateAddress) throws Exception
      Deprecated.
      Create a queue.
      If address is null it will be defaulted to name.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exits.
      Parameters:
      address - address to bind the queue to
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      name - name of the queue
      filterStr - filter of the queue
      durable - is the queue durable?
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      autoCreateAddress - create an address with default values should a matching address not be found
      Returns:
      a textual summary of the queue
      Throws:
      Exception
    • createQueue

      String createQueue(String queueConfiguration) throws Exception
      Create a queue.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exists.
      Parameters:
      queueConfiguration - the configuration of the queue in JSON format
      Returns:
      the configuration of the created queue in JSON format
      Throws:
      Exception
    • createQueue

      String createQueue(String queueConfiguration, boolean ignoreIfExists) throws Exception
      Create a queue.
      This method throws a ActiveMQQueueExistsException) exception if the queue already exists and ignoreIfExists is false.
      Parameters:
      queueConfiguration - the configuration of the queue in JSON format
      ignoreIfExists - whether or not to simply return without an exception if the queue exists
      Returns:
      the configuration of the created queue in JSON format
      Throws:
      Exception
    • updateQueue

      String updateQueue(String queueConfiguration) throws Exception
      Update a queue.
      Parameters:
      queueConfiguration - the configuration of the queue in JSON format
      Returns:
      the configuration of the created queue in JSON format
      Throws:
      Exception
    • updateQueue

      @Deprecated String updateQueue(String name, String routingType, Integer maxConsumers, Boolean purgeOnNoConsumers) throws Exception
      Deprecated.
      Update a queue.
      Parameters:
      name - name of the queue
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      Returns:
      a textual summary of the queue
      Throws:
      Exception
    • updateQueue

      @Deprecated String updateQueue(String name, String routingType, Integer maxConsumers, Boolean purgeOnNoConsumers, Boolean exclusive) throws Exception
      Deprecated.
      Update a queue.
      Parameters:
      name - name of the queue
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      Returns:
      a textual summary of the queue
      Throws:
      Exception
    • updateQueue

      @Deprecated String updateQueue(String name, String routingType, Integer maxConsumers, Boolean purgeOnNoConsumers, Boolean exclusive, String user) throws Exception
      Deprecated.
      Update a queue
      Parameters:
      name - name of the queue
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      user - the user associated with this queue
      Returns:
      Throws:
      Exception
    • updateQueue

      @Deprecated String updateQueue(String name, String routingType, String filter, Integer maxConsumers, Boolean purgeOnNoConsumers, Boolean exclusive, Boolean groupRebalance, Integer groupBuckets, Boolean nonDestructive, Integer consumersBeforeDispatch, Long delayBeforeDispatch, String user) throws Exception
      Deprecated.
      Update a queue
      Parameters:
      name - name of the queue
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      filter - the filter to use on the queue
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      groupRebalance - if the queue should rebalance groups when a consumer is added
      groupBuckets - number of buckets that should be used for message groups, -1 (default) is unlimited, and groups by raw key instead
      nonDestructive - If the queue is non-destructive
      consumersBeforeDispatch - number of consumers needed before dispatch can start
      delayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not met
      user - the user associated with this queue
      Returns:
      Throws:
      Exception
    • updateQueue

      @Deprecated String updateQueue(String name, String routingType, String filter, Integer maxConsumers, Boolean purgeOnNoConsumers, Boolean exclusive, Boolean groupRebalance, Integer groupBuckets, String groupFirstKey, Boolean nonDestructive, Integer consumersBeforeDispatch, Long delayBeforeDispatch, String user) throws Exception
      Deprecated.
      Update a queue
      Parameters:
      name - name of the queue
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      filter - the filter to use on the queue
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      groupRebalance - if the queue should rebalance groups when a consumer is added
      groupBuckets - number of buckets that should be used for message groups, -1 (default) is unlimited, and groups by raw key instead
      groupFirstKey - key used to mark a message is first in a group for a consumer
      nonDestructive - If the queue is non-destructive
      consumersBeforeDispatch - number of consumers needed before dispatch can start
      delayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not met
      user - the user associated with this queue
      Returns:
      Throws:
      Exception
    • updateQueue

      @Deprecated String updateQueue(String name, String routingType, String filter, Integer maxConsumers, Boolean purgeOnNoConsumers, Boolean exclusive, Boolean groupRebalance, Integer groupBuckets, String groupFirstKey, Boolean nonDestructive, Integer consumersBeforeDispatch, Long delayBeforeDispatch, String user, Long ringSize) throws Exception
      Deprecated.
      Update a queue
      Parameters:
      name - name of the queue
      routingType - the routing type used for this address, MULTICAST or ANYCAST
      filter - the filter to use on the queue
      maxConsumers - the maximum number of consumers allowed on this queue at any one time
      purgeOnNoConsumers - delete this queue when the last consumer disconnects
      exclusive - if the queue should route exclusively to one consumer
      groupRebalance - if the queue should rebalance groups when a consumer is added
      groupBuckets - number of buckets that should be used for message groups, -1 (default) is unlimited, and groups by raw key instead
      groupFirstKey - key used to mark a message is first in a group for a consumer
      nonDestructive - If the queue is non-destructive
      consumersBeforeDispatch - number of consumers needed before dispatch can start
      delayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not met
      user - the user associated with this queue
      ringSize - the size this queue should maintain according to ring semantics
      Returns:
      Throws:
      Exception
    • deployQueue

      @Deprecated void deployQueue(String address, String name, String filter) throws Exception
      Deprecated.
      Deploy a durable queue.
      If address is null it will be defaulted to name.
      This method will do nothing if the queue with the given name already exists on the server.
      Parameters:
      address - address to bind the queue to
      name - name of the queue
      filter - of the queue
      Throws:
      Exception
    • deployQueue

      @Deprecated void deployQueue(String address, String name, String filter, boolean durable) throws Exception
      Deprecated.
      Deploy a queue.
      If address is null it will be defaulted to name.
      This method will do nothing if the queue with the given name already exists on the server.
      Parameters:
      address - address to bind the queue to
      name - name of the queue
      filter - of the queue
      durable - whether the queue is durable
      Throws:
      Exception
    • destroyQueue

      void destroyQueue(String name) throws Exception
      Destroys the queue corresponding to the specified name.
      Throws:
      Exception
    • destroyQueue

      void destroyQueue(String name, boolean removeConsumers) throws Exception
      Destroys the queue corresponding to the specified name.
      Throws:
      Exception
    • destroyQueue

      void destroyQueue(String name, boolean removeConsumers, boolean autoDeleteAddress) throws Exception
      Destroys the queue corresponding to the specified name and delete it's address if there are no other queues
      Throws:
      Exception
    • enableMessageCounters

      void enableMessageCounters() throws Exception
      Enables message counters for this server.
      Throws:
      Exception
    • disableMessageCounters

      void disableMessageCounters() throws Exception
      Disables message counters for this server.
      Throws:
      Exception
    • resetAllMessageCounters

      void resetAllMessageCounters() throws Exception
      Reset all message counters.
      Throws:
      Exception
    • resetAllMessageCounterHistories

      void resetAllMessageCounterHistories() throws Exception
      Reset histories for all message counters.
      Throws:
      Exception
    • listPreparedTransactions

      String[] listPreparedTransactions() throws Exception
      List all the prepared transaction, sorted by date, oldest first.
      The Strings are Base-64 representation of the transaction XID and can be used to heuristically commit or rollback the transactions.
      Throws:
      Exception
      See Also:
    • listPreparedTransactionDetailsAsJSON

      String listPreparedTransactionDetailsAsJSON() throws Exception
      List all the prepared transaction, sorted by date, oldest first, with details, in text format.
      Throws:
      Exception
    • listPreparedTransactionDetailsAsHTML

      @Deprecated String listPreparedTransactionDetailsAsHTML() throws Exception
      Deprecated.
      List all the prepared transaction, sorted by date, oldest first, with details, in HTML format
      Throws:
      Exception
    • listHeuristicCommittedTransactions

      String[] listHeuristicCommittedTransactions() throws Exception
      List transactions which have been heuristically committed.
      Throws:
      Exception
    • listHeuristicRolledBackTransactions

      String[] listHeuristicRolledBackTransactions() throws Exception
      List transactions which have been heuristically rolled back.
      Throws:
      Exception
    • commitPreparedTransaction

      boolean commitPreparedTransaction(String transactionAsBase64) throws Exception
      Heuristically commits a prepared transaction.
      Parameters:
      transactionAsBase64 - base 64 representation of a prepare transaction
      Returns:
      true if the transaction was successfully committed, false else
      Throws:
      Exception
      See Also:
    • rollbackPreparedTransaction

      boolean rollbackPreparedTransaction(String transactionAsBase64) throws Exception
      Heuristically rolls back a prepared transaction.
      Parameters:
      transactionAsBase64 - base 64 representation of a prepare transaction
      Returns:
      true if the transaction was successfully rolled back, false else
      Throws:
      Exception
      See Also:
    • listRemoteAddresses

      String[] listRemoteAddresses() throws Exception
      Lists the addresses of all the clients connected to this address.
      Throws:
      Exception
    • listRemoteAddresses

      String[] listRemoteAddresses(String ipAddress) throws Exception
      Lists the addresses of the clients connected to this address which matches the specified IP address.
      Throws:
      Exception
    • closeConnectionsForAddress

      boolean closeConnectionsForAddress(String ipAddress) throws Exception
      Closes all the connections of clients connected to this server which matches the specified IP address.
      Throws:
      Exception
    • closeConsumerConnectionsForAddress

      boolean closeConsumerConnectionsForAddress(String address) throws Exception
      Closes all the connections of clients connected to this server which matches the specified IP address.
      Throws:
      Exception
    • closeConnectionsForUser

      boolean closeConnectionsForUser(String address) throws Exception
      Closes all the connections of sessions with a matching user name.
      Throws:
      Exception
    • closeConnectionWithID

      boolean closeConnectionWithID(String ID) throws Exception
      Closes the connection with the given id.
      Throws:
      Exception
    • closeSessionWithID

      boolean closeSessionWithID(String connectionID, String ID) throws Exception
      Closes the session with the given id.
      Throws:
      Exception
    • closeSessionWithID

      boolean closeSessionWithID(String connectionID, String ID, boolean force) throws Exception
      Closes the session with the given id.
      Throws:
      Exception
    • closeConsumerWithID

      boolean closeConsumerWithID(String sessionID, String ID) throws Exception
      Closes the consumer with the given id.
      Throws:
      Exception
    • listConnectionIDs

      String[] listConnectionIDs() throws Exception
      Lists all the IDs of the connections connected to this server.
      Throws:
      Exception
    • listProducersInfoAsJSON

      String listProducersInfoAsJSON() throws Exception
      Throws:
      Exception
    • listConnectionsAsJSON

      String listConnectionsAsJSON() throws Exception
      Lists all the connections connected to this server. The returned String is a JSON string containing details about each connection, e.g.:
       [
         {
           "creationTime": 1469240429671,
           "sessionCount": 1,
           "implementation": "RemotingConnectionImpl",
           "connectionID": "1648309901",
           "clientAddress": "\/127.0.0.1:57649"
         }
       ]
       
      Throws:
      Exception
    • listConsumersAsJSON

      String listConsumersAsJSON(String connectionID) throws Exception
      Lists all the consumers which belongs to the connection specified by the connectionID. The returned String is a JSON string containing details about each consumer, e.g.:
       [
         {
           "filter": "color = 'RED'",
           "queueName": "2ea5b050-28bf-4ee2-9b24-b73f5983192a",
           "creationTime": 1469239602459,
           "deliveringCount": 0,
           "consumerID": 1,
           "browseOnly": true,
           "connectionID": "1963ece3-507a-11e6-94ff-e8b1fc439540",
           "sessionID": "19676f55-507a-11e6-94ff-e8b1fc439540"
         }
       ]
       
      Throws:
      Exception
    • listAllConsumersAsJSON

      String listAllConsumersAsJSON() throws Exception
      Lists all the consumers connected to this server. The returned String is a JSON string containing details about each consumer, e.g.:
       [
         {
           "queueName": "fa87c64c-0a38-4697-8421-72e34d17429d",
           "creationTime": 1469235956168,
           "deliveringCount": 0,
           "consumerID": 0,
           "browseOnly": false,
           "connectionID": "9c0d42e7-5071-11e6-9e29-e8b1fc439540",
           "sessionID": "9c0d9109-5071-11e6-9e29-e8b1fc439540"
         }
       ]
       
      Throws:
      Exception
    • listSessionsAsJSON

      String listSessionsAsJSON(String connectionID) throws Exception
      Lists details about all the sessions for the specified connection ID. The returned String is a JSON string containing details about each session associated with the specified ID, e.g.:
       [
         {
           "principal": "myUser",
           "creationTime": 1469240773157,
           "consumerCount": 0,
           "sessionID": "d33d10db-507c-11e6-9e47-e8b1fc439540"
         }
       ]
       
      Throws:
      Exception
    • listAllSessionsAsJSON

      String listAllSessionsAsJSON() throws Exception
      Lists details about all sessions. The returned String is a JSON string containing details about each and every session, e.g.:
       [
         {
           "sessionID":"e71d61d7-2176-11e8-9057-a0afbd82eaba",
           "creationTime":1520365520212,
           "consumerCount":1,
           "principal":"myUser"
         },
         {
           "sessionID":"e718a6e6-2176-11e8-9057-a0afbd82eaba",
           "creationTime":1520365520191,
           "consumerCount":0,
           "principal":"guest"
         }
       ]
       
      Throws:
      Exception
    • listSessions

      String[] listSessions(String connectionID) throws Exception
      Lists all the sessions IDs for the specified connection ID.
      Throws:
      Exception
    • addSecuritySettings

      void addSecuritySettings(String addressMatch, String sendRoles, String consumeRoles, String createDurableQueueRoles, String deleteDurableQueueRoles, String createNonDurableQueueRoles, String deleteNonDurableQueueRoles, String manageRoles) throws Exception
      Throws:
      Exception
    • addSecuritySettings

      void addSecuritySettings(String addressMatch, String sendRoles, String consumeRoles, String createDurableQueueRoles, String deleteDurableQueueRoles, String createNonDurableQueueRoles, String deleteNonDurableQueueRoles, String manageRoles, String browseRoles) throws Exception
      Throws:
      Exception
    • addSecuritySettings

      void addSecuritySettings(String addressMatch, String sendRoles, String consumeRoles, String createDurableQueueRoles, String deleteDurableQueueRoles, String createNonDurableQueueRoles, String deleteNonDurableQueueRoles, String manageRoles, String browseRoles, String createAddressRoles, String deleteAddressRoles) throws Exception
      Throws:
      Exception
    • addSecuritySettings

      void addSecuritySettings(String addressMatch, String sendRoles, String consumeRoles, String createDurableQueueRoles, String deleteDurableQueueRoles, String createNonDurableQueueRoles, String deleteNonDurableQueueRoles, String manageRoles, String browseRoles, String createAddressRoles, String deleteAddressRoles, String viewRoles, String editRoles) throws Exception
      Throws:
      Exception
    • removeSecuritySettings

      void removeSecuritySettings(String addressMatch) throws Exception
      Throws:
      Exception
    • getRoles

      Object[] getRoles(String addressMatch) throws Exception
      Throws:
      Exception
    • getRolesAsJSON

      String getRolesAsJSON(String addressMatch) throws Exception
      Throws:
      Exception
    • addAddressSettings

      @Deprecated void addAddressSettings(String addressMatch, String DLA, String expiryAddress, long expiryDelay, boolean lastValueQueue, int deliveryAttempts, long maxSizeBytes, int pageSizeBytes, int pageMaxCacheSize, long redeliveryDelay, double redeliveryMultiplier, long maxRedeliveryDelay, long redistributionDelay, boolean sendToDLAOnNoRoute, String addressFullMessagePolicy, long slowConsumerThreshold, long slowConsumerCheckPeriod, String slowConsumerPolicy, boolean autoCreateJmsQueues, boolean autoDeleteJmsQueues, boolean autoCreateJmsTopics, boolean autoDeleteJmsTopics) throws Exception
      Deprecated.
      adds a new address setting for a specific address
      Throws:
      Exception
    • addAddressSettings

      @Deprecated void addAddressSettings(String addressMatch, String DLA, String expiryAddress, long expiryDelay, boolean lastValueQueue, int deliveryAttempts, long maxSizeBytes, int pageSizeBytes, int pageMaxCacheSize, long redeliveryDelay, double redeliveryMultiplier, long maxRedeliveryDelay, long redistributionDelay, boolean sendToDLAOnNoRoute, String addressFullMessagePolicy, long slowConsumerThreshold, long slowConsumerCheckPeriod, String slowConsumerPolicy, boolean autoCreateJmsQueues, boolean autoDeleteJmsQueues, boolean autoCreateJmsTopics, boolean autoDeleteJmsTopics, boolean autoCreateQueues, boolean autoDeleteQueues, boolean autoCreateAddresses, boolean autoDeleteAddresses) throws Exception
      Deprecated.
      adds a new address setting for a specific address
      Throws:
      Exception
    • addAddressSettings

      @Deprecated void addAddressSettings(String addressMatch, String DLA, String expiryAddress, long expiryDelay, boolean lastValueQueue, int deliveryAttempts, long maxSizeBytes, int pageSizeBytes, int pageMaxCacheSize, long redeliveryDelay, double redeliveryMultiplier, long maxRedeliveryDelay, long redistributionDelay, boolean sendToDLAOnNoRoute, String addressFullMessagePolicy, long slowConsumerThreshold, long slowConsumerCheckPeriod, String slowConsumerPolicy, boolean autoCreateJmsQueues, boolean autoDeleteJmsQueues, boolean autoCreateJmsTopics, boolean autoDeleteJmsTopics, boolean autoCreateQueues, boolean autoDeleteQueues, boolean autoCreateAddresses, boolean autoDeleteAddresses, String configDeleteQueues, String configDeleteAddresses, long maxSizeBytesRejectThreshold, String defaultLastValueKey, boolean defaultNonDestructive, boolean defaultExclusiveQueue, boolean defaultGroupRebalance, int defaultGroupBuckets, String defaultGroupFirstKey, int defaultMaxConsumers, boolean defaultPurgeOnNoConsumers, int defaultConsumersBeforeDispatch, long defaultDelayBeforeDispatch, String defaultQueueRoutingType, String defaultAddressRoutingType, int defaultConsumerWindowSize, long defaultRingSize, boolean autoDeleteCreatedQueues, long autoDeleteQueuesDelay, long autoDeleteQueuesMessageCount, long autoDeleteAddressesDelay, double redeliveryCollisionAvoidanceFactor, long retroactiveMessageCount) throws Exception
      Deprecated.
      adds a new address setting for a specific address
      Throws:
      Exception
    • addAddressSettings

      @Deprecated void addAddressSettings(String addressMatch, String DLA, String expiryAddress, long expiryDelay, boolean lastValueQueue, int deliveryAttempts, long maxSizeBytes, int pageSizeBytes, int pageMaxCacheSize, long redeliveryDelay, double redeliveryMultiplier, long maxRedeliveryDelay, long redistributionDelay, boolean sendToDLAOnNoRoute, String addressFullMessagePolicy, long slowConsumerThreshold, long slowConsumerCheckPeriod, String slowConsumerPolicy, boolean autoCreateJmsQueues, boolean autoDeleteJmsQueues, boolean autoCreateJmsTopics, boolean autoDeleteJmsTopics, boolean autoCreateQueues, boolean autoDeleteQueues, boolean autoCreateAddresses, boolean autoDeleteAddresses, String configDeleteQueues, String configDeleteAddresses, long maxSizeBytesRejectThreshold, String defaultLastValueKey, boolean defaultNonDestructive, boolean defaultExclusiveQueue, boolean defaultGroupRebalance, int defaultGroupBuckets, String defaultGroupFirstKey, int defaultMaxConsumers, boolean defaultPurgeOnNoConsumers, int defaultConsumersBeforeDispatch, long defaultDelayBeforeDispatch, String defaultQueueRoutingType, String defaultAddressRoutingType, int defaultConsumerWindowSize, long defaultRingSize, boolean autoDeleteCreatedQueues, long autoDeleteQueuesDelay, long autoDeleteQueuesMessageCount, long autoDeleteAddressesDelay, double redeliveryCollisionAvoidanceFactor, long retroactiveMessageCount, boolean autoCreateDeadLetterResources, String deadLetterQueuePrefix, String deadLetterQueueSuffix, boolean autoCreateExpiryResources, String expiryQueuePrefix, String expiryQueueSuffix) throws Exception
      Deprecated.
      adds a new address setting for a specific address
      Throws:
      Exception
    • addAddressSettings

      @Deprecated void addAddressSettings(String addressMatch, String DLA, String expiryAddress, long expiryDelay, boolean lastValueQueue, int maxDeliveryAttempts, long maxSizeBytes, int pageSizeBytes, int pageCacheMaxSize, long redeliveryDelay, double redeliveryMultiplier, long maxRedeliveryDelay, long redistributionDelay, boolean sendToDLAOnNoRoute, String addressFullMessagePolicy, long slowConsumerThreshold, long slowConsumerCheckPeriod, String slowConsumerPolicy, boolean autoCreateJmsQueues, boolean autoDeleteJmsQueues, boolean autoCreateJmsTopics, boolean autoDeleteJmsTopics, boolean autoCreateQueues, boolean autoDeleteQueues, boolean autoCreateAddresses, boolean autoDeleteAddresses, String configDeleteQueues, String configDeleteAddresses, long maxSizeBytesRejectThreshold, String defaultLastValueKey, boolean defaultNonDestructive, boolean defaultExclusiveQueue, boolean defaultGroupRebalance, int defaultGroupBuckets, String defaultGroupFirstKey, int defaultMaxConsumers, boolean defaultPurgeOnNoConsumers, int defaultConsumersBeforeDispatch, long defaultDelayBeforeDispatch, String defaultQueueRoutingType, String defaultAddressRoutingType, int defaultConsumerWindowSize, long defaultRingSize, boolean autoDeleteCreatedQueues, long autoDeleteQueuesDelay, long autoDeleteQueuesMessageCount, long autoDeleteAddressesDelay, double redeliveryCollisionAvoidanceFactor, long retroactiveMessageCount, boolean autoCreateDeadLetterResources, String deadLetterQueuePrefix, String deadLetterQueueSuffix, boolean autoCreateExpiryResources, String expiryQueuePrefix, String expiryQueueSuffix, long minExpiryDelay, long maxExpiryDelay, boolean enableMetrics) throws Exception
      Deprecated.
      adds a new address setting for a specific address
      Throws:
      Exception
    • addAddressSettings

      String addAddressSettings(String address, String addressSettingsConfigurationAsJson) throws Exception
      adds a new address setting for a specific address
      Throws:
      Exception
    • removeAddressSettings

      void removeAddressSettings(String addressMatch) throws Exception
      Throws:
      Exception
    • getAddressSettingsAsJSON

      String getAddressSettingsAsJSON(String addressMatch) throws Exception
      returns the address settings as a JSON string
      Throws:
      Exception
    • getDivertNames

      String[] getDivertNames()
    • listDivertNames

      default String[] listDivertNames()
      Jon plugin doesn't recognize an Operation whose name is in form getXXXX(), so add this one.
    • createDivert

      @Deprecated void createDivert(String name, String routingName, String address, String forwardingAddress, boolean exclusive, String filterString, String transformerClassName) throws Exception
      Deprecated.
      Deprecated in favor of createDivert(String)
      Throws:
      Exception
    • createDivert

      @Deprecated void createDivert(String name, String routingName, String address, String forwardingAddress, boolean exclusive, String filterString, String transformerClassName, String routingType) throws Exception
      Deprecated.
      Deprecated in favor of createDivert(String)
      Throws:
      Exception
    • createDivert

      @Deprecated void createDivert(String name, String routingName, String address, String forwardingAddress, boolean exclusive, String filterString, String transformerClassName, Map<String,String> transformerProperties, String routingType) throws Exception
      Deprecated.
      Deprecated in favor of createDivert(String)
      Throws:
      Exception
    • createDivert

      @Deprecated void createDivert(String name, String routingName, String address, String forwardingAddress, boolean exclusive, String filterString, String transformerClassName, String transformerPropertiesAsJSON, String routingType) throws Exception
      Deprecated.
      Deprecated in favor of createDivert(String)
      Throws:
      Exception
    • createDivert

      void createDivert(String divertConfiguration) throws Exception
      Create a Divert.
      Parameters:
      divertConfiguration - the configuration of the divert in JSON format
      Throws:
      Exception
    • updateDivert

      @Deprecated void updateDivert(String name, String forwardingAddress, String filterString, String transformerClassName, Map<String,String> transformerProperties, String routingType) throws Exception
      Deprecated.
      update a divert
      Throws:
      Exception
    • updateDivert

      void updateDivert(String divertConfiguration) throws Exception
      update a divert
      Throws:
      Exception
    • destroyDivert

      void destroyDivert(String name) throws Exception
      Throws:
      Exception
    • getBridgeNames

      String[] getBridgeNames()
    • createBridge

      @Deprecated void createBridge(String name, String queueName, String forwardingAddress, String filterString, String transformerClassName, long retryInterval, double retryIntervalMultiplier, int initialConnectAttempts, int reconnectAttempts, boolean useDuplicateDetection, int confirmationWindowSize, int producerWindowSize, long clientFailureCheckPeriod, String connectorNames, boolean useDiscoveryGroup, boolean ha, String user, String password) throws Exception
      Deprecated.
      Deprecated in favour of createBridge(String)
      Throws:
      Exception
    • createBridge

      @Deprecated void createBridge(String name, String queueName, String forwardingAddress, String filterString, String transformerClassName, Map<String,String> transformerProperties, long retryInterval, double retryIntervalMultiplier, int initialConnectAttempts, int reconnectAttempts, boolean useDuplicateDetection, int confirmationWindowSize, int producerWindowSize, long clientFailureCheckPeriod, String connectorNames, boolean useDiscoveryGroup, boolean ha, String user, String password) throws Exception
      Deprecated.
      Deprecated in favour of createBridge(String)
      Throws:
      Exception
    • createBridge

      @Deprecated void createBridge(String name, String queueName, String forwardingAddress, String filterString, String transformerClassName, String transformerPropertiesAsJSON, long retryInterval, double retryIntervalMultiplier, int initialConnectAttempts, int reconnectAttempts, boolean useDuplicateDetection, int confirmationWindowSize, int producerWindowSize, long clientFailureCheckPeriod, String connectorNames, boolean useDiscoveryGroup, boolean ha, String user, String password) throws Exception
      Deprecated.
      Deprecated in favour of createBridge(String)
      Throws:
      Exception
    • createBridge

      @Deprecated void createBridge(String name, String queueName, String forwardingAddress, String filterString, String transformerClassName, long retryInterval, double retryIntervalMultiplier, int initialConnectAttempts, int reconnectAttempts, boolean useDuplicateDetection, int confirmationWindowSize, long clientFailureCheckPeriod, String connectorNames, boolean useDiscoveryGroup, boolean ha, String user, String password) throws Exception
      Deprecated.
      Deprecated in favour of createBridge(String)
      Throws:
      Exception
    • createBridge

      void createBridge(String bridgeConfiguration) throws Exception
      Create a bridge.
      Parameters:
      bridgeConfiguration - the configuration of the queue in JSON format
      Throws:
      Exception
    • destroyBridge

      void destroyBridge(String name) throws Exception
      Throws:
      Exception
    • addConnector

      void addConnector(String name, String url) throws Exception
      Throws:
      Exception
    • removeConnector

      void removeConnector(String name) throws Exception
      Throws:
      Exception
    • listBrokerConnections

      String listBrokerConnections()
    • startBrokerConnection

      void startBrokerConnection(String name) throws Exception
      Throws:
      Exception
    • stopBrokerConnection

      void stopBrokerConnection(String name) throws Exception
      Throws:
      Exception
    • createConnectorService

      void createConnectorService(String name, String factoryClass, Map<String,Object> parameters) throws Exception
      Throws:
      Exception
    • destroyConnectorService

      void destroyConnectorService(String name) throws Exception
      Throws:
      Exception
    • getConnectorServices

      String[] getConnectorServices()
    • forceFailover

      void forceFailover() throws Exception
      Throws:
      Exception
    • scaleDown

      void scaleDown(String connector) throws Exception
      Throws:
      Exception
    • listNetworkTopology

      String listNetworkTopology() throws Exception
      Throws:
      Exception
    • getAddressInfo

      String getAddressInfo(String address) throws ActiveMQAddressDoesNotExistException
      Throws:
      ActiveMQAddressDoesNotExistException
    • listBindingsForAddress

      String listBindingsForAddress(String address) throws Exception
      Throws:
      Exception
    • listAddresses

      String listAddresses(String separator) throws Exception
      Throws:
      Exception
    • listConnections

      String listConnections(String options, int page, int pageSize) throws Exception
      Throws:
      Exception
    • listSessions

      String listSessions(String options, int page, int pageSize) throws Exception
      Throws:
      Exception
    • listConsumers

      String listConsumers(String options, int page, int pageSize) throws Exception
      Throws:
      Exception
    • listProducers

      String listProducers(String options, int page, int pageSize) throws Exception
      Throws:
      Exception
    • listAddresses

      String listAddresses(String options, int page, int pageSize) throws Exception
      Throws:
      Exception
    • listQueues

      String listQueues(String options, int page, int pageSize) throws Exception
      Throws:
      Exception
    • getQueueNames

      String[] getQueueNames(String routingType) throws Exception
      Returns the names of the queues created on this server with the given routing-type.
      Throws:
      Exception
    • getClusterConnectionNames

      String[] getClusterConnectionNames()
      Returns the names of the cluster-connections deployed on this server.
    • addUser

      void addUser(String username, String password, String roles, boolean plaintext) throws Exception
      Add a user (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager)
      Parameters:
      username -
      password -
      roles -
      Throws:
      Exception
    • listUser

      String listUser(String username) throws Exception
      List the information about a user or all users if no username is supplied (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager).
      Parameters:
      username -
      Returns:
      JSON array of user and role information
      Throws:
      Exception
    • removeUser

      void removeUser(String username) throws Exception
      Remove a user (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager).
      Parameters:
      username -
      Throws:
      Exception
    • resetUser

      void resetUser(String username, String password, String roles) throws Exception
      Set new properties on an existing user (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager).
      Parameters:
      username -
      password -
      roles -
      Throws:
      Exception
    • resetUser

      void resetUser(String username, String password, String roles, boolean plaintext) throws Exception
      Set new properties on an existing user (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager).
      Parameters:
      username -
      password -
      roles -
      plaintext -
      Throws:
      Exception
    • reloadConfigurationFile

      void reloadConfigurationFile() throws Exception
      Throws:
      Exception
    • replay

      void replay(String address, String target, String filter) throws Exception
      Replays messages from all files in the retention folder that match an address and filter.
      Parameters:
      address -
      target -
      filter -
      Throws:
      Exception
    • replay

      void replay(String startScan, String endScan, String address, String target, String filter) throws Exception
      Replays messages from a configurable subset of the files in the retention folder that match an address and filter.
      Parameters:
      startScan -
      endScan -
      address -
      target -
      filter -
      Throws:
      Exception
    • stopEmbeddedWebServer

      void stopEmbeddedWebServer() throws Exception
      Throws:
      Exception
    • startEmbeddedWebServer

      void startEmbeddedWebServer() throws Exception
      Throws:
      Exception
    • restartEmbeddedWebServer

      void restartEmbeddedWebServer() throws Exception
      Throws:
      Exception
    • restartEmbeddedWebServer

      void restartEmbeddedWebServer(long timeout) throws Exception
      Throws:
      Exception
    • isEmbeddedWebServerStarted

      boolean isEmbeddedWebServerStarted()
    • rebuildPageCounters

      void rebuildPageCounters() throws Exception
      Throws:
      Exception
    • clearAuthenticationCache

      void clearAuthenticationCache() throws Exception
      Throws:
      Exception
    • clearAuthorizationCache

      void clearAuthorizationCache() throws Exception
      Throws:
      Exception
    • getAuthenticationSuccessCount

      long getAuthenticationSuccessCount()
    • getAuthenticationFailureCount

      long getAuthenticationFailureCount()
    • getAuthorizationSuccessCount

      long getAuthorizationSuccessCount()
    • getAuthorizationFailureCount

      long getAuthorizationFailureCount()