mirror of https://github.com/apache/activemq.git
Add support for returning some more meaningful error codes.
This commit is contained in:
parent
1ad0117932
commit
490436c136
|
@ -21,6 +21,7 @@ import static org.apache.activemq.transport.amqp.AmqpSupport.toLong;
|
||||||
import java.io.IOException;
|
import java.io.IOException;
|
||||||
|
|
||||||
import javax.jms.Destination;
|
import javax.jms.Destination;
|
||||||
|
import javax.jms.ResourceAllocationException;
|
||||||
|
|
||||||
import org.apache.activemq.command.ActiveMQDestination;
|
import org.apache.activemq.command.ActiveMQDestination;
|
||||||
import org.apache.activemq.command.ActiveMQMessage;
|
import org.apache.activemq.command.ActiveMQMessage;
|
||||||
|
@ -45,6 +46,7 @@ import org.apache.qpid.proton.amqp.Symbol;
|
||||||
import org.apache.qpid.proton.amqp.messaging.Accepted;
|
import org.apache.qpid.proton.amqp.messaging.Accepted;
|
||||||
import org.apache.qpid.proton.amqp.messaging.Rejected;
|
import org.apache.qpid.proton.amqp.messaging.Rejected;
|
||||||
import org.apache.qpid.proton.amqp.transaction.TransactionalState;
|
import org.apache.qpid.proton.amqp.transaction.TransactionalState;
|
||||||
|
import org.apache.qpid.proton.amqp.transport.AmqpError;
|
||||||
import org.apache.qpid.proton.amqp.transport.DeliveryState;
|
import org.apache.qpid.proton.amqp.transport.DeliveryState;
|
||||||
import org.apache.qpid.proton.amqp.transport.ErrorCondition;
|
import org.apache.qpid.proton.amqp.transport.ErrorCondition;
|
||||||
import org.apache.qpid.proton.engine.Delivery;
|
import org.apache.qpid.proton.engine.Delivery;
|
||||||
|
@ -219,11 +221,19 @@ public class AmqpReceiver extends AmqpAbstractReceiver {
|
||||||
@Override
|
@Override
|
||||||
public void onResponse(AmqpProtocolConverter converter, Response response) throws IOException {
|
public void onResponse(AmqpProtocolConverter converter, Response response) throws IOException {
|
||||||
if (response.isException()) {
|
if (response.isException()) {
|
||||||
ExceptionResponse er = (ExceptionResponse) response;
|
ExceptionResponse error = (ExceptionResponse) response;
|
||||||
Rejected rejected = new Rejected();
|
Rejected rejected = new Rejected();
|
||||||
ErrorCondition condition = new ErrorCondition();
|
ErrorCondition condition = new ErrorCondition();
|
||||||
|
|
||||||
|
if (error.getException() instanceof SecurityException) {
|
||||||
|
condition.setCondition(AmqpError.UNAUTHORIZED_ACCESS);
|
||||||
|
} else if (error.getException() instanceof ResourceAllocationException) {
|
||||||
|
condition.setCondition(AmqpError.RESOURCE_LIMIT_EXCEEDED);
|
||||||
|
} else {
|
||||||
condition.setCondition(Symbol.valueOf("failed"));
|
condition.setCondition(Symbol.valueOf("failed"));
|
||||||
condition.setDescription(er.getException().getMessage());
|
}
|
||||||
|
|
||||||
|
condition.setDescription(error.getException().getMessage());
|
||||||
rejected.setError(condition);
|
rejected.setError(condition);
|
||||||
delivery.disposition(rejected);
|
delivery.disposition(rejected);
|
||||||
} else {
|
} else {
|
||||||
|
|
|
@ -0,0 +1,194 @@
|
||||||
|
/**
|
||||||
|
* 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.amqp;
|
||||||
|
|
||||||
|
import static org.junit.Assert.assertTrue;
|
||||||
|
|
||||||
|
import java.util.concurrent.atomic.AtomicBoolean;
|
||||||
|
import java.util.concurrent.atomic.AtomicInteger;
|
||||||
|
|
||||||
|
import javax.jms.Connection;
|
||||||
|
import javax.jms.ExceptionListener;
|
||||||
|
import javax.jms.JMSException;
|
||||||
|
import javax.jms.MessageConsumer;
|
||||||
|
import javax.jms.MessageProducer;
|
||||||
|
import javax.jms.Queue;
|
||||||
|
import javax.jms.Session;
|
||||||
|
import javax.jms.TextMessage;
|
||||||
|
|
||||||
|
import org.apache.activemq.broker.BrokerService;
|
||||||
|
import org.apache.activemq.broker.region.policy.PolicyEntry;
|
||||||
|
import org.apache.activemq.broker.region.policy.PolicyMap;
|
||||||
|
import org.apache.activemq.broker.region.policy.VMPendingQueueMessageStoragePolicy;
|
||||||
|
import org.apache.activemq.broker.region.policy.VMPendingSubscriberMessageStoragePolicy;
|
||||||
|
import org.apache.qpid.jms.JmsConnection;
|
||||||
|
import org.junit.Rule;
|
||||||
|
import org.junit.Test;
|
||||||
|
import org.junit.rules.TestName;
|
||||||
|
|
||||||
|
public class JMSClientProducerFlowSendFailIfNoSpace extends JMSClientTestSupport {
|
||||||
|
|
||||||
|
@Rule
|
||||||
|
public TestName name = new TestName();
|
||||||
|
|
||||||
|
// used to test sendFailIfNoSpace on SystemUsage
|
||||||
|
protected final AtomicBoolean gotResourceException = new AtomicBoolean(false);
|
||||||
|
|
||||||
|
@Override
|
||||||
|
protected void performAdditionalConfiguration(BrokerService brokerService) {
|
||||||
|
|
||||||
|
// Setup a destination policy where it takes only 1 message at a time.
|
||||||
|
PolicyMap policyMap = new PolicyMap();
|
||||||
|
PolicyEntry policy = new PolicyEntry();
|
||||||
|
policy.setMemoryLimit(1);
|
||||||
|
policy.setPendingSubscriberPolicy(new VMPendingSubscriberMessageStoragePolicy());
|
||||||
|
policy.setPendingQueuePolicy(new VMPendingQueueMessageStoragePolicy());
|
||||||
|
policy.setProducerFlowControl(true);
|
||||||
|
policyMap.setDefaultEntry(policy);
|
||||||
|
brokerService.setDestinationPolicy(policyMap);
|
||||||
|
|
||||||
|
brokerService.getSystemUsage().setSendFailIfNoSpace(true);
|
||||||
|
}
|
||||||
|
|
||||||
|
@Test(timeout = 60000)
|
||||||
|
public void testPubisherRecoverAfterBlock() throws Exception {
|
||||||
|
connection = createConnection();
|
||||||
|
|
||||||
|
final Session session = connection.createSession(false, Session.CLIENT_ACKNOWLEDGE);
|
||||||
|
final Queue queueA = session.createQueue(name.getMethodName());
|
||||||
|
final MessageProducer producer = session.createProducer(queueA);
|
||||||
|
|
||||||
|
final AtomicBoolean keepGoing = new AtomicBoolean(true);
|
||||||
|
|
||||||
|
Thread thread = new Thread("Filler") {
|
||||||
|
@Override
|
||||||
|
public void run() {
|
||||||
|
while (keepGoing.get()) {
|
||||||
|
try {
|
||||||
|
producer.send(session.createTextMessage("Test message"));
|
||||||
|
if (gotResourceException.get()) {
|
||||||
|
// do not flood the broker with requests when full as we are
|
||||||
|
// sending async and they will be limited by the network buffers
|
||||||
|
Thread.sleep(200);
|
||||||
|
}
|
||||||
|
} catch (Exception e) {
|
||||||
|
// with async send, there will be no exceptions
|
||||||
|
LOG.info("Caught excepted exception: {}", e.getMessage());
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
};
|
||||||
|
thread.start();
|
||||||
|
waitForBlockedOrResourceLimit(new AtomicBoolean(false));
|
||||||
|
|
||||||
|
// resourceException on second message, resumption if we
|
||||||
|
// can receive 10
|
||||||
|
MessageConsumer consumer = session.createConsumer(queueA);
|
||||||
|
TextMessage msg;
|
||||||
|
for (int idx = 0; idx < 10; ++idx) {
|
||||||
|
msg = (TextMessage) consumer.receive(500);
|
||||||
|
if (msg != null) {
|
||||||
|
msg.acknowledge();
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
keepGoing.set(false);
|
||||||
|
}
|
||||||
|
|
||||||
|
@Test(timeout = 60000)
|
||||||
|
public void testPubisherRecoverAfterBlockWithSyncSend() throws Exception {
|
||||||
|
connection = createConnection(false, false);
|
||||||
|
|
||||||
|
final Session session = connection.createSession(false, Session.CLIENT_ACKNOWLEDGE);
|
||||||
|
final Queue queueA = session.createQueue(name.getMethodName());
|
||||||
|
final MessageProducer producer = session.createProducer(queueA);
|
||||||
|
|
||||||
|
final AtomicBoolean keepGoing = new AtomicBoolean(true);
|
||||||
|
final AtomicInteger exceptionCount = new AtomicInteger(0);
|
||||||
|
Thread thread = new Thread("Filler") {
|
||||||
|
@Override
|
||||||
|
public void run() {
|
||||||
|
while (keepGoing.get()) {
|
||||||
|
try {
|
||||||
|
producer.send(session.createTextMessage("Test message"));
|
||||||
|
} catch (JMSException jmsEx) {
|
||||||
|
LOG.debug("Client caught error: {} {}", jmsEx.getClass().getName(), jmsEx.getMessage());
|
||||||
|
gotResourceException.set(true);
|
||||||
|
exceptionCount.incrementAndGet();
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
};
|
||||||
|
thread.start();
|
||||||
|
waitForBlockedOrResourceLimit();
|
||||||
|
|
||||||
|
// resourceException on second message, resumption if we
|
||||||
|
// can receive 10
|
||||||
|
MessageConsumer consumer = session.createConsumer(queueA);
|
||||||
|
TextMessage msg;
|
||||||
|
for (int idx = 0; idx < 10; ++idx) {
|
||||||
|
msg = (TextMessage) consumer.receive(500);
|
||||||
|
if (msg != null) {
|
||||||
|
msg.acknowledge();
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
assertTrue("we were blocked at least 5 times", 5 < exceptionCount.get());
|
||||||
|
keepGoing.set(false);
|
||||||
|
}
|
||||||
|
|
||||||
|
protected void waitForBlockedOrResourceLimit() throws InterruptedException {
|
||||||
|
waitForBlockedOrResourceLimit(new AtomicBoolean(false));
|
||||||
|
}
|
||||||
|
|
||||||
|
protected void waitForBlockedOrResourceLimit(final AtomicBoolean done) throws InterruptedException {
|
||||||
|
while (true) {
|
||||||
|
Thread.sleep(100);
|
||||||
|
// the producer is blocked once the done flag stays true or there is a resource exception
|
||||||
|
if (done.get() || gotResourceException.get()) {
|
||||||
|
break;
|
||||||
|
}
|
||||||
|
done.set(true);
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
protected Connection createConnection() throws JMSException {
|
||||||
|
return createConnection(true, true);
|
||||||
|
}
|
||||||
|
|
||||||
|
protected Connection createConnection(boolean async, boolean exceptionListener) throws JMSException {
|
||||||
|
connection = super.createConnection();
|
||||||
|
|
||||||
|
JmsConnection jmsConnection = (JmsConnection) connection;
|
||||||
|
jmsConnection.setForceAsyncSend(async);
|
||||||
|
|
||||||
|
if (exceptionListener) {
|
||||||
|
connection.setExceptionListener(new ExceptionListener() {
|
||||||
|
@Override
|
||||||
|
public void onException(JMSException jmsEx) {
|
||||||
|
LOG.debug("Client caught error: {} {}", jmsEx.getClass().getName(), jmsEx.getMessage());
|
||||||
|
gotResourceException.set(true);
|
||||||
|
}
|
||||||
|
});
|
||||||
|
}
|
||||||
|
|
||||||
|
connection.start();
|
||||||
|
|
||||||
|
return connection;
|
||||||
|
}
|
||||||
|
}
|
|
@ -156,6 +156,34 @@ public class JMSClientSimpleAuthTest {
|
||||||
connection.close();
|
connection.close();
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@Test(timeout = 30000)
|
||||||
|
public void testProducerNotAuthorized() throws Exception {
|
||||||
|
connection = JMSClientContext.INSTANCE.createConnection(amqpURI, "guest", "guestPassword");
|
||||||
|
Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
|
||||||
|
Queue queue = session.createQueue("USERS.txQueue");
|
||||||
|
try {
|
||||||
|
session.createProducer(queue);
|
||||||
|
fail("Should not be able to produce here.");
|
||||||
|
} catch (JMSSecurityException jmsSE) {
|
||||||
|
LOG.info("Caught expected exception");
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
@Test(timeout = 30000)
|
||||||
|
public void testAnonymousProducerNotAuthorized() throws Exception {
|
||||||
|
connection = JMSClientContext.INSTANCE.createConnection(amqpURI, "guest", "guestPassword");
|
||||||
|
Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
|
||||||
|
Queue queue = session.createQueue("USERS.txQueue");
|
||||||
|
MessageProducer producer = session.createProducer(null);
|
||||||
|
|
||||||
|
try {
|
||||||
|
producer.send(queue, session.createTextMessage());
|
||||||
|
fail("Should not be able to produce here.");
|
||||||
|
} catch (JMSSecurityException jmsSE) {
|
||||||
|
LOG.info("Caught expected exception");
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
@Test(timeout = 30000)
|
@Test(timeout = 30000)
|
||||||
public void testCreateTemporaryQueueNotAuthorized() throws JMSException {
|
public void testCreateTemporaryQueueNotAuthorized() throws JMSException {
|
||||||
connection = JMSClientContext.INSTANCE.createConnection(amqpURI, "user", "userPassword");
|
connection = JMSClientContext.INSTANCE.createConnection(amqpURI, "user", "userPassword");
|
||||||
|
|
Loading…
Reference in New Issue