Modifier and Type | Class and Description |
---|---|
class |
ActiveMQAddressDoesNotExistException
An operation failed because an address exists on the server.
|
class |
ActiveMQAddressExistsException
An operation failed because an address exists on the server.
|
class |
ActiveMQAddressFullException
An address is full.
|
class |
ActiveMQAlreadyReplicatingException
The server is already paired with a replicating backup.
|
class |
ActiveMQClusterSecurityException
Security exception thrown when the cluster user fails authentication.
|
class |
ActiveMQConnectionTimedOutException
A client timed out will connecting to ActiveMQ Artemis server.
|
class |
ActiveMQDeleteAddressException
An operation failed because an address exists on the server.
|
class |
ActiveMQDisconnectedException
A client was disconnected from ActiveMQ Artemis server when the server has shut down.
|
class |
ActiveMQDuplicateIdException
A DuplicateID was rejected.
|
class |
ActiveMQDuplicateMetaDataException
A Session Metadata was set in duplication
|
class |
ActiveMQIllegalStateException
An ActiveMQ Artemis resource is not in a legal state (e.g.
|
class |
ActiveMQIncompatibleClientServerException
The server version and the client version are incompatible.
|
class |
ActiveMQInterceptorRejectedPacketException
An outgoing interceptor returned false.
|
class |
ActiveMQInternalErrorException
Internal error which prevented ActiveMQ Artemis from performing an important operation.
|
class |
ActiveMQInvalidFilterExpressionException
A filter expression was found to be invalid.
|
class |
ActiveMQInvalidQueueConfiguration
An operation failed because a queue exists on the server.
|
class |
ActiveMQInvalidTransientQueueUseException
An operation failed because a queue exists on the server.
|
class |
ActiveMQIOErrorException
Unexpected I/O error occurred on the server.
|
class |
ActiveMQLargeMessageException
A problem occurred while manipulating the body of a large message.
|
class |
ActiveMQLargeMessageInterruptedException |
class |
ActiveMQNativeIOError
An error has happened at ActiveMQ's native (non-Java) code used in reading and writing data.
|
class |
ActiveMQNonExistentQueueException
An operation failed because a queue does not exist on the server.
|
class |
ActiveMQNotConnectedException
A client is not able to connect to ActiveMQ Artemis server.
|
class |
ActiveMQNullRefException
An operation failed because is dereferencing null pointer.
|
class |
ActiveMQObjectClosedException
A client operation failed because the calling resource (ClientSession, ClientProducer, etc.) is
closed.
|
class |
ActiveMQQueueExistsException
An operation failed because a queue exists on the server.
|
class |
ActiveMQQueueMaxConsumerLimitReached
An operation failed because a queue exists on the server.
|
class |
ActiveMQRemoteDisconnectException
A security problem occurred (authentication issues, permission issues,...)
|
class |
ActiveMQSecurityException
A security problem occurred (authentication issues, permission issues,...)
|
class |
ActiveMQSessionCreationException
The creation of a session was rejected by the server (e.g.
|
class |
ActiveMQShutdownException
An operation failed because an address exists on the server.
|
class |
ActiveMQTransactionOutcomeUnknownException
The outcome of a transaction is unknown.
|
class |
ActiveMQTransactionRolledBackException
A transaction was rolled back.
|
class |
ActiveMQTransactionTimeoutException |
class |
ActiveMQUnBlockedException
A blocking call from a client was unblocked during failover.
|
class |
ActiveMQUnexpectedRoutingTypeForAddress
An operation failed because a queue exists on the server.
|
class |
ActiveMQUnsupportedPacketException
A packet of unsupported type was received by ActiveMQ Artemis PacketHandler.
|
Modifier and Type | Method and Description |
---|---|
static ActiveMQException |
ActiveMQExceptionType.createException(int code,
String msg) |
ActiveMQException |
ActiveMQExceptionType.createException(String msg) |
Modifier and Type | Method and Description |
---|---|
LargeBodyEncoder |
ICoreMessage.getBodyEncoder() |
long |
Message.getPersistentSize()
This is the size of the message when persisted on disk which is used for metrics tracking
Note that even if the message itself is not persisted on disk (ie non-durable) this value is
still used for metrics tracking
If a normal message it will be the encoded message size
If a large message it will be encoded message size + large message body size
|
boolean |
BaseInterceptor.intercept(P packet,
RemotingConnection connection)
Intercepts a packet which is received before it is sent to the channel
|
Modifier and Type | Method and Description |
---|---|
void |
SessionFailureListener.beforeReconnect(ActiveMQException exception)
Notifies that a connection has failed due to the specified exception.
|
Modifier and Type | Method and Description |
---|---|
ClientMessage |
ClientMessage.acknowledge()
Acknowledges reception of this message.
|
void |
ClientSession.addMetaData(String key,
String data)
Attach any metadata to the session.
|
ClientSession.AddressQuery |
ClientSession.addressQuery(SimpleString address)
Queries information on a binding.
|
void |
ClientSession.addUniqueMetaData(String key,
String data)
Attach any metadata to the session.
|
void |
ClientMessage.checkCompletion()
This can be optionally used to verify if the entire message has been received.
|
void |
ClientSession.close()
Closes the session.
|
void |
ClientProducer.close()
Closes the ClientProducer.
|
void |
ClientConsumer.close()
Closes the consumer.
|
void |
ClientSession.commit()
Commits the current transaction, blocking.
|
void |
ClientSession.commit(boolean block)
Commits the current transaction.
|
void |
ClientSession.createAddress(SimpleString address,
EnumSet<RoutingType> routingTypes,
boolean autoCreated)
Create Address with a single initial routing type
|
void |
ClientSession.createAddress(SimpleString address,
RoutingType routingType,
boolean autoCreated)
Create Address with a single initial routing type
|
void |
ClientSession.createAddress(SimpleString address,
Set<RoutingType> routingTypes,
boolean autoCreated)
Deprecated.
|
ClientConsumer |
ClientSession.createConsumer(SimpleString queueName)
Creates a ClientConsumer to consume message from the queue with the given name.
|
ClientConsumer |
ClientSession.createConsumer(SimpleString queueName,
boolean browseOnly)
Creates a ClientConsumer to consume or browse messages from the queue with the given name.
|
ClientConsumer |
ClientSession.createConsumer(SimpleString queueName,
SimpleString filter)
Creates a ClientConsumer to consume messages matching the filter from the queue with the given name.
|
ClientConsumer |
ClientSession.createConsumer(SimpleString queueName,
SimpleString filter,
boolean browseOnly)
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
|
ClientConsumer |
ClientSession.createConsumer(SimpleString queueName,
SimpleString filter,
int windowSize,
int maxRate,
boolean browseOnly)
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
|
ClientConsumer |
ClientSession.createConsumer(String queueName)
Creates a ClientConsumer to consume messages from the queue with the given name.
|
ClientConsumer |
ClientSession.createConsumer(String queueName,
boolean browseOnly)
Creates a ClientConsumer to consume or browse messages from the queue with the given name.
|
ClientConsumer |
ClientSession.createConsumer(String queueName,
String filter)
Creates a ClientConsumer to consume messages matching the filter from the queue with the given name.
|
ClientConsumer |
ClientSession.createConsumer(String queueName,
String filter,
boolean browseOnly)
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
|
ClientConsumer |
ClientSession.createConsumer(String queueName,
String filter,
int windowSize,
int maxRate,
boolean browseOnly)
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
|
ClientProducer |
ClientSession.createProducer()
Creates a producer with no default address.
|
ClientProducer |
ClientSession.createProducer(SimpleString address)
Creates a producer which sends messages to the given address
|
ClientProducer |
ClientSession.createProducer(SimpleString address,
int rate)
Creates a producer which sends messages to the given address
|
ClientProducer |
ClientSession.createProducer(String address)
Creates a producer which sends messages to the given address
|
void |
ClientSession.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName)
Creates a non-temporary queue non-durable queue.
|
void |
ClientSession.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable,
boolean autoCreated)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable,
boolean autoCreated,
int maxConsumers,
boolean purgeOnNoConsumers)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable,
boolean autoCreated,
int maxConsumers,
boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(SimpleString address,
SimpleString queueName)
Deprecated.
|
void |
ClientSession.createQueue(SimpleString address,
SimpleString queueName,
boolean durable)
Deprecated.
|
void |
ClientSession.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filter,
boolean durable)
Deprecated.
|
void |
ClientSession.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filter,
boolean durable,
boolean autoCreated)
Deprecated.
|
void |
ClientSession.createQueue(String address,
RoutingType routingType,
String queueName)
Creates a non-temporary queue non-durable queue.
|
void |
ClientSession.createQueue(String address,
RoutingType routingType,
String queueName,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(String address,
RoutingType routingType,
String queueName,
String filter,
boolean durable)
Creates a non-temporaryqueue.
|
void |
ClientSession.createQueue(String address,
RoutingType routingType,
String queueName,
String filter,
boolean durable,
boolean autoCreated)
Creates a non-temporaryqueue.
|
void |
ClientSession.createQueue(String address,
RoutingType routingType,
String queueName,
String filter,
boolean durable,
boolean autoCreated,
int maxConsumers,
boolean purgeOnNoConsumers)
Creates a non-temporaryqueue.
|
void |
ClientSession.createQueue(String address,
RoutingType routingType,
String queueName,
String filter,
boolean durable,
boolean autoCreated,
int maxConsumers,
boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue)
Creates a non-temporaryqueue.
|
void |
ClientSession.createQueue(String address,
String queueName)
Deprecated.
|
void |
ClientSession.createQueue(String address,
String queueName,
boolean durable)
Deprecated.
|
void |
ClientSession.createQueue(String address,
String queueName,
String filter,
boolean durable)
Deprecated.
|
void |
ClientSession.createQueue(String address,
String queueName,
String filter,
boolean durable,
boolean autoCreated)
Deprecated.
|
ClientSession |
ClientSessionFactory.createSession()
Creates a non-transacted session.
|
ClientSession |
ClientSessionFactory.createSession(boolean autoCommitSends,
boolean autoCommitAcks)
Creates a session.
|
ClientSession |
ClientSessionFactory.createSession(boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks)
Creates a session.
|
ClientSession |
ClientSessionFactory.createSession(boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge)
Creates a session.
|
ClientSession |
ClientSessionFactory.createSession(boolean autoCommitSends,
boolean autoCommitAcks,
int ackBatchSize)
Creates a session.
|
ClientSession |
ClientSessionFactory.createSession(String username,
String password,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
int ackBatchSize)
Creates an authenticated session.
|
void |
ClientSession.createSharedQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
boolean durable)
Creates a transient queue.
|
void |
ClientSession.createSharedQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable)
Creates a transient queue.
|
void |
ClientSession.createSharedQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable,
Integer maxConsumers,
Boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue)
Creates Shared queue.
|
void |
ClientSession.createSharedQueue(SimpleString address,
SimpleString queueName,
boolean durable)
Deprecated.
|
void |
ClientSession.createSharedQueue(SimpleString address,
SimpleString queueName,
SimpleString filter,
boolean durable)
Deprecated.
|
void |
ClientSession.createTemporaryQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName)
Creates a temporary queue.
|
void |
ClientSession.createTemporaryQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter)
Creates a temporary queue with a filter.
|
void |
ClientSession.createTemporaryQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
int maxConsumers,
boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue)
Creates a temporary queue with a filter.
|
void |
ClientSession.createTemporaryQueue(SimpleString address,
SimpleString queueName)
Deprecated.
|
void |
ClientSession.createTemporaryQueue(SimpleString address,
SimpleString queueName,
SimpleString filter)
Deprecated.
|
void |
ClientSession.createTemporaryQueue(String address,
RoutingType routingType,
String queueName)
Creates a temporary queue.
|
void |
ClientSession.createTemporaryQueue(String address,
RoutingType routingType,
String queueName,
String filter)
Creates a temporary queue with a filter.
|
void |
ClientSession.createTemporaryQueue(String address,
String queueName)
Deprecated.
|
void |
ClientSession.createTemporaryQueue(String address,
String queueName,
String filter)
Deprecated.
|
ClientSession |
ClientSessionFactory.createTransactedSession()
Creates a transacted session.
|
ClientSession |
ClientSessionFactory.createXASession()
Creates a session with XA transaction semantics.
|
void |
ClientSession.deleteQueue(SimpleString queueName)
Deletes the queue.
|
void |
ClientSession.deleteQueue(String queueName)
Deletes the queue.
|
MessageHandler |
ClientConsumer.getMessageHandler()
Returns the MessageHandler associated to this consumer.
|
ClientMessage |
ClientMessage.individualAcknowledge()
Acknowledges reception of a single message.
|
void |
ServerLocator.initialize()
This will only instantiate internal objects such as the topology
|
ClientSession.QueueQuery |
ClientSession.queueQuery(SimpleString queueName)
Queries information on a queue.
|
ClientMessage |
ClientConsumer.receive()
Receives a message from a queue.
|
ClientMessage |
ClientConsumer.receive(long timeout)
Receives a message from a queue.
|
ClientMessage |
ClientConsumer.receiveImmediate()
Receives a message from a queue.
|
void |
ClientSession.rollback()
Rolls back the current transaction.
|
void |
ClientSession.rollback(boolean considerLastMessageAsDelivered)
Rolls back the current transaction.
|
void |
ClientMessage.saveToOutputStream(OutputStream out)
Saves the content of the message to the OutputStream.
|
void |
ClientProducer.send(Message message)
Sends a message to an address.
|
void |
ClientProducer.send(Message message,
SendAcknowledgementHandler handler)
Sends a message to the specified address instead of the ClientProducer's address.
|
void |
ClientProducer.send(SimpleString address,
Message message)
Sends a message to the specified address instead of the ClientProducer's address.
|
void |
ClientProducer.send(SimpleString address,
Message message,
SendAcknowledgementHandler handler)
Sends a message to the specified address instead of the ClientProducer's address.
|
void |
ClientProducer.send(String address,
Message message)
Sends a message to the specified address instead of the ClientProducer's address.
|
ClientConsumer |
ClientConsumer.setMessageHandler(MessageHandler handler)
Sets the MessageHandler for this consumer to consume messages asynchronously.
|
ClientMessage |
ClientMessage.setOutputStream(OutputStream out)
Sets the OutputStream that will receive the content of a message received in a non blocking way.
|
ClientSession |
ClientSession.start()
Starts the session.
|
void |
ClientSession.stop()
Stops the session.
|
boolean |
ClientMessage.waitOutputStreamCompletion(long timeMilliseconds)
Wait the outputStream completion of the message.
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
DestAbstract.isFQQN() |
Modifier and Type | Method and Description |
---|---|
void |
ClientSessionFactoryImpl.connectionException(Object connectionID,
ActiveMQException me) |
void |
ClientSessionImpl.connectionFailed(ActiveMQException me,
boolean failedOver) |
void |
ClientSessionImpl.connectionFailed(ActiveMQException me,
boolean failedOver,
String scaleDownTargetNodeID) |
void |
ClientSessionInternal.handleFailover(RemotingConnection backupConnection,
ActiveMQException cause) |
void |
ClientSessionImpl.handleFailover(RemotingConnection backupConnection,
ActiveMQException cause) |
Modifier and Type | Method and Description |
---|---|
ClientMessageImpl |
ClientMessageImpl.acknowledge() |
void |
ClientSessionInternal.acknowledge(ClientConsumer consumer,
Message message) |
void |
ClientSessionImpl.acknowledge(ClientConsumer consumer,
Message message)
Acknowledges all messages received by the consumer so far.
|
void |
ClientConsumerInternal.acknowledge(ClientMessage message) |
void |
ClientConsumerImpl.acknowledge(ClientMessage message) |
void |
ClientProducerCredits.acquireCredits(int credits) |
void |
AbstractProducerCreditsImpl.acquireCredits(int credits) |
void |
ClientSessionImpl.addMetaData(String key,
String data) |
ClientSession.AddressQuery |
ClientSessionImpl.addressQuery(SimpleString address) |
void |
ClientSessionImpl.addUniqueMetaData(String key,
String data) |
void |
ClientMessageImpl.checkCompletion() |
void |
ClientLargeMessageImpl.checkCompletion() |
void |
ClientConsumerInternal.cleanUp() |
void |
ClientSessionInternal.cleanUp(boolean failingOver) |
void |
ClientSessionImpl.cleanUp(boolean failingOver) |
void |
ClientConsumerInternal.clear(boolean waitForOnMessage) |
void |
ClientConsumerImpl.clear(boolean waitForOnMessage) |
void |
ClientSessionImpl.close() |
void |
ClientProducerImpl.close() |
void |
ClientConsumerImpl.close() |
void |
ClientSessionImpl.commit() |
void |
ClientSessionImpl.commit(boolean block) |
ClientSessionFactoryInternal |
ServerLocatorInternal.connect() |
ClientSessionFactoryInternal |
ServerLocatorImpl.connect() |
void |
ClientSessionFactoryInternal.connect(int reconnectAttempts,
boolean failoverOnInitialConnection) |
void |
ClientSessionFactoryImpl.connect(int initialConnectAttempts,
boolean failoverOnInitialConnection) |
ClientSessionFactoryInternal |
ServerLocatorInternal.connectNoWarnings()
Like
ServerLocatorInternal.connect() but it does not log warnings if it fails to connect. |
ClientSessionFactoryInternal |
ServerLocatorImpl.connectNoWarnings() |
void |
ClientSessionImpl.createAddress(SimpleString address,
EnumSet<RoutingType> routingTypes,
boolean autoCreated) |
void |
ClientSessionImpl.createAddress(SimpleString address,
RoutingType routingType,
boolean autoCreated) |
void |
ClientSessionImpl.createAddress(SimpleString address,
Set<RoutingType> routingTypes,
boolean autoCreated) |
ClientConsumer |
ClientSessionImpl.createConsumer(SimpleString queueName) |
ClientConsumer |
ClientSessionImpl.createConsumer(SimpleString queueName,
boolean browseOnly) |
ClientConsumer |
ClientSessionImpl.createConsumer(SimpleString queueName,
SimpleString filterString) |
ClientConsumer |
ClientSessionImpl.createConsumer(SimpleString queueName,
SimpleString filterString,
boolean browseOnly) |
ClientConsumer |
ClientSessionImpl.createConsumer(SimpleString queueName,
SimpleString filterString,
int windowSize,
int maxRate,
boolean browseOnly)
Note, we DO NOT currently support direct consumers (i.e.
|
ClientConsumer |
ClientSessionImpl.createConsumer(String queueName) |
ClientConsumer |
ClientSessionImpl.createConsumer(String queueName,
boolean browseOnly) |
ClientConsumer |
ClientSessionImpl.createConsumer(String queueName,
String filterString) |
ClientConsumer |
ClientSessionImpl.createConsumer(String queueName,
String filterString,
boolean browseOnly) |
ClientConsumer |
ClientSessionImpl.createConsumer(String queueName,
String filterString,
int windowSize,
int maxRate,
boolean browseOnly) |
ClientProducer |
ClientSessionImpl.createProducer() |
ClientProducer |
ClientSessionImpl.createProducer(SimpleString address) |
ClientProducer |
ClientSessionImpl.createProducer(SimpleString address,
int maxRate) |
ClientProducer |
ClientSessionImpl.createProducer(String address) |
ClientProducer |
ClientSessionImpl.createProducer(String address,
int rate) |
void |
ClientSessionImpl.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName)
Creates a non-temporary queue non-durable queue.
|
void |
ClientSessionImpl.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSessionImpl.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSessionImpl.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean autoCreated)
New Queue API
|
void |
ClientSessionImpl.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean autoCreated,
int maxConsumers,
boolean purgeOnNoConsumers) |
void |
ClientSessionImpl.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean autoCreated,
int maxConsumers,
boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue) |
void |
ClientSessionImpl.createQueue(SimpleString address,
SimpleString queueName) |
void |
ClientSessionImpl.createQueue(SimpleString address,
SimpleString queueName,
boolean durable) |
void |
ClientSessionImpl.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable) |
void |
ClientSessionImpl.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean autoCreated) |
void |
ClientSessionImpl.createQueue(String address,
RoutingType routingType,
String queueName)
Creates a non-temporary queue non-durable queue.
|
void |
ClientSessionImpl.createQueue(String address,
RoutingType routingType,
String queueName,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSessionImpl.createQueue(String address,
RoutingType routingType,
String queueName,
String filter,
boolean durable)
Creates a non-temporaryqueue.
|
void |
ClientSessionImpl.createQueue(String address,
RoutingType routingType,
String queueName,
String filterString,
boolean durable,
boolean autoCreated) |
void |
ClientSessionImpl.createQueue(String address,
RoutingType routingType,
String queueName,
String filterString,
boolean durable,
boolean autoCreated,
int maxConsumers,
boolean purgeOnNoConsumers) |
void |
ClientSessionImpl.createQueue(String address,
RoutingType routingType,
String queueName,
String filterString,
boolean durable,
boolean autoCreated,
int maxConsumers,
boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue) |
void |
ClientSessionImpl.createQueue(String address,
String queueName) |
void |
ClientSessionImpl.createQueue(String address,
String queueName,
boolean durable) |
void |
ClientSessionImpl.createQueue(String address,
String queueName,
String filterString,
boolean durable) |
void |
ClientSessionImpl.createQueue(String address,
String queueName,
String filterString,
boolean durable,
boolean autoCreated) |
ClientSession |
ClientSessionFactoryImpl.createSession() |
ClientSession |
ClientSessionFactoryImpl.createSession(boolean autoCommitSends,
boolean autoCommitAcks) |
ClientSession |
ClientSessionFactoryImpl.createSession(boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks) |
ClientSession |
ClientSessionFactoryImpl.createSession(boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge) |
ClientSession |
ClientSessionFactoryImpl.createSession(boolean autoCommitSends,
boolean autoCommitAcks,
int ackBatchSize) |
ClientSession |
ClientSessionFactoryImpl.createSession(String username,
String password,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
int ackBatchSize) |
protected SessionContext |
ClientSessionFactoryImpl.createSessionChannel(String name,
String username,
String password,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge) |
ClientSessionFactory |
ServerLocatorImpl.createSessionFactory() |
void |
ClientSessionImpl.createSharedQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
boolean durable)
Creates a transient queue.
|
void |
ClientSessionImpl.createSharedQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable)
Creates a transient queue.
|
void |
ClientSessionImpl.createSharedQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
boolean durable,
Integer maxConsumers,
Boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue)
Creates Shared queue.
|
void |
ClientSessionImpl.createSharedQueue(SimpleString address,
SimpleString queueName,
boolean durable) |
void |
ClientSessionImpl.createSharedQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable) |
void |
ClientSessionImpl.createTemporaryQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName) |
void |
ClientSessionImpl.createTemporaryQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter) |
void |
ClientSessionImpl.createTemporaryQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filter,
int maxConsumers,
boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue) |
void |
ClientSessionImpl.createTemporaryQueue(SimpleString address,
SimpleString queueName) |
void |
ClientSessionImpl.createTemporaryQueue(SimpleString address,
SimpleString queueName,
SimpleString filter) |
void |
ClientSessionImpl.createTemporaryQueue(String address,
RoutingType routingType,
String queueName) |
void |
ClientSessionImpl.createTemporaryQueue(String address,
RoutingType routingType,
String queueName,
String filter) |
void |
ClientSessionImpl.createTemporaryQueue(String address,
String queueName) |
void |
ClientSessionImpl.createTemporaryQueue(String address,
String queueName,
String filter) |
ClientSession |
ClientSessionFactoryImpl.createTransactedSession() |
ClientSession |
ClientSessionFactoryImpl.createXASession() |
void |
ClientSessionImpl.deleteQueue(SimpleString queueName) |
void |
ClientSessionImpl.deleteQueue(String queueName) |
void |
ClientSessionInternal.expire(ClientConsumer consumer,
Message message) |
void |
ClientSessionImpl.expire(ClientConsumer consumer,
Message message) |
void |
ClientConsumerInternal.flowControl(int messageBytes,
boolean discountSlowConsumer) |
void |
ClientConsumerImpl.flowControl(int messageBytes,
boolean discountSlowConsumer)
LargeMessageBuffer will call flowcontrol here, while other handleMessage will also be calling flowControl.
|
void |
ClientConsumerInternal.flushAcks() |
void |
ClientConsumerImpl.flushAcks() |
LargeBodyEncoder |
ClientMessageImpl.getBodyEncoder() |
MessageHandler |
ClientConsumerImpl.getMessageHandler() |
void |
ClientSessionInternal.handleConsumerDisconnect(ConsumerContext consumerContext) |
void |
ClientSessionImpl.handleConsumerDisconnect(ConsumerContext context) |
ClientMessageImpl |
ClientMessageImpl.individualAcknowledge() |
void |
ClientSessionInternal.individualAcknowledge(ClientConsumer consumer,
Message message) |
void |
ClientSessionImpl.individualAcknowledge(ClientConsumer consumer,
Message message) |
void |
ClientConsumerInternal.individualAcknowledge(ClientMessage message) |
void |
ClientConsumerImpl.individualAcknowledge(ClientMessage message) |
void |
ServerLocatorImpl.initialize() |
Thread |
ClientConsumerInternal.prepareForClose(FutureLatch future)
To be called by things like MDBs during shutdown of the server
|
Thread |
ClientConsumerImpl.prepareForClose(FutureLatch future)
To be used by MDBs to stop any more handling of messages.
|
ClientSession.QueueQuery |
ClientSessionImpl.queueQuery(SimpleString queueName) |
ClientMessage |
ClientConsumerImpl.receive() |
ClientMessage |
ClientConsumerImpl.receive(long timeout) |
ClientMessage |
ClientConsumerImpl.receiveImmediate() |
void |
ClientSessionInternal.removeConsumer(ClientConsumerInternal consumer) |
void |
ClientSessionImpl.removeConsumer(ClientConsumerInternal consumer) |
void |
ClientSessionInternal.resetIfNeeded() |
void |
ClientSessionImpl.resetIfNeeded() |
void |
ClientSessionImpl.rollback() |
void |
ClientSessionImpl.rollback(boolean isLastMessageAsDelivered) |
void |
ClientSessionImpl.rollback(boolean isLastMessageAsDelivered,
boolean waitConsumers) |
void |
LargeMessageControllerImpl.saveBuffer(OutputStream output) |
void |
LargeMessageController.saveBuffer(OutputStream output)
Saves this buffer to the specified output.
|
void |
ClientMessageImpl.saveToOutputStream(OutputStream out) |
void |
ClientLargeMessageImpl.saveToOutputStream(OutputStream out) |
void |
ClientProducerImpl.send(Message msg) |
void |
ClientProducerImpl.send(Message message,
SendAcknowledgementHandler handler) |
void |
ClientProducerImpl.send(SimpleString address1,
Message msg) |
void |
ClientProducerImpl.send(SimpleString address1,
Message message,
SendAcknowledgementHandler handler) |
void |
ClientProducerImpl.send(String address1,
Message message) |
ClientConsumerImpl |
ClientConsumerImpl.setMessageHandler(MessageHandler theHandler) |
void |
LargeMessageControllerImpl.setOutputStream(OutputStream output) |
void |
LargeMessageController.setOutputStream(OutputStream output)
Sets the OutputStream of this buffer to the specified output.
|
ClientMessageImpl |
ClientMessageImpl.setOutputStream(OutputStream out) |
ClientLargeMessageImpl |
ClientLargeMessageImpl.setOutputStream(OutputStream out) |
ClientSessionImpl |
ClientSessionImpl.start() |
void |
ClientSessionImpl.stop() |
void |
ClientSessionImpl.stop(boolean waitForOnMessage) |
void |
ClientConsumerInternal.stop(boolean waitForOnMessage) |
void |
ClientConsumerImpl.stop(boolean waitForOnMessage) |
boolean |
LargeMessageControllerImpl.waitCompletion(long timeWait) |
boolean |
LargeMessageController.waitCompletion(long timeWait)
Waits for the completion for the specified waiting time (in milliseconds).
|
boolean |
ClientMessageImpl.waitOutputStreamCompletion(long timeMilliseconds) |
boolean |
ClientLargeMessageImpl.waitOutputStreamCompletion(long timeMilliseconds) |
Modifier and Type | Method and Description |
---|---|
static Filter |
FilterImpl.createFilter(SimpleString filterStr) |
static Filter |
FilterImpl.createFilter(String filterStr) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractSequentialFile.close() |
void |
SequentialFile.delete() |
void |
AbstractSequentialFile.delete() |
void |
AbstractSequentialFile.renameTo(String newFileName) |
void |
AbstractSequentialFile.write(ActiveMQBuffer bytes,
boolean sync) |
void |
AbstractSequentialFile.write(EncodingSupport bytes,
boolean sync) |
Modifier and Type | Method and Description |
---|---|
void |
AIOSequentialFile.close() |
void |
AIOSequentialFile.close(boolean waitSync) |
void |
AIOSequentialFile.open(int maxIO,
boolean useExecutor) |
int |
AIOSequentialFile.read(ByteBuffer bytes,
IOCallback callback) |
Modifier and Type | Method and Description |
---|---|
void |
NIOSequentialFile.close() |
Modifier and Type | Method and Description |
---|---|
void |
SimpleWaitIOCallback.waitCompletion() |
boolean |
SimpleWaitIOCallback.waitCompletion(long timeout) |
Modifier and Type | Method and Description |
---|---|
Map<String,Map<String,Object>[]> |
QueueControlImpl.listDeliveringMessages() |
Modifier and Type | Method and Description |
---|---|
void |
LargeBodyEncoder.close()
This method must not be called directly by ActiveMQ Artemis clients.
|
void |
BodyEncoder.close()
Deprecated.
This method must not be called directly by ActiveMQ Artemis clients.
|
int |
LargeBodyEncoder.encode(ActiveMQBuffer bufferOut,
int size)
This method must not be called directly by ActiveMQ Artemis clients.
|
int |
BodyEncoder.encode(ActiveMQBuffer bufferOut,
int size)
Deprecated.
This method must not be called directly by ActiveMQ Artemis clients.
|
int |
LargeBodyEncoder.encode(ByteBuffer bufferRead)
This method must not be called directly by ActiveMQ Artemis clients.
|
int |
BodyEncoder.encode(ByteBuffer bufferRead)
Deprecated.
This method must not be called directly by ActiveMQ Artemis clients.
|
long |
LargeBodyEncoder.getLargeBodySize()
This method must not be called directly by ActiveMQ Artemis clients.
|
void |
LargeBodyEncoder.open()
This method must not be called directly by ActiveMQ Artemis clients.
|
void |
BodyEncoder.open()
Deprecated.
This method must not be called directly by ActiveMQ Artemis clients.
|
Modifier and Type | Method and Description |
---|---|
BodyEncoder |
MessageInternalImpl.getBodyEncoder()
Deprecated.
|
BodyEncoder |
MessageInternal.getBodyEncoder()
Deprecated.
|
LargeBodyEncoder |
CoreMessage.getBodyEncoder() |
long |
MessageInternalImpl.getPersistentSize()
Deprecated.
|
long |
CoreMessage.getPersistentSize() |
Modifier and Type | Method and Description |
---|---|
long |
PagedMessage.getPersistentSize()
This is the size of the message when persisted on disk and is used for metrics tracking
If a normal message it will be the encoded message size
If a large message it will be encoded message size + large message body size
|
Modifier and Type | Method and Description |
---|---|
long |
PagedMessageImpl.getPersistentSize() |
Modifier and Type | Method and Description |
---|---|
LargeBodyEncoder |
LargeServerMessageImpl.getBodyEncoder() |
SequentialFile |
LargeServerMessageImpl.getFile() |
long |
LargeServerMessageImpl.getPersistentSize() |
SequentialFile |
LargeServerMessageInSync.getSyncFile() |
void |
LargeServerMessageImpl.validateFile() |
boolean |
OperationContextImpl.waitCompletion(long timeout) |
Modifier and Type | Method and Description |
---|---|
void |
ServerSessionPacketHandler.connectionFailed(ActiveMQException exception,
boolean failedOver) |
Modifier and Type | Method and Description |
---|---|
Packet |
Channel.sendBlocking(Packet packet,
byte expectedPacket)
Sends a packet on this channel and then blocks until a response is received or a timeout
occurs.
|
Packet |
Channel.sendBlocking(Packet packet,
int reconnectID,
byte expectedPacket)
Sends a packet on this channel and then blocks until a response is received or a timeout
occurs.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ActiveMQClientProtocolManager.cleanupBeforeFailover(ActiveMQException cause) |
void |
RemotingConnectionImpl.fail(ActiveMQException me,
String scaleDownTargetNodeID) |
void |
ActiveMQSessionContext.returnBlocking(ActiveMQException cause) |
Modifier and Type | Method and Description |
---|---|
ClientSession.AddressQuery |
ActiveMQSessionContext.addressQuery(SimpleString address) |
void |
ActiveMQSessionContext.addSessionMetadata(String key,
String data) |
void |
ActiveMQSessionContext.addUniqueMetaData(String key,
String data) |
boolean |
ActiveMQClientProtocolManager.checkForFailover(String liveNodeID) |
void |
ActiveMQSessionContext.closeConsumer(ClientConsumer consumer) |
boolean |
ActiveMQSessionContext.configureTransactionTimeout(int seconds) |
void |
ActiveMQSessionContext.createAddress(SimpleString address,
EnumSet<RoutingType> routingTypes,
boolean autoCreated) |
void |
ActiveMQSessionContext.createAddress(SimpleString address,
Set<RoutingType> routingTypes,
boolean autoCreated) |
ClientConsumerInternal |
ActiveMQSessionContext.createConsumer(SimpleString queueName,
SimpleString filterString,
int windowSize,
int maxRate,
int ackBatchSize,
boolean browseOnly,
Executor executor,
Executor flowControlExecutor) |
void |
ActiveMQSessionContext.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean temp,
int maxConsumers,
boolean purgeOnNoConsumers,
boolean autoCreated)
Deprecated.
|
void |
ActiveMQSessionContext.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean temp,
int maxConsumers,
boolean purgeOnNoConsumers,
boolean autoCreated,
Boolean exclusive,
Boolean lastValue) |
void |
ActiveMQSessionContext.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean temp,
boolean autoCreated)
Deprecated.
|
SessionContext |
ActiveMQClientProtocolManager.createSessionContext(String name,
String username,
String password,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
int minLargeMessageSize,
int confirmationWindowSize) |
SessionContext |
ActiveMQClientProtocolManager.createSessionContext(Version clientVersion,
String name,
String username,
String password,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
int minLargeMessageSize,
int confirmationWindowSize) |
void |
ActiveMQSessionContext.createSharedQueue(SimpleString address,
SimpleString queueName,
RoutingType routingType,
SimpleString filterString,
boolean durable) |
void |
ActiveMQSessionContext.createSharedQueue(SimpleString address,
SimpleString queueName,
RoutingType routingType,
SimpleString filterString,
boolean durable,
Integer maxConsumers,
Boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue) |
void |
ActiveMQSessionContext.createSharedQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable) |
void |
ActiveMQSessionContext.deleteQueue(SimpleString queueName) |
void |
ActiveMQSessionContext.expireMessage(ClientConsumer consumer,
Message message) |
void |
ActiveMQSessionContext.forceDelivery(ClientConsumer consumer,
long sequence) |
ClientSession.QueueQuery |
ActiveMQSessionContext.queueQuery(SimpleString queueName) |
boolean |
ActiveMQSessionContext.reattachOnNewConnection(RemotingConnection newConnection) |
int |
ActiveMQSessionContext.recoverSessionTimeout() |
void |
ActiveMQSessionContext.recreateConsumerOnServer(ClientConsumerInternal consumerInternal,
long consumerId,
boolean isSessionStarted) |
void |
ActiveMQSessionContext.recreateSession(String username,
String password,
int minLargeMessageSize,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge) |
void |
ActiveMQSessionContext.restartSession() |
void |
ActiveMQSessionContext.sendACK(boolean individual,
boolean block,
ClientConsumer consumer,
Message message) |
Packet |
ChannelImpl.sendBlocking(Packet packet,
byte expectedPacket) |
Packet |
ChannelImpl.sendBlocking(Packet packet,
int reconnectID,
byte expectedPacket)
Due to networking issues or server issues the server may take longer to answer than expected..
|
void |
ActiveMQSessionContext.sendFullMessage(ICoreMessage msgI,
boolean sendBlocking,
SendAcknowledgementHandler handler,
SimpleString defaultAddress) |
int |
ActiveMQSessionContext.sendInitialChunkOnLargeMessage(Message msgI) |
int |
ActiveMQSessionContext.sendLargeMessageChunk(Message msgI,
long messageBodySize,
boolean sendBlocking,
boolean lastChunk,
byte[] chunk,
int reconnectID,
SendAcknowledgementHandler messageHandler) |
int |
ActiveMQSessionContext.sendServerLargeMessageChunk(Message msgI,
long messageBodySize,
boolean sendBlocking,
boolean lastChunk,
byte[] chunk,
SendAcknowledgementHandler messageHandler) |
void |
ActiveMQSessionContext.sessionClose() |
void |
ActiveMQSessionContext.sessionStart() |
void |
ActiveMQSessionContext.sessionStop() |
void |
ActiveMQSessionContext.simpleCommit() |
void |
ActiveMQSessionContext.simpleCommit(boolean block) |
void |
ActiveMQSessionContext.simpleRollback(boolean lastMessageAsDelivered) |
void |
ActiveMQSessionContext.xaCommit(Xid xid,
boolean onePhase) |
void |
ActiveMQSessionContext.xaEnd(Xid xid,
int flags) |
void |
ActiveMQSessionContext.xaFailed(Xid xid) |
void |
ActiveMQSessionContext.xaForget(Xid xid) |
int |
ActiveMQSessionContext.xaPrepare(Xid xid) |
void |
ActiveMQSessionContext.xaRollback(Xid xid,
boolean wasStarted) |
Xid[] |
ActiveMQSessionContext.xaScan() |
void |
ActiveMQSessionContext.xaStart(Xid xid,
int flags) |
Modifier and Type | Method and Description |
---|---|
ActiveMQException |
ActiveMQExceptionMessage.getException() |
Constructor and Description |
---|
ActiveMQExceptionMessage(ActiveMQException exception) |
Modifier and Type | Method and Description |
---|---|
boolean |
HQPropertiesConversionInterceptor.intercept(Packet packet,
RemotingConnection connection) |
Modifier and Type | Method and Description |
---|---|
ClientSession.AddressQuery |
HornetQClientSessionContext.addressQuery(SimpleString address) |
boolean |
HornetQClientProtocolManager.checkForFailover(String liveNodeID) |
ClientConsumerInternal |
HornetQClientSessionContext.createConsumer(SimpleString queueName,
SimpleString filterString,
int windowSize,
int maxRate,
int ackBatchSize,
boolean browseOnly,
Executor executor,
Executor flowControlExecutor) |
ClientSession.QueueQuery |
HornetQClientSessionContext.queueQuery(SimpleString queueName) |
Modifier and Type | Method and Description |
---|---|
void |
FailureListener.connectionFailed(ActiveMQException exception,
boolean failedOver)
Notifies that a connection has failed due to the specified exception.
|
void |
FailureListener.connectionFailed(ActiveMQException exception,
boolean failedOver,
String scaleDownTargetNodeID)
Notifies that a connection has failed due to the specified exception.
|
Modifier and Type | Method and Description |
---|---|
void |
RemotingServiceImpl.connectionException(Object connectionID,
ActiveMQException me) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationManager.sendStartSyncMessage(JournalFile[] datafiles,
AbstractJournalStorageManager.JournalContent contentType,
String nodeID,
boolean allowsAutoFailBack)
Reserve the following fileIDs in the backup server.
|
void |
ReplicationManager.start() |
Modifier and Type | Method and Description |
---|---|
ActiveMQException |
ActiveMQMessageBundle.groupWhileStopping() |
ActiveMQException |
ActiveMQMessageBundle.noConfigurationFoundForScaleDown() |
ActiveMQException |
ActiveMQMessageBundle.noDiscoveryGroupFound(DiscoveryGroupConfiguration dg) |
Modifier and Type | Method and Description |
---|---|
void |
ActiveMQServer.callBrokerPlugins(ActiveMQPluginRunnable pluginRun) |
List<MessageReference> |
ScheduledDeliveryHandler.cancel(Filter filter) |
void |
LiveNodeLocator.connectToCluster(ServerLocatorInternal serverLocator)
connects to the cluster
|
void |
Queue.deliverScheduledMessages()
cancels scheduled messages and send them to the head of the queue.
|
SequentialFile |
LargeServerMessage.getFile() |
long |
MessageReference.getPersistentSize()
This is the size of the message when persisted on disk which is used for metrics tracking
Note that even if the message itself is not persisted on disk (ie non-durable) this value is
still used for metrics tracking for the amount of data on a queue
|
MessageReference |
Queue.getReference(long id) |
abstract void |
LiveNodeLocator.locateNode()
Locates a possible live server in a cluster
|
abstract void |
LiveNodeLocator.locateNode(long timeout)
Locates a possible live server in a cluster with a timeout
|
MessageReference |
ScheduledDeliveryHandler.removeReferenceWithID(long id) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterControl.announceReplicatingBackupToLive(boolean attemptingFailBack,
String replicationClusterName)
XXX HORNETQ-720
|
void |
ClusterControl.authorize()
authorise this cluster control so it can communicate with the cluster, it will set the cluster channel on a successful
authentication.
|
boolean |
ClusterManager.IncomingInterceptorLookingForExceptionMessage.intercept(Packet packet,
RemotingConnection connection) |
Modifier and Type | Method and Description |
---|---|
static ServerLocatorInternal |
ScaleDownPolicy.getScaleDownConnector(ScaleDownPolicy scaleDownPolicy,
ActiveMQServer activeMQServer) |
Modifier and Type | Method and Description |
---|---|
void |
BridgeImpl.beforeReconnect(ActiveMQException exception) |
void |
BridgeImpl.connectionFailed(ActiveMQException me,
boolean failedOver) |
void |
BridgeImpl.connectionFailed(ActiveMQException me,
boolean failedOver,
String scaleDownTargetNodeID) |
Modifier and Type | Method and Description |
---|---|
void |
SharedNothingBackupQuorum.beforeReconnect(ActiveMQException exception) |
void |
SharedNothingBackupQuorum.connectionFailed(ActiveMQException exception,
boolean failedOver)
if the connection to our replicated live goes down then decide on an action
|
void |
SharedNothingBackupQuorum.connectionFailed(ActiveMQException me,
boolean failedOver,
String scaleDownTargetNodeID) |
Modifier and Type | Method and Description |
---|---|
void |
ServerSessionImpl.connectionFailed(ActiveMQException me,
boolean failedOver) |
void |
ServerSessionImpl.TempQueueCleanerUpper.connectionFailed(ActiveMQException exception,
boolean failedOver) |
void |
ServerSessionImpl.connectionFailed(ActiveMQException me,
boolean failedOver,
String scaleDownTargetNodeID) |
void |
ServerSessionImpl.TempQueueCleanerUpper.connectionFailed(ActiveMQException me,
boolean failedOver,
String scaleDownTargetNodeID) |
Modifier and Type | Method and Description |
---|---|
void |
ActiveMQServerImpl.callBrokerPlugins(ActiveMQPluginRunnable pluginRun) |
List<MessageReference> |
ScheduledDeliveryHandlerImpl.cancel(Filter filter) |
JournalLoader |
SharedStoreBackupActivation.createJournalLoader(PostOffice postOffice,
PagingManager pagingManager,
StorageManager storageManager,
QueueFactory queueFactory,
NodeManager nodeManager,
ManagementService managementService,
GroupingHandler groupingHandler,
Configuration configuration,
ActiveMQServer parentServer) |
JournalLoader |
SharedNothingBackupActivation.createJournalLoader(PostOffice postOffice,
PagingManager pagingManager,
StorageManager storageManager,
QueueFactory queueFactory,
NodeManager nodeManager,
ManagementService managementService,
GroupingHandler groupingHandler,
Configuration configuration,
ActiveMQServer parentServer) |
JournalLoader |
Activation.createJournalLoader(PostOffice postOffice,
PagingManager pagingManager,
StorageManager storageManager,
QueueFactory queueFactory,
NodeManager nodeManager,
ManagementService managementService,
GroupingHandler groupingHandler,
Configuration configuration,
ActiveMQServer parentServer) |
void |
QueueImpl.deliverScheduledMessages() |
long |
MessageReferenceImpl.getPersistentSize() |
MessageReference |
QueueImpl.getReference(long id1) |
void |
NamedNodeIdNodeLocator.locateNode() |
void |
NamedLiveNodeLocatorForScaleDown.locateNode() |
void |
NamedLiveNodeLocatorForReplication.locateNode() |
void |
AnyLiveNodeLocatorForScaleDown.locateNode() |
void |
AnyLiveNodeLocatorForReplication.locateNode() |
void |
NamedNodeIdNodeLocator.locateNode(long timeout) |
void |
NamedLiveNodeLocatorForScaleDown.locateNode(long timeout) |
void |
NamedLiveNodeLocatorForReplication.locateNode(long timeout) |
void |
AnyLiveNodeLocatorForScaleDown.locateNode(long timeout) |
void |
AnyLiveNodeLocatorForReplication.locateNode(long timeout) |
void |
SharedNothingBackupActivation.remoteFailOver(ReplicationLiveIsStoppingMessage.LiveStopping finalMessage) |
MessageReference |
ScheduledDeliveryHandlerImpl.removeReferenceWithID(long id) |
void |
SharedNothingLiveActivation.startReplication(CoreRemotingConnection rc,
ClusterConnection clusterConnection,
Pair<TransportConfiguration,TransportConfiguration> pair,
boolean isFailBackRequest) |
Modifier and Type | Method and Description |
---|---|
default void |
ActiveMQServerPlugin.afterAddAddress(AddressInfo addressInfo,
boolean reload)
After an address has been added tot he broker
|
default void |
ActiveMQServerPlugin.afterAddBinding(Binding binding)
After a binding has been added
|
default void |
ActiveMQServerPlugin.afterCloseConsumer(ServerConsumer consumer,
boolean failed)
After a consumer is closed
|
default void |
ActiveMQServerPlugin.afterCloseSession(ServerSession session,
boolean failed)
After a session is closed
|
default void |
ActiveMQServerPlugin.afterCreateConnection(RemotingConnection connection)
A connection has been created.
|
default void |
ActiveMQServerPlugin.afterCreateConsumer(ServerConsumer consumer)
After a consumer has been created
|
default void |
ActiveMQServerPlugin.afterCreateQueue(Queue queue)
After a queue has been created
|
default void |
ActiveMQServerPlugin.afterCreateSession(ServerSession session)
After a session has been created.
|
default void |
ActiveMQServerPlugin.afterDeliver(MessageReference reference)
|
default void |
ActiveMQServerPlugin.afterDeliver(ServerConsumer consumer,
MessageReference reference)
After a message is delivered to a client consumer
|
default void |
ActiveMQServerPlugin.afterDeployBridge(Bridge bridge)
After a bridge has been deployed
|
default void |
ActiveMQServerPlugin.afterDestroyConnection(RemotingConnection connection)
A connection has been destroyed.
|
default void |
ActiveMQServerPlugin.afterDestroyQueue(Queue queue,
SimpleString address,
SecurityAuth session,
boolean checkConsumerCount,
boolean removeConsumers,
boolean autoDeleteAddress)
After a queue has been destroyed
|
default void |
ActiveMQServerPlugin.afterMessageRoute(Message message,
RoutingContext context,
boolean direct,
boolean rejectDuplicates,
RoutingStatus result)
After a message is routed
|
default void |
ActiveMQServerPlugin.afterRemoveAddress(SimpleString address,
AddressInfo addressInfo)
After an address has been removed
|
default void |
ActiveMQServerPlugin.afterRemoveBinding(Binding binding,
Transaction tx,
boolean deleteData)
After a binding is removed
|
default void |
ActiveMQServerPlugin.afterSend(ServerSession session,
Transaction tx,
Message message,
boolean direct,
boolean noAutoCreateQueue,
RoutingStatus result)
After a message is sent
|
default void |
ActiveMQServerPlugin.afterSend(Transaction tx,
Message message,
boolean direct,
boolean noAutoCreateQueue,
RoutingStatus result)
|
default void |
ActiveMQServerPlugin.afterSessionMetadataAdded(ServerSession session,
String key,
String data)
After session metadata is added to the session
|
default void |
ActiveMQServerPlugin.afterUpdateAddress(AddressInfo addressInfo)
After an address has been updated
|
default void |
ActiveMQServerPlugin.beforeAddAddress(AddressInfo addressInfo,
boolean reload)
Before an address is added tot he broker
|
default void |
ActiveMQServerPlugin.beforeAddBinding(Binding binding)
Before a binding is added
|
default void |
ActiveMQServerPlugin.beforeCloseConsumer(ServerConsumer consumer,
boolean failed)
Before a consumer is closed
|
default void |
ActiveMQServerPlugin.beforeCloseSession(ServerSession session,
boolean failed)
Before a session is closed
|
default void |
ActiveMQServerPlugin.beforeCreateConsumer(long consumerID,
QueueBinding queueBinding,
SimpleString filterString,
boolean browseOnly,
boolean supportLargeMessage)
Before a consumer is created
|
default void |
ActiveMQServerPlugin.beforeCreateConsumer(long consumerID,
SimpleString queueName,
SimpleString filterString,
boolean browseOnly,
boolean supportLargeMessage)
Deprecated.
use {@link #beforeCreateConsumer(long, QueueBinding, SimpleString, boolean, boolean)
|
default void |
ActiveMQServerPlugin.beforeCreateQueue(QueueConfig queueConfig)
Before a queue is created
|
default void |
ActiveMQServerPlugin.beforeCreateSession(String name,
String username,
int minLargeMessageSize,
RemotingConnection connection,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
boolean xa,
String defaultAddress,
SessionCallback callback,
boolean autoCreateQueues,
OperationContext context,
Map<SimpleString,RoutingType> prefixes)
Before a session is created.
|
default void |
ActiveMQServerPlugin.beforeDeliver(MessageReference reference)
Deprecated.
use throws ActiveMQException
ActiveMQServerPlugin.beforeDeliver(ServerConsumer, MessageReference) |
default void |
ActiveMQServerPlugin.beforeDeliver(ServerConsumer consumer,
MessageReference reference)
Before a message is delivered to a client consumer
|
default void |
ActiveMQServerPlugin.beforeDeployBridge(BridgeConfiguration config)
Before a bridge is deployed
|
default void |
ActiveMQServerPlugin.beforeDestroyQueue(SimpleString queueName,
SecurityAuth session,
boolean checkConsumerCount,
boolean removeConsumers,
boolean autoDeleteAddress)
Before a queue is destroyed
|
default void |
ActiveMQServerPlugin.beforeMessageRoute(Message message,
RoutingContext context,
boolean direct,
boolean rejectDuplicates)
Before a message is routed
|
default void |
ActiveMQServerPlugin.beforeRemoveAddress(SimpleString address)
Before an address is removed
|
default void |
ActiveMQServerPlugin.beforeRemoveBinding(SimpleString uniqueName,
Transaction tx,
boolean deleteData)
Before a binding is removed
|
default void |
ActiveMQServerPlugin.beforeSend(ServerSession session,
Transaction tx,
Message message,
boolean direct,
boolean noAutoCreateQueue)
Before a message is sent
|
default void |
ActiveMQServerPlugin.beforeSend(Transaction tx,
Message message,
boolean direct,
boolean noAutoCreateQueue)
|
default void |
ActiveMQServerPlugin.beforeSessionMetadataAdded(ServerSession session,
String key,
String data)
Before session metadata is added to the session
|
default void |
ActiveMQServerPlugin.beforeUpdateAddress(SimpleString address,
EnumSet<RoutingType> routingTypes)
Before an address is updated
|
default void |
ActiveMQServerPlugin.criticalFailure(CriticalComponent components)
A Critical failure has been detected.
|
default void |
ActiveMQServerPlugin.messageAcknowledged(MessageReference ref,
AckReason reason)
|
default void |
ActiveMQServerPlugin.messageAcknowledged(MessageReference ref,
AckReason reason,
ServerConsumer consumer)
A message has been acknowledged
|
default void |
ActiveMQServerPlugin.messageExpired(MessageReference message,
SimpleString messageExpiryAddress)
|
default void |
ActiveMQServerPlugin.messageExpired(MessageReference message,
SimpleString messageExpiryAddress,
ServerConsumer consumer)
A message has been expired
|
void |
ActiveMQPluginRunnable.run(ActiveMQServerPlugin plugin) |
Modifier and Type | Method and Description |
---|---|
void |
NotificationActiveMQServerPlugin.afterAddAddress(AddressInfo addressInfo,
boolean reload) |
void |
LoggingActiveMQServerPlugin.afterCloseConsumer(ServerConsumer consumer,
boolean failed)
After a consumer is closed
|
void |
NotificationActiveMQServerPlugin.afterCloseSession(ServerSession session,
boolean failed) |
void |
LoggingActiveMQServerPlugin.afterCloseSession(ServerSession session,
boolean failed)
After a session is closed
|
void |
NotificationActiveMQServerPlugin.afterCreateConnection(RemotingConnection connection) |
void |
LoggingActiveMQServerPlugin.afterCreateConnection(RemotingConnection connection)
A connection has been created.
|
void |
LoggingActiveMQServerPlugin.afterCreateConsumer(ServerConsumer consumer)
After a consumer has been created
|
void |
LoggingActiveMQServerPlugin.afterCreateQueue(Queue queue)
After a queue has been created
|
void |
NotificationActiveMQServerPlugin.afterCreateSession(ServerSession session) |
void |
LoggingActiveMQServerPlugin.afterCreateSession(ServerSession session)
After a session has been created.
|
void |
NotificationActiveMQServerPlugin.afterDeliver(ServerConsumer consumer,
MessageReference reference) |
void |
LoggingActiveMQServerPlugin.afterDeliver(ServerConsumer consumer,
MessageReference reference)
After a message is delivered to a client consumer
|
void |
LoggingActiveMQServerPlugin.afterDeployBridge(Bridge bridge)
After a bridge has been deployed
|
void |
NotificationActiveMQServerPlugin.afterDestroyConnection(RemotingConnection connection) |
void |
LoggingActiveMQServerPlugin.afterDestroyConnection(RemotingConnection connection)
A connection has been destroyed.
|
void |
LoggingActiveMQServerPlugin.afterDestroyQueue(Queue queue,
SimpleString address,
SecurityAuth session,
boolean checkConsumerCount,
boolean removeConsumers,
boolean autoDeleteAddress)
After a queue has been destroyed
|
void |
LoggingActiveMQServerPlugin.afterMessageRoute(Message message,
RoutingContext context,
boolean direct,
boolean rejectDuplicates,
RoutingStatus result)
After a message is routed
|
void |
NotificationActiveMQServerPlugin.afterRemoveAddress(SimpleString address,
AddressInfo addressInfo) |
void |
LoggingActiveMQServerPlugin.afterSend(ServerSession session,
Transaction tx,
Message message,
boolean direct,
boolean noAutoCreateQueue,
RoutingStatus result)
After a message is sent
|
void |
LoggingActiveMQServerPlugin.afterSessionMetadataAdded(ServerSession session,
String key,
String data)
After session metadata is added to the session
|
void |
LoggingActiveMQServerPlugin.beforeCloseConsumer(ServerConsumer consumer,
boolean failed)
Before a consumer is closed
|
void |
LoggingActiveMQServerPlugin.beforeCloseSession(ServerSession session,
boolean failed)
Before a session is closed
|
void |
LoggingActiveMQServerPlugin.beforeCreateConsumer(long consumerID,
QueueBinding queueBinding,
SimpleString filterString,
boolean browseOnly,
boolean supportLargeMessage)
Before a consumer is created
|
void |
LoggingActiveMQServerPlugin.beforeCreateQueue(QueueConfig queueConfig)
Before a queue is created
|
void |
LoggingActiveMQServerPlugin.beforeCreateSession(String name,
String username,
int minLargeMessageSize,
RemotingConnection connection,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
boolean xa,
String publicAddress,
SessionCallback callback,
boolean autoCreateQueues,
OperationContext context,
Map<SimpleString,RoutingType> prefixes)
Before a session is created.
|
void |
LoggingActiveMQServerPlugin.beforeDeliver(ServerConsumer consumer,
MessageReference reference)
Before a message is delivered to a client consumer
|
void |
LoggingActiveMQServerPlugin.beforeDeployBridge(BridgeConfiguration config)
Before a bridge is deployed
|
void |
LoggingActiveMQServerPlugin.beforeDestroyQueue(SimpleString queueName,
SecurityAuth session,
boolean checkConsumerCount,
boolean removeConsumers,
boolean autoDeleteAddress)
Before a queue is destroyed
|
void |
LoggingActiveMQServerPlugin.beforeMessageRoute(Message message,
RoutingContext context,
boolean direct,
boolean rejectDuplicates)
Before a message is routed
|
void |
LoggingActiveMQServerPlugin.beforeSend(ServerSession session,
Transaction tx,
Message message,
boolean direct,
boolean noAutoCreateQueue)
Before a message is sent
|
void |
LoggingActiveMQServerPlugin.beforeSessionMetadataAdded(ServerSession session,
String key,
String data)
Before session metadata is added to the session
|
void |
LoggingActiveMQServerPlugin.criticalFailure(CriticalComponent components)
A Critical failure has been detected.
|
void |
LoggingActiveMQServerPlugin.messageAcknowledged(MessageReference ref,
AckReason reason,
ServerConsumer consumer)
A message has been acknowledged
|
Modifier and Type | Method and Description |
---|---|
void |
Transaction.markAsRollbackOnly(ActiveMQException exception) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionImpl.markAsRollbackOnly(ActiveMQException exception) |
Modifier and Type | Method and Description |
---|---|
void |
JDBCSequentialFile.delete() |
Modifier and Type | Method and Description |
---|---|
static JMSException |
JMSExceptionHelper.convertFromActiveMQException(ActiveMQException me) |
Modifier and Type | Method and Description |
---|---|
void |
ActiveMQTextMessage.doBeforeReceive() |
void |
ActiveMQObjectMessage.doBeforeReceive() |
void |
ActiveMQMessage.doBeforeReceive() |
void |
ActiveMQMapMessage.doBeforeReceive() |
void |
ActiveMQBytesMessage.doBeforeReceive() |
protected Queue |
ActiveMQSession.internalCreateQueue(String queueName) |
protected ActiveMQQueue |
ActiveMQSession.internalCreateQueueCompatibility(String queueName) |
protected Topic |
ActiveMQSession.internalCreateTopic(String topicName,
boolean retry) |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQConnectionFactory |
JMSServerManagerImpl.internalCreateCFPOJO(ConnectionFactoryConfiguration cfConfig)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static void |
MessageUtil.setJMSCorrelationIDAsBytes(Message message,
byte[] correlationID) |
Modifier and Type | Method and Description |
---|---|
void |
ActiveMQXAResourceWrapper.beforeReconnect(ActiveMQException me) |
void |
ActiveMQXAResourceWrapper.connectionFailed(ActiveMQException me,
boolean failedOver) |
void |
ActiveMQXAResourceWrapper.connectionFailed(ActiveMQException me,
boolean failedOver,
String scaleDownTargetNodeID) |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractRemotingConnection.callFailureListeners(ActiveMQException me,
String scaleDownTargetNodeID) |
void |
RemotingConnection.fail(ActiveMQException me)
called when the underlying connection fails.
|
void |
AbstractRemotingConnection.fail(ActiveMQException me) |
void |
RemotingConnection.fail(ActiveMQException me,
String scaleDownTargetNodeID)
called when the underlying connection fails.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ClientProtocolManager.cleanupBeforeFailover(ActiveMQException cause) |
void |
BaseConnectionLifeCycleListener.connectionException(Object connectionID,
ActiveMQException me)
Called when an error occurs on the connection.
|
abstract void |
SessionContext.returnBlocking(ActiveMQException cause)
Interrupt and return any blocked calls
|
Modifier and Type | Method and Description |
---|---|
abstract ClientSession.AddressQuery |
SessionContext.addressQuery(SimpleString address) |
abstract void |
SessionContext.addSessionMetadata(String key,
String data) |
abstract void |
SessionContext.addUniqueMetaData(String key,
String data) |
boolean |
ClientProtocolManager.checkForFailover(String liveNodeID) |
abstract void |
SessionContext.closeConsumer(ClientConsumer consumer) |
abstract boolean |
SessionContext.configureTransactionTimeout(int seconds) |
abstract void |
SessionContext.createAddress(SimpleString address,
EnumSet<RoutingType> routingTypes,
boolean autoCreated) |
abstract void |
SessionContext.createAddress(SimpleString address,
Set<RoutingType> routingTypes,
boolean autoCreated)
Deprecated.
|
abstract ClientConsumerInternal |
SessionContext.createConsumer(SimpleString queueName,
SimpleString filterString,
int windowSize,
int maxRate,
int ackBatchSize,
boolean browseOnly,
Executor executor,
Executor flowControlExecutor) |
abstract void |
SessionContext.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean temp,
int maxConsumers,
boolean purgeOnNoConsumers,
boolean autoCreated)
Deprecated.
|
abstract void |
SessionContext.createQueue(SimpleString address,
RoutingType routingType,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean temp,
int maxConsumers,
boolean purgeOnNoConsumers,
boolean autoCreated,
Boolean exclusive,
Boolean lastVale) |
abstract void |
SessionContext.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean temp,
boolean autoCreated)
Deprecated.
|
SessionContext |
ClientProtocolManager.createSessionContext(String name,
String username,
String password,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
int minLargeMessageSize,
int confirmationWindowSize) |
abstract void |
SessionContext.createSharedQueue(SimpleString address,
SimpleString queueName,
RoutingType routingType,
SimpleString filterString,
boolean durable) |
abstract void |
SessionContext.createSharedQueue(SimpleString address,
SimpleString queueName,
RoutingType routingType,
SimpleString filterString,
boolean durable,
Integer maxConsumers,
Boolean purgeOnNoConsumers,
Boolean exclusive,
Boolean lastValue)
Creates a shared queue using the routing type set by the Address.
|
abstract void |
SessionContext.createSharedQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable) |
abstract void |
SessionContext.deleteQueue(SimpleString queueName) |
abstract void |
SessionContext.expireMessage(ClientConsumer consumer,
Message message) |
abstract void |
SessionContext.forceDelivery(ClientConsumer consumer,
long sequence) |
abstract ClientSession.QueueQuery |
SessionContext.queueQuery(SimpleString queueName) |
abstract boolean |
SessionContext.reattachOnNewConnection(RemotingConnection newConnection)
it will either reattach or reconnect, preferably reattaching it.
|
abstract int |
SessionContext.recoverSessionTimeout()
Performs a round trip to the server requesting what is the current tx timeout on the session
|
abstract void |
SessionContext.recreateConsumerOnServer(ClientConsumerInternal consumerInternal,
long consumerId,
boolean isSessionStarted) |
abstract void |
SessionContext.recreateSession(String username,
String password,
int minLargeMessageSize,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge) |
abstract void |
SessionContext.restartSession() |
abstract void |
SessionContext.sendACK(boolean individual,
boolean block,
ClientConsumer consumer,
Message message) |
abstract void |
SessionContext.sendFullMessage(ICoreMessage msgI,
boolean sendBlocking,
SendAcknowledgementHandler handler,
SimpleString defaultAddress) |
abstract int |
SessionContext.sendInitialChunkOnLargeMessage(Message msgI)
it should return the number of credits (or bytes) used to send this packet
|
abstract int |
SessionContext.sendLargeMessageChunk(Message msgI,
long messageBodySize,
boolean sendBlocking,
boolean lastChunk,
byte[] chunk,
int reconnectID,
SendAcknowledgementHandler messageHandler) |
abstract int |
SessionContext.sendServerLargeMessageChunk(Message msgI,
long messageBodySize,
boolean sendBlocking,
boolean lastChunk,
byte[] chunk,
SendAcknowledgementHandler messageHandler) |
abstract void |
SessionContext.sessionClose() |
abstract void |
SessionContext.sessionStart() |
abstract void |
SessionContext.sessionStop() |
abstract void |
SessionContext.simpleCommit() |
abstract void |
SessionContext.simpleCommit(boolean block) |
abstract void |
SessionContext.simpleRollback(boolean lastMessageAsDelivered)
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.
|
abstract void |
SessionContext.xaCommit(Xid xid,
boolean onePhase) |
abstract void |
SessionContext.xaEnd(Xid xid,
int flags) |
abstract void |
SessionContext.xaFailed(Xid xid) |
abstract void |
SessionContext.xaForget(Xid xid) |
abstract int |
SessionContext.xaPrepare(Xid xid) |
abstract void |
SessionContext.xaRollback(Xid xid,
boolean wasStarted) |
abstract Xid[] |
SessionContext.xaScan() |
abstract void |
SessionContext.xaStart(Xid xid,
int flags) |
Modifier and Type | Method and Description |
---|---|
static SensitiveDataCodec<String> |
PasswordMaskingUtil.getCodec(String codecDesc) |
Copyright © 2018 JBoss by Red Hat. All rights reserved.