git-svn-id: https://svn.apache.org/repos/asf/activemq/trunk@1503263 13f79535-47bb-0310-9956-ffa450edef68
This commit is contained in:
Timothy A. Bish 2013-07-15 14:21:23 +00:00
parent 8abbfb2376
commit c50b8e49c4
3 changed files with 211 additions and 45 deletions

View File

@ -108,8 +108,7 @@ public class Queue extends BaseDestination implements Task, UsageListener {
protected PendingMessageCursor messages; protected PendingMessageCursor messages;
private final ReentrantReadWriteLock pagedInMessagesLock = new ReentrantReadWriteLock(); private final ReentrantReadWriteLock pagedInMessagesLock = new ReentrantReadWriteLock();
private final LinkedHashMap<MessageId, QueueMessageReference> pagedInMessages = new LinkedHashMap<MessageId, QueueMessageReference>(); private final LinkedHashMap<MessageId, QueueMessageReference> pagedInMessages = new LinkedHashMap<MessageId, QueueMessageReference>();
// Messages that are paged in but have not yet been targeted at a // Messages that are paged in but have not yet been targeted at a subscription
// subscription
private final ReentrantReadWriteLock pagedInPendingDispatchLock = new ReentrantReadWriteLock(); private final ReentrantReadWriteLock pagedInPendingDispatchLock = new ReentrantReadWriteLock();
protected PendingList pagedInPendingDispatch = new OrderedPendingList(); protected PendingList pagedInPendingDispatch = new OrderedPendingList();
protected PendingList redeliveredWaitingDispatch = new OrderedPendingList(); protected PendingList redeliveredWaitingDispatch = new OrderedPendingList();
@ -177,7 +176,6 @@ public class Queue extends BaseDestination implements Task, UsageListener {
} }
return returnValue; return returnValue;
} }
} }
DelayQueue<TimeoutMessage> flowControlTimeoutMessages = new DelayQueue<TimeoutMessage>(); DelayQueue<TimeoutMessage> flowControlTimeoutMessages = new DelayQueue<TimeoutMessage>();
@ -450,7 +448,6 @@ public class Queue extends BaseDestination implements Task, UsageListener {
// consumersLock. // consumersLock.
consumersLock.writeLock().lock(); consumersLock.writeLock().lock();
try { try {
// set a flag if this is a first consumer // set a flag if this is a first consumer
if (consumers.size() == 0) { if (consumers.size() == 0) {
firstConsumer = true; firstConsumer = true;
@ -639,8 +636,7 @@ public class Queue extends BaseDestination implements Task, UsageListener {
if (isProducerFlowControl() && context.isProducerFlowControl()) { if (isProducerFlowControl() && context.isProducerFlowControl()) {
if (warnOnProducerFlowControl) { if (warnOnProducerFlowControl) {
warnOnProducerFlowControl = false; warnOnProducerFlowControl = false;
LOG LOG.info("Usage Manager Memory Limit ("
.info("Usage Manager Memory Limit ("
+ memoryUsage.getLimit() + memoryUsage.getLimit()
+ ") reached on " + ") reached on "
+ getActiveMQDestination().getQualifiedName() + getActiveMQDestination().getQualifiedName()
@ -1120,7 +1116,6 @@ public class Queue extends BaseDestination implements Task, UsageListener {
return allConsumersExclusiveByDefault; return allConsumersExclusiveByDefault;
} }
// Implementation methods // Implementation methods
// ------------------------------------------------------------------------- // -------------------------------------------------------------------------
private QueueMessageReference createMessageReference(Message message) { private QueueMessageReference createMessageReference(Message message) {
@ -1209,7 +1204,6 @@ public class Queue extends BaseDestination implements Task, UsageListener {
messagesLock.writeLock().unlock(); messagesLock.writeLock().unlock();
} }
} }
} catch (Exception e) { } catch (Exception e) {
LOG.error("Problem retrieving message for browse", e); LOG.error("Problem retrieving message for browse", e);
} }
@ -1282,6 +1276,7 @@ public class Queue extends BaseDestination implements Task, UsageListener {
// don't spin/hang if stats are out and there is nothing left in the // don't spin/hang if stats are out and there is nothing left in the
// store // store
} while (!list.isEmpty() && this.destinationStatistics.getMessages().getCount() > 0); } while (!list.isEmpty() && this.destinationStatistics.getMessages().getCount() > 0);
if (this.destinationStatistics.getMessages().getCount() > 0) { if (this.destinationStatistics.getMessages().getCount() > 0) {
LOG.warn(getActiveMQDestination().getQualifiedName() LOG.warn(getActiveMQDestination().getQualifiedName()
+ " after purge complete, message count stats report: " + " after purge complete, message count stats report: "
@ -1615,7 +1610,6 @@ public class Queue extends BaseDestination implements Task, UsageListener {
} }
} }
messagesLock.readLock().lock(); messagesLock.readLock().lock();
try{ try{
pageInMoreMessages |= !messages.isEmpty(); pageInMoreMessages |= !messages.isEmpty();
@ -1640,7 +1634,6 @@ public class Queue extends BaseDestination implements Task, UsageListener {
if (pageInMoreMessages || hasBrowsers || !redeliveredWaitingDispatch.isEmpty()) { if (pageInMoreMessages || hasBrowsers || !redeliveredWaitingDispatch.isEmpty()) {
try { try {
pageInMessages(hasBrowsers); pageInMessages(hasBrowsers);
} catch (Throwable e) { } catch (Throwable e) {
LOG.error("Failed to page in more queue messages ", e); LOG.error("Failed to page in more queue messages ", e);
} }
@ -1670,7 +1663,7 @@ public class Queue extends BaseDestination implements Task, UsageListener {
} }
boolean added = false; boolean added = false;
for (QueueMessageReference node : alreadyDispatchedMessages) { for (QueueMessageReference node : alreadyDispatchedMessages) {
if (!node.isAcked() && !browser.getPending().getMessageAudit().isDuplicate(node.getMessageId())) { if (!node.isAcked() && !browser.isDuplicate(node.getMessageId())) {
msgContext.setMessageReference(node); msgContext.setMessageReference(node);
if (browser.matches(node, msgContext)) { if (browser.matches(node, msgContext)) {
browser.add(node); browser.add(node);
@ -1750,7 +1743,6 @@ public class Queue extends BaseDestination implements Task, UsageListener {
} finally { } finally {
pagedInPendingDispatchLock.writeLock().unlock(); pagedInPendingDispatchLock.writeLock().unlock();
} }
} }
protected void removeMessage(ConnectionContext c, Subscription subs, QueueMessageReference r) throws IOException { protected void removeMessage(ConnectionContext c, Subscription subs, QueueMessageReference r) throws IOException {
@ -2149,7 +2141,6 @@ public class Queue extends BaseDestination implements Task, UsageListener {
} }
return result; return result;
} }
protected void assignGroup(Subscription subs, MessageGroupMap messageGroupOwners, MessageReference n, String groupId) throws IOException { protected void assignGroup(Subscription subs, MessageGroupMap messageGroupOwners, MessageReference n, String groupId) throws IOException {

View File

@ -18,7 +18,9 @@ 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.List; import java.util.List;
import java.util.Map;
import javax.jms.JMSException; import javax.jms.JMSException;
@ -26,15 +28,22 @@ import org.apache.activemq.broker.Broker;
import org.apache.activemq.broker.ConnectionContext; import org.apache.activemq.broker.ConnectionContext;
import org.apache.activemq.command.ConsumerInfo; import org.apache.activemq.command.ConsumerInfo;
import org.apache.activemq.command.MessageAck; import org.apache.activemq.command.MessageAck;
import org.apache.activemq.command.MessageId;
import org.apache.activemq.filter.MessageEvaluationContext; import org.apache.activemq.filter.MessageEvaluationContext;
import org.apache.activemq.usage.SystemUsage; import org.apache.activemq.usage.SystemUsage;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
public class QueueBrowserSubscription extends QueueSubscription { public class QueueBrowserSubscription extends QueueSubscription {
protected static final Logger LOG = LoggerFactory.getLogger(QueueBrowserSubscription.class);
int queueRefs; int queueRefs;
boolean browseDone; boolean browseDone;
boolean destinationsAdded; boolean destinationsAdded;
private final Map<MessageId, Object> audit = new HashMap<MessageId, Object>();
public QueueBrowserSubscription(Broker broker, SystemUsage usageManager, ConnectionContext context, ConsumerInfo info) throws JMSException { public QueueBrowserSubscription(Broker broker, SystemUsage usageManager, ConnectionContext context, ConsumerInfo info) throws JMSException {
super(broker, usageManager, context, info); super(broker, usageManager, context, info);
} }
@ -56,6 +65,16 @@ public class QueueBrowserSubscription extends QueueSubscription {
checkDone(); checkDone();
} }
public boolean isDuplicate(MessageId messageId) {
if (!audit.containsKey(messageId)) {
audit.put(messageId, Boolean.TRUE);
return false;
}
return true;
}
private void checkDone() throws Exception { private void checkDone() throws Exception {
if (!browseDone && queueRefs == 0 && destinationsAdded) { if (!browseDone && queueRefs == 0 && destinationsAdded) {
browseDone = true; browseDone = true;

View File

@ -0,0 +1,156 @@
/**
* 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.bugs;
import static org.junit.Assert.assertEquals;
import java.net.URI;
import java.util.Date;
import java.util.Enumeration;
import javax.jms.Connection;
import javax.jms.DeliveryMode;
import javax.jms.JMSException;
import javax.jms.MessageProducer;
import javax.jms.QueueBrowser;
import javax.jms.Session;
import javax.jms.TextMessage;
import org.apache.activemq.ActiveMQConnection;
import org.apache.activemq.ActiveMQConnectionFactory;
import org.apache.activemq.broker.BrokerService;
import org.apache.activemq.broker.TransportConnector;
import org.apache.activemq.command.ActiveMQQueue;
import org.junit.After;
import org.junit.Before;
import org.junit.Test;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
public class AMQ4595Test {
private static final Logger LOG = LoggerFactory.getLogger(AMQ4595Test.class);
private BrokerService broker;
private URI connectUri;
private ActiveMQConnectionFactory factory;
@Before
public void startBroker() throws Exception {
broker = new BrokerService();
TransportConnector connector = broker.addConnector("vm://localhost");
broker.deleteAllMessages();
// PolicyEntry policy = new PolicyEntry();
// policy.setQueue(">");
// policy.setMaxAuditDepth(16384);
// policy.setCursorMemoryHighWaterMark(95); // More breathing room.
// PolicyMap pMap = new PolicyMap();
// pMap.setDefaultEntry(policy);
// broker.setDestinationPolicy(pMap);
broker.getSystemUsage().getMemoryUsage().setLimit(256 * 1024 * 1024);
broker.start();
broker.waitUntilStarted();
connectUri = connector.getConnectUri();
factory = new ActiveMQConnectionFactory(connectUri);
}
@After
public void stopBroker() throws Exception {
broker.stop();
broker.waitUntilStopped();
}
@Test(timeout=120000)
public void testBrowsingSmallBatch() throws JMSException {
doTestBrowsing(100);
}
@Test(timeout=160000)
public void testBrowsingMediumBatch() throws JMSException {
doTestBrowsing(1000);
}
@Test(timeout=300000)
public void testBrowsingLargeBatch() throws JMSException {
doTestBrowsing(10000);
}
private void doTestBrowsing(int messageToSend) throws JMSException {
ActiveMQQueue queue = new ActiveMQQueue("TEST");
// Send the messages to the Queue.
ActiveMQConnection producerConnection = (ActiveMQConnection) factory.createConnection();
producerConnection.setUseAsyncSend(true);
producerConnection.start();
Session producerSession = producerConnection.createSession(false, Session.AUTO_ACKNOWLEDGE);
MessageProducer producer = producerSession.createProducer(queue);
producer.setDeliveryMode(DeliveryMode.PERSISTENT);
for (int i = 1; i <= messageToSend; i++) {
String msgStr = provideMessageText(i, 8192);
producer.send(producerSession.createTextMessage(msgStr));
if ((i % 1000) == 0) {
LOG.info("P&C: {}", msgStr.substring(0, 100));
}
}
producerConnection.close();
// Browse the queue.
Connection connection = factory.createConnection();
connection.start();
Session session = connection.createSession(true, Session.AUTO_ACKNOWLEDGE);
QueueBrowser browser = session.createBrowser(queue);
Enumeration<?> enumeration = browser.getEnumeration();
int browsed = 0;
while (enumeration.hasMoreElements()) {
TextMessage m = (TextMessage) enumeration.nextElement();
browsed++;
if ((browsed % 1000) == 0) {
LOG.info("B[{}]: {}", browsed, m.getText().substring(0, 100));
}
}
browser.close();
session.close();
connection.close();
// The number of messages browsed should be equal to the number of messages sent.
assertEquals(messageToSend, browsed);
browser.close();
}
public String provideMessageText(int messageNumber, int messageSize) {
StringBuilder buf = new StringBuilder();
buf.append("Message: ");
if (messageNumber > 0) {
buf.append(messageNumber);
}
buf.append(" sent at: ").append(new Date());
if (buf.length() > messageSize) {
return buf.substring(0, messageSize);
}
for (int i = buf.length(); i < messageSize; i++) {
buf.append(' ');
}
return buf.toString();
}
}