Index

A B C D E G H I J K L M N O P R S U 
All Classes and Interfaces|All Packages

A

AbstractMessenger - Class in com.saicone.delivery4j
Messenger abstract class to send messages across channels using a Broker.
This class doesn't offer any abstract method making it usable as plain object, but it's suggested to extend it and override AbstractMessenger.loadBroker() if you want your own implementation.
AbstractMessenger() - Constructor for class com.saicone.delivery4j.AbstractMessenger
 
accept(byte[]) - Method in class com.saicone.delivery4j.MessageChannel
Accept the provided pre-decoded data into current consumer.
accept(String, byte[]) - Method in class com.saicone.delivery4j.AbstractMessenger
Receive provided byte data to be encoded as readable multi-line message.
accept(String, T) - Method in interface com.saicone.delivery4j.ChannelConsumer
Performs this operation with the given channel name and the data produced by itself.
ActiveMQBroker - Class in com.saicone.delivery4j.broker
ActiveMQ broker implementation to send data using topic producers and consumers.
ActiveMQBroker(Connection) - Constructor for class com.saicone.delivery4j.broker.ActiveMQBroker
Create an activemq broker by providing a connection.
ActiveMQBroker.Bridge - Class in com.saicone.delivery4j.broker
Bridge class to save message producer and consumer for specific topic.
andThen(ChannelConsumer<T>) - Method in interface com.saicone.delivery4j.ChannelConsumer
Returns a composed ChannelConsumer that performs, in sequence, this operation followed by the after operation.
asExecutor() - Method in interface com.saicone.delivery4j.util.DelayedExecutor
Return the current executor as Java Executor.

B

BASE64 - Static variable in interface com.saicone.delivery4j.util.ByteCodec
Base64 byte codec that convert bytes into/from Base64 String.
Bridge() - Constructor for class com.saicone.delivery4j.broker.RedisBroker.Bridge
 
Bridge(String) - Constructor for class com.saicone.delivery4j.broker.ActiveMQBroker.Bridge
Constructs a bridge with the provided channel.
Broker - Class in com.saicone.delivery4j
Represents an object that can transfer byte-array data across channels.
In popular terms, this is a globalized producer that deliver/publish temporary data to multiple consumers using topics or queues (depending on the implementation) and can also consume the data itself by subscribing to channels.
Broker() - Constructor for class com.saicone.delivery4j.Broker
 
Broker.Logger - Interface in com.saicone.delivery4j
Logger interface to print messages about broker operations and exceptions.
Unlike normal logger implementations, this one uses numbers as levels:
1 = ERROR / SEVERE
2 = WARNING
3 = INFO
4 = DEBUG INFORMATION
ByteCodec<T> - Interface in com.saicone.delivery4j.util
Byte codec interface to encode and decode bytes into desired object.

C

cache(boolean) - Method in class com.saicone.delivery4j.MessageChannel
Set caching status for the current message channel.
cache(long, TimeUnit) - Method in class com.saicone.delivery4j.MessageChannel
Set the cache time for the current message channel.
cache(MessageChannel.Cache) - Method in class com.saicone.delivery4j.MessageChannel
Set the cache instance for the current message channel.
Cache() - Constructor for class com.saicone.delivery4j.MessageChannel.Cache
 
CaffeineCache - Class in com.saicone.delivery4j.cache
Caffeine integration for message ID caching.
CaffeineCache(long, TimeUnit) - Constructor for class com.saicone.delivery4j.cache.CaffeineCache
Constructs a caffeine cache with provided expiration.
cancel(T) - Method in interface com.saicone.delivery4j.util.DelayedExecutor
Cancel a task type that was created by this executor.
ChannelConsumer<T> - Interface in com.saicone.delivery4j
Represents and operation that accept a channel name and the data produced by the channel.
Unlike Consumer, this operation can throw an IOException.
cleanMessages() - Method in class com.saicone.delivery4j.broker.SqlBroker
Clean old messages from database.
clear() - Method in class com.saicone.delivery4j.AbstractMessenger
Clear any message channels and incoming consumers.
clear() - Method in class com.saicone.delivery4j.Broker
Clear all subscribed channels from broker.
clear() - Method in class com.saicone.delivery4j.cache.CaffeineCache
 
clear() - Method in class com.saicone.delivery4j.cache.GuavaCache
 
clear() - Method in class com.saicone.delivery4j.MessageChannel.Cache
Clear the current cache instance values.
clear() - Method in class com.saicone.delivery4j.MessageChannel
Clear the current message channel instance.
close() - Method in class com.saicone.delivery4j.AbstractMessenger
Close the messenger instance connection.
close() - Method in class com.saicone.delivery4j.broker.ActiveMQBroker.Bridge
Close the current activemq connection.
close() - Method in class com.saicone.delivery4j.Broker
Close the broker connection.
close() - Method in interface com.saicone.delivery4j.util.DataSource
Close the current data source, making it unable to give a connection after this operation.
com.saicone.delivery4j - package com.saicone.delivery4j
 
com.saicone.delivery4j.broker - package com.saicone.delivery4j.broker
 
com.saicone.delivery4j.cache - package com.saicone.delivery4j.cache
 
com.saicone.delivery4j.log - package com.saicone.delivery4j.log
 
com.saicone.delivery4j.util - package com.saicone.delivery4j.util
 
consume(ChannelConsumer<String[]>) - Method in class com.saicone.delivery4j.MessageChannel
Set or append provided consumer into channel inbound consumer.
consumeBefore(ChannelConsumer<String[]>) - Method in class com.saicone.delivery4j.MessageChannel
Set or append before provided consumer into channel inbound consumer.
contains(int) - Method in class com.saicone.delivery4j.cache.CaffeineCache
 
contains(int) - Method in class com.saicone.delivery4j.cache.GuavaCache
 
contains(int) - Method in class com.saicone.delivery4j.MessageChannel.Cache
Check if the current cache contains the provided message ID.

D

DataSource - Interface in com.saicone.delivery4j.util
Data source interface which provides a Connection interaction, depending on its implementation.
DEBUG - Static variable in interface com.saicone.delivery4j.Broker.Logger
Boolean to define if DEBUG INFORMATION will be logged by default.
It needs the property saicone.delivery4j.debug to be set as true.
decode(byte[]) - Method in class com.saicone.delivery4j.MessageChannel
Decodes a byte array into a multi-line message.
decode(T) - Method in interface com.saicone.delivery4j.util.ByteCodec
Decodes an object type into a newly-allocated byte array.
decrypt(byte[]) - Method in interface com.saicone.delivery4j.util.Encryptor
Decrypts the input data and return itself as readable String.
DelayedExecutor<T> - Interface in com.saicone.delivery4j.util
An object that executes submitted Runnable tasks and return itself as cancellable objects.
Unlike Executor, this kind of object allows to execute delayed and repeatable tasks.

E

encode(byte[]) - Method in interface com.saicone.delivery4j.util.ByteCodec
Encodes the specified byte array into object type.
encode(Object...) - Method in class com.saicone.delivery4j.MessageChannel
Encodes the specified message lines into byte array.
encrypt(String) - Method in interface com.saicone.delivery4j.util.Encryptor
Encrypts the input String data and return itself as byte array.
encryptor(Encryptor) - Method in class com.saicone.delivery4j.MessageChannel
Set the message encryptor for the current message channel.
Encryptor - Interface in com.saicone.delivery4j.util
Encryptor interface to encrypt and decrypt any provided String.
By default, this is just a bridge to regular Java Cipher usage.
execute(Runnable) - Method in interface com.saicone.delivery4j.util.DelayedExecutor
Executes the given command at some time in the future.
Unlike Executor.execute(Runnable), this method return the task itself, that can be cancelled at some time in the future.
For example, a recursive call that locks the thread can be cancelled if it's executed using this method.
execute(Runnable, long, long, TimeUnit) - Method in interface com.saicone.delivery4j.util.DelayedExecutor
Executes the given command after the initial delay has passed, and then periodically executed with the specified period.
execute(Runnable, long, TimeUnit) - Method in interface com.saicone.delivery4j.util.DelayedExecutor
Executes the given command after the time delay has passed.

G

generate() - Method in class com.saicone.delivery4j.MessageChannel.Cache
Generate message ID and save into cache.
getBridge() - Method in class com.saicone.delivery4j.broker.RedisBroker
Get the current bridge to receive messages.
getBroker() - Method in class com.saicone.delivery4j.AbstractMessenger
Get the current broker.
getCache() - Method in class com.saicone.delivery4j.MessageChannel
Get the current cache instance.
getChannel() - Method in class com.saicone.delivery4j.broker.ActiveMQBroker.Bridge
Get the current subscribed channel.
getChannels() - Method in class com.saicone.delivery4j.AbstractMessenger
Get the current subscribed channels.
getCodec() - Method in class com.saicone.delivery4j.Broker
Get the current byte codec.
getConnection() - Method in class com.saicone.delivery4j.broker.NatsBroker
Get the current connection.
getConnection() - Method in class com.saicone.delivery4j.broker.RabbitMQBroker
The current connection.
getConnection() - Method in interface com.saicone.delivery4j.util.DataSource
Get the connection object from this data source.
getConsumer() - Method in class com.saicone.delivery4j.broker.ActiveMQBroker.Bridge
Get the current consumer used to listed messages from topic.
getConsumer() - Method in class com.saicone.delivery4j.Broker
Get the current channel consumer.
getConsumer() - Method in class com.saicone.delivery4j.MessageChannel
Get the current message consumer.
getDispatcher() - Method in class com.saicone.delivery4j.broker.NatsBroker
Get the current dispatcher.
getEncryptor() - Method in class com.saicone.delivery4j.MessageChannel
Get the current encryptor.
getExecutor() - Method in class com.saicone.delivery4j.AbstractMessenger
Get the current executor, by default CompletableFuture.defaultExecutor() is used.
getExecutor() - Method in class com.saicone.delivery4j.Broker
Get the current delayed executor.
getHikari() - Method in class com.saicone.delivery4j.broker.HikariBroker
Get the current hikari data source used on this instance.
getHikari() - Method in class com.saicone.delivery4j.broker.PostgreSQLHikariBroker
Get the current hikari data source used on this instance.
getLogger() - Method in class com.saicone.delivery4j.Broker
Get the current logger.
getMessages() - Method in class com.saicone.delivery4j.broker.SqlBroker
Get all unread messages from database.
getName() - Method in class com.saicone.delivery4j.MessageChannel
Get the current channel name.
getPool() - Method in class com.saicone.delivery4j.broker.RedisBroker
Get the current pool.
getProducer() - Method in class com.saicone.delivery4j.broker.ActiveMQBroker.Bridge
Get the current producer used to send messages to topic.
getProducer() - Method in class com.saicone.delivery4j.broker.KafkaBroker
Get the current producer.
getSource() - Method in class com.saicone.delivery4j.broker.PostgreSQLBroker
Get the current data source that database connection is from.
getSource() - Method in class com.saicone.delivery4j.broker.SqlBroker
Get the current data source that database connection is from.
getSubscribedChannels() - Method in class com.saicone.delivery4j.Broker
Get the subscribed channels.
getTablePrefix() - Method in class com.saicone.delivery4j.broker.SqlBroker
Get the current table prefix that is used before messenger table name.
GuavaCache - Class in com.saicone.delivery4j.cache
Guava integration for message ID caching.
GuavaCache(long, TimeUnit) - Constructor for class com.saicone.delivery4j.cache.GuavaCache
Constructs a guava cache with provided expiration.

H

HikariBroker - Class in com.saicone.delivery4j.broker
Sql broker implementation that use hikari library to make connections to database.
The operations are the same as sql broker, it just made any connection with hikari library.
HikariBroker(HikariDataSource) - Constructor for class com.saicone.delivery4j.broker.HikariBroker
Constructs a hikari broker using the provided data source instance.

I

isClosable() - Method in interface com.saicone.delivery4j.util.DataSource
Get the current connection type offered by this data source.
isEnabled() - Method in class com.saicone.delivery4j.AbstractMessenger
Get the current messenger status.
isEnabled() - Method in class com.saicone.delivery4j.Broker
Get the current broker status.
isRunning() - Method in interface com.saicone.delivery4j.util.DataSource
Get the current running status from data source.

J

java(String, String, String) - Static method in interface com.saicone.delivery4j.util.DataSource
Create a data source using the provided connection parameters.
java(Connection) - Static method in interface com.saicone.delivery4j.util.DataSource
Get a wrapped data source instance with the provided connection.
This method assumes that the given connection should not be closed after return it.
JAVA - Static variable in interface com.saicone.delivery4j.util.DelayedExecutor
Delayed executor object that use Java method to execute tasks.
Is NOT suggested to use this object due is not scalable and doesn't use any thread pool, make a better implementation instead.

K

KafkaBroker<K> - Class in com.saicone.delivery4j.broker
Kafka broker implementation to publish and consumer using empty-keys records.
Take in count that any producer and consumer used in this instance should be compatible with byte array values.
KafkaBroker(Properties, Properties) - Constructor for class com.saicone.delivery4j.broker.KafkaBroker
Constructs a kafka broker using provided properties for producer and consumer.
KafkaBroker(KafkaProducer<K, byte[]>, KafkaConsumer<K, byte[]>) - Constructor for class com.saicone.delivery4j.broker.KafkaBroker
Constructs a kafka broker using provided producer and consumer.

L

loadBroker() - Method in class com.saicone.delivery4j.AbstractMessenger
Method to load the used broker on data transfer operations.
log(int, String) - Method in interface com.saicone.delivery4j.Broker.Logger
Log a message.
log(int, String) - Method in class com.saicone.delivery4j.log.Log4jLogger
 
log(int, String) - Method in class com.saicone.delivery4j.log.Slf4jLogger
 
log(int, String, Throwable) - Method in interface com.saicone.delivery4j.Broker.Logger
Log a message, with associated Throwable information.
log(int, String, Throwable) - Method in class com.saicone.delivery4j.log.Log4jLogger
 
log(int, String, Throwable) - Method in class com.saicone.delivery4j.log.Slf4jLogger
 
log(int, Supplier<String>) - Method in interface com.saicone.delivery4j.Broker.Logger
Log a message, which is only to be constructed if the logging level is allowed by current implementation.
log(int, Supplier<String>) - Method in class com.saicone.delivery4j.log.Log4jLogger
 
log(int, Supplier<String>, Throwable) - Method in interface com.saicone.delivery4j.Broker.Logger
Log a message, which is only to be constructed if the logging level is allowed by current implementation.
log(int, Supplier<String>, Throwable) - Method in class com.saicone.delivery4j.log.Log4jLogger
 
Log4jLogger - Class in com.saicone.delivery4j.log
Log4j integration for broker logging.
Log4jLogger(Class<?>) - Constructor for class com.saicone.delivery4j.log.Log4jLogger
Create a log4j logger to provided class.

M

MessageChannel - Class in com.saicone.delivery4j
An object to consume channel messages.
This object can also provide an Encryptor to make a secure message delivery.
MessageChannel(String) - Constructor for class com.saicone.delivery4j.MessageChannel
Constructs a message channel with provided name.
MessageChannel(String, ChannelConsumer<String[]>) - Constructor for class com.saicone.delivery4j.MessageChannel
Constructs a message channel with provided name and consumer.
MessageChannel.Cache - Class in com.saicone.delivery4j
Cache interface to store message IDs with certain delay.

N

NatsBroker - Class in com.saicone.delivery4j.broker
NATS broker implementation to publish data and consume it with subject subscription.
NatsBroker(Connection) - Constructor for class com.saicone.delivery4j.broker.NatsBroker
Constructs a nats broker with provided connection.

O

of(long, TimeUnit) - Static method in class com.saicone.delivery4j.MessageChannel.Cache
Create a cache with provided expiration.
This method try to find the best available implementation and uses it.
of(Class<?>) - Static method in interface com.saicone.delivery4j.Broker.Logger
Create a logger to provided class.
This method try to find the best available implementation and uses it.
of(String) - Static method in class com.saicone.delivery4j.broker.RedisBroker
Create a redis broker with provided url.
This method will try to extract any password from provided url.
of(String) - Static method in class com.saicone.delivery4j.MessageChannel
Create a message channel with provided name.
of(String, int, String, int, boolean) - Static method in class com.saicone.delivery4j.broker.RedisBroker
Create a redis broker with provided parameters.
of(String, int, String, String, String, String) - Static method in class com.saicone.delivery4j.broker.RabbitMQBroker
Create a rabbitmq broker with provided parameters.
of(String, String) - Static method in class com.saicone.delivery4j.broker.KafkaBroker
Create a kafka broker with provided parameters.
This method by default use `void` keys to provide a full empty-key interaction.
of(String, String) - Static method in class com.saicone.delivery4j.broker.RabbitMQBroker
Create a rabbitmq broker with provided parameters.
of(String, String, String) - Static method in class com.saicone.delivery4j.broker.HikariBroker
Create a hikari broker with the provided connection parameters.
of(String, String, String) - Static method in class com.saicone.delivery4j.broker.PostgreSQLBroker
Create a postgres broker with the provided connection parameters.
of(String, String, String) - Static method in class com.saicone.delivery4j.broker.PostgreSQLHikariBroker
Create a postgres hikari broker with the provided connection parameters.
of(String, String, String) - Static method in class com.saicone.delivery4j.broker.SqlBroker
Create a sql broker with the provided connection parameters.
of(String, SecretKey) - Static method in interface com.saicone.delivery4j.util.Encryptor
Create an encryptor with provided arguments that performs automatic resets if any error occurs on encryption/decryption.
of(String, SecretKey, Charset) - Static method in interface com.saicone.delivery4j.util.Encryptor
Create an encryptor with provided arguments that performs automatic resets if any error occurs on encryption/decryption.
of(String, String, String, boolean) - Static method in class com.saicone.delivery4j.broker.NatsBroker
Create a nats broker with provided parameters.
of(String, String, String, Duration) - Static method in class com.saicone.delivery4j.broker.NatsBroker
Create a nats broker with provided parameters.
of(URI, String) - Static method in class com.saicone.delivery4j.broker.RabbitMQBroker
Create a rabbitmq broker with provided parameters.
of(URI, String) - Static method in class com.saicone.delivery4j.broker.RedisBroker
Create a redis broker with provided url and password.
of(Consumer<Options.Builder>) - Static method in class com.saicone.delivery4j.broker.NatsBroker
Create a nats broker by providing builder options.
of(Consumer<ActiveMQConnectionFactory>) - Static method in class com.saicone.delivery4j.broker.ActiveMQBroker
Create an activemq broker by providing connection factory.
of(SecretKey) - Static method in interface com.saicone.delivery4j.util.Encryptor
Create an encryptor with provided arguments that performs automatic resets if any error occurs on encryption/decryption.
of(SecretKey, Charset) - Static method in interface com.saicone.delivery4j.util.Encryptor
Create an encryptor with provided arguments that performs automatic resets if any error occurs on encryption/decryption.
onClose() - Method in class com.saicone.delivery4j.broker.ActiveMQBroker
 
onClose() - Method in class com.saicone.delivery4j.broker.KafkaBroker
 
onClose() - Method in class com.saicone.delivery4j.broker.NatsBroker
 
onClose() - Method in class com.saicone.delivery4j.Broker
Method to run when broker closes.
onClose() - Method in class com.saicone.delivery4j.broker.PostgreSQLBroker
 
onClose() - Method in class com.saicone.delivery4j.broker.RabbitMQBroker
 
onClose() - Method in class com.saicone.delivery4j.broker.RedisBroker
 
onClose() - Method in class com.saicone.delivery4j.broker.SqlBroker
 
onMessage(Message) - Method in class com.saicone.delivery4j.broker.ActiveMQBroker.Bridge
 
onMessage(String, String) - Method in class com.saicone.delivery4j.broker.RedisBroker.Bridge
 
onReceive(String, byte[]) - Method in class com.saicone.delivery4j.Broker
Method to run when byte data was received from broker.
onSend(String, byte[]) - Method in class com.saicone.delivery4j.broker.ActiveMQBroker
 
onSend(String, byte[]) - Method in class com.saicone.delivery4j.broker.KafkaBroker
 
onSend(String, byte[]) - Method in class com.saicone.delivery4j.broker.NatsBroker
 
onSend(String, byte[]) - Method in class com.saicone.delivery4j.Broker
Method to run when byte data is being sent to broker.
onSend(String, byte[]) - Method in class com.saicone.delivery4j.broker.PostgreSQLBroker
 
onSend(String, byte[]) - Method in class com.saicone.delivery4j.broker.RabbitMQBroker
 
onSend(String, byte[]) - Method in class com.saicone.delivery4j.broker.RedisBroker
 
onSend(String, byte[]) - Method in class com.saicone.delivery4j.broker.SqlBroker
 
onStart() - Method in class com.saicone.delivery4j.broker.ActiveMQBroker
 
onStart() - Method in class com.saicone.delivery4j.broker.KafkaBroker
 
onStart() - Method in class com.saicone.delivery4j.broker.NatsBroker
 
onStart() - Method in class com.saicone.delivery4j.Broker
Method to run when broker starts
onStart() - Method in class com.saicone.delivery4j.broker.PostgreSQLBroker
 
onStart() - Method in class com.saicone.delivery4j.broker.RabbitMQBroker
 
onStart() - Method in class com.saicone.delivery4j.broker.RedisBroker
 
onStart() - Method in class com.saicone.delivery4j.broker.SqlBroker
 
onSubscribe(String...) - Method in class com.saicone.delivery4j.broker.ActiveMQBroker
 
onSubscribe(String...) - Method in class com.saicone.delivery4j.broker.KafkaBroker
 
onSubscribe(String...) - Method in class com.saicone.delivery4j.broker.NatsBroker
 
onSubscribe(String...) - Method in class com.saicone.delivery4j.Broker
Method to run when broker is being subscribed to new channels.
onSubscribe(String...) - Method in class com.saicone.delivery4j.broker.PostgreSQLBroker
 
onSubscribe(String...) - Method in class com.saicone.delivery4j.broker.RabbitMQBroker
 
onSubscribe(String...) - Method in class com.saicone.delivery4j.broker.RedisBroker
 
onSubscribe(String, int) - Method in class com.saicone.delivery4j.broker.RedisBroker.Bridge
 
onUnsubscribe(String...) - Method in class com.saicone.delivery4j.broker.ActiveMQBroker
 
onUnsubscribe(String...) - Method in class com.saicone.delivery4j.broker.KafkaBroker
 
onUnsubscribe(String...) - Method in class com.saicone.delivery4j.broker.NatsBroker
 
onUnsubscribe(String...) - Method in class com.saicone.delivery4j.Broker
Method to run when broker is being unsubscribed from channels.
onUnsubscribe(String...) - Method in class com.saicone.delivery4j.broker.PostgreSQLBroker
 
onUnsubscribe(String...) - Method in class com.saicone.delivery4j.broker.RabbitMQBroker
 
onUnsubscribe(String...) - Method in class com.saicone.delivery4j.broker.RedisBroker
 
onUnsubscribe(String, int) - Method in class com.saicone.delivery4j.broker.RedisBroker.Bridge
 

P

PostgreSQLBroker - Class in com.saicone.delivery4j.broker
PostgreSQL broker implementation to send data using LISTEN and NOTIFY statements.

Is this scalable?
No
Allows large messages?
No
Should I use it?
Maybe
PostgreSQLBroker(DataSource) - Constructor for class com.saicone.delivery4j.broker.PostgreSQLBroker
Constructs a postgres broker using the provided data source instance.
PostgreSQLBroker(Connection) - Constructor for class com.saicone.delivery4j.broker.PostgreSQLBroker
Constructs a postgres broker using the provided connection instance.
This constructor assumes that the given connection should not be closed after return it.
PostgreSQLHikariBroker - Class in com.saicone.delivery4j.broker
PostgreSQL broker implementation that use hikari library to make connections to database.
The operations are the same as PostgreSQL broker, it just made any connection with hikari library.
PostgreSQLHikariBroker(HikariDataSource) - Constructor for class com.saicone.delivery4j.broker.PostgreSQLHikariBroker
Constructs a postgres hikari broker using the provided data source instance.

R

RabbitMQBroker - Class in com.saicone.delivery4j.broker
RabbitMQ broker implementation to send data using queue and consumer via exchange.
RabbitMQBroker(Connection, String) - Constructor for class com.saicone.delivery4j.broker.RabbitMQBroker
Constructs a rabbitmq broker with provided parameters.
receive(String, byte[]) - Method in class com.saicone.delivery4j.Broker
Receive byte array from provided channel.
RedisBroker - Class in com.saicone.delivery4j.broker
Redis broker implementation to send data via publish and subscriptions.
This kind of broker will encode any byte array as String and viceversa.
Some operations made in this instance can fail due authentication errors, so it requires the password as well.
RedisBroker(JedisPool, String) - Constructor for class com.saicone.delivery4j.broker.RedisBroker
Constructs a redis broker with provided pool and password.
RedisBroker(JedisPool, String, RedisBroker.Bridge) - Constructor for class com.saicone.delivery4j.broker.RedisBroker
Constructs a redis broker with provided parameters.
RedisBroker.Bridge - Class in com.saicone.delivery4j.broker
Bridge class to detect received messages from Redis database.

S

save(int) - Method in class com.saicone.delivery4j.cache.CaffeineCache
 
save(int) - Method in class com.saicone.delivery4j.cache.GuavaCache
 
save(int) - Method in class com.saicone.delivery4j.MessageChannel.Cache
Save message ID.
send(byte[]) - Method in class com.saicone.delivery4j.broker.ActiveMQBroker.Bridge
Send data to producer.
send(String, byte[]) - Method in class com.saicone.delivery4j.Broker
Send byte data array to provided channel.
send(String, Object...) - Method in class com.saicone.delivery4j.AbstractMessenger
Send multi-line message to provided channel name.
Take in count this method accept any Object as message lines, but everything will be converted to String.
If any object is null or "null" it will be sent as null object, and any consumer will get a null object as well.
send(ProducerRecord<K, byte[]>) - Method in class com.saicone.delivery4j.broker.KafkaBroker
Send a producer record into current producer.
setBroker(Broker) - Method in class com.saicone.delivery4j.AbstractMessenger
Set a broker to transfer data.
setCodec(ByteCodec<String>) - Method in class com.saicone.delivery4j.Broker
Replace the current byte codec.
setConsumer(ChannelConsumer<byte[]>) - Method in class com.saicone.delivery4j.Broker
Replace the current channel consumer.
setEnabled(boolean) - Method in class com.saicone.delivery4j.Broker
Set broker status.
setExecutor(DelayedExecutor<?>) - Method in class com.saicone.delivery4j.Broker
Replace the current delayed executor.
setExecutor(Executor) - Method in class com.saicone.delivery4j.AbstractMessenger
Replace the current executor with a custom implementation.
setHeaders(Iterable<Header>) - Method in class com.saicone.delivery4j.broker.KafkaBroker
Set the default headers used on every producer record created by this instance.
setKey(K) - Method in class com.saicone.delivery4j.broker.KafkaBroker
Set the default key used on every producer record created by this instance.
setLogger(Broker.Logger) - Method in class com.saicone.delivery4j.Broker
Replace the current logger.
setPartition(Integer) - Method in class com.saicone.delivery4j.broker.KafkaBroker
Set the default partition used on every producer record created by this instance.
setPollInterval(int, TimeUnit) - Method in class com.saicone.delivery4j.broker.SqlBroker
Set the poll that will be used to check for new messages from database, this is the maximum communication delay between applications.
Setting a different poll interval between applications may cause synchronization errors due it's value is multiplied by 3 to delete old messages from database in that interval.
By default, 10 seconds is used.
setReconnectionInterval(int, TimeUnit) - Method in class com.saicone.delivery4j.broker.KafkaBroker
Set the reconnection interval that will be used on this kafka broker instance.
By default, 8 seconds is used.
setReconnectionInterval(int, TimeUnit) - Method in class com.saicone.delivery4j.broker.PostgreSQLBroker
Set the reconnection interval that will be used on this postgres broker instance.
By default, 8 seconds is used.
setReconnectionInterval(int, TimeUnit) - Method in class com.saicone.delivery4j.broker.RabbitMQBroker
Set the reconnection interval that will be used on this redis broker instance.
setReconnectionInterval(int, TimeUnit) - Method in class com.saicone.delivery4j.broker.RedisBroker
Set the reconnection interval that will be used on this redis broker instance.
By default, 8 seconds is used.
setTablePrefix(String) - Method in class com.saicone.delivery4j.broker.SqlBroker
Set the table prefix that will be used before messenger table name.
setTimeout(long, TimeUnit) - Method in class com.saicone.delivery4j.broker.KafkaBroker
Set the record poll timeout, this is the maximum communication delay between applications.
By default, 5 seconds is used.
setTimeout(long, TimeUnit) - Method in class com.saicone.delivery4j.broker.PostgreSQLBroker
Set timeout that will be used to listen for new notifications from database, this is the maximum communication delay between applications.
By default, 5 seconds is used.
Slf4jLogger - Class in com.saicone.delivery4j.log
Slf4j integration for broker logging.
Slf4jLogger(Class<?>) - Constructor for class com.saicone.delivery4j.log.Slf4jLogger
Create a slf4j logger to provided class.
SqlBroker - Class in com.saicone.delivery4j.broker
Sql broker implementation to send data via polling.
Take in count that this is not a real broker, can be used as one but the client is doing all the job via insertion and repeatable deletion.
SqlBroker(DataSource) - Constructor for class com.saicone.delivery4j.broker.SqlBroker
Constructs a sql broker using the provided data source instance.
SqlBroker(Connection) - Constructor for class com.saicone.delivery4j.broker.SqlBroker
Constructs a sql broker using the provided connection instance.
This constructor assumes that the given connection should not be closed after return it.
start() - Method in class com.saicone.delivery4j.AbstractMessenger
Start the messenger instance connection.
start() - Method in class com.saicone.delivery4j.Broker
Start the broker connection.
start(Broker) - Method in class com.saicone.delivery4j.AbstractMessenger
Start the messenger instance connection with a provided broker.
subscribe(MessageChannel) - Method in class com.saicone.delivery4j.AbstractMessenger
Subscribe to provided message channel.
his method will make an automatic subscription into broker if it exists and is not subscribed to provided channel.
subscribe(String) - Method in class com.saicone.delivery4j.AbstractMessenger
Find or create a message channel subscription.
This method will make an automatic subscription into broker if it exists and is not subscribed to provided channel name.
subscribe(String...) - Method in class com.saicone.delivery4j.Broker
Subscribe broker into provided channels names.
Any repeated channel will be ignored.

U

unsubscribe(String...) - Method in class com.saicone.delivery4j.Broker
Unsubscribe broker from provided channels names.
Any repeated channel will be ignored.
A B C D E G H I J K L M N O P R S U 
All Classes and Interfaces|All Packages