A B C D E F G H I J K L M N O P Q R S T U V W X

A

add(String, String) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
A helper method to make it easy to create newly populated instances
add(String, String) - Method in class org.apache.camel.builder.xml.Namespaces
 
add(Element) - Method in class org.apache.camel.builder.xml.Namespaces
 
add(Exchange) - Method in class org.apache.camel.processor.aggregate.AggregationCollection
 
add(E) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Adds an element to this resequencer throwing an exception if the maximum capacity is reached.
addAttachment(String, DataHandler) - Method in class org.apache.camel.impl.DefaultMessage
 
addAttachment(String, DataHandler) - Method in interface org.apache.camel.Message
Adds an attachment to the message using the id
addChildService(Object) - Method in class org.apache.camel.impl.ServiceSupport
 
addComponent(String, Component) - Method in interface org.apache.camel.CamelContext
Adds a component to the context.
addComponent(String, Component) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addErrorHandlers(ExceptionType) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
 
addErrorHandlers(ExceptionType) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
addEventDrivenProcessor(Processor) - Method in class org.apache.camel.impl.RouteContext
 
addExceptionPolicy(ExceptionType) - Method in class org.apache.camel.processor.ErrorHandlerSupport
 
addFallbackConverter(TypeConverter) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
addIfMatching(ResolverUtil.Test, String) - Method in class org.apache.camel.util.ResolverUtil
Add the class designated by the fully qualified class name provided to the set of resolved classes if and only if it is approved by the Test supplied.
addInterceptor(InterceptorType) - Method in class org.apache.camel.model.ProcessorType
 
addOutput(ProcessorType) - Method in interface org.apache.camel.model.Block
 
addOutput(ProcessorType) - Method in class org.apache.camel.model.ProcessorType
 
addOutput(ProcessorType) - Method in class org.apache.camel.model.TryType
 
addParameterMapping(Class, Expression) - Method in class org.apache.camel.component.bean.DefaultParameterMappingStrategy
Adds a default parameter type mapping to an expression
addParameters(Transformer, Map<String, Object>) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
addPredicate(Predicate<Exchange>) - Method in class org.apache.camel.component.mock.AssertionClause
 
addProcessor(Processor) - Method in class org.apache.camel.model.loadbalancer.LoadBalancerType
 
addProcessor(Processor) - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Adds a new processor to the load balancer
addProcessor(Processor) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
addPropertyChangeListener(PropertyChangeListener) - Method in class org.apache.camel.component.list.ListEndpoint
 
addPropertyChangeListener(PropertyChangeListener) - Method in class org.apache.camel.component.mock.MockEndpoint
 
addRouteDefinitions(Collection<RouteType>) - Method in interface org.apache.camel.CamelContext
Adds a collection of route definitions to the context
addRouteDefinitions(Collection<RouteType>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addRoutes(Collection<Route>) - Method in interface org.apache.camel.CamelContext
Adds a collection of routes to this context
addRoutes(RouteBuilder) - Method in interface org.apache.camel.CamelContext
Adds a collection of routes to this context using the given builder to build them
addRoutes(Collection<Route>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addRoutes(RouteBuilder) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addRoutes(RouteContext, Collection<Route>) - Method in class org.apache.camel.model.AggregatorType
 
addRoutes(RouteContext, Collection<Route>) - Method in class org.apache.camel.model.ExceptionType
 
addRoutes(RouteContext, Collection<Route>) - Method in class org.apache.camel.model.ProcessorType
 
addRoutes(RouteContext, Collection<Route>) - Method in class org.apache.camel.model.ResequencerType
 
addRoutes(CamelContext, Collection<Route>) - Method in class org.apache.camel.model.RouteType
 
addRoutes(Collection<Route>, FromType) - Method in class org.apache.camel.model.RouteType
 
addService(Object) - Method in class org.apache.camel.impl.DefaultCamelContext
Adds a service, starting it so that it will be stopped with this context
addService(Service) - Method in class org.apache.camel.Route
 
addServices(List<Service>) - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
Factory method to lazily create the complete list of services required for this route such as adding the processor or consumer
addServices(List<Service>) - Method in class org.apache.camel.Route
Strategy method to allow derived classes to lazily load services for the route
addSingletonEndpoint(String, Endpoint) - Method in interface org.apache.camel.CamelContext
Adds the endpoint to the context using the given URI.
addSingletonEndpoint(String, Endpoint) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addSynchronization(Synchronization) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
addSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
Adds a synchronization hook
addTimeoutHandler(TimeoutHandler) - Method in class org.apache.camel.processor.resequencer.Timeout
Appends a new timeout handler at the end of the timeout handler list.
addTimeoutHandlerFirst(TimeoutHandler) - Method in class org.apache.camel.processor.resequencer.Timeout
inserts a new timeout handler at the beginning of the timeout handler list.
addToEnvironment(String, Object) - Method in class org.apache.camel.util.jndi.JndiContext
 
addTypeConverter(Class, Class, TypeConverter) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
addTypeConverter(Class, Class, TypeConverter) - Method in interface org.apache.camel.impl.converter.TypeConverterRegistry
Allows a new type converter to be registered
addTypeConverter(Class, Class, TypeConverter) - Method in class org.apache.camel.util.ReportingTypeConverterRegistry
 
addVariable(String, Object) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
aggregate(Exchange, Exchange) - Method in interface org.apache.camel.processor.aggregate.AggregationStrategy
Aggregates an old and new exchange together to create a single combined exchange
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
AggregationCollection - Class in org.apache.camel.processor.aggregate
A Collection which aggregates exchanges together using a correlation expression so that there is only a single message exchange sent for a single correlation key.
AggregationCollection(Expression<Exchange>, AggregationStrategy) - Constructor for class org.apache.camel.processor.aggregate.AggregationCollection
 
AggregationStrategy - Interface in org.apache.camel.processor.aggregate
A strategy for aggregating two exchanges together into a single exchange.
aggregator() - Method in class org.apache.camel.model.ProcessorType
Creates an Aggregator pattern where a batch of messages are processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined together using some kind of AggregationStrategy (by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.
aggregator(AggregationStrategy) - Method in class org.apache.camel.model.ProcessorType
Creates an Aggregator pattern where a batch of messages are processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined together using some kind of AggregationStrategy (by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.
aggregator(AggregationCollection) - Method in class org.apache.camel.model.ProcessorType
Creates an Aggregator pattern using a custom aggregation collection implementation.
aggregator(Expression) - Method in class org.apache.camel.model.ProcessorType
Creates an Aggregator pattern where a batch of messages are processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined together using some kind of AggregationStrategy (by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.
aggregator(Expression, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorType
Creates an Aggregator pattern where a batch of messages are processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined together using some kind of AggregationStrategy (by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.
Aggregator - Class in org.apache.camel.processor
An implementation of the Aggregator pattern where a batch of messages are processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined together using some kind of AggregationStrategy (by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.
Aggregator(Endpoint, Processor, Expression, AggregationStrategy) - Constructor for class org.apache.camel.processor.Aggregator
 
Aggregator(Endpoint, Processor, Expression, AggregationStrategy, Predicate) - Constructor for class org.apache.camel.processor.Aggregator
 
Aggregator(Endpoint, Processor, AggregationCollection) - Constructor for class org.apache.camel.processor.Aggregator
 
AggregatorType - Class in org.apache.camel.model
 
AggregatorType() - Constructor for class org.apache.camel.model.AggregatorType
 
AggregatorType(Expression) - Constructor for class org.apache.camel.model.AggregatorType
 
AggregatorType(ExpressionType) - Constructor for class org.apache.camel.model.AggregatorType
 
AggregatorType(Expression, AggregationStrategy) - Constructor for class org.apache.camel.model.AggregatorType
 
allMessages() - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an assertion to all the received messages
AlreadyStoppedException - Exception in org.apache.camel
 
AlreadyStoppedException() - Constructor for exception org.apache.camel.AlreadyStoppedException
 
AmbiguousMethodCallException - Exception in org.apache.camel.component.bean
An exception thrown if an attempted method invocation resulted in an ambiguous method such that multiple methods match the inbound message exchange
AmbiguousMethodCallException(Exchange, Collection<MethodInfo>) - Constructor for exception org.apache.camel.component.bean.AmbiguousMethodCallException
 
and(Predicate<E>, Predicate<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to combine multiple predicates by a logical AND
AnnotationExpressionFactory - Interface in org.apache.camel.component.bean
A factory which creates an Expression object from an annotation on a field, property or method parameter of a specified type.
AnnotationTypeConverterLoader - Class in org.apache.camel.impl.converter
A class which will auto-discover converter objects and methods to pre-load the registry of converters on startup
AnnotationTypeConverterLoader() - Constructor for class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
append(Expression<E>, Expression<E>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Appends the String evaluations of the two expressions together
append(Object) - Method in class org.apache.camel.builder.ValueBuilder
Appends the string evaluation of this expression with the given value
append(StringBuffer, NodeList) - Static method in class org.apache.camel.converter.jaxp.DomConverter
 
append(StringBuffer, Node) - Static method in class org.apache.camel.converter.jaxp.DomConverter
 
append(Object) - Method in class org.apache.camel.util.CollectionStringBuffer
 
appendToString(StringBuffer, Object) - Static method in class org.apache.camel.util.IntrospectionSupport
 
appendValue(Map, Object, Object) - Static method in class org.apache.camel.util.CollectionHelper
Sets the value of the entry in the map for the given key, though if the map already contains a value for the given key then the value is appended to a list of values.
applyAssertionOn(MockEndpoint, int, Exchange) - Method in class org.apache.camel.component.mock.AssertionClause
Performs any assertions on the given exchange
applyHeaders(Exchange, long) - Method in class org.apache.camel.component.dataset.DataSetSupport
Allows derived classes to add some custom headers for a given message
ArrayTypeConverter - Class in org.apache.camel.impl.converter
A type converter which is used to convert to and from array types particularly for derived types of array component types and dealing with primitive array types.
ArrayTypeConverter() - Constructor for class org.apache.camel.impl.converter.ArrayTypeConverter
 
artixDS() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Artix Data Services data format for dealing with lots of different message formats such as SWIFT etc.
artixDS(Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Artix Data Services data format with the specified type of ComplexDataObject for marshalling and unmarshalling messages using the dataObject's default Source and Sink.
artixDS(Class<?>, ArtixDSContentType) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Artix Data Services data format with the specified type of ComplexDataObject for marshalling and unmarshalling messages using the dataObject's default Source and Sink.
artixDS(ArtixDSContentType) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Artix Data Services data format with the specified content type for marshalling and unmarshalling messages
ArtixDSContentType - Enum in org.apache.camel.model.dataformat
 
ArtixDSDataFormat - Class in org.apache.camel.model.dataformat
Represents the Artix Data Services DataFormat
ArtixDSDataFormat() - Constructor for class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
ArtixDSDataFormat(Class<?>) - Constructor for class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
ArtixDSDataFormat(Class<?>, ArtixDSContentType) - Constructor for class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
ArtixDSDataFormat(ArtixDSContentType) - Constructor for class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
asExpression(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
assertEquals(String, Object, Object, Exchange) - Static method in class org.apache.camel.component.dataset.DataSetEndpoint
 
assertEquals(String, Object, Object) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertExchangeReceived(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Asserts that the given index of message is received (starting at zero)
AssertionClause - Class in org.apache.camel.component.mock
A builder of assertions on message exchanges
AssertionClause() - Constructor for class org.apache.camel.component.mock.AssertionClause
 
AssertionClause.PredicateValueBuilder - Class in org.apache.camel.component.mock
 
AssertionClause.PredicateValueBuilder(Expression<Exchange>) - Constructor for class org.apache.camel.component.mock.AssertionClause.PredicateValueBuilder
 
assertionFailureMessage(E, Object, Object) - Method in class org.apache.camel.impl.BinaryPredicateSupport
 
assertionFailureMessage(E) - Method in class org.apache.camel.impl.ExpressionSupport
 
assertionFailureMessage(E) - Method in class org.apache.camel.impl.PredicateSupport
 
assertionFailureMessage(E) - Method in class org.apache.camel.language.bean.BeanExpression
 
assertIsNotSatisfied() - Method in class org.apache.camel.component.mock.MockEndpoint
Validates that the assertions fail on this endpoint
assertIsSatisfied(long, TimeUnit, MockEndpoint...) - Static method in class org.apache.camel.component.mock.MockEndpoint
 
assertIsSatisfied(MockEndpoint...) - Static method in class org.apache.camel.component.mock.MockEndpoint
 
assertIsSatisfied(CamelContext) - Static method in class org.apache.camel.component.mock.MockEndpoint
Asserts that all the expectations on any MockEndpoint instances registered in the given context are valid
assertIsSatisfied() - Method in class org.apache.camel.component.mock.MockEndpoint
Validates that all the available expectations on this endpoint are satisfied; or throw an exception
assertIsSatisfied(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Validates that all the available expectations on this endpoint are satisfied; or throw an exception
assertMatches(String, E) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
assertMatches(String, E) - Method in class org.apache.camel.impl.BinaryPredicateSupport
 
assertMatches(String, E) - Method in class org.apache.camel.impl.ExpressionSupport
 
assertMatches(String, E) - Method in class org.apache.camel.impl.PredicateSupport
 
assertMatches(String, Exchange) - Method in class org.apache.camel.model.language.ExpressionType
 
assertMatches(String, E) - Method in interface org.apache.camel.Predicate
Allows this predicate to be used nicely in testing to generate a nicely formatted exception and message if this predicate does not match for the given exchange.
assertMessageExpected(DataSetEndpoint, Exchange, Exchange, long) - Method in interface org.apache.camel.component.dataset.DataSet
Asserts that the expected message has been received for the given index
assertMessageExpected(long, Exchange, Exchange) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
assertMessageExpected(DataSetEndpoint, Exchange, Exchange, long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
assertMessagesAscending(Expression<Exchange>) - Method in class org.apache.camel.component.mock.MockEndpoint
Asserts that the messages have ascending values of the given expression
assertMessagesDescending(Expression<Exchange>) - Method in class org.apache.camel.component.mock.MockEndpoint
Asserts that the messages have descending values of the given expression
assertMessagesSorted(Expression<Exchange>, boolean) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertNoDuplicates(Expression<Exchange>) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertTrue(String, boolean) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertWait(long, TimeUnit, MockEndpoint...) - Static method in class org.apache.camel.component.mock.MockEndpoint
 
association - Variable in class org.apache.camel.view.NodeData
 
asString(Object[]) - Static method in class org.apache.camel.util.ObjectHelper
Turns the given object arrays into a meaningful string
AsyncCallback - Interface in org.apache.camel
The callback interface for an AsyncProcessor so that it can notify you when an Exchange has completed.
AsyncProcessor - Interface in org.apache.camel
A more complex version of Processor which supports asynchronous processing of the Exchange.
AsyncProcessorHelper - Class in org.apache.camel.util
Helper methods for AsyncProcessor objects.
AsyncProcessorTypeConverter - Class in org.apache.camel.impl.converter
A simple converter that can convert any Processor to an AsyncProcessor.
AsyncProcessorTypeConverter() - Constructor for class org.apache.camel.impl.converter.AsyncProcessorTypeConverter
 
AsyncProcessorTypeConverter.ProcessorToAsynProcessorBridge - Class in org.apache.camel.impl.converter
 
await() - Method in class org.apache.camel.component.mock.MockEndpoint
 
await(long, TimeUnit) - Method in class org.apache.camel.component.mock.MockEndpoint
 

B

backOffMultiplier(double) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
backOffMultiplier(double) - Method in class org.apache.camel.model.ExceptionType
 
backOffMultiplier(double) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
backOffMultiplier - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
backOffMultiplier(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables exponential backoff and sets the multiplier used to increase the delay between redeliveries
batch() - Method in class org.apache.camel.model.ResequencerType
Configures the batch-based resequencing algorithm using the default configuration.
batch(BatchResequencerConfig) - Method in class org.apache.camel.model.ResequencerType
Configures the batch-based resequencing algorithm using the given BatchResequencerConfig.
BatchProcessor - Class in org.apache.camel.processor
A base class for any kind of Processor which implements some kind of batch processing.
BatchProcessor(Endpoint, Processor, Collection<Exchange>) - Constructor for class org.apache.camel.processor.BatchProcessor
 
BatchResequencerConfig - Class in org.apache.camel.model.config
Defines the configuration parameters for the batch-processing Resequencer.
BatchResequencerConfig() - Constructor for class org.apache.camel.model.config.BatchResequencerConfig
Creates a new BatchResequencerConfig instance using default values for batchSize (100) and batchTimeout (1000L).
BatchResequencerConfig(int, long) - Constructor for class org.apache.camel.model.config.BatchResequencerConfig
Creates a new BatchResequencerConfig instance using the given values for batchSize and batchTimeout.
batchSize(int) - Method in class org.apache.camel.model.AggregatorType
 
batchTimeout(long) - Method in class org.apache.camel.model.AggregatorType
 
Bean - Annotation Type in org.apache.camel.language
Used to inject a bean expression into a field, property, method or parameter when using Bean Integration.
bean(Object) - Method in class org.apache.camel.model.ProcessorType
Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Object, String) - Method in class org.apache.camel.model.ProcessorType
Adds a bean and method which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Class) - Method in class org.apache.camel.model.ProcessorType
Adds a bean by type which is invoked which could be a final destination, or could be a transformation in a pipeline
bean(Class, String) - Method in class org.apache.camel.model.ProcessorType
Adds a bean type and method which is invoked which could be a final destination, or could be a transformation in a pipeline
BeanComponent - Class in org.apache.camel.component.bean
An alternative to the POJO Component which implements the Bean Component which will look up the URI in the Spring ApplicationContext and use that to handle message dispatching.
BeanComponent() - Constructor for class org.apache.camel.component.bean.BeanComponent
 
BeanExchange - Class in org.apache.camel.component.bean
 
BeanExchange(CamelContext, ExchangePattern) - Constructor for class org.apache.camel.component.bean.BeanExchange
 
BeanExchange(DefaultExchange) - Constructor for class org.apache.camel.component.bean.BeanExchange
 
BeanExpression<E extends Exchange> - Class in org.apache.camel.language.bean
Evaluates an expression using a bean method invocation
BeanExpression(String, String) - Constructor for class org.apache.camel.language.bean.BeanExpression
 
BeanHolder - Interface in org.apache.camel.component.bean
 
BeanInfo - Class in org.apache.camel.component.bean
Represents the metadata about a bean type created via a combination of introspection and annotations together with some useful sensible defaults
BeanInfo(CamelContext, Class) - Constructor for class org.apache.camel.component.bean.BeanInfo
 
BeanInfo(CamelContext, Class, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.BeanInfo
 
BeanInvocation - Class in org.apache.camel.component.bean
 
BeanInvocation() - Constructor for class org.apache.camel.component.bean.BeanInvocation
 
BeanInvocation(Method, Object[]) - Constructor for class org.apache.camel.component.bean.BeanInvocation
 
BeanLanguage - Class in org.apache.camel.language.bean
A registry then the method is invoked to evaluate the expression using the Exchange to the method arguments.
BeanLanguage() - Constructor for class org.apache.camel.language.bean.BeanLanguage
 
beanName() - Method in class org.apache.camel.model.language.MethodCallExpression
 
BeanProcessor - Class in org.apache.camel.component.bean
A Processor which converts the inbound exchange to a method invocation on a POJO
BeanProcessor(Object, BeanInfo) - Constructor for class org.apache.camel.component.bean.BeanProcessor
 
BeanProcessor(Object, CamelContext, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.BeanProcessor
 
BeanProcessor(Object, CamelContext) - Constructor for class org.apache.camel.component.bean.BeanProcessor
 
BeanProcessor(BeanHolder) - Constructor for class org.apache.camel.component.bean.BeanProcessor
 
BeanRef - Class in org.apache.camel.model
 
BeanRef() - Constructor for class org.apache.camel.model.BeanRef
 
BeanRef(String) - Constructor for class org.apache.camel.model.BeanRef
 
BeanRef(String, String) - Constructor for class org.apache.camel.model.BeanRef
 
beanRef(String) - Method in class org.apache.camel.model.ProcessorType
Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
beanRef(String, String) - Method in class org.apache.camel.model.ProcessorType
Adds a bean and method which is invoked which could be a final destination, or could be a transformation in a pipeline
begin(FileEndpoint, FileExchange, File) - Method in interface org.apache.camel.component.file.FileProcessStrategy
Called when work is about to begin on this file.
begin(FileEndpoint, FileExchange, File) - Method in class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
BinaryPredicateSupport<E extends Exchange> - Class in org.apache.camel.impl
A useful base class for Predicate implementations
BinaryPredicateSupport(Expression<E>, Expression<E>) - Constructor for class org.apache.camel.impl.BinaryPredicateSupport
 
bind(String, Object) - Method in class org.apache.camel.impl.JndiRegistry
 
bind(Name, Object) - Method in class org.apache.camel.util.jndi.JndiContext
 
bind(String, Object) - Method in class org.apache.camel.util.jndi.JndiContext
 
Block - Interface in org.apache.camel.model
 
Body - Annotation Type in org.apache.camel
Marks a parameter as being the body of an inbound Message
body() - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the inbound body on an exchange
body() - Method in class org.apache.camel.builder.BuilderSupport
Returns a predicate and value builder for the inbound body on an exchange
body(Class<T>) - Method in class org.apache.camel.builder.BuilderSupport
Returns a predicate and value builder for the inbound message body as a specific type
body() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message body
body(Class) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message body converted to the expected type
body() - Method in class org.apache.camel.component.mock.AssertionClause
Returns a predicate and value builder for the inbound body on an exchange
bodyAs(Class<T>) - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the inbound message body as a specific type
bodyAs(Class<T>) - Method in class org.apache.camel.component.mock.AssertionClause
Returns a predicate and value builder for the inbound message body as a specific type
bodyExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body
bodyExpression(Class<T>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type
bodyParameterMatches(Class) - Method in class org.apache.camel.component.bean.MethodInfo
 
booleanResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to boolean
BrowsableEndpoint<T extends Exchange> - Interface in org.apache.camel.spi
An optional interface an Endpoint may choose to implement which allows it to expose a way of browsing the exchanges available.
Builder - Class in org.apache.camel.builder
A helper class for including portions of the expression and predicate Java DSL
BuilderSupport - Class in org.apache.camel.builder
Base class for implementation inheritance for different clauses in the Java DSL
BuilderSupport(CamelContext) - Constructor for class org.apache.camel.builder.BuilderSupport
 
BuilderSupport(BuilderSupport) - Constructor for class org.apache.camel.builder.BuilderSupport
 
BytesSource - Class in org.apache.camel.converter.jaxp
A helper class which provides a JAXP Source from a byte[] which can be read as many times as required.
BytesSource(byte[]) - Constructor for class org.apache.camel.converter.jaxp.BytesSource
 
BytesSource(byte[], String) - Constructor for class org.apache.camel.converter.jaxp.BytesSource
 

C

CachingInjector<T> - Class in org.apache.camel.impl.converter
A caching proxy
CachingInjector(TypeConverterRegistry, Class<T>) - Constructor for class org.apache.camel.impl.converter.CachingInjector
 
CamelContext - Interface in org.apache.camel
Interface used to represent the context used to configure routes and the policies to use during message exchanges between endpoints.
CamelContextAware - Interface in org.apache.camel
An interface to represent an object which wishes to be injected with a CamelContext such as when working with Spring or Guice
CamelContextHelper - Class in org.apache.camel.util
A number of helper methods
CamelConverter - Class in org.apache.camel.converter
Some useful converters for Camel APIs such as to convert a Predicate or Expression to a Processor
CamelConverter() - Constructor for class org.apache.camel.converter.CamelConverter
 
CamelException - Exception in org.apache.camel
Base class for all Camel checked exceptions typically thrown by a Processor
CamelException() - Constructor for exception org.apache.camel.CamelException
 
CamelException(String) - Constructor for exception org.apache.camel.CamelException
 
CamelException(String, Throwable) - Constructor for exception org.apache.camel.CamelException
 
CamelException(Throwable) - Constructor for exception org.apache.camel.CamelException
 
CamelExchangeException - Exception in org.apache.camel
An exception caused by a specific message Exchange
CamelExchangeException(String, Exchange) - Constructor for exception org.apache.camel.CamelExchangeException
 
CamelExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.CamelExchangeException
 
CamelInitialContextFactory - Class in org.apache.camel.util.jndi
A factory of the Cameel InitialContext which allows a Map to be used to create a JNDI context.
CamelInitialContextFactory() - Constructor for class org.apache.camel.util.jndi.CamelInitialContextFactory
 
CamelInvocationHandler - Class in org.apache.camel.component.bean
An InvocationHandler which invokes a message exchange on a camel Endpoint
CamelInvocationHandler(Endpoint, Producer) - Constructor for class org.apache.camel.component.bean.CamelInvocationHandler
 
CamelNamingStrategy - Class in org.apache.camel.management
 
CamelNamingStrategy() - Constructor for class org.apache.camel.management.CamelNamingStrategy
 
CamelNamingStrategy(String) - Constructor for class org.apache.camel.management.CamelNamingStrategy
 
CamelTemplate<E extends Exchange> - Class in org.apache.camel
A client helper object (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and sending Message instances in an Exchange to an Endpoint.
CamelTemplate(CamelContext) - Constructor for class org.apache.camel.CamelTemplate
 
CamelTemplate(CamelContext, Endpoint) - Constructor for class org.apache.camel.CamelTemplate
 
cancel() - Method in class org.apache.camel.processor.resequencer.SequenceSender
Cancels this thread.
capitalize(String) - Static method in class org.apache.camel.util.ObjectHelper
 
cast(Class<T>, Object) - Static method in class org.apache.camel.util.ObjectHelper
Converts the given value to the required type or throw a meaningful exception
catches(Throwable) - Method in class org.apache.camel.processor.CatchProcessor
 
CatchProcessor - Class in org.apache.camel.processor
 
CatchProcessor(List<Class>, Processor) - Constructor for class org.apache.camel.processor.CatchProcessor
 
CatchType - Class in org.apache.camel.model
 
CatchType() - Constructor for class org.apache.camel.model.CatchType
 
CatchType(List<Class>) - Constructor for class org.apache.camel.model.CatchType
 
CatchType(Class) - Constructor for class org.apache.camel.model.CatchType
 
changeScheme(URI, String) - Static method in class org.apache.camel.util.URISupport
 
checkInitialized() - Method in class org.apache.camel.builder.RouteBuilder
 
checkInitialized() - Method in class org.apache.camel.model.TryType
Checks whether or not this object has been initialized
checkLoaded() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
Checks if the registry is loaded and if not lazily load it
checkNoCompletedPredicate() - Method in class org.apache.camel.model.AggregatorType
 
checkParenthesis(String) - Static method in class org.apache.camel.util.URISupport
 
choice() - Method in class org.apache.camel.model.ProcessorType
Creates a choice of one or more predicates with an otherwise clause
ChoiceProcessor - Class in org.apache.camel.processor
Implements a Choice structure where one or more predicates are used which if they are true their processors are used, with a default otherwise clause used if none match.
ChoiceProcessor(List<FilterProcessor>, Processor) - Constructor for class org.apache.camel.processor.ChoiceProcessor
 
ChoiceType - Class in org.apache.camel.model
 
ChoiceType() - Constructor for class org.apache.camel.model.ChoiceType
 
chooseMethod(Object, Exchange) - Method in class org.apache.camel.component.bean.BeanInfo
Lets try choose one of the available methods to invoke if we can match the message body to the body parameter
chooseMethodWithCustomAnnotations(Exchange, Collection<MethodInfo>) - Method in class org.apache.camel.component.bean.BeanInfo
 
chooseMethodWithMatchingBody(Exchange, Collection<MethodInfo>) - Method in class org.apache.camel.component.bean.BeanInfo
 
chooseProcessor(List<Processor>, Exchange) - Method in class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
chooseProcessor(List<Processor>, Exchange) - Method in class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
chooseProcessor(List<Processor>, Exchange) - Method in class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
chooseProcessor(List<Processor>, Exchange) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
className(Object) - Static method in class org.apache.camel.util.ObjectHelper
Returns the type name of the given value
clear() - Method in class org.apache.camel.processor.aggregate.AggregationCollection
 
clear() - Method in class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 
clearOutput() - Method in class org.apache.camel.model.ProcessorType
 
clearTimeoutHandlers() - Method in class org.apache.camel.processor.resequencer.Timeout
Removes all timeout handlers from the timeout handler list.
close() - Method in class org.apache.camel.impl.JndiRegistry
 
close() - Method in class org.apache.camel.util.jndi.JndiContext
 
close(Closeable, String, Log) - Static method in class org.apache.camel.util.ObjectHelper
Closes the given resource if it is available, logging any closing exceptions to the given log
clusterCounter - Variable in class org.apache.camel.view.GraphGeneratorSupport
 
CollectionConverter - Class in org.apache.camel.converter
Some core java.util Collection based Type Converters
CollectionHelper - Class in org.apache.camel.util
A number of helper methods for working with collections
CollectionProducer - Class in org.apache.camel.component.seda
A simple Producer which just appends to a Collection the Exchange object.
CollectionProducer(Endpoint, Collection<Exchange>) - Constructor for class org.apache.camel.component.seda.CollectionProducer
 
CollectionStringBuffer - Class in org.apache.camel.util
A little helper class for converting a collection of values to a (usually comma separated) string.
CollectionStringBuffer() - Constructor for class org.apache.camel.util.CollectionStringBuffer
 
CollectionStringBuffer(String) - Constructor for class org.apache.camel.util.CollectionStringBuffer
 
collisionAvoidanceFactor(double) - Method in class org.apache.camel.model.ExceptionType
 
collisionAvoidanceFactor(double) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
collisionAvoidanceFactor - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
collisionAvoidancePercent(short) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
collisionAvoidancePercent(short) - Method in class org.apache.camel.model.ExceptionType
 
collisionAvoidancePercent(double) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
collisionAvoidancePercent(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables collision avoidence and sets the percentage used
commit(FileEndpoint, FileExchange, File) - Method in interface org.apache.camel.component.file.FileProcessStrategy
Releases any file locks and possibly deletes or moves the file
commit(FileEndpoint, FileExchange, File) - Method in class org.apache.camel.component.file.strategy.DeleteFileProcessStrategy
 
commit(FileEndpoint, FileExchange, File) - Method in class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
commit(FileEndpoint, FileExchange, File) - Method in class org.apache.camel.component.file.strategy.RenameFileProcessStrategy
 
commit() - Method in class org.apache.camel.impl.RouteContext
Lets complete the route creation, creating a single event driven route for the current from endpoint with any processors required
comparator() - Method in class org.apache.camel.processor.resequencer.Sequence
Returns this sequence's comparator.
compare(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
compare(E, E) - Method in class org.apache.camel.util.ExpressionComparator
 
compare(Exchange, Exchange) - Method in class org.apache.camel.util.ExpressionListComparator
 
compare(Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
A helper method for performing an ordered comparsion on the objects handling nulls and objects which do not handle sorting gracefully
compareTo(Object) - Method in class org.apache.camel.util.TimeoutMapEntry
 
compareTo(TimeoutMapEntry) - Method in class org.apache.camel.util.TimeoutMapEntry
 
completedExchange(long) - Method in class org.apache.camel.management.PerformanceCounter
 
completedExchange() - Method in class org.apache.camel.management.PerformanceCounter
 
completedPredicate() - Method in class org.apache.camel.model.AggregatorType
Sets the predicate used to determine if the aggregation is completed
completedPredicate(Predicate) - Method in class org.apache.camel.model.AggregatorType
Sets the predicate used to determine if the aggregation is completed
CompletedPredicate - Class in org.apache.camel.model
 
CompletedPredicate() - Constructor for class org.apache.camel.model.CompletedPredicate
 
CompletedPredicate(Predicate) - Constructor for class org.apache.camel.model.CompletedPredicate
 
Component<E extends Exchange> - Interface in org.apache.camel
A component is a factory of Endpoint objects.
COMPONENT_FACTORY - Static variable in class org.apache.camel.impl.DefaultComponentResolver
 
ComponentResolver<E extends Exchange> - Interface in org.apache.camel.spi
Represents a resolver of components from a URI to be able to auto-load them using some discovery mechanism like DefaultComponentResolver
composeName(Name, Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
composeName(String, String) - Method in class org.apache.camel.util.jndi.JndiContext
 
CompositeProcessor - Class in org.apache.camel.processor
Represents a composite pattern, aggregating a collection of processors together as a single processor
CompositeProcessor(Collection<Processor>) - Constructor for class org.apache.camel.processor.CompositeProcessor
 
concatExpression(Collection<Expression>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which returns the string concatenation value of the various expressions
concatExpression(Collection<Expression>, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which returns the string concatenation value of the various expressions
configure(ErrorHandlerSupport) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
configure() - Method in class org.apache.camel.builder.RouteBuilder
Called on initialization to to build the required destinationBuilders
configure(NamespaceAware) - Method in class org.apache.camel.builder.xml.Namespaces
Configures the namespace aware object
configure() - Method in class org.apache.camel.impl.NoRouteBuilder
 
configureBuilder(XPathBuilder) - Method in class org.apache.camel.builder.xml.XPathLanguage
 
configureChild(ProcessorType) - Method in class org.apache.camel.model.ExpressionNode
 
configureChild(ProcessorType) - Method in class org.apache.camel.model.OutputType
 
configureChild(ProcessorType) - Method in class org.apache.camel.model.ProcessorType
 
configureChild(ProcessorType) - Method in class org.apache.camel.model.RouteType
 
configureConsumer(Consumer<E>) - Method in class org.apache.camel.impl.ScheduledPollEndpoint
 
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.dataformat.DataFormatType
Allows derived classes to customize the data format
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
configureDomainName() - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
configureExpression(RouteContext, Expression) - Method in class org.apache.camel.model.language.ExpressionType
 
configureExpression(RouteContext, Expression) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
configureExpression(RouteContext, Expression) - Method in class org.apache.camel.model.language.XPathExpression
 
configureExpression(RouteContext, Expression) - Method in class org.apache.camel.model.language.XQueryExpression
 
configureLoadBalancer(LoadBalancer) - Method in class org.apache.camel.model.loadbalancer.LoadBalancerType
Allows derived classes to customize the load balancer
configureLoadBalancer(LoadBalancer) - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
configureMessage(File, Message) - Method in class org.apache.camel.component.file.FileEndpoint
Configures the given message with the file which sets the body to the file object and sets the FileComponent.HEADER_FILE_NAME header.
configureMessage(Message) - Method in class org.apache.camel.impl.DefaultExchange
Configures the message after it has been set on the exchange
configureNamespaceAware(Object) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
configurePredicate(RouteContext, Predicate) - Method in class org.apache.camel.model.language.ExpressionType
 
configurePredicate(RouteContext, Predicate) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
configurePredicate(RouteContext, Predicate) - Method in class org.apache.camel.model.language.XPathExpression
 
configurePredicate(RouteContext, Predicate) - Method in class org.apache.camel.model.language.XQueryExpression
 
configureProperties(Map) - Method in interface org.apache.camel.Endpoint
 
configureProperties(Map) - Method in class org.apache.camel.impl.DefaultEndpoint
 
configureProperties(Map) - Method in class org.apache.camel.impl.ScheduledPollEndpoint
 
configureRoute(RouteType) - Method in class org.apache.camel.builder.RouteBuilder
 
configureTask(TimerTask, Timer) - Method in class org.apache.camel.component.timer.TimerConsumer
 
configureTransformer(Transformer, Exchange) - Method in class org.apache.camel.builder.xml.XsltBuilder
Configures the transformerwith exchange specific parameters
constant(Object) - Static method in class org.apache.camel.builder.Builder
Returns a constant expression
constant(Object) - Method in class org.apache.camel.builder.BuilderSupport
Returns a constant expression value builder
constant(Object) - Method in class org.apache.camel.builder.ExpressionClause
Specify the constant expression value
ConstantBeanHolder - Class in org.apache.camel.component.bean
A constant (singleton) bean implementation of BeanHolder
ConstantBeanHolder(Object, BeanInfo) - Constructor for class org.apache.camel.component.bean.ConstantBeanHolder
 
ConstantBeanHolder(Object, CamelContext) - Constructor for class org.apache.camel.component.bean.ConstantBeanHolder
 
ConstantBeanHolder(Object, CamelContext, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.ConstantBeanHolder
 
constantExpression(Object) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the constant value
ConstantProcessorBuilder - Class in org.apache.camel.builder
 
ConstantProcessorBuilder(Processor) - Constructor for class org.apache.camel.builder.ConstantProcessorBuilder
 
Consumer<E extends Exchange> - Interface in org.apache.camel
A consumer of message exchanges from an Endpoint
contains(Expression<E>, Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
contains(Object) - Method in class org.apache.camel.builder.ValueBuilder
Create a predicate that the left hand expression contains the value of the right hand expression
contains(String) - Method in class org.apache.camel.processor.idempotent.MemoryMessageIdRepository
 
contains(String) - Method in interface org.apache.camel.processor.idempotent.MessageIdRepository
Returns true if this messageId has been processed before otherwise this messageId is added to the repository and false is returned.
contains(Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
Returns true if the collection contains the specified value
context - Variable in class org.apache.camel.impl.DefaultExchange
 
convert(Processor) - Static method in class org.apache.camel.impl.converter.AsyncProcessorTypeConverter
 
convertBeanToEndpoint(String, Object) - Method in class org.apache.camel.impl.DefaultCamelContext
Attempt to convert the bean from a Registry to an endpoint using some kind of transformation or wrapper
ConvertBodyProcessor - Class in org.apache.camel.processor
A processor which converts the payload of the input message to be of the given type
ConvertBodyProcessor(Class) - Constructor for class org.apache.camel.processor.ConvertBodyProcessor
 
convertBodyTo(Class) - Method in class org.apache.camel.model.ProcessorType
Converts the IN message body to the specified type
ConvertBodyType - Class in org.apache.camel.model
 
ConvertBodyType() - Constructor for class org.apache.camel.model.ConvertBodyType
 
ConvertBodyType(String) - Constructor for class org.apache.camel.model.ConvertBodyType
 
ConvertBodyType(Class) - Constructor for class org.apache.camel.model.ConvertBodyType
 
Converter - Annotation Type in org.apache.camel
An annotation used to mark classes and methods to indicate code capable of converting from a type to another type which are then auto-discovered using the Type Conversion Support
convertFaultBodyTo(Class) - Method in class org.apache.camel.model.ProcessorType
Converts the FAULT message body to the specified type
convertOutBodyTo(Class) - Method in class org.apache.camel.model.ProcessorType
Deprecated. Please use ProcessorType.convertBodyTo(Class) instead
convertPrimitiveTypeToWrapperType(Class) - Static method in class org.apache.camel.util.ObjectHelper
Converts primitive types such as int to its wrapper type like Integer
convertTo(Expression, Class) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which converts the given expression to the given type
convertTo(Class) - Method in class org.apache.camel.builder.ValueBuilder
Converts the current value to the given type using the registered type converters
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.ArrayTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.AsyncProcessorTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.EnumTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.PropertyEditorTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.ToStringTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.DefaultComponent
Converts the given value to the requested type
convertTo(Class<E>, Exchange) - Method in class org.apache.camel.impl.DefaultEndpoint
Converts the given exchange to the specified exchange type
convertTo(Class<T>, Exchange) - Method in class org.apache.camel.impl.DefaultExchangeConverter
 
convertTo(Class<T>, Exchange) - Method in interface org.apache.camel.spi.ExchangeConverter
 
convertTo(Class<T>, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type
convertTo(CamelContext, Class<T>, Object) - Static method in class org.apache.camel.util.CamelContextHelper
Converts the given value to the requested type
convertToMandatoryType(Exchange, Class<T>, Object) - Static method in class org.apache.camel.util.ExchangeHelper
Converts the value to the given expected type or throws an exception
convertToStreamCache(StreamSource) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToStreamCache(InputStream) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToString() - Method in class org.apache.camel.builder.ValueBuilder
Converts the current value a String using the registered type converters
convertToType(Exchange, Class<T>, Object) - Static method in class org.apache.camel.util.ExchangeHelper
Converts the value to the given expected type returning null if it could not be converted
copy() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
copy() - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Creates a copy of this builder
copy() - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
copy() - Method in class org.apache.camel.builder.NoErrorHandlerBuilder
 
copy(InputStream, ByteArrayOutputStream) - Static method in class org.apache.camel.converter.IOConverter
 
copy() - Method in interface org.apache.camel.Exchange
Creates a copy of the current message exchange so that it can be forwarded to another destination
copy() - Method in class org.apache.camel.impl.DefaultExchange
 
copy() - Method in class org.apache.camel.impl.MessageSupport
 
copy() - Method in interface org.apache.camel.Message
Creates a copy of this message so that it can be used and possibly modified further in another exchange
copy() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
copyExchangeStrategy(Processor, Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
Strategy method to copy the exchange before sending to another endpoint.
copyFrom(Exchange) - Method in interface org.apache.camel.Exchange
Copies the data into this exchange from the given exchange
copyFrom(Exchange) - Method in class org.apache.camel.impl.DefaultExchange
 
copyFrom(Message) - Method in class org.apache.camel.impl.MessageSupport
 
copyFrom(Message) - Method in interface org.apache.camel.Message
Copies the contents of the other message into this message
copyResults(Exchange, Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Copies the results of a message exchange from the source exchange to the result exchange which will copy the out and fault message contents and the exception
coreSize(int) - Method in class org.apache.camel.model.ThreadType
 
Counter - Class in org.apache.camel.management
 
Counter() - Constructor for class org.apache.camel.management.Counter
 
createAndSetExpression(T) - Static method in class org.apache.camel.builder.ExpressionClause
 
createAttachments() - Method in class org.apache.camel.impl.DefaultMessage
A factory method to lazily create the attachments to make it easy to create efficient Message implementations which only construct and populate the Map on demand
createBatchResequencer(RouteContext, BatchResequencerConfig) - Method in class org.apache.camel.model.ResequencerType
 
createBean(Class<?>, Map, String) - Static method in class org.apache.camel.util.jndi.JndiContext
 
createBeanInfo() - Method in class org.apache.camel.component.bean.RegistryBean
 
createBindingsMapFromEnvironment(Hashtable) - Static method in class org.apache.camel.util.jndi.JndiContext
A helper method to create the JNDI bindings from the input environment properties using $foo.class to point to a class name with $foo.* being properties set on the injected bean
createBody() - Method in class org.apache.camel.component.file.FileMessage
 
createBody() - Method in class org.apache.camel.impl.MessageSupport
A factory method to allow a provider to lazily create the message body for inbound messages from other sources
createBodyAndHeaderProcessor(Object, String, Object) - Method in class org.apache.camel.CamelTemplate
 
createCacheHolder() - Method in class org.apache.camel.component.bean.RegistryBean
 
createComplexExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createComponentResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createCompositeProcessor(List<Processor>) - Method in class org.apache.camel.model.MulticastType
 
createCompositeProcessor(List<Processor>) - Method in class org.apache.camel.model.ProcessorType
Creates a new instance of some kind of composite processor which defaults to using a Pipeline but derived classes could change the behaviour
createConstantExpression(String, int, int) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createConsumer(Processor) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.direct.DirectEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.file.FileEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.list.ListEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.seda.SedaEndpoint
 
createConsumer(Processor) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
createConsumer(Processor) - Method in interface org.apache.camel.Endpoint
Creates a new Event Driven Consumer which consumes messages from the endpoint using the given processor
createConsumer(Processor) - Method in class org.apache.camel.impl.DefaultPollingEndpoint
 
createContainer() - Method in class org.apache.camel.builder.RouteBuilder
Factory method
createContext() - Method in class org.apache.camel.impl.JndiRegistry
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.DataFormatType
Factory method to create the data format instance
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.SerializationDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.StringDataFormat
 
createDefaultExceptionPolicyStrategy() - Static method in class org.apache.camel.processor.ErrorHandlerSupport
Creates the default exception policy strategy to use.
createDefaultFunctionResolver(XPathFunctionResolver) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
createDefaultLogger() - Static method in class org.apache.camel.processor.DeadLetterChannel
 
createDocument() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
createDocumentBuilder() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
createDocumentBuilderFactory() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
createEndpoint(Object) - Method in class org.apache.camel.component.bean.BeanComponent
A helper method to create a new endpoint from a bean with a generated URI
createEndpoint(Object, String) - Method in class org.apache.camel.component.bean.BeanComponent
A helper method to create a new endpoint from a bean with a given URI
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.bean.BeanComponent
 
createEndpoint(String, BeanProcessor) - Method in class org.apache.camel.component.bean.BeanComponent
 
createEndpoint(String) - Method in interface org.apache.camel.Component
Attempt to resolve an endpoint for the given URI if the component is capable of handling the URI
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.dataset.DataSetComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.direct.DirectComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.file.FileComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.jmx.JMXComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.list.ListComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.log.LogComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.mock.MockComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.ref.RefComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.seda.SedaComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.timer.TimerComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.component.vm.VmComponent
 
createEndpoint(String) - Method in class org.apache.camel.impl.DefaultCamelContext
A pluggable strategy to allow an endpoint to be created without requiring a component to be its factory, such as for looking up the URI inside some Registry
createEndpoint(String) - Method in class org.apache.camel.impl.DefaultComponent
 
createEndpoint(String, String, Map) - Method in class org.apache.camel.impl.DefaultComponent
A factory method allowing derived components to create a new endpoint from the given URI, remaining path and optional parameters
createErrorHandler(Processor) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
createErrorHandler(Processor) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Creates the error handler interceptor
createErrorHandler(Processor) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
createErrorHandler(Processor) - Method in class org.apache.camel.builder.NoErrorHandlerBuilder
 
createErrorHandlerBuilder() - Method in class org.apache.camel.builder.BuilderSupport
 
createErrorHandlerBuilder() - Method in class org.apache.camel.model.ProcessorType
 
createExceptionClasses() - Method in class org.apache.camel.model.CatchType
 
createExceptionClasses() - Method in class org.apache.camel.model.ExceptionType
 
createExchange(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Creates a message exchange for the given index in the DataSet
createExchange(File) - Method in class org.apache.camel.component.file.FileEndpoint
Create a new exchange for communicating with this endpoint
createExchange() - Method in class org.apache.camel.component.file.FileEndpoint
 
createExchange(ExchangePattern) - Method in class org.apache.camel.component.file.FileEndpoint
 
createExchange(Notification) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
createExchange() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
createExchange(ExchangePattern) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
createExchange() - Method in interface org.apache.camel.Endpoint
Create a new exchange for communicating with this endpoint
createExchange(ExchangePattern) - Method in interface org.apache.camel.Endpoint
Create a new exchange for communicating with this endpoint with the specified ExchangePattern such as whether its going to be an ExchangePattern.InOnly or ExchangePattern.InOut exchange
createExchange(Exchange) - Method in interface org.apache.camel.Endpoint
Creates a new exchange for communicating with this exchange using the given exchange to pre-populate the values of the headers and messages
createExchange(Exchange) - Method in class org.apache.camel.impl.DefaultEndpoint
 
createExchange() - Method in class org.apache.camel.impl.DefaultEndpoint
 
createExchange(ExchangePattern) - Method in class org.apache.camel.impl.DefaultEndpoint
 
createExchange() - Method in class org.apache.camel.impl.DefaultProducer
 
createExchange(ExchangePattern) - Method in class org.apache.camel.impl.DefaultProducer
 
createExchange(E) - Method in class org.apache.camel.impl.DefaultProducer
 
createExchange() - Method in interface org.apache.camel.Producer
Creates a new exchange to send to this endpoint
createExchange(ExchangePattern) - Method in interface org.apache.camel.Producer
Creates a new exchange of the given pattern to send to this endpoint
createExchange(E) - Method in interface org.apache.camel.Producer
Creates a new exchange for communicating with this exchange using the given exchange to pre-populate the values of the headers and messages
createExchangeConverter() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createExchangeList() - Method in class org.apache.camel.component.list.ListEndpoint
 
createExecutorService() - Method in class org.apache.camel.impl.DefaultComponent
A factory method to create a default thread pool and executor
createExecutorService() - Method in class org.apache.camel.impl.DefaultEndpoint
 
createExpression(String) - Method in class org.apache.camel.builder.xml.XPathLanguage
 
createExpression(CamelContext, Annotation, LanguageAnnotation, Class) - Method in interface org.apache.camel.component.bean.AnnotationExpressionFactory
 
createExpression(CamelContext, Annotation, LanguageAnnotation, Class) - Method in class org.apache.camel.component.bean.DefaultAnnotationExpressionFactory
 
createExpression(CamelContext, Annotation, LanguageAnnotation, Class) - Method in class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
 
createExpression(String) - Method in class org.apache.camel.language.bean.BeanLanguage
 
createExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createExpression(RouteContext) - Method in class org.apache.camel.model.language.ExpressionType
 
createExpression(RouteContext) - Method in class org.apache.camel.model.language.MethodCallExpression
 
createExpression(String) - Method in interface org.apache.camel.spi.Language
 
createFaultMessage() - Method in class org.apache.camel.impl.DefaultExchange
Factory method to lazily create the FAULT message
createFileName(Message) - Method in class org.apache.camel.component.file.FileProducer
 
createFileProcessStrategy(boolean, boolean, boolean, String, String) - Static method in class org.apache.camel.component.file.strategy.FileProcessStrategyFactory
A strategy method to lazily create the file strategy to use.
createFileStrategy() - Method in class org.apache.camel.component.file.FileEndpoint
A strategy method to lazily create the file strategy
createFilter() - Method in class org.apache.camel.model.NodeFactory
 
createFilterProcessor(RouteContext) - Method in class org.apache.camel.model.ExpressionNode
 
createHeaders() - Method in class org.apache.camel.impl.DefaultMessage
A factory method to lazily create the headers to make it easy to create efficient Message implementations which only construct and populate the Map on demand
createInjector() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createInMessage() - Method in class org.apache.camel.impl.DefaultExchange
Factory method used to lazily create the IN message
createInstance(Class<T>) - Method in class org.apache.camel.impl.converter.CachingInjector
 
createInterceptor(RouteContext) - Method in class org.apache.camel.model.InterceptorRef
 
createInterceptor(RouteContext) - Method in class org.apache.camel.model.InterceptorType
 
createInvocation(Method, Object, Exchange) - Method in class org.apache.camel.component.bean.BeanInfo
 
createInvocation(Object, Exchange) - Method in class org.apache.camel.component.bean.BeanInfo
 
createIOException(Throwable) - Static method in class org.apache.camel.util.IOHelper
A factory method which creates an IOException from the given exception and message
createIOException(String, Throwable) - Static method in class org.apache.camel.util.IOHelper
A factory method which creates an IOException from the given exception and message
createJmxConnector(String) - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.LoadBalancerType
Factory method to create the load balancer instance
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.RandomLoadBalanceStrategy
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.RoundRobinLoadBalanceStrategy
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.TopicLoadBalanceStrategy
 
createLogMessage(Exchange, int) - Method in class org.apache.camel.processor.ThroughputLogger
 
createMBeanServer() - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
createMessage(String, Exchange) - Static method in exception org.apache.camel.CamelExchangeException
 
createMessageBody(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
createMessageBody(long) - Method in class org.apache.camel.component.dataset.SimpleDataSet
Creates the message body for a given message
createMessageId() - Method in class org.apache.camel.impl.MessageSupport
Lets allow implementations to auto-create a messageId
createMethodInvocation(Object, Exchange) - Method in class org.apache.camel.component.bean.MethodInfo
 
createNextExchange(Processor, Exchange) - Method in class org.apache.camel.processor.Pipeline
Strategy method to create the next exchange from the
createObjectName(StringBuffer) - Method in class org.apache.camel.management.CamelNamingStrategy
Factory method to create an ObjectName escaping any required characters
createOutMessage() - Method in class org.apache.camel.impl.DefaultExchange
Factory method to lazily create the OUT message
createOutputsProcessor(RouteContext, Collection<ProcessorType<?>>) - Method in class org.apache.camel.model.LoadBalanceType
 
createOutputsProcessor(RouteContext) - Method in class org.apache.camel.model.ProcessorType
 
createOutputsProcessor(RouteContext, Collection<ProcessorType<?>>) - Method in class org.apache.camel.model.ProcessorType
 
createParameterMappingStrategy() - Method in class org.apache.camel.component.bean.BeanComponent
 
createParameterMappingStrategy(CamelContext) - Static method in class org.apache.camel.component.bean.BeanInfo
 
createParameterMappingStrategy() - Method in class org.apache.camel.component.bean.RegistryBean
 
createParametersExpression() - Method in class org.apache.camel.component.bean.MethodInfo
 
createParameterUnmarshalExpression(Class, Method, Class, Annotation[]) - Method in class org.apache.camel.component.bean.BeanInfo
Creates an expression for the given parameter type if the parameter can be mapped automatically or null if the parameter cannot be mapped due to unsufficient annotations or not fitting with the default type conventions.
createParameterUnmarshalExpressionForAnnotation(Class, Method, Class, Annotation) - Method in class org.apache.camel.component.bean.BeanInfo
 
createPollingConsumer() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
createPollingConsumer() - Method in interface org.apache.camel.Endpoint
Creates a new Polling Consumer so that the caller can poll message exchanges from the consumer using PollingConsumer.receive(), PollingConsumer.receiveNoWait() or PollingConsumer.receive(long) whenever it is ready to do so rather than using the Event Based Consumer returned by Endpoint.createConsumer(Processor)
createPollingConsumer() - Method in class org.apache.camel.impl.DefaultEndpoint
 
createPollingConsumer() - Method in class org.apache.camel.impl.ProcessorEndpoint
 
createPredicate() - Method in interface org.apache.camel.builder.PredicateFactory
Creates a predicate object
createPredicate(String) - Method in class org.apache.camel.builder.xml.XPathLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.bean.BeanLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createPredicate(RouteContext) - Method in class org.apache.camel.model.CompletedPredicate
 
createPredicate(RouteContext) - Method in class org.apache.camel.model.language.ExpressionType
 
createPredicate(RouteContext) - Method in class org.apache.camel.model.language.MethodCallExpression
 
createPredicate(String) - Method in interface org.apache.camel.spi.Language
 
createProceedProcessor() - Method in class org.apache.camel.impl.RouteContext
 
createProcessor() - Method in class org.apache.camel.builder.ConstantProcessorBuilder
 
createProcessor() - Method in interface org.apache.camel.builder.ProcessorFactory
 
createProcessor(ProcessorType) - Method in class org.apache.camel.impl.RouteContext
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.BeanRef
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.CatchType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ChoiceType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ConvertBodyType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.DelayerType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ExceptionType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.FilterType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.FinallyType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.IdempotentConsumerType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.InterceptorRef
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.InterceptType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.LoadBalanceType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.MarshalType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.MulticastType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.OtherwiseType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.PolicyRef
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ProceedType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ProcessorRef
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ProcessorType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.RecipientListType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ResequencerType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.RoutingSlipType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SetHeaderType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SplitterType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ThreadType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ThrottlerType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ThrowFaultType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ToType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.TransformType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.TryType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.UnmarshalType
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.WhenType
 
createProcessorExchangePairs(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
createProcessorExchangePairs(Exchange) - Method in class org.apache.camel.processor.Splitter
 
createProducer() - Method in class org.apache.camel.component.direct.DirectEndpoint
 
createProducer() - Method in class org.apache.camel.component.file.FileEndpoint
 
createProducer() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
createProducer() - Method in class org.apache.camel.component.list.ListEndpoint
 
createProducer() - Method in class org.apache.camel.component.mock.MockEndpoint
 
createProducer() - Method in class org.apache.camel.component.seda.SedaEndpoint
 
createProducer() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
createProducer() - Method in interface org.apache.camel.Endpoint
Creates a new producer which is used send messages into the endpoint
createProducer() - Method in class org.apache.camel.impl.ProcessorEndpoint
 
createProxy(Endpoint, ClassLoader, Class[]) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends PojoExchange to the endpoint.
createProxy(Endpoint, Class[]) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends PojoExchange to the endpoint.
createProxy(Endpoint, ClassLoader, Class<T>) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends PojoExchange to the endpoint.
createProxy(Endpoint, Class<T>) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends PojoExchange to the endpoint.
createQueryString(Map) - Static method in class org.apache.camel.util.URISupport
 
createQueue(String, Map) - Method in class org.apache.camel.component.seda.SedaComponent
 
createRedeliveryPolicy(RedeliveryPolicy) - Method in class org.apache.camel.model.ExceptionType
Allows an exception handler to create a new redelivery policy for this exception type
createRedeliveryPolicy(RedeliveryPolicy) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
createRegistry() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createRemainingURI(URI, Map) - Static method in class org.apache.camel.util.URISupport
Creates a URI from the original URI and the remaining parameters
createReporter() - Method in class org.apache.camel.component.dataset.DataSetConsumer
 
createResult() - Method in class org.apache.camel.builder.xml.DomResultHandlerFactory
 
createResult() - Method in interface org.apache.camel.builder.xml.ResultHandlerFactory
 
createResult() - Method in class org.apache.camel.builder.xml.StreamResultHandlerFactory
 
createResult() - Method in class org.apache.camel.builder.xml.StringResultHandlerFactory
 
createRoute() - Method in class org.apache.camel.model.NodeFactory
 
createRoute() - Method in class org.apache.camel.model.RoutesType
 
createRouteBuilder(CamelContext) - Method in class org.apache.camel.model.RouteBuilderRef
 
createRouteGroupMap(List<RouteType>) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
createSchema() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
createSchemaFactory() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
createSchemaSource() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
createSet(Expression<Exchange>) - Static method in class org.apache.camel.processor.Resequencer
 
createSet(List<Expression>) - Static method in class org.apache.camel.processor.Resequencer
 
createSet(Comparator<? super Exchange>) - Static method in class org.apache.camel.processor.Resequencer
 
createSetBodyProcessor(Object) - Method in class org.apache.camel.CamelTemplate
 
createSimpleExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createStreamResequencer(RouteContext, StreamResequencerConfig) - Method in class org.apache.camel.model.ResequencerType
 
createSubcontext(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
createSubcontext(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
createTransfomer() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
createTransformerFactory() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
createTypeClass() - Method in class org.apache.camel.model.ConvertBodyType
 
createTypeConverter() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createURIWithQuery(URI, String) - Static method in class org.apache.camel.util.URISupport
Creates a URI with the given query
createVariableMap(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Creates a Map of the variables which are made available to a script or template
createXMLEventReader(InputStream) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLEventReader(Reader) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLEventReader(XMLStreamReader) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLEventReader(Source) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLEventWriter(OutputStream) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLEventWriter(Writer) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLEventWriter(Result) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLStreamReader(InputStream) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLStreamReader(Reader) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLStreamReader(Source) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLStreamWriter(OutputStream) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLStreamWriter(Writer) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXMLStreamWriter(Result) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
createXPathExpression() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
csv() - Method in class org.apache.camel.builder.DataFormatClause
Uses the CSV data format
CsvDataFormat - Class in org.apache.camel.model.dataformat
Represents a CSV (Comma Separated Values) DataFormat
CsvDataFormat() - Constructor for class org.apache.camel.model.dataformat.CsvDataFormat
 
currentSystemTime() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
currentTime() - Method in class org.apache.camel.util.DefaultTimeoutMap
 
customProcessorForException(Exchange, Throwable) - Method in class org.apache.camel.processor.ErrorHandlerSupport
Attempts to invoke the handler for this particular exception if one is available

D

daemon(boolean) - Method in class org.apache.camel.model.ThreadType
 
DataFormat - Interface in org.apache.camel.spi
Represents a data format used to marshal objects to and from streams such as Java Serialization or using JAXB2 to encode/decode objects using XML or using SOAP encoding.
DataFormatClause<T extends ProcessorType> - Class in org.apache.camel.builder
An expression for constructing the different possible DataFormat options.
DataFormatClause(T, DataFormatClause.Operation) - Constructor for class org.apache.camel.builder.DataFormatClause
 
DataFormatClause.Operation - Enum in org.apache.camel.builder
 
DataFormatType - Class in org.apache.camel.model.dataformat
 
DataFormatType() - Constructor for class org.apache.camel.model.dataformat.DataFormatType
 
DataFormatType(DataFormat) - Constructor for class org.apache.camel.model.dataformat.DataFormatType
 
DataFormatType(String) - Constructor for class org.apache.camel.model.dataformat.DataFormatType
 
DataSet - Interface in org.apache.camel.component.dataset
Represents a strategy for testing endpoints with canned data.
DataSetComponent - Class in org.apache.camel.component.dataset
 
DataSetComponent() - Constructor for class org.apache.camel.component.dataset.DataSetComponent
 
DataSetConsumer - Class in org.apache.camel.component.dataset
 
DataSetConsumer(DataSetEndpoint, Processor) - Constructor for class org.apache.camel.component.dataset.DataSetConsumer
 
DataSetEndpoint - Class in org.apache.camel.component.dataset
 
DataSetEndpoint(String, Component, DataSet) - Constructor for class org.apache.camel.component.dataset.DataSetEndpoint
 
DataSetEndpoint(String, DataSet) - Constructor for class org.apache.camel.component.dataset.DataSetEndpoint
 
DataSetSupport - Class in org.apache.camel.component.dataset
 
DataSetSupport() - Constructor for class org.apache.camel.component.dataset.DataSetSupport
 
DataSetSupport(int) - Constructor for class org.apache.camel.component.dataset.DataSetSupport
 
days(long) - Static method in class org.apache.camel.util.Time
 
daysAsSeconds(long) - Static method in class org.apache.camel.util.Time
 
deadLetterChannel() - Method in class org.apache.camel.builder.BuilderSupport
 
deadLetterChannel(String) - Method in class org.apache.camel.builder.BuilderSupport
 
deadLetterChannel(Endpoint) - Method in class org.apache.camel.builder.BuilderSupport
 
DeadLetterChannel - Class in org.apache.camel.processor
Implements a Dead Letter Channel after attempting to redeliver the message using the RedeliveryPolicy
DeadLetterChannel(Processor, Processor) - Constructor for class org.apache.camel.processor.DeadLetterChannel
 
DeadLetterChannel(Processor, Processor, RedeliveryPolicy, Logger, ExceptionPolicyStrategy) - Constructor for class org.apache.camel.processor.DeadLetterChannel
 
DeadLetterChannelBuilder - Class in org.apache.camel.builder
A builder of a Dead Letter Channel
DeadLetterChannelBuilder() - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
DeadLetterChannelBuilder(Processor) - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
DeadLetterChannelBuilder(ProcessorFactory) - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
decode(String) - Static method in class org.apache.camel.management.ObjectNameEncoder
 
DEFAULT_BATCH_SIZE - Static variable in class org.apache.camel.processor.BatchProcessor
 
DEFAULT_BATCH_TIMEOUT - Static variable in class org.apache.camel.processor.BatchProcessor
 
DEFAULT_CHARSET_PROPERTY - Static variable in class org.apache.camel.converter.jaxp.XmlConverter
 
DEFAULT_DELIMITER - Static variable in class org.apache.camel.model.RoutingSlipType
 
DEFAULT_DOMAIN - Static variable in class org.apache.camel.management.InstrumentationAgentImpl
 
DEFAULT_HOST - Static variable in class org.apache.camel.management.InstrumentationAgentImpl
 
DEFAULT_LOCK_FILE_POSTFIX - Static variable in class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
DEFAULT_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
DEFAULT_PORT - Static variable in class org.apache.camel.management.InstrumentationAgentImpl
 
DEFAULT_TRACE_CATEGORY - Static variable in class org.apache.camel.model.ProcessorType
 
DefaultAnnotationExpressionFactory - Class in org.apache.camel.component.bean
 
DefaultAnnotationExpressionFactory() - Constructor for class org.apache.camel.component.bean.DefaultAnnotationExpressionFactory
 
DefaultCamelContext - Class in org.apache.camel.impl
Represents the context used to configure routes and the policies to use.
DefaultCamelContext() - Constructor for class org.apache.camel.impl.DefaultCamelContext
 
DefaultCamelContext(Context) - Constructor for class org.apache.camel.impl.DefaultCamelContext
Creates the CamelContext using the given JNDI context as the registry
DefaultCamelContext(Registry) - Constructor for class org.apache.camel.impl.DefaultCamelContext
Creates the CamelContext using the given registry
defaultCharset - Static variable in class org.apache.camel.converter.jaxp.XmlConverter
 
DefaultComponent<E extends Exchange> - Class in org.apache.camel.impl
Default component to use for base for components implementations.
DefaultComponent() - Constructor for class org.apache.camel.impl.DefaultComponent
 
DefaultComponent(CamelContext) - Constructor for class org.apache.camel.impl.DefaultComponent
 
DefaultComponentResolver<E extends Exchange> - Class in org.apache.camel.impl
The default implementation of ComponentResolver which tries to find components by using the URI scheme prefix and searching for a file of the URI scheme name in the META-INF/services/org/apache/camel/component/ directory on the classpath.
DefaultComponentResolver() - Constructor for class org.apache.camel.impl.DefaultComponentResolver
 
DefaultConsumer<E extends Exchange> - Class in org.apache.camel.impl
 
DefaultConsumer(Endpoint<E>, Processor) - Constructor for class org.apache.camel.impl.DefaultConsumer
 
DefaultEndpoint<E extends Exchange> - Class in org.apache.camel.impl
A default endpoint useful for implementation inheritance
DefaultEndpoint(String, Component) - Constructor for class org.apache.camel.impl.DefaultEndpoint
 
DefaultEndpoint(String, CamelContext) - Constructor for class org.apache.camel.impl.DefaultEndpoint
 
DefaultEndpoint(String) - Constructor for class org.apache.camel.impl.DefaultEndpoint
 
DefaultExceptionPolicyStrategy - Class in org.apache.camel.processor.exceptionpolicy
The default strategy used in Camel to resolve the ExceptionType that should handle the thrown exception.
DefaultExceptionPolicyStrategy() - Constructor for class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
 
DefaultExchange - Class in org.apache.camel.impl
A default implementation of Exchange
DefaultExchange(CamelContext) - Constructor for class org.apache.camel.impl.DefaultExchange
 
DefaultExchange(CamelContext, ExchangePattern) - Constructor for class org.apache.camel.impl.DefaultExchange
 
DefaultExchange(DefaultExchange) - Constructor for class org.apache.camel.impl.DefaultExchange
 
DefaultExchangeComparator - Class in org.apache.camel.processor.resequencer
Compares elements of an Exchange sequence by comparing long values returned by this comaprator's expression.
DefaultExchangeComparator() - Constructor for class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
DefaultExchangeConverter - Class in org.apache.camel.impl
 
DefaultExchangeConverter() - Constructor for class org.apache.camel.impl.DefaultExchangeConverter
 
DefaultFileRenamer - Class in org.apache.camel.component.file.strategy
Camel default file renamer.
DefaultFileRenamer() - Constructor for class org.apache.camel.component.file.strategy.DefaultFileRenamer
 
DefaultFileRenamer(String, String) - Constructor for class org.apache.camel.component.file.strategy.DefaultFileRenamer
 
DefaultLanguageResolver - Class in org.apache.camel.impl
 
DefaultLanguageResolver() - Constructor for class org.apache.camel.impl.DefaultLanguageResolver
 
DefaultLifecycleStrategy - Class in org.apache.camel.impl
 
DefaultLifecycleStrategy() - Constructor for class org.apache.camel.impl.DefaultLifecycleStrategy
 
DefaultMessage - Class in org.apache.camel.impl
The default implementation of Message
DefaultMessage() - Constructor for class org.apache.camel.impl.DefaultMessage
 
DefaultNamespaceContext - Class in org.apache.camel.builder.xml
An implementation of NamespaceContext which uses a simple Map where the keys are the prefixes and the values are the URIs
DefaultNamespaceContext() - Constructor for class org.apache.camel.builder.xml.DefaultNamespaceContext
 
DefaultNamespaceContext(XPathFactory) - Constructor for class org.apache.camel.builder.xml.DefaultNamespaceContext
 
DefaultNamespaceContext(NamespaceContext, Map<String, String>) - Constructor for class org.apache.camel.builder.xml.DefaultNamespaceContext
 
DefaultParameterMappingStrategy - Class in org.apache.camel.component.bean
Represents the strategy used to figure out how to map a message exchange to a POJO method invocation
DefaultParameterMappingStrategy() - Constructor for class org.apache.camel.component.bean.DefaultParameterMappingStrategy
 
DefaultPollingEndpoint<E extends Exchange> - Class in org.apache.camel.impl
A base class for an endpoint which the default consumer mode is to use a PollingConsumer
DefaultPollingEndpoint(String, Component) - Constructor for class org.apache.camel.impl.DefaultPollingEndpoint
 
DefaultPollingEndpoint(String, CamelContext) - Constructor for class org.apache.camel.impl.DefaultPollingEndpoint
 
DefaultPollingEndpoint(String) - Constructor for class org.apache.camel.impl.DefaultPollingEndpoint
 
defaultProcessTime(Exchange) - Method in class org.apache.camel.processor.Delayer
A Strategy Method to allow derived implementations to decide the current system time or some other default exchange property
DefaultProducer<E extends Exchange> - Class in org.apache.camel.impl
A default implementation of @{link Producer} for implementation inheritence
DefaultProducer(Endpoint<E>) - Constructor for class org.apache.camel.impl.DefaultProducer
 
DefaultScheduledPollConsumer<E extends Exchange> - Class in org.apache.camel.impl
A default implementation of an event driven Consumer which uses the PollingConsumer
DefaultScheduledPollConsumer(DefaultEndpoint<E>, Processor) - Constructor for class org.apache.camel.impl.DefaultScheduledPollConsumer
 
DefaultScheduledPollConsumer(Endpoint<E>, Processor, ScheduledExecutorService) - Constructor for class org.apache.camel.impl.DefaultScheduledPollConsumer
 
DefaultTimeoutMap - Class in org.apache.camel.util
 
DefaultTimeoutMap() - Constructor for class org.apache.camel.util.DefaultTimeoutMap
 
DefaultTimeoutMap(ScheduledExecutorService, long) - Constructor for class org.apache.camel.util.DefaultTimeoutMap
 
DefaultTypeConverter - Class in org.apache.camel.impl.converter
 
DefaultTypeConverter(Injector) - Constructor for class org.apache.camel.impl.converter.DefaultTypeConverter
 
DefaultTypeConverter.TypeMapping - Class in org.apache.camel.impl.converter
Represents a mapping from one type (which can be null) to another
DefaultTypeConverter.TypeMapping(Class, Class) - Constructor for class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
DefaultUnitOfWork - Class in org.apache.camel.impl
The default implementation of UnitOfWork
DefaultUnitOfWork() - Constructor for class org.apache.camel.impl.DefaultUnitOfWork
 
DefaultValidationErrorHandler - Class in org.apache.camel.processor.validation
A default error handler which just stores all the errors so they can be reported or transformed.
DefaultValidationErrorHandler() - Constructor for class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
delay(Exchange) - Method in class org.apache.camel.processor.Delayer
Waits for an optional time period before continuing to process the exchange
delay(Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
delay(Exchange) - Method in class org.apache.camel.processor.Throttler
 
delayer(Expression<Exchange>) - Method in class org.apache.camel.model.ProcessorType
Creates the Delayer pattern where an expression is used to calculate the time which the message will be dispatched on
delayer(Expression<Exchange>, long) - Method in class org.apache.camel.model.ProcessorType
Creates the Delayer pattern where an expression is used to calculate the time which the message will be dispatched on
delayer() - Method in class org.apache.camel.model.ProcessorType
Creates the Delayer pattern where an expression is used to calculate the time which the message will be dispatched on
delayer(long) - Method in class org.apache.camel.model.ProcessorType
Creates the Delayer pattern where a fixed amount of milliseconds are used to delay processing of a message exchange
Delayer - Class in org.apache.camel.processor
A Delayer which delays processing the exchange until the correct amount of time has elapsed using an expression to determine the delivery time.
Delayer(Processor, Expression<Exchange>, long) - Constructor for class org.apache.camel.processor.Delayer
 
DelayerType - Class in org.apache.camel.model
 
DelayerType() - Constructor for class org.apache.camel.model.DelayerType
 
DelayerType(Expression) - Constructor for class org.apache.camel.model.DelayerType
 
DelayerType(ExpressionType) - Constructor for class org.apache.camel.model.DelayerType
 
DelayerType(Expression, long) - Constructor for class org.apache.camel.model.DelayerType
 
DelayProcessorSupport - Class in org.apache.camel.processor
A useful base class for any processor which provides some kind of throttling or delayed processing
DelayProcessorSupport(Processor) - Constructor for class org.apache.camel.processor.DelayProcessorSupport
 
DelegateAsyncProcessor - Class in org.apache.camel.processor
A Delegate pattern which delegates processing to a nested AsyncProcessor which can be useful for implementation inheritance when writing an Policy
DelegateAsyncProcessor() - Constructor for class org.apache.camel.processor.DelegateAsyncProcessor
 
DelegateAsyncProcessor(AsyncProcessor) - Constructor for class org.apache.camel.processor.DelegateAsyncProcessor
 
DelegateLifecycleStrategy - Class in org.apache.camel.impl
A helper class for folks writing delegate listener strategies
DelegateLifecycleStrategy(LifecycleStrategy) - Constructor for class org.apache.camel.impl.DelegateLifecycleStrategy
 
DelegateProcessor - Class in org.apache.camel.processor
A Delegate pattern which delegates processing to a nested processor which can be useful for implementation inheritance when writing an Policy
DelegateProcessor() - Constructor for class org.apache.camel.processor.DelegateProcessor
 
DelegateProcessor(Processor) - Constructor for class org.apache.camel.processor.DelegateProcessor
 
DeleteFileProcessStrategy - Class in org.apache.camel.component.file.strategy
A strategy which will delete the file when its processed
DeleteFileProcessStrategy() - Constructor for class org.apache.camel.component.file.strategy.DeleteFileProcessStrategy
 
DeleteFileProcessStrategy(boolean) - Constructor for class org.apache.camel.component.file.strategy.DeleteFileProcessStrategy
 
description(String, String, Endpoint) - Static method in class org.apache.camel.model.FromType
 
description() - Method in class org.apache.camel.model.PolicyRef
 
destroySubcontext(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
destroySubcontext(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
dir - Variable in class org.apache.camel.view.GraphGeneratorSupport
 
DirectComponent<E extends Exchange> - Class in org.apache.camel.component.direct
Represents the component that manages DirectEndpoint.
DirectComponent() - Constructor for class org.apache.camel.component.direct.DirectComponent
 
DirectEndpoint<E extends Exchange> - Class in org.apache.camel.component.direct
Represents a direct endpoint that synchronously invokes the consumers of the endpoint when a producer sends a message to it.
DirectEndpoint(String, DirectComponent<E>) - Constructor for class org.apache.camel.component.direct.DirectEndpoint
 
DirectEndpoint(String) - Constructor for class org.apache.camel.component.direct.DirectEndpoint
 
DirectProducer<E extends Exchange> - Class in org.apache.camel.component.direct
 
DirectProducer(DirectEndpoint<E>) - Constructor for class org.apache.camel.component.direct.DirectProducer
 
domainName - Variable in class org.apache.camel.management.CamelNamingStrategy
 
DomConverter - Class in org.apache.camel.converter.jaxp
Converts from some DOM types to Java types
DomResultHandler - Class in org.apache.camel.builder.xml
Uses DOM to handle results of the transformation
DomResultHandler() - Constructor for class org.apache.camel.builder.xml.DomResultHandler
 
DomResultHandlerFactory - Class in org.apache.camel.builder.xml
 
DomResultHandlerFactory() - Constructor for class org.apache.camel.builder.xml.DomResultHandlerFactory
 
done(boolean) - Method in interface org.apache.camel.AsyncCallback
This method is invoked once the Exchange is completed.
done(Exchange) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
done(Exchange) - Method in interface org.apache.camel.spi.UnitOfWork
Invoked when this unit of work has been completed, whether it has failed or completed
doStart() - Method in class org.apache.camel.CamelTemplate
 
doStart() - Method in class org.apache.camel.component.bean.BeanProcessor
 
doStart() - Method in class org.apache.camel.component.dataset.DataSetConsumer
 
doStart() - Method in class org.apache.camel.component.seda.ListPollingConsumer
 
doStart() - Method in class org.apache.camel.component.seda.SedaConsumer
 
doStart() - Method in class org.apache.camel.component.timer.TimerConsumer
 
doStart() - Method in class org.apache.camel.component.vm.VmComponent
 
doStart() - Method in class org.apache.camel.impl.DefaultCamelContext
 
doStart() - Method in class org.apache.camel.impl.DefaultComponent
 
doStart() - Method in class org.apache.camel.impl.DefaultConsumer
 
doStart() - Method in class org.apache.camel.impl.DefaultProducer
 
doStart() - Method in class org.apache.camel.impl.DefaultScheduledPollConsumer
 
doStart() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
doStart() - Method in class org.apache.camel.impl.ProcessorPollingConsumer
 
doStart() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
doStart() - Method in class org.apache.camel.impl.ServiceSupport
 
doStart() - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
doStart() - Method in class org.apache.camel.processor.BatchProcessor
 
doStart() - Method in class org.apache.camel.processor.ChoiceProcessor
 
doStart() - Method in class org.apache.camel.processor.CompositeProcessor
 
doStart() - Method in class org.apache.camel.processor.DeadLetterChannel
 
doStart() - Method in class org.apache.camel.processor.DelegateAsyncProcessor
 
doStart() - Method in class org.apache.camel.processor.DelegateProcessor
 
doStart() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doStart() - Method in class org.apache.camel.processor.Interceptor
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doStart() - Method in class org.apache.camel.processor.LoggingErrorHandler
 
doStart() - Method in class org.apache.camel.processor.MulticastProcessor
 
doStart() - Method in class org.apache.camel.processor.RecipientList
 
doStart() - Method in class org.apache.camel.processor.RoutingSlip
 
doStart() - Method in class org.apache.camel.processor.SendProcessor
 
doStart() - Method in class org.apache.camel.processor.StreamResequencer
 
doStart() - Method in class org.apache.camel.processor.TryProcessor
 
doStart() - Method in class org.apache.camel.util.ProducerCache
 
doStop() - Method in class org.apache.camel.CamelTemplate
 
doStop() - Method in class org.apache.camel.component.bean.BeanProcessor
 
doStop() - Method in class org.apache.camel.component.seda.ListPollingConsumer
 
doStop() - Method in class org.apache.camel.component.seda.SedaConsumer
 
doStop() - Method in class org.apache.camel.component.timer.TimerComponent
 
doStop() - Method in class org.apache.camel.component.timer.TimerConsumer
 
doStop() - Method in class org.apache.camel.component.vm.VmComponent
 
doStop() - Method in class org.apache.camel.impl.DefaultCamelContext
 
doStop() - Method in class org.apache.camel.impl.DefaultComponent
 
doStop() - Method in class org.apache.camel.impl.DefaultConsumer
 
doStop() - Method in class org.apache.camel.impl.DefaultProducer
 
doStop() - Method in class org.apache.camel.impl.DefaultScheduledPollConsumer
 
doStop() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
doStop() - Method in class org.apache.camel.impl.ProcessorPollingConsumer
 
doStop() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
doStop() - Method in class org.apache.camel.impl.ServiceSupport
 
doStop() - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
doStop() - Method in class org.apache.camel.processor.BatchProcessor
 
doStop() - Method in class org.apache.camel.processor.ChoiceProcessor
 
doStop() - Method in class org.apache.camel.processor.CompositeProcessor
 
doStop() - Method in class org.apache.camel.processor.DeadLetterChannel
 
doStop() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
doStop() - Method in class org.apache.camel.processor.DelegateAsyncProcessor
 
doStop() - Method in class org.apache.camel.processor.DelegateProcessor
 
doStop() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doStop() - Method in class org.apache.camel.processor.Interceptor
 
doStop() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
doStop() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doStop() - Method in class org.apache.camel.processor.LoggingErrorHandler
 
doStop() - Method in class org.apache.camel.processor.MulticastProcessor
 
doStop() - Method in class org.apache.camel.processor.RecipientList
 
doStop() - Method in class org.apache.camel.processor.RoutingSlip
 
doStop() - Method in class org.apache.camel.processor.SendProcessor
 
doStop() - Method in class org.apache.camel.processor.StreamResequencer
 
doStop() - Method in class org.apache.camel.processor.TryProcessor
 
doStop() - Method in class org.apache.camel.util.ProducerCache
 
drawRoutes(CamelContext) - Method in class org.apache.camel.view.GraphGeneratorSupport
 

E

edgeLabel - Variable in class org.apache.camel.view.NodeData
 
el(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates the EL Language from JSP and JSF using the JUEL library
ELExpression - Class in org.apache.camel.model.language
For EL expresions and predicates
ELExpression() - Constructor for class org.apache.camel.model.language.ELExpression
 
ELExpression(String) - Constructor for class org.apache.camel.model.language.ELExpression
 
enableJmx(String, int) - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
encode(String) - Static method in class org.apache.camel.management.ObjectNameEncoder
 
encode(String, boolean) - Static method in class org.apache.camel.management.ObjectNameEncoder
 
encode(String) - Static method in class org.apache.camel.util.UnsafeUriCharactersEncoder
 
encode(String) - Method in class org.apache.camel.view.XmlGraphGenerator
 
end() - Method in class org.apache.camel.model.ProcessorType
Ends the current block
end() - Method in class org.apache.camel.model.TryType
 
endpoint(String) - Method in class org.apache.camel.builder.BuilderSupport
Resolves the given URI to an endpoint
endpoint(String, Class<T>) - Method in class org.apache.camel.builder.BuilderSupport
Resolves the given URI to an endpoint of the specified type
Endpoint<E extends Exchange> - Interface in org.apache.camel
An endpoint implements the Message Endpoint pattern and represents an endpoint that can send and receive message exchanges
EndpointHelper - Class in org.apache.camel.util
Some helper methods for working with Endpoint instances
EndpointInject - Annotation Type in org.apache.camel
Used to indicate an injection point of an Endpoint, Producer, ProducerTemplate or CamelTemplate into a POJO.
endpoints(String...) - Method in class org.apache.camel.builder.BuilderSupport
Resolves the list of URIs into a list of Endpoint instances
endpoints(Endpoint...) - Method in class org.apache.camel.builder.BuilderSupport
Helper method to create a list of Endpoint instances
EnumTypeConverter - Class in org.apache.camel.impl.converter
A type converter which is used to convert to and from array types particularly for derived types of array component types and dealing with primitive array types.
EnumTypeConverter() - Constructor for class org.apache.camel.impl.converter.EnumTypeConverter
 
ENVIRONMENT_VARIABLES - Static variable in class org.apache.camel.builder.xml.Namespaces
 
equal(Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
A helper method for comparing objects for equality while handling nulls
equalByteArray(byte[], byte[]) - Static method in class org.apache.camel.util.ObjectHelper
A helper method for comparing byte arrays for equality while handling nulls
equals(Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
equals(Object) - Method in class org.apache.camel.impl.DefaultEndpoint
 
equals(Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
Deprecated. use the equal method instead
equals(Object) - Method in class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
error(SAXParseException) - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
errorHandler(ErrorHandlerBuilder) - Method in class org.apache.camel.builder.RouteBuilder
Installs the given error handler builder
errorHandler(ErrorHandlerBuilder) - Method in class org.apache.camel.model.ProcessorType
Installs the given error handler builder
ErrorHandler - Interface in org.apache.camel.processor
An interface used to represent an error handler
ErrorHandlerBuilder - Interface in org.apache.camel.builder
 
ErrorHandlerBuilderSupport - Class in org.apache.camel.builder
 
ErrorHandlerBuilderSupport() - Constructor for class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
ErrorHandlerSupport - Class in org.apache.camel.processor
Support class for ErrorHandler implementations.
ErrorHandlerSupport() - Constructor for class org.apache.camel.processor.ErrorHandlerSupport
 
escapeNodeId(String) - Method in class org.apache.camel.view.RouteDotGenerator
 
evaluate(E) - Method in class org.apache.camel.builder.ValueBuilder
 
evaluate(E) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
evaluate(E) - Method in interface org.apache.camel.Expression
Returns the value of the expression on the given exchange
evaluate(E) - Method in class org.apache.camel.language.bean.BeanExpression
 
evaluate(Exchange) - Method in class org.apache.camel.model.language.ExpressionType
 
evaluateAs(E, QName) - Method in class org.apache.camel.builder.xml.XPathBuilder
Evaluates the expression as the given result type
evaluateAsString(Expression<E>, E) - Static method in class org.apache.camel.util.ExpressionHelper
Evaluates the given expression on the exchange as a String value
evaluateAsType(Expression<E>, E, Class<T>) - Static method in class org.apache.camel.util.ExpressionHelper
Evaluates the given expression on the exchange, converting the result to the given type
evaluateStringExpression(Expression<E>, E) - Static method in class org.apache.camel.builder.ExpressionBuilder
Evaluates the expression on the given exchange and returns the String representation
evaluateValuePredicate(Object) - Static method in class org.apache.camel.builder.PredicateBuilder
Evaluate the value as a predicate which attempts to convert the value to a boolean otherwise true is returned if the value is not null
EventDrivenConsumerRoute<E extends Exchange> - Class in org.apache.camel.impl
A Route which starts with an Event Driven Consumer
EventDrivenConsumerRoute(Endpoint, Processor) - Constructor for class org.apache.camel.impl.EventDrivenConsumerRoute
 
EventDrivenPollingConsumer<E extends Exchange> - Class in org.apache.camel.impl
A default implementation of the PollingConsumer which uses the normal asynchronous consumer mechanism along with a BlockingQueue to allow the caller to pull messages on demand.
EventDrivenPollingConsumer(Endpoint<E>) - Constructor for class org.apache.camel.impl.EventDrivenPollingConsumer
 
EventDrivenPollingConsumer(Endpoint<E>, BlockingQueue<E>) - Constructor for class org.apache.camel.impl.EventDrivenPollingConsumer
 
exception(Class) - Method in class org.apache.camel.builder.RouteBuilder
Adds an exception handler route for the given exception type
exception(Class) - Method in class org.apache.camel.model.ProcessorType
 
exception(Class) - Method in class org.apache.camel.model.RoutesType
 
EXCEPTION_CAUSE_PROPERTY - Static variable in class org.apache.camel.processor.DeadLetterChannel
 
ExceptionHandler - Interface in org.apache.camel.spi
A Strategy pattern for handling exceptions; particularly in asynchronous processes such as consumers
exceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the exception policy to use
ExceptionPolicyStrategy - Interface in org.apache.camel.processor.exceptionpolicy
A strategy to determine witch ExceptionType should handle the thrown exception.
ExceptionType - Class in org.apache.camel.model
 
ExceptionType() - Constructor for class org.apache.camel.model.ExceptionType
 
ExceptionType(List<Class>) - Constructor for class org.apache.camel.model.ExceptionType
 
ExceptionType(Class) - Constructor for class org.apache.camel.model.ExceptionType
 
exchange() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the exchange
Exchange - Interface in org.apache.camel
The base message exchange interface providing access to the request, response and fault Message instances.
EXCHANGE_PROPERTY - Static variable in class org.apache.camel.builder.xml.Namespaces
 
ExchangeConverter - Interface in org.apache.camel.spi
This converter is capable of converting from an exchange to another type
exchangeExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchange
ExchangeHelper - Class in org.apache.camel.util
Some helper methods for working with Exchange objects
ExchangePattern - Enum in org.apache.camel
Represents the kind of message exchange pattern
ExchangeTimedOutException - Exception in org.apache.camel
An exception thrown if an InOut exchange times out receiving the OUT message
ExchangeTimedOutException(Exchange, long) - Constructor for exception org.apache.camel.ExchangeTimedOutException
 
executor(ThreadPoolExecutor) - Method in class org.apache.camel.model.ThreadType
 
expectedBodiesReceived(List) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint
expectedBodiesReceived(Object...) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint
ExpectedBodyTypeException - Exception in org.apache.camel
Thrown if the body could not be converted to the required type
ExpectedBodyTypeException(Exchange, Class) - Constructor for exception org.apache.camel.ExpectedBodyTypeException
 
expectedHeaderReceived(String, String) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given header name & value are received by this endpoint
expectedMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies the expected number of message exchanges that should be received by this endpoint
expectedMinimumMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies the minimum number of expected message exchanges that should be received by this endpoint
expects(Runnable) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds the expection which will be invoked when enough messages are received
expectsAscending(Expression<Exchange>) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that messages received should have ascending values of the given expression such as a user generated counter value
expectsDescending(Expression<Exchange>) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that messages received should have descending values of the given expression such as a user generated counter value
expectsMessageCount(int, MockEndpoint...) - Static method in class org.apache.camel.component.mock.MockEndpoint
 
expectsNoDuplicates(Expression<Exchange>) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that no duplicate messages should be received using the expression to determine the message ID
expression(Expression) - Method in class org.apache.camel.builder.ExpressionClause
Specify an Expression instance
Expression<E extends Exchange> - Interface in org.apache.camel
An expression provides a plugin strategy for evaluating expressions on a message exchange to support things like scripting languages, XQuery or SQL as well as any arbitrary Java expression.
expression(ExpressionType) - Method in class org.apache.camel.model.ResequencerType
 
ExpressionBuilder - Class in org.apache.camel.builder
 
ExpressionClause<T> - Class in org.apache.camel.builder
Represents an expression clause within the DSL which when the expression is complete the clause continues to another part of the DSL
ExpressionClause(T) - Constructor for class org.apache.camel.builder.ExpressionClause
 
ExpressionComparator<E extends Exchange> - Class in org.apache.camel.util
An implementation of Comparator which takes an Expression which is evaluated on each exchange to compare
ExpressionComparator(Expression<E>) - Constructor for class org.apache.camel.util.ExpressionComparator
 
ExpressionEvaluationException - Exception in org.apache.camel.language
 
ExpressionEvaluationException(Expression<Exchange>, Exchange, Throwable) - Constructor for exception org.apache.camel.language.ExpressionEvaluationException
 
ExpressionHelper - Class in org.apache.camel.util
A collection of helper methods for working with expressions.
ExpressionListComparator - Class in org.apache.camel.util
An implementation of Comparator which takes a list of Expression objects which is evaluated on each exchange to compare them
ExpressionListComparator(List<Expression>) - Constructor for class org.apache.camel.util.ExpressionListComparator
 
ExpressionNode - Class in org.apache.camel.model
A base class for nodes which contain an expression and a number of outputs
ExpressionNode() - Constructor for class org.apache.camel.model.ExpressionNode
 
ExpressionNode(ExpressionType) - Constructor for class org.apache.camel.model.ExpressionNode
 
ExpressionNode(Expression) - Constructor for class org.apache.camel.model.ExpressionNode
 
ExpressionNode(Predicate) - Constructor for class org.apache.camel.model.ExpressionNode
 
ExpressionResultComparator<E extends Exchange> - Interface in org.apache.camel.processor.resequencer
A SequenceElementComparator that compares Exchanges based on the result of an expression evaluation.
ExpressionSupport<E extends Exchange> - Class in org.apache.camel.impl
A useful base class for Predicate and Expression implementations
ExpressionSupport() - Constructor for class org.apache.camel.impl.ExpressionSupport
 
ExpressionType - Class in org.apache.camel.model.language
A useful base class for an expression
ExpressionType() - Constructor for class org.apache.camel.model.language.ExpressionType
 
ExpressionType(String) - Constructor for class org.apache.camel.model.language.ExpressionType
 
ExpressionType(Predicate) - Constructor for class org.apache.camel.model.language.ExpressionType
 
ExpressionType(Expression) - Constructor for class org.apache.camel.model.language.ExpressionType
 
extension - Variable in class org.apache.camel.view.GraphGeneratorSupport
 
extractProperties(Map, String) - Static method in class org.apache.camel.util.IntrospectionSupport
 
extractResultBody(E) - Method in class org.apache.camel.CamelTemplate
 

F

FactoryFinder - Class in org.apache.camel.util
 
FactoryFinder() - Constructor for class org.apache.camel.util.FactoryFinder
 
FactoryFinder(String) - Constructor for class org.apache.camel.util.FactoryFinder
 
fail(Object) - Method in class org.apache.camel.component.mock.MockEndpoint
 
FailedToCreateProducerException - Exception in org.apache.camel
 
FailedToCreateProducerException(Endpoint, Throwable) - Constructor for exception org.apache.camel.FailedToCreateProducerException
 
fatalError(SAXParseException) - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
faultBody() - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the fault body on an exchange
faultBody() - Method in class org.apache.camel.builder.BuilderSupport
Returns a predicate and value builder for the fault body on an exchange
faultBodyAs(Class<T>) - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the fault message body as a specific type
faultBodyAs(Class<T>) - Method in class org.apache.camel.builder.BuilderSupport
Returns a predicate and value builder for the fault message body as a specific type
faultBodyExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the fault messages body
faultBodyExpression(Class<T>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges fault message body converted to the given type
FileComponent - Class in org.apache.camel.component.file
The File Component for working with file systems
FileComponent() - Constructor for class org.apache.camel.component.file.FileComponent
 
FileComponent(CamelContext) - Constructor for class org.apache.camel.component.file.FileComponent
 
FileConsumer - Class in org.apache.camel.component.file
For consuming files.
FileConsumer(FileEndpoint, Processor) - Constructor for class org.apache.camel.component.file.FileConsumer
 
FileEndpoint - Class in org.apache.camel.component.file
A File Endpoint for working with file systems
FileEndpoint(File, String, FileComponent) - Constructor for class org.apache.camel.component.file.FileEndpoint
 
FileEndpoint(String, File) - Constructor for class org.apache.camel.component.file.FileEndpoint
 
FileExchange - Class in org.apache.camel.component.file
A Exchange for File
FileExchange(CamelContext, ExchangePattern, File) - Constructor for class org.apache.camel.component.file.FileExchange
 
FileExchange(DefaultExchange, File) - Constructor for class org.apache.camel.component.file.FileExchange
 
FileMessage - Class in org.apache.camel.component.file
A Exchange for File
FileMessage() - Constructor for class org.apache.camel.component.file.FileMessage
 
FileMessage(File) - Constructor for class org.apache.camel.component.file.FileMessage
 
FileProcessStrategy - Interface in org.apache.camel.component.file
Represents a strategy for marking that a file is processed.
FileProcessStrategyFactory - Class in org.apache.camel.component.file.strategy
Factory to provide the FileProcessStrategy to use.
FileProcessStrategySupport - Class in org.apache.camel.component.file.strategy
Base class for FileProcessStrategy implementation to extend.
FileProcessStrategySupport() - Constructor for class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
FileProcessStrategySupport(boolean) - Constructor for class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
FileProcessStrategySupport(boolean, FileRenamer) - Constructor for class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
FileProducer - Class in org.apache.camel.component.file
A Producer implementation for File
FileProducer(FileEndpoint) - Constructor for class org.apache.camel.component.file.FileProducer
 
FileRenamer - Interface in org.apache.camel.component.file.strategy
Used for renaming files.
filter() - Method in class org.apache.camel.model.ProcessorType
Creates a predicate expression which only if it is true then the exchange is forwarded to the destination
filter(Predicate) - Method in class org.apache.camel.model.ProcessorType
Creates a predicate which is applied and only if it is true then the exchange is forwarded to the destination
filter(ExpressionType) - Method in class org.apache.camel.model.ProcessorType
 
filter(String, String) - Method in class org.apache.camel.model.ProcessorType
 
FilterProcessor - Class in org.apache.camel.processor
 
FilterProcessor(Predicate<Exchange>, Processor) - Constructor for class org.apache.camel.processor.FilterProcessor
 
FilterType - Class in org.apache.camel.model
 
FilterType() - Constructor for class org.apache.camel.model.FilterType
 
FilterType(ExpressionType) - Constructor for class org.apache.camel.model.FilterType
 
FilterType(Predicate) - Constructor for class org.apache.camel.model.FilterType
 
finallyBlock() - Method in class org.apache.camel.model.TryType
 
FinallyType - Class in org.apache.camel.model
 
FinallyType() - Constructor for class org.apache.camel.model.FinallyType
 
find(ResolverUtil.Test, String) - Method in class org.apache.camel.util.ResolverUtil
Scans for classes starting at the package provided and descending into subpackages.
find(ResolverUtil.Test, String, ClassLoader) - Method in class org.apache.camel.util.ResolverUtil
 
findAnnotated(Class<? extends Annotation>, String...) - Method in class org.apache.camel.util.ResolverUtil
Attempts to discover classes that are annotated with to the annotation.
findClass(String) - Method in class org.apache.camel.util.FactoryFinder
 
findClass(String, String) - Method in class org.apache.camel.util.FactoryFinder
 
findClasses(String) - Method in class org.apache.camel.util.FactoryFinder
 
findClasses(String, String) - Method in class org.apache.camel.util.FactoryFinder
 
findImplementations(Class, String...) - Method in class org.apache.camel.util.ResolverUtil
Attempts to discover classes that are assignable to the type provided.
findMethodsWithAnnotation(Class<?>, Class<? extends Annotation>) - Static method in class org.apache.camel.util.ObjectHelper
Returns a list of methods which are annotated with the given annotation
findPackageNames() - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
Finds the names of the packages to search for on the classpath looking for text files on the classpath at the AnnotationTypeConverterLoader.META_INF_SERVICES location.
findPackages(Set<String>, ClassLoader) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
findTypeConverter(Class, Class, Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
Tries to auto-discover any available type converters
forceLazyInitialization() - Method in class org.apache.camel.impl.DefaultCamelContext
Lets force some lazy initialization to occur upfront before we start any components and create routes
freeze() - Method in class org.apache.camel.util.jndi.JndiContext
 
from(String) - Method in class org.apache.camel.builder.RouteBuilder
Creates a new route from the given URI input
from(Endpoint) - Method in class org.apache.camel.builder.RouteBuilder
Creates a new route from the given endpoint
from(String) - Method in class org.apache.camel.model.RoutesType
Creates a new route from the given URI input
from(Endpoint) - Method in class org.apache.camel.model.RoutesType
Creates a new route from the given endpoint
from(String) - Method in class org.apache.camel.model.RouteType
Creates an input to the route
from(Endpoint) - Method in class org.apache.camel.model.RouteType
Creates an input to the route
fromCharArray(char[]) - Static method in class org.apache.camel.converter.ObjectConverter
 
FromType - Class in org.apache.camel.model
Represents an XML <from/> element
FromType() - Constructor for class org.apache.camel.model.FromType
 
FromType(String) - Constructor for class org.apache.camel.model.FromType
 
FromType(Endpoint<? extends Exchange>) - Constructor for class org.apache.camel.model.FromType
 
fromWsdlUri(String) - Static method in enum org.apache.camel.ExchangePattern
Converts the WSDL URI into a ExchangePattern instance
functionResolver(XPathFunctionResolver) - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the XPathFunctionResolver instance to use on these XPath expressions

G

generateFile(PrintWriter, Map<String, List<RouteType>>) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
generateFile(PrintWriter, Map<String, List<RouteType>>) - Method in class org.apache.camel.view.RouteDotGenerator
 
generateFile(PrintWriter, Map<String, List<RouteType>>) - Method in class org.apache.camel.view.XmlGraphGenerator
 
generateId() - Method in class org.apache.camel.util.UuidGenerator
Generate a unqiue id
generateSanitizedId() - Method in class org.apache.camel.util.UuidGenerator
Generate a unique ID - that is friendly for a URL or file system
get() - Method in interface org.apache.camel.spi.Provider
Returns the newly constructed instance
get(Object) - Method in class org.apache.camel.util.DefaultTimeoutMap
 
get() - Method in class org.apache.camel.util.Out
 
get(Object) - Method in interface org.apache.camel.util.TimeoutMap
Looks up the value in the map by the given key.
getAction() - Method in class org.apache.camel.processor.ThroughputLogger
 
getAggregationCollection() - Method in class org.apache.camel.model.AggregatorType
 
getAggregationStrategy() - Method in class org.apache.camel.model.AggregatorType
 
getAggregationStrategy() - Method in class org.apache.camel.model.MulticastType
 
getAggregationStrategy() - Method in class org.apache.camel.model.SplitterType
 
getAggregationStrategy() - Method in class org.apache.camel.processor.MulticastProcessor
 
getAndRemoveParameter(Map, String, Class<T>) - Method in class org.apache.camel.impl.DefaultComponent
Gets the parameter and remove it from the parameter map.
getAndRemoveParameter(Map, String, Class<T>, T) - Method in class org.apache.camel.impl.DefaultComponent
Gets the parameter and remove it from the parameter map.
getAnnotations() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getArgs() - Method in class org.apache.camel.component.bean.BeanInvocation
 
getArguments() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getAsyncProcessor() - Method in class org.apache.camel.impl.DefaultConsumer
Provides an AsyncProcessor interface to the configured processor on the consumer.
getAttachment(String) - Method in class org.apache.camel.impl.DefaultMessage
 
getAttachment(String) - Method in interface org.apache.camel.Message
Returns the attachment specified by the id
getAttachmentNames() - Method in class org.apache.camel.impl.DefaultMessage
 
getAttachmentNames() - Method in interface org.apache.camel.Message
Returns a set of attachment names of the message
getAttachments() - Method in class org.apache.camel.impl.DefaultMessage
 
getAttachments() - Method in interface org.apache.camel.Message
Returns all attachments of the message
getAttributeName() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
getBackOffMultiplier() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
getBackOffMultiplier() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getBatchConfig() - Method in class org.apache.camel.model.ResequencerType
 
getBatchConfig(BatchResequencerConfig) - Method in class org.apache.camel.model.ResequencerType
 
getBatchSize() - Method in class org.apache.camel.model.AggregatorType
 
getBatchSize() - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
getBatchSize() - Method in class org.apache.camel.processor.BatchProcessor
 
getBatchTimeout() - Method in class org.apache.camel.model.AggregatorType
 
getBatchTimeout() - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
getBatchTimeout() - Method in class org.apache.camel.processor.BatchProcessor
 
getBean() - Method in interface org.apache.camel.component.bean.BeanHolder
 
getBean() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
getBean() - Method in class org.apache.camel.component.bean.RegistryBean
 
getBean() - Method in exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
getBeanInfo() - Method in interface org.apache.camel.component.bean.BeanHolder
 
getBeanInfo() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
getBeanInfo() - Method in class org.apache.camel.component.bean.RegistryBean
 
getBeanType() - Method in class org.apache.camel.model.BeanRef
 
getBlockingQueue(String, Map) - Method in class org.apache.camel.component.vm.VmComponent
 
getBody() - Method in class org.apache.camel.impl.MessageSupport
 
getBody(Class<T>) - Method in class org.apache.camel.impl.MessageSupport
 
getBody() - Method in interface org.apache.camel.Message
Returns the body of the message as a POJO
getBody(Class<T>) - Method in interface org.apache.camel.Message
Returns the body as the specified type
getBodyFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getBodyParameters() - Method in class org.apache.camel.component.bean.MethodInfo
 
getBodyParameterType() - Method in class org.apache.camel.component.bean.MethodInfo
 
getBufferSize() - Method in class org.apache.camel.component.file.FileEndpoint
 
getCamelContext() - Method in class org.apache.camel.component.bean.BeanInfo
 
getCamelContext() - Method in interface org.apache.camel.Component
Returns the context
getCamelContext() - Method in interface org.apache.camel.Endpoint
Returns the context which created the endpoint
getCamelContext() - Method in class org.apache.camel.impl.DefaultComponent
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultEndpoint
 
getCamelContext() - Method in class org.apache.camel.impl.RouteContext
 
getCamelContext() - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
getCamelContext() - Method in class org.apache.camel.model.RoutesType
 
getCamelContext() - Method in class org.apache.camel.model.RouteType
 
getCapacity() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getCatchClauses() - Method in class org.apache.camel.model.TryType
 
getCharset() - Method in class org.apache.camel.model.dataformat.StringDataFormat
 
getClasses() - Method in class org.apache.camel.util.ResolverUtil
Provides access to the classes discovered so far.
getClassLoaders() - Method in class org.apache.camel.util.ResolverUtil
Returns the classloaders that will be used for scanning for classes.
getCollection() - Method in class org.apache.camel.processor.BatchProcessor
 
getCollisionAvoidanceFactor() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
getCollisionAvoidanceFactor() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getCollisionAvoidancePercent() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getComparator() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getCompletePredicate() - Method in class org.apache.camel.model.AggregatorType
 
getCompletePredicate() - Method in class org.apache.camel.model.CompletedPredicate
 
getComponent(String) - Method in interface org.apache.camel.CamelContext
Gets a component from the context by name.
getComponent(String, Class<T>) - Method in interface org.apache.camel.CamelContext
Gets a component from the context by name and specifying the expected type of component.
getComponent(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getComponent(String, Class<T>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getComponent() - Method in class org.apache.camel.impl.DefaultEndpoint
 
getComponentId(Endpoint<? extends Exchange>) - Method in class org.apache.camel.management.CamelNamingStrategy
 
getComponentResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getComponents() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getConsumeDelay() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getConsumerProperties() - Method in class org.apache.camel.impl.ScheduledPollEndpoint
 
getConsumers() - Method in class org.apache.camel.component.direct.DirectEndpoint
 
getContentType() - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
getContentType(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Returns the MIME content type on the input message or null if one is not defined
getContext() - Method in class org.apache.camel.builder.BuilderSupport
 
getContext() - Method in class org.apache.camel.builder.RouteBuilder
 
getContext() - Method in class org.apache.camel.CamelTemplate
 
getContext() - Method in class org.apache.camel.component.bean.RegistryBean
 
getContext() - Method in interface org.apache.camel.Exchange
Returns the container so that a processor can resolve endpoints from URIs
getContext() - Method in class org.apache.camel.impl.DefaultExchange
 
getContext() - Method in class org.apache.camel.impl.JndiRegistry
 
getContextId(CamelContext) - Method in class org.apache.camel.management.CamelNamingStrategy
 
getContextPath() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getConverter() - Method in class org.apache.camel.builder.xml.XsltBuilder
 
getConverterType() - Method in class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
getCoreSize() - Method in class org.apache.camel.processor.ThreadProcessor
 
getData() - Method in class org.apache.camel.converter.jaxp.BytesSource
 
getDataFormat(RouteContext, DataFormatType, String) - Static method in class org.apache.camel.model.dataformat.DataFormatType
 
getDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.DataFormatType
 
getDataFormatType() - Method in class org.apache.camel.model.MarshalType
 
getDataFormatType() - Method in class org.apache.camel.model.UnmarshalType
 
getDataSet() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getDeadLetter() - Method in class org.apache.camel.processor.DeadLetterChannel
Returns the dead letter that message exchanges will be sent to if the redelivery attempts fail
getDeadLetterFactory() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
getDefault() - Static method in class org.apache.camel.model.config.BatchResequencerConfig
Returns a new BatchResequencerConfig instance using default values for batchSize (100) and batchTimeout (1000L).
getDefault() - Static method in class org.apache.camel.model.config.StreamResequencerConfig
Returns a new StreamResequencerConfig instance using default values for capacity (100) and timeout (1000L).
getDefaultBody() - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
getDefaultCharacterSet() - Static method in class org.apache.camel.util.ObjectHelper
Helper method to return the default character set name
getDefaultDeadLetterEndpoint() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
getDefaultDeadLetterEndpointExpression() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
getDefaultDeadLetterEndpointUri() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
getDefaultEndpoint() - Method in class org.apache.camel.CamelTemplate
 
getDefaultHeaders() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getDefaultParameterTypeExpression(Class) - Method in class org.apache.camel.component.bean.DefaultParameterMappingStrategy
 
getDefaultParameterTypeExpression(Class) - Method in interface org.apache.camel.component.bean.ParameterMappingStrategy
 
getDelay() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
getDelay() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
getDelay() - Method in class org.apache.camel.model.DelayerType
 
getDelay() - Method in class org.apache.camel.processor.Delayer
 
getDescription() - Method in class org.apache.camel.management.ManagedRoute
 
getDestination() - Method in class org.apache.camel.processor.SendProcessor
 
getDir() - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getDocument(E) - Method in class org.apache.camel.builder.xml.XPathBuilder
Strategy method to extract the document from the exchange
getDocumentBuilderFactory() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
getDocumentType() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getDomainName() - Method in class org.apache.camel.management.CamelNamingStrategy
 
getElementType() - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
getElementTypeName() - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
getEndpoint(String) - Method in interface org.apache.camel.CamelContext
Resolves the given URI to an Endpoint.
getEndpoint(String, Class<T>) - Method in interface org.apache.camel.CamelContext
Resolves the given URI to an Endpoint of the specified type.
getEndpoint() - Method in class org.apache.camel.component.file.FileProducer
 
getEndpoint() - Method in exception org.apache.camel.FailedToCreateProducerException
 
getEndpoint(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getEndpoint(String, Class<T>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getEndpoint() - Method in class org.apache.camel.impl.DefaultConsumer
 
getEndpoint() - Method in class org.apache.camel.impl.DefaultProducer
 
getEndpoint() - Method in class org.apache.camel.impl.PollingConsumerSupport
 
getEndpoint() - Method in class org.apache.camel.impl.RouteContext
 
getEndpoint() - Method in class org.apache.camel.management.ManagedEndpoint
 
getEndpoint() - Method in class org.apache.camel.model.FromType
 
getEndpoint() - Method in class org.apache.camel.model.ToType
 
getEndpoint() - Method in class org.apache.camel.processor.BatchProcessor
 
getEndpoint() - Method in interface org.apache.camel.Producer
 
getEndpoint() - Method in class org.apache.camel.Route
 
getEndpointId(Endpoint<? extends Exchange>) - Method in class org.apache.camel.management.CamelNamingStrategy
 
getEndpointUri() - Method in interface org.apache.camel.Endpoint
Returns the string representation of the endpoint URI
getEndpointUri() - Method in class org.apache.camel.impl.DefaultEndpoint
 
getEndpointUri() - Method in class org.apache.camel.management.ManagedRoute
 
getEnvironment() - Method in class org.apache.camel.util.jndi.JndiContext
 
getErrorHandler() - Method in class org.apache.camel.model.ExceptionType
 
getErrorHandler() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
getErrorHandlerBuilder() - Method in class org.apache.camel.builder.BuilderSupport
 
getErrorHandlerBuilder() - Method in class org.apache.camel.model.ProcessorType
 
getErrorHandlerBuilder() - Method in class org.apache.camel.model.RoutesType
 
getErrors() - Method in exception org.apache.camel.processor.validation.SchemaValidationException
Returns the validation errors
getErrors() - Method in class org.apache.camel.util.ReportingTypeConverterRegistry
 
getException() - Method in interface org.apache.camel.Exchange
Returns the exception associated with this exchange
getException() - Method in class org.apache.camel.impl.DefaultExchange
 
getExceptionClasses() - Method in class org.apache.camel.model.CatchType
 
getExceptionClasses() - Method in class org.apache.camel.model.ExceptionType
 
getExceptionHandler() - Method in class org.apache.camel.impl.DefaultConsumer
 
getExceptionHandler() - Method in class org.apache.camel.impl.PollingConsumerSupport
 
getExceptionHandler() - Method in class org.apache.camel.processor.BatchProcessor
 
getExceptionPolicy(Exchange, Throwable) - Method in class org.apache.camel.processor.ErrorHandlerSupport
Attempts to find the best suited ExceptionType to be used for handling the given thrown exception.
getExceptionPolicy(Map<Class, ExceptionType>, Exchange, Throwable) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
 
getExceptionPolicy(Map<Class, ExceptionType>, Exchange, Throwable) - Method in interface org.apache.camel.processor.exceptionpolicy.ExceptionPolicyStrategy
Resolves the ExceptionType that should handle the thrown exception.
getExceptionPolicyStrategy() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the exception policy strategy to use for resolving the ExceptionType to use for a given thrown exception
getExceptions() - Method in class org.apache.camel.model.CatchType
 
getExceptions() - Method in class org.apache.camel.model.ExceptionType
 
getExceptions() - Method in class org.apache.camel.model.RoutesType
 
getExceptions() - Method in class org.apache.camel.processor.CatchProcessor
 
getExchange() - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
getExchange() - Method in exception org.apache.camel.CamelExchangeException
Returns the exchange which caused the exception
getExchange() - Method in class org.apache.camel.component.file.FileMessage
 
getExchange() - Method in class org.apache.camel.component.jmx.JMXMessage
 
getExchange() - Method in exception org.apache.camel.ExpectedBodyTypeException
 
getExchange() - Method in class org.apache.camel.impl.MessageSupport
 
getExchange() - Method in exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
getExchange() - Method in interface org.apache.camel.Message
Returns the exchange this message is related to
getExchange() - Method in exception org.apache.camel.processor.idempotent.NoMessageIdException
The exchange which caused this failure
getExchange() - Method in exception org.apache.camel.RuntimeExchangeException
Returns the exchange which caused the exception
getExchangeConverter() - Method in interface org.apache.camel.CamelContext
Returns the converter of exchanges from one type to another
getExchangeConverter() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getExchangeId() - Method in interface org.apache.camel.Exchange
Returns the exchange id
getExchangeId() - Method in class org.apache.camel.impl.DefaultExchange
 
getExchangePattern() - Method in class org.apache.camel.impl.DefaultEndpoint
 
getExchangeProperty(Exchange, String, Class<T>, T) - Static method in class org.apache.camel.util.ExchangeHelper
Extracts the exchange property of the given name and type; if it is not present then the default value will be used
getExchanges() - Method in class org.apache.camel.component.list.ListEndpoint
 
getExchanges() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getExchanges() - Method in class org.apache.camel.component.seda.SedaEndpoint
 
getExchanges() - Method in interface org.apache.camel.spi.BrowsableEndpoint
Return the exchanges available on this endpoint
getExchangeType() - Method in class org.apache.camel.impl.DefaultEndpoint
Returns the type of the exchange which is generated by this component
getExcludedNamePostfixes() - Method in class org.apache.camel.component.file.FileEndpoint
 
getExcludedNamePrefixes() - Method in class org.apache.camel.component.file.FileEndpoint
 
getExecutor() - Method in class org.apache.camel.model.ThreadType
 
getExecutor() - Method in class org.apache.camel.processor.ThreadProcessor
 
getExecutor() - Method in class org.apache.camel.util.DefaultTimeoutMap
 
getExecutorService() - Method in class org.apache.camel.impl.DefaultComponent
 
getExecutorService() - Method in class org.apache.camel.impl.DefaultEndpoint
 
getExpectedBodyType() - Method in exception org.apache.camel.ExpectedBodyTypeException
 
getExpectedCount() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getExpectedMinimumCount() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getExpireTime() - Method in class org.apache.camel.util.TimeoutMapEntry
 
getExpression() - Method in class org.apache.camel.builder.ValueBuilder
 
getExpression() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getExpression() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getExpression() - Method in exception org.apache.camel.language.ExpressionEvaluationException
 
getExpression() - Method in exception org.apache.camel.language.IllegalSyntaxException
 
getExpression() - Method in class org.apache.camel.model.ExpressionNode
 
getExpression() - Method in class org.apache.camel.model.language.ExpressionType
 
getExpression() - Method in exception org.apache.camel.processor.idempotent.NoMessageIdException
The expression which was used
getExpression() - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
getExpressionFromAnnotation(Annotation) - Method in class org.apache.camel.component.bean.DefaultAnnotationExpressionFactory
 
getExpressions() - Method in class org.apache.camel.model.ResequencerType
 
getExpressionType() - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
getExpressionValue() - Method in class org.apache.camel.model.language.ExpressionType
 
getFailures() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getFatalErrors() - Method in exception org.apache.camel.processor.validation.SchemaValidationException
Returns the fatal validation errors
getFault() - Method in interface org.apache.camel.Exchange
Returns the fault message
getFault(boolean) - Method in interface org.apache.camel.Exchange
Returns the fault message; optionally lazily creating one if one has not been associated with this exchange
getFault() - Method in class org.apache.camel.impl.DefaultExchange
 
getFault(boolean) - Method in class org.apache.camel.impl.DefaultExchange
 
getFault() - Method in class org.apache.camel.model.ThrowFaultType
 
getFaultRef() - Method in class org.apache.camel.model.ThrowFaultType
 
getFile() - Method in class org.apache.camel.component.file.FileEndpoint
 
getFile() - Method in class org.apache.camel.component.file.FileExchange
 
getFile() - Method in class org.apache.camel.component.file.FileMessage
 
getFileStrategy() - Method in class org.apache.camel.component.file.FileEndpoint
 
getFilters() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getFinallyClause() - Method in class org.apache.camel.model.TryType
 
getFormat() - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
getFragment() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getFrom() - Method in class org.apache.camel.impl.RouteContext
 
getFromType() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
getFromType() - Method in exception org.apache.camel.NoTypeConversionAvailableException
Returns the required from type.
getFromType() - Method in class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
getFunctionResolver() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getGranularityPeriod() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
getGroup() - Method in class org.apache.camel.model.RouteType
The group that this route belongs to; could be the name of the RouteBuilder class or be explicitly configured in the XML.
getGroup() - Method in class org.apache.camel.model.ServiceActivationType
 
getGroupSize() - Method in class org.apache.camel.processor.ThroughputLogger
 
getHeader(String) - Method in class org.apache.camel.impl.DefaultMessage
 
getHeader(String, Class<T>) - Method in class org.apache.camel.impl.DefaultMessage
 
getHeader(String) - Method in interface org.apache.camel.Message
Accesses a specific header
getHeader(String, Class<T>) - Method in interface org.apache.camel.Message
Returns a header associated with this message by name and specifying the type required
getHeaderFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getHeaderName() - Method in class org.apache.camel.model.RoutingSlipType
 
getHeaderName() - Method in class org.apache.camel.model.SetHeaderType
 
getHeaderName() - Method in exception org.apache.camel.NoSuchHeaderException
 
getHeaders() - Method in class org.apache.camel.impl.DefaultMessage
 
getHeaders() - Method in interface org.apache.camel.Message
Returns all of the headers associated with the message
getHeaderValue() - Method in exception org.apache.camel.InvalidHeaderTypeException
Returns the actual header value
getHost() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getHostName() - Method in class org.apache.camel.management.CamelNamingStrategy
 
getHostName() - Static method in class org.apache.camel.util.UuidGenerator
As we have to find the hostname as a side-affect of generating a unique stub, we allow it's easy retrevial here
getId() - Method in class org.apache.camel.model.IdentifiedType
Gets the value of the id property.
getId() - Method in class org.apache.camel.model.language.ExpressionType
Gets the value of the id property.
getIn() - Method in interface org.apache.camel.Exchange
Returns the inbound request message
getIn() - Method in class org.apache.camel.impl.DefaultExchange
 
getIndex() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getIndex() - Method in class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
getInheritErrorHandlerFlag() - Method in class org.apache.camel.model.ProcessorType
 
getInheritErrorHandlerFlag() - Method in class org.apache.camel.model.RoutesType
 
getInitialContext(Hashtable) - Method in class org.apache.camel.util.jndi.CamelInitialContextFactory
 
getInitialDelay() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
getInitialRedeliveryDelay() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
getInitialRedeliveryDelay() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getInjector() - Method in interface org.apache.camel.CamelContext
Returns the injector used to instantiate objects by type
getInjector() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
getInjector() - Method in interface org.apache.camel.impl.converter.TypeConverterRegistry
 
getInjector() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getInjector() - Method in class org.apache.camel.util.ReportingTypeConverterRegistry
 
getInputFactory() - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
getInputs() - Method in class org.apache.camel.model.RouteType
 
getInputStream() - Method in class org.apache.camel.converter.jaxp.BytesSource
 
getInputStream() - Method in class org.apache.camel.converter.jaxp.StringSource
 
getInputTransformer() - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
getInstance() - Static method in class org.apache.camel.impl.NoRouteBuilder
 
getInterceptor() - Method in class org.apache.camel.model.InterceptorRef
Get the underlying DelegateProcessor implementation
getInterceptorLogic() - Method in class org.apache.camel.processor.Interceptor
 
getInterceptors() - Method in class org.apache.camel.model.RoutesType
 
getInterceptors() - Method in class org.apache.camel.model.RouteType
 
getIntercepts() - Method in class org.apache.camel.model.RoutesType
 
getInteruptedExceptionHandler() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
getInvocation() - Method in class org.apache.camel.component.bean.BeanExchange
 
getKeepAliveTime() - Method in class org.apache.camel.processor.ThreadProcessor
 
getKey() - Method in class org.apache.camel.util.TimeoutMapEntry
 
getKeys() - Method in class org.apache.camel.util.DefaultTimeoutMap
Returns a copy of the keys in the map
getKeys() - Method in interface org.apache.camel.util.TimeoutMap
Returns a copy of the keys in the map
getLabel() - Method in class org.apache.camel.model.BeanRef
 
getLabel() - Method in class org.apache.camel.model.CatchType
 
getLabel() - Method in class org.apache.camel.model.ChoiceType
 
getLabel() - Method in class org.apache.camel.model.ExpressionNode
 
getLabel() - Method in class org.apache.camel.model.FinallyType
 
getLabel() - Method in class org.apache.camel.model.FromType
 
getLabel() - Method in class org.apache.camel.model.InterceptorRef
 
getLabel(List<ExpressionType>) - Static method in class org.apache.camel.model.language.ExpressionType
 
getLabel() - Method in class org.apache.camel.model.language.ExpressionType
Returns some descriptive text to describe this node
getLabel() - Method in class org.apache.camel.model.LoadBalanceType
 
getLabel() - Method in class org.apache.camel.model.OtherwiseType
 
getLabel() - Method in class org.apache.camel.model.PolicyRef
 
getLabel() - Method in class org.apache.camel.model.ProcessorRef
 
getLabel() - Method in class org.apache.camel.model.ProcessorType
Returns a label to describe this node such as the expression if some kind of expression node
getLabel() - Method in class org.apache.camel.model.ResequencerType
 
getLabel() - Method in class org.apache.camel.model.ThreadType
 
getLabel() - Method in class org.apache.camel.model.ThrottlerType
 
getLabel() - Method in class org.apache.camel.model.ToType
 
getLabel(List<ExpressionType>) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getLabel(ExpressionType) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getLanguage() - Method in class org.apache.camel.builder.ExpressionClause
 
getLanguage() - Method in exception org.apache.camel.language.IllegalSyntaxException
 
getLanguage() - Method in class org.apache.camel.model.language.ELExpression
 
getLanguage() - Method in class org.apache.camel.model.language.ExpressionType
 
getLanguage() - Method in class org.apache.camel.model.language.GroovyExpression
 
getLanguage() - Method in class org.apache.camel.model.language.HeaderExpression
 
getLanguage() - Method in class org.apache.camel.model.language.JavaScriptExpression
 
getLanguage() - Method in class org.apache.camel.model.language.JXPathExpression
 
getLanguage() - Method in class org.apache.camel.model.language.LanguageExpression
 
getLanguage() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getLanguage() - Method in class org.apache.camel.model.language.OgnlExpression
 
getLanguage() - Method in class org.apache.camel.model.language.PhpExpression
 
getLanguage() - Method in class org.apache.camel.model.language.PythonExpression
 
getLanguage() - Method in class org.apache.camel.model.language.RubyExpression
 
getLanguage() - Method in class org.apache.camel.model.language.SimpleExpression
 
getLanguage() - Method in class org.apache.camel.model.language.SqlExpression
 
getLanguage() - Method in class org.apache.camel.model.language.XPathExpression
 
getLanguage() - Method in class org.apache.camel.model.language.XQueryExpression
 
getLanguage() - Method in exception org.apache.camel.NoSuchLanguageException
 
getLanguageResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getLevel() - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
getLevel() - Method in class org.apache.camel.processor.Logger
 
getLevel() - Method in class org.apache.camel.processor.LoggingErrorHandler
 
getLifecycleStrategy() - Method in interface org.apache.camel.CamelContext
Returns the lifecycle strategy used to handle lifecycle notification
getLifecycleStrategy() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getLoadBalancer() - Method in class org.apache.camel.component.list.ListEndpoint
 
getLoadBalancer(RouteContext, LoadBalancerType, String) - Static method in class org.apache.camel.model.loadbalancer.LoadBalancerType
 
getLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.LoadBalancerType
 
getLoadBalancerType() - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
getLoadBalancerType() - Method in class org.apache.camel.model.LoadBalanceType
 
getLockFileRenamer() - Method in class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
getLog() - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
getLog() - Method in class org.apache.camel.processor.Logger
 
getLog() - Method in class org.apache.camel.processor.LoggingErrorHandler
 
getLogger() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
getLogger() - Method in class org.apache.camel.processor.DeadLetterChannel
 
getLoggingLevel(Map) - Method in class org.apache.camel.component.log.LogComponent
 
getMandatoryDefaultEndpoint() - Method in class org.apache.camel.CamelTemplate
 
getMandatoryEndpoint(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
Returns the mandatory endpoint for the given URI or the NoSuchEndpointException is thrown
getMandatoryHeader(Exchange, String, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
 
getMandatoryInBody(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Returns the mandatory inbound message body of the correct type or throws an exception if it is not present
getMandatoryInBody(Exchange, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
Returns the mandatory inbound message body of the correct type or throws an exception if it is not present
getMandatoryOutBody(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Returns the mandatory outbound message body of the correct type or throws an exception if it is not present
getMandatoryOutBody(Exchange, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
Returns the mandatory outbound message body of the correct type or throws an exception if it is not present
getMandatoryProperty(Exchange, String, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
 
getMap() - Method in class org.apache.camel.processor.aggregate.AggregationCollection
 
getMaxCacheSize() - Method in class org.apache.camel.util.LRUCache
Returns the maxCacheSize.
getMaximumRedeliveries() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
getMaximumRedeliveries() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getMaximumRequestsPerPeriod() - Method in class org.apache.camel.model.ThrottlerType
 
getMaximumRequestsPerPeriod() - Method in class org.apache.camel.processor.Throttler
 
getMaxProcessingTime() - Method in class org.apache.camel.management.PerformanceCounter
 
getMaxSize() - Method in class org.apache.camel.processor.ThreadProcessor
 
getMbeanServer() - Method in class org.apache.camel.component.jmx.JMXComponent
 
getMbeanServer() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
getMBeanServer() - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
getMBeanServer() - Method in interface org.apache.camel.spi.InstrumentationAgent
Get the MBeanServer which hosts managed components NOTE: if the configuration is not set the JMXEnabled to be true, this method will return null
getMeanProcessingTime() - Method in class org.apache.camel.management.PerformanceCounter
 
getMessageId() - Method in class org.apache.camel.impl.MessageSupport
 
getMessageId() - Method in interface org.apache.camel.Message
Returns the id of the message
getMessageIdExpression() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getMessageIdRepository() - Method in class org.apache.camel.model.IdempotentConsumerType
 
getMessageIdRepository() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getMessageIdRepositoryRef() - Method in class org.apache.camel.model.IdempotentConsumerType
 
getMethod() - Method in class org.apache.camel.component.bean.BeanInvocation
 
getMethod() - Method in class org.apache.camel.component.bean.BeanProcessor
 
getMethod() - Method in class org.apache.camel.component.bean.MethodBean
 
getMethod() - Method in class org.apache.camel.component.bean.MethodInfo
 
getMethod() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getMethod() - Method in exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
getMethod() - Method in class org.apache.camel.model.BeanRef
 
getMethod() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getMethod() - Method in class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
getMethodObject() - Method in class org.apache.camel.component.bean.BeanProcessor
 
getMethods() - Method in exception org.apache.camel.component.bean.AmbiguousMethodCallException
The ambiguous methods for which a single method could not be chosen
getMinProcessingTime() - Method in class org.apache.camel.management.PerformanceCounter
 
getMoveNamePostfix() - Method in class org.apache.camel.component.file.FileEndpoint
 
getMoveNamePrefix() - Method in class org.apache.camel.component.file.FileEndpoint
 
getName() - Method in interface org.apache.camel.CamelContext
Gets the name of the this context.
getName() - Method in class org.apache.camel.component.bean.MethodBean
 
getName() - Method in exception org.apache.camel.component.bean.NoBeanAvailableException
 
getName() - Method in class org.apache.camel.component.bean.RegistryBean
 
getName() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
getName() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getName() - Method in exception org.apache.camel.NoSuchBeanException
 
getName() - Method in class org.apache.camel.processor.ThreadProcessor
 
getNameInNamespace() - Method in class org.apache.camel.util.jndi.JndiContext
 
getNameParser(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
getNameParser(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
getNamePostfix() - Method in class org.apache.camel.component.file.strategy.DefaultFileRenamer
 
getNamePrefix() - Method in class org.apache.camel.component.file.strategy.DefaultFileRenamer
 
getNamespaceContext() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getNamespaces() - Method in class org.apache.camel.builder.xml.Namespaces
 
getNamespaces() - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
getNamespaceURI(String) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
getNamingStrategy() - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
getNamingStrategy() - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
getNamingStrategy() - Method in interface org.apache.camel.spi.InstrumentationAgent
 
getNextProcessor() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getNodeData(Object) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getNodeFactory() - Method in class org.apache.camel.model.ProcessorType
 
getNotification() - Method in class org.apache.camel.component.jmx.JMXMessage
 
getNumber() - Method in class org.apache.camel.util.Time
 
getNumberFormat() - Method in class org.apache.camel.processor.ThroughputLogger
 
getNumberOfHashGroups() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getNumCompleted() - Method in class org.apache.camel.management.PerformanceCounter
 
getNumExchanges() - Method in class org.apache.camel.management.Counter
 
getNumFailed() - Method in class org.apache.camel.management.PerformanceCounter
 
getObjectName(CamelContext) - Method in class org.apache.camel.management.CamelNamingStrategy
Implements the naming strategy for a CamelContext.
getObjectName(ManagedEndpoint) - Method in class org.apache.camel.management.CamelNamingStrategy
Implements the naming strategy for a ManagedEndpoint.
getObjectName(CamelContext, ManagedService) - Method in class org.apache.camel.management.CamelNamingStrategy
Implements the naming strategy for a Service.
getObjectName(ManagedRoute) - Method in class org.apache.camel.management.CamelNamingStrategy
Implements the naming strategy for a ManagedRoute.
getObjectName(CamelContext, PerformanceCounter, RouteContext) - Method in class org.apache.camel.management.CamelNamingStrategy
Implements the naming strategy for a PerformanceCounter.
getOffset() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
getOperationText() - Method in class org.apache.camel.impl.BinaryPredicateSupport
 
getOrCreateComponent(String, Callable<Component>) - Method in interface org.apache.camel.CamelContext
Gets the a previously added component by name or lazily creates the component using the factory Callback.
getOrCreateComponent(String, Callable<Component>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getOrCreateRedeliveryPolicy() - Method in class org.apache.camel.model.ExceptionType
 
getOrFindTypeConverter(Class, Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
getOtherwise() - Method in class org.apache.camel.model.ChoiceType
 
getOtherwise() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getOut() - Method in interface org.apache.camel.Exchange
Returns the outbound message, lazily creating one if one has not already been associated with this exchange.
getOut(boolean) - Method in interface org.apache.camel.Exchange
Returns the outbound message; optionally lazily creating one if one has not been associated with this exchange
getOut() - Method in class org.apache.camel.impl.DefaultExchange
 
getOut(boolean) - Method in class org.apache.camel.impl.DefaultExchange
 
getOutBodyFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getOutHeaderFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getOutput() - Method in class org.apache.camel.processor.DeadLetterChannel
Returns the output processor
getOutput() - Method in class org.apache.camel.processor.LoggingErrorHandler
Returns the output processor
getOutputFactory() - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
getOutputs() - Method in class org.apache.camel.model.CatchType
 
getOutputs() - Method in class org.apache.camel.model.ChoiceType
 
getOutputs() - Method in class org.apache.camel.model.ConvertBodyType
 
getOutputs() - Method in class org.apache.camel.model.ExceptionType
 
getOutputs() - Method in class org.apache.camel.model.ExpressionNode
 
getOutputs() - Method in class org.apache.camel.model.OutputType
 
getOutputs() - Method in class org.apache.camel.model.ProcessorType
 
getOutputs() - Method in class org.apache.camel.model.ResequencerType
 
getOutputs() - Method in class org.apache.camel.model.RouteType
 
getOutputs() - Method in class org.apache.camel.model.RoutingSlipType
 
getOutputs() - Method in class org.apache.camel.model.ThreadType
 
getOutputs() - Method in class org.apache.camel.model.ThrottlerType
 
getOutputs() - Method in class org.apache.camel.model.ThrowFaultType
 
getOutputs() - Method in class org.apache.camel.model.ToType
 
getOutputsWithoutCatches() - Method in class org.apache.camel.model.TryType
 
getOutputTransformer() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getOutQueue() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the output queue.
getParameterMappingStrategy() - Method in class org.apache.camel.component.bean.BeanComponent
 
getParameterMappingStrategy() - Method in class org.apache.camel.component.bean.RegistryBean
 
getParameters() - Method in class org.apache.camel.builder.xml.XsltBuilder
 
getParameters() - Method in class org.apache.camel.component.bean.MethodInfo
 
getParameters() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getParametersExpression() - Method in class org.apache.camel.component.bean.MethodInfo
 
getParameterTypes() - Method in class org.apache.camel.component.bean.MethodBean
 
getParent() - Method in class org.apache.camel.model.ProcessorType
 
getPath() - Method in class org.apache.camel.util.FactoryFinder
 
getPath() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getPattern() - Method in interface org.apache.camel.Exchange
Returns the ExchangePattern (MEP) of this exchange.
getPattern() - Method in class org.apache.camel.impl.DefaultExchange
 
getPeriod() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
getPredicate() - Method in class org.apache.camel.model.CompletedPredicate
 
getPredicate() - Method in class org.apache.camel.model.language.ExpressionType
 
getPredicate() - Method in class org.apache.camel.processor.FilterProcessor
 
getPrefix(String) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
getPrefixes(String) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
getPreloadSize() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.XMLBeansDataFormat
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getPriority() - Method in class org.apache.camel.processor.ThreadProcessor
 
getProceed() - Method in class org.apache.camel.model.InterceptType
 
getProcessor() - Method in interface org.apache.camel.component.bean.BeanHolder
 
getProcessor() - Method in class org.apache.camel.component.bean.BeanProcessor
 
getProcessor() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
getProcessor() - Method in class org.apache.camel.component.bean.RegistryBean
 
getProcessor() - Method in class org.apache.camel.impl.DefaultConsumer
 
getProcessor() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
getProcessor() - Method in class org.apache.camel.impl.ProcessorEndpoint
 
getProcessor() - Method in class org.apache.camel.processor.BatchProcessor
 
getProcessor() - Method in class org.apache.camel.processor.DelegateAsyncProcessor
 
getProcessor() - Method in class org.apache.camel.processor.DelegateProcessor
 
getProcessors() - Method in class org.apache.camel.model.loadbalancer.LoadBalancerType
 
getProcessors() - Method in class org.apache.camel.processor.CompositeProcessor
 
getProcessors() - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Returns the current processors available to this load balancer
getProcessors() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
getProcessors() - Method in class org.apache.camel.processor.MulticastProcessor
Returns the producers to multicast to
getProduceDelay() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getProducer(Endpoint<E>) - Method in class org.apache.camel.CamelTemplate
 
getProducer(Endpoint<E>) - Method in class org.apache.camel.util.ProducerCache
 
getProperties() - Method in interface org.apache.camel.Exchange
Returns all of the properties associated with the exchange
getProperties() - Method in class org.apache.camel.impl.DefaultExchange
 
getProperties() - Method in class org.apache.camel.Route
This property map is used to associate information about the route.
getProperties(Object, Map, String) - Static method in class org.apache.camel.util.IntrospectionSupport
 
getProperty(String) - Method in interface org.apache.camel.Exchange
Returns a property associated with this exchange by name
getProperty(String, Class<T>) - Method in interface org.apache.camel.Exchange
Returns a property associated with this exchange by name and specifying the type required
getProperty(String) - Method in class org.apache.camel.impl.DefaultExchange
 
getProperty(String, Class<T>) - Method in class org.apache.camel.impl.DefaultExchange
 
getProperty(Object, String) - Static method in class org.apache.camel.util.IntrospectionSupport
 
getPropertyGetter(Class, String) - Static method in class org.apache.camel.util.IntrospectionSupport
 
getPropertyName() - Method in exception org.apache.camel.NoSuchPropertyException
 
getPropertyName(Method) - Static method in class org.apache.camel.util.ObjectHelper
Returns the Java Bean property name of the given method, if it is a setter
getPurgePollTime() - Method in class org.apache.camel.util.DefaultTimeoutMap
 
getQueue() - Method in class org.apache.camel.component.seda.SedaEndpoint
 
getRandomNumberGenerator() - Static method in class org.apache.camel.processor.RedeliveryPolicy
 
getReader() - Method in class org.apache.camel.converter.jaxp.BytesSource
 
getReader() - Method in class org.apache.camel.converter.jaxp.StringSource
 
getReceivedCounter() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getReceivedCounter() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getReceivedExchanges() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getRedeliveryPolicy() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
getRedeliveryPolicy() - Method in class org.apache.camel.model.ExceptionType
 
getRedeliveryPolicy() - Method in class org.apache.camel.processor.DeadLetterChannel
 
getRef() - Method in class org.apache.camel.model.BeanRef
 
getRef() - Method in class org.apache.camel.model.FromType
 
getRef() - Method in class org.apache.camel.model.InterceptorRef
 
getRef() - Method in class org.apache.camel.model.LoadBalanceType
 
getRef() - Method in class org.apache.camel.model.MarshalType
 
getRef() - Method in class org.apache.camel.model.PolicyRef
 
getRef() - Method in class org.apache.camel.model.ProcessorRef
 
getRef() - Method in class org.apache.camel.model.RouteBuilderRef
 
getRef() - Method in class org.apache.camel.model.ToType
 
getRef() - Method in class org.apache.camel.model.UnmarshalType
 
getRegexPattern() - Method in class org.apache.camel.component.file.FileConsumer
 
getRegistry() - Method in interface org.apache.camel.CamelContext
Returns the registry used to lookup components by name and type such as the Spring ApplicationContext, JNDI or the OSGi Service Registry
getRegistry() - Method in class org.apache.camel.component.bean.RegistryBean
 
getRegistry() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getRenamer() - Method in class org.apache.camel.component.file.strategy.RenameFileProcessStrategy
 
getReportCount() - Method in interface org.apache.camel.component.dataset.DataSet
Returns the number of messages which should be received before reporting on the progress of the test
getReportCount() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getReporter() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getRequestCount() - Method in class org.apache.camel.processor.Throttler
The number of requests which have taken place so far within this time period
getResolvedEndpoint(String, Class<T>) - Method in class org.apache.camel.CamelTemplate
 
getResult() - Method in class org.apache.camel.builder.xml.DomResultHandler
 
getResult() - Method in interface org.apache.camel.builder.xml.ResultHandler
 
getResult() - Method in class org.apache.camel.builder.xml.StreamResultHandler
 
getResult() - Method in class org.apache.camel.builder.xml.StringResultHandler
 
getResultHandlerFactory() - Method in class org.apache.camel.builder.xml.XsltBuilder
 
getResultQName() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getResultType() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getResultType() - Method in class org.apache.camel.builder.xml.XPathLanguage
 
getResultType() - Method in class org.apache.camel.model.language.XPathExpression
 
getResultType() - Method in class org.apache.camel.model.language.XQueryExpression
 
getResultWaitTime() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getRoute() - Method in class org.apache.camel.impl.RouteContext
 
getRoute() - Method in class org.apache.camel.management.ManagedRoute
 
getRouteCollection() - Method in class org.apache.camel.builder.RouteBuilder
 
getRouteDefinitions() - Method in interface org.apache.camel.CamelContext
Returns a list of the current route definitions
getRouteDefinitions() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getRouteList() - Method in class org.apache.camel.builder.RouteBuilder
Returns the routing map from inbound endpoints to processors
getRoutes() - Method in interface org.apache.camel.CamelContext
Returns the current routes in this context
getRoutes() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getRoutes() - Method in interface org.apache.camel.model.RouteContainer
Returns the routes
getRoutes() - Method in class org.apache.camel.model.RoutesType
 
getSchema() - Method in exception org.apache.camel.processor.validation.SchemaValidationException
Returns the schema that failed
getSchema() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
getSchemaFactory() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
getSchemaFile() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
getSchemaLanguage() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
getSchemaSource() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
getSchemaUrl() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
getScheme() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getSeparator() - Method in class org.apache.camel.util.CollectionStringBuffer
 
getService() - Method in class org.apache.camel.management.ManagedService
 
getServices() - Method in class org.apache.camel.Route
Returns the additional services required for this particular route
getServicesForRoute() - Method in class org.apache.camel.Route
 
getSingletonEndpoints() - Method in interface org.apache.camel.CamelContext
Returns the collection of all registered singleton endpoints.
getSingletonEndpoints() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getSingletonEndpoints(CamelContext, Class<T>) - Static method in class org.apache.camel.util.CamelContextHelper
Returns a list of all endpoints of the given type
getSize() - Method in interface org.apache.camel.component.dataset.DataSet
Returns the size of the dataset
getSize() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getSleepForEmptyTest() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getSource(Exchange) - Method in class org.apache.camel.builder.xml.XsltBuilder
Converts the inbound body to a Source
getStackSize() - Method in class org.apache.camel.processor.ThreadProcessor
 
getStartTimeMillis() - Method in class org.apache.camel.processor.Throttler
The start time when this current period began
getStaticPart() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getStickyKey(Object) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
A strategy to create the key for the sticky load balancing map.
getStrategyRef() - Method in class org.apache.camel.model.AggregatorType
 
getStreamConfig() - Method in class org.apache.camel.model.ResequencerType
 
getSystemProperty(String, String) - Static method in class org.apache.camel.util.ObjectHelper
A helper method to access a system property, catching any security exceptions
getTaskQueue() - Method in class org.apache.camel.processor.ThreadProcessor
 
getText() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getText() - Method in class org.apache.camel.converter.jaxp.StringSource
 
getThis() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getThreadGroup() - Method in class org.apache.camel.processor.ThreadProcessor
 
getThreadName(String) - Method in class org.apache.camel.impl.ServiceSupport
Creates a new thread name with the given prefix
getThreadPoolExecutor() - Method in class org.apache.camel.model.MulticastType
 
getThreadPoolExecutor() - Method in class org.apache.camel.model.SplitterType
 
getThreshold() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
getTime() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
getTimeout() - Method in exception org.apache.camel.ExchangeTimedOutException
Return the timeout which expired in milliseconds
getTimeout() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getTimeout() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns this resequencer's timeout value.
getTimeout() - Method in class org.apache.camel.processor.StreamResequencer
 
getTimeout() - Method in class org.apache.camel.util.TimeoutMapEntry
 
getTimeoutHandlers() - Method in class org.apache.camel.processor.resequencer.Timeout
Returns the list of timeout handlers that have been registered for notification.
getTimePeriodMillis() - Method in class org.apache.camel.model.ThrottlerType
 
getTimePeriodMillis() - Method in class org.apache.camel.processor.Throttler
 
getTimer(TimerEndpoint) - Method in class org.apache.camel.component.timer.TimerComponent
 
getTimer() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
getTimerName() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
getTimeUnit() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
getTimeUnit() - Method in class org.apache.camel.util.Time
 
getToType() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
getToType() - Method in class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
getTransformer() - Method in class org.apache.camel.builder.xml.XsltBuilder
 
getTransformerFactory() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
getType() - Method in class org.apache.camel.component.bean.BeanInfo
 
getType() - Method in class org.apache.camel.component.bean.MethodBean
 
getType() - Method in class org.apache.camel.component.bean.MethodInfo
 
getType() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getType() - Method in exception org.apache.camel.InvalidPayloadException
The expected type of the body
getType() - Method in exception org.apache.camel.InvalidPayloadRuntimeException
The expected type of the body
getType() - Method in exception org.apache.camel.InvalidTypeException
The expected type of the value
getType() - Method in class org.apache.camel.model.ConvertBodyType
 
getType() - Method in class org.apache.camel.model.language.XQueryExpression
 
getType() - Method in exception org.apache.camel.NoSuchHeaderException
 
getType() - Method in exception org.apache.camel.NoSuchPropertyException
 
getType() - Method in exception org.apache.camel.NoTypeConversionAvailableException
Returns the required to type
getTypeClass() - Method in class org.apache.camel.model.ConvertBodyType
 
getTypeConversions() - Method in class org.apache.camel.util.ReportingTypeConverterLoader
 
getTypeConverter() - Method in interface org.apache.camel.CamelContext
Returns the type converter used to coerce types from one type to another
getTypeConverter(Class, Class) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
getTypeConverter() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getUnchangedDelay() - Method in class org.apache.camel.component.file.FileConsumer
 
getUnitOfWork() - Method in interface org.apache.camel.Exchange
Returns the unit of work that this exchange belongs to; which may map to zero, one or more physical transactions
getUnitOfWork() - Method in class org.apache.camel.impl.DefaultExchange
 
getUri() - Method in class org.apache.camel.management.ManagedEndpoint
 
getUri() - Method in class org.apache.camel.model.FromType
 
getUri() - Method in class org.apache.camel.model.ToType
 
getUri() - Method in exception org.apache.camel.NoSuchEndpointException
 
getUri() - Method in exception org.apache.camel.ResolveEndpointFailedException
 
getUri() - Method in exception org.apache.camel.util.NoFactoryAvailableException
 
getUriDelimiter() - Method in class org.apache.camel.model.RoutingSlipType
 
getUriOrRef() - Method in class org.apache.camel.model.FromType
Returns the endpoint URI or the name of the reference to it
getUriOrRef() - Method in class org.apache.camel.model.ToType
Returns the endpoint URI or the name of the reference to it
getUris() - Method in class org.apache.camel.model.ServiceActivationType
 
getUseCollisionAvoidance() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
getUseExponentialBackOff() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
getValue() - Method in exception org.apache.camel.InvalidTypeException
The value
getValue() - Method in class org.apache.camel.model.SetHeaderType
 
getValue() - Method in exception org.apache.camel.NoTypeConversionAvailableException
Returns the value which could not be converted
getValue() - Method in class org.apache.camel.util.TimeoutMapEntry
 
getWarnings() - Method in exception org.apache.camel.processor.validation.SchemaValidationException
Returns the validation warnings
getWhenClauses() - Method in class org.apache.camel.model.ChoiceType
 
getWsdlUri() - Method in enum org.apache.camel.ExchangePattern
Returns the WSDL URI for this message exchange pattern
getXpath() - Method in exception org.apache.camel.builder.xml.InvalidXPathExpression
 
getXPathFactory() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
GraphGeneratorSupport - Class in org.apache.camel.view
 
GraphGeneratorSupport(String, String) - Constructor for class org.apache.camel.view.GraphGeneratorSupport
 
groovy(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Groovy expression
GroovyExpression - Class in org.apache.camel.model.language
For Groovy expresions and predicates
GroovyExpression() - Constructor for class org.apache.camel.model.language.GroovyExpression
 
GroovyExpression(String) - Constructor for class org.apache.camel.model.language.GroovyExpression
 
group(String) - Method in class org.apache.camel.model.RouteType
Set the group name for this route
GROUP_ENDPOINTS - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
GROUP_PROPERTY - Static variable in class org.apache.camel.Route
 
GROUP_ROUTE_TYPE - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
GROUP_ROUTES - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
GROUP_SERVICES - Static variable in class org.apache.camel.management.CamelNamingStrategy
 

H

handle(Class<?>) - Method in class org.apache.camel.model.TryType
 
handleAll() - Method in class org.apache.camel.model.TryType
Deprecated. Use TryType.finallyBlock() instead, as the name is better. Current name sugests that it handles exception, while it mimics java finally keyword.
handleErrors(Exchange, Schema, DOMResult) - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
handleErrors(Exchange, Object) - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
handleErrors(Exchange, Schema, DOMResult) - Method in interface org.apache.camel.processor.validation.ValidatorErrorHandler
Process any errors which may have occurred during validation
handleException(Throwable) - Method in class org.apache.camel.impl.DefaultConsumer
Handles the given exception using the DefaultConsumer.getExceptionHandler()
handleException(Throwable) - Method in class org.apache.camel.impl.LoggingExceptionHandler
 
handleException(Throwable) - Method in class org.apache.camel.impl.PollingConsumerSupport
Handles the given exception using the PollingConsumerSupport.getExceptionHandler()
handleException(Exchange, Throwable) - Method in class org.apache.camel.processor.TryProcessor
 
handleException(Throwable) - Method in interface org.apache.camel.spi.ExceptionHandler
Handles the given exception
handleFault() - Method in class org.apache.camel.model.ProcessorType
Forces handling of faults as exceptions
HandleFaultProcessor - Class in org.apache.camel.processor
 
HandleFaultProcessor() - Constructor for class org.apache.camel.processor.HandleFaultProcessor
 
HandleFaultType - Class in org.apache.camel.model
 
HandleFaultType() - Constructor for class org.apache.camel.model.HandleFaultType
 
handleInteruptedException(InterruptedException) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
handleNotification(Notification, Object) - Method in class org.apache.camel.component.jmx.JMXConsumer
 
handleSleepInteruptedException(InterruptedException) - Method in class org.apache.camel.processor.DelayProcessorSupport
Called when a sleep is interupted; allows derived classes to handle this case differently
HasAnnotation - Annotation Type in org.apache.camel.converter
Used to indicate that the actual type of a parameter on a converter method must have the given annotation class to be applicable.
hasAnnotation(Annotation[], Class<?>) - Static method in class org.apache.camel.util.ObjectHelper
Returns true if the given collection of annotations matches the given type
hasAttachments() - Method in class org.apache.camel.impl.DefaultMessage
 
hasAttachments() - Method in interface org.apache.camel.Message
Returns true if this message has any attachments.
hasBodyParameter() - Method in class org.apache.camel.component.bean.MethodInfo
 
hashCode() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
hashCode() - Method in class org.apache.camel.impl.DefaultEndpoint
 
hashCode() - Method in class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
hasPopulatedHeaders() - Method in class org.apache.camel.impl.DefaultMessage
Returns true if the headers have been mutated in some way
header(String) - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for headers on an exchange
header(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a value builder for the given header
header(String) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message header of the given name
header(String) - Method in class org.apache.camel.component.mock.AssertionClause
Returns a predicate and value builder for headers on an exchange
Header - Annotation Type in org.apache.camel
Marks a parameter as being a header on an inbound Message
HEADER_FILE_NAME - Static variable in class org.apache.camel.component.file.FileComponent
 
headerExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the header value with the given name
HeaderExpression - Class in org.apache.camel.model.language
An expression which extracts the named header
HeaderExpression() - Constructor for class org.apache.camel.model.language.HeaderExpression
 
HeaderExpression(String) - Constructor for class org.apache.camel.model.language.HeaderExpression
 
headers() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the inbound headers
Headers - Annotation Type in org.apache.camel
Marks a parameter as being an injection point of the headers of an inbound Message
headersExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the inbound message headers
higher(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the next higher element in the sequence to the given element.
host - Variable in class org.apache.camel.util.URISupport.CompositeData
 
hostName - Variable in class org.apache.camel.management.CamelNamingStrategy
 
hours(long) - Static method in class org.apache.camel.util.Time
 
hoursAsSeconds(long) - Static method in class org.apache.camel.util.Time
 

I

id - Variable in class org.apache.camel.view.NodeData
 
idempotentConsumer(Expression, MessageIdRepository) - Method in class org.apache.camel.model.ProcessorType
Creates an IdempotentConsumer to avoid duplicate messages
idempotentConsumer(MessageIdRepository) - Method in class org.apache.camel.model.ProcessorType
Creates an IdempotentConsumer to avoid duplicate messages
IdempotentConsumer - Class in org.apache.camel.processor.idempotent
An implementation of the Idempotent Consumer pattern.
IdempotentConsumer(Expression<Exchange>, MessageIdRepository, Processor) - Constructor for class org.apache.camel.processor.idempotent.IdempotentConsumer
 
IdempotentConsumerType - Class in org.apache.camel.model
 
IdempotentConsumerType() - Constructor for class org.apache.camel.model.IdempotentConsumerType
 
IdempotentConsumerType(Expression, MessageIdRepository) - Constructor for class org.apache.camel.model.IdempotentConsumerType
 
IdentifiedType - Class in org.apache.camel.model
The unique identifier for a bean.
IdentifiedType() - Constructor for class org.apache.camel.model.IdentifiedType
 
ifStartsWithReturnRemainder(String, String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
IllegalSyntaxException - Exception in org.apache.camel.language
An exception thrown if some illegal syntax is rejected by a specific language
IllegalSyntaxException(Language, String) - Constructor for exception org.apache.camel.language.IllegalSyntaxException
 
image - Variable in class org.apache.camel.view.NodeData
 
IN_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
increment() - Method in class org.apache.camel.management.Counter
 
incrementRedeliveryCounter(Exchange, Throwable) - Method in class org.apache.camel.processor.DeadLetterChannel
Increments the redelivery counter and adds the redelivered flag if the message has been redelivered
INDEX_HEADER - Static variable in interface org.apache.camel.component.dataset.DataSet
 
indexOfParenthesisMatch(String) - Method in class org.apache.camel.util.URISupport
Deprecated. this method will be removed in a future release
inheritErrorHandler(boolean) - Method in class org.apache.camel.builder.RouteBuilder
Configures whether or not the error handler is inherited by every processing node (or just the top most one)
inheritErrorHandler(boolean) - Method in class org.apache.camel.model.ProcessorType
Configures whether or not the error handler is inherited by every processing node (or just the top most one)
initialRedeliveryDelay(long) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
initialRedeliveryDelay(long) - Method in class org.apache.camel.model.ExceptionType
 
initialRedeliveryDelay(long) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
initialRedeliveryDelay - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
initialRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the initial redelivery delay in milliseconds on the first redelivery
Injector - Interface in org.apache.camel.spi
A pluggable strategy for creating and possibly dependency injecting objects which could be implemented using straight forward reflection or using Spring or Guice to perform dependency injection.
INJETOR - Static variable in class org.apache.camel.util.jndi.JndiContext
 
inMessage() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message
inMessageExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the IN message
insertSpacesBetweenCamelCase(String) - Static method in class org.apache.camel.view.NodeData
Lets insert a space before each upper case letter after a lowercase
InstanceMethodTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter implementation which instantiates an object so that an instance method can be used as a type converter
InstanceMethodTypeConverter(CachingInjector, Method) - Constructor for class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
InstrumentationAgent - Interface in org.apache.camel.spi
 
InstrumentationAgentImpl - Class in org.apache.camel.management
 
InstrumentationAgentImpl() - Constructor for class org.apache.camel.management.InstrumentationAgentImpl
 
InstrumentationLifecycleStrategy - Class in org.apache.camel.management
 
InstrumentationLifecycleStrategy(InstrumentationAgent) - Constructor for class org.apache.camel.management.InstrumentationLifecycleStrategy
 
InstrumentationProcessor - Class in org.apache.camel.management
 
intercept(DelegateProcessor) - Method in class org.apache.camel.builder.RouteBuilder
Adds the given interceptor to this route
intercept() - Method in class org.apache.camel.builder.RouteBuilder
Adds a route for an interceptor; use the ProcessorType.proceed() method to continue processing the underlying route being intercepted.
intercept(Predicate) - Method in class org.apache.camel.builder.RouteBuilder
Applies a route for an interceptor if the given predicate is true otherwise the interceptor route is not applied
intercept(Interceptor) - Method in class org.apache.camel.impl.RouteContext
 
intercept(DelegateProcessor) - Method in class org.apache.camel.model.ProcessorType
 
intercept() - Method in class org.apache.camel.model.ProcessorType
 
intercept(Predicate) - Method in class org.apache.camel.model.ProcessorType
Apply an interceptor route if the predicate is true
intercept(DelegateProcessor) - Method in class org.apache.camel.model.RoutesType
 
intercept() - Method in class org.apache.camel.model.RoutesType
 
intercept(Predicate) - Method in class org.apache.camel.model.RoutesType
 
interceptor(String) - Method in class org.apache.camel.model.ProcessorType
 
Interceptor - Class in org.apache.camel.processor
An interceptor which provides the processing logic as a pluggable processor which allows the DelegateProcessor.proceed(Exchange) method to be called at some point
Interceptor() - Constructor for class org.apache.camel.processor.Interceptor
 
Interceptor(Processor) - Constructor for class org.apache.camel.processor.Interceptor
 
InterceptorRef - Class in org.apache.camel.model
 
InterceptorRef() - Constructor for class org.apache.camel.model.InterceptorRef
 
InterceptorRef(String) - Constructor for class org.apache.camel.model.InterceptorRef
 
InterceptorRef(DelegateProcessor) - Constructor for class org.apache.camel.model.InterceptorRef
 
interceptors(String...) - Method in class org.apache.camel.model.ProcessorType
 
InterceptorType - Class in org.apache.camel.model
 
InterceptorType() - Constructor for class org.apache.camel.model.InterceptorType
 
InterceptType - Class in org.apache.camel.model
 
InterceptType() - Constructor for class org.apache.camel.model.InterceptType
 
internalBind(String, Object) - Method in class org.apache.camel.util.jndi.JndiContext
internalBind is intended for use only during setup or possibly by suitably synchronized superclasses.
introspect(Class) - Method in class org.apache.camel.component.bean.BeanInfo
 
introspect(Class, Method) - Method in class org.apache.camel.component.bean.BeanInfo
 
IntrospectionSupport - Class in org.apache.camel.util
 
InvalidHeaderTypeException - Exception in org.apache.camel
 
InvalidHeaderTypeException(Throwable, Object) - Constructor for exception org.apache.camel.InvalidHeaderTypeException
 
InvalidHeaderTypeException(String, Object) - Constructor for exception org.apache.camel.InvalidHeaderTypeException
 
InvalidPayloadException - Exception in org.apache.camel
 
InvalidPayloadException(Exchange, Class<?>) - Constructor for exception org.apache.camel.InvalidPayloadException
 
InvalidPayloadException(Exchange, Class<?>, Message) - Constructor for exception org.apache.camel.InvalidPayloadException
 
InvalidPayloadRuntimeException - Exception in org.apache.camel
 
InvalidPayloadRuntimeException(Exchange, Class<?>) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
 
InvalidTypeException - Exception in org.apache.camel
 
InvalidTypeException(Exchange, Object, Class<?>) - Constructor for exception org.apache.camel.InvalidTypeException
 
InvalidXPathExpression - Exception in org.apache.camel.builder.xml
An exception thrown if am XPath expression could not be parsed or evaluated
InvalidXPathExpression(String, XPathException) - Constructor for exception org.apache.camel.builder.xml.InvalidXPathExpression
 
invoke(Object, Exchange) - Method in class org.apache.camel.component.bean.BeanInvocation
This causes us to invoke the endpoint Pojo using reflection.
invoke(Object, Method, Object[]) - Method in class org.apache.camel.component.bean.CamelInvocationHandler
 
invoke(Method, Object, Object[], Exchange) - Method in class org.apache.camel.component.bean.MethodInfo
 
invokeMethod(Method, Object, Object...) - Static method in class org.apache.camel.util.ObjectHelper
A helper method to invoke a method via reflection and wrap any exceptions as RuntimeCamelException instances
IOConverter - Class in org.apache.camel.converter
Some core java.io based Type Converters
IOHelper - Class in org.apache.camel.util
 
isAllowMultipleConsumers() - Method in class org.apache.camel.component.direct.DirectEndpoint
 
isAppend() - Method in class org.apache.camel.component.file.FileEndpoint
 
isAssignableFrom(Class, Class) - Static method in class org.apache.camel.util.ObjectHelper
Returns true if a class is assignable from another class like the Class.isAssignableFrom(Class) method but which also includes coercion between primitive types to deal with Java 5 primitive type wrapping
isAutoCreate() - Method in class org.apache.camel.component.file.FileEndpoint
 
isAutoCreateComponents() - Method in class org.apache.camel.impl.DefaultCamelContext
 
isBatchCompleted(int) - Method in class org.apache.camel.processor.Aggregator
 
isBatchCompleted(int) - Method in class org.apache.camel.processor.BatchProcessor
A strategy method to decide if the batch is completed the resulting exchanges should be sent
isChanged(File) - Method in class org.apache.camel.component.file.FileConsumer
 
isCollection(Object) - Static method in class org.apache.camel.converter.ObjectConverter
 
isDaemon() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
isDaemon() - Method in class org.apache.camel.processor.ThreadProcessor
 
isDelete() - Method in class org.apache.camel.component.file.FileEndpoint
 
isEqualTo(Expression<E>, Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isEqualToAny(Object, Object...) - Static method in class org.apache.camel.util.ObjectHelper
Returns true if the given object is equal to any of the expected value
isFailed() - Method in interface org.apache.camel.Exchange
Returns true if this exchange failed due to either an exception or fault
isFailed() - Method in class org.apache.camel.impl.DefaultExchange
Returns true if this exchange failed due to either an exception or fault
isFailOnNullBody() - Method in class org.apache.camel.builder.xml.XsltBuilder
 
isFailureHandled(Exchange) - Static method in class org.apache.camel.processor.DeadLetterChannel
 
isFastStop() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
isFaultCapable() - Method in enum org.apache.camel.ExchangePattern
Return true if there can be a FAULT message
isFixedRate() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
isGenerateEmptyExchangeWhenIdle() - Method in class org.apache.camel.component.file.FileConsumer
 
isGreaterThan(Expression<E>, Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isGreaterThan(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isGreaterThanOrEqualTo(Expression<E>, Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isGreaterThanOrEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isHasCustomAnnotation() - Method in class org.apache.camel.component.bean.MethodInfo
 
isIgnoreFileNameHeader() - Method in class org.apache.camel.component.file.FileEndpoint
 
isInCapable() - Method in enum org.apache.camel.ExchangePattern
Return true if there can be an IN message
isInCapable(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Returns true if the given exchange pattern (if defined) can support IN messagea
isInheritErrorHandler() - Method in class org.apache.camel.builder.BuilderSupport
 
isInheritErrorHandler() - Method in class org.apache.camel.model.ProcessorType
 
isInheritErrorHandler() - Method in class org.apache.camel.model.RoutesType
 
isInstanceOf(Expression<E>, Class) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isInstanceOf(Class) - Method in class org.apache.camel.builder.ValueBuilder
 
isJavaIdentifier(String) - Static method in class org.apache.camel.util.ObjectHelper
Returns true if the given name is a valid java identifier
isLessThan(Expression<E>, Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isLessThan(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isLessThanOrEqualTo(Expression<E>, Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isLessThanOrEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isLock() - Method in class org.apache.camel.component.file.FileEndpoint
 
isLockFile() - Method in class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
isMatched(File) - Method in class org.apache.camel.component.file.FileConsumer
 
isMatchingNamespaceOrEmptyNamespace(String, String) - Static method in class org.apache.camel.builder.xml.Namespaces
Returns true if the given namespaceURI is empty or if it matches the given expected namespace
isMulticastNode(ProcessorType) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
isNoop() - Method in class org.apache.camel.component.file.FileEndpoint
 
isNotEqualTo(Expression<E>, Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNotEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isNotNull(Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNotNull() - Method in class org.apache.camel.builder.ValueBuilder
 
isNotNullAndNonEmpty(String) - Static method in class org.apache.camel.util.ObjectHelper
 
isNull(Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNull() - Method in class org.apache.camel.builder.ValueBuilder
 
isNullOrBlank(String) - Static method in class org.apache.camel.util.ObjectHelper
 
isOutCapable() - Method in enum org.apache.camel.ExchangePattern
Return true if there can be an OUT message
isOutCapable(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Returns true if the given exchange pattern (if defined) can support OUT messagea
isParallelProcessing() - Method in class org.apache.camel.model.MulticastType
 
isParallelProcessing() - Method in class org.apache.camel.model.SplitterType
 
isPossibleBodyParameter(Annotation[]) - Method in class org.apache.camel.component.bean.BeanInfo
 
isProcessedSync(Exchange) - Static method in class org.apache.camel.util.ProducerCache
 
isRecursive() - Method in class org.apache.camel.component.file.FileConsumer
 
isRunAllowed() - Method in class org.apache.camel.impl.ServiceSupport
Helper methods so the service knows if it should keep running.
isSingleton() - Method in class org.apache.camel.component.direct.DirectEndpoint
 
isSingleton() - Method in class org.apache.camel.component.file.FileEndpoint
 
isSingleton() - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
isSingleton() - Method in class org.apache.camel.component.list.ListEndpoint
 
isSingleton() - Method in class org.apache.camel.component.mock.MockEndpoint
 
isSingleton() - Method in class org.apache.camel.component.seda.SedaEndpoint
 
isSingleton() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
isSingleton() - Method in interface org.apache.camel.Endpoint
Returns if the endpoint should be a CamelContext singleton.
isSingleton() - Method in class org.apache.camel.impl.ProcessorEndpoint
 
isStarted() - Method in class org.apache.camel.impl.ServiceSupport
 
isStarted() - Method in class org.apache.camel.management.ManagedService
 
isStarting() - Method in class org.apache.camel.impl.ServiceSupport
 
isStopped() - Method in class org.apache.camel.impl.ServiceSupport
 
isStopping() - Method in class org.apache.camel.impl.ServiceSupport
 
isSynchronous() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
isUnchangedSize() - Method in class org.apache.camel.component.file.FileConsumer
 
isUseCollisionAvoidance() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isUseEndpointCache() - Method in class org.apache.camel.CamelTemplate
 
isUseExponentialBackOff() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isUseFixedDelay() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
isValid() - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
isValidFile(File) - Method in class org.apache.camel.component.file.FileConsumer
 
isValidForEviction(TimeoutMapEntry) - Method in class org.apache.camel.util.DefaultTimeoutMap
A hook to allow derivations to avoid evicting the current entry
isValidMethod(Class, Method) - Method in class org.apache.camel.component.bean.BeanInfo
 
isValidVersion(String, double) - Static method in class org.apache.camel.util.PackageHelper
Returns true if the version number of the given package name can be found and is greater than or equal to the minimum version.
iterator(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Creates an iterator over the value if the value is a collection, an Object[] or a primitive type array; otherwise to simplify the caller's code, we just create a singleton collection iterator over a single value
iterator() - Method in class org.apache.camel.processor.aggregate.AggregationCollection
 
iterator() - Method in class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 

J

javaScript(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a JavaScript expression
JavaScriptExpression - Class in org.apache.camel.model.language
For JavaScript expresions and predicates
JavaScriptExpression() - Constructor for class org.apache.camel.model.language.JavaScriptExpression
 
JavaScriptExpression(String) - Constructor for class org.apache.camel.model.language.JavaScriptExpression
 
jaxb() - Method in class org.apache.camel.builder.DataFormatClause
Uses the JAXB data format
jaxb(boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JAXB data format turning pretty printing on or off
JaxbDataFormat - Class in org.apache.camel.model.dataformat
Represents the JAXB2 XML DataFormat
JaxbDataFormat() - Constructor for class org.apache.camel.model.dataformat.JaxbDataFormat
 
JaxbDataFormat(boolean) - Constructor for class org.apache.camel.model.dataformat.JaxbDataFormat
 
JMXComponent - Class in org.apache.camel.component.jmx
The JMX Component for monitoring jmx attributes
JMXComponent() - Constructor for class org.apache.camel.component.jmx.JMXComponent
 
JMXComponent(CamelContext) - Constructor for class org.apache.camel.component.jmx.JMXComponent
 
JMXConsumer - Class in org.apache.camel.component.jmx
Generate an Exchange after getting a JMX Notification
JMXConsumer(JMXEndpoint, Processor) - Constructor for class org.apache.camel.component.jmx.JMXConsumer
 
JMXEndpoint - Class in org.apache.camel.component.jmx
Creates a CounterMonitor for jmx attributes
JMXEndpoint(String, JMXComponent) - Constructor for class org.apache.camel.component.jmx.JMXEndpoint
 
JMXEndpoint(String) - Constructor for class org.apache.camel.component.jmx.JMXEndpoint
 
JMXExchange - Class in org.apache.camel.component.jmx
A Exchange for a jmx notification
JMXExchange(CamelContext, ExchangePattern, Notification) - Constructor for class org.apache.camel.component.jmx.JMXExchange
Constructor
JMXMessage - Class in org.apache.camel.component.jmx
A Message for a JMX Notification
JMXMessage() - Constructor for class org.apache.camel.component.jmx.JMXMessage
 
JMXMessage(Notification) - Constructor for class org.apache.camel.component.jmx.JMXMessage
 
JndiContext - Class in org.apache.camel.util.jndi
A default JNDI context
JndiContext() - Constructor for class org.apache.camel.util.jndi.JndiContext
 
JndiContext(Hashtable) - Constructor for class org.apache.camel.util.jndi.JndiContext
 
JndiContext(Hashtable, Map) - Constructor for class org.apache.camel.util.jndi.JndiContext
 
JndiContext(Hashtable, Map, String) - Constructor for class org.apache.camel.util.jndi.JndiContext
 
JndiContext(JndiContext, Hashtable) - Constructor for class org.apache.camel.util.jndi.JndiContext
 
JndiContext(JndiContext, Hashtable, String) - Constructor for class org.apache.camel.util.jndi.JndiContext
 
JndiRegistry - Class in org.apache.camel.impl
A Registry implementation which looks up the objects in JNDI
JndiRegistry() - Constructor for class org.apache.camel.impl.JndiRegistry
 
JndiRegistry(Context) - Constructor for class org.apache.camel.impl.JndiRegistry
 
jxpath(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a JXPath expression
JXPathExpression - Class in org.apache.camel.model.language
For JXPath expresions and predicates
JXPathExpression() - Constructor for class org.apache.camel.model.language.JXPathExpression
 
JXPathExpression(String) - Constructor for class org.apache.camel.model.language.JXPathExpression
 

K

keepAliveTime(long) - Method in class org.apache.camel.model.ThreadType
 
KEY_BUILDER - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
KEY_COMPONENT - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
KEY_CONTEXT - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
KEY_GROUP - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
KEY_NAME - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
KEY_ROUTE - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
KEY_ROUTE_TYPE - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
KEY_TYPE - Static variable in class org.apache.camel.management.CamelNamingStrategy
 

L

label - Variable in class org.apache.camel.view.NodeData
 
language(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a given language name with the expression text
Language - Interface in org.apache.camel.spi
Represents a language to be used for Expression or Predicate instances
LANGUAGE_FACTORY - Static variable in class org.apache.camel.impl.DefaultLanguageResolver
 
LANGUAGE_RESOLVER - Static variable in class org.apache.camel.impl.DefaultLanguageResolver
 
LanguageAnnotation - Annotation Type in org.apache.camel.language
 
LanguageExpression - Annotation Type in org.apache.camel.language
 
LanguageExpression - Class in org.apache.camel.model.language
Represents a parameterised language expression which can support any language at runtime using the language attribute.
LanguageExpression() - Constructor for class org.apache.camel.model.language.LanguageExpression
 
LanguageExpression(String, String) - Constructor for class org.apache.camel.model.language.LanguageExpression
 
LanguageResolver - Interface in org.apache.camel.spi
A pluggable strategy for resolving different languages in a loosely coupled manner
LifecycleStrategy - Interface in org.apache.camel.spi
 
list(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
list(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
listBindings(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
listBindings(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
ListComponent - Class in org.apache.camel.component.list
 
ListComponent() - Constructor for class org.apache.camel.component.list.ListComponent
 
ListEndpoint - Class in org.apache.camel.component.list
An endpoint which maintains a List of Exchange instances which can be useful for tooling, debugging and visualising routes.
ListEndpoint(String, CamelContext) - Constructor for class org.apache.camel.component.list.ListEndpoint
 
ListEndpoint(String, Component) - Constructor for class org.apache.camel.component.list.ListEndpoint
 
ListEndpoint(String) - Constructor for class org.apache.camel.component.list.ListEndpoint
 
ListPollingConsumer - Class in org.apache.camel.component.seda
 
ListPollingConsumer(Endpoint, List<Exchange>) - Constructor for class org.apache.camel.component.seda.ListPollingConsumer
 
load(TypeConverterRegistry) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
load(TypeConverterRegistry) - Method in interface org.apache.camel.impl.converter.TypeConverterLoader
A pluggable strategy to load type converters into a registry from some kind of mechanism
loadBalance() - Method in class org.apache.camel.model.ProcessorType
 
LoadBalancer - Interface in org.apache.camel.processor.loadbalancer
A strategy for load balancing across a number of Processor instances
LoadBalancerConsumer - Class in org.apache.camel.processor.loadbalancer
Represents a consumer which on starting registers itself with a LoadBalancer and on closing unregisters itself with a load balancer
LoadBalancerConsumer(Endpoint, Processor, LoadBalancer) - Constructor for class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
LoadBalancerSupport - Class in org.apache.camel.processor.loadbalancer
A default base class for a LoadBalancer implementation
LoadBalancerSupport() - Constructor for class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
LoadBalancerType - Class in org.apache.camel.model.loadbalancer
 
LoadBalancerType() - Constructor for class org.apache.camel.model.loadbalancer.LoadBalancerType
 
LoadBalancerType(LoadBalancer) - Constructor for class org.apache.camel.model.loadbalancer.LoadBalancerType
 
LoadBalancerType(String) - Constructor for class org.apache.camel.model.loadbalancer.LoadBalancerType
 
LoadBalanceType - Class in org.apache.camel.model
 
LoadBalanceType() - Constructor for class org.apache.camel.model.LoadBalanceType
 
loadClass(String) - Static method in class org.apache.camel.util.ObjectHelper
Attempts to load the given class name using the thread context class loader or the class loader used to load this class
loadClass(String, ClassLoader) - Static method in class org.apache.camel.util.ObjectHelper
Attempts to load the given class name using the thread context class loader or the given class loader
loadConverterMethods(TypeConverterRegistry, Class) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
Loads all of the converter methods for the given type
loadDefaultRegistry() - Method in class org.apache.camel.component.bean.DefaultParameterMappingStrategy
Creates an invocation on the given POJO using annotations to decide which method to invoke and to figure out which parameters to use
loadFallbackTypeConverters() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
log(Log) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the log used for caught exceptions
log(String) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the log used for caught exceptions
log(Class) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the log used for caught exceptions
log(String) - Method in class org.apache.camel.processor.Logger
 
log(String, Throwable) - Method in class org.apache.camel.processor.Logger
 
LogComponent - Class in org.apache.camel.component.log
The Log Component to log message exchanges to the underlying logging mechanism.
LogComponent() - Constructor for class org.apache.camel.component.log.LogComponent
 
logError(Exchange, Throwable) - Method in class org.apache.camel.processor.LoggingErrorHandler
 
logger(Logger) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the logger used for caught exceptions
Logger - Class in org.apache.camel.processor
A Processor which just logs to a Log object which can be used as an exception handler instead of using a dead letter queue.
Logger() - Constructor for class org.apache.camel.processor.Logger
 
Logger(Log) - Constructor for class org.apache.camel.processor.Logger
 
Logger(Log, LoggingLevel) - Constructor for class org.apache.camel.processor.Logger
 
Logger(String) - Constructor for class org.apache.camel.processor.Logger
 
Logger(String, LoggingLevel) - Constructor for class org.apache.camel.processor.Logger
 
loggingErrorHandler() - Method in class org.apache.camel.builder.BuilderSupport
Creates an error handler which just logs errors
loggingErrorHandler(String) - Method in class org.apache.camel.builder.BuilderSupport
Creates an error handler which just logs errors
loggingErrorHandler(Log) - Method in class org.apache.camel.builder.BuilderSupport
Creates an error handler which just logs errors
loggingErrorHandler(Log, LoggingLevel) - Method in class org.apache.camel.builder.BuilderSupport
Creates an error handler which just logs errors
LoggingErrorHandler - Class in org.apache.camel.processor
An ErrorHandler which uses commons-logging to dump the error
LoggingErrorHandler(Processor) - Constructor for class org.apache.camel.processor.LoggingErrorHandler
 
LoggingErrorHandler(Processor, Log, LoggingLevel) - Constructor for class org.apache.camel.processor.LoggingErrorHandler
 
LoggingErrorHandlerBuilder - Class in org.apache.camel.builder
Uses the Logger as an error handler
LoggingErrorHandlerBuilder() - Constructor for class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
LoggingErrorHandlerBuilder(Log) - Constructor for class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
LoggingErrorHandlerBuilder(Log, LoggingLevel) - Constructor for class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
LoggingExceptionHandler - Class in org.apache.camel.impl
A default implementation of ExceptionHandler which uses a Logger to log to an arbitrary Log with some LoggingLevel
LoggingExceptionHandler(Class) - Constructor for class org.apache.camel.impl.LoggingExceptionHandler
 
LoggingExceptionHandler(Logger) - Constructor for class org.apache.camel.impl.LoggingExceptionHandler
 
loggingLevel(LoggingLevel) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the logging level of exceptions caught
LoggingLevel - Enum in org.apache.camel.processor
Used to configure the logging levels
logMessage(Exchange) - Method in class org.apache.camel.processor.Logger
 
logMessage(Exchange, Throwable) - Method in class org.apache.camel.processor.LoggingErrorHandler
 
logMessage(Exchange) - Method in class org.apache.camel.processor.ThroughputLogger
 
lookup(String) - Method in class org.apache.camel.impl.DefaultComponent
Look up the given named bean in the Registry on the CamelContext
lookup(String, Class<T>) - Method in class org.apache.camel.impl.DefaultComponent
Look up the given named bean of the given type in the Registry on the CamelContext
lookup(String, Class<T>) - Method in class org.apache.camel.impl.JndiRegistry
 
lookup(String) - Method in class org.apache.camel.impl.JndiRegistry
 
lookup(String, Class<T>) - Method in class org.apache.camel.impl.RouteContext
lookup an object by name and type
lookup(String, Class<T>) - Method in interface org.apache.camel.spi.Registry
Looks up a service in the registry, returning the service or null if it could not be found.
lookup(String) - Method in interface org.apache.camel.spi.Registry
Looks up a service in the registry based purely on name, returning the service or null if it could not be found.
lookup(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
Look up the given named bean in the Registry on the CamelContext
lookup(CamelContext, String, Class<T>) - Static method in class org.apache.camel.util.CamelContextHelper
Look up the given named bean of the given type in the Registry on the CamelContext
lookup(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
lookup(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
lookupBean() - Method in class org.apache.camel.component.bean.RegistryBean
 
lookupBean(Exchange, String) - Static method in class org.apache.camel.util.ExchangeHelper
Performs a lookup in the registry of the bean name
lookupBean(Exchange, String, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
Performs a lookup in the registry of the bean name and type
lookupLink(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
lookupLink(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
lookupMandatoryBean(Exchange, String) - Static method in class org.apache.camel.util.ExchangeHelper
Performs a lookup in the registry of the mandatory bean name and throws an exception if it could not be found
lookupMandatoryBean(Exchange, String, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
Performs a lookup in the registry of the mandatory bean name and throws an exception if it could not be found
lower(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the next lower element in the sequence to the given element.
LRUCache<K,V> - Class in org.apache.camel.util
A Least Recently Used Cache
LRUCache(int) - Constructor for class org.apache.camel.util.LRUCache
 
LRUCache(int, int, float, boolean) - Constructor for class org.apache.camel.util.LRUCache
Constructs an empty LRUCache instance with the specified initial capacity, maximumCacheSize,load factor and ordering mode.

M

makeProcessor(RouteContext) - Method in class org.apache.camel.model.ProcessorType
Creates the processor and wraps it in any necessary interceptors and error handlers
ManagedEndpoint - Class in org.apache.camel.management
 
ManagedEndpoint(Endpoint<? extends Exchange>) - Constructor for class org.apache.camel.management.ManagedEndpoint
 
ManagedRoute - Class in org.apache.camel.management
 
ManagedService - Class in org.apache.camel.management
 
ManagedService(ServiceSupport) - Constructor for class org.apache.camel.management.ManagedService
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.DefaultComponent
Converts the given value to the specified type throwing an IllegalArgumentException if the value could not be converted to a non null value
mandatoryConvertTo(CamelContext, Class<T>, Object) - Static method in class org.apache.camel.util.CamelContextHelper
Converts the given value to the specified type throwing an IllegalArgumentException if the value could not be converted to a non null value
mandatoryLookup(String) - Method in class org.apache.camel.impl.DefaultComponent
Look up the given named bean in the Registry on the CamelContext or throws
mandatoryLookup(String, Class<T>) - Method in class org.apache.camel.impl.DefaultComponent
Look up the given named bean of the given type in the Registry on the CamelContext
mandatoryLookup(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
Look up the given named bean in the Registry on the CamelContext or throws
mandatoryLookup(CamelContext, String, Class<T>) - Static method in class org.apache.camel.util.CamelContextHelper
Look up the given named bean of the given type in the Registry on the CamelContext
MAP - Static variable in enum org.apache.camel.ExchangePattern
 
marshal(Exchange, Object, OutputStream) - Method in class org.apache.camel.impl.SerializationDataFormat
 
marshal(Exchange, Object, OutputStream) - Method in class org.apache.camel.impl.StringDataFormat
 
marshal(Exchange, Object, OutputStream) - Method in class org.apache.camel.model.dataformat.DataFormatType
 
marshal() - Method in class org.apache.camel.model.ProcessorType
Marshals the in body using a DataFormat expression to define the format of the output which will be added to the out body.
marshal(DataFormatType) - Method in class org.apache.camel.model.ProcessorType
Marshals the in body using the specified DataFormat and sets the output on the out message body.
marshal(DataFormat) - Method in class org.apache.camel.model.ProcessorType
Marshals the in body using the specified DataFormat and sets the output on the out message body.
marshal(String) - Method in class org.apache.camel.model.ProcessorType
Marshals the in body the specified DataFormat reference in the Registry and sets the output on the out message body.
marshal(Exchange, Object, OutputStream) - Method in interface org.apache.camel.spi.DataFormat
Marshals the object to the given Stream.
MarshalProcessor - Class in org.apache.camel.processor
Marshals the body of the incoming message using the given data format
MarshalProcessor(DataFormat) - Constructor for class org.apache.camel.processor.MarshalProcessor
 
MarshalType - Class in org.apache.camel.model
Marshals to a binary payload using the given DataFormatType
MarshalType() - Constructor for class org.apache.camel.model.MarshalType
 
MarshalType(DataFormatType) - Constructor for class org.apache.camel.model.MarshalType
 
MarshalType(String) - Constructor for class org.apache.camel.model.MarshalType
 
matches(E) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
matches(E) - Method in class org.apache.camel.impl.BinaryPredicateSupport
 
matches(E, Object, Object) - Method in class org.apache.camel.impl.BinaryPredicateSupport
 
matches(E) - Method in class org.apache.camel.impl.ExpressionSupport
 
matches(Exchange) - Method in class org.apache.camel.model.language.ExpressionType
 
matches(E) - Method in interface org.apache.camel.Predicate
Evaluates the predicate on the message exchange and returns true if this exchange matches the predicate
matches(List) - Static method in class org.apache.camel.util.ObjectHelper
Returns the predicate matching boolean on a List result set where if the first element is a boolean its value is used otherwise this method returns true if the collection is not empty
matches(Class) - Method in class org.apache.camel.util.ResolverUtil.AnnotatedWith
Returns true if the type is annotated with the class provided to the constructor.
matches(Class) - Method in class org.apache.camel.util.ResolverUtil.IsA
Returns true if type is assignable to the parent type supplied in the constructor.
matches(Class) - Method in interface org.apache.camel.util.ResolverUtil.Test
Will be called repeatedly with candidate classes.
matchesRegex(String) - Method in class org.apache.camel.builder.ValueBuilder
 
maximumRedeliveries(int) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
maximumRedeliveries(int) - Method in class org.apache.camel.model.ExceptionType
 
maximumRedeliveries(int) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
maximumRedeliveries - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
maximumRedeliveries(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered
maxSize(int) - Method in class org.apache.camel.model.ThreadType
 
MemoryMessageIdRepository - Class in org.apache.camel.processor.idempotent
A memory based implementation of MessageIdRepository.
MemoryMessageIdRepository(Map) - Constructor for class org.apache.camel.processor.idempotent.MemoryMessageIdRepository
 
memoryMessageIdRepository() - Static method in class org.apache.camel.processor.idempotent.MemoryMessageIdRepository
Creates a new MemoryMessageIdRepository with a memory based respository.
memoryMessageIdRepository(int) - Static method in class org.apache.camel.processor.idempotent.MemoryMessageIdRepository
Creates a new MemoryMessageIdRepository with a memory based respository.
memoryMessageIdRepository(Map) - Static method in class org.apache.camel.processor.idempotent.MemoryMessageIdRepository
Creates a new MemoryMessageIdRepository using the given Map to use to store the processed Message ID objects.
message(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an assertion to the given message index
Message - Interface in org.apache.camel
Implements the Message pattern and represents an inbound or outbound message as part of an Exchange
message(Object, List<SAXParseException>, List<SAXParseException>, List<SAXParseException>) - Static method in exception org.apache.camel.processor.validation.SchemaValidationException
 
MessageDriven - Annotation Type in org.apache.camel
Used to indicate a method on a POJO which is used as a Consumer of Exchange instances to process Message instances.
MessageIdRepository - Interface in org.apache.camel.processor.idempotent
Access to a repository of Message IDs to implement the Idempotent Consumer pattern.
messagesPerSecond(long, long, long) - Method in class org.apache.camel.processor.ThroughputLogger
 
MessageSupport - Class in org.apache.camel.impl
A base class for implementation inheritence providing the core Message body handling features but letting the derived class deal with headers.
MessageSupport() - Constructor for class org.apache.camel.impl.MessageSupport
 
MessageVariableResolver - Class in org.apache.camel.builder.xml
A variable resolver for XPath expressions which support properties on the messge, exchange as well as making system properties and environment properties available.
MessageVariableResolver() - Constructor for class org.apache.camel.builder.xml.MessageVariableResolver
 
META_INF_SERVICES - Static variable in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
method(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the method(String, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the METHOD_NAME - Static variable in class org.apache.camel.component.bean.BeanProcessor
 
MethodBean - Class in org.apache.camel.component.bean
Represents a Serializable version of a Method
MethodBean() - Constructor for class org.apache.camel.component.bean.MethodBean
 
MethodBean(Method) - Constructor for class org.apache.camel.component.bean.MethodBean
 
MethodCallExpression - Class in org.apache.camel.model.language
For expresions and predicates using the MethodCallExpression() - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(String) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(String, String) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodInfo - Class in org.apache.camel.component.bean
 
MethodInfo(Class, Method, List<ParameterInfo>, List<ParameterInfo>, boolean) - Constructor for class org.apache.camel.component.bean.MethodInfo
 
MethodInvocation - Interface in org.apache.camel.component.bean
 
micros(long) - Static method in class org.apache.camel.util.Time
 
millis(long) - Static method in class org.apache.camel.util.Time
 
minutes(long) - Static method in class org.apache.camel.util.Time
 
minutesAsSeconds(long) - Static method in class org.apache.camel.util.Time
 
MockComponent - Class in org.apache.camel.component.mock
A factory of MockEndpoint instances
MockComponent() - Constructor for class org.apache.camel.component.mock.MockComponent
 
MockEndpoint - Class in org.apache.camel.component.mock
A Mock endpoint which provides a literate, fluent API for testing routes using a JMock style API.
MockEndpoint(String, Component) - Constructor for class org.apache.camel.component.mock.MockEndpoint
 
MockEndpoint(String) - Constructor for class org.apache.camel.component.mock.MockEndpoint
 
multicast() - Method in class org.apache.camel.model.ProcessorType
Multicasts messages to all its child outputs; so that each processor and destination gets a copy of the original message to avoid the processors interfering with each other.
multicast(AggregationStrategy, boolean) - Method in class org.apache.camel.model.ProcessorType
Multicasts messages to all its child outputs; so that each processor and destination gets a copy of the original message to avoid the processors interfering with each other.
multicast(AggregationStrategy) - Method in class org.apache.camel.model.ProcessorType
Multicasts messages to all its child outputs; so that each processor and destination gets a copy of the original message to avoid the processors interfering with each other.
MulticastProcessor - Class in org.apache.camel.processor
Implements the Multicast pattern to send a message exchange to a number of endpoints, each endpoint receiving a copy of the message exchange.
MulticastProcessor(Collection<Processor>) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(Collection<Processor>, AggregationStrategy) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(Collection<Processor>, AggregationStrategy, boolean, ThreadPoolExecutor) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastType - Class in org.apache.camel.model
 
MulticastType() - Constructor for class org.apache.camel.model.MulticastType
 

N

name(String) - Method in class org.apache.camel.model.ThreadType
 
name(Class) - Static method in class org.apache.camel.util.ObjectHelper
Returns the type name of the given type or null if the type variable is null
NAME_PARSER - Static variable in class org.apache.camel.util.jndi.JndiContext
 
namespace(String, String) - Method in class org.apache.camel.builder.xml.XPathBuilder
Registers the namespace prefix and URI with the builder so that the prefix can be used in XPath expressions
NamespaceAware - Interface in org.apache.camel.spi
Represents an object which is aware of the namespaces in which its used such as XPath and XQuery type expressions so that the current namespace context can be injected
NamespaceAwareExpression - Class in org.apache.camel.model.language
A useful base class for any expression which may be namespace or XML content aware such as XPathExpression or XQueryExpression
NamespaceAwareExpression() - Constructor for class org.apache.camel.model.language.NamespaceAwareExpression
 
NamespaceAwareExpression(String) - Constructor for class org.apache.camel.model.language.NamespaceAwareExpression
 
NamespacePrefix - Annotation Type in org.apache.camel.language
Creates a namespace prefix for an XPath
Namespaces - Class in org.apache.camel.builder.xml
A helper class for working with namespaces or creating namespace based expressions
Namespaces(Element) - Constructor for class org.apache.camel.builder.xml.Namespaces
Creates a namespaces object from the given XML element
Namespaces(String, String) - Constructor for class org.apache.camel.builder.xml.Namespaces
Creates a namespace context with a single prefix and URI
namespaces(Namespaces) - Method in class org.apache.camel.builder.xml.XPathBuilder
Registers namespaces with the builder so that the registered prefixes can be used in XPath expressions
nanos(long) - Static method in class org.apache.camel.util.Time
 
newContext() - Method in class org.apache.camel.util.jndi.JndiContext
 
newInstance() - Method in class org.apache.camel.component.bean.BeanExchange
 
newInstance() - Method in class org.apache.camel.component.file.FileExchange
 
newInstance() - Method in class org.apache.camel.component.file.FileMessage
 
newInstance() - Method in class org.apache.camel.component.jmx.JMXMessage
 
newInstance() - Method in interface org.apache.camel.Exchange
Creates a new exchange instance with empty messages, headers and properties
newInstance() - Method in class org.apache.camel.impl.converter.CachingInjector
 
newInstance(Class<T>) - Method in class org.apache.camel.impl.DefaultComponent
Creates a new instance of the given type using the Injector on the given CamelContext
newInstance() - Method in class org.apache.camel.impl.DefaultExchange
 
newInstance() - Method in class org.apache.camel.impl.DefaultMessage
 
newInstance() - Method in class org.apache.camel.impl.MessageSupport
Returns a new instance
newInstance(Class<T>) - Method in class org.apache.camel.impl.ReflectionInjector
 
newInstance(List<Processor>) - Static method in class org.apache.camel.processor.Pipeline
 
newInstance(Class<T>) - Method in interface org.apache.camel.spi.Injector
Instantiates a new instance of the given type possibly injecting values into the object in the process
newInstance(CamelContext, Class<T>) - Static method in class org.apache.camel.util.CamelContextHelper
Creates a new instance of the given type using the Injector on the given CamelContext
newInstance(Exchange, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
Creates a new instance of the given type from the injector
newInstance(String) - Method in class org.apache.camel.util.FactoryFinder
Creates a new instance of the given key
newInstance(String, String) - Method in class org.apache.camel.util.FactoryFinder
 
newInstance(String, Injector) - Method in class org.apache.camel.util.FactoryFinder
 
newInstance(String, Injector, String) - Method in class org.apache.camel.util.FactoryFinder
 
newInstance(String, Injector, Class<T>) - Method in class org.apache.camel.util.FactoryFinder
 
newInstance(String, Injector, String, Class<T>) - Method in class org.apache.camel.util.FactoryFinder
 
newInstance(Class<T>) - Static method in class org.apache.camel.util.ObjectHelper
A helper method to create a new instance of a type using the default constructor arguments.
newInstance(Class<?>, Class<T>) - Static method in class org.apache.camel.util.ObjectHelper
A helper method to create a new instance of a type using the default constructor arguments.
newInstances(String, Injector, Class<T>) - Method in class org.apache.camel.util.FactoryFinder
 
nextThreadCounter() - Static method in class org.apache.camel.impl.ServiceSupport
 
NIOConverter - Class in org.apache.camel.converter
Some core java.nio based Type Converters
NoBeanAvailableException - Exception in org.apache.camel.component.bean
 
NoBeanAvailableException(String) - Constructor for exception org.apache.camel.component.bean.NoBeanAvailableException
 
NodeData - Class in org.apache.camel.view
Represents a node in the EIP diagram tree
NodeData(String, Object, String) - Constructor for class org.apache.camel.view.NodeData
 
NodeFactory - Class in org.apache.camel.model
A simple factory used to create new child nodes which allows pluggable extension points such as to add extra DSL helper methods such as for the Groovy or Ruby DSLs
NodeFactory() - Constructor for class org.apache.camel.model.NodeFactory
 
nodeResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to boolean
nodeSetResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to boolean
nodeType - Variable in class org.apache.camel.view.NodeData
 
nodeWritten - Variable in class org.apache.camel.view.NodeData
 
noErrorHandler() - Method in class org.apache.camel.builder.BuilderSupport
Creates a disabled error handler for removing the default error handler
NoErrorHandlerBuilder - Class in org.apache.camel.builder
A builder to disable the use of an error handler so that any exceptions are thrown.
NoErrorHandlerBuilder() - Constructor for class org.apache.camel.builder.NoErrorHandlerBuilder
 
NoFactoryAvailableException - Exception in org.apache.camel.util
Thrown if no factory resource is available for the given URI
NoFactoryAvailableException(String) - Constructor for exception org.apache.camel.util.NoFactoryAvailableException
 
NoMessageIdException - Exception in org.apache.camel.processor.idempotent
An exception thrown if no message ID could be found on a message which is to be used with the Idempotent Consumer pattern.
NoMessageIdException(Exchange, Expression) - Constructor for exception org.apache.camel.processor.idempotent.NoMessageIdException
 
NoOpFileProcessStrategy - Class in org.apache.camel.component.file.strategy
A simple strategy which just locks the file but does not modify it
NoOpFileProcessStrategy() - Constructor for class org.apache.camel.component.file.strategy.NoOpFileProcessStrategy
 
NoPolicy<E> - Class in org.apache.camel.impl
Represents an Policy which adds no interceptors.
NoPolicy() - Constructor for class org.apache.camel.impl.NoPolicy
 
NoRouteBuilder - Class in org.apache.camel.impl
A helper class, usually used for testing which does not create any routes.
NoRouteBuilder() - Constructor for class org.apache.camel.impl.NoRouteBuilder
 
noSpecificLanguageFound(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
noStreamCaching() - Method in class org.apache.camel.builder.RouteBuilder
Completely disable stream caching for all routes being defined in the same RouteBuilder after this.
noStreamCaching() - Method in class org.apache.camel.model.RouteType
Disable stream caching for this Route.
noStreamCaching(List<InterceptorType>) - Static method in class org.apache.camel.processor.interceptor.StreamCachingInterceptor
Remove the StreamCachingInterceptor type of interceptor from the given list of interceptors
NoSuchBeanException - Exception in org.apache.camel
A runtime exception if a given bean could not be found in the Registry
NoSuchBeanException(String) - Constructor for exception org.apache.camel.NoSuchBeanException
 
NoSuchEndpointException - Exception in org.apache.camel
A runtime exception thrown if a routing processor such as a RecipientList is unable to resolve an Endpoint from a URI.
NoSuchEndpointException(String) - Constructor for exception org.apache.camel.NoSuchEndpointException
 
NoSuchHeaderException - Exception in org.apache.camel
An exception caused when a mandatory header is not available on a message Exchange
NoSuchHeaderException(Exchange, String, Class<?>) - Constructor for exception org.apache.camel.NoSuchHeaderException
 
NoSuchLanguageException - Exception in org.apache.camel
A runtime exception thrown if an attempt is made to resolve an unknown language definition.
NoSuchLanguageException(String) - Constructor for exception org.apache.camel.NoSuchLanguageException
 
NoSuchPropertyException - Exception in org.apache.camel
An exception caused when a mandatory property is not available on a message Exchange
NoSuchPropertyException(Exchange, String, Class<?>) - Constructor for exception org.apache.camel.NoSuchPropertyException
 
not(Predicate<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to return the logical not of the given predicate
notNull(Object, String) - Static method in class org.apache.camel.util.ObjectHelper
 
NoTypeConversionAvailableException - Exception in org.apache.camel
An exception thrown if a value could not be converted to the required type
NoTypeConversionAvailableException(Object, Class) - Constructor for exception org.apache.camel.NoTypeConversionAvailableException
 
NoXmlBodyValidationException - Exception in org.apache.camel.processor.validation
An exception found if no XML body is available on the inbound message
NoXmlBodyValidationException(Exchange) - Constructor for exception org.apache.camel.processor.validation.NoXmlBodyValidationException
 
numberResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to boolean
numExchanges - Variable in class org.apache.camel.management.Counter
 

O

ObjectConverter - Class in org.apache.camel.converter
Some core java.lang based Type Converters
ObjectHelper - Class in org.apache.camel.util
A number of useful helper methods for working with Objects
objectModel(String) - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the object model URI to use
ObjectNameEncoder - Class in org.apache.camel.management
Utility class providing RFC 1738 style encoding for ObjectName values.
ognl(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an OGNL expression
OgnlExpression - Class in org.apache.camel.model.language
For OGNL expresions and predicates
OgnlExpression() - Constructor for class org.apache.camel.model.language.OgnlExpression
 
OgnlExpression(String) - Constructor for class org.apache.camel.model.language.OgnlExpression
 
onAggregation(Object, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregationCollection
A strategy method allowing derived classes such as PredicateAggregationCollection to check to see if the aggregation has completed
onAggregation(Object, Exchange) - Method in class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 
onComplete(Exchange) - Method in interface org.apache.camel.spi.Synchronization
Called when the processing of the message exchange is complete
onContextCreate(CamelContext) - Method in class org.apache.camel.impl.DefaultLifecycleStrategy
 
onContextCreate(CamelContext) - Method in class org.apache.camel.impl.DelegateLifecycleStrategy
 
onContextCreate(CamelContext) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
onContextCreate(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding a CamelContext.
onDuplicateMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
A strategy method to allow derived classes to overload the behaviour of processing a duplicate message
onEndpointAdd(Endpoint<? extends Exchange>) - Method in class org.apache.camel.impl.DefaultLifecycleStrategy
 
onEndpointAdd(Endpoint<? extends Exchange>) - Method in class org.apache.camel.impl.DelegateLifecycleStrategy
 
onEndpointAdd(Endpoint<? extends Exchange>) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
onEndpointAdd(Endpoint<? extends Exchange>) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding an Endpoint.
onExchange(Exchange) - Method in class org.apache.camel.component.list.ListEndpoint
Invoked on a message exchange being sent by a producer
onExchange(Exchange) - Method in class org.apache.camel.component.mock.MockEndpoint
 
onExchange(Exchange) - Method in class org.apache.camel.impl.ProcessorEndpoint
 
onFailure(Exchange) - Method in interface org.apache.camel.spi.Synchronization
Called when the processing of the message exchange has failed for some reason.
onNewPredicate(Predicate<E>) - Method in class org.apache.camel.builder.ValueBuilder
A stategy method to allow derived classes to deal with the newly created predicate in different ways
onNewPredicate(Predicate<Exchange>) - Method in class org.apache.camel.component.mock.AssertionClause.PredicateValueBuilder
 
onRouteContextCreate(RouteContext) - Method in class org.apache.camel.impl.DefaultLifecycleStrategy
 
onRouteContextCreate(RouteContext) - Method in class org.apache.camel.impl.DelegateLifecycleStrategy
 
onRouteContextCreate(RouteContext) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
onRouteContextCreate(RouteContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding RouteContext(s).
onRoutesAdd(Collection<Route>) - Method in class org.apache.camel.impl.DefaultLifecycleStrategy
 
onRoutesAdd(Collection<Route>) - Method in class org.apache.camel.impl.DelegateLifecycleStrategy
 
onRoutesAdd(Collection<Route>) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
onRoutesAdd(Collection<Route>) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding Route(s).
onServiceAdd(CamelContext, Service) - Method in class org.apache.camel.impl.DefaultLifecycleStrategy
 
onServiceAdd(CamelContext, Service) - Method in class org.apache.camel.impl.DelegateLifecycleStrategy
 
onServiceAdd(CamelContext, Service) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
onServiceAdd(CamelContext, Service) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding a Service.
or(Predicate<E>, Predicate<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to combine multiple predicates by a logical OR
org.apache.camel - package org.apache.camel
The core Camel API
org.apache.camel.builder - package org.apache.camel.builder
The Camel Domain Specific Language for creating Routes, Predicates, Expressions and Error Handlers.
org.apache.camel.builder.xml - package org.apache.camel.builder.xml
Support for XPath based Expressions and Predicates as well as an XSLT processor
org.apache.camel.component.bean - package org.apache.camel.component.bean
The Bean Component which will look up the bean name in the Spring ApplicationContext and use that to dispatch messages to a POJO
org.apache.camel.component.dataset - package org.apache.camel.component.dataset
A DataSet Endpoint for testing of endpoints using defined DataSets
org.apache.camel.component.direct - package org.apache.camel.component.direct
The Direct Component which synchronously invokes all the consumers when a producer sends an exchange to the endpoint.
org.apache.camel.component.file - package org.apache.camel.component.file
The File Component for working with file systems.
org.apache.camel.component.file.strategy - package org.apache.camel.component.file.strategy
Strategies for the File Component.
org.apache.camel.component.jmx - package org.apache.camel.component.jmx
The JMX Component for monitoring JMX Attributes uisng a CounterMonitor.
org.apache.camel.component.list - package org.apache.camel.component.list
The List Component which is a simple in memory component which maintains a List of all message exchanges which can be useful for debugging, tooling or visualistion.
org.apache.camel.component.log - package org.apache.camel.component.log
The Log Component uses Jakarta Commons Logging to log message exchanges.
org.apache.camel.component.mock - package org.apache.camel.component.mock
The Mock Component which is used for testing of routing and mediation rules.
org.apache.camel.component.ref - package org.apache.camel.component.ref
 
org.apache.camel.component.seda - package org.apache.camel.component.seda
The SEDA Component for asynchronous SEDA exchanges on a BlockingQueue within a single CamelContext
org.apache.camel.component.timer - package org.apache.camel.component.timer
The Timer Component extends the POJO component to provide a simple timer
org.apache.camel.component.vm - package org.apache.camel.component.vm
The VM Component for asynchronous SEDA exchanges on a BlockingQueue within the current JVM; so across CamelContext instances.
org.apache.camel.converter - package org.apache.camel.converter
A set of helper classes for converting from different types of Java object to be used by the Type Conversion Support
org.apache.camel.converter.jaxp - package org.apache.camel.converter.jaxp
A number of JAXP related helper classes for converting to and from various JAXP related classes like Document and Source to be used by a TypeConverter
org.apache.camel.converter.stream - package org.apache.camel.converter.stream
Package with converters for dealing with stream-based messages
org.apache.camel.impl - package org.apache.camel.impl
Default implementation classes for Camel Core
org.apache.camel.impl.converter - package org.apache.camel.impl.converter
Default implementation classes the Type Conversion Strategies
org.apache.camel.language - package org.apache.camel.language
Camel language support such as Bean and Simple language.
org.apache.camel.language.bean - package org.apache.camel.language.bean
Camel Bean language.
org.apache.camel.language.simple - package org.apache.camel.language.simple
Camel Simple language.
org.apache.camel.management - package org.apache.camel.management
Camel JMX export services.
org.apache.camel.model - package org.apache.camel.model
The JAXB POJOs for the XML Configuration of the routing rules.
org.apache.camel.model.config - package org.apache.camel.model.config
The Resequencer Configuration classes
org.apache.camel.model.dataformat - package org.apache.camel.model.dataformat
The JAXB POJOs for the Data Formats used to marshal and unmarshal objects to and from streams inside components
org.apache.camel.model.language - package org.apache.camel.model.language
The JAXB POJOs for the Expression and Predicate plugins for the XML Configuration.
org.apache.camel.model.loadbalancer - package org.apache.camel.model.loadbalancer
The LoadBalancer and the LoadBalancerStrategy JAXB Objects
org.apache.camel.processor - package org.apache.camel.processor
A collection of Processor implementations which are used to implement the Enterprise Integration Patterns
org.apache.camel.processor.aggregate - package org.apache.camel.processor.aggregate
Helper classes for the Aggregator pattern.
org.apache.camel.processor.exceptionpolicy - package org.apache.camel.processor.exceptionpolicy
Exception policy startegies for Dead Letter Channel pattern.
org.apache.camel.processor.idempotent - package org.apache.camel.processor.idempotent
An implementation of the Idempotent Consumer pattern.
org.apache.camel.processor.interceptor - package org.apache.camel.processor.interceptor
Helper classes for interceptors.
org.apache.camel.processor.loadbalancer - package org.apache.camel.processor.loadbalancer
Various load balancer processors
org.apache.camel.processor.resequencer - package org.apache.camel.processor.resequencer
Helper classes for the Resequencer pattern.
org.apache.camel.processor.validation - package org.apache.camel.processor.validation
Performs XML validation using JAXP for validating against XSD or RelaxNG
org.apache.camel.spi - package org.apache.camel.spi
Service Provider Interfaces used internally by the Camel runtime which are plugin strategies.
org.apache.camel.util - package org.apache.camel.util
Utility classes used by the core of Camel and useful for Camel component developers
org.apache.camel.util.jndi - package org.apache.camel.util.jndi
A simple JNDI context which can be used with the JndiRegistry
org.apache.camel.view - package org.apache.camel.view
Helper class to help with the Visualisation of Routes
otherwise() - Method in class org.apache.camel.model.ChoiceType
 
OtherwiseType - Class in org.apache.camel.model
 
OtherwiseType() - Constructor for class org.apache.camel.model.OtherwiseType
 
Out<V> - Class in org.apache.camel.util
 
Out() - Constructor for class org.apache.camel.util.Out
 
Out(V) - Constructor for class org.apache.camel.util.Out
 
OUT_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
outBody() - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the outbound body on an exchange
outBody() - Method in class org.apache.camel.builder.BuilderSupport
Returns a predicate and value builder for the outbound body on an exchange
outBody(Class<T>) - Method in class org.apache.camel.builder.BuilderSupport
Returns a predicate and value builder for the outbound message body as a specific type
outBody() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an outbound message body
outBody(Class) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an outbound message body converted to the expected type
outBody() - Method in class org.apache.camel.component.mock.AssertionClause
Returns a predicate and value builder for the outbound body on an exchange
outBody(Class<T>) - Method in class org.apache.camel.component.mock.AssertionClause
Returns a predicate and value builder for the outbound message body as a specific type
outBodyAs(Class<T>) - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the outbound message body as a specific type
outBodyExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the out messages body
outBodyExpression(Class<T>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges outbound message body converted to the given type
outHeader(String) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an outbound message header of the given name
outHeaderExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the out header value with the given name
outHeaders() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the outbound headers
OutHeaders - Annotation Type in org.apache.camel
Marks a parameter as being an injection point of the headers of an outbound Message
outHeadersExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the outbound message headers
outMessage() - Method in class org.apache.camel.builder.ExpressionClause
An expression of an inbound message
outMessageExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the OUT message
outputBytes() - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the output as being a byte[]
outputDOM() - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the output as being a DOM
outputs - Variable in class org.apache.camel.model.OutputType
 
outputs - Variable in class org.apache.camel.view.NodeData
 
outputString() - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the output as being a String
OutputType<Type extends ProcessorType> - Class in org.apache.camel.model
A useful base class for output types
OutputType() - Constructor for class org.apache.camel.model.OutputType
 

P

PackageHelper - Class in org.apache.camel.util
Some helper methods for working with Java packages and versioning.
parameter(String, Object) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
ParameterInfo - Class in org.apache.camel.component.bean
 
ParameterInfo(int, Class, Annotation[], Expression) - Constructor for class org.apache.camel.component.bean.ParameterInfo
 
ParameterMappingStrategy - Interface in org.apache.camel.component.bean
A strategy for creating a default parameter expression for a given type
PARENT_PROPERTY - Static variable in class org.apache.camel.Route
 
parseComposite(URI) - Static method in class org.apache.camel.util.URISupport
 
parseParameters(URI) - Static method in class org.apache.camel.util.URISupport
 
parseQuery(String) - Static method in class org.apache.camel.util.URISupport
 
PerformanceCounter - Class in org.apache.camel.management
 
PerformanceCounter() - Constructor for class org.apache.camel.management.PerformanceCounter
 
performAssertions(Exchange) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
performAssertions(Exchange) - Method in class org.apache.camel.component.mock.MockEndpoint
 
php(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a PHP expression
PhpExpression - Class in org.apache.camel.model.language
For PHP expresions and predicates
PhpExpression() - Constructor for class org.apache.camel.model.language.PhpExpression
 
PhpExpression(String) - Constructor for class org.apache.camel.model.language.PhpExpression
 
pipeline(String...) - Method in class org.apache.camel.model.ProcessorType
Creates a Pipeline of the list of endpoints so that the message will get processed by each endpoint in turn and for request/response the output of one endpoint will be the input of the next endpoint
pipeline(Endpoint...) - Method in class org.apache.camel.model.ProcessorType
Creates a Pipeline of the list of endpoints so that the message will get processed by each endpoint in turn and for request/response the output of one endpoint will be the input of the next endpoint
pipeline(Collection<Endpoint>) - Method in class org.apache.camel.model.ProcessorType
Creates a Pipeline of the list of endpoints so that the message will get processed by each endpoint in turn and for request/response the output of one endpoint will be the input of the next endpoint
Pipeline - Class in org.apache.camel.processor
Creates a Pipeline pattern where the output of the previous step is sent as input to the next step, reusing the same message exchanges
Pipeline(Collection<Processor>) - Constructor for class org.apache.camel.processor.Pipeline
 
policies() - Method in class org.apache.camel.model.ProcessorType
 
policy(Policy) - Method in class org.apache.camel.model.ProcessorType
 
Policy<E> - Interface in org.apache.camel.spi
A strategy capable of applying interceptors to a processor
PolicyRef - Class in org.apache.camel.model
 
PolicyRef() - Constructor for class org.apache.camel.model.PolicyRef
 
PolicyRef(Policy) - Constructor for class org.apache.camel.model.PolicyRef
 
poll() - Method in class org.apache.camel.component.file.FileConsumer
 
poll() - Method in class org.apache.camel.impl.DefaultScheduledPollConsumer
 
poll() - Method in class org.apache.camel.impl.ScheduledPollConsumer
The polling method which is invoked periodically to poll this consumer
pollEndpoint(Endpoint, Processor, long) - Static method in class org.apache.camel.util.EndpointHelper
Creates a PollingConsumer and polls all pending messages on the endpoint and invokes the given Processor to process each Exchange and then closes down the consumer and throws any exceptions thrown.
pollEndpoint(Endpoint, Processor) - Static method in class org.apache.camel.util.EndpointHelper
Creates a PollingConsumer and polls all pending messages on the endpoint and invokes the given Processor to process each Exchange and then closes down the consumer and throws any exceptions thrown.
pollFile(File) - Method in class org.apache.camel.component.file.FileConsumer
Polls the given file
pollFileOrDirectory(File, boolean) - Method in class org.apache.camel.component.file.FileConsumer
Pools the given file or directory for files to process.
PollingConsumer<E extends Exchange> - Interface in org.apache.camel
Represents a Polling Consumer where the caller polls for messages when it is ready.
PollingConsumerSupport<E extends Exchange> - Class in org.apache.camel.impl
A useful base class for implementations of PollingConsumer
PollingConsumerSupport(Endpoint<E>) - Constructor for class org.apache.camel.impl.PollingConsumerSupport
 
popBlock() - Method in class org.apache.camel.model.ProcessorType
 
populateDefaultHeaders(Map<String, Object>) - Method in class org.apache.camel.component.dataset.DataSetSupport
Allows derived classes to customize a default set of properties
populateDefaultNamespaces(DefaultNamespaceContext) - Method in class org.apache.camel.builder.xml.XPathBuilder
Lets populate a number of standard prefixes if they are not already there
populateInitialAttachments(Map<String, DataHandler>) - Method in class org.apache.camel.impl.DefaultMessage
A strategy method populate the initial set of attachments on an inbound message from an underlying binding
populateInitialHeaders(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultMessage
A strategy method populate the initial set of headers on an inbound message from an underlying binding
populateMessage(Exchange, long) - Method in interface org.apache.camel.component.dataset.DataSet
Populates a message exchange when using the DataSet as a source of messages
populateMessage(Exchange, long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
populateRoutes(List<Route>) - Method in class org.apache.camel.builder.RouteBuilder
 
populateVariableMap(Exchange, Map) - Static method in class org.apache.camel.util.ExchangeHelper
Populates the Map with the variables which are made available to a script or template
predecessor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
predecessor(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the immediate predecessor of the given element in this sequence or null if no predecessor exists.
predecessor(E, E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if o1 is an immediate predecessor of o2.
predicate(Predicate<Exchange>) - Method in class org.apache.camel.component.mock.AssertionClause
Adds the given predicate to this assertion clause
predicate() - Method in class org.apache.camel.component.mock.AssertionClause
 
Predicate<E> - Interface in org.apache.camel
Evaluates a binary predicate on the message exchange to support things like scripting languages, XQuery or SQL as well as any arbitrary Java expression.
PredicateAggregationCollection - Class in org.apache.camel.processor.aggregate
An aggregator collection which uses a predicate to decide when an aggregation is completed for a particular correlation key
PredicateAggregationCollection(Expression<Exchange>, AggregationStrategy, Predicate) - Constructor for class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 
PredicateBuilder - Class in org.apache.camel.builder
A helper class for working with predicates
PredicateFactory<E extends Exchange> - Interface in org.apache.camel.builder
A Factory of Predicate objects typically implemented by a builder such as @{XPathBuilder}
PredicateSupport<E extends Exchange> - Class in org.apache.camel.impl
A useful base class for Predicate implementations
PredicateSupport() - Constructor for class org.apache.camel.impl.PredicateSupport
 
printNode(PrintWriter, NodeData, ProcessorType) - Method in class org.apache.camel.view.RouteDotGenerator
 
printNode(PrintWriter, NodeData) - Method in class org.apache.camel.view.RouteDotGenerator
 
printNode(PrintWriter, NodeData, ProcessorType) - Method in class org.apache.camel.view.XmlGraphGenerator
 
printNode(PrintWriter, NodeData) - Method in class org.apache.camel.view.XmlGraphGenerator
 
printRoute(PrintWriter, RouteType, FromType) - Method in class org.apache.camel.view.RouteDotGenerator
 
printRoute(PrintWriter, RouteType, NodeData) - Method in class org.apache.camel.view.XmlGraphGenerator
 
printRoutes(PrintWriter, Map<String, List<RouteType>>) - Method in class org.apache.camel.view.RouteDotGenerator
 
printRoutes(PrintWriter, String, List<RouteType>) - Method in class org.apache.camel.view.RouteDotGenerator
 
printRoutes(PrintWriter, Map<String, List<RouteType>>) - Method in class org.apache.camel.view.XmlGraphGenerator
 
printRoutes(PrintWriter, String, List<RouteType>) - Method in class org.apache.camel.view.XmlGraphGenerator
 
priority(int) - Method in class org.apache.camel.model.ThreadType
 
proceed() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
proceed() - Method in class org.apache.camel.model.ProcessorType
 
proceed(Exchange) - Method in class org.apache.camel.processor.DelegateProcessor
Proceed with the underlying delegated processor
ProceedProcessor - Class in org.apache.camel.processor
A Processor which proceeds on an Interceptor
ProceedProcessor(Interceptor) - Constructor for class org.apache.camel.processor.ProceedProcessor
 
ProceedType - Class in org.apache.camel.model
 
ProceedType() - Constructor for class org.apache.camel.model.ProceedType
 
process(Exchange, AsyncCallback) - Method in interface org.apache.camel.AsyncProcessor
Processes the message exchange.
process(Exchange) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
process(Exchange) - Method in class org.apache.camel.component.bean.BeanProcessor
 
process(Exchange) - Method in class org.apache.camel.component.direct.DirectProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.direct.DirectProducer
 
process(Exchange) - Method in class org.apache.camel.component.file.FileProducer
 
process(FileExchange) - Method in class org.apache.camel.component.file.FileProducer
 
process(Exchange) - Method in class org.apache.camel.component.seda.CollectionProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.seda.CollectionProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.impl.converter.AsyncProcessorTypeConverter.ProcessorToAsynProcessorBridge
 
process(Exchange) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
process(Exchange) - Method in class org.apache.camel.management.InstrumentationProcessor
 
process(Exchange) - Method in class org.apache.camel.model.loadbalancer.LoadBalancerType
 
process(Processor) - Method in class org.apache.camel.model.ProcessorType
Adds the custom processor to this destination which could be a final destination, or could be a transformation in a pipeline
process(Exchange) - Method in class org.apache.camel.processor.ChoiceProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.CompositeProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DeadLetterChannel
 
process(Exchange, AsyncCallback, DeadLetterChannel.RedeliveryData) - Method in class org.apache.camel.processor.DeadLetterChannel
 
process(Exchange) - Method in class org.apache.camel.processor.DeadLetterChannel
 
process(Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DelegateAsyncProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.DelegateAsyncProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.DelegateProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.FilterProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.HandleFaultProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
process(Exchange) - Method in class org.apache.camel.processor.Interceptor
 
process(Exchange) - Method in class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
process(Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
 
process(Exchange) - Method in class org.apache.camel.processor.Logger
 
process(Exchange) - Method in class org.apache.camel.processor.LoggingErrorHandler
 
process(Exchange) - Method in class org.apache.camel.processor.MarshalProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.Pipeline
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Pipeline
 
process(Exchange) - Method in class org.apache.camel.processor.ProceedProcessor
 
process(Exchange) - Method in interface org.apache.camel.Processor
Processes the message exchange
process(Exchange) - Method in class org.apache.camel.processor.RecipientList
 
process(Exchange) - Method in class org.apache.camel.processor.RoutingSlip
 
process(Exchange) - Method in class org.apache.camel.processor.SendProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SendProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.SetHeaderProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.StreamResequencer
 
process(Exchange) - Method in class org.apache.camel.processor.ThreadProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ThreadProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.ThroughputLogger
 
process(Exchange) - Method in class org.apache.camel.processor.ThrowFaultProcessor
Set the fault message in the exchange
process(Exchange) - Method in class org.apache.camel.processor.TransformProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.TryProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.UnitOfWorkProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.UnmarshalProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
process(AsyncProcessor, Exchange) - Static method in class org.apache.camel.util.AsyncProcessorHelper
Calls the async version of the processor's process method and waits for it to complete before returning.
processBatch() - Method in class org.apache.camel.processor.BatchProcessor
A transactional method to process a batch of messages up to a timeout period or number of messages reached.
processExchange(Exchange) - Method in class org.apache.camel.processor.BatchProcessor
Strategy Method to process an exchange in the batch.
processFinally(Exchange) - Method in class org.apache.camel.processor.TryProcessor
 
processNext(Exchange) - Method in class org.apache.camel.processor.DelegateProcessor
 
Processor - Interface in org.apache.camel
A processor is used to implement the Event Driven Consumer and Message Translater patterns and to process message exchanges.
processor - Variable in class org.apache.camel.processor.DelegateAsyncProcessor
 
processor - Variable in class org.apache.camel.processor.DelegateProcessor
 
ProcessorBuilder - Class in org.apache.camel.builder
A builder of a number of different Processor implementations
ProcessorEndpoint - Class in org.apache.camel.impl
An endpoint which allows exchanges to be sent into it which just invokes a given Processor.
ProcessorEndpoint(String, CamelContext, Processor) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
 
ProcessorEndpoint(String, Component, Processor) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
 
ProcessorEndpoint(String, Processor) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
 
ProcessorFactory - Interface in org.apache.camel.builder
An interface representing a builder of a Processor
ProcessorPollingConsumer - Class in org.apache.camel.impl
A simple implementation of PollingConsumer which just uses a Processor.
ProcessorPollingConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.impl.ProcessorPollingConsumer
 
ProcessorRef - Class in org.apache.camel.model
 
ProcessorRef() - Constructor for class org.apache.camel.model.ProcessorRef
 
ProcessorRef(Processor) - Constructor for class org.apache.camel.model.ProcessorRef
 
ProcessorType<Type extends ProcessorType> - Class in org.apache.camel.model
 
ProcessorType() - Constructor for class org.apache.camel.model.ProcessorType
 
processRef(String) - Method in class org.apache.camel.model.ProcessorType
Adds the custom processor reference to this destination which could be a final destination, or could be a transformation in a pipeline
Producer<E extends Exchange> - Interface in org.apache.camel
Provides a channel on which clients can create and invoke message exchanges on an Endpoint
ProducerCache<E extends Exchange> - Class in org.apache.camel.util
 
ProducerCache() - Constructor for class org.apache.camel.util.ProducerCache
 
ProducerTemplate<E extends Exchange> - Interface in org.apache.camel
 
properties() - Method in class org.apache.camel.builder.ExpressionClause
An expression of the exchange properties
Properties - Annotation Type in org.apache.camel
Marks a parameter as being an injection point of the properties of an Exchange
propertiesExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the property value with the given name
property(String) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an exchange property of the given name
Property - Annotation Type in org.apache.camel
Marks a parameter as being an injection point of a property of an Exchange
PropertyEditorTypeConverter - Class in org.apache.camel.impl.converter
Uses the java.beans.PropertyEditor conversion system to convert Objects to and from String values.
PropertyEditorTypeConverter() - Constructor for class org.apache.camel.impl.converter.PropertyEditorTypeConverter
 
propertyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the property value with the given name
Provider<T> - Interface in org.apache.camel.spi
A provider of newly constructed objects
ProxyHelper - Class in org.apache.camel.component.bean
A helper class for creating proxies which delegate to Camel
purge() - Method in class org.apache.camel.util.DefaultTimeoutMap
Purges any old entries from the map
purge() - Method in interface org.apache.camel.util.TimeoutMap
Purges any old entries from the map
pushBlock(Block) - Method in class org.apache.camel.model.ProcessorType
 
put(E) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Adds an element to this resequencer waiting, if necessary, until capacity becomes available.
put(Object, Object, long) - Method in class org.apache.camel.util.DefaultTimeoutMap
 
put(Object, Object, long) - Method in interface org.apache.camel.util.TimeoutMap
Adds the key value pair into the map such that some time after the given timeout the entry will be evicted
python(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Python expression
PythonExpression - Class in org.apache.camel.model.language
For Python expresions and predicates
PythonExpression() - Constructor for class org.apache.camel.model.language.PythonExpression
 
PythonExpression(String) - Constructor for class org.apache.camel.model.language.PythonExpression
 

Q

QueueComponent - Class in org.apache.camel.component.seda
An implementation of the Queue components for asynchronous SEDA exchanges on a BlockingQueue within a CamelContext
QueueComponent() - Constructor for class org.apache.camel.component.seda.QueueComponent
 
QueueLoadBalancer - Class in org.apache.camel.processor.loadbalancer
A base class for LoadBalancer implementations which choose a single destination for each exchange (rather like JMS Queues)
QueueLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
queues - Static variable in class org.apache.camel.component.vm.VmComponent
 

R

random() - Method in class org.apache.camel.model.LoadBalanceType
 
RandomLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements the random load balancing policy
RandomLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
RandomLoadBalanceStrategy - Class in org.apache.camel.model.loadbalancer
 
RandomLoadBalanceStrategy() - Constructor for class org.apache.camel.model.loadbalancer.RandomLoadBalanceStrategy
 
randomNumberGenerator - Static variable in class org.apache.camel.processor.RedeliveryPolicy
 
readExternal(ObjectInput) - Method in class org.apache.camel.component.bean.BeanInvocation
 
reason(Exchange, String) - Static method in exception org.apache.camel.NoSuchHeaderException
 
reason(Exchange, String) - Static method in exception org.apache.camel.NoSuchPropertyException
 
rebind(Name, Object) - Method in class org.apache.camel.util.jndi.JndiContext
 
rebind(String, Object) - Method in class org.apache.camel.util.jndi.JndiContext
 
receive() - Method in class org.apache.camel.component.seda.ListPollingConsumer
 
receive(long) - Method in class org.apache.camel.component.seda.ListPollingConsumer
 
receive() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
receive(long) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
receive() - Method in class org.apache.camel.impl.ProcessorPollingConsumer
 
receive(long) - Method in class org.apache.camel.impl.ProcessorPollingConsumer
 
receive() - Method in interface org.apache.camel.PollingConsumer
Waits until a message is available and then returns it.
receive(long) - Method in interface org.apache.camel.PollingConsumer
Attempts to receive a message exchange, waiting up to the given timeout to expire if a message is not yet available
receiveNoWait() - Method in class org.apache.camel.component.seda.ListPollingConsumer
 
receiveNoWait() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
receiveNoWait() - Method in class org.apache.camel.impl.ProcessorPollingConsumer
 
receiveNoWait() - Method in interface org.apache.camel.PollingConsumer
Attempts to receive a message exchange immediately without waiting and returning null if a message exchange is not available yet.
recipientList(Expression) - Method in class org.apache.camel.model.ProcessorType
Creates a dynamic Recipient List pattern.
recipientList() - Method in class org.apache.camel.model.ProcessorType
Creates a dynamic Recipient List pattern.
RecipientList - Class in org.apache.camel.processor
Implements a dynamic Recipient List pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.
RecipientList(Expression<Exchange>) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientListType - Class in org.apache.camel.model
 
RecipientListType() - Constructor for class org.apache.camel.model.RecipientListType
 
RecipientListType(ExpressionType) - Constructor for class org.apache.camel.model.RecipientListType
 
RecipientListType(Expression) - Constructor for class org.apache.camel.model.RecipientListType
 
REDELIVERED - Static variable in class org.apache.camel.processor.DeadLetterChannel
 
REDELIVERY_COUNTER - Static variable in class org.apache.camel.processor.DeadLetterChannel
 
RedeliveryPolicy - Class in org.apache.camel.processor
The policy used to decide how many times to redeliver and the time between the redeliveries before being sent to a Dead Letter Channel
RedeliveryPolicy() - Constructor for class org.apache.camel.processor.RedeliveryPolicy
 
RedeliveryPolicyType - Class in org.apache.camel.model
 
RedeliveryPolicyType() - Constructor for class org.apache.camel.model.RedeliveryPolicyType
 
RefComponent - Class in org.apache.camel.component.ref
Component for lookup of existing endpoints bound in the Registry.
RefComponent() - Constructor for class org.apache.camel.component.ref.RefComponent
 
ReflectionInjector - Class in org.apache.camel.impl
A simple implementation of Injector which just uses reflection to instantiate new objects using their zero argument constructor.
ReflectionInjector() - Constructor for class org.apache.camel.impl.ReflectionInjector
 
regex(Expression<E>, String) - Static method in class org.apache.camel.builder.PredicateBuilder
Returns a predicate which is true if the expression matches the given regular expression
regex(Expression<E>, Pattern) - Static method in class org.apache.camel.builder.PredicateBuilder
Returns a predicate which is true if the expression matches the given regular expression
regex(String) - Method in class org.apache.camel.builder.ValueBuilder
Creates a predicate which is true if this expression matches the given regular expression
regexReplaceAll(Expression<E>, String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Transforms the expression into a String then performs the regex replaceAll to transform the String and return the result
regexReplaceAll(Expression<E>, String, Expression<E>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Transforms the expression into a String then performs the regex replaceAll to transform the String and return the result
regexReplaceAll(String, String) - Method in class org.apache.camel.builder.ValueBuilder
Replaces all occurrencies of the regular expression with the given replacement
regexReplaceAll(String, Expression<E>) - Method in class org.apache.camel.builder.ValueBuilder
Replaces all occurrencies of the regular expression with the given replacement
regexTokenize(Expression<E>, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a tokenize expression which will tokenize the string with the given regex
regexTokenize(String) - Method in class org.apache.camel.builder.ValueBuilder
Tokenizes the string conversion of this expression using the given regular expression
register(Object, ObjectName) - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
register(Object, ObjectName, boolean) - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
register(Object, ObjectName) - Method in interface org.apache.camel.spi.InstrumentationAgent
Registers object with management infrastructure with a specific name.
register(Object, ObjectName, boolean) - Method in interface org.apache.camel.spi.InstrumentationAgent
Registers object with management infrastructure with a specific name.
registerTypeConverter(TypeConverterRegistry, Method, Class, Class, TypeConverter) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
registerTypeConverter(TypeConverterRegistry, Method, Class, Class, TypeConverter) - Method in class org.apache.camel.util.ReportingTypeConverterLoader
 
Registry - Interface in org.apache.camel.spi
Represents a service registry which may be implemented via a Spring ApplicationContext, via JNDI, a simple Map or the OSGI Service Registry
RegistryBean - Class in org.apache.camel.component.bean
An implementation of a BeanHolder which will
RegistryBean(CamelContext, String) - Constructor for class org.apache.camel.component.bean.RegistryBean
 
RegistryBean(CamelContext, String, ParameterMappingStrategy) - Constructor for class org.apache.camel.component.bean.RegistryBean
 
remove(Object) - Method in class org.apache.camel.util.DefaultTimeoutMap
 
remove(Object) - Method in interface org.apache.camel.util.TimeoutMap
 
removeAttachment(String) - Method in class org.apache.camel.impl.DefaultMessage
 
removeAttachment(String) - Method in interface org.apache.camel.Message
Removes the attachment specified by the id
removeChildService(Object) - Method in class org.apache.camel.impl.ServiceSupport
 
removeComponent(String) - Method in interface org.apache.camel.CamelContext
Removes a previously added component.
removeComponent(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
removeEldestEntry(Map.Entry) - Method in class org.apache.camel.util.LRUCache
 
removeFaultHeader(String) - Static method in class org.apache.camel.builder.ProcessorBuilder
Removes the header on the FAULT message
removeFaultHeader(String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which removes the header on the FAULT message
removeFromEnvironment(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
removeHeader(String) - Static method in class org.apache.camel.builder.ProcessorBuilder
Removes the header on the IN message
removeHeader(String) - Method in class org.apache.camel.impl.DefaultMessage
 
removeHeader(String) - Method in interface org.apache.camel.Message
Removes the named header from this message
removeHeader(String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which removes the header on the IN message
removeOutHeader(String) - Static method in class org.apache.camel.builder.ProcessorBuilder
Removes the header on the OUT message
removeOutHeader(String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which removes the header on the OUT message
removeProcessor(Processor) - Method in class org.apache.camel.model.loadbalancer.LoadBalancerType
 
removeProcessor(Processor) - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Removes the given processor from the load balancer
removeProcessor(Processor) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
removeProcessor(Processor) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
removeProperty(String) - Static method in class org.apache.camel.builder.ProcessorBuilder
Removes the property on the exchange
removeProperty(String) - Method in interface org.apache.camel.Exchange
Removes the given property on the exchange
removeProperty(String) - Method in class org.apache.camel.impl.DefaultExchange
 
removeProperty(String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which removes the exchange property
removePropertyChangeListener(PropertyChangeListener) - Method in class org.apache.camel.component.list.ListEndpoint
 
removePropertyChangeListener(PropertyChangeListener) - Method in class org.apache.camel.component.mock.MockEndpoint
 
removeQuery(URI) - Static method in class org.apache.camel.util.URISupport
Removes any URI query from the given uri
removeQueryString(String) - Method in class org.apache.camel.view.NodeData
 
removeSingletonEndpoint(String) - Method in interface org.apache.camel.CamelContext
Removes the singleton endpoint with the given URI
removeSingletonEndpoint(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
removeStartingCharacters(String, char) - Static method in class org.apache.camel.util.ObjectHelper
Removes any starting characters on the given text which match the given character
removeSynchronization(Synchronization) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
removeSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
Removes a synchronization hook
rename(Name, Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
rename(String, String) - Method in class org.apache.camel.util.jndi.JndiContext
 
renameFile(File) - Method in class org.apache.camel.component.file.strategy.DefaultFileRenamer
 
renameFile(File) - Method in interface org.apache.camel.component.file.strategy.FileRenamer
Renames the given file
renameFileName(File) - Method in class org.apache.camel.component.file.strategy.DefaultFileRenamer
 
RenameFileProcessStrategy - Class in org.apache.camel.component.file.strategy
A strategy to rename a file
RenameFileProcessStrategy() - Constructor for class org.apache.camel.component.file.strategy.RenameFileProcessStrategy
 
RenameFileProcessStrategy(boolean) - Constructor for class org.apache.camel.component.file.strategy.RenameFileProcessStrategy
 
RenameFileProcessStrategy(boolean, String, String) - Constructor for class org.apache.camel.component.file.strategy.RenameFileProcessStrategy
 
RenameFileProcessStrategy(boolean, FileRenamer) - Constructor for class org.apache.camel.component.file.strategy.RenameFileProcessStrategy
 
ReportingTypeConverterLoader - Class in org.apache.camel.util
 
ReportingTypeConverterLoader() - Constructor for class org.apache.camel.util.ReportingTypeConverterLoader
 
ReportingTypeConverterLoader.TypeMapping - Class in org.apache.camel.util
Represents a mapping from one type (which can be null) to another
ReportingTypeConverterLoader.TypeMapping(Class, Class, Class, Method) - Constructor for class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
ReportingTypeConverterRegistry - Class in org.apache.camel.util
 
ReportingTypeConverterRegistry() - Constructor for class org.apache.camel.util.ReportingTypeConverterRegistry
 
reportProgress(Exchange, int) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
request(Endpoint<E>, Processor) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint returning any result output body
request(String, Processor) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint returning any result output body
request(Endpoint<E>, Processor) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body
request(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body
requestBody(Endpoint<E>, Object) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint returning any result output body
requestBody(String, Object) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint returning any result output body
requestBody(Endpoint<E>, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body
requestBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body
requestBodyAndHeader(Endpoint<E>, Object, String, Object) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint returning any result output body
requestBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint returning any result output body
requestBodyAndHeader(Endpoint<E>, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body
requestBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body
resequencer() - Method in class org.apache.camel.model.ProcessorType
Creates the Resequencer pattern where a list of expressions are evaluated to be able to compare the message exchanges to reorder them.
resequencer(Expression<Exchange>) - Method in class org.apache.camel.model.ProcessorType
Creates the Resequencer pattern where an expression is evaluated to be able to compare the message exchanges to reorder them.
resequencer(List<Expression>) - Method in class org.apache.camel.model.ProcessorType
Creates the Resequencer pattern where a list of expressions are evaluated to be able to compare the message exchanges to reorder them.
resequencer(Expression...) - Method in class org.apache.camel.model.ProcessorType
Creates the Resequencer pattern where a list of expressions are evaluated to be able to compare the message exchanges to reorder them.
Resequencer - Class in org.apache.camel.processor
An implementation of the Resequencer which can reorder messages within a batch.
Resequencer(Endpoint, Processor, Expression<Exchange>) - Constructor for class org.apache.camel.processor.Resequencer
 
Resequencer(Endpoint, Processor, List<Expression>) - Constructor for class org.apache.camel.processor.Resequencer
 
Resequencer(Endpoint, Processor, Set<Exchange>) - Constructor for class org.apache.camel.processor.Resequencer
 
ResequencerEngine<E> - Class in org.apache.camel.processor.resequencer
Resequences elements based on a given SequenceElementComparator.
ResequencerEngine(SequenceElementComparator<E>) - Constructor for class org.apache.camel.processor.resequencer.ResequencerEngine
Creates a new resequencer instance with a default timeout of 2000 milliseconds.
ResequencerEngine(SequenceElementComparator<E>, int) - Constructor for class org.apache.camel.processor.resequencer.ResequencerEngine
Creates a new resequencer instance with a default timeout of 2000 milliseconds.
ResequencerType - Class in org.apache.camel.model
 
ResequencerType() - Constructor for class org.apache.camel.model.ResequencerType
 
ResequencerType(List<Expression>) - Constructor for class org.apache.camel.model.ResequencerType
 
reset() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
reset() - Method in class org.apache.camel.component.list.ListEndpoint
 
reset() - Method in class org.apache.camel.component.mock.MockEndpoint
 
reset() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
reset() - Method in class org.apache.camel.management.Counter
 
reset() - Method in class org.apache.camel.management.PerformanceCounter
 
reset() - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
reset() - Method in interface org.apache.camel.processor.validation.ValidatorErrorHandler
Resets any state within this error handler
resolveComponent(String, CamelContext) - Method in class org.apache.camel.impl.DefaultComponentResolver
 
resolveComponent(String, CamelContext) - Method in interface org.apache.camel.spi.ComponentResolver
Attempts to resolve the component for the given URI
resolveEndpoint(String) - Method in class org.apache.camel.impl.RouteContext
 
resolveEndpoint(String, String) - Method in class org.apache.camel.impl.RouteContext
Resolves an endpoint from either a URI or a named reference
resolveEndpoint(RouteContext) - Method in class org.apache.camel.model.FromType
 
resolveEndpoint(String) - Method in class org.apache.camel.model.RouteType
 
resolveEndpoint(RouteContext) - Method in class org.apache.camel.model.ToType
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.RecipientList
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.RoutingSlip
 
resolveEndpoint(E, Object) - Static method in class org.apache.camel.util.ExchangeHelper
Attempts to resolve the endpoint for the given value
ResolveEndpointFailedException - Exception in org.apache.camel
A runtime exception thrown if an Endpoint can not be resolved via URI
ResolveEndpointFailedException(String, Throwable) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
 
ResolveEndpointFailedException(String, String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
 
resolveLanguage(String) - Method in interface org.apache.camel.CamelContext
Resolves a language for creating expressions
resolveLanguage(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
resolveLanguage(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
resolveLanguage(String, CamelContext) - Method in interface org.apache.camel.spi.LanguageResolver
 
resolveMandatoryEndpoint(String) - Method in class org.apache.camel.CamelTemplate
 
resolveMandatoryExpression(CamelContext, String, String) - Static method in class org.apache.camel.util.CamelContextHelper
Resolves the mandatory language name and expression text into a Expression instance throwing an exception if it could not be created
resolveMandatoryLanguage(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
Resolves the given language name into a Language or throws an exception if it could not be converted
resolveMessageIdRepository(RouteContext) - Method in class org.apache.camel.model.IdempotentConsumerType
 
resolvePolicy(RouteContext) - Method in class org.apache.camel.model.PolicyRef
 
ResolverUtil<T> - Class in org.apache.camel.util
ResolverUtil is used to locate classes that are available in the/a class path and meet arbitrary conditions.
ResolverUtil() - Constructor for class org.apache.camel.util.ResolverUtil
 
ResolverUtil.AnnotatedWith - Class in org.apache.camel.util
A Test that checks to see if each class is annotated with a specific annotation.
ResolverUtil.AnnotatedWith(Class<? extends Annotation>) - Constructor for class org.apache.camel.util.ResolverUtil.AnnotatedWith
Constructs an AnnotatedWith test for the specified annotation type.
ResolverUtil.IsA - Class in org.apache.camel.util
A Test that checks to see if each class is assignable to the provided class.
ResolverUtil.IsA(Class) - Constructor for class org.apache.camel.util.ResolverUtil.IsA
Constructs an IsA test using the supplied Class as the parent class/interface.
ResolverUtil.Test - Interface in org.apache.camel.util
A simple interface that specifies how to test classes to determine if they are to be included in the results produced by the ResolverUtil.
resolveVariable(QName) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
restoreExceptionOnExchange(Exchange) - Static method in class org.apache.camel.processor.DeadLetterChannel
 
ResultHandler - Interface in org.apache.camel.builder.xml
A strategy for handling XSLT results
ResultHandlerFactory - Interface in org.apache.camel.builder.xml
 
resultType(Class) - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to boolean
roundRobin() - Method in class org.apache.camel.model.LoadBalanceType
 
RoundRobinLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements the round robin load balancing policy
RoundRobinLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
RoundRobinLoadBalanceStrategy - Class in org.apache.camel.model.loadbalancer
 
RoundRobinLoadBalanceStrategy() - Constructor for class org.apache.camel.model.loadbalancer.RoundRobinLoadBalanceStrategy
 
route() - Method in class org.apache.camel.model.RoutesType
Creates a new route
route(RouteType) - Method in class org.apache.camel.model.RoutesType
 
Route<E extends Exchange> - Class in org.apache.camel
A Route defines the processing used on an inbound message exchange from a specific Endpoint within a CamelContext
Route(Endpoint<E>) - Constructor for class org.apache.camel.Route
 
Route(Endpoint<E>, Service...) - Constructor for class org.apache.camel.Route
 
RouteBuilder - Class in org.apache.camel.builder
A Java DSL which is used to build Route instances in a CamelContext for smart routing.
RouteBuilder() - Constructor for class org.apache.camel.builder.RouteBuilder
 
RouteBuilder(CamelContext) - Constructor for class org.apache.camel.builder.RouteBuilder
 
RouteBuilderRef - Class in org.apache.camel.model
 
RouteBuilderRef() - Constructor for class org.apache.camel.model.RouteBuilderRef
 
RouteBuilderRef(String) - Constructor for class org.apache.camel.model.RouteBuilderRef
 
RouteContainer - Interface in org.apache.camel.model
 
RouteContext - Class in org.apache.camel.impl
The context used to activate new routing rules
RouteContext(RouteType, FromType, Collection<Route>) - Constructor for class org.apache.camel.impl.RouteContext
 
RouteContext(CamelContext) - Constructor for class org.apache.camel.impl.RouteContext
Only used for lazy construction from inside ExpressionType
RouteDotGenerator - Class in org.apache.camel.view
A DOT file creator plugin which creates a DOT file showing the current routes
RouteDotGenerator(String) - Constructor for class org.apache.camel.view.RouteDotGenerator
 
RoutesType - Class in org.apache.camel.model
Represents a collection of routes
RoutesType() - Constructor for class org.apache.camel.model.RoutesType
 
RouteType - Class in org.apache.camel.model
Represents an XML <route/> element
RouteType() - Constructor for class org.apache.camel.model.RouteType
 
RouteType(String) - Constructor for class org.apache.camel.model.RouteType
 
RouteType(Endpoint) - Constructor for class org.apache.camel.model.RouteType
 
ROUTING_SLIP_HEADER - Static variable in class org.apache.camel.model.RoutingSlipType
 
routingSlip(String, String) - Method in class org.apache.camel.model.ProcessorType
Creates a Routing Slip pattern.
routingSlip(String) - Method in class org.apache.camel.model.ProcessorType
Creates a Routing Slip pattern.
routingSlip() - Method in class org.apache.camel.model.ProcessorType
Creates a Routing Slip pattern with the default header RoutingSlipType.ROUTING_SLIP_HEADER.
RoutingSlip - Class in org.apache.camel.processor
Implements a Routing Slip pattern where the list of actual endpoints to send a message exchange to are dependent on the value of a message header.
RoutingSlip(String) - Constructor for class org.apache.camel.processor.RoutingSlip
 
RoutingSlip(String, String) - Constructor for class org.apache.camel.processor.RoutingSlip
 
RoutingSlipType - Class in org.apache.camel.model
 
RoutingSlipType() - Constructor for class org.apache.camel.model.RoutingSlipType
 
RoutingSlipType(String) - Constructor for class org.apache.camel.model.RoutingSlipType
 
RoutingSlipType(String, String) - Constructor for class org.apache.camel.model.RoutingSlipType
 
ruby(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Ruby expression
RubyExpression - Class in org.apache.camel.model.language
For Ruby expresions and predicates
RubyExpression() - Constructor for class org.apache.camel.model.language.RubyExpression
 
RubyExpression(String) - Constructor for class org.apache.camel.model.language.RubyExpression
 
run() - Method in class org.apache.camel.component.seda.SedaConsumer
 
run() - Method in class org.apache.camel.impl.ScheduledPollConsumer
Invoked whenever we should be polled
run() - Method in class org.apache.camel.processor.BatchProcessor
 
run() - Method in class org.apache.camel.processor.resequencer.SequenceSender
 
run() - Method in class org.apache.camel.processor.resequencer.Timeout
Notifies all timeout handlers about the scheduled timeout.
run() - Method in class org.apache.camel.util.DefaultTimeoutMap
The timer task which purges old requests and schedules another poll
RuntimeBeanExpressionException - Exception in org.apache.camel.language.bean
 
RuntimeBeanExpressionException(Exchange, String, String, Throwable) - Constructor for exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
RuntimeCamelException - Exception in org.apache.camel
 
RuntimeCamelException() - Constructor for exception org.apache.camel.RuntimeCamelException
 
RuntimeCamelException(String) - Constructor for exception org.apache.camel.RuntimeCamelException
 
RuntimeCamelException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeCamelException
 
RuntimeCamelException(Throwable) - Constructor for exception org.apache.camel.RuntimeCamelException
 
RuntimeExchangeException - Exception in org.apache.camel
A runtime exception caused by a specific message Exchange
RuntimeExchangeException(String, Exchange) - Constructor for exception org.apache.camel.RuntimeExchangeException
 
RuntimeExchangeException(Exception, Exchange) - Constructor for exception org.apache.camel.RuntimeExchangeException
 
RuntimeExpressionException - Exception in org.apache.camel
Thrown if an expression evaluation fails
RuntimeExpressionException(String) - Constructor for exception org.apache.camel.RuntimeExpressionException
 
RuntimeExpressionException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeExpressionException
 
RuntimeExpressionException(Throwable) - Constructor for exception org.apache.camel.RuntimeExpressionException
 
RuntimeTransformException - Exception in org.apache.camel
Thrown if a message transformation fails
RuntimeTransformException(String) - Constructor for exception org.apache.camel.RuntimeTransformException
 
RuntimeTransformException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeTransformException
 
RuntimeTransformException(Throwable) - Constructor for exception org.apache.camel.RuntimeTransformException
 

S

schedule() - Method in class org.apache.camel.processor.resequencer.Timeout
Schedules this timeout task.
ScheduledPollConsumer<E extends Exchange> - Class in org.apache.camel.impl
A useful base class for any consumer which is polling based
ScheduledPollConsumer(DefaultEndpoint<E>, Processor) - Constructor for class org.apache.camel.impl.ScheduledPollConsumer
 
ScheduledPollConsumer(Endpoint<E>, Processor, ScheduledExecutorService) - Constructor for class org.apache.camel.impl.ScheduledPollConsumer
 
ScheduledPollEndpoint<E extends Exchange> - Class in org.apache.camel.impl
A base class for Endpoint which creates a ScheduledPollConsumer
ScheduledPollEndpoint(String, Component) - Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
 
ScheduledPollEndpoint(String, CamelContext) - Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
 
ScheduledPollEndpoint(String) - Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
 
schedulePoll() - Method in class org.apache.camel.util.DefaultTimeoutMap
lets schedule each time to allow folks to change the time at runtime
SchemaValidationException - Exception in org.apache.camel.processor.validation
A Schema validation exception occurred
SchemaValidationException(Exchange, Object, List<SAXParseException>, List<SAXParseException>, List<SAXParseException>) - Constructor for exception org.apache.camel.processor.validation.SchemaValidationException
 
seconds(long) - Static method in class org.apache.camel.util.Time
 
SedaComponent - Class in org.apache.camel.component.seda
An implementation of the SEDA components for asynchronous SEDA exchanges on a BlockingQueue within a CamelContext
SedaComponent() - Constructor for class org.apache.camel.component.seda.SedaComponent
 
SedaConsumer - Class in org.apache.camel.component.seda
 
SedaConsumer(SedaEndpoint, Processor) - Constructor for class org.apache.camel.component.seda.SedaConsumer
 
SedaEndpoint - Class in org.apache.camel.component.seda
An implementation of the Queue components for asynchronous SEDA exchanges on a BlockingQueue within a CamelContext
SedaEndpoint(String, Component, BlockingQueue<Exchange>) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
 
SedaEndpoint(String, SedaComponent, Map) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
 
SedaEndpoint(String, BlockingQueue<Exchange>) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
 
send(String, E) - Method in class org.apache.camel.CamelTemplate
Sends the exchange to the given endpoint
send(String, Processor) - Method in class org.apache.camel.CamelTemplate
Sends an exchange to an endpoint using a supplied
send(String, Processor, AsyncCallback) - Method in class org.apache.camel.CamelTemplate
Sends an exchange to an endpoint using a supplied
send(String, ExchangePattern, Processor) - Method in class org.apache.camel.CamelTemplate
Sends an exchange to an endpoint using a supplied
send(Endpoint<E>, E) - Method in class org.apache.camel.CamelTemplate
Sends the exchange to the given endpoint
send(Endpoint<E>, Processor) - Method in class org.apache.camel.CamelTemplate
Sends an exchange to an endpoint using a supplied
send(Endpoint<E>, Processor, AsyncCallback) - Method in class org.apache.camel.CamelTemplate
Sends an exchange to an endpoint using a supplied
send(Endpoint<E>, ExchangePattern, Processor) - Method in class org.apache.camel.CamelTemplate
Sends an exchange to an endpoint using a supplied
send(E) - Method in class org.apache.camel.CamelTemplate
Sends the exchange to the default endpoint
send(Processor) - Method in class org.apache.camel.CamelTemplate
Sends an exchange to the default endpoint using a supplied
send(E) - Method in interface org.apache.camel.ProducerTemplate
Sends the exchange to the default endpoint
send(Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to the default endpoint using a supplied
send(String, E) - Method in interface org.apache.camel.ProducerTemplate
Sends the exchange to the given endpoint
send(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied
send(String, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied
send(Endpoint<E>, E) - Method in interface org.apache.camel.ProducerTemplate
Sends the exchange to the given endpoint
send(Endpoint<E>, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied
send(Endpoint<E>, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied
send(Endpoint<E>, E) - Method in class org.apache.camel.util.ProducerCache
Sends the exchange to the given endpoint
send(Endpoint<E>, Processor) - Method in class org.apache.camel.util.ProducerCache
Sends an exchange to an endpoint using a supplied Processor to populate the exchange
send(Endpoint<E>, Processor, AsyncCallback) - Method in class org.apache.camel.util.ProducerCache
Sends an exchange to an endpoint using a supplied Processor to populate the exchange.
send(Endpoint<E>, ExchangePattern, Processor) - Method in class org.apache.camel.util.ProducerCache
Sends an exchange to an endpoint using a supplied Processor to populate the exchange
sendBody(Endpoint<E>, ExchangePattern, Object) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint with the given ExchangePattern returning any result output body
sendBody(Endpoint<E>, Object) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint returning any result output body
sendBody(String, Object) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint
sendBody(String, ExchangePattern, Object) - Method in class org.apache.camel.CamelTemplate
Send the body to an endpoint
sendBody(Object) - Method in class org.apache.camel.CamelTemplate
Sends the body to the default endpoint and returns the result content
sendBody(Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint and returns the result content
sendBody(Endpoint<E>, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint
sendBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint
sendBody(Endpoint<E>, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint with the given ExchangePattern returning any result output body
sendBody(String, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint
sendBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.CamelTemplate
Sends the body to an endpoint with a specified header and header value
sendBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.CamelTemplate
Sends the body to an endpoint with a specified header and header value
sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.CamelTemplate
Sends the body to an endpoint with a specified header and header value
sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.CamelTemplate
Sends the body to an endpoint with a specified header and header value
sendBodyAndHeader(Object, String, Object) - Method in class org.apache.camel.CamelTemplate
 
sendBodyAndHeader(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint with a specified header and header value
sendBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified header and header value
sendBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified header and header value
sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified header and header value
sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified header and header value
sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.CamelTemplate
Sends the body to an endpoint with the specified headers and header values
sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.CamelTemplate
Sends the body to an endpoint with the specified headers and header values
sendBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.CamelTemplate
 
sendBodyAndHeaders(Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint with the specified headers and header values
sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values
sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values
sendExchange(Endpoint<E>, Producer<E>, Processor, E) - Method in class org.apache.camel.util.ProducerCache
 
sendExchange(Endpoint<E>, Producer<E>, Processor, E, AsyncCallback) - Method in class org.apache.camel.util.ProducerCache
 
sendMessages(long, long) - Method in class org.apache.camel.component.dataset.DataSetConsumer
 
SendProcessor - Class in org.apache.camel.processor
 
SendProcessor(Endpoint) - Constructor for class org.apache.camel.processor.SendProcessor
 
sendTimerExchange() - Method in class org.apache.camel.component.timer.TimerConsumer
 
SEPARATOR - Static variable in class org.apache.camel.util.jndi.JndiContext
 
Sequence<E> - Class in org.apache.camel.processor.resequencer
A sorted set of elements with additional methods for obtaining immediate successors and immediate predecessors of a given element in the sequence.
Sequence(SequenceElementComparator<E>) - Constructor for class org.apache.camel.processor.resequencer.Sequence
Creates a new Sequence instance.
SequenceElementComparator<E> - Interface in org.apache.camel.processor.resequencer
A strategy for comparing elements of a sequence.
SequenceSender - Class in org.apache.camel.processor.resequencer
A thread that takes re-ordered Exchanges from a blocking queue and send them to the linked processor.
SequenceSender(Processor) - Constructor for class org.apache.camel.processor.resequencer.SequenceSender
Creates a new SequenceSender thread.
serialization() - Method in class org.apache.camel.builder.DataFormatClause
Uses the Java Serialization data format
SerializationDataFormat - Class in org.apache.camel.impl
The data format using Java Serialiation.
SerializationDataFormat() - Constructor for class org.apache.camel.impl.SerializationDataFormat
 
SerializationDataFormat - Class in org.apache.camel.model.dataformat
Represents the Java Serialization DataFormat
SerializationDataFormat() - Constructor for class org.apache.camel.model.dataformat.SerializationDataFormat
 
Service - Interface in org.apache.camel
Represents the core lifecycle API for POJOs which can be started and stopped
ServiceActivationType - Class in org.apache.camel.model
 
ServiceActivationType() - Constructor for class org.apache.camel.model.ServiceActivationType
 
ServiceHelper - Class in org.apache.camel.util
A collection of helper methods for working with Service objects
ServiceSupport - Class in org.apache.camel.impl
A useful base class which ensures that a service is only initialized once and provides some helper methods for enquiring of its status
ServiceSupport() - Constructor for class org.apache.camel.impl.ServiceSupport
 
set(V) - Method in class org.apache.camel.util.Out
 
setAction(String) - Method in class org.apache.camel.processor.ThroughputLogger
 
setAggregationCollection(AggregationCollection) - Method in class org.apache.camel.model.AggregatorType
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.AggregatorType
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.MulticastType
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.SplitterType
 
setAllowMultipleConsumers(boolean) - Method in class org.apache.camel.component.direct.DirectEndpoint
 
setAppend(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
When writing do we append to the end of the file, or replace it? The default is to append
setArgs(Object[]) - Method in class org.apache.camel.component.bean.BeanInvocation
 
setAttachments(Map<String, DataHandler>) - Method in class org.apache.camel.impl.DefaultMessage
 
setAttachments(Map<String, DataHandler>) - Method in interface org.apache.camel.Message
Set all the attachments associated with this message
setAttributeName(String) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
setAutoCreate(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
 
setAutoCreateComponents(boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setBackOffMultiplier(Double) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
setBackOffMultiplier(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the multiplier used to increase the delay between redeliveries if RedeliveryPolicy.setUseExponentialBackOff(boolean) is enabled
setBatchConfig(BatchResequencerConfig) - Method in class org.apache.camel.model.ResequencerType
 
setBatchSize(Integer) - Method in class org.apache.camel.model.AggregatorType
 
setBatchSize(int) - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
setBatchSize(int) - Method in class org.apache.camel.processor.BatchProcessor
 
setBatchTimeout(Long) - Method in class org.apache.camel.model.AggregatorType
 
setBatchTimeout(long) - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
setBatchTimeout(long) - Method in class org.apache.camel.processor.BatchProcessor
 
setBean(Object) - Method in class org.apache.camel.model.BeanRef
 
setBeanType(Class) - Method in class org.apache.camel.model.BeanRef
 
setBody(Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
Creates a processor which sets the body of the IN message to the value of the expression
setBody(Message) - Method in class org.apache.camel.builder.xml.DomResultHandler
 
setBody(Message) - Method in interface org.apache.camel.builder.xml.ResultHandler
 
setBody(Message) - Method in class org.apache.camel.builder.xml.StreamResultHandler
 
setBody(Message) - Method in class org.apache.camel.builder.xml.StringResultHandler
 
setBody(Object) - Method in class org.apache.camel.impl.MessageSupport
 
setBody(Object, Class<T>) - Method in class org.apache.camel.impl.MessageSupport
 
setBody(Object) - Method in interface org.apache.camel.Message
Sets the body of the message
setBody(Object, Class<T>) - Method in interface org.apache.camel.Message
Sets the body of the message as a specific type
setBody() - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the body on the IN message
setBody(Expression) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the body on the IN message
setBodyFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setBufferSize(int) - Method in class org.apache.camel.component.file.FileEndpoint
Sets the buffer size used to read/write files
setCamelContext(CamelContext) - Method in interface org.apache.camel.CamelContextAware
Injects the CamelContext
setCamelContext(CamelContext) - Method in interface org.apache.camel.Component
The CamelContext is injected into the component when it is added to it
setCamelContext(CamelContext) - Method in interface org.apache.camel.Endpoint
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultComponent
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultEndpoint
 
setCamelContext(CamelContext) - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
setCamelContext(CamelContext) - Method in class org.apache.camel.model.RoutesType
 
setCamelContext(CamelContext) - Method in class org.apache.camel.model.RouteType
 
setCapacity(int) - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
setCharset(String) - Method in class org.apache.camel.model.dataformat.StringDataFormat
 
setClassLoaders(Set<ClassLoader>) - Method in class org.apache.camel.util.ResolverUtil
Sets the ClassLoader instances that should be used when scanning for classes.
setCollisionAvoidanceFactor(Double) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
setCollisionAvoidanceFactor(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the factor used for collision avoidence if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setCollisionAvoidancePercent(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the percentage used for collision avoidence if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setComparator(ExpressionResultComparator<Exchange>) - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
setCompletePredicate(CompletedPredicate) - Method in class org.apache.camel.model.AggregatorType
 
setCompletePredicate(ExpressionType) - Method in class org.apache.camel.model.CompletedPredicate
 
setComponentResolver(ComponentResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setConsumeDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Allows a delay to be specified which causes consumers to pause - to simulate slow consumers
setConsumerProperties(Map) - Method in class org.apache.camel.impl.ScheduledPollEndpoint
 
setContentType(ArtixDSContentType) - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
setContext(CamelContext) - Method in class org.apache.camel.builder.BuilderSupport
 
setContext(Context) - Method in class org.apache.camel.impl.JndiRegistry
 
setContextPath(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
setConverter(XmlConverter) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
setCoreSize(int) - Method in class org.apache.camel.model.ThreadType
 
setCoreSize(int) - Method in class org.apache.camel.processor.ThreadProcessor
 
setCorrelationExpression(Expression<Exchange>) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
setDaemon(boolean) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setDaemon(boolean) - Method in class org.apache.camel.model.ThreadType
 
setDaemon(boolean) - Method in class org.apache.camel.processor.ThreadProcessor
 
setDataFormatType(DataFormatType) - Method in class org.apache.camel.model.MarshalType
 
setDataFormatType(DataFormatType) - Method in class org.apache.camel.model.UnmarshalType
 
setDataSet(DataSet) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
setDeadLetterFactory(ProcessorFactory) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the default dead letter queue factory
setDefaultBody(Object) - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
setDefaultDeadLetterEndpoint(Processor) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the default dead letter endpoint used
setDefaultDeadLetterEndpointExpression(Expression) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the expression used to decide the dead letter channel endpoint for an exchange if no factory is provided via DeadLetterChannelBuilder.setDeadLetterFactory(ProcessorFactory)
setDefaultDeadLetterEndpointUri(String) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the default dead letter endpoint URI used if no factory is provided via DeadLetterChannelBuilder.setDeadLetterFactory(ProcessorFactory) and no expression is provided via DeadLetterChannelBuilder.setDefaultDeadLetterEndpointExpression(Expression)
setDefaultEndpoint(Endpoint<E>) - Method in class org.apache.camel.CamelTemplate
 
setDefaultEndpointUri(String) - Method in class org.apache.camel.CamelTemplate
Sets the default endpoint to use if none is specified
setDefaultHeaders(Map<String, Object>) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
setDelay(long) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setDelay(long) - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
setDelay(Long) - Method in class org.apache.camel.model.DelayerType
 
setDelay(long) - Method in class org.apache.camel.processor.Delayer
Sets the delay from the publish time; which is typically the time from the expression or the current system time if none is available
setDelete(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
 
setDir(String) - Method in class org.apache.camel.view.GraphGeneratorSupport
Sets the destination directory in which to create the diagrams
setDocumentBuilderFactory(DocumentBuilderFactory) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
setDocumentType(Class) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setDomainName(String) - Method in class org.apache.camel.management.CamelNamingStrategy
 
setElementType(Class<?>) - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
setElementTypeName(String) - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
setEndpoint(Endpoint) - Method in class org.apache.camel.model.FromType
 
setEndpoint(Endpoint) - Method in class org.apache.camel.model.ToType
 
setEndpoint(Endpoint<E>) - Method in class org.apache.camel.Route
 
setErrorHandler(ValidatorErrorHandler) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.builder.BuilderSupport
Sets the error handler to use with processors created by this builder
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.builder.RouteBuilder
 
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.model.ProcessorType
Sets the error handler to use with processors created by this builder
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.model.RoutesType
 
setException(Throwable) - Method in interface org.apache.camel.Exchange
Sets the exception associated with this exchange
setException(Throwable) - Method in class org.apache.camel.impl.DefaultExchange
 
setExceptionClasses(List<Class>) - Method in class org.apache.camel.model.CatchType
 
setExceptionClasses(List<Class>) - Method in class org.apache.camel.model.ExceptionType
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.impl.DefaultConsumer
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.impl.PollingConsumerSupport
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.BatchProcessor
 
setExceptionPolicy(ExceptionPolicyStrategy) - Method in class org.apache.camel.processor.ErrorHandlerSupport
Sets the strategy to use for resolving the ExceptionType to use for handling thrown exceptions.
setExceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
setExceptions(List<String>) - Method in class org.apache.camel.model.CatchType
 
setExceptions(List<String>) - Method in class org.apache.camel.model.ExceptionType
 
setExceptions(List<ExceptionType>) - Method in class org.apache.camel.model.RoutesType
 
setExchange(Exchange) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
setExchange(Exchange) - Method in class org.apache.camel.impl.MessageSupport
 
setExchangeConverter(ExchangeConverter) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setExchangeId(String) - Method in interface org.apache.camel.Exchange
Set the exchange id
setExchangeId(String) - Method in class org.apache.camel.impl.DefaultExchange
 
setExchangePattern(ExchangePattern) - Method in class org.apache.camel.impl.DefaultEndpoint
 
setExcludedNamePostfixes(String[]) - Method in class org.apache.camel.component.file.FileEndpoint
Sets the excluded file name postfixes, such as FileProcessStrategySupport.DEFAULT_LOCK_FILE_POSTFIX to ignore lock files by default.
setExcludedNamePrefixes(String[]) - Method in class org.apache.camel.component.file.FileEndpoint
Sets the excluded file name prefixes, such as "." for hidden files which are excluded by default
setExecutor(ThreadPoolExecutor) - Method in class org.apache.camel.model.ThreadType
 
setExecutor(ThreadPoolExecutor) - Method in class org.apache.camel.processor.ThreadProcessor
 
setExecutor(ScheduledExecutorService) - Method in class org.apache.camel.util.DefaultTimeoutMap
Sets the executor used to schedule purge events of inactive requests
setExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.impl.DefaultComponent
 
setExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.impl.DefaultEndpoint
 
setExpectedMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies the expected number of message exchanges that should be received by this endpoint
setExpireTime(long) - Method in class org.apache.camel.util.TimeoutMapEntry
 
setExpression(Expression) - Method in class org.apache.camel.component.bean.ParameterInfo
 
setExpression(ExpressionType) - Method in class org.apache.camel.model.ExpressionNode
 
setExpression(String) - Method in class org.apache.camel.model.language.ExpressionType
 
setExpression(Expression<Exchange>) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
setExpressions(List<Expression>) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
setExpressions(List<Expression>) - Method in interface org.apache.camel.processor.resequencer.ExpressionResultComparator
Sets the list expressions used for comparing Exchanges.
setExpressionType(ExpressionType) - Method in class org.apache.camel.model.language.ExpressionType
Allows derived classes to set a lazily created expressionType instance such as if using the ExpressionClause
setExpressionType(ExpressionType) - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
setExpressionValue(Expression) - Method in class org.apache.camel.model.language.ExpressionType
 
setFailOnNullBody(boolean) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
setFailureHandled(Exchange, boolean) - Static method in class org.apache.camel.processor.DeadLetterChannel
 
setFastStop(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
Enables & disables a fast stop; basically to avoid waiting a possibly long time for delays to complete before the context shuts down; instead the current processing method throws AlreadyStoppedException to terminate processing.
setFault(Message) - Method in class org.apache.camel.impl.DefaultExchange
 
setFault(Throwable) - Method in class org.apache.camel.model.ThrowFaultType
 
setFaultBody(Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
Creates a processor which sets the body of the FAULT message to the value of the expression
setFaultBody(Expression) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the body on the FAULT message
setFaultHeader(String, Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
Sets the header on the FAULT message
setFaultHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the header on the FAULT message
setFaultRef(String) - Method in class org.apache.camel.model.ThrowFaultType
 
setFile(File) - Method in class org.apache.camel.component.file.FileExchange
 
setFile(File) - Method in class org.apache.camel.component.file.FileMessage
 
setFileStrategy(FileProcessStrategy) - Method in class org.apache.camel.component.file.FileEndpoint
Sets the strategy to be used when the file has been processed such as deleting or renaming it etc.
setFixedRate(boolean) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setFormat(String) - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
setFunctionResolver(XPathFunctionResolver) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setGenerateEmptyExchangeWhenIdle(boolean) - Method in class org.apache.camel.component.file.FileConsumer
 
setGranularityPeriod(long) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
setGroup(String) - Method in class org.apache.camel.model.RouteType
 
setGroup(String) - Method in class org.apache.camel.model.ServiceActivationType
 
setGroupSize(int) - Method in class org.apache.camel.processor.ThroughputLogger
 
setHeader(String, Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
Sets the header on the IN message
setHeader(String, Object) - Method in class org.apache.camel.impl.DefaultMessage
 
setHeader(String, Object) - Method in interface org.apache.camel.Message
Sets a header on the message
setHeader(String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the header on the IN message
setHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the header on the IN message
setHeader(String, String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the header on the IN message to the given value
setHeaderFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setHeaderName(String) - Method in class org.apache.camel.model.RoutingSlipType
 
setHeaderName(String) - Method in class org.apache.camel.model.SetHeaderType
 
SetHeaderProcessor - Class in org.apache.camel.processor
A processor which sets the header on the IN message
SetHeaderProcessor(String, Expression) - Constructor for class org.apache.camel.processor.SetHeaderProcessor
 
SetHeaderProcessor(String, Expression, Processor) - Constructor for class org.apache.camel.processor.SetHeaderProcessor
 
setHeaders(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultMessage
 
setHeaders(Map<String, Object>) - Method in interface org.apache.camel.Message
Set all the headers associated with this message
SetHeaderType - Class in org.apache.camel.model
 
SetHeaderType() - Constructor for class org.apache.camel.model.SetHeaderType
 
SetHeaderType(String, ExpressionType) - Constructor for class org.apache.camel.model.SetHeaderType
 
SetHeaderType(String, Expression) - Constructor for class org.apache.camel.model.SetHeaderType
 
SetHeaderType(String, String) - Constructor for class org.apache.camel.model.SetHeaderType
 
setHostName(String) - Method in class org.apache.camel.management.CamelNamingStrategy
 
setId(String) - Method in class org.apache.camel.model.IdentifiedType
Sets the value of the id property.
setId(String) - Method in class org.apache.camel.model.language.ExpressionType
Sets the value of the id property.
setIgnoreFileNameHeader(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
If this flag is enabled then producers will ignore the FileComponent.HEADER_FILE_NAME header and generate a new dynamic file
setIn(Message) - Method in interface org.apache.camel.Exchange
Sets the inbound message instance
setIn(Message) - Method in class org.apache.camel.impl.DefaultExchange
 
setInheritErrorHandler(boolean) - Method in class org.apache.camel.builder.BuilderSupport
 
setInheritErrorHandler(boolean) - Method in class org.apache.camel.builder.RouteBuilder
 
setInheritErrorHandlerFlag(Boolean) - Method in class org.apache.camel.model.ProcessorType
 
setInheritErrorHandlerFlag(Boolean) - Method in class org.apache.camel.model.RoutesType
 
setInitialDelay(long) - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
setInitialRedeliveryDelay(Long) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
setInitialRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the initial redelivery delay in milliseconds on the first redelivery
setInjector(Injector) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
setInjector(Injector) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setInputFactory(XMLInputFactory) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
setInputs(List<FromType>) - Method in class org.apache.camel.model.RouteType
 
setInputTransformer(Processor) - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
setInterceptorLogic(Processor) - Method in class org.apache.camel.processor.Interceptor
 
setInterceptors(List<InterceptorType>) - Method in class org.apache.camel.model.RoutesType
 
setInterceptors(List<InterceptorType>) - Method in class org.apache.camel.model.RouteType
 
setIntercepts(List<InterceptType>) - Method in class org.apache.camel.model.RoutesType
 
setInteruptedExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
setInvocation(BeanInvocation) - Method in class org.apache.camel.component.bean.BeanExchange
 
setKeepAliveTime(long) - Method in class org.apache.camel.model.ThreadType
 
setKeepAliveTime(long) - Method in class org.apache.camel.processor.ThreadProcessor
 
setLanguage(String) - Method in class org.apache.camel.builder.ExpressionClause
 
setLanguage(String) - Method in class org.apache.camel.model.language.LanguageExpression
 
setLanguageResolver(LanguageResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setLevel(LoggingLevel) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
setLevel(LoggingLevel) - Method in class org.apache.camel.processor.Logger
 
setLevel(LoggingLevel) - Method in class org.apache.camel.processor.LoggingErrorHandler
 
setLifecycleStrategy(LifecycleStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setLoadBalancer(LoadBalancer) - Method in class org.apache.camel.model.LoadBalanceType
 
setLoadBalancer(QueueLoadBalancer) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
setLoadBalancerType(LoadBalancerType) - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
setLoadBalancerType(LoadBalancerType) - Method in class org.apache.camel.model.LoadBalanceType
 
setLock(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
 
setLockFile(boolean) - Method in class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
setLockFileRenamer(FileRenamer) - Method in class org.apache.camel.component.file.strategy.FileProcessStrategySupport
 
setLog(Log) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
setLog(Log) - Method in class org.apache.camel.processor.Logger
 
setLog(Log) - Method in class org.apache.camel.processor.LoggingErrorHandler
 
setLogger(Logger) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
setLogger(Logger) - Method in class org.apache.camel.processor.DeadLetterChannel
Sets the logger strategy; which Log to use and which LoggingLevel to use
setMaximumRedeliveries(Integer) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
setMaximumRedeliveries(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered.
setMaximumRequestsPerPeriod(Long) - Method in class org.apache.camel.model.ThrottlerType
 
setMaximumRequestsPerPeriod(long) - Method in class org.apache.camel.processor.Throttler
Sets the maximum number of requests per time period
setMaxSize(int) - Method in class org.apache.camel.model.ThreadType
 
setMaxSize(int) - Method in class org.apache.camel.processor.ThreadProcessor
 
setMbeanServer(MBeanServer) - Method in class org.apache.camel.component.jmx.JMXComponent
 
setMbeanServer(MBeanServer) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
setMBeanServer(MBeanServer) - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
setMessageId(String) - Method in class org.apache.camel.impl.MessageSupport
 
setMessageId(String) - Method in interface org.apache.camel.Message
Sets the id of the message
setMessageIdRepository(MessageIdRepository) - Method in class org.apache.camel.model.IdempotentConsumerType
 
setMessageIdRepositoryRef(String) - Method in class org.apache.camel.model.IdempotentConsumerType
 
setMethod(Method) - Method in class org.apache.camel.component.bean.BeanInvocation
 
setMethod(String) - Method in class org.apache.camel.component.bean.BeanProcessor
Sets the method name to use
setMethod(String) - Method in class org.apache.camel.model.BeanRef
 
setMethod(String) - Method in class org.apache.camel.model.language.MethodCallExpression
 
setMethodName(String) - Method in class org.apache.camel.component.bean.BeanProcessor
Deprecated.  
setMethodObject(Method) - Method in class org.apache.camel.component.bean.BeanProcessor
 
setMinimumExpectedMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
Specifies the minimum number of expected message exchanges that should be received by this endpoint
setMoveNamePostfix(String) - Method in class org.apache.camel.component.file.FileEndpoint
Sets the name postfix appended to moved files.
setMoveNamePrefix(String) - Method in class org.apache.camel.component.file.FileEndpoint
Sets the name prefix appended to moved files.
setName(String) - Method in class org.apache.camel.component.bean.MethodBean
 
setName(String) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
setName(String) - Method in class org.apache.camel.impl.DefaultCamelContext
Sets the name of the this context.
setName(String) - Method in class org.apache.camel.model.ThreadType
 
setName(String) - Method in class org.apache.camel.processor.ThreadProcessor
 
setNamePostfix(String) - Method in class org.apache.camel.component.file.strategy.DefaultFileRenamer
Sets the name postfix appended to moved files.
setNamePrefix(String) - Method in class org.apache.camel.component.file.strategy.DefaultFileRenamer
Sets the name prefix appended to moved files.
setNamespaceContext(DefaultNamespaceContext) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setNamespaceIfNotPresent(DefaultNamespaceContext, String, String) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setNamespaces(Map<String, String>) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
 
setNamespaces(Map<String, String>) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setNamespaces(Map<String, String>) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
Injects the XML Namespaces of prefix -> uri mappings
setNamespaces(Map<String, String>) - Method in interface org.apache.camel.spi.NamespaceAware
Injects the XML Namespaces of prefix -> uri mappings
setNamingStrategy(CamelNamingStrategy) - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
setNamingStrategy(CamelNamingStrategy) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
setNodeFactory(NodeFactory) - Method in class org.apache.camel.model.ProcessorType
 
setNoop(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
If set to true then the default FileProcessStrategy will be to use the NoOpFileProcessStrategy to not move or copy processed files
setNumberFormat(NumberFormat) - Method in class org.apache.camel.processor.ThroughputLogger
 
setNumberOfHashGroups(int) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
setOffset(Number) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
setOtherwise(OtherwiseType) - Method in class org.apache.camel.model.ChoiceType
 
setOut(Message) - Method in interface org.apache.camel.Exchange
Sets the outbound message
setOut(Message) - Method in class org.apache.camel.impl.DefaultExchange
 
setOutBody(Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
Creates a processor which sets the body of the OUT message to the value of the expression
setOutBody(Expression) - Method in class org.apache.camel.model.ProcessorType
Deprecated. Please use ProcessorType.transform(Expression) instead
setOutBody() - Method in class org.apache.camel.model.ProcessorType
Deprecated. Please use ProcessorType.transform() instead
setOutBodyFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setOutHeader(String, Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
Sets the header on the OUT message
setOutHeader(String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the header on the OUT message
setOutHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the header on the OUT message
setOutHeader(String, String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the header on the OUT message
setOutHeaderFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setOutputFactory(XMLOutputFactory) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
setOutputs(List<ProcessorType<?>>) - Method in class org.apache.camel.model.CatchType
 
setOutputs(List<ProcessorType<?>>) - Method in class org.apache.camel.model.ExceptionType
 
setOutputs(List<ProcessorType<?>>) - Method in class org.apache.camel.model.ExpressionNode
 
setOutputs(List<ProcessorType<?>>) - Method in class org.apache.camel.model.OutputType
 
setOutputs(List<ProcessorType<?>>) - Method in class org.apache.camel.model.ResequencerType
 
setOutputs(List<ProcessorType<?>>) - Method in class org.apache.camel.model.RouteType
 
setOutputs(List<ProcessorType<?>>) - Method in class org.apache.camel.model.ThrottlerType
 
setOutputs(List<ProcessorType<?>>) - Method in class org.apache.camel.model.TryType
 
setOutputTransformer(Processor) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
setOutQueue(Queue<E>) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Sets the output queue.
setParallelProcessing(boolean) - Method in class org.apache.camel.model.MulticastType
 
setParallelProcessing(boolean) - Method in class org.apache.camel.model.SplitterType
 
setParameterMappingStrategy(ParameterMappingStrategy) - Method in class org.apache.camel.component.bean.BeanComponent
 
setParameterMappingStrategy(ParameterMappingStrategy) - Method in class org.apache.camel.component.bean.RegistryBean
 
setParameters(Map<String, Object>) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
setParameterTypes(Class<?>[]) - Method in class org.apache.camel.component.bean.MethodBean
 
setParent(ProcessorType<? extends ProcessorType>) - Method in class org.apache.camel.model.ProcessorType
 
setPattern(ExchangePattern) - Method in class org.apache.camel.impl.DefaultExchange
 
setPeriod(long) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setPredicate(Predicate) - Method in class org.apache.camel.model.CompletedPredicate
 
setPreloadSize(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Sets how many messages should be preloaded (sent) before the route completes its initialisation
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.XMLBeansDataFormat
 
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
setPriority(int) - Method in class org.apache.camel.model.ThreadType
 
setPriority(int) - Method in class org.apache.camel.processor.ThreadProcessor
 
setProcessedSync(Exchange, boolean) - Static method in class org.apache.camel.util.ProducerCache
 
setProcessor(Processor) - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
setProcessor(AsyncProcessor) - Method in class org.apache.camel.processor.DelegateAsyncProcessor
 
setProcessor(Processor) - Method in class org.apache.camel.processor.DelegateProcessor
 
setProduceDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Allows a delay to be specified which causes producers to pause - to simpulate slow producers
setProperties(Object, Map) - Method in class org.apache.camel.impl.DefaultComponent
Sets the bean properties on the given bean
setProperties(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultExchange
 
setProperties(Object, Map, String) - Static method in class org.apache.camel.util.IntrospectionSupport
 
setProperties(TypeConverter, Object, Map) - Static method in class org.apache.camel.util.IntrospectionSupport
 
setProperties(Object, Map) - Static method in class org.apache.camel.util.IntrospectionSupport
 
setProperty(String, Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
Sets the property on the exchange
setProperty(String, Object) - Method in interface org.apache.camel.Exchange
Sets a property on the exchange
setProperty(String, Object) - Method in class org.apache.camel.impl.DefaultExchange
 
setProperty(Object, String, Object) - Method in class org.apache.camel.model.dataformat.DataFormatType
Sets a named property on the data format instance using introspection
setProperty(Object, String, Object) - Method in class org.apache.camel.model.language.ExpressionType
Sets a named property on the object instance using introspection
setProperty(Object, String, Object) - Method in class org.apache.camel.model.loadbalancer.LoadBalancerType
Sets a named property on the data format instance using introspection
setProperty(String, Expression) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the exchange property
setProperty(String) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the exchange property
setProperty(TypeConverter, Object, String, Object) - Static method in class org.apache.camel.util.IntrospectionSupport
 
setProperty(Object, String, Object) - Static method in class org.apache.camel.util.IntrospectionSupport
 
setPurgePollTime(long) - Method in class org.apache.camel.util.DefaultTimeoutMap
Sets the next purge poll time in milliseconds
setQueue(BlockingQueue<Exchange>) - Method in class org.apache.camel.processor.resequencer.SequenceSender
Sets the BlockingQueue to take messages from.
setRecursive(boolean) - Method in class org.apache.camel.component.file.FileConsumer
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
Sets the redelivery policy
setRedeliveryPolicy(RedeliveryPolicyType) - Method in class org.apache.camel.model.ExceptionType
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.apache.camel.processor.DeadLetterChannel
Sets the redelivery policy
setRef(String) - Method in class org.apache.camel.model.BeanRef
 
setRef(String) - Method in class org.apache.camel.model.FromType
Sets the name of the endpoint within the registry (such as the Spring ApplicationContext or JNDI) to use
setRef(String) - Method in class org.apache.camel.model.InterceptorRef
 
setRef(String) - Method in class org.apache.camel.model.LoadBalanceType
 
setRef(String) - Method in class org.apache.camel.model.MarshalType
 
setRef(String) - Method in class org.apache.camel.model.PolicyRef
 
setRef(String) - Method in class org.apache.camel.model.ProcessorRef
 
setRef(String) - Method in class org.apache.camel.model.RouteBuilderRef
 
setRef(String) - Method in class org.apache.camel.model.ToType
Sets the name of the endpoint within the registry (such as the Spring ApplicationContext or JNDI) to use
setRef(String) - Method in class org.apache.camel.model.UnmarshalType
 
setRegexPattern(String) - Method in class org.apache.camel.component.file.FileConsumer
 
setRegistry(Registry) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setRenamer(FileRenamer) - Method in class org.apache.camel.component.file.strategy.RenameFileProcessStrategy
 
setReportCount(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
Sets the number of messages in a group on which we will report that messages have been received.
setReporter(Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
Allows a processor to added to the endpoint to report on progress of the test
setResultHandlerFactory(ResultHandlerFactory) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
setResultQName(QName) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setResultType(Class) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setResultType(QName) - Method in class org.apache.camel.builder.xml.XPathLanguage
 
setResultType(Class) - Method in class org.apache.camel.model.language.XPathExpression
 
setResultType(Class) - Method in class org.apache.camel.model.language.XQueryExpression
 
setResultWaitTime(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets the maximum amount of time (in millis) the MockEndpoint.assertIsSatisfied() will wait on a latch until it is satisfied
setRouteCollection(RoutesType) - Method in class org.apache.camel.builder.RouteBuilder
 
setRoutes(List<Route>) - Method in interface org.apache.camel.CamelContext
Sets the routes for this context, replacing any current routes
setRoutes(List<Route>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setRoutes(List<RouteType>) - Method in interface org.apache.camel.model.RouteContainer
Sets the routes to use
setRoutes(List<RouteType>) - Method in class org.apache.camel.model.RoutesType
 
setSchema(Schema) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
setSchemaFactory(SchemaFactory) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
setSchemaFile(File) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
setSchemaLanguage(String) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
setSchemaSource(Source) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
setSchemaUrl(URL) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
setSeparator(String) - Method in class org.apache.camel.util.CollectionStringBuffer
 
setServices(List<Service>) - Method in class org.apache.camel.Route
 
setSize(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
setSleepForEmptyTest(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Allows a sleep to be specified to wait to check that this endpoint really is empty when MockEndpoint.expectedMessageCount(int) is called with zero
setStackSize(long) - Method in class org.apache.camel.model.ThreadType
 
setStackSize(long) - Method in class org.apache.camel.processor.ThreadProcessor
 
setStrategyRef(String) - Method in class org.apache.camel.model.AggregatorType
 
setStreamConfig(StreamResequencerConfig) - Method in class org.apache.camel.model.ResequencerType
 
setTaskQueue(BlockingQueue<Runnable>) - Method in class org.apache.camel.model.ThreadType
 
setTaskQueue(BlockingQueue<Runnable>) - Method in class org.apache.camel.processor.ThreadProcessor
 
setThreadGroup(ThreadGroup) - Method in class org.apache.camel.model.ThreadType
 
setThreadGroup(ThreadGroup) - Method in class org.apache.camel.processor.ThreadProcessor
 
setThreadPoolExecutor(ThreadPoolExecutor) - Method in class org.apache.camel.model.MulticastType
 
setThreadPoolExecutor(ThreadPoolExecutor) - Method in class org.apache.camel.model.SplitterType
 
setThreshold(Number) - Method in class org.apache.camel.component.jmx.JMXEndpoint
 
setTime(Date) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setTimeout(long) - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
setTimeout(long) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Sets this sequencer's timeout value.
setTimeout(long) - Method in class org.apache.camel.processor.StreamResequencer
 
setTimeout(long) - Method in class org.apache.camel.util.TimeoutMapEntry
 
setTimePeriodMillis(long) - Method in class org.apache.camel.model.ThrottlerType
 
setTimePeriodMillis(long) - Method in class org.apache.camel.processor.Throttler
Sets the time period during which the maximum number of requests apply
setTimer(Timer) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setTimerName(String) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setTimeUnit(TimeUnit) - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
setTransformer(Transformer) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
setTransformerFactory(TransformerFactory) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
setTransformerFile(File) - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the XSLT transformer from a File
setTransformerInputStream(InputStream) - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the XSLT transformer from the given input stream
setTransformerSource(Source) - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the XSLT transformer from a Source
setTransformerURL(URL) - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the XSLT transformer from a URL
setType(Class<?>) - Method in class org.apache.camel.component.bean.MethodBean
 
setType(String) - Method in class org.apache.camel.model.ConvertBodyType
 
setType(String) - Method in class org.apache.camel.model.language.XQueryExpression
 
setTypeClass(Class) - Method in class org.apache.camel.model.ConvertBodyType
 
setTypeConverter(TypeConverter) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setTypeConverter(TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterAware
 
setUnchangedDelay(int) - Method in class org.apache.camel.component.file.FileConsumer
 
setUnchangedSize(boolean) - Method in class org.apache.camel.component.file.FileConsumer
 
setUnitOfWork(UnitOfWork) - Method in interface org.apache.camel.Exchange
Sets the unit of work that this exchange belongs to; which may map to zero, one or more physical transactions
setUnitOfWork(UnitOfWork) - Method in class org.apache.camel.impl.DefaultExchange
 
setUri(String) - Method in class org.apache.camel.model.FromType
Sets the URI of the endpoint to use
setUri(String) - Method in class org.apache.camel.model.ToType
Sets the URI of the endpoint to use
setUriDelimiter(String) - Method in class org.apache.camel.model.RoutingSlipType
 
setUris(List<ExpressionType>) - Method in class org.apache.camel.model.ServiceActivationType
 
setUseCollisionAvoidance(Boolean) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
setUseCollisionAvoidance(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables/disables collision avoidence which adds some randomization to the backoff timings to reduce contention probability
setUseEndpointCache(boolean) - Method in class org.apache.camel.CamelTemplate
 
setUseExponentialBackOff(Boolean) - Method in class org.apache.camel.model.RedeliveryPolicyType
 
setUseExponentialBackOff(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables/disables exponential backof using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
setUseFixedDelay(boolean) - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
setValue(String) - Method in class org.apache.camel.model.SetHeaderType
 
setValue(Object) - Method in class org.apache.camel.util.TimeoutMapEntry
 
setWhenClauses(List<WhenType>) - Method in class org.apache.camel.model.ChoiceType
 
setXPathFactory(XPathFactory) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
shape - Variable in class org.apache.camel.view.NodeData
 
shouldRedeliver(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Returns true if the policy decides that the message exchange should be redelivered
shouldStartRoutes() - Method in class org.apache.camel.impl.DefaultCamelContext
Should we start newly added routes?
simple(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Simple expression
Simple - Annotation Type in org.apache.camel.language
Used to inject a simple expression into a field, property, method or parameter when using Bean Integration.
simple(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
 
SimpleDataSet - Class in org.apache.camel.component.dataset
A simple DataSet that allows a static payload to be used to create each message exchange along with using a pluggable transformer to randomize the message.
SimpleDataSet() - Constructor for class org.apache.camel.component.dataset.SimpleDataSet
 
SimpleDataSet(int) - Constructor for class org.apache.camel.component.dataset.SimpleDataSet
 
SimpleExpression - Class in org.apache.camel.model.language
For expresions and predicates using the SimpleExpression() - Constructor for class org.apache.camel.model.language.SimpleExpression
 
SimpleExpression(String) - Constructor for class org.apache.camel.model.language.SimpleExpression
 
SimpleLanguage - Class in org.apache.camel.language.simple
A SimpleLanguage() - Constructor for class org.apache.camel.language.simple.SimpleLanguage
 
simpleName(Class) - Static method in class org.apache.camel.util.IntrospectionSupport
 
size() - Method in class org.apache.camel.processor.aggregate.AggregationCollection
 
size() - Method in class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 
size(Object) - Static method in class org.apache.camel.util.CollectionHelper
Returns the size of the collection if it can be determined to be a collection
size() - Method in class org.apache.camel.util.DefaultTimeoutMap
 
size() - Method in interface org.apache.camel.util.TimeoutMap
 
sleep(long) - Method in class org.apache.camel.processor.DeadLetterChannel
 
sleep(long) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
SPLIT_COUNTER - Static variable in class org.apache.camel.processor.Splitter
 
SPLIT_SIZE - Static variable in class org.apache.camel.processor.Splitter
 
splitOnCharacter(String, String, int) - Static method in class org.apache.camel.util.ObjectHelper
 
splitter(Expression) - Method in class org.apache.camel.model.ProcessorType
Creates the Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
splitter() - Method in class org.apache.camel.model.ProcessorType
Creates the Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
splitter(Expression, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorType
Creates the Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
splitter(AggregationStrategy) - Method in class org.apache.camel.model.ProcessorType
Creates the Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
splitter(Expression, boolean) - Method in class org.apache.camel.model.ProcessorType
Creates the Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
splitter(boolean) - Method in class org.apache.camel.model.ProcessorType
Creates the Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
splitter(Expression, AggregationStrategy, boolean) - Method in class org.apache.camel.model.ProcessorType
Creates the Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
splitter(AggregationStrategy, boolean) - Method in class org.apache.camel.model.ProcessorType
Creates the Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
Splitter - Class in org.apache.camel.processor
Implements a dynamic Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
Splitter(Expression, Processor, AggregationStrategy) - Constructor for class org.apache.camel.processor.Splitter
 
Splitter(Expression, Processor, AggregationStrategy, boolean, ThreadPoolExecutor) - Constructor for class org.apache.camel.processor.Splitter
 
SplitterType - Class in org.apache.camel.model
 
SplitterType() - Constructor for class org.apache.camel.model.SplitterType
 
SplitterType(Expression) - Constructor for class org.apache.camel.model.SplitterType
 
SplitterType(ExpressionType) - Constructor for class org.apache.camel.model.SplitterType
 
sql(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an SQL expression
SqlExpression - Class in org.apache.camel.model.language
For SQL expresions and predicates
SqlExpression() - Constructor for class org.apache.camel.model.language.SqlExpression
 
SqlExpression(String) - Constructor for class org.apache.camel.model.language.SqlExpression
 
stackSize(long) - Method in class org.apache.camel.model.ThreadType
 
start() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
start() - Method in class org.apache.camel.impl.ServiceSupport
 
start() - Method in class org.apache.camel.management.ManagedRoute
 
start() - Method in class org.apache.camel.management.ManagedService
 
start() - Method in class org.apache.camel.processor.ThreadProcessor
 
start() - Method in interface org.apache.camel.Service
Starts the service
startRouteDefinitions(Collection<RouteType>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
startRoutes(Collection<Route>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
startService(Object) - Static method in class org.apache.camel.util.ServiceHelper
 
startServices(Object...) - Static method in class org.apache.camel.util.ServiceHelper
Starts all of the given services
startServices(Collection) - Static method in class org.apache.camel.util.ServiceHelper
Starts all of the given services
StaticMethodTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter implementation which invokes a static method to convert from a type to another type
StaticMethodTypeConverter(Method) - Constructor for class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
StaxConverter - Class in org.apache.camel.converter.jaxp
A converter of StAX objects
StaxConverter() - Constructor for class org.apache.camel.converter.jaxp.StaxConverter
 
sticky(Expression<Exchange>) - Method in class org.apache.camel.model.LoadBalanceType
 
StickyLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements a sticky load balancer using an Expression to calculate a correlation key to perform the sticky load balancing; rather like jsessionid in the web or JMSXGroupID in JMS.
StickyLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
StickyLoadBalancer(Expression<Exchange>) - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
StickyLoadBalancer(Expression<Exchange>, QueueLoadBalancer) - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
StickyLoadBalanceStrategy - Class in org.apache.camel.model.loadbalancer
 
StickyLoadBalanceStrategy() - Constructor for class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
StickyLoadBalanceStrategy(ExpressionType) - Constructor for class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
StickyLoadBalanceStrategy(ExpressionType, LoadBalancerType) - Constructor for class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
stop() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
stop() - Method in class org.apache.camel.impl.ServiceSupport
 
stop() - Method in class org.apache.camel.management.ManagedRoute
 
stop() - Method in class org.apache.camel.management.ManagedService
 
stop() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Stops this resequencer (i.e.
stop() - Method in class org.apache.camel.processor.ThreadProcessor
 
stop() - Method in interface org.apache.camel.Service
Stops the service
stopService(Object) - Static method in class org.apache.camel.util.ServiceHelper
 
stopServices(Object...) - Static method in class org.apache.camel.util.ServiceHelper
Stops all of the given services, throwing the first exception caught
stopServices(Collection) - Static method in class org.apache.camel.util.ServiceHelper
Stops all of the given services, throwing the first exception caught
stream() - Method in class org.apache.camel.model.ResequencerType
Configures the stream-based resequencing algorithm using the default configuration.
stream(StreamResequencerConfig) - Method in class org.apache.camel.model.ResequencerType
Configures the stream-based resequencing algorithm using the given StreamResequencerConfig.
StreamCache - Interface in org.apache.camel.converter.stream
Tagging interface to indicate that a type is capable of caching the underlying data stream.
StreamCacheConverter - Class in org.apache.camel.converter.stream
A set of Converter methods for wrapping stream-based messages in a StreamCache implementation to ensure message re-readability (e.g.
StreamCacheConverter() - Constructor for class org.apache.camel.converter.stream.StreamCacheConverter
 
streamCaching() - Method in class org.apache.camel.builder.RouteBuilder
Enable stream caching for all routes being defined in the same RouteBuilder after this call.
streamCaching() - Method in class org.apache.camel.model.RouteType
Enable stream caching for this Route.
StreamCachingInterceptor - Class in org.apache.camel.processor.interceptor
Interceptor that converts a message into a re-readable format
StreamCachingInterceptor() - Constructor for class org.apache.camel.processor.interceptor.StreamCachingInterceptor
 
StreamCachingInterceptor(Processor) - Constructor for class org.apache.camel.processor.interceptor.StreamCachingInterceptor
 
StreamResequencer - Class in org.apache.camel.processor
A resequencer that re-orders a (continuous) stream of Exchanges.
StreamResequencer(Processor, SequenceElementComparator<Exchange>, int) - Constructor for class org.apache.camel.processor.StreamResequencer
Creates a new StreamResequencer instance.
StreamResequencerConfig - Class in org.apache.camel.model.config
Defines the configuration parameters for the StreamResequencer.
StreamResequencerConfig() - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
Creates a new StreamResequencerConfig instance using default values for capacity (100) and timeout (1000L).
StreamResequencerConfig(int, long) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
Creates a new BatchResequencerConfig instance using the given values for capacity and timeout.
StreamResequencerConfig(int, long, ExpressionResultComparator<Exchange>) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
Creates a new BatchResequencerConfig instance using the given values for capacity and timeout.
StreamResultHandler - Class in org.apache.camel.builder.xml
Processes the XSLT result as a byte[]
StreamResultHandler() - Constructor for class org.apache.camel.builder.xml.StreamResultHandler
 
StreamResultHandlerFactory - Class in org.apache.camel.builder.xml
 
StreamResultHandlerFactory() - Constructor for class org.apache.camel.builder.xml.StreamResultHandlerFactory
 
string() - Method in class org.apache.camel.builder.DataFormatClause
Uses the String data format
string(String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the String data format supporting encoding using given charset
StringDataFormat - Class in org.apache.camel.impl
The text based data format supporting charset encoding.
StringDataFormat(String) - Constructor for class org.apache.camel.impl.StringDataFormat
 
StringDataFormat - Class in org.apache.camel.model.dataformat
Represents the String (text based) DataFormat
StringDataFormat() - Constructor for class org.apache.camel.model.dataformat.StringDataFormat
 
stringResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to boolean
StringResultHandler - Class in org.apache.camel.builder.xml
Processes the XSLT result as a String
StringResultHandler() - Constructor for class org.apache.camel.builder.xml.StringResultHandler
 
StringResultHandlerFactory - Class in org.apache.camel.builder.xml
 
StringResultHandlerFactory() - Constructor for class org.apache.camel.builder.xml.StringResultHandlerFactory
 
StringSource - Class in org.apache.camel.converter.jaxp
A helper class which provides a JAXP Source from a String which can be read as many times as required.
StringSource(String) - Constructor for class org.apache.camel.converter.jaxp.StringSource
 
StringSource(String, String) - Constructor for class org.apache.camel.converter.jaxp.StringSource
 
StringSource(String, String, String) - Constructor for class org.apache.camel.converter.jaxp.StringSource
 
stripPrefix(String, String) - Static method in class org.apache.camel.util.URISupport
 
stripScheme(URI) - Static method in class org.apache.camel.util.URISupport
 
successor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
successor(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the immediate successor of the given element in this sequence or null if no successor exists.
successor(E, E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if o1 is an immediate successor of o2.
Synchronization - Interface in org.apache.camel.spi
Provides a hook for custom Processor or Component instances to respond to completed or failed processing of an Exchange rather like Spring's TransactionSynchronization
SYSTEM_PROPERTIES_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
SYSTEM_PROPERTY_JMX - Static variable in class org.apache.camel.management.InstrumentationAgentImpl
 
SYSTEM_PROPERTY_JMX_USE_PLATFORM_MBS - Static variable in class org.apache.camel.management.InstrumentationAgentImpl
 
systemProperty(String) - Static method in class org.apache.camel.builder.Builder
Returns an expression for the given system property
systemProperty(String, String) - Static method in class org.apache.camel.builder.Builder
Returns an expression for the given system property
systemProperty(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a value builder for the given system property
systemProperty(String, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a value builder for the given system property
systemProperty(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the given system property
systemProperty(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the given system property
systemPropertyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for a system property value with the given name
systemPropertyExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for a system property value with the given name

T

taskQueue(BlockingQueue<Runnable>) - Method in class org.apache.camel.model.ThreadType
 
thread(int) - Method in class org.apache.camel.model.ProcessorType
Causes subsequent processors to be called asynchronously
thread(ThreadPoolExecutor) - Method in class org.apache.camel.model.ProcessorType
Causes subsequent processors to be called asynchronously
threadGroup(ThreadGroup) - Method in class org.apache.camel.model.ThreadType
 
ThreadProcessor - Class in org.apache.camel.processor
A processor that forces async processing of the exchange using a thread pool.
ThreadProcessor() - Constructor for class org.apache.camel.processor.ThreadProcessor
 
ThreadType - Class in org.apache.camel.model
Represents an XML <thread/> element
ThreadType() - Constructor for class org.apache.camel.model.ThreadType
 
ThreadType(int) - Constructor for class org.apache.camel.model.ThreadType
 
ThreadType(ThreadPoolExecutor) - Constructor for class org.apache.camel.model.ThreadType
 
throttler(long) - Method in class org.apache.camel.model.ProcessorType
Creates the Delayer pattern where an expression is used to calculate the time which the message will be dispatched on
Throttler - Class in org.apache.camel.processor
A Throttler will set a limit on the maximum number of message exchanges which can be sent to a processor within a specific time period.
Throttler(Processor, long) - Constructor for class org.apache.camel.processor.Throttler
 
Throttler(Processor, long, long) - Constructor for class org.apache.camel.processor.Throttler
 
ThrottlerType - Class in org.apache.camel.model
 
ThrottlerType() - Constructor for class org.apache.camel.model.ThrottlerType
 
ThrottlerType(long) - Constructor for class org.apache.camel.model.ThrottlerType
 
ThroughputLogger - Class in org.apache.camel.processor
 
ThroughputLogger() - Constructor for class org.apache.camel.processor.ThroughputLogger
 
ThroughputLogger(Log) - Constructor for class org.apache.camel.processor.ThroughputLogger
 
ThroughputLogger(Log, LoggingLevel) - Constructor for class org.apache.camel.processor.ThroughputLogger
 
ThroughputLogger(String) - Constructor for class org.apache.camel.processor.ThroughputLogger
 
ThroughputLogger(String, LoggingLevel) - Constructor for class org.apache.camel.processor.ThroughputLogger
 
ThroughputLogger(String, LoggingLevel, int) - Constructor for class org.apache.camel.processor.ThroughputLogger
 
ThroughputLogger(String, int) - Constructor for class org.apache.camel.processor.ThroughputLogger
 
ThroughputLogger(int) - Constructor for class org.apache.camel.processor.ThroughputLogger
 
throwException(Exception) - Static method in class org.apache.camel.builder.ProcessorBuilder
Throws an exception
throwException() - Method in class org.apache.camel.impl.DefaultExchange
 
throwFault(Throwable) - Method in class org.apache.camel.model.ProcessorType
 
throwFault(String) - Method in class org.apache.camel.model.ProcessorType
 
ThrowFaultProcessor - Class in org.apache.camel.processor
The processor which implements the ThrowFault DSL
ThrowFaultProcessor(Throwable) - Constructor for class org.apache.camel.processor.ThrowFaultProcessor
 
ThrowFaultType - Class in org.apache.camel.model
 
ThrowFaultType() - Constructor for class org.apache.camel.model.ThrowFaultType
 
Time - Class in org.apache.camel.util
A helper class for working with times in various units
Time(long, TimeUnit) - Constructor for class org.apache.camel.util.Time
 
timeout(Timeout) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Handles a timeout notification by starting a delivery attempt.
Timeout - Class in org.apache.camel.processor.resequencer
A timer task that notifies handlers about scheduled timeouts.
Timeout(Timer, long) - Constructor for class org.apache.camel.processor.resequencer.Timeout
Creates a new timeout task using the given Timer instance a timeout value.
timeout(Timeout) - Method in interface org.apache.camel.processor.resequencer.TimeoutHandler
Handles a timeout notification.
TimeoutHandler - Interface in org.apache.camel.processor.resequencer
Implemented by classes that handle timeout notifications.
TimeoutMap - Interface in org.apache.camel.util
Represents a thread safe map of values which timeout after a period of inactivity.
TimeoutMapEntry - Class in org.apache.camel.util
Represents an entry in a TimeoutMap
TimeoutMapEntry(Object, Object, long) - Constructor for class org.apache.camel.util.TimeoutMapEntry
 
timePeriodMillis(long) - Method in class org.apache.camel.model.ThrottlerType
Sets the time period during which the maximum request count is valid for
TimerComponent - Class in org.apache.camel.component.timer
Represents the component that manages TimerEndpoint.
TimerComponent() - Constructor for class org.apache.camel.component.timer.TimerComponent
 
TimerConsumer - Class in org.apache.camel.component.timer
 
TimerConsumer(TimerEndpoint, Processor) - Constructor for class org.apache.camel.component.timer.TimerConsumer
 
TimerEndpoint - Class in org.apache.camel.component.timer
Represents a timer endpoint that can generate periodic inbound PojoExchanges.
TimerEndpoint(String, TimerComponent, String) - Constructor for class org.apache.camel.component.timer.TimerEndpoint
 
TimerEndpoint(String, Timer) - Constructor for class org.apache.camel.component.timer.TimerEndpoint
 
TimerEndpoint(String) - Constructor for class org.apache.camel.component.timer.TimerEndpoint
 
to(String) - Method in class org.apache.camel.model.ProcessorType
Sends the exchange to the given endpoint URI
to(Endpoint) - Method in class org.apache.camel.model.ProcessorType
Sends the exchange to the given endpoint
to(String...) - Method in class org.apache.camel.model.ProcessorType
Sends the exchange to a list of endpoints using the MulticastProcessor pattern
to(Endpoint...) - Method in class org.apache.camel.model.ProcessorType
Sends the exchange to a list of endpoints using the MulticastProcessor pattern
to(Collection<Endpoint>) - Method in class org.apache.camel.model.ProcessorType
Sends the exchange to a list of endpoint using the MulticastProcessor pattern
toArray(Collection) - Static method in class org.apache.camel.converter.CollectionConverter
Converts a collection to an array
toBool(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Converts the given value to a boolean, handling strings or Boolean objects; otherwise returning false if the value could not be converted to a boolean
toBoolean(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Converts the given value to a Boolean, handling strings or Boolean objects; otherwise returning null if the value cannot be converted to a boolean
toBoolean(Boolean) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the boolean value, or null if the value is null
toByte(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toByteArray(ByteBuffer) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteArray(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toByteBuffer(byte[]) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(File) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(String) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Short) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Integer) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Long) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Float) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Double) - Static method in class org.apache.camel.converter.NIOConverter
 
toBytes(InputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toCharArray(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toDate() - Method in class org.apache.camel.util.Time
 
toDOMDocument(byte[]) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given data to a DOM document
toDOMDocument(InputStream) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given InputStream to a DOM document
toDOMDocument(Reader) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given InputStream to a DOM document
toDOMDocument(InputSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given InputSource to a DOM document
toDOMDocument(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given String to a DOM document
toDOMDocument(File) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given File to a DOM document
toDOMDocument(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Create a DOM document from the given source.
toDOMDocument(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Create a DOM document from the given Node.
toDOMElement(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Create a DOM element from the given source.
toDOMElement(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Create a DOM element from the DOM node.
toDOMNode(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given TRaX Source into a W3C DOM node
toDOMNodeFromSAX(SAXSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toDOMSource(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the source instance to a DOMSource or returns null if the conversion is not supported (making it easy to derive from this class to add new kinds of conversion).
toDOMSource(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the source instance to a DOMSource or returns null if the conversion is not supported (making it easy to derive from this class to add new kinds of conversion).
toDOMSourceFromSAX(SAXSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toDOMSourceFromStream(StreamSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toDouble(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toFile(String) - Static method in class org.apache.camel.converter.IOConverter
 
toFloat(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toHashMap(Map) - Static method in class org.apache.camel.converter.CollectionConverter
 
toHashtable(Map) - Static method in class org.apache.camel.converter.CollectionConverter
 
toInputStream(URL) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(File) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(String) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(BufferedReader) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(byte[]) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(ByteBuffer) - Static method in class org.apache.camel.converter.NIOConverter
 
toInputStrean(DOMSource) - Static method in class org.apache.camel.converter.IOConverter
 
toInteger(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
tokenize() - Method in class org.apache.camel.builder.ValueBuilder
 
tokenize(String) - Method in class org.apache.camel.builder.ValueBuilder
 
tokenize(Set<String>, String) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
Tokenizes the line from the META-IN/services file using commas and ignoring whitespace between packages
tokenizeExpression(Expression<E>, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a tokenize expression which will tokenize the string with the given token
toList(Object[]) - Static method in class org.apache.camel.converter.CollectionConverter
Converts an array to a collection
toList(Collection) - Static method in class org.apache.camel.converter.CollectionConverter
Converts a collection to a List if it is not already
toLong(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toMillis() - Method in class org.apache.camel.util.Time
 
toObjectInput(InputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toObjectOutput(OutputStream) - Static method in class org.apache.camel.converter.IOConverter
 
tooltop - Variable in class org.apache.camel.view.NodeData
 
toOutputStream(File) - Static method in class org.apache.camel.converter.IOConverter
 
topic() - Method in class org.apache.camel.model.LoadBalanceType
 
TopicLoadBalancer - Class in org.apache.camel.processor.loadbalancer
A LoadBalancer implementations which sends to all destinations (rather like JMS Topics)
TopicLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
 
TopicLoadBalanceStrategy - Class in org.apache.camel.model.loadbalancer
 
TopicLoadBalanceStrategy() - Constructor for class org.apache.camel.model.loadbalancer.TopicLoadBalanceStrategy
 
toPredicate(Expression<E>) - Static method in class org.apache.camel.builder.PredicateBuilder
Converts the given expression into an Predicate
toProcessor(Predicate<Exchange>) - Method in class org.apache.camel.converter.CamelConverter
 
toProcessor(Expression<Exchange>) - Method in class org.apache.camel.converter.CamelConverter
 
toProducers(Collection<Endpoint>) - Static method in class org.apache.camel.processor.MulticastProcessor
A helper method to convert a list of endpoints into a list of processors
toProperties(Map) - Static method in class org.apache.camel.converter.CollectionConverter
 
toReader(File) - Static method in class org.apache.camel.converter.IOConverter
 
toReader(InputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toReader(String) - Static method in class org.apache.camel.converter.IOConverter
 
toReaderFromSource(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toResult(Source, Result) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given input Source into the required result
toSAXSource(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the source instance to a SAXSource or returns null if the conversion is not supported (making it easy to derive from this class to add new kinds of conversion).
toSAXSource(InputStream) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the source instance to a SAXSource or returns null if the conversion is not supported (making it easy to derive from this class to add new kinds of conversion).
toSAXSource(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the source instance to a SAXSource or returns null if the conversion is not supported (making it easy to derive from this class to add new kinds of conversion).
toSAXSourceFromDOM(DOMSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toSAXSourceFromStream(StreamSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toSet(Object[]) - Static method in class org.apache.camel.converter.CollectionConverter
 
toSet(Collection) - Static method in class org.apache.camel.converter.CollectionConverter
 
toSet(Map) - Static method in class org.apache.camel.converter.CollectionConverter
 
toShort(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toSource(byte[]) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given byte[] to a Source
toSource(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given String to a Source
toSource(Document) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given Document to a Source
toSource(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given Node to a Source
toStreamSource(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toStreamSource(InputStream) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toStreamSource(Reader) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toStreamSource(File) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toStreamSource(byte[]) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toStreamSource(ByteBuffer) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toStreamSourceFromDOM(DOMSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toStreamSourceFromSAX(SAXSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toString() - Method in class org.apache.camel.builder.RouteBuilder
 
toString() - Method in class org.apache.camel.builder.ValueBuilder
 
toString() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
toString() - Method in class org.apache.camel.builder.xml.XsltBuilder
 
toString() - Method in class org.apache.camel.component.bean.BeanInvocation
 
toString() - Method in class org.apache.camel.component.bean.BeanProcessor
 
toString() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
toString() - Method in class org.apache.camel.component.bean.MethodInfo
 
toString() - Method in class org.apache.camel.component.bean.RegistryBean
 
toString() - Method in class org.apache.camel.component.file.FileMessage
 
toString() - Method in class org.apache.camel.component.jmx.JMXMessage
 
toString() - Method in class org.apache.camel.component.seda.SedaConsumer
 
toString(byte[]) - Static method in class org.apache.camel.converter.IOConverter
 
toString(File) - Static method in class org.apache.camel.converter.IOConverter
 
toString(URL) - Static method in class org.apache.camel.converter.IOConverter
 
toString(Reader) - Static method in class org.apache.camel.converter.IOConverter
 
toString(BufferedReader) - Static method in class org.apache.camel.converter.IOConverter
 
toString(InputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toString(Source) - Static method in class org.apache.camel.converter.IOConverter
 
toString(Source, Properties) - Static method in class org.apache.camel.converter.IOConverter
 
toString() - Method in class org.apache.camel.converter.jaxp.BytesSource
 
toString(NodeList) - Static method in class org.apache.camel.converter.jaxp.DomConverter
 
toString() - Method in class org.apache.camel.converter.jaxp.StringSource
 
toString(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given input Source into text
toString(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given input Node into text
toString(ByteBuffer) - Static method in class org.apache.camel.converter.NIOConverter
 
toString() - Method in class org.apache.camel.impl.BinaryPredicateSupport
 
toString() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
toString() - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
toString() - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
toString() - Method in class org.apache.camel.impl.DefaultConsumer
 
toString() - Method in class org.apache.camel.impl.DefaultEndpoint
 
toString() - Method in class org.apache.camel.impl.DefaultExchange
 
toString() - Method in class org.apache.camel.impl.DefaultMessage
 
toString() - Method in class org.apache.camel.impl.DefaultProducer
 
toString() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
toString() - Method in class org.apache.camel.impl.PollingConsumerSupport
 
toString() - Method in class org.apache.camel.language.bean.BeanExpression
 
toString() - Method in class org.apache.camel.model.AggregatorType
 
toString() - Method in class org.apache.camel.model.BeanRef
 
toString() - Method in class org.apache.camel.model.CatchType
 
toString() - Method in class org.apache.camel.model.ChoiceType
 
toString() - Method in class org.apache.camel.model.ConvertBodyType
 
toString() - Method in class org.apache.camel.model.DelayerType
 
toString() - Method in class org.apache.camel.model.ExceptionType
 
toString() - Method in class org.apache.camel.model.FilterType
 
toString() - Method in class org.apache.camel.model.FinallyType
 
toString() - Method in class org.apache.camel.model.FromType
 
toString() - Method in class org.apache.camel.model.HandleFaultType
 
toString() - Method in class org.apache.camel.model.IdempotentConsumerType
 
toString() - Method in class org.apache.camel.model.InterceptorRef
 
toString() - Method in class org.apache.camel.model.InterceptType
 
toString() - Method in class org.apache.camel.model.language.ExpressionType
 
toString() - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalanceStrategy
 
toString() - Method in class org.apache.camel.model.LoadBalanceType
 
toString() - Method in class org.apache.camel.model.MarshalType
 
toString() - Method in class org.apache.camel.model.MulticastType
 
toString() - Method in class org.apache.camel.model.OtherwiseType
 
toString() - Method in class org.apache.camel.model.PolicyRef
 
toString() - Method in class org.apache.camel.model.ProcessorRef
 
toString() - Method in class org.apache.camel.model.RecipientListType
 
toString() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
toString() - Method in class org.apache.camel.model.ResequencerType
 
toString() - Method in class org.apache.camel.model.RouteBuilderRef
 
toString() - Method in class org.apache.camel.model.RoutesType
 
toString() - Method in class org.apache.camel.model.RouteType
 
toString() - Method in class org.apache.camel.model.RoutingSlipType
 
toString() - Method in class org.apache.camel.model.SetHeaderType
 
toString() - Method in class org.apache.camel.model.SplitterType
 
toString() - Method in class org.apache.camel.model.ThreadType
 
toString() - Method in class org.apache.camel.model.ThrottlerType
 
toString() - Method in class org.apache.camel.model.ToType
 
toString() - Method in class org.apache.camel.model.TransformType
 
toString() - Method in class org.apache.camel.model.TryType
 
toString() - Method in class org.apache.camel.model.UnmarshalType
 
toString() - Method in class org.apache.camel.model.WhenType
 
toString() - Method in class org.apache.camel.processor.Aggregator
 
toString() - Method in class org.apache.camel.processor.BatchProcessor
 
toString() - Method in class org.apache.camel.processor.CatchProcessor
 
toString() - Method in class org.apache.camel.processor.ChoiceProcessor
 
toString() - Method in class org.apache.camel.processor.CompositeProcessor
 
toString() - Method in class org.apache.camel.processor.DeadLetterChannel
 
toString() - Method in class org.apache.camel.processor.Delayer
 
toString() - Method in class org.apache.camel.processor.DelegateAsyncProcessor
 
toString() - Method in class org.apache.camel.processor.DelegateProcessor
 
toString() - Method in class org.apache.camel.processor.FilterProcessor
 
toString() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
toString() - Method in class org.apache.camel.processor.Logger
 
toString() - Method in class org.apache.camel.processor.LoggingErrorHandler
 
toString() - Method in class org.apache.camel.processor.MulticastProcessor
 
toString() - Method in class org.apache.camel.processor.Pipeline
 
toString() - Method in class org.apache.camel.processor.ProceedProcessor
 
toString() - Method in class org.apache.camel.processor.RecipientList
 
toString() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
toString() - Method in class org.apache.camel.processor.Resequencer
 
toString() - Method in class org.apache.camel.processor.RoutingSlip
 
toString() - Method in class org.apache.camel.processor.SendProcessor
 
toString() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
toString() - Method in class org.apache.camel.processor.Splitter
 
toString() - Method in class org.apache.camel.processor.StreamResequencer
 
toString() - Method in class org.apache.camel.processor.Throttler
 
toString() - Method in class org.apache.camel.processor.TransformProcessor
 
toString() - Method in class org.apache.camel.processor.TryProcessor
 
toString() - Method in class org.apache.camel.Route
 
toString() - Method in class org.apache.camel.util.CollectionStringBuffer
 
toString(Object) - Static method in class org.apache.camel.util.IntrospectionSupport
 
toString(Object, Class) - Static method in class org.apache.camel.util.IntrospectionSupport
 
toString() - Method in class org.apache.camel.util.ReportingTypeConverterLoader.TypeMapping
 
toString() - Method in class org.apache.camel.util.ResolverUtil.AnnotatedWith
 
toString() - Method in class org.apache.camel.util.ResolverUtil.IsA
 
toString() - Method in class org.apache.camel.util.TimeoutMapEntry
 
ToStringTypeConverter - Class in org.apache.camel.impl.converter
A simple converter that can convert any object to a String type by using the toString() method of the object.
ToStringTypeConverter() - Constructor for class org.apache.camel.impl.converter.ToStringTypeConverter
 
ToType - Class in org.apache.camel.model
Represents an XML <to/> element
ToType() - Constructor for class org.apache.camel.model.ToType
 
ToType(String) - Constructor for class org.apache.camel.model.ToType
 
ToType(Endpoint) - Constructor for class org.apache.camel.model.ToType
 
toURI() - Method in class org.apache.camel.util.URISupport.CompositeData
 
toWriter(File) - Static method in class org.apache.camel.converter.IOConverter
 
toWriter(OutputStream) - Static method in class org.apache.camel.converter.IOConverter
 
trace() - Method in class org.apache.camel.model.ProcessorType
Trace logs the exchange before it goes to the next processing step using the ProcessorType.DEFAULT_TRACE_CATEGORY logging category.
trace(String) - Method in class org.apache.camel.model.ProcessorType
Trace logs the exchange before it goes to the next processing step using the specified logging category.
transform(Expression) - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the body on the OUT message
transform() - Method in class org.apache.camel.model.ProcessorType
Adds a processor which sets the body on the OUT message
TransformProcessor - Class in org.apache.camel.processor
A processor which sets the body on the OUT message with an expression
TransformProcessor(Expression) - Constructor for class org.apache.camel.processor.TransformProcessor
 
TransformProcessor(Expression, Processor) - Constructor for class org.apache.camel.processor.TransformProcessor
 
TransformType - Class in org.apache.camel.model
 
TransformType() - Constructor for class org.apache.camel.model.TransformType
 
TransformType(Expression) - Constructor for class org.apache.camel.model.TransformType
 
tryBlock() - Method in class org.apache.camel.model.ProcessorType
Creates a try/catch block
TryProcessor - Class in org.apache.camel.processor
Implements try/catch/finally type processing
TryProcessor(Processor, List<CatchProcessor>, Processor) - Constructor for class org.apache.camel.processor.TryProcessor
 
TryType - Class in org.apache.camel.model
 
TryType() - Constructor for class org.apache.camel.model.TryType
 
type(Object) - Static method in class org.apache.camel.util.ObjectHelper
Returns the type of the given object or null if the value is null
TypeConverter - Interface in org.apache.camel
A pluggable strategy to be able to convert objects to different types such as to and from String, InputStream/OutputStream, Reader/Writer, Document, byte[], ByteBuffer etc
TypeConverterAware - Interface in org.apache.camel.spi
An interface for an object which is interested in being injected with the root TypeConverter such as for implementing a fallback type converter
TypeConverterLoader - Interface in org.apache.camel.impl.converter
 
TypeConverterRegistry - Interface in org.apache.camel.impl.converter
 
typeName(Object) - Static method in exception org.apache.camel.InvalidHeaderTypeException
 

U

unbind(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
unbind(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
UnitOfWork - Interface in org.apache.camel.spi
An object representing the unit of work processing an Exchange which allows the use of Synchronization hooks.
UnitOfWorkProcessor - Class in org.apache.camel.processor
Handles calling the UnitOfWork.done() method when processing of an exchange is complete.
UnitOfWorkProcessor(AsyncProcessor) - Constructor for class org.apache.camel.processor.UnitOfWorkProcessor
 
unmarshal(Exchange, InputStream) - Method in class org.apache.camel.impl.SerializationDataFormat
 
unmarshal(Exchange, InputStream) - Method in class org.apache.camel.impl.StringDataFormat
 
unmarshal(Exchange, InputStream) - Method in class org.apache.camel.model.dataformat.DataFormatType
 
unmarshal() - Method in class org.apache.camel.model.ProcessorType
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.
unmarshal(DataFormatType) - Method in class org.apache.camel.model.ProcessorType
Unmarshals the in body using the specified DataFormat and sets the output on the out message body.
unmarshal(DataFormat) - Method in class org.apache.camel.model.ProcessorType
Unmarshals the in body using the specified DataFormat and sets the output on the out message body.
unmarshal(String) - Method in class org.apache.camel.model.ProcessorType
Unmarshals the in body using the specified DataFormat reference in the Registry and sets the output on the out message body.
unmarshal(Exchange, InputStream) - Method in interface org.apache.camel.spi.DataFormat
Unmarshals the given stream into an object.
UnmarshalProcessor - Class in org.apache.camel.processor
Unmarshals the body of the incoming message using the given data format
UnmarshalProcessor(DataFormat) - Constructor for class org.apache.camel.processor.UnmarshalProcessor
 
UnmarshalType - Class in org.apache.camel.model
Unmarshals the binary payload using the given DataFormatType
UnmarshalType() - Constructor for class org.apache.camel.model.UnmarshalType
 
UnmarshalType(DataFormatType) - Constructor for class org.apache.camel.model.UnmarshalType
 
UnmarshalType(String) - Constructor for class org.apache.camel.model.UnmarshalType
 
unregister(ObjectName) - Method in class org.apache.camel.management.InstrumentationAgentImpl
 
unregister(ObjectName) - Method in interface org.apache.camel.spi.InstrumentationAgent
Unregisters component based upon registered name
UnsafeUriCharactersEncoder - Class in org.apache.camel.util
 
updateExpireTime(TimeoutMapEntry) - Method in class org.apache.camel.util.DefaultTimeoutMap
 
updateNewExchange(Exchange, int, List<MulticastProcessor.ProcessorExchangePair>) - Method in class org.apache.camel.processor.MulticastProcessor
 
updateNewExchange(Exchange, int, List<MulticastProcessor.ProcessorExchangePair>) - Method in class org.apache.camel.processor.Splitter
 
URISupport - Class in org.apache.camel.util
URI utilities.
URISupport() - Constructor for class org.apache.camel.util.URISupport
 
URISupport.CompositeData - Class in org.apache.camel.util
 
URISupport.CompositeData() - Constructor for class org.apache.camel.util.URISupport.CompositeData
 
url - Variable in class org.apache.camel.view.NodeData
 
useCollisionAvoidance() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
useCollisionAvoidance() - Method in class org.apache.camel.model.ExceptionType
 
useCollisionAvoidance() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
useCollisionAvoidance - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
useCollisionAvoidance() - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables collision avoidence which adds some randomization to the backoff timings to reduce contention probability
useExponentialBackOff() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
useExponentialBackOff() - Method in class org.apache.camel.model.ExceptionType
 
useExponentialBackOff() - Method in class org.apache.camel.model.RedeliveryPolicyType
 
useExponentialBackOff - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
useExponentialBackOff() - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables exponential backof using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
useIntrospectionOnEndpoint() - Method in class org.apache.camel.impl.DefaultComponent
Derived classes may wish to overload this to prevent the default introspection of URI parameters on the created Endpoint instance
UseLatestAggregationStrategy - Class in org.apache.camel.processor.aggregate
An AggregationStrategy which just uses the latest exchange which is useful for status messages where old status messages have no real value; another example is things like market data prices, where old stock prices are not that relevant, only the current price is.
UseLatestAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
UuidGenerator - Class in org.apache.camel.util
Generator for Globally unique Strings.
UuidGenerator(String) - Constructor for class org.apache.camel.util.UuidGenerator
Construct an IdGenerator
UuidGenerator() - Constructor for class org.apache.camel.util.UuidGenerator
 

V

validateURI(String, String, Map) - Method in class org.apache.camel.impl.DefaultComponent
Strategy for validation of the uri when creating the endpoint.
ValidatingProcessor - Class in org.apache.camel.processor.validation
A processor which validates the XML version of the inbound message body against some schema either in XSD or RelaxNG
ValidatingProcessor() - Constructor for class org.apache.camel.processor.validation.ValidatingProcessor
 
ValidationException - Exception in org.apache.camel
The base class for any validation exception, such as SchemaValidationException so that it is easy to treat all validation errors in a similar way irrespective of the particular validation technology used.
ValidationException(Exchange, String) - Constructor for exception org.apache.camel.ValidationException
 
ValidationException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.ValidationException
 
ValidatorErrorHandler - Interface in org.apache.camel.processor.validation
 
VALUE_DEFAULT_BUILDER - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
VALUE_ROUTE - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
VALUE_STATS - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
VALUE_UNKNOWN - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
VALUE_UNKNOWN - Static variable in class org.apache.camel.management.ManagedRoute
 
ValueBuilder<E extends Exchange> - Class in org.apache.camel.builder
A builder of expressions or predicates based on values.
ValueBuilder(Expression<E>) - Constructor for class org.apache.camel.builder.ValueBuilder
 
valueOf(String) - Static method in enum org.apache.camel.builder.DataFormatClause.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.ExchangePattern
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.dataformat.ArtixDSContentType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.processor.LoggingLevel
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.camel.builder.DataFormatClause.Operation
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.camel.ExchangePattern
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.camel.model.dataformat.ArtixDSContentType
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.camel.processor.LoggingLevel
Returns an array containing the constants of this enum type, in the order they're declared.
variable(String, Object) - Method in class org.apache.camel.builder.xml.XPathBuilder
Registers a variable (in the global namespace) which can be referred to from XPath expressions
VmComponent - Class in org.apache.camel.component.vm
An implementation of the VM components for asynchronous SEDA exchanges on a BlockingQueue within the classloader tree containing the camel-core.jar.
VmComponent() - Constructor for class org.apache.camel.component.vm.VmComponent
 

W

waitForCompleteLatch() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
waitForCompleteLatch() - Method in class org.apache.camel.component.mock.MockEndpoint
 
waitUntil(long, Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
Wait until the given system time before continuing
warning(SAXParseException) - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
when(Predicate) - Method in class org.apache.camel.model.ChoiceType
 
when() - Method in class org.apache.camel.model.ChoiceType
 
when(Predicate) - Method in class org.apache.camel.model.InterceptType
Applies this interceptor only if the given predicate is true
whenAnyExchangeReceived(Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
Set the processor that will be invoked when the some message is received.
whenExchangeReceived(int, Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
Set the processor that will be invoked when the index message is received.
WhenType<Type extends ProcessorType> - Class in org.apache.camel.model
 
WhenType() - Constructor for class org.apache.camel.model.WhenType
 
WhenType(Predicate) - Constructor for class org.apache.camel.model.WhenType
 
WhenType(ExpressionType) - Constructor for class org.apache.camel.model.WhenType
 
wrap(Processor) - Method in class org.apache.camel.impl.NoPolicy
 
wrap(Processor) - Method in interface org.apache.camel.spi.Policy
Wraps any applicable interceptors around the given processor
wrapInErrorHandler(Processor) - Method in class org.apache.camel.model.ProcessorType
A strategy method to allow newly created processors to be wrapped in an error handler.
wrapProcessor(RouteContext, Processor) - Method in class org.apache.camel.model.ProcessorType
Wraps the child processor in whatever necessary interceptors and error handlers
wrapProcessorInInterceptors(RouteContext, Processor) - Method in class org.apache.camel.model.ProcessorType
A strategy method which allows derived classes to wrap the child processor in some kind of interceptor
writeExternal(ObjectOutput) - Method in class org.apache.camel.component.bean.BeanInvocation
 

X

xmlBeans() - Method in class org.apache.camel.builder.DataFormatClause
Uses the JAXB data format
XMLBeansDataFormat - Class in org.apache.camel.model.dataformat
Represents the XMLBeans XML DataFormat
XMLBeansDataFormat() - Constructor for class org.apache.camel.model.dataformat.XMLBeansDataFormat
 
XmlConverter - Class in org.apache.camel.converter.jaxp
A helper class to transform to and from various JAXB types such as Source and Document
XmlConverter() - Constructor for class org.apache.camel.converter.jaxp.XmlConverter
 
XmlConverter(DocumentBuilderFactory) - Constructor for class org.apache.camel.converter.jaxp.XmlConverter
 
XmlGraphGenerator - Class in org.apache.camel.view
 
XmlGraphGenerator(String) - Constructor for class org.apache.camel.view.XmlGraphGenerator
 
xpath(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression
xpath(String, Class) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified result type
xpath(String, Class, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified result type and set of namespace prefixes and URIs
xpath(String, Class, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified result type and set of namespace prefixes and URIs
xpath(String, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified set of namespace prefixes and URIs
xpath(String, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XPath expression with the specified set of namespace prefixes and URIs
xpath(String) - Method in class org.apache.camel.builder.xml.Namespaces
Creates the XPath expression using the current namespace context
xpath(String, Class<?>) - Method in class org.apache.camel.builder.xml.Namespaces
Creates the XPath expression using the current namespace context
xpath(String) - Static method in class org.apache.camel.builder.xml.XPathBuilder
 
XPath - Annotation Type in org.apache.camel.language
Used to inject an XPath expression into a field, property, method or parameter when using Bean Integration.
XPathAnnotationExpressionFactory - Class in org.apache.camel.component.bean
 
XPathAnnotationExpressionFactory() - Constructor for class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
 
XPathBuilder<E extends Exchange> - Class in org.apache.camel.builder.xml
Creates an XPath expression builder which creates a nodeset result by default.
XPathBuilder(String) - Constructor for class org.apache.camel.builder.xml.XPathBuilder
 
XPathExpression - Class in org.apache.camel.model.language
For XPath expresions and predicates
XPathExpression() - Constructor for class org.apache.camel.model.language.XPathExpression
 
XPathExpression(String) - Constructor for class org.apache.camel.model.language.XPathExpression
 
XPathLanguage - Class in org.apache.camel.builder.xml
 
XPathLanguage() - Constructor for class org.apache.camel.builder.xml.XPathLanguage
 
xquery(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression
xquery(String, Class) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified result type
xquery(String, Class, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified result type and set of namespace prefixes and URIs
xquery(String, Class, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified result type and set of namespace prefixes and URIs
xquery(String, Namespaces) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified set of namespace prefixes and URIs
xquery(String, Map<String, String>) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an XQuery expression with the specified set of namespace prefixes and URIs
xquery(String) - Method in class org.apache.camel.builder.xml.Namespaces
Creates the XQuery expression using the current namespace context
xquery(String, Class<?>) - Method in class org.apache.camel.builder.xml.Namespaces
Creates the XQuery expression using the current namespace context and the given expected return type
XQueryExpression - Class in org.apache.camel.model.language
For XQuery expresions and predicates
XQueryExpression() - Constructor for class org.apache.camel.model.language.XQueryExpression
 
XQueryExpression(String) - Constructor for class org.apache.camel.model.language.XQueryExpression
 
xslt(Transformer) - Static method in class org.apache.camel.builder.xml.XsltBuilder
Creates an XSLT processor using the given transformer instance
xslt(Source) - Static method in class org.apache.camel.builder.xml.XsltBuilder
Creates an XSLT processor using the given XSLT source
xslt(File) - Static method in class org.apache.camel.builder.xml.XsltBuilder
Creates an XSLT processor using the given XSLT source
xslt(URL) - Static method in class org.apache.camel.builder.xml.XsltBuilder
Creates an XSLT processor using the given XSLT source
xslt(InputStream) - Static method in class org.apache.camel.builder.xml.XsltBuilder
Creates an XSLT processor using the given XSLT source
XsltBuilder - Class in org.apache.camel.builder.xml
Creates a Processor which performs an XSLT transformation of the IN message body
XsltBuilder() - Constructor for class org.apache.camel.builder.xml.XsltBuilder
 
XsltBuilder(Transformer) - Constructor for class org.apache.camel.builder.xml.XsltBuilder
 
xstream() - Method in class org.apache.camel.builder.DataFormatClause
Uses the XStream data format
XStreamDataFormat - Class in org.apache.camel.model.dataformat
Represents the XStream XML DataFormat
XStreamDataFormat() - Constructor for class org.apache.camel.model.dataformat.XStreamDataFormat
 

A B C D E F G H I J K L M N O P Q R S T U V W X

Copyright © 2008 IONA Open Source Community. All Rights Reserved.