git-svn-id: https://svn.apache.org/repos/asf/activemq/trunk@1356431 13f79535-47bb-0310-9956-ffa450edef68
This commit is contained in:
Timothy A. Bish 2012-07-02 19:36:24 +00:00
parent e0d264181f
commit ae5bd2ec3c
4 changed files with 309 additions and 85 deletions

View File

@ -808,4 +808,14 @@ public abstract class PrefetchSubscription extends AbstractSubscription {
protected int getPrefetchExtension() { protected int getPrefetchExtension() {
return this.prefetchExtension.get(); return this.prefetchExtension.get();
} }
@Override
public void setPrefetchSize(int prefetchSize) {
this.info.setPrefetchSize(prefetchSize);
try {
this.dispatchPending();
} catch (Exception e) {
LOG.trace("Caught exception during dispatch after prefetch change.", e);
}
}
} }

View File

@ -18,7 +18,6 @@ package org.apache.activemq.broker.region;
import java.io.IOException; import java.io.IOException;
import java.util.ArrayList; import java.util.ArrayList;
import java.util.HashMap;
import java.util.LinkedList; import java.util.LinkedList;
import java.util.List; import java.util.List;
import java.util.Map; import java.util.Map;
@ -153,13 +152,13 @@ public class Topic extends BaseDestination implements Task {
synchronized (consumers) { synchronized (consumers) {
boolean hasSubscription = false; boolean hasSubscription = false;
if(consumers.size()==0) { if (consumers.size() == 0) {
hasSubscription = false; hasSubscription = false;
} else { } else {
for(Subscription currentSub : consumers) { for (Subscription currentSub : consumers) {
if(currentSub.getConsumerInfo().isDurable()) { if (currentSub.getConsumerInfo().isDurable()) {
DurableTopicSubscription dcurrentSub = (DurableTopicSubscription) currentSub; DurableTopicSubscription dcurrentSub = (DurableTopicSubscription) currentSub;
if(dcurrentSub.getSubscriptionKey().equals(dsub.getSubscriptionKey())) { if (dcurrentSub.getSubscriptionKey().equals(dsub.getSubscriptionKey())) {
hasSubscription = true; hasSubscription = true;
break; break;
} }
@ -167,16 +166,16 @@ public class Topic extends BaseDestination implements Task {
} }
} }
if(!hasSubscription) if (!hasSubscription) {
consumers.add(sub); consumers.add(sub);
} }
} }
}
durableSubcribers.put(dsub.getSubscriptionKey(), dsub); durableSubcribers.put(dsub.getSubscriptionKey(), dsub);
} }
} }
public void removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId) public void removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId) throws Exception {
throws Exception {
if (!sub.getConsumerInfo().isDurable()) { if (!sub.getConsumerInfo().isDurable()) {
super.removeSubscription(context, sub, lastDeliveredSequenceId); super.removeSubscription(context, sub, lastDeliveredSequenceId);
synchronized (consumers) { synchronized (consumers) {
@ -332,9 +331,7 @@ public class Topic extends BaseDestination implements Task {
+ " See http://activemq.apache.org/producer-flow-control.html for more info"); + " See http://activemq.apache.org/producer-flow-control.html for more info");
} }
// We can avoid blocking due to low usage if the producer is // We can avoid blocking due to low usage if the producer is sending a sync message or
// sending
// a sync message or
// if it is using a producer window // if it is using a producer window
if (producerInfo.getWindowSize() > 0 || message.isResponseRequired()) { if (producerInfo.getWindowSize() > 0 || message.isResponseRequired()) {
synchronized (messagesWaitingForSpace) { synchronized (messagesWaitingForSpace) {
@ -378,10 +375,8 @@ public class Topic extends BaseDestination implements Task {
} }
} else { } else {
// Producer flow control cannot be used, so we have do the // Producer flow control cannot be used, so we have do the flow control
// flow // at the broker by blocking this thread until there is space available.
// control at the broker
// by blocking this thread until there is space available.
if (memoryUsage.isFull()) { if (memoryUsage.isFull()) {
if (context.isInTransaction()) { if (context.isInTransaction()) {
@ -763,17 +758,6 @@ public class Topic extends BaseDestination implements Task {
} }
} }
private void clearPendingMessages(SubscriptionKey subscriptionKey) {
dispatchLock.readLock().lock();
try {
DurableTopicSubscription durableTopicSubscription = durableSubcribers.get(subscriptionKey);
clearPendingAndDispatch(durableTopicSubscription);
} finally {
dispatchLock.readLock().unlock();
}
}
private void clearPendingAndDispatch(DurableTopicSubscription durableTopicSubscription) { private void clearPendingAndDispatch(DurableTopicSubscription durableTopicSubscription) {
synchronized (durableTopicSubscription.pendingLock) { synchronized (durableTopicSubscription.pendingLock) {
durableTopicSubscription.pending.clear(); durableTopicSubscription.pending.clear();
@ -790,5 +774,4 @@ public class Topic extends BaseDestination implements Task {
public Map<SubscriptionKey, DurableTopicSubscription> getDurableTopicSubs() { public Map<SubscriptionKey, DurableTopicSubscription> getDurableTopicSubs() {
return durableSubcribers; return durableSubcribers;
} }
} }

View File

@ -19,7 +19,9 @@ package org.apache.activemq.broker.region;
import java.io.IOException; import java.io.IOException;
import java.util.LinkedList; import java.util.LinkedList;
import java.util.concurrent.atomic.AtomicLong; import java.util.concurrent.atomic.AtomicLong;
import javax.jms.JMSException; import javax.jms.JMSException;
import org.apache.activemq.ActiveMQMessageAudit; import org.apache.activemq.ActiveMQMessageAudit;
import org.apache.activemq.broker.Broker; import org.apache.activemq.broker.Broker;
import org.apache.activemq.broker.ConnectionContext; import org.apache.activemq.broker.ConnectionContext;
@ -99,9 +101,9 @@ public class TopicSubscription extends AbstractSubscription {
dispatch(node); dispatch(node);
setSlowConsumer(false); setSlowConsumer(false);
} else { } else {
if ( info.getPrefetchSize() > 1 && matched.size() > info.getPrefetchSize() ) { if (info.getPrefetchSize() > 1 && matched.size() > info.getPrefetchSize()) {
//we are slow // Slow consumers should log and set their state as such.
if(!isSlowConsumer()) { if (!isSlowConsumer()) {
LOG.warn(toString() + ": has twice its prefetch limit pending, without an ack; it appears to be slow"); LOG.warn(toString() + ": has twice its prefetch limit pending, without an ack; it appears to be slow");
setSlowConsumer(true); setSlowConsumer(true);
for (Destination dest: destinations) { for (Destination dest: destinations) {
@ -131,15 +133,14 @@ public class TopicSubscription extends AbstractSubscription {
} }
matchedListMutex.wait(20); matchedListMutex.wait(20);
} }
//Temporary storage could be full - so just try to add the message // Temporary storage could be full - so just try to add the message
//see https://issues.apache.org/activemq/browse/AMQ-2475 // see https://issues.apache.org/activemq/browse/AMQ-2475
if (matched.tryAddMessageLast(node, 10)) { if (matched.tryAddMessageLast(node, 10)) {
break; break;
} }
} }
} }
synchronized (matchedListMutex) { synchronized (matchedListMutex) {
// NOTE - be careful about the slaveBroker! // NOTE - be careful about the slaveBroker!
if (maximumPendingMessages > 0) { if (maximumPendingMessages > 0) {
// calculate the high water mark from which point we // calculate the high water mark from which point we
@ -154,8 +155,7 @@ public class TopicSubscription extends AbstractSubscription {
// lets discard old messages as we are a slow consumer // lets discard old messages as we are a slow consumer
while (!matched.isEmpty() && matched.size() > maximumPendingMessages) { while (!matched.isEmpty() && matched.size() > maximumPendingMessages) {
int pageInSize = matched.size() - maximumPendingMessages; int pageInSize = matched.size() - maximumPendingMessages;
// only page in a 1000 at a time - else we could // only page in a 1000 at a time - else we could blow the memory
// blow da memory
pageInSize = Math.max(1000, pageInSize); pageInSize = Math.max(1000, pageInSize);
LinkedList<MessageReference> list = null; LinkedList<MessageReference> list = null;
MessageReference[] oldMessages=null; MessageReference[] oldMessages=null;
@ -174,8 +174,7 @@ public class TopicSubscription extends AbstractSubscription {
discard(oldMessage); discard(oldMessage);
} }
} }
// lets avoid an infinite loop if we are given a bad // lets avoid an infinite loop if we are given a bad eviction strategy
// eviction strategy
// for a bad strategy lets just not evict // for a bad strategy lets just not evict
if (messagesToEvict == 0) { if (messagesToEvict == 0) {
LOG.warn("No messages to evict returned for " + destination + " from eviction strategy: " + messageEvictionStrategy + " out of " + list.size() + " candidates"); LOG.warn("No messages to evict returned for " + destination + " from eviction strategy: " + messageEvictionStrategy + " out of " + list.size() + " candidates");
@ -275,8 +274,7 @@ public class TopicSubscription extends AbstractSubscription {
dispatchMatched(); dispatchMatched();
return; return;
} else if (ack.isDeliveredAck()) { } else if (ack.isDeliveredAck()) {
// Message was delivered but not acknowledged: update pre-fetch // Message was delivered but not acknowledged: update pre-fetch counters.
// counters.
// also. get these for a consumer expired message. // also. get these for a consumer expired message.
if (destination != null && !ack.isInTransaction()) { if (destination != null && !ack.isInTransaction()) {
destination.getDestinationStatistics().getDequeues().add(ack.getMessageCount()); destination.getDestinationStatistics().getDequeues().add(ack.getMessageCount());
@ -389,7 +387,7 @@ public class TopicSubscription extends AbstractSubscription {
public synchronized void setEnableAudit(boolean enableAudit) { public synchronized void setEnableAudit(boolean enableAudit) {
this.enableAudit = enableAudit; this.enableAudit = enableAudit;
if (enableAudit && audit==null) { if (enableAudit && audit == null) {
audit = new ActiveMQMessageAudit(maxAuditDepth,maxProducersToAudit); audit = new ActiveMQMessageAudit(maxAuditDepth,maxProducersToAudit);
} }
} }
@ -404,7 +402,6 @@ public class TopicSubscription extends AbstractSubscription {
return getDispatchedQueueSize(); return getDispatchedQueueSize();
} }
/** /**
* @return true when 60% or more room is left for dispatching messages * @return true when 60% or more room is left for dispatching messages
*/ */
@ -478,8 +475,7 @@ public class TopicSubscription extends AbstractSubscription {
MessageReference message = matched.next(); MessageReference message = matched.next();
message.decrementReferenceCount(); message.decrementReferenceCount();
matched.remove(); matched.remove();
// Message may have been sitting in the matched list a // Message may have been sitting in the matched list a while
// while
// waiting for the consumer to ak the message. // waiting for the consumer to ak the message.
if (message.isExpired()) { if (message.isExpired()) {
discard(message); discard(message);
@ -503,8 +499,7 @@ public class TopicSubscription extends AbstractSubscription {
md.setConsumerId(info.getConsumerId()); md.setConsumerId(info.getConsumerId());
md.setDestination(node.getRegionDestination().getActiveMQDestination()); md.setDestination(node.getRegionDestination().getActiveMQDestination());
dispatchedCounter.incrementAndGet(); dispatchedCounter.incrementAndGet();
// Keep track if this subscription is receiving messages from a single // Keep track if this subscription is receiving messages from a single destination.
// destination.
if (singleDestination) { if (singleDestination) {
if (destination == null) { if (destination == null) {
destination = node.getRegionDestination(); destination = node.getRegionDestination();
@ -572,4 +567,13 @@ public class TopicSubscription extends AbstractSubscription {
return info.getPrefetchSize(); return info.getPrefetchSize();
} }
@Override
public void setPrefetchSize(int newSize) {
info.setPrefetchSize(newSize);
try {
dispatchMatched();
} catch(Exception e) {
LOG.trace("Caught exception on dispatch after prefetch size change.");
}
}
} }

View File

@ -0,0 +1,227 @@
/**
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You 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.apache.activemq.transport.stomp;
import static org.junit.Assert.assertEquals;
import static org.junit.Assert.fail;
import java.io.IOException;
import java.net.Socket;
import java.net.URI;
import java.util.HashMap;
import java.util.UUID;
import org.apache.activemq.broker.BrokerFactory;
import org.apache.activemq.broker.BrokerService;
import org.junit.After;
import org.junit.Before;
import org.junit.Test;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
public class StompMissingMessageTest {
private static final Logger LOG = LoggerFactory.getLogger(StompMissingMessageTest.class);
protected String bindAddress = "stomp://localhost:61613";
protected String confUri = "xbean:org/apache/activemq/transport/stomp/stomp-auth-broker.xml";
protected String jmsUri = "vm://localhost";
private BrokerService broker;
protected String destination;
@Before
public void setUp() throws Exception {
broker = BrokerFactory.createBroker(new URI(confUri));
broker.setDeleteAllMessagesOnStartup(true);
broker.start();
broker.waitUntilStarted();
destination = "/topic/" + getTopicName();
}
@After
public void tearDown() throws Exception {
if (broker != null) {
broker.stop();
broker.waitUntilStopped();
}
}
@Test
public void testProducerConsumerLoop() throws Exception {
final int ITERATIONS = 500;
int received = 0;
for (int i = 1; i <= ITERATIONS*2; i+=2) {
if (doTestProducerConsumer(i) != null) {
received++;
}
}
assertEquals(ITERATIONS, received);
}
public String doTestProducerConsumer(int index) throws Exception {
String message = null;
assertEquals("Should not be any consumers", 0, broker.getAdminView().getTopicSubscribers().length);
StompConnection producer = stompConnect();
StompConnection consumer = stompConnect();
subscribe(consumer, Integer.toString(index));
sendMessage(producer, index);
try {
StompFrame frame = consumer.receive();
LOG.debug("Consumer got frame: " + message);
assertEquals(index, (int) Integer.valueOf(frame.getBody()));
message = frame.getBody();
} catch(Exception e) {
fail("Consumer["+index+"] got error while consuming: " + e.getMessage());
}
unsubscribe(consumer, Integer.toString(index));
stompDisconnect(consumer);
stompDisconnect(producer);
return message;
}
@Test
public void testProducerDurableConsumerLoop() throws Exception {
final int ITERATIONS = 500;
int received = 0;
for (int i = 1; i <= ITERATIONS*2; i+=2) {
if (doTestProducerDurableConsumer(i) != null) {
received++;
}
}
assertEquals(ITERATIONS, received);
}
public String doTestProducerDurableConsumer(int index) throws Exception {
String message = null;
assertEquals("Should not be any consumers", 0, broker.getAdminView().getTopicSubscribers().length);
StompConnection producer = stompConnect();
StompConnection consumer = stompConnect("test");
subscribe(consumer, Integer.toString(index), true);
sendMessage(producer, index);
try {
StompFrame frame = consumer.receive();
LOG.debug("Consumer got frame: " + message);
assertEquals(index, (int) Integer.valueOf(frame.getBody()));
message = frame.getBody();
} catch(Exception e) {
fail("Consumer["+index+"] got error while consuming: " + e.getMessage());
}
unsubscribe(consumer, Integer.toString(index));
stompDisconnect(consumer);
stompDisconnect(producer);
return message;
}
protected void subscribe(StompConnection stompConnection, String subscriptionId) throws Exception {
subscribe(stompConnection, subscriptionId, false);
}
protected void subscribe(StompConnection stompConnection, String subscriptionId, boolean durable) throws Exception {
HashMap<String, String> headers = new HashMap<String, String>();
headers.put("id", subscriptionId);
if (durable) {
headers.put("activemq.subscriptionName", subscriptionId);
}
headers.put(Stomp.Headers.RECEIPT_REQUESTED, UUID.randomUUID().toString());
stompConnection.subscribe(destination, "auto", headers);
StompFrame received = stompConnection.receive();
assertEquals("RECEIPT", received.getAction());
String receipt = received.getHeaders().get(Stomp.Headers.Response.RECEIPT_ID);
assertEquals(headers.get(Stomp.Headers.RECEIPT_REQUESTED), receipt);
}
protected void unsubscribe(StompConnection stompConnection, String subscriptionId) throws Exception {
HashMap<String, String> headers = new HashMap<String, String>();
headers.put("id", subscriptionId);
headers.put(Stomp.Headers.RECEIPT_REQUESTED, UUID.randomUUID().toString());
stompConnection.unsubscribe(destination, headers);
StompFrame received = stompConnection.receive();
assertEquals("RECEIPT", received.getAction());
String receipt = received.getHeaders().get(Stomp.Headers.Response.RECEIPT_ID);
assertEquals(headers.get(Stomp.Headers.RECEIPT_REQUESTED), receipt);
}
protected void sendMessage(StompConnection producer, int index) throws Exception {
HashMap<String, String> headers = new HashMap<String, String>();
headers.put(Stomp.Headers.RECEIPT_REQUESTED, UUID.randomUUID().toString());
producer.send(destination, Integer.toString(index), null, headers);
StompFrame received = producer.receive();
assertEquals("RECEIPT", received.getAction());
String receipt = received.getHeaders().get(Stomp.Headers.Response.RECEIPT_ID);
assertEquals(headers.get(Stomp.Headers.RECEIPT_REQUESTED), receipt);
}
protected StompConnection stompConnect() throws Exception {
return stompConnect(null);
}
protected StompConnection stompConnect(String clientId) throws Exception {
StompConnection stompConnection = new StompConnection();
URI connectUri = new URI(bindAddress);
stompConnection.open(createSocket(connectUri));
stompConnection.connect("system", "manager", clientId);
return stompConnection;
}
protected Socket createSocket(URI connectUri) throws IOException {
return new Socket("127.0.0.1", connectUri.getPort());
}
protected String getTopicName() {
return getClass().getName() + ".Messages";
}
protected void stompDisconnect(StompConnection connection) throws Exception {
if (connection != null) {
String receiptId = UUID.randomUUID().toString();
connection.disconnect(receiptId);
if (!connection.receive().getAction().equals(Stomp.Responses.RECEIPT)) {
throw new Exception("Failed to receive receipt for disconnect.");
}
connection.close();
connection = null;
}
}
}