-
PubSub+ Connector for Kafka Connect 2.1.0 is available now!
PubSub+ Connector for Kafka Connect 2.1.0 has been released and is available for download now. Release Summary: * (Sink) Added the capability for record processor implementations to be configurable through the connector configuration. * (Sink) Added the sol.emit.kafka.record.headers.enabled connector configuration option…
-
PubSub+ Connector for MuleSoft Anypoint Platform 1.0.0 is live now!
PubSub+ Connector for MuleSoft Anypoint Platform 1.0.0 has been released and is available for download! Release Summary: * Use the PubSub+ Connector to leverage PubSub+ Event Broker (event streaming) and PubSub+ Event Portal (event management) within the MuleSoft Anypoint Platform to make your MuleSoft integrations more…
-
Prevent Queue subscribing application to receive another message until ACK is sent
Hi there, I have a consuming application using the solace .NET client API which binds to an exclusive queue. May aim is to process messages in order without any loss. Suppose I have the following messages on the Queue: msg1, msg2, and msg3. Let's say I have received msg1 and am processing it on the FlowMessageHandler in my…
-
Sample code for request/reply design by using Spring Cloud Stream
Hi, I am new to solace and my application is using solace request/reply by using old approach. I have planned to use spring cloud stream in my project for the below scenarios. please refer the below use case and help me with samples: I have three microservice services in my application ServiceA -- > Request the message to…
-
How to keep message listener up and running to asynchronously keep receiving messages
Hi, I am using JCSMP API. For listening to messages. I am using asynchronous receiving by implementing XMLMessageListener. Once I started FlowReceiver, it starts listening to messages, my program terminates after some time. I want my listener to be up and running until I terminate my program. Is it possible keep the…
-
JMS Message Handling Scenarios
I am coming through the Solace docs trying to figure out the differences between various JMS pub/sub configurations and how the message and acks would be handled. Here are my scenarios. What I am trying to identify is when an ack is sent, when a message is spooled to disk vs retained in memory, and when/how a message may…
-
cli to legacy semp for session-idle-timeout
Hello Solace-Community, new Solace user here :smile: We are currently developing our own terraform solace provider and are now at a point where we want to be able to configure some broker settings through terraform. For that we are using the semp v2 api whenever possible but have to fall back to the legacy semp from time…
-
Solace PubSub+ Event Broker (Software & Appliance) new versions are released
The following Solace PubSub+ Platform products have been released and are available for download: * Solace PubSub+ Event Broker: Software version 9.6.0.27 * Solace PubSub+ Event Broker: Appliance version 9.6.0.27 Please refer to the product release notes for information on new features, changed functionality, resolved…
-
Max transacted sessions exceeded (503) error - PubSub+ Event Broker and Camel Solace component issue
Our team is currently working on a proof of concept with Apache Camel to split a file and publish the events to a Solace queue (PubSub+ Event Broker). Unfortunately, we are experiencing a persistent issue from the consuming route where, after a few minutes of consuming messages using the Solace Camel component, we start to…
-
Disaster recovery setup
I am trying to enable Disaster recovery between 2 HA pairs. Is there a consolidated documentation of the steps to follow? I followed the default solace documentation, and there are lot of moving parts/configurations, and now my replication bridge is not coming up. I don't see anything in the logs to debug the problem.…
-
Solace with multi threading environment
How to use Solace in a multithreading environment, similar to kafka consumers with multiple partitions.
-
Debugging replay log issues
I am trying to debug replay in Solace. I see the messages in the internal replay queues, but when I tried replay on a new queue with subscriptions to the same topic, messages are not being processed. The queue is showing "Replay State" of "Active", but nothing is being replayed. Even the live feed is not going to the new…
-
Increase Single Message Maximum Size Limit of Direct Messages in localhost
Hello everyone, I am using the Solace localhost (PubSub+ standard edition) The current maximum single message size limit for direct messages is 10GB. I need a limit of at least 30GB and above for Direct messages in the localhost. Is there any way to increase this limit? Thanks in advance!
-
solace broker WSS connection issue
WSS connection is not getting established for solace. Neither with/out corporate vpn.
-
Applying backpressure to a flow by blocking in the MessageEventHandler
I have a few days of free time and so I am developing a new branch of my Solace subscriber wrapper library. I thought I'd play with exposing the message stream as an IAsyncEnumerable. I decided to use a System.Threading.Channels.Channel with a bounded capacity for this. The idea is to (usually) quickly let the message…
-
Try-Me seems to send message as byte[] array and not text
Hi, Using the the try-me functionality of the Solace Cloud Console to publish a message. The problem is that it seems to sends the message as byte array while my consumer code expects it to be a string. I don't want to change the consumer code but rather instruct Try-Me to send message as text and receive it as is. Is it…
-
Python - Additional properties for with_missing_resources_creation_strategy()
Hi, As a python subscriber to an external broker, we are only limited to create Durable Exclusive queue via SMF Api. Since there's an existing method prior to starting the receiver, with_missing_resources_creation_strategy(), by default its endpoint created on a permission for that queue is Delete. However, it is required…
-
Python - publish and subscribe message with message in the Content and not in the Attachment
In our current use case we will be expecting published messages to be stored in the Attachment or in Content from our external broker. Our python subscriber currently can read published messages via get_payload_as_string() or get_payload_as_bytes().decode("utf-8"). 1. How can we publish a message via python and stored as a…
-
Transactional applications in event driven approach
I understand the benefits of event driven approach which is like decoupling the applications and making the integration seamless with more reliability but there is a bit of delay in as well with event driven more on the side for the call backs and so in case of an ecommerce application which has payment transaction…
-
SSL/TLS connection rejected by remote host
Below error is triggered and fills the log file event and system log files. Please assist what could be the issue. 2021-08-25T09:46:47.432+00:00 <local3.info> **** SOLACEINFO: SYSTEM: SYSTEM_SSL_CONNECTION_REJECTED: - - SSL Connection rejected: reason (Connection closed by remote host); connection to 127.0.0.1:8091 from…
-
Receiving Event Logs via the Message Broker
When receiving event logs with a consumer, there doesn't seem to be any message text/body. Does the message topic contain all of the available information, or am I missing something?
-
JMS API connection factory route to different VPN
I don't see a set target VPN name, while creating the connection factory, so after the connection factory lookup the messages are going to the same VPN where the lookup is done, but I want to redirect the messages to different VPN. is it possible? It is like routing to different VPN for the actual data, and all the clients…
-
Dealing with messages in Dead message Queue
Hi Team, How to process the messages in Dead msg queue and how long messages remain on solace queue?
-
Azure Event Bus, RabbitMQ and PUBSUB
Hello still very new to Solace and PUBSUB. I have a Azure Microservice project using RabbitMQ as my event bus. Does Solace have its own preferred event bus?
-
Integration Testing with Solace
All, I have a java based spring cloud stream application that publishes messages to solace topics based on an internal trigger. I am using StreamBridge to publish messages. I want to write integration test cases for it for which I need to bring up a solace server. Any idea on the best ways to do it? Thanks in advance!
-
TaskCompletionSource as CorrelationKey for guaranteed messages - safe async?
Suppose I wish to publish guaranteed messages, but I want to wrap the solace callback guts inside a library which is a little more modern - for example, using the TAP. Is there any reason why something like the following would be unsafe? For this example, assume send blocking is enabled (although I think this could be…
-
Latency test between 2 appliances in 2 Diff DC
Hi Team, Looking of suggestion to do a latency test across DC **solace connectivity **connected via Bridge component. Solace (DC 1) <> BRIDGE bi directional <> Solace (DC2) How can we use sdkperf in this case , where publisher and consumer not connected to same DC ? Any suggestion is very much appreciated!
-
Error creating consumers: intern error creating consumers (503: mac client exceeded for durable topi
Analysis: I have increased max bind count from 1 to 50!! Is it correct? Kindly help!!
-
Delete all subscriptions from a queue in one shot
Hello, Is there anyway to delete all subscriptions in one shot from a queue using Legacy SEMP and SEMP V2? @nram @Aaron Thank you
-
Solace/Boomi moves all messages to DMQ if a single message fails after x retries
It appears that our Solace test instance moves all messages to the DMQ if a single message fails after x retries. Example: Queue X contains 100 messages Queue X settings: retries = 3 Boomi listener retrieves 1 message from the queue, which fails. Then Boomi retries the messages 3 times (OK), but then Solace moves all 100…