Class SplitDefinition

All Implemented Interfaces:
org.apache.camel.CamelContextAware, org.apache.camel.LineNumberAware, Block, ExecutorServiceAwareDefinition<SplitDefinition>, HasExpressionType, 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 SplitDefinition extends OutputExpressionNode implements ExecutorServiceAwareDefinition<SplitDefinition>
Splits a single message into many sub-messages.
  • Constructor Details

    • SplitDefinition

      public SplitDefinition()
    • SplitDefinition

      public SplitDefinition(org.apache.camel.Expression expression)
    • SplitDefinition

      public SplitDefinition(ExpressionDefinition expression)
  • Method Details

    • toString

      public String toString()
      Overrides:
      toString in class Object
    • getShortName

      public String getShortName()
      Specified by:
      getShortName in interface org.apache.camel.NamedNode
    • 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 ExpressionNode
    • delimiter

      public SplitDefinition delimiter(String delimiter)
      Delimiter used in splitting messages. Can be turned off using the value false.

      The default value is ,

      Parameters:
      delimiter - the delimiter
      Returns:
      the builder
    • aggregationStrategy

      public SplitDefinition aggregationStrategy(org.apache.camel.AggregationStrategy aggregationStrategy)
      Sets the AggregationStrategy to be used to assemble the replies from the split messages, into a single outgoing message from the Splitter. By default Camel will use the original incoming message to the splitter (leave it unchanged). You can also use a POJO as the AggregationStrategy
    • aggregationStrategy

      public SplitDefinition aggregationStrategy(String aggregationStrategy)
      Sets a reference to the AggregationStrategy to be used to assemble the replies from the split messages, into a single outgoing message from the Splitter. By default Camel will use the original incoming message to the splitter (leave it unchanged). You can also use a POJO as the AggregationStrategy
    • aggregationStrategyMethodName

      public SplitDefinition 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 SplitDefinition 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
    • aggregationStrategyMethodAllowNull

      public SplitDefinition aggregationStrategyMethodAllowNull(boolean 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
    • aggregationStrategyMethodAllowNull

      public SplitDefinition aggregationStrategyMethodAllowNull(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
      Returns:
      the builder
    • parallelProcessing

      public SplitDefinition parallelProcessing()
      If enabled then processing each split messages occurs concurrently. Note the caller thread will still wait until all messages has been fully processed, before it continues. It's only processing the sub messages from the splitter 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 splitter, then make sure to enable the synchronous option as well.
      Returns:
      the builder
    • parallelProcessing

      public SplitDefinition parallelProcessing(boolean parallelProcessing)
      If enabled then processing each split messages occurs concurrently. Note the caller thread will still wait until all messages has been fully processed, before it continues. It's only processing the sub messages from the splitter 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 splitter, then make sure to enable the synchronous option as well.
      Returns:
      the builder
    • parallelProcessing

      public SplitDefinition parallelProcessing(String parallelProcessing)
      If enabled then processing each split messages occurs concurrently. Note the caller thread will still wait until all messages has been fully processed, before it continues. It's only processing the sub messages from the splitter 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 splitter, then make sure to enable the synchronous option as well.
      Returns:
      the builder
    • parallelAggregate

      public SplitDefinition 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 SplitDefinition 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 SplitDefinition 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
    • synchronous

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

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

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

      public SplitDefinition streaming()
      When in streaming mode, then the splitter splits the original message on-demand, and each split message is processed one by one. This reduces memory usage as the splitter do not split all the messages first, but then we do not know the total size, and therefore the Exchange.SPLIT_SIZE is empty.

      In non-streaming mode (default) the splitter will split each message first, to know the total size, and then process each message one by one. This requires to keep all the split messages in memory and therefore requires more memory. The total size is provided in the Exchange.SPLIT_SIZE header.

      The streaming mode also affects the aggregation behavior. If enabled then Camel will process replies out-of-order, e.g. in the order they come back. If disabled, Camel will process replies in the same order as the messages was split.

      Returns:
      the builder
    • streaming

      public SplitDefinition streaming(boolean streaming)
      When in streaming mode, then the splitter splits the original message on-demand, and each split message is processed one by one. This reduces memory usage as the splitter do not split all the messages first, but then we do not know the total size, and therefore the Exchange.SPLIT_SIZE is empty.

      In non-streaming mode (default) the splitter will split each message first, to know the total size, and then process each message one by one. This requires to keep all the split messages in memory and therefore requires more memory. The total size is provided in the Exchange.SPLIT_SIZE header.

      The streaming mode also affects the aggregation behavior. If enabled then Camel will process replies out-of-order, e.g. in the order they come back. If disabled, Camel will process replies in the same order as the messages was split.

      Returns:
      the builder
    • streaming

      public SplitDefinition streaming(String streaming)
      When in streaming mode, then the splitter splits the original message on-demand, and each split message is processed one by one. This reduces memory usage as the splitter do not split all the messages first, but then we do not know the total size, and therefore the Exchange.SPLIT_SIZE is empty.

      In non-streaming mode (default) the splitter will split each message first, to know the total size, and then process each message one by one. This requires to keep all the split messages in memory and therefore requires more memory. The total size is provided in the Exchange.SPLIT_SIZE header.

      The streaming mode also affects the aggregation behavior. If enabled then Camel will process replies out-of-order, e.g. in the order they come back. If disabled, Camel will process replies in the same order as the messages was split.

      Returns:
      the builder
    • stopOnException

      public SplitDefinition 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 splitter 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 SplitDefinition stopOnException(boolean 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 splitter 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 SplitDefinition 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 splitter 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 SplitDefinition 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<SplitDefinition>
      Parameters:
      executorService - the executor service
      Returns:
      the builder
    • executorService

      public SplitDefinition 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<SplitDefinition>
      Parameters:
      executorService - reference for a ExecutorService to lookup in the Registry
      Returns:
      the builder
    • onPrepare

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

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

      public SplitDefinition timeout(long timeout)
      Sets a total timeout specified in millis, when using parallel processing. If the Splitter hasn't been able to split and process all the sub messages within the given timeframe, then the timeout triggers and the Splitter 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 SplitDefinition timeout(String timeout)
      Sets a total timeout specified in millis, when using parallel processing. If the Splitter hasn't been able to split and process all the sub messages within the given timeframe, then the timeout triggers and the Splitter 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 SplitDefinition shareUnitOfWork()
      Shares the UnitOfWork with the parent and each of the sub messages. Splitter will by default not share unit of work between the parent exchange and each split exchange. This means each split exchange has its own individual unit of work.
      Returns:
      the builder.
    • shareUnitOfWork

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

      public SplitDefinition shareUnitOfWork(String shareUnitOfWork)
      Shares the UnitOfWork with the parent and each of the sub messages. Splitter will by default not share unit of work between the parent exchange and each split exchange. This means each split 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<SplitDefinition>
    • 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<SplitDefinition>
    • setExpression

      public void setExpression(ExpressionDefinition expression)
      Expression of how to split the message body, such as as-is, using a tokenizer, or using a xpath.
      Overrides:
      setExpression in class ExpressionNode
    • getDelimiter

      public String getDelimiter()
    • setDelimiter

      public void setDelimiter(String delimiter)
    • 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)
    • getParallelAggregate

      public String getParallelAggregate()
    • setParallelAggregate

      public void setParallelAggregate(String parallelAggregate)
    • getStopOnException

      public String getStopOnException()
    • setStopOnException

      public void setStopOnException(String stopOnException)
    • getAggregationStrategy

      public String getAggregationStrategy()
    • setAggregationStrategy

      public void setAggregationStrategy(String aggregationStrategy)
      Sets a reference to the AggregationStrategy to be used to assemble the replies from the split messages, into a single outgoing message from the Splitter. By default Camel will use the original incoming message to the splitter (leave it unchanged). You can also use a POJO as the AggregationStrategy
    • setAggregationStrategy

      public void setAggregationStrategy(org.apache.camel.AggregationStrategy aggregationStrategyBean)
      Sets the AggregationStrategy to be used to assemble the replies from the split messages, into a single outgoing message from the Splitter. By default Camel will use the original incoming message to the splitter (leave it unchanged). 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
    • getTimeout

      public String getTimeout()
    • setTimeout

      public void setTimeout(String timeout)
    • getOnPrepare

      public String getOnPrepare()
    • setOnPrepare

      public void setOnPrepare(String onPrepare)
    • getShareUnitOfWork

      public String getShareUnitOfWork()
    • setShareUnitOfWork

      public void setShareUnitOfWork(String shareUnitOfWork)
    • getExecutorService

      public String getExecutorService()
    • setExecutorService

      public void setExecutorService(String executorService)