void |
AbortSlowConsumerStrategyViewMBean.abortConnection(String objectNameOfConsumerToAbort) |
|
void |
AbortSlowConsumerStrategyViewMBean.abortConnection(ObjectName consumerToAbort) |
|
void |
AbortSlowConsumerStrategyViewMBean.abortConsumer(String objectNameOfConsumerToAbort) |
|
void |
AbortSlowConsumerStrategyViewMBean.abortConsumer(ObjectName consumerToAbort) |
|
String |
BrokerViewMBean.addConnector(String discoveryAddress) |
|
String |
BrokerViewMBean.addNetworkConnector(String discoveryAddress) |
|
void |
BrokerViewMBean.addQueue(String name) |
Adds a Queue destination to the broker.
|
void |
BrokerViewMBean.addTopic(String name) |
Adds a Topic destination to the broker.
|
CompositeData[] |
DestinationViewMBean.browse() |
|
CompositeData[] |
DestinationViewMBean.browse(String selector) |
|
CompositeData[] |
DurableSubscriptionViewMBean.browse() |
Browse messages for this durable subscriber
|
TabularData |
DestinationViewMBean.browseAsTable() |
|
TabularData |
DestinationViewMBean.browseAsTable(String selector) |
|
TabularData |
DurableSubscriptionViewMBean.browseAsTable() |
Browse messages for this durable subscriber
|
List<?> |
DestinationViewMBean.browseMessages() |
Browses the current destination returning a list of messages
|
List<?> |
DestinationViewMBean.browseMessages(String selector) |
Browses the current destination with the given selector returning a list
of messages
|
int |
ConnectorViewMBean.connectionCount() |
|
int |
QueueViewMBean.copyMatchingMessagesTo(String selector,
String destinationName) |
Copies the messages matching the given selector
|
int |
QueueViewMBean.copyMatchingMessagesTo(String selector,
String destinationName,
int maximumMessages) |
Copies the messages matching the given selector up to the maximum number
of matched messages
|
boolean |
QueueViewMBean.copyMessageTo(String messageId,
String destinationName) |
Copies a given message to another destination.
|
ObjectName |
BrokerViewMBean.createDurableSubscriber(String clientId,
String subscriberName,
String topicName,
String selector) |
Creates a new durable topic subscriber
|
int |
DurableSubscriptionViewMBean.cursorSize() |
|
int |
QueueViewMBean.cursorSize() |
|
boolean |
VirtualDestinationSelectorCacheViewMBean.deleteAllSelectorsForDestination(String destinationName) |
|
boolean |
VirtualDestinationSelectorCacheViewMBean.deleteSelectorForDestination(String destinationName,
String selector) |
|
void |
DurableSubscriptionViewMBean.destroy() |
Destroys the durable subscription so that messages will no longer be
stored for this subscription
|
void |
BrokerViewMBean.destroyDurableSubscriber(String clientId,
String subscriberName) |
Destroys a durable subscriber
|
void |
BrokerViewMBean.disableStatistics() |
|
void |
ConnectorViewMBean.disableStatistics() |
disable statistics gathering
|
boolean |
DurableSubscriptionViewMBean.doesCursorHaveMessagesBuffered() |
|
boolean |
QueueViewMBean.doesCursorHaveMessagesBuffered() |
|
boolean |
DurableSubscriptionViewMBean.doesCursorHaveSpace() |
|
boolean |
QueueViewMBean.doesCursorHaveSpace() |
|
void |
BrokerViewMBean.enableStatistics() |
|
void |
ConnectorViewMBean.enableStatistics() |
enable statistics gathering
|
void |
BrokerViewMBean.gc() |
The Broker will flush it's caches so that the garbage collector can
reclaim more memory.
|
int |
ConnectionViewMBean.getActiveTransactionCount() |
Returns the number of active transactions established on this Connection.
|
int |
NetworkConnectorViewMBean.getAdvisoryPrefetchSize() |
|
TabularData |
JobSchedulerViewMBean.getAllJobs() |
Get all the outstanding Jobs that are scheduled in this scheduler store.
|
TabularData |
JobSchedulerViewMBean.getAllJobs(String start,
String finish) |
Get all outstanding jobs due to run between start and finish time range.
|
double |
DestinationViewMBean.getAverageBlockedTime() |
|
double |
DestinationViewMBean.getAverageEnqueueTime() |
|
long |
BrokerViewMBean.getAverageMessageSize() |
|
long |
DestinationViewMBean.getAverageMessageSize() |
|
long |
DestinationViewMBean.getBlockedProducerWarningInterval() |
|
long |
DestinationViewMBean.getBlockedSends() |
|
byte[] |
RecoveredXATransactionViewMBean.getBranchQualifier() |
|
String |
BrokerViewMBean.getBrokerId() |
|
String |
BrokerViewMBean.getBrokerName() |
|
String |
BrokerViewMBean.getBrokerVersion() |
|
long |
AbortSlowConsumerStrategyViewMBean.getCheckPeriod() |
|
String |
ConnectionViewMBean.getClientId() |
Returns the client identifier for this connection
|
String |
ProducerViewMBean.getClientId() |
|
String |
SubscriptionViewMBean.getClientId() |
|
ObjectName |
SubscriptionViewMBean.getConnection() |
Returns the ObjectName of the Connection that created this Subscription.
|
String |
ProducerViewMBean.getConnectionId() |
|
String |
SubscriptionViewMBean.getConnectionId() |
|
long |
SubscriptionViewMBean.getConsumedCount() |
|
long |
DestinationViewMBean.getConsumerCount() |
Returns the number of consumers subscribed this destination.
|
ObjectName[] |
ConnectionViewMBean.getConsumers() |
Returns the ObjectNames of all the Consumers created by this Connection.
|
long |
NetworkDestinationViewMBean.getCount() |
Returns the number of messages that have been sent to the destination.
|
String |
HealthViewMBean.getCurrentStatus() |
Warning, this method only return a value if the health or healthList method has previously
been called.
|
long |
DurableSubscriptionViewMBean.getCursorMemoryUsage() |
|
long |
QueueViewMBean.getCursorMemoryUsage() |
|
int |
DurableSubscriptionViewMBean.getCursorPercentUsage() |
|
int |
QueueViewMBean.getCursorPercentUsage() |
|
String |
PersistenceAdapterViewMBean.getData() |
|
String |
BrokerViewMBean.getDataDirectory() |
|
int |
JobSchedulerViewMBean.getDelayedMessageCount() |
Get the number of delayed messages.
|
long |
DestinationViewMBean.getDequeueCount() |
Returns the number of messages that have been acknowledged from the
destination.
|
long |
SubscriptionViewMBean.getDequeueCounter() |
|
String |
ProducerViewMBean.getDestinationName() |
|
String |
SubscriptionViewMBean.getDestinationName() |
|
int |
TopicSubscriptionViewMBean.getDiscardedCount() |
|
long |
DestinationViewMBean.getDispatchCount() |
Returns the number of messages that have been delivered (potentially not
acknowledged) to consumers.
|
long |
SubscriptionViewMBean.getDispatchedCounter() |
|
int |
SubscriptionViewMBean.getDispatchedQueueSize() |
|
int |
ConnectionViewMBean.getDispatchQueueSize() |
Returns the number of messages to be dispatched to this connection
|
long |
DestinationViewMBean.getDuplicateFromStoreCount() |
Returns the number of duplicate messages that have been paged-in
from the store.
|
ObjectName[] |
BrokerViewMBean.getDurableTopicSubscribers() |
|
ObjectName[] |
BrokerViewMBean.getDynamicDestinationProducers() |
|
long |
DestinationViewMBean.getEnqueueCount() |
Returns the number of messages that have been sent to the destination.
|
long |
SubscriptionViewMBean.getEnqueueCounter() |
|
int |
JobSchedulerViewMBean.getExecutionCount(String jobId) |
Gets the number of times a scheduled Job has been executed.
|
long |
DestinationViewMBean.getExpiredCount() |
Returns the number of messages that have expired
|
int |
RecoveredXATransactionViewMBean.getFormatId() |
|
long |
DestinationViewMBean.getForwardCount() |
Returns the number of messages that have been acknowledged by network subscriptions from the
destination.
|
byte[] |
RecoveredXATransactionViewMBean.getGlobalTransactionId() |
|
ObjectName[] |
BrokerViewMBean.getInactiveDurableTopicSubscribers() |
|
long |
DestinationViewMBean.getInFlightCount() |
Returns the number of messages that have been dispatched but not
acknowledged
|
ObjectName |
BrokerViewMBean.getJMSJobScheduler() |
|
long |
BrokerViewMBean.getJobSchedulerStoreLimit() |
|
int |
BrokerViewMBean.getJobSchedulerStorePercentUsage() |
|
List<String> |
Log4JConfigViewMBean.getLoggers() |
list of all the logger names and their levels
|
String |
Log4JConfigViewMBean.getLogLevel(String loggerName) |
Get the log level for a given logger
|
int |
DestinationViewMBean.getMaxAuditDepth() |
|
long |
DestinationViewMBean.getMaxEnqueueTime() |
|
int |
SubscriptionViewMBean.getMaximumPendingMessageLimit() |
|
int |
TopicSubscriptionViewMBean.getMaximumPendingQueueSize() |
|
long |
BrokerViewMBean.getMaxMessageSize() |
|
long |
DestinationViewMBean.getMaxMessageSize() |
|
int |
DestinationViewMBean.getMaxPageSize() |
|
int |
DestinationViewMBean.getMaxProducersToAudit() |
|
long |
AbortSlowConsumerStrategyViewMBean.getMaxSlowCount() |
|
long |
AbortSlowConsumerStrategyViewMBean.getMaxSlowDuration() |
|
long |
AbortSlowAckConsumerStrategyViewMBean.getMaxTimeSinceLastAck() |
|
long |
BrokerViewMBean.getMemoryLimit() |
|
long |
DestinationViewMBean.getMemoryLimit() |
|
int |
BrokerViewMBean.getMemoryPercentUsage() |
|
int |
DestinationViewMBean.getMemoryPercentUsage() |
|
long |
DestinationViewMBean.getMemoryUsageByteCount() |
|
float |
DestinationViewMBean.getMemoryUsagePortion() |
|
CompositeData |
QueueViewMBean.getMessage(String messageId) |
Retrieve a message from the destination's queue.
|
int |
SubscriptionViewMBean.getMessageCountAwaitingAcknowledge() |
The same as the number of messages dispatched - making it explicit
|
Map<String,String> |
QueueViewMBean.getMessageGroups() |
|
String |
QueueViewMBean.getMessageGroupType() |
|
long |
DestinationViewMBean.getMinEnqueueTime() |
|
long |
BrokerViewMBean.getMinMessageSize() |
|
long |
DestinationViewMBean.getMinMessageSize() |
|
String |
DestinationViewMBean.getName() |
Returns the name of this destination
|
String |
NetworkDestinationViewMBean.getName() |
Returns the name of this destination
|
String |
PersistenceAdapterViewMBean.getName() |
|
TabularData |
JobSchedulerViewMBean.getNextScheduleJobs() |
Get all the jobs scheduled to run next.
|
String |
JobSchedulerViewMBean.getNextScheduleTime() |
Get the next time jobs will be fired from this scheduler store.
|
Long |
ConnectionViewMBean.getOldestActiveTransactionDuration() |
Returns the number of active transactions established on this Connection.
|
String |
DestinationViewMBean.getOptions() |
|
int |
SubscriptionViewMBean.getPendingQueueSize() |
|
int |
ProducerViewMBean.getPercentageBlocked() |
|
int |
SubscriptionViewMBean.getPrefetchSize() |
|
byte |
SubscriptionViewMBean.getPriority() |
|
long |
DestinationViewMBean.getProducerCount() |
|
String |
ProducerViewMBean.getProducerId() |
|
ObjectName[] |
ConnectionViewMBean.getProducers() |
Returns the ObjectNames of all the Producers created by this Connection.
|
int |
ProducerViewMBean.getProducerWindowSize() |
|
ObjectName[] |
BrokerViewMBean.getQueueProducers() |
|
ObjectName[] |
BrokerViewMBean.getQueues() |
|
long |
DestinationViewMBean.getQueueSize() |
Returns the number of messages in this destination which are yet to be
consumed
|
ObjectName[] |
BrokerViewMBean.getQueueSubscribers() |
|
double |
NetworkDestinationViewMBean.getRate() |
Returns the rate of messages that have been sent to the destination.
|
String |
ConnectionViewMBean.getRemoteAddress() |
Returns the source address for this connection
|
String |
Log4JConfigViewMBean.getRootLogLevel() |
Get the log level for the root logger
|
int |
JobSchedulerViewMBean.getScheduledMessageCount() |
Get the number of messages in the scheduler.
|
String |
SubscriptionViewMBean.getSelector() |
|
long |
ProducerViewMBean.getSentCount() |
|
long |
ProducerViewMBean.getSessionId() |
|
long |
SubscriptionViewMBean.getSessionId() |
|
long |
PersistenceAdapterViewMBean.getSize() |
|
TabularData |
AbortSlowConsumerStrategyViewMBean.getSlowConsumers() |
|
ObjectName |
DestinationViewMBean.getSlowConsumerStrategy() |
Returns the slow consumer strategy MBean for this destination
|
String |
PersistenceAdapterViewMBean.getStatistics() |
|
long |
BrokerViewMBean.getStoreLimit() |
|
long |
DestinationViewMBean.getStoreMessageSize() |
Returns the memory size of all messages in this destination's store
|
int |
BrokerViewMBean.getStorePercentUsage() |
|
long |
SubscriptionViewMBean.getSubscriptionId() |
|
String |
DurableSubscriptionViewMBean.getSubscriptionName() |
|
String |
SubscriptionViewMBean.getSubscriptionName() |
|
ObjectName[] |
DestinationViewMBean.getSubscriptions() |
Returns all the current subscription MBeans matching this destination
|
long |
BrokerViewMBean.getTempLimit() |
|
ObjectName[] |
BrokerViewMBean.getTemporaryQueueProducers() |
|
ObjectName[] |
BrokerViewMBean.getTemporaryQueues() |
|
ObjectName[] |
BrokerViewMBean.getTemporaryQueueSubscribers() |
|
ObjectName[] |
BrokerViewMBean.getTemporaryTopicProducers() |
|
ObjectName[] |
BrokerViewMBean.getTemporaryTopics() |
|
ObjectName[] |
BrokerViewMBean.getTemporaryTopicSubscribers() |
|
int |
BrokerViewMBean.getTempPercentUsage() |
|
long |
DestinationViewMBean.getTempUsageLimit() |
|
int |
DestinationViewMBean.getTempUsagePercentUsage() |
|
ObjectName[] |
BrokerViewMBean.getTopicProducers() |
|
ObjectName[] |
BrokerViewMBean.getTopics() |
|
ObjectName[] |
BrokerViewMBean.getTopicSubscribers() |
|
long |
DestinationViewMBean.getTotalBlockedTime() |
|
long |
BrokerViewMBean.getTotalConsumerCount() |
|
long |
BrokerViewMBean.getTotalDequeueCount() |
|
long |
BrokerViewMBean.getTotalEnqueueCount() |
|
long |
BrokerViewMBean.getTotalMessageCount() |
|
long |
BrokerViewMBean.getTotalProducerCount() |
|
long |
ProducerViewMBean.getTotalTimeBlocked() |
|
String |
PersistenceAdapterViewMBean.getTransactions() |
|
String |
BrokerViewMBean.getTransportConnectorByType(String type) |
|
Map<String,String> |
BrokerViewMBean.getTransportConnectors() |
|
String |
ConnectorViewMBean.getUpdateClusterFilter() |
|
String |
BrokerViewMBean.getUptime() |
|
long |
BrokerViewMBean.getUptimeMillis() |
|
String |
ConnectionViewMBean.getUserName() |
Returns the User Name used to authorize creation of this Connection.
|
String |
ProducerViewMBean.getUserName() |
Returns the User Name used to authorize creation of this Producer.
|
String |
SubscriptionViewMBean.getUserName() |
Returns the User Name used to authorize creation of this Subscription.
|
String |
BrokerViewMBean.getVMURL() |
|
List<HealthStatus> |
HealthViewMBean.healthList() |
Warning this method can only be invoked if you have the correct version
of HealthStatus on your classpath or you use something
like jolokia to access JMX.
|
String |
HealthViewMBean.healthStatus() |
|
void |
RecoveredXATransactionViewMBean.heuristicCommit() |
|
void |
RecoveredXATransactionViewMBean.heuristicRollback() |
|
boolean |
ConnectionViewMBean.isActive() |
|
boolean |
SubscriptionViewMBean.isActive() |
|
boolean |
ConnectorViewMBean.isAllowLinkStealingEnabled() |
Returns true if link stealing is enabled on this Connector
|
boolean |
DestinationViewMBean.isAlwaysRetroactive() |
|
boolean |
ConnectionViewMBean.isBlocked() |
|
boolean |
QueueViewMBean.isCacheEnabled() |
|
boolean |
ConnectionViewMBean.isConnected() |
|
boolean |
DurableSubscriptionViewMBean.isCursorFull() |
|
boolean |
QueueViewMBean.isCursorFull() |
|
boolean |
ProducerViewMBean.isDestinationQueue() |
|
boolean |
SubscriptionViewMBean.isDestinationQueue() |
|
boolean |
ProducerViewMBean.isDestinationTemporary() |
|
boolean |
SubscriptionViewMBean.isDestinationTemporary() |
|
boolean |
ProducerViewMBean.isDestinationTopic() |
|
boolean |
SubscriptionViewMBean.isDestinationTopic() |
|
boolean |
ProducerViewMBean.isDispatchAsync() |
Deprecated.
|
boolean |
SubscriptionViewMBean.isDispatchAsync() |
|
boolean |
DestinationViewMBean.isDLQ() |
|
boolean |
SubscriptionViewMBean.isDurable() |
|
boolean |
SubscriptionViewMBean.isExclusive() |
|
boolean |
AbortSlowAckConsumerStrategyViewMBean.isIgnoreIdleConsumers() |
|
boolean |
AbortSlowAckConsumerStrategyViewMBean.isIgnoreNetworkConsumers() |
|
boolean |
SubscriptionViewMBean.isMatchingQueue(String queueName) |
Returns true if this subscription (which may be using wildcards) matches the given queue name
|
boolean |
SubscriptionViewMBean.isMatchingTopic(String topicName) |
Returns true if this subscription (which may be using wildcards) matches the given topic name
|
boolean |
SubscriptionViewMBean.isNetwork() |
|
boolean |
SubscriptionViewMBean.isNoLocal() |
|
boolean |
QueueViewMBean.isPaused() |
|
boolean |
BrokerViewMBean.isPersistent() |
|
boolean |
DestinationViewMBean.isPrioritizedMessages() |
|
boolean |
ProducerViewMBean.isProducerBlocked() |
|
boolean |
DestinationViewMBean.isProducerFlowControl() |
|
boolean |
ConnectorViewMBean.isRebalanceClusterClients() |
|
boolean |
SubscriptionViewMBean.isRetroactive() |
|
boolean |
DestinationViewMBean.isSendDuplicateFromStoreToDLQ() |
Returns the config setting to send a duplicate message from store
to the dead letter queue.
|
boolean |
BrokerViewMBean.isSlave() |
|
boolean |
ConnectionViewMBean.isSlow() |
|
boolean |
SubscriptionViewMBean.isSlowConsumer() |
Returns true if the subscription is slow
|
boolean |
BrokerViewMBean.isStatisticsEnabled() |
|
boolean |
ConnectorViewMBean.isStatisticsEnabled() |
Returns true if statistics is enabled
|
boolean |
ConnectorViewMBean.isUpdateClusterClients() |
|
boolean |
ConnectorViewMBean.isUpdateClusterClientsOnRemove() |
|
boolean |
DestinationViewMBean.isUseCache() |
|
int |
QueueViewMBean.moveMatchingMessagesTo(String selector,
String destinationName) |
Moves the messages matching the given selector
|
int |
QueueViewMBean.moveMatchingMessagesTo(String selector,
String destinationName,
int maximumMessages) |
Moves the messages matching the given selector up to the maximum number
of matched messages
|
boolean |
QueueViewMBean.moveMessageTo(String messageId,
String destinationName) |
Moves the message to another destination.
|
void |
QueueViewMBean.pause() |
|
void |
QueueViewMBean.purge() |
Removes all of the messages in the queue.
|
String |
BrokerViewMBean.queryQueues(String filter,
int page,
int pageSize) |
|
String |
BrokerViewMBean.queryTopics(String filter,
int page,
int pageSize) |
|
void |
BrokerViewMBean.reloadLog4jProperties() |
Reloads log4j.properties from the classpath.
|
void |
Log4JConfigViewMBean.reloadLog4jProperties() |
Reloads log4j.properties from the classpath.
|
void |
JobSchedulerViewMBean.removeAllJobs() |
Remove all the Jobs from the scheduler,
|
void |
JobSchedulerViewMBean.removeAllJobs(String start,
String finish) |
Remove all the Jobs from the scheduler that are due between the start and finish times.
|
void |
JobSchedulerViewMBean.removeAllJobsAtScheduledTime(String time) |
Remove all jobs scheduled to run at this time.
|
void |
QueueViewMBean.removeAllMessageGroups() |
remove all the message groups - will rebalance all message groups across consumers
|
boolean |
BrokerViewMBean.removeConnector(String connectorName) |
|
void |
JobSchedulerViewMBean.removeJob(String jobId) |
Remove a job with the matching jobId.
|
int |
QueueViewMBean.removeMatchingMessages(String selector) |
Removes the messages matching the given selector
|
int |
QueueViewMBean.removeMatchingMessages(String selector,
int maximumMessages) |
Removes the messages matching the given selector up to the maximum number
of matched messages
|
void |
DurableSubscriptionViewMBean.removeMessage(String messageId) |
Removes a message from the durable subscription.
|
boolean |
QueueViewMBean.removeMessage(String messageId) |
Removes a message from the queue.
|
void |
QueueViewMBean.removeMessageGroup(String groupName) |
remove a message group = has the effect of rebalancing group
|
boolean |
BrokerViewMBean.removeNetworkConnector(String connectorName) |
|
void |
BrokerViewMBean.removeQueue(String name) |
Removes a Queue destination from the broker.
|
void |
BrokerViewMBean.removeTopic(String name) |
Removes a Topic destination from the broker.
|
void |
ProducerViewMBean.resetFlowControlStats() |
|
void |
BrokerViewMBean.resetStatistics() |
|
void |
ConnectionViewMBean.resetStatistics() |
Resets the statistics
|
void |
ConnectorViewMBean.resetStatistics() |
Resets the statistics
|
void |
DestinationViewMBean.resetStatistics() |
Resets the management counters.
|
String |
PersistenceAdapterViewMBean.resetStatistics() |
|
void |
ProducerViewMBean.resetStatistics() |
|
void |
SubscriptionViewMBean.resetStatistics() |
|
void |
NetworkDestinationViewMBean.resetStats() |
Resets the managment counters.
|
void |
BrokerViewMBean.restart() |
Restart the broker and all it's components.
|
void |
QueueViewMBean.resume() |
|
boolean |
QueueViewMBean.retryMessage(String messageId) |
Moves a message back to its original destination
|
int |
QueueViewMBean.retryMessages() |
Retries messages sent to the DLQ
|
Set<String> |
VirtualDestinationSelectorCacheViewMBean.selectorsForDestination(String destinationName) |
|
String |
DestinationViewMBean.sendTextMessage(String body) |
Sends a TextMesage to the destination.
|
String |
DestinationViewMBean.sendTextMessage(String body,
String user,
String password) |
Sends a TextMesage to the destination.
|
String |
DestinationViewMBean.sendTextMessage(Map<?,?> headers,
String body) |
Sends a TextMesage to the destination.
|
String |
DestinationViewMBean.sendTextMessage(Map<String,String> headers,
String body,
String user,
String password) |
|
String |
DestinationViewMBean.sendTextMessageWithProperties(String properties) |
Sends a TextMessage to the destination.
|
String |
DestinationViewMBean.sendTextMessageWithProperties(String properties,
String delimiter) |
Sends a TextMessage to the destination.
|
void |
AbortSlowAckConsumerStrategyViewMBean.setIgnoreIdleConsumers(boolean ignoreIdleConsumers) |
|
void |
AbortSlowAckConsumerStrategyViewMBean.setIgnoreNetworkConsumers(boolean ignoreIdleConsumers) |
|
void |
Log4JConfigViewMBean.setLogLevel(String loggerName,
String level) |
Set the log level for a given logger
|
void |
AbortSlowConsumerStrategyViewMBean.setMaxSlowCount(long maxSlowCount) |
|
void |
AbortSlowConsumerStrategyViewMBean.setMaxSlowDuration(long maxSlowDuration) |
|
void |
AbortSlowAckConsumerStrategyViewMBean.setMaxTimeSinceLastAck(long maxTimeSinceLastAck) |
|
void |
Log4JConfigViewMBean.setRootLogLevel(String level) |
Get the log level for the root logger
|
void |
BrokerViewMBean.stop() |
Stop the broker and all it's components.
|
void |
BrokerViewMBean.stopGracefully(String connectorName,
String queueName,
long timeout,
long pollInterval) |
|
void |
BrokerViewMBean.terminateJVM(int exitCode) |
Shuts down the JVM.
|