Interface Configuration
-
public interface Configuration
A Configuration is used to configure ActiveMQ Artemis servers.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Deprecated Methods Modifier and Type Method Description Configuration
addAcceptorConfiguration(String name, String uri)
Add an acceptor to the configConfiguration
addAcceptorConfiguration(TransportConfiguration infos)
Configuration
addAddressConfiguration(CoreAddressConfiguration config)
Adds an addresses configurationConfiguration
addAddressesSetting(String key, org.apache.activemq.artemis.core.settings.impl.AddressSettings addressesSetting)
Deprecated.Configuration
addAddressSetting(String key, org.apache.activemq.artemis.core.settings.impl.AddressSettings addressesSetting)
Configuration
addAMQPConnection(AMQPBrokerConnectConfiguration amqpBrokerConnectConfiguration)
Configuration
addBroadcastGroupConfiguration(BroadcastGroupConfiguration config)
ClusterConnectionConfiguration
addClusterConfiguration(String name, String uri)
Configuration
addClusterConfiguration(ClusterConnectionConfiguration config)
Configuration
addConnectionRouter(ConnectionRouterConfiguration config)
Configuration
addConnectorConfiguration(String name, String uri)
Configuration
addConnectorConfiguration(String key, TransportConfiguration info)
Configuration
addConnectorServiceConfiguration(ConnectorServiceConfiguration config)
Configuration
addDiscoveryGroupConfiguration(String key, DiscoveryGroupConfiguration discoveryGroupConfiguration)
Configuration
addDivertConfiguration(DivertConfiguration config)
Configuration
addQueueConfiguration(QueueConfiguration config)
Configuration
addQueueConfiguration(CoreQueueConfiguration config)
Deprecated.Configuration
addResourceLimitSettings(org.apache.activemq.artemis.core.settings.impl.ResourceLimitSettings resourceLimitSettings)
Configuration
addSecurityRoleNameMapping(String internalRole, Set<String> externalRoles)
Configuration
addSecuritySettingPlugin(org.apache.activemq.artemis.core.server.SecuritySettingPlugin plugin)
Configuration
clearAcceptorConfigurations()
Configuration
clearAddressesSettings()
Deprecated.Configuration
clearAddressSettings()
Configuration
clearAMQPConnectionConfigurations()
Clears the current configuration object of all set or added AMQP connection configuration elements.Configuration
clearClusterConfigurations()
Configuration
clearConnectorConfigurations()
Configuration
copy()
String
debugConnectors()
It will return all the connectors in a toString manner for debug purposes.Set<TransportConfiguration>
getAcceptorConfigurations()
Returns the acceptors configured for this server.List<CoreAddressConfiguration>
getAddressConfigurations()
Returns the addresses configured for this server.Map<String,org.apache.activemq.artemis.core.settings.impl.AddressSettings>
getAddressesSettings()
Deprecated.long
getAddressQueueScanPeriod()
Returns the frequency (in milliseconds) to scan addresses and queues to detect which ones should be deleted.Map<String,org.apache.activemq.artemis.core.settings.impl.AddressSettings>
getAddressSettings()
List<AMQPBrokerConnectConfiguration>
getAMQPConnection()
long
getAuthenticationCacheSize()
Returns the configured size of the authentication cache.long
getAuthorizationCacheSize()
Returns the configured size of the authorization cache.String
getBindingsDirectory()
Returns the file system directory used to store bindings.File
getBindingsLocation()
The binding location related to artemis.instance.List<BridgeConfiguration>
getBridgeConfigurations()
Returns the bridges configured for this server.List<BroadcastGroupConfiguration>
getBroadcastGroupConfigurations()
Returns the broadcast groups configured for this server.List<ActiveMQServerAddressPlugin>
getBrokerAddressPlugins()
List<AMQPFederationBrokerPlugin>
getBrokerAMQPFederationPlugins()
List<ActiveMQServerBindingPlugin>
getBrokerBindingPlugins()
List<ActiveMQServerBridgePlugin>
getBrokerBridgePlugins()
List<ActiveMQServerConnectionPlugin>
getBrokerConnectionPlugins()
List<ActiveMQServerConsumerPlugin>
getBrokerConsumerPlugins()
List<ActiveMQServerCriticalPlugin>
getBrokerCriticalPlugins()
List<ActiveMQServerFederationPlugin>
getBrokerFederationPlugins()
File
getBrokerInstance()
Set the Artemis instance relative folder for data and stuff.List<ActiveMQServerMessagePlugin>
getBrokerMessagePlugins()
List<ActiveMQServerBasePlugin>
getBrokerPlugins()
List<ActiveMQServerQueuePlugin>
getBrokerQueuePlugins()
List<ActiveMQServerResourcePlugin>
getBrokerResourcePlugins()
List<ActiveMQServerSessionPlugin>
getBrokerSessionPlugins()
List<ClusterConnectionConfiguration>
getClusterConfigurations()
Returns the cluster connections configured for this server.String
getClusterPassword()
Returns the cluster password for this server.String
getClusterUser()
Returns the cluster user for this server.long
getConfigurationFileRefreshPeriod()
URL
getConfigurationUrl()
List<ConnectionRouterConfiguration>
getConnectionRouters()
Returns the redirects configured for this server.long
getConnectionTtlCheckInterval()
long
getConnectionTTLOverride()
Returns the connection time to live.Map<String,TransportConfiguration>
getConnectorConfigurations()
Returns the connectors configured for this server.List<ConnectorServiceConfiguration>
getConnectorServiceConfigurations()
long
getCriticalAnalyzerCheckPeriod()
org.apache.activemq.artemis.utils.critical.CriticalAnalyzerPolicy
getCriticalAnalyzerPolicy()
long
getCriticalAnalyzerTimeout()
Map<String,DiscoveryGroupConfiguration>
getDiscoveryGroupConfigurations()
Returns the discovery groups configured for this server.int
getDiskScanPeriod()
List<DivertConfiguration>
getDivertConfigurations()
Returns the diverts configured for this server.List<FederationConfiguration>
getFederationConfigurations()
long
getFileDeployerScanPeriod()
Returns the period (in milliseconds) to scan configuration files used by deployment.long
getGlobalMaxMessages()
long
getGlobalMaxSize()
long
getGracefulShutdownTimeout()
Returns the graceful shutdown timeout for this server.org.apache.activemq.artemis.core.server.group.impl.GroupingHandlerConfiguration
getGroupingHandlerConfiguration()
Returns the grouping handler configured for this server.HAPolicyConfiguration
getHAPolicyConfiguration()
int
getIDCacheSize()
Returns the size of the cache for pre-creating message IDs.List<String>
getIncomingInterceptorClassNames()
Returns the list of interceptors classes used by this server for incoming messages (i.e.String
getInternalNamingPrefix()
String
getJMXDomain()
Returns the domain used by JMX MBeans (provided JMX management is enabled).int
getJournalBufferSize_AIO()
Returns the buffer size (in bytes) for AIO.int
getJournalBufferSize_NIO()
Returns the buffer size (in bytes) for NIO.int
getJournalBufferTimeout_AIO()
Returns the timeout (in nanoseconds) used to flush buffers in the AIO queue.int
getJournalBufferTimeout_NIO()
Returns the timeout (in nanoseconds) used to flush buffers in the NIO.int
getJournalCompactMinFiles()
Returns the minimal number of journal files before compacting.int
getJournalCompactPercentage()
Returns the percentage of live data before compacting the journal.Integer
getJournalDeviceBlockSize()
This is the device block size used on writing.String
getJournalDirectory()
Returns the file system directory used to store journal log.int
getJournalFileOpenTimeout()
int
getJournalFileSize()
Returns the size (in bytes) of each journal files.File
getJournalLocation()
The location of the journal related to artemis.instance.long
getJournalLockAcquisitionTimeout()
int
getJournalMaxAtticFiles()
Returns the maximal number of data files before we can start deleting corrupted files instead of moving them to attic.int
getJournalMaxIO_AIO()
Returns the maximum number of write requests that can be in the AIO queue at any given time.int
getJournalMaxIO_NIO()
Returns the maximum number of write requests for NIO journal.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
getJournalRetentionDirectory()
File
getJournalRetentionLocation()
long
getJournalRetentionMaxBytes()
long
getJournalRetentionPeriod()
The retention period for the journal in milliseconds (always in milliseconds, a conversion is performed on set)org.apache.activemq.artemis.core.server.JournalType
getJournalType()
Returns the type of journal used by this server (NIO
,ASYNCIO
orMAPPED
).String
getLargeMessagesDirectory()
Returns the file system directory used to store large messages.File
getLargeMessagesLocation()
The large message location related to artemis.instanceString
getLiteralMatchMarkers()
SimpleString
getManagementAddress()
Returns the management address of this server.SimpleString
getManagementNotificationAddress()
Returns the management notification address of this server.String
getManagementRbacPrefix()
int
getMaxDiskUsage()
int
getMaxRedeliveryRecords()
long
getMemoryMeasureInterval()
int
getMemoryWarningThreshold()
int
getMessageCounterMaxDayHistory()
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.int
getMessageExpiryThreadPriority()
Deprecated.MetricsConfiguration
getMetricsConfiguration()
org.apache.activemq.artemis.core.server.metrics.ActiveMQMetricsPlugin
getMetricsPlugin()
Deprecated.long
getMinDiskFree()
int
getMirrorAckManagerPageAttempts()
This configures the Mirror Ack Manager number of attempts on page acks.int
getMirrorAckManagerQueueAttempts()
This configures the Mirror Ack Manager number of attempts on queues before trying page acks.int
getMirrorAckManagerRetryDelay()
This configures the interval in which the Mirror AckManager will retry acks when It is not intended to be configured through the XML.long
getMqttSessionScanInterval()
long
getMqttSessionStatePersistenceTimeout()
String
getName()
To be used on dependency management on the application serverString
getNetworkCheckList()
String
getNetworkCheckNIC()
long
getNetworkCheckPeriod()
String
getNetworkCheckPing6Command()
String
getNetworkCheckPingCommand()
int
getNetworkCheckTimeout()
String
getNetworkCheckURLList()
String
getNodeManagerLockDirectory()
the directory that contains the lock fileFile
getNodeManagerLockLocation()
The location of the node manager lock file related to artemis.instance.List<String>
getOutgoingInterceptorClassNames()
Returns the list of interceptors classes used by this server for outgoing messages (i.e.int
getPageMaxConcurrentIO()
The max number of concurrent reads allowed on paging.int
getPageSyncTimeout()
Returns the timeout (in nanoseconds) used to sync pages.String
getPagingDirectory()
Returns the file system directory used to store paging files.File
getPagingLocation()
The paging location related to artemis.instanceString
getPasswordCodec()
Gets the default password decoderList<QueueConfiguration>
getQueueConfigs()
List<CoreQueueConfiguration>
getQueueConfigurations()
Deprecated.Map<String,org.apache.activemq.artemis.core.settings.impl.ResourceLimitSettings>
getResourceLimitSettings()
int
getScheduledThreadPoolMaxSize()
Returns the maximum number of threads in the scheduled thread pool of this server.long
getSecurityInvalidationInterval()
Returns the interval time (in milliseconds) to invalidate security credentials.Map<String,Set<String>>
getSecurityRoleNameMappings()
Map<String,Set<org.apache.activemq.artemis.core.security.Role>>
getSecurityRoles()
List<org.apache.activemq.artemis.core.server.SecuritySettingPlugin>
getSecuritySettingPlugins()
long
getServerDumpInterval()
String
getStatus()
StoreConfiguration
getStoreConfiguration()
String
getSystemPropertyPrefix()
See doc atsetSystemPropertyPrefix(String)
.String
getTemporaryQueueNamespace()
int
getThreadPoolMaxSize()
Returns the maximum number of threads in the thread pool of this server.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.TransportConfiguration[]
getTransportConfigurations(String... connectorNames)
TransportConfiguration[]
getTransportConfigurations(List<String> connectorNames)
String
getViewPermissionMethodMatchPattern()
WildcardConfiguration
getWildcardConfiguration()
boolean
isAmqpUseCoreSubscriptionNaming()
Returns if to use Core subscription naming for AMQP.boolean
isAsyncConnectionExecutionEnabled()
Deprecated.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
isCriticalAnalyzer()
boolean
isGracefulShutdownEnabled()
Returns whether graceful shutdown is enabled for this server.default boolean
isJDBC()
boolean
isJMXManagementEnabled()
Returns whether this server is manageable using JMX or not.boolean
isJMXUseBrokerName()
whether or not to use the broker name in the JMX treeboolean
isJournalDatasync()
Should use fdatasync on journal files.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
isLargeMessageSync()
boolean
isLogJournalWriteRate()
boolean
isManagementMessageRbac()
Boolean
isMaskPassword()
If passwords are masked.boolean
isMessageCounterEnabled()
Returns whether message counter is enabled for this server.boolean
isMirrorAckManagerWarnUnacked()
boolean
isMirrorPageTransaction()
Should Mirror use Page Transactions When target destinations is paging? When a target queue on the mirror is paged, the mirror will not record a page transaction for every message.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
isPopulateValidatedUser()
boolean
isReadWholePage()
Returns whether the whole page is read while getting message after page cache is evicted.boolean
isRejectEmptyValidatedUser()
boolean
isResolveProtocols()
boolean
isSecurityEnabled()
Returns whether security is enabled for this server.boolean
isSuppressSessionNotifications()
Returns whether suppression of session-notifications is enabled for this server.boolean
isWildcardRoutingEnabled()
Returns whether wildcard routing is supported by this server.void
parsePrefixedProperties(Object target, String name, Properties properties, String prefix)
Configuration
parseProperties(String optionalUrlToPropertiesFile)
Configuration
putSecurityRoles(String match, Set<org.apache.activemq.artemis.core.security.Role> roles)
void
registerBrokerPlugin(ActiveMQServerBasePlugin plugin)
void
registerBrokerPlugins(List<ActiveMQServerBasePlugin> plugins)
default String
resolvePropertiesSources(String propertiesFileUrl)
Configuration
setAcceptorConfigurations(Set<TransportConfiguration> infos)
Sets the acceptors configured for this server.Configuration
setAddressConfigurations(List<CoreAddressConfiguration> configs)
Sets the addresses configured for this server.Configuration
setAddressesSettings(Map<String,org.apache.activemq.artemis.core.settings.impl.AddressSettings> addressesSettings)
Deprecated.Configuration
setAddressQueueScanPeriod(long addressQueueScanPeriod)
Sets the frequency (in milliseconds) to scan addresses and queues to detect which ones should be deleted.Configuration
setAddressSettings(Map<String,org.apache.activemq.artemis.core.settings.impl.AddressSettings> addressSettings)
Configuration
setAMQPConnectionConfigurations(List<AMQPBrokerConnectConfiguration> amqpConnectionConfiugrations)
Quick set of all AMQP connection configurations in one call which will clear all previously set or added broker configurations.Configuration
setAmqpUseCoreSubscriptionNaming(boolean amqpUseCoreSubscriptionNaming)
Sets if to use Core subscription naming for AMQP.Configuration
setAuthenticationCacheSize(long size)
Sets the size of the authentication cache.Configuration
setAuthorizationCacheSize(long size)
Sets the size of the authorization cache.Configuration
setBindingsDirectory(String dir)
Sets the file system directory used to store bindings.Configuration
setBridgeConfigurations(List<BridgeConfiguration> configs)
Sets the bridges configured for this server.Configuration
setBroadcastGroupConfigurations(List<BroadcastGroupConfiguration> configs)
Sets the broadcast groups configured for this server.void
setBrokerInstance(File directory)
Set the Artemis instance relative folder for data and stuff.Configuration
setClusterConfigurations(List<ClusterConnectionConfiguration> configs)
Sets the cluster connections configured for this server.Configuration
setClusterPassword(String password)
Sets the cluster password for this server.Configuration
setClusterUser(String user)
Sets the cluster user for this server.Configuration
setConfigurationFileRefreshPeriod(long configurationFileRefreshPeriod)
Configuration
setConfigurationUrl(URL configurationUrl)
Configuration
setConnectionRouters(List<ConnectionRouterConfiguration> configs)
Sets the redirects configured for this server.Configuration
setConnectionTtlCheckInterval(long connectionTtlCheckInterval)
Configuration
setConnectionTTLOverride(long ttl)
Sets the connection time to live.Configuration
setConnectorConfigurations(Map<String,TransportConfiguration> infos)
Sets the connectors configured for this server.Configuration
setConnectorServiceConfigurations(List<ConnectorServiceConfiguration> configs)
Configuration
setCreateBindingsDir(boolean create)
Sets whether the bindings directory is created on this server startup.Configuration
setCreateJournalDir(boolean create)
Sets whether the journal directory is created on this server startup.Configuration
setCriticalAnalyzer(boolean CriticalAnalyzer)
Configuration
setCriticalAnalyzerCheckPeriod(long checkPeriod)
Configuration
setCriticalAnalyzerPolicy(org.apache.activemq.artemis.utils.critical.CriticalAnalyzerPolicy policy)
Configuration
setCriticalAnalyzerTimeout(long timeout)
Configuration
setDiscoveryGroupConfigurations(Map<String,DiscoveryGroupConfiguration> configs)
Sets the discovery groups configured for this server.Configuration
setDiskScanPeriod(int diskScanPeriod)
Configuration
setDivertConfigurations(List<DivertConfiguration> configs)
Sets the diverts configured for this server.Configuration
setEnabledAsyncConnectionExecution(boolean enabled)
Deprecated.Configuration
setFileDeployerScanPeriod(long period)
Sets the period to scan configuration files used by deployment.Configuration
setGlobalMaxMessages(long globalMaxMessages)
Configuration
setGlobalMaxSize(long globalMaxSize)
Configuration
setGracefulShutdownEnabled(boolean enabled)
Sets whether security is enabled for this server.Configuration
setGracefulShutdownTimeout(long timeout)
Sets the graceful shutdown timeoutConfiguration
setGroupingHandlerConfiguration(org.apache.activemq.artemis.core.server.group.impl.GroupingHandlerConfiguration groupingHandlerConfiguration)
Sets the grouping handler configured for this server.Configuration
setHAPolicyConfiguration(HAPolicyConfiguration haPolicyConfiguration)
Configuration
setIDCacheSize(int idCacheSize)
Sets the size of the cache for pre-creating message IDs.Configuration
setIncomingInterceptorClassNames(List<String> interceptors)
Sets the list of interceptors classes used by this server for incoming messages (i.e.org.apache.activemq.artemis.core.config.impl.ConfigurationImpl
setInternalNamingPrefix(String internalNamingPrefix)
Configuration
setJMXDomain(String domain)
Sets the domain used by JMX MBeans (provided JMX management is enabled).Configuration
setJMXManagementEnabled(boolean enabled)
Sets whether this server is manageable using JMX or not.org.apache.activemq.artemis.core.config.impl.ConfigurationImpl
setJMXUseBrokerName(boolean jmxUseBrokerName)
whether or not to use the broker name in the JMX treeConfiguration
setJournalBufferSize_AIO(int journalBufferSize)
Sets the buffer size (in bytes) for AIO.Configuration
setJournalBufferSize_NIO(int journalBufferSize)
Sets the buffer size (in bytes) for NIO.Configuration
setJournalBufferTimeout_AIO(int journalBufferTimeout)
Sets the timeout (in nanoseconds) used to flush buffers in the AIO queue.Configuration
setJournalBufferTimeout_NIO(int journalBufferTimeout)
Sets the timeout (in nanoseconds) used to flush buffers in the NIO.Configuration
setJournalCompactMinFiles(int minFiles)
Sets the minimal number of journal files before compacting.Configuration
setJournalCompactPercentage(int percentage)
Sets the percentage of live data before compacting the journal.Configuration
setJournalDatasync(boolean enable)
documented atisJournalDatasync()
()}Configuration
setJournalDeviceBlockSize(Integer deviceBlockSize)
Configuration
setJournalDirectory(String dir)
Sets the file system directory used to store journal log.Configuration
setJournalFileOpenTimeout(int journalFileOpenTimeout)
Sets the journal file open timeoutConfiguration
setJournalFileSize(int size)
Sets the size (in bytes) of each journal files.Configuration
setJournalLockAcquisitionTimeout(long journalLockAcquisitionTimeout)
Configuration
setJournalMaxAtticFiles(int maxAtticFiles)
Sets the maximal number of data files before we can start deleting corrupted files instead of moving them to attic.Configuration
setJournalMaxIO_AIO(int journalMaxIO)
Sets the maximum number of write requests that can be in the AIO queue at any given time.Configuration
setJournalMaxIO_NIO(int journalMaxIO)
Sets the maximum number of write requests for NIO journal.Configuration
setJournalMinFiles(int files)
Sets the number of journal files to pre-create.Configuration
setJournalPoolFiles(int poolSize)
Number of files that would be acceptable to keep on a pool.Configuration
setJournalRetentionDirectory(String dir)
Sets the file system directory used to store historical backup journal.Configuration
setJournalRetentionMaxBytes(long bytes)
Configuration
setJournalRetentionPeriod(TimeUnit unit, long limit)
Configuration
setJournalSyncNonTransactional(boolean sync)
Sets whether the journal is synchronized when receiving non-transactional data.Configuration
setJournalSyncTransactional(boolean sync)
Sets whether the journal is synchronized when receiving transactional data.Configuration
setJournalType(org.apache.activemq.artemis.core.server.JournalType type)
Sets the type of journal used by this server (eitherNIO
orASYNCIO
).Configuration
setLargeMessagesDirectory(String directory)
Sets the file system directory used to store large messages.Configuration
setLargeMessageSync(boolean largeMessageSync)
Configuration
setLiteralMatchMarkers(String literalMatchMarkers)
Configuration
setLogJournalWriteRate(boolean rate)
Configuration
setManagementAddress(SimpleString address)
Sets the management address of this server.void
setManagementMessageRbac(boolean val)
Configuration
setManagementNotificationAddress(SimpleString address)
Sets the management notification address of this server.void
setManagementRbacPrefix(String prefix)
Configuration
setMaskPassword(Boolean maskPassword)
Sets if passwords should be masked or not.Configuration
setMaxDiskUsage(int maxDiskUsage)
Configuration
setMaxRedeliveryRecords(int maxPersistRedelivery)
Maximum number of redelivery records stored on the journal per message reference.Configuration
setMemoryMeasureInterval(long memoryMeasureInterval)
Configuration
setMemoryWarningThreshold(int memoryWarningThreshold)
Configuration
setMessageCounterEnabled(boolean enabled)
Sets whether message counter is enabled for this server.Configuration
setMessageCounterMaxDayHistory(int maxDayHistory)
Sets the maximum number of days kept in memory for message counter.Configuration
setMessageCounterSamplePeriod(long period)
Sets the sample period to take message counter snapshot.Configuration
setMessageExpiryScanPeriod(long messageExpiryScanPeriod)
Sets the frequency (in milliseconds) to scan messages to detect which messages have expired.Configuration
setMessageExpiryThreadPriority(int messageExpiryThreadPriority)
Deprecated.Configuration
setMetricsConfiguration(MetricsConfiguration metricsConfiguration)
Configuration
setMetricsPlugin(org.apache.activemq.artemis.core.server.metrics.ActiveMQMetricsPlugin plugin)
Deprecated.Configuration
setMinDiskFree(long minDiskFree)
Configuration
setMirrorAckManagerPageAttempts(int pageAttempts)
Configuration
setMirrorAckManagerQueueAttempts(int queueAttempts)
Configuration
setMirrorAckManagerRetryDelay(int delay)
Configuration
setMirrorAckManagerWarnUnacked(boolean warnUnacked)
should log.warn when ack retries failed.Configuration
setMirrorPageTransaction(boolean ignorePageTransactions)
Configuration
setMqttSessionScanInterval(long mqttSessionScanInterval)
This is necessary because the MQTT session scan interval is a broker-wide setting and can't be set on a per-connector basis like most of the other MQTT-specific settings.Configuration
setMqttSessionStatePersistenceTimeout(long mqttSessionStatePersistenceTimeout)
This is necessary because MQTT sessions and handled on a broker-wide basis so this can't be set on a per-connector basis like most of the other MQTT-specific settings.Configuration
setName(String name)
To be used on dependency management on the application serverConfiguration
setNetworCheckNIC(String nic)
Deprecated.Configuration
setNetworkCheckList(String list)
A comma separated list of IPs we could use to validate if the network is UP.Configuration
setNetworkCheckNIC(String nic)
The NIC name to be used on network checksConfiguration
setNetworkCheckPeriod(long period)
The interval on which we will perform network checks.Configuration
setNetworkCheckPing6Command(String command)
Configuration
setNetworkCheckPingCommand(String command)
Configuration
setNetworkCheckTimeout(int timeout)
Time in ms for how long we should wait for a ping to finish.Configuration
setNetworkCheckURLList(String uris)
A comma separated list of URIs we could use to validate if the network is UP.Configuration
setNodeManagerLockDirectory(String dir)
Sets the file system directory used to store the node manager lock file.Configuration
setOutgoingInterceptorClassNames(List<String> interceptors)
Sets the list of interceptors classes used by this server for outgoing messages (i.e.Configuration
setPageMaxConcurrentIO(int maxIO)
The max number of concurrent reads allowed on paging.Configuration
setPageSyncTimeout(int pageSyncTimeout)
Sets the timeout (in nanoseconds) used to sync pages.Configuration
setPagingDirectory(String dir)
Sets the file system directory used to store paging files.Configuration
setPasswordCodec(String codec)
The default password decoderConfiguration
setPersistDeliveryCountBeforeDelivery(boolean persistDeliveryCountBeforeDelivery)
Sets whether delivery count is persisted before messages are delivered to consumers.Configuration
setPersistenceEnabled(boolean enable)
Sets whether this server is using persistence and store data.Configuration
setPersistIDCache(boolean persist)
Sets whether message ID cache is persisted.Configuration
setPopulateValidatedUser(boolean populateValidatedUser)
Configuration
setQueueConfigs(List<QueueConfiguration> configs)
Sets the queues configured for this server.Configuration
setQueueConfigurations(List<CoreQueueConfiguration> configs)
Deprecated.Configuration
setReadWholePage(boolean read)
Sets whether the whole page is read while getting message after page cache is evicted.Configuration
setRejectEmptyValidatedUser(boolean rejectEmptyValidatedUser)
Configuration
setResolveProtocols(boolean resolveProtocols)
Configuration
setResourceLimitSettings(Map<String,org.apache.activemq.artemis.core.settings.impl.ResourceLimitSettings> resourceLimitSettings)
Configuration
setScheduledThreadPoolMaxSize(int maxSize)
Sets the maximum number of threads in the scheduled thread pool of this server.Configuration
setSecurityEnabled(boolean enabled)
Sets whether security is enabled for this server.Configuration
setSecurityInvalidationInterval(long interval)
Sets the interval time (in milliseconds) to invalidate security credentials.Configuration
setSecurityRoles(Map<String,Set<org.apache.activemq.artemis.core.security.Role>> roles)
Configuration
setSecuritySettingPlugins(List<org.apache.activemq.artemis.core.server.SecuritySettingPlugin> plugins)
Configuration
setServerDumpInterval(long interval)
void
setStatus(String status)
This value can reflect a desired state (revision) of config.Configuration
setStoreConfiguration(StoreConfiguration storeConfiguration)
Configuration
setSuppressSessionNotifications(boolean suppressSessionNotifications)
Configuration
setSystemPropertyPrefix(String systemPropertyPrefix)
We use Bean-utils to pass in System.properties that start withsetSystemPropertyPrefix(String)
.Configuration
setTemporaryQueueNamespace(String temporaryQueueNamespace)
Configuration
setThreadPoolMaxSize(int maxSize)
Sets the maximum number of threads in the thread pool of this server.Configuration
setTransactionTimeout(long timeout)
Sets the timeout (in milliseconds) after which transactions is removed from the resource manager after it was created.Configuration
setTransactionTimeoutScanPeriod(long period)
Sets the frequency (in milliseconds) to scan transactions to detect which transactions have timed out.void
setViewPermissionMethodMatchPattern(String permissionMatchPattern)
Configuration
setWildCardConfiguration(WildcardConfiguration wildcardConfiguration)
Configuration
setWildcardRoutingEnabled(boolean enabled)
Sets whether wildcard routing is supported by this server.void
unRegisterBrokerPlugin(ActiveMQServerBasePlugin plugin)
-
-
-
Method Detail
-
getName
String getName()
To be used on dependency management on the application server
-
setName
Configuration setName(String name)
To be used on dependency management on the application server
-
setSystemPropertyPrefix
Configuration setSystemPropertyPrefix(String systemPropertyPrefix)
We use Bean-utils to pass in System.properties that start withsetSystemPropertyPrefix(String)
. The default should be 'brokerconfig.' (Including the "."). For example if you want to set clustered through a system property you must do: -Dbrokerconfig.clustered=true The prefix is configured here.- Parameters:
systemPropertyPrefix
-- Returns:
-
getSystemPropertyPrefix
String getSystemPropertyPrefix()
See doc atsetSystemPropertyPrefix(String)
.- Returns:
-
parseProperties
Configuration parseProperties(String optionalUrlToPropertiesFile) throws Exception
- Throws:
Exception
-
parsePrefixedProperties
void parsePrefixedProperties(Object target, String name, Properties properties, String prefix) throws Exception
- Throws:
Exception
-
isCriticalAnalyzer
boolean isCriticalAnalyzer()
-
setCriticalAnalyzer
Configuration setCriticalAnalyzer(boolean CriticalAnalyzer)
-
getCriticalAnalyzerTimeout
long getCriticalAnalyzerTimeout()
-
setCriticalAnalyzerTimeout
Configuration setCriticalAnalyzerTimeout(long timeout)
-
getCriticalAnalyzerCheckPeriod
long getCriticalAnalyzerCheckPeriod()
-
setCriticalAnalyzerCheckPeriod
Configuration setCriticalAnalyzerCheckPeriod(long checkPeriod)
-
getCriticalAnalyzerPolicy
org.apache.activemq.artemis.utils.critical.CriticalAnalyzerPolicy getCriticalAnalyzerPolicy()
-
setCriticalAnalyzerPolicy
Configuration setCriticalAnalyzerPolicy(org.apache.activemq.artemis.utils.critical.CriticalAnalyzerPolicy policy)
-
isClustered
boolean isClustered()
-
isPersistDeliveryCountBeforeDelivery
boolean isPersistDeliveryCountBeforeDelivery()
Returns whether delivery count is persisted before messages are delivered to the consumers.
Default value isActiveMQDefaultConfiguration.DEFAULT_PERSIST_DELIVERY_COUNT_BEFORE_DELIVERY
-
setPersistDeliveryCountBeforeDelivery
Configuration setPersistDeliveryCountBeforeDelivery(boolean persistDeliveryCountBeforeDelivery)
Sets whether delivery count is persisted before messages are delivered to consumers.
-
isPersistenceEnabled
boolean isPersistenceEnabled()
Returns whether this server is using persistence and store data.
Default value isActiveMQDefaultConfiguration.DEFAULT_PERSISTENCE_ENABLED
.
-
setPersistenceEnabled
Configuration setPersistenceEnabled(boolean enable)
Sets whether this server is using persistence and store data.
-
setMaxRedeliveryRecords
Configuration setMaxRedeliveryRecords(int maxPersistRedelivery)
Maximum number of redelivery records stored on the journal per message reference.
-
getMaxRedeliveryRecords
int getMaxRedeliveryRecords()
-
isJournalDatasync
boolean isJournalDatasync()
Should use fdatasync on journal files.- Returns:
- a boolean
- See Also:
- fdatasync
-
setJournalDatasync
Configuration setJournalDatasync(boolean enable)
documented atisJournalDatasync()
()}- Parameters:
enable
-- Returns:
- this
-
getResourceLimitSettings
Map<String,org.apache.activemq.artemis.core.settings.impl.ResourceLimitSettings> getResourceLimitSettings()
- Returns:
- usernames mapped to ResourceLimitSettings
-
setResourceLimitSettings
Configuration setResourceLimitSettings(Map<String,org.apache.activemq.artemis.core.settings.impl.ResourceLimitSettings> resourceLimitSettings)
- Parameters:
resourceLimitSettings
- usernames mapped to ResourceLimitSettings
-
addResourceLimitSettings
Configuration addResourceLimitSettings(org.apache.activemq.artemis.core.settings.impl.ResourceLimitSettings resourceLimitSettings)
- Parameters:
resourceLimitSettings
- usernames mapped to ResourceLimitSettings
-
getFileDeployerScanPeriod
long getFileDeployerScanPeriod()
Returns the period (in milliseconds) to scan configuration files used by deployment.
Default value isActiveMQDefaultConfiguration.DEFAULT_FILE_DEPLOYER_SCAN_PERIOD
.
-
setFileDeployerScanPeriod
Configuration setFileDeployerScanPeriod(long period)
Sets the period to scan configuration files used by deployment.
-
getThreadPoolMaxSize
int getThreadPoolMaxSize()
Returns the maximum number of threads in the thread pool of this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_THREAD_POOL_MAX_SIZE
.
-
setThreadPoolMaxSize
Configuration setThreadPoolMaxSize(int maxSize)
Sets the maximum number of threads in the thread pool of this server.
-
getScheduledThreadPoolMaxSize
int getScheduledThreadPoolMaxSize()
Returns the maximum number of threads in the scheduled thread pool of this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_SCHEDULED_THREAD_POOL_MAX_SIZE
.
-
setScheduledThreadPoolMaxSize
Configuration setScheduledThreadPoolMaxSize(int maxSize)
Sets the maximum number of threads in the scheduled thread pool of this server.
-
getSecurityInvalidationInterval
long getSecurityInvalidationInterval()
Returns the interval time (in milliseconds) to invalidate security credentials.
Default value isActiveMQDefaultConfiguration.DEFAULT_SECURITY_INVALIDATION_INTERVAL
.
-
setSecurityInvalidationInterval
Configuration setSecurityInvalidationInterval(long interval)
Sets the interval time (in milliseconds) to invalidate security credentials.
-
setAuthenticationCacheSize
Configuration setAuthenticationCacheSize(long size)
Sets the size of the authentication cache.
-
getAuthenticationCacheSize
long getAuthenticationCacheSize()
Returns the configured size of the authentication cache.
Default value isActiveMQDefaultConfiguration.DEFAULT_AUTHENTICATION_CACHE_SIZE
.
-
setAuthorizationCacheSize
Configuration setAuthorizationCacheSize(long size)
Sets the size of the authorization cache.
-
getAuthorizationCacheSize
long getAuthorizationCacheSize()
Returns the configured size of the authorization cache.
Default value isActiveMQDefaultConfiguration.DEFAULT_AUTHORIZATION_CACHE_SIZE
.
-
isSecurityEnabled
boolean isSecurityEnabled()
Returns whether security is enabled for this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_SECURITY_ENABLED
.
-
setSecurityEnabled
Configuration setSecurityEnabled(boolean enabled)
Sets whether security is enabled for this server.
-
isGracefulShutdownEnabled
boolean isGracefulShutdownEnabled()
Returns whether graceful shutdown is enabled for this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_GRACEFUL_SHUTDOWN_ENABLED
.
-
setGracefulShutdownEnabled
Configuration setGracefulShutdownEnabled(boolean enabled)
Sets whether security is enabled for this server.
-
getGracefulShutdownTimeout
long getGracefulShutdownTimeout()
Returns the graceful shutdown timeout for this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_GRACEFUL_SHUTDOWN_TIMEOUT
.
-
setGracefulShutdownTimeout
Configuration setGracefulShutdownTimeout(long timeout)
Sets the graceful shutdown timeout
-
isJMXManagementEnabled
boolean isJMXManagementEnabled()
Returns whether this server is manageable using JMX or not.
Default value isActiveMQDefaultConfiguration.DEFAULT_JMX_MANAGEMENT_ENABLED
.
-
setJMXManagementEnabled
Configuration setJMXManagementEnabled(boolean enabled)
Sets whether this server is manageable using JMX or not.
Default value isActiveMQDefaultConfiguration.DEFAULT_JMX_MANAGEMENT_ENABLED
.
-
getJMXDomain
String getJMXDomain()
Returns the domain used by JMX MBeans (provided JMX management is enabled).
Default value isActiveMQDefaultConfiguration.DEFAULT_JMX_DOMAIN
.
-
setJMXDomain
Configuration setJMXDomain(String domain)
Sets the domain used by JMX MBeans (provided JMX management is enabled).Changing this JMX domain is required if multiple ActiveMQ Artemis servers are run inside the same JVM and all servers are using the same MBeanServer.
-
isJMXUseBrokerName
boolean isJMXUseBrokerName()
whether or not to use the broker name in the JMX tree
-
setJMXUseBrokerName
org.apache.activemq.artemis.core.config.impl.ConfigurationImpl setJMXUseBrokerName(boolean jmxUseBrokerName)
whether or not to use the broker name in the JMX tree
-
getIncomingInterceptorClassNames
List<String> getIncomingInterceptorClassNames()
Returns the list of interceptors classes used by this server for incoming messages (i.e. those being delivered to the server from clients).
-
getOutgoingInterceptorClassNames
List<String> getOutgoingInterceptorClassNames()
Returns the list of interceptors classes used by this server for outgoing messages (i.e. those being delivered to clients from the server).
-
setIncomingInterceptorClassNames
Configuration setIncomingInterceptorClassNames(List<String> interceptors)
Sets the list of interceptors classes used by this server for incoming messages (i.e. those being delivered to the server from clients).
Classes must implementInterceptor
.
-
setOutgoingInterceptorClassNames
Configuration setOutgoingInterceptorClassNames(List<String> interceptors)
Sets the list of interceptors classes used by this server for outgoing messages (i.e. those being delivered to clients from the server).
Classes must implementInterceptor
.
-
getConnectionTTLOverride
long getConnectionTTLOverride()
Returns the connection time to live.
This value overrides the connection time-to-live sent by the client.
Default value isActiveMQDefaultConfiguration.DEFAULT_CONNECTION_TTL_OVERRIDE
.
-
setConnectionTTLOverride
Configuration setConnectionTTLOverride(long ttl)
Sets the connection time to live.
-
isAmqpUseCoreSubscriptionNaming
boolean isAmqpUseCoreSubscriptionNaming()
Returns if to use Core subscription naming for AMQP.
-
setAmqpUseCoreSubscriptionNaming
Configuration setAmqpUseCoreSubscriptionNaming(boolean amqpUseCoreSubscriptionNaming)
Sets if to use Core subscription naming for AMQP.
-
isAsyncConnectionExecutionEnabled
@Deprecated boolean isAsyncConnectionExecutionEnabled()
Deprecated.deprecated: we decide based on the semantic context when to make things async or not Returns whether code coming from connection is executed asynchronously or not.
Default value isActiveMQDefaultConfiguration.DEFAULT_ASYNC_CONNECTION_EXECUTION_ENABLED
.
-
setEnabledAsyncConnectionExecution
@Deprecated Configuration setEnabledAsyncConnectionExecution(boolean enabled)
Deprecated.Sets whether code coming from connection is executed asynchronously or not.
-
getAcceptorConfigurations
Set<TransportConfiguration> getAcceptorConfigurations()
Returns the acceptors configured for this server.
-
setAcceptorConfigurations
Configuration setAcceptorConfigurations(Set<TransportConfiguration> infos)
Sets the acceptors configured for this server.
-
addAcceptorConfiguration
Configuration addAcceptorConfiguration(TransportConfiguration infos)
-
addAcceptorConfiguration
Configuration addAcceptorConfiguration(String name, String uri) throws Exception
Add an acceptor to the config- Parameters:
name
- the name of the acceptoruri
- the URI of the acceptor- Returns:
- this
- Throws:
Exception
- in case of Parsing errors on the URI- See Also:
- Configuring the Transport
-
clearAcceptorConfigurations
Configuration clearAcceptorConfigurations()
-
getConnectorConfigurations
Map<String,TransportConfiguration> getConnectorConfigurations()
Returns the connectors configured for this server.
-
setConnectorConfigurations
Configuration setConnectorConfigurations(Map<String,TransportConfiguration> infos)
Sets the connectors configured for this server.
-
addConnectorConfiguration
Configuration addConnectorConfiguration(String key, TransportConfiguration info)
-
addConnectorConfiguration
Configuration addConnectorConfiguration(String name, String uri) throws Exception
- Throws:
Exception
-
clearConnectorConfigurations
Configuration clearConnectorConfigurations()
-
getBroadcastGroupConfigurations
List<BroadcastGroupConfiguration> getBroadcastGroupConfigurations()
Returns the broadcast groups configured for this server.
-
setBroadcastGroupConfigurations
Configuration setBroadcastGroupConfigurations(List<BroadcastGroupConfiguration> configs)
Sets the broadcast groups configured for this server.
-
addBroadcastGroupConfiguration
Configuration addBroadcastGroupConfiguration(BroadcastGroupConfiguration config)
-
getDiscoveryGroupConfigurations
Map<String,DiscoveryGroupConfiguration> getDiscoveryGroupConfigurations()
Returns the discovery groups configured for this server.
-
setDiscoveryGroupConfigurations
Configuration setDiscoveryGroupConfigurations(Map<String,DiscoveryGroupConfiguration> configs)
Sets the discovery groups configured for this server.
-
addDiscoveryGroupConfiguration
Configuration addDiscoveryGroupConfiguration(String key, DiscoveryGroupConfiguration discoveryGroupConfiguration)
-
getGroupingHandlerConfiguration
org.apache.activemq.artemis.core.server.group.impl.GroupingHandlerConfiguration getGroupingHandlerConfiguration()
Returns the grouping handler configured for this server.
-
setGroupingHandlerConfiguration
Configuration setGroupingHandlerConfiguration(org.apache.activemq.artemis.core.server.group.impl.GroupingHandlerConfiguration groupingHandlerConfiguration)
Sets the grouping handler configured for this server.
-
getBridgeConfigurations
List<BridgeConfiguration> getBridgeConfigurations()
Returns the bridges configured for this server.
-
setBridgeConfigurations
Configuration setBridgeConfigurations(List<BridgeConfiguration> configs)
Sets the bridges configured for this server.
-
getDivertConfigurations
List<DivertConfiguration> getDivertConfigurations()
Returns the diverts configured for this server.
-
setDivertConfigurations
Configuration setDivertConfigurations(List<DivertConfiguration> configs)
Sets the diverts configured for this server.
-
addDivertConfiguration
Configuration addDivertConfiguration(DivertConfiguration config)
-
getConnectionRouters
List<ConnectionRouterConfiguration> getConnectionRouters()
Returns the redirects configured for this server.
-
setConnectionRouters
Configuration setConnectionRouters(List<ConnectionRouterConfiguration> configs)
Sets the redirects configured for this server.
-
addConnectionRouter
Configuration addConnectionRouter(ConnectionRouterConfiguration config)
-
getClusterConfigurations
List<ClusterConnectionConfiguration> getClusterConfigurations()
Returns the cluster connections configured for this server.Modifying the returned list will modify the list of
ClusterConnectionConfiguration
used by this configuration.
-
setClusterConfigurations
Configuration setClusterConfigurations(List<ClusterConnectionConfiguration> configs)
Sets the cluster connections configured for this server.
-
addClusterConfiguration
Configuration addClusterConfiguration(ClusterConnectionConfiguration config)
-
addClusterConfiguration
ClusterConnectionConfiguration addClusterConfiguration(String name, String uri) throws Exception
- Throws:
Exception
-
clearClusterConfigurations
Configuration clearClusterConfigurations()
-
addAMQPConnection
Configuration addAMQPConnection(AMQPBrokerConnectConfiguration amqpBrokerConnectConfiguration)
-
getAMQPConnection
List<AMQPBrokerConnectConfiguration> getAMQPConnection()
-
setAMQPConnectionConfigurations
Configuration setAMQPConnectionConfigurations(List<AMQPBrokerConnectConfiguration> amqpConnectionConfiugrations)
Quick set of all AMQP connection configurations in one call which will clear all previously set or added broker configurations.- Parameters:
amqpConnectionConfiugrations
- A list of AMQP broker connection configurations to assign to the broker.- Returns:
- this configuration object.
-
clearAMQPConnectionConfigurations
Configuration clearAMQPConnectionConfigurations()
Clears the current configuration object of all set or added AMQP connection configuration elements.- Returns:
- this configuration object.
-
getQueueConfigurations
@Deprecated List<CoreQueueConfiguration> getQueueConfigurations()
Deprecated.Returns the queues configured for this server.
-
getQueueConfigs
List<QueueConfiguration> getQueueConfigs()
-
setQueueConfigurations
@Deprecated Configuration setQueueConfigurations(List<CoreQueueConfiguration> configs)
Deprecated.Sets the queues configured for this server.
-
setQueueConfigs
Configuration setQueueConfigs(List<QueueConfiguration> configs)
Sets the queues configured for this server.
-
addQueueConfiguration
@Deprecated Configuration addQueueConfiguration(CoreQueueConfiguration config)
Deprecated.
-
addQueueConfiguration
Configuration addQueueConfiguration(QueueConfiguration config)
-
getAddressConfigurations
List<CoreAddressConfiguration> getAddressConfigurations()
Returns the addresses configured for this server.
-
setAddressConfigurations
Configuration setAddressConfigurations(List<CoreAddressConfiguration> configs)
Sets the addresses configured for this server.
-
addAddressConfiguration
Configuration addAddressConfiguration(CoreAddressConfiguration config)
Adds an addresses configuration
-
getManagementAddress
SimpleString getManagementAddress()
Returns the management address of this server.
Clients can send management messages to this address to manage this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_MANAGEMENT_ADDRESS
.
-
setManagementAddress
Configuration setManagementAddress(SimpleString address)
Sets the management address of this server.
-
getManagementNotificationAddress
SimpleString getManagementNotificationAddress()
Returns the management notification address of this server.
Clients can bind queues to this address to receive management notifications emitted by this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_MANAGEMENT_NOTIFICATION_ADDRESS
.
-
setManagementNotificationAddress
Configuration setManagementNotificationAddress(SimpleString address)
Sets the management notification address of this server.
-
getClusterUser
String getClusterUser()
Returns the cluster user for this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_CLUSTER_USER
.
-
setClusterUser
Configuration setClusterUser(String user)
Sets the cluster user for this server.
-
getClusterPassword
String getClusterPassword()
Returns the cluster password for this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_CLUSTER_PASSWORD
.
-
setClusterPassword
Configuration setClusterPassword(String password)
Sets the cluster password for this server.
-
getIDCacheSize
int getIDCacheSize()
Returns the size of the cache for pre-creating message IDs.
Default value isActiveMQDefaultConfiguration.DEFAULT_ID_CACHE_SIZE
.
-
setIDCacheSize
Configuration setIDCacheSize(int idCacheSize)
Sets the size of the cache for pre-creating message IDs.
-
isPersistIDCache
boolean isPersistIDCache()
Returns whether message ID cache is persisted.
Default value isActiveMQDefaultConfiguration.DEFAULT_PERSIST_ID_CACHE
.
-
setPersistIDCache
Configuration setPersistIDCache(boolean persist)
Sets whether message ID cache is persisted.
-
getBindingsDirectory
String getBindingsDirectory()
Returns the file system directory used to store bindings.
Default value isActiveMQDefaultConfiguration.DEFAULT_BINDINGS_DIRECTORY
.
-
getBindingsLocation
File getBindingsLocation()
The binding location related to artemis.instance.
-
setBindingsDirectory
Configuration setBindingsDirectory(String dir)
Sets the file system directory used to store bindings.
-
getPageMaxConcurrentIO
int getPageMaxConcurrentIO()
The max number of concurrent reads allowed on paging.Default value is
ActiveMQDefaultConfiguration.DEFAULT_MAX_CONCURRENT_PAGE_IO
.
-
setPageMaxConcurrentIO
Configuration setPageMaxConcurrentIO(int maxIO)
The max number of concurrent reads allowed on paging.Default = 5
-
isReadWholePage
boolean isReadWholePage()
Returns whether the whole page is read while getting message after page cache is evicted.
Default value isActiveMQDefaultConfiguration.DEFAULT_READ_WHOLE_PAGE
.
-
setReadWholePage
Configuration setReadWholePage(boolean read)
Sets whether the whole page is read while getting message after page cache is evicted.
-
getJournalDirectory
String getJournalDirectory()
Returns the file system directory used to store journal log.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_DIR
.
-
getJournalLocation
File getJournalLocation()
The location of the journal related to artemis.instance.- Returns:
-
getNodeManagerLockLocation
File getNodeManagerLockLocation()
The location of the node manager lock file related to artemis.instance.
-
setNodeManagerLockDirectory
Configuration setNodeManagerLockDirectory(String dir)
Sets the file system directory used to store the node manager lock file.
-
getNodeManagerLockDirectory
String getNodeManagerLockDirectory()
the directory that contains the lock file- Returns:
- the directory
-
setJournalDirectory
Configuration setJournalDirectory(String dir)
Sets the file system directory used to store journal log.
-
getJournalRetentionDirectory
String getJournalRetentionDirectory()
-
setJournalRetentionDirectory
Configuration setJournalRetentionDirectory(String dir)
Sets the file system directory used to store historical backup journal.
-
getJournalRetentionLocation
File getJournalRetentionLocation()
-
getJournalRetentionPeriod
long getJournalRetentionPeriod()
The retention period for the journal in milliseconds (always in milliseconds, a conversion is performed on set)
-
setJournalRetentionPeriod
Configuration setJournalRetentionPeriod(TimeUnit unit, long limit)
-
getJournalRetentionMaxBytes
long getJournalRetentionMaxBytes()
-
setJournalRetentionMaxBytes
Configuration setJournalRetentionMaxBytes(long bytes)
-
getJournalType
org.apache.activemq.artemis.core.server.JournalType getJournalType()
Returns the type of journal used by this server (NIO
,ASYNCIO
orMAPPED
).
Default value is ASYNCIO.
-
setJournalType
Configuration setJournalType(org.apache.activemq.artemis.core.server.JournalType type)
Sets the type of journal used by this server (eitherNIO
orASYNCIO
).
-
isJournalSyncTransactional
boolean isJournalSyncTransactional()
Returns whether the journal is synchronized when receiving transactional data.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_SYNC_TRANSACTIONAL
.
-
setJournalSyncTransactional
Configuration setJournalSyncTransactional(boolean sync)
Sets whether the journal is synchronized when receiving transactional data.
-
isJournalSyncNonTransactional
boolean isJournalSyncNonTransactional()
Returns whether the journal is synchronized when receiving non-transactional data.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_SYNC_NON_TRANSACTIONAL
.
-
setJournalSyncNonTransactional
Configuration setJournalSyncNonTransactional(boolean sync)
Sets whether the journal is synchronized when receiving non-transactional data.
-
getJournalFileSize
int getJournalFileSize()
Returns the size (in bytes) of each journal files.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_FILE_SIZE
.
-
setJournalFileSize
Configuration setJournalFileSize(int size)
Sets the size (in bytes) of each journal files.
-
getJournalCompactMinFiles
int getJournalCompactMinFiles()
Returns the minimal number of journal files before compacting.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_COMPACT_MIN_FILES
.
-
setJournalCompactMinFiles
Configuration setJournalCompactMinFiles(int minFiles)
Sets the minimal number of journal files before compacting.
-
getJournalPoolFiles
int getJournalPoolFiles()
Number of files that would be acceptable to keep on a pool. Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_POOL_FILES
.
-
setJournalPoolFiles
Configuration setJournalPoolFiles(int poolSize)
Number of files that would be acceptable to keep on a pool. Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_POOL_FILES
.
-
getJournalCompactPercentage
int getJournalCompactPercentage()
Returns the percentage of live data before compacting the journal.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_COMPACT_PERCENTAGE
.
-
getJournalFileOpenTimeout
int getJournalFileOpenTimeout()
- Returns:
- How long to wait when opening a new Journal file before failing
-
setJournalFileOpenTimeout
Configuration setJournalFileOpenTimeout(int journalFileOpenTimeout)
Sets the journal file open timeout
-
setJournalCompactPercentage
Configuration setJournalCompactPercentage(int percentage)
Sets the percentage of live data before compacting the journal.
-
getJournalMinFiles
int getJournalMinFiles()
Returns the number of journal files to pre-create.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_MIN_FILES
.
-
setJournalMinFiles
Configuration setJournalMinFiles(int files)
Sets the number of journal files to pre-create.
-
getJournalMaxIO_AIO
int getJournalMaxIO_AIO()
Returns the maximum number of write requests that can be in the AIO queue at any given time.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_MAX_IO_AIO
.
-
setJournalMaxIO_AIO
Configuration setJournalMaxIO_AIO(int journalMaxIO)
Sets the maximum number of write requests that can be in the AIO queue at any given time.
-
getJournalBufferTimeout_AIO
int getJournalBufferTimeout_AIO()
Returns the timeout (in nanoseconds) used to flush buffers in the AIO queue.
Default value isArtemisConstants.DEFAULT_JOURNAL_BUFFER_TIMEOUT_AIO
.
-
setJournalBufferTimeout_AIO
Configuration setJournalBufferTimeout_AIO(int journalBufferTimeout)
Sets the timeout (in nanoseconds) used to flush buffers in the AIO queue.
-
getJournalDeviceBlockSize
Integer getJournalDeviceBlockSize()
This is the device block size used on writing. This is usually translated as st_blksize from fstat. returning null mans the system should instead make a call on fstat and use st_blksize. The intention of this setting was to bypass the value in certain devices that will return a huge number as their block size (e.g. CephFS)
-
setJournalDeviceBlockSize
Configuration setJournalDeviceBlockSize(Integer deviceBlockSize)
- See Also:
getJournalDeviceBlockSize()
-
getJournalBufferSize_AIO
int getJournalBufferSize_AIO()
Returns the buffer size (in bytes) for AIO.
Default value isArtemisConstants.DEFAULT_JOURNAL_BUFFER_SIZE_AIO
.
-
setJournalBufferSize_AIO
Configuration setJournalBufferSize_AIO(int journalBufferSize)
Sets the buffer size (in bytes) for AIO.
-
getJournalMaxIO_NIO
int getJournalMaxIO_NIO()
Returns the maximum number of write requests for NIO journal.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_MAX_IO_NIO
.
-
setJournalMaxIO_NIO
Configuration setJournalMaxIO_NIO(int journalMaxIO)
Sets the maximum number of write requests for NIO journal.
-
getJournalBufferTimeout_NIO
int getJournalBufferTimeout_NIO()
Returns the timeout (in nanoseconds) used to flush buffers in the NIO.
Default value isArtemisConstants.DEFAULT_JOURNAL_BUFFER_TIMEOUT_NIO
.
-
setJournalBufferTimeout_NIO
Configuration setJournalBufferTimeout_NIO(int journalBufferTimeout)
Sets the timeout (in nanoseconds) used to flush buffers in the NIO.
-
getJournalBufferSize_NIO
int getJournalBufferSize_NIO()
Returns the buffer size (in bytes) for NIO.
Default value isArtemisConstants.DEFAULT_JOURNAL_BUFFER_SIZE_NIO
.
-
setJournalBufferSize_NIO
Configuration setJournalBufferSize_NIO(int journalBufferSize)
Sets the buffer size (in bytes) for NIO.
-
getJournalMaxAtticFiles
int getJournalMaxAtticFiles()
Returns the maximal number of data files before we can start deleting corrupted files instead of moving them to attic.
Default value isActiveMQDefaultConfiguration.DEFAULT_JOURNAL_MAX_ATTIC_FILES
.
-
setJournalMaxAtticFiles
Configuration setJournalMaxAtticFiles(int maxAtticFiles)
Sets the maximal number of data files before we can start deleting corrupted files instead of moving them to attic.
-
isCreateBindingsDir
boolean isCreateBindingsDir()
Returns whether the bindings directory is created on this server startup.
Default value isActiveMQDefaultConfiguration.DEFAULT_CREATE_BINDINGS_DIR
.
-
setCreateBindingsDir
Configuration setCreateBindingsDir(boolean create)
Sets whether the bindings directory is created on this server startup.
-
isCreateJournalDir
boolean isCreateJournalDir()
Returns whether the journal directory is created on this server startup.
Default value isActiveMQDefaultConfiguration.DEFAULT_CREATE_JOURNAL_DIR
.
-
setCreateJournalDir
Configuration setCreateJournalDir(boolean create)
Sets whether the journal directory is created on this server startup.
-
isLogJournalWriteRate
boolean isLogJournalWriteRate()
-
setLogJournalWriteRate
Configuration setLogJournalWriteRate(boolean rate)
-
getServerDumpInterval
long getServerDumpInterval()
-
setServerDumpInterval
Configuration setServerDumpInterval(long interval)
-
getMemoryWarningThreshold
int getMemoryWarningThreshold()
-
setMemoryWarningThreshold
Configuration setMemoryWarningThreshold(int memoryWarningThreshold)
-
getMemoryMeasureInterval
long getMemoryMeasureInterval()
-
setMemoryMeasureInterval
Configuration setMemoryMeasureInterval(long memoryMeasureInterval)
-
getPagingDirectory
String getPagingDirectory()
Returns the file system directory used to store paging files.
Default value isActiveMQDefaultConfiguration.DEFAULT_PAGING_DIR
.
-
setPagingDirectory
Configuration setPagingDirectory(String dir)
Sets the file system directory used to store paging files.
-
getPagingLocation
File getPagingLocation()
The paging location related to artemis.instance
-
getLargeMessagesDirectory
String getLargeMessagesDirectory()
Returns the file system directory used to store large messages.
Default value isActiveMQDefaultConfiguration.DEFAULT_LARGE_MESSAGES_DIR
.
-
getLargeMessagesLocation
File getLargeMessagesLocation()
The large message location related to artemis.instance
-
setLargeMessagesDirectory
Configuration setLargeMessagesDirectory(String directory)
Sets the file system directory used to store large messages.
-
isWildcardRoutingEnabled
boolean isWildcardRoutingEnabled()
Returns whether wildcard routing is supported by this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_WILDCARD_ROUTING_ENABLED
.
-
setWildcardRoutingEnabled
Configuration setWildcardRoutingEnabled(boolean enabled)
Sets whether wildcard routing is supported by this server.
-
getWildcardConfiguration
WildcardConfiguration getWildcardConfiguration()
-
setWildCardConfiguration
Configuration setWildCardConfiguration(WildcardConfiguration wildcardConfiguration)
-
getTransactionTimeout
long getTransactionTimeout()
Returns the timeout (in milliseconds) after which transactions is removed from the resource manager after it was created.
Default value isActiveMQDefaultConfiguration.DEFAULT_TRANSACTION_TIMEOUT
.
-
setTransactionTimeout
Configuration setTransactionTimeout(long timeout)
Sets the timeout (in milliseconds) after which transactions is removed from the resource manager after it was created.
-
isMessageCounterEnabled
boolean isMessageCounterEnabled()
Returns whether message counter is enabled for this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_MESSAGE_COUNTER_ENABLED
.
-
setMessageCounterEnabled
Configuration setMessageCounterEnabled(boolean enabled)
Sets whether message counter is enabled for this server.
-
getMessageCounterSamplePeriod
long getMessageCounterSamplePeriod()
Returns the sample period (in milliseconds) to take message counter snapshot.
Default value isActiveMQDefaultConfiguration.DEFAULT_MESSAGE_COUNTER_SAMPLE_PERIOD
.
-
setMessageCounterSamplePeriod
Configuration setMessageCounterSamplePeriod(long period)
Sets the sample period to take message counter snapshot.- Parameters:
period
- value must be greater than 1000ms
-
getMessageCounterMaxDayHistory
int getMessageCounterMaxDayHistory()
Returns the maximum number of days kept in memory for message counter.
Default value isActiveMQDefaultConfiguration.DEFAULT_MESSAGE_COUNTER_MAX_DAY_HISTORY
.
-
setMessageCounterMaxDayHistory
Configuration setMessageCounterMaxDayHistory(int maxDayHistory)
Sets the maximum number of days kept in memory for message counter.- Parameters:
maxDayHistory
- value must be greater than 0
-
getTransactionTimeoutScanPeriod
long getTransactionTimeoutScanPeriod()
Returns the frequency (in milliseconds) to scan transactions to detect which transactions have timed out.
Default value isActiveMQDefaultConfiguration.DEFAULT_TRANSACTION_TIMEOUT_SCAN_PERIOD
.
-
setTransactionTimeoutScanPeriod
Configuration setTransactionTimeoutScanPeriod(long period)
Sets the frequency (in milliseconds) to scan transactions to detect which transactions have timed out.
-
getMessageExpiryScanPeriod
long getMessageExpiryScanPeriod()
Returns the frequency (in milliseconds) to scan messages to detect which messages have expired.
Default value isActiveMQDefaultConfiguration.DEFAULT_MESSAGE_EXPIRY_SCAN_PERIOD
.
-
setMessageExpiryScanPeriod
Configuration setMessageExpiryScanPeriod(long messageExpiryScanPeriod)
Sets the frequency (in milliseconds) to scan messages to detect which messages have expired.
-
getMessageExpiryThreadPriority
@Deprecated int getMessageExpiryThreadPriority()
Deprecated.Returns the priority of the thread used to scan message expiration.
Default value isActiveMQDefaultConfiguration.DEFAULT_MESSAGE_EXPIRY_THREAD_PRIORITY
.
-
setMessageExpiryThreadPriority
@Deprecated Configuration setMessageExpiryThreadPriority(int messageExpiryThreadPriority)
Deprecated.Sets the priority of the thread used to scan message expiration.
-
getAddressQueueScanPeriod
long getAddressQueueScanPeriod()
Returns the frequency (in milliseconds) to scan addresses and queues to detect which ones should be deleted.
Default value isActiveMQDefaultConfiguration.DEFAULT_MESSAGE_EXPIRY_SCAN_PERIOD
.
-
setAddressQueueScanPeriod
Configuration setAddressQueueScanPeriod(long addressQueueScanPeriod)
Sets the frequency (in milliseconds) to scan addresses and queues to detect which ones should be deleted.
-
getAddressSettings
Map<String,org.apache.activemq.artemis.core.settings.impl.AddressSettings> getAddressSettings()
- Returns:
- A list of AddressSettings per matching to be deployed to the address settings repository
-
setAddressSettings
Configuration setAddressSettings(Map<String,org.apache.activemq.artemis.core.settings.impl.AddressSettings> addressSettings)
- Parameters:
addressSettings
- list of AddressSettings per matching to be deployed to the address settings repository
-
addAddressSetting
Configuration addAddressSetting(String key, org.apache.activemq.artemis.core.settings.impl.AddressSettings addressesSetting)
-
clearAddressSettings
Configuration clearAddressSettings()
-
getAddressesSettings
@Deprecated Map<String,org.apache.activemq.artemis.core.settings.impl.AddressSettings> getAddressesSettings()
Deprecated.
-
setAddressesSettings
@Deprecated Configuration setAddressesSettings(Map<String,org.apache.activemq.artemis.core.settings.impl.AddressSettings> addressesSettings)
Deprecated.
-
addAddressesSetting
@Deprecated Configuration addAddressesSetting(String key, org.apache.activemq.artemis.core.settings.impl.AddressSettings addressesSetting)
Deprecated.
-
clearAddressesSettings
@Deprecated Configuration clearAddressesSettings()
Deprecated.
-
setSecurityRoles
Configuration setSecurityRoles(Map<String,Set<org.apache.activemq.artemis.core.security.Role>> roles)
- Parameters:
roles
- a list of roles per matching
-
getSecurityRoles
Map<String,Set<org.apache.activemq.artemis.core.security.Role>> getSecurityRoles()
- Returns:
- a list of roles per matching
-
addSecurityRoleNameMapping
Configuration addSecurityRoleNameMapping(String internalRole, Set<String> externalRoles)
-
putSecurityRoles
Configuration putSecurityRoles(String match, Set<org.apache.activemq.artemis.core.security.Role> roles)
-
setConnectorServiceConfigurations
Configuration setConnectorServiceConfigurations(List<ConnectorServiceConfiguration> configs)
-
addConnectorServiceConfiguration
Configuration addConnectorServiceConfiguration(ConnectorServiceConfiguration config)
-
setSecuritySettingPlugins
Configuration setSecuritySettingPlugins(List<org.apache.activemq.artemis.core.server.SecuritySettingPlugin> plugins)
-
addSecuritySettingPlugin
Configuration addSecuritySettingPlugin(org.apache.activemq.artemis.core.server.SecuritySettingPlugin plugin)
-
setMetricsPlugin
@Deprecated Configuration setMetricsPlugin(org.apache.activemq.artemis.core.server.metrics.ActiveMQMetricsPlugin plugin)
Deprecated.
-
setMetricsConfiguration
Configuration setMetricsConfiguration(MetricsConfiguration metricsConfiguration)
-
getConnectorServiceConfigurations
List<ConnectorServiceConfiguration> getConnectorServiceConfigurations()
- Returns:
- list of
ConnectorServiceConfiguration
-
getSecuritySettingPlugins
List<org.apache.activemq.artemis.core.server.SecuritySettingPlugin> getSecuritySettingPlugins()
-
getMetricsPlugin
@Deprecated org.apache.activemq.artemis.core.server.metrics.ActiveMQMetricsPlugin getMetricsPlugin()
Deprecated.
-
getMetricsConfiguration
MetricsConfiguration getMetricsConfiguration()
-
setPasswordCodec
Configuration setPasswordCodec(String codec)
The default password decoder
-
getPasswordCodec
String getPasswordCodec()
Gets the default password decoder
-
setMaskPassword
Configuration setMaskPassword(Boolean maskPassword)
Sets if passwords should be masked or not. True means the passwords should be masked.
-
isMaskPassword
Boolean isMaskPassword()
If passwords are masked. True means the passwords are masked.enableda
-
setResolveProtocols
Configuration setResolveProtocols(boolean resolveProtocols)
-
getTransportConfigurations
TransportConfiguration[] getTransportConfigurations(String... connectorNames)
-
getTransportConfigurations
TransportConfiguration[] getTransportConfigurations(List<String> connectorNames)
-
isResolveProtocols
boolean isResolveProtocols()
-
copy
Configuration copy() throws Exception
- Throws:
Exception
-
setJournalLockAcquisitionTimeout
Configuration setJournalLockAcquisitionTimeout(long journalLockAcquisitionTimeout)
-
getJournalLockAcquisitionTimeout
long getJournalLockAcquisitionTimeout()
-
getHAPolicyConfiguration
HAPolicyConfiguration getHAPolicyConfiguration()
-
setHAPolicyConfiguration
Configuration setHAPolicyConfiguration(HAPolicyConfiguration haPolicyConfiguration)
-
setBrokerInstance
void setBrokerInstance(File directory)
Set the Artemis instance relative folder for data and stuff.
-
getBrokerInstance
File getBrokerInstance()
Set the Artemis instance relative folder for data and stuff.
-
isJDBC
default boolean isJDBC()
-
getStoreConfiguration
StoreConfiguration getStoreConfiguration()
-
setStoreConfiguration
Configuration setStoreConfiguration(StoreConfiguration storeConfiguration)
-
isPopulateValidatedUser
boolean isPopulateValidatedUser()
-
setPopulateValidatedUser
Configuration setPopulateValidatedUser(boolean populateValidatedUser)
-
isRejectEmptyValidatedUser
boolean isRejectEmptyValidatedUser()
-
setRejectEmptyValidatedUser
Configuration setRejectEmptyValidatedUser(boolean rejectEmptyValidatedUser)
-
debugConnectors
String debugConnectors()
It will return all the connectors in a toString manner for debug purposes.
-
setConnectionTtlCheckInterval
Configuration setConnectionTtlCheckInterval(long connectionTtlCheckInterval)
-
getConnectionTtlCheckInterval
long getConnectionTtlCheckInterval()
-
getConfigurationUrl
URL getConfigurationUrl()
-
setConfigurationUrl
Configuration setConfigurationUrl(URL configurationUrl)
-
getConfigurationFileRefreshPeriod
long getConfigurationFileRefreshPeriod()
-
setConfigurationFileRefreshPeriod
Configuration setConfigurationFileRefreshPeriod(long configurationFileRefreshPeriod)
-
getGlobalMaxSize
long getGlobalMaxSize()
-
setGlobalMaxSize
Configuration setGlobalMaxSize(long globalMaxSize)
-
setGlobalMaxMessages
Configuration setGlobalMaxMessages(long globalMaxMessages)
-
getGlobalMaxMessages
long getGlobalMaxMessages()
-
getMaxDiskUsage
int getMaxDiskUsage()
-
setMaxDiskUsage
Configuration setMaxDiskUsage(int maxDiskUsage)
-
getMinDiskFree
long getMinDiskFree()
-
setMinDiskFree
Configuration setMinDiskFree(long minDiskFree)
-
setInternalNamingPrefix
org.apache.activemq.artemis.core.config.impl.ConfigurationImpl setInternalNamingPrefix(String internalNamingPrefix)
-
setDiskScanPeriod
Configuration setDiskScanPeriod(int diskScanPeriod)
-
getDiskScanPeriod
int getDiskScanPeriod()
-
setNetworkCheckList
Configuration setNetworkCheckList(String list)
A comma separated list of IPs we could use to validate if the network is UP. In case of none of these Ips are reached (if configured) the server will be shutdown.
-
getNetworkCheckList
String getNetworkCheckList()
-
setNetworkCheckURLList
Configuration setNetworkCheckURLList(String uris)
A comma separated list of URIs we could use to validate if the network is UP. In case of none of these Ips are reached (if configured) the server will be shutdown. The difference from networkCheckList is that we will use HTTP to make this validation.
-
getNetworkCheckURLList
String getNetworkCheckURLList()
-
setNetworkCheckPeriod
Configuration setNetworkCheckPeriod(long period)
The interval on which we will perform network checks.
-
getNetworkCheckPeriod
long getNetworkCheckPeriod()
-
setNetworkCheckTimeout
Configuration setNetworkCheckTimeout(int timeout)
Time in ms for how long we should wait for a ping to finish.
-
getNetworkCheckTimeout
int getNetworkCheckTimeout()
-
setNetworCheckNIC
@Deprecated Configuration setNetworCheckNIC(String nic)
Deprecated.The NIC name to be used on network checks
-
setNetworkCheckNIC
Configuration setNetworkCheckNIC(String nic)
The NIC name to be used on network checks
-
getNetworkCheckNIC
String getNetworkCheckNIC()
-
getNetworkCheckPingCommand
String getNetworkCheckPingCommand()
-
setNetworkCheckPingCommand
Configuration setNetworkCheckPingCommand(String command)
-
getNetworkCheckPing6Command
String getNetworkCheckPing6Command()
-
setNetworkCheckPing6Command
Configuration setNetworkCheckPing6Command(String command)
-
getInternalNamingPrefix
String getInternalNamingPrefix()
-
getPageSyncTimeout
int getPageSyncTimeout()
Returns the timeout (in nanoseconds) used to sync pages.
Default value isArtemisConstants.DEFAULT_JOURNAL_BUFFER_TIMEOUT_NIO
.
-
setPageSyncTimeout
Configuration setPageSyncTimeout(int pageSyncTimeout)
Sets the timeout (in nanoseconds) used to sync pages.
-
registerBrokerPlugins
void registerBrokerPlugins(List<ActiveMQServerBasePlugin> plugins)
- Parameters:
plugins
-
-
registerBrokerPlugin
void registerBrokerPlugin(ActiveMQServerBasePlugin plugin)
- Parameters:
plugin
-
-
unRegisterBrokerPlugin
void unRegisterBrokerPlugin(ActiveMQServerBasePlugin plugin)
- Parameters:
plugin
-
-
getBrokerPlugins
List<ActiveMQServerBasePlugin> getBrokerPlugins()
- Returns:
-
getBrokerConnectionPlugins
List<ActiveMQServerConnectionPlugin> getBrokerConnectionPlugins()
- Returns:
-
getBrokerSessionPlugins
List<ActiveMQServerSessionPlugin> getBrokerSessionPlugins()
- Returns:
-
getBrokerConsumerPlugins
List<ActiveMQServerConsumerPlugin> getBrokerConsumerPlugins()
- Returns:
-
getBrokerAddressPlugins
List<ActiveMQServerAddressPlugin> getBrokerAddressPlugins()
- Returns:
-
getBrokerQueuePlugins
List<ActiveMQServerQueuePlugin> getBrokerQueuePlugins()
- Returns:
-
getBrokerBindingPlugins
List<ActiveMQServerBindingPlugin> getBrokerBindingPlugins()
- Returns:
-
getBrokerMessagePlugins
List<ActiveMQServerMessagePlugin> getBrokerMessagePlugins()
- Returns:
-
getBrokerBridgePlugins
List<ActiveMQServerBridgePlugin> getBrokerBridgePlugins()
- Returns:
-
getBrokerCriticalPlugins
List<ActiveMQServerCriticalPlugin> getBrokerCriticalPlugins()
- Returns:
-
getBrokerFederationPlugins
List<ActiveMQServerFederationPlugin> getBrokerFederationPlugins()
- Returns:
-
getBrokerAMQPFederationPlugins
List<AMQPFederationBrokerPlugin> getBrokerAMQPFederationPlugins()
- Returns:
-
getFederationConfigurations
List<FederationConfiguration> getFederationConfigurations()
- Returns:
-
getBrokerResourcePlugins
List<ActiveMQServerResourcePlugin> getBrokerResourcePlugins()
- Returns:
-
getTemporaryQueueNamespace
String getTemporaryQueueNamespace()
-
setTemporaryQueueNamespace
Configuration setTemporaryQueueNamespace(String temporaryQueueNamespace)
-
setMqttSessionScanInterval
Configuration setMqttSessionScanInterval(long mqttSessionScanInterval)
This is necessary because the MQTT session scan interval is a broker-wide setting and can't be set on a per-connector basis like most of the other MQTT-specific settings.
-
getMqttSessionScanInterval
long getMqttSessionScanInterval()
- Returns:
- See Also:
setMqttSessionScanInterval(long)
-
setMqttSessionStatePersistenceTimeout
Configuration setMqttSessionStatePersistenceTimeout(long mqttSessionStatePersistenceTimeout)
This is necessary because MQTT sessions and handled on a broker-wide basis so this can't be set on a per-connector basis like most of the other MQTT-specific settings.
-
getMqttSessionStatePersistenceTimeout
long getMqttSessionStatePersistenceTimeout()
- Returns:
- See Also:
setMqttSessionStatePersistenceTimeout(long)
-
isSuppressSessionNotifications
boolean isSuppressSessionNotifications()
Returns whether suppression of session-notifications is enabled for this server.
Default value isActiveMQDefaultConfiguration.DEFAULT_SUPPRESS_SESSION_NOTIFICATIONS
.
-
setSuppressSessionNotifications
Configuration setSuppressSessionNotifications(boolean suppressSessionNotifications)
-
getStatus
String getStatus()
-
setStatus
void setStatus(String status)
This value can reflect a desired state (revision) of config. Useful when configurationFileRefreshPeriod > 0. Eventually with some coordination we can update it from various server components.
-
getLiteralMatchMarkers
String getLiteralMatchMarkers()
-
setLiteralMatchMarkers
Configuration setLiteralMatchMarkers(String literalMatchMarkers)
-
setLargeMessageSync
Configuration setLargeMessageSync(boolean largeMessageSync)
-
isLargeMessageSync
boolean isLargeMessageSync()
-
getViewPermissionMethodMatchPattern
String getViewPermissionMethodMatchPattern()
-
setViewPermissionMethodMatchPattern
void setViewPermissionMethodMatchPattern(String permissionMatchPattern)
-
isManagementMessageRbac
boolean isManagementMessageRbac()
-
setManagementMessageRbac
void setManagementMessageRbac(boolean val)
-
getManagementRbacPrefix
String getManagementRbacPrefix()
-
setManagementRbacPrefix
void setManagementRbacPrefix(String prefix)
-
getMirrorAckManagerQueueAttempts
int getMirrorAckManagerQueueAttempts()
This configures the Mirror Ack Manager number of attempts on queues before trying page acks. The default value here is 5.
-
setMirrorAckManagerQueueAttempts
Configuration setMirrorAckManagerQueueAttempts(int queueAttempts)
-
getMirrorAckManagerPageAttempts
int getMirrorAckManagerPageAttempts()
This configures the Mirror Ack Manager number of attempts on page acks. The default value here is 2.
-
setMirrorAckManagerPageAttempts
Configuration setMirrorAckManagerPageAttempts(int pageAttempts)
-
getMirrorAckManagerRetryDelay
int getMirrorAckManagerRetryDelay()
This configures the interval in which the Mirror AckManager will retry acks when It is not intended to be configured through the XML. The default value here is 100, and this is in milliseconds.
-
setMirrorAckManagerRetryDelay
Configuration setMirrorAckManagerRetryDelay(int delay)
-
isMirrorPageTransaction
boolean isMirrorPageTransaction()
Should Mirror use Page Transactions When target destinations is paging? When a target queue on the mirror is paged, the mirror will not record a page transaction for every message. The default is false, and the overhead of paged messages will be smaller, but there is a possibility of eventual duplicates in case of interrupted communication between the mirror source and target. If you set this to true there will be a record stored on the journal for the page-transaction additionally to the record in the page store.
-
setMirrorPageTransaction
Configuration setMirrorPageTransaction(boolean ignorePageTransactions)
-
setMirrorAckManagerWarnUnacked
Configuration setMirrorAckManagerWarnUnacked(boolean warnUnacked)
should log.warn when ack retries failed.- Parameters:
warnUnacked
-- Returns:
-
isMirrorAckManagerWarnUnacked
boolean isMirrorAckManagerWarnUnacked()
-
-