org.apache.qpid.server.queue
Class SimpleAMQQueue

java.lang.Object
  extended by org.apache.qpid.server.queue.SimpleAMQQueue
All Implemented Interfaces:
Comparable<AMQQueue>, ConfiguredObject<QueueConfigType,QueueConfig>, QueueConfig, ExchangeReferrer, Managable, AMQQueue, BaseQueue, TransactionLogResource, Subscription.StateListener
Direct Known Subclasses:
AMQPriorityQueue, ConflationQueue

public class SimpleAMQQueue
extends Object
implements AMQQueue, Subscription.StateListener


Nested Class Summary
static interface SimpleAMQQueue.QueueEntryFilter
           
 
Nested classes/interfaces inherited from interface org.apache.qpid.server.queue.AMQQueue
AMQQueue.Context, AMQQueue.ExistingExclusiveSubscription, AMQQueue.ExistingSubscriptionPreventsExclusive, AMQQueue.Task
 
Nested classes/interfaces inherited from interface org.apache.qpid.server.queue.BaseQueue
BaseQueue.PostEnqueueAction
 
Field Summary
protected  QueueEntryList _entries
          Used to track bindings to exchanges so that on deletion they can easily be cancelled.
 long _maximumMessageAge
          maximum message age before alerts occur
 long _maximumMessageCount
          max allowed number of messages on a queue.
 long _maximumMessageSize
          max allowed size(KB) of a single message
 long _maximumQueueDepth
          max queue depth for the queue
 long _minimumAlertRepeatGap
          the minimum interval between sending out consecutive alerts of the same type
protected  SubscriptionList _subscriptionList
           
(package private) static int MAX_ASYNC_DELIVERIES
           
 
Constructor Summary
protected SimpleAMQQueue(org.apache.qpid.framing.AMQShortString name, boolean durable, org.apache.qpid.framing.AMQShortString owner, boolean autoDelete, boolean exclusive, VirtualHost virtualHost, Map<String,Object> arguments)
           
protected SimpleAMQQueue(org.apache.qpid.framing.AMQShortString name, boolean durable, org.apache.qpid.framing.AMQShortString owner, boolean autoDelete, boolean exclusive, VirtualHost virtualHost, QueueEntryListFactory entryListFactory, Map<String,Object> arguments)
           
  SimpleAMQQueue(String queueName, boolean durable, String owner, boolean autoDelete, boolean exclusive, VirtualHost virtualHost, Map<String,Object> arguments)
           
  SimpleAMQQueue(String queueName, boolean durable, String owner, boolean autoDelete, boolean exclusive, VirtualHost virtualHost, QueueEntryListFactory entryListFactory, Map<String,Object> arguments)
           
 
Method Summary
 void addBinding(Binding binding)
           
 void addQueueDeleteTask(AMQQueue.Task task)
           
protected  void advanceAllSubscriptions()
           
 void checkCapacity(AMQChannel channel)
           
 void checkMessageStatus()
          Checks the status of messages on the queue, purging expired ones, firing age related alerts etc.
protected  void checkSubscriptionsNotAheadOfDelivery(QueueEntry entry)
           
 long clearQueue()
           
 int compareTo(AMQQueue o)
           
 void configure(ConfigurationPlugin config)
           
 void copyMessagesToAnotherQueue(long fromMessageId, long toMessageId, String queueName, ServerTransaction txn)
           
(package private)  void decrementQueueCount()
           
 void decrementUnackedMsgCount()
           
 int delete()
           
 void deleteMessageFromTop()
           
 void deliverAsync()
           
 void deliverAsync(Subscription sub)
           
 void dequeue(QueueEntry entry, Subscription sub)
           
 void enqueue(ServerMessage message)
           
 void enqueue(ServerMessage message, BaseQueue.PostEnqueueAction action)
           
 void execute(org.apache.qpid.pool.ReadWriteRunnable runnable)
           
 void flushSubscription(Subscription sub)
           
 boolean flushSubscription(Subscription sub, long iterations)
           
 int getActiveConsumerCount()
           
 Exchange getAlternateExchange()
           
 Map<String,Object> getArguments()
           
 AtomicInteger getAtomicQueueCount()
           
 AtomicLong getAtomicQueueSize()
           
 int getBindingCount()
           
 int getBindingCountHigh()
           
 List<Binding> getBindings()
           
 long getByteTxnDequeues()
           
 long getByteTxnEnqueues()
           
 long getCapacity()
           
 ConfigStore getConfigStore()
           
 QueueConfigType getConfigType()
           
 ConfigurationPlugin getConfiguration()
           
 int getConsumerCount()
           
 int getConsumerCountHigh()
           
 long getCreateTime()
           
 boolean getDeleteOnNoConsumers()
           
 AMQSessionModel getExclusiveOwningSession()
           
 long getFlowResumeCapacity()
           
 UUID getId()
           
 LogSubject getLogSubject()
           
 ManagedObject getManagedObject()
           
 long getMaximumMessageAge()
           
 long getMaximumMessageCount()
           
 long getMaximumMessageSize()
           
 long getMaximumQueueDepth()
           
 int getMessageCount()
           
 long getMessageDequeueCount()
           
 QueueEntry getMessageOnTheQueue(long messageId)
           
 List<QueueEntry> getMessagesOnTheQueue()
           
 List<Long> getMessagesOnTheQueue(int num)
           
 List<Long> getMessagesOnTheQueue(int num, int offset)
           
 List<QueueEntry> getMessagesOnTheQueue(long fromMessageId, long toMessageId)
           
 List<QueueEntry> getMessagesOnTheQueue(SimpleAMQQueue.QueueEntryFilter filter)
           
 List<QueueEntry> getMessagesRangeOnTheQueue(long fromPosition, long toPosition)
          Returns a list of QueEntries from a given range of queue positions, eg messages 5 to 10 on the queue.
 long getMinimumAlertRepeatGap()
           
 long getMsgTxnDequeues()
           
 long getMsgTxnEnqueues()
           
 String getName()
           
 org.apache.qpid.framing.AMQShortString getNameShortString()
           
 Set<NotificationCheck> getNotificationChecks()
           
 long getOldestMessageArrivalTime()
           
protected  QueueEntry getOldestQueueEntry()
           
 org.apache.qpid.framing.AMQShortString getOwner()
           
 ConfiguredObject getParent()
           
 long getPersistentByteDequeues()
           
 long getPersistentByteEnqueues()
           
 long getPersistentMsgDequeues()
           
 long getPersistentMsgEnqueues()
           
 PrincipalHolder getPrincipalHolder()
           
 long getQueueDepth()
           
 long getReceivedMessageCount()
           
 String getResourceName()
           
 long getTotalDequeueSize()
           
 long getTotalEnqueueSize()
           
 long getUnackedMessageCount()
           
 long getUnackedMessageCountHigh()
           
 int getUndeliveredMessageCount()
           
 VirtualHost getVirtualHost()
           
 boolean hasExclusiveSubscriber()
           
 boolean isAutoDelete()
           
 boolean isDeleted()
           
 boolean isDurable()
           
 boolean isEmpty()
           
 boolean isExclusive()
           
 boolean isOverfull()
           
 boolean isUnused()
           
 void moveMessagesToAnotherQueue(long fromMessageId, long toMessageId, String queueName, ServerTransaction txn)
           
 void purge(long request)
           
 void registerSubscription(Subscription subscription, boolean exclusive)
           
 void removeBinding(Binding binding)
           
 void removeMessagesFromQueue(long fromMessageId, long toMessageId)
           
 void removeQueueDeleteTask(AMQQueue.Task task)
           
 void requeue(QueueEntry entry)
           
 void requeue(QueueEntryImpl entry, Subscription subscription)
           
 boolean resend(QueueEntry entry, Subscription subscription)
           
 void resetNotifications()
           
 void setAlternateExchange(Exchange exchange)
           
 void setCapacity(long capacity)
           
 void setDeleteOnNoConsumers(boolean b)
           
 void setExclusive(boolean exclusive)
           
 void setExclusiveOwningSession(AMQSessionModel exclusiveOwner)
           
 void setFlowResumeCapacity(long flowResumeCapacity)
           
 void setMaximumMessageAge(long maximumMessageAge)
           
 void setMaximumMessageCount(long maximumMessageCount)
           
 void setMaximumMessageSize(long maximumMessageSize)
           
 void setMaximumQueueDepth(long maximumQueueDepth)
           
 void setMinimumAlertRepeatGap(long minimumAlertRepeatGap)
           
 void setNoLocal(boolean nolocal)
           
 void setPrincipalHolder(PrincipalHolder prinicpalHolder)
           
 void stateChange(Subscription sub, Subscription.State oldState, Subscription.State newState)
           
 void stop()
           
 String toString()
           
 void unregisterSubscription(Subscription subscription)
           
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
 

Field Detail

_entries

protected final QueueEntryList _entries
Used to track bindings to exchanges so that on deletion they can easily be cancelled.


_subscriptionList

protected final SubscriptionList _subscriptionList

_maximumMessageSize

public long _maximumMessageSize
max allowed size(KB) of a single message


_maximumMessageCount

public long _maximumMessageCount
max allowed number of messages on a queue.


_maximumQueueDepth

public long _maximumQueueDepth
max queue depth for the queue


_maximumMessageAge

public long _maximumMessageAge
maximum message age before alerts occur


_minimumAlertRepeatGap

public long _minimumAlertRepeatGap
the minimum interval between sending out consecutive alerts of the same type


MAX_ASYNC_DELIVERIES

static final int MAX_ASYNC_DELIVERIES
See Also:
Constant Field Values
Constructor Detail

SimpleAMQQueue

protected SimpleAMQQueue(org.apache.qpid.framing.AMQShortString name,
                         boolean durable,
                         org.apache.qpid.framing.AMQShortString owner,
                         boolean autoDelete,
                         boolean exclusive,
                         VirtualHost virtualHost,
                         Map<String,Object> arguments)

SimpleAMQQueue

public SimpleAMQQueue(String queueName,
                      boolean durable,
                      String owner,
                      boolean autoDelete,
                      boolean exclusive,
                      VirtualHost virtualHost,
                      Map<String,Object> arguments)

SimpleAMQQueue

public SimpleAMQQueue(String queueName,
                      boolean durable,
                      String owner,
                      boolean autoDelete,
                      boolean exclusive,
                      VirtualHost virtualHost,
                      QueueEntryListFactory entryListFactory,
                      Map<String,Object> arguments)

SimpleAMQQueue

protected SimpleAMQQueue(org.apache.qpid.framing.AMQShortString name,
                         boolean durable,
                         org.apache.qpid.framing.AMQShortString owner,
                         boolean autoDelete,
                         boolean exclusive,
                         VirtualHost virtualHost,
                         QueueEntryListFactory entryListFactory,
                         Map<String,Object> arguments)
Method Detail

resetNotifications

public void resetNotifications()

execute

public void execute(org.apache.qpid.pool.ReadWriteRunnable runnable)

getNameShortString

public org.apache.qpid.framing.AMQShortString getNameShortString()
Specified by:
getNameShortString in interface BaseQueue

setNoLocal

public void setNoLocal(boolean nolocal)
Specified by:
setNoLocal in interface AMQQueue

getId

public UUID getId()
Specified by:
getId in interface ConfiguredObject<QueueConfigType,QueueConfig>

getConfigType

public QueueConfigType getConfigType()
Specified by:
getConfigType in interface ConfiguredObject<QueueConfigType,QueueConfig>

getParent

public ConfiguredObject getParent()
Specified by:
getParent in interface ConfiguredObject<QueueConfigType,QueueConfig>

isDurable

public boolean isDurable()
Specified by:
isDurable in interface ConfiguredObject<QueueConfigType,QueueConfig>
Specified by:
isDurable in interface BaseQueue

isExclusive

public boolean isExclusive()
Specified by:
isExclusive in interface QueueConfig
Specified by:
isExclusive in interface AMQQueue

setExclusive

public void setExclusive(boolean exclusive)
                  throws org.apache.qpid.AMQException
Specified by:
setExclusive in interface AMQQueue
Throws:
org.apache.qpid.AMQException

getAlternateExchange

public Exchange getAlternateExchange()
Specified by:
getAlternateExchange in interface QueueConfig
Specified by:
getAlternateExchange in interface AMQQueue

setAlternateExchange

public void setAlternateExchange(Exchange exchange)
Specified by:
setAlternateExchange in interface AMQQueue

getArguments

public Map<String,Object> getArguments()
Specified by:
getArguments in interface QueueConfig
Specified by:
getArguments in interface AMQQueue

isAutoDelete

public boolean isAutoDelete()
Specified by:
isAutoDelete in interface QueueConfig
Specified by:
isAutoDelete in interface AMQQueue

getOwner

public org.apache.qpid.framing.AMQShortString getOwner()
Specified by:
getOwner in interface AMQQueue

getPrincipalHolder

public PrincipalHolder getPrincipalHolder()
Specified by:
getPrincipalHolder in interface AMQQueue

setPrincipalHolder

public void setPrincipalHolder(PrincipalHolder prinicpalHolder)
Specified by:
setPrincipalHolder in interface AMQQueue

getVirtualHost

public VirtualHost getVirtualHost()
Specified by:
getVirtualHost in interface QueueConfig
Specified by:
getVirtualHost in interface AMQQueue

getName

public String getName()
Specified by:
getName in interface QueueConfig

registerSubscription

public void registerSubscription(Subscription subscription,
                                 boolean exclusive)
                          throws org.apache.qpid.AMQSecurityException,
                                 AMQQueue.ExistingExclusiveSubscription,
                                 AMQQueue.ExistingSubscriptionPreventsExclusive
Specified by:
registerSubscription in interface AMQQueue
Throws:
org.apache.qpid.AMQSecurityException
AMQQueue.ExistingExclusiveSubscription
AMQQueue.ExistingSubscriptionPreventsExclusive

unregisterSubscription

public void unregisterSubscription(Subscription subscription)
                            throws org.apache.qpid.AMQException
Specified by:
unregisterSubscription in interface AMQQueue
Throws:
org.apache.qpid.AMQException

getDeleteOnNoConsumers

public boolean getDeleteOnNoConsumers()
Specified by:
getDeleteOnNoConsumers in interface AMQQueue

setDeleteOnNoConsumers

public void setDeleteOnNoConsumers(boolean b)
Specified by:
setDeleteOnNoConsumers in interface AMQQueue

addBinding

public void addBinding(Binding binding)
Specified by:
addBinding in interface AMQQueue

getBindingCountHigh

public int getBindingCountHigh()
Specified by:
getBindingCountHigh in interface QueueConfig

removeBinding

public void removeBinding(Binding binding)
Specified by:
removeBinding in interface AMQQueue

getBindings

public List<Binding> getBindings()
Specified by:
getBindings in interface AMQQueue

getBindingCount

public int getBindingCount()
Specified by:
getBindingCount in interface QueueConfig
Specified by:
getBindingCount in interface AMQQueue

getLogSubject

public LogSubject getLogSubject()
Specified by:
getLogSubject in interface AMQQueue

enqueue

public void enqueue(ServerMessage message)
             throws org.apache.qpid.AMQException
Specified by:
enqueue in interface BaseQueue
Throws:
org.apache.qpid.AMQException

enqueue

public void enqueue(ServerMessage message,
                    BaseQueue.PostEnqueueAction action)
             throws org.apache.qpid.AMQException
Specified by:
enqueue in interface BaseQueue
Throws:
org.apache.qpid.AMQException

checkSubscriptionsNotAheadOfDelivery

protected void checkSubscriptionsNotAheadOfDelivery(QueueEntry entry)

requeue

public void requeue(QueueEntry entry)
Specified by:
requeue in interface AMQQueue

requeue

public void requeue(QueueEntryImpl entry,
                    Subscription subscription)
Specified by:
requeue in interface AMQQueue

dequeue

public void dequeue(QueueEntry entry,
                    Subscription sub)
Specified by:
dequeue in interface AMQQueue

decrementQueueCount

void decrementQueueCount()

resend

public boolean resend(QueueEntry entry,
                      Subscription subscription)
               throws org.apache.qpid.AMQException
Specified by:
resend in interface AMQQueue
Throws:
org.apache.qpid.AMQException

getConsumerCount

public int getConsumerCount()
Specified by:
getConsumerCount in interface QueueConfig
Specified by:
getConsumerCount in interface AMQQueue

getConsumerCountHigh

public int getConsumerCountHigh()
Specified by:
getConsumerCountHigh in interface QueueConfig

getActiveConsumerCount

public int getActiveConsumerCount()
Specified by:
getActiveConsumerCount in interface AMQQueue

isUnused

public boolean isUnused()
Specified by:
isUnused in interface AMQQueue

isEmpty

public boolean isEmpty()
Specified by:
isEmpty in interface AMQQueue

getMessageCount

public int getMessageCount()
Specified by:
getMessageCount in interface QueueConfig
Specified by:
getMessageCount in interface AMQQueue

getQueueDepth

public long getQueueDepth()
Specified by:
getQueueDepth in interface QueueConfig
Specified by:
getQueueDepth in interface AMQQueue

getUndeliveredMessageCount

public int getUndeliveredMessageCount()
Specified by:
getUndeliveredMessageCount in interface AMQQueue

getReceivedMessageCount

public long getReceivedMessageCount()
Specified by:
getReceivedMessageCount in interface QueueConfig
Specified by:
getReceivedMessageCount in interface AMQQueue

getOldestMessageArrivalTime

public long getOldestMessageArrivalTime()
Specified by:
getOldestMessageArrivalTime in interface AMQQueue

getOldestQueueEntry

protected QueueEntry getOldestQueueEntry()

isDeleted

public boolean isDeleted()
Specified by:
isDeleted in interface AMQQueue

getMessagesOnTheQueue

public List<QueueEntry> getMessagesOnTheQueue()
Specified by:
getMessagesOnTheQueue in interface AMQQueue

stateChange

public void stateChange(Subscription sub,
                        Subscription.State oldState,
                        Subscription.State newState)
Specified by:
stateChange in interface Subscription.StateListener

compareTo

public int compareTo(AMQQueue o)
Specified by:
compareTo in interface Comparable<AMQQueue>

getAtomicQueueCount

public AtomicInteger getAtomicQueueCount()

getAtomicQueueSize

public AtomicLong getAtomicQueueSize()

hasExclusiveSubscriber

public boolean hasExclusiveSubscriber()
Specified by:
hasExclusiveSubscriber in interface AMQQueue

getMessagesOnTheQueue

public List<QueueEntry> getMessagesOnTheQueue(long fromMessageId,
                                              long toMessageId)
Specified by:
getMessagesOnTheQueue in interface AMQQueue

getMessageOnTheQueue

public QueueEntry getMessageOnTheQueue(long messageId)
Specified by:
getMessageOnTheQueue in interface AMQQueue

getMessagesOnTheQueue

public List<QueueEntry> getMessagesOnTheQueue(SimpleAMQQueue.QueueEntryFilter filter)

getMessagesRangeOnTheQueue

public List<QueueEntry> getMessagesRangeOnTheQueue(long fromPosition,
                                                   long toPosition)
Returns a list of QueEntries from a given range of queue positions, eg messages 5 to 10 on the queue. The 'queue position' index starts from 1. Using 0 in 'from' will be ignored and continue from 1. Using 0 in the 'to' field will return an empty list regardless of the 'from' value.

Specified by:
getMessagesRangeOnTheQueue in interface AMQQueue
Parameters:
fromPosition -
toPosition -
Returns:

moveMessagesToAnotherQueue

public void moveMessagesToAnotherQueue(long fromMessageId,
                                       long toMessageId,
                                       String queueName,
                                       ServerTransaction txn)
                                throws IllegalArgumentException
Specified by:
moveMessagesToAnotherQueue in interface AMQQueue
Throws:
IllegalArgumentException

copyMessagesToAnotherQueue

public void copyMessagesToAnotherQueue(long fromMessageId,
                                       long toMessageId,
                                       String queueName,
                                       ServerTransaction txn)
                                throws IllegalArgumentException
Specified by:
copyMessagesToAnotherQueue in interface AMQQueue
Throws:
IllegalArgumentException

removeMessagesFromQueue

public void removeMessagesFromQueue(long fromMessageId,
                                    long toMessageId)
Specified by:
removeMessagesFromQueue in interface AMQQueue

purge

public void purge(long request)
           throws org.apache.qpid.AMQException
Specified by:
purge in interface QueueConfig
Throws:
org.apache.qpid.AMQException

getCreateTime

public long getCreateTime()
Specified by:
getCreateTime in interface ConfiguredObject<QueueConfigType,QueueConfig>

deleteMessageFromTop

public void deleteMessageFromTop()
Specified by:
deleteMessageFromTop in interface AMQQueue

clearQueue

public long clearQueue()
                throws org.apache.qpid.AMQException
Specified by:
clearQueue in interface AMQQueue
Throws:
org.apache.qpid.AMQException

addQueueDeleteTask

public void addQueueDeleteTask(AMQQueue.Task task)
Specified by:
addQueueDeleteTask in interface AMQQueue

removeQueueDeleteTask

public void removeQueueDeleteTask(AMQQueue.Task task)
Specified by:
removeQueueDeleteTask in interface AMQQueue

delete

public int delete()
           throws org.apache.qpid.AMQSecurityException,
                  org.apache.qpid.AMQException
Specified by:
delete in interface AMQQueue
Throws:
org.apache.qpid.AMQSecurityException
org.apache.qpid.AMQException

stop

public void stop()
Specified by:
stop in interface AMQQueue

checkCapacity

public void checkCapacity(AMQChannel channel)
Specified by:
checkCapacity in interface AMQQueue

deliverAsync

public void deliverAsync()
Specified by:
deliverAsync in interface AMQQueue

deliverAsync

public void deliverAsync(Subscription sub)
Specified by:
deliverAsync in interface AMQQueue

flushSubscription

public void flushSubscription(Subscription sub)
                       throws org.apache.qpid.AMQException
Specified by:
flushSubscription in interface AMQQueue
Throws:
org.apache.qpid.AMQException

flushSubscription

public boolean flushSubscription(Subscription sub,
                                 long iterations)
                          throws org.apache.qpid.AMQException
Throws:
org.apache.qpid.AMQException

advanceAllSubscriptions

protected void advanceAllSubscriptions()
                                throws org.apache.qpid.AMQException
Throws:
org.apache.qpid.AMQException

checkMessageStatus

public void checkMessageStatus()
                        throws org.apache.qpid.AMQException
Description copied from interface: AMQQueue
Checks the status of messages on the queue, purging expired ones, firing age related alerts etc.

Specified by:
checkMessageStatus in interface AMQQueue
Throws:
org.apache.qpid.AMQException

getMinimumAlertRepeatGap

public long getMinimumAlertRepeatGap()
Specified by:
getMinimumAlertRepeatGap in interface AMQQueue

setMinimumAlertRepeatGap

public void setMinimumAlertRepeatGap(long minimumAlertRepeatGap)
Specified by:
setMinimumAlertRepeatGap in interface AMQQueue

getMaximumMessageAge

public long getMaximumMessageAge()
Specified by:
getMaximumMessageAge in interface AMQQueue

setMaximumMessageAge

public void setMaximumMessageAge(long maximumMessageAge)
Specified by:
setMaximumMessageAge in interface AMQQueue

getMaximumMessageCount

public long getMaximumMessageCount()
Specified by:
getMaximumMessageCount in interface AMQQueue

setMaximumMessageCount

public void setMaximumMessageCount(long maximumMessageCount)
Specified by:
setMaximumMessageCount in interface AMQQueue

getMaximumQueueDepth

public long getMaximumQueueDepth()
Specified by:
getMaximumQueueDepth in interface AMQQueue

setMaximumQueueDepth

public void setMaximumQueueDepth(long maximumQueueDepth)
Specified by:
setMaximumQueueDepth in interface AMQQueue

getMaximumMessageSize

public long getMaximumMessageSize()
Specified by:
getMaximumMessageSize in interface AMQQueue

setMaximumMessageSize

public void setMaximumMessageSize(long maximumMessageSize)
Specified by:
setMaximumMessageSize in interface AMQQueue

getCapacity

public long getCapacity()
Specified by:
getCapacity in interface AMQQueue

setCapacity

public void setCapacity(long capacity)
Specified by:
setCapacity in interface AMQQueue

getFlowResumeCapacity

public long getFlowResumeCapacity()
Specified by:
getFlowResumeCapacity in interface AMQQueue

setFlowResumeCapacity

public void setFlowResumeCapacity(long flowResumeCapacity)
Specified by:
setFlowResumeCapacity in interface AMQQueue

isOverfull

public boolean isOverfull()
Specified by:
isOverfull in interface AMQQueue

getNotificationChecks

public Set<NotificationCheck> getNotificationChecks()
Specified by:
getNotificationChecks in interface AMQQueue

getManagedObject

public ManagedObject getManagedObject()
Specified by:
getManagedObject in interface Managable
Specified by:
getManagedObject in interface AMQQueue

getMessagesOnTheQueue

public List<Long> getMessagesOnTheQueue(int num)
Specified by:
getMessagesOnTheQueue in interface AMQQueue

getMessagesOnTheQueue

public List<Long> getMessagesOnTheQueue(int num,
                                        int offset)
Specified by:
getMessagesOnTheQueue in interface AMQQueue

getExclusiveOwningSession

public AMQSessionModel getExclusiveOwningSession()
Specified by:
getExclusiveOwningSession in interface AMQQueue

setExclusiveOwningSession

public void setExclusiveOwningSession(AMQSessionModel exclusiveOwner)
Specified by:
setExclusiveOwningSession in interface AMQQueue

configure

public void configure(ConfigurationPlugin config)
Specified by:
configure in interface AMQQueue

getConfiguration

public ConfigurationPlugin getConfiguration()
Specified by:
getConfiguration in interface AMQQueue

getResourceName

public String getResourceName()
Specified by:
getResourceName in interface TransactionLogResource

getConfigStore

public ConfigStore getConfigStore()
Specified by:
getConfigStore in interface QueueConfig

getMessageDequeueCount

public long getMessageDequeueCount()
Specified by:
getMessageDequeueCount in interface QueueConfig

getTotalEnqueueSize

public long getTotalEnqueueSize()
Specified by:
getTotalEnqueueSize in interface QueueConfig

getTotalDequeueSize

public long getTotalDequeueSize()
Specified by:
getTotalDequeueSize in interface QueueConfig

getByteTxnEnqueues

public long getByteTxnEnqueues()
Specified by:
getByteTxnEnqueues in interface QueueConfig

getByteTxnDequeues

public long getByteTxnDequeues()
Specified by:
getByteTxnDequeues in interface QueueConfig

getMsgTxnEnqueues

public long getMsgTxnEnqueues()
Specified by:
getMsgTxnEnqueues in interface QueueConfig

getMsgTxnDequeues

public long getMsgTxnDequeues()
Specified by:
getMsgTxnDequeues in interface QueueConfig

getPersistentByteEnqueues

public long getPersistentByteEnqueues()
Specified by:
getPersistentByteEnqueues in interface QueueConfig

getPersistentByteDequeues

public long getPersistentByteDequeues()
Specified by:
getPersistentByteDequeues in interface QueueConfig

getPersistentMsgEnqueues

public long getPersistentMsgEnqueues()
Specified by:
getPersistentMsgEnqueues in interface QueueConfig

getPersistentMsgDequeues

public long getPersistentMsgDequeues()
Specified by:
getPersistentMsgDequeues in interface QueueConfig

toString

public String toString()
Overrides:
toString in class Object

getUnackedMessageCountHigh

public long getUnackedMessageCountHigh()
Specified by:
getUnackedMessageCountHigh in interface QueueConfig

getUnackedMessageCount

public long getUnackedMessageCount()
Specified by:
getUnackedMessageCount in interface QueueConfig

decrementUnackedMsgCount

public void decrementUnackedMsgCount()
Specified by:
decrementUnackedMsgCount in interface AMQQueue


Licensed to the Apache Software Foundation