Uses of Class
org.apache.camel.model.ProcessorDefinition

Packages that use ProcessorDefinition
org.apache.camel The core Camel API. 
org.apache.camel.builder The Camel Domain Specific Language for creating Routes, Predicates, Expressions and Error Handlers
org.apache.camel.impl Default implementation classes for Camel Core 
org.apache.camel.management Camel management 
org.apache.camel.management.mbean Camel management JMX MBeans 
org.apache.camel.model The JAXB POJOs for the XML Configuration of the routing rules. 
org.apache.camel.processor.interceptor Helper classes for interceptors. 
org.apache.camel.spi Service Provider Interfaces used internally by the Camel runtime which are plugin strategies. 
org.apache.camel.view Helper class to help with the Visualisation of Routes 
 

Uses of ProcessorDefinition in org.apache.camel
 

Methods in org.apache.camel that return ProcessorDefinition
 ProcessorDefinition<?> RouteNode.getProcessorDefinition()
          Gets the model definition that represents this node
 

Uses of ProcessorDefinition in org.apache.camel.builder
 

Classes in org.apache.camel.builder with type parameters of type ProcessorDefinition
 class AdviceWithBuilder<T extends ProcessorDefinition<?>>
          A builder when using the advice with feature.
 class DataFormatClause<T extends ProcessorDefinition<?>>
          An expression for constructing the different possible DataFormat options.
 

Methods in org.apache.camel.builder with type parameters of type ProcessorDefinition
<T extends ProcessorDefinition<?>>
ProcessorDefinition<?>
AdviceWithRouteBuilder.weaveAddFirst()
          Weaves by adding the nodes to the start of the route.
<T extends ProcessorDefinition<?>>
ProcessorDefinition<?>
AdviceWithRouteBuilder.weaveAddLast()
          Weaves by adding the nodes to the end of the route.
<T extends ProcessorDefinition<?>>
AdviceWithBuilder<T>
AdviceWithRouteBuilder.weaveById(String pattern)
          Weaves by matching id of the nodes in the route.
<T extends ProcessorDefinition<?>>
AdviceWithBuilder<T>
AdviceWithRouteBuilder.weaveByToString(String pattern)
          Weaves by matching the to string representation of the nodes in the route.
<T extends ProcessorDefinition<?>>
AdviceWithBuilder<T>
AdviceWithRouteBuilder.weaveByType(Class<T> type)
          Weaves by matching type of the nodes in the route.
 

Methods in org.apache.camel.builder that return ProcessorDefinition
 ProcessorDefinition<?> AdviceWithBuilder.after()
          Insert the following node(s) after the matched node(s)
 ProcessorDefinition<?> AdviceWithBuilder.before()
          Insert the following node(s) before the matched node(s)
 ProcessorDefinition<?> AdviceWithBuilder.replace()
          Replaces the matched node(s) with the following nodes.
<T extends ProcessorDefinition<?>>
ProcessorDefinition<?>
AdviceWithRouteBuilder.weaveAddFirst()
          Weaves by adding the nodes to the start of the route.
<T extends ProcessorDefinition<?>>
ProcessorDefinition<?>
AdviceWithRouteBuilder.weaveAddLast()
          Weaves by adding the nodes to the end of the route.
 

Methods in org.apache.camel.builder with parameters of type ProcessorDefinition
static AdviceWithTask AdviceWithTasks.afterById(RouteDefinition route, String id, ProcessorDefinition<?> after, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
static AdviceWithTask AdviceWithTasks.afterByToString(RouteDefinition route, String toString, ProcessorDefinition<?> after, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
static AdviceWithTask AdviceWithTasks.afterByType(RouteDefinition route, Class<?> type, ProcessorDefinition<?> after, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
static AdviceWithTask AdviceWithTasks.beforeById(RouteDefinition route, String id, ProcessorDefinition<?> before, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
static AdviceWithTask AdviceWithTasks.beforeByToString(RouteDefinition route, String toString, ProcessorDefinition<?> before, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
static AdviceWithTask AdviceWithTasks.beforeByType(RouteDefinition route, Class<?> type, ProcessorDefinition<?> before, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
static AdviceWithTask AdviceWithTasks.replaceById(RouteDefinition route, String id, ProcessorDefinition<?> replace, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
static AdviceWithTask AdviceWithTasks.replaceByToString(RouteDefinition route, String toString, ProcessorDefinition<?> replace, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
static AdviceWithTask AdviceWithTasks.replaceByType(RouteDefinition route, Class<?> type, ProcessorDefinition<?> replace, boolean selectFirst, boolean selectLast, int selectFrom, int selectTo)
           
 

Uses of ProcessorDefinition in org.apache.camel.impl
 

Methods in org.apache.camel.impl that return ProcessorDefinition
 ProcessorDefinition<?> OnExceptionRouteNode.getProcessorDefinition()
           
 ProcessorDefinition<?> OnCompletionRouteNode.getProcessorDefinition()
           
 ProcessorDefinition<?> DoFinallyRouteNode.getProcessorDefinition()
           
 ProcessorDefinition<?> DoCatchRouteNode.getProcessorDefinition()
           
 ProcessorDefinition<?> DefaultRouteNode.getProcessorDefinition()
           
 ProcessorDefinition<?> AggregateRouteNode.getProcessorDefinition()
           
 

Methods in org.apache.camel.impl with parameters of type ProcessorDefinition
 boolean DefaultDebugger.afterProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition, long timeTaken)
           
 void BreakpointSupport.afterProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition, long timeTaken)
           
 boolean DefaultDebugger.beforeProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition)
           
 void BreakpointSupport.beforeProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition)
           
 int DefaultRouteContext.getAndIncrement(ProcessorDefinition<?> node)
           
 int DefaultTracedRouteNodes.getAndIncrementCounter(ProcessorDefinition<?> node)
           
 boolean ConditionSupport.matchProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition)
           
protected  void DefaultDebugger.onAfterProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition, long timeTaken, Breakpoint breakpoint)
           
protected  void DefaultDebugger.onBeforeProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition, Breakpoint breakpoint)
           
 void BreakpointSupport.onEvent(Exchange exchange, EventObject event, ProcessorDefinition<?> definition)
           
 

Constructors in org.apache.camel.impl with parameters of type ProcessorDefinition
DefaultRouteNode(ProcessorDefinition<?> processorDefinition, Expression expression)
           
DefaultRouteNode(ProcessorDefinition<?> processorDefinition, Processor processor)
           
 

Uses of ProcessorDefinition in org.apache.camel.management
 

Methods in org.apache.camel.management with parameters of type ProcessorDefinition
 Object DefaultManagementObjectStrategy.getManagedObjectForProcessor(CamelContext context, Processor processor, ProcessorDefinition<?> definition, Route route)
           
 ObjectName DefaultManagementNamingStrategy.getObjectNameForProcessor(CamelContext context, Processor processor, ProcessorDefinition<?> definition)
           
 boolean ManagedManagementStrategy.manageProcessor(ProcessorDefinition<?> definition)
           
 boolean DefaultManagementStrategy.manageProcessor(ProcessorDefinition<?> definition)
           
protected  boolean DefaultManagementLifecycleStrategy.registerProcessor(ProcessorDefinition<?> processor)
          Should the given processor be registered.
 Processor InstrumentationInterceptStrategy.wrapProcessorInInterceptors(CamelContext context, ProcessorDefinition<?> definition, Processor target, Processor nextTarget)
           
 

Constructor parameters in org.apache.camel.management with type arguments of type ProcessorDefinition
InstrumentationInterceptStrategy(Map<ProcessorDefinition<?>,PerformanceCounter> registeredCounters, Map<Processor,KeyValueHolder<ProcessorDefinition<?>,InstrumentationProcessor>> wrappedProcessors)
           
InstrumentationInterceptStrategy(Map<ProcessorDefinition<?>,PerformanceCounter> registeredCounters, Map<Processor,KeyValueHolder<ProcessorDefinition<?>,InstrumentationProcessor>> wrappedProcessors)
           
 

Uses of ProcessorDefinition in org.apache.camel.management.mbean
 

Methods in org.apache.camel.management.mbean that return ProcessorDefinition
 ProcessorDefinition<?> ManagedProcessor.getDefinition()
           
 

Methods in org.apache.camel.management.mbean with parameters of type ProcessorDefinition
 void JMXNotificationTraceEventHandler.traceExchange(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange)
           
 Object JMXNotificationTraceEventHandler.traceExchangeIn(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange)
           
 void JMXNotificationTraceEventHandler.traceExchangeOut(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange, Object traceState)
           
 

Constructors in org.apache.camel.management.mbean with parameters of type ProcessorDefinition
ManagedBeanProcessor(CamelContext context, BeanProcessor processor, ProcessorDefinition<?> definition)
           
ManagedDelayer(CamelContext context, Delayer delayer, ProcessorDefinition<?> definition)
           
ManagedIdempotentConsumer(CamelContext context, IdempotentConsumer idempotentConsumer, ProcessorDefinition<?> definition)
           
ManagedProcessor(CamelContext context, Processor processor, ProcessorDefinition<?> definition)
           
ManagedSendProcessor(CamelContext context, SendProcessor processor, ProcessorDefinition<?> definition)
           
ManagedThrottler(CamelContext context, Throttler throttler, ProcessorDefinition<?> definition)
           
 

Uses of ProcessorDefinition in org.apache.camel.model
 

Classes in org.apache.camel.model with type parameters of type ProcessorDefinition
 class DynamicRouterDefinition<Type extends ProcessorDefinition<Type>>
          Represents an XML <dynamicRouter/> element
 interface ExecutorServiceAwareDefinition<Type extends ProcessorDefinition<?>>
          Enables definitions to support concurrency using ExecutorService
 class NoOutputDefinition<Type extends ProcessorDefinition<Type>>
          Base class for definitions which does not support outputs.
 class OutputDefinition<Type extends ProcessorDefinition<Type>>
          A useful base class for output types
 class ProcessorDefinition<Type extends ProcessorDefinition<Type>>
          Base class for processor types that most XML types extend.
 class RecipientListDefinition<Type extends ProcessorDefinition<Type>>
          Represents an XML <recipientList/> element
 class RoutingSlipDefinition<Type extends ProcessorDefinition<Type>>
          Represents an XML <routingSlip/> element
 class SendDefinition<Type extends ProcessorDefinition<Type>>
          Base class for sending to an endpoint with an optional ExchangePattern
 class WireTapDefinition<Type extends ProcessorDefinition<Type>>
          Represents an XML <wireTap/> element
 

Subclasses of ProcessorDefinition in org.apache.camel.model
 class AggregateDefinition
          Represents an XML <aggregate/> element
 class AOPDefinition
          Deprecated. will be removed in the future. You can for example use Processor and InterceptStrategy to do AOP in Camel.
 class BeanDefinition
          Represents an XML <bean/> element
 class CatchDefinition
          Represents an XML <catch/> element
 class ChoiceDefinition
          Represents an XML <choice/> element
 class ConvertBodyDefinition
          Represents an XML <convertBodyTo/> element
 class DelayDefinition
          Represents an XML <delay/> element
 class DynamicRouterDefinition<Type extends ProcessorDefinition<Type>>
          Represents an XML <dynamicRouter/> element
 class EnrichDefinition
          Represents an XML <enrich/> element
 class ExpressionNode
          A base class for nodes which contain an expression and a number of outputs
 class FilterDefinition
          Represents an XML <filter/> element
 class FinallyDefinition
          Represents an XML <finally/> element
 class IdempotentConsumerDefinition
          Represents an XML <idempotentConsumer/> element
 class InOnlyDefinition
          Represents an XML <inOnly/> element
 class InOutDefinition
          Represents an XML <inOut/> element
 class InterceptDefinition
          Represents an XML <intercept/> element
 class InterceptFromDefinition
          Represents an XML <interceptFrom/> element
 class InterceptSendToEndpointDefinition
          Represents an XML <interceptToEndpoint/> element
 class LoadBalanceDefinition
          Represents an XML <loadBalance/> element
 class LogDefinition
          Represents an XML <log/> element
 class LoopDefinition
          Represents an XML <loop/> element
 class MarshalDefinition
          Marshals to a binary payload using the given DataFormatDefinition
 class MulticastDefinition
          Represents an XML <multicast/> element
 class NoOutputDefinition<Type extends ProcessorDefinition<Type>>
          Base class for definitions which does not support outputs.
 class NoOutputExpressionNode
          An ExpressionNode which does not support any outputs.
 class OnCompletionDefinition
          Represents an XML <onCompletion/> element
 class OnExceptionDefinition
          Represents an XML <onException/> element
 class OtherwiseDefinition
          Represents an XML <otherwise/> element
 class OutputDefinition<Type extends ProcessorDefinition<Type>>
          A useful base class for output types
 class PipelineDefinition
          Represents an XML <pipeline/> element which can be used to define an explicit pipeline; or to define a specific pipeline within a <multicast> block
 class PolicyDefinition
          Represents an XML <policy/> element
 class PollEnrichDefinition
          Represents an XML <pollEnrich/> element
 class ProcessDefinition
          Represents an XML <process/> element
 class RecipientListDefinition<Type extends ProcessorDefinition<Type>>
          Represents an XML <recipientList/> element
 class RemoveHeaderDefinition
          Represents an XML <removeHeader/> element
 class RemoveHeadersDefinition
          Represents an XML <removeHeaders/> element
 class RemovePropertyDefinition
          Represents an XML <removeProperty/> element
 class ResequenceDefinition
          Represents an XML <resequence/> element
 class RollbackDefinition
          Represents an XML <rollback/> element
 class RouteDefinition
          Represents an XML <route/> element
 class RoutingSlipDefinition<Type extends ProcessorDefinition<Type>>
          Represents an XML <routingSlip/> element
 class SamplingDefinition
          Represents an XML <sample/> element
 class SendDefinition<Type extends ProcessorDefinition<Type>>
          Base class for sending to an endpoint with an optional ExchangePattern
 class SetBodyDefinition
          Represents an XML <setBody/> element.
 class SetExchangePatternDefinition
          Represents an XML <setExchangePattern/> element
 class SetFaultBodyDefinition
          Represents an XML <setFaultBody/> element.
 class SetHeaderDefinition
          Represents an XML <setHeader/> element
 class SetOutHeaderDefinition
          Deprecated. not really needed, will be removed in the future
 class SetPropertyDefinition
          Represents an XML <setProperty/> element
 class SortDefinition<T>
          Represents an XML <sort/> element
 class SplitDefinition
          Represents an XML <split/> element
 class StopDefinition
          Represents an XML <stop/> element
 class ThreadsDefinition
          Represents an XML <threads/> element
 class ThrottleDefinition
          Represents an XML <throttle/> element
 class ThrowExceptionDefinition
          Represents an XML <throwException/> element
 class ToDefinition
          Represents an XML <to/> element
 class TransactedDefinition
          Represents an XML <transacted/> element
 class TransformDefinition
          Represents an XML <transform/> element
 class TryDefinition
          Represents an XML <try/> element
 class UnmarshalDefinition
          Unmarshals the binary payload using the given DataFormatDefinition
 class ValidateDefinition
          Represents an XML <validate/> element
 class WhenDefinition
          Represents an XML <when/> element
 class WhenSkipSendToEndpointDefinition
           
 class WireTapDefinition<Type extends ProcessorDefinition<Type>>
          Represents an XML <wireTap/> element
 

Fields in org.apache.camel.model with type parameters of type ProcessorDefinition
protected  List<ProcessorDefinition<?>> OutputDefinition.outputs
           
 

Methods in org.apache.camel.model that return ProcessorDefinition
 ProcessorDefinition<?> ProcessorDefinition.end()
          Ends the current block
 ProcessorDefinition<?> OnCompletionDefinition.end()
           
 ProcessorDefinition<?> WhenDefinition.endParent()
           
 ProcessorDefinition<?> ProcessorDefinition.endParent()
          Strategy to allow ProcessorDefinitions to have special logic when using end() in the DSL to return back to the intended parent.
 ProcessorDefinition<?> ProcessorDefinition.getParent()
           
 ProcessorDefinition<?> ModelChannel.getProcessorDefinition()
          Gets the definition of the next processor
 

Methods in org.apache.camel.model that return types with arguments of type ProcessorDefinition
 List<ProcessorDefinition<?>> RoutingSlipDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> RouteDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> ResequenceDefinition.getOutputs()
           
abstract  List<ProcessorDefinition<?>> ProcessorDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> OutputDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> OnExceptionDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> OnCompletionDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> NoOutputExpressionNode.getOutputs()
           
 List<ProcessorDefinition<?>> NoOutputDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> LoadBalanceDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> ExpressionNode.getOutputs()
           
 List<ProcessorDefinition<?>> DynamicRouterDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> ChoiceDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> CatchDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> AggregateDefinition.getOutputs()
           
 List<ProcessorDefinition<?>> TryDefinition.getOutputsWithoutCatches()
           
 DataFormatClause<ProcessorDefinition<Type>> ProcessorDefinition.marshal()
          DataFormat: Marshals the in body using a DataFormat expression to define the format of the output which will be added to the out body.
 ExpressionClause<ProcessorDefinition<Type>> ProcessorDefinition.setBody()
          Message Translator EIP: Adds a processor which sets the body on the IN message
 ExpressionClause<ProcessorDefinition<Type>> ProcessorDefinition.setHeader(String name)
          Adds a processor which sets the header on the IN message
 ExpressionClause<ProcessorDefinition<Type>> ProcessorDefinition.setOutHeader(String name)
          Deprecated. use setHeader(String)
 ExpressionClause<ProcessorDefinition<Type>> ProcessorDefinition.setProperty(String name)
          Adds a processor which sets the exchange property
 ExpressionClause<ProcessorDefinition<Type>> ProcessorDefinition.transform()
          Message Translator EIP: Adds a processor which sets the body on the OUT message
 DataFormatClause<ProcessorDefinition<Type>> ProcessorDefinition.unmarshal()
          DataFormat: Unmarshals the in body using a DataFormat expression to define the format of the input message and the output will be set on the out message body.
 

Methods in org.apache.camel.model with parameters of type ProcessorDefinition
 void WireTapDefinition.addOutput(ProcessorDefinition<?> output)
           
 void TryDefinition.addOutput(ProcessorDefinition<?> output)
           
 void ProcessorDefinition.addOutput(ProcessorDefinition<?> output)
           
 void NoOutputExpressionNode.addOutput(ProcessorDefinition<?> output)
           
 void LogDefinition.addOutput(ProcessorDefinition<?> output)
           
 void Block.addOutput(ProcessorDefinition<?> processorDefinition)
          Adds the given definition as output to this block
protected  void ProcessorDefinition.configureChild(ProcessorDefinition<?> output)
          Strategy for children to do any custom configuration
protected  void ExpressionNode.configureChild(ProcessorDefinition<?> output)
           
protected  void ChoiceDefinition.configureChild(ProcessorDefinition<?> output)
           
protected  void AggregateDefinition.configureChild(ProcessorDefinition<?> output)
           
static void RouteDefinitionHelper.forceAssignIds(CamelContext context, ProcessorDefinition processor)
          Force assigning ids to the give node and all its children (recursively).
static RouteDefinition ProcessorDefinitionHelper.getRoute(ProcessorDefinition<?> node)
          Gets the route definition the given node belongs to.
 void ModelChannel.initChannel(ProcessorDefinition<?> outputDefinition, RouteContext routeContext)
          Initializes the channel.
static void RouteDefinitionHelper.initParent(ProcessorDefinition parent)
           
static boolean ProcessorDefinitionHelper.isFirstChildOfType(Class<?> parentType, ProcessorDefinition<?> node)
          Is the given child the first in the outputs from the parent?
static boolean ProcessorDefinitionHelper.isParentOfType(Class<?> parentType, ProcessorDefinition<?> node, boolean recursive)
          Is the given node parent(s) of the given type
 void ModelChannel.postInitChannel(ProcessorDefinition<?> outputDefinition, RouteContext routeContext)
          Post initializes the channel.
 void OnCompletionDefinition.removeAllOnCompletionDefinition(ProcessorDefinition<?> definition)
          Removes all existing OnCompletionDefinition from the definition.
 void ModelChannel.setChildDefinition(ProcessorDefinition<?> child)
          If the initialized output definition contained outputs (children) then we need to set the child so we can leverage fine grained tracing
 void ProcessorDefinition.setParent(ProcessorDefinition<?> parent)
           
protected  Processor ProcessorDefinition.wrapChannel(RouteContext routeContext, Processor processor, ProcessorDefinition<?> child)
           
 

Method parameters in org.apache.camel.model with type arguments of type ProcessorDefinition
protected  Processor ProcessorDefinition.createOutputsProcessor(RouteContext routeContext, Collection<ProcessorDefinition<?>> outputs)
           
protected  Processor LoadBalanceDefinition.createOutputsProcessor(RouteContext routeContext, Collection<ProcessorDefinition<?>> outputs)
           
static
<T> Iterator<T>
ProcessorDefinitionHelper.filterTypeInOutputs(List<ProcessorDefinition<?>> outputs, Class<T> type)
          Looks for the given type in the list of outputs and recurring all the children as well.
static
<T> T
ProcessorDefinitionHelper.findFirstTypeInOutputs(List<ProcessorDefinition<?>> outputs, Class<T> type)
          Looks for the given type in the list of outputs and recurring all the children as well.
static boolean ProcessorDefinitionHelper.hasOutputs(List<ProcessorDefinition<?>> outputs, boolean excludeAbstract)
          Is there any outputs in the given list.
static void RouteDefinitionHelper.prepareRouteForInit(RouteDefinition route, List<ProcessorDefinition<?>> abstracts, List<ProcessorDefinition<?>> lower)
           
static void RouteDefinitionHelper.prepareRouteForInit(RouteDefinition route, List<ProcessorDefinition<?>> abstracts, List<ProcessorDefinition<?>> lower)
           
 void TryDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void RouteDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void ResequenceDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void OutputDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void OnExceptionDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void OnCompletionDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void LoadBalanceDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void ExpressionNode.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void CatchDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 void AggregateDefinition.setOutputs(List<ProcessorDefinition<?>> outputs)
           
 

Uses of ProcessorDefinition in org.apache.camel.processor.interceptor
 

Methods in org.apache.camel.processor.interceptor that return ProcessorDefinition
 ProcessorDefinition<?> TraceInterceptor.getNode()
           
 ProcessorDefinition<?> DefaultChannel.getProcessorDefinition()
           
 

Methods in org.apache.camel.processor.interceptor with parameters of type ProcessorDefinition
 Processor TraceInterceptorFactory.createTraceInterceptor(ProcessorDefinition<?> node, Processor target, TraceFormatter formatter, Tracer tracer)
          Create a trace interceptor.
 Processor DefaultTraceInterceptorFactory.createTraceInterceptor(ProcessorDefinition<?> node, Processor target, TraceFormatter formatter, Tracer tracer)
           
protected  String DefaultTraceFormatter.extractBreadCrumb(TraceInterceptor interceptor, ProcessorDefinition<?> currentNode, Exchange exchange)
          Creates the breadcrumb based on whether this was a trace of an exchange coming out of or into a processing step.
protected  String DefaultTraceFormatter.extractRoute(ProcessorDefinition<?> node)
           
 Object TraceFormatter.format(TraceInterceptor interceptor, ProcessorDefinition<?> node, Exchange exchange)
          Formats a log message at given point of interception.
 Object DefaultTraceFormatter.format(TraceInterceptor interceptor, ProcessorDefinition<?> node, Exchange exchange)
           
 void DefaultChannel.initChannel(ProcessorDefinition<?> outputDefinition, RouteContext routeContext)
           
 void DefaultChannel.postInitChannel(ProcessorDefinition<?> outputDefinition, RouteContext routeContext)
           
 void DefaultChannel.setChildDefinition(ProcessorDefinition<?> childDefinition)
           
protected  boolean TraceInterceptor.shouldLogNode(ProcessorDefinition<?> node)
          Returns true if the given node should be logged in the trace list
 void TraceEventHandler.traceExchange(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange)
          Event called when an Exchange is about to be processed

This event is only called if trace out has been disabled (which it is by default).

 void DefaultTraceEventHandler.traceExchange(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange)
           
 Object TraceEventHandler.traceExchangeIn(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange)
          Event called when an Exchange is about to be processed (in)

This event is only called if trace out has been enabled.

 Object DefaultTraceEventHandler.traceExchangeIn(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange)
           
 void TraceEventHandler.traceExchangeOut(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange, Object traceState)
          Event called when an Exchange has been processed (out)

This event is only called if trace out has been enabled.

 void DefaultTraceEventHandler.traceExchangeOut(ProcessorDefinition<?> node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange, Object traceState)
           
 Processor Tracer.wrapProcessorInInterceptors(CamelContext context, ProcessorDefinition<?> definition, Processor target, Processor nextTarget)
           
 Processor StreamCaching.wrapProcessorInInterceptors(CamelContext context, ProcessorDefinition<?> definition, Processor target, Processor nextTarget)
           
 Processor HandleFault.wrapProcessorInInterceptors(CamelContext context, ProcessorDefinition<?> definition, Processor target, Processor nextTarget)
           
 Processor Delayer.wrapProcessorInInterceptors(CamelContext context, ProcessorDefinition<?> definition, Processor target, Processor nextTarget)
           
 Processor Debug.wrapProcessorInInterceptors(CamelContext context, ProcessorDefinition<?> definition, Processor target, Processor nextTarget)
           
 

Constructors in org.apache.camel.processor.interceptor with parameters of type ProcessorDefinition
DefaultTraceEventMessage(Date timestamp, ProcessorDefinition<?> toNode, Exchange exchange)
          Creates a DefaultTraceEventMessage based on the given node it was traced while processing the current Exchange
DelayInterceptor(CamelContext camelContext, ProcessorDefinition<?> node, Processor target, Delayer delayer)
           
TraceInterceptor(ProcessorDefinition<?> node, Processor target, TraceFormatter formatter, Tracer tracer)
           
 

Uses of ProcessorDefinition in org.apache.camel.spi
 

Methods in org.apache.camel.spi with parameters of type ProcessorDefinition
 boolean Debugger.afterProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition, long timeTaken)
          Callback invoked when an Exchange has been processed which allows implementators to notify breakpoints.
 void Breakpoint.afterProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition, long timeTaken)
          Callback invoked when the breakpoint was hit and the Exchange has been processed (after).
 boolean Debugger.beforeProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition)
          Callback invoked when an Exchange is about to be processed which allows implementators to notify breakpoints.
 void Breakpoint.beforeProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition)
          Callback invoked when the breakpoint was hit and the Exchange is about to be processed (before).
 void Policy.beforeWrap(RouteContext routeContext, ProcessorDefinition<?> definition)
          Hook invoked before the wrap.
 Processor ProcessorFactory.createChildProcessor(RouteContext routeContext, ProcessorDefinition<?> definition, boolean mandatory)
          Creates the child processor.
 Processor ProcessorFactory.createProcessor(RouteContext routeContext, ProcessorDefinition<?> definition)
          Creates the processor.
 int RouteContext.getAndIncrement(ProcessorDefinition<?> node)
          A private counter that increments, is used to as book keeping when building a route based on the model

We need this special book keeping be able to assign the correct ProcessorDefinition to the Channel

 int TracedRouteNodes.getAndIncrementCounter(ProcessorDefinition<?> node)
          A private counter that increments, is used to as book keeping how far this exchange have been intercepted by the general intercept().
 Object ManagementObjectStrategy.getManagedObjectForProcessor(CamelContext context, Processor processor, ProcessorDefinition<?> definition, Route route)
           
 ObjectName ManagementNamingStrategy.getObjectNameForProcessor(CamelContext context, Processor processor, ProcessorDefinition<?> definition)
           
 boolean ManagementStrategy.manageProcessor(ProcessorDefinition<?> definition)
          Filter whether the processor should be managed or not.
 boolean Condition.matchProcess(Exchange exchange, Processor processor, ProcessorDefinition<?> definition)
          Does the condition match
 void Breakpoint.onEvent(Exchange exchange, EventObject event, ProcessorDefinition<?> definition)
          Callback invoked when the breakpoint was hit and any of the Exchange events occurred.
 Processor InterceptStrategy.wrapProcessorInInterceptors(CamelContext context, ProcessorDefinition<?> definition, Processor target, Processor nextTarget)
          This method is invoked by wrapProcessor(RouteContext, Processor) to give the implementor an opportunity to wrap the target processor in a route.
 

Uses of ProcessorDefinition in org.apache.camel.view
 

Fields in org.apache.camel.view with type parameters of type ProcessorDefinition
 List<ProcessorDefinition<?>> NodeData.outputs
           
 

Methods in org.apache.camel.view with parameters of type ProcessorDefinition
protected  boolean GraphSupport.isMulticastNode(ProcessorDefinition<?> node)
           
protected  boolean GraphSupport.isPipeline(ProcessorDefinition<?> node)
          Is the given node a pipeline
protected  NodeData XmlGraphGenerator.printNode(PrintWriter writer, NodeData fromData, ProcessorDefinition<?> node)
           
protected  NodeData RouteDotGenerator.printNode(PrintWriter writer, NodeData fromData, ProcessorDefinition<?> node)
           
 



Apache CAMEL