Modifier and Type | Class and Description |
---|---|
class |
HornetQAddressExistsException
An operation failed because an address exists on the server.
|
class |
HornetQAddressFullException
An address is full.
|
class |
HornetQAlreadyReplicatingException
The server is already paired with a replicating backup.
|
class |
HornetQClusterSecurityException
Security exception thrown when the cluster user fails authentication.
|
class |
HornetQConnectionTimedOutException
A client timed out will connecting to HornetQ server.
|
class |
HornetQDisconnectedException
A client was disconnected from HornetQ server when the server has shut down.
|
class |
HornetQDuplicateIdException
A DuplicateID was rejected.
|
class |
HornetQDuplicateMetaDataException
A Session Metadata was set in duplication
|
class |
HornetQIllegalStateException
A HornetQ resource is not in a legal state (e.g.
|
class |
HornetQIncompatibleClientServerException
The server version and the client version are incompatible.
|
class |
HornetQInterceptorRejectedPacketException
An outgoing interceptor returned false.
|
class |
HornetQInternalErrorException
Internal error which prevented HornetQ from performing an important operation.
|
class |
HornetQInvalidFilterExpressionException
A filter expression was found to be invalid.
|
class |
HornetQIOErrorException
Unexpected I/O error occurred on the server.
|
class |
HornetQLargeMessageException
A problem occurred while manipulating the body of a large message.
|
class |
HornetQLargeMessageInterruptedException |
class |
HornetQNativeIOError
An error has happened at HornetQ's native (non-Java) code used in reading and writing data.
|
class |
HornetQNonExistentQueueException
An operation failed because a queue does not exist on the server.
|
class |
HornetQNotConnectedException
A client is not able to connect to HornetQ server.
|
class |
HornetQObjectClosedException
A client operation failed because the calling resource (ClientSession, ClientProducer, etc.) is
closed.
|
class |
HornetQQueueExistsException
An operation failed because a queue exists on the server.
|
class |
HornetQSecurityException
A security problem occurred (authentication issues, permission issues,...)
|
class |
HornetQSessionCreationException
The creation of a session was rejected by the server (e.g.
|
class |
HornetQTransactionOutcomeUnknownException
The outcome of a transaction is unknown.
|
class |
HornetQTransactionRolledBackException
A transaction was rolled back.
|
class |
HornetQUnBlockedException
A blocking call from a client was unblocked during failover.
|
class |
HornetQUnsupportedPacketException
A packet of unsupported type was received by HornetQ PacketHandler.
|
Modifier and Type | Method and Description |
---|---|
static HornetQException |
HornetQExceptionType.createException(int code,
String msg) |
HornetQException |
HornetQExceptionType.createException(String msg) |
Modifier and Type | Method and Description |
---|---|
boolean |
Interceptor.intercept(Packet 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(HornetQException exception)
Notifies that a connection has failed due to the specified exception.
|
Modifier and Type | Method and Description |
---|---|
void |
ClientMessage.acknowledge()
Acknowledge reception of this message.
|
void |
ClientSession.addMetaData(String key,
String data)
Attach any metadata to the session.
|
void |
ClientSession.addUniqueMetaData(String key,
String data)
Attach any metadata to the session.
|
ClientSession.BindingQuery |
ClientSession.bindingQuery(SimpleString address)
Queries information on a binding.
|
void |
ClientMessage.checkCompletion()
This can be optionally used to verify if the entire message has been received.
|
void |
ClientProducer.close()
Closes the ClientProducer.
|
void |
ClientConsumer.close()
Closes the consumer.
|
void |
ClientSession.close()
Closes the session.
|
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.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.
|
void |
ClientMessage.individualAcknowledge()
Acknowledge 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(SimpleString address,
Message message)
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.
|
void |
ClientConsumer.setMessageHandler(MessageHandler handler)
Sets the MessageHandler for this consumer to consume messages asynchronously.
|
void |
ClientMessage.setOutputStream(OutputStream out)
Sets the OutputStream that will receive the content of a message received in a non blocking way.
|
void |
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 |
AsynchronousFile.close() |
void |
AsynchronousFile.fill(long position,
int blocks,
long size,
byte fillChar) |
void |
AsynchronousFile.open(String fileName,
int maxIO)
Note: If you are using a native Linux implementation, maxIO can't be higher than what's defined on /proc/sys/fs/aio-max-nr, or you would get an error
|
void |
AsynchronousFile.read(long position,
long size,
ByteBuffer directByteBuffer,
AIOCallback aioCallback) |
long |
AsynchronousFile.size()
Warning: This function will perform a synchronous IO, probably translating to a fstat call
|
void |
AsynchronousFile.writeInternal(long positionToWrite,
long size,
ByteBuffer bytes)
Performs an internal direct write.
|
Modifier and Type | Method and Description |
---|---|
void |
AsynchronousFileImpl.close() |
void |
AsynchronousFileImpl.fill(long position,
int blocks,
long size,
byte fillChar) |
void |
AsynchronousFileImpl.open(String fileName1,
int maxIOArgument) |
void |
AsynchronousFileImpl.read(long position,
long size,
ByteBuffer directByteBuffer,
AIOCallback aioPackage) |
long |
AsynchronousFileImpl.size() |
void |
AsynchronousFileImpl.writeInternal(long positionToWrite,
long size,
ByteBuffer bytes) |
Modifier and Type | Method and Description |
---|---|
void |
ClientSessionFactoryImpl.connectionException(Object connectionID,
HornetQException me) |
void |
ClientSessionInternal.handleFailover(CoreRemotingConnection backupConnection,
HornetQException cause) |
void |
DelegatingSession.handleFailover(CoreRemotingConnection backupConnection,
HornetQException cause) |
Modifier and Type | Method and Description |
---|---|
void |
ClientMessageImpl.acknowledge() |
void |
ClientConsumerImpl.acknowledge(ClientMessage message) |
void |
ClientConsumerInternal.acknowledge(ClientMessage message) |
void |
ClientSessionInternal.acknowledge(long consumerID,
long messageID) |
void |
DelegatingSession.acknowledge(long consumerID,
long messageID) |
void |
ClientProducerCreditsImpl.acquireCredits(int credits) |
void |
ClientProducerCredits.acquireCredits(int credits) |
void |
DelegatingSession.addMetaData(String key,
String data) |
void |
DelegatingSession.addUniqueMetaData(String key,
String data) |
ClientSession.BindingQuery |
DelegatingSession.bindingQuery(SimpleString address) |
void |
ClientLargeMessageImpl.checkCompletion() |
void |
ClientConsumerInternal.cleanUp() |
void |
ClientSessionInternal.cleanUp(boolean failingOver) |
void |
DelegatingSession.cleanUp(boolean failingOver) |
void |
ClientConsumerImpl.clear(boolean waitForOnMessage) |
void |
ClientConsumerInternal.clear(boolean waitForOnMessage) |
void |
ClientConsumerImpl.close() |
void |
DelegatingSession.close() |
void |
ClientProducerImpl.close() |
void |
DelegatingSession.commit() |
ClientSessionFactoryInternal |
ServerLocatorImpl.connect() |
ClientSessionFactoryInternal |
ServerLocatorInternal.connect() |
void |
ClientSessionFactoryImpl.connect(int initialConnectAttempts,
boolean failoverOnInitialConnection) |
void |
ClientSessionFactoryInternal.connect(int reconnectAttempts,
boolean failoverOnInitialConnection) |
ClientSessionFactoryInternal |
ServerLocatorImpl.connectNoWarnings() |
ClientSessionFactoryInternal |
ServerLocatorInternal.connectNoWarnings()
Like
ServerLocatorInternal.connect() but it does not log warnings if it fails to connect. |
ClientConsumer |
DelegatingSession.createConsumer(SimpleString queueName) |
ClientConsumer |
DelegatingSession.createConsumer(SimpleString queueName,
boolean browseOnly) |
ClientConsumer |
DelegatingSession.createConsumer(SimpleString queueName,
SimpleString filterString) |
ClientConsumer |
DelegatingSession.createConsumer(SimpleString queueName,
SimpleString filterString,
boolean browseOnly) |
ClientConsumer |
DelegatingSession.createConsumer(SimpleString queueName,
SimpleString filterString,
int windowSize,
int maxRate,
boolean browseOnly) |
ClientConsumer |
DelegatingSession.createConsumer(String queueName) |
ClientConsumer |
DelegatingSession.createConsumer(String queueName,
boolean browseOnly) |
ClientConsumer |
DelegatingSession.createConsumer(String queueName,
String filterString) |
ClientConsumer |
DelegatingSession.createConsumer(String queueName,
String filterString,
boolean browseOnly) |
ClientConsumer |
DelegatingSession.createConsumer(String queueName,
String filterString,
int windowSize,
int maxRate,
boolean browseOnly) |
ClientProducer |
DelegatingSession.createProducer() |
ClientProducer |
DelegatingSession.createProducer(SimpleString address) |
ClientProducer |
DelegatingSession.createProducer(SimpleString address,
int rate) |
ClientProducer |
DelegatingSession.createProducer(String address) |
void |
DelegatingSession.createQueue(SimpleString address,
SimpleString queueName) |
void |
DelegatingSession.createQueue(SimpleString address,
SimpleString queueName,
boolean durable) |
void |
DelegatingSession.createQueue(SimpleString address,
SimpleString queueName,
SimpleString filterString,
boolean durable) |
void |
DelegatingSession.createQueue(String address,
String queueName) |
void |
DelegatingSession.createQueue(String address,
String queueName,
boolean durable) |
void |
DelegatingSession.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) |
ClientSessionFactory |
ServerLocatorImpl.createSessionFactory() |
void |
DelegatingSession.createTemporaryQueue(SimpleString address,
SimpleString queueName) |
void |
DelegatingSession.createTemporaryQueue(SimpleString address,
SimpleString queueName,
SimpleString filter) |
void |
DelegatingSession.createTemporaryQueue(String address,
String queueName) |
void |
DelegatingSession.createTemporaryQueue(String address,
String queueName,
String filter) |
ClientSession |
ClientSessionFactoryImpl.createTransactedSession() |
ClientSession |
ClientSessionFactoryImpl.createXASession() |
void |
DelegatingSession.deleteQueue(SimpleString queueName) |
void |
DelegatingSession.deleteQueue(String queueName) |
void |
ClientSessionInternal.expire(long consumerID,
long messageID) |
void |
DelegatingSession.expire(long consumerID,
long messageID) |
void |
ClientConsumerImpl.flowControl(int messageBytes,
boolean discountSlowConsumer)
LargeMessageBuffer will call flowcontrol here, while other handleMessage will also be calling flowControl.
|
void |
ClientConsumerInternal.flowControl(int messageBytes,
boolean discountSlowConsumer) |
void |
ClientConsumerImpl.flushAcks() |
void |
ClientConsumerInternal.flushAcks() |
void |
ClientSessionInternal.forceDelivery(long consumerID,
long sequence) |
void |
DelegatingSession.forceDelivery(long consumerID,
long sequence) |
BodyEncoder |
ClientMessageImpl.getBodyEncoder() |
MessageHandler |
ClientConsumerImpl.getMessageHandler() |
void |
ClientMessageImpl.individualAcknowledge() |
void |
ClientConsumerImpl.individualAcknowledge(ClientMessage message) |
void |
ClientConsumerInternal.individualAcknowledge(ClientMessage message) |
void |
ClientSessionInternal.individualAcknowledge(long consumerID,
long messageID) |
void |
DelegatingSession.individualAcknowledge(long consumerID,
long messageID) |
Thread |
ClientConsumerImpl.prepareForClose(FutureLatch future)
To be used by MDBs to stop any more handling of messages.
|
Thread |
ClientConsumerInternal.prepareForClose(FutureLatch future)
To be called by things like MDBs during shutdown of the server
|
ClientSession.QueueQuery |
DelegatingSession.queueQuery(SimpleString queueName) |
ClientMessage |
ClientConsumerImpl.receive() |
ClientMessage |
ClientConsumerImpl.receive(long timeout) |
ClientMessage |
ClientConsumerImpl.receiveImmediate() |
void |
ClientSessionInternal.removeConsumer(ClientConsumerInternal consumer) |
void |
DelegatingSession.removeConsumer(ClientConsumerInternal consumer) |
void |
ClientSessionInternal.resetIfNeeded() |
void |
DelegatingSession.resetIfNeeded() |
void |
DelegatingSession.rollback() |
void |
DelegatingSession.rollback(boolean considerLastMessageAsDelivered) |
void |
LargeMessageController.saveBuffer(OutputStream output)
Saves this buffer to the specified output.
|
void |
LargeMessageControllerImpl.saveBuffer(OutputStream output) |
void |
ClientMessageImpl.saveToOutputStream(OutputStream out) |
void |
ClientLargeMessageImpl.saveToOutputStream(OutputStream out) |
void |
ClientProducerImpl.send(Message msg) |
void |
ClientProducerImpl.send(SimpleString address,
Message msg) |
void |
ClientProducerImpl.send(String address,
Message message) |
void |
ClientConsumerImpl.setMessageHandler(MessageHandler theHandler) |
void |
LargeMessageController.setOutputStream(OutputStream output)
Sets the OutputStream of this buffer to the specified output.
|
void |
LargeMessageControllerImpl.setOutputStream(OutputStream output) |
void |
ClientMessageImpl.setOutputStream(OutputStream out) |
void |
ClientLargeMessageImpl.setOutputStream(OutputStream out) |
void |
DelegatingSession.start() |
void |
DelegatingSession.stop() |
void |
ClientConsumerImpl.stop(boolean waitForOnMessage) |
void |
ClientConsumerInternal.stop(boolean waitForOnMessage) |
boolean |
LargeMessageController.waitCompletion(long timeWait)
Waits for the completion for the specified waiting time (in milliseconds).
|
boolean |
LargeMessageControllerImpl.waitCompletion(long timeWait) |
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 |
SequentialFile.delete() |
Modifier and Type | Method and Description |
---|---|
void |
NIOSequentialFile.close() |
void |
AIOSequentialFile.close() |
void |
AbstractSequentialFile.close() |
void |
AbstractSequentialFile.delete() |
void |
AIOSequentialFile.open(int maxIO,
boolean useExecutor) |
int |
AIOSequentialFile.read(ByteBuffer bytes,
IOAsyncTask callback) |
void |
AbstractSequentialFile.renameTo(String newFileName) |
void |
SimpleWaitIOCallback.waitCompletion() |
boolean |
SimpleWaitIOCallback.waitCompletion(long timeout) |
void |
AbstractSequentialFile.write(EncodingSupport bytes,
boolean sync) |
void |
AbstractSequentialFile.write(HornetQBuffer bytes,
boolean sync) |
void |
AIOSequentialFile.writeInternal(ByteBuffer bytes) |
Modifier and Type | Method and Description |
---|---|
void |
BodyEncoder.close()
This method must not be called directly by HornetQ clients.
|
int |
BodyEncoder.encode(ByteBuffer bufferRead)
This method must not be called directly by HornetQ clients.
|
int |
BodyEncoder.encode(HornetQBuffer bufferOut,
int size)
This method must not be called directly by HornetQ clients.
|
void |
BodyEncoder.open()
This method must not be called directly by HornetQ 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(HornetQException 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.
|
Modifier and Type | Method and Description |
---|---|
void |
RemotingConnectionImpl.fail(HornetQException me) |
Modifier and Type | Method and Description |
---|---|
Packet |
ChannelImpl.sendBlocking(Packet packet,
byte expectedPacket)
Due to networking issues or server issues the server may take longer to answer than expected..
|
Modifier and Type | Method and Description |
---|---|
HornetQException |
HornetQExceptionMessage.getException() |
Constructor and Description |
---|
HornetQExceptionMessage(HornetQException exception) |
Modifier and Type | Method and Description |
---|---|
void |
StompConnection.fail(HornetQException me) |
Modifier and Type | Method and Description |
---|---|
void |
FailureListener.connectionFailed(HornetQException exception,
boolean failedOver)
Notifies that a connection has failed due to the specified exception.
|
Modifier and Type | Method and Description |
---|---|
void |
RemotingServiceImpl.connectionException(Object connectionID,
HornetQException 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 |
---|---|
HornetQException |
HornetQMessageBundle.groupWhileStopping() |
HornetQException |
HornetQMessageBundle.noDiscoveryGroupFound(DiscoveryGroupConfiguration dg) |
Modifier and Type | Method and Description |
---|---|
void |
LiveNodeLocator.connectToCluster(ServerLocatorInternal serverLocator)
connects to the cluster
|
SequentialFile |
LargeServerMessage.getFile() |
abstract void |
LiveNodeLocator.locateNode()
Locates a possible live server in a cluster
|
void |
HornetQServer.startReplication(CoreRemotingConnection rc,
ClusterConnection clusterConnection,
Pair<TransportConfiguration,TransportConfiguration> pair,
boolean failBackRequest)
Starts replication.
|
Modifier and Type | Method and Description |
---|---|
void |
ClusterManager.announceReplicatingBackupToLive(Channel liveChannel,
boolean attemptingFailBack)
XXX HORNETQ-720
|
boolean |
ClusterManager.IncomingInterceptorLookingForExceptionMessage.intercept(Packet packet,
RemotingConnection connection) |
Modifier and Type | Method and Description |
---|---|
void |
BridgeImpl.beforeReconnect(HornetQException exception) |
void |
BridgeImpl.connectionFailed(HornetQException me,
boolean failedOver) |
Modifier and Type | Method and Description |
---|---|
void |
QuorumManager.beforeReconnect(HornetQException exception) |
void |
ServerSessionImpl.connectionFailed(HornetQException me,
boolean failedOver) |
void |
QuorumManager.connectionFailed(HornetQException exception,
boolean failedOver) |
Modifier and Type | Method and Description |
---|---|
void |
NamedLiveNodeLocator.locateNode() |
void |
AnyLiveNodeLocator.locateNode() |
void |
HornetQServerImpl.remoteFailOver(ReplicationLiveIsStoppingMessage.LiveStopping finalMessage) |
void |
HornetQServerImpl.startReplication(CoreRemotingConnection rc,
ClusterConnection clusterConnection,
Pair<TransportConfiguration,TransportConfiguration> pair,
boolean isFailBackRequest) |
Modifier and Type | Method and Description |
---|---|
void |
Transaction.markAsRollbackOnly(HornetQException exception) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionImpl.markAsRollbackOnly(HornetQException exception1) |
Modifier and Type | Method and Description |
---|---|
static javax.jms.JMSException |
JMSExceptionHelper.convertFromHornetQException(HornetQException me) |
Modifier and Type | Method and Description |
---|---|
void |
HornetQMapMessage.doBeforeReceive() |
void |
HornetQBytesMessage.doBeforeReceive() |
void |
HornetQMessage.doBeforeReceive() |
void |
HornetQTextMessage.doBeforeReceive() |
void |
HornetQObjectMessage.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 HornetQConnectionFactory |
JMSServerManagerImpl.internalCreateCFPOJO(ConnectionFactoryConfiguration cfConfig) |
Modifier and Type | Method and Description |
---|---|
void |
HornetQXAResourceWrapper.beforeReconnect(HornetQException me) |
void |
RecoveryDiscovery.beforeReconnect(HornetQException exception) |
void |
HornetQXAResourceWrapper.connectionFailed(HornetQException me,
boolean failedOver) |
void |
RecoveryDiscovery.connectionFailed(HornetQException exception,
boolean failedOver) |
Modifier and Type | Method and Description |
---|---|
void |
HornetQRAProperties.init() |
protected void |
HornetQResourceAdapter.setup()
Setup the factory
|
Modifier and Type | Method and Description |
---|---|
void |
HornetQMessageHandler.start() |
Modifier and Type | Method and Description |
---|---|
void |
RemotingConnection.fail(HornetQException me)
called when the underlying connection fails.
|
Modifier and Type | Method and Description |
---|---|
void |
ConnectionLifeCycleListener.connectionException(Object connectionID,
HornetQException me)
Called when an error occurs on the connection.
|
Modifier and Type | Method and Description |
---|---|
static SensitiveDataCodec<String> |
PasswordMaskingUtil.getCodec(String codecDesc) |
Copyright © 2015 JBoss, a division of Red Hat. All Rights Reserved.