- calculateSize(MemorySize.ObjectFactory) - Static method in class org.hornetq.utils.MemorySize
-
- cancel() - Method in interface org.hornetq.core.client.impl.LargeMessageController
-
Cancels this buffer.
- cancel() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- cannotConnectToServers() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- cannotConnectToStaticConnectors(Exception) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- cannotConnectToStaticConnectors2() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- cannotFindPacketToClear(Integer, Integer) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- capacity() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- caughtunexpectedThrowable(Throwable) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- causeExit() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- causeExit() - Method in interface org.hornetq.core.client.impl.ClientSessionFactoryInternal
-
- changeMessagePriority(long, int) - Method in interface org.hornetq.api.core.management.QueueControl
-
Changes the message's priority corresponding to the specified message ID to the specified priority.
- changeMessagesPriority(String, int) - Method in interface org.hornetq.api.core.management.QueueControl
-
Changes the priority for all the message corresponding to the specified filter to the specified priority.
- Channel - Interface in org.hornetq.core.protocol.core
-
- channelBuffer() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- channelDisconnected() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- ChannelHandler - Interface in org.hornetq.core.protocol.core
-
A ChannelHandler is used by
Channel
.
- channelID - Variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- ChannelImpl - Class in org.hornetq.core.protocol.core.impl
-
A ChannelImpl
- ChannelImpl(CoreRemotingConnection, long, int, List<Interceptor>) - Constructor for class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- ChannelImpl.CHANNEL_ID - Enum in org.hornetq.core.protocol.core.impl
-
- checkCompletion() - Method in interface org.hornetq.api.core.client.ClientMessage
-
This can be optionally used to verify if the entire message has been received.
- checkCompletion() - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- checkCompletion() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- checkCopy() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- checkCopy() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- checkDataReceived() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- checkDataReceived() - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
returns true if any data has been received since the last time this method was called.
- checkFlushBatchBuffer() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- checkFlushBatchBuffer() - Method in interface org.hornetq.spi.core.remoting.Connection
-
Called periodically to flush any data in the batch buffer
- checkKeys(Set<String>, Set<String>) - Static method in class org.hornetq.utils.ConfigurationHelper
-
- checkKeysExist(Set<String>, Set<String>) - Static method in class org.hornetq.utils.ConfigurationHelper
-
- cleanup() - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Opposed to close, will call cleanup only on every created session and children objects.
- cleanUp() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- cleanUp() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- cleanUp() - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- cleanUp() - Method in interface org.hornetq.core.client.impl.ClientProducerInternal
-
- cleanup() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- cleanUp(boolean) - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- cleanUp(boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- cleanup() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- cleanup() - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- clear() - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- clear(boolean) - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- clear(boolean) - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- clear() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- clear() - Method in class org.hornetq.core.client.impl.Topology
-
It will remove all elements as if it haven't received anyone from the server.
- clear() - Method in interface org.hornetq.utils.LinkedList
-
- clear() - Method in class org.hornetq.utils.LinkedListImpl
-
- clear() - Method in interface org.hornetq.utils.PriorityLinkedList
-
- clear() - Method in class org.hornetq.utils.PriorityLinkedListImpl
-
- clear() - Method in class org.hornetq.utils.SoftValueHashMap
-
- clearAtFailover() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- clearAtFailover() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- clearCommands() - Method in interface org.hornetq.core.protocol.core.Channel
-
clears any commands from the cache that are yet to be confirmed.
- clearCommands() - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- clearThreadPools() - Static method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- ClientConsumer - Interface in org.hornetq.api.core.client
-
A ClientConsumer receives messages from HornetQ queues.
- ClientConsumerImpl - Class in org.hornetq.core.client.impl
-
- ClientConsumerImpl(ClientSessionInternal, long, SimpleString, SimpleString, boolean, int, int, TokenBucketLimiter, Executor, Executor, Channel, SessionQueueQueryResponseMessage, ClassLoader) - Constructor for class org.hornetq.core.client.impl.ClientConsumerImpl
-
- ClientConsumerInternal - Interface in org.hornetq.core.client.impl
-
A ClientConsumerInternal
- ClientLargeMessageImpl - Class in org.hornetq.core.client.impl
-
ClientLargeMessageImpl is only created when receiving large messages.
- ClientLargeMessageImpl() - Constructor for class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- ClientLargeMessageInternal - Interface in org.hornetq.core.client.impl
-
A ClientLargeMessageInternal
- ClientMessage - Interface in org.hornetq.api.core.client
-
A ClientMessage represents a message sent and/or received by HornetQ.
- ClientMessageImpl - Class in org.hornetq.core.client.impl
-
A ClientMessageImpl
- ClientMessageImpl() - Constructor for class org.hornetq.core.client.impl.ClientMessageImpl
-
- ClientMessageImpl(byte, boolean, long, long, byte, int) - Constructor for class org.hornetq.core.client.impl.ClientMessageImpl
-
- ClientMessageInternal - Interface in org.hornetq.core.client.impl
-
A ClientMessageInternal
- ClientPacketDecoder - Class in org.hornetq.core.protocol
-
- ClientPacketDecoder() - Constructor for class org.hornetq.core.protocol.ClientPacketDecoder
-
- ClientProducer - Interface in org.hornetq.api.core.client
-
A ClientProducer is used to send messages to a specific address.
- ClientProducerCreditManager - Interface in org.hornetq.core.client.impl
-
A ClientProducerCreditManager
- ClientProducerCreditManagerImpl - Class in org.hornetq.core.client.impl
-
A ProducerCreditManager
- ClientProducerCreditManagerImpl(ClientSessionInternal, int) - Constructor for class org.hornetq.core.client.impl.ClientProducerCreditManagerImpl
-
- ClientProducerCredits - Interface in org.hornetq.core.client.impl
-
A ClientProducerCredits
- ClientProducerCreditsImpl - Class in org.hornetq.core.client.impl
-
A ClientProducerCreditsImpl
- ClientProducerCreditsImpl(ClientSessionInternal, SimpleString, int) - Constructor for class org.hornetq.core.client.impl.ClientProducerCreditsImpl
-
- ClientProducerImpl - Class in org.hornetq.core.client.impl
-
The client-side Producer connectionFactory class.
- ClientProducerImpl(ClientSessionInternal, SimpleString, TokenBucketLimiter, boolean, boolean, boolean, SimpleString, int, Channel) - Constructor for class org.hornetq.core.client.impl.ClientProducerImpl
-
- ClientProducerInternal - Interface in org.hornetq.core.client.impl
-
A ClientProducerInternal
- ClientRequestor - Class in org.hornetq.api.core.client
-
The ClientRequestor class helps making requests.
- ClientRequestor(ClientSession, SimpleString) - Constructor for class org.hornetq.api.core.client.ClientRequestor
-
Constructor for the ClientRequestor.
- ClientRequestor(ClientSession, String) - Constructor for class org.hornetq.api.core.client.ClientRequestor
-
- ClientSession - Interface in org.hornetq.api.core.client
-
A ClientSession is a single-thread object required for producing and consuming messages.
- ClientSession.BindingQuery - Interface in org.hornetq.api.core.client
-
Information returned by a binding query
- ClientSession.QueueQuery - Interface in org.hornetq.api.core.client
-
Information returned by a queue query
- clientSessionClosed() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- ClientSessionFactory - Interface in org.hornetq.api.core.client
-
A ClientSessionFactory is the entry point to create and configure HornetQ resources to produce and consume messages.
- ClientSessionFactoryImpl - Class in org.hornetq.core.client.impl
-
- ClientSessionFactoryImpl.CloseRunnable - Class in org.hornetq.core.client.impl
-
- ClientSessionFactoryInternal - Interface in org.hornetq.core.client.impl
-
A ClientSessionFactoryInternal
- ClientSessionInternal - Interface in org.hornetq.core.client.impl
-
A ClientSessionInternal
- clientSessionNotClosed(Exception, int) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- clietSessionInternal() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- close(boolean) - Method in interface org.hornetq.api.core.BroadcastEndpoint
-
Close the endpoint.
- close() - Method in interface org.hornetq.api.core.client.ClientConsumer
-
Closes the consumer.
- close() - Method in interface org.hornetq.api.core.client.ClientProducer
-
Closes the ClientProducer.
- close() - Method in class org.hornetq.api.core.client.ClientRequestor
-
Closes the ClientRequestor and its session.
- close() - Method in interface org.hornetq.api.core.client.ClientSession
-
Closes the session.
- close() - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Closes this factory and any session created by it.
- close() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Closes this factory and release all its resources
- close() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- close() - Method in interface org.hornetq.core.client.impl.ClientProducerCreditManager
-
- close() - Method in class org.hornetq.core.client.impl.ClientProducerCreditManagerImpl
-
- close() - Method in interface org.hornetq.core.client.impl.ClientProducerCredits
-
- close() - Method in class org.hornetq.core.client.impl.ClientProducerCreditsImpl
-
- close() - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- close() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- close() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- close() - Method in interface org.hornetq.core.client.impl.LargeMessageController
-
Closes this buffer.
- close() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- close() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- close() - Method in interface org.hornetq.core.message.BodyEncoder
-
This method must not be called directly by HornetQ clients.
- close() - Method in interface org.hornetq.core.protocol.core.Channel
-
closes this channel.
- close() - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- close() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- close() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnector
-
- close() - Method in interface org.hornetq.spi.core.remoting.Connection
-
Closes the connection.
- close() - Method in interface org.hornetq.spi.core.remoting.Connector
-
closes the connector
- close() - Method in class org.hornetq.utils.HornetQBufferInputStream
-
- close() - Method in class org.hornetq.utils.InflaterWriter
-
- close() - Method in interface org.hornetq.utils.LinkedListIterator
-
- CLOSE_RUNNABLES - Static variable in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- closeConnectionsForAddress(String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Closes all the connections of clients connected to this server which matches the specified IP address.
- closeConnectionsForUser(String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Closes all the connections of sessions with a matching user name.
- closeConsumerConnectionsForAddress(String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Closes all the connections of clients connected to this server which matches the specified IP address.
- CloseListener - Interface in org.hornetq.core.remoting
-
CloseListeners can be registered with a
RemotingConnection
to get notified when the connection is closed.
- closeListenerCannotBeNull() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- closeStream() - Method in class org.hornetq.utils.DeflaterReader
-
- CLUSTER_CONNECTION - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- CLUSTER_TOPOLOGY - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- CLUSTER_TOPOLOGY_V2 - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- ClusterConnectionControl - Interface in org.hornetq.api.core.management
-
A ClusterConnectionControl is used to manage a cluster connection.
- ClusterTopologyChangeMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- ClusterTopologyChangeMessage(String, Pair<TransportConfiguration, TransportConfiguration>, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- ClusterTopologyChangeMessage(String) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- ClusterTopologyChangeMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- ClusterTopologyChangeMessage(byte) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- ClusterTopologyChangeMessage_V2 - Class in org.hornetq.core.protocol.core.impl.wireformat
-
Clebert Suconic
- ClusterTopologyChangeMessage_V2(long, String, String, Pair<TransportConfiguration, TransportConfiguration>, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage_V2
-
- ClusterTopologyChangeMessage_V2(long, String) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage_V2
-
- ClusterTopologyChangeMessage_V2() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage_V2
-
- ClusterTopologyListener - Interface in org.hornetq.api.core.client
-
A cluster topology listener.
- column - Variable in class org.hornetq.core.filter.impl.SimpleCharStream
-
- COMMA - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- CommandConfirmationHandler - Interface in org.hornetq.core.protocol.core
-
A CommandConfirmationHandler is used by the channel to confirm confirmations of packets.
- commandConfirmed(Packet) - Method in interface org.hornetq.core.protocol.core.CommandConfirmationHandler
-
called by channel after a confirmation has been received.
- commit() - Method in interface org.hornetq.api.core.client.ClientSession
-
Commits the current transaction.
- commit() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- commit(Xid, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- commitAfterFailover() - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- commitPreparedTransaction(String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Heuristically commits a prepared transaction.
- comparisonExpression() - Method in class org.hornetq.core.filter.impl.FilterParser
-
- compressedLargeMessageError(int, int) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- conditionalExpression() - Method in class org.hornetq.core.filter.impl.FilterParser
-
- configuration - Variable in class org.hornetq.spi.core.remoting.AbstractConnector
-
- ConfigurationHelper - Class in org.hornetq.utils
-
A ConfigurationHelper
- ConfigurationHelper() - Constructor for class org.hornetq.utils.ConfigurationHelper
-
- confirm(Packet) - Method in interface org.hornetq.core.protocol.core.Channel
-
sends a confirmation of a packet being received.
- confirm(Packet) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- connect(int, boolean) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- connect(int, boolean) - Method in interface org.hornetq.core.client.impl.ClientSessionFactoryInternal
-
- connect() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- connect() - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- connection - Variable in class org.hornetq.spi.core.protocol.ConnectionEntry
-
- Connection - Interface in org.hornetq.spi.core.remoting
-
The connection used by a channel to write data to.
- CONNECTION_TTL - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- connectionClosed() - Method in interface org.hornetq.core.remoting.CloseListener
-
called when the connection is closed
- connectionCreated(HornetQComponent, Connection, ProtocolType) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- connectionCreated(HornetQComponent, Connection, ProtocolType) - Method in interface org.hornetq.spi.core.remoting.ConnectionLifeCycleListener
-
This method is used both by client connector creation and server connection creation through
acceptors.
- connectionDestroyed() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- connectionDestroyed(Object) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- connectionDestroyed(Object) - Method in interface org.hornetq.spi.core.remoting.ConnectionLifeCycleListener
-
Called when a connection is destroyed.
- ConnectionEntry - Class in org.hornetq.spi.core.protocol
-
A ConnectionEntry
- ConnectionEntry(RemotingConnection, Executor, long, long) - Constructor for class org.hornetq.spi.core.protocol.ConnectionEntry
-
- connectionException(Object, HornetQException) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- connectionException(Object, HornetQException) - Method in interface org.hornetq.spi.core.remoting.ConnectionLifeCycleListener
-
Called when an error occurs on the connection.
- connectionExecutor - Variable in class org.hornetq.spi.core.protocol.ConnectionEntry
-
- connectionExists(Object) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- connectionFailed(HornetQException, boolean) - Method in interface org.hornetq.core.remoting.FailureListener
-
Notifies that a connection has failed due to the specified exception.
- connectionFailureDetected(String, HornetQExceptionType) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- ConnectionLifeCycleListener - Interface in org.hornetq.spi.core.remoting
-
A ConnectionLifeCycleListener is called by the remoting implementation to notify of connection events.
- ConnectionLoadBalancingPolicy - Interface in org.hornetq.api.core.client.loadbalance
-
A ConnectionLoadBalancingPolicy defines a policy to load balance between connections.
- connectionReadyForWrites(Object, boolean) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- connectionReadyForWrites(Object, boolean) - Method in interface org.hornetq.spi.core.remoting.ConnectionLifeCycleListener
-
- connectionTimedOut(Connection) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- connectionTimedOutInInitialBroadcast() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- connectionTimedOutOnReceiveTopology(DiscoveryGroup) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- connectNoWarnings() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- connectNoWarnings() - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- Connector - Interface in org.hornetq.spi.core.remoting
-
A Connector is used by the client for creating and controlling a connection.
- ConnectorFactory - Interface in org.hornetq.spi.core.remoting
-
A ConnectorFactory is used by the client for creating connectors.
- connectorsChanged(List<DiscoveryEntry>) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- connectorsChanged(List<DiscoveryEntry>) - Method in interface org.hornetq.core.cluster.DiscoveryListener
-
- consumerClosed() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- containsKey(Object) - Method in class org.hornetq.utils.SoftValueHashMap
-
- containsProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns true
if this message contains a property with the given key, false
else.
- containsProperty(String) - Method in interface org.hornetq.api.core.Message
-
- containsProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- containsProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- containsValue(Object) - Method in class org.hornetq.utils.SoftValueHashMap
-
- continues - Variable in class org.hornetq.core.protocol.core.impl.wireformat.SessionContinuationMessage
-
- copy() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- copy(int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- copyHeadersAndProperties(MessageInternal) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- CORE_ACCEPTOR - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CORE_ADDRESS - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CORE_BRIDGE - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CORE_BROADCAST_GROUP - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CORE_CLUSTER_CONNECTION - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CORE_DISCOVERY_GROUP - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CORE_DIVERT - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CORE_QUEUE - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CORE_SERVER - Static variable in class org.hornetq.api.core.management.ResourceNames
-
- CoreNotificationType - Enum in org.hornetq.api.core.management
-
This enum defines all core notification types
- CoreRemotingConnection - Interface in org.hornetq.core.protocol.core
-
Extension of RemotingConnection for the HornetQ core protocol
- countMessages(String) - Method in interface org.hornetq.api.core.management.QueueControl
-
Counts the number of messages in this queue matching the specified filter.
- create(String) - Static method in class org.hornetq.api.core.management.ObjectNameBuilder
-
- CREATE_QUEUE - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- createBody(int) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- createBridge(String, String, String, String, String, long, double, int, boolean, int, long, String, boolean, boolean, String, String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
- createBroadcastEndpoint() - Method in interface org.hornetq.api.core.BroadcastEndpointFactory
-
- createBroadcastEndpointFactory() - Method in interface org.hornetq.api.core.BroadcastEndpointFactoryConfiguration
-
- createBroadcastEndpointFactory() - Method in class org.hornetq.api.core.JGroupsBroadcastGroupConfiguration
-
- createBroadcastEndpointFactory() - Method in class org.hornetq.api.core.UDPBroadcastGroupConfiguration
-
- createBuffer(int) - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- createBuffer(int) - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- createBuffer(int) - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
creates a new HornetQBuffer of the specified size.
- createBuffer(int) - Method in interface org.hornetq.spi.core.remoting.Connection
-
Create a new HornetQBuffer of the given size.
- createConnection() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnector
-
- createConnection() - Method in interface org.hornetq.spi.core.remoting.Connector
-
Create and return a connection from this connector.
- createConnector(Map<String, Object>, BufferHandler, ConnectionLifeCycleListener, Executor, Executor, ScheduledExecutorService) - Method in class org.hornetq.core.remoting.impl.netty.NettyConnectorFactory
-
- createConnector(Map<String, Object>, BufferHandler, ConnectionLifeCycleListener, Executor, Executor, ScheduledExecutorService) - Method in interface org.hornetq.spi.core.remoting.ConnectorFactory
-
creates a new instance of a connector.
- createConnectorException(Exception) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- createConsumer(SimpleString) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume message from the queue with the given name.
- createConsumer(String) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume messages from the queue with the given name.
- createConsumer(SimpleString, SimpleString) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume messages matching the filter from the queue with the given name.
- createConsumer(String, String) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume messages matching the filter from the queue with the given name.
- createConsumer(SimpleString, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages from the queue with the given name.
- createConsumer(String, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages from the queue with the given name.
- createConsumer(String, String, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
- createConsumer(SimpleString, SimpleString, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
- createConsumer(SimpleString, SimpleString, int, int, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
- createConsumer(String, String, int, int, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientConsumer to consume or browse messages matching the filter from the queue with
the given name.
- createConsumer(SimpleString, SimpleString, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(SimpleString, SimpleString, int, int, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(SimpleString, SimpleString) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(SimpleString) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(String, String, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(String, String, int, int, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(String, String) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(String) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(SimpleString, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createConsumer(String, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createContext(String, String, String, String, String, String) - Static method in class org.hornetq.core.remoting.impl.ssl.SSLSupport
-
- createContext(Context, String) - Static method in class org.hornetq.utils.JNDIUtil
-
Create a context path recursively.
- createDivert(String, String, String, String, boolean, String, String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
- createMessage(boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientMessage.
- createMessage(byte, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientMessage.
- createMessage(byte, boolean, long, long, byte) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a ClientMessage.
- createMessage(boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createMessage(byte, boolean, long, long, byte) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createMessage(byte, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createObject() - Method in interface org.hornetq.utils.MemorySize.ObjectFactory
-
- createProducer() - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a producer with no default address.
- createProducer(SimpleString) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a producer which sends messages to the given address
- createProducer(String) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a producer which sends messages to the given address
- createProducer(SimpleString, int) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a producer which sends messages to the given address
- createProducer() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createProducer(SimpleString, int) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createProducer(SimpleString) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createProducer(String) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createQueue(SimpleString, SimpleString, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a non-temporary queue.
- createQueue(String, String, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a non-temporary queue.
- createQueue(String, String) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a non-temporary queue non-durable queue.
- createQueue(SimpleString, SimpleString) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a non-temporary queue non-durable queue.
- createQueue(SimpleString, SimpleString, SimpleString, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a non-temporary queue.
- createQueue(String, String, String, boolean) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a non-temporaryqueue.
- createQueue(String, String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Create a durable queue.
- createQueue(String, String, String, boolean) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Create a queue.
- createQueue(String, String, boolean) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Create a queue.
- createQueue(String, String) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createQueue(SimpleString, SimpleString) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createQueue(SimpleString, SimpleString, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createQueue(SimpleString, SimpleString, SimpleString, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createQueue(String, String, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createQueue(String, String, String, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- CreateQueueMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- CreateQueueMessage(SimpleString, SimpleString, SimpleString, boolean, boolean, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- CreateQueueMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- createSecurity(String, String, String, String, String, String, String) - Static method in class org.hornetq.utils.SecurityFormatter
-
- createServerLocator(boolean, TransportConfiguration...) - Static method in class org.hornetq.api.core.client.HornetQClient
-
Create a ServerLocator which creates session factories using a static list of transportConfigurations, the ServerLocator is not updated automatically
as the cluster topology changes, and no HA backup information is propagated to the client
- createServerLocator(boolean, DiscoveryGroupConfiguration) - Static method in class org.hornetq.api.core.client.HornetQClient
-
Create a ServerLocator which creates session factories from a set of live servers, no HA
backup information is propagated to the client The UDP address and port are used to listen for
live servers in the cluster
- createServerLocatorWithHA(TransportConfiguration...) - Static method in class org.hornetq.api.core.client.HornetQClient
-
Create a ServerLocator which will receive cluster topology updates from the cluster as servers
leave or join and new backups are appointed or removed.
- createServerLocatorWithHA(DiscoveryGroupConfiguration) - Static method in class org.hornetq.api.core.client.HornetQClient
-
Create a ServerLocator which will receive cluster topology updates from the cluster as servers
leave or join and new backups are appointed or removed.
- createServerLocatorWithoutHA(TransportConfiguration...) - Static method in class org.hornetq.api.core.client.HornetQClient
-
Create a ServerLocator which creates session factories using a static list of transportConfigurations, the ServerLocator is not updated automatically
as the cluster topology changes, and no HA backup information is propagated to the client
- createServerLocatorWithoutHA(DiscoveryGroupConfiguration) - Static method in class org.hornetq.api.core.client.HornetQClient
-
Create a ServerLocator which creates session factories from a set of live servers, no HA
backup information is propagated to the client
- createSession() - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Creates a non-transacted session.
- createSession(boolean, boolean) - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Creates a session.
- createSession(boolean, boolean, int) - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Creates a session.
- createSession(boolean, boolean, boolean) - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Creates a session.
- createSession(boolean, boolean, boolean, boolean) - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Creates a session.
- createSession(String, String, boolean, boolean, boolean, boolean, int) - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Creates an authenticated session.
- createSession(String, String, boolean, boolean, boolean, boolean, int) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- createSession(boolean, boolean, int) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- createSession() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- createSession(boolean, boolean) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- createSession(boolean, boolean, boolean) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- createSession(boolean, boolean, boolean, boolean) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- CREATESESSION - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- CREATESESSION_RESP - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- createSessionFactory() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Creates a ClientSessionFactory using whatever load balancing policy is in force
- createSessionFactory(String) - Method in interface org.hornetq.api.core.client.ServerLocator
-
- createSessionFactory(TransportConfiguration) - Method in interface org.hornetq.api.core.client.ServerLocator
-
- createSessionFactory(TransportConfiguration, int, boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
- createSessionFactory(String) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- createSessionFactory(TransportConfiguration) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- createSessionFactory(TransportConfiguration, int, boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- createSessionFactory() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- CreateSessionMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- CreateSessionMessage(String, long, int, String, String, int, boolean, boolean, boolean, boolean, int, String) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- CreateSessionMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- CreateSessionResponseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- CreateSessionResponseMessage(int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionResponseMessage
-
- CreateSessionResponseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionResponseMessage
-
- createTemporaryQueue(SimpleString, SimpleString) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a temporary queue.
- createTemporaryQueue(String, String) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a temporary queue.
- createTemporaryQueue(SimpleString, SimpleString, SimpleString) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a temporary queue with a filter.
- createTemporaryQueue(String, String, String) - Method in interface org.hornetq.api.core.client.ClientSession
-
Creates a temporary queue with a filter.
- createTemporaryQueue(SimpleString, SimpleString, SimpleString) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createTemporaryQueue(SimpleString, SimpleString) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createTemporaryQueue(String, String, String) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createTemporaryQueue(String, String) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- createTransactedSession() - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Creates a transacted session.
- createTransactedSession() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- createXASession() - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Creates a session with XA transaction semantics.
- createXASession() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- creatingNewSession(long) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- creditsMapSize() - Method in interface org.hornetq.core.client.impl.ClientProducerCreditManager
-
- creditsMapSize() - Method in class org.hornetq.core.client.impl.ClientProducerCreditManagerImpl
-
- curChar - Variable in class org.hornetq.core.filter.impl.FilterParserTokenManager
-
- currentToken - Variable in exception org.hornetq.core.filter.impl.ParseException
-
This is the last token that has been consumed successfully.
- GE - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- GE - Static variable in class org.hornetq.core.filter.impl.Operator
-
- generateChannelID() - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
generate a unique (within this connection) channel id
- generateChannelID() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- generateID() - Method in interface org.hornetq.utils.IDGenerator
-
- generateID() - Method in class org.hornetq.utils.SimpleIDGenerator
-
- generateID() - Method in class org.hornetq.utils.TimeAndCounterIDGenerator
-
- generateParseException() - Method in class org.hornetq.core.filter.impl.FilterParser
-
Generate ParseException.
- get(int) - Method in class org.hornetq.utils.json.JSONArray
-
Get the object value associated with an index.
- get(String) - Method in class org.hornetq.utils.json.JSONObject
-
Get the value object associated with a key.
- get(Object) - Method in class org.hornetq.utils.SoftValueHashMap
-
- getAcceptorObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by AcceptorControl.
- getAckBatchSize() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the acknowledgments batch size.
- getAckBatchSize() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getAddress() - Method in interface org.hornetq.api.core.client.ClientProducer
-
Returns the address where messages will be sent.
- getAddress() - Method in interface org.hornetq.api.core.client.ClientSession.QueueQuery
-
Returns the address that the queue is bound to.
- getAddress() - Method in interface org.hornetq.api.core.management.AddressControl
-
Returns the managed address.
- getAddress() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns the address used by this cluster connection.
- getAddress() - Method in interface org.hornetq.api.core.management.DivertControl
-
Returns the origin address used by this divert.
- getAddress() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the address this queue is bound to.
- getAddress() - Method in interface org.hornetq.api.core.Message
-
Returns the address this message is sent to.
- getAddress() - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- getAddress() - Method in class org.hornetq.core.message.impl.MessageImpl
-
this doesn't need to be synchronized as setAddress is protecting the buffer,
not the address
- getAddress() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- getAddress() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionBindingQueryMessage
-
- getAddress() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionProducerCreditsFailMessage
-
- getAddress() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionProducerCreditsMessage
-
- getAddress() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- getAddress() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionRequestProducerCreditsMessage
-
- getAddress() - Method in class org.hornetq.core.server.QueueQueryResult
-
- getAddressFullMessagePolicy() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getAddressNames() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the addresses created on this server.
- getAddressObjectName(SimpleString) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by AddressControl.
- getAddressSettingsAsJSON(String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
returns the address settings as a JSON string
- getAfterConnectInternalListener() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getAfterConnectInternalListener() - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- getAllowableProperties() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnectorFactory
-
- getAllowableProperties() - Method in interface org.hornetq.spi.core.remoting.ConnectorFactory
-
Returns the allowable properties for this connector.
- getBackup() - Method in interface org.hornetq.api.core.client.TopologyMember
-
Returns the TransportConfiguration relative to the backup server if any.
- getBackup() - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- getBackupConnector() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- getBackupConnector() - Method in interface org.hornetq.core.client.impl.ClientSessionFactoryInternal
-
- getBackupConnector() - Method in class org.hornetq.core.protocol.core.impl.wireformat.NodeAnnounceMessage
-
- getBackupForConnector(Connector) - Method in class org.hornetq.core.client.impl.Topology
-
- getBackupGroupName() - Method in interface org.hornetq.api.core.client.TopologyMember
-
Returns the backup-group-name
of the live server and backup servers associated with
Topology entry.
- getBackupGroupName() - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- getBalance() - Method in class org.hornetq.core.client.impl.ClientProducerCreditsImpl
-
- getBeginColumn() - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
Get token beginning column number.
- getBeginLine() - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
Get token beginning line number.
- getBindingNames() - Method in interface org.hornetq.api.core.management.AddressControl
-
Returns the names of all bindings (both queues and diverts) bound to this address
- getBindingsDirectory() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the file system directory used to store bindings.
- getBlockingCallFailoverTimeout() - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
Returns the current timeout for blocking calls
- getBlockingCallFailoverTimeout() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getBlockingCallTimeout() - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
Returns the current timeout for blocking calls
- getBlockingCallTimeout() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getBody() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionContinuationMessage
-
- getBodyBuffer() - Method in interface org.hornetq.api.core.Message
-
Returns the message body as a HornetQBuffer
- getBodyBuffer() - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- getBodyBuffer() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getBodyBufferCopy() - Method in interface org.hornetq.api.core.Message
-
Returns a copy of the message body as a HornetQBuffer.
- getBodyBufferCopy() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getBodyEncoder() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- getBodyEncoder() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getBodyEncoder() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- getBodyInputStream() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- getBodyInputStream() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- getBodySize() - Method in interface org.hornetq.api.core.client.ClientMessage
-
Return the size (in bytes) of this message's body
- getBodySize() - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- getBodySize() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- getBoolean(int) - Method in class org.hornetq.utils.json.JSONArray
-
Get the boolean value associated with an index.
- getBoolean(String) - Method in class org.hornetq.utils.json.JSONObject
-
Get the boolean value associated with a key.
- getBooleanProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a Boolean.
- getBooleanProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getBooleanProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getBooleanProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getBooleanProperty(String, boolean, Map<String, Object>) - Static method in class org.hornetq.utils.ConfigurationHelper
-
- getBootStrap() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnector
-
- getBranchQualifier() - Method in class org.hornetq.core.transaction.impl.XidImpl
-
- getBridgeNames() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
- getBridgeObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by BridgeControl.
- getBroadcastEndpointFactoryConfiguration() - Method in class org.hornetq.api.core.DiscoveryGroupConfiguration
-
- getBroadcastGroupObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by BroadcastGroupControl.
- getBroadcastPeriod() - Method in class org.hornetq.api.core.BroadcastGroupConfiguration
-
- getBroadcastPeriod() - Method in interface org.hornetq.api.core.management.BroadcastGroupControl
-
Returns the period used by this broadcast group.
- getBufferSize() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- getBufferSize() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- getByte(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getByteProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a Byte.
- getByteProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getByteProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getByteProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getBytes(int, HornetQBuffer, int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(int, byte[], int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(long, byte[], int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(int, ByteBuffer) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(long, ByteBuffer) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(int, OutputStream, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(long, OutputStream, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(int, GatheringByteChannel, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(int, byte[]) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(long, byte[]) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(int, HornetQBuffer) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytes(int, HornetQBuffer, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getBytesProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a byte[].
- getBytesProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getBytesProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getBytesProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getCallFailoverTimeout() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the blocking calls failover timeout when the client is awaiting failover,
this is over and above the normal call timeout.
- getCallFailoverTimeout() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getCallTimeout() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the blocking calls timeout.
- getCallTimeout() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getCause() - Method in exception org.hornetq.utils.json.JSONException
-
- getChannel() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- getChannel() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getChannel(long, int) - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
Returns the channel with the channel id specified.
- getChannel(long, int) - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getChannelID() - Method in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- getChannelID() - Method in interface org.hornetq.core.protocol.core.Packet
-
Returns the channel id of the channel that should handle this packet.
- getChar(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getClasspathString() - Static method in class org.hornetq.utils.VersionLoader
-
- getClientFailureCheckPeriod() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the period used to check if a client has failed to receive pings from the server.
- getClientFailureCheckPeriod() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getClientID() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getClientVersion() - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
The client protocol used on the communication.
- getClientVersion() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getClientVersion() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessageV2
-
- getClientVersions() - Static method in class org.hornetq.utils.VersionLoader
-
- getClientWindowSize() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- getClientWindowSize() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- getClusterConnectionObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by ClusterConnectionControl.
- getClusterTransportConfiguration() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getClusterTransportConfiguration() - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- getColumn() - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
Deprecated.
- getCommandID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.PacketsConfirmedMessage
-
- getConfirmationWindowSize() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the size for the confirmation window of clients using this factory.
- getConfirmationWindowSize() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getConfirmationWindowSize() - Method in interface org.hornetq.core.protocol.core.Channel
-
returns the confirmation window size this channel is using.
- getConfirmationWindowSize() - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- getConnection() - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
Returns the code connection used by this session factory.
- getConnection() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- getConnection() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- getConnection() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getConnection() - Method in interface org.hornetq.core.protocol.core.Channel
-
- getConnection() - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- getConnectionCount() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the number of connections connected to this server.
- getConnectionFactoryObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by ConnectionFactoryControl.
- getConnectionLoadBalancingPolicyClassName() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the class name of the connection load balancing policy.
- getConnectionLoadBalancingPolicyClassName() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getConnectionTTL() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the connection time-to-live.
- getConnectionTTL() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getConnectionTTL() - Method in class org.hornetq.core.protocol.core.impl.wireformat.Ping
-
- getConnectionTTLOverride() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the connection time to live.
- getConnector() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- getConnector() - Method in interface org.hornetq.core.client.impl.ClientSessionFactoryInternal
-
- getConnector() - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- getConnector() - Method in class org.hornetq.core.cluster.DiscoveryEntry
-
- getConnector() - Method in class org.hornetq.core.protocol.core.impl.wireformat.NodeAnnounceMessage
-
- getConnectorConfig() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- getConnectorConfig() - Method in interface org.hornetq.spi.core.remoting.Connection
-
- getConnectorConfiguration() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- getConnectorConfiguration() - Method in interface org.hornetq.core.client.impl.ClientSessionFactoryInternal
-
- getConnectorInfos() - Method in class org.hornetq.api.core.BroadcastGroupConfiguration
-
- getConnectorPairs() - Method in interface org.hornetq.api.core.management.BroadcastGroupControl
-
Returns the pairs of live-backup connectors that are broadcasted by this broadcast group.
- getConnectorPairsAsJSON() - Method in interface org.hornetq.api.core.management.BroadcastGroupControl
-
Returns the pairs of live-backup connectors that are broadcasted by this broadcast group
using JSON serialization.
- getConnectors() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the connectors configured for this server.
- getConnectorsAsJSON() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the connectors configured for this server using JSON serialization.
- getConsumerCount() - Method in interface org.hornetq.api.core.client.ClientSession.QueueQuery
-
Returns the number of consumers attached to the queue.
- getConsumerCount() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the number of consumers consuming messages from this queue.
- getConsumerCount() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- getConsumerCount() - Method in class org.hornetq.core.server.QueueQueryResult
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAcknowledgeMessage
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionConsumerCloseMessage
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionConsumerFlowCreditMessage
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionExpireMessage
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionForceConsumerDelivery
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionIndividualAcknowledgeMessage
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveContinuationMessage
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveLargeMessage
-
- getConsumerID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveMessage
-
- getConsumerMaxRate() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the maximum rate of message consumption for consumers created through this factory.
- getConsumerMaxRate() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getConsumerWindowSize() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the window size for flow control of the consumers created through this factory.
- getConsumerWindowSize() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getCounters() - Method in class org.hornetq.api.core.management.DayCounterInfo
-
Returns a 24-length array corresponding to the number of messages added to the queue
for the given hour of the day.
- getCreationTime() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getCreationTime() - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
- getCredits(SimpleString, boolean) - Method in interface org.hornetq.core.client.impl.ClientProducerCreditManager
-
- getCredits(SimpleString, boolean) - Method in class org.hornetq.core.client.impl.ClientProducerCreditManagerImpl
-
- getCredits(SimpleString, boolean) - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- getCredits(SimpleString, boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getCredits() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionConsumerFlowCreditMessage
-
- getCredits() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionProducerCreditsFailMessage
-
- getCredits() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionProducerCreditsMessage
-
- getCredits() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionRequestProducerCreditsMessage
-
- getCurrentEventID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.NodeAnnounceMessage
-
- getCurrentID() - Method in interface org.hornetq.utils.IDGenerator
-
- getCurrentID() - Method in class org.hornetq.utils.SimpleIDGenerator
-
- getCurrentID() - Method in class org.hornetq.utils.TimeAndCounterIDGenerator
-
- getData() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessage
-
- getData() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessageV2
-
- getDate() - Method in class org.hornetq.api.core.management.DayCounterInfo
-
Returns the date of the counter.
- getDeadLetterAddress() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getDeadLetterAddress() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the dead-letter address associated to this queue.
- getDefaultAddress() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- getDefaultBindingsDirectory() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultBridgeConnectSameNode() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultBridgeReconnectAttempts() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultBroadcastPeriod() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultBroadcastRefreshTimeout() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClientFailureCheckPeriod() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterConnectionTtl() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterFailureCheckPeriod() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterMaxHops() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterMaxRetryInterval() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterNotificationAttempts() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterNotificationInterval() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterPassword() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterReconnectAttempts() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterRetryInterval() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterRetryIntervalMultiplier() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultClusterUser() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultConnectionTtl() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultConnectionTtlOverride() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultFailbackDelay() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultFileDeployerScanPeriod() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultGroupTimeout() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultHornetQPrincipal() - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
Returns the default security principal
- getDefaultHornetQPrincipal() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getDefaultHornetQPrincipal() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- getDefaultHornetQPrincipal() - Method in interface org.hornetq.spi.core.remoting.Connection
-
- getDefaultIdCacheSize() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJmxDomain() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalBufferSizeAio() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalBufferSizeNio() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalBufferTimeoutAio() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalBufferTimeoutNio() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalCompactMinFiles() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalCompactPercentage() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalDir() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalFileSize() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalMaxIoAio() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalMaxIoNio() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalMinFiles() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultJournalPerfBlastPages() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultLargeMessagesDir() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultManagementAddress() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultManagementNotificationAddress() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMaxConcurrentPageIo() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMaxRetryInterval() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMaxSavedReplicatedJournalsSize() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMemoryMeasureInterval() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMemoryWarningThreshold() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMessageCounterMaxDayHistory() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMessageCounterSamplePeriod() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMessageExpiryScanPeriod() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultMessageExpiryThreadPriority() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultPagingDir() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultRetryIntervalMultiplier() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultScheduledThreadPoolMaxSize() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultSecurityInvalidationInterval() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultServerDumpInterval() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultThreadPoolMaxSize() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultTransactionTimeout() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDefaultTransactionTimeoutScanPeriod() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getDeliveringCount() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the number of messages that this queue is currently delivering to its consumers.
- getDeliveryCount() - Method in interface org.hornetq.api.core.client.ClientMessage
-
Returns the number of times this message was delivered.
- getDeliveryCount() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- getDeliveryCount() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveLargeMessage
-
- getDeliveryCount() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveMessage
-
- getDiscoveryEntries() - Method in class org.hornetq.core.cluster.DiscoveryGroup
-
- getDiscoveryGroupConfiguration() - Method in interface org.hornetq.api.core.client.ServerLocator
-
The discovery group configuration
- getDiscoveryGroupConfiguration() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getDiscoveryGroupName() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns the name of the discovery group used by this bridge.
- getDiscoveryGroupName() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns the name of the discovery group used by this cluster connection.
- getDiscoveryGroupObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by DiscoveryGroupControl.
- getDiscoveryInitialWaitTimeout() - Method in class org.hornetq.api.core.DiscoveryGroupConfiguration
-
- getDivertNames() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
- getDivertObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by DivertControl.
- getDouble(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getDouble(int) - Method in class org.hornetq.utils.json.JSONArray
-
Get the double value associated with an index.
- getDouble(String) - Method in class org.hornetq.utils.json.JSONObject
-
Get the double value associated with a key.
- getDoubleProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a Double.
- getDoubleProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getDoubleProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getDoubleProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getEncodedBuffer() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getEncodedBuffer() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- getEncodeSize() - Method in interface org.hornetq.api.core.Message
-
Returns the size of the encoded message.
- getEncodeSize() - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- getEncodeSize() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getEndColumn() - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
Get token end column number.
- getEndLine() - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
Get token end line number.
- getEndOfBodyPosition() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getEndOfBodyPosition() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- getEndOfMessagePosition() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getEndOfMessagePosition() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- getEndpointFactoryConfiguration() - Method in class org.hornetq.api.core.BroadcastGroupConfiguration
-
- getException() - Method in class org.hornetq.core.protocol.core.impl.wireformat.HornetQExceptionMessage
-
- getExecutor() - Method in interface org.hornetq.utils.ExecutorFactory
-
- getExecutor() - Method in class org.hornetq.utils.OrderedExecutorFactory
-
Get an executor that always executes tasks in order.
- getExpiration() - Method in interface org.hornetq.api.core.Message
-
Returns the expiration time of this message.
- getExpiration() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getExpiryAddress() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getExpiryAddress() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the expiry address associated to this queue.
- getFactoryClassName() - Method in interface org.hornetq.api.core.management.AcceptorControl
-
Returns the class name of the AcceptorFactory implementation
used by this acceptor.
- getFactoryClassName() - Method in class org.hornetq.api.core.TransportConfiguration
-
Returns the class name of ConnectorFactory being used by this TransportConfiguration
- getFailureListeners() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getFailureListeners() - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
return all the failure listeners
- getFilter() - Method in interface org.hornetq.api.core.management.DivertControl
-
Returns the filter used by this divert.
- getFilter() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the filter associated to this queue.
- getFilterString() - Method in interface org.hornetq.api.core.client.ClientSession.QueueQuery
-
Returns the queue's filter string (or null
if the queue has no filter).
- getFilterString() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns the filter string associated to this bridge.
- getFilterString() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- getFilterString() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- getFilterString() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- getFilterString() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- getFilterString() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- getFilterString() - Method in class org.hornetq.core.server.QueueQueryResult
-
- getFloat(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getFloatProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a Float.
- getFloatProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getFloatProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getFloatProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getFlowControlSize() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- getFlowControlSize() - Method in interface org.hornetq.core.client.impl.ClientMessageInternal
-
Size used for FlowControl
- getFormatId() - Method in class org.hornetq.core.transaction.impl.XidImpl
-
- getForwardingAddress() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns the address this bridge will forward messages to.
- getForwardingAddress() - Method in interface org.hornetq.api.core.management.DivertControl
-
Returns the forwarding address used by this divert.
- getFullVersion() - Method in class org.hornetq.core.version.impl.VersionImpl
-
- getFullVersion() - Method in interface org.hornetq.core.version.Version
-
- getGlobalTransactionId() - Method in class org.hornetq.core.transaction.impl.XidImpl
-
- getGroupAddress() - Method in interface org.hornetq.api.core.DiscoveryGroupConfigurationCompatibilityHelper
-
- getGroupAddress() - Method in class org.hornetq.api.core.JGroupsBroadcastGroupConfiguration
-
- getGroupAddress() - Method in interface org.hornetq.api.core.management.BroadcastGroupControl
-
Returns the address this broadcast group is broadcasting to.
- getGroupAddress() - Method in class org.hornetq.api.core.UDPBroadcastGroupConfiguration
-
- getGroupID() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the group ID that will be eventually set on each message for the property
Message.HDR_GROUP_ID
.
- getGroupID() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getGroupPort() - Method in interface org.hornetq.api.core.DiscoveryGroupConfigurationCompatibilityHelper
-
- getGroupPort() - Method in class org.hornetq.api.core.JGroupsBroadcastGroupConfiguration
-
- getGroupPort() - Method in interface org.hornetq.api.core.management.BroadcastGroupControl
-
Returns the port this broadcast group is broadcasting to.
- getGroupPort() - Method in class org.hornetq.api.core.UDPBroadcastGroupConfiguration
-
- getHandler() - Method in interface org.hornetq.core.protocol.core.Channel
-
Gets the
ChannelHandler
that this channel should
forward received packets to.
- getHandler() - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- getHeadersAndPropertiesEncodeSize() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getHeadersAndPropertiesEncodeSize() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- getHornetQServerObjectName() - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
- getID() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns this queue ID.
- getID() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- getID() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- getID() - Method in interface org.hornetq.core.protocol.core.Channel
-
returns the id of this channel.
- getID() - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- getID() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- getID() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- getID() - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
- getID() - Method in interface org.hornetq.spi.core.remoting.Connection
-
returns the unique id of this wire.
- getIDCacheSize() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the size of the cache for pre-creating message IDs.
- getIDGeneratorSequence() - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
Returns the next id to be chosen.
- getIDGeneratorSequence() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- GetImage() - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
Get token literal value.
- getIncomingInterceptorClassNames() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the list of interceptors used by this server for incoming messages.
- getIncrementingVersion() - Method in class org.hornetq.core.version.impl.VersionImpl
-
- getIncrementingVersion() - Method in interface org.hornetq.core.version.Version
-
- getInitialConnectAttempts() - Method in interface org.hornetq.api.core.client.ServerLocator
-
- getInitialConnectAttempts() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getInitialMessagePacketSize() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the initial size of messages created through this factory.
- getInitialMessagePacketSize() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getInt(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getInt(long) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getInt(int) - Method in class org.hornetq.utils.json.JSONArray
-
Get the int value associated with an index.
- getInt(String) - Method in class org.hornetq.utils.json.JSONObject
-
Get the int value associated with a key.
- getInterceptorClassNames() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
- getInternalTimeMark() - Method in class org.hornetq.utils.TimeAndCounterIDGenerator
-
- getIntProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as an Integer.
- getIntProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getIntProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getIntProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getIntProperty(String, int, Map<String, Object>) - Static method in class org.hornetq.utils.ConfigurationHelper
-
- getJMSQueueObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by JMSQueueControl.
- getJMSServerObjectName() - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by JMSServerControl.
- getJMSTopicObjectName(String) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by TopicControl.
- getJournalBufferSize() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the size of the internal buffer on the journal.
- getJournalBufferTimeout() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the timeout (in nanoseconds) used to flush internal buffers on the journal.
- getJournalCompactMinFiles() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the minimal number of journal files before compacting.
- getJournalCompactPercentage() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Return the percentage of live data before compacting the journal.
- getJournalDirectory() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the file system directory used to store journal log.
- getJournalFileSize() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the size (in bytes) of each journal files.
- getJournalMaxIO() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the maximum number of write requests that can be in the AIO queue at any given time.
- getJournalMinFiles() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the number of journal files to pre-create.
- getJournalType() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the type of journal used by this server (either NIO
or ASYNCIO
).
- getJSONArray(int) - Method in class org.hornetq.utils.json.JSONArray
-
Get the JSONArray associated with an index.
- getJSONArray(String) - Method in class org.hornetq.utils.json.JSONObject
-
Get the JSONArray value associated with a key.
- getJSONObject(int) - Method in class org.hornetq.utils.json.JSONArray
-
Get the JSONObject associated with an index.
- getJSONObject(String) - Method in class org.hornetq.utils.json.JSONObject
-
Get the JSONObject value associated with a key.
- getKey() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessage
-
- getKey() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessageV2
-
- getLargeBodySize() - Method in interface org.hornetq.core.message.BodyEncoder
-
This method must not be called directly by HornetQ clients.
- getLargeMessage() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveLargeMessage
-
- getLargeMessage() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionSendLargeMessage
-
- getLargeMessageController() - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- getLargeMessageController() - Method in interface org.hornetq.core.client.impl.ClientLargeMessageInternal
-
- getLargeMessagesDirectory() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the file system directory used to store large messages.
- getLargeMessageSize() - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- getLargeMessageSize() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveLargeMessage
-
- getLastConfirmedCommandID() - Method in interface org.hornetq.core.protocol.core.Channel
-
returns the last confirmed packet command id
- getLastConfirmedCommandID() - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- getLastConfirmedCommandID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ReattachSessionMessage
-
- getLastConfirmedCommandID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ReattachSessionResponseMessage
-
- getLastException() - Method in interface org.hornetq.api.core.client.ClientConsumer
-
Returns the last exception thrown by a call to this consumer's MessageHandler.
- getLastException() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- getLastUpdate() - Method in class org.hornetq.core.cluster.DiscoveryEntry
-
- getLine() - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
Deprecated.
- getLive() - Method in interface org.hornetq.api.core.client.TopologyMember
-
- getLive() - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- getLocalBindAddress() - Method in interface org.hornetq.api.core.DiscoveryGroupConfigurationCompatibilityHelper
-
- getLocalBindAddress() - Method in class org.hornetq.api.core.JGroupsBroadcastGroupConfiguration
-
- getLocalBindAddress() - Method in class org.hornetq.api.core.UDPBroadcastGroupConfiguration
-
- getLocalBindPort() - Method in interface org.hornetq.api.core.DiscoveryGroupConfigurationCompatibilityHelper
-
- getLocalBindPort() - Method in class org.hornetq.api.core.JGroupsBroadcastGroupConfiguration
-
- getLocalBindPort() - Method in interface org.hornetq.api.core.management.BroadcastGroupControl
-
Returns the local port this broadcast group is bound to.
- getLocalBindPort() - Method in class org.hornetq.api.core.UDPBroadcastGroupConfiguration
-
- getLock() - Method in interface org.hornetq.core.protocol.core.Channel
-
returns the channel lock
- getLock() - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- getLong(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getLong(long) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getLong(int) - Method in class org.hornetq.utils.json.JSONArray
-
Get the long value associated with an index.
- getLong(String) - Method in class org.hornetq.utils.json.JSONObject
-
Get the long value associated with a key.
- getLongProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a Long.
- getLongProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getLongProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getLongProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getLongProperty(String, long, Map<String, Object>) - Static method in class org.hornetq.utils.ConfigurationHelper
-
- getMajorVersion() - Method in class org.hornetq.core.version.impl.VersionImpl
-
- getMajorVersion() - Method in interface org.hornetq.core.version.Version
-
- getManagementAddress() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the management address of this server.
- getManagementNotificationAddress() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the management notification address of this server.
- getMaxDeliveryAttempts() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getMaxEelements() - Method in class org.hornetq.utils.SoftValueHashMap
-
- getMaxHops() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns the maximum number of hops used by this cluster connection.
- getMaxRate() - Method in interface org.hornetq.api.core.client.ClientProducer
-
Returns the maximum rate at which a ClientProducer can send messages per second.
- getMaxRate() - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- getMaxRedeliveryDelay() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getMaxRetryInterval() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the maximum retry interval (in the case a retry interval multiplier has been specified).
- getMaxRetryInterval() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getMaxSizeBytes() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getMedium(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getMember(String) - Method in class org.hornetq.core.client.impl.Topology
-
- getMember(TransportConfiguration) - Method in class org.hornetq.core.client.impl.Topology
-
- getMembers() - Method in class org.hornetq.core.client.impl.Topology
-
- getMessage() - Method in error org.hornetq.core.filter.impl.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMessage() - Method in class org.hornetq.core.protocol.core.impl.wireformat.MessagePacket
-
- getMessage() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionSendContinuationMessage
-
- getMessage() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResponseMessage
-
- getMessageBodySize() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionSendContinuationMessage
-
- getMessageCount() - Method in interface org.hornetq.api.core.client.ClientSession.QueueQuery
-
Returns the number of messages in the queue.
- getMessageCount() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the number of messages currently in this queue.
- getMessageCount() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- getMessageCount() - Method in class org.hornetq.core.server.QueueQueryResult
-
- getMessageCounterMaxDayCount() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the maximum number of days kept in memory for message counter.
- getMessageCounterSamplePeriod() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the sample period (in milliseconds) to take message counter snapshot.
- getMessageExpiryScanPeriod() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the frequency (in milliseconds) to scan messages to detect which messages
have expired.
- getMessageExpiryThreadPriority() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the priority of the thread used to scan message expiration.
- getMessageHandler() - Method in interface org.hornetq.api.core.client.ClientConsumer
-
Returns the MessageHandler associated to this consumer.
- getMessageHandler() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- getMessageID() - Method in interface org.hornetq.api.core.Message
-
Returns the messageID.
- getMessageID() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getMessageID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAcknowledgeMessage
-
- getMessageID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionExpireMessage
-
- getMessageID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionIndividualAcknowledgeMessage
-
- getMessagesAdded() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the number of messages added to this queue since it was created.
- getMicroVersion() - Method in class org.hornetq.core.version.impl.VersionImpl
-
- getMicroVersion() - Method in interface org.hornetq.core.version.Version
-
- getMinLargeMessageSize() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the large message size threshold.
- getMinLargeMessageSize() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- getMinLargeMessageSize() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getMinLargeMessageSize() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getMinLargeMessageSize() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- getMinorVersion() - Method in class org.hornetq.core.version.impl.VersionImpl
-
- getMinorVersion() - Method in interface org.hornetq.core.version.Version
-
- getName() - Method in class org.hornetq.api.core.BroadcastGroupConfiguration
-
- getName() - Method in class org.hornetq.api.core.DiscoveryGroupConfiguration
-
- getName() - Method in interface org.hornetq.api.core.management.AcceptorControl
-
Returns the name of the acceptor
- getName() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns the name of this bridge
- getName() - Method in interface org.hornetq.api.core.management.BroadcastGroupControl
-
Returns the configuration name of this broadcast group.
- getName() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns the configuration name of this cluster connection.
- getName() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the name of this queue.
- getName() - Method in class org.hornetq.api.core.management.RoleInfo
-
Returns the name of the role.
- getName() - Method in class org.hornetq.api.core.TransportConfiguration
-
Returns the name of this TransportConfiguration.
- getName() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- getName() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getName() - Method in class org.hornetq.core.cluster.DiscoveryGroup
-
- getName() - Method in class org.hornetq.core.filter.impl.Identifier
-
- getName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- getName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ReattachSessionMessage
-
- getName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- getName() - Method in class org.hornetq.core.security.Role
-
- getName() - Method in class org.hornetq.core.server.QueueQueryResult
-
- getNames(JSONObject) - Static method in class org.hornetq.utils.json.JSONObject
-
Get an array of field names from a JSONObject.
- getNames(Object) - Static method in class org.hornetq.utils.json.JSONObject
-
Get an array of field names from an Object.
- getNettyChannel() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- getNextToken() - Method in class org.hornetq.core.filter.impl.FilterParser
-
Get the next Token.
- getNextToken() - Method in class org.hornetq.core.filter.impl.FilterParserTokenManager
-
Get the next Token.
- getNodeId() - Method in interface org.hornetq.api.core.client.TopologyMember
-
Returns the nodeId of the server.
- getNodeID() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns the node ID used by this cluster connection.
- getNodeID() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getNodeID() - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- getNodeId() - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- getNodeID() - Method in class org.hornetq.core.cluster.DiscoveryEntry
-
- getNodeID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- getNodeID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.DisconnectMessage
-
- getNodeID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.NodeAnnounceMessage
-
- getNodeName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage_V2
-
- getNodeName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.NodeAnnounceMessage
-
- getNodes() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns a map of the nodes connected to this cluster connection.
- getNumberOfBytesPerPage() - Method in interface org.hornetq.api.core.management.AddressControl
-
Returns the number of bytes used by each page for this address.
- getNumberOfPages() - Method in interface org.hornetq.api.core.management.AddressControl
-
Returns the number of pages used by this address.
- getObjectProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key
- getObjectProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getObjectProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getObjectProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getOutgoingInterceptorClassNames() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the list of interceptors used by this server for outgoing messages.
- getPacketSize() - Method in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- getPacketSize() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveContinuationMessage
-
- getPacketSize() - Method in interface org.hornetq.core.protocol.core.Packet
-
returns the size needed to encode this packet.
- getPageCacheMaxSize() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getPageSizeBytes() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getPagingDirectory() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the file system directory used to store paging files.
- getPair() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- getParameters() - Method in interface org.hornetq.api.core.management.AcceptorControl
-
Returns the parameters used to configure this acceptor
- getParams() - Method in class org.hornetq.api.core.TransportConfiguration
-
Returns any parameters set for this TransportConfiguration
- getParentString() - Method in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- getPassword() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- getPassword() - Method in class org.hornetq.core.security.HornetQPrincipal
-
- getPasswordProperty(String, String, Map<String, Object>, String, String) - Static method in class org.hornetq.utils.ConfigurationHelper
-
- getPriority() - Method in interface org.hornetq.api.core.Message
-
Returns the message priority.
- getPriority() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getProducerCreditManager() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- getProducerCreditManager() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getProducerCredits() - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- getProducerCredits() - Method in interface org.hornetq.core.client.impl.ClientProducerInternal
-
- getProducerMaxRate() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the maximum rate of message production for producers created through this factory.
- getProducerMaxRate() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getProducerWindowSize() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the window size for flow control of the producers created through this factory.
- getProducerWindowSize() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getProperties() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getProperties() - Method in class org.hornetq.core.server.management.Notification
-
- getPropertyNames() - Method in interface org.hornetq.api.core.Message
-
Returns all the names of the properties for this message.
- getPropertyNames() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getPropMaskPassword() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getPropPasswordCodec() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- getQueueInfo() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- getQueueInfo() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- getQueueName() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns the name of the queue this bridge is consuming messages from.
- getQueueName() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- getQueueName() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- getQueueName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- getQueueName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- getQueueName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionDeleteQueueMessage
-
- getQueueName() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryMessage
-
- getQueueNames() - Method in interface org.hornetq.api.core.client.ClientSession.BindingQuery
-
Returns the names of the queues bound to the binding.
- getQueueNames() - Method in interface org.hornetq.api.core.management.AddressControl
-
Returns the names of the queues bound to this address.
- getQueueNames() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the names of the queues created on this server.
- getQueueNames() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionBindingQueryResponseMessage
-
- getQueueObjectName(SimpleString, SimpleString) - Method in class org.hornetq.api.core.management.ObjectNameBuilder
-
Returns the ObjectName used by QueueControl.
- getRandom() - Method in class org.hornetq.utils.Random
-
- getRate() - Method in interface org.hornetq.utils.TokenBucketLimiter
-
Returns the rate in cycles per second (which is the same as saying 'in Hertz').
- getRate() - Method in class org.hornetq.utils.TokenBucketLimiterImpl
-
- getReconnectAttempts() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the maximum number of attempts to retry connection in case of failure.
- getReconnectAttempts() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns the number of reconnection attempts used by this bridge.
- getReconnectAttempts() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getRedeliveryDelay() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getRedeliveryMultiplier() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getRedistributionDelay() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getRefreshTimeout() - Method in class org.hornetq.api.core.DiscoveryGroupConfiguration
-
- getRemoteAddress() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getRemoteAddress() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- getRemoteAddress() - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
returns a string representation of the remote address of this connection
- getRemoteAddress() - Method in interface org.hornetq.spi.core.remoting.Connection
-
Returns a string representation of the remote address this connection is connected to.
- getResponseCode() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResponseMessage
-
- getResult(Message) - Static method in class org.hornetq.api.core.management.ManagementHelper
-
Returns the result of an operation invocation or an attribute value.
- getResults(Message) - Static method in class org.hornetq.api.core.management.ManagementHelper
-
Returns the result of an operation invocation or an attribute value.
- getRetryInterval() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the time to retry connections created by this factory after failure.
- getRetryInterval() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns the retry interval used by this bridge.
- getRetryInterval() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns the connection retry interval used by this cluster connection.
- getRetryInterval() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getRetryIntervalMultiplier() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the multiplier to apply to successive retry intervals.
- getRetryIntervalMultiplier() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns the retry interval multiplier used by this bridge.
- getRetryIntervalMultiplier() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getRoles() - Method in interface org.hornetq.api.core.management.AddressControl
-
Returns the roles (name and permissions) associated to this address.
- getRoles(String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
- getRolesAsJSON() - Method in interface org.hornetq.api.core.management.AddressControl
-
Returns the roles (name and permissions) associated to this address
using JSON serialization.
- getRolesAsJSON(String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
- getRoutingName() - Method in interface org.hornetq.api.core.management.DivertControl
-
Returns the routing name of this divert.
- getScheduledCount() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns the number of scheduled messages in this queue.
- getScheduledThreadPoolMaxSize() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the maximum size of the scheduled thread pool.
- getScheduledThreadPoolMaxSize() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the maximum number of threads in the scheduled thread pool.
- getScheduledThreadPoolMaxSize() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getSecurityInvalidationInterval() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the interval time (in milliseconds) to invalidate security credentials.
- getSequence() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionForceConsumerDelivery
-
- getServerLocator() - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
- getServerLocator() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- getServerVersion() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionResponseMessage
-
- getSessionChannelID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- getSessionFactory() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- getSessionFactory() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getShort(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getShort(long) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getShortProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a Short.
- getShortProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getShortProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getShortProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getSimpleStringProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a SimpleString.
- getSimpleStringProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getSimpleStringProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getSimpleStringProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getSize() - Method in interface org.hornetq.core.client.impl.LargeMessageController
-
Returns the size of this buffer.
- getSize() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getSlowConsumerCheckPeriod() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getSlowConsumerPolicy() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getSlowConsumerThreshold() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- getStaticConnectors() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns any list of static connectors used by this bridge
- getStaticConnectors() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns the list of static connectors
- getStaticConnectorsAsJSON() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Returns the list of static connectors as JSON
- getStaticTransportConfigurations() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns an array of TransportConfigurations representing the static list of live servers used
when creating this object
- getStaticTransportConfigurations() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getString(int) - Method in class org.hornetq.utils.json.JSONArray
-
Get the string associated with an index.
- getString(String) - Method in class org.hornetq.utils.json.JSONObject
-
Get the string associated with a key.
- getStringProperty(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Returns the property corresponding to the specified key as a String.
- getStringProperty(String) - Method in interface org.hornetq.api.core.Message
-
- getStringProperty(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getStringProperty(String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getStringProperty(String, String, Map<String, Object>) - Static method in class org.hornetq.utils.ConfigurationHelper
-
- GetSuffix(int) - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
Get the suffix.
- getTabSize(int) - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
- getTextContent(Node) - Static method in class org.hornetq.utils.XMLUtil
-
This metod is here because Node.getTextContent() is not available in JDK 1.4 and I would like
to have an uniform access to this functionality.
- getThreadPoolMaxSize() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the maximum size of the thread pool.
- getThreadPoolMaxSize() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the maximum number of threads in the thread pool.
- getThreadPoolMaxSize() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getTimeoutSeconds() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAGetTimeoutResponseMessage
-
- getTimeoutSeconds() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXASetTimeoutMessage
-
- getTimestamp() - Method in interface org.hornetq.api.core.Message
-
Returns the message timestamp.
- getTimestamp() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getToken(int) - Method in class org.hornetq.core.filter.impl.FilterParser
-
Get the specific Token.
- getTopology() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Exposes the Topology used by this ServerLocator.
- getTopology() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Return the Topology that this Cluster Connection knows about
- getTopology() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- getTopology() - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- getTotalSize() - Method in class org.hornetq.utils.DeflaterReader
-
- getTransactionTimeout() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the timeout (in milliseconds) after which transactions is removed
from the resource manager after it was created.
- getTransactionTimeout() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getTransactionTimeoutScanPeriod() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns the frequency (in milliseconds) to scan transactions to detect which transactions
have timed out.
- getTransferLock() - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
Returns the transfer lock used when transferring connections.
- getTransferLock() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getTransformerClassName() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Return the name of the org.hornetq.core.server.cluster.Transformer implementation associated to this bridge.
- getTransformerClassName() - Method in interface org.hornetq.api.core.management.DivertControl
-
Return the name of the org.hornetq.core.server.cluster.Transformer implementation associated to this bridge.
- getTransportConnection() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- getTransportConnection() - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
return the underlying Connection.
- getType() - Method in enum org.hornetq.api.core.management.CoreNotificationType
-
- getType() - Method in interface org.hornetq.api.core.management.NotificationType
-
- getType() - Method in interface org.hornetq.api.core.Message
-
Returns this message type.
- getType() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getType() - Method in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- getType() - Method in interface org.hornetq.core.protocol.core.Packet
-
returns the type of the packet.
- getType() - Method in class org.hornetq.core.server.management.Notification
-
- getTypedProperties() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getTypedProperties() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- getUID() - Method in class org.hornetq.core.server.management.Notification
-
- getUnderlyingBuffer() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getUniqueEventID() - Method in interface org.hornetq.api.core.client.TopologyMember
-
- getUniqueEventID() - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- getUniqueEventID() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage_V2
-
- getUniqueName() - Method in interface org.hornetq.api.core.management.DivertControl
-
Returns the cluster-wide unique name of this divert.
- getUnsignedByte(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getUnsignedInt(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getUnsignedMedium(long) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getUnsignedShort(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- getUserID() - Method in interface org.hornetq.api.core.Message
-
Returns the userID - this is an optional user specified UUID that can be set to identify the message
and will be passed around with the message
- getUserID() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getUsername() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- getUserName() - Method in class org.hornetq.core.security.HornetQPrincipal
-
- getValue() - Method in class org.hornetq.core.filter.impl.Identifier
-
- getValue() - Method in class org.hornetq.core.filter.impl.Token
-
An optional attribute value of the Token.
- getVersion() - Method in interface org.hornetq.api.core.client.ClientSession
-
Returns the server's incrementingVersion.
- getVersion() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns this server's version.
- getVersion() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getVersion() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- getVersion() - Static method in class org.hornetq.utils.VersionLoader
-
- getVersionName() - Method in class org.hornetq.core.version.impl.VersionImpl
-
- getVersionName() - Method in interface org.hornetq.core.version.Version
-
- getVersionSuffix() - Method in class org.hornetq.core.version.impl.VersionImpl
-
- getVersionSuffix() - Method in interface org.hornetq.core.version.Version
-
- getWholeBuffer() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- getWholeBuffer() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- getWindowSize() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- getXAResource() - Method in interface org.hornetq.api.core.client.ClientSession
-
Returns the XAResource associated to the session.
- getXAResource() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAAfterFailedMessage
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXACommitMessage
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAEndMessage
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAForgetMessage
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAJoinMessage
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAPrepareMessage
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResumeMessage
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXARollbackMessage
-
- getXid() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAStartMessage
-
- getXidEncodeLength(Xid) - Static method in class org.hornetq.utils.XidCodecSupport
-
- getXids() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAGetInDoubtXidsResponseMessage
-
- GT - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- GT - Static variable in class org.hornetq.core.filter.impl.Operator
-
- id - Variable in enum org.hornetq.core.protocol.core.impl.ChannelImpl.CHANNEL_ID
-
- ID_MASK - Static variable in class org.hornetq.utils.TimeAndCounterIDGenerator
-
- identifier() - Method in class org.hornetq.core.filter.impl.FilterParser
-
- IDENTIFIER - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- Identifier - Class in org.hornetq.core.filter.impl
-
A Identifier
- Identifier(SimpleString) - Constructor for class org.hornetq.core.filter.impl.Identifier
-
- IDGenerator - Interface in org.hornetq.utils
-
Generator of record IDs for the journals.
- idToString(long) - Static method in enum org.hornetq.core.protocol.core.impl.ChannelImpl.CHANNEL_ID
-
- image - Variable in class org.hornetq.core.filter.impl.Token
-
The string image of the token.
- IN - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- IN - Static variable in class org.hornetq.core.filter.impl.Operator
-
- inBuf - Variable in class org.hornetq.core.filter.impl.SimpleCharStream
-
- incrementRefCount() - Method in interface org.hornetq.core.client.impl.ClientProducerCredits
-
- incrementRefCount() - Method in class org.hornetq.core.client.impl.ClientProducerCreditsImpl
-
- individualAcknowledge() - Method in interface org.hornetq.api.core.client.ClientMessage
-
Acknowledge reception of a single message.
- individualAcknowledge(ClientMessage) - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- individualAcknowledge(ClientMessage) - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- individualAcknowledge() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- individualAcknowledge(long, long) - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- individualAcknowledge(long, long) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- InflaterReader - Class in org.hornetq.utils
-
An InflaterReader
It takes an compressed input stream and decompressed it as it is being read.
- InflaterReader(InputStream) - Constructor for class org.hornetq.utils.InflaterReader
-
- InflaterReader(InputStream, int) - Constructor for class org.hornetq.utils.InflaterReader
-
- InflaterWriter - Class in org.hornetq.utils
-
A InflaterWriter
This class takes an OutputStream.
- InflaterWriter(OutputStream) - Constructor for class org.hornetq.utils.InflaterWriter
-
- init() - Method in interface org.hornetq.core.client.impl.ClientProducerCredits
-
- init() - Method in class org.hornetq.core.client.impl.ClientProducerCreditsImpl
-
- INITIAL_CONNECT_ATTEMPTS - Static variable in class org.hornetq.api.core.client.HornetQClient
-
- input_stream - Variable in class org.hornetq.core.filter.impl.FilterParserTokenManager
-
- inputStream - Variable in class org.hornetq.core.filter.impl.SimpleCharStream
-
- inReceive() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- INSTANCE - Static variable in class org.hornetq.core.protocol.ClientPacketDecoder
-
- INTEGER_LITERAL - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- intercept(Packet, RemotingConnection) - Method in interface org.hornetq.api.core.Interceptor
-
Intercepts a packet which is received before it is sent to the channel
- Interceptor - Interface in org.hornetq.api.core
-
This is class is a simple way to intercepting calls on HornetQ client and servers.
- interceptorRejectedPacket(String) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- internalRunning() - Method in class org.hornetq.core.cluster.DiscoveryGroup
-
This will start the DiscoveryRunnable and run it directly.
- invalidCommandID(Integer) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- invalidConcurrentSessionUsage(Throwable) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- invalidEncodeType(Object) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- invalidManagementParam(Object) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- invalidType(Object) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- invalidWindowSize(Integer) - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- invokeInterceptors(Packet, List<Interceptor>, RemotingConnection) - Static method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- ioDiscoveryError(String, String) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- IS - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- is64bitArch() - Static method in class org.hornetq.utils.MemorySize
-
- IS_NOT_NULL - Static variable in class org.hornetq.core.filter.impl.Operator
-
- IS_NULL - Static variable in class org.hornetq.core.filter.impl.Operator
-
- isAsyncConnectionExecutionEnabled() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether code coming from connection is executed asynchronously or not.
- isAsyncExec() - Method in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- isAsyncExec() - Method in class org.hornetq.core.protocol.core.impl.wireformat.RollbackMessage
-
- isAsyncExec() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCloseMessage
-
- isAsyncExec() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCommitMessage
-
- isAsyncExec() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXACommitMessage
-
- isAsyncExec() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAPrepareMessage
-
- isAsyncExec() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXARollbackMessage
-
- isAsyncExec() - Method in interface org.hornetq.core.protocol.core.Packet
-
- isAttributesResult(Message) - Static method in class org.hornetq.api.core.management.ManagementHelper
-
Returns whether the JMS message corresponds to the result of a management attribute value.
- isAutoCommitAcks() - Method in interface org.hornetq.api.core.client.ClientSession
-
Returns whether the session will automatically commit its transaction every time a message is acknowledged
by a ClientConsumer created by this session, false
else
- isAutoCommitAcks() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isAutoCommitAcks() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- isAutoCommitSends() - Method in interface org.hornetq.api.core.client.ClientSession
-
Returns whether the session will automatically commit its transaction every time a message is sent
by a ClientProducer created by this session, false
else
- isAutoCommitSends() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isAutoCommitSends() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- isAutoGroup() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns whether producers created through this factory will automatically
assign a group ID to the messages they sent.
- isAutoGroup() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isBackup() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns true
if this server is a backup, false
if it is a live server.
- isBackup() - Method in class org.hornetq.core.protocol.core.impl.wireformat.NodeAnnounceMessage
-
- isBlocked() - Method in interface org.hornetq.core.client.impl.ClientProducerCredits
-
- isBlocked() - Method in class org.hornetq.core.client.impl.ClientProducerCreditsImpl
-
- isBlockOnAcknowledge() - Method in interface org.hornetq.api.core.client.ClientSession
-
Returns whether the ClientConsumer created by the session will block when they acknowledge a message.
- isBlockOnAcknowledge() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns whether consumers created through this factory will block while
sending message acknowledgments or do it asynchronously.
- isBlockOnAcknowledge() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isBlockOnAcknowledge() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isBlockOnDurableSend() - Method in interface org.hornetq.api.core.client.ClientProducer
-
Returns whether the producer will block when sending durable messages.
- isBlockOnDurableSend() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns whether producers created through this factory will block while sending durable messages or do it asynchronously.
- isBlockOnDurableSend() - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- isBlockOnDurableSend() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isBlockOnNonDurableSend() - Method in interface org.hornetq.api.core.client.ClientProducer
-
Returns whether the producer will block when sending non-durable messages.
- isBlockOnNonDurableSend() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns whether producers created through this factory will block while sending non-durable messages or do it asynchronously.
- isBlockOnNonDurableSend() - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- isBlockOnNonDurableSend() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isBrowseOnly() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- isBrowseOnly() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- isBrowseOnly() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- isCacheLargeMessageClient() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- isCacheLargeMessageClient() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isCacheLargeMessagesClient() - Method in interface org.hornetq.api.core.client.ServerLocator
-
When true
, consumers created through this factory will create temporary files to
cache large messages.
- isCacheLargeMessagesClient() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isClient() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- isClient() - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
- isClosed() - Method in interface org.hornetq.api.core.client.ClientConsumer
-
Returns whether the consumer is closed or not.
- isClosed() - Method in interface org.hornetq.api.core.client.ClientProducer
-
Returns whether the producer is closed or not.
- isClosed() - Method in interface org.hornetq.api.core.client.ClientSession
-
Returns whether the session is closed or not.
- isClosed() - Method in interface org.hornetq.api.core.client.ClientSessionFactory
-
- isClosed() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns true if close was already called
- isClosed() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- isClosed() - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- isClosed() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- isClosed() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isClosed() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isClusterConnection() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isClusterConnection() - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- isClusterConnection() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessage
-
- isClustered() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether this server is clustered.
- isCompatible(int) - Method in class org.hornetq.core.version.impl.VersionImpl
-
- isCompatible(int) - Method in interface org.hornetq.core.version.Version
-
- isCompressed() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- isCompressed() - Method in interface org.hornetq.core.client.impl.ClientMessageInternal
-
- isCompressLargeMessage() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Whether to compress large messages.
- isCompressLargeMessage() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isCompressLargeMessages() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- isCompressLargeMessages() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isConsiderLastMessageAsDelivered() - Method in class org.hornetq.core.protocol.core.impl.wireformat.RollbackMessage
-
- isConsume() - Method in class org.hornetq.api.core.management.RoleInfo
-
Returns whether this role can consume messages from queues bound to the address.
- isConsume() - Method in class org.hornetq.core.security.Role
-
- isContinues() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionContinuationMessage
-
- isCreateBindingsDir() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether the bindings directory is created on this server startup.
- isCreateDurableQueue() - Method in class org.hornetq.api.core.management.RoleInfo
-
Returns whether this role can create durable queues bound to the address.
- isCreateDurableQueue() - Method in class org.hornetq.core.security.Role
-
- isCreateJournalDir() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether the journal directory is created on this server startup.
- isCreateNonDurableQueue() - Method in class org.hornetq.api.core.management.RoleInfo
-
Returns whether this role can create non-durable queues bound to the address.
- isCreateNonDurableQueue() - Method in class org.hornetq.core.security.Role
-
- isDefaultAllowAutoFailback() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultAsyncConnectionExecutionEnabled() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultBackup() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultBridgeDuplicateDetection() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultCheckForLiveServer() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultClusterDuplicateDetection() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultClusterForwardWhenNoConsumers() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultCreateBindingsDir() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultCreateJournalDir() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultDivertExclusive() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultFailoverOnServerShutdown() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultFileDeploymentEnabled() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultJmxManagementEnabled() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultJournalLogWriteRate() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultJournalSyncNonTransactional() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultJournalSyncTransactional() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultMaskPassword() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultMessageCounterEnabled() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultPersistDeliveryCountBeforeDelivery() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultPersistenceEnabled() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultPersistIdCache() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultRunSyncSpeedTest() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultSecurityEnabled() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultSharedStore() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDefaultWildcardRoutingEnabled() - Static method in class org.hornetq.api.config.HornetQDefaultConfiguration
-
- isDeleteDurableQueue() - Method in class org.hornetq.api.core.management.RoleInfo
-
Returns whether this role can delete durable queues bound to the address.
- isDeleteDurableQueue() - Method in class org.hornetq.core.security.Role
-
- isDeleteNonDurableQueue() - Method in class org.hornetq.api.core.management.RoleInfo
-
Returns whether this role can delete non-durable queues bound to the address.
- isDeleteNonDurableQueue() - Method in class org.hornetq.core.security.Role
-
- isDestroyed() - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- isDestroyed() - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
- isDirectDeliver() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnection
-
- isDuplicateDetection() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Return whether this cluster connection use duplicate detection.
- isDurable() - Method in interface org.hornetq.api.core.client.ClientSession.QueueQuery
-
Returns true
if the queue is durable, false
else.
- isDurable() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns whether this queue is durable.
- isDurable() - Method in interface org.hornetq.api.core.Message
-
Returns whether this message is durable or not.
- isDurable() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- isDurable() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- isDurable() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- isDurable() - Method in class org.hornetq.core.server.QueueQueryResult
-
- isEmpty() - Method in class org.hornetq.core.client.impl.Topology
-
- isEmpty() - Method in interface org.hornetq.utils.PriorityLinkedList
-
- isEmpty() - Method in class org.hornetq.utils.PriorityLinkedListImpl
-
- isEmpty() - Method in class org.hornetq.utils.SoftValueHashMap
-
- isEquivalent(TransportConfiguration) - Method in class org.hornetq.api.core.TransportConfiguration
-
There's a case on ClusterConnections that we need to find an equivalent Connector and we can't
use a Netty Cluster Connection on an InVM ClusterConnection (inVM used on tests) for that
reason I need to test if the two instances of the TransportConfiguration are equivalent while
a test a connector against an acceptor
- isEquivalent(Map<String, Object>) - Method in class org.hornetq.core.remoting.impl.netty.NettyConnector
-
- isEquivalent(Map<String, Object>) - Method in interface org.hornetq.spi.core.remoting.Connector
-
If the configuration is equivalent to this connector, which means
if the parameter configuration is used to create a connection to a target
node, it will be the same node as of the connections made with this connector.
- isError() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResponseMessage
-
- isExclusive() - Method in interface org.hornetq.api.core.management.DivertControl
-
Returns whether this divert is exclusive.
- isExists() - Method in interface org.hornetq.api.core.client.ClientSession.BindingQuery
-
Returns true
if the binding exists, false
else.
- isExists() - Method in interface org.hornetq.api.core.client.ClientSession.QueueQuery
-
Returns true
if the queue exists, false
else.
- isExists() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionBindingQueryResponseMessage
-
- isExists() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- isExists() - Method in class org.hornetq.core.server.QueueQueryResult
-
- isExit() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- isExpired() - Method in interface org.hornetq.api.core.Message
-
Returns whether this message is expired or not.
- isExpired() - Method in class org.hornetq.core.message.impl.MessageImpl
-
- isFailed() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAEndMessage
-
- isFailoverOnInitialConnection() - Method in interface org.hornetq.api.core.client.ServerLocator
-
- isFailoverOnInitialConnection() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isFailoverOnServerShutdown() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
returns if clients failover on a server shutdown
- isForwardWhenNoConsumers() - Method in interface org.hornetq.api.core.management.ClusterConnectionControl
-
Return whether this cluster connection forward messages when it has no local consumers.
- isHA() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Whether this server receives topology notifications from the cluster as servers join or leave
the cluster.
- isHA() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns whether this bridge is using high availability
- isHA() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isJournalSyncNonTransactional() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether the journal is synchronized when receiving non-transactional data.
- isJournalSyncTransactional() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether the journal is synchronized when receiving transactional data.
- isLargeMessage() - Method in interface org.hornetq.api.core.Message
-
Returns whether this message is a large message or a regular message.
- isLargeMessage() - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- isLargeMessage() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- isLast() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- isLastValueQueue() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- isLive() - Method in interface org.hornetq.utils.SoftValueHashMap.ValueCache
-
- isManage() - Method in class org.hornetq.api.core.management.RoleInfo
-
Returns whether this role can send management messages to the address.
- isManage() - Method in class org.hornetq.core.security.Role
-
- isMember(RemotingConnection) - Method in interface org.hornetq.api.core.client.TopologyMember
-
Returns true if this TopologyMember is the target of this remoting connection
- isMember(TransportConfiguration) - Method in interface org.hornetq.api.core.client.TopologyMember
-
Returns true if this configuration is the target of this remoting connection
- isMember(RemotingConnection) - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- isMember(TransportConfiguration) - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- isMessageCounterEnabled() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether message counter is enabled for this server.
- isNull(int) - Method in class org.hornetq.utils.json.JSONArray
-
Determine if the value is null.
- isNull(String) - Method in class org.hornetq.utils.json.JSONObject
-
Determine if the value associated with the key is null or if there is
no value.
- isOK() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXASetTimeoutResponseMessage
-
- isOnePhase() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXACommitMessage
-
- isOperationResult(Message) - Static method in class org.hornetq.api.core.management.ManagementHelper
-
Returns whether the JMS message corresponds to the result of a management operation invocation.
- isPaging() - Method in interface org.hornetq.api.core.management.AddressControl
-
Returns whether this address is paging.
- isPaused() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns whether the queue is paused.
- isPersistDeliveryCountBeforeDelivery() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether delivery count is persisted before messages are delivered to the consumers.
- isPersistenceEnabled() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether this server is using persistence and store data.
- isPersistIDCache() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether message ID cache is persisted.
- isPreAcknowledge() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns whether messages will pre-acknowledged on the server before they are sent to the consumers or not.
- isPreAcknowledge() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isPreAcknowledge() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- isReadyToHandle(HornetQBuffer) - Method in interface org.hornetq.spi.core.remoting.BufferDecoder
-
- isReattached() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ReattachSessionResponseMessage
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionResponseMessage
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.DisconnectMessage
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.PacketsConfirmedMessage
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.Ping
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ReattachSessionMessage
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ReattachSessionResponseMessage
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessage
-
- isRequiresConfirmations() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessageV2
-
- isRequiresConfirmations() - Method in interface org.hornetq.core.protocol.core.Packet
-
returns true if a confirmation should be sent on receipt of this packet.
- isRequiresResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- isRequiresResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionAcknowledgeMessage
-
- isRequiresResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- isRequiresResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionIndividualAcknowledgeMessage
-
- isRequiresResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionSendContinuationMessage
-
- isRequiresResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionSendMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionResponseMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.HornetQExceptionMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.NullResponseMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.ReattachSessionResponseMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionBindingQueryResponseMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAGetInDoubtXidsResponseMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAGetTimeoutResponseMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResponseMessage
-
- isResponse() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionXASetTimeoutResponseMessage
-
- isResponse() - Method in interface org.hornetq.core.protocol.core.Packet
-
returns true if this packet is being sent in response to a previously received packet
- isRollbackOnly() - Method in interface org.hornetq.api.core.client.ClientSession
-
Returns true
if the current transaction has been flagged to rollback, false
else.
- isRollbackOnly() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isSameRM(XAResource) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isSecurityEnabled() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether security is enabled for this server.
- isSend() - Method in class org.hornetq.api.core.management.RoleInfo
-
Returns whether this role can send messages to the address.
- isSend() - Method in class org.hornetq.core.security.Role
-
- isSendToDLAOnNoRoute() - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- isServerMessage() - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- isServerMessage() - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- isSharedStore() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether this server shares its data store with a corresponding live or backup server.
- isSpin() - Method in interface org.hornetq.utils.TokenBucketLimiter
-
- isSpin() - Method in class org.hornetq.utils.TokenBucketLimiterImpl
-
- isStarted() - Method in interface org.hornetq.api.core.management.HornetQComponentControl
-
Returns true
if this component is started, false
else.
- isStarted() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Return whether this server is started.
- isStarted() - Method in class org.hornetq.core.cluster.DiscoveryGroup
-
- isStarted() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnector
-
- isStarted() - Method in interface org.hornetq.spi.core.remoting.Connector
-
returns true if the connector is started, oterwise false.
- isTemporary() - Method in interface org.hornetq.api.core.management.QueueControl
-
Returns whether this queue is temporary.
- isTemporary() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- isTemporary() - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- isTemporary() - Method in class org.hornetq.core.server.QueueQueryResult
-
- isUseDuplicateDetection() - Method in interface org.hornetq.api.core.management.BridgeControl
-
Returns whether this bridge is using duplicate detection.
- isUseGlobalPools() - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns whether this factory will use global thread pools (shared among all the factories in the same JVM)
or its own pools.
- isUseGlobalPools() - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- isWildcardRoutingEnabled() - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Returns whether wildcard routing is supported by this server.
- isXA() - Method in interface org.hornetq.api.core.client.ClientSession
-
Return true
if the session supports XA, false
else.
- isXA() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- isXA() - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateSessionMessage
-
- iterator() - Method in interface org.hornetq.utils.LinkedList
-
- iterator() - Method in class org.hornetq.utils.LinkedListImpl
-
- iterator() - Method in interface org.hornetq.utils.PriorityLinkedList
-
- iterator() - Method in class org.hornetq.utils.PriorityLinkedListImpl
-
- Packet - Interface in org.hornetq.core.protocol.core
-
A Packet represents a packet of data transmitted over a connection.
- PACKET_HEADERS_SIZE - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- PacketDecoder - Class in org.hornetq.core.protocol.core.impl
-
A PacketDecoder
- PacketDecoder() - Constructor for class org.hornetq.core.protocol.core.impl.PacketDecoder
-
- PacketImpl - Class in org.hornetq.core.protocol.core.impl
-
- PacketImpl(byte) - Constructor for class org.hornetq.core.protocol.core.impl.PacketImpl
-
- packetOutOfOrder(Object, Throwable) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- PACKETS_CONFIRMED - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- PacketsConfirmedMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A PacketsConfirmedMessage
- PacketsConfirmedMessage(int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.PacketsConfirmedMessage
-
- PacketsConfirmedMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.PacketsConfirmedMessage
-
- packetTimeout(long) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- pair - Variable in class org.hornetq.core.protocol.core.impl.wireformat.ClusterTopologyChangeMessage
-
- Parameter - Annotation Type in org.hornetq.api.core.management
-
Info for a MBean Operation Parameter.
- parse(SimpleString, Map<SimpleString, Identifier>) - Method in class org.hornetq.core.filter.impl.FilterParser
-
- parse(SimpleString, Map<SimpleString, Identifier>, boolean) - Method in class org.hornetq.core.filter.impl.FilterParser
-
- parseBoolean(Node) - Static method in class org.hornetq.utils.XMLUtil
-
- parseDouble(Node) - Static method in class org.hornetq.utils.XMLUtil
-
- ParseException - Exception in org.hornetq.core.filter.impl
-
This exception is thrown when parse errors are encountered.
- ParseException(Token, int[][], String[]) - Constructor for exception org.hornetq.core.filter.impl.ParseException
-
This constructor is used by the method "generateParseException"
in the generated parser.
- ParseException() - Constructor for exception org.hornetq.core.filter.impl.ParseException
-
The following constructors are for use by you for whatever
purpose you can think of.
- ParseException(String) - Constructor for exception org.hornetq.core.filter.impl.ParseException
-
Constructor with message.
- parseInt(Node) - Static method in class org.hornetq.utils.XMLUtil
-
- parseLong(Node) - Static method in class org.hornetq.utils.XMLUtil
-
- patternExpression(Object) - Method in class org.hornetq.core.filter.impl.FilterParser
-
- pause() - Method in interface org.hornetq.api.core.management.QueueControl
-
Pauses the queue.
- PING - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- Ping - Class in org.hornetq.core.protocol.core.impl.wireformat
-
Ping is sent on the client side at ClientSessionFactoryImpl
.
- Ping(long) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.Ping
-
- Ping() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.Ping
-
- PLUS - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- poll() - Method in interface org.hornetq.utils.LinkedList
-
- poll() - Method in class org.hornetq.utils.LinkedListImpl
-
- poll() - Method in interface org.hornetq.utils.PriorityLinkedList
-
- poll() - Method in class org.hornetq.utils.PriorityLinkedListImpl
-
- PORT_PROP_NAME - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- preHandleFailover(CoreRemotingConnection) - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- preHandleFailover(CoreRemotingConnection) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- prepare(Xid) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- prepareForClose(FutureLatch) - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
To be used by MDBs to stop any more handling of messages.
- prepareForClose(FutureLatch) - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
To be called by things like MDBs during shutdown of the server
- prevCharIsCR - Variable in class org.hornetq.core.filter.impl.SimpleCharStream
-
- prevCharIsLF - Variable in class org.hornetq.core.filter.impl.SimpleCharStream
-
- print(String) - Method in class org.hornetq.core.filter.impl.Operator
-
- priority - Variable in class org.hornetq.core.message.impl.MessageImpl
-
- PriorityLinkedList<T> - Interface in org.hornetq.utils
-
A type of linked list which maintains items according to a priority
and allows adding and removing of elements at both ends, and peeking
- PriorityLinkedListImpl<T> - Class in org.hornetq.utils
-
A priority linked list implementation
It implements this by maintaining an individual LinkedBlockingDeque for each priority level.
- PriorityLinkedListImpl(int) - Constructor for class org.hornetq.utils.PriorityLinkedListImpl
-
- producerClosed() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- properties - Variable in class org.hornetq.core.message.impl.MessageImpl
-
- propertyNotBoolean(String, String) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- propertyNotInteger(String, String) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- propertyNotLong(String, String) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- PROTOCOL_PROP_NAME - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- ProtocolType - Enum in org.hornetq.spi.core.protocol
-
A ProtocolType
- put(boolean) - Method in class org.hornetq.utils.json.JSONArray
-
Append a boolean value.
- put(Collection) - Method in class org.hornetq.utils.json.JSONArray
-
Put a value in the JSONArray, where the value will be a
JSONArray which is produced from a Collection.
- put(double) - Method in class org.hornetq.utils.json.JSONArray
-
Append a double value.
- put(int) - Method in class org.hornetq.utils.json.JSONArray
-
Append an int value.
- put(long) - Method in class org.hornetq.utils.json.JSONArray
-
Append an long value.
- put(Map) - Method in class org.hornetq.utils.json.JSONArray
-
Put a value in the JSONArray, where the value will be a
JSONObject which is produced from a Map.
- put(Object) - Method in class org.hornetq.utils.json.JSONArray
-
Append an object value.
- put(int, boolean) - Method in class org.hornetq.utils.json.JSONArray
-
Put or replace a boolean value in the JSONArray.
- put(int, Collection) - Method in class org.hornetq.utils.json.JSONArray
-
Put a value in the JSONArray, where the value will be a
JSONArray which is produced from a Collection.
- put(int, double) - Method in class org.hornetq.utils.json.JSONArray
-
Put or replace a double value.
- put(int, int) - Method in class org.hornetq.utils.json.JSONArray
-
Put or replace an int value.
- put(int, long) - Method in class org.hornetq.utils.json.JSONArray
-
Put or replace a long value.
- put(int, Map) - Method in class org.hornetq.utils.json.JSONArray
-
Put a value in the JSONArray, where the value will be a
JSONObject which is produced from a Map.
- put(int, Object) - Method in class org.hornetq.utils.json.JSONArray
-
Put or replace an object value in the JSONArray.
- put(String, Collection) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/value pair in the JSONObject, where the value will be a
JSONArray which is produced from a Collection.
- put(String, boolean) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/boolean pair in the JSONObject.
- put(String, double) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/double pair in the JSONObject.
- put(String, int) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/int pair in the JSONObject.
- put(String, long) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/long pair in the JSONObject.
- put(String, Map) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/value pair in the JSONObject, where the value will be a
JSONObject which is produced from a Map.
- put(String, Object) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/value pair in the JSONObject.
- put(K, V) - Method in class org.hornetq.utils.SoftValueHashMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.hornetq.utils.SoftValueHashMap
-
- putAttribute(Message, String, String) - Static method in class org.hornetq.api.core.management.ManagementHelper
-
Stores a resource attribute in a message to retrieve the value from the server resource.
- putBooleanProperty(SimpleString, boolean) - Method in interface org.hornetq.api.core.Message
-
Puts a boolean property in this message.
- putBooleanProperty(String, boolean) - Method in interface org.hornetq.api.core.Message
-
- putBooleanProperty(SimpleString, boolean) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putBooleanProperty(String, boolean) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putByteProperty(SimpleString, byte) - Method in interface org.hornetq.api.core.Message
-
Puts a byte property in this message.
- putByteProperty(String, byte) - Method in interface org.hornetq.api.core.Message
-
- putByteProperty(SimpleString, byte) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putByteProperty(String, byte) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putBytesProperty(SimpleString, byte[]) - Method in interface org.hornetq.api.core.Message
-
Puts a byte[] property in this message.
- putBytesProperty(String, byte[]) - Method in interface org.hornetq.api.core.Message
-
- putBytesProperty(SimpleString, byte[]) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putBytesProperty(String, byte[]) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putChannel(long, Channel) - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
add the channel with the specified channel id
- putChannel(long, Channel) - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- putDoubleProperty(SimpleString, double) - Method in interface org.hornetq.api.core.Message
-
Puts a double property in this message.
- putDoubleProperty(String, double) - Method in interface org.hornetq.api.core.Message
-
- putDoubleProperty(SimpleString, double) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putDoubleProperty(String, double) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putFloatProperty(SimpleString, float) - Method in interface org.hornetq.api.core.Message
-
Puts a float property in this message.
- putFloatProperty(String, float) - Method in interface org.hornetq.api.core.Message
-
- putFloatProperty(SimpleString, float) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putFloatProperty(String, float) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putIntProperty(SimpleString, int) - Method in interface org.hornetq.api.core.Message
-
Puts a int property in this message.
- putIntProperty(String, int) - Method in interface org.hornetq.api.core.Message
-
- putIntProperty(SimpleString, int) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putIntProperty(String, int) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putLongProperty(SimpleString, long) - Method in interface org.hornetq.api.core.Message
-
Puts a long property in this message.
- putLongProperty(String, long) - Method in interface org.hornetq.api.core.Message
-
- putLongProperty(SimpleString, long) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putLongProperty(String, long) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putObjectProperty(SimpleString, Object) - Method in interface org.hornetq.api.core.Message
-
Puts an Object property in this message.
- putObjectProperty(String, Object) - Method in interface org.hornetq.api.core.Message
-
- putObjectProperty(SimpleString, Object) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putObjectProperty(String, Object) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putOnce(String, Object) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/value pair in the JSONObject, but only if the key and the
value are both non-null, and only if there is not already a member
with that name.
- putOperationInvocation(Message, String, String) - Static method in class org.hornetq.api.core.management.ManagementHelper
-
Stores a operation invocation in a message to invoke the corresponding operation the value from the server resource.
- putOperationInvocation(Message, String, String, Object...) - Static method in class org.hornetq.api.core.management.ManagementHelper
-
Stores a operation invocation in a message to invoke the corresponding operation the value from the server resource.
- putOpt(String, Object) - Method in class org.hornetq.utils.json.JSONObject
-
Put a key/value pair in the JSONObject, but only if the
key and the value are both non-null.
- putShortProperty(SimpleString, short) - Method in interface org.hornetq.api.core.Message
-
Puts a short property in this message.
- putShortProperty(String, short) - Method in interface org.hornetq.api.core.Message
-
- putShortProperty(SimpleString, short) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putShortProperty(String, short) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putStringProperty(SimpleString, SimpleString) - Method in interface org.hornetq.api.core.Message
-
Puts a SimpleString property in this message.
- putStringProperty(String, String) - Method in interface org.hornetq.api.core.Message
-
Puts a String property in this message.
- putStringProperty(SimpleString, SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putStringProperty(String, String) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- putTypedProperties(TypedProperties) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- saveBuffer(OutputStream) - Method in interface org.hornetq.core.client.impl.LargeMessageController
-
Saves this buffer to the specified output.
- saveBuffer(OutputStream) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- saveToOutputStream(OutputStream) - Method in interface org.hornetq.api.core.client.ClientMessage
-
Saves the content of the message to the OutputStream.
- saveToOutputStream(OutputStream) - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- saveToOutputStream(OutputStream) - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- secondNodeNull() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- SecurityFormatter - Class in org.hornetq.utils
-
- SecurityFormatter() - Constructor for class org.hornetq.utils.SecurityFormatter
-
- select(int) - Method in interface org.hornetq.api.core.client.loadbalance.ConnectionLoadBalancingPolicy
-
Returns the selected index according to the policy implementation.
- select(int) - Method in class org.hornetq.api.core.client.loadbalance.FirstElementConnectionLoadBalancingPolicy
-
- select(int) - Method in class org.hornetq.api.core.client.loadbalance.RandomConnectionLoadBalancingPolicy
-
Returns a pseudo random number between 0
(inclusive) and max
exclusive.
- select(int) - Method in class org.hornetq.api.core.client.loadbalance.RandomStickyConnectionLoadBalancingPolicy
-
- select(int) - Method in class org.hornetq.api.core.client.loadbalance.RoundRobinConnectionLoadBalancingPolicy
-
- selectorExpression() - Method in class org.hornetq.core.filter.impl.FilterParser
-
- selectorFactor() - Method in class org.hornetq.core.filter.impl.FilterParser
-
- selectorTerm() - Method in class org.hornetq.core.filter.impl.FilterParser
-
- SEMICOLON - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- send(Message) - Method in interface org.hornetq.api.core.client.ClientProducer
-
Sends a message to an address.
- send(SimpleString, Message) - Method in interface org.hornetq.api.core.client.ClientProducer
-
Sends a message to the specified address instead of the ClientProducer's address.
- send(String, Message) - Method in interface org.hornetq.api.core.client.ClientProducer
-
Sends a message to the specified address instead of the ClientProducer's address.
- send(Message) - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- send(SimpleString, Message) - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- send(String, Message) - Method in class org.hornetq.core.client.impl.ClientProducerImpl
-
- send(Packet) - Method in interface org.hornetq.core.protocol.core.Channel
-
sends a packet on this channel.
- send(Packet) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- send(Packet, boolean, boolean) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- sendAcknowledged(Message) - Method in interface org.hornetq.api.core.client.SendAcknowledgementHandler
-
Notifies the client that a message sent asynchronously has been received by the server.
- SendAcknowledgementHandler - Interface in org.hornetq.api.core.client
-
A SendAcknowledgementHandler notifies a client when an message sent asynchronously has been
received by the server.
- sendAndFlush(Packet) - Method in interface org.hornetq.core.protocol.core.Channel
-
sends a packet on this channel and then blocks until it has been written to the connection.
- sendAndFlush(Packet) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- sendBatched(Packet) - Method in interface org.hornetq.core.protocol.core.Channel
-
sends a packet on this channel using batching algorithm if appropriate
- sendBatched(Packet) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- sendBlocking(Packet, byte) - Method in interface org.hornetq.core.protocol.core.Channel
-
sends a packet on this channel and then blocks until a response is received or a timeout occurs.
- sendBlocking(Packet, byte) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
Due to networking issues or server issues the server may take longer to answer than expected..
- sendMessagesToDeadLetterAddress(String) - Method in interface org.hornetq.api.core.management.QueueControl
-
Sends all the message corresponding to the specified filter to this queue's dead letter address.
- sendMessageToDeadLetterAddress(long) - Method in interface org.hornetq.api.core.management.QueueControl
-
Sends the message corresponding to the specified message ID to this queue's dead letter address.
- sendNodeAnnounce(long, String, String, boolean, TransportConfiguration, TransportConfiguration) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- sendNodeAnnounce(long, String, String, boolean, TransportConfiguration, TransportConfiguration) - Method in interface org.hornetq.core.client.impl.ClientSessionFactoryInternal
-
- sendNotification(Notification) - Method in interface org.hornetq.core.server.management.NotificationService
-
the message corresponding to a notification will always contain the properties:
ManagementHelper.HDR_NOTIFICATION_TYPE
- the type of notification (SimpleString)
ManagementHelper.HDR_NOTIFICATION_MESSAGE
- a message contextual to the notification (SimpleString)
ManagementHelper.HDR_NOTIFICATION_TIMESTAMP
- the timestamp when the notification occured (long)
in addition to the properties defined in
props
- sendProducerCreditsMessage(int, SimpleString) - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- sendProducerCreditsMessage(int, SimpleString) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- sendQueueInfoToQueue(String, String) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
This method is used by HornetQ clustering and must not be called by HornetQ clients.
- sendTopology(ClusterTopologyListener) - Method in class org.hornetq.core.client.impl.Topology
-
- ServerLocator - Interface in org.hornetq.api.core.client
-
The serverLocator locates a server, but beyond that it locates a server based on a list.
- ServerLocatorImpl - Class in org.hornetq.core.client.impl
-
This is the implementation of
ServerLocator
and all
the proper javadoc is located on that interface.
- ServerLocatorImpl(boolean, DiscoveryGroupConfiguration) - Constructor for class org.hornetq.core.client.impl.ServerLocatorImpl
-
Create a ServerLocatorImpl using UDP discovery to lookup cluster
- ServerLocatorImpl(boolean, TransportConfiguration...) - Constructor for class org.hornetq.core.client.impl.ServerLocatorImpl
-
Create a ServerLocatorImpl using a static list of live servers
- ServerLocatorImpl(Topology, boolean, DiscoveryGroupConfiguration) - Constructor for class org.hornetq.core.client.impl.ServerLocatorImpl
-
Create a ServerLocatorImpl using UDP discovery to lookup cluster
- ServerLocatorImpl(Topology, boolean, TransportConfiguration...) - Constructor for class org.hornetq.core.client.impl.ServerLocatorImpl
-
Create a ServerLocatorImpl using a static list of live servers
- ServerLocatorInternal - Interface in org.hornetq.core.client.impl
-
A ServerLocatorInternal
- serverLocatorNotClosed(Exception, int) - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- SERVLET_PATH - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- SESS_ACKNOWLEDGE - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_ADD_METADATA - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_ADD_METADATA2 - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_BINDINGQUERY - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_BINDINGQUERY_RESP - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_CLOSE - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_COMMIT - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_CONSUMER_CLOSE - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_CREATECONSUMER - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_EXPIRED - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_FLOWTOKEN - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_FORCE_CONSUMER_DELIVERY - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_INDIVIDUAL_ACKNOWLEDGE - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_PRODUCER_CREDITS - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_PRODUCER_FAIL_CREDITS - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_PRODUCER_REQUEST_CREDITS - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_QUEUEQUERY - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_QUEUEQUERY_RESP - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_RECEIVE_CONTINUATION - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_RECEIVE_LARGE_MSG - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_RECEIVE_MSG - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_ROLLBACK - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_SEND - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_SEND_CONTINUATION - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_SEND_LARGE - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_START - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_STOP - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_UNIQUE_ADD_METADATA - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_COMMIT - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_END - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_FAILED - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_FORGET - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_GET_TIMEOUT - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_GET_TIMEOUT_RESP - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_INDOUBT_XIDS - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_INDOUBT_XIDS_RESP - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_JOIN - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_PREPARE - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_RESP - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_RESUME - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_ROLLBACK - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_SET_TIMEOUT - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_SET_TIMEOUT_RESP - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_START - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESS_XA_SUSPEND - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SESSION_CONTINUATION_BASE_SIZE - Static variable in class org.hornetq.core.protocol.core.impl.wireformat.SessionContinuationMessage
-
- SESSION_RECEIVE_CONTINUATION_BASE_SIZE - Static variable in class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveContinuationMessage
-
- SessionAcknowledgeMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionAcknowledgeMessage(long, long, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAcknowledgeMessage
-
- SessionAcknowledgeMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAcknowledgeMessage
-
- SessionAddMetaDataMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionAddMetaDataMessage
Packet deprecated: It exists only to support old formats
- SessionAddMetaDataMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessage
-
- SessionAddMetaDataMessage(String, String) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessage
-
- SessionAddMetaDataMessageV2 - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionAddMetaDataMessageV2() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessageV2
-
- SessionAddMetaDataMessageV2(byte) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessageV2
-
- SessionAddMetaDataMessageV2(String, String) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessageV2
-
- SessionAddMetaDataMessageV2(byte, String, String) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessageV2
-
- SessionAddMetaDataMessageV2(String, String, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionAddMetaDataMessageV2
-
- SessionBindingQueryMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionQueueQueryMessage
- SessionBindingQueryMessage(SimpleString) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionBindingQueryMessage
-
- SessionBindingQueryMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionBindingQueryMessage
-
- SessionBindingQueryResponseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionBindingQueryResponseMessage
- SessionBindingQueryResponseMessage(boolean, List<SimpleString>) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionBindingQueryResponseMessage
-
- SessionBindingQueryResponseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionBindingQueryResponseMessage
-
- sessionClosed() - Method in interface org.hornetq.core.client.HornetQClientMessageBundle
-
- SessionCloseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionCloseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionCloseMessage
-
- SessionCommitMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionCommitMessage
- SessionCommitMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionCommitMessage
-
- SessionConsumerCloseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionConsumerCloseMessage(long) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionConsumerCloseMessage
-
- SessionConsumerCloseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionConsumerCloseMessage
-
- SessionConsumerFlowCreditMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionConsumerFlowCreditMessage(long, int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionConsumerFlowCreditMessage
-
- SessionConsumerFlowCreditMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionConsumerFlowCreditMessage
-
- SessionContinuationMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionContinuationMessage
- SessionContinuationMessage(byte, byte[], boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionContinuationMessage
-
- SessionContinuationMessage(byte) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionContinuationMessage
-
- SessionCreateConsumerMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionCreateConsumerMessage(long, SimpleString, SimpleString, boolean, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- SessionCreateConsumerMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- SessionDeleteQueueMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionDeleteQueueMessage(SimpleString) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionDeleteQueueMessage
-
- SessionDeleteQueueMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionDeleteQueueMessage
-
- SessionExpireMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionExpireMessage(long, long) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionExpireMessage
-
- SessionExpireMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionExpireMessage
-
- SessionFailureListener - Interface in org.hornetq.api.core.client
-
A SessionFailureListener notifies the client when a failure occurred on the session.
- SessionForceConsumerDelivery - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionConsumerForceDelivery
- SessionForceConsumerDelivery(long, long) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionForceConsumerDelivery
-
- SessionForceConsumerDelivery() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionForceConsumerDelivery
-
- SessionIndividualAcknowledgeMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionIndividualAcknowledgeMessage(long, long, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionIndividualAcknowledgeMessage
-
- SessionIndividualAcknowledgeMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionIndividualAcknowledgeMessage
-
- sessionNotXA() - Method in interface org.hornetq.core.client.HornetQClientLogger
-
- SessionProducerCreditsFailMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionProducerCreditsFailMessage(int, SimpleString) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionProducerCreditsFailMessage
-
- SessionProducerCreditsFailMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionProducerCreditsFailMessage
-
- SessionProducerCreditsMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionProducerCreditsMessage(int, SimpleString) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionProducerCreditsMessage
-
- SessionProducerCreditsMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionProducerCreditsMessage
-
- SessionQueueQueryMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionQueueQueryMessage
- SessionQueueQueryMessage(SimpleString) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryMessage
-
- SessionQueueQueryMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryMessage
-
- SessionQueueQueryResponseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionQueueQueryResponseMessage
- SessionQueueQueryResponseMessage(QueueQueryResult) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- SessionQueueQueryResponseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionQueueQueryResponseMessage
-
- SessionReceiveClientLargeMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionReceiveClientLargeMessage(MessageInternal) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveClientLargeMessage
-
- SessionReceiveContinuationMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionSendContinuationMessage
- SessionReceiveContinuationMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveContinuationMessage
-
- SessionReceiveContinuationMessage(long, byte[], boolean, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveContinuationMessage
-
- SessionReceiveContinuationMessage(long, byte[], boolean, boolean, int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveContinuationMessage
-
- SessionReceiveLargeMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionReceiveLargeMessage
- SessionReceiveLargeMessage(MessageInternal) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveLargeMessage
-
- SessionReceiveLargeMessage(long, MessageInternal, long, int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveLargeMessage
-
- SessionReceiveMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionReceiveMessage(long, MessageInternal, int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveMessage
-
- SessionReceiveMessage(MessageInternal) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionReceiveMessage
-
- SessionRequestProducerCreditsMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionRequestProducerCreditsMessage(int, SimpleString) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionRequestProducerCreditsMessage
-
- SessionRequestProducerCreditsMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionRequestProducerCreditsMessage
-
- SessionSendContinuationMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionSendContinuationMessage
- SessionSendContinuationMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionSendContinuationMessage
-
- SessionSendContinuationMessage(MessageInternal, byte[], boolean, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionSendContinuationMessage
-
- SessionSendContinuationMessage(MessageInternal, byte[], boolean, boolean, long) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionSendContinuationMessage
-
- SessionSendLargeMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionSendLargeMessage(MessageInternal) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionSendLargeMessage
-
- SessionSendMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionSendMessage(MessageInternal, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionSendMessage
-
- SessionSendMessage(MessageInternal) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionSendMessage
-
- SessionUniqueAddMetaDataMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
A SessionUniqueAddMetaDataMessageV2
- SessionUniqueAddMetaDataMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionUniqueAddMetaDataMessage
-
- SessionUniqueAddMetaDataMessage(String, String) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionUniqueAddMetaDataMessage
-
- SessionXAAfterFailedMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
to be called after a failure on an XA Session
- SessionXAAfterFailedMessage(Xid) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAAfterFailedMessage
-
- SessionXAAfterFailedMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAAfterFailedMessage
-
- SessionXACommitMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXACommitMessage(Xid, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXACommitMessage
-
- SessionXACommitMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXACommitMessage
-
- SessionXAEndMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAEndMessage(Xid, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAEndMessage
-
- SessionXAEndMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAEndMessage
-
- SessionXAForgetMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAForgetMessage(Xid) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAForgetMessage
-
- SessionXAForgetMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAForgetMessage
-
- SessionXAGetInDoubtXidsResponseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAGetInDoubtXidsResponseMessage(List<Xid>) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAGetInDoubtXidsResponseMessage
-
- SessionXAGetInDoubtXidsResponseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAGetInDoubtXidsResponseMessage
-
- SessionXAGetTimeoutResponseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAGetTimeoutResponseMessage(int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAGetTimeoutResponseMessage
-
- SessionXAGetTimeoutResponseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAGetTimeoutResponseMessage
-
- SessionXAJoinMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAJoinMessage(Xid) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAJoinMessage
-
- SessionXAJoinMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAJoinMessage
-
- SessionXAPrepareMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAPrepareMessage(Xid) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAPrepareMessage
-
- SessionXAPrepareMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAPrepareMessage
-
- SessionXAResponseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAResponseMessage(boolean, int, String) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResponseMessage
-
- SessionXAResponseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResponseMessage
-
- SessionXAResumeMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAResumeMessage(Xid) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResumeMessage
-
- SessionXAResumeMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAResumeMessage
-
- SessionXARollbackMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXARollbackMessage(Xid) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXARollbackMessage
-
- SessionXARollbackMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXARollbackMessage
-
- SessionXASetTimeoutMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXASetTimeoutMessage(int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXASetTimeoutMessage
-
- SessionXASetTimeoutMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXASetTimeoutMessage
-
- SessionXASetTimeoutResponseMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXASetTimeoutResponseMessage(boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXASetTimeoutResponseMessage
-
- SessionXASetTimeoutResponseMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXASetTimeoutResponseMessage
-
- SessionXAStartMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SessionXAStartMessage(Xid) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAStartMessage
-
- SessionXAStartMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SessionXAStartMessage
-
- setAckBatchSize(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the acknowledgments batch size.
- setAckBatchSize(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setAddress(SimpleString) - Method in interface org.hornetq.api.core.Message
-
Sets the address to send this message to.
- setAddress(Message, SimpleString) - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- setAddress(Message, SimpleString) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- setAddress(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
The only reason this is synchronized is because of encoding a message versus invalidating the buffer.
- setAddress(SimpleString) - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- setAddressTransient(SimpleString) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- setAddressTransient(SimpleString) - Method in interface org.hornetq.core.message.impl.MessageInternal
-
- setAfterConnectionInternalListener(AfterConnectInternalListener) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setAfterConnectionInternalListener(AfterConnectInternalListener) - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- setAutoGroup(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets whether producers created through this factory will automatically
assign a group ID to the messages they sent.
- setAutoGroup(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setBackup(TransportConfiguration) - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- setBackupConnector(TransportConfiguration, TransportConfiguration) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- setBackupConnector(TransportConfiguration, TransportConfiguration) - Method in interface org.hornetq.core.client.impl.ClientSessionFactoryInternal
-
- setBlockOnAcknowledge(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets whether consumers created through this factory will block while
sending message acknowledgments or do it asynchronously.
- setBlockOnAcknowledge(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setBlockOnDurableSend(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets whether producers created through this factory will block while sending durable messages or do it asynchronously.
- setBlockOnDurableSend(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setBlockOnNonDurableSend(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets whether producers created through this factory will block while sending non-durable messages or do it asynchronously.
- setBlockOnNonDurableSend(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setBodyInputStream(InputStream) - Method in interface org.hornetq.api.core.client.ClientMessage
-
Sets the body's IntputStream.
- setBodyInputStream(InputStream) - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- setBroadcastPeriod(long) - Method in class org.hornetq.api.core.BroadcastGroupConfiguration
-
- setBrowseOnly(boolean) - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- setBuffer(HornetQBuffer) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setByte(int, byte) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setByte(int, byte) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setBytes(int, byte[], int, int) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setBytes(int, byte[]) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setBytes(int, ByteBuffer) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setBytes(int, HornetQBuffer, int, int) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setBytes(int, HornetQBuffer, int) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setBytes(int, HornetQBuffer) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setBytes(int, HornetQBuffer, int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setBytes(int, byte[], int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setBytes(int, ByteBuffer) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setBytes(int, byte[]) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setBytes(int, HornetQBuffer) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setBytes(int, HornetQBuffer, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setCacheLargeMessagesClient(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets whether large messages received by consumers created through this factory will be cached in temporary files or not.
- setCacheLargeMessagesClient(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setCallFailoverTimeout(long) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the blocking call failover timeout.
- setCallFailoverTimeout(long) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setCallTimeout(long) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the blocking call timeout.
- setCallTimeout(long) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setChannelID(long) - Method in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- setChannelID(long) - Method in interface org.hornetq.core.protocol.core.Packet
-
Sets the channel id that should be used once the packet has been successfully decoded it is
sent to the correct channel.
- setChar(int, char) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setChar(int, char) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setClientFailureCheckPeriod(long) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the period (in milliseconds) used to check if a client has failed to receive pings from
the server.
- setClientFailureCheckPeriod(long) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setClientID(String) - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- setClientVersion(int) - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
Sets the client protocol used on the communication.
- setClientVersion(int) - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- setCloseListeners(List<CloseListener>) - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- setCloseListeners(List<CloseListener>) - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
- setClusterConnection(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setClusterConnection(boolean) - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- setClusterTransportConfiguration(TransportConfiguration) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setClusterTransportConfiguration(TransportConfiguration) - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- setCommandConfirmationHandler(CommandConfirmationHandler) - Method in interface org.hornetq.core.protocol.core.Channel
-
sets the handler to use when a confirmation is received.
- setCommandConfirmationHandler(CommandConfirmationHandler) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- setCompressLargeMessage(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets whether to compress or not large messages.
- setCompressLargeMessage(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setConfirmationWindowSize(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the size for the confirmation window buffer of clients using this factory.
- setConfirmationWindowSize(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setConnectionLoadBalancingPolicyClassName(String) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the class name of the connection load balancing policy.
- setConnectionLoadBalancingPolicyClassName(String) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setConnectionTTL(long) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets this factory's connections time-to-live.
- setConnectionTTL(long) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setConnectorInfos(List<String>) - Method in class org.hornetq.api.core.BroadcastGroupConfiguration
-
- setConsiderLastMessageAsDelivered(boolean) - Method in class org.hornetq.core.protocol.core.impl.wireformat.RollbackMessage
-
- setConsumerMaxRate(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the maximum rate of message consumption for consumers created through this factory.
- setConsumerMaxRate(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setConsumerWindowSize(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the window size for flow control of the consumers created through this factory.
- setConsumerWindowSize(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setDeadLetterAddress(String) - Method in interface org.hornetq.api.core.management.QueueControl
-
Sets the dead-letter address associated to this queue to the specified deadLetterAddress.
- setDebugStream(PrintStream) - Method in class org.hornetq.core.filter.impl.FilterParserTokenManager
-
Set debug output.
- setDeliveryCount(int) - Method in interface org.hornetq.api.core.client.ClientMessage
-
Set the delivery count for this message.
- setDeliveryCount(int) - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- setDiscoveryInitialWaitTimeout(long) - Method in class org.hornetq.api.core.DiscoveryGroupConfiguration
-
- setDouble(int, double) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setDouble(int, double) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setDurable(boolean) - Method in interface org.hornetq.api.core.Message
-
Sets whether this message is durable or not.
- setDurable(boolean) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- setDurable(boolean) - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- setExecutor(Executor) - Method in class org.hornetq.core.client.impl.Topology
-
- setExpiration(long) - Method in interface org.hornetq.api.core.Message
-
Sets the expiration of this message.
- setExpiration(long) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- setExpiryAddress(String) - Method in interface org.hornetq.api.core.management.QueueControl
-
Sets the expiry address associated to this queue to the specified expiryAddress.
- setFailoverOnInitialConnection(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the value for FailoverOnInitialReconnection
- setFailoverOnInitialConnection(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setFailoverOnServerShutdown(boolean) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
do any clients failover on a server shutdown
- setFailureListeners(List<FailureListener>) - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- setFailureListeners(List<FailureListener>) - Method in interface org.hornetq.spi.core.protocol.RemotingConnection
-
set the failure listeners.
- setFilterString(SimpleString) - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- setFilterString(SimpleString) - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- setFloat(int, float) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setFloat(int, float) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setFlowControlSize(int) - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- setFlowControlSize(int) - Method in interface org.hornetq.core.client.impl.ClientMessageInternal
-
Size used for FlowControl
- setForceNotSameRM(boolean) - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- setForceNotSameRM(boolean) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- setGroupID(String) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the group ID that will be set on each message sent through this factory.
- setGroupID(String) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setHandler(ChannelHandler) - Method in interface org.hornetq.core.protocol.core.Channel
-
Sets the
ChannelHandler
that this channel should
forward received packets to.
- setHandler(ChannelHandler) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- setIdentity(String) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setIdentity(String) - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
Used to better identify Cluster Connection Locators on logs.
- setIndex(int, int) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setIndex(int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setInitialConnectAttempts(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the maximum number of attempts to establish an initial connection.
- setInitialConnectAttempts(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setInitialMessagePacketSize(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the initial size of messages created through this factory.
- setInitialMessagePacketSize(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setInt(int, int) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setInt(int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setInternalDate(long) - Method in class org.hornetq.utils.TimeAndCounterIDGenerator
-
- setInternalID(long) - Method in class org.hornetq.utils.TimeAndCounterIDGenerator
-
- setLargeMessageController(LargeMessageController) - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- setLargeMessageController(LargeMessageController) - Method in interface org.hornetq.core.client.impl.ClientLargeMessageInternal
-
- setLargeMessageSize(long) - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- setLargeMessageSize(long) - Method in interface org.hornetq.core.client.impl.ClientLargeMessageInternal
-
- setLive(TransportConfiguration) - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- setLocal(boolean) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setLong(int, long) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setLong(int, long) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setMaxElements(int) - Method in class org.hornetq.utils.SoftValueHashMap
-
- setMaxRetryInterval(long) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the maximum retry interval.
- setMaxRetryInterval(long) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setMessageCounterMaxDayCount(int) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Sets the maximum number of days kept in memory for message counter.
- setMessageCounterSamplePeriod(long) - Method in interface org.hornetq.api.core.management.HornetQServerControl
-
Sets the sample period to take message counter snapshot.
- setMessageHandler(MessageHandler) - Method in interface org.hornetq.api.core.client.ClientConsumer
-
Sets the MessageHandler for this consumer to consume messages asynchronously.
- setMessageHandler(MessageHandler) - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- setMinLargeMessageSize(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the large message size threshold.
- setMinLargeMessageSize(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setName(String) - Method in class org.hornetq.api.core.BroadcastGroupConfiguration
-
- setName(String) - Method in class org.hornetq.api.core.DiscoveryGroupConfiguration
-
- setNodeID(String) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setNodeID(String) - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- setOutputStream(OutputStream) - Method in interface org.hornetq.api.core.client.ClientMessage
-
Sets the OutputStream that will receive the content of a message received in a non blocking way.
- setOutputStream(OutputStream) - Method in class org.hornetq.core.client.impl.ClientLargeMessageImpl
-
- setOutputStream(OutputStream) - Method in class org.hornetq.core.client.impl.ClientMessageImpl
-
- setOutputStream(OutputStream) - Method in interface org.hornetq.core.client.impl.LargeMessageController
-
Sets the OutputStream of this buffer to the specified output.
- setOutputStream(OutputStream) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setOwner(Object) - Method in class org.hornetq.core.client.impl.Topology
-
The owner exists mainly for debug purposes.
- setPacketDecoder(PacketDecoder) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setPacketDecoder(PacketDecoder) - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- setPacketSize(int) - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
- setPacketSize(int) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- setPageCacheMaxSize(int) - Method in class org.hornetq.api.core.management.AddressSettingsInfo
-
- setPreAcknowledge(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets to true
to pre-acknowledge consumed messages on the
server before they are sent to consumers, else set to false
to let clients acknowledge the message they consume.
- setPreAcknowledge(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setPriority(byte) - Method in interface org.hornetq.api.core.Message
-
Sets the message priority.
- setPriority(byte) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- setProducerMaxRate(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the maximum rate of message production for producers created through this factory.
- setProducerMaxRate(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setProducerWindowSize(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Returns the window size for flow control of the producers created through this factory.
- setProducerWindowSize(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setQueueName(SimpleString) - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- setQueueName(SimpleString) - Method in class org.hornetq.core.protocol.core.impl.wireformat.SessionCreateConsumerMessage
-
- setReconnectAttempts(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the maximum number of attempts to retry connection in case of failure.
- setReconnectAttempts(int) - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- setReconnectAttempts(int) - Method in interface org.hornetq.core.client.impl.ClientSessionFactoryInternal
-
- setReconnectAttempts(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setRefreshTimeout(long) - Method in class org.hornetq.api.core.DiscoveryGroupConfiguration
-
- setRetryInterval(long) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the time to retry connections created by this factory after failure.
- setRetryInterval(long) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setRetryIntervalMultiplier(double) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the multiplier to apply to successive retry intervals.
- setRetryIntervalMultiplier(double) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setScheduledThreadPoolMaxSize(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the maximum size of the scheduled thread pool.
- setScheduledThreadPoolMaxSize(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setSendAcknowledgementHandler(SendAcknowledgementHandler) - Method in interface org.hornetq.api.core.client.ClientSession
-
Sets a SendAcknowledgementHandler
for this session.
- setSendAcknowledgementHandler(SendAcknowledgementHandler) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- setShort(int, short) - Method in class org.hornetq.core.buffers.impl.ResetLimitWrappedHornetQBuffer
-
- setShort(int, short) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- setStopSignal() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
Sets a stop signal to true.
- setStopSignal() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- setTabSize(int) - Method in class org.hornetq.core.filter.impl.SimpleCharStream
-
- setTemporary(boolean) - Method in class org.hornetq.core.protocol.core.impl.wireformat.CreateQueueMessage
-
- setThreadPoolMaxSize(int) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets the maximum size of the thread pool.
- setThreadPoolMaxSize(int) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setTimestamp(long) - Method in interface org.hornetq.api.core.Message
-
Sets the message timestamp.
- setTimestamp(long) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- setTransactionTimeout(int) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- setTransferring(boolean) - Method in interface org.hornetq.core.protocol.core.Channel
-
notifies the channel if it is transferring its connection.
- setTransferring(boolean) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- setType(byte) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- setUniqueEventID(long) - Method in class org.hornetq.core.client.impl.TopologyMemberImpl
-
- setUseGlobalPools(boolean) - Method in interface org.hornetq.api.core.client.ServerLocator
-
Sets whether this factory will use global thread pools (shared among all the factories in the same JVM)
or its own pools.
- setUseGlobalPools(boolean) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- setUserID(UUID) - Method in interface org.hornetq.api.core.Message
-
Sets the user ID
- setUserID(UUID) - Method in class org.hornetq.core.message.impl.MessageImpl
-
- setValue(Object) - Method in class org.hornetq.core.filter.impl.Identifier
-
- setZero(int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- SIMPLE_STRING - Static variable in interface org.hornetq.core.filter.impl.FilterParserConstants
-
RegularExpression Id.
- SIMPLE_STRING - Static variable in class org.hornetq.core.filter.impl.Operator
-
- SimpleCharStream - Class in org.hornetq.core.filter.impl
-
An implementation of interface CharStream, where the stream is assumed to
contain only ASCII characters (without unicode processing).
- SimpleCharStream(Reader, int, int, int) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleCharStream(Reader, int, int) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleCharStream(Reader) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, String, int, int, int) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, int, int, int) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, String, int, int) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, int, int) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream, String) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleCharStream(InputStream) - Constructor for class org.hornetq.core.filter.impl.SimpleCharStream
-
Constructor.
- SimpleIDGenerator - Class in org.hornetq.utils
-
A SimpleIDGenerator
- SimpleIDGenerator(long) - Constructor for class org.hornetq.utils.SimpleIDGenerator
-
- size - Variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- size() - Method in interface org.hornetq.utils.LinkedList
-
- size() - Method in class org.hornetq.utils.LinkedListImpl
-
- size() - Method in interface org.hornetq.utils.PriorityLinkedList
-
- size() - Method in class org.hornetq.utils.PriorityLinkedListImpl
-
- size() - Method in class org.hornetq.utils.SoftValueHashMap
-
- SizeFormatterUtil - Class in org.hornetq.utils
-
A SizeFormatterUtil
- SizeFormatterUtil() - Constructor for class org.hornetq.utils.SizeFormatterUtil
-
- sizeof(long) - Static method in class org.hornetq.utils.SizeFormatterUtil
-
- sizeOfNullableBoolean(Boolean) - Static method in class org.hornetq.utils.BufferHelper
-
- sizeOfNullableDouble(Double) - Static method in class org.hornetq.utils.BufferHelper
-
- sizeOfNullableInteger(Integer) - Static method in class org.hornetq.utils.BufferHelper
-
- sizeOfNullableLong(Long) - Static method in class org.hornetq.utils.BufferHelper
-
- sizeOfNullableSimpleString(String) - Static method in class org.hornetq.utils.BufferHelper
-
Size of a String as if it was a Nullable Simple String
- sizeOfSimpleString(String) - Static method in class org.hornetq.utils.BufferHelper
-
Size of a String as it if was a Simple String
- skip(long) - Method in class org.hornetq.utils.HornetQBufferInputStream
-
- skipBytes(int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- skipTo(char) - Method in class org.hornetq.utils.json.JSONTokener
-
Skip characters until the next character is the requested character.
- slice(int, int) - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- slice() - Method in class org.hornetq.core.client.impl.LargeMessageControllerImpl
-
- SoftValueHashMap<K,V extends SoftValueHashMap.ValueCache> - Class in org.hornetq.utils
-
A SoftValueHashMap
- SoftValueHashMap(int) - Constructor for class org.hornetq.utils.SoftValueHashMap
-
- SoftValueHashMap.ValueCache - Interface in org.hornetq.utils
-
- sortedKeys() - Method in class org.hornetq.utils.json.JSONObject
-
Get an enumeration of the keys of the JSONObject.
- specialToken - Variable in class org.hornetq.core.filter.impl.Token
-
This field is used to access special tokens that occur prior to this
token, but after the immediately preceding regular (non-special) token.
- splitHosts(String) - Static method in class org.hornetq.api.core.TransportConfiguration
-
Utility method for splitting a comma separated list of hosts
- SSL_ENABLED_PROP_NAME - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- SSLSupport - Class in org.hornetq.core.remoting.impl.ssl
-
- SSLSupport() - Constructor for class org.hornetq.core.remoting.impl.ssl.SSLSupport
-
- start() - Method in interface org.hornetq.api.core.client.ClientSession
-
Starts the session.
- start() - Method in interface org.hornetq.api.core.management.HornetQComponentControl
-
Starts this component.
- start() - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- start() - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- start() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- start(Xid, int) - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- start(Executor) - Method in class org.hornetq.core.client.impl.ServerLocatorImpl
-
- start(Executor) - Method in interface org.hornetq.core.client.impl.ServerLocatorInternal
-
- start() - Method in class org.hornetq.core.cluster.DiscoveryGroup
-
- start() - Method in class org.hornetq.core.remoting.impl.netty.NettyConnector
-
- start() - Method in interface org.hornetq.spi.core.remoting.Connector
-
starts the connector
- startCall() - Method in interface org.hornetq.core.client.impl.ClientSessionInternal
-
This is used internally to control and educate the user
about using the thread boundaries properly.
- startCall() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- staticFlag - Static variable in class org.hornetq.core.filter.impl.SimpleCharStream
-
Whether parser is static.
- STOMP_CONSUMERS_CREDIT - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- STOMP_DEFAULT_CONSUMERS_CREDIT - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- STOMP_ENABLE_MESSAGE_ID - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- STOMP_MIN_LARGE_MESSAGE_SIZE - Static variable in class org.hornetq.core.remoting.impl.netty.TransportConstants
-
- stop() - Method in interface org.hornetq.api.core.client.ClientSession
-
Stops the session.
- stop() - Method in interface org.hornetq.api.core.management.HornetQComponentControl
-
Stops this component.
- stop(boolean) - Method in class org.hornetq.core.client.impl.ClientConsumerImpl
-
- stop(boolean) - Method in interface org.hornetq.core.client.impl.ClientConsumerInternal
-
- stop() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl.CloseRunnable
-
- stop() - Method in class org.hornetq.core.client.impl.DelegatingSession
-
- stop() - Method in class org.hornetq.core.cluster.DiscoveryGroup
-
- stopPingingAfterOne() - Method in class org.hornetq.core.client.impl.ClientSessionFactoryImpl
-
- storeResult(Message, Object) - Static method in class org.hornetq.api.core.management.ManagementHelper
-
Used by HornetQ management service.
- STREAM_TYPE - Static variable in interface org.hornetq.api.core.Message
-
- stringExpression() - Method in class org.hornetq.core.filter.impl.FilterParser
-
- stringList(Set<SimpleString>) - Method in class org.hornetq.core.filter.impl.FilterParser
-
- stringLiteral() - Method in class org.hornetq.core.filter.impl.FilterParser
-
- stringSetToCommaListString(Set<String>) - Static method in class org.hornetq.utils.ConfigurationHelper
-
- stringToElement(String) - Static method in class org.hornetq.utils.XMLUtil
-
- stringToken(Set<SimpleString>) - Method in class org.hornetq.core.filter.impl.FilterParser
-
- stringToValue(String) - Static method in class org.hornetq.utils.json.JSONObject
-
Try to convert a string into a number, boolean, or null.
- stripCDATA(String) - Static method in class org.hornetq.utils.XMLUtil
-
- SUB - Static variable in class org.hornetq.core.filter.impl.Operator
-
- SUBSCRIBE_TOPOLOGY - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SUBSCRIBE_TOPOLOGY_V2 - Static variable in class org.hornetq.core.protocol.core.impl.PacketImpl
-
- SubscribeClusterTopologyUpdatesMessage - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SubscribeClusterTopologyUpdatesMessage(boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessage
-
- SubscribeClusterTopologyUpdatesMessage(byte, boolean) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessage
-
- SubscribeClusterTopologyUpdatesMessage() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessage
-
- SubscribeClusterTopologyUpdatesMessage(byte) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessage
-
- SubscribeClusterTopologyUpdatesMessageV2 - Class in org.hornetq.core.protocol.core.impl.wireformat
-
- SubscribeClusterTopologyUpdatesMessageV2(boolean, int) - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessageV2
-
- SubscribeClusterTopologyUpdatesMessageV2() - Constructor for class org.hornetq.core.protocol.core.impl.wireformat.SubscribeClusterTopologyUpdatesMessageV2
-
- supports(byte) - Method in interface org.hornetq.core.protocol.core.Channel
-
For protocol check
- supports(byte) - Method in class org.hornetq.core.protocol.core.impl.ChannelImpl
-
- SwitchTo(int) - Method in class org.hornetq.core.filter.impl.FilterParserTokenManager
-
Switch to specified lex state.
- syncIDGeneratorSequence(long) - Method in interface org.hornetq.core.protocol.core.CoreRemotingConnection
-
Resets the id generator used to generate id's.
- syncIDGeneratorSequence(long) - Method in class org.hornetq.core.protocol.core.impl.RemotingConnectionImpl
-
- syntaxError(String) - Method in class org.hornetq.utils.json.JSONTokener
-
Make a JSONException to signal a syntax error.