Uses of Annotation Interface
org.apache.activemq.artemis.api.core.management.Attribute

Packages that use Attribute
  • Uses of Attribute in org.apache.activemq.artemis.api.core.management

    Modifier and Type
    Method
    Description
    boolean
    AddressControl.clearDuplicateIdCache()
     
    ActiveMQServerControl.getAcceptors()
    Returns the acceptors configured for this server..
    ActiveMQServerControl.getAcceptorsAsJSON()
    Returns the acceptors configured for this server using JSON serialization..
    long
    QueueControl.getAcknowledgeAttempts()
    Returns the number of messages added to this queue since it was created.
    long
    ActiveMQServerControl.getActivationSequence()
    Returns the current activation sequence number of this server; when replicated, peers may coordinate activation with this monotonic sequence.
    AddressControl.getAddress()
    Returns the name of this address.
    ClusterConnectionControl.getAddress()
    Returns the address used by this cluster connection.
    DivertControl.getAddress()
    Returns the origin address used by this divert.
    QueueControl.getAddress()
    Returns the address this queue is bound to.
    int
    ActiveMQServerControl.getAddressCount()
    Returns the number of addresses created on this server..
    int
    AddressControl.getAddressLimitPercent()
    Returns the % of memory limit that is currently in use.
    long
    ActiveMQServerControl.getAddressMemoryUsage()
    Returns the memory used by all the addresses on broker for in-memory messages.
    int
    ActiveMQServerControl.getAddressMemoryUsagePercentage()
    Returns the memory used by all the addresses on broker as a percentage of the global-max-size.
    ActiveMQServerControl.getAddressNames()
    Returns the names of the addresses created on this server..
    long
    AddressControl.getAddressSize()
    Returns the number of estimated bytes being used by all the queue(s) bound to this address; used to control paging and blocking.
    AddressControl.getAllQueueNames()
    Returns the names of both the local and remote queue(s) bound to this address.
    long
    ActiveMQServerControl.getAuthenticationCacheSize()
    Returns the runtime size of the authentication cache.
    long
    ActiveMQServerControl.getAuthenticationFailureCount()
     
    long
    ActiveMQServerControl.getAuthenticationSuccessCount()
     
    long
    ActiveMQServerControl.getAuthorizationCacheSize()
    Returns the runtime size of the authorization cache.
    long
    ActiveMQServerControl.getAuthorizationFailureCount()
     
    long
    ActiveMQServerControl.getAuthorizationSuccessCount()
     
    AddressControl.getBindingNames()
    Returns the names of all bindings (both queues and diverts) bound to this address.
    ActiveMQServerControl.getBindingsDirectory()
    Returns the file system directory used to store bindings..
    ActiveMQServerControl.getBridgeNames()
     
    long
    BaseBroadcastGroupControl.getBroadcastPeriod()
    Returns the period used by this broadcast group.
    ActiveMQServerControl.getBrokerPluginClassNames()
     
    JGroupsChannelBroadcastGroupControl.getChannelName()
    Returns the JGroups channel name.
    JGroupsFileBroadcastGroupControl.getChannelName()
    Returns jgroups channel name.
    int
    ActiveMQServerControl.getConnectionCount()
    Returns the number of clients connected to this server..
    long
    ActiveMQServerControl.getConnectionTTLOverride()
    Returns the connection time to live; this value overrides the connection time to live sent by the client.
    BaseBroadcastGroupControl.getConnectorPairs()
    Returns the pairs of live-backup connectors that are broadcasted by this broadcast group.
    BaseBroadcastGroupControl.getConnectorPairsAsJSON()
    Returns the pairs of live-backup connectors that are broadcasted by this broadcast group.
    ActiveMQServerControl.getConnectors()
    Returns the connectors configured for this server..
    ActiveMQServerControl.getConnectorsAsJSON()
    Returns the connectors configured for this server using JSON serialization..
    ActiveMQServerControl.getConnectorServices()
     
    int
    QueueControl.getConsumerCount()
    Returns the number of consumers consuming messages from this queue.
    int
    Returns the Consumers Before Dispatch.
    long
     
    long
    ActiveMQServerControl.getCurrentTimeMillis()
     
    QueueControl.getDeadLetterAddress()
    Returns the dead-letter address associated with this queue.
    long
    QueueControl.getDelayBeforeDispatch()
    Returns the Delay Before Dispatch.
    int
    QueueControl.getDeliveringCount()
    Returns the number of messages that this queue is currently delivering to its consumers.
    long
    QueueControl.getDeliveringSize()
    Returns the persistent size of messages that this queue is currently delivering to its consumers.
    BridgeControl.getDiscoveryGroupName()
    Returns the name of the discovery group used by this bridge.
    ClusterConnectionControl.getDiscoveryGroupName()
    Returns the name of the discovery group used by this cluster connection.
    int
    ActiveMQServerControl.getDiskScanPeriod()
    Returns how often the server checks for disk space usage..
    double
    ActiveMQServerControl.getDiskStoreUsage()
    Returns the percentage of total disk store use.
    ActiveMQServerControl.getDivertNames()
     
    int
    Returns the number of durable messages that this queue is currently delivering to its consumers.
    long
    Returns the size of durable messages that this queue is currently delivering to its consumers.
    long
    QueueControl.getDurableMessageCount()
    Returns the number of durable messages currently in this queue.
    long
    Returns the persistent size of durable messages currently in this queue; the persistent size of a message is the amount of space the message would take up on disk which is used to track how much data there is to consume on this queue.
    long
    Returns the number of durable scheduled messages in this queue.
    long
    Returns the size of durable scheduled messages in this queue.
    QueueControl.getExpiryAddress()
    Returns the expiry address associated with this queue.
    AcceptorControl.getFactoryClassName()
    Returns the class name of the AcceptorFactory implementation used by this acceptor.
    JGroupsFileBroadcastGroupControl.getFile()
    Returns the jgroups file name.
    JGroupsFileBroadcastGroupControl.getFileContents()
    Returns the contents of the jgroups file.
    DivertControl.getFilter()
    Returns the filter used by this divert.
    QueueControl.getFilter()
    Returns the filter associated with this queue.
    BridgeControl.getFilterString()
    Returns the filter string associated with this bridge.
    QueueControl.getFirstMessageAge()
    Returns the age of the first message in milliseconds.
    QueueControl.getFirstMessageAsJSON()
    Returns the first message on the queue as JSON.
    Returns the timestamp of the first message in milliseconds.
    BridgeControl.getForwardingAddress()
    Returns the address this bridge will forward messages to.
    DivertControl.getForwardingAddress()
    Returns the forwarding address used by this divert.
    long
    ActiveMQServerControl.getGlobalMaxSize()
    Returns the global max bytes limit for in-memory messages..
    BroadcastGroupControl.getGroupAddress()
    Returns the address this broadcast group is broadcasting to.
    int
    QueueControl.getGroupBuckets()
    Will return the group buckets.
    int
    QueueControl.getGroupCount()
    Will return the current number of active groups.
    QueueControl.getGroupFirstKey()
    Will return the header key to notify a consumer of a group change.
    int
    BroadcastGroupControl.getGroupPort()
    Returns the port this broadcast group is broadcasting to.
    ActiveMQServerControl.getHAPolicy()
     
    long
    AddressControl.getId()
    Returns the internal ID of this address.
    long
    QueueControl.getID()
    Returns this queue ID.
    int
    ActiveMQServerControl.getIDCacheSize()
    Returns the size of the cache for pre-creating message IDs..
    ActiveMQServerControl.getIncomingInterceptorClassNames()
    Returns the list of interceptors used by this server for incoming messages..
    int
    ActiveMQServerControl.getJournalBufferSize()
    Returns the size of the internal buffer on the journal..
    int
    ActiveMQServerControl.getJournalBufferTimeout()
    Returns the timeout (in nanoseconds) used to flush internal buffers on the journal..
    int
    ActiveMQServerControl.getJournalCompactMinFiles()
    Returns the minimal number of journal files before compacting..
    int
    ActiveMQServerControl.getJournalCompactPercentage()
    Return the percentage of live data before compacting the journal.
    ActiveMQServerControl.getJournalDirectory()
    Returns the file system directory used to store journal log..
    int
    ActiveMQServerControl.getJournalFileSize()
    Returns the size (in bytes) of each journal files..
    int
    ActiveMQServerControl.getJournalMaxIO()
    Returns the maximum number of write requests that can be in the AIO queue at any given time..
    int
    ActiveMQServerControl.getJournalMinFiles()
    Returns the number of journal files to pre-create..
    int
    ActiveMQServerControl.getJournalPoolFiles()
    Number of files that would be acceptable to keep on a pool
    ActiveMQServerControl.getJournalType()
    Returns the type of journal used by this server (either NIO or ASYNCIO)..
    ActiveMQServerControl.getLargeMessagesDirectory()
    Returns the file system directory used to store large messages..
    QueueControl.getLastValueKey()
    Returns key used for the last value queues.
    int
    BroadcastGroupControl.getLocalBindPort()
    Returns the local port this broadcast group is bound to.
    ActiveMQServerControl.getManagementAddress()
    Returns the management address of this server; clients can send management messages to this address to manage this server.
    ActiveMQServerControl.getManagementNotificationAddress()
    Returns the management notification address of this server; clients can bind queues to this address to receive management notifications emitted by this server.
    int
    QueueControl.getMaxConsumers()
     
    int
    ActiveMQServerControl.getMaxDiskUsage()
    Returns the disk use max limit..
    int
    ClusterConnectionControl.getMaxHops()
    Returns the maximum number of hops used by this cluster connection.
    int
    AddressControl.getMaxPageReadBytes()
    Returns the maximum number of bytes that can be read into memory from paged files.
    int
    AddressControl.getMaxPageReadMessages()
    Returns the maximum number of messages that can be read into memory from paged files.
    long
    BridgeControl.getMaxRetryInterval()
    Returns the max retry interval used by this bridge.
    long
    AddressControl.getMessageCount()
    Returns number of messages currently in all queues bound to this address (includes scheduled, paged, and in-delivery messages).
    long
    QueueControl.getMessageCount()
    Returns the number of messages currently in this queue.
    int
    ActiveMQServerControl.getMessageCounterMaxDayCount()
    Returns the maximum number of days kept in memory for message counter..
    long
    ActiveMQServerControl.getMessageCounterSamplePeriod()
    Returns the sample period (in milliseconds) to take message counter snapshot..
    long
    ActiveMQServerControl.getMessageExpiryScanPeriod()
    Returns the frequency (in milliseconds) to scan messages to detect which messages.
    long
    ActiveMQServerControl.getMessageExpiryThreadPriority()
    Deprecated.
    ClusterConnectionControl.getMessageLoadBalancingType()
    Returns the type of message load balancing strategy this bridge will use.
    long
    BridgeControl.getMessagesAcknowledged()
    The messagesAcknowledged counter is the number of messages actually received by the remote broker.
    long
    ClusterConnectionControl.getMessagesAcknowledged()
    The messagesAcknowledged counter is the number of messages actually received by a remote broker for all bridges in this cluster connection
    long
    Returns the number of messages added to this queue since it was created.
    long
    QueueControl.getMessagesAdded()
    Returns the number of messages added to this queue since it was created.
    long
    QueueControl.getMessagesExpired()
    Returns the number of messages expired from this queue since it was created.
    long
    QueueControl.getMessagesKilled()
    Returns the number of messages removed from this queue since it was created due to exceeding the max delivery attempts.
    long
    The messagesPendingAcknowledgement counter is incremented when the bridge is has forwarded a message but is waiting acknowledgement from the other broker.
    long
    ClusterConnectionControl.getMessagesPendingAcknowledgement()
    The messagesPendingAcknowledgement counter is incremented when any bridge in the cluster connection has forwarded a message and is waiting acknowledgement from the other broker.
    BridgeControl.getMetrics()
    The bridge metrics for this bridge
    ClusterConnectionControl.getMetrics()
    The current metrics for this cluster connection (aggregate over all bridges to other nodes)
    AcceptorControl.getName()
    Returns the name of the acceptor.
    ActiveMQServerControl.getName()
    Returns this server's name..
    BaseBroadcastGroupControl.getName()
    Returns the configuration name of this broadcast group.
    BridgeControl.getName()
    Returns the name of this bridge.
    BrokerConnectionControl.getName()
    Returns the name of this broker connection.
    ClusterConnectionControl.getName()
    Returns the configuration name of this cluster connection.
    QueueControl.getName()
    Returns the name of this queue.
    RemoteBrokerConnectionControl.getName()
    Returns the name of the remote broker connection.
    RemoteBrokerConnectionControl.getNodeId()
    Returns the Node ID of the remote broker connection.
    ActiveMQServerControl.getNodeID()
    Returns the node ID of this server..
    ClusterConnectionControl.getNodeID()
    Returns the node ID used by this cluster connection.
    ClusterConnectionControl.getNodes()
    Returns a map of the nodes connected to this cluster connection; keys are node IDs, values are the addresses used to connect to the nodes.
    long
    AddressControl.getNumberOfBytesPerPage()
    Returns the number of bytes used by each page for this address.
    long
    AddressControl.getNumberOfMessages()
    Deprecated.
    long
    AddressControl.getNumberOfPages()
    Returns the number of pages used by this address.
    ActiveMQServerControl.getOutgoingInterceptorClassNames()
    Returns the list of interceptors used by this server for outgoing messages..
    ActiveMQServerControl.getPagingDirectory()
    Returns the file system directory used to store paging files..
    AcceptorControl.getParameters()
    Returns the parameters used to configure this acceptor.
    int
    ActiveMQServerControl.getPendingMirrorAcks()
     
    long
    QueueControl.getPersistentSize()
    Returns the persistent size of all messages currently in this queue; the persistent size of a message is the amount of space the message would take up on disk which is used to track how much data there is to consume on this queue.
    int
    AddressControl.getPrefetchPageBytes()
    Returns the number of bytes to prefetch from storage into memory before reching maxReadBytes.
    int
    AddressControl.getPrefetchPageMessages()
    Returns the number of messages prefetch from storage into memory before reching maxReadBytes.
    int
    Will return the number of messages stuck in prepared transactions
    long
    ClusterConnectionControl.getProducerWindowSize()
     
    BrokerConnectionControl.getProtocol()
    Returns the wire protocol this broker connection is using.
    RemoteBrokerConnectionControl.getProtocol()
    Returns the wire protocol this broker connection is using.
    int
    ActiveMQServerControl.getQueueCount()
    Returns the number of queues created on this server..
    long
    AddressControl.getQueueCount()
    Returns number of local queues bound to this address.
    BridgeControl.getQueueName()
    Returns the name of the queue this bridge is consuming messages from.
    ActiveMQServerControl.getQueueNames()
    Returns the names of the queues created on this server..
    AddressControl.getQueueNames()
    Returns the names of the local queue(s) bound to this address.
    int
    BridgeControl.getReconnectAttempts()
    Returns the number of reconnection attempts used by this bridge.
    int
    BrokerConnectionControl.getReconnectAttempts()
    Returns the number of reconnection attempts configured for this broker connection.
    AddressControl.getRemoteQueueNames()
    Returns the names of the remote queue(s) bound to this address.
    long
    BridgeControl.getRetryInterval()
    Returns the retry interval used by this bridge.
    long
    BrokerConnectionControl.getRetryInterval()
    Returns the retry interval configured for this broker connection.
    long
    ClusterConnectionControl.getRetryInterval()
    Returns the connection retry interval used by this cluster connection.
    double
    Returns the retry interval multiplier used by this bridge.
    long
    QueueControl.getRingSize()
    Will return the ring size.
    AddressControl.getRoles()
    Returns the roles (name and permissions) associated with this address.
    AddressControl.getRolesAsJSON()
    Returns the roles (name and permissions) associated with this address using JSON serialization. Java objects can be recreated from JSON serialization using RoleInfo.from(String).
    long
    AddressControl.getRoutedMessageCount()
    Returns the number of messages routed to one or more bindings.
    DivertControl.getRoutingName()
    Returns the routing name of this divert.
    DivertControl.getRoutingType()
    Returns the routing type used by this divert.
    QueueControl.getRoutingType()
    The routing type of this queue.
    AddressControl.getRoutingTypes()
    Returns the routing types enabled on this address.
    AddressControl.getRoutingTypesAsJSON()
    Returns the routing types enabled on this address as JSON.
    long
    QueueControl.getScheduledCount()
    Returns the number of scheduled messages in this queue.
    long
    QueueControl.getScheduledSize()
    Returns the size of scheduled messages in this queue.
    int
    ActiveMQServerControl.getScheduledThreadPoolMaxSize()
    Returns the maximum number of threads in the scheduled thread pool..
    long
    ActiveMQServerControl.getSecurityInvalidationInterval()
    Returns the interval time (in milliseconds) to invalidate security credentials..
    int
    ActiveMQServerControl.getSessionCount()
    Returns the number of sessions on this server.
    BridgeControl.getStaticConnectors()
    Returns any list of static connectors used by this bridge.
    ClusterConnectionControl.getStaticConnectors()
    Returns the list of static connectors.
    ClusterConnectionControl.getStaticConnectorsAsJSON()
    Returns the list of static connectors as JSON.
    ActiveMQServerControl.getStatus()
     
    int
    ActiveMQServerControl.getThreadPoolMaxSize()
    Returns the maximum number of threads in the thread pool..
    ClusterConnectionControl.getTopology()
    Returns the Topology that this Cluster Connection knows about.
    long
    ActiveMQServerControl.getTotalConnectionCount()
    Returns the total number of clients which have connected to this server since it was started..
    long
    ActiveMQServerControl.getTotalConsumerCount()
    Returns the number of consumers on all the queues currently on this server..
    long
    ActiveMQServerControl.getTotalMessageCount()
    Returns the number of messages in all queues currently on the server..
    long
    ActiveMQServerControl.getTotalMessagesAcknowledged()
    Returns the number of messages acknowledged from all the queues currently on this server since they were created..
    long
    ActiveMQServerControl.getTotalMessagesAdded()
    Returns the number of messages sent to all queues currently on the server since they were created..
    long
    ActiveMQServerControl.getTotalSessionCount()
    Returns the total number of sessions created on this server since it was started.
    long
    ActiveMQServerControl.getTransactionTimeout()
    Returns the timeout (in milliseconds) after which transactions is removed.
    long
    ActiveMQServerControl.getTransactionTimeoutScanPeriod()
    Returns the frequency (in milliseconds) to scan transactions to detect which transactions.
    BridgeControl.getTransformerClassName()
    Returns the name of the org.apache.activemq.artemis.core.server.cluster.Transformer implementation associated with this bridge.
    DivertControl.getTransformerClassName()
    Returns the name of the org.apache.activemq.artemis.core.server.transformer.Transformer implementation associated with this divert.
    BridgeControl.getTransformerProperties()
    Returns a map of the properties configured for the transformer.
    DivertControl.getTransformerProperties()
    Returns a map of the key/value pairs used to configure the transformer.
    Returns a map of the properties configured for the transformer.
    Returns a map of key/value pairs used to configure the transformer in JSON form.
    DivertControl.getUniqueName()
    Returns the cluster-wide unique name of this divert.
    long
    AddressControl.getUnRoutedMessageCount()
    Returns the number of messages not routed to any bindings.
    ActiveMQServerControl.getUptime()
    Returns the uptime of this server..
    long
    ActiveMQServerControl.getUptimeMillis()
    Returns the uptime of this server..
    BrokerConnectionControl.getUri()
    Returns the connection URI for this broker connection.
    BrokerConnectionControl.getUser()
    Returns the user this broker connection is using.
    QueueControl.getUser()
    Returns the user that is associated with creating the queue.
    ActiveMQServerControl.getVersion()
    Returns this server's version..
    boolean
    ActiveMQServerControl.isActive()
     
    boolean
    ActiveMQServerControl.isAsyncConnectionExecutionEnabled()
    Returns whether code coming from connection is executed asynchronously or not..
    boolean
    AddressControl.isAutoCreated()
    Returns whether this address was created automatically in response to client action.
    boolean
    QueueControl.isAutoDelete()
    Returns whether this queue is available for auto deletion.
    boolean
    ActiveMQServerControl.isBackup()
    Returns true if this server is a backup, false if it is a primary server or if it is a backup server and has been activated.
    boolean
    ActiveMQServerControl.isClustered()
    Returns whether this server is clustered..
    boolean
    QueueControl.isConfigurationManaged()
     
    boolean
    BridgeControl.isConnected()
    Returns whether the bridge is actively connected to the remote broker.
    boolean
    BrokerConnectionControl.isConnected()
    Returns if this broker connection is currently connected to the remote.
    boolean
    ActiveMQServerControl.isCreateBindingsDir()
    Returns whether the bindings directory is created on this server startup..
    boolean
    ActiveMQServerControl.isCreateJournalDir()
    Returns whether the journal directory is created on this server startup..
    boolean
    ClusterConnectionControl.isDuplicateDetection()
    Returns whether this cluster connection use duplicate detection.
    boolean
    QueueControl.isDurable()
    Returns whether this queue is durable.
    boolean
    ActiveMQServerControl.isEmbeddedWebServerStarted()
     
    boolean
    QueueControl.isEnabled()
     
    boolean
    DivertControl.isExclusive()
    Returns true if messages will be exclusively diverted and will not be routed to the origin address; otherwise false if messages will be routed both to the origin address and the forwarding address.
    boolean
    QueueControl.isExclusive()
     
    boolean
    ActiveMQServerControl.isFailoverOnServerShutdown()
    Returns if clients failover on a server shutdown.
    boolean
    QueueControl.isGroupRebalance()
    Returns whether the groups of this queue are automatically rebalanced.
    boolean
    Returns whether the dispatch is paused when groups of this queue are automatically rebalanced.
    boolean
    BridgeControl.isHA()
    Returns whether this bridge is using high availability.
    boolean
    AddressControl.isInternal()
    Returns whether this address was created for the broker's internal use.
    boolean
    QueueControl.isInternalQueue()
    Returns whether this queue was created for the broker's internal use.
    boolean
    ActiveMQServerControl.isJournalSyncNonTransactional()
    Returns whether the journal is synchronized when receiving non-transactional data..
    boolean
    ActiveMQServerControl.isJournalSyncTransactional()
    Returns whether the journal is synchronized when receiving transactional data..
    boolean
    QueueControl.isLastValue()
     
    boolean
    ActiveMQServerControl.isMessageCounterEnabled()
    Returns whether message counter is enabled for this server..
    boolean
    AddressControl.isPaging()
    Returns whether this address is paging.
    boolean
    AddressControl.isPaused()
     
    boolean
    QueueControl.isPaused()
    Returns whether the queue is paused.
    boolean
    ActiveMQServerControl.isPersistDeliveryCountBeforeDelivery()
    Returns whether delivery count is persisted before messages are delivered to the consumers..
    boolean
    QueueControl.isPersistedPause()
    Returns whether the queue's paused status is persisted.
    boolean
    ActiveMQServerControl.isPersistenceEnabled()
    Returns whether this server is using persistence and store data..
    boolean
    ActiveMQServerControl.isPersistIDCache()
    Returns whether message ID cache is persisted..
    boolean
    QueueControl.isPurgeOnNoConsumers()
     
    boolean
    ActiveMQServerControl.isReplicaSync()
    Returns whether the initial replication synchronization process with the backup server is complete; applicable for either the primary or backup server.
    boolean
    AddressControl.isRetroactiveResource()
     
    boolean
    DivertControl.isRetroactiveResource()
     
    boolean
    QueueControl.isRetroactiveResource()
    Returns whether this queue is used for a retroactive address.
    boolean
    ActiveMQServerControl.isSecurityEnabled()
    Returns whether security is enabled for this server..
    boolean
    ActiveMQServerControl.isSharedStore()
    Returns whether this server shares its data store with a corresponding primary or backup server..
    boolean
    ActiveMQComponentControl.isStarted()
    Returns true if this component is started, false else..
    boolean
    ActiveMQServerControl.isStarted()
    Return whether this server is started.
    boolean
    AddressControl.isTemporary()
    Returns whether this address is temporary.
    boolean
    QueueControl.isTemporary()
    Returns whether this queue is temporary.
    boolean
    BridgeControl.isUseDuplicateDetection()
    Returns whether this bridge is using duplicate detection.
    boolean
    ActiveMQServerControl.isWildcardRoutingEnabled()
    Returns whether wildcard routing is supported by this server..
    void
    ActiveMQServerControl.rebuildPageCounters()
     
    void
    ActiveMQServerControl.setFailoverOnServerShutdown(boolean failoverOnServerShutdown)
    do any clients failover on a server shutdown
    void
    ActiveMQServerControl.setMessageCounterMaxDayCount(int count)
    Sets the maximum number of days kept in memory for message counter.
    void
    ActiveMQServerControl.setMessageCounterSamplePeriod(long newPeriod)
    Sets the sample period to take message counter snapshot.