Class MulticastDefinition

All Implemented Interfaces:
org.apache.camel.CamelContextAware, org.apache.camel.LineNumberAware, Block, ExecutorServiceAwareDefinition<MulticastDefinition>, OutputNode, org.apache.camel.NamedNode, org.apache.camel.spi.HasCamelContext, org.apache.camel.spi.HasId, org.apache.camel.spi.IdAware

@Metadata(label="eip,routing") public class MulticastDefinition extends OutputDefinition<MulticastDefinition> implements ExecutorServiceAwareDefinition<MulticastDefinition>
Routes the same message to multiple paths either sequentially or in parallel.
  • Constructor Details

    • MulticastDefinition

      public MulticastDefinition()
  • Method Details

    • getOutputs

      public List<ProcessorDefinition<?>> getOutputs()
      Overrides:
      getOutputs in class OutputDefinition<MulticastDefinition>
    • setOutputs

      public void setOutputs(List<ProcessorDefinition<?>> outputs)
      Overrides:
      setOutputs in class OutputDefinition<MulticastDefinition>
    • toString

      public String toString()
      Overrides:
      toString in class OutputDefinition<MulticastDefinition>
    • getShortName

      public String getShortName()
      Specified by:
      getShortName in interface org.apache.camel.NamedNode
      Overrides:
      getShortName in class OutputDefinition<MulticastDefinition>
    • getLabel

      public String getLabel()
      Description copied from class: ProcessorDefinition
      Returns a label to describe this node such as the expression if some kind of expression node
      Specified by:
      getLabel in interface org.apache.camel.NamedNode
      Overrides:
      getLabel in class ProcessorDefinition<MulticastDefinition>
    • aggregationStrategy

      public AggregationStrategyClause<MulticastDefinition> aggregationStrategy()
      Sets the AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast using a fluent builder.
    • aggregationStrategy

      public MulticastDefinition aggregationStrategy(org.apache.camel.AggregationStrategy aggregationStrategy)
      Sets the AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast. By default Camel will use the last reply as the outgoing message. You can also use a POJO as the AggregationStrategy. If an exception is thrown from the aggregate method in the AggregationStrategy, then by default, that exception is not handled by the error handler. The error handler can be enabled to react if enabling the shareUnitOfWork option.
    • aggregationStrategy

      public MulticastDefinition aggregationStrategy(String aggregationStrategy)
      Sets a reference to the AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast. By default Camel will use the last reply as the outgoing message. You can also use a POJO as the AggregationStrategy. If an exception is thrown from the aggregate method in the AggregationStrategy, then by default, that exception is not handled by the error handler. The error handler can be enabled to react if enabling the shareUnitOfWork option.
    • aggregationStrategyMethodName

      public MulticastDefinition aggregationStrategyMethodName(String methodName)
      This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
      Parameters:
      methodName - the method name to call
      Returns:
      the builder
    • aggregationStrategyMethodAllowNull

      public MulticastDefinition aggregationStrategyMethodAllowNull()
      If this option is false then the aggregate method is not used if there was no data to enrich. If this option is true then null values is used as the oldExchange (when no data to enrich), when using POJOs as the AggregationStrategy
      Returns:
      the builder
    • parallelProcessing

      public MulticastDefinition parallelProcessing()
      If enabled then sending messages to the multicasts occurs concurrently. Note the caller thread will still wait until all messages has been fully processed, before it continues. Its only the sending and processing the replies from the multicasts which happens concurrently. When parallel processing is enabled, then the Camel routing engin will continue processing using last used thread from the parallel thread pool. However, if you want to use the original thread that called the multicast, then make sure to enable the synchronous option as well.
      Returns:
      the builder
    • parallelProcessing

      public MulticastDefinition parallelProcessing(String parallelProcessing)
      If enabled then sending messages to the multicasts occurs concurrently. Note the caller thread will still wait until all messages has been fully processed, before it continues. Its only the sending and processing the replies from the multicasts which happens concurrently. When parallel processing is enabled, then the Camel routing engin will continue processing using last used thread from the parallel thread pool. However, if you want to use the original thread that called the multicast, then make sure to enable the synchronous option as well.
      Returns:
      the builder
    • parallelProcessing

      public MulticastDefinition parallelProcessing(boolean parallelProcessing)
      If enabled then sending messages to the multicasts occurs concurrently. Note the caller thread will still wait until all messages has been fully processed, before it continues. Its only the sending and processing the replies from the multicasts which happens concurrently. When parallel processing is enabled, then the Camel routing engin will continue processing using last used thread from the parallel thread pool. However, if you want to use the original thread that called the multicast, then make sure to enable the synchronous option as well.
      Returns:
      the builder
    • synchronous

      public MulticastDefinition synchronous()
      Sets whether synchronous processing should be strictly used. When enabled then the same thread is used to continue routing after the multicast is complete, even if parallel processing is enabled.
      Returns:
      the builder
    • synchronous

      public MulticastDefinition synchronous(boolean synchronous)
      Sets whether synchronous processing should be strictly used. When enabled then the same thread is used to continue routing after the multicast is complete, even if parallel processing is enabled.
      Returns:
      the builder
    • synchronous

      public MulticastDefinition synchronous(String synchronous)
      Sets whether synchronous processing should be strictly used. When enabled then the same thread is used to continue routing after the multicast is complete, even if parallel processing is enabled.
      Returns:
      the builder
    • parallelAggregate

      public MulticastDefinition parallelAggregate()
      If enabled then the aggregate method on AggregationStrategy can be called concurrently. Notice that this would require the implementation of AggregationStrategy to be implemented as thread-safe. By default this is false meaning that Camel synchronizes the call to the aggregate method. Though in some use-cases this can be used to archive higher performance when the AggregationStrategy is implemented as thread-safe.
      Returns:
      the builder
    • parallelAggregate

      public MulticastDefinition parallelAggregate(boolean parallelAggregate)
      If enabled then the aggregate method on AggregationStrategy can be called concurrently. Notice that this would require the implementation of AggregationStrategy to be implemented as thread-safe. By default this is false meaning that Camel synchronizes the call to the aggregate method. Though in some use-cases this can be used to archive higher performance when the AggregationStrategy is implemented as thread-safe.
      Returns:
      the builder
    • parallelAggregate

      public MulticastDefinition parallelAggregate(String parallelAggregate)
      If enabled then the aggregate method on AggregationStrategy can be called concurrently. Notice that this would require the implementation of AggregationStrategy to be implemented as thread-safe. By default this is false meaning that Camel synchronizes the call to the aggregate method. Though in some use-cases this can be used to archive higher performance when the AggregationStrategy is implemented as thread-safe.
      Returns:
      the builder
    • streaming

      public MulticastDefinition streaming()
      If enabled then Camel will process replies out-of-order, eg in the order they come back. If disabled, Camel will process replies in the same order as defined by the multicast.
      Returns:
      the builder
    • stopOnException

      public MulticastDefinition stopOnException()
      Will now stop further processing if an exception or failure occurred during processing of an Exchange and the caused exception will be thrown.

      Will also stop if processing the exchange failed (has a fault message) or an exception was thrown and handled by the error handler (such as using onException). In all situations the multicast will stop further processing. This is the same behavior as in pipeline, which is used by the routing engine.

      The default behavior is to not stop but continue processing till the end

      Returns:
      the builder
    • stopOnException

      public MulticastDefinition stopOnException(String stopOnException)
      Will now stop further processing if an exception or failure occurred during processing of an Exchange and the caused exception will be thrown.

      Will also stop if processing the exchange failed (has a fault message) or an exception was thrown and handled by the error handler (such as using onException). In all situations the multicast will stop further processing. This is the same behavior as in pipeline, which is used by the routing engine.

      The default behavior is to not stop but continue processing till the end

      Returns:
      the builder
    • executorService

      public MulticastDefinition executorService(ExecutorService executorService)
      To use a custom Thread Pool to be used for parallel processing. Notice if you set this option, then parallel processing is automatically implied, and you do not have to enable that option as well.
      Specified by:
      executorService in interface ExecutorServiceAwareDefinition<MulticastDefinition>
      Parameters:
      executorService - the executor service
      Returns:
      the builder
    • executorService

      public MulticastDefinition executorService(String executorService)
      Refers to a custom Thread Pool to be used for parallel processing. Notice if you set this option, then parallel processing is automatically implied, and you do not have to enable that option as well.
      Specified by:
      executorService in interface ExecutorServiceAwareDefinition<MulticastDefinition>
      Parameters:
      executorService - reference for a ExecutorService to lookup in the Registry
      Returns:
      the builder
    • onPrepare

      public ProcessClause<MulticastDefinition> onPrepare()
      Set the Processor to use when preparing the Exchange to be send using a fluent builder.
    • onPrepare

      public MulticastDefinition onPrepare(org.apache.camel.Processor onPrepare)
      Uses the Processor when preparing the Exchange to be send. This can be used to deep-clone messages that should be send, or any custom logic needed before the exchange is send.
      Parameters:
      onPrepare - the processor
      Returns:
      the builder
    • onPrepare

      public MulticastDefinition onPrepare(String onPrepare)
      Uses the Processor when preparing the Exchange to be send. This can be used to deep-clone messages that should be send, or any custom logic needed before the exchange is send.
      Parameters:
      onPrepare - reference to the processor to lookup in the Registry
      Returns:
      the builder
    • timeout

      public MulticastDefinition timeout(long timeout)
      Sets a total timeout specified in millis, when using parallel processing. If the Multicast hasn't been able to send and process all replies within the given timeframe, then the timeout triggers and the Multicast breaks out and continues. Notice if you provide a TimeoutAwareAggregationStrategy then the timeout method is invoked before breaking out. If the timeout is reached with running tasks still remaining, certain tasks for which it is difficult for Camel to shut down in a graceful manner may continue to run. So use this option with a bit of care.
      Parameters:
      timeout - timeout in millis
      Returns:
      the builder
    • timeout

      public MulticastDefinition timeout(String timeout)
      Sets a total timeout specified in millis, when using parallel processing. If the Multicast hasn't been able to send and process all replies within the given timeframe, then the timeout triggers and the Multicast breaks out and continues. Notice if you provide a TimeoutAwareAggregationStrategy then the timeout method is invoked before breaking out. If the timeout is reached with running tasks still remaining, certain tasks for which it is difficult for Camel to shut down in a graceful manner may continue to run. So use this option with a bit of care.
      Parameters:
      timeout - timeout in millis
      Returns:
      the builder
    • shareUnitOfWork

      public MulticastDefinition shareUnitOfWork()
      Shares the UnitOfWork with the parent and each of the sub messages. Multicast will by default not share unit of work between the parent exchange and each multicasted exchange. This means each sub exchange has its own individual unit of work.
      Returns:
      the builder.
    • getAggregationStrategyBean

      public org.apache.camel.AggregationStrategy getAggregationStrategyBean()
    • getOnPrepareProcessor

      public org.apache.camel.Processor getOnPrepareProcessor()
    • getExecutorServiceBean

      public ExecutorService getExecutorServiceBean()
      Description copied from interface: ExecutorServiceAwareDefinition
      Gets the executor service for executing
      Specified by:
      getExecutorServiceBean in interface ExecutorServiceAwareDefinition<MulticastDefinition>
    • getExecutorServiceRef

      public String getExecutorServiceRef()
      Description copied from interface: ExecutorServiceAwareDefinition
      Gets a reference id to lookup the executor service from the registry
      Specified by:
      getExecutorServiceRef in interface ExecutorServiceAwareDefinition<MulticastDefinition>
    • getParallelProcessing

      public String getParallelProcessing()
    • setParallelProcessing

      public void setParallelProcessing(String parallelProcessing)
    • getSynchronous

      public String getSynchronous()
    • setSynchronous

      public void setSynchronous(String synchronous)
    • getStreaming

      public String getStreaming()
    • setStreaming

      public void setStreaming(String streaming)
    • getStopOnException

      public String getStopOnException()
    • setStopOnException

      public void setStopOnException(String stopOnException)
    • getAggregationStrategy

      public String getAggregationStrategy()
    • setAggregationStrategy

      public void setAggregationStrategy(String aggregationStrategy)
      Refers to an AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast. By default Camel will use the last reply as the outgoing message. You can also use a POJO as the AggregationStrategy
    • setAggregationStrategy

      public void setAggregationStrategy(org.apache.camel.AggregationStrategy aggregationStrategy)
      Refers to an AggregationStrategy to be used to assemble the replies from the multicasts, into a single outgoing message from the Multicast. By default Camel will use the last reply as the outgoing message. You can also use a POJO as the AggregationStrategy
    • getAggregationStrategyMethodName

      public String getAggregationStrategyMethodName()
    • setAggregationStrategyMethodName

      public void setAggregationStrategyMethodName(String aggregationStrategyMethodName)
      This option can be used to explicit declare the method name to use, when using POJOs as the AggregationStrategy.
    • getAggregationStrategyMethodAllowNull

      public String getAggregationStrategyMethodAllowNull()
    • setAggregationStrategyMethodAllowNull

      public void setAggregationStrategyMethodAllowNull(String aggregationStrategyMethodAllowNull)
      If this option is false then the aggregate method is not used if there was no data to enrich. If this option is true then null values is used as the oldExchange (when no data to enrich), when using POJOs as the AggregationStrategy
    • getExecutorService

      public String getExecutorService()
    • setExecutorService

      public void setExecutorService(String executorService)
      Refers to a custom Thread Pool to be used for parallel processing. Notice if you set this option, then parallel processing is automatic implied, and you do not have to enable that option as well.
    • getTimeout

      public String getTimeout()
    • setTimeout

      public void setTimeout(String timeout)
    • getShareUnitOfWork

      public String getShareUnitOfWork()
    • setShareUnitOfWork

      public void setShareUnitOfWork(String shareUnitOfWork)
    • getParallelAggregate

      public String getParallelAggregate()
    • setParallelAggregate

      public void setParallelAggregate(String parallelAggregate)
    • getOnPrepare

      public String getOnPrepare()
    • setOnPrepare

      public void setOnPrepare(String onPrepare)