public class QueueImpl extends CriticalComponentImpl implements Queue
Completely non blocking between adding to queue and delivering to consumers.
Modifier and Type | Class and Description |
---|---|
protected static class |
QueueImpl.ConsumerHolder<T extends Consumer> |
Modifier and Type | Field and Description |
---|---|
static int |
CHECK_QUEUE_SIZE_PERIOD |
protected static int |
CRITICAL_CHECK_DEPAGE |
protected static int |
CRITICAL_CONSUMER |
protected static int |
CRITICAL_DELIVER |
protected static int |
CRITICAL_PATH_ADD_HEAD |
protected static int |
CRITICAL_PATH_ADD_TAIL |
protected static int |
CRITICAL_PATHS |
static int |
DEFAULT_FLUSH_LIMIT |
static int |
DELIVERY_TIMEOUT
If The system gets slow for any reason, this is the maximum time a Delivery or
or depage executor should be hanging on
|
int |
dispatching |
long |
dispatchStartTime |
static int |
MAX_DELIVERIES_IN_LOOP |
static int |
NUM_PRIORITIES |
static int |
REDISTRIBUTOR_BATCH_SIZE |
protected ScheduledDeliveryHandler |
scheduledDeliveryHandler |
MAX_CONSUMERS_UNLIMITED
Constructor and Description |
---|
QueueImpl(long id,
SimpleString address,
SimpleString name,
Filter filter,
PageSubscription pageSubscription,
SimpleString user,
boolean durable,
boolean temporary,
boolean autoCreated,
RoutingType routingType,
Integer maxConsumers,
Boolean exclusive,
Boolean groupRebalance,
Integer groupBuckets,
Boolean nonDestructive,
Integer consumersBeforeDispatch,
Long delayBeforeDispatch,
Boolean purgeOnNoConsumers,
Boolean autoDelete,
Long autoDeleteDelay,
Long autoDeleteMessageCount,
boolean configurationManaged,
ScheduledExecutorService scheduledExecutor,
PostOffice postOffice,
StorageManager storageManager,
HierarchicalRepository<AddressSettings> addressSettingsRepository,
ArtemisExecutor executor,
ActiveMQServer server,
QueueFactory factory) |
QueueImpl(long id,
SimpleString address,
SimpleString name,
Filter filter,
PageSubscription pageSubscription,
SimpleString user,
boolean durable,
boolean temporary,
boolean autoCreated,
RoutingType routingType,
Integer maxConsumers,
Boolean exclusive,
Boolean groupRebalance,
Integer groupBuckets,
SimpleString groupFirstKey,
Boolean nonDestructive,
Integer consumersBeforeDispatch,
Long delayBeforeDispatch,
Boolean purgeOnNoConsumers,
Boolean autoDelete,
Long autoDeleteDelay,
Long autoDeleteMessageCount,
boolean configurationManaged,
ScheduledExecutorService scheduledExecutor,
PostOffice postOffice,
StorageManager storageManager,
HierarchicalRepository<AddressSettings> addressSettingsRepository,
ArtemisExecutor executor,
ActiveMQServer server,
QueueFactory factory) |
QueueImpl(long id,
SimpleString address,
SimpleString name,
Filter filter,
PageSubscription pageSubscription,
SimpleString user,
boolean durable,
boolean temporary,
boolean autoCreated,
RoutingType routingType,
Integer maxConsumers,
Boolean exclusive,
Boolean purgeOnNoConsumers,
ScheduledExecutorService scheduledExecutor,
PostOffice postOffice,
StorageManager storageManager,
HierarchicalRepository<AddressSettings> addressSettingsRepository,
ArtemisExecutor executor,
ActiveMQServer server,
QueueFactory factory) |
QueueImpl(long id,
SimpleString address,
SimpleString name,
Filter filter,
PageSubscription pageSubscription,
SimpleString user,
boolean durable,
boolean temporary,
boolean autoCreated,
RoutingType routingType,
Integer maxConsumers,
Boolean purgeOnNoConsumers,
ScheduledExecutorService scheduledExecutor,
PostOffice postOffice,
StorageManager storageManager,
HierarchicalRepository<AddressSettings> addressSettingsRepository,
ArtemisExecutor executor,
ActiveMQServer server,
QueueFactory factory) |
QueueImpl(long id,
SimpleString address,
SimpleString name,
Filter filter,
PageSubscription pageSubscription,
SimpleString user,
boolean durable,
boolean temporary,
boolean autoCreated,
ScheduledExecutorService scheduledExecutor,
PostOffice postOffice,
StorageManager storageManager,
HierarchicalRepository<AddressSettings> addressSettingsRepository,
ArtemisExecutor executor,
ActiveMQServer server,
QueueFactory factory) |
QueueImpl(long id,
SimpleString address,
SimpleString name,
Filter filter,
SimpleString user,
boolean durable,
boolean temporary,
boolean autoCreated,
ScheduledExecutorService scheduledExecutor,
PostOffice postOffice,
StorageManager storageManager,
HierarchicalRepository<AddressSettings> addressSettingsRepository,
ArtemisExecutor executor,
ActiveMQServer server,
QueueFactory factory) |
Modifier and Type | Method and Description |
---|---|
void |
acknowledge(MessageReference ref) |
void |
acknowledge(MessageReference ref,
AckReason reason,
ServerConsumer consumer) |
void |
acknowledge(MessageReference ref,
ServerConsumer consumer) |
void |
acknowledge(Transaction tx,
MessageReference ref) |
void |
acknowledge(Transaction tx,
MessageReference ref,
AckReason reason,
ServerConsumer consumer) |
void |
addConsumer(Consumer consumer) |
void |
addHead(List<MessageReference> refs,
boolean scheduling) |
void |
addHead(MessageReference ref,
boolean scheduling) |
void |
addRedistributor(long delay) |
void |
addTail(MessageReference ref) |
void |
addTail(MessageReference ref,
boolean direct) |
boolean |
allowsReferenceCallback()
the current queue and consumer settings will allow use of the Reference Execution and callback.
|
org.apache.activemq.artemis.core.server.impl.QueueImpl.QueueBrowserIterator |
browserIterator() |
void |
cancel(MessageReference reference,
long timeBase) |
void |
cancel(Transaction tx,
MessageReference reference) |
void |
cancel(Transaction tx,
MessageReference reference,
boolean ignoreRedeliveryCheck) |
void |
cancelRedistributor() |
boolean |
changeReferencePriority(long messageID,
byte newPriority) |
int |
changeReferencesPriority(Filter filter,
byte newPriority) |
Pair<Boolean,Boolean> |
checkRedelivery(MessageReference reference,
long timeBase,
boolean ignoreRedeliveryDelay) |
void |
close() |
String |
debug() |
void |
decDelivering(MessageReference reference) |
int |
deleteAllReferences() |
int |
deleteAllReferences(int flushLimit) |
int |
deleteMatchingReferences(Filter filter) |
int |
deleteMatchingReferences(int flushLimit,
Filter filter1,
AckReason ackReason) |
void |
deleteQueue() |
void |
deleteQueue(boolean removeConsumers) |
boolean |
deleteReference(long messageID) |
void |
deliverAsync() |
void |
deliverNow() |
void |
deliverScheduledMessages()
cancels scheduled messages and send them to the head of the queue.
|
void |
destroyPaging() |
boolean |
equals(Object other) |
void |
errorProcessing(Consumer consumer,
Throwable t,
MessageReference reference)
This will print errors and decide what to do with the errored consumer from the protocol layer.
|
void |
expire(MessageReference ref) |
void |
expire(MessageReference ref,
ServerConsumer consumer) |
boolean |
expireReference(long messageID) |
void |
expireReferences() |
int |
expireReferences(Filter filter)
Expire all the references in the queue which matches the filter
|
protected void |
finalize() |
boolean |
flushExecutor() |
void |
forceDelivery()
This method will make sure that any pending message (including paged message) will be delivered
|
long |
getAcknowledgeAttempts() |
SimpleString |
getAddress() |
long |
getAutoDeleteDelay() |
long |
getAutoDeleteMessageCount() |
int |
getConsumerCount() |
long |
getConsumerRemovedTimestamp() |
Set<Consumer> |
getConsumers() |
int |
getConsumersBeforeDispatch() |
ReferenceCounter |
getConsumersRefCount() |
long |
getDelayBeforeDispatch() |
int |
getDeliveringCount() |
Map<String,List<MessageReference>> |
getDeliveringMessages()
Return a Map consisting of consumer.toString and its messages
Delivering message is a property of the consumer, this method will aggregate the results per Server's consumer object
|
long |
getDeliveringSize() |
long |
getDispatchStartTime() |
int |
getDurableDeliveringCount() |
long |
getDurableDeliveringSize() |
long |
getDurableMessageCount()
This is the number of the durable messages in the queue
|
long |
getDurablePersistentSize()
This is the persistent size of all the durable messages in the queue
|
int |
getDurableScheduledCount() |
long |
getDurableScheduledSize() |
ArtemisExecutor |
getExecutor() |
SimpleString |
getExpiryAddress() |
Filter |
getFilter() |
int |
getGroupBuckets() |
int |
getGroupCount() |
SimpleString |
getGroupFirstKey() |
Map<SimpleString,Consumer> |
getGroups() |
long |
getID() |
SimpleString |
getLastValueKey() |
int |
getMaxConsumers() |
long |
getMessageCount() |
long |
getMessagesAcknowledged() |
long |
getMessagesAdded() |
long |
getMessagesExpired() |
long |
getMessagesKilled() |
SimpleString |
getName() |
int |
getNumberOfReferences()
Used on testing only *
|
PageSubscription |
getPageSubscription() |
long |
getPersistentSize()
This is the size of the messages in the queue when persisted on disk which is used for metrics tracking
to give an idea of the amount of data on the queue to be consumed
Note that this includes all messages on the queue, even messages that are non-durable which may only be in memory
|
float |
getRate() |
MessageReference |
getReference(long id1) |
SimpleString |
getRoutingName() |
RoutingType |
getRoutingType() |
int |
getScheduledCount() |
List<MessageReference> |
getScheduledMessages() |
long |
getScheduledSize() |
SimpleString |
getUniqueName() |
SimpleString |
getUser() |
static MessageGroups<Consumer> |
groupMap(int groupBuckets) |
int |
hashCode() |
boolean |
hasMatchingConsumer(Message message) |
void |
incrementMesssagesAdded() |
boolean |
isAutoCreated() |
boolean |
isAutoDelete() |
boolean |
isConfigurationManaged() |
boolean |
isDirectDeliver() |
boolean |
isDispatching() |
boolean |
isDurable() |
boolean |
isDurableMessage()
The queue definition could be durable, but the messages could eventually be considered non durable.
|
boolean |
isExclusive() |
boolean |
isExpirationRedundant() |
boolean |
isGroupRebalance() |
boolean |
isInternalQueue()
We can't send stuff to DLQ on queues used on clustered-bridge-communication
|
boolean |
isLastValue() |
boolean |
isNonDestructive() |
boolean |
isPaused() |
boolean |
isPersistedPause()
if the pause was persisted
|
boolean |
isPurgeOnNoConsumers() |
boolean |
isTemporary() |
LinkedListIterator<MessageReference> |
iterator()
It will iterate thorugh memory only (not paging)
|
boolean |
moveReference(long messageID,
SimpleString toAddress,
Binding binding,
boolean rejectDuplicate) |
int |
moveReferences(Filter filter,
SimpleString toAddress,
Binding binding) |
int |
moveReferences(int flushLimit,
Filter filter,
SimpleString toAddress,
boolean rejectDuplicates,
Binding binding) |
int |
moveReferencesBetweenSnFQueues(SimpleString queueSuffix) |
void |
pause()
Pauses the queue.
|
void |
pause(boolean persist)
Pauses the queue.
|
void |
postAcknowledge(MessageReference ref,
AckReason reason) |
void |
reacknowledge(Transaction tx,
MessageReference ref) |
void |
recheckRefCount(OperationContext context)
This is to perform a check on the counter again
|
protected void |
refAdded(MessageReference ref) |
void |
referenceHandled(MessageReference ref) |
protected void |
refRemoved(MessageReference ref) |
void |
reload(MessageReference ref) |
void |
reloadPause(long recordID) |
void |
removeConsumer(Consumer consumer) |
protected void |
removeMessageReference(QueueImpl.ConsumerHolder<? extends Consumer> holder,
MessageReference ref) |
MessageReference |
removeReferenceWithID(long id1) |
void |
resetAllGroups() |
void |
resetAllIterators() |
void |
resetGroup(SimpleString groupId) |
void |
resetMessagesAcknowledged() |
void |
resetMessagesAdded() |
void |
resetMessagesExpired() |
void |
resetMessagesKilled() |
void |
resume()
Resumes the delivery of message for the queue.
|
int |
retryMessages(Filter filter) |
void |
route(Message message,
RoutingContext context) |
void |
routeWithAck(Message message,
RoutingContext context) |
protected boolean |
scheduleIfPossible(MessageReference ref) |
int |
sendMessagesToDeadLetterAddress(Filter filter) |
boolean |
sendMessageToDeadLetterAddress(long messageID) |
boolean |
sendToDeadLetterAddress(Transaction tx,
MessageReference ref) |
void |
setConfigurationManaged(boolean configurationManaged) |
void |
setConsumersBeforeDispatch(int consumersBeforeDispatch) |
void |
setConsumersRefCount(ReferenceCounter referenceCounter)
This will set a reference counter for every consumer present on the queue.
|
void |
setDelayBeforeDispatch(long delayBeforeDispatch) |
void |
setDispatching(boolean dispatching) |
void |
setExclusive(boolean exclusive) |
void |
setFilter(Filter filter) |
void |
setGroupBuckets(int groupBuckets) |
void |
setGroupFirstKey(SimpleString groupFirstKey) |
void |
setGroupRebalance(boolean groupRebalance) |
void |
setInternalQueue(boolean internalQueue) |
void |
setMaxConsumer(int maxConsumers) |
void |
setNonDestructive(boolean nonDestructive) |
void |
setPurgeOnNoConsumers(boolean value) |
void |
setRoutingType(RoutingType routingType) |
void |
setUser(SimpleString user) |
String |
toString() |
void |
unproposed(SimpleString groupID) |
enterCritical, getCriticalAnalyzer, isExpired, leaveCritical
deleteMatchingReferences
enterCritical, getCriticalAnalyzer, isExpired, leaveCritical
protected static final int CRITICAL_PATHS
protected static final int CRITICAL_PATH_ADD_TAIL
protected static final int CRITICAL_PATH_ADD_HEAD
protected static final int CRITICAL_DELIVER
protected static final int CRITICAL_CONSUMER
protected static final int CRITICAL_CHECK_DEPAGE
public static final int REDISTRIBUTOR_BATCH_SIZE
public static final int NUM_PRIORITIES
public static final int MAX_DELIVERIES_IN_LOOP
public static final int CHECK_QUEUE_SIZE_PERIOD
public static final int DELIVERY_TIMEOUT
public static final int DEFAULT_FLUSH_LIMIT
protected final ScheduledDeliveryHandler scheduledDeliveryHandler
public volatile int dispatching
public volatile long dispatchStartTime
public QueueImpl(long id, SimpleString address, SimpleString name, Filter filter, SimpleString user, boolean durable, boolean temporary, boolean autoCreated, ScheduledExecutorService scheduledExecutor, PostOffice postOffice, StorageManager storageManager, HierarchicalRepository<AddressSettings> addressSettingsRepository, ArtemisExecutor executor, ActiveMQServer server, QueueFactory factory)
public QueueImpl(long id, SimpleString address, SimpleString name, Filter filter, PageSubscription pageSubscription, SimpleString user, boolean durable, boolean temporary, boolean autoCreated, ScheduledExecutorService scheduledExecutor, PostOffice postOffice, StorageManager storageManager, HierarchicalRepository<AddressSettings> addressSettingsRepository, ArtemisExecutor executor, ActiveMQServer server, QueueFactory factory)
public QueueImpl(long id, SimpleString address, SimpleString name, Filter filter, PageSubscription pageSubscription, SimpleString user, boolean durable, boolean temporary, boolean autoCreated, RoutingType routingType, Integer maxConsumers, Boolean purgeOnNoConsumers, ScheduledExecutorService scheduledExecutor, PostOffice postOffice, StorageManager storageManager, HierarchicalRepository<AddressSettings> addressSettingsRepository, ArtemisExecutor executor, ActiveMQServer server, QueueFactory factory)
public QueueImpl(long id, SimpleString address, SimpleString name, Filter filter, PageSubscription pageSubscription, SimpleString user, boolean durable, boolean temporary, boolean autoCreated, RoutingType routingType, Integer maxConsumers, Boolean exclusive, Boolean purgeOnNoConsumers, ScheduledExecutorService scheduledExecutor, PostOffice postOffice, StorageManager storageManager, HierarchicalRepository<AddressSettings> addressSettingsRepository, ArtemisExecutor executor, ActiveMQServer server, QueueFactory factory)
public QueueImpl(long id, SimpleString address, SimpleString name, Filter filter, PageSubscription pageSubscription, SimpleString user, boolean durable, boolean temporary, boolean autoCreated, RoutingType routingType, Integer maxConsumers, Boolean exclusive, Boolean groupRebalance, Integer groupBuckets, Boolean nonDestructive, Integer consumersBeforeDispatch, Long delayBeforeDispatch, Boolean purgeOnNoConsumers, Boolean autoDelete, Long autoDeleteDelay, Long autoDeleteMessageCount, boolean configurationManaged, ScheduledExecutorService scheduledExecutor, PostOffice postOffice, StorageManager storageManager, HierarchicalRepository<AddressSettings> addressSettingsRepository, ArtemisExecutor executor, ActiveMQServer server, QueueFactory factory)
public QueueImpl(long id, SimpleString address, SimpleString name, Filter filter, PageSubscription pageSubscription, SimpleString user, boolean durable, boolean temporary, boolean autoCreated, RoutingType routingType, Integer maxConsumers, Boolean exclusive, Boolean groupRebalance, Integer groupBuckets, SimpleString groupFirstKey, Boolean nonDestructive, Integer consumersBeforeDispatch, Long delayBeforeDispatch, Boolean purgeOnNoConsumers, Boolean autoDelete, Long autoDeleteDelay, Long autoDeleteMessageCount, boolean configurationManaged, ScheduledExecutorService scheduledExecutor, PostOffice postOffice, StorageManager storageManager, HierarchicalRepository<AddressSettings> addressSettingsRepository, ArtemisExecutor executor, ActiveMQServer server, QueueFactory factory)
public String debug()
public boolean allowsReferenceCallback()
Queue
allowsReferenceCallback
in interface Queue
public SimpleString getRoutingName()
public SimpleString getUniqueName()
public SimpleString getUser()
public void setUser(SimpleString user)
public boolean isExclusive()
isExclusive
in interface Queue
public void setExclusive(boolean exclusive)
setExclusive
in interface Queue
public int getConsumersBeforeDispatch()
getConsumersBeforeDispatch
in interface Queue
public void setConsumersBeforeDispatch(int consumersBeforeDispatch)
setConsumersBeforeDispatch
in interface Queue
public long getDelayBeforeDispatch()
getDelayBeforeDispatch
in interface Queue
public void setDelayBeforeDispatch(long delayBeforeDispatch)
setDelayBeforeDispatch
in interface Queue
public long getDispatchStartTime()
getDispatchStartTime
in interface Queue
public boolean isDispatching()
isDispatching
in interface Queue
public void setDispatching(boolean dispatching)
setDispatching
in interface Queue
public boolean isLastValue()
isLastValue
in interface Queue
public SimpleString getLastValueKey()
getLastValueKey
in interface Queue
public boolean isNonDestructive()
isNonDestructive
in interface Queue
public void setNonDestructive(boolean nonDestructive)
setNonDestructive
in interface Queue
public void route(Message message, RoutingContext context) throws Exception
public void routeWithAck(Message message, RoutingContext context)
routeWithAck
in interface Bindable
public void setConsumersRefCount(ReferenceCounter referenceCounter)
Queue
setConsumersRefCount
in interface Queue
public ReferenceCounter getConsumersRefCount()
getConsumersRefCount
in interface Queue
public boolean isDurableMessage()
Queue
isDurableMessage
in interface Queue
public boolean isAutoDelete()
isAutoDelete
in interface Queue
public long getAutoDeleteDelay()
getAutoDeleteDelay
in interface Queue
public long getAutoDeleteMessageCount()
getAutoDeleteMessageCount
in interface Queue
public boolean isTemporary()
isTemporary
in interface Queue
public boolean isAutoCreated()
isAutoCreated
in interface Queue
public boolean isPurgeOnNoConsumers()
isPurgeOnNoConsumers
in interface Queue
public void setPurgeOnNoConsumers(boolean value)
setPurgeOnNoConsumers
in interface Queue
public int getMaxConsumers()
getMaxConsumers
in interface Queue
public void setMaxConsumer(int maxConsumers)
setMaxConsumer
in interface Queue
public int getGroupBuckets()
getGroupBuckets
in interface Queue
public void setGroupBuckets(int groupBuckets)
setGroupBuckets
in interface Queue
public boolean isGroupRebalance()
isGroupRebalance
in interface Queue
public void setGroupRebalance(boolean groupRebalance)
setGroupRebalance
in interface Queue
public SimpleString getGroupFirstKey()
getGroupFirstKey
in interface Queue
public void setGroupFirstKey(SimpleString groupFirstKey)
setGroupFirstKey
in interface Queue
public boolean isConfigurationManaged()
isConfigurationManaged
in interface Queue
public void setConfigurationManaged(boolean configurationManaged)
setConfigurationManaged
in interface Queue
public SimpleString getName()
public SimpleString getAddress()
getAddress
in interface Queue
public PageSubscription getPageSubscription()
getPageSubscription
in interface Queue
public RoutingType getRoutingType()
getRoutingType
in interface Queue
public void setRoutingType(RoutingType routingType)
setRoutingType
in interface Queue
public void unproposed(SimpleString groupID)
unproposed
in interface Queue
public void addHead(MessageReference ref, boolean scheduling)
public void addHead(List<MessageReference> refs, boolean scheduling)
public void reload(MessageReference ref)
public void addTail(MessageReference ref)
public void addTail(MessageReference ref, boolean direct)
protected boolean scheduleIfPossible(MessageReference ref)
public void forceDelivery()
Queue
forceDelivery
in interface Queue
public void deliverAsync()
deliverAsync
in interface Queue
public ArtemisExecutor getExecutor()
getExecutor
in interface Queue
public void deliverNow()
public boolean flushExecutor()
flushExecutor
in interface Queue
public void addConsumer(Consumer consumer) throws Exception
addConsumer
in interface Queue
Exception
public void removeConsumer(Consumer consumer)
removeConsumer
in interface Queue
public void addRedistributor(long delay)
addRedistributor
in interface Queue
public void cancelRedistributor() throws Exception
cancelRedistributor
in interface Queue
Exception
protected void finalize() throws Throwable
public int getConsumerCount()
getConsumerCount
in interface Queue
public long getConsumerRemovedTimestamp()
getConsumerRemovedTimestamp
in interface Queue
public Set<Consumer> getConsumers()
getConsumers
in interface Queue
public Map<SimpleString,Consumer> getGroups()
public void resetGroup(SimpleString groupId)
resetGroup
in interface Queue
public void resetAllGroups()
resetAllGroups
in interface Queue
public int getGroupCount()
getGroupCount
in interface Queue
public boolean hasMatchingConsumer(Message message)
hasMatchingConsumer
in interface Queue
public LinkedListIterator<MessageReference> iterator()
Queue
public org.apache.activemq.artemis.core.server.impl.QueueImpl.QueueBrowserIterator browserIterator()
browserIterator
in interface Queue
public MessageReference removeReferenceWithID(long id1) throws Exception
removeReferenceWithID
in interface Queue
Exception
public MessageReference getReference(long id1) throws ActiveMQException
getReference
in interface Queue
ActiveMQException
public long getMessageCount()
getMessageCount
in interface Queue
public long getPersistentSize()
Queue
getPersistentSize
in interface Queue
public long getDurableMessageCount()
Queue
getDurableMessageCount
in interface Queue
public long getDurablePersistentSize()
Queue
getDurablePersistentSize
in interface Queue
public int getScheduledCount()
getScheduledCount
in interface Queue
public long getScheduledSize()
getScheduledSize
in interface Queue
public int getDurableScheduledCount()
getDurableScheduledCount
in interface Queue
public long getDurableScheduledSize()
getDurableScheduledSize
in interface Queue
public List<MessageReference> getScheduledMessages()
getScheduledMessages
in interface Queue
public Map<String,List<MessageReference>> getDeliveringMessages()
Queue
getDeliveringMessages
in interface Queue
public int getDeliveringCount()
getDeliveringCount
in interface Queue
public long getDeliveringSize()
getDeliveringSize
in interface Queue
public int getDurableDeliveringCount()
getDurableDeliveringCount
in interface Queue
public long getDurableDeliveringSize()
getDurableDeliveringSize
in interface Queue
public void acknowledge(MessageReference ref) throws Exception
acknowledge
in interface Queue
Exception
public void acknowledge(MessageReference ref, ServerConsumer consumer) throws Exception
acknowledge
in interface Queue
Exception
public void acknowledge(MessageReference ref, AckReason reason, ServerConsumer consumer) throws Exception
acknowledge
in interface Queue
Exception
public void acknowledge(Transaction tx, MessageReference ref) throws Exception
acknowledge
in interface Queue
Exception
public void acknowledge(Transaction tx, MessageReference ref, AckReason reason, ServerConsumer consumer) throws Exception
acknowledge
in interface Queue
Exception
public void reacknowledge(Transaction tx, MessageReference ref) throws Exception
reacknowledge
in interface Queue
Exception
public void cancel(Transaction tx, MessageReference reference)
public void cancel(Transaction tx, MessageReference reference, boolean ignoreRedeliveryCheck)
public void cancel(MessageReference reference, long timeBase) throws Exception
public void expire(MessageReference ref) throws Exception
public void expire(MessageReference ref, ServerConsumer consumer) throws Exception
public SimpleString getExpiryAddress()
getExpiryAddress
in interface Queue
public void referenceHandled(MessageReference ref)
referenceHandled
in interface Queue
public void incrementMesssagesAdded()
incrementMesssagesAdded
in interface Queue
public void deliverScheduledMessages() throws ActiveMQException
Queue
deliverScheduledMessages
in interface Queue
ActiveMQException
public long getMessagesAdded()
getMessagesAdded
in interface Queue
public long getMessagesAcknowledged()
getMessagesAcknowledged
in interface Queue
public long getAcknowledgeAttempts()
getAcknowledgeAttempts
in interface Queue
public long getMessagesExpired()
getMessagesExpired
in interface Queue
public long getMessagesKilled()
getMessagesKilled
in interface Queue
public int deleteAllReferences() throws Exception
deleteAllReferences
in interface Queue
Exception
public int deleteAllReferences(int flushLimit) throws Exception
deleteAllReferences
in interface Queue
Exception
public int deleteMatchingReferences(Filter filter) throws Exception
deleteMatchingReferences
in interface Queue
Exception
public int deleteMatchingReferences(int flushLimit, Filter filter1, AckReason ackReason) throws Exception
deleteMatchingReferences
in interface Queue
Exception
public void destroyPaging() throws Exception
destroyPaging
in interface Queue
Exception
public boolean deleteReference(long messageID) throws Exception
deleteReference
in interface Queue
Exception
public void deleteQueue() throws Exception
deleteQueue
in interface Queue
Exception
public void deleteQueue(boolean removeConsumers) throws Exception
deleteQueue
in interface Queue
Exception
public boolean expireReference(long messageID) throws Exception
expireReference
in interface Queue
Exception
public int expireReferences(Filter filter) throws Exception
Queue
expireReferences
in interface Queue
Exception
public void expireReferences()
expireReferences
in interface Queue
public boolean isExpirationRedundant()
public boolean sendMessageToDeadLetterAddress(long messageID) throws Exception
sendMessageToDeadLetterAddress
in interface Queue
Exception
public int sendMessagesToDeadLetterAddress(Filter filter) throws Exception
sendMessagesToDeadLetterAddress
in interface Queue
Exception
public boolean moveReference(long messageID, SimpleString toAddress, Binding binding, boolean rejectDuplicate) throws Exception
moveReference
in interface Queue
Exception
public int moveReferences(Filter filter, SimpleString toAddress, Binding binding) throws Exception
moveReferences
in interface Queue
Exception
public int moveReferences(int flushLimit, Filter filter, SimpleString toAddress, boolean rejectDuplicates, Binding binding) throws Exception
moveReferences
in interface Queue
Exception
public int moveReferencesBetweenSnFQueues(SimpleString queueSuffix) throws Exception
Exception
public int retryMessages(Filter filter) throws Exception
retryMessages
in interface Queue
Exception
public boolean changeReferencePriority(long messageID, byte newPriority) throws Exception
changeReferencePriority
in interface Queue
Exception
public int changeReferencesPriority(Filter filter, byte newPriority) throws Exception
changeReferencesPriority
in interface Queue
Exception
public void resetAllIterators()
resetAllIterators
in interface Queue
public void pause()
Queue
public void reloadPause(long recordID)
reloadPause
in interface Queue
public void pause(boolean persist)
Queue
public void resume()
Queue
public boolean isPaused()
public boolean isPersistedPause()
Queue
isPersistedPause
in interface Queue
public boolean isDirectDeliver()
isDirectDeliver
in interface Queue
public boolean isInternalQueue()
Queue
isInternalQueue
in interface Queue
public void setInternalQueue(boolean internalQueue)
setInternalQueue
in interface Queue
internalQueue
- the internalQueue to setprotected void removeMessageReference(QueueImpl.ConsumerHolder<? extends Consumer> holder, MessageReference ref)
protected void refRemoved(MessageReference ref)
protected void refAdded(MessageReference ref)
public Pair<Boolean,Boolean> checkRedelivery(MessageReference reference, long timeBase, boolean ignoreRedeliveryDelay) throws Exception
checkRedelivery
in interface Queue
Exception
public int getNumberOfReferences()
public boolean sendToDeadLetterAddress(Transaction tx, MessageReference ref) throws Exception
sendToDeadLetterAddress
in interface Queue
Exception
public void errorProcessing(Consumer consumer, Throwable t, MessageReference reference)
errorProcessing
in interface Queue
public void postAcknowledge(MessageReference ref, AckReason reason)
postAcknowledge
in interface Queue
public void resetMessagesAdded()
resetMessagesAdded
in interface Queue
public void resetMessagesAcknowledged()
resetMessagesAcknowledged
in interface Queue
public void resetMessagesExpired()
resetMessagesExpired
in interface Queue
public void resetMessagesKilled()
resetMessagesKilled
in interface Queue
public void recheckRefCount(OperationContext context)
Queue
recheckRefCount
in interface Queue
public static MessageGroups<Consumer> groupMap(int groupBuckets)
public void decDelivering(MessageReference reference)
Copyright © 2019 JBoss by Red Hat. All rights reserved.