mirror of https://github.com/apache/activemq.git
https://issues.apache.org/activemq/browse/AMQ-2590 - ensure beforeEnd is called once per transaction so ack on rollback is avoided, add more tests
git-svn-id: https://svn.apache.org/repos/asf/activemq/trunk@907174 13f79535-47bb-0310-9956-ffa450edef68
This commit is contained in:
parent
ecaacd852e
commit
39d071798a
|
@ -16,6 +16,28 @@
|
||||||
*/
|
*/
|
||||||
package org.apache.activemq;
|
package org.apache.activemq;
|
||||||
|
|
||||||
|
import java.io.IOException;
|
||||||
|
import java.util.ArrayList;
|
||||||
|
import java.util.HashMap;
|
||||||
|
import java.util.Iterator;
|
||||||
|
import java.util.LinkedList;
|
||||||
|
import java.util.List;
|
||||||
|
import java.util.Map;
|
||||||
|
import java.util.Map.Entry;
|
||||||
|
import java.util.concurrent.ExecutorService;
|
||||||
|
import java.util.concurrent.Executors;
|
||||||
|
import java.util.concurrent.TimeUnit;
|
||||||
|
import java.util.concurrent.atomic.AtomicBoolean;
|
||||||
|
import java.util.concurrent.atomic.AtomicReference;
|
||||||
|
|
||||||
|
import javax.jms.IllegalStateException;
|
||||||
|
import javax.jms.InvalidDestinationException;
|
||||||
|
import javax.jms.JMSException;
|
||||||
|
import javax.jms.Message;
|
||||||
|
import javax.jms.MessageConsumer;
|
||||||
|
import javax.jms.MessageListener;
|
||||||
|
import javax.jms.TransactionRolledBackException;
|
||||||
|
|
||||||
import org.apache.activemq.blob.BlobDownloader;
|
import org.apache.activemq.blob.BlobDownloader;
|
||||||
import org.apache.activemq.command.ActiveMQBlobMessage;
|
import org.apache.activemq.command.ActiveMQBlobMessage;
|
||||||
import org.apache.activemq.command.ActiveMQDestination;
|
import org.apache.activemq.command.ActiveMQDestination;
|
||||||
|
@ -29,6 +51,7 @@ import org.apache.activemq.command.MessageDispatch;
|
||||||
import org.apache.activemq.command.MessageId;
|
import org.apache.activemq.command.MessageId;
|
||||||
import org.apache.activemq.command.MessagePull;
|
import org.apache.activemq.command.MessagePull;
|
||||||
import org.apache.activemq.command.RemoveInfo;
|
import org.apache.activemq.command.RemoveInfo;
|
||||||
|
import org.apache.activemq.command.TransactionId;
|
||||||
import org.apache.activemq.management.JMSConsumerStatsImpl;
|
import org.apache.activemq.management.JMSConsumerStatsImpl;
|
||||||
import org.apache.activemq.management.StatsCapable;
|
import org.apache.activemq.management.StatsCapable;
|
||||||
import org.apache.activemq.management.StatsImpl;
|
import org.apache.activemq.management.StatsImpl;
|
||||||
|
@ -40,27 +63,6 @@ import org.apache.activemq.util.IntrospectionSupport;
|
||||||
import org.apache.activemq.util.JMSExceptionSupport;
|
import org.apache.activemq.util.JMSExceptionSupport;
|
||||||
import org.apache.commons.logging.Log;
|
import org.apache.commons.logging.Log;
|
||||||
import org.apache.commons.logging.LogFactory;
|
import org.apache.commons.logging.LogFactory;
|
||||||
import java.io.IOException;
|
|
||||||
import java.util.ArrayList;
|
|
||||||
import java.util.HashMap;
|
|
||||||
import java.util.Iterator;
|
|
||||||
import java.util.LinkedList;
|
|
||||||
import java.util.List;
|
|
||||||
import java.util.ListIterator;
|
|
||||||
import java.util.Map;
|
|
||||||
import java.util.Map.Entry;
|
|
||||||
import java.util.concurrent.ExecutorService;
|
|
||||||
import java.util.concurrent.Executors;
|
|
||||||
import java.util.concurrent.TimeUnit;
|
|
||||||
import java.util.concurrent.atomic.AtomicBoolean;
|
|
||||||
import java.util.concurrent.atomic.AtomicReference;
|
|
||||||
import javax.jms.IllegalStateException;
|
|
||||||
import javax.jms.InvalidDestinationException;
|
|
||||||
import javax.jms.JMSException;
|
|
||||||
import javax.jms.Message;
|
|
||||||
import javax.jms.MessageConsumer;
|
|
||||||
import javax.jms.MessageListener;
|
|
||||||
import javax.jms.TransactionRolledBackException;
|
|
||||||
|
|
||||||
/**
|
/**
|
||||||
* A client uses a <CODE>MessageConsumer</CODE> object to receive messages
|
* A client uses a <CODE>MessageConsumer</CODE> object to receive messages
|
||||||
|
@ -100,6 +102,14 @@ import javax.jms.TransactionRolledBackException;
|
||||||
*/
|
*/
|
||||||
public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsCapable, ActiveMQDispatcher {
|
public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsCapable, ActiveMQDispatcher {
|
||||||
|
|
||||||
|
@SuppressWarnings("serial")
|
||||||
|
class PreviouslyDeliveredMap<K, V> extends HashMap<K, V> {
|
||||||
|
final TransactionId transactionId;
|
||||||
|
public PreviouslyDeliveredMap(TransactionId transactionId) {
|
||||||
|
this.transactionId = transactionId;
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
private static final Log LOG = LogFactory.getLog(ActiveMQMessageConsumer.class);
|
private static final Log LOG = LogFactory.getLog(ActiveMQMessageConsumer.class);
|
||||||
protected static final Scheduler scheduler = Scheduler.getInstance();
|
protected static final Scheduler scheduler = Scheduler.getInstance();
|
||||||
protected final ActiveMQSession session;
|
protected final ActiveMQSession session;
|
||||||
|
@ -113,7 +123,7 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
// Always walk list in reverse order.
|
// Always walk list in reverse order.
|
||||||
private final LinkedList<MessageDispatch> deliveredMessages = new LinkedList<MessageDispatch>();
|
private final LinkedList<MessageDispatch> deliveredMessages = new LinkedList<MessageDispatch>();
|
||||||
// track duplicate deliveries in a transaction such that the tx integrity can be validated
|
// track duplicate deliveries in a transaction such that the tx integrity can be validated
|
||||||
private HashMap<MessageId, Boolean> previouslyDeliveredMessages;
|
private PreviouslyDeliveredMap<MessageId, Boolean> previouslyDeliveredMessages;
|
||||||
private int deliveredCounter;
|
private int deliveredCounter;
|
||||||
private int additionalWindowSize;
|
private int additionalWindowSize;
|
||||||
private long redeliveryDelay;
|
private long redeliveryDelay;
|
||||||
|
@ -143,7 +153,6 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
private long optimizeAckTimestamp = System.currentTimeMillis();
|
private long optimizeAckTimestamp = System.currentTimeMillis();
|
||||||
private long optimizeAckTimeout = 300;
|
private long optimizeAckTimeout = 300;
|
||||||
private long failoverRedeliveryWaitPeriod = 0;
|
private long failoverRedeliveryWaitPeriod = 0;
|
||||||
private boolean rollbackInitiated;
|
|
||||||
|
|
||||||
/**
|
/**
|
||||||
* Create a MessageConsumer
|
* Create a MessageConsumer
|
||||||
|
@ -558,8 +567,7 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
|
|
||||||
MessageDispatch md;
|
MessageDispatch md;
|
||||||
if (info.getPrefetchSize() == 0) {
|
if (info.getPrefetchSize() == 0) {
|
||||||
md = dequeue(-1); // We let the broker let us know when we
|
md = dequeue(-1); // We let the broker let us know when we timeout.
|
||||||
// timeout.
|
|
||||||
} else {
|
} else {
|
||||||
md = dequeue(timeout);
|
md = dequeue(timeout);
|
||||||
}
|
}
|
||||||
|
@ -992,7 +1000,8 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
if (numberNotReplayed > 0) {
|
if (numberNotReplayed > 0) {
|
||||||
LOG.info("waiting for redelivery of " + numberNotReplayed + " to consumer :" + this.getConsumerId());
|
LOG.info("waiting for redelivery of " + numberNotReplayed + " in transaction: "
|
||||||
|
+ previouslyDeliveredMessages.transactionId + ", to consumer :" + this.getConsumerId());
|
||||||
try {
|
try {
|
||||||
Thread.sleep(Math.max(500, failoverRedeliveryWaitPeriod/4));
|
Thread.sleep(Math.max(500, failoverRedeliveryWaitPeriod/4));
|
||||||
} catch (InterruptedException outOfhere) {
|
} catch (InterruptedException outOfhere) {
|
||||||
|
@ -1008,12 +1017,6 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
*/
|
*/
|
||||||
private void rollbackOnFailedRecoveryRedelivery() throws JMSException {
|
private void rollbackOnFailedRecoveryRedelivery() throws JMSException {
|
||||||
if (previouslyDeliveredMessages != null) {
|
if (previouslyDeliveredMessages != null) {
|
||||||
if (rollbackInitiated) {
|
|
||||||
// second call from rollback, nothing more to do
|
|
||||||
// REVISIT - should beforeEnd be called again by transaction context?
|
|
||||||
rollbackInitiated = false;
|
|
||||||
return;
|
|
||||||
}
|
|
||||||
// if any previously delivered messages was not re-delivered, transaction is invalid and must rollback
|
// if any previously delivered messages was not re-delivered, transaction is invalid and must rollback
|
||||||
// as messages have been dispatched else where.
|
// as messages have been dispatched else where.
|
||||||
int numberNotReplayed = 0;
|
int numberNotReplayed = 0;
|
||||||
|
@ -1021,20 +1024,20 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
if (!entry.getValue()) {
|
if (!entry.getValue()) {
|
||||||
numberNotReplayed++;
|
numberNotReplayed++;
|
||||||
if (LOG.isDebugEnabled()) {
|
if (LOG.isDebugEnabled()) {
|
||||||
LOG.debug("previously delivered message has not been replayed in transaction, id: " + entry.getKey());
|
LOG.debug("previously delivered message has not been replayed in transaction: "
|
||||||
|
+ previouslyDeliveredMessages.transactionId
|
||||||
|
+ " , messageId: " + entry.getKey());
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
if (numberNotReplayed > 0) {
|
if (numberNotReplayed > 0) {
|
||||||
String message = "rolling back transaction post failover recovery. " + numberNotReplayed
|
String message = "rolling back transaction ("
|
||||||
|
+ previouslyDeliveredMessages.transactionId + ") post failover recovery. " + numberNotReplayed
|
||||||
+ " previously delivered message(s) not replayed to consumer: " + this.getConsumerId();
|
+ " previously delivered message(s) not replayed to consumer: " + this.getConsumerId();
|
||||||
LOG.warn(message);
|
LOG.warn(message);
|
||||||
rollbackInitiated = true;
|
throw new TransactionRolledBackException(message);
|
||||||
throw new TransactionRolledBackException(message);
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
}
|
}
|
||||||
|
|
||||||
void acknowledge(MessageDispatch md) throws JMSException {
|
void acknowledge(MessageDispatch md) throws JMSException {
|
||||||
|
@ -1157,7 +1160,6 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
removeFromDeliveredMessages(entry.getKey());
|
removeFromDeliveredMessages(entry.getKey());
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
rollbackInitiated = false;
|
|
||||||
clearPreviouslyDelivered();
|
clearPreviouslyDelivered();
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -1166,9 +1168,9 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
* called with deliveredMessages locked
|
* called with deliveredMessages locked
|
||||||
*/
|
*/
|
||||||
private void removeFromDeliveredMessages(MessageId key) {
|
private void removeFromDeliveredMessages(MessageId key) {
|
||||||
ListIterator<MessageDispatch> iterator = deliveredMessages.listIterator(deliveredMessages.size());
|
Iterator<MessageDispatch> iterator = deliveredMessages.iterator();
|
||||||
while (iterator.hasPrevious()) {
|
while (iterator.hasNext()) {
|
||||||
MessageDispatch candidate = iterator.previous();
|
MessageDispatch candidate = iterator.next();
|
||||||
if (key.equals(candidate.getMessage().getMessageId())) {
|
if (key.equals(candidate.getMessage().getMessageId())) {
|
||||||
session.connection.rollbackDuplicate(this, candidate.getMessage());
|
session.connection.rollbackDuplicate(this, candidate.getMessage());
|
||||||
iterator.remove();
|
iterator.remove();
|
||||||
|
@ -1234,13 +1236,15 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
if (previouslyDeliveredMessages != null) {
|
if (previouslyDeliveredMessages != null) {
|
||||||
previouslyDeliveredMessages.put(md.getMessage().getMessageId(), true);
|
previouslyDeliveredMessages.put(md.getMessage().getMessageId(), true);
|
||||||
} else {
|
} else {
|
||||||
// existing transaction gone but still a duplicate!, lets mark as poison ftm,
|
// delivery while pending redelivery to another consumer on the same connection
|
||||||
// possibly could allow redelivery..
|
// not waiting for redelivery will help here
|
||||||
needsPoisonAck = true;
|
needsPoisonAck = true;
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
if (needsPoisonAck) {
|
if (needsPoisonAck) {
|
||||||
LOG.warn("acking as poison, duplicate transacted delivery but no recovering transaction for: " + md);
|
LOG.warn("acking duplicate delivery as poison, redelivery must be pending to another"
|
||||||
|
+ " consumer on this connection, failoverRedeliveryWaitPeriod="
|
||||||
|
+ failoverRedeliveryWaitPeriod + ". Message: " + md);
|
||||||
MessageAck poisonAck = new MessageAck(md, MessageAck.POSION_ACK_TYPE, 1);
|
MessageAck poisonAck = new MessageAck(md, MessageAck.POSION_ACK_TYPE, 1);
|
||||||
poisonAck.setFirstMessageId(md.getMessage().getMessageId());
|
poisonAck.setFirstMessageId(md.getMessage().getMessageId());
|
||||||
session.sendAck(poisonAck);
|
session.sendAck(poisonAck);
|
||||||
|
@ -1271,7 +1275,7 @@ public class ActiveMQMessageConsumer implements MessageAvailableConsumer, StatsC
|
||||||
LOG.debug(getConsumerId() + " tracking existing transacted delivered list (" + deliveredMessages.size() + ") on transport interrupt");
|
LOG.debug(getConsumerId() + " tracking existing transacted delivered list (" + deliveredMessages.size() + ") on transport interrupt");
|
||||||
}
|
}
|
||||||
if (previouslyDeliveredMessages == null) {
|
if (previouslyDeliveredMessages == null) {
|
||||||
previouslyDeliveredMessages = new HashMap<MessageId, Boolean>();
|
previouslyDeliveredMessages = new PreviouslyDeliveredMap<MessageId, Boolean>(session.getTransactionContext().getTransactionId());
|
||||||
}
|
}
|
||||||
for (MessageDispatch delivered : deliveredMessages) {
|
for (MessageDispatch delivered : deliveredMessages) {
|
||||||
previouslyDeliveredMessages.put(delivered.getMessage().getMessageId(), false);
|
previouslyDeliveredMessages.put(delivered.getMessage().getMessageId(), false);
|
||||||
|
|
|
@ -79,6 +79,7 @@ public class TransactionContext implements XAResource {
|
||||||
private Xid associatedXid;
|
private Xid associatedXid;
|
||||||
private TransactionId transactionId;
|
private TransactionId transactionId;
|
||||||
private LocalTransactionEventListener localTransactionEventListener;
|
private LocalTransactionEventListener localTransactionEventListener;
|
||||||
|
private int beforeEndIndex;
|
||||||
|
|
||||||
public TransactionContext(ActiveMQConnection connection) {
|
public TransactionContext(ActiveMQConnection connection) {
|
||||||
this.connection = connection;
|
this.connection = connection;
|
||||||
|
@ -174,8 +175,8 @@ public class TransactionContext implements XAResource {
|
||||||
|
|
||||||
int size = synchronizations.size();
|
int size = synchronizations.size();
|
||||||
try {
|
try {
|
||||||
for (int i = 0; i < size; i++) {
|
for (;beforeEndIndex < size;) {
|
||||||
synchronizations.get(i).beforeEnd();
|
synchronizations.get(beforeEndIndex++).beforeEnd();
|
||||||
}
|
}
|
||||||
} catch (JMSException e) {
|
} catch (JMSException e) {
|
||||||
throw e;
|
throw e;
|
||||||
|
@ -206,6 +207,7 @@ public class TransactionContext implements XAResource {
|
||||||
|
|
||||||
if (transactionId == null) {
|
if (transactionId == null) {
|
||||||
synchronizations = null;
|
synchronizations = null;
|
||||||
|
beforeEndIndex = 0;
|
||||||
this.transactionId = new LocalTransactionId(connectionId, localTransactionIdGenerator.getNextSequenceId());
|
this.transactionId = new LocalTransactionId(connectionId, localTransactionIdGenerator.getNextSequenceId());
|
||||||
TransactionInfo info = new TransactionInfo(getConnectionId(), transactionId, TransactionInfo.BEGIN);
|
TransactionInfo info = new TransactionInfo(getConnectionId(), transactionId, TransactionInfo.BEGIN);
|
||||||
this.connection.ensureConnectionInfoSent();
|
this.connection.ensureConnectionInfoSent();
|
||||||
|
@ -341,6 +343,7 @@ public class TransactionContext implements XAResource {
|
||||||
|
|
||||||
// associate
|
// associate
|
||||||
synchronizations = null;
|
synchronizations = null;
|
||||||
|
beforeEndIndex = 0;
|
||||||
setXid(xid);
|
setXid(xid);
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -0,0 +1,140 @@
|
||||||
|
/**
|
||||||
|
* 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;
|
||||||
|
|
||||||
|
import static org.junit.Assert.assertEquals;
|
||||||
|
import static org.junit.Assert.fail;
|
||||||
|
|
||||||
|
import java.util.concurrent.atomic.AtomicInteger;
|
||||||
|
|
||||||
|
import javax.jms.TransactionRolledBackException;
|
||||||
|
|
||||||
|
import org.apache.activemq.transaction.Synchronization;
|
||||||
|
import org.junit.After;
|
||||||
|
import org.junit.Before;
|
||||||
|
import org.junit.Test;
|
||||||
|
|
||||||
|
public class TransactionContextTest {
|
||||||
|
|
||||||
|
TransactionContext underTest;
|
||||||
|
ActiveMQConnectionFactory factory = new ActiveMQConnectionFactory("vm://localhost");
|
||||||
|
ActiveMQConnection connection;
|
||||||
|
|
||||||
|
|
||||||
|
@Before
|
||||||
|
public void setup() throws Exception {
|
||||||
|
connection = factory.createActiveMQConnection();
|
||||||
|
underTest = new TransactionContext(connection);
|
||||||
|
}
|
||||||
|
|
||||||
|
@After
|
||||||
|
public void tearDown() throws Exception {
|
||||||
|
connection.close();
|
||||||
|
}
|
||||||
|
|
||||||
|
@Test
|
||||||
|
public void testSyncBeforeEndCalledOnceOnRollback() throws Exception {
|
||||||
|
final AtomicInteger beforeEndCountA = new AtomicInteger(0);
|
||||||
|
final AtomicInteger beforeEndCountB = new AtomicInteger(0);
|
||||||
|
final AtomicInteger rollbackCountA = new AtomicInteger(0);
|
||||||
|
final AtomicInteger rollbackCountB = new AtomicInteger(0);
|
||||||
|
underTest.addSynchronization(new Synchronization() {
|
||||||
|
@Override
|
||||||
|
public void beforeEnd() throws Exception {
|
||||||
|
if (beforeEndCountA.getAndIncrement() == 0) {
|
||||||
|
throw new TransactionRolledBackException("force rollback");
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public void afterCommit() throws Exception {
|
||||||
|
fail("exepcted rollback exception");
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public void afterRollback() throws Exception {
|
||||||
|
rollbackCountA.incrementAndGet();
|
||||||
|
}
|
||||||
|
|
||||||
|
});
|
||||||
|
|
||||||
|
underTest.addSynchronization(new Synchronization() {
|
||||||
|
@Override
|
||||||
|
public void beforeEnd() throws Exception {
|
||||||
|
beforeEndCountB.getAndIncrement();
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public void afterCommit() throws Exception {
|
||||||
|
fail("exepcted rollback exception");
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public void afterRollback() throws Exception {
|
||||||
|
rollbackCountB.incrementAndGet();
|
||||||
|
}
|
||||||
|
|
||||||
|
});
|
||||||
|
|
||||||
|
|
||||||
|
try {
|
||||||
|
underTest.commit();
|
||||||
|
fail("exepcted rollback exception");
|
||||||
|
} catch (TransactionRolledBackException expected) {
|
||||||
|
}
|
||||||
|
|
||||||
|
assertEquals("beforeEnd A called once", 1, beforeEndCountA.get());
|
||||||
|
assertEquals("beforeEnd B called once", 1, beforeEndCountA.get());
|
||||||
|
assertEquals("rollbackCount B 0", 1, rollbackCountB.get());
|
||||||
|
assertEquals("rollbackCount A B", rollbackCountA.get(), rollbackCountB.get());
|
||||||
|
}
|
||||||
|
|
||||||
|
@Test
|
||||||
|
public void testSyncIndexCleared() throws Exception {
|
||||||
|
final AtomicInteger beforeEndCountA = new AtomicInteger(0);
|
||||||
|
final AtomicInteger rollbackCountA = new AtomicInteger(0);
|
||||||
|
Synchronization sync = new Synchronization() {
|
||||||
|
@Override
|
||||||
|
public void beforeEnd() throws Exception {
|
||||||
|
beforeEndCountA.getAndIncrement();
|
||||||
|
}
|
||||||
|
@Override
|
||||||
|
public void afterCommit() throws Exception {
|
||||||
|
fail("exepcted rollback exception");
|
||||||
|
}
|
||||||
|
@Override
|
||||||
|
public void afterRollback() throws Exception {
|
||||||
|
rollbackCountA.incrementAndGet();
|
||||||
|
}
|
||||||
|
};
|
||||||
|
|
||||||
|
underTest.begin();
|
||||||
|
underTest.addSynchronization(sync);
|
||||||
|
underTest.rollback();
|
||||||
|
|
||||||
|
assertEquals("beforeEnd", 1, beforeEndCountA.get());
|
||||||
|
assertEquals("rollback", 1, rollbackCountA.get());
|
||||||
|
|
||||||
|
// do it again
|
||||||
|
underTest.begin();
|
||||||
|
underTest.addSynchronization(sync);
|
||||||
|
underTest.rollback();
|
||||||
|
|
||||||
|
assertEquals("beforeEnd", 2, beforeEndCountA.get());
|
||||||
|
assertEquals("rollback", 2, rollbackCountA.get());
|
||||||
|
}
|
||||||
|
}
|
|
@ -288,7 +288,7 @@ public class FailoverConsumerOutstandingCommitTest {
|
||||||
Message msg = testConsumer.receive(5000);
|
Message msg = testConsumer.receive(5000);
|
||||||
assertNotNull(msg);
|
assertNotNull(msg);
|
||||||
|
|
||||||
// restart with out standing delivered message
|
// restart with outstanding delivered message
|
||||||
broker.stop();
|
broker.stop();
|
||||||
broker.waitUntilStopped();
|
broker.waitUntilStopped();
|
||||||
broker = createBroker(false);
|
broker = createBroker(false);
|
||||||
|
|
|
@ -16,9 +16,11 @@
|
||||||
*/
|
*/
|
||||||
package org.apache.activemq.transport.failover;
|
package org.apache.activemq.transport.failover;
|
||||||
|
|
||||||
|
import static org.junit.Assert.assertEquals;
|
||||||
import static org.junit.Assert.assertNotNull;
|
import static org.junit.Assert.assertNotNull;
|
||||||
import static org.junit.Assert.assertNull;
|
import static org.junit.Assert.assertNull;
|
||||||
import static org.junit.Assert.assertTrue;
|
import static org.junit.Assert.assertTrue;
|
||||||
|
import static org.junit.Assert.fail;
|
||||||
|
|
||||||
import java.io.File;
|
import java.io.File;
|
||||||
import java.io.IOException;
|
import java.io.IOException;
|
||||||
|
@ -291,8 +293,8 @@ public class FailoverTransactionTest {
|
||||||
|
|
||||||
@Test
|
@Test
|
||||||
public void testFailoverConsumerAckLost() throws Exception {
|
public void testFailoverConsumerAckLost() throws Exception {
|
||||||
// as failure depends on hash order, do a few times
|
// as failure depends on hash order of state tracker recovery, do a few times
|
||||||
for (int i=0; i<4; i++) {
|
for (int i=0; i<3; i++) {
|
||||||
try {
|
try {
|
||||||
doTestFailoverConsumerAckLost(i);
|
doTestFailoverConsumerAckLost(i);
|
||||||
} finally {
|
} finally {
|
||||||
|
@ -482,14 +484,14 @@ public class FailoverTransactionTest {
|
||||||
|
|
||||||
broker.stop();
|
broker.stop();
|
||||||
broker = createBroker(false);
|
broker = createBroker(false);
|
||||||
// use empty jdbc store so that default wait for redeliveries will timeout after failover
|
// use empty jdbc store so that default wait(0) for redeliveries will timeout after failover
|
||||||
setPersistenceAdapter(1);
|
setPersistenceAdapter(1);
|
||||||
broker.start();
|
broker.start();
|
||||||
|
|
||||||
try {
|
try {
|
||||||
consumerSession.commit();
|
consumerSession.commit();
|
||||||
} catch (JMSException expectedRolledback) {
|
fail("expected transaciton rolledback ex");
|
||||||
assertTrue(expectedRolledback instanceof TransactionRolledBackException);
|
} catch (TransactionRolledBackException expected) {
|
||||||
}
|
}
|
||||||
|
|
||||||
broker.stop();
|
broker.stop();
|
||||||
|
@ -550,6 +552,65 @@ public class FailoverTransactionTest {
|
||||||
connection.close();
|
connection.close();
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
||||||
|
@Test
|
||||||
|
public void testPoisonOnDeliveryWhilePending() throws Exception {
|
||||||
|
LOG.info("testWaitForMissingRedeliveries()");
|
||||||
|
broker = createBroker(true);
|
||||||
|
broker.start();
|
||||||
|
ActiveMQConnectionFactory cf = new ActiveMQConnectionFactory("failover:(" + url + ")?jms.consumerFailoverRedeliveryWaitPeriod=10000");
|
||||||
|
Connection connection = cf.createConnection();
|
||||||
|
connection.start();
|
||||||
|
final Session producerSession = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
|
||||||
|
final Queue destination = producerSession.createQueue(QUEUE_NAME + "?consumer.prefetchSize=0");
|
||||||
|
final Session consumerSession = connection.createSession(true, Session.SESSION_TRANSACTED);
|
||||||
|
MessageConsumer consumer = consumerSession.createConsumer(destination);
|
||||||
|
|
||||||
|
produceMessage(producerSession, destination);
|
||||||
|
Message msg = consumer.receive(20000);
|
||||||
|
if (msg == null) {
|
||||||
|
AutoFailTestSupport.dumpAllThreads("missing-");
|
||||||
|
}
|
||||||
|
assertNotNull("got message just produced", msg);
|
||||||
|
|
||||||
|
broker.stop();
|
||||||
|
broker = createBroker(false);
|
||||||
|
broker.start();
|
||||||
|
|
||||||
|
final CountDownLatch commitDone = new CountDownLatch(1);
|
||||||
|
|
||||||
|
|
||||||
|
// with prefetch=0, it will not get redelivered as there will not be another receive
|
||||||
|
// for this consumer. so it will block till it timeout with an exception
|
||||||
|
// will block pending re-deliveries
|
||||||
|
Executors.newSingleThreadExecutor().execute(new Runnable() {
|
||||||
|
public void run() {
|
||||||
|
LOG.info("doing async commit...");
|
||||||
|
try {
|
||||||
|
consumerSession.commit();
|
||||||
|
} catch (JMSException ignored) {
|
||||||
|
commitDone.countDown();
|
||||||
|
}
|
||||||
|
}
|
||||||
|
});
|
||||||
|
|
||||||
|
// pull the pending message to this consumer where it will be poison as it is a duplicate without a tx
|
||||||
|
MessageConsumer consumer2 = consumerSession.createConsumer(consumerSession.createQueue(QUEUE_NAME + "?consumer.prefetchSize=1"));
|
||||||
|
assertNull("consumer2 not get a message while pending to 1", consumer2.receive(2000));
|
||||||
|
|
||||||
|
assertTrue("commit completed with ex", commitDone.await(15, TimeUnit.SECONDS));
|
||||||
|
assertNull("consumer should not get rolledback and non redelivered message", consumer.receive(5000));
|
||||||
|
|
||||||
|
// message should be in dlq
|
||||||
|
MessageConsumer dlqConsumer = consumerSession.createConsumer(consumerSession.createQueue("ActiveMQ.DLQ"));
|
||||||
|
TextMessage dlqMessage = (TextMessage) dlqConsumer.receive(5000);
|
||||||
|
assertNotNull("found message in dlq", dlqMessage);
|
||||||
|
assertEquals("text matches", "Test message", dlqMessage.getText());
|
||||||
|
consumerSession.commit();
|
||||||
|
|
||||||
|
connection.close();
|
||||||
|
}
|
||||||
|
|
||||||
private void produceMessage(final Session producerSession, Queue destination)
|
private void produceMessage(final Session producerSession, Queue destination)
|
||||||
throws JMSException {
|
throws JMSException {
|
||||||
MessageProducer producer = producerSession.createProducer(destination);
|
MessageProducer producer = producerSession.createProducer(destination);
|
||||||
|
|
Loading…
Reference in New Issue