A B C D E F G H I L M N P Q R S T V W 
All Classes All Packages

A

accept(FlowInfo) - Method in class com.github.dbmdz.flusswerk.framework.monitoring.DefaultFlowMetrics
 
ack(Envelope) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
ack(Message) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.MessageBroker
Acknowledges a message to remove it from the queue.
ack(Message) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitMQ
Acknowledges a message with RabbitMQ.
AppProperties - Class in com.github.dbmdz.flusswerk.framework.config.properties
 
AppProperties(String) - Constructor for class com.github.dbmdz.flusswerk.framework.config.properties.AppProperties
 

B

because(String, Object...) - Static method in exception com.github.dbmdz.flusswerk.framework.exceptions.RetryProcessingException
Fluid interface to create exception suppliers, e.g.
because(String, Object...) - Static method in exception com.github.dbmdz.flusswerk.framework.exceptions.SkipProcessingException
Fluid interface to create exception suppliers, e.g.
because(String, Object...) - Static method in exception com.github.dbmdz.flusswerk.framework.exceptions.StopProcessingException
Fluid interface to create exception suppliers, e.g.
bindQueue(String, String, String) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
build() - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.ConfigurationStep
Build the new flow.

C

causedBy(Throwable) - Method in class com.github.dbmdz.flusswerk.framework.exceptions.ExceptionSupplier
Add the exceptions cause to the supplier without interfering with the format string arguments.
causedBy(Throwable) - Method in exception com.github.dbmdz.flusswerk.framework.exceptions.RetryProcessingException
Add the exceptions cause to the exception without interfering with the format string arguments.
causedBy(Throwable) - Method in exception com.github.dbmdz.flusswerk.framework.exceptions.SkipProcessingException
Add the exceptions cause to the exception without interfering with the format string arguments.
causedBy(Throwable) - Method in exception com.github.dbmdz.flusswerk.framework.exceptions.StopProcessingException
Add the exceptions cause to the exception without interfering with the format string arguments.
cleanup(Runnable) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.ConfigurationStep
Sets a cleanup task process monitor that consumes a FlowInfo instance every time a message has been processed.
com.github.dbmdz.flusswerk.framework - package com.github.dbmdz.flusswerk.framework
 
com.github.dbmdz.flusswerk.framework.config - package com.github.dbmdz.flusswerk.framework.config
 
com.github.dbmdz.flusswerk.framework.config.properties - package com.github.dbmdz.flusswerk.framework.config.properties
 
com.github.dbmdz.flusswerk.framework.engine - package com.github.dbmdz.flusswerk.framework.engine
 
com.github.dbmdz.flusswerk.framework.exceptions - package com.github.dbmdz.flusswerk.framework.exceptions
 
com.github.dbmdz.flusswerk.framework.flow - package com.github.dbmdz.flusswerk.framework.flow
 
com.github.dbmdz.flusswerk.framework.flow.builder - package com.github.dbmdz.flusswerk.framework.flow.builder
 
com.github.dbmdz.flusswerk.framework.jackson - package com.github.dbmdz.flusswerk.framework.jackson
 
com.github.dbmdz.flusswerk.framework.model - package com.github.dbmdz.flusswerk.framework.model
 
com.github.dbmdz.flusswerk.framework.monitoring - package com.github.dbmdz.flusswerk.framework.monitoring
 
com.github.dbmdz.flusswerk.framework.rabbitmq - package com.github.dbmdz.flusswerk.framework.rabbitmq
 
com.github.dbmdz.flusswerk.framework.reporting - package com.github.dbmdz.flusswerk.framework.reporting
 
compareTo(Task) - Method in class com.github.dbmdz.flusswerk.framework.engine.Task
 
ConfigurationStep<M extends Message,​R,​W> - Class in com.github.dbmdz.flusswerk.framework.flow.builder
Set configuration for the new flow and build it.
consume(Consumer<M>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.MessageProcessorStep
Set a message processor that receives a message of type M and does not return any Message for Flusswerk to send.
counter(String, Status, String...) - Method in class com.github.dbmdz.flusswerk.framework.monitoring.MeterFactory
 
counter(String, String...) - Method in class com.github.dbmdz.flusswerk.framework.monitoring.MeterFactory
 
createQueue(String, Map<String, Object>) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 

D

debug(String, Object...) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkLogger
Log messages with level debug.
declareQueue(String, String, String, Map<String, Object>) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
decrementActiveWorkers() - Method in class com.github.dbmdz.flusswerk.framework.monitoring.FlusswerkMetrics
 
DEFAULT_EXCHANGE - Static variable in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
defaultDeadLetterExchange(String) - Static method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
DefaultFlowMetrics - Class in com.github.dbmdz.flusswerk.framework.monitoring
Collect metrics on flow execution.
DefaultFlowMetrics(MeterFactory) - Constructor for class com.github.dbmdz.flusswerk.framework.monitoring.DefaultFlowMetrics
 
DefaultMixin - Interface in com.github.dbmdz.flusswerk.framework.jackson
 
DefaultProcessReport - Class in com.github.dbmdz.flusswerk.framework.reporting
 
DefaultProcessReport(String) - Constructor for class com.github.dbmdz.flusswerk.framework.reporting.DefaultProcessReport
 
defaults() - Static method in class com.github.dbmdz.flusswerk.framework.config.properties.MonitoringProperties
 
defaults() - Static method in class com.github.dbmdz.flusswerk.framework.config.properties.ProcessingProperties
 
defaults() - Static method in class com.github.dbmdz.flusswerk.framework.config.properties.RabbitMQProperties
 
defaults() - Static method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
deregister() - Method in class com.github.dbmdz.flusswerk.framework.reporting.Tracing
Delete tracing information for current Thread.
deserialize(String) - Method in class com.github.dbmdz.flusswerk.framework.jackson.FlusswerkObjectMapper
 
done() - Method in class com.github.dbmdz.flusswerk.framework.engine.Task
 
duration() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowInfo
 

E

EnableFlusswerk - Annotation Type in com.github.dbmdz.flusswerk.framework
Spring Boot annotation to enable automatic configuration of Flusswerk via application.yml and provide beans for autowiring.
engine - Variable in class com.github.dbmdz.flusswerk.framework.FlusswerkApplication
 
engine(Optional<Flow>, List<FlusswerkConsumer>, ProcessingProperties, RabbitConnection, Set<FlowMetrics>, MeterFactory, List<Worker>) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
Engine - Class in com.github.dbmdz.flusswerk.framework.engine
Run flows Flow for every message from the MessageBroker - usually several in parallel.
Engine(Channel, List<FlusswerkConsumer>, List<Worker>) - Constructor for class com.github.dbmdz.flusswerk.framework.engine.Engine
Creates a new Engine bridging RabbitMQ consumers and Flusswerk workers.
Engine(Channel, List<FlusswerkConsumer>, List<Worker>, ExecutorService) - Constructor for class com.github.dbmdz.flusswerk.framework.engine.Engine
 
Envelope - Class in com.github.dbmdz.flusswerk.framework.model
Technical metadata all implementations of Message must have.
Envelope() - Constructor for class com.github.dbmdz.flusswerk.framework.model.Envelope
Default constructor setting the Envelope.timestamp to now.
EnvelopeMixin - Interface in com.github.dbmdz.flusswerk.framework.jackson
 
equals(Object) - Method in class com.github.dbmdz.flusswerk.framework.engine.Task
 
equals(Object) - Method in class com.github.dbmdz.flusswerk.framework.model.Message
 
equals(Object) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Queue
 
equals(Object) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Topic
 
error(String, Object...) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkLogger
Log messages with level error.
ERROR_RETRY - com.github.dbmdz.flusswerk.framework.monitoring.Status
 
ERROR_STOP - com.github.dbmdz.flusswerk.framework.monitoring.Status
 
ExceptionSupplier<T extends Exception> - Class in com.github.dbmdz.flusswerk.framework.exceptions
Generic supplier for exceptions.
ExceptionSupplier(Class<T>, String, Object[]) - Constructor for class com.github.dbmdz.flusswerk.framework.exceptions.ExceptionSupplier
 
expand(Function<M, Collection<Message>>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.MessageProcessorStep
Set a message processor that receives a message of type M and returns a Collection of Message, then moves you to the next builder step.

F

fail(Message) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.MessageBroker
 
FailurePolicy - Class in com.github.dbmdz.flusswerk.framework.rabbitmq
 
FailurePolicy(String) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.FailurePolicy
 
FailurePolicy(String, int) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.FailurePolicy
 
FailurePolicy(String, String, String, Integer, Duration) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.FailurePolicy
 
FailurePolicyProperties(Integer, String, String, Duration) - Constructor for class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties.FailurePolicyProperties
 
FALLBACK_MAPPER - Static variable in class com.github.dbmdz.flusswerk.framework.engine.FlusswerkConsumer
 
flow(Type<M>, Type<R>, Type<W>) - Static method in class com.github.dbmdz.flusswerk.framework.flow.builder.FlowBuilder
Create a builder for a new read/transform/write flow.
flow(Type<M>, Type<T>) - Static method in class com.github.dbmdz.flusswerk.framework.flow.builder.FlowBuilder
Create a builder for a new read/transform/write flow for the special case that the reader output type is used throughout the flow.
flow(Class<M>, Class<R>, Class<W>) - Static method in class com.github.dbmdz.flusswerk.framework.flow.builder.FlowBuilder
Create a builder for a new read/transform/write flow.
flow(Class<M>, Class<T>) - Static method in class com.github.dbmdz.flusswerk.framework.flow.builder.FlowBuilder
Create a builder for a new read/transform/write flow for the special case that the reader output type is used throughout the flow.
flow(Optional<FlowSpec>, Tracing) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
Flow - Class in com.github.dbmdz.flusswerk.framework.flow
Recipe for the data processing.
Flow(FlowSpec, Tracing) - Constructor for class com.github.dbmdz.flusswerk.framework.flow.Flow
 
FlowBuilder - Class in com.github.dbmdz.flusswerk.framework.flow.builder
Experimental implementation of a new FlowBuilderApi.
FlowBuilder() - Constructor for class com.github.dbmdz.flusswerk.framework.flow.builder.FlowBuilder
 
FlowInfo - Class in com.github.dbmdz.flusswerk.framework.flow
Collect base metrics for a single flow - did the execution have errors and how long does it take?
FlowInfo(Message) - Constructor for class com.github.dbmdz.flusswerk.framework.flow.FlowInfo
 
FlowMetrics - Interface in com.github.dbmdz.flusswerk.framework.monitoring
Interface for all metrics collectors that need access to the execution information of a flow.
FlowSpec - Class in com.github.dbmdz.flusswerk.framework.flow
 
FlowSpec(Function<Message, Object>, Function<Object, Object>, Function<Object, Collection<Message>>, Runnable, Consumer<FlowInfo>) - Constructor for class com.github.dbmdz.flusswerk.framework.flow.FlowSpec
 
FlusswerkApplication - Class in com.github.dbmdz.flusswerk.framework
Common base class for application main class to remove boilerplate.
FlusswerkApplication(Optional<Engine>) - Constructor for class com.github.dbmdz.flusswerk.framework.FlusswerkApplication
 
FlusswerkConfiguration - Class in com.github.dbmdz.flusswerk.framework.config
Spring configuration to provide beans forMessageBroker and Engine.
FlusswerkConfiguration() - Constructor for class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
FlusswerkConsumer - Class in com.github.dbmdz.flusswerk.framework.engine
Receive AMQP message from a RabbitMQ queue, deserialize the Flusswerk Message and put that into the internal task queue.
FlusswerkConsumer(Semaphore, Channel, FlusswerkObjectMapper, String, int, PriorityBlockingQueue<Task>) - Constructor for class com.github.dbmdz.flusswerk.framework.engine.FlusswerkConsumer
Constructs a new instance and records its association to the passed-in channel.
flusswerkConsumers(FlusswerkObjectMapper, ProcessingProperties, RabbitConnection, RoutingProperties, PriorityBlockingQueue<Task>) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
FlusswerkLogger - Class in com.github.dbmdz.flusswerk.framework.reporting
Logger class to automatically add tracing paths to your structured logging.
FlusswerkLoggerFactory - Class in com.github.dbmdz.flusswerk.framework.reporting
 
FlusswerkLoggerFactory(Tracing) - Constructor for class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkLoggerFactory
 
FlusswerkMetrics - Class in com.github.dbmdz.flusswerk.framework.monitoring
 
FlusswerkMetrics(ProcessingProperties, MeterRegistry) - Constructor for class com.github.dbmdz.flusswerk.framework.monitoring.FlusswerkMetrics
 
flusswerkObjectMapper(ObjectProvider<IncomingMessageType>) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
FlusswerkObjectMapper - Class in com.github.dbmdz.flusswerk.framework.jackson
 
FlusswerkObjectMapper(IncomingMessageType) - Constructor for class com.github.dbmdz.flusswerk.framework.jackson.FlusswerkObjectMapper
 
FlusswerkProcessReport - Class in com.github.dbmdz.flusswerk.framework.reporting
 
FlusswerkProcessReport(String, FlusswerkLogger) - Constructor for class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkProcessReport
 
FlusswerkProperties - Class in com.github.dbmdz.flusswerk.framework.config.properties
Model for the configuration parameters in application.yml.
FlusswerkProperties(ProcessingProperties, RabbitMQProperties, RoutingProperties, MonitoringProperties) - Constructor for class com.github.dbmdz.flusswerk.framework.config.properties.FlusswerkProperties
 
FlusswerkPropertiesConfiguration - Class in com.github.dbmdz.flusswerk.framework.config
Separate config class for reading configuration properties to enable automated testing.
FlusswerkPropertiesConfiguration() - Constructor for class com.github.dbmdz.flusswerk.framework.config.FlusswerkPropertiesConfiguration
 
forIncoming(Class<? extends Message>) - Static method in class com.github.dbmdz.flusswerk.framework.jackson.FlusswerkObjectMapper
Convenience factory method to prevent overly long lines.
frameworkCounter(String, Status) - Method in class com.github.dbmdz.flusswerk.framework.monitoring.MeterFactory
 

G

get() - Method in class com.github.dbmdz.flusswerk.framework.exceptions.ExceptionSupplier
 
getBackoff() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties.FailurePolicyProperties
 
getBackoff() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.FailurePolicy
 
getBody() - Method in interface com.github.dbmdz.flusswerk.framework.jackson.EnvelopeMixin
 
getBody() - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
The original String representation before serializing into an Message instance.
getChannel() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitConnection
Access to the low-level RabbitMQ Channel.
getCleanup() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowSpec
 
getCreated() - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
Gets the timestamp when the Message was created.
getDeadLetterExchange() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
Deprecated.
getDeadLetterExchange(String) - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
getDeadLetterExchanges() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
getDefaultExchange() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
Deprecated.
getDeliveryTag() - Method in interface com.github.dbmdz.flusswerk.framework.jackson.EnvelopeMixin
 
getDeliveryTag() - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
The delivery tag set by RabbitMQ for low level message handling.
getEnvelope() - Method in exception com.github.dbmdz.flusswerk.framework.exceptions.InvalidMessageException
 
getEnvelope() - Method in class com.github.dbmdz.flusswerk.framework.model.Message
Technical metadata like timestamps and retries.
getExchange(String) - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
getExchanges() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
getFailedRoutingKey() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties.FailurePolicyProperties
 
getFailedRoutingKey() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.FailurePolicy
 
getFailurePolicy(Message) - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
getFailurePolicy(String) - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
getFlusswerkLogger(Class<?>) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkLoggerFactory
 
getHosts() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RabbitMQProperties
 
getIncoming() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
getInputQueue() - Method in class com.github.dbmdz.flusswerk.framework.engine.FlusswerkConsumer
 
getInputQueue() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.FailurePolicy
 
getLogger() - Method in class com.github.dbmdz.flusswerk.framework.reporting.DefaultProcessReport
 
getLogger() - Method in class com.github.dbmdz.flusswerk.framework.reporting.StructuredProcessReport
 
getMessage() - Method in class com.github.dbmdz.flusswerk.framework.engine.Task
 
getMessage() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowInfo
 
getMessageClass() - Method in class com.github.dbmdz.flusswerk.framework.model.IncomingMessageType
 
getMessageCount(String) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
getMixin() - Method in class com.github.dbmdz.flusswerk.framework.model.IncomingMessageType
 
getMonitor() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowSpec
 
getMonitoring() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.FlusswerkProperties
 
getName() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.AppProperties
 
getName() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Queue
 
getName() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Topic
 
getOutgoing() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
getOutgoingMessages() - Method in exception com.github.dbmdz.flusswerk.framework.exceptions.SkipProcessingException
 
getPassword() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RabbitMQProperties
 
getPrefix() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.MonitoringProperties
 
getPriority() - Method in class com.github.dbmdz.flusswerk.framework.engine.Task
 
getProcessing() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.FlusswerkProperties
 
getRabbitMQ() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.FlusswerkProperties
 
getReader() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowSpec
 
getRetries() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties.FailurePolicyProperties
 
getRetries() - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
Gets the number of retries before a message is sent to the failed queue.
getRetries() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.FailurePolicy
 
getRetryMessageCounts() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.MessageBroker
 
getRetryRoutingKey() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties.FailurePolicyProperties
 
getRetryRoutingKey() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.FailurePolicy
 
getRouting() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.FlusswerkProperties
 
getSource() - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
Gets the queue name where this message was received from.
getStatus() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowInfo
 
getThreads() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.ProcessingProperties
 
getTracing() - Method in class com.github.dbmdz.flusswerk.framework.model.Message
 
getTransformer() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowSpec
 
getUsername() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RabbitMQProperties
 
getVirtualHost() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RabbitMQProperties
 
getWriter() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowSpec
 

H

handleDelivery(String, Envelope, AMQP.BasicProperties, byte[]) - Method in class com.github.dbmdz.flusswerk.framework.engine.FlusswerkConsumer
 
hashCode() - Method in class com.github.dbmdz.flusswerk.framework.engine.Task
 
hashCode() - Method in class com.github.dbmdz.flusswerk.framework.model.Message
 
hashCode() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Queue
 
hashCode() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Topic
 
hasMixin() - Method in class com.github.dbmdz.flusswerk.framework.model.IncomingMessageType
 

I

IncomingMessageType - Class in com.github.dbmdz.flusswerk.framework.model
Register a custom message implementation via Spring.
IncomingMessageType() - Constructor for class com.github.dbmdz.flusswerk.framework.model.IncomingMessageType
Use Message for incoming messages.
IncomingMessageType(Class<? extends Message>) - Constructor for class com.github.dbmdz.flusswerk.framework.model.IncomingMessageType
Provide a custom Message implementation with default serialization and deserialization settings.
IncomingMessageType(Class<? extends Message>, Class<?>) - Constructor for class com.github.dbmdz.flusswerk.framework.model.IncomingMessageType
Provide a custom Message implementation with custom serialization and deserialization settings.
incrementActiveWorkers() - Method in class com.github.dbmdz.flusswerk.framework.monitoring.FlusswerkMetrics
 
info(String, Object...) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkLogger
Log messages with level info.
innerProcess(Message) - Method in class com.github.dbmdz.flusswerk.framework.flow.Flow
 
InvalidMessageException - Exception in com.github.dbmdz.flusswerk.framework.exceptions
 
InvalidMessageException(Envelope, String) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.InvalidMessageException
 
InvalidMessageException(Envelope, String, Throwable) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.InvalidMessageException
 
isChannelAvailable() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
isSet(Object) - Static method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 

L

LockingException - Exception in com.github.dbmdz.flusswerk.framework.exceptions
 
LockingException(String) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.LockingException
 
LockingException(String, Throwable) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.LockingException
 
logger - Variable in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkProcessReport
 

M

Message - Class in com.github.dbmdz.flusswerk.framework.model
A generic message as it will be sent over RabbitMQ.
Message() - Constructor for class com.github.dbmdz.flusswerk.framework.model.Message
 
messageBroker(RoutingProperties, RabbitClient) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
MessageBroker - Class in com.github.dbmdz.flusswerk.framework.rabbitmq
A MessageBroker provides a high level API to interact with an MessageBroker like RabbitMQ and provides the framework engines logic for message operations like sending, retrieving or rejecting for messages.
MessageBroker(RoutingProperties, RabbitClient) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.MessageBroker
 
messageCount() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Queue
 
messageProcessor(Type<M>) - Static method in class com.github.dbmdz.flusswerk.framework.flow.builder.FlowBuilder
Create builder for a special flow that operates on the messages only and does not fit the usual read/transform/write pattern.
messageProcessor(Class<M>) - Static method in class com.github.dbmdz.flusswerk.framework.flow.builder.FlowBuilder
Create builder for a special flow that operates on the messages only and does not fit the usual read/transform/write pattern.
MessageProcessorStep<M extends Message> - Class in com.github.dbmdz.flusswerk.framework.flow.builder
Set a new message processor that takes a message and returns a List of messages.
messagesSeconds - Variable in class com.github.dbmdz.flusswerk.framework.monitoring.DefaultFlowMetrics
 
messagesTotal - Variable in class com.github.dbmdz.flusswerk.framework.monitoring.DefaultFlowMetrics
 
meterFactory(MonitoringProperties, MeterRegistry) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
MeterFactory - Class in com.github.dbmdz.flusswerk.framework.monitoring
Convenience factory to simplify the creation of Counter meters.
MeterFactory(String, MeterRegistry) - Constructor for class com.github.dbmdz.flusswerk.framework.monitoring.MeterFactory
 
metrics(ProcessingProperties, MeterRegistry) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
metrics(Consumer<FlowInfo>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.ConfigurationStep
Sets a process metrics monitor that consumes a FlowInfo instance every time a message has been processed.
minimal(List<String>, Map<String, String>) - Static method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
Create RoutingProperties by only specifying input queues and routes to support simple tests.
MonitoringProperties - Class in com.github.dbmdz.flusswerk.framework.config.properties
Settings for monitoring endpoints.
MonitoringProperties(String) - Constructor for class com.github.dbmdz.flusswerk.framework.config.properties.MonitoringProperties
 

N

name - Variable in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkProcessReport
 
newPath() - Method in class com.github.dbmdz.flusswerk.framework.reporting.Tracing
Generates a new tracing path that contains exactly one tracing id.
noTransformer() - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.TransformerStep
Declares that the flow does not have a transformer and the output of the reader should go directly into the writer, then moves you to the next builder step (setting a writer).

P

process(Message) - Method in class com.github.dbmdz.flusswerk.framework.engine.Worker
 
process(Message) - Method in class com.github.dbmdz.flusswerk.framework.flow.Flow
 
process(Function<M, Message>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.MessageProcessorStep
Set a message processor that receives a message of type M and returns an arbitrary Message, then moves you to the next builder step.
ProcessingProperties - Class in com.github.dbmdz.flusswerk.framework.config.properties
Configuration related to the processing.
ProcessingProperties(Integer) - Constructor for class com.github.dbmdz.flusswerk.framework.config.properties.ProcessingProperties
 
ProcessReport - Interface in com.github.dbmdz.flusswerk.framework.reporting
 
provideExchange(String) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
purge() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Queue
Removes all messages from a queue.

Q

queue(String) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitMQ
A RabbitMQ queue.
Queue - Class in com.github.dbmdz.flusswerk.framework.rabbitmq
Represents a AMQP/RabbitMQ queue to receive messages or perform management tasks.

R

rabbitClient(FlusswerkObjectMapper, RabbitConnection) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
RabbitClient - Class in com.github.dbmdz.flusswerk.framework.rabbitmq
 
RabbitClient(FlusswerkObjectMapper, RabbitConnection) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
RabbitClient(IncomingMessageType, RabbitConnection) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
RabbitClient(RabbitConnection) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
rabbitConnection(AppProperties, RabbitMQProperties) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
RabbitConnection - Class in com.github.dbmdz.flusswerk.framework.rabbitmq
 
RabbitConnection(RabbitMQProperties, String) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitConnection
 
rabbitMQ(RoutingProperties, RabbitClient, MessageBroker, Tracing) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
RabbitMQ - Class in com.github.dbmdz.flusswerk.framework.rabbitmq
Interactions with RabbitMQ - send messages, get the number of messages in a queue and more.
RabbitMQ(RoutingProperties, RabbitClient, MessageBroker, Tracing) - Constructor for class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitMQ
Creates a new Queues instance.
RabbitMQProperties - Class in com.github.dbmdz.flusswerk.framework.config.properties
Connection information for RabbitMQ.
RabbitMQProperties(List<String>, String, String, String) - Constructor for class com.github.dbmdz.flusswerk.framework.config.properties.RabbitMQProperties
 
reader(Function<M, R>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.ReaderStep
Sets a reader that receives a message of type M and creates a model object of type R, then moves you to the next builder step.
ReaderStep<M extends Message,​R,​W> - Class in com.github.dbmdz.flusswerk.framework.flow.builder
Set a new reader while building the new flow (typesafe).
receive() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.MessageBroker
Gets one message from the input queue but does not acknowledge it.
receive() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Queue
Tries to receives a message from RabbitMQ.
receive(String) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.MessageBroker
Gets one message from the queue but does not acknowledge it.
receive(String) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitClient
 
register(List<String>) - Method in class com.github.dbmdz.flusswerk.framework.reporting.Tracing
Saves the tracing path and adds a new tracing ID for the current workflow job.
registerFlowMetrics(Set<FlowMetrics>) - Method in class com.github.dbmdz.flusswerk.framework.flow.Flow
 
reject(Message) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.MessageBroker
Rejects a messaging and takes care of proper dead lettering, retries and, if the message failed too often, routing to the failed queue.
reportFail(Message, StopProcessingException) - Method in class com.github.dbmdz.flusswerk.framework.reporting.DefaultProcessReport
 
reportFail(Message, StopProcessingException) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkProcessReport
 
reportFail(Message, StopProcessingException) - Method in interface com.github.dbmdz.flusswerk.framework.reporting.ProcessReport
Report a failed (finally failed) message
reportFail(Message, StopProcessingException) - Method in class com.github.dbmdz.flusswerk.framework.reporting.SilentProcessReport
 
reportFail(Message, StopProcessingException) - Method in class com.github.dbmdz.flusswerk.framework.reporting.StructuredProcessReport
 
reportFailAfterMaxRetries(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.DefaultProcessReport
 
reportFailAfterMaxRetries(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkProcessReport
 
reportFailAfterMaxRetries(Message, Exception) - Method in interface com.github.dbmdz.flusswerk.framework.reporting.ProcessReport
Report a failed message, which failed after the maximum number of retries
reportFailAfterMaxRetries(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.SilentProcessReport
 
reportFailAfterMaxRetries(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.StructuredProcessReport
 
reportReject(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.DefaultProcessReport
 
reportReject(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkProcessReport
 
reportReject(Message, Exception) - Method in interface com.github.dbmdz.flusswerk.framework.reporting.ProcessReport
Report a rejected (temporarily failed) message
reportReject(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.SilentProcessReport
 
reportReject(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.StructuredProcessReport
 
reportSkip(Message, Exception) - Method in class com.github.dbmdz.flusswerk.framework.reporting.DefaultProcessReport
 
reportSkip(Message, Exception) - Method in interface com.github.dbmdz.flusswerk.framework.reporting.ProcessReport
 
reportSuccess(Message) - Method in class com.github.dbmdz.flusswerk.framework.reporting.DefaultProcessReport
 
reportSuccess(Message) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkProcessReport
 
reportSuccess(Message) - Method in interface com.github.dbmdz.flusswerk.framework.reporting.ProcessReport
Report a successfully handled message
reportSuccess(Message) - Method in class com.github.dbmdz.flusswerk.framework.reporting.SilentProcessReport
 
reportSuccess(Message) - Method in class com.github.dbmdz.flusswerk.framework.reporting.StructuredProcessReport
 
RetryProcessingException - Exception in com.github.dbmdz.flusswerk.framework.exceptions
Throw this exception in case of errors that might go away when trying again later.
RetryProcessingException(String) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.RetryProcessingException
 
RetryProcessingException(String, Object...) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.RetryProcessingException
 
route(String) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitMQ
A topic to send messages to.
RoutingProperties - Class in com.github.dbmdz.flusswerk.framework.config.properties
AMQP/RabbitMQ routing information.
RoutingProperties(String, List<String>, Map<String, String>, Map<String, String>, Map<String, String>, Map<String, RoutingProperties.FailurePolicyProperties>) - Constructor for class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
RoutingProperties.FailurePolicyProperties - Class in com.github.dbmdz.flusswerk.framework.config.properties
 
run() - Method in class com.github.dbmdz.flusswerk.framework.engine.Worker
 
run(String...) - Method in class com.github.dbmdz.flusswerk.framework.FlusswerkApplication
 

S

send(Message) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Topic
Sends a message to this topic.
send(Message...) - Method in exception com.github.dbmdz.flusswerk.framework.exceptions.SkipProcessingException
Add messages to send to the next workflow job.
send(Message...) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Topic
Convenience implementation, mostly for tests.
send(Collection<? extends Message>) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.MessageBroker
Deprecated.
send(Collection<Message>) - Method in exception com.github.dbmdz.flusswerk.framework.exceptions.SkipProcessingException
Add messages to send to the next workflow job.
send(Collection<Message>) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Topic
Sends multiple messages to this topic.
sendRaw(byte[]) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Topic
Sends a bunch of bytes to RabbitMQ.
setBody(String) - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
The original String representation before serializing into an Message instance.
setCreated(Instant) - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
Sets the timestamp when the Message was created.
setDeliveryTag(long) - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
The delivery tag set by RabbitMQ for low level message handling.
setRetries(int) - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
Sets the number of retries before a message is sent to the failed queue.
setSource(String) - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
Gets the queue name where this message was received from.
setTracing(List<String>) - Method in class com.github.dbmdz.flusswerk.framework.model.Message
 
shutdown() - Method in class com.github.dbmdz.flusswerk.framework.FlusswerkApplication
 
SilentProcessReport - Class in com.github.dbmdz.flusswerk.framework.reporting
Empty implementation for unit tests that reports nothing.
SilentProcessReport() - Constructor for class com.github.dbmdz.flusswerk.framework.reporting.SilentProcessReport
 
SKIP - com.github.dbmdz.flusswerk.framework.monitoring.Status
 
SkipProcessingException - Exception in com.github.dbmdz.flusswerk.framework.exceptions
Indicates that processing should be skipped from the point on where this exception is thrown.
SkipProcessingException(String) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.SkipProcessingException
Skip processing with an explanation of why.
start() - Method in class com.github.dbmdz.flusswerk.framework.engine.Engine
Starts processing messages until Engine.stop() is called.
Status - Enum in com.github.dbmdz.flusswerk.framework.monitoring
 
stop() - Method in class com.github.dbmdz.flusswerk.framework.engine.Engine
Stops processing new messages or waiting for new messages to arrive.
stop() - Method in class com.github.dbmdz.flusswerk.framework.engine.Worker
Stops processing new messages or waiting for new messages to arrive.
stop() - Method in class com.github.dbmdz.flusswerk.framework.flow.FlowInfo
 
StopProcessingException - Exception in com.github.dbmdz.flusswerk.framework.exceptions
Throw this exception in case of errors that won't go away when trying again later.
StopProcessingException(String) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.StopProcessingException
 
StopProcessingException(String, Object...) - Constructor for exception com.github.dbmdz.flusswerk.framework.exceptions.StopProcessingException
 
StructuredProcessReport - Class in com.github.dbmdz.flusswerk.framework.reporting
 
StructuredProcessReport(String, Tracing) - Constructor for class com.github.dbmdz.flusswerk.framework.reporting.StructuredProcessReport
 
SUCCESS - com.github.dbmdz.flusswerk.framework.monitoring.Status
 

T

Task - Class in com.github.dbmdz.flusswerk.framework.engine
 
Task(Message, int) - Constructor for class com.github.dbmdz.flusswerk.framework.engine.Task
 
Task(Message, int, Runnable) - Constructor for class com.github.dbmdz.flusswerk.framework.engine.Task
 
taskQueue() - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
topic(String) - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.RabbitMQ
A topic to send messages to.
Topic - Class in com.github.dbmdz.flusswerk.framework.rabbitmq
Represents a AMQP/RabbitMQ topic to send messages to.
toString() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.AppProperties
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.FlusswerkProperties
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.MonitoringProperties
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.ProcessingProperties
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RabbitMQProperties
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.config.properties.RoutingProperties
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.engine.Task
 
toString() - Method in exception com.github.dbmdz.flusswerk.framework.exceptions.StopProcessingException
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.model.Envelope
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.model.Message
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Queue
 
toString() - Method in class com.github.dbmdz.flusswerk.framework.rabbitmq.Topic
 
trace(String, Object...) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkLogger
Log messages with level trace.
tracing() - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
Tracing - Class in com.github.dbmdz.flusswerk.framework.reporting
 
Tracing() - Constructor for class com.github.dbmdz.flusswerk.framework.reporting.Tracing
 
tracingPath() - Method in class com.github.dbmdz.flusswerk.framework.reporting.Tracing
 
transformer(Function<R, W>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.TransformerStep
Sets a transformer that receives data of type R and returns new data of type R, then moves you to the next builder step.
TransformerStep<M extends Message,​R,​W> - Class in com.github.dbmdz.flusswerk.framework.flow.builder
Set a new transformer while building the new flow (typesafe).
TransformerStep(Model<M, R, W>) - Constructor for class com.github.dbmdz.flusswerk.framework.flow.builder.TransformerStep
 
Type<T> - Class in com.github.dbmdz.flusswerk.framework.flow
A type instance represents a generic type information for the fluent FlowBuilder interface.
Type() - Constructor for class com.github.dbmdz.flusswerk.framework.flow.Type
 

V

valueOf(String) - Static method in enum com.github.dbmdz.flusswerk.framework.monitoring.Status
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.github.dbmdz.flusswerk.framework.monitoring.Status
Returns an array containing the constants of this enum type, in the order they are declared.

W

warn(String, Object...) - Method in class com.github.dbmdz.flusswerk.framework.reporting.FlusswerkLogger
Log messages with level warn.
Worker - Class in com.github.dbmdz.flusswerk.framework.engine
 
Worker(Flow, FlusswerkMetrics, MessageBroker, ProcessReport, PriorityBlockingQueue<Task>, Tracing) - Constructor for class com.github.dbmdz.flusswerk.framework.engine.Worker
 
workers(AppProperties, Optional<Flow>, MessageBroker, ProcessingProperties, Optional<ProcessReport>, PriorityBlockingQueue<Task>, Tracing, FlusswerkMetrics) - Method in class com.github.dbmdz.flusswerk.framework.config.FlusswerkConfiguration
 
writerSendingMessage(Function<W, Message>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.WriterStep
Sets a writer that receives data of type and sends a new message, then moves you to the next builder step.
writerSendingMessages(Function<W, Collection<Message>>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.WriterStep
Sets a writer that receives data of type and sends a List of new messages, then moves you to the next builder step.
writerSendingNothing(Consumer<W>) - Method in class com.github.dbmdz.flusswerk.framework.flow.builder.WriterStep
Sets a writer that receives data of type and stops processing, then moves you to the next builder step.
WriterStep<M extends Message,​R,​W> - Class in com.github.dbmdz.flusswerk.framework.flow.builder
Set a new writer while building the new flow (typesafe).
WriterStep(Model<M, R, W>) - Constructor for class com.github.dbmdz.flusswerk.framework.flow.builder.WriterStep
 
A B C D E F G H I L M N P Q R S T V W 
All Classes All Packages