public class ActiveMQServerControlImpl extends AbstractControl implements ActiveMQServerControl, NotificationEmitter, NotificationListener
| Modifier and Type | Class and Description |
|---|---|
static class |
ActiveMQServerControlImpl.QueueTextFormatter |
storageManagerADDRESS_MEMORY_USAGE_DESCRIPTION, ADDRESS_MEMORY_USAGE_PERCENTAGE_DESCRIPTION, CONNECTION_COUNT_DESCRIPTION, DISK_STORE_USAGE_DESCRIPTION, TOTAL_CONNECTION_COUNT_DESCRIPTION| Constructor and Description |
|---|
ActiveMQServerControlImpl(PostOffice postOffice,
Configuration configuration,
ResourceManager resourceManager,
RemotingService remotingService,
ActiveMQServer messagingServer,
MessageCounterManager messageCounterManager,
StorageManager storageManager,
NotificationBroadcasterSupport broadcaster) |
| Modifier and Type | Method and Description |
|---|---|
void |
addAddressSettings(String address,
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)
adds a new address setting for a specific address
|
void |
addAddressSettings(String address,
String DLA,
String expiryAddress,
long expiryDelay,
boolean defaultLastValueQueue,
int maxDeliveryAttempts,
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)
adds a new address setting for a specific address
|
void |
addAddressSettings(String address,
String DLA,
String expiryAddress,
long expiryDelay,
boolean defaultLastValueQueue,
int maxDeliveryAttempts,
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)
adds a new address setting for a specific address
|
void |
addAddressSettings(String address,
String DLA,
String expiryAddress,
long expiryDelay,
boolean defaultLastValueQueue,
int maxDeliveryAttempts,
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)
adds a new address setting for a specific address
|
void |
addAddressSettings(String address,
String DLA,
String expiryAddress,
long expiryDelay,
boolean defaultLastValueQueue,
int maxDeliveryAttempts,
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,
long minExpiryDelay,
long maxExpiryDelay,
boolean enableMetrics)
adds a new address setting for a specific address
|
void |
addNotificationListener(NotificationListener listener,
NotificationFilter filter,
Object handback) |
void |
addSecuritySettings(String addressMatch,
String sendRoles,
String consumeRoles,
String createDurableQueueRoles,
String deleteDurableQueueRoles,
String createNonDurableQueueRoles,
String deleteNonDurableQueueRoles,
String manageRoles) |
void |
addSecuritySettings(String addressMatch,
String sendRoles,
String consumeRoles,
String createDurableQueueRoles,
String deleteDurableQueueRoles,
String createNonDurableQueueRoles,
String deleteNonDurableQueueRoles,
String manageRoles,
String browseRoles) |
void |
addSecuritySettings(String addressMatch,
String sendRoles,
String consumeRoles,
String createDurableQueueRoles,
String deleteDurableQueueRoles,
String createNonDurableQueueRoles,
String deleteNonDurableQueueRoles,
String manageRoles,
String browseRoles,
String createAddressRoles,
String deleteAddressRoles) |
void |
addUser(String username,
String password,
String roles,
boolean plaintext)
Add a user (only applicable when using the JAAS PropertiesLoginModule)
|
void |
buildSessionJSON(JsonArrayBuilder array,
ServerSession sess) |
boolean |
closeConnectionsForAddress(String ipAddress)
Closes all the connections of clients connected to this server which matches the specified IP address.
|
boolean |
closeConnectionsForUser(String userName)
Closes all the connections of sessions with a matching user name.
|
boolean |
closeConnectionWithID(String ID)
Closes the connection with the given id.
|
boolean |
closeConsumerConnectionsForAddress(String address)
Closes all the connections of clients connected to this server which matches the specified IP address.
|
boolean |
closeConsumerWithID(String sessionID,
String ID)
Closes the consumer with the given id.
|
boolean |
closeSessionWithID(String connectionID,
String ID)
Closes the session with the given id.
|
boolean |
commitPreparedTransaction(String transactionAsBase64)
Heuristically commits a prepared transaction.
|
String |
createAddress(String name,
String routingTypes) |
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 staticConnectorsOrDiscoveryGroup,
boolean useDiscoveryGroup,
boolean ha,
String user,
String password) |
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 staticConnectorsOrDiscoveryGroup,
boolean useDiscoveryGroup,
boolean ha,
String user,
String password) |
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 staticConnectorsOrDiscoveryGroup,
boolean useDiscoveryGroup,
boolean ha,
String user,
String password) |
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 staticConnectorsOrDiscoveryGroup,
boolean useDiscoveryGroup,
boolean ha,
String user,
String password) |
void |
createConnectorService(String name,
String factoryClass,
Map<String,Object> parameters) |
void |
createDivert(String name,
String routingName,
String address,
String forwardingAddress,
boolean exclusive,
String filterString,
String transformerClassName) |
void |
createDivert(String name,
String routingName,
String address,
String forwardingAddress,
boolean exclusive,
String filterString,
String transformerClassName,
Map<String,String> transformerProperties,
String routingType) |
void |
createDivert(String name,
String routingName,
String address,
String forwardingAddress,
boolean exclusive,
String filterString,
String transformerClassName,
String routingType) |
void |
createDivert(String name,
String routingName,
String address,
String forwardingAddress,
boolean exclusive,
String filterString,
String transformerClassName,
String transformerPropertiesAsJSON,
String routingType) |
String |
createQueue(String queueConfigurationAsJson)
Create a queue.
|
String |
createQueue(String queueConfigurationAsJson,
boolean ignoreIfExists)
Create a queue.
|
void |
createQueue(String address,
String name)
Create a durable queue.
|
void |
createQueue(String address,
String name,
boolean durable)
Create a queue.
|
void |
createQueue(String address,
String name,
boolean durable,
String routingType)
Create a queue.
|
void |
createQueue(String address,
String name,
String routingType)
Create a durable queue.
|
void |
createQueue(String address,
String name,
String filterStr,
boolean durable)
Create a queue.
|
void |
createQueue(String address,
String name,
String filterStr,
boolean durable,
String routingType)
Create a queue.
|
String |
createQueue(String address,
String routingType,
String name,
String filterStr,
boolean durable,
int maxConsumers,
boolean purgeOnNoConsumers,
boolean autoCreateAddress)
Create a queue.
|
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)
Create a queue.
|
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)
Create a queue.
|
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)
Create a queue.
|
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)
Create a queue.
|
void |
deleteAddress(String name) |
void |
deleteAddress(String name,
boolean force) |
void |
deployQueue(String address,
String name,
String filterString)
Deprecated.
|
void |
deployQueue(String address,
String name,
String filterStr,
boolean durable)
Deprecated.
|
void |
destroyBridge(String name) |
void |
destroyConnectorService(String name) |
void |
destroyDivert(String name) |
void |
destroyQueue(String name)
Destroys the queue corresponding to the specified name.
|
void |
destroyQueue(String name,
boolean removeConsumers)
Destroys the queue corresponding to the specified name.
|
void |
destroyQueue(String name,
boolean removeConsumers,
boolean autoDeleteAddress)
Destroys the queue corresponding to the specified name and delete it's address if there are no other queues
|
void |
disableMessageCounters()
Disables message counters for this server.
|
void |
enableMessageCounters()
Enables message counters for this server.
|
protected MBeanAttributeInfo[] |
fillMBeanAttributeInfo() |
protected MBeanOperationInfo[] |
fillMBeanOperationInfo() |
void |
forceFailover() |
boolean |
freezeReplication() |
String |
getAddressInfo(String address) |
long |
getAddressMemoryUsage()
Returns the memory used by all the addresses on broker for in-memory messages
|
int |
getAddressMemoryUsagePercentage()
Returns the memory used by all the addresses on broker as a percentage of the global-max-size
|
String[] |
getAddressNames()
Returns the addresses created on this server.
|
String |
getAddressSettingsAsJSON(String address)
returns the address settings as a JSON string
|
long |
getAuthenticationCacheSize()
Returns the runtime size of the authentication cache
|
long |
getAuthorizationCacheSize()
Returns the runtime size of the authorization cache
|
String |
getBindingsDirectory()
Returns the file system directory used to store bindings.
|
String[] |
getBridgeNames() |
String[] |
getClusterConnectionNames()
Returns the names of the cluster-connections deployed on this server.
|
int |
getConnectionCount()
Returns the number of clients connected to this server.
|
long |
getConnectionTTLOverride()
Returns the connection time to live.
|
Object[] |
getConnectors()
Returns the connectors configured for this server.
|
String |
getConnectorsAsJSON()
Returns the connectors configured for this server using JSON serialization.
|
String[] |
getConnectorServices() |
int |
getDiskScanPeriod()
Returns how often the server checks for disk space usage.
|
double |
getDiskStoreUsage()
Returns the percentage of total disk store use
|
String[] |
getDivertNames() |
long |
getGlobalMaxSize()
Returns the global max bytes limit for in-memory messages.
|
String |
getHAPolicy() |
int |
getIDCacheSize()
Returns the size of the cache for pre-creating message IDs.
|
String[] |
getIncomingInterceptorClassNames()
Returns the list of interceptors used by this server for incoming messages.
|
String[] |
getInterceptorClassNames() |
int |
getJournalBufferSize()
Returns the size of the internal buffer on the journal.
|
int |
getJournalBufferTimeout()
Returns the timeout (in nanoseconds) used to flush internal buffers on the journal.
|
int |
getJournalCompactMinFiles()
Returns the minimal number of journal files before compacting.
|
int |
getJournalCompactPercentage()
Return the percentage of live data before compacting the journal.
|
String |
getJournalDirectory()
Returns the file system directory used to store journal log.
|
int |
getJournalFileSize()
Returns the size (in bytes) of each journal files.
|
int |
getJournalMaxIO()
Returns the maximum number of write requests that can be in the AIO queue at any given time.
|
int |
getJournalMinFiles()
Returns the number of journal files to pre-create.
|
int |
getJournalPoolFiles()
Number of files that would be acceptable to keep on a pool
|
String |
getJournalType()
Returns the type of journal used by this server (either
NIO or ASYNCIO). |
String |
getLargeMessagesDirectory()
Returns the file system directory used to store large messages.
|
String |
getManagementAddress()
Returns the management address of this server.
|
String |
getManagementNotificationAddress()
Returns the management notification address of this server.
|
int |
getMaxDiskUsage()
Returns the disk use max limit.
|
int |
getMessageCounterMaxDayCount()
Returns the maximum number of days kept in memory for message counter.
|
long |
getMessageCounterSamplePeriod()
Returns the sample period (in milliseconds) to take message counter snapshot.
|
long |
getMessageExpiryScanPeriod()
Returns the frequency (in milliseconds) to scan messages to detect which messages
have expired.
|
long |
getMessageExpiryThreadPriority()
Deprecated.
|
String |
getNodeID()
Returns the node ID of this server.
|
MBeanNotificationInfo[] |
getNotificationInfo() |
String[] |
getOutgoingInterceptorClassNames()
Returns the list of interceptors used by this server for outgoing messages.
|
String |
getPagingDirectory()
Returns the file system directory used to store paging files.
|
String[] |
getQueueNames()
Returns the names of the queues created on this server.
|
String[] |
getQueueNames(String routingType)
Returns the names of the queues created on this server with the given routing-type.
|
Object[] |
getRoles(String addressMatch) |
String |
getRolesAsJSON(String addressMatch) |
int |
getScheduledThreadPoolMaxSize()
Returns the maximum number of threads in the scheduled thread pool.
|
long |
getSecurityInvalidationInterval()
Returns the interval time (in milliseconds) to invalidate security credentials.
|
int |
getThreadPoolMaxSize()
Returns the maximum number of threads in the thread pool.
|
long |
getTotalConnectionCount()
Returns the number of clients which have connected to this server since it was started.
|
long |
getTotalConsumerCount()
Returns the number of messages sent to this server since it was started.
|
long |
getTotalMessageCount()
Returns the number of messages in all queues on the server.
|
long |
getTotalMessagesAcknowledged()
Returns the number of messages sent to this server since it was started.
|
long |
getTotalMessagesAdded()
Returns the number of messages sent to this server since it was started.
|
long |
getTransactionTimeout()
Returns the timeout (in milliseconds) after which transactions is removed
from the resource manager after it was created.
|
long |
getTransactionTimeoutScanPeriod()
Returns the frequency (in milliseconds) to scan transactions to detect which transactions
have timed out.
|
String |
getUptime()
Returns the uptime of this server.
|
long |
getUptimeMillis()
Returns the uptime of this server.
|
String |
getVersion()
Returns this server's version.
|
boolean |
isActive() |
boolean |
isAsyncConnectionExecutionEnabled()
Returns whether code coming from connection is executed asynchronously or not.
|
boolean |
isBackup()
Returns
true if this server is a backup, false if it is a live server. |
boolean |
isClustered()
Returns whether this server is clustered.
|
boolean |
isCreateBindingsDir()
Returns whether the bindings directory is created on this server startup.
|
boolean |
isCreateJournalDir()
Returns whether the journal directory is created on this server startup.
|
boolean |
isFailoverOnServerShutdown()
returns if clients failover on a server shutdown
|
boolean |
isJournalSyncNonTransactional()
Returns whether the journal is synchronized when receiving non-transactional data.
|
boolean |
isJournalSyncTransactional()
Returns whether the journal is synchronized when receiving transactional data.
|
boolean |
isMessageCounterEnabled()
Returns whether message counter is enabled for this server.
|
boolean |
isPersistDeliveryCountBeforeDelivery()
Returns whether delivery count is persisted before messages are delivered to the consumers.
|
boolean |
isPersistenceEnabled()
Returns whether this server is using persistence and store data.
|
boolean |
isPersistIDCache()
Returns whether message ID cache is persisted.
|
boolean |
isReplicaSync()
Returns whether the initial replication synchronization process with the backup server is complete; applicable for
either the live or backup server.
|
boolean |
isSecurityEnabled()
Returns whether security is enabled for this server.
|
boolean |
isSharedStore()
Returns whether this server shares its data store with a corresponding live or backup server.
|
boolean |
isStarted()
Return whether this server is started.
|
boolean |
isWildcardRoutingEnabled()
Returns whether wildcard routing is supported by this server.
|
String |
listAddresses(String separator) |
String |
listAddresses(String options,
int page,
int pageSize) |
String |
listAllConsumersAsJSON()
Lists all the consumers connected to this server.
|
String |
listAllSessionsAsJSON()
Lists details about all sessions.
|
String |
listBindingsForAddress(String address) |
String |
listBrokerConnections() |
String[] |
listConnectionIDs()
Lists all the IDs of the connections connected to this server.
|
String |
listConnections(String options,
int page,
int pageSize) |
String |
listConnectionsAsJSON()
Lists all the connections connected to this server.
|
String |
listConsumers(String options,
int page,
int pageSize) |
String |
listConsumersAsJSON(String connectionID)
Lists all the consumers which belongs to the connection specified by the connectionID.
|
String[] |
listHeuristicCommittedTransactions()
List transactions which have been heuristically committed.
|
String[] |
listHeuristicRolledBackTransactions()
List transactions which have been heuristically rolled back.
|
String |
listNetworkTopology() |
String |
listPreparedTransactionDetailsAsHTML()
List all the prepared transaction, sorted by date,
oldest first, with details, in HTML format
|
String |
listPreparedTransactionDetailsAsHTML(TransactionDetailFactory factory) |
String |
listPreparedTransactionDetailsAsJSON()
List all the prepared transaction, sorted by date,
oldest first, with details, in text format.
|
String |
listPreparedTransactionDetailsAsJSON(TransactionDetailFactory factory) |
String[] |
listPreparedTransactions()
List all the prepared transaction, sorted by date, oldest first.
|
String |
listProducers(String options,
int page,
int pageSize) |
String |
listProducersInfoAsJSON() |
String |
listQueues(String options,
int page,
int pageSize) |
String[] |
listRemoteAddresses()
Lists the addresses of all the clients connected to this address.
|
String[] |
listRemoteAddresses(String ipAddress)
Lists the addresses of the clients connected to this address which matches the specified IP address.
|
String[] |
listSessions(String connectionID)
Lists all the sessions IDs for the specified connection ID.
|
String |
listSessions(String options,
int page,
int pageSize) |
String |
listSessionsAsJSON(String connectionID)
Lists details about all the sessions for the specified connection ID.
|
String[] |
listTargetAddresses(String sessionID) |
String |
listUser(String username)
List the information about a user or all users if no username is supplied (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager).
|
void |
onNotification(Notification notification) |
void |
removeAddressSettings(String addressMatch) |
void |
removeNotificationListener(NotificationListener listener) |
void |
removeNotificationListener(NotificationListener listener,
NotificationFilter filter,
Object handback) |
void |
removeSecuritySettings(String addressMatch) |
void |
removeUser(String username)
Remove a user (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager).
|
void |
resetAllMessageCounterHistories()
Reset histories for all message counters.
|
void |
resetAllMessageCounters()
Reset all message counters.
|
void |
resetUser(String username,
String password,
String roles)
Set new properties on an existing user (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager).
|
void |
resetUser(String username,
String password,
String roles,
boolean plaintext)
Set new properties on an existing user (only applicable when using the JAAS PropertiesLoginModule or the ActiveMQBasicSecurityManager).
|
boolean |
rollbackPreparedTransaction(String transactionAsBase64)
Heuristically rolls back a prepared transaction.
|
void |
scaleDown(String connector) |
void |
sendQueueInfoToQueue(String queueName,
String address) |
void |
setFailoverOnServerShutdown(boolean failoverOnServerShutdown)
do any clients failover on a server shutdown
|
void |
setMessageCounterMaxDayCount(int count)
Sets the maximum number of days kept in memory for message counter.
|
void |
setMessageCounterSamplePeriod(long newPeriod)
Sets the sample period to take message counter snapshot.
|
void |
startBrokerConnection(String name) |
void |
stopBrokerConnection(String name) |
String |
updateAddress(String name,
String routingTypes) |
void |
updateDivert(String name,
String forwardingAddress,
String filterString,
String transformerClassName,
Map<String,String> transformerProperties,
String routingType)
update a divert
|
void |
updateDuplicateIdCache(String address,
Object[] ids) |
String |
updateQueue(String queueConfigurationAsJson)
Update a queue.
|
String |
updateQueue(String name,
String routingType,
Integer maxConsumers,
Boolean purgeOnNoConsumers)
Deprecated.
|
String |
updateQueue(String name,
String routingType,
Integer maxConsumers,
Boolean purgeOnNoConsumers,
Boolean exclusive)
Deprecated.
|
String |
updateQueue(String name,
String routingType,
Integer maxConsumers,
Boolean purgeOnNoConsumers,
Boolean exclusive,
String user)
Update a queue
|
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)
Update a queue
|
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)
Update a queue
|
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)
Update a queue
|
blockOnIO, clearIO, getMBeanInfo, sendMessage, tcclCall, tcclInvokecacheMBeanInfo, getAttribute, getAttributes, getCachedMBeanInfo, getClassName, getConstructors, getDescription, getDescription, getDescription, getDescription, getDescription, getDescription, getDescription, getImpact, getImplementation, getImplementationClass, getMBeanInterface, getParameterName, getParameterName, invoke, postDeregister, postRegister, preDeregister, preRegister, setAttribute, setAttributes, setImplementationclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitlistDivertNamespublic ActiveMQServerControlImpl(PostOffice postOffice, Configuration configuration, ResourceManager resourceManager, RemotingService remotingService, ActiveMQServer messagingServer, MessageCounterManager messageCounterManager, StorageManager storageManager, NotificationBroadcasterSupport broadcaster) throws Exception
Exceptionpublic boolean isStarted()
ActiveMQServerControlisStarted in interface ActiveMQServerControlpublic String getVersion()
ActiveMQServerControlgetVersion in interface ActiveMQServerControlpublic boolean isActive()
isActive in interface ActiveMQServerControlpublic boolean isBackup()
ActiveMQServerControltrue if this server is a backup, false if it is a live server.
false.isBackup in interface ActiveMQServerControlpublic boolean isSharedStore()
ActiveMQServerControlisSharedStore in interface ActiveMQServerControlpublic String getBindingsDirectory()
ActiveMQServerControlgetBindingsDirectory in interface ActiveMQServerControlpublic String[] getInterceptorClassNames()
public String[] getIncomingInterceptorClassNames()
ActiveMQServerControlgetIncomingInterceptorClassNames in interface ActiveMQServerControlInterceptorpublic String[] getOutgoingInterceptorClassNames()
ActiveMQServerControlgetOutgoingInterceptorClassNames in interface ActiveMQServerControlInterceptorpublic int getJournalPoolFiles()
ActiveMQServerControlgetJournalPoolFiles in interface ActiveMQServerControlpublic int getJournalBufferSize()
ActiveMQServerControlgetJournalBufferSize in interface ActiveMQServerControlpublic int getJournalBufferTimeout()
ActiveMQServerControlgetJournalBufferTimeout in interface ActiveMQServerControlpublic void setFailoverOnServerShutdown(boolean failoverOnServerShutdown)
ActiveMQServerControlsetFailoverOnServerShutdown in interface ActiveMQServerControlpublic boolean isFailoverOnServerShutdown()
ActiveMQServerControlisFailoverOnServerShutdown in interface ActiveMQServerControlpublic int getJournalMaxIO()
ActiveMQServerControlgetJournalMaxIO in interface ActiveMQServerControlpublic String getJournalDirectory()
ActiveMQServerControlgetJournalDirectory in interface ActiveMQServerControlpublic int getJournalFileSize()
ActiveMQServerControlgetJournalFileSize in interface ActiveMQServerControlpublic int getJournalMinFiles()
ActiveMQServerControlgetJournalMinFiles in interface ActiveMQServerControlpublic int getJournalCompactMinFiles()
ActiveMQServerControlgetJournalCompactMinFiles in interface ActiveMQServerControlpublic int getJournalCompactPercentage()
ActiveMQServerControlgetJournalCompactPercentage in interface ActiveMQServerControlpublic boolean isPersistenceEnabled()
ActiveMQServerControlisPersistenceEnabled in interface ActiveMQServerControlpublic String getJournalType()
ActiveMQServerControlNIO or ASYNCIO).getJournalType in interface ActiveMQServerControlpublic String getPagingDirectory()
ActiveMQServerControlgetPagingDirectory in interface ActiveMQServerControlpublic int getScheduledThreadPoolMaxSize()
ActiveMQServerControlgetScheduledThreadPoolMaxSize in interface ActiveMQServerControlpublic int getThreadPoolMaxSize()
ActiveMQServerControlgetThreadPoolMaxSize in interface ActiveMQServerControlpublic long getSecurityInvalidationInterval()
ActiveMQServerControlgetSecurityInvalidationInterval in interface ActiveMQServerControlpublic boolean isClustered()
ActiveMQServerControlisClustered in interface ActiveMQServerControlpublic boolean isCreateBindingsDir()
ActiveMQServerControlisCreateBindingsDir in interface ActiveMQServerControlpublic boolean isCreateJournalDir()
ActiveMQServerControlisCreateJournalDir in interface ActiveMQServerControlpublic boolean isJournalSyncNonTransactional()
ActiveMQServerControlisJournalSyncNonTransactional in interface ActiveMQServerControlpublic boolean isJournalSyncTransactional()
ActiveMQServerControlisJournalSyncTransactional in interface ActiveMQServerControlpublic boolean isSecurityEnabled()
ActiveMQServerControlisSecurityEnabled in interface ActiveMQServerControlpublic boolean isAsyncConnectionExecutionEnabled()
ActiveMQServerControlisAsyncConnectionExecutionEnabled in interface ActiveMQServerControlpublic int getDiskScanPeriod()
ActiveMQServerControlgetDiskScanPeriod in interface ActiveMQServerControlpublic int getMaxDiskUsage()
ActiveMQServerControlgetMaxDiskUsage in interface ActiveMQServerControlpublic long getGlobalMaxSize()
ActiveMQServerControlgetGlobalMaxSize in interface ActiveMQServerControlpublic long getAddressMemoryUsage()
ActiveMQServerControlgetAddressMemoryUsage in interface ActiveMQServerControlpublic double getDiskStoreUsage()
ActiveMQServerControlgetDiskStoreUsage in interface ActiveMQServerControlpublic int getAddressMemoryUsagePercentage()
ActiveMQServerControlgetAddressMemoryUsagePercentage in interface ActiveMQServerControlpublic String getHAPolicy()
getHAPolicy in interface ActiveMQServerControlpublic long getAuthenticationCacheSize()
ActiveMQServerControlgetAuthenticationCacheSize in interface ActiveMQServerControlpublic long getAuthorizationCacheSize()
ActiveMQServerControlgetAuthorizationCacheSize in interface ActiveMQServerControlpublic boolean freezeReplication()
freezeReplication in interface ActiveMQServerControlpublic String createAddress(String name, String routingTypes) throws Exception
createAddress in interface ActiveMQServerControlExceptionpublic String updateAddress(String name, String routingTypes) throws Exception
updateAddress in interface ActiveMQServerControlExceptionpublic void deleteAddress(String name) throws Exception
deleteAddress in interface ActiveMQServerControlExceptionpublic void deleteAddress(String name, boolean force) throws Exception
deleteAddress in interface ActiveMQServerControlException@Deprecated public void deployQueue(String address, String name, String filterString) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
deployQueue in interface ActiveMQServerControladdress - address to bind the queue toname - name of the queuefilterString - of the queueException@Deprecated public void deployQueue(String address, String name, String filterStr, boolean durable) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
deployQueue in interface ActiveMQServerControladdress - address to bind the queue toname - name of the queuefilterStr - of the queuedurable - whether the queue is durableExceptionpublic void createQueue(String address, String name) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toname - name of the queueExceptionpublic void createQueue(String address, String name, String routingType) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toname - name of the queueroutingType - The routing type used for this address, MULTICAST or ANYCASTExceptionpublic void createQueue(String address, String name, boolean durable) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toname - name of the queuedurable - whether the queue is durableExceptionpublic void createQueue(String address, String name, boolean durable, String routingType) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toname - name of the queuedurable - whether the queue is durableroutingType - The routing type used for this address, MULTICAST or ANYCASTExceptionpublic void createQueue(String address, String name, String filterStr, boolean durable) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toname - name of the queuefilterStr - of the queuedurable - whether the queue is durableExceptionpublic void createQueue(String address, String name, String filterStr, boolean durable, String routingType) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toname - name of the queuefilterStr - of the queuedurable - whether the queue is durableroutingType - The routing type used for this address, MULTICAST or ANYCASTExceptionpublic String createQueue(String address, String routingType, String name, String filterStr, boolean durable, int maxConsumers, boolean purgeOnNoConsumers, boolean autoCreateAddress) throws Exception
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toroutingType - the routing type used for this address, MULTICAST or ANYCASTname - name of the queuefilterStr - filter of the queuedurable - is the queue durable?maxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsautoCreateAddress - create an address with default values should a matching address not be foundExceptionpublic 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
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toroutingType - the routing type used for this address, MULTICAST or ANYCASTname - name of the queuefilterStr - filter of the queuedurable - is the queue durable?maxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumerlastValue - use last-value semanticsconsumersBeforeDispatch - number of consumers needed before dispatch can startdelayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not metautoCreateAddress - create an address with default values should a matching address not be foundExceptionpublic 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
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toroutingType - the routing type used for this address, MULTICAST or ANYCASTname - name of the queuefilterStr - filter of the queuedurable - is the queue durable?maxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumerlastValue - use last-value semanticsconsumersBeforeDispatch - number of consumers needed before dispatch can startdelayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not metautoCreateAddress - create an address with default values should a matching address not be foundExceptionpublic 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
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toroutingType - the routing type used for this address, MULTICAST or ANYCASTname - name of the queuefilterStr - filter of the queuedurable - is the queue durable?maxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumerlastValue - use last-value semanticsconsumersBeforeDispatch - number of consumers needed before dispatch can startdelayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not metautoCreateAddress - create an address with default values should a matching address not be foundExceptionpublic 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
ActiveMQServerControladdress is null it will be defaulted to name.
ActiveMQQueueExistsException) exception if the queue already exits.createQueue in interface ActiveMQServerControladdress - address to bind the queue toroutingType - the routing type used for this address, MULTICAST or ANYCASTname - name of the queuefilterStr - filter of the queuedurable - is the queue durable?maxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumerlastValue - use last-value semanticsconsumersBeforeDispatch - number of consumers needed before dispatch can startdelayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not metautoCreateAddress - create an address with default values should a matching address not be foundringSize - the size this queue should maintain according to ring semanticsExceptionpublic String createQueue(String queueConfigurationAsJson) throws Exception
ActiveMQServerControlActiveMQQueueExistsException) exception if the queue already exists.createQueue in interface ActiveMQServerControlqueueConfigurationAsJson - the configuration of the queue in JSON formatExceptionpublic String createQueue(String queueConfigurationAsJson, boolean ignoreIfExists) throws Exception
ActiveMQServerControlActiveMQQueueExistsException) exception if the queue already exists and ignoreIfExists is false.createQueue in interface ActiveMQServerControlqueueConfigurationAsJson - the configuration of the queue in JSON formatignoreIfExists - whether or not to simply return without an exception if the queue existsExceptionpublic String updateQueue(String queueConfigurationAsJson) throws Exception
ActiveMQServerControlupdateQueue in interface ActiveMQServerControlqueueConfigurationAsJson - the configuration of the queue in JSON formatException@Deprecated public String updateQueue(String name, String routingType, Integer maxConsumers, Boolean purgeOnNoConsumers) throws Exception
ActiveMQServerControlupdateQueue in interface ActiveMQServerControlname - name of the queueroutingType - the routing type used for this address, MULTICAST or ANYCASTmaxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsException@Deprecated public String updateQueue(String name, String routingType, Integer maxConsumers, Boolean purgeOnNoConsumers, Boolean exclusive) throws Exception
ActiveMQServerControlupdateQueue in interface ActiveMQServerControlname - name of the queueroutingType - the routing type used for this address, MULTICAST or ANYCASTmaxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumerExceptionpublic String updateQueue(String name, String routingType, Integer maxConsumers, Boolean purgeOnNoConsumers, Boolean exclusive, String user) throws Exception
ActiveMQServerControlupdateQueue in interface ActiveMQServerControlname - name of the queueroutingType - the routing type used for this address, MULTICAST or ANYCASTmaxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumeruser - the user associated with this queueExceptionpublic 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
ActiveMQServerControlupdateQueue in interface ActiveMQServerControlname - name of the queueroutingType - the routing type used for this address, MULTICAST or ANYCASTfilter - the filter to use on the queuemaxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumergroupRebalance - if the queue should rebalance groups when a consumer is addedgroupBuckets - number of buckets that should be used for message groups, -1 (default) is unlimited, and groups by raw key insteadnonDestructive - If the queue is non-destructiveconsumersBeforeDispatch - number of consumers needed before dispatch can startdelayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not metuser - the user associated with this queueExceptionpublic 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
ActiveMQServerControlupdateQueue in interface ActiveMQServerControlname - name of the queueroutingType - the routing type used for this address, MULTICAST or ANYCASTfilter - the filter to use on the queuemaxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumergroupRebalance - if the queue should rebalance groups when a consumer is addedgroupBuckets - number of buckets that should be used for message groups, -1 (default) is unlimited, and groups by raw key insteadgroupFirstKey - key used to mark a message is first in a group for a consumernonDestructive - If the queue is non-destructiveconsumersBeforeDispatch - number of consumers needed before dispatch can startdelayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not metuser - the user associated with this queueExceptionpublic 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
ActiveMQServerControlupdateQueue in interface ActiveMQServerControlname - name of the queueroutingType - the routing type used for this address, MULTICAST or ANYCASTfilter - the filter to use on the queuemaxConsumers - the maximum number of consumers allowed on this queue at any one timepurgeOnNoConsumers - delete this queue when the last consumer disconnectsexclusive - if the queue should route exclusively to one consumergroupRebalance - if the queue should rebalance groups when a consumer is addedgroupBuckets - number of buckets that should be used for message groups, -1 (default) is unlimited, and groups by raw key insteadgroupFirstKey - key used to mark a message is first in a group for a consumernonDestructive - If the queue is non-destructiveconsumersBeforeDispatch - number of consumers needed before dispatch can startdelayBeforeDispatch - delay to wait before dispatching if number of consumers before dispatch is not metuser - the user associated with this queueringSize - the size this queue should maintain according to ring semanticsExceptionpublic String[] getQueueNames()
ActiveMQServerControlgetQueueNames in interface ActiveMQServerControlpublic String[] getQueueNames(String routingType)
ActiveMQServerControlgetQueueNames in interface ActiveMQServerControlpublic String[] getClusterConnectionNames()
ActiveMQServerControlgetClusterConnectionNames in interface ActiveMQServerControlpublic String getUptime()
ActiveMQServerControlgetUptime in interface ActiveMQServerControlpublic long getUptimeMillis()
ActiveMQServerControlgetUptimeMillis in interface ActiveMQServerControlpublic boolean isReplicaSync()
ActiveMQServerControlisReplicaSync in interface ActiveMQServerControlpublic String[] getAddressNames()
ActiveMQServerControlgetAddressNames in interface ActiveMQServerControlpublic void destroyQueue(String name, boolean removeConsumers, boolean autoDeleteAddress) throws Exception
ActiveMQServerControldestroyQueue in interface ActiveMQServerControlExceptionpublic void destroyQueue(String name, boolean removeConsumers) throws Exception
ActiveMQServerControldestroyQueue in interface ActiveMQServerControlExceptionpublic void destroyQueue(String name) throws Exception
ActiveMQServerControldestroyQueue in interface ActiveMQServerControlExceptionpublic String getAddressInfo(String address) throws ActiveMQAddressDoesNotExistException
getAddressInfo in interface ActiveMQServerControlActiveMQAddressDoesNotExistExceptionpublic String listBindingsForAddress(String address) throws Exception
listBindingsForAddress in interface ActiveMQServerControlExceptionpublic String listAddresses(String separator) throws Exception
listAddresses in interface ActiveMQServerControlExceptionpublic int getConnectionCount()
ActiveMQServerControlgetConnectionCount in interface ActiveMQServerControlpublic long getTotalConnectionCount()
ActiveMQServerControlgetTotalConnectionCount in interface ActiveMQServerControlpublic long getTotalMessageCount()
ActiveMQServerControlgetTotalMessageCount in interface ActiveMQServerControlpublic long getTotalMessagesAdded()
ActiveMQServerControlgetTotalMessagesAdded in interface ActiveMQServerControlpublic long getTotalMessagesAcknowledged()
ActiveMQServerControlgetTotalMessagesAcknowledged in interface ActiveMQServerControlpublic long getTotalConsumerCount()
ActiveMQServerControlgetTotalConsumerCount in interface ActiveMQServerControlpublic void enableMessageCounters()
ActiveMQServerControlenableMessageCounters in interface ActiveMQServerControlpublic void disableMessageCounters()
ActiveMQServerControldisableMessageCounters in interface ActiveMQServerControlpublic void resetAllMessageCounters()
ActiveMQServerControlresetAllMessageCounters in interface ActiveMQServerControlpublic void resetAllMessageCounterHistories()
ActiveMQServerControlresetAllMessageCounterHistories in interface ActiveMQServerControlpublic boolean isMessageCounterEnabled()
ActiveMQServerControlisMessageCounterEnabled in interface ActiveMQServerControlpublic long getMessageCounterSamplePeriod()
ActiveMQServerControlgetMessageCounterSamplePeriod in interface ActiveMQServerControlpublic void setMessageCounterSamplePeriod(long newPeriod)
ActiveMQServerControlsetMessageCounterSamplePeriod in interface ActiveMQServerControlnewPeriod - value must be greater than 1000mspublic int getMessageCounterMaxDayCount()
ActiveMQServerControlgetMessageCounterMaxDayCount in interface ActiveMQServerControlpublic void setMessageCounterMaxDayCount(int count)
ActiveMQServerControlsetMessageCounterMaxDayCount in interface ActiveMQServerControlcount - value must be greater than 0public String[] listPreparedTransactions()
ActiveMQServerControllistPreparedTransactions in interface ActiveMQServerControlActiveMQServerControl.commitPreparedTransaction(String),
ActiveMQServerControl.rollbackPreparedTransaction(String)public String listPreparedTransactionDetailsAsJSON() throws Exception
ActiveMQServerControllistPreparedTransactionDetailsAsJSON in interface ActiveMQServerControlExceptionpublic String listPreparedTransactionDetailsAsJSON(TransactionDetailFactory factory) throws Exception
Exceptionpublic String listPreparedTransactionDetailsAsHTML() throws Exception
ActiveMQServerControllistPreparedTransactionDetailsAsHTML in interface ActiveMQServerControlExceptionpublic String listPreparedTransactionDetailsAsHTML(TransactionDetailFactory factory) throws Exception
Exceptionpublic String[] listHeuristicCommittedTransactions()
ActiveMQServerControllistHeuristicCommittedTransactions in interface ActiveMQServerControlpublic String[] listHeuristicRolledBackTransactions()
ActiveMQServerControllistHeuristicRolledBackTransactions in interface ActiveMQServerControlpublic boolean commitPreparedTransaction(String transactionAsBase64) throws Exception
ActiveMQServerControlcommitPreparedTransaction in interface ActiveMQServerControltransactionAsBase64 - base 64 representation of a prepare transactiontrue if the transaction was successfully committed, false elseExceptionActiveMQServerControl.listPreparedTransactions()public boolean rollbackPreparedTransaction(String transactionAsBase64) throws Exception
ActiveMQServerControlrollbackPreparedTransaction in interface ActiveMQServerControltransactionAsBase64 - base 64 representation of a prepare transactiontrue if the transaction was successfully rolled back, false elseExceptionActiveMQServerControl.listPreparedTransactions()public String[] listRemoteAddresses()
ActiveMQServerControllistRemoteAddresses in interface ActiveMQServerControlpublic String[] listRemoteAddresses(String ipAddress)
ActiveMQServerControllistRemoteAddresses in interface ActiveMQServerControlpublic boolean closeConnectionsForAddress(String ipAddress)
ActiveMQServerControlcloseConnectionsForAddress in interface ActiveMQServerControlpublic boolean closeConsumerConnectionsForAddress(String address)
ActiveMQServerControlcloseConsumerConnectionsForAddress in interface ActiveMQServerControlpublic boolean closeConnectionsForUser(String userName)
ActiveMQServerControlcloseConnectionsForUser in interface ActiveMQServerControlpublic boolean closeConnectionWithID(String ID)
ActiveMQServerControlcloseConnectionWithID in interface ActiveMQServerControlpublic boolean closeSessionWithID(String connectionID, String ID) throws Exception
ActiveMQServerControlcloseSessionWithID in interface ActiveMQServerControlExceptionpublic boolean closeConsumerWithID(String sessionID, String ID) throws Exception
ActiveMQServerControlcloseConsumerWithID in interface ActiveMQServerControlExceptionpublic String[] listConnectionIDs()
ActiveMQServerControllistConnectionIDs in interface ActiveMQServerControlpublic String[] listSessions(String connectionID)
ActiveMQServerControllistSessions in interface ActiveMQServerControlpublic String listProducersInfoAsJSON() throws Exception
listProducersInfoAsJSON in interface ActiveMQServerControlExceptionpublic String listConnections(String options, int page, int pageSize) throws Exception
listConnections in interface ActiveMQServerControlExceptionpublic String listSessions(String options, int page, int pageSize) throws Exception
listSessions in interface ActiveMQServerControlExceptionpublic String listConsumers(String options, int page, int pageSize) throws Exception
listConsumers in interface ActiveMQServerControlExceptionpublic String listAddresses(String options, int page, int pageSize) throws Exception
listAddresses in interface ActiveMQServerControlExceptionpublic String listQueues(String options, int page, int pageSize) throws Exception
listQueues in interface ActiveMQServerControlExceptionpublic String listProducers(String options, int page, int pageSize) throws Exception
listProducers in interface ActiveMQServerControlExceptionpublic String listConnectionsAsJSON() throws Exception
ActiveMQServerControl
[
{
"creationTime": 1469240429671,
"sessionCount": 1,
"implementation": "RemotingConnectionImpl",
"connectionID": "1648309901",
"clientAddress": "\/127.0.0.1:57649"
}
]
listConnectionsAsJSON in interface ActiveMQServerControlExceptionpublic String listSessionsAsJSON(String connectionID) throws Exception
ActiveMQServerControl
[
{
"principal": "myUser",
"creationTime": 1469240773157,
"consumerCount": 0,
"sessionID": "d33d10db-507c-11e6-9e47-e8b1fc439540"
}
]
listSessionsAsJSON in interface ActiveMQServerControlExceptionpublic String listAllSessionsAsJSON() throws Exception
ActiveMQServerControl
[
{
"sessionID":"e71d61d7-2176-11e8-9057-a0afbd82eaba",
"creationTime":1520365520212,
"consumerCount":1,
"principal":"myUser"
},
{
"sessionID":"e718a6e6-2176-11e8-9057-a0afbd82eaba",
"creationTime":1520365520191,
"consumerCount":0,
"principal":"guest"
}
]
listAllSessionsAsJSON in interface ActiveMQServerControlExceptionpublic void buildSessionJSON(JsonArrayBuilder array, ServerSession sess)
public String listConsumersAsJSON(String connectionID) throws Exception
ActiveMQServerControl
[
{
"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"
}
]
listConsumersAsJSON in interface ActiveMQServerControlExceptionpublic String listAllConsumersAsJSON() throws Exception
ActiveMQServerControl
[
{
"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"
}
]
listAllConsumersAsJSON in interface ActiveMQServerControlExceptionpublic Object[] getConnectors() throws Exception
ActiveMQServerControlgetConnectors in interface ActiveMQServerControlExceptionpublic String getConnectorsAsJSON() throws Exception
ActiveMQServerControlgetConnectorsAsJSON in interface ActiveMQServerControlExceptionpublic void addSecuritySettings(String addressMatch, String sendRoles, String consumeRoles, String createDurableQueueRoles, String deleteDurableQueueRoles, String createNonDurableQueueRoles, String deleteNonDurableQueueRoles, String manageRoles) throws Exception
addSecuritySettings in interface ActiveMQServerControlExceptionpublic void addSecuritySettings(String addressMatch, String sendRoles, String consumeRoles, String createDurableQueueRoles, String deleteDurableQueueRoles, String createNonDurableQueueRoles, String deleteNonDurableQueueRoles, String manageRoles, String browseRoles) throws Exception
addSecuritySettings in interface ActiveMQServerControlExceptionpublic 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
addSecuritySettings in interface ActiveMQServerControlExceptionpublic void removeSecuritySettings(String addressMatch) throws Exception
removeSecuritySettings in interface ActiveMQServerControlExceptionpublic Object[] getRoles(String addressMatch) throws Exception
getRoles in interface ActiveMQServerControlExceptionpublic String getRolesAsJSON(String addressMatch) throws Exception
getRolesAsJSON in interface ActiveMQServerControlExceptionpublic String getAddressSettingsAsJSON(String address) throws Exception
ActiveMQServerControlgetAddressSettingsAsJSON in interface ActiveMQServerControlExceptionpublic void addAddressSettings(String address, 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
ActiveMQServerControladdAddressSettings in interface ActiveMQServerControlExceptionpublic void addAddressSettings(String address, String DLA, String expiryAddress, long expiryDelay, boolean defaultLastValueQueue, int maxDeliveryAttempts, 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
ActiveMQServerControladdAddressSettings in interface ActiveMQServerControlExceptionpublic void addAddressSettings(String address, String DLA, String expiryAddress, long expiryDelay, boolean defaultLastValueQueue, int maxDeliveryAttempts, 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
ActiveMQServerControladdAddressSettings in interface ActiveMQServerControlExceptionpublic void addAddressSettings(String address, String DLA, String expiryAddress, long expiryDelay, boolean defaultLastValueQueue, int maxDeliveryAttempts, 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
ActiveMQServerControladdAddressSettings in interface ActiveMQServerControlExceptionpublic void addAddressSettings(String address, String DLA, String expiryAddress, long expiryDelay, boolean defaultLastValueQueue, int maxDeliveryAttempts, 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, long minExpiryDelay, long maxExpiryDelay, boolean enableMetrics) throws Exception
ActiveMQServerControladdAddressSettings in interface ActiveMQServerControlExceptionpublic void removeAddressSettings(String addressMatch) throws Exception
removeAddressSettings in interface ActiveMQServerControlExceptionpublic void sendQueueInfoToQueue(String queueName, String address) throws Exception
Exceptionpublic String[] getDivertNames()
getDivertNames in interface ActiveMQServerControlpublic void createDivert(String name, String routingName, String address, String forwardingAddress, boolean exclusive, String filterString, String transformerClassName) throws Exception
createDivert in interface ActiveMQServerControlExceptionpublic void createDivert(String name, String routingName, String address, String forwardingAddress, boolean exclusive, String filterString, String transformerClassName, String routingType) throws Exception
createDivert in interface ActiveMQServerControlExceptionpublic void createDivert(String name, String routingName, String address, String forwardingAddress, boolean exclusive, String filterString, String transformerClassName, String transformerPropertiesAsJSON, String routingType) throws Exception
createDivert in interface ActiveMQServerControlExceptionpublic void createDivert(String name, String routingName, String address, String forwardingAddress, boolean exclusive, String filterString, String transformerClassName, Map<String,String> transformerProperties, String routingType) throws Exception
createDivert in interface ActiveMQServerControlExceptionpublic void updateDivert(String name, String forwardingAddress, String filterString, String transformerClassName, Map<String,String> transformerProperties, String routingType) throws Exception
ActiveMQServerControlupdateDivert in interface ActiveMQServerControlExceptionpublic void destroyDivert(String name) throws Exception
destroyDivert in interface ActiveMQServerControlExceptionpublic String[] getBridgeNames()
getBridgeNames in interface ActiveMQServerControlpublic 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 staticConnectorsOrDiscoveryGroup, boolean useDiscoveryGroup, boolean ha, String user, String password) throws Exception
createBridge in interface ActiveMQServerControlExceptionpublic 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 staticConnectorsOrDiscoveryGroup, boolean useDiscoveryGroup, boolean ha, String user, String password) throws Exception
createBridge in interface ActiveMQServerControlExceptionpublic 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 staticConnectorsOrDiscoveryGroup, boolean useDiscoveryGroup, boolean ha, String user, String password) throws Exception
createBridge in interface ActiveMQServerControlExceptionpublic 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 staticConnectorsOrDiscoveryGroup, boolean useDiscoveryGroup, boolean ha, String user, String password) throws Exception
createBridge in interface ActiveMQServerControlExceptionpublic String listBrokerConnections()
listBrokerConnections in interface ActiveMQServerControlpublic void startBrokerConnection(String name) throws Exception
startBrokerConnection in interface ActiveMQServerControlExceptionpublic void stopBrokerConnection(String name) throws Exception
stopBrokerConnection in interface ActiveMQServerControlExceptionpublic void destroyBridge(String name) throws Exception
destroyBridge in interface ActiveMQServerControlExceptionpublic void createConnectorService(String name, String factoryClass, Map<String,Object> parameters) throws Exception
createConnectorService in interface ActiveMQServerControlExceptionpublic void destroyConnectorService(String name) throws Exception
destroyConnectorService in interface ActiveMQServerControlExceptionpublic String[] getConnectorServices()
getConnectorServices in interface ActiveMQServerControlpublic void forceFailover()
throws Exception
forceFailover in interface ActiveMQServerControlExceptionpublic void updateDuplicateIdCache(String address, Object[] ids) throws Exception
Exceptionpublic void scaleDown(String connector) throws Exception
scaleDown in interface ActiveMQServerControlExceptionpublic String listNetworkTopology() throws Exception
listNetworkTopology in interface ActiveMQServerControlExceptionpublic void removeNotificationListener(NotificationListener listener, NotificationFilter filter, Object handback) throws ListenerNotFoundException
removeNotificationListener in interface NotificationEmitterListenerNotFoundExceptionpublic void removeNotificationListener(NotificationListener listener) throws ListenerNotFoundException
removeNotificationListener in interface NotificationBroadcasterListenerNotFoundExceptionpublic void addNotificationListener(NotificationListener listener, NotificationFilter filter, Object handback) throws IllegalArgumentException
addNotificationListener in interface NotificationBroadcasterIllegalArgumentExceptionpublic MBeanNotificationInfo[] getNotificationInfo()
getNotificationInfo in interface NotificationBroadcasterpublic long getConnectionTTLOverride()
ActiveMQServerControlgetConnectionTTLOverride in interface ActiveMQServerControlpublic int getIDCacheSize()
ActiveMQServerControlgetIDCacheSize in interface ActiveMQServerControlpublic String getLargeMessagesDirectory()
ActiveMQServerControlgetLargeMessagesDirectory in interface ActiveMQServerControlpublic String getManagementAddress()
ActiveMQServerControlgetManagementAddress in interface ActiveMQServerControlpublic String getNodeID()
ActiveMQServerControlgetNodeID in interface ActiveMQServerControlpublic String getManagementNotificationAddress()
ActiveMQServerControlgetManagementNotificationAddress in interface ActiveMQServerControlpublic long getMessageExpiryScanPeriod()
ActiveMQServerControlgetMessageExpiryScanPeriod in interface ActiveMQServerControl@Deprecated public long getMessageExpiryThreadPriority()
ActiveMQServerControlgetMessageExpiryThreadPriority in interface ActiveMQServerControlpublic long getTransactionTimeout()
ActiveMQServerControlgetTransactionTimeout in interface ActiveMQServerControlpublic long getTransactionTimeoutScanPeriod()
ActiveMQServerControlgetTransactionTimeoutScanPeriod in interface ActiveMQServerControlpublic boolean isPersistDeliveryCountBeforeDelivery()
ActiveMQServerControlisPersistDeliveryCountBeforeDelivery in interface ActiveMQServerControlpublic boolean isPersistIDCache()
ActiveMQServerControlisPersistIDCache in interface ActiveMQServerControlpublic boolean isWildcardRoutingEnabled()
ActiveMQServerControlisWildcardRoutingEnabled in interface ActiveMQServerControlprotected MBeanOperationInfo[] fillMBeanOperationInfo()
fillMBeanOperationInfo in class AbstractControlprotected MBeanAttributeInfo[] fillMBeanAttributeInfo()
fillMBeanAttributeInfo in class AbstractControlpublic void onNotification(Notification notification)
onNotification in interface NotificationListenerpublic void addUser(String username, String password, String roles, boolean plaintext) throws Exception
ActiveMQServerControladdUser in interface ActiveMQServerControlExceptionpublic String listUser(String username) throws Exception
ActiveMQServerControllistUser in interface ActiveMQServerControlExceptionpublic void removeUser(String username) throws Exception
ActiveMQServerControlremoveUser in interface ActiveMQServerControlExceptionpublic void resetUser(String username, String password, String roles, boolean plaintext) throws Exception
ActiveMQServerControlresetUser in interface ActiveMQServerControlExceptionpublic void resetUser(String username, String password, String roles) throws Exception
ActiveMQServerControlresetUser in interface ActiveMQServerControlExceptionCopyright © 2021 JBoss by Red Hat. All rights reserved.