Return-Path: X-Original-To: apmail-activemq-commits-archive@www.apache.org Delivered-To: apmail-activemq-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 09E7C109C5 for ; Tue, 18 Nov 2014 09:24:05 +0000 (UTC) Received: (qmail 95927 invoked by uid 500); 18 Nov 2014 09:24:04 -0000 Delivered-To: apmail-activemq-commits-archive@activemq.apache.org Received: (qmail 95823 invoked by uid 500); 18 Nov 2014 09:24:04 -0000 Mailing-List: contact commits-help@activemq.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@activemq.apache.org Delivered-To: mailing list commits@activemq.apache.org Received: (qmail 95026 invoked by uid 99); 18 Nov 2014 09:24:04 -0000 Received: from tyr.zones.apache.org (HELO tyr.zones.apache.org) (140.211.11.114) by apache.org (qpsmtpd/0.29) with ESMTP; Tue, 18 Nov 2014 09:24:04 +0000 Received: by tyr.zones.apache.org (Postfix, from userid 65534) id 3571999F2AD; Tue, 18 Nov 2014 09:24:04 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: martyntaylor@apache.org To: commits@activemq.apache.org Date: Tue, 18 Nov 2014 09:24:16 -0000 Message-Id: In-Reply-To: <28e950c6ff574ae88ec8b1ef37d6d0d6@git.apache.org> References: <28e950c6ff574ae88ec8b1ef37d6d0d6@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [14/20] activemq-6 git commit: ACTIVEMQ6-3 Renaming Exception classes and fixing native compilation http://git-wip-us.apache.org/repos/asf/activemq-6/blob/1bf2e41f/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryImpl.java ---------------------------------------------------------------------- diff --git a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryImpl.java b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryImpl.java index 7f67773..432234f 100644 --- a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryImpl.java +++ b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryImpl.java @@ -28,10 +28,10 @@ import java.util.concurrent.TimeUnit; import java.util.concurrent.locks.Lock; import java.util.concurrent.locks.ReentrantLock; -import org.apache.activemq.api.core.HornetQBuffer; -import org.apache.activemq.api.core.HornetQException; -import org.apache.activemq.api.core.HornetQInterruptedException; -import org.apache.activemq.api.core.HornetQNotConnectedException; +import org.apache.activemq.api.core.ActiveMQBuffer; +import org.apache.activemq.api.core.ActiveMQException; +import org.apache.activemq.api.core.ActiveMQInterruptedException; +import org.apache.activemq.api.core.ActiveMQNotConnectedException; import org.apache.activemq.api.core.Interceptor; import org.apache.activemq.api.core.Pair; import org.apache.activemq.api.core.TransportConfiguration; @@ -237,7 +237,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C return newFailoverLock; } - public void connect(final int initialConnectAttempts, final boolean failoverOnInitialConnection) throws HornetQException + public void connect(final int initialConnectAttempts, final boolean failoverOnInitialConnection) throws ActiveMQException { // Get the connection getConnectionWithRetry(initialConnectAttempts); @@ -250,7 +250,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C { msg.append(" and backup configuration ").append(backupConfig); } - throw new HornetQNotConnectedException(msg.toString()); + throw new ActiveMQNotConnectedException(msg.toString()); } } @@ -310,7 +310,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C final boolean autoCommitSends, final boolean autoCommitAcks, final boolean preAcknowledge, - final int ackBatchSize) throws HornetQException + final int ackBatchSize) throws ActiveMQException { return createSessionInternal(username, password, @@ -323,7 +323,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C public ClientSession createSession(final boolean autoCommitSends, final boolean autoCommitAcks, - final int ackBatchSize) throws HornetQException + final int ackBatchSize) throws ActiveMQException { return createSessionInternal(null, null, @@ -334,7 +334,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C ackBatchSize); } - public ClientSession createXASession() throws HornetQException + public ClientSession createXASession() throws ActiveMQException { return createSessionInternal(null, null, @@ -345,7 +345,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C serverLocator.getAckBatchSize()); } - public ClientSession createTransactedSession() throws HornetQException + public ClientSession createTransactedSession() throws ActiveMQException { return createSessionInternal(null, null, @@ -356,7 +356,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C serverLocator.getAckBatchSize()); } - public ClientSession createSession() throws HornetQException + public ClientSession createSession() throws ActiveMQException { return createSessionInternal(null, null, @@ -367,7 +367,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C serverLocator.getAckBatchSize()); } - public ClientSession createSession(final boolean autoCommitSends, final boolean autoCommitAcks) throws HornetQException + public ClientSession createSession(final boolean autoCommitSends, final boolean autoCommitAcks) throws ActiveMQException { return createSessionInternal(null, null, @@ -378,7 +378,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C serverLocator.getAckBatchSize()); } - public ClientSession createSession(final boolean xa, final boolean autoCommitSends, final boolean autoCommitAcks) throws HornetQException + public ClientSession createSession(final boolean xa, final boolean autoCommitSends, final boolean autoCommitAcks) throws ActiveMQException { return createSessionInternal(null, null, @@ -392,7 +392,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C public ClientSession createSession(final boolean xa, final boolean autoCommitSends, final boolean autoCommitAcks, - final boolean preAcknowledge) throws HornetQException + final boolean preAcknowledge) throws ActiveMQException { return createSessionInternal(null, null, @@ -413,7 +413,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C { // The exception has to be created in the same thread where it's being called // as to avoid a different stack trace cause - final HornetQException ex = HornetQClientMessageBundle.BUNDLE.channelDisconnected(); + final ActiveMQException ex = HornetQClientMessageBundle.BUNDLE.channelDisconnected(); // It has to use the same executor as the disconnect message is being sent through @@ -427,7 +427,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C } - public void connectionException(final Object connectionID, final HornetQException me) + public void connectionException(final Object connectionID, final ActiveMQException me) { handleConnectionFailure(connectionID, me); } @@ -559,18 +559,18 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C stopPingingAfterOne = true; } - private void handleConnectionFailure(final Object connectionID, final HornetQException me) + private void handleConnectionFailure(final Object connectionID, final ActiveMQException me) { handleConnectionFailure(connectionID, me, null); } - private void handleConnectionFailure(final Object connectionID, final HornetQException me, String scaleDownTargetNodeID) + private void handleConnectionFailure(final Object connectionID, final ActiveMQException me, String scaleDownTargetNodeID) { try { failoverOrReconnect(connectionID, me, scaleDownTargetNodeID); } - catch (HornetQInterruptedException e1) + catch (ActiveMQInterruptedException e1) { // this is just a debug, since an interrupt is an expected event (in case of a shutdown) HornetQClientLogger.LOGGER.debug(e1.getMessage(), e1); @@ -582,7 +582,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C * @param connectionID * @param me */ - private void failoverOrReconnect(final Object connectionID, final HornetQException me, String scaleDownTargetNodeID) + private void failoverOrReconnect(final Object connectionID, final ActiveMQException me, String scaleDownTargetNodeID) { Set sessionsToClose = null; if (!clientProtocolManager.isAlive()) @@ -630,7 +630,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C // locked. // While this is still locked it must then get the channel1 lock // It can then release the failoverLock - // It should catch HornetQException.INTERRUPTED in the call to channel.sendBlocking + // It should catch ActiveMQException.INTERRUPTED in the call to channel.sendBlocking // It should then return its connections, with channel 1 lock still held // It can then release the channel 1 lock, and retry (which will cause locking on // failoverLock @@ -740,7 +740,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C final boolean autoCommitSends, final boolean autoCommitAcks, final boolean preAcknowledge, - final int ackBatchSize) throws HornetQException + final int ackBatchSize) throws ActiveMQException { String name = UUIDGenerator.getInstance().generateStringUUID(); @@ -795,13 +795,13 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C } - private void callSessionFailureListeners(final HornetQException me, final boolean afterReconnect, + private void callSessionFailureListeners(final ActiveMQException me, final boolean afterReconnect, final boolean failedOver) { callSessionFailureListeners(me, afterReconnect, failedOver, null); } - private void callSessionFailureListeners(final HornetQException me, final boolean afterReconnect, + private void callSessionFailureListeners(final ActiveMQException me, final boolean afterReconnect, final boolean failedOver, final String scaleDownTargetNodeID) { final List listenersClone = new ArrayList(listeners); @@ -852,7 +852,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C /* * Re-attach sessions all pre-existing sessions to the new remoting connection */ - private void reconnectSessions(final RemotingConnection oldConnection, final int reconnectAttempts, final HornetQException cause) + private void reconnectSessions(final RemotingConnection oldConnection, final int reconnectAttempts, final ActiveMQException cause) { HashSet sessionsToFailover; synchronized (sessions) @@ -967,7 +967,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C } catch (InterruptedException ignore) { - throw new HornetQInterruptedException(createTrace); + throw new ActiveMQInterruptedException(createTrace); } // Exponential back-off @@ -1065,7 +1065,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C connection = null; } } - catch (HornetQException e) + catch (ActiveMQException e) { if (connection != null) { @@ -1382,7 +1382,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C private class DelegatingBufferHandler implements BufferHandler { - public void bufferReceived(final Object connectionID, final HornetQBuffer buffer) + public void bufferReceived(final Object connectionID, final ActiveMQBuffer buffer) { RemotingConnection theConn = connection; @@ -1407,13 +1407,13 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C } @Override - public void connectionFailed(final HornetQException me, final boolean failedOver) + public void connectionFailed(final ActiveMQException me, final boolean failedOver) { connectionFailed(me, failedOver, null); } @Override - public void connectionFailed(final HornetQException me, final boolean failedOver, String scaleDownTargetNodeID) + public void connectionFailed(final ActiveMQException me, final boolean failedOver, String scaleDownTargetNodeID) { handleConnectionFailure(connectionID, me, scaleDownTargetNodeID); } @@ -1473,7 +1473,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C // We use a different thread to send the fail // but the exception has to be created here to preserve the stack trace - final HornetQException me = HornetQClientMessageBundle.BUNDLE.connectionTimedOut(connection.getTransportConnection()); + final ActiveMQException me = HornetQClientMessageBundle.BUNDLE.connectionTimedOut(connection.getTransportConnection()); cancelled = true; @@ -1550,7 +1550,7 @@ public class ClientSessionFactoryImpl implements ClientSessionFactoryInternal, C final boolean xa, final boolean autoCommitSends, final boolean autoCommitAcks, - final boolean preAcknowledge) throws HornetQException + final boolean preAcknowledge) throws ActiveMQException { synchronized (createSessionLock) { http://git-wip-us.apache.org/repos/asf/activemq-6/blob/1bf2e41f/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryInternal.java ---------------------------------------------------------------------- diff --git a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryInternal.java b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryInternal.java index 64b4194..242ad11 100644 --- a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryInternal.java +++ b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionFactoryInternal.java @@ -14,7 +14,7 @@ package org.apache.activemq.core.client.impl; import java.util.concurrent.locks.Lock; -import org.apache.activemq.api.core.HornetQException; +import org.apache.activemq.api.core.ActiveMQException; import org.apache.activemq.api.core.TransportConfiguration; import org.apache.activemq.api.core.client.ClientSessionFactory; import org.apache.activemq.api.core.client.SessionFailureListener; @@ -47,7 +47,7 @@ public interface ClientSessionFactoryInternal extends ClientSessionFactory void removeSession(final ClientSessionInternal session, boolean failingOver); - void connect(int reconnectAttempts, boolean failoverOnInitialConnection) throws HornetQException; + void connect(int reconnectAttempts, boolean failoverOnInitialConnection) throws ActiveMQException; void setBackupConnector(TransportConfiguration live, TransportConfiguration backUp); http://git-wip-us.apache.org/repos/asf/activemq-6/blob/1bf2e41f/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionImpl.java ---------------------------------------------------------------------- diff --git a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionImpl.java b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionImpl.java index 173df2d..8b95874 100644 --- a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionImpl.java +++ b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionImpl.java @@ -23,10 +23,10 @@ import java.util.Set; import java.util.concurrent.Executor; import java.util.concurrent.atomic.AtomicInteger; -import org.apache.activemq.api.core.HornetQBuffer; -import org.apache.activemq.api.core.HornetQBuffers; -import org.apache.activemq.api.core.HornetQException; -import org.apache.activemq.api.core.HornetQExceptionType; +import org.apache.activemq.api.core.ActiveMQBuffer; +import org.apache.activemq.api.core.ActiveMQBuffers; +import org.apache.activemq.api.core.ActiveMQException; +import org.apache.activemq.api.core.ActiveMQExceptionType; import org.apache.activemq.api.core.Message; import org.apache.activemq.api.core.SimpleString; import org.apache.activemq.api.core.client.ClientConsumer; @@ -171,7 +171,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi final String groupID, final SessionContext sessionContext, final Executor executor, - final Executor flowControlExecutor) throws HornetQException + final Executor flowControlExecutor) throws ActiveMQException { this.sessionFactory = sessionFactory; @@ -233,24 +233,24 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi // ClientSession implementation // ----------------------------------------------------------------- - public void createQueue(final SimpleString address, final SimpleString queueName) throws HornetQException + public void createQueue(final SimpleString address, final SimpleString queueName) throws ActiveMQException { internalCreateQueue(address, queueName, null, false, false); } - public void createQueue(final SimpleString address, final SimpleString queueName, final boolean durable) throws HornetQException + public void createQueue(final SimpleString address, final SimpleString queueName, final boolean durable) throws ActiveMQException { internalCreateQueue(address, queueName, null, durable, false); } - public void createQueue(final String address, final String queueName, final boolean durable) throws HornetQException + public void createQueue(final String address, final String queueName, final boolean durable) throws ActiveMQException { createQueue(SimpleString.toSimpleString(address), SimpleString.toSimpleString(queueName), durable); } public void createSharedQueue(SimpleString address, SimpleString queueName, - boolean durable) throws HornetQException + boolean durable) throws ActiveMQException { createSharedQueue(address, queueName, null, durable); } @@ -258,7 +258,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi public void createSharedQueue(SimpleString address, SimpleString queueName, SimpleString filterString, - boolean durable) throws HornetQException + boolean durable) throws ActiveMQException { checkClosed(); @@ -280,7 +280,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi public void createQueue(final SimpleString address, final SimpleString queueName, final SimpleString filterString, - final boolean durable) throws HornetQException + final boolean durable) throws ActiveMQException { internalCreateQueue(address, queueName, filterString, durable, false); } @@ -288,17 +288,17 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi public void createQueue(final String address, final String queueName, final String filterString, - final boolean durable) throws HornetQException + final boolean durable) throws ActiveMQException { createQueue(SimpleString.toSimpleString(address), SimpleString.toSimpleString(queueName), SimpleString.toSimpleString(filterString), durable); } - public void createTemporaryQueue(final SimpleString address, final SimpleString queueName) throws HornetQException + public void createTemporaryQueue(final SimpleString address, final SimpleString queueName) throws ActiveMQException { internalCreateQueue(address, queueName, null, false, true); } - public void createTemporaryQueue(final String address, final String queueName) throws HornetQException + public void createTemporaryQueue(final String address, final String queueName) throws ActiveMQException { internalCreateQueue(SimpleString.toSimpleString(address), SimpleString.toSimpleString(queueName), @@ -307,12 +307,12 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi true); } - public void createTemporaryQueue(final SimpleString address, final SimpleString queueName, final SimpleString filter) throws HornetQException + public void createTemporaryQueue(final SimpleString address, final SimpleString queueName, final SimpleString filter) throws ActiveMQException { internalCreateQueue(address, queueName, filter, false, true); } - public void createTemporaryQueue(final String address, final String queueName, final String filter) throws HornetQException + public void createTemporaryQueue(final String address, final String queueName, final String filter) throws ActiveMQException { internalCreateQueue(SimpleString.toSimpleString(address), SimpleString.toSimpleString(queueName), @@ -321,7 +321,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi true); } - public void deleteQueue(final SimpleString queueName) throws HornetQException + public void deleteQueue(final SimpleString queueName) throws ActiveMQException { checkClosed(); @@ -336,12 +336,12 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - public void deleteQueue(final String queueName) throws HornetQException + public void deleteQueue(final String queueName) throws ActiveMQException { deleteQueue(SimpleString.toSimpleString(queueName)); } - public QueueQuery queueQuery(final SimpleString queueName) throws HornetQException + public QueueQuery queueQuery(final SimpleString queueName) throws ActiveMQException { checkClosed(); @@ -363,15 +363,15 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi * * @param address * @return - * @throws HornetQException + * @throws org.apache.activemq.api.core.ActiveMQException */ @Deprecated - public BindingQuery bindingQuery(final SimpleString address) throws HornetQException + public BindingQuery bindingQuery(final SimpleString address) throws ActiveMQException { return (BindingQuery) addressQuery(address); } - public AddressQuery addressQuery(final SimpleString address) throws HornetQException + public AddressQuery addressQuery(final SimpleString address) throws ActiveMQException { checkClosed(); @@ -379,51 +379,51 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi return sessionContext.addressQuery(address); } - public ClientConsumer createConsumer(final SimpleString queueName) throws HornetQException + public ClientConsumer createConsumer(final SimpleString queueName) throws ActiveMQException { return createConsumer(queueName, null, false); } - public ClientConsumer createConsumer(final String queueName) throws HornetQException + public ClientConsumer createConsumer(final String queueName) throws ActiveMQException { return createConsumer(SimpleString.toSimpleString(queueName)); } - public ClientConsumer createConsumer(final SimpleString queueName, final SimpleString filterString) throws HornetQException + public ClientConsumer createConsumer(final SimpleString queueName, final SimpleString filterString) throws ActiveMQException { return createConsumer(queueName, filterString, consumerWindowSize, consumerMaxRate, false); } - public void createQueue(final String address, final String queueName) throws HornetQException + public void createQueue(final String address, final String queueName) throws ActiveMQException { createQueue(SimpleString.toSimpleString(address), SimpleString.toSimpleString(queueName)); } - public ClientConsumer createConsumer(final String queueName, final String filterString) throws HornetQException + public ClientConsumer createConsumer(final String queueName, final String filterString) throws ActiveMQException { return createConsumer(SimpleString.toSimpleString(queueName), SimpleString.toSimpleString(filterString)); } public ClientConsumer createConsumer(final SimpleString queueName, final SimpleString filterString, - final boolean browseOnly) throws HornetQException + final boolean browseOnly) throws ActiveMQException { return createConsumer(queueName, filterString, consumerWindowSize, consumerMaxRate, browseOnly); } - public ClientConsumer createConsumer(final SimpleString queueName, final boolean browseOnly) throws HornetQException + public ClientConsumer createConsumer(final SimpleString queueName, final boolean browseOnly) throws ActiveMQException { return createConsumer(queueName, null, consumerWindowSize, consumerMaxRate, browseOnly); } - public ClientConsumer createConsumer(final String queueName, final String filterString, final boolean browseOnly) throws HornetQException + public ClientConsumer createConsumer(final String queueName, final String filterString, final boolean browseOnly) throws ActiveMQException { return createConsumer(SimpleString.toSimpleString(queueName), SimpleString.toSimpleString(filterString), browseOnly); } - public ClientConsumer createConsumer(final String queueName, final boolean browseOnly) throws HornetQException + public ClientConsumer createConsumer(final String queueName, final boolean browseOnly) throws ActiveMQException { return createConsumer(SimpleString.toSimpleString(queueName), null, browseOnly); } @@ -442,7 +442,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi final SimpleString filterString, final int windowSize, final int maxRate, - final boolean browseOnly) throws HornetQException + final boolean browseOnly) throws ActiveMQException { return internalCreateConsumer(queueName, filterString, windowSize, maxRate, browseOnly); } @@ -451,32 +451,32 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi final String filterString, final int windowSize, final int maxRate, - final boolean browseOnly) throws HornetQException + final boolean browseOnly) throws ActiveMQException { return createConsumer(SimpleString.toSimpleString(queueName), SimpleString.toSimpleString(filterString), windowSize, maxRate, browseOnly); } - public ClientProducer createProducer() throws HornetQException + public ClientProducer createProducer() throws ActiveMQException { return createProducer((SimpleString) null); } - public ClientProducer createProducer(final SimpleString address) throws HornetQException + public ClientProducer createProducer(final SimpleString address) throws ActiveMQException { return createProducer(address, producerMaxRate); } - public ClientProducer createProducer(final String address) throws HornetQException + public ClientProducer createProducer(final String address) throws ActiveMQException { return createProducer(SimpleString.toSimpleString(address)); } - public ClientProducer createProducer(final SimpleString address, final int maxRate) throws HornetQException + public ClientProducer createProducer(final SimpleString address, final int maxRate) throws ActiveMQException { return internalCreateProducer(address, maxRate); } - public ClientProducer createProducer(final String address, final int rate) throws HornetQException + public ClientProducer createProducer(final String address, final int rate) throws ActiveMQException { return createProducer(SimpleString.toSimpleString(address), rate); } @@ -486,7 +486,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi return this; } - private void rollbackOnFailover(boolean outcomeKnown) throws HornetQException + private void rollbackOnFailover(boolean outcomeKnown) throws ActiveMQException { rollback(false); @@ -498,7 +498,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi throw HornetQClientMessageBundle.BUNDLE.txOutcomeUnknown(); } - public void commit() throws HornetQException + public void commit() throws ActiveMQException { checkClosed(); @@ -528,9 +528,9 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi { sessionContext.simpleCommit(); } - catch (HornetQException e) + catch (ActiveMQException e) { - if (e.getType() == HornetQExceptionType.UNBLOCKED || rollbackOnly) + if (e.getType() == ActiveMQExceptionType.UNBLOCKED || rollbackOnly) { // The call to commit was unlocked on failover, we therefore rollback the tx, // and throw a transaction rolled back exception instead @@ -558,12 +558,12 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi return rollbackOnly; } - public void rollback() throws HornetQException + public void rollback() throws ActiveMQException { rollback(false); } - public void rollback(final boolean isLastMessageAsDelivered) throws HornetQException + public void rollback(final boolean isLastMessageAsDelivered) throws ActiveMQException { if (HornetQClientLogger.LOGGER.isTraceEnabled()) { @@ -647,7 +647,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi return xa; } - public void resetIfNeeded() throws HornetQException + public void resetIfNeeded() throws ActiveMQException { if (rollbackOnly) { @@ -656,7 +656,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - public ClientSessionImpl start() throws HornetQException + public ClientSessionImpl start() throws ActiveMQException { checkClosed(); @@ -675,12 +675,12 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi return this; } - public void stop() throws HornetQException + public void stop() throws ActiveMQException { stop(true); } - public void stop(final boolean waitForOnMessage) throws HornetQException + public void stop(final boolean waitForOnMessage) throws ActiveMQException { checkClosed(); @@ -762,7 +762,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi /** * Acknowledges all messages received by the consumer so far. */ - public void acknowledge(final ClientConsumer consumer, final Message message) throws HornetQException + public void acknowledge(final ClientConsumer consumer, final Message message) throws ActiveMQException { // if we're pre-acknowledging then we don't need to do anything if (preAcknowledge) @@ -787,7 +787,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - public void individualAcknowledge(final ClientConsumer consumer, final Message message) throws HornetQException + public void individualAcknowledge(final ClientConsumer consumer, final Message message) throws ActiveMQException { // if we're pre-acknowledging then we don't need to do anything if (preAcknowledge) @@ -809,7 +809,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - public void expire(final ClientConsumer consumer, final Message message) throws HornetQException + public void expire(final ClientConsumer consumer, final Message message) throws ActiveMQException { checkClosed(); @@ -836,7 +836,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - public void removeConsumer(final ClientConsumerInternal consumer) throws HornetQException + public void removeConsumer(final ClientConsumerInternal consumer) throws ActiveMQException { synchronized (consumers) { @@ -883,7 +883,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } @Override - public void handleConsumerDisconnect(ConsumerContext context) throws HornetQException + public void handleConsumerDisconnect(ConsumerContext context) throws ActiveMQException { final ClientConsumerInternal consumer = getConsumer(context); @@ -898,7 +898,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi { consumer.close(); } - catch (HornetQException e) + catch (ActiveMQException e) { HornetQClientLogger.LOGGER.unableToCloseConsumer(e); } @@ -907,7 +907,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - public void close() throws HornetQException + public void close() throws ActiveMQException { if (closed) { @@ -942,7 +942,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi doCleanup(false); } - public synchronized void cleanUp(boolean failingOver) throws HornetQException + public synchronized void cleanUp(boolean failingOver) throws ActiveMQException { if (closed) { @@ -972,7 +972,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi // Needs to be synchronized to prevent issues with occurring concurrently with close() - public void handleFailover(final RemotingConnection backupConnection, HornetQException cause) + public void handleFailover(final RemotingConnection backupConnection, ActiveMQException cause) { synchronized (this) { @@ -1089,7 +1089,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } - public void addMetaData(String key, String data) throws HornetQException + public void addMetaData(String key, String data) throws ActiveMQException { synchronized (metadata) { @@ -1099,7 +1099,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi sessionContext.addSessionMetadata(key, data); } - public void addUniqueMetaData(String key, String data) throws HornetQException + public void addUniqueMetaData(String key, String data) throws ActiveMQException { sessionContext.addUniqueMetaData(key, data); } @@ -1425,9 +1425,9 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi { throw xae; } - catch (HornetQException e) + catch (ActiveMQException e) { - if (e.getType() == HornetQExceptionType.UNBLOCKED) + if (e.getType() == ActiveMQExceptionType.UNBLOCKED) { // Unblocked on failover try @@ -1545,9 +1545,9 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi { throw xae; } - catch (HornetQException e) + catch (ActiveMQException e) { - if (e.getType() == HornetQExceptionType.UNBLOCKED) + if (e.getType() == ActiveMQExceptionType.UNBLOCKED) { // Unblocked on failover throw new XAException(XAException.XA_RETRY); @@ -1586,10 +1586,10 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi { throw xae; } - catch (HornetQException e) + catch (ActiveMQException e) { // we can retry this only because we know for sure that no work would have been done - if (e.getType() == HornetQExceptionType.UNBLOCKED) + if (e.getType() == ActiveMQExceptionType.UNBLOCKED) { try { @@ -1624,7 +1624,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi // FailureListener implementation -------------------------------------------- - public void connectionFailed(final HornetQException me, boolean failedOver) + public void connectionFailed(final ActiveMQException me, boolean failedOver) { try { @@ -1636,7 +1636,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - public void connectionFailed(final HornetQException me, boolean failedOver, String scaleDownTargetNodeID) + public void connectionFailed(final ActiveMQException me, boolean failedOver, String scaleDownTargetNodeID) { connectionFailed(me, failedOver); } @@ -1684,13 +1684,13 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi * @param windowSize * @param browseOnly * @return - * @throws HornetQException + * @throws org.apache.activemq.api.core.ActiveMQException */ private ClientConsumer internalCreateConsumer(final SimpleString queueName, final SimpleString filterString, final int windowSize, final int maxRate, - final boolean browseOnly) throws HornetQException + final boolean browseOnly) throws ActiveMQException { checkClosed(); @@ -1712,7 +1712,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi return consumer; } - private ClientProducer internalCreateProducer(final SimpleString address, final int maxRate) throws HornetQException + private ClientProducer internalCreateProducer(final SimpleString address, final int maxRate) throws ActiveMQException { checkClosed(); @@ -1736,7 +1736,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi final SimpleString queueName, final SimpleString filterString, final boolean durable, - final boolean temp) throws HornetQException + final boolean temp) throws ActiveMQException { checkClosed(); @@ -1765,7 +1765,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - private void checkClosed() throws HornetQException + private void checkClosed() throws ActiveMQException { if (closed || inClose) { @@ -1799,7 +1799,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi sessionFactory.removeSession(this, failingOver); } - private void cleanUpChildren() throws HornetQException + private void cleanUpChildren() throws ActiveMQException { Set consumersClone = cloneConsumers(); @@ -1845,7 +1845,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - private void closeChildren() throws HornetQException + private void closeChildren() throws ActiveMQException { Set consumersClone = cloneConsumers(); @@ -1862,7 +1862,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi } } - private void flushAcks() throws HornetQException + private void flushAcks() throws ActiveMQException { for (ClientConsumerInternal consumer : cloneConsumers()) { @@ -1882,7 +1882,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi */ public static Object convert(Xid xid) { - HornetQBuffer buffer = HornetQBuffers.dynamicBuffer(200); + ActiveMQBuffer buffer = ActiveMQBuffers.dynamicBuffer(200); XidCodecSupport.encodeXid(xid, buffer); Object obj = XidCodecSupport.decodeXid(buffer); http://git-wip-us.apache.org/repos/asf/activemq-6/blob/1bf2e41f/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionInternal.java ---------------------------------------------------------------------- diff --git a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionInternal.java b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionInternal.java index 952afd9..7b08ba6 100644 --- a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionInternal.java +++ b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/ClientSessionInternal.java @@ -12,7 +12,7 @@ */ package org.apache.activemq.core.client.impl; -import org.apache.activemq.api.core.HornetQException; +import org.apache.activemq.api.core.ActiveMQException; import org.apache.activemq.api.core.Message; import org.apache.activemq.api.core.SimpleString; import org.apache.activemq.api.core.client.ClientConsumer; @@ -30,9 +30,9 @@ public interface ClientSessionInternal extends ClientSession { String getName(); - void acknowledge(ClientConsumer consumer, Message message) throws HornetQException; + void acknowledge(ClientConsumer consumer, Message message) throws ActiveMQException; - void individualAcknowledge(final ClientConsumer consumer, final Message message) throws HornetQException; + void individualAcknowledge(final ClientConsumer consumer, final Message message) throws ActiveMQException; boolean isCacheLargeMessageClient(); @@ -40,13 +40,13 @@ public interface ClientSessionInternal extends ClientSession boolean isCompressLargeMessages(); - void expire(ClientConsumer consumer, Message message) throws HornetQException; + void expire(ClientConsumer consumer, Message message) throws ActiveMQException; void addConsumer(ClientConsumerInternal consumer); void addProducer(ClientProducerInternal producer); - void removeConsumer(ClientConsumerInternal consumer) throws HornetQException; + void removeConsumer(ClientConsumerInternal consumer) throws ActiveMQException; void removeProducer(ClientProducerInternal producer); @@ -56,15 +56,15 @@ public interface ClientSessionInternal extends ClientSession void handleReceiveContinuation(ConsumerContext consumerID, byte[] chunk, int flowControlSize, boolean isContinues) throws Exception; - void handleConsumerDisconnect(ConsumerContext consumerContext) throws HornetQException; + void handleConsumerDisconnect(ConsumerContext consumerContext) throws ActiveMQException; void preHandleFailover(RemotingConnection connection); - void handleFailover(RemotingConnection backupConnection, HornetQException cause); + void handleFailover(RemotingConnection backupConnection, ActiveMQException cause); RemotingConnection getConnection(); - void cleanUp(boolean failingOver) throws HornetQException; + void cleanUp(boolean failingOver) throws ActiveMQException; void setForceNotSameRM(boolean force); @@ -86,7 +86,7 @@ public interface ClientSessionInternal extends ClientSession void setPacketSize(int packetSize); - void resetIfNeeded() throws HornetQException; + void resetIfNeeded() throws ActiveMQException; /** * This is used internally to control and educate the user http://git-wip-us.apache.org/repos/asf/activemq-6/blob/1bf2e41f/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/CompressedLargeMessageControllerImpl.java ---------------------------------------------------------------------- diff --git a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/CompressedLargeMessageControllerImpl.java b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/CompressedLargeMessageControllerImpl.java index 3f6a319..acadf1a 100644 --- a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/CompressedLargeMessageControllerImpl.java +++ b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/CompressedLargeMessageControllerImpl.java @@ -18,9 +18,9 @@ import java.io.OutputStream; import java.nio.ByteBuffer; import io.netty.buffer.ByteBuf; -import org.apache.activemq.api.core.HornetQBuffer; -import org.apache.activemq.api.core.HornetQBuffers; -import org.apache.activemq.api.core.HornetQException; +import org.apache.activemq.api.core.ActiveMQBuffer; +import org.apache.activemq.api.core.ActiveMQBuffers; +import org.apache.activemq.api.core.ActiveMQException; import org.apache.activemq.api.core.SimpleString; import org.apache.activemq.core.client.HornetQClientLogger; import org.apache.activemq.utils.DataConstants; @@ -69,12 +69,12 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll bufferDelegate.cancel(); } - public void setOutputStream(final OutputStream output) throws HornetQException + public void setOutputStream(final OutputStream output) throws ActiveMQException { bufferDelegate.setOutputStream(new InflaterWriter(output)); } - public synchronized void saveBuffer(final OutputStream output) throws HornetQException + public synchronized void saveBuffer(final OutputStream output) throws ActiveMQException { setOutputStream(output); waitCompletion(0); @@ -83,7 +83,7 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll /** * @param timeWait Milliseconds to Wait. 0 means forever */ - public synchronized boolean waitCompletion(final long timeWait) throws HornetQException + public synchronized boolean waitCompletion(final long timeWait) throws ActiveMQException { return bufferDelegate.waitCompletion(timeWait); } @@ -140,7 +140,7 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll } @Override - public void getBytes(final int index, final HornetQBuffer dst, final int dstIndex, final int length) + public void getBytes(final int index, final ActiveMQBuffer dst, final int dstIndex, final int length) { positioningNotSupported(); } @@ -185,7 +185,7 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll } @Override - public void setBytes(final int index, final HornetQBuffer src, final int srcIndex, final int length) + public void setBytes(final int index, final ActiveMQBuffer src, final int srcIndex, final int length) { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } @@ -330,12 +330,12 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll } } - public void getBytes(final int index, final HornetQBuffer dst) + public void getBytes(final int index, final ActiveMQBuffer dst) { getBytes(index, dst, dst.writableBytes()); } - public void getBytes(final int index, final HornetQBuffer dst, final int length) + public void getBytes(final int index, final ActiveMQBuffer dst, final int length) { if (length > dst.writableBytes()) { @@ -350,12 +350,12 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } - public void setBytes(final int index, final HornetQBuffer src) + public void setBytes(final int index, final ActiveMQBuffer src) { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } - public void setBytes(final int index, final HornetQBuffer src, final int length) + public void setBytes(final int index, final ActiveMQBuffer src, final int length) { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } @@ -446,12 +446,12 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll readBytes(dst, 0, dst.length); } - public void readBytes(final HornetQBuffer dst) + public void readBytes(final ActiveMQBuffer dst) { readBytes(dst, dst.writableBytes()); } - public void readBytes(final HornetQBuffer dst, final int length) + public void readBytes(final ActiveMQBuffer dst, final int length) { if (length > dst.writableBytes()) { @@ -461,7 +461,7 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll dst.writerIndex(dst.writerIndex() + length); } - public void readBytes(final HornetQBuffer dst, final int dstIndex, final int length) + public void readBytes(final ActiveMQBuffer dst, final int dstIndex, final int length) { byte[] destBytes = new byte[length]; readBytes(destBytes); @@ -521,7 +521,7 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } - public void writeBytes(final HornetQBuffer src, final int length) + public void writeBytes(final ActiveMQBuffer src, final int length) { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } @@ -568,11 +568,11 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll return Float.intBitsToFloat(getInt(index)); } - public HornetQBuffer readBytes(final int length) + public ActiveMQBuffer readBytes(final int length) { byte[] bytesToGet = new byte[length]; readBytes(bytesToGet); - return HornetQBuffers.wrappedBuffer(bytesToGet); + return ActiveMQBuffers.wrappedBuffer(bytesToGet); } @Override @@ -710,12 +710,12 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } - public HornetQBuffer copy() + public ActiveMQBuffer copy() { throw new UnsupportedOperationException(); } - public HornetQBuffer slice(final int index, final int length) + public ActiveMQBuffer slice(final int index, final int length) { throw new UnsupportedOperationException(); } @@ -727,17 +727,17 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll return null; } - public HornetQBuffer copy(final int index, final int length) + public ActiveMQBuffer copy(final int index, final int length) { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } - public HornetQBuffer duplicate() + public ActiveMQBuffer duplicate() { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } - public HornetQBuffer readSlice(final int length) + public ActiveMQBuffer readSlice(final int length) { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } @@ -757,12 +757,12 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } - public HornetQBuffer slice() + public ActiveMQBuffer slice() { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } - public void writeBytes(final HornetQBuffer src, final int srcIndex, final int length) + public void writeBytes(final ActiveMQBuffer src, final int srcIndex, final int length) { throw new IllegalAccessError(OPERATION_NOT_SUPPORTED); } http://git-wip-us.apache.org/repos/asf/activemq-6/blob/1bf2e41f/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/DelegatingSession.java ---------------------------------------------------------------------- diff --git a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/DelegatingSession.java b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/DelegatingSession.java index f328aa4..f13de61 100644 --- a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/DelegatingSession.java +++ b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/DelegatingSession.java @@ -17,7 +17,7 @@ import javax.transaction.xa.XAResource; import javax.transaction.xa.Xid; import java.util.Set; -import org.apache.activemq.api.core.HornetQException; +import org.apache.activemq.api.core.ActiveMQException; import org.apache.activemq.api.core.Message; import org.apache.activemq.api.core.SimpleString; import org.apache.activemq.api.core.client.ClientConsumer; @@ -101,12 +101,12 @@ public class DelegatingSession implements ClientSessionInternal return session.isClosing(); } - public void acknowledge(final ClientConsumer consumer, final Message message) throws HornetQException + public void acknowledge(final ClientConsumer consumer, final Message message) throws ActiveMQException { session.acknowledge(consumer, message); } - public void individualAcknowledge(final ClientConsumer consumer, final Message message) throws HornetQException + public void individualAcknowledge(final ClientConsumer consumer, final Message message) throws ActiveMQException { session.individualAcknowledge(consumer, message); } @@ -131,17 +131,17 @@ public class DelegatingSession implements ClientSessionInternal session.addProducer(producer); } - public AddressQuery addressQuery(final SimpleString address) throws HornetQException + public AddressQuery addressQuery(final SimpleString address) throws ActiveMQException { return session.addressQuery(address); } - public void cleanUp(boolean failingOver) throws HornetQException + public void cleanUp(boolean failingOver) throws ActiveMQException { session.cleanUp(failingOver); } - public void close() throws HornetQException + public void close() throws ActiveMQException { closed = true; @@ -153,7 +153,7 @@ public class DelegatingSession implements ClientSessionInternal session.close(); } - public void commit() throws HornetQException + public void commit() throws ActiveMQException { session.commit(); } @@ -184,7 +184,7 @@ public class DelegatingSession implements ClientSessionInternal public ClientConsumer createConsumer(final SimpleString queueName, final SimpleString filterString, - final boolean browseOnly) throws HornetQException + final boolean browseOnly) throws ActiveMQException { return session.createConsumer(queueName, filterString, browseOnly); } @@ -193,22 +193,22 @@ public class DelegatingSession implements ClientSessionInternal final SimpleString filterString, final int windowSize, final int maxRate, - final boolean browseOnly) throws HornetQException + final boolean browseOnly) throws ActiveMQException { return session.createConsumer(queueName, filterString, windowSize, maxRate, browseOnly); } - public ClientConsumer createConsumer(final SimpleString queueName, final SimpleString filterString) throws HornetQException + public ClientConsumer createConsumer(final SimpleString queueName, final SimpleString filterString) throws ActiveMQException { return session.createConsumer(queueName, filterString); } - public ClientConsumer createConsumer(final SimpleString queueName) throws HornetQException + public ClientConsumer createConsumer(final SimpleString queueName) throws ActiveMQException { return session.createConsumer(queueName); } - public ClientConsumer createConsumer(final String queueName, final String filterString, final boolean browseOnly) throws HornetQException + public ClientConsumer createConsumer(final String queueName, final String filterString, final boolean browseOnly) throws ActiveMQException { return session.createConsumer(queueName, filterString, browseOnly); } @@ -217,74 +217,74 @@ public class DelegatingSession implements ClientSessionInternal final String filterString, final int windowSize, final int maxRate, - final boolean browseOnly) throws HornetQException + final boolean browseOnly) throws ActiveMQException { return session.createConsumer(queueName, filterString, windowSize, maxRate, browseOnly); } - public ClientConsumer createConsumer(final String queueName, final String filterString) throws HornetQException + public ClientConsumer createConsumer(final String queueName, final String filterString) throws ActiveMQException { return session.createConsumer(queueName, filterString); } - public ClientConsumer createConsumer(final String queueName) throws HornetQException + public ClientConsumer createConsumer(final String queueName) throws ActiveMQException { return session.createConsumer(queueName); } - public ClientConsumer createConsumer(final SimpleString queueName, final boolean browseOnly) throws HornetQException + public ClientConsumer createConsumer(final SimpleString queueName, final boolean browseOnly) throws ActiveMQException { return session.createConsumer(queueName, browseOnly); } - public ClientConsumer createConsumer(final String queueName, final boolean browseOnly) throws HornetQException + public ClientConsumer createConsumer(final String queueName, final boolean browseOnly) throws ActiveMQException { return session.createConsumer(queueName, browseOnly); } - public ClientProducer createProducer() throws HornetQException + public ClientProducer createProducer() throws ActiveMQException { return session.createProducer(); } - public ClientProducer createProducer(final SimpleString address, final int rate) throws HornetQException + public ClientProducer createProducer(final SimpleString address, final int rate) throws ActiveMQException { return session.createProducer(address, rate); } - public ClientProducer createProducer(final SimpleString address) throws HornetQException + public ClientProducer createProducer(final SimpleString address) throws ActiveMQException { return session.createProducer(address); } - public ClientProducer createProducer(final String address) throws HornetQException + public ClientProducer createProducer(final String address) throws ActiveMQException { return session.createProducer(address); } - public void createQueue(final String address, final String queueName) throws HornetQException + public void createQueue(final String address, final String queueName) throws ActiveMQException { session.createQueue(address, queueName); } - public void createQueue(final SimpleString address, final SimpleString queueName) throws HornetQException + public void createQueue(final SimpleString address, final SimpleString queueName) throws ActiveMQException { session.createQueue(address, queueName); } - public void createQueue(final SimpleString address, final SimpleString queueName, final boolean durable) throws HornetQException + public void createQueue(final SimpleString address, final SimpleString queueName, final boolean durable) throws ActiveMQException { session.createQueue(address, queueName, durable); } @Override - public void createSharedQueue(SimpleString address, SimpleString queueName, boolean durable) throws HornetQException + public void createSharedQueue(SimpleString address, SimpleString queueName, boolean durable) throws ActiveMQException { session.createSharedQueue(address, queueName, durable); } @Override - public void createSharedQueue(SimpleString address, SimpleString queueName, SimpleString filter, boolean durable) throws HornetQException + public void createSharedQueue(SimpleString address, SimpleString queueName, SimpleString filter, boolean durable) throws ActiveMQException { session.createSharedQueue(address, queueName, filter, durable); } @@ -292,12 +292,12 @@ public class DelegatingSession implements ClientSessionInternal public void createQueue(final SimpleString address, final SimpleString queueName, final SimpleString filterString, - final boolean durable) throws HornetQException + final boolean durable) throws ActiveMQException { session.createQueue(address, queueName, filterString, durable); } - public void createQueue(final String address, final String queueName, final boolean durable) throws HornetQException + public void createQueue(final String address, final String queueName, final boolean durable) throws ActiveMQException { session.createQueue(address, queueName, durable); } @@ -305,37 +305,37 @@ public class DelegatingSession implements ClientSessionInternal public void createQueue(final String address, final String queueName, final String filterString, - final boolean durable) throws HornetQException + final boolean durable) throws ActiveMQException { session.createQueue(address, queueName, filterString, durable); } - public void createTemporaryQueue(final SimpleString address, final SimpleString queueName, final SimpleString filter) throws HornetQException + public void createTemporaryQueue(final SimpleString address, final SimpleString queueName, final SimpleString filter) throws ActiveMQException { session.createTemporaryQueue(address, queueName, filter); } - public void createTemporaryQueue(final SimpleString address, final SimpleString queueName) throws HornetQException + public void createTemporaryQueue(final SimpleString address, final SimpleString queueName) throws ActiveMQException { session.createTemporaryQueue(address, queueName); } - public void createTemporaryQueue(final String address, final String queueName, final String filter) throws HornetQException + public void createTemporaryQueue(final String address, final String queueName, final String filter) throws ActiveMQException { session.createTemporaryQueue(address, queueName, filter); } - public void createTemporaryQueue(final String address, final String queueName) throws HornetQException + public void createTemporaryQueue(final String address, final String queueName) throws ActiveMQException { session.createTemporaryQueue(address, queueName); } - public void deleteQueue(final SimpleString queueName) throws HornetQException + public void deleteQueue(final SimpleString queueName) throws ActiveMQException { session.deleteQueue(queueName); } - public void deleteQueue(final String queueName) throws HornetQException + public void deleteQueue(final String queueName) throws ActiveMQException { session.deleteQueue(queueName); } @@ -345,7 +345,7 @@ public class DelegatingSession implements ClientSessionInternal session.end(xid, flags); } - public void expire(final ClientConsumer consumer, final Message message) throws HornetQException + public void expire(final ClientConsumer consumer, final Message message) throws ActiveMQException { session.expire(consumer, message); } @@ -390,7 +390,7 @@ public class DelegatingSession implements ClientSessionInternal session.preHandleFailover(connection); } - public void handleFailover(final RemotingConnection backupConnection, HornetQException cause) + public void handleFailover(final RemotingConnection backupConnection, ActiveMQException cause) { session.handleFailover(backupConnection, cause); } @@ -414,7 +414,7 @@ public class DelegatingSession implements ClientSessionInternal } @Override - public void handleConsumerDisconnect(ConsumerContext consumerContext) throws HornetQException + public void handleConsumerDisconnect(ConsumerContext consumerContext) throws ActiveMQException { session.handleConsumerDisconnect(consumerContext); } @@ -459,7 +459,7 @@ public class DelegatingSession implements ClientSessionInternal return session.prepare(xid); } - public QueueQuery queueQuery(final SimpleString queueName) throws HornetQException + public QueueQuery queueQuery(final SimpleString queueName) throws ActiveMQException { return session.queueQuery(queueName); } @@ -469,7 +469,7 @@ public class DelegatingSession implements ClientSessionInternal return session.recover(flag); } - public void removeConsumer(final ClientConsumerInternal consumer) throws HornetQException + public void removeConsumer(final ClientConsumerInternal consumer) throws ActiveMQException { session.removeConsumer(consumer); } @@ -489,7 +489,7 @@ public class DelegatingSession implements ClientSessionInternal session.removeProducer(producer); } - public void rollback() throws HornetQException + public void rollback() throws ActiveMQException { session.rollback(); } @@ -499,7 +499,7 @@ public class DelegatingSession implements ClientSessionInternal return session.isRollbackOnly(); } - public void rollback(final boolean considerLastMessageAsDelivered) throws HornetQException + public void rollback(final boolean considerLastMessageAsDelivered) throws ActiveMQException { session.rollback(considerLastMessageAsDelivered); } @@ -520,12 +520,12 @@ public class DelegatingSession implements ClientSessionInternal return session.setTransactionTimeout(seconds); } - public void resetIfNeeded() throws HornetQException + public void resetIfNeeded() throws ActiveMQException { session.resetIfNeeded(); } - public DelegatingSession start() throws HornetQException + public DelegatingSession start() throws ActiveMQException { session.start(); return this; @@ -536,7 +536,7 @@ public class DelegatingSession implements ClientSessionInternal session.start(xid, flags); } - public void stop() throws HornetQException + public void stop() throws ActiveMQException { session.stop(); } @@ -596,7 +596,7 @@ public class DelegatingSession implements ClientSessionInternal session.setPacketSize(packetSize); } - public void addMetaData(String key, String data) throws HornetQException + public void addMetaData(String key, String data) throws ActiveMQException { session.addMetaData(key, data); } @@ -613,7 +613,7 @@ public class DelegatingSession implements ClientSessionInternal } @Override - public void addUniqueMetaData(String key, String data) throws HornetQException + public void addUniqueMetaData(String key, String data) throws ActiveMQException { session.addUniqueMetaData(key, data); http://git-wip-us.apache.org/repos/asf/activemq-6/blob/1bf2e41f/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageController.java ---------------------------------------------------------------------- diff --git a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageController.java b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageController.java index b7aba81..61cd049 100644 --- a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageController.java +++ b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageController.java @@ -14,15 +14,15 @@ package org.apache.activemq.core.client.impl; import java.io.OutputStream; -import org.apache.activemq.api.core.HornetQBuffer; -import org.apache.activemq.api.core.HornetQException; +import org.apache.activemq.api.core.ActiveMQBuffer; +import org.apache.activemq.api.core.ActiveMQException; /** * A LargeMessageBufferInternal * * @author Jeff Mesnil */ -public interface LargeMessageController extends HornetQBuffer +public interface LargeMessageController extends ActiveMQBuffer { /** * Returns the size of this buffer. @@ -48,19 +48,19 @@ public interface LargeMessageController extends HornetQBuffer /** * Sets the OutputStream of this buffer to the specified output. */ - void setOutputStream(final OutputStream output) throws HornetQException; + void setOutputStream(final OutputStream output) throws ActiveMQException; /** * Saves this buffer to the specified output. This is just a blocking version of * {@link #setOutputStream(OutputStream)}. */ - void saveBuffer(final OutputStream output) throws HornetQException; + void saveBuffer(final OutputStream output) throws ActiveMQException; void addPacket(byte[] chunk, int flowControlSize, boolean isContinues); /** * Waits for the completion for the specified waiting time (in milliseconds). */ - boolean waitCompletion(long timeWait) throws HornetQException; + boolean waitCompletion(long timeWait) throws ActiveMQException; } http://git-wip-us.apache.org/repos/asf/activemq-6/blob/1bf2e41f/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageControllerImpl.java ---------------------------------------------------------------------- diff --git a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageControllerImpl.java b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageControllerImpl.java index 7c37524..ff14363 100644 --- a/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageControllerImpl.java +++ b/activemq-core-client/src/main/java/org/apache/activemq/core/client/impl/LargeMessageControllerImpl.java @@ -26,11 +26,11 @@ import java.util.concurrent.LinkedBlockingQueue; import java.util.concurrent.TimeUnit; import io.netty.buffer.ByteBuf; -import org.apache.activemq.api.core.HornetQBuffer; -import org.apache.activemq.api.core.HornetQBuffers; -import org.apache.activemq.api.core.HornetQException; -import org.apache.activemq.api.core.HornetQExceptionType; -import org.apache.activemq.api.core.HornetQInterruptedException; +import org.apache.activemq.api.core.ActiveMQBuffer; +import org.apache.activemq.api.core.ActiveMQBuffers; +import org.apache.activemq.api.core.ActiveMQException; +import org.apache.activemq.api.core.ActiveMQExceptionType; +import org.apache.activemq.api.core.ActiveMQInterruptedException; import org.apache.activemq.api.core.SimpleString; import org.apache.activemq.core.client.HornetQClientLogger; import org.apache.activemq.core.client.HornetQClientMessageBundle; @@ -268,7 +268,7 @@ public class LargeMessageControllerImpl implements LargeMessageController } } - public void setOutputStream(final OutputStream output) throws HornetQException + public void setOutputStream(final OutputStream output) throws ActiveMQException { int totalFlowControl = 0; @@ -304,7 +304,7 @@ public class LargeMessageControllerImpl implements LargeMessageController } } - public synchronized void saveBuffer(final OutputStream output) throws HornetQException + public synchronized void saveBuffer(final OutputStream output) throws ActiveMQException { if (streamClosed) { @@ -316,9 +316,9 @@ public class LargeMessageControllerImpl implements LargeMessageController /** * @param timeWait Milliseconds to Wait. 0 means forever - * @throws HornetQException + * @throws org.apache.activemq.api.core.ActiveMQException */ - public synchronized boolean waitCompletion(final long timeWait) throws HornetQException + public synchronized boolean waitCompletion(final long timeWait) throws ActiveMQException { if (outStream == null) { @@ -347,23 +347,17 @@ public class LargeMessageControllerImpl implements LargeMessageController } catch (InterruptedException e) { - throw new HornetQInterruptedException(e); + throw new ActiveMQInterruptedException(e); } if (!streamEnded && handledException == null) { if (timeWait != 0 && System.currentTimeMillis() > timeOut) { - - // TODO: what to do here? - //throw new HornetQException(HornetQException.LARGE_MESSAGE_ERROR_BODY, - // "Timeout waiting for LargeMessage Body"); throw HornetQClientMessageBundle.BUNDLE.timeoutOnLargeMessage(); } else if (System.currentTimeMillis() > timeOut && !packetAdded) { - // throw new HornetQException(HornetQException.LARGE_MESSAGE_ERROR_BODY, - // "No packets have arrived within " + readTimeout + " milliseconds"); throw HornetQClientMessageBundle.BUNDLE.timeoutOnLargeMessage(); } } @@ -376,21 +370,21 @@ public class LargeMessageControllerImpl implements LargeMessageController } /** - * @throws HornetQException + * @throws org.apache.activemq.api.core.ActiveMQException */ - private void checkException() throws HornetQException + private void checkException() throws ActiveMQException { // it's not needed to copy it as we never set it back to null // once the exception is set, the controller is pretty much useless if (handledException != null) { - if (handledException instanceof HornetQException) + if (handledException instanceof ActiveMQException) { - throw (HornetQException)handledException; + throw (ActiveMQException)handledException; } else { - throw new HornetQException(HornetQExceptionType.LARGE_MESSAGE_ERROR_BODY, + throw new ActiveMQException(ActiveMQExceptionType.LARGE_MESSAGE_ERROR_BODY, "Error on saving LargeMessageBufferImpl", handledException); } @@ -431,14 +425,14 @@ public class LargeMessageControllerImpl implements LargeMessageController } @Override - public void getBytes(final int index, final HornetQBuffer dst, final int dstIndex, final int length) + public void getBytes(final int index, final ActiveMQBuffer dst, final int dstIndex, final int length) { byte[] destBytes = new byte[length]; getBytes(index, destBytes); dst.setBytes(dstIndex, destBytes); } - private void getBytes(final long index, final HornetQBuffer dst, final int dstIndex, final int length) + private void getBytes(final long index, final ActiveMQBuffer dst, final int dstIndex, final int length) { byte[] destBytes = new byte[length]; getBytes(index, destBytes); @@ -565,7 +559,7 @@ public class LargeMessageControllerImpl implements LargeMessageController } @Override - public void setBytes(final int index, final HornetQBuffer src, final int srcIndex, final int length) + public void setBytes(final int index, final ActiveMQBuffer src, final int srcIndex, final int length) { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } @@ -763,12 +757,12 @@ public class LargeMessageControllerImpl implements LargeMessageController } } - public void getBytes(final int index, final HornetQBuffer dst) + public void getBytes(final int index, final ActiveMQBuffer dst) { getBytes(index, dst, dst.writableBytes()); } - public void getBytes(final int index, final HornetQBuffer dst, final int length) + public void getBytes(final int index, final ActiveMQBuffer dst, final int length) { if (length > dst.writableBytes()) { @@ -783,12 +777,12 @@ public class LargeMessageControllerImpl implements LargeMessageController throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public void setBytes(final int index, final HornetQBuffer src) + public void setBytes(final int index, final ActiveMQBuffer src) { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public void setBytes(final int index, final HornetQBuffer src, final int length) + public void setBytes(final int index, final ActiveMQBuffer src, final int length) { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } @@ -868,12 +862,12 @@ public class LargeMessageControllerImpl implements LargeMessageController readBytes(dst, 0, dst.length); } - public void readBytes(final HornetQBuffer dst) + public void readBytes(final ActiveMQBuffer dst) { readBytes(dst, dst.writableBytes()); } - public void readBytes(final HornetQBuffer dst, final int length) + public void readBytes(final ActiveMQBuffer dst, final int length) { if (length > dst.writableBytes()) { @@ -883,7 +877,7 @@ public class LargeMessageControllerImpl implements LargeMessageController dst.writerIndex(dst.writerIndex() + length); } - public void readBytes(final HornetQBuffer dst, final int dstIndex, final int length) + public void readBytes(final ActiveMQBuffer dst, final int dstIndex, final int length) { getBytes(readerIndex, dst, dstIndex, length); readerIndex += length; @@ -952,12 +946,12 @@ public class LargeMessageControllerImpl implements LargeMessageController throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public void writeBytes(final HornetQBuffer src) + public void writeBytes(final ActiveMQBuffer src) { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public void writeBytes(final HornetQBuffer src, final int length) + public void writeBytes(final ActiveMQBuffer src, final int length) { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } @@ -1034,12 +1028,12 @@ public class LargeMessageControllerImpl implements LargeMessageController return Float.intBitsToFloat(getInt(index)); } - public HornetQBuffer readBytes(final int length) + public ActiveMQBuffer readBytes(final int length) { byte[] bytesToGet = new byte[length]; getBytes(readerIndex, bytesToGet); readerIndex += length; - return HornetQBuffers.wrappedBuffer(bytesToGet); + return ActiveMQBuffers.wrappedBuffer(bytesToGet); } @Override @@ -1177,12 +1171,12 @@ public class LargeMessageControllerImpl implements LargeMessageController throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public HornetQBuffer copy() + public ActiveMQBuffer copy() { throw new UnsupportedOperationException(); } - public HornetQBuffer slice(final int index, final int length) + public ActiveMQBuffer slice(final int index, final int length) { throw new UnsupportedOperationException(); } @@ -1190,9 +1184,9 @@ public class LargeMessageControllerImpl implements LargeMessageController /** * @param output * @param packet - * @throws HornetQException + * @throws org.apache.activemq.api.core.ActiveMQException */ - private void sendPacketToOutput(final OutputStream output, final LargeData packet) throws HornetQException + private void sendPacketToOutput(final OutputStream output, final LargeData packet) throws ActiveMQException { try { @@ -1427,17 +1421,17 @@ public class LargeMessageControllerImpl implements LargeMessageController return null; } - public HornetQBuffer copy(final int index, final int length) + public ActiveMQBuffer copy(final int index, final int length) { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public HornetQBuffer duplicate() + public ActiveMQBuffer duplicate() { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public HornetQBuffer readSlice(final int length) + public ActiveMQBuffer readSlice(final int length) { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } @@ -1457,12 +1451,12 @@ public class LargeMessageControllerImpl implements LargeMessageController throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public HornetQBuffer slice() + public ActiveMQBuffer slice() { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); } - public void writeBytes(final HornetQBuffer src, final int srcIndex, final int length) + public void writeBytes(final ActiveMQBuffer src, final int srcIndex, final int length) { throw new IllegalAccessError(LargeMessageControllerImpl.READ_ONLY_ERROR_MESSAGE); }