A B C D E F G H I J K L M N O P Q R S T U V _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AbstractEphemeralSupportQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
Abstract ephemeral-support queue implementation.
- AbstractEphemeralSupportQueue() - Constructor for class com.github.ddth.queue.impl.AbstractEphemeralSupportQueue
- AbstractInmemEphemeralQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
Abstract queue implementation that uses in-memory ephemeral storage.
- AbstractInmemEphemeralQueue() - Constructor for class com.github.ddth.queue.impl.AbstractInmemEphemeralQueue
- AbstractLessLockingUniversalJdbcQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Same as
UniversalJdbcQueue
, but using a "less-locking" algorithm, requires only one single db table for both queue and ephemeral storage. - AbstractLessLockingUniversalJdbcQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Same as
UniversalJdbcQueue
, but using a "less-locking" algorithm, requires only one single db table for both queue and ephemeral storage. - AbstractLessLockingUniversalJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.AbstractLessLockingUniversalJdbcQueue
- AbstractLessLockingUniversalJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.AbstractLessLockingUniversalJdbcQueue
- AbstractLessLockingUniversalSingleStorageJdbcQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Same as
AbstractLessLockingUniversalJdbcQueue
, but messages from all queues are stored in one same storage. - AbstractLessLockingUniversalSingleStorageJdbcQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Same as
AbstractLessLockingUniversalJdbcQueue
, but messages from all queues are stored in one same storage. - AbstractLessLockingUniversalSingleStorageJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.AbstractLessLockingUniversalSingleStorageJdbcQueue
- AbstractLessLockingUniversalSingleStorageJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.AbstractLessLockingUniversalSingleStorageJdbcQueue
- AbstractPubSubHub<ID,DATA> - Class in com.github.ddth.pubsub.impl
-
Abstract implementation of
IPubSubHub
. - AbstractPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.AbstractPubSubHub
- AbstractQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
Abstract queue implementation.
- AbstractQueue() - Constructor for class com.github.ddth.queue.impl.AbstractQueue
- AbstractQueue.PutToQueueCase - Enum in com.github.ddth.queue.impl
- AbstractQueueFactory<T extends AbstractQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Abstract queue factory implementation.
- AbstractQueueFactory() - Constructor for class com.github.ddth.queue.impl.AbstractQueueFactory
- ActiveMqQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
(Experimental) ActiveMQ implementation of
IQueue
. - ActiveMqQueue() - Constructor for class com.github.ddth.queue.impl.ActiveMqQueue
- ActiveMqQueueFactory<T extends ActiveMqQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
ActiveMqQueue
instances. - ActiveMqQueueFactory() - Constructor for class com.github.ddth.queue.impl.ActiveMqQueueFactory
B
- BaseLessLockingUniversalJdbcQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Same as
BaseUniversalJdbcQueue
, but using a "less-locking" algorithm, requires only one single db table for both queue and ephemeral storage. - BaseLessLockingUniversalJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
- BaseLessLockingUniversalSingleStorageJdbcQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Same as
BaseLessLockingUniversalJdbcQueue
, but messages from all queues are stored in one same storage. - BaseLessLockingUniversalSingleStorageJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
- BaseRedisPubSubHub<ID,DATA> - Class in com.github.ddth.pubsub.impl
-
Base Redis implementation of
IPubSubHub
. - BaseRedisPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
- BaseRedisQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
Base Redis implementation of
IQueue
. - BaseRedisQueue() - Constructor for class com.github.ddth.queue.impl.BaseRedisQueue
- BaseRedisQueueFactory<T extends RedisQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Base factory to create
BaseRedisQueue
instances. - BaseRedisQueueFactory() - Constructor for class com.github.ddth.queue.impl.BaseRedisQueueFactory
- BaseUniversalActiveMqQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal ActiveMQ queue implementations.
- BaseUniversalActiveMqQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalActiveMqQueue
- BaseUniversalDisruptorQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal LMAX Disruptor queue implementations.
- BaseUniversalDisruptorQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalDisruptorQueue
- BaseUniversalDisruptorQueue(int) - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalDisruptorQueue
- BaseUniversalInmemQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal in-memory queue implementations.
- BaseUniversalInmemQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalInmemQueue
- BaseUniversalInmemQueue(int) - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalInmemQueue
- BaseUniversalJdbcQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal JDBC queue implementations.
- BaseUniversalJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
- BaseUniversalKafkaQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal Kafka queue implementations.
- BaseUniversalKafkaQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalKafkaQueue
- BaseUniversalMessage<ID> - Class in com.github.ddth.pubsub.impl.universal
-
Base class for universal messages, where data is stored as
byte[]
. - BaseUniversalMessage() - Constructor for class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
- BaseUniversalMongodbQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal MongoDB queue implementations.
- BaseUniversalMongodbQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalMongodbQueue
- BaseUniversalQueueMessage<ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal queue messages, where data is stored as
byte[]
. - BaseUniversalQueueMessage() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- BaseUniversalRabbitMqQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal RabbitMQ queue implementations.
- BaseUniversalRabbitMqQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalRabbitMqQueue
- BaseUniversalRedisQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal Redis queue implementations.
- BaseUniversalRedisQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalRedisQueue
- BaseUniversalRocksDbQueue<T extends BaseUniversalQueueMessage<ID>,ID> - Class in com.github.ddth.queue.impl.universal
-
Base class for universal RocksDB queue implementations.
- BaseUniversalRocksDbQueue() - Constructor for class com.github.ddth.queue.impl.universal.BaseUniversalRocksDbQueue
- buildConnectionFactory() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
- buildConnectionFactory() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
- buildJdbcHelper() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Build an
IJdbcHelper
to be used by this JDBC queue. - buildJedisConnector() - Method in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Build a
JedisConnector
instance for my own use. - buildJedisConnector() - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Build a
JedisConnector
instance for my own use. - buildJedisConnector() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Build a
JedisConnector
instance for my own use. - buildJedisConnector() - Method in class com.github.ddth.queue.impl.RedisQueue
-
Build a
JedisConnector
instance for my own use. - buildKafkaClient() - Method in class com.github.ddth.queue.impl.KafkaQueue
- buildMongoClient() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Build a new
MongoClient
instance. - buildMongoClient() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Build a new
MongoClient
instance.
C
- CannotDeserializeQueueMessage() - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotDeserializeQueueMessage
- CannotDeserializeQueueMessage(String) - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotDeserializeQueueMessage
- CannotDeserializeQueueMessage(String, Throwable) - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotDeserializeQueueMessage
- CannotDeserializeQueueMessage(String, Throwable, boolean, boolean) - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotDeserializeQueueMessage
- CannotDeserializeQueueMessage(Throwable) - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotDeserializeQueueMessage
- CannotSerializeQueueMessage() - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotSerializeQueueMessage
- CannotSerializeQueueMessage(String) - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotSerializeQueueMessage
- CannotSerializeQueueMessage(String, Throwable) - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotSerializeQueueMessage
- CannotSerializeQueueMessage(String, Throwable, boolean, boolean) - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotSerializeQueueMessage
- CannotSerializeQueueMessage(Throwable) - Constructor for exception com.github.ddth.queue.utils.QueueException.CannotSerializeQueueMessage
- clone() - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
-
Clone this message.
- clone() - Method in interface com.github.ddth.queue.IMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.queue.IMessage.EmptyMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.queue.impl.GenericMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.queue.impl.GenericQueueMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
-
Clone this message.
- clone() - Method in interface com.github.ddth.queue.IQueueMessage
-
Clone this message.
- clone() - Method in class com.github.ddth.queue.IQueueMessage.EmptyQueueMessage
-
Clone this message.
- close() - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
- close() - Method in class com.github.ddth.queue.impl.AbstractQueue
- close() - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- closeJedisCommands(BinaryJedisCommands) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Close the unused
BinaryJedisCommands
. - closeJedisCommands(BinaryJedisCommands) - Method in class com.github.ddth.queue.impl.RedisQueue
-
Close the unused
BinaryJedisCommands
. - closeJedisConnector(JedisConnector, boolean) - Static method in class com.github.ddth.pubsub.internal.utils.RedisUtils
-
Close the supplied
JedisConnector
. - closeJedisConnector(JedisConnector, boolean) - Static method in class com.github.ddth.queue.internal.utils.RedisUtils
-
Close the supplied
JedisConnector
. - closeQuietly(Channel) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
- closeQuietly(Connection) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
- closeQuietly(Connection) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
- closeQuietly(MessageConsumer) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
- closeQuietly(MessageProducer) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
- closeQuietly(Session) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
- COL_CONTENT - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Table's column name to store message's content
- COL_CONTENT - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Table's column name to store message's content
- COL_CONTENT - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Table's column name to store message's content
- COL_CONTENT - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Table's column name to store message's content
- COL_CONTENT - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Table's column name to store message's content
- COL_CONTENT - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Table's column name to store message's content
- COL_EPHEMERAL_ID - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Table's column name to store ephemeral id
- COL_EPHEMERAL_ID - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Table's column name to store ephemeral id
- COL_NUM_REQUEUES - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Table's column name to store message's number of requeues
- COL_NUM_REQUEUES - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Table's column name to store message's number of requeues
- COL_NUM_REQUEUES - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Table's column name to store message's number of requeues
- COL_NUM_REQUEUES - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Table's column name to store message's number of requeues
- COL_NUM_REQUEUES - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Table's column name to store message's number of requeues
- COL_NUM_REQUEUES - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Table's column name to store message's number of requeues
- COL_ORG_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Table's column name to store message's original timestamp
- COL_ORG_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Table's column name to store message's original timestamp
- COL_ORG_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Table's column name to store message's original timestamp
- COL_ORG_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Table's column name to store message's original timestamp
- COL_ORG_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Table's column name to store message's original timestamp
- COL_ORG_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Table's column name to store message's original timestamp
- COL_QUEUE_ID - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Table's column name to store queue-id
- COL_QUEUE_ID - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Table's column name to store queue-id
- COL_QUEUE_ID - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Table's column name to store queue-id
- COL_QUEUE_ID - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Table's column name to store queue-id
- COL_QUEUE_ID - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Table's column name to store queue-id
- COL_QUEUE_ID - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Table's column name to store queue-id
- COL_QUEUE_NAME - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Table's column name to store queue-name
- COL_QUEUE_NAME - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Table's column name to store queue-name
- COL_QUEUE_NAME - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Table's column name to store queue-name
- COL_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Table's column name to store message's timestamp
- COL_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Table's column name to store message's timestamp
- COL_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Table's column name to store message's timestamp
- COL_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Table's column name to store message's timestamp
- COL_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Table's column name to store message's timestamp
- COL_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Table's column name to store message's timestamp
- COLLECTION_FIELD_DATA - Static variable in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- COLLECTION_FIELD_EPHEMERAL_KEY - Static variable in class com.github.ddth.queue.impl.MongodbQueue
- COLLECTION_FIELD_ID - Static variable in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- COLLECTION_FIELD_ID - Static variable in class com.github.ddth.queue.impl.MongodbQueue
- COLLECTION_FIELD_QUEUE_DATA - Static variable in class com.github.ddth.queue.impl.MongodbQueue
- COLLECTION_FIELD_QUEUE_TIME - Static variable in class com.github.ddth.queue.impl.MongodbQueue
- COLLECTION_FIELD_TIME - Static variable in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- COLLECTION_FIELD_TIME - Static variable in class com.github.ddth.queue.impl.MongodbQueue
- collectionExists(MongoDatabase, String) - Static method in class com.github.ddth.pubsub.internal.utils.MongoUtils
-
Check if a collection exists.
- collectionExists(MongoDatabase, String) - Static method in class com.github.ddth.queue.internal.utils.MongoUtils
-
Check if a collection exists.
- com.github.ddth.pubsub - package com.github.ddth.pubsub
- com.github.ddth.pubsub.impl - package com.github.ddth.pubsub.impl
- com.github.ddth.pubsub.impl.universal - package com.github.ddth.pubsub.impl.universal
- com.github.ddth.pubsub.impl.universal.idint - package com.github.ddth.pubsub.impl.universal.idint
- com.github.ddth.pubsub.impl.universal.idstr - package com.github.ddth.pubsub.impl.universal.idstr
- com.github.ddth.pubsub.internal.utils - package com.github.ddth.pubsub.internal.utils
- com.github.ddth.queue - package com.github.ddth.queue
- com.github.ddth.queue.impl - package com.github.ddth.queue.impl
- com.github.ddth.queue.impl.universal - package com.github.ddth.queue.impl.universal
- com.github.ddth.queue.impl.universal.idint - package com.github.ddth.queue.impl.universal.idint
- com.github.ddth.queue.impl.universal.idstr - package com.github.ddth.queue.impl.universal.idstr
- com.github.ddth.queue.internal.utils - package com.github.ddth.queue.internal.utils
- com.github.ddth.queue.utils - package com.github.ddth.queue.utils
- CountingSubscriber<ID,DATA> - Class in com.github.ddth.pubsub.impl
-
Count number of received messages.
- CountingSubscriber() - Constructor for class com.github.ddth.pubsub.impl.CountingSubscriber
- createAndInitQueue(QueueSpec) - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
-
Create & initialize a new queue instance.
- createChannel() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
- createCollection(MongoDatabase, String, CreateCollectionOptions) - Static method in class com.github.ddth.pubsub.internal.utils.MongoUtils
-
Create a new collection.
- createCollection(MongoDatabase, String, CreateCollectionOptions) - Static method in class com.github.ddth.queue.internal.utils.MongoUtils
-
Create a new collection.
- createMessage() - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Create a new, empty message.
- createMessage() - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessageFactory
-
Create a new, empty message.
- createMessage() - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessageFactory
-
Create a new, empty message.
- createMessage() - Method in interface com.github.ddth.pubsub.IPubSubHub
-
Create a new, empty message.
- createMessage() - Method in interface com.github.ddth.queue.IMessageFactory
-
Create a new, empty message.
- createMessage() - Method in class com.github.ddth.queue.IMessageFactory.EmptyMessageFactory
- createMessage() - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Create a new, empty queue message.
- createMessage() - Method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessageFactory
-
Create a new, empty queue message.
- createMessage() - Method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessageFactory
-
Create a new, empty queue message.
- createMessage() - Method in interface com.github.ddth.queue.IQueue
-
Create a new, empty queue message.
- createMessage() - Method in interface com.github.ddth.queue.IQueueMessageFactory
-
Create a new, empty queue message.
- createMessage(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessageFactory
-
Create a new message, supplying its initial data.
- createMessage(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessageFactory
-
Create a new message, supplying its initial data.
- createMessage(byte[]) - Method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessageFactory
-
Create a new queue message, supplying its initial data.
- createMessage(byte[]) - Method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessageFactory
-
Create a new queue message, supplying its initial data.
- createMessage(DATA) - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Create a new message, supplying its initial data.
- createMessage(DATA) - Method in interface com.github.ddth.pubsub.IPubSubHub
-
Create a new message, supplying its initial data.
- createMessage(DATA) - Method in interface com.github.ddth.queue.IMessageFactory
-
Create a new message, supplying its initial data.
- createMessage(DATA) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Create a new queue message with supplied content.
- createMessage(DATA) - Method in interface com.github.ddth.queue.IQueue
-
Create a new queue message with supplied content.
- createMessage(DATA) - Method in interface com.github.ddth.queue.IQueueMessageFactory
-
Create a new queue message, supplying its initial data.
- createMessage(ID, DATA) - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Create a new message, supplying its initial id and data.
- createMessage(ID, DATA) - Method in interface com.github.ddth.pubsub.IPubSubHub
-
Create a new message, supplying its initial id and data.
- createMessage(ID, DATA) - Method in interface com.github.ddth.queue.IMessageFactory
-
Create a new message, supplying its initial id and data.
- createMessage(ID, DATA) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Create a new queue message with supplied id and content.
- createMessage(ID, DATA) - Method in interface com.github.ddth.queue.IQueue
-
Create a new queue message with supplied id and content.
- createMessage(ID, DATA) - Method in interface com.github.ddth.queue.IQueueMessageFactory
-
Create a new queue message, supplying its initial id and data.
- createMessage(Long, byte[]) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessageFactory
-
Create a new message, supplying its initial id and data.
- createMessage(Long, byte[]) - Method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessageFactory
-
Create a new queue message, supplying its initial id and data.
- createMessage(Object) - Method in class com.github.ddth.queue.IMessageFactory.EmptyMessageFactory
- createMessage(Object, Object) - Method in class com.github.ddth.queue.IMessageFactory.EmptyMessageFactory
- createMessage(String, byte[]) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessageFactory
-
Create a new message, supplying its initial id and data.
- createMessage(String, byte[]) - Method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessageFactory
-
Create a new queue message, supplying its initial id and data.
- createMessge(Map<String, Object>) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
-
Create a message object from input data.
- createQueue(int) - Method in class com.github.ddth.queue.impl.InmemQueue
-
This method will create a
Queue
instance with the following rules: IfInmemQueue.boundary
is set and larger than1024
, aLinkedBlockingQueue
is created; ifInmemQueue.boundary
is less than or equals to1024
, anArrayBlockingQueue
is created instead. Otherwise, aConcurrentLinkedQueue
is created. - createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalActiveMqQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalDisruptorQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalInmemQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalKafkaQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalMongodbQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRabbitMqQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRedisQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRocksDbQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalActiveMqQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalDisruptorQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalInmemQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalKafkaQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalMongodbQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRabbitMqQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRedisQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRocksDbQueueFactory
-
Create a new queue instance.
- createQueueInstance(QueueSpec) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueueFactory
-
Create a new queue instance.
- createSession(int) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
D
- DEFAULT_BOOTSTRAP_SERVERS - Static variable in class com.github.ddth.queue.impl.KafkaQueue
- DEFAULT_CFNAME_EPHEMERAL - Static variable in class com.github.ddth.queue.impl.RocksDbQueue
- DEFAULT_CFNAME_METADATA - Static variable in class com.github.ddth.queue.impl.RocksDbQueue
- DEFAULT_CFNAME_QUEUE - Static variable in class com.github.ddth.queue.impl.RocksDbQueue
- DEFAULT_COLLECTION_NAME - Static variable in class com.github.ddth.queue.impl.MongodbQueue
- DEFAULT_CONN_STR - Static variable in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- DEFAULT_CONN_STR - Static variable in class com.github.ddth.queue.impl.MongodbQueue
- DEFAULT_CONSUMER_GROUP_ID - Static variable in class com.github.ddth.queue.impl.KafkaQueue
- DEFAULT_DATABASE_NAME - Static variable in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- DEFAULT_HASH_NAME - Static variable in class com.github.ddth.queue.impl.BaseRedisQueue
- DEFAULT_HOST_AND_PORT - Static variable in class com.github.ddth.pubsub.impl.RedisPubSubHub
- DEFAULT_HOST_AND_PORT - Static variable in class com.github.ddth.queue.impl.RedisQueue
- DEFAULT_LIST_NAME - Static variable in class com.github.ddth.queue.impl.BaseRedisQueue
- DEFAULT_MAX_COLLECTION_SIZE - Static variable in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- DEFAULT_MAX_DOCUMENTS - Static variable in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- DEFAULT_MAX_RETRIES - Static variable in class com.github.ddth.queue.impl.JdbcQueue
- DEFAULT_PASSWORD - Static variable in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
- DEFAULT_PASSWORD - Static variable in class com.github.ddth.queue.impl.BaseRedisQueue
- DEFAULT_PRODUCER_TYPE - Static variable in class com.github.ddth.queue.impl.KafkaQueue
- DEFAULT_QUEUE_NAME - Static variable in class com.github.ddth.queue.impl.ActiveMqQueue
- DEFAULT_QUEUE_NAME - Static variable in class com.github.ddth.queue.impl.RabbitMqQueue
- DEFAULT_SEND_ASYNC - Static variable in class com.github.ddth.queue.impl.KafkaQueue
- DEFAULT_SORTED_SET_NAME - Static variable in class com.github.ddth.queue.impl.BaseRedisQueue
- DEFAULT_STORAGE_DIR - Static variable in class com.github.ddth.queue.impl.RocksDbQueue
- DEFAULT_TOPIC_NAME - Static variable in class com.github.ddth.queue.impl.KafkaQueue
- DEFAULT_TRANX_ISOLATION_LEVEL - Static variable in class com.github.ddth.queue.impl.JdbcQueue
- DEFAULT_URI - Static variable in class com.github.ddth.queue.impl.ActiveMqQueue
- DEFAULT_URI - Static variable in class com.github.ddth.queue.impl.RabbitMqQueue
- deserialize(byte[]) - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Deserialize a message.
- deserialize(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.idint.UniversalMongodbPubSubHub
-
Deserialize a message.
- deserialize(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.idint.UniversalRedisPubSubHub
-
Deserialize a message.
- deserialize(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.idstr.UniversalMongodbPubSubHub
-
Deserialize a message.
- deserialize(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.idstr.UniversalRedisPubSubHub
-
Deserialize a message.
- deserialize(byte[]) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalActiveMqQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalKafkaQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalMongodbQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRabbitMqQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRedisQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRocksDbQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalActiveMqQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalKafkaQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalMongodbQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRabbitMqQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRedisQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[]) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRocksDbQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - deserialize(byte[], Class<T>) - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Deserialize a message.
- deserialize(byte[], Class<T>) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Deserialize a queue message from bytes (was generated by
AbstractQueue.serialize(IQueueMessage)
. - destroy() - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Clean-up method.
- destroy() - Method in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Destroy method.
- destroy() - Method in class com.github.ddth.pubsub.impl.InmemPubSubHub
-
Clean-up method.
- destroy() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Clean-up method.
- destroy() - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- destroy() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
- destroy() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
- destroy() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
- destroy() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
- destroy() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
Destroy method.
- destroy() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Destroy method.
- DisruptorQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
In-Memory implementation of
IQueue
using LMAX Disruptor library. - DisruptorQueue() - Constructor for class com.github.ddth.queue.impl.DisruptorQueue
- DisruptorQueue(int) - Constructor for class com.github.ddth.queue.impl.DisruptorQueue
- DisruptorQueueFactory<T extends DisruptorQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
DisruptorQueue
instances. - DisruptorQueueFactory() - Constructor for class com.github.ddth.queue.impl.DisruptorQueueFactory
- doPutToEphemeralStorage(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.AbstractInmemEphemeralQueue
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.DisruptorQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.InmemQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Put a message to the queue storage.
- doPutToQueue(IQueueMessage<ID, DATA>, AbstractQueue.PutToQueueCase) - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Put a message to the queue storage.
- doRemoveFromEphemeralStorage(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.AbstractInmemEphemeralQueue
- doSize(Connection, String, String, Object...) - Method in class com.github.ddth.queue.impl.JdbcQueue
E
- EmptyMessage() - Constructor for class com.github.ddth.queue.IMessage.EmptyMessage
- EmptyMessageFactory() - Constructor for class com.github.ddth.queue.IMessageFactory.EmptyMessageFactory
- EmptyQueueMessage() - Constructor for class com.github.ddth.queue.IQueueMessage.EmptyQueueMessage
- ensureEphemeralSize() - Method in class com.github.ddth.queue.impl.AbstractInmemEphemeralQueue
- ensureMessageType(IQueueMessage<ID, byte[]>, Class<X>) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
- EphemeralIsFull(int) - Constructor for exception com.github.ddth.queue.utils.QueueException.EphemeralIsFull
- ephemeralSize() - Method in class com.github.ddth.queue.impl.AbstractInmemEphemeralQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize() - Method in interface com.github.ddth.queue.IQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize(Connection) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize(Connection) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Get number of items currently in ephemeral storage.
- ephemeralSize(Connection) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Get number of items currently in ephemeral storage.
- equals(Object) - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
- equals(Object) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- equals(Object) - Method in class com.github.ddth.queue.QueueSpec
- executeWithRetries(int, int, boolean, Connection, String, Object...) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Execute a query, retry if deadlock.
- executeWithRetries(int, int, boolean, Connection, String, Map<String, Object>) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Execute a query, retry if deadlock.
- executeWithRetries(int, int, Supplier<T>) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Execute queries, retry if deadlock.
F
- FIELD_DATA - Static variable in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
- FIELD_DATA - Static variable in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- FIELD_EPHEMERAL_DISABLED - Static variable in class com.github.ddth.queue.QueueSpec
- FIELD_EPHEMERAL_MAX_SIZE - Static variable in class com.github.ddth.queue.QueueSpec
- FIELD_ID - Static variable in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
- FIELD_MAX_SIZE - Static variable in class com.github.ddth.queue.QueueSpec
- FIELD_NUM_REQUEUES - Static variable in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- FIELD_PARTITION_KEY - Static variable in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
- FIELD_PARTITION_KEY - Static variable in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- FIELD_QUEUE_ID - Static variable in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- FIELD_QUEUE_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- FIELD_TIMESTAMP - Static variable in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
- FIELD_TIMESTAMP - Static variable in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.DisruptorQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.InmemQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- finish(IQueueMessage<ID, DATA>) - Method in interface com.github.ddth.queue.IQueue
-
Called when finish processing the message to cleanup ephemeral storage.
- fromBytes(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
- fromBytes(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
- fromBytes(byte[]) - Method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
- fromBytes(byte[]) - Method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
- fromBytes(byte[], Class<T>) - Static method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Deserializes from a
byte[]
- which has been serialized byBaseUniversalMessage.toBytes()
. - fromBytes(byte[], Class<T>) - Static method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Deserializes from a
byte[]
- which has been serialized byBaseUniversalQueueMessage.toBytes()
. - fromDocument(Document) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- fromDocument(Document) - Method in class com.github.ddth.queue.impl.MongodbQueue
- fromJson(String) - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Deserialize queue message from a Json string.
- fromJson(String) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Deserialize queue message from a Json string.
- fromMap(Map<String, Object>) - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Deserialize queue message from a
Map
. - fromMap(Map<String, Object>) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
-
Deserialize queue message from a
Map
. - fromMap(Map<String, Object>) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
-
Deserialize queue message from a
Map
. - fromMap(Map<String, Object>) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Deserialize queue message from a
Map
. - fromMap(Map<String, Object>) - Method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
-
Deserialize queue message from a
Map
. - fromMap(Map<String, Object>) - Method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
-
Deserialize queue message from a
Map
.
G
- GenericMessage<ID,DATA> - Class in com.github.ddth.queue.impl
-
A generic implementation of
IMessage
- GenericMessage() - Constructor for class com.github.ddth.queue.impl.GenericMessage
- GenericQueueMessage<ID,DATA> - Class in com.github.ddth.queue.impl
-
A generic implementation of
IQueueMessage
- GenericQueueMessage() - Constructor for class com.github.ddth.queue.impl.GenericQueueMessage
- getAllCounters() - Method in class com.github.ddth.pubsub.impl.CountingSubscriber
-
Get all counters as
channel:value
. - getBinaryJedisCommands() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Get
BinaryJedisCommands
instance. - getBinaryJedisCommands() - Method in class com.github.ddth.queue.impl.RedisQueue
-
Get
BinaryJedisCommands
instance. - getBoundary() - Method in class com.github.ddth.queue.impl.InmemQueue
-
Gets queue's boundary (max number of elements).
- getCfNameEphemeral() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Name of the column-family to store ephemeral messages.
- getCfNameMetadata() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Name of the column-family to store metadata.
- getCfNameQueue() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Name of the column-family to store queue messages.
- getCollection() - Method in class com.github.ddth.queue.impl.MongodbQueue
- getCollectionName() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Name of MongoDB collection to store queue messages.
- getConnection() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
- getConnection() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
- getConnectionFactory() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Getter for
ActiveMqQueue.connectionFactory
. - getConnectionFactory() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Getter for
RabbitMqQueue.connectionFactory
. - getConnectionString() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Getter for
MongodbPubSubHub.connectionString
(see http://mongodb.github.io/mongo-java-driver/3.7/driver/getting-started/quick-start/). - getConnectionString() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
MongoDB's connection string (see http://mongodb.github.io/mongo-java-driver/3.10/driver/getting-started/quick-start/).
- getConsumerChannel() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Get the
Channel
dedicated for consuming messages. - getConsumerGroupId() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Kafka group-id to consume messages.
- getConsumerSession() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Get the
Session
dedicated for consuming messages. - getContent() - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Gets message's content.
- getContent() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Gets message's content.
- getContentAsString() - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Gets message's content as a String.
- getContentAsString() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Gets message's content as a String.
- getCounter(String) - Method in class com.github.ddth.pubsub.impl.CountingSubscriber
-
Get total number of received messages on a channel.
- getData() - Method in class com.github.ddth.queue.IMessage.EmptyMessage
- getData() - Method in interface com.github.ddth.queue.IMessage
-
Data/content attached to the queue message.
- getData() - Method in class com.github.ddth.queue.impl.GenericMessage
-
Data/content attached to the queue message.
- getDatabase() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- getDatabase() - Method in class com.github.ddth.queue.impl.MongodbQueue
- getDatabaseName() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Getter for
MongodbPubSubHub.databaseName
. - getDatabaseName() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Name of MongoDB database to store data.
- getDataSource() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Getter for
JdbcQueue.dataSource
. - getDefaultBootstrapServers() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default Kafka bootstrap server list (format
host1:9092,host2:port2,host3:port3
), passed to all queues created by this factory. - getDefaultCfNameEphemeral() - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Default name of the column-family to store ephemeral messages, passed to all queues created by this factory.
- getDefaultCfNameMetaData() - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Default name of the column-family to store metadata, passed to all queues created by this factory.
- getDefaultCfNameQueue() - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Default name of the column-family to store queue messages, passed to all queues created by this factory.
- getDefaultCollectionName() - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
Default name of MongoDB collection to store queue messages, passed to all queues created by this factory.
- getDefaultConnectionFactory() - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
If all
ActiveMqQueue
instances are connecting to one ActiveMQ broker, it's a good idea to pre-create anActiveMQConnectionFactory
instance and share it amongstActiveMqQueue
instances created from this factory by assigning it toActiveMqQueueFactory.defaultConnectionFactory
(seeActiveMqQueueFactory.setDefaultConnectionFactory(ActiveMQConnectionFactory)
). - getDefaultConnectionFactory() - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
If all
RabbitMqQueue
instances are connecting to one RabbitMQ broker, it's a good idea to pre-create anConnectionFactory
instance and share it amongstRabbitMqQueue
instances created from this factory by assigning it toRabbitMqQueueFactory.defaultConnectionFactory
(seeRabbitMqQueueFactory.setDefaultConnectionFactory(ConnectionFactory)
). - getDefaultConnectionString() - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
Default MongoDB's connection string (see http://mongodb.github.io/mongo-java-driver/3.10/driver/getting-started/quick-start/), passed to all queues created by this factory.
- getDefaultConsumerGroupId() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default Kafka group-id to consume messages, passed to all queues created by this factory.
- getDefaultConsumerProps() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default custom configuration properties for Kafka consumer, passed to all queues created by this factory.
- getDefaultDatabaseName() - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
Default name of MongoDB database to store data, passed to all queues created by this factory.
- getDefaultDataSource() - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
If all
JdbcQueue
instances are connecting to one database, it's a good idea to pre-create aDataSource
instance and share it amongstJdbcQueue
instances created from this factory by assigning it toJdbcQueueFactory.defaultDataSource
(seeJdbcQueueFactory.setDefaultDataSource(DataSource)
). - getDefaultEphemeralDisabled() - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- getDefaultEphemeralMaxSize() - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- getDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueueFactory
- getDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueueFactory
- getDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueueFactory
- getDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueueFactory
- getDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueueFactory
- getDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueueFactory
- getDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueueFactory
- getDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueueFactory
- getDefaultHashName() - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Name of the Redis hash to store queue messages.
- getDefaultHostAndPort() - Method in class com.github.ddth.queue.impl.RedisQueueFactory
-
Default Redis host and port scheme (format
host:port
), passed to all queues created by this factory. - getDefaultJdbcHelper() - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
If all
JdbcQueue
instances are connecting to oneDataSource
, it's a good idea to pre-create aIJdbcHelper
instance and share it amongstJdbcQueue
instances created from this factory by assigning it toJdbcQueueFactory.defaultJdbcHelper
(seeJdbcQueueFactory.setDefaultJdbcHelper(IJdbcHelper)
). - getDefaultJedisConnector() - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
If all
BaseRedisQueue
instances are connecting to one Redis server or cluster, it's a good idea to pre-create aJedisConnector
instance and share it amongstBaseRedisQueue
instances created from this factory by assigning it toBaseRedisQueueFactory.defaultJedisConnector
(seeBaseRedisQueueFactory.setDefaultJedisConnector(JedisConnector)
). - getDefaultKafkaClient() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
If all
KafkaQueue
instances are connecting to one Kafka broker, it's a good idea to pre-create aKafkaClient
instance and share it amongstKafkaQueue
instances created from this factory by assigning it toKafkaQueueFactory.defaultKafkaClient
(seeKafkaQueueFactory.setDefaultKafkaClient(KafkaClient)
). - getDefaultListName() - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Name of the Redis list to store queue message ids.
- getDefaultMaxRetries() - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Default max number of retires for DB-operations, passed to all queues created by this factory.
- getDefaultMaxSize() - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- getDefaultMongoClient() - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
If all
MongodbQueue
instances are connecting to one MongoDB server or cluster, it's a good idea to pre-create aMongoClient
instance and share it amongstMongodbQueue
instances created from this factory by assigning it toMongodbQueueFactory.defaultMongoClient
(seeMongodbQueueFactory.setDefaultMongoClient(MongoClient)
). - getDefaultPassword() - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Default password to connect to ActiveMQ server, passed to all queues created by this factory.
- getDefaultPassword() - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Redis' password.
- getDefaultProducerProps() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default custom configuration properties for Kafka producer, passed to all queues created by this factory.
- getDefaultProducerType() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default Kafka's producer type, used to send messages (default
KafkaClient.ProducerType.LEADER_ACK
), passed to all queues created by this factory. - getDefaultQueueName() - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Default name of ActiveMQ queue to send/receive messages, passed to all queues created by this factory.
- getDefaultQueueName() - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
Default name of RabbitMQ queue to send/receive messages, passed to all queues created by this factory.
- getDefaultSendAsync() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Should messages sent to Kafka asynchronously (default
true
)? - getDefaultSortedSetName() - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Name of the Redis sorted-set to store ephemeral message ids.
- getDefaultTableName() - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Default name of database table to store queue messages, passed to all queues created by this factory.
- getDefaultTableNameEphemeral() - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Default name of database table to store ephemeral messages, passed to all queues created by this factory.
- getDefaultTopicName() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default name of Kafka topic to store queue messages, passed to all queues created by this factory.
- getDefaultTransactionIsolationLevel() - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Default transaction isolation level used in DB-operations, passed to all queues created by this factory.
- getDefaultUri() - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Default ActiveMQ's connection URI, passed to all queues created by this factory (see http://activemq.apache.org/connection-configuration-uri.html).
- getDefaultUri() - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
Default RabbitMQ's connection URI (format
amqp://username:password@host:port/virtualHost
), passed to all queues created by this factory. - getDefaultUsername() - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Default username to connect to ActiveMQ server, passed to all queues created by this factory.
- getEphemeralDisabled() - Method in class com.github.ddth.queue.impl.AbstractEphemeralSupportQueue
-
Is ephemeral storage disabled?
- getEphemeralMaxSize() - Method in class com.github.ddth.queue.impl.AbstractEphemeralSupportQueue
-
Return a positive integer as max number of items can be stored in the ephemeral storage.
- getField(String) - Method in class com.github.ddth.queue.QueueSpec
-
Get a field's value.
- getField(String, Class<T>) - Method in class com.github.ddth.queue.QueueSpec
-
Get a field's value.
- getFieldOptional(String, Class<T>) - Method in class com.github.ddth.queue.QueueSpec
-
Get a field's value.
- getFifo() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
-
Alias of
BaseUniversalJdbcQueue.isFifo()
. - getId() - Method in class com.github.ddth.queue.IMessage.EmptyMessage
- getId() - Method in interface com.github.ddth.queue.IMessage
-
Message's unique id in queue.
- getId() - Method in class com.github.ddth.queue.impl.GenericMessage
-
Message's unique id in queue.
- getJdbcHelper() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Getter for
JdbcQueue.jdbcHelper
. - getJedisConnector() - Method in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Get the current
JedisConnector
used by this pubsub-hub. - getJedisConnector() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Get the current
JedisConnector
used by this queue. - getKafkaBootstrapServers() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Kafka bootstrap server list (format
host1:9092,host2:port2,host3:port3
). - getKafkaClient() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
An external
KafkaClient
can be used. - getKafkaConsumerProperties() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Custom configuration properties for Kafka consumer.
- getKafkaProducerProperties() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Custom configuration properties for Kafka producer.
- getMaxCollectionSize() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Max collection's size in bytes.
- getMaxDocuments() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Max number of document per pub/sub collection.
- getMaxRetries() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Max number of retires for DB-operations.
- getMessageConsumer() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
- getMessageFactory() - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Factory to create messages.
- getMessageFactory() - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Factory to create queue messages.
- getMessageProducer() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
- getMongoClient() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Getter for
MongodbPubSubHub.mongoClient
. - getMongoClient() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Getter for
MongodbQueue.mongoClient
. - getNumRequeues() - Method in class com.github.ddth.queue.impl.GenericQueueMessage
-
How many times message has been re-queued?
- getNumRequeues() - Method in class com.github.ddth.queue.IQueueMessage.EmptyQueueMessage
- getNumRequeues() - Method in interface com.github.ddth.queue.IQueueMessage
-
How many times message has been re-queued?
- getOrphanMessages(long) - Method in class com.github.ddth.queue.impl.AbstractInmemEphemeralQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessages(long) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessages(long) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessages(long) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessages(long) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessages(long) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessages(long) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessages(long) - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessages(long) - Method in interface com.github.ddth.queue.IQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessagesFromEphemeralStorage(Connection, long) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Primitive operation: Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessagesFromEphemeralStorage(Connection, long) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Primitive operation: Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessagesFromEphemeralStorage(Connection, long) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Primitive operation: Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessagesFromEphemeralStorage(Connection, long) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Primitive operation: Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessagesFromEphemeralStorage(Connection, long) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Primitive operation: Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessagesFromEphemeralStorage(Connection, long) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Primitive operation: Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getOrphanMessagesFromEphemeralStorage(Connection, long) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Primitive operation: Get all orphan messages (messages that were left in ephemeral storage for a long time).
- getPartitionKey() - Method in class com.github.ddth.queue.impl.GenericMessage
-
Key used for partitioning messages (some queue implementations, such as Kafka queue, support message partitioning).
- getPartitionKey() - Method in interface com.github.ddth.queue.IPartitionSupport
-
Key used for partitioning messages (some queue implementations, such as Kafka queue, support message partitioning).
- getPassword() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Password to connect to ActiveMQ server.
- getProducerChannel() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Get the
Channel
dedicated for sending messages. - getProducerSession() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Get the
Session
dedicated for sending messages. - getProducerType() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Kafka's producer type, used to send messages (default
KafkaClient.ProducerType.LEADER_ACK
). - getQueue(QueueSpec) - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
-
Gets an
IQueue
instance. - getQueue(QueueSpec) - Method in interface com.github.ddth.queue.IQueueFactory
-
Gets an
IQueue
instance. - getQueueName() - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Queue's name.
- getQueueName() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Name of ActiveMQ queue to send/receive messages.
- getQueueName() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Name of RabbitMQ queue to send/receive messages.
- getQueueTimestamp() - Method in class com.github.ddth.queue.impl.GenericQueueMessage
-
Get message's last-queued timestamp.
- getQueueTimestamp() - Method in class com.github.ddth.queue.IQueueMessage.EmptyQueueMessage
- getQueueTimestamp() - Method in interface com.github.ddth.queue.IQueueMessage
-
Get message's last-queued timestamp.
- getRedisHashName() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis hash to store queue messages.
- getRedisHashNameAsBytes() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis hash to store queue messages.
- getRedisHostAndPort() - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Redis' host and port scheme (format
host:port
). - getRedisHostAndPort() - Method in class com.github.ddth.queue.impl.RedisQueue
-
Redis host and port scheme (format
host:port
). - getRedisListName() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis list to store queue message ids.
- getRedisListNameAsBytes() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis list to store queue message ids.
- getRedisPassword() - Method in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Password to connect to Redis.
- getRedisPassword() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Redis' password.
- getRedisSortedSetName() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis sorted-set to store ephemeral message ids.
- getRedisSortedSetNameAsBytes() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis sorted-set to store ephemeral message ids.
- getRingSize() - Method in class com.github.ddth.queue.impl.DisruptorQueue
-
Size of the ring buffer, should be power of 2.
- getRootStorageDir() - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Root directory to store RocksDB's data.
- getScriptTake() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
LUA script to take a message out of queue.
- getScriptTakeAsBytes() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
LUA script to take a message out of queue.
- getSerDeser() - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Message serializer/deserializer.
- getSerDeser() - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Message serializer/deserializer.
- getStorageDir() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Directory to store RocksDB data files.
- getTableName() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Name of database table to store queue messages.
- getTableNameEphemeral() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Name of database table to store ephemeral messages.
- getTableNameEphemeral() - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Name of database table to store ephemeral messages.
- getTableNameEphemeral() - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Name of database table to store ephemeral messages.
- getTimestamp() - Method in class com.github.ddth.queue.IMessage.EmptyMessage
- getTimestamp() - Method in interface com.github.ddth.queue.IMessage
-
Message's timestamp.
- getTimestamp() - Method in class com.github.ddth.queue.impl.GenericMessage
-
Message's timestamp.
- getTopicName() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Name of Kafka topic to store queue messages.
- getTotalMessages() - Method in class com.github.ddth.pubsub.impl.CountingSubscriber
-
Get total number of received messages.
- getTransactionIsolationLevel() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Transaction isolation level used in DB-operations.
- getUri() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
ActiveMQ's connection URI (see http://activemq.apache.org/connection-configuration-uri.html).
- getUri() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
RabbitMQ's connection URI (format
amqp://username:password@host:port/virtualHost
). - getUsername() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Username to connect to ActiveMQ server.
H
- hashCode() - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
- hashCode() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
- hashCode() - Method in class com.github.ddth.queue.QueueSpec
I
- IDGEN - Static variable in class com.github.ddth.pubsub.internal.utils.PubSubUtils
- IDGEN - Static variable in class com.github.ddth.queue.internal.utils.QueueUtils
- IMessage<ID,DATA> - Interface in com.github.ddth.queue
-
Represent a message.
- IMessage.EmptyMessage - Class in com.github.ddth.queue
-
An empty message.
- IMessageFactory<ID,DATA> - Interface in com.github.ddth.queue
-
Factory to create
IMessage
s. - IMessageFactory.EmptyMessageFactory - Class in com.github.ddth.queue
- incNumRequeues() - Method in class com.github.ddth.queue.impl.GenericQueueMessage
-
Increase message's number of re-queue times by 1.
- incNumRequeues() - Method in class com.github.ddth.queue.IQueueMessage.EmptyQueueMessage
- incNumRequeues() - Method in interface com.github.ddth.queue.IQueueMessage
-
Increase message's number of re-queue times by 1.
- init() - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Initializing method.
- init() - Method in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Init method.
- init() - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Initializing method.
- init() - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Init method.
- init() - Method in class com.github.ddth.pubsub.impl.universal.idint.UniversalInmemPubSubHub
-
Initializing method.
- init() - Method in class com.github.ddth.pubsub.impl.universal.idint.UniversalMongodbPubSubHub
-
Initializing method.
- init() - Method in class com.github.ddth.pubsub.impl.universal.idint.UniversalRedisPubSubHub
-
Init method.
- init() - Method in class com.github.ddth.pubsub.impl.universal.idstr.UniversalInmemPubSubHub
-
Initializing method.
- init() - Method in class com.github.ddth.pubsub.impl.universal.idstr.UniversalMongodbPubSubHub
-
Initializing method.
- init() - Method in class com.github.ddth.pubsub.impl.universal.idstr.UniversalRedisPubSubHub
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- init() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.DisruptorQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.InmemQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.AbstractLessLockingUniversalJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.AbstractLessLockingUniversalSingleStorageJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalActiveMqQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalDisruptorQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalInmemQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalKafkaQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalMongodbQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRabbitMqQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRedisQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalRocksDbQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.AbstractLessLockingUniversalJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.AbstractLessLockingUniversalSingleStorageJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalActiveMqQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalDisruptorQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalInmemQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Initializing method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalKafkaQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalMongodbQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRabbitMqQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRedisQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalRocksDbQueue
-
Init method.
- init() - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Initializing method.
- initCollection() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Initialize collection: Check if collection exists. If collection does not exist, create collection and indexes.
- initEphemeralStorage(int) - Method in class com.github.ddth.queue.impl.AbstractInmemEphemeralQueue
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.DisruptorQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.InmemQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.RedisQueueFactory
-
Initialize a newly created queue instance.
- initQueue(T, QueueSpec) - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Initialize a newly created queue instance.
- InmemPubSubHub<ID,DATA> - Class in com.github.ddth.pubsub.impl
-
In-memory implementation of
IPubSubHub
. - InmemPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.InmemPubSubHub
- InmemQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
In-Memory implementation of
IQueue
. - InmemQueue() - Constructor for class com.github.ddth.queue.impl.InmemQueue
- InmemQueue(int) - Constructor for class com.github.ddth.queue.impl.InmemQueue
- InmemQueueFactory<T extends InmemQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
InmemQueue
instances. - InmemQueueFactory() - Constructor for class com.github.ddth.queue.impl.InmemQueueFactory
- insertToCollection(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Insert a new message to collection.
- INSTANCE - Static variable in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessageFactory
- INSTANCE - Static variable in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessageFactory
- INSTANCE - Static variable in class com.github.ddth.queue.IMessage.EmptyMessage
- INSTANCE - Static variable in class com.github.ddth.queue.IMessageFactory.EmptyMessageFactory
- INSTANCE - Static variable in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessageFactory
- INSTANCE - Static variable in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessageFactory
- IPartitionSupport - Interface in com.github.ddth.queue
-
Marker for message partitioning support.
- IPubSubHub<ID,DATA> - Interface in com.github.ddth.pubsub
-
API interface to publish messages and subscribe to channels for messages.
- IQueue<ID,DATA> - Interface in com.github.ddth.queue
-
APIs to interact with queue.
- IQueueFactory<ID,DATA> - Interface in com.github.ddth.queue
-
Factory to create
IQueue
instances. - IQueueMessage<ID,DATA> - Interface in com.github.ddth.queue
-
Represents a queue message.
- IQueueMessage.EmptyQueueMessage - Class in com.github.ddth.queue
-
An empty queue message.
- IQueueMessageFactory<ID,DATA> - Interface in com.github.ddth.queue
-
Factory to create
IQueueMessage
s. - isDefaultEphemeralDisabled() - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- isDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueueFactory
-
Deprecated.
- isDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueueFactory
-
Deprecated.
- isDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueueFactory
- isDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueueFactory
- isDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueueFactory
-
Deprecated.
- isDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueueFactory
- isDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueueFactory
- isDefaultFifo() - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueueFactory
- isDefaultSendAsync() - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Should messages sent to Kafka asynchronously (default
true
)? - isEphemeralDisabled() - Method in class com.github.ddth.queue.impl.AbstractEphemeralSupportQueue
-
Is ephemeral storage disabled?
- isFifo() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
-
If
true
, queue message with lower id is ensured to be taken first. - isReady() - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Return
true
if this hub is ready for subscribing. - isSendAsync() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Should messages sent to Kafka asynchronously (default
true
)? - ISubscriber<ID,DATA> - Interface in com.github.ddth.pubsub
-
API interface used to subscribe to message channels.
J
- JdbcQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
Abstract JDBC implementation of
IQueue
. - JdbcQueue() - Constructor for class com.github.ddth.queue.impl.JdbcQueue
- JdbcQueueFactory<T extends JdbcQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
JdbcQueue
instances. - JdbcQueueFactory() - Constructor for class com.github.ddth.queue.impl.JdbcQueueFactory
K
- KafkaQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
(Experimental) Kafka implementation of
IQueue
. - KafkaQueue() - Constructor for class com.github.ddth.queue.impl.KafkaQueue
- KafkaQueueFactory<T extends KafkaQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
KafkaQueue
instances. - KafkaQueueFactory() - Constructor for class com.github.ddth.queue.impl.KafkaQueueFactory
L
- LessLockingUniversalMySQLQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Same as
UniversalJdbcQueue
, but using a "less-locking" algorithm - specific for MySQL, requires only one single db table for both queue and ephemeral storage. - LessLockingUniversalMySQLQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Same as
UniversalJdbcQueue
, but using a "less-locking" algorithm - specific for MySQL, requires only one single db table for both queue and ephemeral storage. - LessLockingUniversalMySQLQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueue
- LessLockingUniversalMySQLQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueue
- LessLockingUniversalMySQLQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
LessLockingUniversalMySQLQueue
instances. - LessLockingUniversalMySQLQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
LessLockingUniversalMySQLQueue
instances. - LessLockingUniversalMySQLQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueueFactory
- LessLockingUniversalMySQLQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueueFactory
- LessLockingUniversalPgSQLQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Same as
UniversalJdbcQueue
, but using a "less-locking" algorithm - specific for PgSQL, requires only one single db table for both queue and ephemeral storage. - LessLockingUniversalPgSQLQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Same as
UniversalJdbcQueue
, but using a "less-locking" algorithm - specific for PgSQL, requires only one single db table for both queue and ephemeral storage. - LessLockingUniversalPgSQLQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueue
- LessLockingUniversalPgSQLQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueue
- LessLockingUniversalPgSQLQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
LessLockingUniversalPgSQLQueue
instances. - LessLockingUniversalPgSQLQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
LessLockingUniversalPgSQLQueue
instances. - LessLockingUniversalPgSQLQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueueFactory
- LessLockingUniversalPgSQLQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueueFactory
- LessLockingUniversalSingleStorageMySQLQueue - Class in com.github.ddth.queue.impl.universal.idint
-
MySQL-specific implementation of
AbstractLessLockingUniversalSingleStorageJdbcQueue
. - LessLockingUniversalSingleStorageMySQLQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
MySQL-specific implementation of
AbstractLessLockingUniversalSingleStorageJdbcQueue
. - LessLockingUniversalSingleStorageMySQLQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueue
- LessLockingUniversalSingleStorageMySQLQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueue
- LessLockingUniversalSingleStorageMySQLQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
LessLockingUniversalSingleStorageMySQLQueue
instances. - LessLockingUniversalSingleStorageMySQLQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
LessLockingUniversalSingleStorageMySQLQueue
instances. - LessLockingUniversalSingleStorageMySQLQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueueFactory
- LessLockingUniversalSingleStorageMySQLQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueueFactory
- LessLockingUniversalSingleStoragePgSQLQueue - Class in com.github.ddth.queue.impl.universal.idint
-
PostgreSQL-specific implementation of
AbstractLessLockingUniversalSingleStorageJdbcQueue
. - LessLockingUniversalSingleStoragePgSQLQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
PostgreSQL-specific implementation of
AbstractLessLockingUniversalSingleStorageJdbcQueue
. - LessLockingUniversalSingleStoragePgSQLQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueue
- LessLockingUniversalSingleStoragePgSQLQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueue
- LessLockingUniversalSingleStoragePgSQLQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
LessLockingUniversalPgSQLQueue
instances. - LessLockingUniversalSingleStoragePgSQLQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
LessLockingUniversalPgSQLQueue
instances. - LessLockingUniversalSingleStoragePgSQLQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueueFactory
- LessLockingUniversalSingleStoragePgSQLQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueueFactory
M
- markFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
-
When set to
true
, queue message with lower id is ensured to be taken first. - MongodbPubSubHub<ID,DATA> - Class in com.github.ddth.pubsub.impl
-
(Experimental) MongoDB implementation of
IPubSubHub
. - MongodbPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.MongodbPubSubHub
- MongodbQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
(Experimental) MongoDB implementation of
IQueue
. - MongodbQueue() - Constructor for class com.github.ddth.queue.impl.MongodbQueue
- MongodbQueueFactory<T extends MongodbQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
MongodbQueue
instances. - MongodbQueueFactory() - Constructor for class com.github.ddth.queue.impl.MongodbQueueFactory
- MongoUtils - Class in com.github.ddth.pubsub.internal.utils
-
MongoDB utility class.
- MongoUtils - Class in com.github.ddth.queue.internal.utils
-
MongoDB utility class.
- MongoUtils() - Constructor for class com.github.ddth.pubsub.internal.utils.MongoUtils
- MongoUtils() - Constructor for class com.github.ddth.queue.internal.utils.MongoUtils
- myOwnRedis - Variable in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Flag to mark if the Redis resource (e.g.
- myOwnRedis - Variable in class com.github.ddth.queue.impl.BaseRedisQueue
-
Flag to mark if the Redis resource (e.g.
- myOwnRedis - Variable in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Flag to mark if the Redis resource (e.g.
N
- name - Variable in class com.github.ddth.queue.QueueSpec
- NEW - com.github.ddth.queue.impl.AbstractQueue.PutToQueueCase
- newInstance() - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
-
Create a new
UniversalIdIntMessage
object. - newInstance() - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
-
Creates a new
UniversalIdStrMessage
object. - newInstance() - Static method in class com.github.ddth.queue.impl.GenericMessage
- newInstance() - Static method in class com.github.ddth.queue.impl.GenericQueueMessage
- newInstance() - Static method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
-
Create a new
UniversalIdIntQueueMessage
object. - newInstance() - Static method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
-
Creates a new
UniversalIdStrQueueMessage
object. - newInstance(byte[]) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
-
Create a new
UniversalIdIntMessage
object with specified content. - newInstance(byte[]) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
-
Create a new
UniversalIdStrMessage
object with specified content. - newInstance(byte[]) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
-
Create a new
UniversalIdIntQueueMessage
object with specified content. - newInstance(byte[]) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
-
Create a new
UniversalIdStrQueueMessage
object with specified content. - newInstance(DATA) - Static method in class com.github.ddth.queue.impl.GenericMessage
- newInstance(DATA) - Static method in class com.github.ddth.queue.impl.GenericQueueMessage
- newInstance(ID, DATA) - Static method in class com.github.ddth.queue.impl.GenericMessage
- newInstance(ID, DATA) - Static method in class com.github.ddth.queue.impl.GenericQueueMessage
- newInstance(Long, byte[]) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
-
Create a new
UniversalIdIntMessage
object with specified id and content. - newInstance(Long, byte[]) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
-
Create a new
UniversalIdIntQueueMessage
object with specified id and content. - newInstance(Long, String) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
-
Create a new
UniversalIdIntMessage
object with specified id and content. - newInstance(Long, String) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
-
Create a new
UniversalIdIntQueueMessage
object with specified id and content. - newInstance(String) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
-
Create a new
UniversalIdIntMessage
object with specified content. - newInstance(String) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
-
Create a new
UniversalIdStrMessage
object with specified content. - newInstance(String) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
-
Create a new
UniversalIdIntQueueMessage
object with specified content. - newInstance(String) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
-
Create a new
UniversalIdStrQueueMessage
object with specified content. - newInstance(String, byte[]) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
-
Create a new
UniversalIdStrMessage
object with specified id and content. - newInstance(String, byte[]) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
-
Create a new
UniversalIdStrQueueMessage
object with specified id and content. - newInstance(String, String) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
-
Create a new
UniversalIdStrMessage
object with specified id and content. - newInstance(String, String) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
-
Create a new
UniversalIdStrQueueMessage
object with specified id and content. - newInstance(Map<String, Object>) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
-
Create a new
UniversalIdIntMessage
. - newInstance(Map<String, Object>) - Static method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
-
Create a new
UniversalIdStrMessage
. - newInstance(Map<String, Object>) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
-
Create a new
UniversalIdIntQueueMessage
. - newInstance(Map<String, Object>) - Static method in class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
-
Create a new
UniversalIdStrQueueMessage
. - NO_BOUNDARY - Static variable in class com.github.ddth.queue.QueueSpec
O
- onMessage(String, UniversalIdIntMessage) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntSubscriber
-
Sub-class override this method to implement its own business logic.
- onMessage(String, UniversalIdStrMessage) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrSubscriber
-
Sub-class override this method to implement its own business logic.
- onMessage(String, IMessage<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.CountingSubscriber
-
Called when a message arrives on a channel.
- onMessage(String, IMessage<ID, DATA>) - Method in interface com.github.ddth.pubsub.ISubscriber
-
Called when a message arrives on a channel.
- onMessage(String, IMessage<Long, byte[]>) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdIntSubscriber
-
Called when a message arrives on a channel.
- onMessage(String, IMessage<String, byte[]>) - Method in class com.github.ddth.pubsub.impl.universal.UniversalIdStrSubscriber
-
Called when a message arrives on a channel.
- OperationNotSupported() - Constructor for exception com.github.ddth.queue.utils.QueueException.OperationNotSupported
- OperationNotSupported(String) - Constructor for exception com.github.ddth.queue.utils.QueueException.OperationNotSupported
P
- peekFromQueueStorage(Connection) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Primitive operation: Read (but not removed) message from head of queue storage.
- peekFromQueueStorage(Connection) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Primitive operation: Read (but not removed) message from head of queue storage.
- peekFromQueueStorage(Connection) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Primitive operation: Read (but not removed) message from head of queue storage.
- peekFromQueueStorage(Connection) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Primitive operation: Read (but not removed) message from head of queue storage.
- peekFromQueueStorage(Connection) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Primitive operation: Read (but not removed) message from head of queue storage.
- peekFromQueueStorage(Connection) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Primitive operation: Read (but not removed) message from head of queue storage.
- peekFromQueueStorage(Connection) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Primitive operation: Read (but not removed) message from head of queue storage.
- publish(String, IMessage<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.InmemPubSubHub
-
Publish a message to a channel.
- publish(String, IMessage<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Publish a message to a channel.
- publish(String, IMessage<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Publish a message to a channel.
- publish(String, IMessage<ID, DATA>) - Method in interface com.github.ddth.pubsub.IPubSubHub
-
Publish a message to a channel.
- PubSubUtils - Class in com.github.ddth.pubsub.internal.utils
-
Utilities and Constants
- PubSubUtils() - Constructor for class com.github.ddth.pubsub.internal.utils.PubSubUtils
- putToEphemeralStorage(Connection, IQueueMessage<ID, byte[]>) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Primitive operation: Put a message to the ephemeral storage.
- putToEphemeralStorage(Connection, IQueueMessage<ID, byte[]>) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Primitive operation: Put a message to the ephemeral storage.
- putToEphemeralStorage(Connection, IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Primitive operation: Put a message to the ephemeral storage.
- putToEphemeralStorage(Connection, IQueueMessage<Long, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Primitive operation: Put a message to the ephemeral storage.
- putToEphemeralStorage(Connection, IQueueMessage<Long, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Primitive operation: Put a message to the ephemeral storage.
- putToEphemeralStorage(Connection, IQueueMessage<String, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Primitive operation: Put a message to the ephemeral storage.
- putToEphemeralStorage(Connection, IQueueMessage<String, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Primitive operation: Put a message to the ephemeral storage.
- putToQueueStorage(Connection, IQueueMessage<ID, byte[]>) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Primitive operation: Put a message to tail of the queue storage.
- putToQueueStorage(Connection, IQueueMessage<ID, byte[]>) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Primitive operation: Put a message to tail of the queue storage.
- putToQueueStorage(Connection, IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Primitive operation: Put a message to tail of the queue storage.
- putToQueueStorage(Connection, IQueueMessage<Long, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Primitive operation: Put a message to tail of the queue storage.
- putToQueueStorage(Connection, IQueueMessage<Long, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Primitive operation: Put a message to tail of the queue storage.
- putToQueueStorage(Connection, IQueueMessage<String, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Primitive operation: Put a message to tail of the queue storage.
- putToQueueStorage(Connection, IQueueMessage<String, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Primitive operation: Put a message to tail of the queue storage.
Q
- queue(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Queue a message.
- queue(IQueueMessage<ID, DATA>) - Method in interface com.github.ddth.queue.IQueue
-
Queue a message.
- QueueException - Exception in com.github.ddth.queue.utils
-
Thrown to indicate that there has been an error with queue oeration.
- QueueException() - Constructor for exception com.github.ddth.queue.utils.QueueException
- QueueException(String) - Constructor for exception com.github.ddth.queue.utils.QueueException
- QueueException(String, Throwable) - Constructor for exception com.github.ddth.queue.utils.QueueException
- QueueException(String, Throwable, boolean, boolean) - Constructor for exception com.github.ddth.queue.utils.QueueException
- QueueException(Throwable) - Constructor for exception com.github.ddth.queue.utils.QueueException
- QueueException.CannotDeserializeQueueMessage - Exception in com.github.ddth.queue.utils
-
Thrown to indicate that the queue message can not be deserialized.
- QueueException.CannotSerializeQueueMessage - Exception in com.github.ddth.queue.utils
-
Thrown to indicate that the queue message can not be serialized.
- QueueException.EphemeralIsFull - Exception in com.github.ddth.queue.utils
-
Thrown to indicate that the ephemeral storage is full.
- QueueException.OperationNotSupported - Exception in com.github.ddth.queue.utils
-
Thrown to indicate that the queue implementation does not support the invoked operation.
- QueueException.QueueIsFull - Exception in com.github.ddth.queue.utils
-
Thrown to indicate that the queue storage is full.
- QueueIsFull(int) - Constructor for exception com.github.ddth.queue.utils.QueueException.QueueIsFull
- queueSize() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in class com.github.ddth.queue.impl.DisruptorQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in class com.github.ddth.queue.impl.InmemQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Get number of items currently in queue storage.
- queueSize() - Method in interface com.github.ddth.queue.IQueue
-
Get number of items currently in queue storage.
- queueSize(Connection) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Get number of items currently in queue storage.
- queueSize(Connection) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Get number of items currently in queue storage.
- queueSize(Connection) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Get number of items currently in queue storage.
- QueueSpec - Class in com.github.ddth.queue
- QueueSpec() - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(boolean) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(boolean, int) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(boolean, int, int) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(int) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(int, int) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(String) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(String, boolean) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(String, boolean, int) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(String, boolean, int, int) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(String, int) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueSpec(String, int, int) - Constructor for class com.github.ddth.queue.QueueSpec
- QueueUtils - Class in com.github.ddth.queue.internal.utils
-
Utilities and Constants
- QueueUtils() - Constructor for class com.github.ddth.queue.internal.utils.QueueUtils
R
- RabbitMqQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
(Experimental) RabbitMQ implementation of
IQueue
. - RabbitMqQueue() - Constructor for class com.github.ddth.queue.impl.RabbitMqQueue
- RabbitMqQueueFactory<T extends RabbitMqQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
RabbitMqQueue
instances. - RabbitMqQueueFactory() - Constructor for class com.github.ddth.queue.impl.RabbitMqQueueFactory
- readFromEphemeralStorage(Connection, IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Deprecated.deprecated since 1.0.0, use
JdbcQueue.readFromEphemeralStorage(Connection, Object)
- readFromEphemeralStorage(Connection, ID) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Primitive operation: Read (but not removed) a message from the ephemeral storage.
- readFromEphemeralStorage(Connection, ID) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Primitive operation: Read (but not removed) a message from the ephemeral storage.
- readFromEphemeralStorage(Connection, ID) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Primitive operation: Read (but not removed) a message from the ephemeral storage.
- readFromEphemeralStorage(Connection, Long) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Primitive operation: Read (but not removed) a message from the ephemeral storage.
- readFromEphemeralStorage(Connection, Long) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Primitive operation: Read (but not removed) a message from the ephemeral storage.
- readFromEphemeralStorage(Connection, String) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Primitive operation: Read (but not removed) a message from the ephemeral storage.
- readFromEphemeralStorage(Connection, String) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Primitive operation: Read (but not removed) a message from the ephemeral storage.
- RedisPubSubHub<ID,DATA> - Class in com.github.ddth.pubsub.impl
-
Redis implementation of
IPubSubHub
. - RedisPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.RedisPubSubHub
- RedisQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
Redis implementation of
IQueue
. - RedisQueue() - Constructor for class com.github.ddth.queue.impl.RedisQueue
- RedisQueueFactory<T extends RedisQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
RedisQueue
instances. - RedisQueueFactory() - Constructor for class com.github.ddth.queue.impl.RedisQueueFactory
- RedisUtils - Class in com.github.ddth.pubsub.internal.utils
-
Internal Redis utility class.
- RedisUtils - Class in com.github.ddth.queue.internal.utils
-
Internal Redis utility class.
- RedisUtils() - Constructor for class com.github.ddth.pubsub.internal.utils.RedisUtils
- RedisUtils() - Constructor for class com.github.ddth.queue.internal.utils.RedisUtils
- remove(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Remove a message completely.
- remove(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.RedisQueue
-
Remove a message completely.
- removeFromEphemeralStorage(Connection, IQueueMessage<ID, byte[]>) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromEphemeralStorage(Connection, IQueueMessage<ID, byte[]>) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
- removeFromEphemeralStorage(Connection, IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromEphemeralStorage(Connection, IQueueMessage<Long, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromEphemeralStorage(Connection, IQueueMessage<Long, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromEphemeralStorage(Connection, IQueueMessage<String, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromEphemeralStorage(Connection, IQueueMessage<String, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromQueueStorage(Connection, IQueueMessage<ID, byte[]>) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromQueueStorage(Connection, IQueueMessage<ID, byte[]>) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromQueueStorage(Connection, IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromQueueStorage(Connection, IQueueMessage<Long, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromQueueStorage(Connection, IQueueMessage<Long, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromQueueStorage(Connection, IQueueMessage<String, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- removeFromQueueStorage(Connection, IQueueMessage<String, byte[]>) - Method in class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
-
Primitive operation: Remove a message from the queue storage.
- requeue(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Re-queue a message.
- requeue(IQueueMessage<ID, DATA>) - Method in interface com.github.ddth.queue.IQueue
-
Re-queue a message.
- REQUEUE - com.github.ddth.queue.impl.AbstractQueue.PutToQueueCase
- REQUEUE_SILENT - com.github.ddth.queue.impl.AbstractQueue.PutToQueueCase
- requeueSilent(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Silently re-queue a message.
- requeueSilent(IQueueMessage<ID, DATA>) - Method in interface com.github.ddth.queue.IQueue
-
Silently re-queue a message.
- resetCounter() - Method in class com.github.ddth.pubsub.impl.CountingSubscriber
-
Reset counter to value zero.
- RocksDbQueue<ID,DATA> - Class in com.github.ddth.queue.impl
-
RocksDB implementation of
IQueue
. - RocksDbQueue() - Constructor for class com.github.ddth.queue.impl.RocksDbQueue
- RocksDbQueueFactory<T extends RocksDbQueue<ID,DATA>,ID,DATA> - Class in com.github.ddth.queue.impl
-
Factory to create
RocksDbQueue
instances. - RocksDbQueueFactory() - Constructor for class com.github.ddth.queue.impl.RocksDbQueueFactory
S
- selectMessages(Connection, String, Map<String, Object>) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
-
Convenient method to query list of messages.
- serialize(IMessage<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Serialize a queue message to store in Redis.
- serialize(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Serialize a queue message to bytes.
- setBoundary(int) - Method in class com.github.ddth.queue.impl.InmemQueue
-
Sets queue's boundary (max number of elements).
- setCfNameEphemeral(String) - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Name of the column-family to store ephemeral messages.
- setCfNameMetadata(String) - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Name of the column-family to store metadata.
- setCfNameQueue(String) - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Name of the column-family to store queue messages.
- setCollectionName(String) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Name of MongoDB collection to store queue messages.
- setConnectionFactory(ConnectionFactory) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Setter for
RabbitMqQueue.connectionFactory
. - setConnectionFactory(ConnectionFactory, boolean) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Setter for
RabbitMqQueue.connectionFactory
. - setConnectionFactory(ActiveMQConnectionFactory) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Setter for
ActiveMqQueue.connectionFactory
. - setConnectionFactory(ActiveMQConnectionFactory, boolean) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Setter for
ActiveMqQueue.connectionFactory
. - setConnectionString(String) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Setter for
MongodbPubSubHub.connectionString
(see http://mongodb.github.io/mongo-java-driver/3.7/driver/getting-started/quick-start/). - setConnectionString(String) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
MongoDB's connection string (see http://mongodb.github.io/mongo-java-driver/3.10/driver/getting-started/quick-start/).
- setConsumerGroupId(String) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Kafka group-id to consume messages.
- setContent(byte[]) - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Sets message's content.
- setContent(byte[]) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Sets message's content.
- setContent(String) - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Sets message's content.
- setContent(String) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Sets message's content.
- setData(DATA) - Method in interface com.github.ddth.queue.IMessage
-
Attach data/content to the queue message.
- setData(DATA) - Method in class com.github.ddth.queue.impl.GenericMessage
-
Attach data/content to the queue message.
- setData(Object) - Method in class com.github.ddth.queue.IMessage.EmptyMessage
- setDatabaseName(String) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Setter for
MongodbPubSubHub.databaseName
. - setDatabaseName(String) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Name of MongoDB database to store data.
- setDataSource(DataSource) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Setter for
JdbcQueue.dataSource
. - setDefaultBootstrapServers(String) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default Kafka bootstrap server list (format
host1:9092,host2:port2,host3:port3
), passed to all queues created by this factory. - setDefaultCfNameEphemeral(String) - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Default name of the column-family to store ephemeral messages, passed to all queues created by this factory.
- setDefaultCfNameMetaData(String) - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Default name of the column-family to store metadata, passed to all queues created by this factory.
- setDefaultCfNameQueue(String) - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Default name of the column-family to store queue messages, passed to all queues created by this factory.
- setDefaultCollectionName(String) - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
Default name of MongoDB collection to store queue messages, passed to all queues created by this factory.
- setDefaultConnectionFactory(ConnectionFactory) - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
If all
RabbitMqQueue
instances are connecting to one RabbitMQ broker, it's a good idea to pre-create anConnectionFactory
instance and share it amongstRabbitMqQueue
instances created from this factory by assigning it toRabbitMqQueueFactory.defaultConnectionFactory
(seeRabbitMqQueueFactory.setDefaultConnectionFactory(ConnectionFactory)
). - setDefaultConnectionFactory(ConnectionFactory, boolean) - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
If all
RabbitMqQueue
instances are connecting to one RabbitMQ broker, it's a good idea to pre-create anConnectionFactory
instance and share it amongstRabbitMqQueue
instances created from this factory by assigning it toRabbitMqQueueFactory.defaultConnectionFactory
(seeRabbitMqQueueFactory.setDefaultConnectionFactory(ConnectionFactory)
). - setDefaultConnectionFactory(ActiveMQConnectionFactory) - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
If all
ActiveMqQueue
instances are connecting to one ActiveMQ broker, it's a good idea to pre-create anActiveMQConnectionFactory
instance and share it amongstActiveMqQueue
instances created from this factory by assigning it toActiveMqQueueFactory.defaultConnectionFactory
(seeActiveMqQueueFactory.setDefaultConnectionFactory(ActiveMQConnectionFactory)
). - setDefaultConnectionFactory(ActiveMQConnectionFactory, boolean) - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
If all
ActiveMqQueue
instances are connecting to one ActiveMQ broker, it's a good idea to pre-create anActiveMQConnectionFactory
instance and share it amongstActiveMqQueue
instances created from this factory by assigning it toActiveMqQueueFactory.defaultConnectionFactory
(seeActiveMqQueueFactory.setDefaultConnectionFactory(ActiveMQConnectionFactory)
). - setDefaultConnectionString(String) - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
Default MongoDB's connection string (see http://mongodb.github.io/mongo-java-driver/3.10/driver/getting-started/quick-start/), passed to all queues created by this factory.
- setDefaultConsumerGroupId(String) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default Kafka group-id to consume messages, passed to all queues created by this factory.
- setDefaultConsumerProps(Properties) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default custom configuration properties for Kafka consumer, passed to all queues created by this factory.
- setDefaultDatabaseName(String) - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
Default name of MongoDB database to store data, passed to all queues created by this factory.
- setDefaultDataSource(DataSource) - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
If all
JdbcQueue
instances are connecting to one database, it's a good idea to pre-create aDataSource
instance and share it amongstJdbcQueue
instances created from this factory by assigning it toJdbcQueueFactory.defaultDataSource
(seeJdbcQueueFactory.setDefaultDataSource(DataSource)
). - setDefaultEphemeralDisabled(boolean) - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- setDefaultEphemeralMaxSize(int) - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- setDefaultFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueueFactory
- setDefaultFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueueFactory
- setDefaultFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueueFactory
- setDefaultFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueueFactory
- setDefaultFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueueFactory
- setDefaultFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueueFactory
- setDefaultFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueueFactory
- setDefaultFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueueFactory
- setDefaultHashName(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Name of the Redis hash to store queue messages.
- setDefaultHostAndPort(String) - Method in class com.github.ddth.queue.impl.RedisQueueFactory
-
Default Redis host and port scheme (format
host:port
), passed to all queues created by this factory. - setDefaultJdbcHelper(IJdbcHelper) - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
If all
JdbcQueue
instances are connecting to oneDataSource
, it's a good idea to pre-create aIJdbcHelper
instance and share it amongstJdbcQueue
instances created from this factory by assigning it toJdbcQueueFactory.defaultJdbcHelper
(seeJdbcQueueFactory.setDefaultJdbcHelper(IJdbcHelper)
). - setDefaultJdbcHelper(IJdbcHelper, boolean) - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
If all
JdbcQueue
instances are connecting to oneDataSource
, it's a good idea to pre-create aIJdbcHelper
instance and share it amongstJdbcQueue
instances created from this factory by assigning it toJdbcQueueFactory.defaultJdbcHelper
(seeJdbcQueueFactory.setDefaultJdbcHelper(IJdbcHelper)
). - setDefaultJedisConnector(JedisConnector) - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
If all
BaseRedisQueue
instances are connecting to one Redis server or cluster, it's a good idea to pre-create aJedisConnector
instance and share it amongstBaseRedisQueue
instances created from this factory by assigning it toBaseRedisQueueFactory.defaultJedisConnector
(seeBaseRedisQueueFactory.setDefaultJedisConnector(JedisConnector)
). - setDefaultJedisConnector(JedisConnector, boolean) - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
If all
BaseRedisQueue
instances are connecting to one Redis server or cluster, it's a good idea to pre-create aJedisConnector
instance and share it amongstBaseRedisQueue
instances created from this factory by assigning it toBaseRedisQueueFactory.defaultJedisConnector
(seeBaseRedisQueueFactory.setDefaultJedisConnector(JedisConnector)
). - setDefaultKafkaClient(KafkaClient) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
If all
KafkaQueue
instances are connecting to one Kafka broker, it's a good idea to pre-create aKafkaClient
instance and share it amongstKafkaQueue
instances created from this factory by assigning it toKafkaQueueFactory.defaultKafkaClient
(seeKafkaQueueFactory.setDefaultKafkaClient(KafkaClient)
). - setDefaultKafkaClient(KafkaClient, boolean) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
If all
KafkaQueue
instances are connecting to one Kafka broker, it's a good idea to pre-create aKafkaClient
instance and share it amongstKafkaQueue
instances created from this factory by assigning it toKafkaQueueFactory.defaultKafkaClient
(seeKafkaQueueFactory.setDefaultKafkaClient(KafkaClient)
). - setDefaultListName(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Name of the Redis list to store queue message ids.
- setDefaultMaxRetries(int) - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Default max number of retires for DB-operations, passed to all queues created by this factory.
- setDefaultMaxSize(int) - Method in class com.github.ddth.queue.impl.AbstractQueueFactory
- setDefaultMongoClient(MongoClient) - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
If all
MongodbQueue
instances are connecting to one MongoDB server or cluster, it's a good idea to pre-create aMongoClient
instance and share it amongstMongodbQueue
instances created from this factory by assigning it toMongodbQueueFactory.defaultMongoClient
(seeMongodbQueueFactory.setDefaultMongoClient(MongoClient)
). - setDefaultMongoClient(MongoClient, boolean) - Method in class com.github.ddth.queue.impl.MongodbQueueFactory
-
If all
MongodbQueue
instances are connecting to one MongoDB server or cluster, it's a good idea to pre-create aMongoClient
instance and share it amongstMongodbQueue
instances created from this factory by assigning it toMongodbQueueFactory.defaultMongoClient
(seeMongodbQueueFactory.setDefaultMongoClient(MongoClient)
). - setDefaultPassword(String) - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Default password to connect to ActiveMQ server, passed to all queues created by this factory.
- setDefaultPassword(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Redis' password.
- setDefaultProducerProps(Properties) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default custom configuration properties for Kafka producer, passed to all queues created by this factory.
- setDefaultProducerType(KafkaClient.ProducerType) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default Kafka's producer type, used to send messages (default
KafkaClient.ProducerType.LEADER_ACK
), passed to all queues created by this factory. - setDefaultQueueName(String) - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Default name of ActiveMQ queue to send/receive messages, passed to all queues created by this factory.
- setDefaultQueueName(String) - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
Default name of RabbitMQ queue to send/receive messages, passed to all queues created by this factory.
- setDefaultSendAsync(boolean) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Should messages sent to Kafka asynchronously (default
true
)? - setDefaultSortedSetName(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueueFactory
-
Name of the Redis sorted-set to store ephemeral message ids.
- setDefaultTableName(String) - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Default name of database table to store queue messages, passed to all queues created by this factory.
- setDefaultTableNameEphemeral(String) - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Default name of database table to store ephemeral messages, passed to all queues created by this factory.
- setDefaultTopicName(String) - Method in class com.github.ddth.queue.impl.KafkaQueueFactory
-
Default name of Kafka topic to store queue messages, passed to all queues created by this factory.
- setDefaultTransactionIsolationLevel(int) - Method in class com.github.ddth.queue.impl.JdbcQueueFactory
-
Default transaction isolation level used in DB-operations, passed to all queues created by this factory.
- setDefaultUri(String) - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Default ActiveMQ's connection URI, passed to all queues created by this factory (see http://activemq.apache.org/connection-configuration-uri.html).
- setDefaultUri(String) - Method in class com.github.ddth.queue.impl.RabbitMqQueueFactory
-
Default RabbitMQ's connection URI (format
amqp://username:password@host:port/virtualHost
), passed to all queues created by this factory. - setDefaultUsername(String) - Method in class com.github.ddth.queue.impl.ActiveMqQueueFactory
-
Default username to connect to ActiveMQ server, passed to all queues created by this factory.
- setEphemeralDisabled(boolean) - Method in class com.github.ddth.queue.impl.AbstractEphemeralSupportQueue
-
Disable/Enable ephemeral storage.
- setEphemeralDisabled(boolean) - Method in class com.github.ddth.queue.impl.AbstractInmemEphemeralQueue
- setEphemeralMaxSize(int) - Method in class com.github.ddth.queue.impl.AbstractEphemeralSupportQueue
-
Provide a positive integer to limit size (max number of items) of ephemeral storage.
- setField(String, Object) - Method in class com.github.ddth.queue.QueueSpec
-
Set a field's value.
- setFifo(boolean) - Method in class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
-
Alias of
BaseUniversalJdbcQueue.markFifo(boolean)
. - setId(ID) - Method in interface com.github.ddth.queue.IMessage
-
Set message's unique queue id.
- setId(ID) - Method in class com.github.ddth.queue.impl.GenericMessage
-
Set message's unique queue id.
- setId(Object) - Method in class com.github.ddth.queue.IMessage.EmptyMessage
- setJdbcHelper(IJdbcHelper) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Setter for
JdbcQueue.jdbcHelper
. - setJdbcHelper(IJdbcHelper, boolean) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Setter for
JdbcQueue.jdbcHelper
. - setJedisConnector(JedisConnector) - Method in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Set the external
JedisConnector
to be used by this pubsub-hub. - setJedisConnector(JedisConnector) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Set the external
JedisConnector
to be used by this queue. - setJedisConnector(JedisConnector, boolean) - Method in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Set the external
JedisConnector
to be used by this pubsub-hub. - setJedisConnector(JedisConnector, boolean) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Setter for
BaseRedisQueue.jedisConnector
. - setKafkaBootstrapServers(String) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Kafka bootstrap server list (format
host1:9092,host2:port2,host3:port3
). - setKafkaClient(KafkaClient) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
An external
KafkaClient
can be used. - setKafkaClient(KafkaClient, boolean) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
An external
KafkaClient
can be used. - setKafkaConsumerProperties(Properties) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Custom configuration properties for Kafka consumer.
- setKafkaProducerProperties(Properties) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Custom configuration properties for Kafka producer.
- setMaxCollectionSize(long) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Max number of document per pub/sub collection.
- setMaxDocuments(long) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Max number of document per pub/sub collection.
- setMaxRetries(int) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Max number of retires for DB-operations.
- setMessageFactory(IMessageFactory<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Factory to create messages.
- setMessageFactory(IQueueMessageFactory<ID, DATA>) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Factory to create queue messages.
- setMongoClient(MongoClient) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Setter for
MongodbPubSubHub.mongoClient
. - setMongoClient(MongoClient) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Setter for
MongodbQueue.mongoClient
. - setMongoClient(MongoClient, boolean) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Setter for
MongodbPubSubHub.mongoClient
. - setMongoClient(MongoClient, boolean) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Setter for
MongodbQueue.mongoClient
. - setNumRequeues(int) - Method in class com.github.ddth.queue.impl.GenericQueueMessage
-
Set message's number of re-queue times.
- setNumRequeues(int) - Method in class com.github.ddth.queue.IQueueMessage.EmptyQueueMessage
- setNumRequeues(int) - Method in interface com.github.ddth.queue.IQueueMessage
-
Set message's number of re-queue times.
- setPartitionKey(String) - Method in class com.github.ddth.queue.impl.GenericMessage
-
Key used for partitioning messages (some queue implementations, such as Kafka queue, support message partitioning).
- setPartitionKey(String) - Method in interface com.github.ddth.queue.IPartitionSupport
-
Key used for partitioning messages (some queue implementations, such as Kafka queue, support message partitioning).
- setPassword(String) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Password to connect to ActiveMQ server.
- setProducerType(KafkaClient.ProducerType) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Kafka's producer type, used to send messages (default
KafkaClient.ProducerType.LEADER_ACK
). - setQueueName(String) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Queue's name.
- setQueueName(String) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Name of ActiveMQ queue to send/receive messages.
- setQueueName(String) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Name of RabbitMQ queue to send/receive messages.
- setQueueTimestamp(Date) - Method in class com.github.ddth.queue.impl.GenericQueueMessage
-
Set message's last-queued timestamp.
- setQueueTimestamp(Date) - Method in class com.github.ddth.queue.IQueueMessage.EmptyQueueMessage
- setQueueTimestamp(Date) - Method in interface com.github.ddth.queue.IQueueMessage
-
Set message's last-queued timestamp.
- setRedisHashName(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis hash to store queue messages.
- setRedisHostAndPort(String) - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Redis' host and port scheme (format
host:port
). - setRedisHostAndPort(String) - Method in class com.github.ddth.queue.impl.RedisQueue
-
Redis host and port scheme (format
host:port
). - setRedisListName(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis list to store queue message ids.
- setRedisPassword(String) - Method in class com.github.ddth.pubsub.impl.BaseRedisPubSubHub
-
Password to connect to Redis.
- setRedisPassword(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Redis' password.
- setRedisSortedSetName(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Name of the Redis sorted-set to store ephemeral message ids.
- setRingSize(int) - Method in class com.github.ddth.queue.impl.DisruptorQueue
-
Size of the ring buffer, should be power of 2.
- setRootStorageDir(String) - Method in class com.github.ddth.queue.impl.RocksDbQueueFactory
-
Root directory to store RocksDB's data.
- setScriptTake(String) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
LUA script to take a message out of queue.
- setSendAsync(boolean) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Should messages sent to Kafka asynchronously (default
true
)? - setSerDeser(ISerDeser) - Method in class com.github.ddth.pubsub.impl.AbstractPubSubHub
-
Message serializer/deserializer.
- setSerDeser(ISerDeser) - Method in class com.github.ddth.queue.impl.AbstractQueue
-
Message serializer/deserializer.
- setStorageDir(String) - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Directory to store RocksDB data files.
- setTableName(String) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Name of database table to store queue messages.
- setTableNameEphemeral(String) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Name of database table to store ephemeral messages.
- setTimestamp(Date) - Method in class com.github.ddth.queue.IMessage.EmptyMessage
- setTimestamp(Date) - Method in interface com.github.ddth.queue.IMessage
-
Set message's timestamp.
- setTimestamp(Date) - Method in class com.github.ddth.queue.impl.GenericMessage
-
Set message's timestamp.
- setTopicName(String) - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Name of Kafka topic to store queue messages.
- setTransactionIsolationLevel(int) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Transaction isolation level used in DB-operations.
- setUri(String) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
ActiveMQ's connection URI (see http://activemq.apache.org/connection-configuration-uri.html).
- setUri(String) - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
RabbitMQ's connection URI (format
amqp://username:password@host:port/virtualHost
). - setUsername(String) - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Username to connect to ActiveMQ server.
- SIZE_NOT_SUPPORTED - Static variable in interface com.github.ddth.queue.IQueue
-
Return this value to indicate that get-size functionality is not supported.
- SPEC_FIELD_BOOTSTRAP_SERVERS - Static variable in class com.github.ddth.queue.impl.KafkaQueueFactory
- SPEC_FIELD_CF_EPHEMERAL - Static variable in class com.github.ddth.queue.impl.RocksDbQueueFactory
- SPEC_FIELD_CF_METADATA - Static variable in class com.github.ddth.queue.impl.RocksDbQueueFactory
- SPEC_FIELD_CF_QUEUE - Static variable in class com.github.ddth.queue.impl.RocksDbQueueFactory
- SPEC_FIELD_COLLECTION_NAME - Static variable in class com.github.ddth.queue.impl.MongodbQueueFactory
- SPEC_FIELD_CONNECTION_STRING - Static variable in class com.github.ddth.queue.impl.MongodbQueueFactory
- SPEC_FIELD_CONSUMER_GROUP_ID - Static variable in class com.github.ddth.queue.impl.KafkaQueueFactory
- SPEC_FIELD_CONSUMER_PROPERTIES - Static variable in class com.github.ddth.queue.impl.KafkaQueueFactory
- SPEC_FIELD_DATABASE_NAME - Static variable in class com.github.ddth.queue.impl.MongodbQueueFactory
- SPEC_FIELD_FIFO - Static variable in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueueFactory
- SPEC_FIELD_FIFO - Static variable in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueueFactory
- SPEC_FIELD_FIFO - Static variable in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueueFactory
- SPEC_FIELD_FIFO - Static variable in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueueFactory
- SPEC_FIELD_FIFO - Static variable in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueueFactory
- SPEC_FIELD_FIFO - Static variable in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueueFactory
- SPEC_FIELD_FIFO - Static variable in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueueFactory
- SPEC_FIELD_FIFO - Static variable in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueueFactory
- SPEC_FIELD_HASH_NAME - Static variable in class com.github.ddth.queue.impl.BaseRedisQueueFactory
- SPEC_FIELD_HOST_AND_PORT - Static variable in class com.github.ddth.queue.impl.BaseRedisQueueFactory
- SPEC_FIELD_LIST_NAME - Static variable in class com.github.ddth.queue.impl.BaseRedisQueueFactory
- SPEC_FIELD_MAX_RETRIES - Static variable in class com.github.ddth.queue.impl.JdbcQueueFactory
- SPEC_FIELD_PASSWORD - Static variable in class com.github.ddth.queue.impl.ActiveMqQueueFactory
- SPEC_FIELD_PASSWORD - Static variable in class com.github.ddth.queue.impl.BaseRedisQueueFactory
- SPEC_FIELD_PRODUCER_PROPERTIES - Static variable in class com.github.ddth.queue.impl.KafkaQueueFactory
- SPEC_FIELD_PRODUCER_TYPE - Static variable in class com.github.ddth.queue.impl.KafkaQueueFactory
- SPEC_FIELD_QUEUE_NAME - Static variable in class com.github.ddth.queue.impl.ActiveMqQueueFactory
- SPEC_FIELD_QUEUE_NAME - Static variable in class com.github.ddth.queue.impl.RabbitMqQueueFactory
- SPEC_FIELD_SEND_ASYNC - Static variable in class com.github.ddth.queue.impl.KafkaQueueFactory
- SPEC_FIELD_SORTED_SET_NAME - Static variable in class com.github.ddth.queue.impl.BaseRedisQueueFactory
- SPEC_FIELD_STORAGE_DIR - Static variable in class com.github.ddth.queue.impl.RocksDbQueueFactory
- SPEC_FIELD_TABLE_NAME - Static variable in class com.github.ddth.queue.impl.JdbcQueueFactory
- SPEC_FIELD_TABLE_NAME_EPHEMERAL - Static variable in class com.github.ddth.queue.impl.JdbcQueueFactory
- SPEC_FIELD_TOPIC - Static variable in class com.github.ddth.queue.impl.KafkaQueueFactory
- SPEC_FIELD_TRANSACTION_ISOLATION_LEVEL - Static variable in class com.github.ddth.queue.impl.JdbcQueueFactory
- SPEC_FIELD_URI - Static variable in class com.github.ddth.queue.impl.ActiveMqQueueFactory
- SPEC_FIELD_URI - Static variable in class com.github.ddth.queue.impl.RabbitMqQueueFactory
- SPEC_FIELD_USERNAME - Static variable in class com.github.ddth.queue.impl.ActiveMqQueueFactory
- storeNew(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Store a new message.
- storeNew(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.RedisQueue
-
Store a new message.
- storeOld(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.BaseRedisQueue
-
Re-store an old message (called by
AbstractQueue.requeue(IQueueMessage)
orAbstractQueue.requeueSilent(IQueueMessage)
. - storeOld(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.RedisQueue
-
Re-store an old message (called by
AbstractQueue.requeue(IQueueMessage)
orAbstractQueue.requeueSilent(IQueueMessage)
. - subscribe(String, ISubscriber<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.InmemPubSubHub
-
Subscribe to a channel for messages.
- subscribe(String, ISubscriber<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Subscribe to a channel for messages.
- subscribe(String, ISubscriber<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Subscribe to a channel for messages.
- subscribe(String, ISubscriber<ID, DATA>) - Method in interface com.github.ddth.pubsub.IPubSubHub
-
Subscribe to a channel for messages.
T
- take() - Method in class com.github.ddth.queue.impl.ActiveMqQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.DisruptorQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.InmemQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.RabbitMqQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.RedisQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.RocksDbQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalActiveMqQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalDisruptorQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalInmemQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalJdbcQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalKafkaQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalMongodbQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalRabbitMqQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalRedisQueue
-
Take a message out of queue.
- take() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalRocksDbQueue
-
Take a message out of queue.
- take() - Method in interface com.github.ddth.queue.IQueue
-
Take a message out of queue.
- takeFromQueue() - Method in class com.github.ddth.queue.impl.InmemQueue
-
Takes a message from the internal queue.
- takeFromQueue() - Method in class com.github.ddth.queue.impl.KafkaQueue
-
Take a message from Kafka queue.
- takeFromRingBuffer() - Method in class com.github.ddth.queue.impl.DisruptorQueue
-
Take a message from the ring buffer.
- toBytes() - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Serializes to
byte[]
. - toBytes() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Serializes to
byte[]
. - toDocument(IMessage<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
- toDocument(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.MongodbQueue
- toJson() - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Serialize this queue message to Json string.
- toJson() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Serialize this queue message to Json string.
- toMap() - Method in class com.github.ddth.pubsub.impl.universal.BaseUniversalMessage
-
Serialize this queue message to a
Map
. - toMap() - Method in class com.github.ddth.queue.impl.universal.BaseUniversalQueueMessage
-
Serialize this queue message to a
Map
. - toString() - Method in class com.github.ddth.queue.impl.GenericMessage
- toString() - Method in class com.github.ddth.queue.impl.GenericQueueMessage
- toString() - Method in class com.github.ddth.queue.QueueSpec
U
- UniversalActiveMqQueue - Class in com.github.ddth.queue.impl.universal.idint
-
(Experimental) Universal ActiveMQ implementation of
IQueue
. - UniversalActiveMqQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
(Experimental) Universal ActiveMQ implementation of
IQueue
. - UniversalActiveMqQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalActiveMqQueue
- UniversalActiveMqQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalActiveMqQueue
- UniversalActiveMqQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalActiveMqQueue
instances. - UniversalActiveMqQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalActiveMqQueue
instances. - UniversalActiveMqQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalActiveMqQueueFactory
- UniversalActiveMqQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalActiveMqQueueFactory
- UniversalDisruptorQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Universal LMAX Disruptor implementation of
IQueue
. - UniversalDisruptorQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Universal LMAX Disruptor implementation of
IQueue
. - UniversalDisruptorQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalDisruptorQueue
- UniversalDisruptorQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalDisruptorQueue
- UniversalDisruptorQueue(int) - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalDisruptorQueue
- UniversalDisruptorQueue(int) - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalDisruptorQueue
- UniversalDisruptorQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalDisruptorQueue
instances. - UniversalDisruptorQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalDisruptorQueue
instances. - UniversalDisruptorQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalDisruptorQueueFactory
- UniversalDisruptorQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalDisruptorQueueFactory
- UniversalIdIntMessage - Class in com.github.ddth.pubsub.impl.universal
-
Extended from
BaseUniversalMessage
where message's id is along
. - UniversalIdIntMessage() - Constructor for class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessage
- UniversalIdIntMessageFactory - Class in com.github.ddth.pubsub.impl.universal
-
Factory that creates
UniversalIdIntMessage
s. - UniversalIdIntMessageFactory() - Constructor for class com.github.ddth.pubsub.impl.universal.UniversalIdIntMessageFactory
- UniversalIdIntQueueMessage - Class in com.github.ddth.queue.impl.universal
-
Extended from
BaseUniversalQueueMessage
where queue message's id is aLong
. - UniversalIdIntQueueMessage() - Constructor for class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessage
- UniversalIdIntQueueMessageFactory - Class in com.github.ddth.queue.impl.universal
-
Factory that creates
UniversalIdIntQueueMessage
s. - UniversalIdIntQueueMessageFactory() - Constructor for class com.github.ddth.queue.impl.universal.UniversalIdIntQueueMessageFactory
- UniversalIdIntSubscriber - Class in com.github.ddth.pubsub.impl.universal
-
A subscriber that accepts only
UniversalIdIntMessage
s. - UniversalIdIntSubscriber() - Constructor for class com.github.ddth.pubsub.impl.universal.UniversalIdIntSubscriber
- UniversalIdStrMessage - Class in com.github.ddth.pubsub.impl.universal
-
Extended from
BaseUniversalMessage
where message's is aString
. - UniversalIdStrMessage() - Constructor for class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessage
- UniversalIdStrMessageFactory - Class in com.github.ddth.pubsub.impl.universal
-
Factory that creates
UniversalIdStrMessage
s. - UniversalIdStrMessageFactory() - Constructor for class com.github.ddth.pubsub.impl.universal.UniversalIdStrMessageFactory
- UniversalIdStrQueueMessage - Class in com.github.ddth.queue.impl.universal
-
Extended from
BaseUniversalQueueMessage
where message's id is aString
. - UniversalIdStrQueueMessage() - Constructor for class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessage
- UniversalIdStrQueueMessageFactory - Class in com.github.ddth.queue.impl.universal
-
Factory that creates
UniversalIdStrQueueMessage
s. - UniversalIdStrQueueMessageFactory() - Constructor for class com.github.ddth.queue.impl.universal.UniversalIdStrQueueMessageFactory
- UniversalIdStrSubscriber - Class in com.github.ddth.pubsub.impl.universal
-
A subscriber that accepts only
UniversalIdStrMessage
s. - UniversalIdStrSubscriber() - Constructor for class com.github.ddth.pubsub.impl.universal.UniversalIdStrSubscriber
- UniversalInmemPubSubHub - Class in com.github.ddth.pubsub.impl.universal.idint
-
Universal in-memory implementation of
IPubSubHub
. - UniversalInmemPubSubHub - Class in com.github.ddth.pubsub.impl.universal.idstr
-
Universal in-memory implementation of
IPubSubHub
. - UniversalInmemPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.universal.idint.UniversalInmemPubSubHub
- UniversalInmemPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.universal.idstr.UniversalInmemPubSubHub
- UniversalInmemQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Universal in-memory implementation of
IQueue
. - UniversalInmemQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Universal in-memory implementation of
IQueue
. - UniversalInmemQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalInmemQueue
- UniversalInmemQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalInmemQueue
- UniversalInmemQueue(int) - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalInmemQueue
- UniversalInmemQueue(int) - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalInmemQueue
- UniversalInmemQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalInmemQueue
instances. - UniversalInmemQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalInmemQueue
instances. - UniversalInmemQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalInmemQueueFactory
- UniversalInmemQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalInmemQueueFactory
- UniversalJdbcQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Universal JDBC implementation of
IQueue
. - UniversalJdbcQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Universal JDBC implementation of
IQueue
. - UniversalJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueue
- UniversalJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueue
- UniversalJdbcQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalJdbcQueue
instances. - UniversalJdbcQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalJdbcQueue
instances. - UniversalJdbcQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalJdbcQueueFactory
- UniversalJdbcQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalJdbcQueueFactory
- UniversalKafkaQueue - Class in com.github.ddth.queue.impl.universal.idint
-
(Experimental) Universal Kafka implementation of
IQueue
. - UniversalKafkaQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
(Experimental) Universal Kafka implementation of
IQueue
. - UniversalKafkaQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalKafkaQueue
- UniversalKafkaQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalKafkaQueue
- UniversalKafkaQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalKafkaQueue
instances. - UniversalKafkaQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalKafkaQueue
instances. - UniversalKafkaQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalKafkaQueueFactory
- UniversalKafkaQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalKafkaQueueFactory
- UniversalMongodbPubSubHub - Class in com.github.ddth.pubsub.impl.universal.idint
-
Universal MongoDB implementation of
IPubSubHub
. - UniversalMongodbPubSubHub - Class in com.github.ddth.pubsub.impl.universal.idstr
-
Universal MongoDB implementation of
IPubSubHub
. - UniversalMongodbPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.universal.idint.UniversalMongodbPubSubHub
- UniversalMongodbPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.universal.idstr.UniversalMongodbPubSubHub
- UniversalMongodbQueue - Class in com.github.ddth.queue.impl.universal.idint
-
(Experimental) Universal MongoDB implementation of
IQueue
. - UniversalMongodbQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
(Experimental) Universal MongoDB implementation of
IQueue
. - UniversalMongodbQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalMongodbQueue
- UniversalMongodbQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalMongodbQueue
- UniversalMongodbQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalMongodbQueue
instances. - UniversalMongodbQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalMongodbQueue
instances. - UniversalMongodbQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalMongodbQueueFactory
- UniversalMongodbQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalMongodbQueueFactory
- UniversalRabbitMqQueue - Class in com.github.ddth.queue.impl.universal.idint
-
(Experimental) Universal RabbitMQ implementation of
IQueue
. - UniversalRabbitMqQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
(Experimental) Universal RabbitMQ implementation of
IQueue
. - UniversalRabbitMqQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalRabbitMqQueue
- UniversalRabbitMqQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalRabbitMqQueue
- UniversalRabbitMqQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalRabbitMqQueue
instances. - UniversalRabbitMqQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalRabbitMqQueue
instances. - UniversalRabbitMqQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalRabbitMqQueueFactory
- UniversalRabbitMqQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalRabbitMqQueueFactory
- UniversalRedisPubSubHub - Class in com.github.ddth.pubsub.impl.universal.idint
-
Universal Redis implementation of
IPubSubHub
. - UniversalRedisPubSubHub - Class in com.github.ddth.pubsub.impl.universal.idstr
-
Universal Redis implementation of
IPubSubHub
. - UniversalRedisPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.universal.idint.UniversalRedisPubSubHub
- UniversalRedisPubSubHub() - Constructor for class com.github.ddth.pubsub.impl.universal.idstr.UniversalRedisPubSubHub
- UniversalRedisQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Universal Redis implementation of
IQueue
. - UniversalRedisQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Universal Redis implementation of
IQueue
. - UniversalRedisQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalRedisQueue
- UniversalRedisQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalRedisQueue
- UniversalRedisQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalRedisQueue
instances. - UniversalRedisQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalRedisQueue
instances. - UniversalRedisQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalRedisQueueFactory
- UniversalRedisQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalRedisQueueFactory
- UniversalRocksDbQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Universal RocskDB implementation of
IQueue
. - UniversalRocksDbQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Universal RocskDB implementation of
IQueue
. - UniversalRocksDbQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalRocksDbQueue
- UniversalRocksDbQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalRocksDbQueue
- UniversalRocksDbQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalRocksDbQueue
instances. - UniversalRocksDbQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalRocksDbQueue
instances. - UniversalRocksDbQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalRocksDbQueueFactory
- UniversalRocksDbQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalRocksDbQueueFactory
- UniversalSingleStorageJdbcQueue - Class in com.github.ddth.queue.impl.universal.idint
-
Same as
UniversalJdbcQueue
but messages from all queues are stored in one same storage. - UniversalSingleStorageJdbcQueue - Class in com.github.ddth.queue.impl.universal.idstr
-
Same as
UniversalJdbcQueue
but messages from all queues are stored in one same storage. - UniversalSingleStorageJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueue
- UniversalSingleStorageJdbcQueue() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueue
- UniversalSingleStorageJdbcQueueFactory - Class in com.github.ddth.queue.impl.universal.idint
-
Factory to create
UniversalJdbcQueue
instances. - UniversalSingleStorageJdbcQueueFactory - Class in com.github.ddth.queue.impl.universal.idstr
-
Factory to create
UniversalJdbcQueue
instances. - UniversalSingleStorageJdbcQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idint.UniversalSingleStorageJdbcQueueFactory
- UniversalSingleStorageJdbcQueueFactory() - Constructor for class com.github.ddth.queue.impl.universal.idstr.UniversalSingleStorageJdbcQueueFactory
- unsubscribe(String, ISubscriber<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.InmemPubSubHub
-
Unsubscribe from a channel.
- unsubscribe(String, ISubscriber<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.MongodbPubSubHub
-
Unsubscribe from a channel.
- unsubscribe(String, ISubscriber<ID, DATA>) - Method in class com.github.ddth.pubsub.impl.RedisPubSubHub
-
Unsubscribe from a channel.
- unsubscribe(String, ISubscriber<ID, DATA>) - Method in interface com.github.ddth.pubsub.IPubSubHub
-
Unsubscribe from a channel.
- upsertToCollection(IQueueMessage<ID, DATA>) - Method in class com.github.ddth.queue.impl.MongodbQueue
-
Insert/Update the message to collection.
V
- value() - Method in enum com.github.ddth.queue.impl.AbstractQueue.PutToQueueCase
- valueOf(String) - Static method in enum com.github.ddth.queue.impl.AbstractQueue.PutToQueueCase
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.github.ddth.queue.impl.AbstractQueue.PutToQueueCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
_
- _finishWithRetries(Connection, IQueueMessage<ID, byte[]>, int, int) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Perform "finish" action, retry if deadlock.
- _finishWithRetries(Connection, IQueueMessage<ID, byte[]>, int, int) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Perform "finish" action, retry if deadlock.
- _finishWithRetries(Connection, IQueueMessage<ID, DATA>, int, int) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Perform "finish" action, retry if deadlock.
- _getOrphanMessagesWithRetries(long, Connection, int, int) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Get all orphan messages (messages that were left in ephemeral storage for a long time), retry if deadlock.
- _queueWithRetries(Connection, IQueueMessage<ID, DATA>, int, int) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Queue a message, retry if deadlock.
- _requeueSilentWithRetries(Connection, IQueueMessage<ID, byte[]>, int, int) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Re-queue (silentlt) a message, retry if deadlock.
- _requeueSilentWithRetries(Connection, IQueueMessage<ID, byte[]>, int, int) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Re-queue (silentlt) a message, retry if deadlock.
- _requeueSilentWithRetries(Connection, IQueueMessage<ID, DATA>, int, int) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Re-queue (silentlt) a message, retry if deadlock.
- _requeueWithRetries(Connection, IQueueMessage<ID, byte[]>, int, int) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Re-queue a message, retry if deadlock.
- _requeueWithRetries(Connection, IQueueMessage<ID, byte[]>, int, int) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Re-queue a message, retry if deadlock.
- _requeueWithRetries(Connection, IQueueMessage<ID, DATA>, int, int) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Re-queue a message, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.JdbcQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalJdbcQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.BaseLessLockingUniversalSingleStorageJdbcQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalMySQLQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalPgSQLQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStorageMySQLQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.idint.LessLockingUniversalSingleStoragePgSQLQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalMySQLQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalPgSQLQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStorageMySQLQueue
-
Take a message from queue, retry if deadlock.
- _takeWithRetries(Connection, int, int) - Method in class com.github.ddth.queue.impl.universal.idstr.LessLockingUniversalSingleStoragePgSQLQueue
-
Take a message from queue, retry if deadlock.
All Classes All Packages