Modifier and Type | Class and Description |
---|---|
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 |
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 |
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 |
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 |
ActiveMQSecurityException
A security problem occurred (authentication issues, permission issues,...)
|
class |
ActiveMQSessionCreationException
The creation of a session was rejected by the server (e.g.
|
class |
ActiveMQTransactionOutcomeUnknownException
The outcome of a transaction is unknown.
|
class |
ActiveMQTransactionRolledBackException
A transaction was rolled back.
|
class |
ActiveMQUnBlockedException
A blocking call from a client was unblocked during failover.
|
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 |
---|---|
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.
|
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,
SimpleString queueName)
Creates a non-temporary queue non-durable queue.
|
void |
ClientSession.createQueue(SimpleString address,
SimpleString queueName,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filter,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(String address,
String queueName)
Creates a non-temporary queue non-durable queue.
|
void |
ClientSession.createQueue(String address,
String queueName,
boolean durable)
Creates a non-temporary queue.
|
void |
ClientSession.createQueue(String address,
String queueName,
String filter,
boolean durable)
Creates a non-temporaryqueue.
|
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,
SimpleString queueName,
boolean durable)
Creates a transient queue.
|
void |
ClientSession.createSharedQueue(SimpleString address,
SimpleString queueName,
SimpleString filter,
boolean durable)
Creates a transient queue.
|
void |
ClientSession.createTemporaryQueue(SimpleString address,
SimpleString queueName)
Creates a temporary queue.
|
void |
ClientSession.createTemporaryQueue(SimpleString address,
SimpleString queueName,
SimpleString filter)
Creates a temporary queue with a filter.
|
void |
ClientSession.createTemporaryQueue(String address,
String queueName)
Creates a temporary queue.
|
void |
ClientSession.createTemporaryQueue(String address,
String queueName,
String filter)
Creates a temporary queue with a filter.
|
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.
|
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 |
---|---|
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 |
ClientProducerCreditsImpl.acquireCredits(int credits) |
void |
ClientProducerCredits.acquireCredits(int credits) |
void |
ClientSessionImpl.addMetaData(String key,
String data) |
ClientSession.AddressQuery |
ClientSessionImpl.addressQuery(SimpleString address) |
void |
ClientSessionImpl.addUniqueMetaData(String key,
String data) |
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() |
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() |
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,
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(String address,
String queueName) |
void |
ClientSessionImpl.createQueue(String address,
String queueName,
boolean durable) |
void |
ClientSessionImpl.createQueue(String address,
String queueName,
String filterString,
boolean durable) |
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,
SimpleString queueName,
boolean durable) |
void |
ClientSessionImpl.createSharedQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable) |
void |
ClientSessionImpl.createTemporaryQueue(SimpleString address,
SimpleString queueName) |
void |
ClientSessionImpl.createTemporaryQueue(SimpleString address,
SimpleString queueName,
SimpleString 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() |
BodyEncoder |
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) |
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.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 |
BodyEncoder.close()
This method must not be called directly by ActiveMQ Artemis clients.
|
int |
BodyEncoder.encode(ActiveMQBuffer bufferOut,
int size)
This method must not be called directly by ActiveMQ Artemis clients.
|
int |
BodyEncoder.encode(ByteBuffer bufferRead)
This method must not be called directly by ActiveMQ Artemis clients.
|
void |
BodyEncoder.open()
This method must not be called directly by ActiveMQ Artemis clients.
|
Modifier and Type | Method and Description |
---|---|
void |
MessageImpl.checkCompletion() |
BodyEncoder |
MessageInternal.getBodyEncoder() |
BodyEncoder |
MessageImpl.getBodyEncoder() |
Modifier and Type | Method and Description |
---|---|
BodyEncoder |
LargeServerMessageImpl.getBodyEncoder() |
SequentialFile |
LargeServerMessageImpl.getFile() |
SequentialFile |
LargeServerMessageInSync.getSyncFile() |
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) |
ClientConsumerInternal |
ActiveMQSessionContext.createConsumer(SimpleString queueName,
SimpleString filterString,
int windowSize,
int maxRate,
int ackBatchSize,
boolean browseOnly,
Executor executor,
Executor flowControlExecutor) |
void |
ActiveMQSessionContext.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean temp) |
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,
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) |
void |
ActiveMQSessionContext.recreateSession(String username,
String password,
int minLargeMessageSize,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
SimpleString defaultAddress) |
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(MessageInternal msgI,
boolean sendBlocking,
SendAcknowledgementHandler handler,
SimpleString defaultAddress) |
int |
ActiveMQSessionContext.sendInitialChunkOnLargeMessage(MessageInternal msgI) |
int |
ActiveMQSessionContext.sendLargeMessageChunk(MessageInternal msgI,
long messageBodySize,
boolean sendBlocking,
boolean lastChunk,
byte[] chunk,
int reconnectID,
SendAcknowledgementHandler messageHandler) |
void |
ActiveMQSessionContext.sessionClose() |
void |
ActiveMQSessionContext.sessionStart() |
void |
ActiveMQSessionContext.sessionStop() |
void |
ActiveMQSessionContext.simpleCommit() |
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) |
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 |
ReplicationEndpoint.compareJournalInformation(JournalLoadInformation[] journalInformation) |
void |
ReplicationManager.sendStartSyncMessage(JournalFile[] datafiles,
JournalStorageManager.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 |
---|---|
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() |
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 |
---|---|
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() |
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 |
---|---|
void |
Transaction.markAsRollbackOnly(ActiveMQException exception) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionImpl.markAsRollbackOnly(ActiveMQException exception) |
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() |
Modifier and Type | Method and Description |
---|---|
static String |
JMSTopicControlImpl.createFilterFromJMSSelector(String selectorStr) |
static String |
JMSQueueControlImpl.createFilterFromJMSSelector(String selectorStr)
Returns null if the string is null or empty
|
Modifier and Type | Method and Description |
---|---|
protected ActiveMQConnectionFactory |
JMSServerManagerImpl.internalCreateCFPOJO(ConnectionFactoryConfiguration cfConfig) |
Modifier and Type | Method and Description |
---|---|
static void |
MessageUtil.setJMSCorrelationIDAsBytes(Message message,
byte[] correlationID) |
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 |
ConnectionLifeCycleListener.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 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,
SimpleString queueName,
SimpleString filterString,
boolean durable,
boolean temp) |
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,
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 eather 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) |
abstract void |
SessionContext.recreateSession(String username,
String password,
int minLargeMessageSize,
boolean xa,
boolean autoCommitSends,
boolean autoCommitAcks,
boolean preAcknowledge,
SimpleString defaultAddress) |
abstract void |
SessionContext.restartSession() |
abstract void |
SessionContext.sendACK(boolean individual,
boolean block,
ClientConsumer consumer,
Message message) |
abstract void |
SessionContext.sendFullMessage(MessageInternal msgI,
boolean sendBlocking,
SendAcknowledgementHandler handler,
SimpleString defaultAddress) |
abstract int |
SessionContext.sendInitialChunkOnLargeMessage(MessageInternal msgI)
it should return the number of credits (or bytes) used to send this packet
|
abstract int |
SessionContext.sendLargeMessageChunk(MessageInternal msgI,
long messageBodySize,
boolean sendBlocking,
boolean lastChunk,
byte[] chunk,
int reconnectID,
SendAcknowledgementHandler messageHandler) |
abstract void |
SessionContext.sessionClose() |
abstract void |
SessionContext.sessionStart() |
abstract void |
SessionContext.sessionStop() |
abstract void |
SessionContext.simpleCommit() |
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 © 2016 JBoss by Red Hat. All rights reserved.