Package | Description |
---|---|
com.solace.messaging |
A root API package that contains interfaces and classes for developing Java applications using
Solace PubSub Messaging Java Client
|
com.solace.messaging.config |
A package of interfaces to configure PubSub+ messages, receivers, and publishers.
|
com.solace.messaging.publisher |
A package that contains interfaces and classes to handle publishing messages.
|
com.solace.messaging.receiver |
A package that contains interfaces and classes to handle receiving messages.
|
com.solace.messaging.util |
A package that contains interfaces and classes of utilities required to work with other PubSub+
Messaging APIs.
|
Modifier and Type | Class and Description |
---|---|
static class |
PubSubPlusClientException.AuthenticationException
A class for raising errors when client authentication fails.
|
static class |
PubSubPlusClientException.AuthorizationException
A class for raising errors when client authorizations fails, client authorizations unsupported
or not enabled for the service
|
static class |
PubSubPlusClientException.IncompatibleMessageException
A class for raising errors for clients that have received incompatible messages.
|
static class |
PubSubPlusClientException.IncompleteMessageDeliveryException
A class for raising errors when a publisher or receiver has been terminated gracefully, but
there are messages left in the buffer.
|
static class |
PubSubPlusClientException.InvalidConfigurationException
A class for raising errors for invalid configuration.
|
static class |
PubSubPlusClientException.MessageDestinationDoesNotExistException
A class for raising errors for messages with a destination that does not exist.
|
static class |
PubSubPlusClientException.MessageNotAcknowledgedByBrokerException
A class for raising errors when a broker does not acknowledge a message.
|
static class |
PubSubPlusClientException.MessageRejectedByBrokerException
A class for raising errors when a broker rejects a message.
|
static class |
PubSubPlusClientException.MessageReplayException
A class for raising message replay related errors
|
static class |
PubSubPlusClientException.MessageTooBigException
A class for raising errors when a message too large.
|
static class |
PubSubPlusClientException.MissingResourceException
A class for raising errors when a remote resource like a queue, vpn is not found on a broker.
|
static class |
PubSubPlusClientException.PublisherOverflowException
A class for raising errors when the broker is unable to publish a message because the transport
is full and buffer space is not available.
|
static class |
PubSubPlusClientException.PubSubPlusClientIOException
A class for raising errors for I/O errors that occur between a messaging broker and a client.
|
static class |
PubSubPlusClientException.RequestInterruptedException
A class for raising errors when a request operation was interrupted.
|
static class |
PubSubPlusClientException.ResourceProvisioningException
A class for raising errors when provisioning of resources on a broker failed
|
static class |
PubSubPlusClientException.ServiceCapabilityException
A class for service capability exceptions mostly due to missing permissions on vpn or user
account.
|
static class |
PubSubPlusClientException.ServiceDownException
A class for raising errors when a messaging broker is not reachable or service is down
(unavailable).
|
static class |
PubSubPlusClientException.ServiceUnreachableException
A class for raising errors for services that are unreachable.
|
static class |
PubSubPlusClientException.TimeoutException
A class for raising errors when a time-out occurs.
|
static class |
PubSubPlusClientException.UnsupportedAuthorizationException
A class for raising errors when client authorizations unsupported or not enabled for the
service.
|
Modifier and Type | Method and Description |
---|---|
PubSubPlusClientException |
MessagingService.ServiceEvent.getCause()
Retrieves the cause of the client exception if any.
|
static PubSubPlusClientException |
PubSubPlusClientException.of(Throwable t)
Converts a given exception to the appropriate
PubSubPlusClientException . |
Modifier and Type | Method and Description |
---|---|
RequestReplyMessagePublisher |
RequestReplyMessagePublisherBuilder.build()
Builds a request-reply message publisher.
|
PersistentMessagePublisher |
PersistentMessagePublisherBuilder.build()
Creates an instance of
PersistentMessagePublisher . |
MessagingService |
MessagingServiceClientBuilder.build()
Creates a PubSub+ messaging service connector based on the provided configuration.
|
DirectMessageReceiver |
DirectMessageReceiverBuilder.build()
Creates a new instance of
DirectMessageReceiver based on the provided configuration, to
be used in applications when distribution of messages among different application instances for
horizontal scalability purposes does not matter. |
DirectMessagePublisher |
DirectMessagePublisherBuilder.build()
Builds a new instance of
DirectMessagePublisher based on the provided configuration. |
PersistentMessageReceiver |
PersistentMessageReceiverBuilder.build(Queue endpointToConsumeFrom)
Creates an instance of
PersistentMessageReceiver . |
MessageQueueBrowser |
MessageQueueBrowserBuilder.build(Queue endpointToConsumeFrom)
Creates an instance of
MessageQueueBrowser . |
DirectMessageReceiver |
DirectMessageReceiverBuilder.build(ShareName shareName)
Creates a new instance of
DirectMessageReceiver to be used in applications designed
with horizontal scalability in mind with more than one instance running. |
MessagingService |
MessagingServiceClientBuilder.build(String clientName)
Creates a PubSub+ messaging service connector based on the provided configuration to expose the
identity of the application using the provided configuration to fulfill the messaging needs.
|
RequestReplyMessageReceiver |
RequestReplyMessageReceiverBuilder.build(TopicSubscription requestTopicSubscription)
Builds a request-reply message receiver with the specified topic subscription.
|
RequestReplyMessageReceiver |
RequestReplyMessageReceiverBuilder.build(TopicSubscription requestTopicSubscription,
ShareName shareName)
Builds a request-reply message receiver with a shared topic subscription and the shared name.
|
MessagingService |
MessagingService.connect() |
<MessagingService> |
MessagingService.connectAsync() |
<MessagingService> |
MessagingService.connectAsync(CompletionListener<MessagingService> connectionListener) |
void |
MessagingService.updateProperty(String property,
Object value)
Sets a modifiable service property once the service has been created.
|
Modifier and Type | Method and Description |
---|---|
void |
UpdatableConfiguration.updateProperty(String property,
Object value)
Updates configuration property.
|
Modifier and Type | Method and Description |
---|---|
PubSubPlusClientException |
PersistentMessagePublisher.PublishReceipt.getException()
Gets exception if any, indicating failure case
|
PubSubPlusClientException |
DirectMessagePublisher.FailedPublishEvent.getException()
Retrieves the exception that's associated with a given event.
|
Modifier and Type | Method and Description |
---|---|
void |
RequestReplyMessagePublisher.ReplyMessageHandler.onMessage(InboundMessage message,
Object userContext,
PubSubPlusClientException exception)
The callback to handle a reply message.
|
Modifier and Type | Method and Description |
---|---|
void |
PersistentMessagePublisher.publish(byte[] message,
Topic destination)
Sends a persistent byte-array message to the given destination using defaults.
|
void |
DirectMessagePublisher.publish(byte[] message,
Topic destination)
Sends a byte-array message to the given destination using defaults This method is
non-blocking.
|
void |
PersistentMessagePublisher.publish(byte[] message,
Topic destination,
Object userContext)
Sends a persistent byte array message to the given destination using defaults.
|
void |
PersistentMessagePublisher.publish(OutboundMessage message,
Topic destination)
Sends a persistent message; nonblocking
|
void |
DirectMessagePublisher.publish(OutboundMessage message,
Topic destination)
Sends an
OutboundMessage to the given destination, non blocking. |
void |
PersistentMessagePublisher.publish(OutboundMessage message,
Topic destination,
Object userContext)
Sends a persistent message to the given destination, non blocking
|
void |
PersistentMessagePublisher.publish(OutboundMessage message,
Topic destination,
Object userContext,
Properties additionalMessageProperties)
Sends a persistent message to the given destination, non-blocking
|
void |
DirectMessagePublisher.publish(OutboundMessage message,
Topic destination,
Properties additionalMessageProperties)
Sends
OutboundMessage to the given destination, extendedMessageProperties can
be included into the message, non blocking. |
void |
PersistentMessagePublisher.publish(String message,
Topic destination)
Sends a UTF-8 encoded persistent text message as a payload to the given destination using
defaults.
|
void |
DirectMessagePublisher.publish(String message,
Topic destination)
Sends a UTF-8 encoded-text message (payload) to the specified destination using defaults This
method is non-blocking.
|
void |
PersistentMessagePublisher.publish(String message,
Topic destination,
Object userContext)
Sends a UTF-8 encoded persistent text message as the payload to the given destination using
defaults.
|
void |
PersistentMessagePublisher.publishAwaitAcknowledgement(OutboundMessage message,
Topic destination,
long timeout)
Sends a persistent message, blocking until delivery acknowledgement is received or timeout
occurs.
|
void |
PersistentMessagePublisher.publishAwaitAcknowledgement(OutboundMessage message,
Topic destination,
long timeout,
Properties additionalMessageProperties)
Sends a persistent message, blocking until delivery acknowledgement is received or timeout
occurs
|
InboundMessage |
RequestReplyMessagePublisher.publishAwaitResponse(OutboundMessage requestMessage,
Properties additionalMessageProperties,
Topic requestDestination,
long replyTimeout)
Sends a request message return response message that blocks until a response is received or a
timeout occurs.
|
InboundMessage |
RequestReplyMessagePublisher.publishAwaitResponse(OutboundMessage requestMessage,
Topic requestDestination,
long replyTimeout)
Sends a request message return response message that blocks until a response is received or a
timeout occurs.
|
<DirectMessagePublisher> |
DirectMessagePublisher.startAsync() |
<PersistentMessagePublisher> |
PersistentMessagePublisher.startAsync() |
<RequestReplyMessagePublisher> |
RequestReplyMessagePublisher.startAsync() |
<DirectMessagePublisher> |
DirectMessagePublisher.startAsync(CompletionListener<DirectMessagePublisher> startListener) |
<PersistentMessagePublisher> |
PersistentMessagePublisher.startAsync(CompletionListener<PersistentMessagePublisher> startListener) |
<RequestReplyMessagePublisher> |
RequestReplyMessagePublisher.startAsync(CompletionListener<RequestReplyMessagePublisher> startListener) |
Modifier and Type | Method and Description |
---|---|
PubSubPlusClientException |
RequestReplyMessageReceiver.FailedReplyEvent.getException()
Retrieves the exception that's associated with a given event.
|
PubSubPlusClientException |
MessageReceiver.FailedReceiveEvent.getException()
Retrieves the exception associated with a given event.
|
Modifier and Type | Method and Description |
---|---|
void |
AsyncReceiverSubscriptions.SubscriptionChangeListener.onSubscriptionChange(TopicSubscription topicSubscription,
AsyncReceiverSubscriptions.SubscriptionChangeListener.SubscriptionOperation change,
PubSubPlusClientException exception)
A callback method that executes when a subscription change occurs and the broker response is
processed.
|
Modifier and Type | Method and Description |
---|---|
void |
AcknowledgementSupport.ack(InboundMessage message)
Acknowledges the inbound message.
|
void |
ReceiverSubscriptions.addSubscription(TopicSubscription anotherSubscription)
Subscribes to another message source on a broker to receive messages from.
|
void |
AsyncReceiverSubscriptions.addSubscriptionAsync(TopicSubscription topicSubscription,
AsyncReceiverSubscriptions.SubscriptionChangeListener listener)
Requests to subscribe asynchronously to a given topic subscription.
|
void |
ReceiverFlowControl.pause()
Pauses message delivery to an asynchronous message handler or stream.
|
void |
PersistentMessageReceiver.receiveAsync(MessageReceiver.MessageHandler messageHandler)
Request to register an async message handler.
|
void |
DirectMessageReceiver.receiveAsync(MessageReceiver.MessageHandler messageHandler)
Request to register an async message handler.
|
void |
PersistentMessageReceiver.receiveAsync(MessageReceiver.MessageHandler messageHandler,
ExecutorService executorService)
Request to register an async message handler using own thread executor for callbacks.
|
void |
DirectMessageReceiver.receiveAsync(MessageReceiver.MessageHandler messageHandler,
ExecutorService executorService)
Request to register an asynchronous message handler using supplied thread executor for
callbacks.
|
void |
RequestReplyMessageReceiver.receiveAsync(RequestReplyMessageReceiver.RequestMessageHandler messageHandler)
Request to register an async request message handler.
|
void |
RequestReplyMessageReceiver.receiveAsync(RequestReplyMessageReceiver.RequestMessageHandler messageHandler,
ExecutorService executorService)
Request to register an asynchronous request message handler using supplied thread executor for
callbacks.
|
InboundMessage |
PersistentMessageReceiver.receiveMessage()
Blocking request to receive a next message.
|
InboundMessage |
MessageQueueBrowser.receiveMessage()
Blocking request to receive a next message from a message browser without removing them from a
persistent store of Queue Endpoints.
|
InboundMessage |
DirectMessageReceiver.receiveMessage()
Receive the next message.
|
InboundMessage |
PersistentMessageReceiver.receiveMessage(long timeOut)
Temporarily blocking request to receive a next message;
|
InboundMessage |
MessageQueueBrowser.receiveMessage(long timeOut)
Blocking request to receive a next message from a message browser without removing them from a
persistent store of Queue Endpoints.
|
InboundMessage |
DirectMessageReceiver.receiveMessage(long timeOut)
Receive the next message.
|
void |
RequestReplyMessageReceiver.receiveMessage(RequestReplyMessageReceiver.RequestMessageHandler messageHandler)
Receive the next request message to be processed with a given
RequestMessageHandler . |
void |
RequestReplyMessageReceiver.receiveMessage(RequestReplyMessageReceiver.RequestMessageHandler messageHandler,
long timeOut)
Receive the next request message to be processed with a given
RequestMessageHandler . |
void |
MessageQueueBrowser.remove(InboundMessage message)
Request to remove a message from the PubSubPlus broker's Queue Endpoint.
|
void |
ReceiverSubscriptions.removeSubscription(TopicSubscription subscription)
Un-subscribes from a previously subscribed message source on a broker.
|
void |
AsyncReceiverSubscriptions.removeSubscriptionAsync(TopicSubscription topicSubscription,
AsyncReceiverSubscriptions.SubscriptionChangeListener listener)
Unsubscribe from a previously subscribed message source on a broker, so that no more messages
will be received from it.
|
void |
RequestReplyMessageReceiver.Replier.reply(OutboundMessage responseMessage)
Publish a reply or response message.
|
void |
RequestReplyMessageReceiver.Replier.reply(OutboundMessage responseMessage,
Properties additionalMessageProperties)
Publish a reply or response message.
|
void |
ReceiverFlowControl.resume()
Resumes previously paused message delivery.
|
void |
AcknowledgementSupport.settle(InboundMessage message,
MessageAcknowledgementConfiguration.Outcome settlementOutcome)
Settles a message in a requested way.
|
RequestReplyMessageReceiver |
RequestReplyMessageReceiver.start() |
PersistentMessageReceiver |
PersistentMessageReceiver.start() |
MessageReceiver |
MessageReceiver.start() |
MessageQueueBrowser |
MessageQueueBrowser.start() |
DirectMessageReceiver |
DirectMessageReceiver.start() |
<DirectMessageReceiver> |
DirectMessageReceiver.startAsync() |
<MessageQueueBrowser> |
MessageQueueBrowser.startAsync() |
<MessageReceiver> |
MessageReceiver.startAsync() |
<DirectMessageReceiver> |
DirectMessageReceiver.startAsync(CompletionListener<DirectMessageReceiver> startListener) |
<PersistentMessageReceiver> |
PersistentMessageReceiver.startAsync(CompletionListener<PersistentMessageReceiver> startListener) |
<RequestReplyMessageReceiver> |
RequestReplyMessageReceiver.startAsync(CompletionListener<RequestReplyMessageReceiver> startListener) |
Constructor and Description |
---|
FailedReceiveEvent(PubSubPlusClientException exception)
Creates an instance of representing the event of failed attempt to receive a message.
|
FailedReceiveEvent(PubSubPlusClientException exception,
long timeStamp)
Creates an instance of representing the event of failed attempt to receive a message.
|
Modifier and Type | Method and Description |
---|---|
PubSubPlusClientException |
LifecycleControl.TerminationEvent.getCause()
Retrieves the cause of the client exception if any.
|
Modifier and Type | Method and Description |
---|---|
Connectable |
Connectable.connect()
Connects synchronously with a PubSub+ event broker.
|
<T> CompletableFuture<T> |
AsyncConnectable.connectAsync()
Connects asynchronously with a PubSub+ event broker.
|
<T> void |
AsyncConnectable.connectAsync(CompletionListener<T> connectionListener)
Connects asynchronously with a PubSub+ event broker with a callback.
|
void |
Connectable.disconnect()
Disconnects with a PubSub+ event broker.
|
CompletableFuture<Void> |
AsyncConnectable.disconnectAsync()
Disconnects asynchronously with a PubSub+ event broker.
|
void |
AsyncConnectable.disconnectAsync(CompletionListener<Void> disconnectionListener)
Disconnects asynchronously with a PubSub+ event broker with a callback.
|
Object |
SolaceSDTMap.get(String key)
Returns the value mapped to the specified case-sensitive key.
|
Boolean |
SolaceSDTMap.getBoolean(String key)
Returns the Boolean value mapped to the specified case-sensitive key.
|
Byte |
SolaceSDTMap.getByte(String key)
Returns the Boolean value mapped to the specified case-sensitive key.
|
byte[] |
SolaceSDTMap.getBytes(String key)
Returns the byte[] value mapped to the specified case-sensitive key.
|
Character |
SolaceSDTMap.getCharacter(String key)
Returns the Character value mapped to the specified case-sensitive key.
|
com.solacesystems.jcsmp.Destination |
SolaceSDTMap.getDestination(String key)
Returns the Destination value mapped to the specified case-sensitive key.
|
Double |
SolaceSDTMap.getDouble(String key)
Returns the Double value mapped to the specified case-sensitive key.
|
Float |
SolaceSDTMap.getFloat(String key)
Returns the Float value mapped to the specified case-sensitive key.
|
Integer |
SolaceSDTMap.getInteger(String key)
Returns the Integer value mapped to the specified case-sensitive key.
|
Long |
SolaceSDTMap.getLong(String key)
Returns the Long value mapped to the specified case-sensitive key.
|
com.solacesystems.jcsmp.SDTMap |
SolaceSDTMap.getMap(String key)
Returns the SDTMap value mapped to the specified case-sensitive key.
|
Short |
SolaceSDTMap.getShort(String key)
Returns the Short value mapped to the specified case-sensitive key.
|
com.solacesystems.jcsmp.SDTStream |
SolaceSDTMap.getStream(String key)
Returns the SDTStream value mapped to the specified case-sensitive key.
|
String |
SolaceSDTMap.getString(String key)
Returns the String value mapped to the specified case-sensitive key.
|
void |
SolaceSDTMap.putAll(com.solacesystems.jcsmp.SDTMap sdtMap)
Copies the mappings from the given SDTMap and puts them in this SDTMap.
|
void |
SolaceSDTMap.putBoolean(String key,
Boolean aBoolean)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putByte(String key,
Byte aByte)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putBytes(String key,
byte[] bytes)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putBytes(String key,
byte[] bytes,
int offset,
int length)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putCharacter(String key,
Character character)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putDestination(String key,
com.solacesystems.jcsmp.Destination destination)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putDouble(String key,
Double aDouble)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putFloat(String key,
Float aFloat)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putInteger(String key,
Integer integer)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putLong(String key,
Long aLong)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putMap(String key,
com.solacesystems.jcsmp.SDTMap sdtMap)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putObject(String key,
Object value)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putShort(String key,
Short aShort)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putStream(String key,
com.solacesystems.jcsmp.SDTStream sdtStream)
Associates the specified case-sensitive key with the value in the map.
|
void |
SolaceSDTMap.putString(String key,
String value)
Associates the specified case-sensitive key with the value in the map.
|
LifecycleControl |
LifecycleControl.start()
Enables service regular duties.
|
<T> CompletableFuture<T> |
AsyncLifecycleControl.startAsync()
Asynchronously starts service for consuming/publishing operations.
|
<T> void |
AsyncLifecycleControl.startAsync(CompletionListener<T> startListener)
Asynchronously starts service for consuming/publishing operations using a callback for
completion notification.
|
void |
LifecycleControl.terminate(long gracePeriod)
Disables gracefully the regular duties of a receiver or publisher.
|
void |
AsyncLifecycleControl.terminateAsync(CompletionListener<Void> terminationListener,
long gracePeriod)
Asynchronously terminates (gracefully) the service for consuming/publishing operations using a
callback for a completion notification.
|
CompletableFuture<Void> |
AsyncLifecycleControl.terminateAsync(long gracePeriod)
Asynchronously terminates (gracefully) the service for consuming/publishing operations.
|
Copyright 2019-2024 Solace Corporation. All rights reserved.