- callClosingListeners() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- callFailureListeners(ActiveMQException, String) - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- changeMessagePriority(long, int) - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Changes the message's priority corresponding to the specified message ID to the specified priority.
- changeMessagesPriority(String, int) - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Changes the priority for all the message corresponding to the specified filter to the specified priority.
- ChannelBroadcastEndpointFactory - Class in org.apache.activemq.artemis.api.core
-
An implementation of BroadcastEndpointFactory that uses an externally managed JChannel for JGroups clustering.
- ChannelBroadcastEndpointFactory(JChannel, String) - Constructor for class org.apache.activemq.artemis.api.core.ChannelBroadcastEndpointFactory
-
- checkCompletion() - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
This can be optionally used to verify if the entire message has been received.
- checkDataReceived() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- checkDataReceived() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
returns true if any data has been received since the last time this method was called.
- checkFlushBatchBuffer() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
Called periodically to flush any data in the batch buffer
- checkForFailover(String) - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- cleanup() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Opposed to close, will call cleanup only on every created session and children objects.
- cleanup() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- cleanupBeforeFailover(ActiveMQException) - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- cleanupInternalProperties() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- clear() - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelManager
-
- clearProperties(Message) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- clearThreadPools() - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
- clearThreadPools(long, TimeUnit) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
- ClientConnectionLifeCycleListener - Interface in org.apache.activemq.artemis.spi.core.remoting
-
- ClientConsumer - Interface in org.apache.activemq.artemis.api.core.client
-
A ClientConsumer receives messages from ActiveMQ Artemis queues.
- ClientMessage - Interface in org.apache.activemq.artemis.api.core.client
-
A ClientMessage represents a message sent and/or received by ActiveMQ Artemis.
- ClientProducer - Interface in org.apache.activemq.artemis.api.core.client
-
A ClientProducer is used to send messages to a specific address.
- ClientProtocolManager - Interface in org.apache.activemq.artemis.spi.core.remoting
-
- ClientProtocolManagerFactory - Interface in org.apache.activemq.artemis.spi.core.remoting
-
- ClientRequestor - Class in org.apache.activemq.artemis.api.core.client
-
The ClientRequestor class helps making requests.
- ClientRequestor(ClientSession, SimpleString) - Constructor for class org.apache.activemq.artemis.api.core.client.ClientRequestor
-
Constructor for the ClientRequestor.
- ClientRequestor(ClientSession, String) - Constructor for class org.apache.activemq.artemis.api.core.client.ClientRequestor
-
- ClientSession - Interface in org.apache.activemq.artemis.api.core.client
-
A ClientSession is a single-thread object required for producing and consuming messages.
- ClientSession.AddressQuery - Interface in org.apache.activemq.artemis.api.core.client
-
Information returned by a binding query
- ClientSession.QueueQuery - Interface in org.apache.activemq.artemis.api.core.client
-
Information returned by a queue query
- ClientSessionFactory - Interface in org.apache.activemq.artemis.api.core.client
-
A ClientSessionFactory is the entry point to create and configure ActiveMQ Artemis resources to produce and consume messages.
- close(boolean) - Method in interface org.apache.activemq.artemis.api.core.BroadcastEndpoint
-
Close the endpoint.
- close() - Method in interface org.apache.activemq.artemis.api.core.client.ClientConsumer
-
Closes the consumer.
- close() - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Closes the ClientProducer.
- close() - Method in class org.apache.activemq.artemis.api.core.client.ClientRequestor
-
Closes the ClientRequestor and its session.
- close() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Closes the session.
- close() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Closes this factory and any session created by it.
- close() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Closes this factory and release all its resources
- close(boolean) - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelWrapper
-
- close(boolean) - Method in class org.apache.activemq.artemis.api.core.JGroupsBroadcastEndpoint
-
- close() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
Closes the connection.
- close() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connector
-
closes the connector
- closeChannel() - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelWrapper
-
- closeConnectionsForAddress(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Closes all the connections of clients connected to this server which matches the specified IP address.
- closeConnectionsForUser(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Closes all the connections of sessions with a matching user name.
- closeConsumer(ClientConsumer) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- closeConsumerConnectionsForAddress(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Closes all the connections of clients connected to this server which matches the specified IP address.
- closeListeners - Variable in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- ClusterConnectionControl - Interface in org.apache.activemq.artemis.api.core.management
-
A ClusterConnectionControl is used to manage a cluster connection.
- ClusterTopologyListener - Interface in org.apache.activemq.artemis.api.core.client
-
A cluster topology listener.
- commit() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Commits the current transaction.
- commitPreparedTransaction(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Heuristically commits a prepared transaction.
- configuration - Variable in class org.apache.activemq.artemis.spi.core.remoting.AbstractConnector
-
- configureTransactionTimeout(int) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- connect() - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelWrapper
-
- connect(Connection, long, long, List<Interceptor>, List<Interceptor>, TopologyResponseHandler) - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- connection - Variable in class org.apache.activemq.artemis.spi.core.protocol.ConnectionEntry
-
- Connection - Interface in org.apache.activemq.artemis.spi.core.remoting
-
The connection used by a channel to write data to.
- CONNECTION_ID_PROPERTY_NAME - Static variable in class org.apache.activemq.artemis.reader.MessageUtil
-
- connectionCreated(ActiveMQComponent, Connection, ProtocolClass) - Method in interface org.apache.activemq.artemis.spi.core.remoting.BaseConnectionLifeCycleListener
-
This method is used both by client connector creation and server connection creation through
acceptors.
- connectionDestroyed(Object) - Method in interface org.apache.activemq.artemis.spi.core.remoting.BaseConnectionLifeCycleListener
-
Called when a connection is destroyed.
- ConnectionEntry - Class in org.apache.activemq.artemis.spi.core.protocol
-
- ConnectionEntry(RemotingConnection, Executor, long, long) - Constructor for class org.apache.activemq.artemis.spi.core.protocol.ConnectionEntry
-
- connectionException(Object, ActiveMQException) - Method in interface org.apache.activemq.artemis.spi.core.remoting.BaseConnectionLifeCycleListener
-
Called when an error occurs on the connection.
- connectionExecutor - Variable in class org.apache.activemq.artemis.spi.core.protocol.ConnectionEntry
-
- ConnectionLifeCycleListener - Interface in org.apache.activemq.artemis.spi.core.remoting
-
- ConnectionLoadBalancingPolicy - Interface in org.apache.activemq.artemis.api.core.client.loadbalance
-
A ConnectionLoadBalancingPolicy defines a policy to load balance between connections.
- ConnectionOptions - Class in org.apache.activemq.artemis.uri.schema.serverLocator
-
This will represent all the possible options you could setup on URLs
When parsing the URL this will serve as an intermediate object
And it could also be a pl
- ConnectionOptions() - Constructor for class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
- connectionReadyForWrites(Object, boolean) - Method in interface org.apache.activemq.artemis.spi.core.remoting.BaseConnectionLifeCycleListener
-
- CONNECTIONS_ALLOWED - Static variable in class org.apache.activemq.artemis.uri.schema.connector.InVMTransportConfigurationSchema
-
- Connector - Interface in org.apache.activemq.artemis.spi.core.remoting
-
A Connector is used by the client for creating and controlling a connection.
- ConnectorFactory - Interface in org.apache.activemq.artemis.spi.core.remoting
-
A ConnectorFactory is used by the client for creating connectors.
- ConnectorTransportConfigurationParser - Class in org.apache.activemq.artemis.uri
-
- ConnectorTransportConfigurationParser() - Constructor for class org.apache.activemq.artemis.uri.ConnectorTransportConfigurationParser
-
- ConsumerContext - Class in org.apache.activemq.artemis.spi.core.remoting
-
- ConsumerContext() - Constructor for class org.apache.activemq.artemis.spi.core.remoting.ConsumerContext
-
- containsProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- containsProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- convertJsonValue(Object, Class) - Static method in class org.apache.activemq.artemis.api.core.JsonUtil
-
- copy() - Method in interface org.apache.activemq.artemis.api.core.Message
-
It will generate a new instance of the message encode, being a deep copy, new properties, new everything
- copy(long) - Method in interface org.apache.activemq.artemis.api.core.Message
-
It will generate a new instance of the message encode, being a deep copy, new properties, new everything
- copyHeadersAndProperties(Message) - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
Used on large messages treatment
- CORE_CLUSTER_CONNECTION - Static variable in class org.apache.activemq.artemis.api.core.management.ResourceNames
-
- CoreNotificationType - Enum in org.apache.activemq.artemis.api.core.management
-
This enum defines all core notification types
- CORRELATIONID_HEADER_NAME - Static variable in class org.apache.activemq.artemis.reader.MessageUtil
-
- countMessages(String) - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Counts the number of messages in this queue matching the specified filter.
- create(String) - Static method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
- create(String, String) - Static method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
- create(String, String, boolean) - Static method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
- createAddress(SimpleString, Set<RoutingType>, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Create Address with a single initial routing type
- createAddress(SimpleString, RoutingType, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Create Address with a single initial routing type
- createAddress(String, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- createAddress(SimpleString, Set<RoutingType>, boolean) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- createBridge(String, String, String, String, String, long, double, int, int, boolean, int, int, long, String, boolean, boolean, String, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- createBridge(String, String, String, String, String, long, double, int, int, boolean, int, long, String, boolean, boolean, String, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- createBroadcastEndpoint() - Method in interface org.apache.activemq.artemis.api.core.BroadcastEndpointFactory
-
- createBroadcastEndpoint() - Method in class org.apache.activemq.artemis.api.core.ChannelBroadcastEndpointFactory
-
- createBroadcastEndpoint() - Method in class org.apache.activemq.artemis.api.core.JGroupsFileBroadcastEndpointFactory
-
- createBroadcastEndpoint() - Method in class org.apache.activemq.artemis.api.core.JGroupsPropertiesBroadcastEndpointFactory
-
- createBroadcastEndpoint() - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- createChannel() - Method in class org.apache.activemq.artemis.api.core.JGroupsBroadcastEndpoint
-
- createChannel() - Method in class org.apache.activemq.artemis.api.core.JGroupsChannelBroadcastEndpoint
-
- createChannel() - Method in class org.apache.activemq.artemis.api.core.JGroupsFileBroadcastEndpoint
-
- createChannel() - Method in class org.apache.activemq.artemis.api.core.JGroupsPropertiesBroadcastEndpoint
-
- createConnection() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connector
-
Create and return a connection from this connector.
- createConnector(Map<String, Object>, BufferHandler, ClientConnectionLifeCycleListener, Executor, Executor, ScheduledExecutorService, ClientProtocolManager) - Method in interface org.apache.activemq.artemis.spi.core.remoting.ConnectorFactory
-
creates a new instance of a connector.
- createConnectorService(String, String, Map<String, Object>) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- createConsumer(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume message from the queue with the given name.
- createConsumer(String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume messages from the queue with the given name.
- createConsumer(SimpleString, SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume messages matching the filter from the queue with the given name.
- createConsumer(String, String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume messages matching the filter from the queue with the given name.
- createConsumer(SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages from the queue with the given name.
- createConsumer(String, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages from the queue with the given name.
- createConsumer(String, String, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
- createConsumer(SimpleString, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
- createConsumer(SimpleString, SimpleString, int, int, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
- createConsumer(String, String, int, int, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
- createConsumer(SimpleString, SimpleString, int, int, int, boolean, Executor, Executor) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- createDivert(String, String, String, String, boolean, String, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- createDivert(String, String, String, String, boolean, String, String, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- createMessage(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientMessage.
- createMessage(byte, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientMessage.
- createMessage(byte, boolean, long, long, byte) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a ClientMessage.
- createProducer() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a producer with no default address.
- createProducer(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a producer which sends messages to the given address
- createProducer(String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a producer which sends messages to the given address
- createProducer(SimpleString, int) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a producer which sends messages to the given address
- createQueue(SimpleString, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createQueue(String, String, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createQueue(String, String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createQueue(SimpleString, SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createQueue(SimpleString, SimpleString, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createQueue(String, String, String, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createQueue(SimpleString, SimpleString, SimpleString, boolean, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createQueue(String, String, String, boolean, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createQueue(SimpleString, RoutingType, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporary queue.
- createQueue(String, RoutingType, String, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporary queue.
- createQueue(String, RoutingType, String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporary queue non-durable queue.
- createQueue(SimpleString, RoutingType, SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporary queue non-durable queue.
- createQueue(SimpleString, RoutingType, SimpleString, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporary queue.
- createQueue(String, RoutingType, String, String, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporaryqueue.
- createQueue(SimpleString, RoutingType, SimpleString, SimpleString, boolean, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporary queue.
- createQueue(SimpleString, RoutingType, SimpleString, SimpleString, boolean, boolean, int, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporary queue.
- createQueue(String, RoutingType, String, String, boolean, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporaryqueue.
- createQueue(String, RoutingType, String, String, boolean, boolean, int, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a non-temporaryqueue.
- createQueue(String, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Deprecated.
- createQueue(String, String, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Create a durable queue.
- createQueue(String, String, boolean) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Deprecated.
- createQueue(String, String, boolean, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Create a queue.
- createQueue(String, String, String, boolean) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Create a queue.
- createQueue(String, String, String, boolean, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Create a queue.
- createQueue(String, String, String, String, boolean, int, boolean, boolean) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Create a queue.
- createQueue(SimpleString, SimpleString, SimpleString, boolean, boolean, boolean) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
Deprecated.
- createQueue(SimpleString, RoutingType, SimpleString, SimpleString, boolean, boolean, int, boolean, boolean) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- createServerLocator(String) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Creates an ActiveMQConnectionFactory;
- createServerLocator(boolean, TransportConfiguration...) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Create a ServerLocator which creates session factories using a static list of transportConfigurations, the ServerLocator is not updated automatically
as the cluster topology changes, and no HA backup information is propagated to the client
- createServerLocator(boolean, DiscoveryGroupConfiguration) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Create a ServerLocator which creates session factories from a set of live servers, no HA
backup information is propagated to the client The UDP address and port are used to listen for
live servers in the cluster
- createServerLocatorWithHA(TransportConfiguration...) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Create a ServerLocator which will receive cluster topology updates from the cluster as servers
leave or join and new backups are appointed or removed.
- createServerLocatorWithHA(DiscoveryGroupConfiguration) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Create a ServerLocator which will receive cluster topology updates from the cluster as servers
leave or join and new backups are appointed or removed.
- createServerLocatorWithoutHA(TransportConfiguration...) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Create a ServerLocator which creates session factories using a static list of transportConfigurations, the ServerLocator is not updated automatically
as the cluster topology changes, and no HA backup information is propagated to the client
- createServerLocatorWithoutHA(DiscoveryGroupConfiguration) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Create a ServerLocator which creates session factories from a set of live servers, no HA
backup information is propagated to the client
- createSession() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Creates a non-transacted session.
- createSession(boolean, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Creates a session.
- createSession(boolean, boolean, int) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Creates a session.
- createSession(boolean, boolean, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Creates a session.
- createSession(boolean, boolean, boolean, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Creates a session.
- createSession(String, String, boolean, boolean, boolean, boolean, int) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Creates an authenticated session.
- createSessionContext(String, String, String, boolean, boolean, boolean, boolean, int, int) - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- createSessionFactory() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Creates a ClientSessionFactory using whatever load balancing policy is in force
- createSessionFactory(String) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- createSessionFactory(TransportConfiguration) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- createSessionFactory(TransportConfiguration, int, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- createSharedQueue(SimpleString, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createSharedQueue(SimpleString, SimpleString, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createSharedQueue(SimpleString, RoutingType, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a transient queue.
- createSharedQueue(SimpleString, RoutingType, SimpleString, SimpleString, boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a transient queue.
- createSharedQueue(SimpleString, SimpleString, RoutingType, SimpleString, boolean) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
Creates a shared queue using the routing type set by the Address.
- createSharedQueue(SimpleString, SimpleString, SimpleString, boolean) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- createTemporaryQueue(SimpleString, SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createTemporaryQueue(String, String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createTemporaryQueue(SimpleString, SimpleString, SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createTemporaryQueue(String, String, String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Deprecated.
- createTemporaryQueue(SimpleString, RoutingType, SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a temporary queue.
- createTemporaryQueue(String, RoutingType, String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a temporary queue.
- createTemporaryQueue(SimpleString, RoutingType, SimpleString, SimpleString) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a temporary queue with a filter.
- createTemporaryQueue(String, RoutingType, String, String) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Creates a temporary queue with a filter.
- createTransactedSession() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Creates a transacted session.
- createTransportBuffer(int) - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- createTransportBuffer(int) - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
creates a new ActiveMQBuffer of the specified size.
- createTransportBuffer(int) - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
Create a new ActiveMQBuffer of the given size.
- createTransportConfiguration(URI, Map<String, String>, String, String) - Static method in class org.apache.activemq.artemis.uri.schema.connector.InVMTransportConfigurationSchema
-
- createXASession() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Creates a session with XA transaction semantics.
- creationTime - Variable in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- getAcceptorObjectName(String) - Method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by AcceptorControl.
- getAckBatchSize() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the acknowledgments batch size.
- getActiveMQServerObjectName() - Method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
- getAddress() - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Returns the address where messages will be sent.
- getAddress() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Returns the address that the queue is bound to.
- getAddress() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the managed address.
- getAddress() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns the address used by this cluster connection.
- getAddress() - Method in interface org.apache.activemq.artemis.api.core.management.DivertControl
-
Returns the origin address used by this divert.
- getAddress() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the address this queue is bound to.
- getAddress() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getAddressFullMessagePolicy() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getAddressInfo(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- getAddressNames() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the addresses created on this server.
- getAddressObjectName(SimpleString) - Method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by AddressControl.
- getAddressSettingsAsJSON(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
returns the address settings as a JSON string
- getAddressSimpleString() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getAddressSize() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the number of estimated bytes being used by the queue(s), used to control paging and blocking.
- getAnnotation(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getAnnotationString(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getBackup() - Method in interface org.apache.activemq.artemis.api.core.client.TopologyMember
-
Returns the TransportConfiguration relative to the backup server if any.
- getBackupGroupName() - Method in interface org.apache.activemq.artemis.api.core.client.TopologyMember
-
Returns the backup-group-name
of the live server and backup servers associated with
Topology entry.
- getBindingNames() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the names of all bindings (both queues and diverts) bound to this address
- getBindingsDirectory() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the file system directory used to store bindings.
- getBodyBuffer() - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
The buffer to write the body.
- getBodyBuffer() - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
The body used for this message.
- getBodyBuffer() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getBodyEncoder() - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
- getBodyInputStream() - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
Return the bodyInputStream for large messages
- getBodyInputStream() - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
- getBodyInputStream() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getBodySize() - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
Returns the size (in bytes) of this message's body
- getBooleanProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getBooleanProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getBridgeNames() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- getBridgeObjectName(String) - Method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by BridgeControl.
- getBroadcastEndpointFactory() - Method in class org.apache.activemq.artemis.api.core.DiscoveryGroupConfiguration
-
- getBroadcastGroupObjectName(String) - Method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by BroadcastGroupControl.
- getBroadcastPeriod() - Method in class org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration
-
- getBroadcastPeriod() - Method in interface org.apache.activemq.artemis.api.core.management.BroadcastGroupControl
-
Returns the period used by this broadcast group.
- getBuffer() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getByteProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getByteProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getBytesProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getBytesProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getCallFailoverTimeout() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the blocking calls failover timeout when the client is awaiting failover,
this is over and above the normal call timeout.
- getCallTimeout() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the blocking calls timeout.
- getChannel() - Method in class org.apache.activemq.artemis.api.core.ChannelBroadcastEndpointFactory
-
- getChannel() - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelWrapper
-
- getChannelName() - Method in class org.apache.activemq.artemis.api.core.ChannelBroadcastEndpointFactory
-
- getChannelName() - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelWrapper
-
- getChannelName() - Method in class org.apache.activemq.artemis.api.core.JGroupsFileBroadcastEndpointFactory
-
- getChannelName() - Method in class org.apache.activemq.artemis.api.core.JGroupsPropertiesBroadcastEndpointFactory
-
- getClientFailureCheckPeriod() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the period used to check if a client has failed to receive pings from the server.
- getClusterConnectionObjectName(String) - Method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by ClusterConnectionControl.
- getConfirmationWindowSize() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the size for the confirmation window of clients using this factory.
- getConnection() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Returns the code connection used by this session factory.
- getConnectionCount() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the number of clients connected to this server.
- getConnectionID() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getConnectionLoadBalancingPolicyClassName() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the class name of the connection load balancing policy.
- getConnectionTTL() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the connection time-to-live.
- getConnectionTTLOverride() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the connection time to live.
- getConnectorConfig() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
- getConnectorConfiguration() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
Return the configuration used
- getConnectorInfos() - Method in class org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration
-
- getConnectorPairs() - Method in interface org.apache.activemq.artemis.api.core.management.BroadcastGroupControl
-
Returns the pairs of live-backup connectors that are broadcasted by this broadcast group.
- getConnectorPairsAsJSON() - Method in interface org.apache.activemq.artemis.api.core.management.BroadcastGroupControl
-
Returns the pairs of live-backup connectors that are broadcasted by this broadcast group
using JSON serialization.
- getConnectors() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the connectors configured for this server.
- getConnectorsAsJSON() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the connectors configured for this server using JSON serialization.
- getConnectorServices() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- getConsumerContext() - Method in interface org.apache.activemq.artemis.api.core.client.ClientConsumer
-
The server's ID associated with this consumer.
- getConsumerCount() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Returns the number of consumers attached to the queue.
- getConsumerCount() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the number of consumers consuming messages from this queue.
- getConsumerMaxRate() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the maximum rate of message consumption for consumers created through this factory.
- getConsumerWindowSize() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the window size for flow control of the consumers created through this factory.
- getContext() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Context can be used by the application server to inject extra control, like a protocol specific on the server.
- getContext() - Method in class org.apache.activemq.artemis.api.core.RefCountMessage
-
- getCounters() - Method in class org.apache.activemq.artemis.api.core.management.DayCounterInfo
-
Returns a 24-length array corresponding to the number of messages added to the queue
for the given hour of the day.
- getCreationTime() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- getCreationTime() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
- getCreditsOnSendingFull(Message) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- getCurrentConnection() - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- getDate() - Method in class org.apache.activemq.artemis.api.core.management.DayCounterInfo
-
Returns the date of the counter.
- getDeadLetterAddress() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getDeadLetterAddress() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the dead-letter address associated with this queue.
- getDefaultActiveMQPrincipal() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
- getDefaultAddressPathSeparator() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultBindingsDirectory() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the directory to store the persisted bindings to
- getDefaultBindingsTableName() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultBridgeConfirmationWindowSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Once the bridge has received this many bytes, it sends a confirmation
- getDefaultBridgeConnectSameNode() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Upon reconnection this configures the number of time the same node on the topology will be retried before reseting the server locator and using the initial connectors
- getDefaultBridgeInitialConnectAttempts() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
maximum number of initial connection attempts, -1 means 'no limits'
- getDefaultBridgeProducerWindowSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Producer flow control
- getDefaultBridgeReconnectAttempts() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
maximum number of retry attempts, -1 means 'no limits'
- getDefaultBroadcastPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
period in milliseconds between consecutive broadcasts
- getDefaultBroadcastRefreshTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Period the discovery group waits after receiving the last broadcast from a particular server before removing that servers connector pair entry from its list.
- getDefaultClientFailureCheckPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultClusterAddress() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The default Cluster address for the Cluster connection
- getDefaultClusterCallFailoverTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How long to wait for a reply if in the middle of a fail-over.
- getDefaultClusterCallTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How long to wait for a reply
- getDefaultClusterConfirmationWindowSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The size (in bytes) of the window used for confirming data from the server connected to.
- getDefaultClusterConnectionTtl() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how long to keep a connection alive in the absence of any data arriving from the client
- getDefaultClusterFailureCheckPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The period (in milliseconds) used to check if the cluster connection has failed to receive pings from another server
- getDefaultClusterInitialConnectAttempts() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How many attempts should be made to connect initially
- getDefaultClusterMaxHops() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
maximum number of hops cluster topology is propagated
- getDefaultClusterMaxRetryInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Maximum value for retry-interval
- getDefaultClusterMessageLoadBalancingType() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
should messages be load balanced if there are no matching consumers on target?
- getDefaultClusterNotificationAttempts() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how many times this cluster connection will notify the cluster of its existence right after joining the cluster
- getDefaultClusterNotificationInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how often the cluster connection will notify the cluster of its existence right after joining the cluster
- getDefaultClusterPassword() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Cluster password.
- getDefaultClusterReconnectAttempts() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How many attempts should be made to reconnect after failure
- getDefaultClusterRetryInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
period (in ms) between successive retries
- getDefaultClusterRetryIntervalMultiplier() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
multiplier to apply to the retry-interval
- getDefaultClusterUser() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Cluster username.
- getDefaultConfigurationFileRefreshPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultConnectionTtl() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how long to keep a connection alive in the absence of any data arriving from the client.
- getDefaultConnectionTtlCheckInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultConnectionTtlOverride() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
if set, this will override how long (in ms) to keep a connection alive without receiving a ping.
- getDefaultDatabaseUrl() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The default database URL, used with DATABASE store type.
- getDefaultDiskScanPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultDivertRoutingType() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how the divert should handle the message's routing type
- getDefaultDriverClassName() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultFailbackDelay() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultFileDeployerScanPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultGracefulShutdownTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that graceful shutdown is enabled
- getDefaultGroupingHandlerGroupTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How long a group binding will be used, -1 means for ever.
- getDefaultGroupingHandlerReaperPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How often the reaper will be run to check for timed out group bindings.
- getDefaultGroupingHandlerTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How long to wait for a decision
- getDefaultHapolicyBackupPortOffset() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The offset to use for the Connectors and Acceptors when creating a new backup server.
- getDefaultHapolicyBackupRequestRetries() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How many times the live server will try to request a backup, -1 means for ever.
- getDefaultHapolicyBackupRequestRetryInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How long to wait for retries between attempts to request a backup server.
- getDefaultHapolicyBackupStrategy() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The backup strategy to use if we are a backup or for any colocated backups.
- getDefaultHapolicyMaxBackups() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Whether or not this live server will accept backup requests from other live servers.
- getDefaultHapolicyType() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
what kind of HA Policy should we use
- getDefaultIdCacheSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the size of the cache for pre-creating message ID's
- getDefaultInitialReplicationSyncTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
if we have to start as a replicated server this is the delay to wait before fail-back occurs
- getDefaultJmxDomain() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the JMX domain used to registered ActiveMQ Artemis MBeans in the MBeanServer
- getDefaultJournalBufferSizeAio() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultJournalBufferSizeNio() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultJournalBufferTimeoutAio() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultJournalBufferTimeoutNio() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultJournalCompactMinFiles() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The minimal number of data files before we can start compacting
- getDefaultJournalCompactPercentage() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The percentage of live data on which we consider compacting the journal
- getDefaultJournalDir() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the directory to store the journal files in
- getDefaultJournalFileSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the size (in bytes) of each journal file
- getDefaultJournalLockAcquisitionTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how long (in ms) to wait to acquire a file lock on the journal
- getDefaultJournalMaxIoAio() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultJournalMaxIoNio() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultJournalMinFiles() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how many journal files to pre-create
- getDefaultJournalPoolFiles() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
How many journal files can be resued
- getDefaultLargeMessagesDir() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the directory to store large messages
- getDefaultLargeMessagesTableName() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultManagementAddress() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the name of the management address to send management messages to.
- getDefaultManagementNotificationAddress() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the name of the address that consumers bind to receive management notifications
- getDefaultMaxConcurrentPageIo() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The max number of concurrent reads allowed on paging
- getDefaultMaxConsumers() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.AddressQuery
-
- getDefaultMaxDiskUsage() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultMaxGlobalSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The default global max size.
- getDefaultMaxQueueConsumers() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultMaxRetryInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Limit to the retry-interval growth (due to retry-interval-multiplier)
- getDefaultMaxSavedReplicatedJournalsSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
This specifies how many times a replicated backup server can restart after moving its files on start.
- getDefaultMemoryMeasureInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
frequency to sample JVM memory in ms (or -1 to disable memory sampling)
- getDefaultMemoryWarningThreshold() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Percentage of available memory which will trigger a warning log
- getDefaultMessageCounterMaxDayHistory() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how many days to keep message counter history
- getDefaultMessageCounterSamplePeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the sample period (in ms) to use for message counters
- getDefaultMessageExpiryScanPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how often (in ms) to scan for expired messages
- getDefaultMessageExpiryThreadPriority() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the priority of the thread expiring messages
- getDefaultMessageTableName() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The default Message Journal table name, used with DATABASE store.
- getDefaultNetworkCheckList() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultNetworkCheckNic() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultNetworkCheckPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultNetworkCheckTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultNetworkCheckURLList() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultPageStoreTableName() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultPagingDir() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
the directory to store paged messages in
- getDefaultPurgeOnNoConsumers() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultQuorumSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultRetryIntervalMultiplier() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
multiplier to apply to successive retry intervals
- getDefaultRoutingType() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaults() - Method in interface org.apache.activemq.artemis.api.core.TransportConfigurationHelper
-
- getDefaultScheduledThreadPoolMaxSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Maximum number of threads to use for the scheduled thread pool
- getDefaultSecurityInvalidationInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how long (in ms) to wait before invalidating the security cache
- getDefaultServerDumpInterval() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Interval to log server specific information (e.g.
- getDefaultStoreType() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
The default storage type.
- getDefaultSystemPropertyPrefix() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDefaultThreadPoolMaxSize() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Maximum number of threads to use for the thread pool.
- getDefaultTransactionTimeout() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how long (in ms) before a transaction can be removed from the resource manager after create time
- getDefaultTransactionTimeoutScanPeriod() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
how often (in ms) to scan for timeout transactions
- getDefaultVoteOnReplicationFailure() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getDeliveringCount() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the number of messages that this queue is currently delivering to its consumers.
- getDeliveryCount() - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
Returns the number of times this message was delivered.
- getDiscoveryGroupConfiguration() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
The discovery group configuration
- getDiscoveryGroupConfiguration(URI, Map<String, String>, String) - Static method in class org.apache.activemq.artemis.uri.schema.serverLocator.JGroupsServerLocatorSchema
-
- getDiscoveryGroupConfiguration(URI, Map<String, String>, String, int, String) - Static method in class org.apache.activemq.artemis.uri.schema.serverLocator.UDPServerLocatorSchema
-
- getDiscoveryGroupName() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns the name of the discovery group used by this bridge.
- getDiscoveryGroupName() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns the name of the discovery group used by this cluster connection.
- getDiscoveryInitialWaitTimeout() - Method in class org.apache.activemq.artemis.api.core.DiscoveryGroupConfiguration
-
- getDiskScanPeriod() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns how often the server checks for disk space usage.
- getDivertNames() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- getDivertObjectName(String, String) - Method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by DivertControl.
- getDoubleProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getDoubleProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getDuplicateIDBytes() - Method in interface org.apache.activemq.artemis.api.core.Message
-
it will translate a property named HDR_DUPLICATE_DETECTION_ID.
- getDuplicateProperty() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getEncodeSize() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Returns the size of the encoded message.
- getEndOfBodyPosition() - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
- getEndpointFactory() - Method in class org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration
-
- getExpiration() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Returns the expiration time of this message.
- getExpiryAddress() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getExpiryAddress() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the expiry address associated with this queue.
- getExtraParams() - Method in class org.apache.activemq.artemis.api.core.TransportConfiguration
-
- getFactoryClassName() - Method in interface org.apache.activemq.artemis.api.core.management.AcceptorControl
-
Returns the class name of the AcceptorFactory implementation
used by this acceptor.
- getFactoryClassName() - Method in class org.apache.activemq.artemis.api.core.TransportConfiguration
-
Returns the class name of ConnectorFactory being used by this TransportConfiguration
- getFactoryName() - Method in class org.apache.activemq.artemis.uri.schema.connector.InVMTransportConfigurationSchema
-
- getFactoryName(URI) - Method in class org.apache.activemq.artemis.uri.schema.connector.TCPTransportConfigurationSchema
-
- getFailureListeners() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- getFailureListeners() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
return all the failure listeners
- getFile() - Method in class org.apache.activemq.artemis.api.core.JGroupsFileBroadcastEndpointFactory
-
- getFilter() - Method in interface org.apache.activemq.artemis.api.core.management.DivertControl
-
Returns the filter used by this divert.
- getFilter() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the filter associated with this queue.
- getFilterString() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Returns the queue's filter string (or null
if the queue has no filter).
- getFilterString() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns the filter string associated with this bridge.
- getFirstMessageAge() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the age of the first message in milliseconds.
- getFirstMessageAsJSON() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the first message on the queue as JSON
- getFirstMessageTimestamp() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the timestamp of the first message in milliseconds.
- getFloatProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getFloatProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getForwardingAddress() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns the address this bridge will forward messages to.
- getForwardingAddress() - Method in interface org.apache.activemq.artemis.api.core.management.DivertControl
-
Returns the forwarding address used by this divert.
- getGlobalMaxSize() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the global max bytes limit for in-memory messages.
- getGlobalScheduledThreadPool() - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
- getGlobalScheduledThreadPoolSize() - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
- getGlobalThreadPool() - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
- getGlobalThreadPoolSize() - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
- getGroupAddress() - Method in interface org.apache.activemq.artemis.api.core.management.BroadcastGroupControl
-
Returns the address this broadcast group is broadcasting to.
- getGroupAddress() - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- getGroupID() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the group ID that will be eventually set on each message for the property
Message.HDR_GROUP_ID
.
- getGroupID() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getGroupPort() - Method in interface org.apache.activemq.artemis.api.core.management.BroadcastGroupControl
-
Returns the port this broadcast group is broadcasting to.
- getGroupPort() - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- getHeadersAndPropertiesEncodeSize() - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
- getHost() - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
- getID() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns this queue ID.
- getID() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- getID() - Method in class org.apache.activemq.artemis.spi.core.protocol.ConnectionEntry
-
- getID() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
- getID() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
returns the unique id of this wire.
- getIDCacheSize() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the size of the cache for pre-creating message IDs.
- getIncomingInterceptorClassNames() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the list of interceptors used by this server for incoming messages.
- getIncomingInterceptorList() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- getInitialConnectAttempts() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- getInitialMessagePacketSize() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the initial size of messages created through this factory.
- getInstance() - Static method in class org.apache.activemq.artemis.api.core.jgroups.JChannelManager
-
- getInternalNamingPrefix() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getIntProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getIntProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getJChannel(String, JGroupsBroadcastEndpoint) - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelManager
-
- getJMSCorrelationID(Message) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- getJMSCorrelationIDAsBytes(Message) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- getJMSReplyTo(Message) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- getJMSType(Message) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- getJournalBufferSize() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the size of the internal buffer on the journal.
- getJournalBufferTimeout() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the timeout (in nanoseconds) used to flush internal buffers on the journal.
- getJournalCompactMinFiles() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the minimal number of journal files before compacting.
- getJournalCompactPercentage() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Return the percentage of live data before compacting the journal.
- getJournalDirectory() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the file system directory used to store journal log.
- getJournalFileSize() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the size (in bytes) of each journal files.
- getJournalMaxIO() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the maximum number of write requests that can be in the AIO queue at any given time.
- getJournalMinFiles() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the number of journal files to pre-create.
- getJournalType() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the type of journal used by this server (either NIO
or ASYNCIO
).
- getLargeMessagesDirectory() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the file system directory used to store large messages.
- getLastException() - Method in interface org.apache.activemq.artemis.api.core.client.ClientConsumer
-
Returns the last exception thrown by a call to this consumer's MessageHandler.
- getLastValueProperty() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getLive() - Method in interface org.apache.activemq.artemis.api.core.client.TopologyMember
-
- getLocalAddress() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- getLocalAddress() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
Returns a string representation of the local address this connection is connected to.
- getLocalBindAddress() - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- getLocalBindPort() - Method in interface org.apache.activemq.artemis.api.core.management.BroadcastGroupControl
-
Returns the local port this broadcast group is bound to.
- getLocalBindPort() - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- getLocator() - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManagerFactory
-
- getLongProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getLongProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getManagementAddress() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the management address of this server.
- getManagementNotificationAddress() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the management notification address of this server.
- getMaxConsumers() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
- getMaxConsumers() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
- getMaxDeliveryAttempts() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getMaxDiskUsage() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the disk use max limit.
- getMaxHops() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns the maximum number of hops used by this cluster connection.
- getMaxRate() - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Returns the maximum rate at which a ClientProducer can send messages per second.
- getMaxRedeliveryDelay() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getMaxRetryInterval() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the maximum retry interval (in the case a retry interval multiplier has been specified).
- getMaxSizeBytes() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getMemoryEstimate() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getMessageCount() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Returns the number of messages in the queue.
- getMessageCount() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
- getMessageCount() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the number of messages currently in this queue.
- getMessageCounterMaxDayCount() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the maximum number of days kept in memory for message counter.
- getMessageCounterSamplePeriod() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the sample period (in milliseconds) to take message counter snapshot.
- getMessageExpiryScanPeriod() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the frequency (in milliseconds) to scan messages to detect which messages
have expired.
- getMessageExpiryThreadPriority() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the priority of the thread used to scan message expiration.
- getMessageHandler() - Method in interface org.apache.activemq.artemis.api.core.client.ClientConsumer
-
Returns the MessageHandler associated to this consumer.
- getMessageID() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Returns the messageID.
- getMessageLoadBalancingType() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Return the type of message load balancing strategy this bridge will use.
- getMessagesAcknowledged() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the number of messages added to this queue since it was created.
- getMessagesAdded() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the number of messages added to this queue since it was created.
- getMessagesExpired() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the number of messages expired from this queue since it was created.
- getMessagesKilled() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the number of messages removed from this queue since it was created due to exceeding the max delivery attempts.
- getMinLargeMessageSize() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the large message size threshold.
- getName() - Method in class org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration
-
- getName() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Return the name of the queue
- getName() - Method in class org.apache.activemq.artemis.api.core.DiscoveryGroupConfiguration
-
- getName() - Method in interface org.apache.activemq.artemis.api.core.management.AcceptorControl
-
Returns the name of the acceptor
- getName() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns the name of this bridge
- getName() - Method in interface org.apache.activemq.artemis.api.core.management.BroadcastGroupControl
-
Returns the configuration name of this broadcast group.
- getName() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns the configuration name of this cluster connection.
- getName() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the name of this queue.
- getName() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns the name of the role.
- getName() - Method in class org.apache.activemq.artemis.api.core.TransportConfiguration
-
Returns the name of this TransportConfiguration.
- getName() - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- getNodeId() - Method in interface org.apache.activemq.artemis.api.core.client.TopologyMember
-
Returns the nodeId of the server.
- getNodeID() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the node ID of this server.
- getNodeID() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns the node ID used by this cluster connection.
- getNodes() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns a map of the nodes connected to this cluster connection.
- getNumberOfBytesPerPage() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the number of bytes used by each page for this address.
- getNumberOfMessages() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the sum of messages on queue(s), including messages in delivery.
- getNumberOfPages() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the number of pages used by this address.
- getObjectProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getObjectProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getOutgoingInterceptorClassNames() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the list of interceptors used by this server for outgoing messages.
- getOutgoingInterceptorList() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- getPageCacheMaxSize() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getPageSizeBytes() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getPagingDirectory() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the file system directory used to store paging files.
- getParameters() - Method in interface org.apache.activemq.artemis.api.core.management.AcceptorControl
-
Returns the parameters used to configure this acceptor
- getParams() - Method in class org.apache.activemq.artemis.api.core.TransportConfiguration
-
Returns any parameters set for this TransportConfiguration
- getPersister() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getPersistSize() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getPort() - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
- getPriority() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Returns the message priority.
- getProducerMaxRate() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the maximum rate of message production for producers created through this factory.
- getProducerWindowSize() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the window size for flow control of the producers created through this factory.
- getProperties() - Method in class org.apache.activemq.artemis.api.core.JGroupsPropertiesBroadcastEndpointFactory
-
- getPropertyNames() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Returns all the names of the properties for this message.
- getPropertyNames(Message) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- getPropMaskPassword() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getPropPasswordCodec() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- getProtocolConnection() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
- getProtocolManagerFactory() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- getQueueName() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns the name of the queue this bridge is consuming messages from.
- getQueueNames() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.AddressQuery
-
Returns the names of the queues bound to the binding.
- getQueueNames() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the names of the queues created on this server.
- getQueueNames(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the names of the queues created on this server with the given routing-type.
- getQueueNames() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the names of the queues bound to this address.
- getQueueObjectName(SimpleString, SimpleString, RoutingType) - Method in class org.apache.activemq.artemis.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by QueueControl.
- getReadOnlyBodyBuffer() - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
Returns a new Buffer slicing the current Body.
- getReconnectAttempts() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the maximum number of attempts to retry connection in case of failure.
- getReconnectAttempts() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns the number of reconnection attempts used by this bridge.
- getReconnectID() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- getRedeliveryDelay() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getRedeliveryMultiplier() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getRedistributionDelay() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getRefCount() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getRefCount() - Method in class org.apache.activemq.artemis.api.core.RefCountMessage
-
- getRefreshTimeout() - Method in class org.apache.activemq.artemis.api.core.DiscoveryGroupConfiguration
-
- getRemoteAddress() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- getRemoteAddress() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
returns a string representation of the remote address of this connection
- getRemoteAddress() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
Returns a string representation of the remote address this connection is connected to.
- getRemotingConnection() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- getReplyTo() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getResult(ICoreMessage) - Static method in class org.apache.activemq.artemis.api.core.management.ManagementHelper
-
Returns the result of an operation invocation or an attribute value.
- getResult(ICoreMessage, Class) - Static method in class org.apache.activemq.artemis.api.core.management.ManagementHelper
-
Returns the result of an operation invocation or an attribute value.
- getResults(ICoreMessage) - Static method in class org.apache.activemq.artemis.api.core.management.ManagementHelper
-
Returns the result of an operation invocation or an attribute value.
- getRetryInterval() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the time to retry connections created by this factory after failure.
- getRetryInterval() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns the retry interval used by this bridge.
- getRetryInterval() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns the connection retry interval used by this cluster connection.
- getRetryIntervalMultiplier() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the multiplier to apply to successive retry intervals.
- getRetryIntervalMultiplier() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns the retry interval multiplier used by this bridge.
- getRoles(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- getRoles() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the roles (name and permissions) associated with this address.
- getRolesAsJSON(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- getRolesAsJSON() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns the roles (name and permissions) associated with this address
using JSON serialization.
- getRoutingName() - Method in interface org.apache.activemq.artemis.api.core.management.DivertControl
-
Returns the routing name of this divert.
- getRoutingType() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
- getRoutingType() - Method in interface org.apache.activemq.artemis.api.core.management.DivertControl
-
Returns the routing type used by this divert.
- getRoutingType() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
The routing type of this queue.
- getRoutingType() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getRoutingTypes() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
- getRoutingTypesAsJSON() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
- getScaleDownGroupName() - Method in interface org.apache.activemq.artemis.api.core.client.TopologyMember
-
Returns the scale-down-group-name
of the live server with this Topology entry.
- getScheduledCount() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns the number of scheduled messages in this queue.
- getScheduledDeliveryTime() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Used to calculate what is the delivery time.
- getScheduledThreadPoolMaxSize() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the maximum size of the scheduled thread pool.
- getScheduledThreadPoolMaxSize() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the maximum number of threads in the scheduled thread pool.
- getSchemaName() - Method in class org.apache.activemq.artemis.uri.schema.connector.InVMTransportConfigurationSchema
-
- getSchemaName() - Method in class org.apache.activemq.artemis.uri.schema.connector.TCPTransportConfigurationSchema
-
- getSchemaName() - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.InVMServerLocatorSchema
-
- getSchemaName() - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.JGroupsServerLocatorSchema
-
- getSchemaName() - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.TCPServerLocatorSchema
-
- getSchemaName() - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.UDPServerLocatorSchema
-
- getSecurityInvalidationInterval() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the interval time (in milliseconds) to invalidate security credentials.
- getServerLocator() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
- getServerVersion() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- getSession() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- getSessionFactory() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Return the sessionFactory used to created this Session.
- getSessionFactory() - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- getShortProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getShortProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getSimpleStringProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getSimpleStringProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getSlowConsumerCheckPeriod() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getSlowConsumerPolicy() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getSlowConsumerThreshold() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- getStaticConnectors() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns any list of static connectors used by this bridge
- getStaticConnectors() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns the list of static connectors
- getStaticConnectorsAsJSON() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Returns the list of static connectors as JSON
- getStaticTransportConfigurations() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns an array of TransportConfigurations representing the static list of live servers used
when creating this object
- getStringProperty(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getStringProperty(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getThreadPoolMaxSize() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the maximum size of the thread pool.
- getThreadPoolMaxSize() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the maximum number of threads in the thread pool.
- getTimestamp() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getTopology() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Exposes the Topology used by this ServerLocator.
- getTopology() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Return the Topology that this Cluster Connection knows about
- getTotalConnectionCount() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the number of clients which have connected to this server since it was started.
- getTotalConsumerCount() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the number of messages sent to this server since it was started.
- getTotalMessageCount() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the number of messages in all queues on the server.
- getTotalMessagesAcknowledged() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the number of messages sent to this server since it was started.
- getTotalMessagesAdded() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the number of messages sent to this server since it was started.
- getTransactionTimeout() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the timeout (in milliseconds) after which transactions is removed
from the resource manager after it was created.
- getTransactionTimeoutScanPeriod() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the frequency (in milliseconds) to scan transactions to detect which transactions
have timed out.
- getTransformerClassName() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Return the name of the org.apache.activemq.artemis.core.server.cluster.Transformer implementation associated with this bridge.
- getTransformerClassName() - Method in interface org.apache.activemq.artemis.api.core.management.DivertControl
-
Return the name of the org.apache.activemq.artemis.core.server.cluster.Transformer implementation associated with this divert.
- getTransportConfigurations(URI, Map<String, String>, Set<String>, String, String) - Static method in class org.apache.activemq.artemis.uri.schema.connector.TCPTransportConfigurationSchema
-
- getTransportConnection() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- getTransportConnection() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
return the underlying Connection.
- getType() - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
Return the type of the message
- getType() - Method in enum org.apache.activemq.artemis.api.core.management.CoreNotificationType
-
- getType() - Method in interface org.apache.activemq.artemis.api.core.management.NotificationType
-
- getType() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- getUniqueEventID() - Method in interface org.apache.activemq.artemis.api.core.client.TopologyMember
-
- getUniqueName() - Method in interface org.apache.activemq.artemis.api.core.management.DivertControl
-
Returns the cluster-wide unique name of this divert.
- getUptime() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the uptime of this server.
- getUptimeMillis() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns the uptime of this server.
- getUri(TransportConfiguration[]) - Static method in class org.apache.activemq.artemis.uri.schema.serverLocator.InVMServerLocatorSchema
-
- getURI(String, TransportConfiguration[]) - Static method in class org.apache.activemq.artemis.uri.schema.serverLocator.TCPServerLocatorSchema
-
- getUserID() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Returns the userID - this is an optional user specified UUID that can be set to identify the message
and will be passed around with the message
- getVersion() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Returns the server's incrementingVersion.
- getVersion() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns this server's version.
- getXAResource() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Returns the XAResource associated to the session.
- ICoreMessage - Interface in org.apache.activemq.artemis.api.core
-
This interface is only to determine the API of methods required for Core Messages
- idGenerator - Variable in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- IGNORED - Static variable in class org.apache.activemq.artemis.uri.schema.serverLocator.UDPServerLocatorSchema
-
- incrementDurableRefCount() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- incrementDurableRefCount() - Method in class org.apache.activemq.artemis.api.core.RefCountMessage
-
- incrementRefCount() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- incrementRefCount() - Method in class org.apache.activemq.artemis.api.core.RefCountMessage
-
- individualAcknowledge() - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
Acknowledges reception of a single message.
- initChannel() - Method in class org.apache.activemq.artemis.api.core.JGroupsBroadcastEndpoint
-
- INITIAL_CONNECT_ATTEMPTS - Static variable in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
- initializeGlobalThreadPoolProperties() - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Initializes the global thread pools properties from System properties.
- injectPools(ExecutorService, ScheduledExecutorService) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Warning: This method has to be called before any clients or servers is started on the JVM otherwise previous ServerLocator would be broken after this call.
- intercept(P, RemotingConnection) - Method in interface org.apache.activemq.artemis.api.core.BaseInterceptor
-
Intercepts a packet which is received before it is sent to the channel
- Interceptor - Interface in org.apache.activemq.artemis.api.core
-
This is class is a simple way to intercepting calls on ActiveMQ Artemis client and servers.
- internalCloseChannel(JChannelWrapper) - Method in class org.apache.activemq.artemis.api.core.JGroupsBroadcastEndpoint
-
Closes the channel used in this JGroups Broadcast.
- internalCloseChannel(JChannelWrapper) - Method in class org.apache.activemq.artemis.api.core.JGroupsChannelBroadcastEndpoint
-
- internalNewObject(URI, Map<String, String>, String) - Method in class org.apache.activemq.artemis.uri.schema.connector.InVMTransportConfigurationSchema
-
- internalNewObject(URI, Map<String, String>, String) - Method in class org.apache.activemq.artemis.uri.schema.connector.TCPTransportConfigurationSchema
-
- internalNewObject(URI, Map<String, String>, String) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.InVMServerLocatorSchema
-
- internalNewObject(URI, Map<String, String>, String) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.JGroupsServerLocatorSchema
-
- internalNewObject(URI, Map<String, String>, String) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.TCPServerLocatorSchema
-
- internalNewObject(URI, Map<String, String>, String) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.UDPServerLocatorSchema
-
- internalNewURI(List<TransportConfiguration>) - Method in class org.apache.activemq.artemis.uri.schema.connector.InVMTransportConfigurationSchema
-
- internalNewURI(List<TransportConfiguration>) - Method in class org.apache.activemq.artemis.uri.schema.connector.TCPTransportConfigurationSchema
-
- internalNewURI(ServerLocator) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.InVMServerLocatorSchema
-
- internalNewURI(ServerLocator) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.JGroupsServerLocatorSchema
-
- internalNewURI(ServerLocator) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.TCPServerLocatorSchema
-
- internalNewURI(ServerLocator) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.UDPServerLocatorSchema
-
- internalOpen() - Method in class org.apache.activemq.artemis.api.core.JGroupsBroadcastEndpoint
-
- InVMServerLocatorSchema - Class in org.apache.activemq.artemis.uri.schema.serverLocator
-
- InVMServerLocatorSchema() - Constructor for class org.apache.activemq.artemis.uri.schema.serverLocator.InVMServerLocatorSchema
-
- InVMTransportConfigurationSchema - Class in org.apache.activemq.artemis.uri.schema.connector
-
- InVMTransportConfigurationSchema() - Constructor for class org.apache.activemq.artemis.uri.schema.connector.InVMTransportConfigurationSchema
-
- isAlive() - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- isAsyncConnectionExecutionEnabled() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether code coming from connection is executed asynchronously or not.
- isAttributesResult(Message) - Static method in class org.apache.activemq.artemis.api.core.management.ManagementHelper
-
Returns whether the JMS message corresponds to the result of a management attribute value.
- isAutoCommitAcks() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Returns whether the session will automatically commit its transaction every time a message is acknowledged
by a ClientConsumer created by this session, false
else
- isAutoCommitSends() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Returns whether the session will automatically commit its transaction every time a message is sent
by a ClientProducer created by this session, false
else
- isAutoCreateAddresses() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.AddressQuery
-
Returns true
if auto-address-creation for this address is enabled, false
else.
- isAutoCreated() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
- isAutoCreateJmsQueues() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- isAutoCreateJmsTopics() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- isAutoCreateQueues() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.AddressQuery
-
Returns true
if auto-queue-creation for this address is enabled, false
else.
- isAutoCreateQueues() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Returns true
if auto-creation for this queue is enabled and if the queue queried is a JMS queue,
false
else.
- isAutoDeleteJmsQueues() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- isAutoDeleteJmsTopics() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- isAutoGroup() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns whether producers created through this factory will automatically
assign a group ID to the messages they sent.
- isBackup() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns true
if this server is a backup, false
if it is a live server.
- isBlockOnAcknowledge() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Returns whether the ClientConsumer created by the session will block when they acknowledge a message.
- isBlockOnAcknowledge() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns whether consumers created through this factory will block while
sending message acknowledgments or do it asynchronously.
- isBlockOnDurableSend() - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Returns whether the producer will block when sending durable messages.
- isBlockOnDurableSend() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns whether producers created through this factory will block while sending durable messages or do it asynchronously.
- isBlockOnNonDurableSend() - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Returns whether the producer will block when sending non-durable messages.
- isBlockOnNonDurableSend() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns whether producers created through this factory will block while sending non-durable messages or do it asynchronously.
- isBrowse() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can browse queues bound to the address.
- isCacheLargeMessagesClient() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
When true
, consumers created through this factory will create temporary files to
cache large messages.
- isClient() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
- isClosed() - Method in interface org.apache.activemq.artemis.api.core.client.ClientConsumer
-
Returns whether the consumer is closed or not.
- isClosed() - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Returns whether the producer is closed or not.
- isClosed() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Returns whether the session is closed or not.
- isClosed() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSessionFactory
-
- isClosed() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns true if close was already called
- isClustered() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether this server is clustered.
- isCompressLargeMessage() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Whether to compress large messages.
- isConsume() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can consume messages from queues bound to the address.
- isCreateAddress() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can create addresses.
- isCreateBindingsDir() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether the bindings directory is created on this server startup.
- isCreateDurableQueue() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can create durable queues bound to the address.
- isCreateJournalDir() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether the journal directory is created on this server startup.
- isCreateNonDurableQueue() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can create non-durable queues bound to the address.
- isDefaultAllowAutoFailback() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Whether a server will automatically stop when another places a request to take over its place.
- isDefaultAsyncConnectionExecutionEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
should certain incoming packets on the server be handed off to a thread from the thread pool for processing or should they be handled on the remoting thread?
- isDefaultBridgeDuplicateDetection() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
should duplicate detection headers be inserted in forwarded messages?
- isDefaultCheckForLiveServer() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Whether to check the cluster for a (live) server using our own server ID when starting up.
- isDefaultClusterDuplicateDetection() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
should duplicate detection headers be inserted in forwarded messages?
- isDefaultClusterForwardWhenNoConsumers() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- isDefaultCreateBindingsDir() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that the server will create the bindings directory on start up
- isDefaultCreateJournalDir() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that the journal directory will be created
- isDefaultDivertExclusive() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
whether this is an exclusive divert
- isDefaultFailoverOnServerShutdown() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Will this backup server come live on a normal server shutdown
- isDefaultFileDeploymentEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that the server will load configuration from the configuration files
- isDefaultGracefulShutdownEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that graceful shutdown is enabled
- isDefaultHapolicyRequestBackup() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
If true then the server will request a backup on another node
- isDefaultJmxManagementEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that the management API is available via JMX
- isDefaultJMXUseBrokerName() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- isDefaultJournalDatasync() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
- isDefaultJournalLogWriteRate() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Whether to log messages about the journal write rate
- isDefaultJournalSyncNonTransactional() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
if true wait for non transaction data to be synced to the journal before returning response to client.
- isDefaultJournalSyncTransactional() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
if true wait for transaction data to be synchronized to the journal before returning response to client
- isDefaultMaskPassword() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
This option controls whether passwords in server configuration need be masked.
- isDefaultMessageCounterEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that message counters are enabled
- isDefaultPersistDeliveryCountBeforeDelivery() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
True means that the delivery count is persisted before delivery.
- isDefaultPersistenceEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that the server will use the file based journal for persistence.
- isDefaultPersistIdCache() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that ID's are persisted to the journal
- isDefaultPopulateValidatedUser() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Will the broker populate the message with the name of the validated user
- isDefaultPurgeOnNoConsumers() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.AddressQuery
-
- isDefaultResolveProtocols() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
If true then the ActiveMQ Artemis Server will make use of any Protocol Managers that are in available on the classpath.
- isDefaultRestartBackup() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
Will this server, if a backup, restart once it has been stopped because of failback or scaling down.
- isDefaultScaleDownEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
its possible that you only want a server to partake in scale down as a receiver, via a group.
- isDefaultSecurityEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that security is enabled
- isDefaultWildcardRoutingEnabled() - Static method in class org.apache.activemq.artemis.api.config.ActiveMQDefaultConfiguration
-
true means that the server supports wild card routing
- isDeleteDurableQueue() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can delete durable queues bound to the address.
- isDeleteNonDurableQueue() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can delete non-durable queues bound to the address.
- isDestroyed() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
- isDuplicateDetection() - Method in interface org.apache.activemq.artemis.api.core.management.ClusterConnectionControl
-
Return whether this cluster connection use duplicate detection.
- isDurable() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Returns true
if the queue is durable, false
else.
- isDurable() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns whether this queue is durable.
- isDurable() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Returns whether this message is durable or not.
- isEquivalent(TransportConfiguration) - Method in class org.apache.activemq.artemis.api.core.TransportConfiguration
-
There's a case on ClusterConnections that we need to find an equivalent Connector and we can't
use a Netty Cluster Connection on an InVM ClusterConnection (inVM used on tests) for that
reason I need to test if the two instances of the TransportConfiguration are equivalent while
a test a connector against an acceptor
- isEquivalent(Map<String, Object>) - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connector
-
If the configuration is equivalent to this connector, which means
if the parameter configuration is used to create a connection to a target
node, it will be the same node as of the connections made with this connector.
- isExclusive() - Method in interface org.apache.activemq.artemis.api.core.management.DivertControl
-
Returns whether this divert is exclusive.
- isExists() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.AddressQuery
-
Returns true
if the binding exists, false
else.
- isExists() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Returns true
if the queue exists, false
else.
- isExpired() - Method in interface org.apache.activemq.artemis.api.core.Message
-
Returns whether this message is expired or not.
- isFailoverOnInitialConnection() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns true if the client will automatically attempt to connect to the backup server if the initial
connection to the live server fails
- isFailoverOnServerShutdown() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
returns if clients failover on a server shutdown
- isHA() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Whether this server receives topology notifications from the cluster as servers join or leave
the cluster.
- isHA() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns whether this bridge is using high availability
- isHa() - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
- isHA() - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
Se need both options (ha / HA in case of typos on the URI)
- isJournalSyncNonTransactional() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether the journal is synchronized when receiving non-transactional data.
- isJournalSyncTransactional() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether the journal is synchronized when receiving transactional data.
- isLargeMessage() - Method in interface org.apache.activemq.artemis.api.core.Message
-
- isLastValueQueue() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- isLoopbackMessages() - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelManager
-
- isManage() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can send management messages to the address.
- isMember(RemotingConnection) - Method in interface org.apache.activemq.artemis.api.core.client.TopologyMember
-
Returns true if this TopologyMember is the target of this remoting connection
- isMember(TransportConfiguration) - Method in interface org.apache.activemq.artemis.api.core.client.TopologyMember
-
Returns true if this configuration is the target of this remoting connection
- isMessageCounterEnabled() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether message counter is enabled for this server.
- isOperationResult(Message) - Static method in class org.apache.activemq.artemis.api.core.management.ManagementHelper
-
Returns whether the JMS message corresponds to the result of a management operation invocation.
- isPaging() - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
Returns whether this address is paging.
- isPaused() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns whether the queue is paused.
- isPersistDeliveryCountBeforeDelivery() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether delivery count is persisted before messages are delivered to the consumers.
- isPersistenceEnabled() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether this server is using persistence and store data.
- isPersistIDCache() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether message ID cache is persisted.
- isPreAcknowledge() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns whether messages will pre-acknowledged on the server before they are sent to the consumers or not.
- isPurgeOnNoConsumers() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
- isPurgeOnNoConsumers() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
- isReadyToHandle(ActiveMQBuffer) - Method in interface org.apache.activemq.artemis.spi.core.remoting.BufferDecoder
-
- isReliable() - Method in interface org.apache.activemq.artemis.spi.core.remoting.ConnectorFactory
-
Indicates if connectors from this factory are reliable or not.
- isReplicaSync() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether the initial replication synchronization process with the backup server is complete; applicable for
either the live or backup server.
- isRollbackOnly() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Returns true
if the current transaction has been flagged to rollback, false
else.
- isSameParams(TransportConfiguration) - Method in class org.apache.activemq.artemis.api.core.TransportConfiguration
-
- isSecurityEnabled() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether security is enabled for this server.
- isSend() - Method in class org.apache.activemq.artemis.api.core.management.RoleInfo
-
Returns whether this role can send messages to the address.
- isSendToDLAOnNoRoute() - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- isServerMessage() - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
We are really interested if this is a LargeServerMessage.
- isSharedStore() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether this server shares its data store with a corresponding live or backup server.
- isStarted() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQComponentControl
-
Returns true
if this component is started, false
else.
- isStarted() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Return whether this server is started.
- isStarted() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connector
-
returns true if the connector is started, oterwise false.
- isSupportReconnect() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- isSupportReconnect() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
This will check if reconnects are supported on the protocol and configuration.
- isSupportsFlowControl() - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- isSupportsFlowControl() - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
Return true if the protocol supports flow control.
- isTemporary() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession.QueueQuery
-
Return true
if the queue is temporary, false
else.
- isTemporary() - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Returns whether this queue is temporary.
- isUseDuplicateDetection() - Method in interface org.apache.activemq.artemis.api.core.management.BridgeControl
-
Returns whether this bridge is using duplicate detection.
- isUseGlobalPools() - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns whether this factory will use global thread pools (shared among all the factories in the same JVM)
or its own pools.
- isUsingProtocolHandling() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
the InVM Connection has some special handling as it doesn't use Netty ProtocolChannel
we will use this method Instead of using instanceof
- isWildcardRoutingEnabled() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Returns whether wildcard routing is supported by this server.
- isWritable(ReadyListener) - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- isWritable(ReadyListener) - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
- isWritable(ReadyListener) - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
- isWritable(ReadyListener) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- isXA() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Return true
if the session supports XA, false
else.
- saveToOutputStream(OutputStream) - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
Saves the content of the message to the OutputStream.
- scaleDown(String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
- SCHEDULED_THREAD_POOL_SIZE_PROPERTY_KEY - Static variable in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
- select(int) - Method in interface org.apache.activemq.artemis.api.core.client.loadbalance.ConnectionLoadBalancingPolicy
-
Returns the selected index according to the policy implementation.
- select(int) - Method in class org.apache.activemq.artemis.api.core.client.loadbalance.FirstElementConnectionLoadBalancingPolicy
-
- select(int) - Method in class org.apache.activemq.artemis.api.core.client.loadbalance.RandomConnectionLoadBalancingPolicy
-
Returns a pseudo random number between 0
(inclusive) and max
exclusive.
- select(int) - Method in class org.apache.activemq.artemis.api.core.client.loadbalance.RandomStickyConnectionLoadBalancingPolicy
-
- select(int) - Method in class org.apache.activemq.artemis.api.core.client.loadbalance.RoundRobinConnectionLoadBalancingPolicy
-
- send(Message) - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Sends a message to an address.
- send(Message, SendAcknowledgementHandler) - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Sends a message to the specified address instead of the ClientProducer's address.
- send(SimpleString, Message) - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Sends a message to the specified address instead of the ClientProducer's address.
- send(SimpleString, Message, SendAcknowledgementHandler) - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Sends a message to the specified address instead of the ClientProducer's address.
- send(String, Message) - Method in interface org.apache.activemq.artemis.api.core.client.ClientProducer
-
Sends a message to the specified address instead of the ClientProducer's address.
- send(Message) - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelWrapper
-
- sendACK(boolean, boolean, ClientConsumer, Message) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sendAckHandler - Variable in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sendAcknowledged(Message) - Method in interface org.apache.activemq.artemis.api.core.client.SendAcknowledgementHandler
-
Notifies the client that a message sent asynchronously has been received by the server.
- SendAcknowledgementHandler - Interface in org.apache.activemq.artemis.api.core.client
-
A SendAcknowledgementHandler notifies a client when a message sent asynchronously has been
received by the server.
- sendBuffer(ByteBuf, int) - Method in interface org.apache.activemq.artemis.api.core.Message
-
Used to send this message to an encoded medium buffer.
- sendConsumerCredits(ClientConsumer, int) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sendFullMessage(ICoreMessage, boolean, SendAcknowledgementHandler, SimpleString) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sendInitialChunkOnLargeMessage(Message) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
it should return the number of credits (or bytes) used to send this packet
- sendLargeMessageChunk(Message, long, boolean, boolean, byte[], int, SendAcknowledgementHandler) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sendMessage(Map<String, String>, int, String, boolean, String, String) - Method in interface org.apache.activemq.artemis.api.core.management.AddressControl
-
- sendMessage(Map<String, String>, int, String, boolean, String, String) - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
- sendMessagesToDeadLetterAddress(String) - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Sends all the message corresponding to the specified filter to this queue's dead letter address.
- sendMessageToDeadLetterAddress(long) - Method in interface org.apache.activemq.artemis.api.core.management.QueueControl
-
Sends the message corresponding to the specified message ID to this queue's dead letter address.
- sendProducerCreditsMessage(int, SimpleString) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sendQueueInfoToQueue(String, String) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
This method is used by ActiveMQ Artemis clustering and must not be called by ActiveMQ Artemis clients.
- sendServerLargeMessageChunk(Message, long, boolean, boolean, byte[], SendAcknowledgementHandler) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sendSubscribeTopology(boolean) - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- ServerLocator - Interface in org.apache.activemq.artemis.api.core.client
-
The serverLocator locates a server, but beyond that it locates a server based on a list.
- ServerLocatorParser - Class in org.apache.activemq.artemis.uri
-
- ServerLocatorParser() - Constructor for class org.apache.activemq.artemis.uri.ServerLocatorParser
-
- session - Variable in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sessionClose() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- SessionContext - Class in org.apache.activemq.artemis.spi.core.remoting
-
- SessionContext(RemotingConnection) - Constructor for class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- SessionFailureListener - Interface in org.apache.activemq.artemis.api.core.client
-
A SessionFailureListener notifies the client when a failure occurred on the session.
- sessionStart() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- sessionStop() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- setAckBatchSize(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the acknowledgments batch size.
- setAddress(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setAddress(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setAnnotation(SimpleString, Object) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setAutoGroup(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets whether producers created through this factory will automatically
assign a group ID to the messages they sent.
- setAutoRead(boolean) - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
This will disable reading from the channel.
- setBlockOnAcknowledge(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets whether consumers created through this factory will block while
sending message acknowledgments or do it asynchronously.
- setBlockOnDurableSend(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets whether producers created through this factory will block while sending durable messages or do it asynchronously.
- setBlockOnNonDurableSend(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets whether producers created through this factory will block while sending non-durable messages or do it asynchronously.
- setBodyInputStream(InputStream) - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
Sets the body's IntputStream.
- setBroadcastEndpointFactory(BroadcastEndpointFactory) - Method in class org.apache.activemq.artemis.api.core.DiscoveryGroupConfiguration
-
- setBroadcastPeriod(long) - Method in class org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration
-
- setBuffer(ByteBuf) - Method in interface org.apache.activemq.artemis.api.core.Message
-
The buffer will belong to this message, until release is called.
- setCacheLargeMessagesClient(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets whether large messages received by consumers created through this factory will be cached in temporary files or not.
- setCallFailoverTimeout(long) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the blocking call failover timeout.
- setCallTimeout(long) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the blocking call timeout.
- setChannelName(String) - Method in class org.apache.activemq.artemis.api.core.JGroupsFileBroadcastEndpointFactory
-
- setChannelName(String) - Method in class org.apache.activemq.artemis.api.core.JGroupsPropertiesBroadcastEndpointFactory
-
- setClientFailureCheckPeriod(long) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the period (in milliseconds) used to check if a client has failed to receive pings from
the server.
- setCloseListeners(List<CloseListener>) - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- setCloseListeners(List<CloseListener>) - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
- setCompressLargeMessage(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets whether to compress or not large messages.
- setConfirmationWindowSize(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the size for the confirmation window buffer of clients using this factory.
- setConnectionID(String) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setConnectionLoadBalancingPolicyClassName(String) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the class name of the connection load balancing policy.
- setConnectionTTL(long) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets this factory's connections time-to-live.
- setConnectorInfos(List<String>) - Method in class org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration
-
- setConsumerMaxRate(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the maximum rate of message consumption for consumers created through this factory.
- setConsumerWindowSize(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the window size for flow control of the consumers created through this factory.
- setContext(RefCountMessageListener) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setContext(RefCountMessageListener) - Method in class org.apache.activemq.artemis.api.core.RefCountMessage
-
- setDeliveryCount(int) - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
Sets the delivery count for this message.
- setDiscoveryInitialWaitTimeout(long) - Method in class org.apache.activemq.artemis.api.core.DiscoveryGroupConfiguration
-
- setDurable(boolean) - Method in interface org.apache.activemq.artemis.api.core.Message
-
Sets whether this message is durable or not.
- setEndpointFactory(BroadcastEndpointFactory) - Method in class org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration
-
- setExpiration(long) - Method in interface org.apache.activemq.artemis.api.core.Message
-
Sets the expiration of this message.
- setFailoverOnInitialConnection(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the value for FailoverOnInitialReconnection
- setFailoverOnServerShutdown(boolean) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
do any clients failover on a server shutdown
- setFailureListeners(List<FailureListener>) - Method in class org.apache.activemq.artemis.spi.core.protocol.AbstractRemotingConnection
-
- setFailureListeners(List<FailureListener>) - Method in interface org.apache.activemq.artemis.spi.core.protocol.RemotingConnection
-
set the failure listeners.
- setFile(String) - Method in class org.apache.activemq.artemis.api.core.JGroupsFileBroadcastEndpointFactory
-
- setGlobalThreadPoolProperties(int, int) - Static method in class org.apache.activemq.artemis.api.core.client.ActiveMQClient
-
Allows programmatical configuration of global thread pools properties.
- setGroupAddress(String) - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- setGroupID(String) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the group ID that will be set on each message sent through this factory.
- setGroupPort(int) - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- setHa(boolean) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
- setHA(boolean) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
- setHost(String) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
- setIncomingInterceptorList(String) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- setInitialConnectAttempts(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the maximum number of attempts to establish an initial connection.
- setInitialMessagePacketSize(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the initial size of messages created through this factory.
- setJMSCorrelationID(Message, String) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- setJMSCorrelationIDAsBytes(Message, byte[]) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- setJMSReplyTo(Message, SimpleString) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- setJMSType(Message, String) - Static method in class org.apache.activemq.artemis.reader.MessageUtil
-
- setLocalBindAddress(String) - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- setLocalBindPort(int) - Method in class org.apache.activemq.artemis.api.core.UDPBroadcastEndpointFactory
-
- setLocator(ServerLocator) - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManagerFactory
-
- setLoopbackMessages(boolean) - Method in class org.apache.activemq.artemis.api.core.jgroups.JChannelManager
-
- setMaxRetryInterval(long) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the maximum retry interval.
- setMessageCounterMaxDayCount(int) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Sets the maximum number of days kept in memory for message counter.
- setMessageCounterSamplePeriod(long) - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQServerControl
-
Sets the sample period to take message counter snapshot.
- setMessageHandler(MessageHandler) - Method in interface org.apache.activemq.artemis.api.core.client.ClientConsumer
-
Sets the MessageHandler for this consumer to consume messages asynchronously.
- setMessageID(long) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setMinLargeMessageSize(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the large message size threshold.
- setName(String) - Method in class org.apache.activemq.artemis.api.core.BroadcastGroupConfiguration
-
- setName(String) - Method in class org.apache.activemq.artemis.api.core.DiscoveryGroupConfiguration
-
- setOutgoingInterceptorList(String) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- setOutputStream(OutputStream) - Method in interface org.apache.activemq.artemis.api.core.client.ClientMessage
-
Sets the OutputStream that will receive the content of a message received in a non blocking way.
- setPageCacheMaxSize(int) - Method in class org.apache.activemq.artemis.api.core.management.AddressSettingsInfo
-
- setPort(int) - Method in class org.apache.activemq.artemis.uri.schema.serverLocator.ConnectionOptions
-
- setPreAcknowledge(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets to true
to pre-acknowledge consumed messages on the
server before they are sent to consumers, else set to false
to let clients acknowledge the message they consume.
- setPriority(byte) - Method in interface org.apache.activemq.artemis.api.core.Message
-
Sets the message priority.
- setProducerMaxRate(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the maximum rate of message production for producers created through this factory.
- setProducerWindowSize(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Returns the window size for flow control of the producers created through this factory.
- setProperties(String) - Method in class org.apache.activemq.artemis.api.core.JGroupsPropertiesBroadcastEndpointFactory
-
- setProtocolConnection(RemotingConnection) - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connection
-
- setProtocolManagerFactory(ClientProtocolManagerFactory) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- setReconnectAttempts(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the maximum number of attempts to retry connection in case of failure.
- setRefreshTimeout(long) - Method in class org.apache.activemq.artemis.api.core.DiscoveryGroupConfiguration
-
- setReplyTo(SimpleString) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setRetryInterval(long) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the time to retry connections created by this factory after failure.
- setRetryIntervalMultiplier(double) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the multiplier to apply to successive retry intervals.
- setRoutingType(RoutingType) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setScheduledDeliveryTime(Long) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setScheduledThreadPoolMaxSize(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the maximum size of the scheduled thread pool.
- setSendAcknowledgementHandler(SendAcknowledgementHandler) - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Sets a SendAcknowledgementHandler
for this session.
- setSendAcknowledgementHandler(SendAcknowledgementHandler) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- setSession(ClientSessionInternal) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- setSessionFactory(ClientSessionFactory) - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
- setThreadPoolMaxSize(int) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets the maximum size of the thread pool.
- setThreadPools(ExecutorService, ScheduledExecutorService) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
- setTimestamp(long) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setType(byte) - Method in interface org.apache.activemq.artemis.api.core.ICoreMessage
-
the type of the message
- setType(byte) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- setUseGlobalPools(boolean) - Method in interface org.apache.activemq.artemis.api.core.client.ServerLocator
-
Sets whether this factory will use global thread pools (shared among all the factories in the same JVM)
or its own pools.
- setUserID(Object) - Method in interface org.apache.activemq.artemis.api.core.Message
-
- simpleCommit() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
- simpleRollback(boolean) - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-
If we are doing a simple rollback on the RA, we need to ack the last message sent to the consumer,
otherwise DLQ won't work.
- splitHosts(String) - Static method in class org.apache.activemq.artemis.api.core.TransportConfiguration
-
Utility method for splitting a comma separated list of hosts
- start() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Starts the session.
- start() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQComponentControl
-
Starts this component.
- start() - Method in interface org.apache.activemq.artemis.spi.core.remoting.Connector
-
starts the connector
- stop() - Method in interface org.apache.activemq.artemis.api.core.client.ClientSession
-
Stops the session.
- stop() - Method in interface org.apache.activemq.artemis.api.core.management.ActiveMQComponentControl
-
Stops this component.
- stop() - Method in interface org.apache.activemq.artemis.spi.core.remoting.ClientProtocolManager
-
This is to be called when a connection failed and we want to interrupt any communication.
- storeResult(CoreMessage, Object) - Static method in class org.apache.activemq.artemis.api.core.management.ManagementHelper
-
Used by ActiveMQ Artemis management service.
- STREAM_TYPE - Static variable in interface org.apache.activemq.artemis.api.core.Message
-
- StreamMessageUtil - Class in org.apache.activemq.artemis.reader
-
- StreamMessageUtil() - Constructor for class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadBoolean(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
Method to read boolean values out of the Stream protocol existent on JMS Stream Messages
Throws IllegalStateException if the type was invalid
- streamReadByte(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadBytes(ActiveMQBuffer, int, byte[]) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
Utility for reading bytes out of streaming.
- streamReadChar(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadDouble(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadFloat(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadInteger(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadLong(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadObject(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadShort(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- streamReadString(ActiveMQBuffer) - Static method in class org.apache.activemq.artemis.reader.StreamMessageUtil
-
- supportsLargeMessage() - Method in class org.apache.activemq.artemis.spi.core.remoting.SessionContext
-