Package org.codehaus.activemq

Source Code of org.codehaus.activemq.ActiveMQSession

/**
*
* Copyright 2004 Protique Ltd
*
* Licensed 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.codehaus.activemq;
import java.io.Serializable;
import java.util.Iterator;
import java.util.LinkedList;
import java.util.ListIterator;
import javax.jms.BytesMessage;
import javax.jms.DeliveryMode;
import javax.jms.Destination;
import javax.jms.IllegalStateException;
import javax.jms.InvalidDestinationException;
import javax.jms.InvalidSelectorException;
import javax.jms.JMSException;
import javax.jms.MapMessage;
import javax.jms.Message;
import javax.jms.MessageConsumer;
import javax.jms.MessageListener;
import javax.jms.MessageProducer;
import javax.jms.ObjectMessage;
import javax.jms.Queue;
import javax.jms.QueueBrowser;
import javax.jms.QueueReceiver;
import javax.jms.QueueSender;
import javax.jms.QueueSession;
import javax.jms.Session;
import javax.jms.StreamMessage;
import javax.jms.TemporaryQueue;
import javax.jms.TemporaryTopic;
import javax.jms.TextMessage;
import javax.jms.Topic;
import javax.jms.TopicPublisher;
import javax.jms.TopicSession;
import javax.jms.TopicSubscriber;
import javax.jms.TransactionRolledBackException;
import javax.management.j2ee.statistics.Stats;
import org.apache.commons.logging.Log;
import org.apache.commons.logging.LogFactory;
import org.codehaus.activemq.management.JMSSessionStatsImpl;
import org.codehaus.activemq.management.StatsCapable;
import org.codehaus.activemq.message.ActiveMQBytesMessage;
import org.codehaus.activemq.message.ActiveMQDestination;
import org.codehaus.activemq.message.ActiveMQMapMessage;
import org.codehaus.activemq.message.ActiveMQMessage;
import org.codehaus.activemq.message.ActiveMQObjectMessage;
import org.codehaus.activemq.message.ActiveMQQueue;
import org.codehaus.activemq.message.ActiveMQStreamMessage;
import org.codehaus.activemq.message.ActiveMQTemporaryQueue;
import org.codehaus.activemq.message.ActiveMQTemporaryTopic;
import org.codehaus.activemq.message.ActiveMQTextMessage;
import org.codehaus.activemq.message.ActiveMQTopic;
import org.codehaus.activemq.message.ConsumerInfo;
import org.codehaus.activemq.message.DurableUnsubscribe;
import org.codehaus.activemq.message.MessageAck;
import org.codehaus.activemq.message.MessageAcknowledge;
import org.codehaus.activemq.message.ProducerInfo;
import org.codehaus.activemq.message.TransactionInfo;
import org.codehaus.activemq.service.impl.DefaultQueueList;
import org.codehaus.activemq.util.IdGenerator;
import EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList;
import EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean;

/**
* <P>
* A <CODE>Session</CODE> object is a single-threaded context for producing and consuming messages. Although it may
* allocate provider resources outside the Java virtual machine (JVM), it is considered a lightweight JMS object.
* <P>
* A session serves several purposes:
* <UL>
* <LI>It is a factory for its message producers and consumers.
* <LI>It supplies provider-optimized message factories.
* <LI>It is a factory for <CODE>TemporaryTopics</CODE> and <CODE>TemporaryQueues</CODE>.
* <LI>It provides a way to create <CODE>Queue</CODE> or <CODE>Topic</CODE> objects for those clients that need to
* dynamically manipulate provider-specific destination names.
* <LI>It supports a single series of transactions that combine work spanning its producers and consumers into atomic
* units.
* <LI>It defines a serial order for the messages it consumes and the messages it produces.
* <LI>It retains messages it consumes until they have been acknowledged.
* <LI>It serializes execution of message listeners registered with its message consumers.
* <LI>It is a factory for <CODE>QueueBrowsers</CODE>.
* </UL>
* <P>
* A session can create and service multiple message producers and consumers.
* <P>
* One typical use is to have a thread block on a synchronous <CODE>MessageConsumer</CODE> until a message arrives.
* The thread may then use one or more of the <CODE>Session</CODE>'s<CODE>MessageProducer</CODE>s.
* <P>
* If a client desires to have one thread produce messages while others consume them, the client should use a separate
* session for its producing thread.
* <P>
* Once a connection has been started, any session with one or more registered message listeners is dedicated to the
* thread of control that delivers messages to it. It is erroneous for client code to use this session or any of its
* constituent objects from another thread of control. The only exception to this rule is the use of the session or
* connection <CODE>close</CODE> method.
* <P>
* It should be easy for most clients to partition their work naturally into sessions. This model allows clients to
* start simply and incrementally add message processing complexity as their need for concurrency grows.
* <P>
* The <CODE>close</CODE> method is the only session method that can be called while some other session method is
* being executed in another thread.
* <P>
* A session may be specified as transacted. Each transacted session supports a single series of transactions. Each
* transaction groups a set of message sends and a set of message receives into an atomic unit of work. In effect,
* transactions organize a session's input message stream and output message stream into series of atomic units. When a
* transaction commits, its atomic unit of input is acknowledged and its associated atomic unit of output is sent. If a
* transaction rollback is done, the transaction's sent messages are destroyed and the session's input is automatically
* recovered.
* <P>
* The content of a transaction's input and output units is simply those messages that have been produced and consumed
* within the session's current transaction.
* <P>
* A transaction is completed using either its session's <CODE>commit</CODE> method or its session's <CODE>rollback
* </CODE> method. The completion of a session's current transaction automatically begins the next. The result is that a
* transacted session always has a current transaction within which its work is done.
* <P>
* The Java Transaction Service (JTS) or some other transaction monitor may be used to combine a session's transaction
* with transactions on other resources (databases, other JMS sessions, etc.). Since Java distributed transactions are
* controlled via the Java Transaction API (JTA), use of the session's <CODE>commit</CODE> and <CODE>rollback</CODE>
* methods in this context is prohibited.
* <P>
* The JMS API does not require support for JTA; however, it does define how a provider supplies this support.
* <P>
* Although it is also possible for a JMS client to handle distributed transactions directly, it is unlikely that many
* JMS clients will do this. Support for JTA in the JMS API is targeted at systems vendors who will be integrating the
* JMS API into their application server products.
*
* @version $Revision: 1.11.2.1 $
* @see javax.jms.Session
* @see javax.jms.QueueSession
* @see javax.jms.TopicSession
* @see javax.jms.XASession
*/
public class ActiveMQSession
        implements
            Session,
            QueueSession,
            TopicSession,
            ActiveMQMessageDispatcher,
            MessageAcknowledge,
            StatsCapable {
    protected static final int CONSUMER_DISPATCH_UNSET = 1;
    protected static final int CONSUMER_DISPATCH_ASYNC = 2;
    protected static final int CONSUMER_DISPATCH_SYNC = 3;
    private static final Log log = LogFactory.getLog(ActiveMQSession.class);
    protected ActiveMQConnection connection;
    protected int acknowledgeMode;
    protected CopyOnWriteArrayList consumers;
    protected CopyOnWriteArrayList producers;
    private IdGenerator transactionIdGenerator;
    private IdGenerator temporaryDestinationGenerator;
    protected IdGenerator packetIdGenerator;
    private IdGenerator consumerIdGenerator;
    private MessageListener messageListener;
    protected SynchronizedBoolean closed;
    private SynchronizedBoolean startTransaction;
    private String sessionId;
    protected String currentTransactionId;
    private long startTime;
    private LocalTransactionEventListener localTransactionEventListener;
    private DefaultQueueList deliveredMessages;
    private ActiveMQSessionExecutor messageExecutor;
    private JMSSessionStatsImpl stats;
    private int consumerDispatchState;

    /**
     * Construct the Session
     *
     * @param theConnection
     * @param theAcknowledgeMode n.b if transacted - the acknowledgeMode == Session.SESSION_TRANSACTED
     * @throws JMSException on internal error
     */
    protected ActiveMQSession(ActiveMQConnection theConnection, int theAcknowledgeMode) throws JMSException {
        this.connection = theConnection;
        this.acknowledgeMode = theAcknowledgeMode;
        this.consumers = new CopyOnWriteArrayList();
        this.producers = new CopyOnWriteArrayList();
        this.consumerIdGenerator = new IdGenerator();
        this.transactionIdGenerator = new IdGenerator();
        this.temporaryDestinationGenerator = new IdGenerator();
        this.packetIdGenerator = new IdGenerator();
        this.closed = new SynchronizedBoolean(false);
        this.startTransaction = new SynchronizedBoolean(false);
        this.sessionId = connection.generateSessionId();
        this.startTime = System.currentTimeMillis();
        this.deliveredMessages = new DefaultQueueList();
        this.messageExecutor = new ActiveMQSessionExecutor(this, connection.getMemoryBoundedQueue(sessionId));
        connection.addSession(this);
        stats = new JMSSessionStatsImpl(producers, consumers);
        this.consumerDispatchState = CONSUMER_DISPATCH_UNSET;
    }

    public Stats getStats() {
        return stats;
    }

    public JMSSessionStatsImpl getSessionStats() {
        return stats;
    }

    /**
     * Creates a <CODE>BytesMessage</CODE> object. A <CODE>BytesMessage</CODE> object is used to send a message
     * containing a stream of uninterpreted bytes.
     *
     * @return the an ActiveMQBytesMessage
     * @throws JMSException if the JMS provider fails to create this message due to some internal error.
     */
    public BytesMessage createBytesMessage() throws JMSException {
        checkClosed();
        return new ActiveMQBytesMessage();
    }

    /**
     * Creates a <CODE>MapMessage</CODE> object. A <CODE>MapMessage</CODE> object is used to send a self-defining
     * set of name-value pairs, where names are <CODE>String</CODE> objects and values are primitive values in the
     * Java programming language.
     *
     * @return an ActiveMQMapMessage
     * @throws JMSException if the JMS provider fails to create this message due to some internal error.
     */
    public MapMessage createMapMessage() throws JMSException {
        checkClosed();
        return new ActiveMQMapMessage();
    }

    /**
     * Creates a <CODE>Message</CODE> object. The <CODE>Message</CODE> interface is the root interface of all JMS
     * messages. A <CODE>Message</CODE> object holds all the standard message header information. It can be sent when
     * a message containing only header information is sufficient.
     *
     * @return an ActiveMQMessage
     * @throws JMSException if the JMS provider fails to create this message due to some internal error.
     */
    public Message createMessage() throws JMSException {
        checkClosed();
        return new ActiveMQMessage();
    }

    /**
     * Creates an <CODE>ObjectMessage</CODE> object. An <CODE>ObjectMessage</CODE> object is used to send a message
     * that contains a serializable Java object.
     *
     * @return an ActiveMQObjectMessage
     * @throws JMSException if the JMS provider fails to create this message due to some internal error.
     */
    public ObjectMessage createObjectMessage() throws JMSException {
        checkClosed();
        return new ActiveMQObjectMessage();
    }

    /**
     * Creates an initialized <CODE>ObjectMessage</CODE> object. An <CODE>ObjectMessage</CODE> object is used to
     * send a message that contains a serializable Java object.
     *
     * @param object the object to use to initialize this message
     * @return an ActiveMQObjectMessage
     * @throws JMSException if the JMS provider fails to create this message due to some internal error.
     */
    public ObjectMessage createObjectMessage(Serializable object) throws JMSException {
        checkClosed();
        ActiveMQObjectMessage msg = new ActiveMQObjectMessage();
        msg.setObject(object);
        return msg;
    }

    /**
     * Creates a <CODE>StreamMessage</CODE> object. A <CODE>StreamMessage</CODE> object is used to send a
     * self-defining stream of primitive values in the Java programming language.
     *
     * @return an ActiveMQStreamMessage
     * @throws JMSException if the JMS provider fails to create this message due to some internal error.
     */
    public StreamMessage createStreamMessage() throws JMSException {
        checkClosed();
        return new ActiveMQStreamMessage();
    }

    /**
     * Creates a <CODE>TextMessage</CODE> object. A <CODE>TextMessage</CODE> object is used to send a message
     * containing a <CODE>String</CODE> object.
     *
     * @return an ActiveMQTextMessage
     * @throws JMSException if the JMS provider fails to create this message due to some internal error.
     */
    public TextMessage createTextMessage() throws JMSException {
        checkClosed();
        return new ActiveMQTextMessage();
    }

    /**
     * Creates an initialized <CODE>TextMessage</CODE> object. A <CODE>TextMessage</CODE> object is used to send a
     * message containing a <CODE>String</CODE>.
     *
     * @param text the string used to initialize this message
     * @return an ActiveMQTextMessage
     * @throws JMSException if the JMS provider fails to create this message due to some internal error.
     */
    public TextMessage createTextMessage(String text) throws JMSException {
        checkClosed();
        ActiveMQTextMessage msg = new ActiveMQTextMessage();
        msg.setText(text);
        return msg;
    }

    /**
     * Indicates whether the session is in transacted mode.
     *
     * @return true if the session is in transacted mode
     * @throws JMSException if there is some internal error.
     */
    public boolean getTransacted() throws JMSException {
        checkClosed();
        return this.acknowledgeMode == Session.SESSION_TRANSACTED;
    }

    /**
     * Returns the acknowledgement mode of the session. The acknowledgement mode is set at the time that the session is
     * created. If the session is transacted, the acknowledgement mode is ignored.
     *
     * @return If the session is not transacted, returns the current acknowledgement mode for the session. If the
     * session is transacted, returns SESSION_TRANSACTED.
     * @throws JMSException
     * @see javax.jms.Connection#createSession(boolean,int)
     * @since 1.1 exception JMSException if there is some internal error.
     */
    public int getAcknowledgeMode() throws JMSException {
        checkClosed();
        return this.acknowledgeMode;
    }

    /**
     * Commits all messages done in this transaction and releases any locks currently held.
     *
     * @throws JMSException if the JMS provider fails to commit the transaction due to some internal error.
     * @throws TransactionRolledBackException if the transaction is rolled back due to some internal error during
     * commit.
     * @throws javax.jms.IllegalStateException if the method is not called by a transacted session.
     */
    public void commit() throws JMSException {
        commitLocalTransaction();
    }

    /**
     * Commits all messages done in this transaction and releases any locks currently held.
     *
     * @throws JMSException if the JMS provider fails to commit the transaction due to some internal error.
     * @throws TransactionRolledBackException if the transaction is rolled back due to some internal error during
     * commit.
     * @throws javax.jms.IllegalStateException if the method is not called by a transacted session.
     */
    protected void commitLocalTransaction() throws IllegalStateException, JMSException {
        checkClosed();
        if (!getTransacted()) {
            throw new javax.jms.IllegalStateException("Not a transacted session");
        }
        // Only send commit if the transaction was started.
        if (this.startTransaction.commit(true, false)) {
            TransactionInfo info = new TransactionInfo();
            info.setId(this.packetIdGenerator.generateId());
            info.setTransactionId(currentTransactionId);
            info.setType(TransactionInfo.COMMIT);
            //before we send, update the current transaction id
            this.currentTransactionId = null;
            // Notify the listener that the tx was commited back
            this.connection.syncSendPacket(info);
            if (localTransactionEventListener != null) {
                localTransactionEventListener.commitEvent();
            }
        }
        deliveredMessages.clear();
    }

    /**
     * Rolls back any messages done in this transaction and releases any locks currently held.
     *
     * @throws JMSException if the JMS provider fails to roll back the transaction due to some internal error.
     * @throws javax.jms.IllegalStateException if the method is not called by a transacted session.
     */
    public void rollback() throws JMSException {
        rollbackLocalTransaction();
    }

    /**
     * Rolls back any messages done in this transaction and releases any locks currently held.
     *
     * @throws JMSException if the JMS provider fails to roll back the transaction due to some internal error.
     * @throws javax.jms.IllegalStateException if the method is not called by a transacted session.
     */
    protected void rollbackLocalTransaction() throws IllegalStateException, JMSException {
        checkClosed();
        if (!getTransacted()) {
            throw new javax.jms.IllegalStateException("Not a transacted session");
        }
        // Only rollback commit if the transaction was started.
        if (this.startTransaction.commit(true, false)) {
            TransactionInfo info = new TransactionInfo();
            info.setId(this.packetIdGenerator.generateId());
            info.setTransactionId(currentTransactionId);
            info.setType(TransactionInfo.ROLLBACK);
            //before we send, update the current transaction id
            this.currentTransactionId = null;
            this.connection.asyncSendPacket(info);
            // Notify the listener that the tx was rolled back
            if (localTransactionEventListener != null) {
                localTransactionEventListener.rollbackEvent();
            }
        }
        redeliverUnacknowledgedMessages(true);
        deliveredMessages.clear();
    }

    /**
     * Closes the session.
     * <P>
     * Since a provider may allocate some resources on behalf of a session outside the JVM, clients should close the
     * resources when they are not needed. Relying on garbage collection to eventually reclaim these resources may not
     * be timely enough.
     * <P>
     * There is no need to close the producers and consumers of a closed session.
     * <P>
     * This call will block until a <CODE>receive</CODE> call or message listener in progress has completed. A blocked
     * message consumer <CODE>receive</CODE> call returns <CODE>null</CODE> when this session is closed.
     * <P>
     * Closing a transacted session must roll back the transaction in progress.
     * <P>
     * This method is the only <CODE>Session</CODE> method that can be called concurrently.
     * <P>
     * Invoking any other <CODE>Session</CODE> method on a closed session must throw a <CODE>
     * JMSException.IllegalStateException</CODE>. Closing a closed session must <I>not </I> throw an exception.
     *
     * @throws JMSException if the JMS provider fails to close the session due to some internal error.
     */
    public void close() throws JMSException {
        if (!this.closed.get()) {
            if (getTransacted()) {
                rollback();
            }
            doClose();
            closed.set(true);
        }
    }

    protected void doClose() throws JMSException {
        for (Iterator i = consumers.iterator();i.hasNext();) {
            ActiveMQMessageConsumer consumer = (ActiveMQMessageConsumer) i.next();
            consumer.close();
        }
        for (Iterator i = producers.iterator();i.hasNext();) {
            ActiveMQMessageProducer producer = (ActiveMQMessageProducer) i.next();
            producer.close();
        }
        consumers.clear();
        producers.clear();
        doAcknowledge(true);
        this.connection.removeSession(this);
        messageExecutor.close();
        deliveredMessages.clear();
    }

    /**
     * @throws IllegalStateException if the Session is closed
     */
    protected void checkClosed() throws IllegalStateException {
        if (this.closed.get()) {
            throw new IllegalStateException("The Session is closed");
        }
    }

    /**
     * Stops message delivery in this session, and restarts message delivery with the oldest unacknowledged message.
     * <P>
     * All consumers deliver messages in a serial order. Acknowledging a received message automatically acknowledges all
     * messages that have been delivered to the client.
     * <P>
     * Restarting a session causes it to take the following actions:
     * <UL>
     * <LI>Stop message delivery
     * <LI>Mark all messages that might have been delivered but not acknowledged as "redelivered"
     * <LI>Restart the delivery sequence including all unacknowledged messages that had been previously delivered.
     * Redelivered messages do not have to be delivered in exactly their original delivery order.
     * </UL>
     *
     * @throws JMSException if the JMS provider fails to stop and restart message delivery due to some internal error.
     * @throws IllegalStateException if the method is called by a transacted session.
     */
    public void recover() throws JMSException {
        checkClosed();
        if (getTransacted()) {
            throw new IllegalStateException("This session is transacted");
        }
        redeliverUnacknowledgedMessages();
    }

    /**
     * Returns the session's distinguished message listener (optional).
     *
     * @return the message listener associated with this session
     * @throws JMSException if the JMS provider fails to get the message listener due to an internal error.
     * @see javax.jms.Session#setMessageListener(javax.jms.MessageListener)
     * @see javax.jms.ServerSessionPool
     * @see javax.jms.ServerSession
     */
    public MessageListener getMessageListener() throws JMSException {
        checkClosed();
        return this.messageListener;
    }

    /**
     * Sets the session's distinguished message listener (optional).
     * <P>
     * When the distinguished message listener is set, no other form of message receipt in the session can be used;
     * however, all forms of sending messages are still supported.
     * <P>
     * This is an expert facility not used by regular JMS clients.
     *
     * @param listener the message listener to associate with this session
     * @throws JMSException if the JMS provider fails to set the message listener due to an internal error.
     * @see javax.jms.Session#getMessageListener()
     * @see javax.jms.ServerSessionPool
     * @see javax.jms.ServerSession
     */
    public void setMessageListener(MessageListener listener) throws JMSException {
        checkClosed();
        this.messageListener = listener;
        if (listener != null) {
            messageExecutor.setDoDispatch(false);
        }
    }

    /**
     * Optional operation, intended to be used only by Application Servers, not by ordinary JMS clients.
     *
     * @see javax.jms.ServerSession
     */
    public void run() {
        ActiveMQMessage message;
        while ((message = messageExecutor.dequeueNoWait()) != null) {
            this.beforeMessageDelivered(message);
            preDeliveryHook(messageListener, message);
            deliver(message);
            postDeliveryHook(messageListener, message);
        }
    }

    /**
     * Hook method for subclasses that need to perform pre-delivery
     * operations.
     *
     * @param listener the listener which will receive the message
     * @param message the message that will be delivered
     */
    protected void preDeliveryHook(MessageListener listener, ActiveMQMessage message) {
    }

    /**
     * Hook method for subclasses that need to perform post delivery
     * operations.
     * 
     * @param listener the listener which received the message
     * @param message the message that was delivered
     */
    protected void postDeliveryHook(MessageListener listener, ActiveMQMessage message) {
    }

    /**
     * Delivers a message to the messageListern
     * @param message The message to deliver
     */
    private void deliver(ActiveMQMessage message) {
        if (!message.isExpired() && this.messageListener != null) {
            try {
                this.messageListener.onMessage(message);
                this.afterMessageDelivered(true, message, true, false, true);
            }
            catch (Throwable t) {
                log.info("Caught :" + t, t);
                this.afterMessageDelivered(true, message, false, false, true);
            }
        }
        else {
            this.afterMessageDelivered(true, message, false, message.isExpired(), true);
        }
    }

    /**
     * Creates a <CODE>MessageProducer</CODE> to send messages to the specified destination.
     * <P>
     * A client uses a <CODE>MessageProducer</CODE> object to send messages to a destination. Since <CODE>Queue
     * </CODE> and <CODE>Topic</CODE> both inherit from <CODE>Destination</CODE>, they can be used in the
     * destination parameter to create a <CODE>MessageProducer</CODE> object.
     *
     * @param destination the <CODE>Destination</CODE> to send to, or null if this is a producer which does not have a
     * specified destination.
     * @return the MessageProducer
     * @throws JMSException if the session fails to create a MessageProducer due to some internal error.
     * @throws InvalidDestinationException if an invalid destination is specified.
     * @since 1.1
     */
    public MessageProducer createProducer(Destination destination) throws JMSException {
        checkClosed();
        return new ActiveMQMessageProducer(this, ActiveMQMessageTransformation.transformDestination(destination));
    }

    /**
     * Creates a <CODE>MessageConsumer</CODE> for the specified destination. Since <CODE>Queue</CODE> and <CODE>
     * Topic</CODE> both inherit from <CODE>Destination</CODE>, they can be used in the destination parameter to
     * create a <CODE>MessageConsumer</CODE>.
     *
     * @param destination the <CODE>Destination</CODE> to access.
     * @return the MessageConsumer
     * @throws JMSException if the session fails to create a consumer due to some internal error.
     * @throws InvalidDestinationException if an invalid destination is specified.
     * @since 1.1
     */
    public MessageConsumer createConsumer(Destination destination) throws JMSException {
        checkClosed();
        int prefetch = destination instanceof Topic ? connection.getPrefetchPolicy().getTopicPrefetch() : connection
                .getPrefetchPolicy().getQueuePrefetch();
        return new ActiveMQMessageConsumer(this, ActiveMQMessageTransformation.transformDestination(destination), "",
                "", this.connection.getNextConsumerNumber(), prefetch, false, false);
    }

    /**
     * Creates a <CODE>MessageConsumer</CODE> for the specified destination, using a message selector. Since <CODE>
     * Queue</CODE> and <CODE>Topic</CODE> both inherit from <CODE>Destination</CODE>, they can be used in the
     * destination parameter to create a <CODE>MessageConsumer</CODE>.
     * <P>
     * A client uses a <CODE>MessageConsumer</CODE> object to receive messages that have been sent to a destination.
     *
     * @param destination the <CODE>Destination</CODE> to access
     * @param messageSelector only messages with properties matching the message selector expression are delivered. A
     * value of null or an empty string indicates that there is no message selector for the message consumer.
     * @return the MessageConsumer
     * @throws JMSException if the session fails to create a MessageConsumer due to some internal error.
     * @throws InvalidDestinationException if an invalid destination is specified.
     * @throws InvalidSelectorException if the message selector is invalid.
     * @since 1.1
     */
    public MessageConsumer createConsumer(Destination destination, String messageSelector) throws JMSException {
        checkClosed();
        int prefetch = destination instanceof Topic ? connection.getPrefetchPolicy().getTopicPrefetch() : connection
                .getPrefetchPolicy().getQueuePrefetch();
        return new ActiveMQMessageConsumer(this, ActiveMQMessageTransformation.transformDestination(destination), "",
                messageSelector, this.connection.getNextConsumerNumber(), prefetch, false, false);
    }

    /**
     * Creates <CODE>MessageConsumer</CODE> for the specified destination, using a message selector. This method can
     * specify whether messages published by its own connection should be delivered to it, if the destination is a
     * topic.
     * <P>
     * Since <CODE>Queue</CODE> and <CODE>Topic</CODE> both inherit from <CODE>Destination</CODE>, they can be
     * used in the destination parameter to create a <CODE>MessageConsumer</CODE>.
     * <P>
     * A client uses a <CODE>MessageConsumer</CODE> object to receive messages that have been published to a
     * destination.
     * <P>
     * In some cases, a connection may both publish and subscribe to a topic. The consumer <CODE>NoLocal</CODE>
     * attribute allows a consumer to inhibit the delivery of messages published by its own connection. The default
     * value for this attribute is False. The <CODE>noLocal</CODE> value must be supported by destinations that are
     * topics.
     *
     * @param destination the <CODE>Destination</CODE> to access
     * @param messageSelector only messages with properties matching the message selector expression are delivered. A
     * value of null or an empty string indicates that there is no message selector for the message consumer.
     * @param NoLocal - if true, and the destination is a topic, inhibits the delivery of messages published by its own
     * connection. The behavior for <CODE>NoLocal</CODE> is not specified if the destination is a queue.
     * @return the MessageConsumer
     * @throws JMSException if the session fails to create a MessageConsumer due to some internal error.
     * @throws InvalidDestinationException if an invalid destination is specified.
     * @throws InvalidSelectorException if the message selector is invalid.
     * @since 1.1
     */
    public MessageConsumer createConsumer(Destination destination, String messageSelector, boolean NoLocal)
            throws JMSException {
        checkClosed();
        int prefetch = connection.getPrefetchPolicy().getTopicPrefetch();
        return new ActiveMQMessageConsumer(this, ActiveMQMessageTransformation.transformDestination(destination), "",
                messageSelector, this.connection.getNextConsumerNumber(), prefetch, NoLocal, false);
    }

    /**
     * Creates a queue identity given a <CODE>Queue</CODE> name.
     * <P>
     * This facility is provided for the rare cases where clients need to dynamically manipulate queue identity. It
     * allows the creation of a queue identity with a provider-specific name. Clients that depend on this ability are
     * not portable.
     * <P>
     * Note that this method is not for creating the physical queue. The physical creation of queues is an
     * administrative task and is not to be initiated by the JMS API. The one exception is the creation of temporary
     * queues, which is accomplished with the <CODE>createTemporaryQueue</CODE> method.
     *
     * @param queueName the name of this <CODE>Queue</CODE>
     * @return a <CODE>Queue</CODE> with the given name
     * @throws JMSException if the session fails to create a queue due to some internal error.
     * @since 1.1
     */
    public Queue createQueue(String queueName) throws JMSException {
        checkClosed();
        return new ActiveMQQueue(queueName);
    }

    /**
     * Creates a topic identity given a <CODE>Topic</CODE> name.
     * <P>
     * This facility is provided for the rare cases where clients need to dynamically manipulate topic identity. This
     * allows the creation of a topic identity with a provider-specific name. Clients that depend on this ability are
     * not portable.
     * <P>
     * Note that this method is not for creating the physical topic. The physical creation of topics is an
     * administrative task and is not to be initiated by the JMS API. The one exception is the creation of temporary
     * topics, which is accomplished with the <CODE>createTemporaryTopic</CODE> method.
     *
     * @param topicName the name of this <CODE>Topic</CODE>
     * @return a <CODE>Topic</CODE> with the given name
     * @throws JMSException if the session fails to create a topic due to some internal error.
     * @since 1.1
     */
    public Topic createTopic(String topicName) throws JMSException {
        checkClosed();
        return new ActiveMQTopic(topicName);
    }

    /**
     * Creates a <CODE>QueueBrowser</CODE> object to peek at the messages on the specified queue.
     *
     * @param queue the <CODE>queue</CODE> to access
     * @exception InvalidDestinationException if an invalid destination is specified
     * @since 1.1
     */
    /**
     * Creates a durable subscriber to the specified topic.
     * <P>
     * If a client needs to receive all the messages published on a topic, including the ones published while the
     * subscriber is inactive, it uses a durable <CODE>TopicSubscriber</CODE>. The JMS provider retains a record of
     * this durable subscription and insures that all messages from the topic's publishers are retained until they are
     * acknowledged by this durable subscriber or they have expired.
     * <P>
     * Sessions with durable subscribers must always provide the same client identifier. In addition, each client must
     * specify a name that uniquely identifies (within client identifier) each durable subscription it creates. Only one
     * session at a time can have a <CODE>TopicSubscriber</CODE> for a particular durable subscription.
     * <P>
     * A client can change an existing durable subscription by creating a durable <CODE>TopicSubscriber</CODE> with
     * the same name and a new topic and/or message selector. Changing a durable subscriber is equivalent to
     * unsubscribing (deleting) the old one and creating a new one.
     * <P>
     * In some cases, a connection may both publish and subscribe to a topic. The subscriber <CODE>NoLocal</CODE>
     * attribute allows a subscriber to inhibit the delivery of messages published by its own connection. The default
     * value for this attribute is false.
     *
     * @param topic the non-temporary <CODE>Topic</CODE> to subscribe to
     * @param name the name used to identify this subscription
     * @return the TopicSubscriber
     * @throws JMSException if the session fails to create a subscriber due to some internal error.
     * @throws InvalidDestinationException if an invalid topic is specified.
     * @since 1.1
     */
    public TopicSubscriber createDurableSubscriber(Topic topic, String name) throws JMSException {
        checkClosed();
        return new ActiveMQTopicSubscriber(this, ActiveMQMessageTransformation.transformDestination(topic), name, "",
                this.connection.getNextConsumerNumber(), this.connection.getPrefetchPolicy().getDurableTopicPrefetch(),
                false, false);
    }

    /**
     * Creates a durable subscriber to the specified topic, using a message selector and specifying whether messages
     * published by its own connection should be delivered to it.
     * <P>
     * If a client needs to receive all the messages published on a topic, including the ones published while the
     * subscriber is inactive, it uses a durable <CODE>TopicSubscriber</CODE>. The JMS provider retains a record of
     * this durable subscription and insures that all messages from the topic's publishers are retained until they are
     * acknowledged by this durable subscriber or they have expired.
     * <P>
     * Sessions with durable subscribers must always provide the same client identifier. In addition, each client must
     * specify a name which uniquely identifies (within client identifier) each durable subscription it creates. Only
     * one session at a time can have a <CODE>TopicSubscriber</CODE> for a particular durable subscription. An
     * inactive durable subscriber is one that exists but does not currently have a message consumer associated with it.
     * <P>
     * A client can change an existing durable subscription by creating a durable <CODE>TopicSubscriber</CODE> with
     * the same name and a new topic and/or message selector. Changing a durable subscriber is equivalent to
     * unsubscribing (deleting) the old one and creating a new one.
     *
     * @param topic the non-temporary <CODE>Topic</CODE> to subscribe to
     * @param name the name used to identify this subscription
     * @param messageSelector only messages with properties matching the message selector expression are delivered. A
     * value of null or an empty string indicates that there is no message selector for the message consumer.
     * @param noLocal if set, inhibits the delivery of messages published by its own connection
     * @return the Queue Browser
     * @throws JMSException if the session fails to create a subscriber due to some internal error.
     * @throws InvalidDestinationException if an invalid topic is specified.
     * @throws InvalidSelectorException if the message selector is invalid.
     * @since 1.1
     */
    public TopicSubscriber createDurableSubscriber(Topic topic, String name, String messageSelector, boolean noLocal)
            throws JMSException {
        checkClosed();
        return new ActiveMQTopicSubscriber(this, ActiveMQMessageTransformation.transformDestination(topic), name,
                messageSelector, this.connection.getNextConsumerNumber(), this.connection.getPrefetchPolicy()
                        .getDurableTopicPrefetch(), noLocal, false);
    }

    /**
     * Creates a <CODE>QueueBrowser</CODE> object to peek at the messages on the specified queue.
     *
     * @param queue the <CODE>queue</CODE> to access
     * @return the Queue Browser
     * @throws JMSException if the session fails to create a browser due to some internal error.
     * @throws InvalidDestinationException if an invalid destination is specified
     * @since 1.1
     */
    public QueueBrowser createBrowser(Queue queue) throws JMSException {
        checkClosed();
        return new ActiveMQQueueBrowser(this, ActiveMQMessageTransformation.transformDestination(queue), "",
                this.connection.getNextConsumerNumber());
    }

    /**
     * Creates a <CODE>QueueBrowser</CODE> object to peek at the messages on the specified queue using a message
     * selector.
     *
     * @param queue the <CODE>queue</CODE> to access
     * @param messageSelector only messages with properties matching the message selector expression are delivered. A
     * value of null or an empty string indicates that there is no message selector for the message consumer.
     * @return the Queue Browser
     * @throws JMSException if the session fails to create a browser due to some internal error.
     * @throws InvalidDestinationException if an invalid destination is specified
     * @throws InvalidSelectorException if the message selector is invalid.
     * @since 1.1
     */
    public QueueBrowser createBrowser(Queue queue, String messageSelector) throws JMSException {
        checkClosed();
        return new ActiveMQQueueBrowser(this, ActiveMQMessageTransformation.transformDestination(queue),
                messageSelector, this.connection.getNextConsumerNumber());
    }

    /**
     * Creates a <CODE>TemporaryQueue</CODE> object. Its lifetime will be that of the <CODE>Connection</CODE> unless
     * it is deleted earlier.
     *
     * @return a temporary queue identity
     * @throws JMSException if the session fails to create a temporary queue due to some internal error.
     * @since 1.1
     */
    public TemporaryQueue createTemporaryQueue() throws JMSException {
        checkClosed();
        String tempQueueName = "TemporaryQueue-"
                + ActiveMQDestination.createTemporaryName(this.connection.getInitializedClientID());
        tempQueueName += this.temporaryDestinationGenerator.generateId();
        return new ActiveMQTemporaryQueue(tempQueueName);
    }

    /**
     * Creates a <CODE>TemporaryTopic</CODE> object. Its lifetime will be that of the <CODE>Connection</CODE> unless
     * it is deleted earlier.
     *
     * @return a temporary topic identity
     * @throws JMSException if the session fails to create a temporary topic due to some internal error.
     * @since 1.1
     */
    public TemporaryTopic createTemporaryTopic() throws JMSException {
        checkClosed();
        String tempTopicName = "TemporaryTopic-"
                + ActiveMQDestination.createTemporaryName(this.connection.getInitializedClientID());
        tempTopicName += this.temporaryDestinationGenerator.generateId();
        return new ActiveMQTemporaryTopic(tempTopicName);
    }

    /**
     * Creates a <CODE>QueueReceiver</CODE> object to receive messages from the specified queue.
     *
     * @param queue the <CODE>Queue</CODE> to access
     * @return @throws JMSException if the session fails to create a receiver due to some internal error.
     * @throws JMSException
     * @throws InvalidDestinationException if an invalid queue is specified.
     */
    public QueueReceiver createReceiver(Queue queue) throws JMSException {
        checkClosed();
        return new ActiveMQQueueReceiver(this, ActiveMQDestination.transformDestination(queue), "", this.connection
                .getNextConsumerNumber(), this.connection.getPrefetchPolicy().getQueuePrefetch());
    }

    /**
     * Creates a <CODE>QueueReceiver</CODE> object to receive messages from the specified queue using a message
     * selector.
     *
     * @param queue the <CODE>Queue</CODE> to access
     * @param messageSelector only messages with properties matching the message selector expression are delivered. A
     * value of null or an empty string indicates that there is no message selector for the message consumer.
     * @return QueueReceiver
     * @throws JMSException if the session fails to create a receiver due to some internal error.
     * @throws InvalidDestinationException if an invalid queue is specified.
     * @throws InvalidSelectorException if the message selector is invalid.
     */
    public QueueReceiver createReceiver(Queue queue, String messageSelector) throws JMSException {
        checkClosed();
        return new ActiveMQQueueReceiver(this, ActiveMQMessageTransformation.transformDestination(queue),
                messageSelector, this.connection.getNextConsumerNumber(), this.connection.getPrefetchPolicy()
                        .getQueuePrefetch());
    }

    /**
     * Creates a <CODE>QueueSender</CODE> object to send messages to the specified queue.
     *
     * @param queue the <CODE>Queue</CODE> to access, or null if this is an unidentified producer
     * @return QueueSender
     * @throws JMSException if the session fails to create a sender due to some internal error.
     * @throws InvalidDestinationException if an invalid queue is specified.
     */
    public QueueSender createSender(Queue queue) throws JMSException {
        checkClosed();
        return new ActiveMQQueueSender(this, ActiveMQMessageTransformation.transformDestination(queue));
    }

    /**
     * Creates a nondurable subscriber to the specified topic. <p/>
     * <P>
     * A client uses a <CODE>TopicSubscriber</CODE> object to receive messages that have been published to a topic.
     * <p/>
     * <P>
     * Regular <CODE>TopicSubscriber</CODE> objects are not durable. They receive only messages that are published
     * while they are active. <p/>
     * <P>
     * In some cases, a connection may both publish and subscribe to a topic. The subscriber <CODE>NoLocal</CODE>
     * attribute allows a subscriber to inhibit the delivery of messages published by its own connection. The default
     * value for this attribute is false.
     *
     * @param topic the <CODE>Topic</CODE> to subscribe to
     * @return TopicSubscriber
     * @throws JMSException if the session fails to create a subscriber due to some internal error.
     * @throws InvalidDestinationException if an invalid topic is specified.
     */
    public TopicSubscriber createSubscriber(Topic topic) throws JMSException {
        checkClosed();
        return new ActiveMQTopicSubscriber(this, ActiveMQMessageTransformation.transformDestination(topic), null, null,
                this.connection.getNextConsumerNumber(), this.connection.getPrefetchPolicy().getTopicPrefetch(), false,
                false);
    }

    /**
     * Creates a nondurable subscriber to the specified topic, using a message selector or specifying whether messages
     * published by its own connection should be delivered to it. <p/>
     * <P>
     * A client uses a <CODE>TopicSubscriber</CODE> object to receive messages that have been published to a topic.
     * <p/>
     * <P>
     * Regular <CODE>TopicSubscriber</CODE> objects are not durable. They receive only messages that are published
     * while they are active. <p/>
     * <P>
     * Messages filtered out by a subscriber's message selector will never be delivered to the subscriber. From the
     * subscriber's perspective, they do not exist. <p/>
     * <P>
     * In some cases, a connection may both publish and subscribe to a topic. The subscriber <CODE>NoLocal</CODE>
     * attribute allows a subscriber to inhibit the delivery of messages published by its own connection. The default
     * value for this attribute is false.
     *
     * @param topic the <CODE>Topic</CODE> to subscribe to
     * @param messageSelector only messages with properties matching the message selector expression are delivered. A
     * value of null or an empty string indicates that there is no message selector for the message consumer.
     * @param noLocal if set, inhibits the delivery of messages published by its own connection
     * @return TopicSubscriber
     * @throws JMSException if the session fails to create a subscriber due to some internal error.
     * @throws InvalidDestinationException if an invalid topic is specified.
     * @throws InvalidSelectorException if the message selector is invalid.
     */
    public TopicSubscriber createSubscriber(Topic topic, String messageSelector, boolean noLocal) throws JMSException {
        checkClosed();
        return new ActiveMQTopicSubscriber(this, ActiveMQMessageTransformation.transformDestination(topic), null,
                messageSelector, this.connection.getNextConsumerNumber(), this.connection.getPrefetchPolicy()
                        .getTopicPrefetch(), noLocal, false);
    }

    /**
     * Creates a publisher for the specified topic. <p/>
     * <P>
     * A client uses a <CODE>TopicPublisher</CODE> object to publish messages on a topic. Each time a client creates a
     * <CODE>TopicPublisher</CODE> on a topic, it defines a new sequence of messages that have no ordering
     * relationship with the messages it has previously sent.
     *
     * @param topic the <CODE>Topic</CODE> to publish to, or null if this is an unidentified producer
     * @return TopicPublisher
     * @throws JMSException if the session fails to create a publisher due to some internal error.
     * @throws InvalidDestinationException if an invalid topic is specified.
     */
    public TopicPublisher createPublisher(Topic topic) throws JMSException {
        checkClosed();
        return new ActiveMQTopicPublisher(this, ActiveMQMessageTransformation.transformDestination(topic));
    }

    /**
     * Unsubscribes a durable subscription that has been created by a client.
     * <P>
     * This method deletes the state being maintained on behalf of the subscriber by its provider.
     * <P>
     * It is erroneous for a client to delete a durable subscription while there is an active <CODE>MessageConsumer
     * </CODE> or <CODE>TopicSubscriber</CODE> for the subscription, or while a consumed message is part of a pending
     * transaction or has not been acknowledged in the session.
     *
     * @param name the name used to identify this subscription
     * @throws JMSException if the session fails to unsubscribe to the durable subscription due to some internal error.
     * @throws InvalidDestinationException if an invalid subscription name is specified.
     * @since 1.1
     */
    public void unsubscribe(String name) throws JMSException {
        checkClosed();
        DurableUnsubscribe ds = new DurableUnsubscribe();
        ds.setId(this.packetIdGenerator.generateId());
        ds.setClientId(this.connection.getClientID());
        ds.setSubscriberName(name);
        this.connection.syncSendPacket(ds);
    }

    /**
     * Tests to see if the Message Dispatcher is a target for this message
     *
     * @param message the message to test
     * @return true if the Message Dispatcher can dispatch the message
     */
    public boolean isTarget(ActiveMQMessage message) {
        for (Iterator i = this.consumers.iterator();i.hasNext();) {
            ActiveMQMessageConsumer consumer = (ActiveMQMessageConsumer) i.next();
            if (message.isConsumerTarget(consumer.getConsumerNumber())) {
                return true;
            }
        }
        return false;
    }

    /**
     * Dispatch an ActiveMQMessage
     *
     * @param message
     */
    public void dispatch(ActiveMQMessage message) {
        message.setMessageAcknowledge(this);
        messageExecutor.execute(message);
    }

    /**
     * Acknowledges all consumed messages of the session of this consumed message.
     * <P>
     * All consumed JMS messages support the <CODE>acknowledge</CODE> method for use when a client has specified that
     * its JMS session's consumed messages are to be explicitly acknowledged. By invoking <CODE>acknowledge</CODE> on
     * a consumed message, a client acknowledges all messages consumed by the session that the message was delivered to.
     * <P>
     * Calls to <CODE>acknowledge</CODE> are ignored for both transacted sessions and sessions specified to use
     * implicit acknowledgement modes.
     * <P>
     * A client may individually acknowledge each message as it is consumed, or it may choose to acknowledge messages as
     * an application-defined group (which is done by calling acknowledge on the last received message of the group,
     * thereby acknowledging all messages consumed by the session.)
     * <P>
     * Messages that have been received but not acknowledged may be redelivered.
     *
     * @throws JMSException if the JMS provider fails to acknowledge the messages due to some internal error.
     * @throws javax.jms.IllegalStateException if this method is called on a closed session.
     * @see javax.jms.Session#CLIENT_ACKNOWLEDGE
     */
    public void acknowledge() throws JMSException {
        doAcknowledge(false);
    }

    protected void doAcknowledge(boolean isClosing) throws JMSException {
        checkClosed();
        if (this.acknowledgeMode == Session.CLIENT_ACKNOWLEDGE) {
            ActiveMQMessage msg = null;
            while ((msg = (ActiveMQMessage) deliveredMessages.removeFirst()) != null) {
                MessageAck ack = new MessageAck();
                ack.setConsumerId(msg.getConsumerId());
                ack.setMessageID(msg.getJMSMessageID());
                if (!isClosing) {
                    ack.setMessageRead(msg.isMessageConsumed());
                }
                ack.setId(packetIdGenerator.generateId());
                ack.setDestination(msg.getJMSActiveMQDestination());
                ack.setPersistent(msg.getJMSDeliveryMode() == DeliveryMode.PERSISTENT);
                this.connection.asyncSendPacket(ack, false);
            }
            deliveredMessages.clear();
        }
    }
   
    protected void beforeMessageDelivered(ActiveMQMessage message) {
        if (message != null && !closed.get()) {
            deliveredMessages.add(message);
        }
    }
   
    protected void afterMessageDelivered(boolean sendAcknowledge, ActiveMQMessage message, boolean messageConsumed, boolean messageExpired, boolean beforeCalled) {
        if (message != null && !closed.get()) {

            if ((isClientAcknowledge() && !messageExpired) || (isTransacted() && message.isTransientConsumed())) {
                message.setMessageConsumed(messageConsumed);
                if( !beforeCalled ) {
                    deliveredMessages.add(message);               
                }
            } else {
                if( beforeCalled ) {
                    deliveredMessages.remove(message);               
                }
            }

            //don't send acks for expired messages unless sendAcknowledge is set
            //the sendAcknowledge flag is set for all messages expect those destined
            //for transient Topic subscribers
            if (sendAcknowledge && !isClientAcknowledge()) {
                try {
                    doStartTransaction();
                    MessageAck ack = new MessageAck();
                    ack.setConsumerId(message.getConsumerId());
                    ack.setTransactionId(this.currentTransactionId);
                    ack.setMessageID(message.getJMSMessageID());
                    ack.setMessageRead(messageConsumed);
                    ack.setId(packetIdGenerator.generateId());
                    ack.setXaTransacted(isXaTransacted());
                    ack.setDestination(message.getJMSActiveMQDestination());
                    ack.setPersistent(message.getJMSDeliveryMode() == DeliveryMode.PERSISTENT);
                    ack.setExpired(messageExpired);
                    this.connection.asyncSendPacket(ack);
                }
                catch (JMSException e) {
                    log.warn("failed to notify Broker that message is delivered", e);
                }
            }
        }
    }

    /**
     * @param consumer
     * @throws JMSException
     */
    protected void addConsumer(ActiveMQMessageConsumer consumer) throws JMSException {
        // ensure that the connection info is sent to the broker
        connection.sendConnectionInfoToBroker();
        // lets add the stat
        if (consumer.isDurableSubscriber()) {
            stats.onCreateDurableSubscriber();
        }
        consumer.setConsumerId(consumerIdGenerator.generateId());
        ConsumerInfo info = createConsumerInfo(consumer);
        info.setStarted(true);
        //we add before notifying the server - as messages could
        //start to be dispatched before receipt from syncSend()
        //is returned
        this.consumers.add(consumer);
        try {
            this.connection.syncSendPacket(info);
        }
        catch (JMSException jmsEx) {
            this.consumers.remove(consumer);
            throw jmsEx;
        }
    }

    /**
     * @param consumer
     * @throws JMSException
     */
    protected void removeConsumer(ActiveMQMessageConsumer consumer) throws JMSException {
        this.consumers.remove(consumer);
        // lets remove the stat
        if (consumer.isDurableSubscriber()) {
            stats.onRemoveDurableSubscriber();
        }
        if (!closed.get()) {
            ConsumerInfo info = createConsumerInfo(consumer);
            info.setStarted(false);
            this.connection.asyncSendPacket(info, false);
        }
    }

    protected ConsumerInfo createConsumerInfo(ActiveMQMessageConsumer consumer) throws JMSException {
        ConsumerInfo info = new ConsumerInfo();
        info.setConsumerId(consumer.consumerId);
        info.setClientId(connection.clientID);
        info.setSessionId(this.sessionId);
        info.setConsumerNo(consumer.consumerNumber);
        info.setPrefetchNumber(consumer.prefetchNumber);
        info.setDestination(consumer.destination);
        info.setId(this.packetIdGenerator.generateId());
        info.setNoLocal(consumer.noLocal);
        info.setBrowser(consumer.browser);
        info.setSelector(consumer.messageSelector);
        info.setStartTime(consumer.startTime);
        info.setConsumerName(consumer.consumerName);
        return info;
    }

    /**
     * @param producer
     * @throws JMSException
     */
    protected void addProducer(ActiveMQMessageProducer producer) throws JMSException {
        // ensure that the connection info is sent to the broker
        connection.sendConnectionInfoToBroker();
        ProducerInfo info = createProducerInfo(producer);
        info.setStarted(true);
        this.connection.syncSendPacket(info);
        this.producers.add(producer);
    }

    /**
     * @param producer
     * @throws JMSException
     */
    protected void removeProducer(ActiveMQMessageProducer producer) throws JMSException {
        this.producers.remove(producer);
        if (!closed.get()) {
            ProducerInfo info = createProducerInfo(producer);
            info.setStarted(false);
            this.connection.asyncSendPacket(info, false);
        }
    }

    protected ProducerInfo createProducerInfo(ActiveMQMessageProducer producer) throws JMSException {
        ProducerInfo info = new ProducerInfo();
        info.setProducerId(producer.getProducerId());
        info.setClientId(connection.clientID);
        info.setSessionId(this.sessionId);
        info.setDestination(producer.defaultDestination);
        info.setId(this.packetIdGenerator.generateId());
        info.setStartTime(producer.getStartTime());
        return info;
    }

    /**
     * Start this Session
     */
    protected void start() {
        messageExecutor.start();
    }

    /**
     * Stop this Session
     */
    protected void stop() {
        messageExecutor.stop();
    }

    /**
     * @return Returns the sessionId.
     */
    protected String getSessionId() {
        return sessionId;
    }

    /**
     * @param sessionId The sessionId to set.
     */
    protected void setSessionId(String sessionId) {
        this.sessionId = sessionId;
    }

    /**
     * @return Returns the startTime.
     */
    protected long getStartTime() {
        return startTime;
    }

    /**
     * @param startTime The startTime to set.
     */
    protected void setStartTime(long startTime) {
        this.startTime = startTime;
    }

    /**
     * send the message for dispatch by the broker
     *
     * @param producer
     * @param destination
     * @param message
     * @param deliveryMode
     * @param priority
     * @param timeToLive
     * @throws JMSException
     */
    protected void send(ActiveMQMessageProducer producer, Destination destination, Message message, int deliveryMode,
            int priority, long timeToLive, boolean reuseMessageId) throws JMSException {
        checkClosed();
        // ensure that the connection info is sent to the broker
        connection.sendConnectionInfoToBroker();
        // tell the Broker we are about to start a new transaction
        doStartTransaction();
        message.setJMSDestination(destination);
        message.setJMSDeliveryMode(deliveryMode);
        message.setJMSPriority(priority);
        long expiration = 0L;
        if (!producer.getDisableMessageTimestamp()) {
            long timeStamp = System.currentTimeMillis();
            message.setJMSTimestamp(timeStamp);
            if (timeToLive > 0) {
                expiration = timeToLive + timeStamp;
            }
        }
        message.setJMSExpiration(expiration);
        String id = message.getJMSMessageID();
        String producerId = producer.getProducerId();
        long sequenceNumber = producer.getNextSequenceNumber();
        if ((id == null || id.length() == 0) || !producer.getDisableMessageID() && !reuseMessageId) {
            message.setJMSMessageID(producerId + sequenceNumber);
        }
        //transform to our own message format here
        ActiveMQMessage msg = ActiveMQMessageTransformation.transformMessage(message);
        msg.prepareMessageBody();
        msg.setProducerID(producerId);
        msg.setSequenceNumber(sequenceNumber);
        msg.setTransactionId(currentTransactionId);
        msg.setXaTransacted(isXaTransacted());
        msg.setJMSClientID(this.connection.clientID);
        msg.setJMSRedelivered(false);//could be forwarding this message on
        if (log.isDebugEnabled()) {
            log.debug("Sending message: " + msg);
        }
        // Should we use an async send?
        if (this.connection.isUseAsyncSend()) {
            this.connection.asyncSendPacket(msg);
        }
        else {
            this.connection.syncSendPacket(msg);
        }
    }

    /**
     * Send TransactionInfo to indicate transaction has started
     *
     * @throws JMSException if some internal error occurs
     */
    protected void doStartTransaction() throws JMSException {
        if (getTransacted()) {
            startLocalTransaction();
        }
    }

    /**
     * @throws JMSException
     */
    protected void startLocalTransaction() throws JMSException {
        if (startTransaction.commit(false, true)) {
            this.currentTransactionId = transactionIdGenerator.generateId();
            TransactionInfo info = new TransactionInfo();
            info.setId(this.packetIdGenerator.generateId());
            info.setTransactionId(currentTransactionId);
            info.setType(TransactionInfo.START);
            this.connection.asyncSendPacket(info);
            // Notify the listener that the tx was started.
            if (localTransactionEventListener != null) {
                localTransactionEventListener.beginEvent();
            }
        }
    }

    /**
     * @return Returns the localTransactionEventListener.
     */
    public LocalTransactionEventListener getLocalTransactionEventListener() {
        return localTransactionEventListener;
    }

    /**
     * Used by the resource adapter to listen to transaction events.
     *
     * @param localTransactionEventListener The localTransactionEventListener to set.
     */
    public void setLocalTransactionEventListener(LocalTransactionEventListener localTransactionEventListener) {
        this.localTransactionEventListener = localTransactionEventListener;
    }

    protected boolean isXaTransacted() {
        return false;
    }

    protected void setSessionConsumerDispatchState(int value) throws JMSException {
        if (consumerDispatchState != ActiveMQSession.CONSUMER_DISPATCH_UNSET && value != consumerDispatchState) {
            String errorStr = "Cannot mix consumer dispatching on a session - already: ";
            if (value == ActiveMQSession.CONSUMER_DISPATCH_SYNC) {
                errorStr += "synchronous";
            }
            else {
                errorStr += "asynchronous";
            }
            throw new IllegalStateException(errorStr);
        }
        consumerDispatchState = value;
    }

    protected void redeliverUnacknowledgedMessages() {
        redeliverUnacknowledgedMessages(false);
    }

    protected void redeliverUnacknowledgedMessages(boolean onlyDeliverTransientConsumed) {
        messageExecutor.stop();
        LinkedList replay = new LinkedList();
        Object obj = null;
        while ((obj = deliveredMessages.removeFirst()) != null) {
            replay.add(obj);
        }
        deliveredMessages.clear();
        if (!replay.isEmpty()) {
            for (ListIterator i = replay.listIterator(replay.size());i.hasPrevious();) {
                ActiveMQMessage msg = (ActiveMQMessage) i.previous();
                if (!onlyDeliverTransientConsumed || msg.isTransientConsumed()) {
                    msg.setJMSRedelivered(true);
                    msg.incrementDeliveryCount();
                    messageExecutor.executeFirst(msg);
                }
            }
        }
        replay.clear();
        messageExecutor.start();
    }

    protected void clearMessagesInProgress() {
        messageExecutor.clearMessagesInProgress();
        for (Iterator i = consumers.iterator();i.hasNext();) {
            ActiveMQMessageConsumer consumer = (ActiveMQMessageConsumer) i.next();
            consumer.clearMessagesInProgress();
        }
    }

    protected boolean isTransacted() {
        return this.acknowledgeMode == Session.SESSION_TRANSACTED;
    }

    protected boolean isClientAcknowledge() {
        return this.acknowledgeMode == Session.CLIENT_ACKNOWLEDGE;
    }
}
TOP

Related Classes of org.codehaus.activemq.ActiveMQSession

TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.