Skip navigation links
A B C D E F G H I J M N O P Q R S T U V W X 

A

acknowledge() - Method in interface javax.jms.Message
Acknowledges all consumed messages of the session of this consumed message.
ActiveFlowIndicationEvent - Class in com.solacesystems.jms.events
This event is used to indicate a change in the state of a bound SolQueueReceiver.
ActiveFlowIndicationEvent() - Constructor for class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
ActiveFlowIndicationEvent(int) - Constructor for class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
addSolEventListener(SolEventListener, long) - Method in interface com.solacesystems.jms.SolEventSource
Deprecated.
Registers a SolEventListener to receive events of types specified in eventTypeMask (possible types are defined in com.solacesystems.jms.SolEvent).
addSolEventListener(SolEventListener) - Method in interface com.solacesystems.jms.SolEventSource
Deprecated.
Registers a SolEventListener to receive all possible event types specified in com.solacesystems.jms.SolEvent.
AUTHENTICATION_SCHEME_BASIC - Static variable in interface com.solacesystems.jms.SupportedProperty
Username/Password based Authentication Scheme.
AUTHENTICATION_SCHEME_CLIENT_CERTIFICATE - Static variable in interface com.solacesystems.jms.SupportedProperty
Client certificate based Authentication Scheme.
AUTHENTICATION_SCHEME_GSS_KRB - Static variable in interface com.solacesystems.jms.SupportedProperty
Kerberos based Authentication Scheme.
AUTHENTICATION_SCHEME_OAUTH2 - Static variable in interface com.solacesystems.jms.SupportedProperty
OAuth 2.0 based Authentication Scheme.
AUTO_ACKNOWLEDGE - Static variable in interface javax.jms.Session
With this acknowledgment mode, the session automatically acknowledges a client's receipt of a message either when the session has successfully returned from a call to receive or when the message listener the session has called to process the message successfully returns.

B

BytesMessage - Interface in javax.jms
A BytesMessage object is used to send a message containing a stream of uninterpreted bytes.

C

clearBody() - Method in interface javax.jms.Message
Clears out the message body.
clearProperties() - Method in interface javax.jms.Message
Clears a message's properties.
CLIENT_ACKNOWLEDGE - Static variable in interface javax.jms.Session
With this acknowledgment mode, the client acknowledges a consumed message by calling the message's acknowledge method.
close() - Method in interface javax.jms.Connection
Closes the connection.
close() - Method in interface javax.jms.ConnectionConsumer
Closes the connection consumer.
close() - Method in interface javax.jms.MessageConsumer
Closes the message consumer.
close() - Method in interface javax.jms.MessageProducer
Closes the message producer.
close() - Method in interface javax.jms.QueueBrowser
Closes the QueueBrowser.
close() - Method in class javax.jms.QueueRequestor
Closes the QueueRequestor and its session.
close() - Method in interface javax.jms.Session
Closes the session.
close() - Method in class javax.jms.TopicRequestor
Closes the TopicRequestor and its session.
com.solacesystems.common.xa - package com.solacesystems.common.xa
 
com.solacesystems.jms - package com.solacesystems.jms
The Solace Java Message Service (JMS) implementation and samples.
com.solacesystems.jms.events - package com.solacesystems.jms.events
 
com.solacesystems.jms.impl - package com.solacesystems.jms.impl
 
com.solacesystems.jms.interceptors - package com.solacesystems.jms.interceptors
 
com.solacesystems.jndi - package com.solacesystems.jndi
 
commit() - Method in interface javax.jms.Session
Commits all messages done in this transaction and releases any locks currently held.
commit() - Method in interface javax.jms.XASession
Throws a TransactionInProgressException, since it should not be called for an XASession object.
ConfigurationException - Exception in com.solacesystems.jms
An exception thrown when a service is not correctly configured or an API is not supported.
ConfigurationException(String) - Constructor for exception com.solacesystems.jms.ConfigurationException
 
ConfigurationException(String, String) - Constructor for exception com.solacesystems.jms.ConfigurationException
 
Connection - Interface in javax.jms
A Connection object is a client's active connection to its JMS provider.
ConnectionConsumer - Interface in javax.jms
For application servers, Connection objects provide a special facility for creating a ConnectionConsumer (optional).
ConnectionFactory - Interface in javax.jms
A ConnectionFactory object encapsulates a set of connection configuration parameters that has been defined by an administrator.
ConnectionMetaData - Interface in javax.jms
A ConnectionMetaData object provides information describing the Connection object.
createBrowser(Queue) - Method in interface javax.jms.QueueSession
Creates a QueueBrowser object to peek at the messages on the specified queue.
createBrowser(Queue, String) - Method in interface javax.jms.QueueSession
Creates a QueueBrowser object to peek at the messages on the specified queue using a message selector.
createBrowser(Queue) - Method in interface javax.jms.Session
Creates a QueueBrowser object to peek at the messages on the specified queue.
createBrowser(Queue, String) - Method in interface javax.jms.Session
Creates a QueueBrowser object to peek at the messages on the specified queue using a message selector.
createBytesMessage() - Method in interface javax.jms.Session
Creates a BytesMessage object.
createConnection() - Method in interface javax.jms.ConnectionFactory
Creates a connection with the default user identity.
createConnection(String, String) - Method in interface javax.jms.ConnectionFactory
Creates a connection with the specified user identity.
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in interface javax.jms.Connection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Queue, String, ServerSessionPool, int) - Method in interface javax.jms.QueueConnection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Topic, String, ServerSessionPool, int) - Method in interface javax.jms.TopicConnection
Creates a connection consumer for this connection (optional operation).
createConnectionFactory() - Static method in class com.solacesystems.jms.SolJmsUtility
Creates a Solace proprietary implementation of a ConnectionFactory.
createConnectionFactory(Hashtable<?, ?>) - Static method in class com.solacesystems.jms.SolJmsUtility
Creates a Solace proprietary implementation of a ConnectionFactory given an environment.
createConnectionFactory(String, String, String, String, Hashtable<?, ?>) - Static method in class com.solacesystems.jms.SolJmsUtility
Creates a Solace proprietary implementation of a ConnectionFactory given connection parameters and an environment.
createConsumer(Destination) - Method in interface javax.jms.Session
Creates a MessageConsumer for the specified destination.
createConsumer(Destination, String) - Method in interface javax.jms.Session
Creates a MessageConsumer for the specified destination, using a message selector.
createConsumer(Destination, String, boolean) - Method in interface javax.jms.Session
Creates MessageConsumer for the specified destination, using a message selector.
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in interface javax.jms.Connection
Create a durable connection consumer for this connection (optional operation).
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in interface javax.jms.TopicConnection
Create a durable connection consumer for this connection (optional operation).
createDurableSubscriber(Topic, String) - Method in interface javax.jms.Session
Creates a durable subscriber to the specified topic.
createDurableSubscriber(Topic, String, String, boolean) - Method in interface javax.jms.Session
Creates a durable subscriber to the specified topic, using a message selector and specifying whether messages published by its own connection should be delivered to it.
createDurableSubscriber(Topic, String) - Method in interface javax.jms.TopicSession
Creates a durable subscriber to the specified topic.
createDurableSubscriber(Topic, String, String, boolean) - Method in interface javax.jms.TopicSession
Creates a durable subscriber to the specified topic, using a message selector or specifying whether messages published by its own connection should be delivered to it.
createMapMessage() - Method in interface javax.jms.Session
Creates a MapMessage object.
createMessage() - Method in interface javax.jms.Session
Creates a Message object.
createObjectMessage() - Method in interface javax.jms.Session
Creates an ObjectMessage object.
createObjectMessage(Serializable) - Method in interface javax.jms.Session
Creates an initialized ObjectMessage object.
createProducer(Destination) - Method in interface javax.jms.Session
Creates a MessageProducer to send messages to the specified destination.
createPublisher(Topic) - Method in interface javax.jms.TopicSession
Creates a publisher for the specified topic.
createQueue(String) - Static method in class com.solacesystems.jms.SolJmsUtility
Creates a Solace proprietary implementation of a queue given a queue name.
createQueue(String) - Method in interface javax.jms.QueueSession
Creates a queue identity given a Queue name.
createQueue(String) - Method in interface javax.jms.Session
Creates a queue identity given a Queue name.
createQueueConnection() - Method in interface javax.jms.QueueConnectionFactory
Creates a queue connection with the default user identity.
createQueueConnection(String, String) - Method in interface javax.jms.QueueConnectionFactory
Creates a queue connection with the specified user identity.
createQueueSession(boolean, int) - Method in interface javax.jms.QueueConnection
Creates a QueueSession object.
createQueueSession(boolean, int) - Method in interface javax.jms.XAQueueConnection
Creates an XAQueueSession object.
createReceiver(Queue) - Method in interface javax.jms.QueueSession
Creates a QueueReceiver object to receive messages from the specified queue.
createReceiver(Queue, String) - Method in interface javax.jms.QueueSession
Creates a QueueReceiver object to receive messages from the specified queue using a message selector.
createSender(Queue) - Method in interface javax.jms.QueueSession
Creates a QueueSender object to send messages to the specified queue.
createSession(boolean, int) - Method in interface javax.jms.Connection
Creates a Session object.
createSession(boolean, int) - Method in interface javax.jms.XAConnection
Creates an Session object.
createStreamMessage() - Method in interface javax.jms.Session
Creates a StreamMessage object.
createSubscriber(Topic) - Method in interface javax.jms.TopicSession
Creates a nondurable subscriber to the specified topic.
createSubscriber(Topic, String, boolean) - Method in interface javax.jms.TopicSession
Creates a nondurable subscriber to the specified topic, using a message selector or specifying whether messages published by its own connection should be delivered to it.
createTemporaryQueue() - Method in interface javax.jms.QueueSession
Creates a TemporaryQueue object.
createTemporaryQueue() - Method in interface javax.jms.Session
Creates a TemporaryQueue object.
createTemporaryTopic() - Method in interface javax.jms.Session
Creates a TemporaryTopic object.
createTemporaryTopic() - Method in interface javax.jms.TopicSession
Creates a TemporaryTopic object.
createTextMessage() - Method in interface javax.jms.Session
Creates a TextMessage object.
createTextMessage(String) - Method in interface javax.jms.Session
Creates an initialized TextMessage object.
createTopic(String) - Static method in class com.solacesystems.jms.SolJmsUtility
Creates a Solace proprietary implementation of a topic given a topic name.
createTopic(String) - Method in interface javax.jms.Session
Creates a topic identity given a Topic name.
createTopic(String) - Method in interface javax.jms.TopicSession
Creates a topic identity given a Topic name.
createTopicConnection() - Method in interface javax.jms.TopicConnectionFactory
Creates a topic connection with the default user identity.
createTopicConnection(String, String) - Method in interface javax.jms.TopicConnectionFactory
Creates a topic connection with the specified user identity.
createTopicSession(boolean, int) - Method in interface javax.jms.TopicConnection
Creates a TopicSession object.
createTopicSession(boolean, int) - Method in interface javax.jms.XATopicConnection
Creates an XATopicSession object.
createXAConnection() - Method in interface javax.jms.XAConnectionFactory
Creates an XAConnection with the default user identity.
createXAConnection(String, String) - Method in interface javax.jms.XAConnectionFactory
Creates an XA connection with the specified user identity.
createXAConnectionFactory() - Static method in class com.solacesystems.jms.SolJmsUtility
Creates a Solace proprietary implementation of an XAConnectionFactory.
createXAConnectionFactory(Hashtable<?, ?>) - Static method in class com.solacesystems.jms.SolJmsUtility
Creates a Solace proprietary implementation of an XAConnectionFactory given an environment.
createXAConnectionFactory(String, String, String, String, Hashtable<?, ?>) - Static method in class com.solacesystems.jms.SolJmsUtility
Creates a Solace proprietary implementation of an XAConnectionFactory given connection parameters and an environment.
createXAQueueConnection() - Method in interface javax.jms.XAQueueConnectionFactory
Creates an XA queue connection with the default user identity.
createXAQueueConnection(String, String) - Method in interface javax.jms.XAQueueConnectionFactory
Creates an XA queue connection with the specified user identity.
createXAQueueSession() - Method in interface javax.jms.XAQueueConnection
Creates an XAQueueSession object.
createXASession() - Method in interface javax.jms.XAConnection
Creates an XASession object.
createXATopicConnection() - Method in interface javax.jms.XATopicConnectionFactory
Creates an XA topic connection with the default user identity.
createXATopicConnection(String, String) - Method in interface javax.jms.XATopicConnectionFactory
Creates an XA topic connection with the specified user identity.
createXATopicSession() - Method in interface javax.jms.XATopicConnection
Creates an XATopicSession object.

D

DEFAULT_DELIVERY_MODE - Static variable in interface javax.jms.Message
The message producer's default delivery mode is PERSISTENT.
DEFAULT_KRB_SERVICE_NAME - Static variable in interface com.solacesystems.jms.SupportedProperty
The default value for the SupportedProperty.SOLACE_JMS_KRB_SERVICE_NAME property.
DEFAULT_PASSWORD - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
Default Password for the Connection
DEFAULT_PRIORITY - Static variable in interface javax.jms.Message
The message producer's default priority is 4.
DEFAULT_TIME_TO_LIVE - Static variable in interface javax.jms.Message
The message producer's default time to live is unlimited; the message never expires.
DEFAULT_USER - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
Default UserName for the Connection
delete() - Method in interface javax.jms.TemporaryQueue
Deletes this temporary queue.
delete() - Method in interface javax.jms.TemporaryTopic
Deletes this temporary topic.
DeliveryMode - Interface in javax.jms
The delivery modes supported by the JMS API are PERSISTENT and NON_PERSISTENT.
Destination - Interface in javax.jms
A Destination object encapsulates a provider-specific address.
dumpMessage(Message) - Static method in class com.solacesystems.jms.SolJmsUtility
Produces a human-readable dump of the message properties and its contents (can be quite large).
DUPS_OK_ACKNOWLEDGE - Static variable in interface javax.jms.Session
This acknowledgment mode instructs the session to lazily acknowledge the delivery of messages.

E

EC_ACCESS_DENIED_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The endpoint doesn't have the required permissions.
EC_BASIC_AUTHENTICATION_IS_SHUTDOWN - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The basic authentication is shut down.
EC_BROWSER_DIRECT_MISMATCH_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The browser is not supported with direct transport.
EC_CLIENT_CERTIFICATE_AUTHENTICATION_IS_SHUTDOWN - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The client certificate authentication is shut down.
EC_CLIENT_CERTIFICATE_DATE_INVALID - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The client certificate date is invalid.
EC_CLIENTID_ADMINISTRATIVELY_CONFIGURED_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The client id cannot be set because it is already administratively configured.
EC_CLIENTID_ALREADY_IN_USE_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The client id cannot be set because it is already in use.
EC_CLIENTID_INVALID_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The client id cannot be set because it is invalid.
EC_CLIENTID_NOT_SETTABLE_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The client id cannot be set because already invoked an operation on the connection.
EC_CLOSED_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The requested operation cannot be fulfilled because the underlying resource was stale or closed.
EC_DOCUMENT_TO_LARGE - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The message size is too large.
EC_DUPLICATE_SUBSCRIBER_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The subscriber already exists.
EC_ILLEGAL_DESTINATION_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The destination name is illegal.
EC_ILLEGAL_OPERATION_NON_TRANSACTED_SESSION_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The operation is illegal on a non-transacted session.
EC_ILLEGAL_OPERATION_TRANSACTED_SESSION_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The operation is illegal on a transacted session.
EC_ILLEGAL_STATE_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The requested operation cannot be fulfilled because the object on which it was performed is not in a state to support such an operation.
EC_INTERNAL_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
An internal error occurred.
EC_INVALID_SELECTOR_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The selector provided is invalid.
EC_INVALID_TTL_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The provided TTL value is invalid.
EC_KERBEROS_AUTHENTICATION_IS_SHUTDOWN - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Kerberos Authentication is shutdown Related JMS exception: JMSSecurityException
EC_LOGIN_FAILURE_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
There has been a general login failure to the appliance: authentication failed of unauthorized.
EC_MAX_TRANSACTED_SESSIONS_EXCEEDED_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Max Transacted Sessions exceeded.
EC_MAX_TRANSACTIONS_EXCEEDED_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Max transactions configured is exceeded.
EC_MESSAGE_FORMAT_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
A read operation or a type conversion error occurred on a Structured Data Type.
EC_MISMATCH_RESPECT_TTL_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Respect TTL settings conflicts with the operation attempted.
EC_NOLOCAL_DIRECT_MISMATCH_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
NoLocal attribute enabled is not supported with direct transport.
EC_NON_XASESSION_TO_XAENDPOINT_BIND_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Non-XA session cannot bind to an XA endpoint.
EC_NOT_CAPABLE_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The API is not capable to perform an operation because the operation is invalid in the API's or the appliance's state.
EC_NULL_MESSAGE_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The provided message parameter was null.
EC_QUEUE_NOT_FOUND_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The queue cannot be found.
EC_REPLICATION_IS_STANDBY_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Guaranteed publishing is not allowed when the Message VPN has a Replication standby state.
EC_SELECTOR_DIRECT_MISMATCH_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The selector is not supported with direct transport.
EC_SHUTDOWN_ENDPOINT_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The endpoint is shut down.
EC_SPOOL_OVER_QUOTA_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The client has attempted to publish to a spool which already over quota.
EC_TEMP_DESTINATION_DELETED_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The temporary destination doesn't exist any more.
EC_TEMP_DESTINATION_IN_USE_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Unable to delete a temporary destination because it is in use.
EC_TEMP_DESTINATION_NOT_CREATOR_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The connection used for the temporary destination is not the connection used to create it.
EC_TOO_MANY_SUBSCRIBERS_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The number of consumers has reached the limit.
EC_TOPIC_ENDPOINT_SELECTOR_MATCH_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Binding to a non-exclusive topic endpoint that is already bound with a different ingress selector.
EC_TOPIC_ENDPOINT_SUBSCRIPTION_MATCH_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Binding to a non-exclusive topic endpoint that is already bound with a different subscription.
EC_TRANSACTED_SESSION_DIRECT_MISMATCH_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Transacted sessions or XA sessions are not supported with direct transport.
EC_TRANSACTION_ROLLED_BACK_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The transaction rolled back unexpectedly.
EC_TRANSPORT_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Communication error with the Solace appliance due to an error condition or administrative operation.
EC_UNKNOWN_ENDPOINT_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
The referenced endpoint is not compatible with the API or the appliance's state.
EC_UNKNOWN_FLOW_NAME_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
An attempt to re-establish a publisher flow failed due to lack of publisher flow state recovered.
EC_UNKNOWN_TRANSACTED_SESSION_NAME_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
An attempt to re-establish a transacted session failed because the transacted session name is no longer known.
EC_UNTRUSTED_CLIENT_CERTIFICATE - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Untrusted Client Certificate.
EC_XASESSION_TO_LVQ_BIND_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
Binding to a Last Value Queue (LVQ) within an XASession is not allowed.
EC_XASESSION_TO_NON_XAENDPOINT_BIND_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
XA session cannot bind to a non-XA endpoint.
EC_XASESSION_TO_PARTITIONED_QUEUE_BIND_ERROR - Static variable in class com.solacesystems.jms.impl.SolJMSErrorCodes
XA Transacted Sessions Cannot Bind to Partitioned Queues.
equals(Object) - Method in class com.solacesystems.common.xa.SolXid
 
ExceptionListener - Interface in javax.jms
If a JMS provider detects a serious problem with a Connection object, it informs the Connection object's ExceptionListener, if one has been registered.

F

FLOW_ACTIVE - Static variable in class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
FLOW_INACTIVE - Static variable in class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
FLOW_STATE_MAX - Static variable in class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
fromByteArray(byte[]) - Static method in class com.solacesystems.jms.SolJmsUtility
Converts a byte array representing a serialized JMS Message into a JMS Message.
fromProperties(Properties) - Method in interface com.solacesystems.jms.SolConnectionFactory
Sets the properties based on values in a Properties instance.

G

GD_RECONNECT_FAIL_ACTION_AUTO_RETRY - Static variable in interface com.solacesystems.jms.SupportedProperty
Clear the publisher state and reconnect the publisher flow.
GD_RECONNECT_FAIL_ACTION_DISCONNECT - Static variable in interface com.solacesystems.jms.SupportedProperty
Close the connection, even if SOLCLIENT_SESSION_PROP_RECONNECT_RETRIES is configured to a non-zero value.
getAcknowledgeMode() - Method in interface javax.jms.Session
Returns the acknowledgement mode of the session.
getAllowDuplicateClientId() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether a duplicate client ID is allowed.
getAuthenticationScheme() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the authentication scheme.
getBodyLength() - Method in interface javax.jms.BytesMessage
Gets the number of bytes of the message body when the message is in read-only mode.
getBoolean(String) - Method in interface javax.jms.MapMessage
Returns the boolean value with the specified name.
getBooleanProperty(String) - Method in interface javax.jms.Message
Returns the value of the boolean property with the specified name.
getBranchQualifier() - Method in class com.solacesystems.common.xa.SolXid
 
getBrowserTimeoutInMS() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the maximum time in milliseconds for a QueueBrowser Enumeration.hasMoreElements() to wait for a message to arrive in the browser's local message buffer before returning.
getByte(String) - Method in interface javax.jms.MapMessage
Returns the byte value with the specified name.
getByteProperty(String) - Method in interface javax.jms.Message
Returns the value of the byte property with the specified name.
getBytes(String) - Method in interface javax.jms.MapMessage
Returns the byte array value with the specified name.
getCallbackOnIOThread() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether to call MessageListeners directly from the IO thread.
getChar(String) - Method in interface javax.jms.MapMessage
Returns the Unicode character value with the specified name.
getClientDescription() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the application description on the appliance for the data connection.
getClientID() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the client name on the appliance for the data connection.
getClientID() - Method in interface javax.jms.Connection
Gets the client identifier for this connection.
getCompressionLevel() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to enable and specify the ZLIB compression level.
getConnectRetries() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the total number of times to attempt and retry a connection when establishing an initial connection for a Session to a host router.
getConnectRetriesPerHost() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the number of times to retry data connection attempts to a single host before moving on to the next host in the list.
getConnectTimeoutInMillis() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the timeout in milliseconds on a data connection attempt.
getDataHostList(int) - Method in class com.solacesystems.jndi.SolJNDIInitialContextFactory.SolJNDIInitialContext
 
getDeliverToOne() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether sent messages are deliver to one.
getDeliverToOneOverride() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether to override deliver to one settings.
getDeliveryMode() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the delivery mode for sent messages.
getDeliveryMode() - Method in interface javax.jms.MessageProducer
Gets the producer's default delivery mode.
getDestination() - Method in interface javax.jms.MessageProducer
Gets the destination associated with this MessageProducer.
getDirectOptimized() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether to optimize the API for direct transport.
getDirectTransport() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether to use direct transport for non-persistent messages.
getDisableMessageID() - Method in interface javax.jms.MessageProducer
Gets an indication of whether message IDs are disabled.
getDisableMessageTimestamp() - Method in interface javax.jms.MessageProducer
Gets an indication of whether message timestamps are disabled.
getDmqEligible() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether sent messages are eligible for the dead message queue.
getDouble(String) - Method in interface javax.jms.MapMessage
Returns the double value with the specified name.
getDoubleProperty(String) - Method in interface javax.jms.Message
Returns the value of the double property with the specified name.
getDynamicDurables() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate whether durable topic endpoints or queues are to be created on the appliance when the corresponding Session.createDurableSubscriber() or Session.createQueue() is called.
getEffectiveProperty(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
Gets a property's value given its name.
getElidingEligible() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether sent messages are marked as eligible for eliding.
getEnumeration() - Method in interface javax.jms.QueueBrowser
Gets an enumeration for browsing the current queue messages in the order they would be received.
getEnvironment() - Method in interface com.solacesystems.jms.SolConnectionFactory
This method gets the environment that the ConnectionFactory may have.
getErrorCode() - Method in exception javax.jms.JMSException
Gets the vendor-specific error code.
getEventType() - Method in class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
getEventType() - Method in interface com.solacesystems.jms.events.SolEvent
Returns the event type of the SolEvent instance as defined by constants starting with SOLEVENT_TYPE_
getException() - Method in class com.solacesystems.jms.events.SolJMSEvent
Returns the exception associated with the event, if any.
getExceptionListener() - Method in interface javax.jms.Connection
Gets the ExceptionListener object for this connection.
getFloat(String) - Method in interface javax.jms.MapMessage
Returns the float value with the specified name.
getFloatProperty(String) - Method in interface javax.jms.Message
Returns the value of the float property with the specified name.
getFlowState() - Method in class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
getFormatId() - Method in class com.solacesystems.common.xa.SolXid
 
getFormmater() - Static method in class com.solacesystems.common.xa.SolXid
 
getGenerateSenderID() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to Indicates whether the client name should be included in the SenderID message header parameter.
getGlobalTransactionId() - Method in class com.solacesystems.common.xa.SolXid
 
getHost() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is the hostname / IP address of the appliance.
getInitialContext(Hashtable<?, ?>) - Method in class com.solacesystems.jndi.SolJNDIInitialContextFactory
Creates a Solace JMS Initial Context for beginning name resolution.
getInt(String) - Method in interface javax.jms.MapMessage
Returns the int value with the specified name.
getIntProperty(String) - Method in interface javax.jms.Message
Returns the value of the int property with the specified name.
getJCSMPProperties() - Method in class com.solacesystems.jndi.SolJNDIInitialContextFactory.SolJNDIInitialContext
 
getJMSCorrelationID() - Method in interface javax.jms.Message
Gets the correlation ID for the message.
getJMSCorrelationIDAsBytes() - Method in interface javax.jms.Message
Gets the correlation ID as an array of bytes for the message.
getJMSDeliveryMode() - Method in interface javax.jms.Message
Gets the DeliveryMode value specified for this message.
getJMSDestination() - Method in interface javax.jms.Message
Gets the Destination object for this message.
getJMSExpiration() - Method in interface javax.jms.Message
Gets the message's expiration value.
getJMSMajorVersion() - Method in interface javax.jms.ConnectionMetaData
Gets the JMS major version number.
getJMSMessageID() - Method in interface javax.jms.Message
Gets the message ID.
getJMSMinorVersion() - Method in interface javax.jms.ConnectionMetaData
Gets the JMS minor version number.
getJMSPriority() - Method in interface javax.jms.Message
Gets the message priority level.
getJMSProperties() - Method in class com.solacesystems.jndi.SolJNDIInitialContextFactory.SolJNDIInitialContext
 
getJMSProviderName() - Method in interface javax.jms.ConnectionMetaData
Gets the JMS provider name.
getJMSRedelivered() - Method in interface javax.jms.Message
Gets an indication of whether this message is being redelivered.
getJMSReplyTo() - Method in interface javax.jms.Message
Gets the Destination object to which a reply to this message should be sent.
getJMSTimestamp() - Method in interface javax.jms.Message
Gets the message timestamp.
getJMSType() - Method in interface javax.jms.Message
Gets the message type identifier supplied by the client when the message was sent.
getJMSVersion() - Method in interface javax.jms.ConnectionMetaData
Gets the JMS API version.
getJMSXPropertyNames() - Method in interface javax.jms.ConnectionMetaData
Gets an enumeration of the JMSX property names.
getJMSXUserIDEnabled() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether JMSXUserID property should be set.
getJNDIHostList() - Method in class com.solacesystems.jndi.SolJNDIInitialContextFactory.SolJNDIInitialContext
 
getKeepAliveCountMax() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the allowed number of consecutive keep-alive messages for which no response is received before the connection is closed by the API.
getKeepAliveIntervalInMillis() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the interval between keep alives in milliseconds.
getKeepAlives() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to enable/disable keep alives.
getKRBMutualAuthentication() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate that mutual authentication is to be used when Kerberos is enabled.
getKRBServiceName() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the ServiceName portion of the Service Principal Name (SPN) that has a format of ServiceName/ApplianceName@REALM.
getLargeMessaging() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to enable/disable publish/receive large AD messages.
getLargeMessagingConsumeTimeoutInMillis() - Method in interface com.solacesystems.jms.SolConnectionFactory
 
getLargeMessagingIncompletePolicy() - Method in interface com.solacesystems.jms.SolConnectionFactory
 
getLargeMessagingMaximumSize() - Method in interface com.solacesystems.jms.SolConnectionFactory
 
getLargeMessagingSegmentSize() - Method in interface com.solacesystems.jms.SolConnectionFactory
 
getLinkedException() - Method in exception javax.jms.JMSException
Gets the exception linked to this one.
getLong(String) - Method in interface javax.jms.MapMessage
Returns the long value with the specified name.
getLongProperty(String) - Method in interface javax.jms.Message
Returns the value of the long property with the specified name.
getMapNames() - Method in interface javax.jms.MapMessage
Returns an Enumeration of all the names in the MapMessage object.
getMessage() - Method in interface com.solacesystems.jms.interceptors.MessageProducerInterceptor.MessageProducerInterceptingContext
Gets originally published message.
getMessage() - Method in interface com.solacesystems.jms.interceptors.MessageReceiverInterceptor.ReceiverInterceptingContext
Gets originally published message before it is passed to the application using synchronous or asynchronous message handler.
getMessageListener() - Method in interface javax.jms.MessageConsumer
Gets the message consumer's MessageListener.
getMessageListener() - Method in interface javax.jms.Session
Returns the session's distinguished message listener (optional).
getMessageProducer() - Method in interface com.solacesystems.jms.interceptors.MessageProducerInterceptor.MessageProducerInterceptingContext
Gets MessageProducer instance that was used to send a message
getMessageSelector() - Method in interface javax.jms.MessageConsumer
Gets this message consumer's message selector expression.
getMessageSelector() - Method in interface javax.jms.QueueBrowser
Gets this queue browser's message selector expression.
getMessageSize(Message) - Static method in class com.solacesystems.jms.SolJmsUtility
Gets the encoded size of the message payload in bytes.
getMetaData() - Method in interface javax.jms.Connection
Gets the metadata for this connection.
getNoLocal() - Method in interface javax.jms.TopicSubscriber
Gets the NoLocal attribute for this subscriber.
getNumberOfUnackedMessages() - Method in class com.solacesystems.jms.events.SolRepublishUnackedMessageEvent
 
getObject(String) - Method in interface javax.jms.MapMessage
Returns the value of the object with the specified name.
getObject() - Method in interface javax.jms.ObjectMessage
Gets the serializable object containing this message's data.
getObjectProperty(String) - Method in interface javax.jms.Message
Returns the value of the Java object property with the specified name.
getPassword() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the password to connect to the appliance with.
getPassword() - Method in class com.solacesystems.jndi.SolJNDIInitialContextFactory.SolJNDIInitialContext
 
getPort() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the port to use for the data connection.
getPriority() - Method in interface javax.jms.MessageProducer
Gets the producer's default priority.
getProperty(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
Gets the property value given its name.
getPropertyNames() - Method in interface com.solacesystems.jms.SolConnectionFactory
Gets the property names for all the properties.
getPropertyNames() - Method in interface javax.jms.Message
Returns an Enumeration of all the property names.
getProviderMajorVersion() - Method in interface javax.jms.ConnectionMetaData
Gets the JMS provider major version number.
getProviderMinorVersion() - Method in interface javax.jms.ConnectionMetaData
Gets the JMS provider minor version number.
getProviderVersion() - Method in interface javax.jms.ConnectionMetaData
Gets the JMS provider version.
getQueue() - Method in interface javax.jms.QueueBrowser
Gets the queue associated with this queue browser.
getQueue() - Method in interface javax.jms.QueueReceiver
Gets the Queue associated with this queue receiver.
getQueue() - Method in interface javax.jms.QueueSender
Gets the queue associated with this QueueSender.
getQueueName() - Method in interface javax.jms.Queue
Gets the name of this queue.
getQueueSession() - Method in interface javax.jms.XAQueueSession
Gets the queue session associated with this XAQueueSession.
getReadTimeoutInMillis() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the timeout in milliseconds for reading a reply from the appliance.
getReceiveAdAckThreshold() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the threshold for sending an acknowledgement to the appliance.
getReceiveADAckTimerInMillis() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the duration of the acknowledgement timer.
getReceiveADWindowSize() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the size of the sliding acknowledgement window.
getReceiveBufferSize() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to configure the socket’s receive buffer size in bytes.
getReceiveReconnectRetries() - Method in interface com.solacesystems.jms.SolConnectionFactory
Gets how much time (in ms) to wait between each attempt to reconnect to an endpoint.
getReceiveReconnectRetryWaitInMillis() - Method in interface com.solacesystems.jms.SolConnectionFactory
Gets how much time (in ms) to wait between each attempt to reconnect to an endpoint.
getReconnectRetries() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the number of times to attempt a reconnect once the initial data connection to the appliance has been lost.
getReconnectRetryWaitInMillis() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the amount of time to wait in milliseconds between reconnect attempts.
getReference(Referenceable) - Method in interface com.solacesystems.jms.SolReferenceableDelegate
The ConnectionFactory, XAConnection, Topic, or Queue is given as the referenceable argument and can be cast to a SolConnectionFactory, SolXAConnectionFactory, SolTopic, or SolQueue.
getReferenceableDelegate() - Static method in class com.solacesystems.jms.SolJmsUtility
Gets the Referenceable delegate for ConnectionFactorys, Topics, and Queues.
getRespectTTL() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate whether dynamically created durable topic endpoints or queues are set to respect time to live (see Dynamic Durables).
getSendADAckTimerInMillis() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the duration of the acknowledgement timer in milliseconds.
getSendADMaxResends() - Method in interface com.solacesystems.jms.SolConnectionFactory
Deprecated.
getSendADWindowSize() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the size of the sliding acknowledgement window for non-persistent messages.
getSendBufferSize() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the socket’s send buffer size in bytes.
getServerSession() - Method in interface javax.jms.ServerSessionPool
Return a server session from the pool.
getServerSessionPool() - Method in interface javax.jms.ConnectionConsumer
Gets the server session pool associated with this connection consumer.
getSession() - Method in interface javax.jms.ServerSession
Return the ServerSession's Session.
getSession() - Method in interface javax.jms.XASession
Gets the session associated with this XASession.
getShort(String) - Method in interface javax.jms.MapMessage
Returns the short value with the specified name.
getShortProperty(String) - Method in interface javax.jms.Message
Returns the value of the short property with the specified name.
getSSLCipherSuites() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies a comma separated list of the cipher suites to enable in order of preference.
getSSLConnectionDowngradeTo() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies a transport protocol that SSL connection will be downgraded to after client authentication.
getSSLExcludedProtocols() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify a comma separated list of encryption protocol(s) to exclude from use.
getSSLKeyStore() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the key store to use in URL or path format.
getSSLKeyStoreFormat() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the format of the given key store.
getSSLKeyStoreNormalizedFormat() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the internal normalized format of the given key store.
getSSLKeyStorePassword() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the key store password to use.
getSSLPrivateKeyAlias() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies which private key in the key store is to be used for the client certificate authentication.
getSSLPrivateKeyPassword() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the password used to decipher the client certificate private key from the key store.
getSSLProtocol() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify a comma separated list of encryption protocol(s) to use.
getSSLTrustedCommonNameList() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the list of acceptable common names for matching in server certificates.
getSSLTrustStore() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the trust store to use in URL or path format.
getSSLTrustStoreFormat() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the format of the given trust store.
getSSLTrustStorePassword() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the trust store password to use.
getSSLValidateCertificate() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate that the API should validate server certificates with certificates in the trust store.
getSSLValidateCertificateDate() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate that the session connection should fail when an expired certificate or a certificate not yet in effect is received.
getSSLValidateCertificateHost() - Method in interface com.solacesystems.jms.SolConnectionFactory
This method is used to get the value of the SSLValidateCertificateHost property.
getString(String) - Method in interface javax.jms.MapMessage
Returns the String value with the specified name.
getStringProperty(String) - Method in interface javax.jms.Message
Returns the value of the String property with the specified name.
getSubscriberLocalPriority() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the priority that a client’s subscriptions have for receiving Deliver-To-One messages published on the Solace appliance that the client is directly connected to.
getSubscriberNetworkPriority() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the priority that a client’s subscriptions have for receiving Deliver-To-One messages published by other Solace appliances in the Solace Messaging Platform.
getTcpNoDelay() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify whether to set the TCP_NODELAY option.
getText() - Method in interface javax.jms.TextMessage
Gets the string containing this message's data.
getTimeToLive() - Method in interface javax.jms.MessageProducer
Gets the default length of time in milliseconds from its dispatch time that a produced message should be retained by the message system.
getTopic() - Method in interface javax.jms.TopicPublisher
Gets the topic associated with this TopicPublisher.
getTopic() - Method in interface javax.jms.TopicSubscriber
Gets the Topic associated with this subscriber.
getTopicName() - Method in interface javax.jms.Topic
Gets the name of this topic.
getTopicSession() - Method in interface javax.jms.XATopicSession
Gets the topic session associated with this XATopicSession.
getTransacted() - Method in interface javax.jms.Session
Indicates whether the session is in transacted mode.
getTransacted() - Method in interface javax.jms.XASession
Indicates whether the session is in transacted mode.
getType() - Method in class com.solacesystems.jms.events.SolJMSEvent
Returns the event type
getUnknownPublisherFlowAction() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies
getUseDefaultContext() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate whether to use a new context or reuse the default context for new JMS connections.
getUsername() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the username to connect to the appliance with.
getUsername() - Method in class com.solacesystems.jndi.SolJNDIInitialContextFactory.SolJNDIInitialContext
 
getVPN() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the VPN to use when connecting to the appliance.
getXA() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specified whether this is an XA Connection Factory.
getXAResource() - Method in interface javax.jms.XASession
Returns an XA resource to the caller.
getXmlPayload() - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether sent text messages have an XML payload.

H

handleEvent(SolEventSource, SolEvent) - Method in interface com.solacesystems.jms.SolEventListener
Deprecated.
Invoked when an event of interested is emitted by the SolEventSource instance
hashCode() - Method in class com.solacesystems.common.xa.SolXid
 

I

IllegalStateException - Exception in javax.jms
This exception is thrown when a method is invoked at an illegal or inappropriate time or if the provider is not in an appropriate state for the requested operation.
IllegalStateException(String, String) - Constructor for exception javax.jms.IllegalStateException
Constructs an IllegalStateException with the specified reason and error code.
IllegalStateException(String) - Constructor for exception javax.jms.IllegalStateException
Constructs an IllegalStateException with the specified reason.
InvalidClientIDException - Exception in javax.jms
This exception must be thrown when a client attempts to set a connection's client ID to a value that is rejected by a provider.
InvalidClientIDException(String, String) - Constructor for exception javax.jms.InvalidClientIDException
Constructs an InvalidClientIDException with the specified reason and error code.
InvalidClientIDException(String) - Constructor for exception javax.jms.InvalidClientIDException
Constructs an InvalidClientIDException with the specified reason.
InvalidDestinationException - Exception in javax.jms
This exception must be thrown when a destination either is not understood by a provider or is no longer valid.
InvalidDestinationException(String, String) - Constructor for exception javax.jms.InvalidDestinationException
Constructs an InvalidDestinationException with the specified reason and error code.
InvalidDestinationException(String) - Constructor for exception javax.jms.InvalidDestinationException
Constructs an InvalidDestinationException with the specified reason.
InvalidSelectorException - Exception in javax.jms
This exception must be thrown when a JMS client attempts to give a provider a message selector with invalid syntax.
InvalidSelectorException(String, String) - Constructor for exception javax.jms.InvalidSelectorException
Constructs an InvalidSelectorException with the specified reason and error code.
InvalidSelectorException(String) - Constructor for exception javax.jms.InvalidSelectorException
Constructs an InvalidSelectorException with the specified reason.
itemExists(String) - Method in interface javax.jms.MapMessage
Indicates whether an item exists in this MapMessage object.

J

javax.jms - package javax.jms
The standard JMS 1.1 API.
JMSException - Exception in javax.jms
This is the root class of all JMS API exceptions.
JMSException(String, String) - Constructor for exception javax.jms.JMSException
Constructs a JMSException with the specified reason and error code.
JMSException(String) - Constructor for exception javax.jms.JMSException
Constructs a JMSException with the specified reason and with the error code defaulting to null.
JMSSecurityException - Exception in javax.jms
This exception must be thrown when a provider rejects a user name/password submitted by a client.
JMSSecurityException(String, String) - Constructor for exception javax.jms.JMSSecurityException
Constructs a JMSSecurityException with the specified reason and error code.
JMSSecurityException(String) - Constructor for exception javax.jms.JMSSecurityException
Constructs a JMSSecurityException with the specified reason.
JMSX_DELIVERY_COUNT - Static variable in interface com.solacesystems.jms.SupportedProperty
The number of delivery attempts for this message.
JMSX_GROUP_ID - Static variable in interface com.solacesystems.jms.SupportedProperty
The identity of the message group this message is part of.
JMSX_GROUP_SEQ - Static variable in interface com.solacesystems.jms.SupportedProperty
The sequence number of this message within the group.
JMSX_USER_ID - Static variable in interface com.solacesystems.jms.SupportedProperty
The identity of the application sending the message.

M

main(String[]) - Static method in class com.solacesystems.common.xa.SolXid
 
MapMessage - Interface in javax.jms
A MapMessage object is used to send a set of name-value pairs.
Message - Interface in javax.jms
The Message interface is the root interface of all JMS messages.
MessageConsumer - Interface in javax.jms
A client uses a MessageConsumer object to receive messages from a destination.
MessageEOFException - Exception in javax.jms
This exception must be thrown when an unexpected end of stream has been reached when a StreamMessage or BytesMessage is being read.
MessageEOFException(String, String) - Constructor for exception javax.jms.MessageEOFException
Constructs a MessageEOFException with the specified reason and error code.
MessageEOFException(String) - Constructor for exception javax.jms.MessageEOFException
Constructs a MessageEOFException with the specified reason.
MessageFormatException - Exception in javax.jms
This exception must be thrown when a JMS client attempts to use a data type not supported by a message or attempts to read data in a message as the wrong type.
MessageFormatException(String, String) - Constructor for exception javax.jms.MessageFormatException
Constructs a MessageFormatException with the specified reason and error code.
MessageFormatException(String) - Constructor for exception javax.jms.MessageFormatException
Constructs a MessageFormatException with the specified reason.
MessageListener - Interface in javax.jms
A MessageListener object is used to receive asynchronously delivered messages.
MessageNotReadableException - Exception in javax.jms
This exception must be thrown when a JMS client attempts to read a write-only message.
MessageNotReadableException(String, String) - Constructor for exception javax.jms.MessageNotReadableException
Constructs a MessageNotReadableException with the specified reason and error code.
MessageNotReadableException(String) - Constructor for exception javax.jms.MessageNotReadableException
Constructs a MessageNotReadableException with the specified reason.
MessageNotWriteableException - Exception in javax.jms
This exception must be thrown when a JMS client attempts to write to a read-only message.
MessageNotWriteableException(String, String) - Constructor for exception javax.jms.MessageNotWriteableException
Constructs a MessageNotWriteableException with the specified reason and error code.
MessageNotWriteableException(String) - Constructor for exception javax.jms.MessageNotWriteableException
Constructs a MessageNotWriteableException with the specified reason.
MessageProducer - Interface in javax.jms
A client uses a MessageProducer object to send messages to a destination.
MessageProducerInterceptor - Interface in com.solacesystems.jms.interceptors
JMS message producer interceptor can be used to intercept the JMS message publishing process performed by any of the send method from a MessageProducer interface or its implementations.
MessageProducerInterceptor.MessageProducerInterceptingContext - Interface in com.solacesystems.jms.interceptors
Represents a mutable intercepting context associated with a single message publishing/send event.
MessageReceiverInterceptor - Interface in com.solacesystems.jms.interceptors
JMS message consumer interceptor that can be used to intercept JMS message consumption process.
MessageReceiverInterceptor.ReceiverInterceptingContext - Interface in com.solacesystems.jms.interceptors
Represents a mutable intercepting context associated with a single act of message receive.

N

NON_PERSISTENT - Static variable in interface javax.jms.DeliveryMode
This is the lowest-overhead delivery mode because it does not require that the message be logged to stable storage.

O

ObjectMessage - Interface in javax.jms
An ObjectMessage object is used to send a message that contains a serializable object in the Java programming language ("Java object").
onEvent(SolConnectionEvent) - Method in interface com.solacesystems.jms.SolConnectionEventListener
 
onEvent(SolConsumerEvent) - Method in interface com.solacesystems.jms.SolConsumerEventListener
Called when an event occurs.
onEvent(SolProducerEvent) - Method in interface com.solacesystems.jms.SolProducerEventListener
 
onException(JMSException) - Method in interface javax.jms.ExceptionListener
Notifies user of a JMS exception.
onMessage(Message) - Method in interface javax.jms.MessageListener
Passes a message to the listener.
onPrePublish(MessageProducerInterceptor.MessageProducerInterceptingContext) - Method in interface com.solacesystems.jms.interceptors.MessageProducerInterceptor
This method is executed after every call to send a message using MessageProducer before message is processed by the underlying Solace JMS API and send to its destination.
onPreReceive(MessageReceiverInterceptor.ReceiverInterceptingContext) - Method in interface com.solacesystems.jms.interceptors.MessageReceiverInterceptor
This method is executed right after every inbound message is received and before message is passed to the JMS application synchronously or asynchronously.

P

PERSISTENT - Static variable in interface javax.jms.DeliveryMode
This delivery mode instructs the JMS provider to log the message to stable storage as part of the client's send operation.
propertyExists(String) - Method in interface javax.jms.Message
Indicates whether a property value exists.
publish(Message) - Method in interface javax.jms.TopicPublisher
Publishes a message to the topic.
publish(Message, int, int, long) - Method in interface javax.jms.TopicPublisher
Publishes a message to the topic, specifying delivery mode, priority, and time to live.
publish(Topic, Message) - Method in interface javax.jms.TopicPublisher
Publishes a message to a topic for an unidentified message producer.
publish(Topic, Message, int, int, long) - Method in interface javax.jms.TopicPublisher
Publishes a message to a topic for an unidentified message producer, specifying delivery mode, priority and time to live.

Q

Queue - Interface in javax.jms
A Queue object encapsulates a provider-specific queue name.
QueueBrowser - Interface in javax.jms
A client uses a QueueBrowser object to look at messages on a queue without removing them.
QueueConnection - Interface in javax.jms
A QueueConnection object is an active connection to a point-to-point JMS provider.
QueueConnectionFactory - Interface in javax.jms
A client uses a QueueConnectionFactory object to create QueueConnection objects with a point-to-point JMS provider.
QueueReceiver - Interface in javax.jms
A client uses a QueueReceiver object to receive messages that have been delivered to a queue.
QueueRequestor - Class in javax.jms
The QueueRequestor helper class simplifies making service requests.
QueueRequestor(QueueSession, Queue) - Constructor for class javax.jms.QueueRequestor
Constructor for the QueueRequestor class.
QueueSender - Interface in javax.jms
A client uses a QueueSender object to send messages to a queue.
QueueSession - Interface in javax.jms
A QueueSession object provides methods for creating QueueReceiver, QueueSender, QueueBrowser, and TemporaryQueue objects.

R

readBoolean() - Method in interface javax.jms.BytesMessage
Reads a boolean from the bytes message stream.
readBoolean() - Method in interface javax.jms.StreamMessage
Reads a boolean from the stream message.
readByte() - Method in interface javax.jms.BytesMessage
Reads a signed 8-bit value from the bytes message stream.
readByte() - Method in interface javax.jms.StreamMessage
Reads a byte value from the stream message.
readBytes(byte[]) - Method in interface javax.jms.BytesMessage
Reads a byte array from the bytes message stream.
readBytes(byte[], int) - Method in interface javax.jms.BytesMessage
Reads a portion of the bytes message stream.
readBytes(byte[]) - Method in interface javax.jms.StreamMessage
Reads a byte array field from the stream message into the specified byte[] object (the read buffer).
readChar() - Method in interface javax.jms.BytesMessage
Reads a Unicode character value from the bytes message stream.
readChar() - Method in interface javax.jms.StreamMessage
Reads a Unicode character value from the stream message.
readDouble() - Method in interface javax.jms.BytesMessage
Reads a double from the bytes message stream.
readDouble() - Method in interface javax.jms.StreamMessage
Reads a double from the stream message.
readFloat() - Method in interface javax.jms.BytesMessage
Reads a float from the bytes message stream.
readFloat() - Method in interface javax.jms.StreamMessage
Reads a float from the stream message.
readInt() - Method in interface javax.jms.BytesMessage
Reads a signed 32-bit integer from the bytes message stream.
readInt() - Method in interface javax.jms.StreamMessage
Reads a 32-bit integer from the stream message.
readLong() - Method in interface javax.jms.BytesMessage
Reads a signed 64-bit integer from the bytes message stream.
readLong() - Method in interface javax.jms.StreamMessage
Reads a 64-bit integer from the stream message.
readObject() - Method in interface javax.jms.StreamMessage
Reads an object from the stream message.
readShort() - Method in interface javax.jms.BytesMessage
Reads a signed 16-bit number from the bytes message stream.
readShort() - Method in interface javax.jms.StreamMessage
Reads a 16-bit integer from the stream message.
readString() - Method in interface javax.jms.StreamMessage
Reads a String from the stream message.
readUnsignedByte() - Method in interface javax.jms.BytesMessage
Reads an unsigned 8-bit number from the bytes message stream.
readUnsignedShort() - Method in interface javax.jms.BytesMessage
Reads an unsigned 16-bit number from the bytes message stream.
readUTF() - Method in interface javax.jms.BytesMessage
Reads a string that has been encoded using a modified UTF-8 format from the bytes message stream.
receive() - Method in interface javax.jms.MessageConsumer
Receives the next message produced for this message consumer.
receive(long) - Method in interface javax.jms.MessageConsumer
Receives the next message that arrives within the specified timeout interval.
receiveNoWait() - Method in interface javax.jms.MessageConsumer
Receives the next message if one is immediately available.
recover() - Method in interface javax.jms.Session
Stops message delivery in this session, and restarts message delivery with the oldest unacknowledged message.
removeSolEventListener(SolEventListener) - Method in interface com.solacesystems.jms.SolEventSource
Deprecated.
Removes the previously added SolEventListner for all possible event types.
removeSolEventListener(SolEventListener, long) - Method in interface com.solacesystems.jms.SolEventSource
Deprecated.
Removes the previously added SolEventListner for the given eventTypeMask.
request(Message) - Method in class javax.jms.QueueRequestor
Sends a request and waits for a reply.
request(Message) - Method in class javax.jms.TopicRequestor
Sends a request and waits for a reply.
reset() - Method in interface javax.jms.BytesMessage
Puts the message body in read-only mode and repositions the stream of bytes to the beginning.
reset() - Method in interface javax.jms.StreamMessage
Puts the message body in read-only mode and repositions the stream to the beginning.
ResourceAllocationException - Exception in javax.jms
This exception is thrown when a provider is unable to allocate the resources required by a method.
ResourceAllocationException(String, String) - Constructor for exception javax.jms.ResourceAllocationException
Constructs a ResourceAllocationException with the specified reason and error code.
ResourceAllocationException(String) - Constructor for exception javax.jms.ResourceAllocationException
Constructs a ResourceAllocationException with the specified reason.
rollback() - Method in interface javax.jms.Session
Rolls back any messages done in this transaction and releases any locks currently held.
rollback() - Method in interface javax.jms.XASession
Throws a TransactionInProgressException, since it should not be called for an XASession object.
run() - Method in interface javax.jms.Session
Optional operation, intended to be used only by Application Servers, not by ordinary JMS clients.

S

send(Message) - Method in interface javax.jms.MessageProducer
Sends a message using the MessageProducer's default delivery mode, priority, and time to live.
send(Message, int, int, long) - Method in interface javax.jms.MessageProducer
Sends a message to the destination, specifying delivery mode, priority, and time to live.
send(Destination, Message) - Method in interface javax.jms.MessageProducer
Sends a message to a destination for an unidentified message producer.
send(Destination, Message, int, int, long) - Method in interface javax.jms.MessageProducer
Sends a message to a destination for an unidentified message producer, specifying delivery mode, priority and time to live.
send(Message) - Method in interface javax.jms.QueueSender
Sends a message to the queue.
send(Message, int, int, long) - Method in interface javax.jms.QueueSender
Sends a message to the queue, specifying delivery mode, priority, and time to live.
send(Queue, Message) - Method in interface javax.jms.QueueSender
Sends a message to a queue for an unidentified message producer.
send(Queue, Message, int, int, long) - Method in interface javax.jms.QueueSender
Sends a message to a queue for an unidentified message producer, specifying delivery mode, priority and time to live.
ServerSession - Interface in javax.jms
A ServerSession object is an application server object that is used by a server to associate a thread with a JMS session (optional).
ServerSessionPool - Interface in javax.jms
A ServerSessionPool object is an object implemented by an application server to provide a pool of ServerSession objects for processing the messages of a ConnectionConsumer (optional).
Session - Interface in javax.jms
A Session object is a single-threaded context for producing and consuming messages.
SESSION_TRANSACTED - Static variable in interface javax.jms.Session
This value is returned from the method getAcknowledgeMode if the session is transacted.
setAuthenticationScheme(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the authentication scheme.
setBoolean(String, boolean) - Method in interface javax.jms.MapMessage
Sets a boolean value with the specified name into the Map.
setBooleanProperty(String, boolean) - Method in interface javax.jms.Message
Sets a boolean property value with the specified name into the message.
setBrowserTimeoutInMS(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the maximum time in milliseconds for a QueueBrowser Enumeration.hasMoreElements() to wait for a message to arrive in the browser's local message buffer before returning.
setByte(String, byte) - Method in interface javax.jms.MapMessage
Sets a byte value with the specified name into the Map.
setByteProperty(String, byte) - Method in interface javax.jms.Message
Sets a byte property value with the specified name into the message.
setBytes(String, byte[]) - Method in interface javax.jms.MapMessage
Sets a byte array value with the specified name into the Map.
setBytes(String, byte[], int, int) - Method in interface javax.jms.MapMessage
Sets a portion of the byte array value with the specified name into the Map.
setCallbackOnIOThread(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether to call MessageListeners directly from the IO thread.
setChar(String, char) - Method in interface javax.jms.MapMessage
Sets a Unicode character value with the specified name into the Map.
setClientDescription(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the application description on the appliance for the data connection.
setClientID(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the client name on the appliance for the data connection.
setClientID(String) - Method in interface javax.jms.Connection
Sets the client identifier for this connection.
setCompressionLevel(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to enable and specify the ZLIB compression level.
setConnectionEventListener(SolConnectionEventListener) - Method in interface com.solacesystems.jms.SolConnectionEventSource
Called to set the SolConnectionEventListener on a connection.
setConnectRetries(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the total number of times to attempt and retry a connection when establishing an initial connection for a Session to a host router.
setConnectRetriesPerHost(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the number of times to retry data connection attempts to a single host before moving on to the next host in the list.
setConnectTimeoutInMillis(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the timeout in milliseconds on a data connection attempt.
setDeliverToOne(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether sent messages are deliver to one.
setDeliverToOneOverride(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether to override deliver to one settings.
setDeliveryMode(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the delivery mode for sent messages.
setDeliveryMode(int) - Method in interface javax.jms.MessageProducer
Sets the producer's default delivery mode.
setDirectOptimized(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether to optimize the API for direct transport.
setDirectTransport(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether to use direct transport for non-persistent messages.
setDisableMessageID(boolean) - Method in interface javax.jms.MessageProducer
Sets whether message IDs are disabled.
setDisableMessageTimestamp(boolean) - Method in interface javax.jms.MessageProducer
Sets whether message timestamps are disabled.
setDmqEligible(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether sent messages are eligible for the dead message queue.
setDouble(String, double) - Method in interface javax.jms.MapMessage
Sets a double value with the specified name into the Map.
setDoubleProperty(String, double) - Method in interface javax.jms.Message
Sets a double property value with the specified name into the message.
setDynamicDurables(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate whether durable topic endpoints or queues are to be created on the appliance when the corresponding Session.createDurableSubscriber() or Session.createQueue() is called.
setElidingEligible(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether sent messages are marked as eligible for eliding.
setExceptionListener(ExceptionListener) - Method in interface javax.jms.Connection
Sets an exception listener for this connection.
setFloat(String, float) - Method in interface javax.jms.MapMessage
Sets a float value with the specified name into the Map.
setFloatProperty(String, float) - Method in interface javax.jms.Message
Sets a float property value with the specified name into the message.
setFlowState(int) - Method in class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
setFormatter(XidFormatter) - Static method in class com.solacesystems.common.xa.SolXid
 
setGenerateSenderID(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to Indicates whether the client name should be included in the SenderID message header parameter.
setHost(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is the hostname / IP address of the appliance.
setInt(String, int) - Method in interface javax.jms.MapMessage
Sets an int value with the specified name into the Map.
setIntProperty(String, int) - Method in interface javax.jms.Message
Sets an int property value with the specified name into the message.
setJMSCorrelationID(String) - Method in interface javax.jms.Message
Sets the correlation ID for the message.
setJMSCorrelationIDAsBytes(byte[]) - Method in interface javax.jms.Message
Sets the correlation ID as an array of bytes for the message.
setJMSDeliveryMode(int) - Method in interface javax.jms.Message
Sets the DeliveryMode value for this message.
setJMSDestination(Destination) - Method in interface javax.jms.Message
Sets the Destination object for this message.
setJMSExpiration(long) - Method in interface javax.jms.Message
Sets the message's expiration value.
setJMSMessageID(String) - Method in interface javax.jms.Message
Sets the message ID.
setJMSPriority(int) - Method in interface javax.jms.Message
Sets the priority level for this message.
setJMSRedelivered(boolean) - Method in interface javax.jms.Message
Specifies whether this message is being redelivered.
setJMSReplyTo(Destination) - Method in interface javax.jms.Message
Sets the Destination object to which a reply to this message should be sent.
setJMSTimestamp(long) - Method in interface javax.jms.Message
Sets the message timestamp.
setJMSType(String) - Method in interface javax.jms.Message
Sets the message type.
setKeepAliveCountMax(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the allowed number of consecutive keep-alive messages for which no response is received before the connection is closed by the API.
setKeepAliveIntervalInMillis(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the interval between keep alives in milliseconds.
setKeepAlives(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to enable/disable keep alives.
setKRBMutualAuthentication(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate that mutual authentication is to be used when Kerberos is enabled.
setKRBServiceName(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the ServiceName portion of the Service Principal Name (SPN) that has a format of ServiceName/ApplianceName@REALM.
setLargeMessaging(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to enable/disable publish/receive large AD messages..
setLargeMessagingConsumeTimeoutInMillis(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
 
setLargeMessagingIncompletePolicy(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
 
setLargeMessagingMaximumSize(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
 
setLargeMessagingSegmentSize(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
 
setLinkedException(Exception) - Method in exception javax.jms.JMSException
Adds a linked Exception.
setLong(String, long) - Method in interface javax.jms.MapMessage
Sets a long value with the specified name into the Map.
setLongProperty(String, long) - Method in interface javax.jms.Message
Sets a long property value with the specified name into the message.
setMessageListener(MessageListener) - Method in interface javax.jms.MessageConsumer
Sets the message consumer's MessageListener.
setMessageListener(MessageListener) - Method in interface javax.jms.Session
Sets the session's distinguished message listener (optional).
setObject(String, Object) - Method in interface javax.jms.MapMessage
Sets an object value with the specified name into the Map.
setObject(Serializable) - Method in interface javax.jms.ObjectMessage
Sets the serializable object containing this message's data.
setObjectProperty(String, Object) - Method in interface javax.jms.Message
Sets a Java object property value with the specified name into the message.
setPassword(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the password to connect to the appliance with.
setPort(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the port to use for the data connection.
setPriority(int) - Method in interface javax.jms.MessageProducer
Sets the producer's default priority.
setProducerEventListener(SolProducerEventListener) - Method in interface com.solacesystems.jms.SolProducerEventSource
Called to set the SolProducerEventListener on a MessageProducer.
setProperty(String, Object) - Method in interface com.solacesystems.jms.SolConnectionFactory
Sets a property's value given its name.
setReadTimeoutInMillis(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the timeout in milliseconds for reading a reply from the appliance.
setReceiveAdAckThreshold(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the threshold for sending an acknowledgement to the appliance.
setReceiveADAckTimerInMillis(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the duration of the acknowledgement timer.
setReceiveADWindowSize(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the size of the sliding acknowledgement window.
setReceiveBufferSize(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to configure the socket’s receive buffer size in bytes.
setReceiveReconnectRetries(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the number of times to attempt to reconnect to an endpoint after the initial bound flow goes down.
setReceiveReconnectRetryWaitInMillis(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies how much time (in ms) to wait between each attempt to reconnect to an endpoint.
setReconnectRetries(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the number of times to attempt a reconnect once the initial data connection to the appliance has been lost.
setReconnectRetryWaitInMillis(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the amount of time to wait in milliseconds between reconnect attempts.
setReferenceableDelegate(SolReferenceableDelegate) - Static method in class com.solacesystems.jms.SolJmsUtility
Sets the Referenceable delegate for ConnectionFactorys, Topics, and Queues.
setRespectTTL(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate whether dynamically created durable topic endpoints or queues are set to respect time to live (see Dynamic Durables).
setSendADAckTimerInMillis(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the duration of the acknowledgement timer in milliseconds.
setSendADMaxResends(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
Deprecated.
setSendADWindowSize(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the size of the sliding acknowledgement window for non-persistent and transacted messages.
setSendBufferSize(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the socket’s send buffer size in bytes.
setShort(String, short) - Method in interface javax.jms.MapMessage
Sets a short value with the specified name into the Map.
setShortProperty(String, short) - Method in interface javax.jms.Message
Sets a short property value with the specified name into the message.
setSolConsumerEventListener(SolConsumerEventListener) - Method in interface com.solacesystems.jms.SolConsumerEventSource
Called to set the SolConsumerEventListener on a MessageConsumer.
setSSLCipherSuites(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies a comma separated list of the cipher suites to enable in order of preference.
setSSLConnectionDowngradeTo(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies a transport protocol that SSL connection will be downgraded to after client authentication.
setSSLExcludedProtocols(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify a comma separated list of encryption protocol(s) to exclude from use.
setSSLKeyStore(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the key store to use in URL or path format.
setSSLKeyStoreFormat(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the format of the given key store.
setSSLKeyStoreNormalizedFormat(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the internal normalized format of the given key store.
setSSLKeyStorePassword(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the key store password to use.
setSSLPrivateKeyAlias(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies which private key in the key store is to be used for the client certificate authentication.
setSSLPrivateKeyPassword(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the password used to decipher the client certificate private key from the key store.
setSSLProtocol(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify a comma separated list of encryption protocol(s) to use.
setSSLTrustedCommonNameList(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the list of acceptable common names for matching in server certificates.
setSSLTrustStore(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the trust store to use in URL or path format.
setSSLTrustStoreFormat(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the format of the given trust store.
setSSLTrustStorePassword(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the trust store password to use.
setSSLValidateCertificate(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate that the API should validate server certificates with certificates in the trust store.
setSSLValidateCertificateDate(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate that the session connection should fail when an expired certificate or a certificate not yet in effect is received.
setSSLValidateCertificateHost(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
Boolean property to indicate if the session connection should fail when a certificate with an invalid host is received.
setString(String, String) - Method in interface javax.jms.MapMessage
Sets a String value with the specified name into the Map.
setStringProperty(String, String) - Method in interface javax.jms.Message
Sets a String property value with the specified name into the message.
setSubscriberLocalPriority(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the priority that a client’s subscriptions have for receiving Deliver-To-One messages published on the Solace appliance that the client is directly connected to.
setSubscriberNetworkPriority(Integer) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies the priority that a client’s subscriptions have for receiving Deliver-To-One messages published by other Solace appliances in the Solace Messaging Platform.
setTcpNoDelay(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify whether to set the TCP_NODELAY option.
setText(String) - Method in interface javax.jms.TextMessage
Sets the string containing this message's data.
setTimeToLive(long) - Method in interface javax.jms.MessageProducer
Sets the default length of time in milliseconds from its dispatch time that a produced message should be retained by the message system.
setUnknownPublisherFlowAction(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies
setUseDefaultContext(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to indicate whether to use a new context or reuse the default context for new JMS connections.
setUsername(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the username to connect to the appliance with.
setVPN(String) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property is used to specify the VPN to use when connecting to the appliance.
setXmlPayload(Boolean) - Method in interface com.solacesystems.jms.SolConnectionFactory
This property specifies whether sent text messages have an XML payload.
SOL_CLIENT_ACKNOWLEDGE - Static variable in interface com.solacesystems.jms.SupportedProperty
A Solace defined message acknowledgement mode.
SOL_CLIENT_ACKNOWLEDGE_ALIAS - Static variable in interface com.solacesystems.jms.SupportedProperty
An alias of SOL_CLIENT_ACKNOWLEDGE.
SOLACE_JMS_AUTHENTICATION_SCHEME - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the authentication scheme.
SOLACE_JMS_BROWSER_TIMEOUT_IN_MS - Static variable in interface com.solacesystems.jms.SupportedProperty
Specifies the maximum time in milliseconds for a QueueBrowser Enumeration.hasMoreElements() to wait for a message to arrive in the browser's local message buffer before returning.
SOLACE_JMS_CLIENT_DESCRIPTION - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property that overrides the JNDI "Client Description" property.
SOLACE_JMS_COMPRESSION_LEVEL - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property (Integer value - default 0).
SOLACE_JMS_CONSUMER_DEFAULT_FLOW_CONGESTION_LIMIT - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional JVM property (Integer value - default 5000).
SOLACE_JMS_CONSUMER_DISPATCHER_QUEUE_SIZE - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional JVM property (Integer value - default 75000).
SOLACE_JMS_DELAYED_START_OVERRIDE - Static variable in interface com.solacesystems.jms.SupportedProperty
 
SOLACE_JMS_DELIVER_TO_ONE_OVERRIDE - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property that overrides the JNDI "Deliver To One Override" property.
SOLACE_JMS_DYNAMIC_DURABLES - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property that overrides the JNDI "Dynamic Durables" property.
SOLACE_JMS_GD_RECONNECT_FAIL_ACTION - Static variable in interface com.solacesystems.jms.SupportedProperty
A string property that indicates the behaviour when the API is unable to reconnect guaranteed delivery after reconnecting the session.
SOLACE_JMS_GENERATE_SENDER_ID - Static variable in interface com.solacesystems.jms.SupportedProperty
Indicates whether the client name should be included in the SenderID message header parameter.
SOLACE_JMS_JAAS_CONFIG_FILE_RELOAD_ENABLED - Static variable in interface com.solacesystems.jms.SupportedProperty
A boolean property when true indicates that the login configuration file is reloaded before connect or reconnect to the router.
SOLACE_JMS_JAAS_LOGIN_CONTEXT - Static variable in interface com.solacesystems.jms.SupportedProperty
A connection property that specifies a name that applications use to refer to the entry in a login configuration file when they instantiate a LoginContext.
SOLACE_JMS_JMS_MESSAGE_ID_MODE - Static variable in interface com.solacesystems.jms.SupportedProperty
This property controls the mode used for generating JMSMessageIDs.
SOLACE_JMS_JMS_MESSAGE_ID_MODE_ASCII_ENCODED_HASH - Static variable in interface com.solacesystems.jms.SupportedProperty
A mode for generating fixed length JMSMessageIDs that are 23 characters long.
SOLACE_JMS_JMS_MESSAGE_ID_MODE_DEFAULT - Static variable in interface com.solacesystems.jms.SupportedProperty
The default mode for generating JMSMessageIDs.
SOLACE_JMS_JNDI_CLIENT_DESCRIPTION - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the JNDI Connection Client Description.
SOLACE_JMS_JNDI_CLIENT_ID - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the JNDI Connection Client ID used to register with the appliance running in SolOS-TR.
SOLACE_JMS_JNDI_CONNECT_RETRIES - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the number of times to attempt to connect the JNDI Connection, when the first connect fails.
SOLACE_JMS_JNDI_CONNECT_RETRIES_PER_HOST - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the number of times to retry JNDI connection attempts to a single host before moving on to the next host in the list.
SOLACE_JMS_JNDI_CONNECT_TIMEOUT - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the timeout in milliseconds on a JNDI connection attempt.
SOLACE_JMS_JNDI_READ_TIMEOUT - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the timeout in milliseconds for reading a JNDI lookup reply from the router.
SOLACE_JMS_JNDI_RECONNECT_RETRIES - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the number of times to attempt a reconnect once the JNDI connection to the router has been lost.
SOLACE_JMS_JNDI_RECONNECT_RETRY_WAIT - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the amount of time to wait in milliseconds between reconnect attempts.
SOLACE_JMS_KRB_MUTUAL_AUTHENTICATION - Static variable in interface com.solacesystems.jms.SupportedProperty
 
SOLACE_JMS_KRB_SERVICE_NAME - Static variable in interface com.solacesystems.jms.SupportedProperty
This property is used to specify the ServiceName portion of the Service Principal Name (SPN) that has a format of ServiceName/ApplianceName@REALM.
SOLACE_JMS_LARGE_MESSAGING - Static variable in interface com.solacesystems.jms.SupportedProperty
 
SOLACE_JMS_LARGE_MESSAGING_CONSUME_TIMEOUT_IN_MILLIS - Static variable in interface com.solacesystems.jms.SupportedProperty
 
SOLACE_JMS_LARGE_MESSAGING_MAXIMUM_SIZE - Static variable in interface com.solacesystems.jms.SupportedProperty
 
SOLACE_JMS_LARGE_MESSAGING_PAYLOAD_SEGMENT_SIZE - Static variable in interface com.solacesystems.jms.SupportedProperty
 
SOLACE_JMS_LOCALHOST - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
Can be passed in as a System property to specify outgoing interface
SOLACE_JMS_LOCALHOST - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to set the IP address of the local interface to use.
SOLACE_JMS_MESSAGE_CONSUMER_INTERCEPTOR_CLASS_NAME - Static variable in interface com.solacesystems.jms.SupportedProperty
A connection String property that specifies a fully qualified class name of message consumer interceptor that implements MessageReceiverInterceptor interface.
SOLACE_JMS_MESSAGE_PRODUCER_INTERCEPTOR_CLASS_NAME - Static variable in interface com.solacesystems.jms.SupportedProperty
A connection String property that specifies a fully qualified class name of message producer interceptor that implements MessageProducerInterceptor interface.
SOLACE_JMS_MSG_CALLBACK_ON_IO_THREAD - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property to indicate that messages delivered asynchronously to a MessageListener are delivered directly from the I/O thread instead of a consumer notification thread.
SOLACE_JMS_OAUTH2_ACCESS_TOKEN - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the OAuth 2.0 access token.
SOLACE_JMS_OAUTH2_ISSUER_IDENTIFIER - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the OAuth 2.0 Issuer Identifier URI.
SOLACE_JMS_OIDC_ID_TOKEN - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the OIDC (OpenId Connect) ID Token.
SOLACE_JMS_OPTIMIZE_DIRECT - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property that overrides the JNDI "Optimize Direct" property.
SOLACE_JMS_PRODUCER_DISPATCHER_QUEUE_SIZE - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional JVM property (Integer value - default 2000).
SOLACE_JMS_PROP_DEAD_MSG_QUEUE_ELIGIBLE - Static variable in interface com.solacesystems.jms.SupportedProperty
Message property to indicate the message is eligible for a dead message queue.
SOLACE_JMS_PROP_DELIVER_TO_ONE - Static variable in interface com.solacesystems.jms.SupportedProperty
Message property to indicate whether the message is to be delivered to one client only.
SOLACE_JMS_PROP_ELIDING_ELIGIBLE - Static variable in interface com.solacesystems.jms.SupportedProperty
Message property to indicate the message is eligible for message eliding.
SOLACE_JMS_PROP_HTTP_CONTENT_ENCODING - Static variable in interface com.solacesystems.jms.SupportedProperty
A String property that indicates the HTTP content encoding.
SOLACE_JMS_PROP_HTTP_CONTENT_TYPE - Static variable in interface com.solacesystems.jms.SupportedProperty
A String property that indicates the HTTP content type.
SOLACE_JMS_PROP_IS_REPLY_MESSAGE - Static variable in interface com.solacesystems.jms.SupportedProperty
Message property specifying whether this message is a reply to a direct request message.
SOLACE_JMS_PROP_ISXML - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
Solace JMS defined Property
SOLACE_JMS_PROP_ISXML - Static variable in interface com.solacesystems.jms.SupportedProperty
Message property to indicate that TextMessages contain XML content.
SOLACE_JMS_PROP_ISXML - Static variable in interface javax.jms.TextMessage
Solace defined boolean property indicating that a TextMessage contains XML content.
SOLACE_JMS_PROP_MSG_DISCARD_INDICATION - Static variable in interface com.solacesystems.jms.SupportedProperty
Message property to indicate that a message has been discarded prior to the current one.
SOLACE_JMS_PROP_SENDER_ID - Static variable in interface com.solacesystems.jms.SupportedProperty
A String property that indicates the Sender ID.
SOLACE_JMS_PROP_TOPIC_SEQUENCE_NUMBER - Static variable in interface com.solacesystems.jms.SupportedProperty
Message property indicating the message's topic sequence number.
SOLACE_JMS_RECONNECT_FREQ_MANAGER_MAX_RECONNECTS - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional JVM property (Integer value - default 10).
SOLACE_JMS_RESPECT_TIME_TO_LIVE - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property that overrides the JNDI "Respect TTL" property.
SOLACE_JMS_SSL_CIPHER_SUITES - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying a comma separated list of the cipher suites to enable in order of preference.
SOLACE_JMS_SSL_CONNECTION_DOWNGRADE_TO - Static variable in interface com.solacesystems.jms.SupportedProperty
This property specifies a transport protocol that SSL session connection will be downgraded to after client authentication.
SOLACE_JMS_SSL_EXCLUDED_PROTOCOLS - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying a comma separated list of the encryption protocol(s) NOT to use.
SOLACE_JMS_SSL_KEY_STORE - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the keystore file to use in URL or path format.
SOLACE_JMS_SSL_KEY_STORE_FORMAT - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the keystore format to use.
SOLACE_JMS_SSL_KEY_STORE_NORMALIZED_FORMAT - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the internal keystore format to use.
SOLACE_JMS_SSL_KEY_STORE_PASSWORD - Static variable in interface com.solacesystems.jms.SupportedProperty
This property is used to specify the password of the keystore specified by SOLACE_JMS_SSL_KEY_STORE.
SOLACE_JMS_SSL_PRIVATE_KEY_ALIAS - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the private key alias.
SOLACE_JMS_SSL_PRIVATE_KEY_PASSWORD - Static variable in interface com.solacesystems.jms.SupportedProperty
This property is used to specify the password that deciphers the private key from the key store.
SOLACE_JMS_SSL_PROTOCOL - Static variable in interface com.solacesystems.jms.SupportedProperty
Deprecated. 
SOLACE_JMS_SSL_TRUST_STORE - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the truststore file to use in URL or path format.
SOLACE_JMS_SSL_TRUST_STORE_FORMAT - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the truststore format to use.
SOLACE_JMS_SSL_TRUST_STORE_PASSWORD - Static variable in interface com.solacesystems.jms.SupportedProperty
String property specifying the truststore password.
SOLACE_JMS_SSL_TRUSTED_COMMON_NAME_LIST - Static variable in interface com.solacesystems.jms.SupportedProperty
String array property specifying a comma separated list of up to 16 acceptable common names for matching in server certificates.
SOLACE_JMS_SSL_VALIDATE_CERTIFICATE - Static variable in interface com.solacesystems.jms.SupportedProperty
Boolean property when true indicates that the API should validate server certificates with certificates in the truststore.
SOLACE_JMS_SSL_VALIDATE_CERTIFICATE_DATE - Static variable in interface com.solacesystems.jms.SupportedProperty
Boolean property when true indicates that the session connection should fail when an expired certificate or a certificate not yet in effect is received.
SOLACE_JMS_SSL_VALIDATE_CERTIFICATE_HOST - Static variable in interface com.solacesystems.jms.SupportedProperty
Boolean property to indicate if the session connection should fail when a certificate with an invalid host is received.
SOLACE_JMS_SUBSCRIBER_LOCAL_DTO_PRIORITY - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property that overrides the JNDI "Subscriber Local Priority" property.
SOLACE_JMS_SUBSCRIBER_NETWORK_DTO_PRIORITY - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property that overrides the JNDI "Subscriber Network Priority" property.
SOLACE_JMS_TRANSPORT_PROTOCOL_PLAIN_TEXT - Static variable in interface com.solacesystems.jms.SupportedProperty
Plain Text transport protocol.
SOLACE_JMS_USE_DEFAULT_CONTEXT - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property (Boolean value - default false).
SOLACE_JMS_VPN - Static variable in interface com.solacesystems.jms.SupportedProperty
An Optional InitialContext environment property (String value - default null).
SOLACE_JNDI_CONNECT_RETRIES - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
 
SOLACE_JNDI_CONNECT_TIMEOUT - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
JNDI System Properties
SOLACE_JNDI_CONNECTION_RETRIES_PER_HOST - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
 
SOLACE_JNDI_READ_TIMEOUT - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
 
SOLACE_JNDI_RECONNECT_RETRIES - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
 
SOLACE_JNDI_RECONNECT_RETRY_WAIT - Static variable in interface com.solacesystems.jms.impl.SolJMSConstants
 
SolConnectionEvent - Class in com.solacesystems.jms.events
 
SolConnectionEvent.EventType - Enum in com.solacesystems.jms.events
 
SolConnectionEventListener - Interface in com.solacesystems.jms
A callback Listener for JMS Connection events.
SolConnectionEventSource - Interface in com.solacesystems.jms
The SolConnectionEventSource allows the application to set a SolConnectionEventListener, used to receive SolConnectionEvents.
SolConnectionFactory - Interface in com.solacesystems.jms
This is an interface to our proprietary implementation of a ConnectionFactory.
SolConsumerEvent - Class in com.solacesystems.jms.events
 
SolConsumerEvent.EventType - Enum in com.solacesystems.jms.events
 
SolConsumerEventListener - Interface in com.solacesystems.jms
A callback listener for JMS Consumer events.
SolConsumerEventSource - Interface in com.solacesystems.jms
The SolConsumerEventSource allows the application to set a SolConsumerEventListener, used to receive SolConsumerEvents.
SolEvent - Interface in com.solacesystems.jms.events
 
SOLEVENT_MASK_ALL - Static variable in interface com.solacesystems.jms.SolEventSource
Deprecated.
This mask will accept all event types
SOLEVENT_TYPE_ACTIVE_FLOW_INDICATION - Static variable in interface com.solacesystems.jms.events.SolEvent
These type of events are emitted by SolJMS QueueReceivers bound to a queue (not in a direct transport mode)
SolEventListener - Interface in com.solacesystems.jms
Deprecated.
This interface has been replaced by SolConsumerEventListener, which is simpler to use and uses a more traditional object-oriented approach.
SolEventSource - Interface in com.solacesystems.jms
Deprecated.
SolConsumerEventSource largely implements the same concepts provided by this class. It makes use of SolConsumerEventListener which replaced SolEventListener.
SolJMSConstants - Interface in com.solacesystems.jms.impl
SolJMSConstants defines all constants used in the implementation
SolJMSErrorCodes - Class in com.solacesystems.jms.impl
This class defines the Solace specific string error codes for JMS exceptions.
SolJMSErrorCodes() - Constructor for class com.solacesystems.jms.impl.SolJMSErrorCodes
 
SolJMSEvent<EventType> - Class in com.solacesystems.jms.events
 
SolJmsUtility - Class in com.solacesystems.jms
Utility functions for working with Solace JMS.
SolJNDIInitialContext() - Constructor for class com.solacesystems.jndi.SolJNDIInitialContextFactory.SolJNDIInitialContext
 
SolJNDIInitialContext(Hashtable<?, ?>) - Constructor for class com.solacesystems.jndi.SolJNDIInitialContextFactory.SolJNDIInitialContext
 
SolJNDIInitialContextFactory - Class in com.solacesystems.jndi
SolJNDIInitialContextFactory is the default implementation of InitialContextFactory for Solace JMS.
SolJNDIInitialContextFactory() - Constructor for class com.solacesystems.jndi.SolJNDIInitialContextFactory
 
SolJNDIInitialContextFactory.SolJNDIInitialContext - Class in com.solacesystems.jndi
 
SolProducerEvent - Class in com.solacesystems.jms.events
 
SolProducerEvent.EventType - Enum in com.solacesystems.jms.events
Producer event that can be given to the producer event listener ( SolProducerEventListener).
SolProducerEventListener - Interface in com.solacesystems.jms
A callback Listener for JMS Producer events.
SolProducerEventSource - Interface in com.solacesystems.jms
The SolProducerEventSource allows the application to set a SolProducerEventListener, used to receive SolProducerEvents.
SolQueue - Interface in com.solacesystems.jms
This is an interface to our proprietary implementation of a Queue.
SolReconnectedEvent - Class in com.solacesystems.jms.events
This event indicates that a previously established connection has successfully reconnected
SolReconnectedEvent() - Constructor for class com.solacesystems.jms.events.SolReconnectedEvent
 
SolReconnectingEvent - Class in com.solacesystems.jms.events
This event indicates that a previously established connection is currently reconnecting
SolReconnectingEvent() - Constructor for class com.solacesystems.jms.events.SolReconnectingEvent
 
SolReconnectingEvent(JMSException) - Constructor for class com.solacesystems.jms.events.SolReconnectingEvent
 
SolReferenceableDelegate - Interface in com.solacesystems.jms
This interface is used to override default implementations of the Referenceable.getReference() for ConnectionFactorys, Topics, and Queues.
SolRepublishUnackedMessageEvent - Class in com.solacesystems.jms.events
An event indicates that all unacknowledged messages are republished by the API.
SolRepublishUnackedMessageEvent(JMSException, Integer) - Constructor for class com.solacesystems.jms.events.SolRepublishUnackedMessageEvent
 
SolTopic - Interface in com.solacesystems.jms
This is an interface to our proprietary implementation of a Topic.
SolXAConnectionFactory - Interface in com.solacesystems.jms
This is an interface to our proprietary implementation of a ConnectionFactory.
SolXid - Class in com.solacesystems.common.xa
This class demonstrates how Solace XA can be used.
SolXid(int, byte[], byte[]) - Constructor for class com.solacesystems.common.xa.SolXid
 
SolXid(int, String, String) - Constructor for class com.solacesystems.common.xa.SolXid
 
start() - Method in interface javax.jms.Connection
Starts (or restarts) a connection's delivery of incoming messages.
start() - Method in interface javax.jms.ServerSession
Cause the Session's run method to be called to process messages that were just assigned to it.
stop() - Method in interface javax.jms.Connection
Temporarily stops a connection's delivery of incoming messages.
StreamMessage - Interface in javax.jms
A StreamMessage object is used to send a stream of primitive types in the Java programming language.
SupportedProperty - Interface in com.solacesystems.jms
The properties supported by Solace JMS.

T

TemporaryQueue - Interface in javax.jms
A TemporaryQueue object is a unique Queue object created for the duration of a Connection.
TemporaryTopic - Interface in javax.jms
A TemporaryTopic object is a unique Topic object created for the duration of a Connection.
TextMessage - Interface in javax.jms
A TextMessage object is used to send a message containing a java.lang.String.
toByteArray(Message) - Static method in class com.solacesystems.jms.SolJmsUtility
Serializes a JMS Message into a byte array.
toEffectiveString() - Method in interface com.solacesystems.jms.SolConnectionFactory
Returns a string representation of all the property values as if the method SolConnectionFactory.getEffectiveProperty(String) was used to retrieve them.
Topic - Interface in javax.jms
A Topic object encapsulates a provider-specific topic name.
TopicConnection - Interface in javax.jms
A TopicConnection object is an active connection to a publish/subscribe JMS provider.
TopicConnectionFactory - Interface in javax.jms
A client uses a TopicConnectionFactory object to create TopicConnection objects with a publish/subscribe JMS provider.
TopicPublisher - Interface in javax.jms
A client uses a TopicPublisher object to publish messages on a topic.
TopicRequestor - Class in javax.jms
The TopicRequestor helper class simplifies making service requests.
TopicRequestor(TopicSession, Topic) - Constructor for class javax.jms.TopicRequestor
Constructor for the TopicRequestor class.
TopicSession - Interface in javax.jms
A TopicSession object provides methods for creating TopicPublisher, TopicSubscriber, and TemporaryTopic objects.
TopicSubscriber - Interface in javax.jms
A client uses a TopicSubscriber object to receive messages that have been published to a topic.
toProperties() - Method in interface com.solacesystems.jms.SolConnectionFactory
Gets the properties in a Properties instance.
toString() - Method in class com.solacesystems.common.xa.SolXid
 
toString() - Method in class com.solacesystems.jms.events.ActiveFlowIndicationEvent
 
toString() - Method in interface com.solacesystems.jms.events.SolEvent
Returns a string representation of the event
toString() - Method in class com.solacesystems.jms.events.SolJMSEvent
Returns a string representation of the event
toString() - Method in interface javax.jms.Queue
Returns a string representation of this object.
toString() - Method in interface javax.jms.Topic
Returns a string representation of this object.
TransactionInProgressException - Exception in javax.jms
This exception is thrown when an operation is invalid because a transaction is in progress.
TransactionInProgressException(String, String) - Constructor for exception javax.jms.TransactionInProgressException
Constructs a TransactionInProgressException with the specified reason and error code.
TransactionInProgressException(String) - Constructor for exception javax.jms.TransactionInProgressException
Constructs a TransactionInProgressException with the specified reason.
TransactionRolledBackException - Exception in javax.jms
This exception must be thrown when a call to Session.commit results in a rollback of the current transaction.
TransactionRolledBackException(String, String) - Constructor for exception javax.jms.TransactionRolledBackException
Constructs a TransactionRolledBackException with the specified reason and error code.
TransactionRolledBackException(String) - Constructor for exception javax.jms.TransactionRolledBackException
Constructs a TransactionRolledBackException with the specified reason.

U

unsubscribe(String) - Method in interface javax.jms.Session
Unsubscribes a durable subscription that has been created by a client.
unsubscribe(String) - Method in interface javax.jms.TopicSession
Unsubscribes a durable subscription that has been created by a client.

V

valueOf(String) - Static method in enum com.solacesystems.jms.events.SolConnectionEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.solacesystems.jms.events.SolConsumerEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.solacesystems.jms.events.SolProducerEvent.EventType
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.solacesystems.jms.events.SolConnectionEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.solacesystems.jms.events.SolConsumerEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.solacesystems.jms.events.SolProducerEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.

W

writeBoolean(boolean) - Method in interface javax.jms.BytesMessage
Writes a boolean to the bytes message stream as a 1-byte value.
writeBoolean(boolean) - Method in interface javax.jms.StreamMessage
Writes a boolean to the stream message.
writeByte(byte) - Method in interface javax.jms.BytesMessage
Writes a byte to the bytes message stream as a 1-byte value.
writeByte(byte) - Method in interface javax.jms.StreamMessage
Writes a byte to the stream message.
writeBytes(byte[]) - Method in interface javax.jms.BytesMessage
Writes a byte array to the bytes message stream.
writeBytes(byte[], int, int) - Method in interface javax.jms.BytesMessage
Writes a portion of a byte array to the bytes message stream.
writeBytes(byte[]) - Method in interface javax.jms.StreamMessage
Writes a byte array field to the stream message.
writeBytes(byte[], int, int) - Method in interface javax.jms.StreamMessage
Writes a portion of a byte array as a byte array field to the stream message.
writeChar(char) - Method in interface javax.jms.BytesMessage
Writes a char to the bytes message stream as a 2-byte value, high byte first.
writeChar(char) - Method in interface javax.jms.StreamMessage
Writes a char to the stream message.
writeDouble(double) - Method in interface javax.jms.BytesMessage
Converts the double argument to a long using the doubleToLongBits method in class Double, and then writes that long value to the bytes message stream as an 8-byte quantity, high byte first.
writeDouble(double) - Method in interface javax.jms.StreamMessage
Writes a double to the stream message.
writeFloat(float) - Method in interface javax.jms.BytesMessage
Converts the float argument to an int using the floatToIntBits method in class Float, and then writes that int value to the bytes message stream as a 4-byte quantity, high byte first.
writeFloat(float) - Method in interface javax.jms.StreamMessage
Writes a float to the stream message.
writeInt(int) - Method in interface javax.jms.BytesMessage
Writes an int to the bytes message stream as four bytes, high byte first.
writeInt(int) - Method in interface javax.jms.StreamMessage
Writes an int to the stream message.
writeLong(long) - Method in interface javax.jms.BytesMessage
Writes a long to the bytes message stream as eight bytes, high byte first.
writeLong(long) - Method in interface javax.jms.StreamMessage
Writes a long to the stream message.
writeObject(Object) - Method in interface javax.jms.BytesMessage
Writes an object to the bytes message stream.
writeObject(Object) - Method in interface javax.jms.StreamMessage
Writes an object to the stream message.
writeShort(short) - Method in interface javax.jms.BytesMessage
Writes a short to the bytes message stream as two bytes, high byte first.
writeShort(short) - Method in interface javax.jms.StreamMessage
Writes a short to the stream message.
writeString(String) - Method in interface javax.jms.StreamMessage
Writes a String to the stream message.
writeUTF(String) - Method in interface javax.jms.BytesMessage
Writes a string to the bytes message stream using UTF-8 encoding in a machine-independent manner.

X

XAConnection - Interface in javax.jms
The XAConnection interface extends the capability of Connection by providing an XASession (optional).
XAConnectionFactory - Interface in javax.jms
The XAConnectionFactory interface is a base interface for the XAQueueConnectionFactory and XATopicConnectionFactory interfaces.
XAQueueConnection - Interface in javax.jms
An XAQueueConnection provides the same create options as QueueConnection (optional).
XAQueueConnectionFactory - Interface in javax.jms
An XAQueueConnectionFactory provides the same create options as a QueueConnectionFactory (optional).
XAQueueSession - Interface in javax.jms
An XAQueueSession provides a regular QueueSession, which can be used to create QueueReceiver, QueueSender, and QueueBrowser objects (optional).
XASession - Interface in javax.jms
The XASession interface extends the capability of Session by adding access to a JMS provider's support for the Java Transaction API (JTA) (optional).
XATopicConnection - Interface in javax.jms
An XATopicConnection provides the same create options as TopicConnection (optional).
XATopicConnectionFactory - Interface in javax.jms
An XATopicConnectionFactory provides the same create options as a TopicConnectionFactory (optional).
XATopicSession - Interface in javax.jms
An XATopicSession provides a regular TopicSession.
A B C D E F G H I J M N O P Q R S T U V W X 
Skip navigation links

Copyright 2004-2024 Solace Corporation. All rights reserved.