Draining Messages Before Disconnect

A feature recently added across the NATS client libraries is the ability to drain connections or subscriptions. Closing a connection, or unsubscribing from a subscription, are generally considered immediate requests. When you close or unsubscribe the library will halt messages in any pending queue or cache for subscribers. When you drain a subscription or connection, it will process any inflight and cached/pending messages before closing.

Drain provides clients that use queue subscriptions with a way to bring down applications without losing any messages. A client can bring up a new queue member, drain and shut down the old queue member, all without losing messages sent to the old client. Without drain, there is the possibility of lost messages due to delivery timing.

The libraries can provide drain on a connection or on a subscriber, or both.

For a connection the process is essentially:

  1. Drain all subscriptions
  2. Stop new messages from being published
  3. Flush any remaining published messages
  4. Close

The API for drain can generally be used instead of close:

As an example of draining a connection:

Go

  1. wg := sync.WaitGroup{}
  2. wg.Add(1)
  3. errCh := make(chan error, 1)
  4. // To simulate a timeout, you would set the DrainTimeout()
  5. // to a value less than the time spent in the message callback,
  6. // so say: nats.DrainTimeout(10*time.Millisecond).
  7. nc, err := nats.Connect("demo.nats.io",
  8. nats.DrainTimeout(10*time.Second),
  9. nats.ErrorHandler(func(_ *nats.Conn, _ *nats.Subscription, err error) {
  10. errCh <- err
  11. }),
  12. nats.ClosedHandler(func(_ *nats.Conn) {
  13. wg.Done()
  14. }))
  15. if err != nil {
  16. log.Fatal(err)
  17. }
  18. // Just to not collide using the demo server with other users.
  19. subject := nats.NewInbox()
  20. // Subscribe, but add some delay while processing.
  21. if _, err := nc.Subscribe(subject, func(_ *nats.Msg) {
  22. time.Sleep(200 * time.Millisecond)
  23. }); err != nil {
  24. log.Fatal(err)
  25. }
  26. // Publish a message
  27. if err := nc.Publish(subject, []byte("hello")); err != nil {
  28. log.Fatal(err)
  29. }
  30. // Drain the connection, which will close it when done.
  31. if err := nc.Drain(); err != nil {
  32. log.Fatal(err)
  33. }
  34. // Wait for the connection to be closed.
  35. wg.Wait()
  36. // Check if there was an error
  37. select {
  38. case e := <-errCh:
  39. log.Fatal(e)
  40. default:
  41. }

Java

  1. Connection nc = Nats.connect("nats://demo.nats.io:4222");
  2. // Use a latch to wait for a message to arrive
  3. CountDownLatch latch = new CountDownLatch(1);
  4. // Create a dispatcher and inline message handler
  5. Dispatcher d = nc.createDispatcher((msg) -> {
  6. String str = new String(msg.getData(), StandardCharsets.UTF_8);
  7. System.out.println(str);
  8. latch.countDown();
  9. });
  10. // Subscribe
  11. d.subscribe("updates");
  12. // Wait for a message to come in
  13. latch.await();
  14. // Drain the connection, which will close it
  15. CompletableFuture<Boolean> drained = nc.drain(Duration.ofSeconds(10));
  16. // Wait for the drain to complete
  17. drained.get();

JavaScript

  1. let nc = NATS.connect({url: "nats://demo.nats.io:4222"});
  2. let inbox = createInbox();
  3. let counter = 0;
  4. nc.subscribe(inbox, () => {
  5. counter++;
  6. });
  7. nc.publish(inbox);
  8. nc.drain((err)=> {
  9. if(err) {
  10. t.log(err);
  11. }
  12. t.log('connection is closed:', nc.closed);
  13. t.log('processed', counter, 'messages');
  14. t.pass();
  15. // the snippet is running as a promise in a test
  16. // and calls resolve to pass the test
  17. resolve();
  18. });

Python

  1. import asyncio
  2. from nats.aio.client import Client as NATS
  3. async def example(loop):
  4. nc = NATS()
  5. await nc.connect("nats://127.0.0.1:4222", loop=loop)
  6. async def handler(msg):
  7. print("[Received] ", msg)
  8. await nc.publish(msg.reply, b'I can help')
  9. # Can check whether client is in draining state
  10. if nc.is_draining:
  11. print("Connection is draining")
  12. await nc.subscribe("help", "workers", cb=handler)
  13. await nc.flush()
  14. requests = []
  15. for i in range(0, 10):
  16. request = nc.request("help", b'help!', timeout=1)
  17. requests.append(request)
  18. # Wait for all the responses
  19. responses = []
  20. responses = await asyncio.gather(*requests)
  21. # Gracefully close the connection.
  22. await nc.drain()
  23. print("Received {} responses".format(len(responses)))

Ruby

  1. NATS.start(drain_timeout: 1) do |nc|
  2. NATS.subscribe('foo', queue: "workers") do |msg, reply, sub|
  3. nc.publish(reply, "ACK:#{msg}")
  4. end
  5. NATS.subscribe('bar', queue: "workers") do |msg, reply, sub|
  6. nc.publish(reply, "ACK:#{msg}")
  7. end
  8. NATS.subscribe('quux', queue: "workers") do |msg, reply, sub|
  9. nc.publish(reply, "ACK:#{msg}")
  10. end
  11. EM.add_timer(2) do
  12. next if NATS.draining?
  13. # Drain gracefully closes the connection.
  14. NATS.drain do
  15. puts "Done draining. Connection is closed."
  16. end
  17. end
  18. end

TypeScript

  1. let sub = await nc.subscribe('updates', (err, msg) => {
  2. t.log('worker got message', msg.data);
  3. }, {queue: "workers"});
  4. // [end drain_sub]
  5. nc.flush();
  6. await nc.drain();
  7. // client must close when the connection drain resolves
  8. nc.close();

C

  1. static void
  2. onMsg(natsConnection *conn, natsSubscription *sub, natsMsg *msg, void *closure)
  3. {
  4. printf("Received msg: %s - %.*s\n",
  5. natsMsg_GetSubject(msg),
  6. natsMsg_GetDataLength(msg),
  7. natsMsg_GetData(msg));
  8. // Add some delay while processing
  9. nats_Sleep(200);
  10. // Need to destroy the message!
  11. natsMsg_Destroy(msg);
  12. }
  13. static void
  14. closeHandler(natsConnection *conn, void *closure)
  15. {
  16. cond_variable cv = (cond_variable) closure;
  17. notify_cond_variable(cv);
  18. }
  19. (...)
  20. natsConnection *conn = NULL;
  21. natsOptions *opts = NULL;
  22. natsSubscription *sub = NULL;
  23. natsStatus s = NATS_OK;
  24. cond_variable cv = new_cond_variable(); // some fictuous way to notify between threads.
  25. s = natsOptions_Create(&opts);
  26. if (s == NATS_OK)
  27. // Setup a close handler and pass a reference to our condition variable.
  28. s = natsOptions_SetClosedCB(opts, closeHandler, (void*) cv);
  29. if (s == NATS_OK)
  30. s = natsConnection_Connect(&conn, opts);
  31. // Subscribe
  32. if (s == NATS_OK)
  33. s = natsConnection_Subscribe(&sub, conn, "foo", onMsg, NULL);
  34. // Publish a message
  35. if (s == NATS_OK)
  36. s = natsConnection_PublishString(conn, "foo", "hello");
  37. // Drain the connection, which will close it when done.
  38. if (s == NATS_OK)
  39. s = natsConnection_Drain(conn);
  40. // Wait for the connection to be closed
  41. if (s == NATS_OK)
  42. cond_variable_wait(cv);
  43. (...)
  44. // Destroy objects that were created
  45. natsSubscription_Destroy(sub);
  46. natsConnection_Destroy(conn);
  47. natsOptions_Destroy(opts);

The mechanics of drain for a subscription are simpler:

  1. Unsubscribe
  2. Process all cached or inflight messages
  3. Clean up

The API for drain can generally be used instead of unsubscribe:

Go

  1. nc, err := nats.Connect("demo.nats.io")
  2. if err != nil {
  3. log.Fatal(err)
  4. }
  5. defer nc.Close()
  6. done := sync.WaitGroup{}
  7. done.Add(1)
  8. count := 0
  9. errCh := make(chan error, 1)
  10. msgAfterDrain := "not this one"
  11. // Just to not collide using the demo server with other users.
  12. subject := nats.NewInbox()
  13. // This callback will process each message slowly
  14. sub, err := nc.Subscribe(subject, func(m *nats.Msg) {
  15. if string(m.Data) == msgAfterDrain {
  16. errCh <- fmt.Errorf("Should not have received this message")
  17. return
  18. }
  19. time.Sleep(100 * time.Millisecond)
  20. count++
  21. if count == 2 {
  22. done.Done()
  23. }
  24. })
  25. // Send 2 messages
  26. for i := 0; i < 2; i++ {
  27. nc.Publish(subject, []byte("hello"))
  28. }
  29. // Call Drain on the subscription. It unsubscribes but
  30. // wait for all pending messages to be processed.
  31. if err := sub.Drain(); err != nil {
  32. log.Fatal(err)
  33. }
  34. // Send one more message, this message should not be received
  35. nc.Publish(subject, []byte(msgAfterDrain))
  36. // Wait for the subscription to have processed the 2 messages.
  37. done.Wait()
  38. // Now check that the 3rd message was not received
  39. select {
  40. case e := <-errCh:
  41. log.Fatal(e)
  42. case <-time.After(200 * time.Millisecond):
  43. // OK!
  44. }

Java

  1. Connection nc = Nats.connect("nats://demo.nats.io:4222");
  2. // Use a latch to wait for a message to arrive
  3. CountDownLatch latch = new CountDownLatch(1);
  4. // Create a dispatcher and inline message handler
  5. Dispatcher d = nc.createDispatcher((msg) -> {
  6. String str = new String(msg.getData(), StandardCharsets.UTF_8);
  7. System.out.println(str);
  8. latch.countDown();
  9. });
  10. // Subscribe
  11. d.subscribe("updates");
  12. // Wait for a message to come in
  13. latch.await();
  14. // Messages that have arrived will be processed
  15. CompletableFuture<Boolean> drained = d.drain(Duration.ofSeconds(10));
  16. // Wait for the drain to complete
  17. drained.get();
  18. // Close the connection
  19. nc.close();

JavaScript

  1. let nc = NATS.connect({url: "nats://demo.nats.io:4222"});
  2. let inbox = createInbox();
  3. let counter = 0;
  4. let sid = nc.subscribe(inbox, () => {
  5. counter++;
  6. });
  7. nc.publish(inbox);
  8. nc.drainSubscription(sid, (err)=> {
  9. if(err) {
  10. t.log(err);
  11. }
  12. t.log('processed', counter, 'messages');
  13. });
  14. nc.flush(() => {
  15. nc.close();
  16. t.pass();
  17. resolve();
  18. });

Python

  1. import asyncio
  2. from nats.aio.client import Client as NATS
  3. async def example(loop):
  4. nc = NATS()
  5. await nc.connect("nats://127.0.0.1:4222", loop=loop)
  6. async def handler(msg):
  7. print("[Received] ", msg)
  8. await nc.publish(msg.reply, b'I can help')
  9. # Can check whether client is in draining state
  10. if nc.is_draining:
  11. print("Connection is draining")
  12. sid = await nc.subscribe("help", "workers", cb=handler)
  13. await nc.flush()
  14. # Gracefully unsubscribe the subscription
  15. await nc.drain(sid)

Ruby

  1. # There is currently no API to drain a single subscription, the whole connection can be drained though via NATS.drain

TypeScript

  1. let sub = await nc.subscribe('updates', (err, msg) => {
  2. t.log('worker got message', msg.data);
  3. }, {queue: "workers"});

C

  1. natsConnection *conn = NULL;
  2. natsSubscription *sub = NULL;
  3. natsStatus s = NATS_OK;
  4. s = natsConnection_ConnectTo(&conn, NATS_DEFAULT_URL);
  5. // Subscribe
  6. if (s == NATS_OK)
  7. s = natsConnection_Subscribe(&sub, conn, "foo", onMsg, NULL);
  8. // Publish 2 messages
  9. if (s == NATS_OK)
  10. {
  11. int i;
  12. for (i=0; (s == NATS_OK) && (i<2); i++)
  13. {
  14. s = natsConnection_PublishString(conn, "foo", "hello");
  15. }
  16. }
  17. // Call Drain on the subscription. It unsubscribes but
  18. // wait for all pending messages to be processed.
  19. if (s == NATS_OK)
  20. s = natsSubscription_Drain(sub);
  21. (...)
  22. // Destroy objects that were created
  23. natsSubscription_Destroy(sub);
  24. natsConnection_Destroy(conn);

Because draining can involve messages flowing to the server, for a flush and asynchronous message processing, the timeout for drain should generally be higher than the timeout for a simple message request/reply or similar.