/*
* Copyright (c) 2008-2017 the original author or authors.
*
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package org.cometd.client;
import java.util.HashMap;
import java.util.Iterator;
import java.util.Map;
import java.util.Queue;
import java.util.concurrent.BlockingQueue;
import java.util.concurrent.CountDownLatch;
import java.util.concurrent.LinkedBlockingQueue;
import java.util.concurrent.TimeUnit;
import java.util.concurrent.atomic.AtomicInteger;
import org.cometd.bayeux.Channel;
import org.cometd.bayeux.Message;
import org.cometd.bayeux.client.ClientSessionChannel;
import org.cometd.bayeux.server.BayeuxServer;
import org.cometd.bayeux.server.ConfigurableServerChannel;
import org.cometd.bayeux.server.ServerMessage;
import org.cometd.bayeux.server.ServerSession;
import org.cometd.server.ext.TimestampExtension;
import org.junit.Assert;
import org.junit.Test;
public class MessageFlowControlTest extends ClientServerTest {
@Test
public void testMessageFlowControlWithDeQueueListener() throws Exception {
startServer(null);
testMessageFlowControlWithDeQueueListener(false, -1);
}
@Test
public void testMessageFlowControlWithDeQueueListenerAndLazyChannel() throws Exception {
Map<String, String> initParams = new HashMap<>();
long maxLazyTimeout = 1000;
initParams.put("maxLazyTimeout", String.valueOf(maxLazyTimeout));
startServer(initParams);
testMessageFlowControlWithDeQueueListener(true, maxLazyTimeout);
}
public void testMessageFlowControlWithDeQueueListener(final boolean lazyChannel, long maxLazyTimeout) throws Exception {
bayeux.addExtension(new TimestampExtension("yyyyMMddHHmmss"));
final String channelName = "/test";
bayeux.createChannelIfAbsent(channelName, new ConfigurableServerChannel.Initializer() {
@Override
public void configureChannel(ConfigurableServerChannel channel) {
channel.setPersistent(true);
if (lazyChannel) {
channel.setLazy(true);
}
}
});
int totalMessages = 8;
final CountDownLatch queuedMessages = new CountDownLatch(totalMessages);
final long toleranceSeconds = 2;
final AtomicInteger keptMessages = new AtomicInteger();
bayeux.addListener(new BayeuxServer.SessionListener() {
@Override
public void sessionAdded(ServerSession session, ServerMessage message) {
session.addListener(new ServerSession.DeQueueListener() {
@Override
public void deQueue(ServerSession session, Queue<ServerMessage> queue) {
long lastTimeStamp = 0;
for (Iterator<ServerMessage> iterator = queue.iterator(); iterator.hasNext(); ) {
ServerMessage message = iterator.next();
if (channelName.equals(message.getChannel())) {
long timeStamp = Long.parseLong(message.get(Message.TIMESTAMP_FIELD).toString());
if (timeStamp <= lastTimeStamp + toleranceSeconds) {
System.err.println("removed " + message);
iterator.remove();
} else {
System.err.println("kept " + message);
keptMessages.incrementAndGet();
lastTimeStamp = timeStamp;
}
queuedMessages.countDown();
}
}
}
});
}
@Override
public void sessionRemoved(ServerSession session, boolean timedout) {
}
});
BayeuxClient client = newBayeuxClient();
client.handshake();
Assert.assertTrue(client.waitFor(5000, BayeuxClient.State.CONNECTED));
// Wait for the long poll to establish
Thread.sleep(1000);
final CountDownLatch subscribed = new CountDownLatch(1);
client.getChannel(Channel.META_SUBSCRIBE).addListener(new ClientSessionChannel.MessageListener() {
@Override
public void onMessage(ClientSessionChannel channel, Message message) {
subscribed.countDown();
}
});
final BlockingQueue<Message> messages = new LinkedBlockingQueue<>();
client.getChannel(channelName).subscribe(new ClientSessionChannel.MessageListener() {
@Override
public void onMessage(ClientSessionChannel channel, Message message) {
System.err.println("message = " + message);
messages.offer(message);
}
});
Assert.assertTrue(subscribed.await(5, TimeUnit.SECONDS));
// Publishing a message result in the long poll being woken up, which in turn will
// drain the queue. There is a race between the publish of messages below and the
// resumed long poll to access the queue, so it's possible that the messages are
// drained from the queue in more than one pass (e.g. publish0, publish1, drain -
// keep publish0, discard publish1 - publish2, ... publishN, drain - keep publish2,
// discard publish3 to publishN). We take this in account when asserting below.
for (int i = 0; i < totalMessages; ++i) {
bayeux.getChannel(channelName).publish(null, "msg_" + i);
}
// Wait for all the message to be processed on server side,
// to avoids a race to access variable keptMessages
Assert.assertTrue(queuedMessages.await(5, TimeUnit.SECONDS));
if (lazyChannel) {
Thread.sleep(maxLazyTimeout);
}
for (int i = 0; i < keptMessages.get(); ++i) {
Assert.assertNotNull(messages.poll(1, TimeUnit.SECONDS));
}
Assert.assertNull(messages.poll(1, TimeUnit.SECONDS));
disconnectBayeuxClient(client);
}
}