Package | Description |
---|---|
org.apache.activemq |
The core JMS client API implementation classes.
|
org.apache.activemq.broker.region |
Region abstraction and implementations in the Broker.
|
org.apache.activemq.broker.region.cursors |
Cursors used to page persistent messages into the broker from the store
|
org.apache.activemq.command |
Command objects used via the Command Pattern to communicate among nodes
|
org.apache.activemq.kaha |
fast message persistence implementation
|
org.apache.activemq.store |
The APIs which need to be implemented for persistent message stores for durable messaging
|
org.apache.activemq.store.amq |
The default Store implementation for ActiveMQ
|
org.apache.activemq.store.jdbc |
Message persistence implemented using JDBC
|
org.apache.activemq.store.jdbc.adapter |
Implements database/driver apapters to compensate for the
wide differences in the BLOB handing of JDBC drivers.
|
org.apache.activemq.store.journal |
Message persistence using a high performance transaction log via the Journal interface.
|
org.apache.activemq.store.kahadaptor |
kaha implementation of message persistence for the broker
|
org.apache.activemq.store.kahadb | |
org.apache.activemq.store.memory |
VM based implementation of message persistence
|
org.apache.activemq.transport.stomp |
An implementation of the Stomp protocol which is a simple wire protocol for writing clients for ActiveMQ in different
languages like Ruby, Python, PHP, C etc.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ActiveMQMessageAudit.isDuplicate(MessageId id) |
boolean |
ActiveMQMessageAuditNoSync.isDuplicate(MessageId id)
Checks if this messageId has been seen before
|
boolean |
ActiveMQMessageAudit.isInOrder(MessageId id) |
boolean |
ActiveMQMessageAuditNoSync.isInOrder(MessageId id)
Check the MessageId is in order
|
void |
ActiveMQMessageAudit.rollback(MessageId id) |
void |
ActiveMQMessageAuditNoSync.rollback(MessageId id)
mark this message as being received
|
Modifier and Type | Method and Description |
---|---|
MessageId |
IndirectMessageReference.getMessageId() |
MessageId |
MessageReference.getMessageId() |
Modifier and Type | Method and Description |
---|---|
Message |
Topic.loadMessage(MessageId messageId) |
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractPendingMessageCursor.isDuplicate(MessageId messageId) |
boolean |
AbstractPendingMessageCursor.recordUniqueId(MessageId messageId)
records a message id and checks if it is a duplicate
|
void |
AbstractPendingMessageCursor.rollback(MessageId id) |
void |
PendingMessageCursor.rollback(MessageId id)
remove from auditing the message id
|
protected void |
AbstractStoreCursor.setBatch(MessageId messageId) |
Modifier and Type | Field and Description |
---|---|
protected MessageId |
MessageAck.firstMessageId |
protected MessageId |
MessageAck.lastMessageId |
protected MessageId |
MessageDispatchNotification.messageId |
protected MessageId |
Message.messageId |
Modifier and Type | Method and Description |
---|---|
MessageId |
MessageId.copy() |
MessageId |
MessageAck.getFirstMessageId() |
MessageId |
MessageAck.getLastMessageId() |
MessageId |
MessageDispatchNotification.getMessageId() |
MessageId |
JournalTopicAck.getMessageId() |
MessageId |
MessagePull.getMessageId()
An optional message ID which could be used by a broker to decide which messages are pulled
on demand from a queue for a consumer
|
MessageId |
Message.getMessageId() |
Modifier and Type | Method and Description |
---|---|
int |
MessageId.compareTo(MessageId other) |
void |
MessageAck.setFirstMessageId(MessageId firstMessageId) |
void |
MessageAck.setLastMessageId(MessageId lastMessageId) |
void |
MessageDispatchNotification.setMessageId(MessageId messageId) |
void |
JournalTopicAck.setMessageId(MessageId messageId) |
void |
MessagePull.setMessageId(MessageId messageId) |
void |
Message.setMessageId(MessageId messageId) |
void |
MessageAck.setMessageID(MessageId messageID)
A helper method to allow a single message ID to be acknowledged
|
Modifier and Type | Method and Description |
---|---|
MessageId |
MessageIdMarshaller.readPayload(DataInput dataIn)
Read the entry from the RawContainer
|
Modifier and Type | Method and Description |
---|---|
void |
MessageIdMarshaller.writePayload(MessageId object,
DataOutput dataOut)
Write the payload of this entry to the RawContainer
|
Modifier and Type | Method and Description |
---|---|
void |
ProxyTopicMessageStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck ack) |
void |
TopicMessageStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck ack)
Stores the last acknowledged messgeID for the given subscription so that
we can recover and commence dispatching messages from the last checkpoint
|
boolean |
TopicReferenceStore.acknowledgeReference(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId)
Removes the last acknowledged messgeID for the given subscription so that
we can recover and commence dispatching messages from the last checkpoint
N.B.
|
boolean |
ReferenceStore.addMessageReference(ConnectionContext context,
MessageId messageId,
ReferenceStore.ReferenceData data)
Adds a message reference to the message store
|
Message |
ProxyTopicMessageStore.getMessage(MessageId identity) |
Message |
ProxyMessageStore.getMessage(MessageId identity) |
Message |
MessageStore.getMessage(MessageId identity)
Looks up a message using either the String messageID or the
messageNumber.
|
ReferenceStore.ReferenceData |
ReferenceStore.getMessageReference(MessageId identity)
Looks up a message using either the String messageID or the
messageNumber.
|
boolean |
MessageRecoveryListener.isDuplicate(MessageId ref)
check if ref is a duplicate but do not record the reference
|
boolean |
MessageRecoveryListener.recoverMessageReference(MessageId ref) |
void |
ProxyTopicMessageStore.setBatch(MessageId messageId) |
void |
ProxyMessageStore.setBatch(MessageId messageId) |
void |
AbstractMessageStore.setBatch(MessageId messageId) |
void |
MessageStore.setBatch(MessageId messageId)
allow caching cursors to set the current batch offset when cache is exhausted
|
void |
ReferenceStore.setBatch(MessageId startAfter) |
Modifier and Type | Method and Description |
---|---|
protected void |
AMQTopicMessageStore.acknowledge(ConnectionContext context,
MessageId messageId,
Location location,
String clientId,
String subscriptionName) |
void |
AMQTopicMessageStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck originalAck) |
void |
AMQMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
String messageRef) |
protected Location |
AMQMessageStore.getLocation(MessageId messageId) |
Message |
AMQMessageStore.getMessage(MessageId identity) |
String |
AMQMessageStore.getMessageReference(MessageId identity) |
boolean |
AMQTopicMessageStore.replayAcknowledge(ConnectionContext context,
String clientId,
String subscritionName,
MessageId messageId) |
void |
AMQMessageStore.setBatch(MessageId messageId) |
Modifier and Type | Method and Description |
---|---|
void |
JDBCTopicMessageStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck ack) |
void |
JDBCMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
String messageRef) |
void |
JDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority) |
void |
JDBCAdapter.doAddMessageReference(TransactionContext c,
long sequence,
MessageId messageId,
ActiveMQDestination destination,
long expirationTime,
String messageRef) |
byte[] |
JDBCAdapter.doGetMessage(TransactionContext c,
MessageId id) |
Message |
JDBCMessageStore.getMessage(MessageId messageId) |
String |
JDBCMessageStore.getMessageReference(MessageId messageId) |
long[] |
JDBCAdapter.getStoreSequenceId(TransactionContext c,
ActiveMQDestination destination,
MessageId messageID) |
void |
JDBCMessageIdScanListener.messageId(MessageId id) |
protected void |
JDBCMessageStore.onAdd(MessageId messageId,
long sequenceId,
byte priority) |
protected void |
JDBCTopicMessageStore.onAdd(MessageId messageId,
long sequenceId,
byte priority) |
void |
JDBCMessageStore.setBatch(MessageId messageId) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultJDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority) |
void |
BlobJDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority) |
void |
DefaultJDBCAdapter.doAddMessageReference(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
long expirationTime,
String messageRef) |
byte[] |
DefaultJDBCAdapter.doGetMessage(TransactionContext c,
MessageId id) |
byte[] |
BlobJDBCAdapter.doGetMessage(TransactionContext c,
MessageId id) |
long[] |
DefaultJDBCAdapter.getStoreSequenceId(TransactionContext c,
ActiveMQDestination destination,
MessageId messageID) |
Modifier and Type | Method and Description |
---|---|
void |
JournalTopicMessageStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck originalAck) |
protected void |
JournalTopicMessageStore.acknowledge(MessageId messageId,
org.apache.activeio.journal.RecordLocation location,
SubscriptionKey key) |
void |
JournalMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
String messageRef) |
Message |
JournalMessageStore.getMessage(MessageId identity) |
String |
JournalMessageStore.getMessageReference(MessageId identity) |
void |
JournalTopicMessageStore.replayAcknowledge(ConnectionContext context,
String clientId,
String subscritionName,
MessageId messageId) |
void |
JournalMessageStore.setBatch(MessageId messageId) |
Modifier and Type | Field and Description |
---|---|
protected MapContainer<MessageId,ReferenceRecord> |
KahaReferenceStore.messageContainer |
protected MapContainer<MessageId,Message> |
KahaMessageStore.messageContainer |
Modifier and Type | Method and Description |
---|---|
MessageId |
ConsumerMessageRef.getMessageId() |
protected MessageId |
KahaTopicReferenceStore.getMessageId(Object object) |
protected MessageId |
KahaReferenceStore.getMessageId(Object object) |
protected MessageId |
KahaMessageStore.getMessageId(Object object) |
MessageId |
KahaMessageStore.getPreviousMessageIdToDeliver(MessageId id) |
Modifier and Type | Method and Description |
---|---|
protected MapContainer<MessageId,Message> |
KahaPersistenceAdapter.getMapContainer(Object id,
String containerName) |
protected MapContainer<MessageId,ReferenceRecord> |
KahaReferenceStoreAdapter.getMapReferenceContainer(Object id,
String containerName) |
Modifier and Type | Method and Description |
---|---|
void |
KahaTopicReferenceStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck ack) |
void |
KahaTopicMessageStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck ack) |
boolean |
KahaTopicReferenceStore.acknowledgeReference(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId) |
boolean |
KahaTopicReferenceStore.addMessageReference(ConnectionContext context,
MessageId messageId,
ReferenceStore.ReferenceData data) |
boolean |
KahaReferenceStore.addMessageReference(ConnectionContext context,
MessageId messageId,
ReferenceStore.ReferenceData data) |
Message |
KahaTopicReferenceStore.getMessage(MessageId identity) |
Message |
KahaReferenceStore.getMessage(MessageId identity) |
Message |
KahaMessageStore.getMessage(MessageId identity) |
ReferenceStore.ReferenceData |
KahaTopicReferenceStore.getMessageReference(MessageId identity) |
ReferenceStore.ReferenceData |
KahaReferenceStore.getMessageReference(MessageId identity) |
MessageId |
KahaMessageStore.getPreviousMessageIdToDeliver(MessageId id) |
protected boolean |
KahaReferenceStore.isDuplicate(MessageId messageId) |
ConsumerMessageRef |
TopicSubContainer.remove(MessageId id) |
void |
KahaMessageStore.removeMessage(MessageId msgId) |
void |
KahaReferenceStore.setBatch(MessageId startAfter) |
void |
KahaMessageStore.setBatch(MessageId messageId) |
void |
ConsumerMessageRef.setMessageId(MessageId messageId) |
Constructor and Description |
---|
KahaMessageStore(MapContainer<MessageId,Message> container,
ActiveMQDestination destination) |
KahaReferenceStore(KahaReferenceStoreAdapter adapter,
MapContainer<MessageId,ReferenceRecord> container,
ActiveMQDestination destination) |
KahaTopicMessageStore(Store store,
MapContainer<MessageId,Message> messageContainer,
ListContainer<TopicSubAck> ackContainer,
MapContainer<String,SubscriptionInfo> subsContainer,
ActiveMQDestination destination) |
KahaTopicReferenceStore(Store store,
KahaReferenceStoreAdapter adapter,
MapContainer<MessageId,ReferenceRecord> messageContainer,
ListContainer<TopicSubAck> ackContainer,
MapContainer<String,SubscriptionInfo> subsContainer,
ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
Message |
TempKahaDBStore.KahaDBMessageStore.getMessage(MessageId identity) |
Message |
KahaDBStore.KahaDBMessageStore.getMessage(MessageId identity) |
protected org.apache.activemq.store.kahadb.KahaDBStore.StoreQueueTask |
KahaDBStore.removeQueueTask(KahaDBStore.KahaDBMessageStore store,
MessageId id) |
protected org.apache.activemq.store.kahadb.KahaDBStore.StoreTopicTask |
KahaDBStore.removeTopicTask(org.apache.activemq.store.kahadb.KahaDBStore.KahaDBTopicMessageStore store,
MessageId id) |
void |
TempKahaDBStore.KahaDBMessageStore.setBatch(MessageId identity) |
void |
KahaDBStore.KahaDBMessageStore.setBatch(MessageId identity) |
Modifier and Type | Field and Description |
---|---|
protected MessageId |
MemoryMessageStore.lastBatchId |
Modifier and Type | Field and Description |
---|---|
protected Map<MessageId,Message> |
MemoryMessageStore.messageTable |
Modifier and Type | Method and Description |
---|---|
void |
MemoryTopicMessageStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck ack) |
Message |
MemoryMessageStore.getMessage(MessageId identity) |
void |
MemoryMessageStore.removeMessage(MessageId msgId) |
void |
MemoryMessageStore.setBatch(MessageId messageId) |
Constructor and Description |
---|
MemoryMessageStore(ActiveMQDestination destination,
Map<MessageId,Message> messageTable) |
MemoryTopicMessageStore(ActiveMQDestination destination,
Map<MessageId,Message> messageTable,
Map<SubscriptionKey,SubscriptionInfo> subscriberDatabase) |
Modifier and Type | Field and Description |
---|---|
protected LinkedHashMap<MessageId,MessageDispatch> |
StompSubscription.dispatchedMessage |
Copyright © 2005–2014. All rights reserved.