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

A

accept(GenericFile) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
 
accept(GenericFile<T>) - Method in interface org.apache.camel.component.file.GenericFileFilter
Tests whether or not the specified generic file should be included
ACCEPT_CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
 
acquire(Key) - Method in class org.apache.camel.impl.DefaultServicePool
 
acquire(Key) - Method in interface org.apache.camel.spi.ServicePool
Tries to acquire the servie with the given key
acquireExclusiveReadLock(GenericFileOperations<T>, GenericFile<T>, Exchange) - Method in interface org.apache.camel.component.file.GenericFileExclusiveReadLockStrategy
Acquires exclusive read lock to the file.
acquireExclusiveReadLock(GenericFileOperations<File>, GenericFile<File>, Exchange) - Method in class org.apache.camel.component.file.strategy.FileChangedExclusiveReadLockStrategy
 
acquireExclusiveReadLock(GenericFileOperations<File>, GenericFile<File>, Exchange) - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
 
acquireExclusiveReadLock(GenericFileOperations<T>, GenericFile<T>, Exchange) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
 
acquireExclusiveReadLock(GenericFileOperations<File>, GenericFile<File>, Exchange) - Method in class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
 
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 interface org.apache.camel.processor.aggregate.AggregationCollection
Adds the given exchange to this collection
add(Exchange) - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
add(String) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
add(String) - Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
 
add(E) - Method in interface org.apache.camel.spi.IdempotentRepository
Adds the key to the repository.
addAndAcquire(Key, Service) - Method in class org.apache.camel.impl.DefaultServicePool
 
addAndAcquire(Key, Service) - Method in interface org.apache.camel.spi.ServicePool
Adds the given service to the pool and acquires it.
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
 
addClassLoader(ClassLoader) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
addClassLoader(ClassLoader) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Adds the class loader to the existing loaders
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
 
addEndpoint(String, Endpoint) - Method in interface org.apache.camel.CamelContext
Adds the endpoint to the context using the given URI.
addEndpoint(String, Endpoint) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addEndpointToRegistry(String, Endpoint) - Method in class org.apache.camel.impl.DefaultCamelContext
Strategy to add the given endpoint to the internal endpoint registry
addErrorHandlers(OnExceptionDefinition) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Adds error handler for the given exception type
addErrorHandlers(OnExceptionDefinition) - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
addErrorHandlers(OnExceptionDefinition) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
addEventDrivenProcessor(Processor) - Method in class org.apache.camel.impl.DefaultRouteContext
 
addEventDrivenProcessor(Processor) - Method in interface org.apache.camel.spi.RouteContext
Adds an event driven processor
addExceptionPolicy(OnExceptionDefinition) - Method in class org.apache.camel.processor.ErrorHandlerSupport
 
addExcludePattern(String) - Method in class org.apache.camel.impl.scan.PatternBasedPackageScanFilter
add and exclude pattern to the filter.
addExcludePatterns(Collection<String>) - Method in class org.apache.camel.impl.scan.PatternBasedPackageScanFilter
 
addFallbackTypeConverter(TypeConverter) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
addFallbackTypeConverter(TypeConverter) - Method in class org.apache.camel.impl.ReportingTypeConverterRegistry
 
addFallbackTypeConverter(TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Registers a new fallback type converter
addFilter(PackageScanFilter) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
addFilter(PackageScanFilter) - Method in class org.apache.camel.impl.scan.CompositePackageScanFilter
 
addFilter(PackageScanFilter) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Add a filter that will be applied to all scan operations
addIfMatching(PackageScanFilter, String, Set<Class>) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
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.
addIncludePattern(String) - Method in class org.apache.camel.impl.scan.PatternBasedPackageScanFilter
add and include pattern to the filter.
addIncludePatterns(Collection<String>) - Method in class org.apache.camel.impl.scan.PatternBasedPackageScanFilter
 
addInterceptStrategies(List<InterceptStrategy>) - Method in interface org.apache.camel.Channel
Adds a list of InterceptStrategy to apply each Exchange before its routed to the next Processor.
addInterceptStrategies(RouteContext, Channel, List<InterceptStrategy>) - Method in class org.apache.camel.model.ProcessorDefinition
Adds the given list of interceptors to the channel.
addInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.processor.DefaultChannel
 
addInterceptStrategy(InterceptStrategy) - Method in interface org.apache.camel.CamelContext
Adds the given interceptor strategy
addInterceptStrategy(InterceptStrategy) - Method in interface org.apache.camel.Channel
Adds a InterceptStrategy to apply each Exchange before its routed to the next Processor.
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.impl.DefaultRouteContext
 
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
 
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.processor.DefaultChannel
 
addInterceptStrategy(InterceptStrategy) - Method in interface org.apache.camel.spi.RouteContext
Adds a InterceptStrategy to this route context
addOnCompletion(Synchronization) - Method in interface org.apache.camel.Exchange
Adds a Synchronization to be invoked as callback when this exchange is completed.
addOnCompletion(Synchronization) - Method in class org.apache.camel.impl.DefaultExchange
 
addOption(MainSupport.Option) - Method in class org.apache.camel.impl.MainSupport
 
addOutput(ProcessorDefinition) - Method in interface org.apache.camel.model.Block
 
addOutput(ProcessorDefinition) - Method in class org.apache.camel.model.ProcessorDefinition
 
addOutput(ProcessorDefinition) - Method in class org.apache.camel.model.TryDefinition
 
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
 
addParentType(Class) - Method in class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
addPredicate(Predicate) - Method in class org.apache.camel.component.mock.AssertionClause
 
addProcessor(Processor) - Method in class org.apache.camel.model.LoadBalancerDefinition
 
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.browse.BrowseEndpoint
 
addRegisterEndpointCallback(EndpointStrategy) - Method in interface org.apache.camel.CamelContext
Registers a callback to allow you to do custom logic when an Endpoint is about to be registered to the CamelContext endpoint registry.
addRegisterEndpointCallback(EndpointStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addRouteBuilder(RouteBuilder) - Method in class org.apache.camel.impl.MainSupport
 
addRouteDefinitions(Collection<RouteDefinition>) - Method in interface org.apache.camel.CamelContext
Adds a collection of route definitions to the context
addRouteDefinitions(Collection<RouteDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addRoutes(RoutesBuilder) - Method in class org.apache.camel.builder.RouteBuilder
Adds a collection of routes to this context
addRoutes(RoutesBuilder) - Method in interface org.apache.camel.CamelContext
Adds a collection of routes to this context using the given builder to build them
addRoutes(RoutesBuilder) - Method in class org.apache.camel.impl.DefaultCamelContext
 
addRoutes(RouteContext, Collection<Route>) - Method in class org.apache.camel.model.OnExceptionDefinition
 
addRoutes(RouteContext, Collection<Route>) - Method in class org.apache.camel.model.ProcessorDefinition
 
addRoutes(CamelContext, Collection<Route>) - Method in class org.apache.camel.model.RouteDefinition
 
addRoutes(Collection<Route>, FromDefinition) - Method in class org.apache.camel.model.RouteDefinition
 
addRoutesToCamelContext(CamelContext) - Method in class org.apache.camel.builder.RouteBuilder
 
addRoutesToCamelContext(CamelContext) - Method in interface org.apache.camel.RoutesBuilder
Adds the routes from this Route Builder to the CamelContext.
addRouteToMap(Map<String, List<RouteDefinition>>, RouteDefinition) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
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.impl.DefaultRoute
 
addService(Service) - Method in interface org.apache.camel.Route
Adds a service to this route
addServices(List<Service>) - Method in class org.apache.camel.impl.DefaultRoute
Strategy method to allow derived classes to lazily load services for the 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
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
addToEnvironment(String, Object) - Method in class org.apache.camel.util.jndi.JndiContext
 
addTraced(RouteNode) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
addTraced(RouteNode) - Method in interface org.apache.camel.spi.TraceableUnitOfWork
Adds the entry that was intercepted
addTypeAndSuperTypes(Class<?>, List<Class<?>>) - Method in class org.apache.camel.component.bean.MethodInfo
Adds the current class and all of its base classes (apart from Object to the given list
addTypeConverter(Class, Class, TypeConverter) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
addTypeConverter(Class, Class, TypeConverter) - Method in class org.apache.camel.impl.ReportingTypeConverterRegistry
 
addTypeConverter(Class, Class, TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Registers a new type converter
addVariable(String, Object) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
after(String) - Method in class org.apache.camel.model.AOPDefinition
Uses a AOP after.
after(String, String) - Static method in class org.apache.camel.util.ObjectHelper
 
afterFinally(String) - Method in class org.apache.camel.model.AOPDefinition
Uses a AOP after with after being invoked in a finally block.
afterIntercept(InterceptDefinition, TraceableUnitOfWork, Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
afterPropertiesSet(GenericFileEndpoint<File>) - Method in class org.apache.camel.component.file.FileComponent
 
afterPropertiesSet(GenericFileEndpoint<T>) - Method in class org.apache.camel.component.file.GenericFileComponent
A factory method for derived file components to perform validation of properties
afterPropertiesSet() - Method in class org.apache.camel.model.InterceptDefinition
This method is only for handling some post configuration that is needed from the Spring DSL side as JAXB does not invoke the fluent builders, so we need to manually handle this afterwards, and since this is an interceptor it has to do a bit of magic logic to fixup to handle predicates with or without proceed/stop set as well.
afterPropertiesSet() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
This method is only for handling some post configuration that is needed from the Spring DSL side as JAXB does not invoke the fluent builders, so we need to manually handle this afterwards, and since this is an interceptor it has to do a bit of magic logic to fixup to handle predicates with or without proceed/stop set as well.
aggregate() - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
aggregate(AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
aggregate(AggregationCollection) - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
aggregate(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
aggregate(Expression, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
Aggregator EIP: Creates an aggregator allowing you to combine a number of messages together into a single message.
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.GroupedExchangeAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
AGGREGATED_INDEX - Static variable in interface org.apache.camel.Exchange
 
AGGREGATED_SIZE - Static variable in interface org.apache.camel.Exchange
 
AggregateDefinition - Class in org.apache.camel.model
Represents an XML <aggregate/> element
AggregateDefinition() - Constructor for class org.apache.camel.model.AggregateDefinition
 
AggregateDefinition(Predicate) - Constructor for class org.apache.camel.model.AggregateDefinition
 
AggregateDefinition(Expression) - Constructor for class org.apache.camel.model.AggregateDefinition
 
AggregateDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.AggregateDefinition
 
AggregateDefinition(Expression, AggregationStrategy) - Constructor for class org.apache.camel.model.AggregateDefinition
 
aggregationCollection(AggregationCollection) - Method in class org.apache.camel.model.AggregateDefinition
Sets the aggregate collection to use
AggregationCollection - Interface in org.apache.camel.processor.aggregate
A Collection which aggregates exchanges together, using a correlation Expression and a AggregationStrategy.
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.AggregateDefinition
Sets the aggregate strategy to use
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.MulticastDefinition
Set the multicasting aggregationStrategy
aggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.SplitDefinition
Set the aggregationStrategy
AggregationStrategy - Interface in org.apache.camel.processor.aggregate
A strategy for aggregating two exchanges together into a single exchange.
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(Processor, Expression, AggregationStrategy) - Constructor for class org.apache.camel.processor.Aggregator
 
Aggregator(Processor, Expression, AggregationStrategy, Predicate) - Constructor for class org.apache.camel.processor.Aggregator
 
Aggregator(Processor, AggregationCollection) - Constructor for class org.apache.camel.processor.Aggregator
 
allMessages() - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an assertion to all the received messages
AlreadyStoppedException - Exception in org.apache.camel
Exception thrown in situations when a Service has already been stopped.
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, Predicate) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to combine multiple predicates by a logical AND
AnnotatedWithAnyPackageScanFilter - Class in org.apache.camel.impl.scan
Package scan filter for testing if a given class is annotated with any of the annotations.
AnnotatedWithAnyPackageScanFilter(Set<Class<? extends Annotation>>) - Constructor for class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
 
AnnotatedWithAnyPackageScanFilter(Set<Class<? extends Annotation>>, boolean) - Constructor for class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
 
AnnotatedWithPackageScanFilter - Class in org.apache.camel.impl.scan
Package scan filter for testing if a given class is annotated with a certain annotation.
AnnotatedWithPackageScanFilter(Class<? extends Annotation>) - Constructor for class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
 
AnnotatedWithPackageScanFilter(Class<? extends Annotation>, boolean) - Constructor for class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
 
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(PackageScanClassResolver) - Constructor for class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
AntPathMatcherGenericFileFilter - Class in org.apache.camel.component.file
File filter using Spring's AntPathMatcher.
AntPathMatcherGenericFileFilter() - Constructor for class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
 
aop() - Method in class org.apache.camel.model.ProcessorDefinition
Wraps the sub route using AOP allowing you to do before and after work (AOP around).
AOPDefinition - Class in org.apache.camel.model
Represents an XML <aop/> element
AOPDefinition() - Constructor for class org.apache.camel.model.AOPDefinition
 
AOPProcessor - Class in org.apache.camel.processor
 
AOPProcessor(Processor, List<CatchProcessor>, Processor) - Constructor for class org.apache.camel.processor.AOPProcessor
 
append(Expression, Expression) - 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(Object) - Method in class org.apache.camel.util.CollectionStringBuffer
 
appendToStore(String) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Appends the given message id to the file store
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
applyFilterToCamelHeaders(String, Object, Exchange) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
 
applyFilterToCamelHeaders(String, Object, Exchange) - Method in interface org.apache.camel.spi.HeaderFilterStrategy
Applies filtering logic to Camel Message header that is going to be copied to target message such as CXF and JMS message.
applyFilterToExternalHeaders(String, Object, Exchange) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
 
applyFilterToExternalHeaders(String, Object, Exchange) - Method in interface org.apache.camel.spi.HeaderFilterStrategy
Applies filtering logic to an external message header such as CXF and JMS message that is going to be copied to Camel message header.
applyHeaders(Exchange, long) - Method in class org.apache.camel.component.dataset.DataSetSupport
Allows derived classes to add some custom headers for a given message
around(String, String) - Method in class org.apache.camel.model.AOPDefinition
Uses a AOP around.
aroundFinally(String, String) - Method in class org.apache.camel.model.AOPDefinition
Uses a AOP around with after being invoked in a finally block
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
 
asEnum(String) - Static method in enum org.apache.camel.ExchangePattern
 
asExpression(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
asGenericFile(String, File) - Static method in class org.apache.camel.component.file.FileConsumer
Creates a new GenericFile based on the given file.
asMap() - Method in class org.apache.camel.model.config.PropertiesDefinition
 
asMap() - Method in class org.apache.camel.model.dataformat.DataFormatsDefinition
 
asOperator(String) - Static method in enum org.apache.camel.language.simple.SimpleLangaugeOperator
 
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
Public class needed for fluent builders
AssertionClause.PredicateValueBuilder(Expression) - Constructor for class org.apache.camel.component.mock.AssertionClause.PredicateValueBuilder
 
assertionFailureMessage(Exchange, Object, Object) - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
assertionFailureMessage(Exchange) - Method in class org.apache.camel.impl.ExpressionAdapter
 
assertionFailureMessage(Exchange) - Method in class org.apache.camel.impl.ExpressionSupport
 
assertionFailureMessage(Exchange) - 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
assertIsNotSatisfied(long) - 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, Exchange) - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
assertMatches(String, Exchange) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
assertMatches(String, Exchange) - Method in class org.apache.camel.impl.ExpressionSupport
 
assertMatches(String, Exchange) - Method in class org.apache.camel.language.bean.BeanExpression
 
assertMatches(String, Exchange) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
assertMatches(Predicate, String, Exchange) - Static method in class org.apache.camel.util.PredicateAssertHelper
 
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) - Method in class org.apache.camel.component.mock.MockEndpoint
Asserts that the messages have ascending values of the given expression
assertMessagesDescending(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
Asserts that the messages have descending values of the given expression
assertMessagesSorted(Expression, boolean) - Method in class org.apache.camel.component.mock.MockEndpoint
 
assertNoDuplicates(Expression) - 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
 
assign() - Method in class org.apache.camel.processor.Throttler.TimeSlot
 
AssignableToPackageScanFilter - Class in org.apache.camel.impl.scan
Package scan filter for testing if a given class is assignable to another class.
AssignableToPackageScanFilter() - Constructor for class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
AssignableToPackageScanFilter(Class) - Constructor for class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
AssignableToPackageScanFilter(Set<Class>) - Constructor for class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
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
ASYNC_WAIT - Static variable in interface org.apache.camel.Exchange
 
asyncCallback(String, Exchange, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(String, Processor, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(Endpoint, ExchangePattern, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(Endpoint, Exchange, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(Endpoint, Processor, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallback(String, Exchange, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncCallback(Endpoint, Exchange, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncCallback(String, Processor, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint using a supplied processor.
asyncCallback(Endpoint, Processor, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint using a supplied processor.
asyncCallbackRequestBody(String, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallbackRequestBody(Endpoint, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallbackRequestBody(String, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncCallbackRequestBody(Endpoint, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncCallbackSendBody(String, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallbackSendBody(Endpoint, Object, Synchronization) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncCallbackSendBody(String, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncCallbackSendBody(Endpoint, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncProcess(ExecutorService, Processor, Exchange) - Static method in class org.apache.camel.util.AsyncProcessorHelper
Processes the exchange async.
AsyncProcessorHelper - Class in org.apache.camel.util
Helper methods for AsyncProcessor objects.
asyncRequestBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBody(String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBody(Endpoint, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncSend(String, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend(String, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend(Endpoint, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSend(String, Exchange) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncSend(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncSend(Endpoint, Exchange) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncSend(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncSendBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSendBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
asyncSendBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncSendBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
AtomicExchange - Class in org.apache.camel.util.concurrent
Convenience class for holding an Exchange in a thread-safe way
AtomicExchange() - Constructor for class org.apache.camel.util.concurrent.AtomicExchange
 
autoCreate - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
available() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
 
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.DefaultErrorHandlerBuilder
 
backOffMultiplier(double) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the back off multiplier
backOffMultiplier(double) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the back off multiplier
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.ResequenceDefinition
Configures the batch-based resequencing algorithm using the default configuration.
batch(BatchResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
Configures the batch-based resequencing algorithm using the given BatchResequencerConfig.
BATCH_COMPLETE - Static variable in interface org.apache.camel.Exchange
 
BATCH_INDEX - Static variable in interface org.apache.camel.Exchange
 
BATCH_SIZE - Static variable in interface org.apache.camel.Exchange
 
BatchConsumer - Interface in org.apache.camel
A consumer of a batch of message exchanges from an Endpoint
BatchProcessor - Class in org.apache.camel.processor
A base class for any kind of Processor which implements some kind of batch processing.
BatchProcessor(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.AggregateDefinition
Sets the in batch size for number of exchanges received
batchSizeFromConsumer() - Method in class org.apache.camel.model.AggregateDefinition
Enables the batch completion mode where we aggregate from a BatchConsumer and aggregate the total number of exchanges the BatchConsumer has reported as total by setting the exchange property Exchange.BATCH_SIZE.
batchTimeout(long) - Method in class org.apache.camel.model.AggregateDefinition
Sets the batch timeout
bean(String) - Static method in class org.apache.camel.builder.Builder
Returns a bean expression value builder
bean(String, String) - Static method in class org.apache.camel.builder.Builder
Returns a bean expression value builder
bean(Class, String) - Static method in class org.apache.camel.builder.Builder
Returns a bean expression value builder
bean(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a bean expression value builder
bean(String, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a bean expression value builder
bean(Class) - Method in class org.apache.camel.builder.BuilderSupport
Returns a bean expression value builder
bean(Class, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a bean expression value builder
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(String) - Static method in class org.apache.camel.language.bean.BeanLanguage
Creates the expression based on the string syntax.
bean(Class, String) - Static method in class org.apache.camel.language.bean.BeanLanguage
Creates the expression for invoking the bean type.
bean(Object, String) - Static method in class org.apache.camel.language.bean.BeanLanguage
Creates the expression for invoking the bean type.
bean(Object) - Method in class org.apache.camel.model.BeanDefinition
Sets the bean's instance that camel to call
bean(Object) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: 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.ProcessorDefinition
Message Translator EIP: Adds a bean 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.ProcessorDefinition
Message Translator EIP: Adds a bean 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.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
BEAN_HOLDER - Static variable in interface org.apache.camel.Exchange
 
BEAN_METHOD_NAME - Static variable in interface org.apache.camel.Exchange
 
BEAN_MULTI_PARAMETER_ARRAY - Static variable in interface org.apache.camel.Exchange
 
BEAN_PARAMETER_MAPPING_STRATEGY - Static variable in class org.apache.camel.component.bean.BeanConstants
 
BeanComponent - Class in org.apache.camel.component.bean
The Bean Component 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
 
BeanConstants - Class in org.apache.camel.component.bean
 
BeanDefinition - Class in org.apache.camel.model
Represents an XML <bean/> element
BeanDefinition() - Constructor for class org.apache.camel.model.BeanDefinition
 
BeanDefinition(String) - Constructor for class org.apache.camel.model.BeanDefinition
 
BeanDefinition(String, String) - Constructor for class org.apache.camel.model.BeanDefinition
 
BeanEndpoint - Class in org.apache.camel.component.bean
Endpoint for the bean component.
BeanEndpoint() - Constructor for class org.apache.camel.component.bean.BeanEndpoint
 
BeanEndpoint(String) - Constructor for class org.apache.camel.component.bean.BeanEndpoint
 
BeanEndpoint(String, BeanProcessor) - Constructor for class org.apache.camel.component.bean.BeanEndpoint
 
BeanEndpoint(String, Component, BeanProcessor) - Constructor for class org.apache.camel.component.bean.BeanEndpoint
 
BeanEndpoint(String, Component) - Constructor for class org.apache.camel.component.bean.BeanEndpoint
 
beanExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
beanExpression(Class, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
beanExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
BeanExpression - Class in org.apache.camel.language.bean
Evaluates an expression using a bean method invocation
BeanExpression(Object, String) - Constructor for class org.apache.camel.language.bean.BeanExpression
 
BeanExpression(String, String) - Constructor for class org.apache.camel.language.bean.BeanExpression
 
BeanHolder - Interface in org.apache.camel.component.bean
Object holder for a 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
Invocation of beans that can handle being serialized.
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 bean language which uses a simple text notation to invoke methods on beans to evaluate predicates or expressions

The notation is essentially beanName.methodName which is then invoked using the beanName to lookup in the bean integration to bind 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(String) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: 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.ProcessorDefinition
Message Translator EIP: Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
beanType(Class) - Method in class org.apache.camel.model.BeanDefinition
Sets the Class of the bean that camel will instantiation it for calling
before(String) - Method in class org.apache.camel.model.AOPDefinition
Uses a AOP before.
before(String, String) - Static method in class org.apache.camel.util.ObjectHelper
 
beforeOnCompletion(OnCompletionDefinition, TraceableUnitOfWork, Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
beforeOnException(OnExceptionDefinition, TraceableUnitOfWork, Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
begin(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in interface org.apache.camel.component.file.GenericFileProcessStrategy
Called when work is about to begin on this file.
begin(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
 
begin(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
begin(Consumer, Endpoint) - Method in class org.apache.camel.impl.DefaultPollingConsumerPollStrategy
 
begin(Consumer, Endpoint) - Method in interface org.apache.camel.PollingConsumerPollStrategy
Called when poll is about to begin
between(String, String, String) - Static method in class org.apache.camel.util.ObjectHelper
 
BinaryPredicateSupport - Class in org.apache.camel.builder
A useful base class for Predicate implementations
BinaryPredicateSupport(Expression, Expression) - Constructor for class org.apache.camel.builder.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
 
BINDING - Static variable in interface org.apache.camel.Exchange
 
bindToExchange(Exchange) - Method in class org.apache.camel.component.file.GenericFile
Bind this GenericFile to an Exchange
bindy(BindyType, String...) - Method in class org.apache.camel.builder.DataFormatClause
Uses the Bindy data format
BindyDataFormat - Class in org.apache.camel.model.dataformat
Represents the Bindy DataFormat
BindyDataFormat() - Constructor for class org.apache.camel.model.dataformat.BindyDataFormat
 
BindyType - Enum in org.apache.camel.model.dataformat
Represents the different types of bindy data formats.
Block - Interface in org.apache.camel.model
Interface to add block featuring to the XML element type.
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
body(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
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
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
 
bodyTypeExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchanges inbound message body type
booleanResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to boolean
BrowsableEndpoint - 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.
BrowseComponent - Class in org.apache.camel.component.browse
The browse component.
BrowseComponent() - Constructor for class org.apache.camel.component.browse.BrowseComponent
 
BrowseEndpoint - Class in org.apache.camel.component.browse
An endpoint which maintains a List of Exchange instances which can be useful for tooling, debugging and visualising routes.
BrowseEndpoint(String, CamelContext) - Constructor for class org.apache.camel.component.browse.BrowseEndpoint
 
BrowseEndpoint(String, Component) - Constructor for class org.apache.camel.component.browse.BrowseEndpoint
 
BrowseEndpoint(String) - Constructor for class org.apache.camel.component.browse.BrowseEndpoint
 
bufferSize - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
buildDirectory(String, boolean) - Method in class org.apache.camel.component.file.FileOperations
 
buildDirectory(String, boolean) - Method in interface org.apache.camel.component.file.GenericFileOperations
Builds the directory structure.
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
 
buildFileEndpoint(String, String, Map) - Method in class org.apache.camel.component.file.FileComponent
 
buildFileEndpoint(String, String, Map) - Method in class org.apache.camel.component.file.GenericFileComponent
A factory method for derived file components to create the endpoint
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() - Constructor for class org.apache.camel.converter.jaxp.BytesSource
 
BytesSource(byte[]) - Constructor for class org.apache.camel.converter.jaxp.BytesSource
 
BytesSource(byte[], String) - Constructor for class org.apache.camel.converter.jaxp.BytesSource
 

C

CachedOutputStream - Class in org.apache.camel.converter.stream
This output stream will store the content into a File if the stream context size is exceed the THRESHOLD which's default value is 64K.
CachedOutputStream(Exchange) - Constructor for class org.apache.camel.converter.stream.CachedOutputStream
 
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
 
calculateRedeliverDelayUsingPattern(String, int) - Static method in class org.apache.camel.processor.RedeliveryPolicy
Calculates the delay using the delay pattern
calculateRedeliveryDelay(long, int) - Method in class org.apache.camel.processor.RedeliveryPolicy
 
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
camelContextExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the CamelContext
CamelContextHelper - Class in org.apache.camel.util
A number of helper methods
camelContextPropertiesExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the properties of the camel context
camelContextPropertyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the property value of the camel context with the given name
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
 
CamelExecutionException - Exception in org.apache.camel
Exception occured during execution/processing of an Exchange.
CamelExecutionException(String, Exchange) - Constructor for exception org.apache.camel.CamelExecutionException
 
CamelExecutionException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.CamelExecutionException
 
CamelInitialContextFactory - Class in org.apache.camel.util.jndi
A factory of the Camel 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, MethodInfoCache) - Constructor for class org.apache.camel.component.bean.CamelInvocationHandler
 
CamelNamingStrategy - Class in org.apache.camel.management
Naming strategy used when registering MBeans.
CamelNamingStrategy() - Constructor for class org.apache.camel.management.CamelNamingStrategy
 
CamelNamingStrategy(String) - Constructor for class org.apache.camel.management.CamelNamingStrategy
 
CamelPostProcessorHelper - Class in org.apache.camel.impl
A helper class for Camel based injector or post processing hooks which can be reused by both the Spring and Guice support.
CamelPostProcessorHelper() - Constructor for class org.apache.camel.impl.CamelPostProcessorHelper
 
CamelPostProcessorHelper(CamelContext) - Constructor for class org.apache.camel.impl.CamelPostProcessorHelper
 
capacity - Variable in class org.apache.camel.impl.DefaultServicePool
 
capacity(int) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the capacity for the stream resequencer
capitalize(String) - Static method in class org.apache.camel.util.ObjectHelper
 
CaseInsensitiveMap - Class in org.apache.camel.util
A map that uses case insensitive keys, but preserves the original keys in the keySet.
CaseInsensitiveMap() - Constructor for class org.apache.camel.util.CaseInsensitiveMap
 
CaseInsensitiveMap(Map<? extends String, ?>) - Constructor for class org.apache.camel.util.CaseInsensitiveMap
 
CaseInsensitiveMap(int, float) - Constructor for class org.apache.camel.util.CaseInsensitiveMap
 
CaseInsensitiveMap(int) - Constructor for class org.apache.camel.util.CaseInsensitiveMap
 
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
catchClauses - Variable in class org.apache.camel.processor.TryProcessor
 
CatchDefinition - Class in org.apache.camel.model
Represents an XML <catch/> element
CatchDefinition() - Constructor for class org.apache.camel.model.CatchDefinition
 
CatchDefinition(List<Class>) - Constructor for class org.apache.camel.model.CatchDefinition
 
CatchDefinition(Class) - Constructor for class org.apache.camel.model.CatchDefinition
 
catches(Exchange, Throwable) - Method in class org.apache.camel.processor.CatchProcessor
Returns with the exception that is caught by this processor.
CatchProcessor - Class in org.apache.camel.processor
A processor which catches exceptions.
CatchProcessor(List<Class>, Processor, Predicate, Predicate) - Constructor for class org.apache.camel.processor.CatchProcessor
 
changeCurrentDirectory(String) - Method in class org.apache.camel.component.file.FileOperations
 
changeCurrentDirectory(String) - Method in interface org.apache.camel.component.file.GenericFileOperations
Change the current remote directory
changeFileName(String) - Method in class org.apache.camel.component.file.GenericFile
Changes the name of this remote file.
changeScheme(URI, String) - Static method in class org.apache.camel.util.URISupport
 
Channel - Interface in org.apache.camel
Channel acts as a channel between Processors in the route graph.
CHARSET_NAME - Static variable in interface org.apache.camel.Exchange
 
checkException(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
checkInitialized() - Method in class org.apache.camel.builder.RouteBuilder
 
checkInitialized() - Method in class org.apache.camel.model.TryDefinition
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.AggregateDefinition
 
checkParenthesis(String) - Static method in class org.apache.camel.util.URISupport
 
choice() - Method in class org.apache.camel.model.ProcessorDefinition
Content Based Router EIP: Creates a choice of one or more predicates with an otherwise clause
ChoiceDefinition - Class in org.apache.camel.model
Represents an XML <choice/> element
ChoiceDefinition() - Constructor for class org.apache.camel.model.ChoiceDefinition
 
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
 
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
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
 
classCanonicalName(Object) - Static method in class org.apache.camel.util.ObjectHelper
Returns the canonical type name of the given value
classMap - Variable in class org.apache.camel.impl.DefaultFactoryFinder
 
className(Object) - Static method in class org.apache.camel.util.ObjectHelper
Returns the type name of the given value
ClassResolver - Interface in org.apache.camel.spi
A class resolver for loading classes in a loosly coupled manner to cater for different platforms such as standalone, web container, j2ee container and OSGi platforms.
clear() - Method in class org.apache.camel.model.FromDefinition
 
clear() - Method in class org.apache.camel.model.PackageScanDefinition
 
clear() - Method in interface org.apache.camel.processor.aggregate.AggregationCollection
Clears this collection
clear() - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
clear() - Method in class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 
clear() - Method in class org.apache.camel.util.CaseInsensitiveMap
 
clearOutput() - Method in class org.apache.camel.model.ProcessorDefinition
 
close() - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
close() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
 
close() - Method in class org.apache.camel.converter.stream.ReaderCache
 
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
 
collectionAsCommaDelimitedString(String[]) - Static method in class org.apache.camel.util.CollectionHelper
 
collectionAsCommaDelimitedString(Collection) - Static method in class org.apache.camel.util.CollectionHelper
 
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
 
collectionRef(String) - Method in class org.apache.camel.model.AggregateDefinition
Sets the aggregate collection to use
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.OnExceptionDefinition
Sets the collision avoidance factor
collisionAvoidanceFactor(double) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the collision avoidance factor
collisionAvoidanceFactor - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
collisionAvoidancePercent(double) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
collisionAvoidancePercent(double) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the collision avoidance percentage
collisionAvoidancePercent(double) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the collision avoidance percentage
collisionAvoidancePercent(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables collision avoidance and sets the percentage used
commit(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in interface org.apache.camel.component.file.GenericFileProcessStrategy
Releases any file locks and possibly deletes or moves the file after successful processing
commit(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileDeleteProcessStrategy
 
commit(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
 
commit(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
commit(Consumer, Endpoint) - Method in class org.apache.camel.impl.DefaultPollingConsumerPollStrategy
 
commit() - Method in class org.apache.camel.impl.DefaultRouteContext
 
commit(Consumer, Endpoint) - Method in interface org.apache.camel.PollingConsumerPollStrategy
Called when poll is completed successfully
commit() - Method in interface org.apache.camel.spi.RouteContext
Lets complete the route creation, creating a single event driven route for the current from endpoint with any processors required
compactPath(String) - Static method in class org.apache.camel.util.FileUtil
Compacts a path by stacking it and reducing ..
comparator(ExpressionResultComparator) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the comparator to use for stream resequencer
comparator(Comparator) - Method in class org.apache.camel.model.SortDefinition
Sets the comparator to use for sorting
comparator() - Method in class org.apache.camel.processor.resequencer.Sequence
Returns this sequence's comparator.
comparatorRef(String) - Method in class org.apache.camel.model.SortDefinition
Sets a reference to lookup for the comparator to use for sorting
compare(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
compare(Exchange, Exchange) - 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 comparison on the objects handling nulls and objects which do not handle sorting gracefully
compare(Object, Object, boolean) - Static method in class org.apache.camel.util.ObjectHelper
A helper method for performing an ordered comparison 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
 
completed() - Method in class org.apache.camel.impl.MainSupport
Marks this process as being completed
completedExchange(double) - Method in class org.apache.camel.management.PerformanceCounter
This method is called when an exchange has been processed successfully.
completionPredicate() - Method in class org.apache.camel.model.AggregateDefinition
Sets the predicate used to determine if the aggregation is completed
completionPredicate(Predicate) - Method in class org.apache.camel.model.AggregateDefinition
Sets the predicate used to determine if the aggregation is completed
Component - Interface in org.apache.camel
A component is a factory of Endpoint objects.
ComponentResolver - 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
 
CompositePackageScanFilter - Class in org.apache.camel.impl.scan
CompositePackageScanFilter allows multiple PackageScanFilters to be composed into a single filter.
CompositePackageScanFilter() - Constructor for class org.apache.camel.impl.scan.CompositePackageScanFilter
 
CompositePackageScanFilter(Set<PackageScanFilter>) - Constructor for class org.apache.camel.impl.scan.CompositePackageScanFilter
 
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
configuration - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
configure(ErrorHandler) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Configures the other error handler based on this error handler.
configure(ErrorHandler) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
configure() - Method in class org.apache.camel.builder.RouteBuilder
Called on initialization to build the routes using the fluent builder syntax.

This is a central method for RouteBuilder implementations to implement the routes using the Java fluent builder syntax.

configure(NamespaceAware) - Method in class org.apache.camel.builder.xml.Namespaces
Configures the namespace aware object
configure(URI) - Method in class org.apache.camel.component.file.GenericFileConfiguration
 
configureBuilder(XPathBuilder) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
configureChild(ProcessorDefinition) - Method in class org.apache.camel.model.ProcessorDefinition
 
configureConsumer(Consumer) - 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.BindyDataFormat
 
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.dataformat.HL7DataFormat
 
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
configureDataFormat(DataFormat) - Method in class org.apache.camel.model.DataFormatDefinition
Allows derived classes to customize the data format
configureExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.SendProcessor
 
configureExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.WireTapProcessor
 
configureExpression(RouteContext, Expression) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
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.LoadBalancerDefinition
Allows derived classes to customize the load balancer
configureMessage(GenericFile<T>, Message) - Method in class org.apache.camel.component.file.GenericFileEndpoint
Configures the given message with the file which sets the body to the file object.
configureMessage(Message) - Method in class org.apache.camel.impl.DefaultExchange
Configures the message after it has been set on the exchange
configureMoveOrPreMoveExpression(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
Strategy to configure the move or premove option based on a String input.
configureNamespaceAware(Object) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
 
configurePredicate(RouteContext, Predicate) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
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
Configure properties on this endpoint.
configureProperties(Map) - Method in class org.apache.camel.impl.DefaultEndpoint
 
configureProperties(Map) - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
configureProperties(Map) - Method in class org.apache.camel.impl.ScheduledPollEndpoint
 
configureRoute(RouteDefinition) - 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 transformer with exchange specific parameters
confirm(String) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
confirm(String) - Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
 
confirm(E) - Method in interface org.apache.camel.spi.IdempotentRepository
Confirms the key, after the exchange has been processed sucesfully.
CONNECTOR_PORT - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
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
Constant - Annotation Type in org.apache.camel.language
Used to inject a constant expression into a field, property, method or parameter when using Bean Integration.
constant(Object) - Static method in class org.apache.camel.language.constant.ConstantLanguage
 
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
ConstantExpression - Class in org.apache.camel.model.language
For expressions and predicates using a constant
ConstantExpression() - Constructor for class org.apache.camel.model.language.ConstantExpression
 
ConstantExpression(String) - Constructor for class org.apache.camel.model.language.ConstantExpression
 
ConstantLanguage - Class in org.apache.camel.language.constant
A language for constant expressions.
ConstantLanguage() - Constructor for class org.apache.camel.language.constant.ConstantLanguage
 
Constants - Class in org.apache.camel.model
 
Consume - Annotation Type in org.apache.camel
Subscribes a method to an Endpoint either via its URI or via the name of the endpoint reference which is then resolved in a registry such as the Spring Application Context.
Consumer - Interface in org.apache.camel
A consumer of message exchanges from an Endpoint
ConsumerCache - Class in org.apache.camel.impl
Cache containing created Consumer.
ConsumerCache() - Constructor for class org.apache.camel.impl.ConsumerCache
 
ConsumerCache(Map<String, PollingConsumer>) - Constructor for class org.apache.camel.impl.ConsumerCache
 
consumerInjection(Method, Object) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
ConsumerTemplate - Interface in org.apache.camel
Template (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and consuming Message instances in an Exchange from an Endpoint.
contains(Expression, Expression) - 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.FileIdempotentRepository
 
contains(String) - Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
 
contains(E) - Method in interface org.apache.camel.spi.IdempotentRepository
Returns true if this repository contains the specified element.
contains(Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
Returns true if the collection contains the specified value
containsKey(Object) - Method in class org.apache.camel.util.CaseInsensitiveMap
 
CONTENT_ENCODING - Static variable in interface org.apache.camel.Exchange
 
CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
 
context - Variable in class org.apache.camel.impl.DefaultExchange
 
continueProcessing(Exchange) - Method in class org.apache.camel.processor.DefaultChannel
Strategy to determine if we should continue processing the Exchange.
continueRouting(Iterator<Processor>, Exchange) - Method in class org.apache.camel.processor.Pipeline
 
convertBeanToEndpoint(String, Object) - Method in class org.apache.camel.impl.DefaultCamelContext
Strategy method for attempting to convert the bean from a Registry to an endpoint using some kind of transformation or wrapper
ConvertBodyDefinition - Class in org.apache.camel.model
Represents an XML <convertBodyTo/> element
ConvertBodyDefinition() - Constructor for class org.apache.camel.model.ConvertBodyDefinition
 
ConvertBodyDefinition(String) - Constructor for class org.apache.camel.model.ConvertBodyDefinition
 
ConvertBodyDefinition(Class) - Constructor for class org.apache.camel.model.ConvertBodyDefinition
 
ConvertBodyDefinition(Class, String) - Constructor for class org.apache.camel.model.ConvertBodyDefinition
 
ConvertBodyProcessor - Class in org.apache.camel.processor
A processor which converts the payload of the input message to be of the given type

If the convertions fails an InvalidPayloadException is thrown.

ConvertBodyProcessor(Class) - Constructor for class org.apache.camel.processor.ConvertBodyProcessor
 
ConvertBodyProcessor(Class, String) - Constructor for class org.apache.camel.processor.ConvertBodyProcessor
 
convertBodyTo(Class) - Method in class org.apache.camel.model.ProcessorDefinition
Converts the IN message body to the specified type
convertBodyTo(Class, String) - Method in class org.apache.camel.model.ProcessorDefinition
Converts the IN message body to the specified type
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
convertPrimitiveTypeToWrapperType(Class) - Static method in class org.apache.camel.util.ObjectHelper
Converts primitive types such as int to its wrapper type like Integer
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<?>, Exchange, Object, TypeConverterRegistry) - Static method in class org.apache.camel.component.file.GenericFileConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.ArrayTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.ArrayTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
convertTo(Class<T>, Exchange, 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>, Exchange, Object) - Method in class org.apache.camel.impl.converter.EnumTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.FutureTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.FutureTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
convertTo(Class<T>, Exchange, 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>, Exchange, Object) - Method in class org.apache.camel.impl.converter.PropertyEditorTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
convertTo(Class<T>, Exchange, 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>, Exchange, 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<T>, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type
convertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type in the context of an exchange

Used when conversion requires extra information from the current exchange (such as encoding).

convertTo(CamelContext, Class<T>, Object) - Static method in class org.apache.camel.util.CamelContextHelper
Converts the given value to the requested type
convertToByteArray(StreamCache, Exchange) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToExpression(Expression, Class) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which converts the given expression to the given type
convertToExpression(Expression, Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression which converts the given expression to the given type the type expression is evaluted to
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
convertToSerializable(StreamCache, Exchange) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToStreamCache(StreamSource, Exchange) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToStreamCache(StringSource) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToStreamCache(BytesSource) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToStreamCache(SAXSource, Exchange) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToStreamCache(InputStream, Exchange) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToStreamCache(Reader, Exchange) - Method in class org.apache.camel.converter.stream.StreamCacheConverter
 
convertToString() - Method in class org.apache.camel.builder.ValueBuilder
Converts the current value to a String using the registered type converters
convertToString(GenericFile, Exchange) - Static method in class org.apache.camel.component.file.GenericFileConverter
 
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 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
 
copy(InputStream, OutputStream) - Static method in class org.apache.camel.util.IOHelper
 
copy(InputStream, OutputStream, int) - Static method in class org.apache.camel.util.IOHelper
 
copyAndCloseInput(InputStream, OutputStream) - Static method in class org.apache.camel.util.IOHelper
 
copyAndCloseInput(InputStream, OutputStream, int) - Static method in class org.apache.camel.util.IOHelper
 
copyExchangeStrategy(Processor, Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
Strategy method to copy the exchange before sending to another endpoint.
copyFrom(GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFile
Creates a copy based on the source
copyFrom(Message) - Method in class org.apache.camel.impl.DefaultMessage
 
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
copyProperties(Object, Object, String) - Static method in class org.apache.camel.util.IntrospectionSupport
Copies the properties from the source to the target
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
copyResultsPreservePattern(Exchange, Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Copies the source exchange to target exchange preserving the ExchangePattern of target.
CORRELATION_ID - Static variable in interface org.apache.camel.Exchange
 
Counter - Class in org.apache.camel.management
 
Counter() - Constructor for class org.apache.camel.management.Counter
 
CREATE_CONNECTOR - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
createAggregator(RouteContext) - Method in class org.apache.camel.model.AggregateDefinition
 
createAndSetExpression(T) - Static method in class org.apache.camel.builder.ExpressionClause
 
createAndSetExpression() - Method in class org.apache.camel.model.AggregateDefinition
 
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.ResequenceDefinition
Creates a batch Resequencer instance applying the given config.
createBean(Class<?>, Map, String) - Static method in class org.apache.camel.util.jndi.JndiContext
 
createBeanInfo(Class<?>) - Method in class org.apache.camel.component.bean.MethodInfoCache
 
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.GenericFileMessage
 
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.impl.DefaultProducerTemplate
 
createBodyAndPropertyProcessor(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
createCacheHolder() - Method in class org.apache.camel.component.bean.RegistryBean
 
createChannel(RouteContext) - Method in class org.apache.camel.model.ProcessorDefinition
Creates a new instance of the Channel.
createComplexConcatExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguageSupport
 
createComponentResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createCompositeProcessor(RouteContext, List<Processor>) - Method in class org.apache.camel.model.MulticastDefinition
 
createCompositeProcessor(RouteContext, List<Processor>) - Method in class org.apache.camel.model.ProcessorDefinition
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.SimpleLanguageSupport
 
createConstantExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguageSupport
 
createConsumer(Processor) - Method in class org.apache.camel.component.browse.BrowseEndpoint
 
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.file.GenericFileEndpoint
 
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
 
createConsumer(Processor) - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
createConsumerProcessor(Object, Method, Endpoint) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Create a processor which invokes the given method when an incoming message exchange is received
createConsumerTemplate() - Method in interface org.apache.camel.CamelContext
Creates a new ConsumerTemplate.
createConsumerTemplate() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createContainer() - Method in class org.apache.camel.builder.RouteBuilder
Factory method
createContext() - Method in class org.apache.camel.impl.JndiRegistry
 
createCorrelatedCopy(Exchange, boolean) - Static method in class org.apache.camel.util.ExchangeHelper
Creates a new instance and copies from the current message exchange so that it can be forwarded to another destination as a new instance.
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.GzipDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.SerializationDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.StringDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.dataformat.ZipDataFormat
 
createDataFormat(RouteContext) - Method in class org.apache.camel.model.DataFormatDefinition
Factory method to create the data format instance
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
 
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, String, Map) - Method in class org.apache.camel.component.browse.BrowseComponent
 
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.GenericFileComponent
 
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
createEndpointUri() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
createEndpointUri() - Method in class org.apache.camel.component.file.FileEndpoint
 
createEndpointUri() - Method in class org.apache.camel.component.log.LogEndpoint
 
createEndpointUri() - Method in class org.apache.camel.impl.DefaultEndpoint
A factory method to lazily create the endpointUri if none is specified
createErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
createErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
createErrorHandler(RouteContext, Processor) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Creates the error handler interceptor
createErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
createErrorHandler(RouteContext, Processor) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
createErrorHandler(RouteContext, 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.ProcessorDefinition
 
createExceptionClasses() - Method in class org.apache.camel.model.CatchDefinition
 
createExceptionClasses() - Method in class org.apache.camel.model.OnExceptionDefinition
 
createExceptionIterator(Throwable) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
Strategy method creating the iterator to walk the exception in the order Camel should use for find the OnExceptionDefinition should be used.
createExceptionIterator(Throwable) - Static method in class org.apache.camel.util.ObjectHelper
Creates an iterator to walk the exception from the bottom up (the last caused by going upwards to the root exception).
createExchange(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Creates a message exchange for the given index in the DataSet
createExchange(GenericFile<File>) - Method in class org.apache.camel.component.file.FileEndpoint
 
createExchange(GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
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(Exchange) - Method in class org.apache.camel.impl.DefaultProducer
 
createExchange() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
createExchange(ExchangePattern) - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
createExchange(Exchange) - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
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(Exchange) - 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
createExchangeId() - Method in class org.apache.camel.impl.DefaultExchange
 
createExchangeId() - Method in class org.apache.camel.impl.DefaultMessage
 
createExchangeId() - Method in interface org.apache.camel.Message
Returns the unique ID for a message exchange if this message is capable of creating one or null if not
createExchangeList() - Method in class org.apache.camel.component.browse.BrowseEndpoint
 
createExecutorService() - Method in class org.apache.camel.processor.ThreadsProcessor
 
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(Object, String) - Method in class org.apache.camel.language.bean.BeanLanguage
 
createExpression(String) - Method in class org.apache.camel.language.constant.ConstantLanguage
 
createExpression(String) - Method in class org.apache.camel.language.header.HeaderLanguage
 
createExpression(String) - Method in class org.apache.camel.language.property.PropertyLanguage
 
createExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguageSupport
 
createExpression() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
Creates a tokenize expression.
createExpression(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
createExpression(String) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
createExpression(RouteContext) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
createExpression(RouteContext) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
createExpression(RouteContext) - Method in class org.apache.camel.model.language.MethodCallExpression
 
createExpression(RouteContext) - Method in class org.apache.camel.model.language.TokenizerExpression
 
createExpression(String) - Method in interface org.apache.camel.spi.Language
Creates an expression based on the given string input
createFileName(Exchange) - Method in class org.apache.camel.component.file.GenericFileProducer
 
createFilter() - Method in class org.apache.camel.model.NodeFactory
 
createFilterProcessor(RouteContext) - Method in class org.apache.camel.model.ExpressionNode
 
createGenericFileProcessStrategy(CamelContext, Map<String, Object>) - Static method in class org.apache.camel.component.file.strategy.FileProcessStrategyFactory
 
createGenericFileProcessStrategy(CamelContext, Map<String, Object>) - Static method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategyFactory
 
createGenericFileStrategy() - Method in class org.apache.camel.component.file.GenericFileEndpoint
A strategy method to lazily create the file strategy
createHandledPolicy() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
createHandledPolicy() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
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
createId(OptionalIdentifiedDefinition) - Method in class org.apache.camel.impl.DefaultNodeIdFactory
 
createId(OptionalIdentifiedDefinition) - Method in interface org.apache.camel.spi.NodeIdFactory
Creates an id for the given model definiton.
createInjectionPollingConsumer(Endpoint) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Factory method to create a started PollingConsumer to be injected into a POJO
createInjectionProducer(Endpoint) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
A Factory method to create a started Producer to be injected into a POJO
createInjectionProducerTemplate(String, String, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Factory method to create a ProducerTemplate to be injected into a POJO
createInjector() - Method in class org.apache.camel.impl.DefaultCamelContext
Lazily create a default implementation
createInstance(Class<T>) - Method in class org.apache.camel.impl.converter.CachingInjector
 
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
createIterator(Object) - Static method in class org.apache.camel.util.ObjectHelper
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

Will default use comma for String separating String values.

createIterator(Object, String) - Static method in class org.apache.camel.util.ObjectHelper
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
createJmxConnector(String) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.RandomLoadBalancerDefinition
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.RoundRobinLoadBalancerDefinition
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.loadbalancer.TopicLoadBalancerDefinition
 
createLoadBalancer(RouteContext) - Method in class org.apache.camel.model.LoadBalancerDefinition
Factory method to create the load balancer instance
createLogger() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
createLogger() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
createLogMessage(Exchange, int) - Method in class org.apache.camel.processor.ThroughputLogger
 
createLoop() - Method in class org.apache.camel.model.NodeFactory
 
createLruCache(int) - Static method in class org.apache.camel.component.bean.MethodInfoCache
 
createMBeanServer() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
createMessage(String, Exchange) - Static method in exception org.apache.camel.CamelExchangeException
 
createMessage(Object, Class) - Static method in exception org.apache.camel.NoTypeConversionAvailableException
Returns an error message for no type converter available.
createMessage(String, Exchange) - Static method in exception org.apache.camel.RuntimeExchangeException
 
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
createMethodInfo(Class, Method) - Method in class org.apache.camel.component.bean.BeanInfo
 
createMethodInfo(Method) - Method in class org.apache.camel.component.bean.MethodInfoCache
 
createMethodInfoCache(Endpoint) - Static method in class org.apache.camel.component.bean.ProxyHelper
 
createMethodInvocation(Object, Exchange) - Method in class org.apache.camel.component.bean.MethodInfo
 
createModelFileGenerator() - Method in class org.apache.camel.impl.MainSupport
 
createNextExchange(Exchange) - Method in class org.apache.camel.processor.Pipeline
Strategy method to create the next exchange from the previous exchange.
createObjectName(StringBuffer) - Method in class org.apache.camel.management.CamelNamingStrategy
Factory method to create an ObjectName escaping any required characters
createOutputsProcessor(RouteContext, Collection<ProcessorDefinition>) - Method in class org.apache.camel.model.LoadBalanceDefinition
 
createOutputsProcessor(RouteContext) - Method in class org.apache.camel.model.ProcessorDefinition
 
createOutputsProcessor(RouteContext, Collection<ProcessorDefinition>) - Method in class org.apache.camel.model.ProcessorDefinition
 
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
 
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.InterceptSendToEndpoint
 
createPollingConsumer() - Method in class org.apache.camel.impl.ProcessorEndpoint
 
createPredicate(String) - Method in class org.apache.camel.language.bean.BeanLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.constant.ConstantLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.header.HeaderLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.property.PropertyLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.simple.SimpleLanguageSupport
 
createPredicate(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.xpath.XPathLanguage
 
createPredicate(RouteContext) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
createPredicate(RouteContext) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
createPredicate(RouteContext) - Method in class org.apache.camel.model.language.MethodCallExpression
 
createPredicate(String) - Method in interface org.apache.camel.spi.Language
Creates a predicate based on the given string input
createProcessor() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
createProcessor(ProcessorDefinition) - Method in class org.apache.camel.impl.DefaultRouteContext
 
createProcessor() - Method in class org.apache.camel.impl.ProcessorEndpoint
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.AggregateDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.AOPDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.BeanDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.CatchDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ChoiceDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ConvertBodyDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.DelayDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.EnrichDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.FilterDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.FinallyDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.InterceptDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.InterceptFromDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.LoadBalanceDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.LoopDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.MarshalDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.MulticastDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.OnCompletionDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.OnExceptionDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.OtherwiseDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.PipelineDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.PolicyDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.PollEnrichDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ProcessDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ProcessorDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.RecipientListDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.RemovePropertyDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ResequenceDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.RollbackDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.RoutingSlipDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SendDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SetBodyDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SetHeaderDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SetOutHeaderDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SetPropertyDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SortDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.SplitDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.StopDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ThreadsDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ThrottleDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.TransactedDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.TransformDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.TryDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.UnmarshalDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.WhenDefinition
 
createProcessor(RouteContext) - Method in class org.apache.camel.model.WireTapDefinition
 
createProcessor(ProcessorDefinition) - Method in interface org.apache.camel.spi.RouteContext
Creates a processor
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.browse.BrowseEndpoint
 
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.file.GenericFileEndpoint
 
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.InterceptSendToEndpoint
 
createProducer() - Method in class org.apache.camel.impl.ProcessorEndpoint
 
createProducerTemplate() - Method in interface org.apache.camel.CamelContext
Creates a new ProducerTemplate.
createProducerTemplate() - Method in class org.apache.camel.impl.DefaultCamelContext
 
createProxy(Endpoint, ClassLoader, Class[], MethodInfoCache) - 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.
createProxy(Endpoint, Producer, Class<T>...) - Static method in class org.apache.camel.component.bean.ProxyHelper
Creates a Proxy which sends PojoExchange to the endpoint.
createProxyInstantiationRuntimeException(Class<?>, Endpoint, Exception) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
createProxyObject(Endpoint, Producer, ClassLoader, Class[], MethodInfoCache) - 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() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
createRedeliveryPolicy() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
createRedeliveryPolicy(CamelContext, RedeliveryPolicy) - Method in class org.apache.camel.model.OnExceptionDefinition
Allows an exception handler to create a new redelivery policy for this exception type
createRedeliveryPolicy(CamelContext, RedeliveryPolicy) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
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
 
createReporter() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
createResourceExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.Enricher
Creates a new DefaultExchange instance from the given exchange.
createResourceExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.PollEnricher
Creates a new DefaultExchange instance from the given exchange.
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.RoutesDefinition
 
createRouteBuilder(CamelContext) - Method in class org.apache.camel.model.RouteBuilderDefinition
 
createRouteGroupMap(List<RouteDefinition>) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
createRouteGroupMap(RouteDefinition) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
createRoutes(CamelContext) - Method in class org.apache.camel.model.RouteBuilderDefinition
 
createScheduledExecutorService() - Method in class org.apache.camel.impl.DefaultComponent
A factory method to create a default thread pool and executor
createScheduledExecutorService() - Method in class org.apache.camel.impl.DefaultEndpoint
 
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) - 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.impl.DefaultProducerTemplate
 
createSetContaining(T...) - Static method in class org.apache.camel.util.CollectionHelper
 
createSimpleExpression(String, boolean) - Method in class org.apache.camel.language.simple.FileLanguage
 
createSimpleExpression(String, boolean) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createSimpleExpression(String, boolean) - Method in class org.apache.camel.language.simple.SimpleLanguageSupport
Creates the simple expression based on the extracted content from the ${ } place holders
createSimpleOrConstantExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguageSupport
 
createStreamResequencer(RouteContext, StreamResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
Creates a StreamResequencer instance applying the given config.
createSubcontext(Name) - Method in class org.apache.camel.util.jndi.JndiContext
 
createSubcontext(String) - Method in class org.apache.camel.util.jndi.JndiContext
 
createTask(Processor, Exchange) - Method in class org.apache.camel.processor.ThreadsProcessor
 
createTempFile(String, String) - Static method in class org.apache.camel.util.FileUtil
 
createTempFile(String, String, File) - Static method in class org.apache.camel.util.FileUtil
 
createTempFileName(String) - Method in class org.apache.camel.component.file.GenericFileProducer
 
createTracer(CamelContext) - Static method in class org.apache.camel.processor.interceptor.Tracer
Creates a new tracer.
createTransfomer() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
createTransformerFactory() - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
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

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 ProcessorDefinition> - 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
DataFormat operations.
DataFormatDefinition - Class in org.apache.camel.model
Represents the base XML type for DataFormat.
DataFormatDefinition() - Constructor for class org.apache.camel.model.DataFormatDefinition
 
DataFormatDefinition(DataFormat) - Constructor for class org.apache.camel.model.DataFormatDefinition
 
DataFormatDefinition(String) - Constructor for class org.apache.camel.model.DataFormatDefinition
 
DataFormatsDefinition - Class in org.apache.camel.model.dataformat
Represents the XML type for a collection of DataFormats.
DataFormatsDefinition() - Constructor for class org.apache.camel.model.dataformat.DataFormatsDefinition
 
DataSet - Interface in org.apache.camel.component.dataset
Represents a strategy for testing endpoints with canned data.
DATASET_INDEX - Static variable in interface org.apache.camel.Exchange
 
DataSetComponent - Class in org.apache.camel.component.dataset
Component for DataSet.
DataSetComponent() - Constructor for class org.apache.camel.component.dataset.DataSetComponent
 
DataSetConsumer - Class in org.apache.camel.component.dataset
DataSet consumer.
DataSetConsumer(DataSetEndpoint, Processor) - Constructor for class org.apache.camel.component.dataset.DataSetConsumer
 
DataSetEndpoint - Class in org.apache.camel.component.dataset
Endpoint for DataSet.
DataSetEndpoint() - Constructor for class org.apache.camel.component.dataset.DataSetEndpoint
 
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
Base class for DataSet
DataSetSupport() - Constructor for class org.apache.camel.component.dataset.DataSetSupport
 
DataSetSupport(int) - Constructor for class org.apache.camel.component.dataset.DataSetSupport
 
dateExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
dateExpression(String, String) - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
days(long) - Static method in class org.apache.camel.util.Time
 
daysAsSeconds(long) - Static method in class org.apache.camel.util.Time
 
deadLetter - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
deadLetter - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
deadLetterChannel(String) - Method in class org.apache.camel.builder.BuilderSupport
Dead Letter Channel EIP: is a error handler for handling messages that could not be delivered to it's intented destination.
deadLetterChannel(Endpoint) - Method in class org.apache.camel.builder.BuilderSupport
Dead Letter Channel EIP: is a error handler for handling messages that could not be delivered to it's intented destination.
DeadLetterChannel - Class in org.apache.camel.processor
Implements a Dead Letter Channel after attempting to redeliver the message using the RedeliveryPolicy
DeadLetterChannel(Processor, Logger, Processor, RedeliveryPolicy, Predicate, ExceptionPolicyStrategy, Processor, String, boolean) - Constructor for class org.apache.camel.processor.DeadLetterChannel
Creates the dead letter channel.
DeadLetterChannelBuilder - Class in org.apache.camel.builder
A builder of a Dead Letter Channel
DeadLetterChannelBuilder() - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
DeadLetterChannelBuilder(Endpoint) - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
DeadLetterChannelBuilder(String) - Constructor for class org.apache.camel.builder.DeadLetterChannelBuilder
 
deadLetterUri - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
deadLetterUri - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
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_CONNECTION_PORT - Static variable in class org.apache.camel.management.DefaultInstrumentationAgent
 
DEFAULT_DELIMITER - Static variable in class org.apache.camel.model.RoutingSlipDefinition
 
DEFAULT_DOMAIN - Static variable in class org.apache.camel.management.DefaultInstrumentationAgent
 
DEFAULT_ERROR_HANDLER_BUILDER - Static variable in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
DEFAULT_HOST - Static variable in class org.apache.camel.management.DefaultInstrumentationAgent
 
DEFAULT_IDEMPOTENT_CACHE_SIZE - Static variable in class org.apache.camel.component.file.GenericFileEndpoint
 
DEFAULT_LOCK_FILE_POSTFIX - Static variable in class org.apache.camel.component.file.FileComponent
Default camel lock filename postfix
DEFAULT_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
DEFAULT_REGISTRY_PORT - Static variable in class org.apache.camel.management.DefaultInstrumentationAgent
 
DEFAULT_SERVICE_URL_PATH - Static variable in class org.apache.camel.management.DefaultInstrumentationAgent
 
DEFAULT_STRATEGYFACTORY_CLASS - Static variable in class org.apache.camel.component.file.GenericFileEndpoint
 
DEFAULT_THREADPOOL_SIZE - Static variable in class org.apache.camel.processor.ThreadsProcessor
 
DefaultAggregationCollection - 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.
DefaultAggregationCollection() - Constructor for class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
DefaultAggregationCollection(Expression, AggregationStrategy) - Constructor for class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
DefaultAnnotationExpressionFactory - Class in org.apache.camel.component.bean
Default implementation of the AnnotationExpressionFactory.
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
DefaultChannel - Class in org.apache.camel.processor
DefaultChannel is the default Channel.
DefaultChannel() - Constructor for class org.apache.camel.processor.DefaultChannel
 
defaultCharset - Static variable in class org.apache.camel.converter.jaxp.XmlConverter
 
DefaultClassResolver - Class in org.apache.camel.impl
Default class resolver that uses regular class loader to load classes.
DefaultClassResolver() - Constructor for class org.apache.camel.impl.DefaultClassResolver
 
DefaultComponent - 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 - 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 - Class in org.apache.camel.impl
A default consumer useful for implementation inheritance.
DefaultConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.impl.DefaultConsumer
 
DefaultConsumerTemplate - Class in org.apache.camel.impl
 
DefaultConsumerTemplate(CamelContext) - Constructor for class org.apache.camel.impl.DefaultConsumerTemplate
 
DefaultEndpoint - 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
 
DefaultEndpoint() - Constructor for class org.apache.camel.impl.DefaultEndpoint
 
defaultErrorHandler() - Method in class org.apache.camel.builder.BuilderSupport
Creates a default error handler.
DefaultErrorHandler - Class in org.apache.camel.processor
Default error handler
DefaultErrorHandler(Processor, Logger, Processor, RedeliveryPolicy, Predicate, ExceptionPolicyStrategy) - Constructor for class org.apache.camel.processor.DefaultErrorHandler
Creates the default error handler.
DefaultErrorHandlerBuilder - Class in org.apache.camel.builder
The default error handler builder.
DefaultErrorHandlerBuilder() - Constructor for class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
DefaultExceptionPolicyStrategy - Class in org.apache.camel.processor.exceptionpolicy
The default strategy used in Camel to resolve the OnExceptionDefinition 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(Exchange) - Constructor for class org.apache.camel.impl.DefaultExchange
 
DefaultExchange(Endpoint) - Constructor for class org.apache.camel.impl.DefaultExchange
 
DefaultExchange(Endpoint, ExchangePattern) - 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
 
DefaultExchangeFormatter - Class in org.apache.camel.impl
A default ExchangeFormatter which just uses the Exchange toString() method
DefaultExchangeFormatter() - Constructor for class org.apache.camel.impl.DefaultExchangeFormatter
 
DefaultExchangeHolder - Class in org.apache.camel.impl
Holder object for sending an exchange over a remote wire as a serialized object.
DefaultExchangeHolder() - Constructor for class org.apache.camel.impl.DefaultExchangeHolder
 
DefaultFactoryFinder - Class in org.apache.camel.impl
Default factory finder.
DefaultFactoryFinder(ClassResolver, String) - Constructor for class org.apache.camel.impl.DefaultFactoryFinder
 
DefaultFactoryFinderResolver - Class in org.apache.camel.impl
Default factory finder.
DefaultFactoryFinderResolver() - Constructor for class org.apache.camel.impl.DefaultFactoryFinderResolver
 
DefaultHeaderFilterStrategy - Class in org.apache.camel.impl
The default header filtering strategy.
DefaultHeaderFilterStrategy() - Constructor for class org.apache.camel.impl.DefaultHeaderFilterStrategy
 
DefaultInstrumentationAgent - Class in org.apache.camel.management
Default implementation of the Camel JMX service agent
DefaultInstrumentationAgent() - Constructor for class org.apache.camel.management.DefaultInstrumentationAgent
 
DefaultLanguageResolver - Class in org.apache.camel.impl
Default language resolver that looks for language factories in META-INF/services/org/apache/camel/language/ and language resolvers in META-INF/services/org/apache/camel/language/resolver/.
DefaultLanguageResolver() - Constructor for class org.apache.camel.impl.DefaultLanguageResolver
 
DefaultLifecycleStrategy - Class in org.apache.camel.impl
Default implementation of the lifecycle strategy.
DefaultLifecycleStrategy() - Constructor for class org.apache.camel.impl.DefaultLifecycleStrategy
 
DefaultMessage - Class in org.apache.camel.impl
The default implementation of Message

This implementation uses a CaseInsensitiveMap storing the headers.

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
 
DefaultNodeIdFactory - Class in org.apache.camel.impl
Default id factory.
DefaultNodeIdFactory() - Constructor for class org.apache.camel.impl.DefaultNodeIdFactory
 
defaultOutputProperties() - Method in class org.apache.camel.converter.jaxp.XmlConverter
Returns the default set of output properties for conversions.
DefaultPackageScanClassResolver - Class in org.apache.camel.impl
Default implement of PackageScanClassResolver
DefaultPackageScanClassResolver() - Constructor for class org.apache.camel.impl.DefaultPackageScanClassResolver
 
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
 
DefaultPollingConsumerPollStrategy - Class in org.apache.camel.impl
A default implementation that just logs a WARN level log in case of rollback.
DefaultPollingConsumerPollStrategy() - Constructor for class org.apache.camel.impl.DefaultPollingConsumerPollStrategy
 
DefaultPollingEndpoint - Class in org.apache.camel.impl
A base class for an endpoint which the default consumer mode is to use a PollingConsumer
DefaultPollingEndpoint() - Constructor for class org.apache.camel.impl.DefaultPollingEndpoint
 
DefaultPollingEndpoint(String) - Constructor for class org.apache.camel.impl.DefaultPollingEndpoint
 
DefaultPollingEndpoint(String, Component) - Constructor for class org.apache.camel.impl.DefaultPollingEndpoint
 
DefaultPollingEndpoint(String, CamelContext) - 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 - Class in org.apache.camel.impl
A default implementation of @{link Producer} for implementation inheritence
DefaultProducer(Endpoint) - Constructor for class org.apache.camel.impl.DefaultProducer
 
DefaultProducerServicePool - Class in org.apache.camel.impl
A service pool for Producer.
DefaultProducerServicePool(int) - Constructor for class org.apache.camel.impl.DefaultProducerServicePool
 
DefaultProducerTemplate - Class in org.apache.camel.impl
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.
DefaultProducerTemplate(CamelContext) - Constructor for class org.apache.camel.impl.DefaultProducerTemplate
 
DefaultProducerTemplate(CamelContext, ExecutorService) - Constructor for class org.apache.camel.impl.DefaultProducerTemplate
 
DefaultProducerTemplate(CamelContext, Endpoint) - Constructor for class org.apache.camel.impl.DefaultProducerTemplate
 
DefaultRoute - Class in org.apache.camel.impl
A Route defines the processing used on an inbound message exchange from a specific Endpoint within a CamelContext
DefaultRoute(Endpoint) - Constructor for class org.apache.camel.impl.DefaultRoute
 
DefaultRoute(Endpoint, Service...) - Constructor for class org.apache.camel.impl.DefaultRoute
 
DefaultRouteContext - Class in org.apache.camel.impl
The context used to activate new routing rules
DefaultRouteContext(RouteDefinition, FromDefinition, Collection<Route>) - Constructor for class org.apache.camel.impl.DefaultRouteContext
 
DefaultRouteContext(CamelContext) - Constructor for class org.apache.camel.impl.DefaultRouteContext
Only used for lazy construction from inside ExpressionType
DefaultRouteNode - Class in org.apache.camel.impl
A default implementation of the RouteNode
DefaultRouteNode(ProcessorDefinition, Processor) - Constructor for class org.apache.camel.impl.DefaultRouteNode
 
DefaultRouteNode(ProcessorDefinition, Expression) - Constructor for class org.apache.camel.impl.DefaultRouteNode
 
DefaultScheduledPollConsumer - Class in org.apache.camel.impl
A default implementation of an event driven Consumer which uses the PollingConsumer
DefaultScheduledPollConsumer(DefaultEndpoint, Processor) - Constructor for class org.apache.camel.impl.DefaultScheduledPollConsumer
 
DefaultScheduledPollConsumer(Endpoint, Processor, ScheduledExecutorService) - Constructor for class org.apache.camel.impl.DefaultScheduledPollConsumer
 
DefaultServicePool<Key,Service> - Class in org.apache.camel.impl
Default implementation to inherit for a basic service pool.
DefaultServicePool(int) - Constructor for class org.apache.camel.impl.DefaultServicePool
The capacity, note this is per key.
DefaultTimeoutMap - Class in org.apache.camel.util
Default implementation of the TimeoutMap.
DefaultTimeoutMap() - Constructor for class org.apache.camel.util.DefaultTimeoutMap
 
DefaultTimeoutMap(ScheduledExecutorService, long) - Constructor for class org.apache.camel.util.DefaultTimeoutMap
 
DefaultTraceEventMessage - Class in org.apache.camel.processor.interceptor
Default TraceEventMessage.
DefaultTraceEventMessage(Date, ProcessorDefinition, Exchange) - Constructor for class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
Creates a DefaultTraceEventMessage based on the given node it was traced while processing the current Exchange
DefaultTraceFormatter - Class in org.apache.camel.processor.interceptor
 
DefaultTraceFormatter() - Constructor for class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
DefaultTypeConverter - Class in org.apache.camel.impl.converter
Default implementation of a type converter registry used for type converters in Camel.
DefaultTypeConverter(PackageScanClassResolver, Injector, FactoryFinder) - 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(Exchange) - 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(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Delayer EIP: Creates a delayer allowing you to delay the delivery of messages to some destination.
delay() - Method in class org.apache.camel.model.ProcessorDefinition
Delayer EIP: Creates a delayer allowing you to delay the delivery of messages to some destination.
delay(long) - Method in class org.apache.camel.model.ProcessorDefinition
Delayer EIP: Creates a delayer allowing you to delay the delivery of messages to some destination.
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.interceptor.DelayInterceptor
 
delay(Exchange) - Method in class org.apache.camel.processor.Throttler
 
DelayDefinition - Class in org.apache.camel.model
Represents an XML <delay/> element
DelayDefinition() - Constructor for class org.apache.camel.model.DelayDefinition
 
DelayDefinition(Expression) - Constructor for class org.apache.camel.model.DelayDefinition
 
delayer(long) - Method in class org.apache.camel.model.RouteDefinition
Enable delayer for this route.
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) - Constructor for class org.apache.camel.processor.Delayer
 
Delayer - Class in org.apache.camel.processor.interceptor
An interceptor strategy for delaying routes.
Delayer() - Constructor for class org.apache.camel.processor.interceptor.Delayer
 
Delayer(long) - Constructor for class org.apache.camel.processor.interceptor.Delayer
 
DelayInterceptor - Class in org.apache.camel.processor.interceptor
An interceptor for delaying routes.
DelayInterceptor(ProcessorDefinition, Processor, Delayer) - Constructor for class org.apache.camel.processor.interceptor.DelayInterceptor
 
delayPattern(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
delayPattern - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
delayPattern(String) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the delay pattern with delay intervals.
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
 
delayTime(Long) - Method in class org.apache.camel.model.DelayDefinition
Sets the delay time in millis to delay
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
 
delete - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
delete(File) - Static method in class org.apache.camel.util.FileUtil
 
deleteFile(String) - Method in class org.apache.camel.component.file.FileOperations
 
deleteFile(String) - Method in interface org.apache.camel.component.file.GenericFileOperations
Deletes the file name by name, relative to the current directory
deliver() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Delivers all elements which are currently ready to deliver.
deliverNext() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Attempts to deliver a single element from the head of the resequencer queue (sequence).
deliverToFailureProcessor(Processor, Exchange, RedeliveryErrorHandler.RedeliveryData) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
All redelivery attempts failed so move the exchange to the dead letter queue
deliverToRedeliveryProcessor(Exchange, RedeliveryErrorHandler.RedeliveryData) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Gives an optional configure redelivery processor a chance to process before the Exchange will be redelivered.
description(String, String, Endpoint) - Static method in class org.apache.camel.model.FromDefinition
 
description(String, String, String) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Sets the description of this node
description() - Method in class org.apache.camel.model.PolicyDefinition
 
description() - Method in class org.apache.camel.model.TransactedDefinition
 
DescriptionDefinition - Class in org.apache.camel.model
Represents a description element which can be used on any element in the EIP route
DescriptionDefinition() - Constructor for class org.apache.camel.model.DescriptionDefinition
 
destination - Variable in class org.apache.camel.processor.SendProcessor
 
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 - Class in org.apache.camel.component.direct
Represents the component that manages DirectEndpoint.
DirectComponent() - Constructor for class org.apache.camel.component.direct.DirectComponent
 
DirectConsumer - Class in org.apache.camel.component.direct
The direct consumer.
DirectConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.component.direct.DirectConsumer
 
DirectEndpoint - 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() - Constructor for class org.apache.camel.component.direct.DirectEndpoint
 
DirectEndpoint(String, DirectComponent) - Constructor for class org.apache.camel.component.direct.DirectEndpoint
 
DirectEndpoint(String) - Constructor for class org.apache.camel.component.direct.DirectEndpoint
 
DirectProducer - Class in org.apache.camel.component.direct
The direct producer.
DirectProducer(DirectEndpoint) - Constructor for class org.apache.camel.component.direct.DirectProducer
 
DISABLED - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
disableRedelivery() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
disableRedelivery() - Method in class org.apache.camel.processor.RedeliveryPolicy
Disables redelivery by setting maximum redeliveries to 0.
doAggregate(AtomicExchange, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Aggregate the Exchange with the current result
doCatch(Class...) - Method in class org.apache.camel.model.TryDefinition
Handles the given exception(s)
doConvertTo(Class, Exchange, Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
doFinally() - Method in class org.apache.camel.model.TryDefinition
The finally block for a given handle
doGetProducer(Endpoint, boolean) - Method in class org.apache.camel.impl.ProducerCache
 
doInProducer(Endpoint, Exchange, ExchangePattern, ProducerCallback<T>) - Method in class org.apache.camel.impl.ProducerCache
Sends an exchange to an endpoint using a supplied callback
doInProducer(Producer, Exchange, ExchangePattern) - Method in interface org.apache.camel.ProducerCallback
Performs operation on the given producer to send the given exchange.
DOMAIN - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
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
Factory for DomResultHandler
DomResultHandlerFactory() - Constructor for class org.apache.camel.builder.xml.DomResultHandlerFactory
 
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
doProcess(String, LinkedList<String>) - Method in class org.apache.camel.impl.MainSupport.Option
 
doProcess(String, LinkedList<String>) - Method in class org.apache.camel.impl.MainSupport.ParameterOption
 
doProcess(String, String, LinkedList<String>) - Method in class org.apache.camel.impl.MainSupport.ParameterOption
 
doProcessParallel(AtomicExchange, Iterable<MulticastProcessor.ProcessorExchangePair>, boolean) - Method in class org.apache.camel.processor.MulticastProcessor
 
doProcessSequntiel(AtomicExchange, Iterable<MulticastProcessor.ProcessorExchangePair>) - Method in class org.apache.camel.processor.MulticastProcessor
 
doResolvePolicy(RouteContext, String, Class<? extends Policy>) - Static method in class org.apache.camel.model.TransactedDefinition
 
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.SedaConsumer
 
doStart() - Method in class org.apache.camel.component.seda.SedaProducer
 
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.ConsumerCache
 
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.DefaultProducerTemplate
 
doStart() - Method in class org.apache.camel.impl.DefaultScheduledPollConsumer
 
doStart() - Method in class org.apache.camel.impl.DefaultServicePool
 
doStart() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
doStart() - Method in class org.apache.camel.impl.MainSupport
 
doStart() - Method in class org.apache.camel.impl.ProcessorPollingConsumer
 
doStart() - Method in class org.apache.camel.impl.ProducerCache
 
doStart() - Method in class org.apache.camel.impl.RouteService
 
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.DefaultInstrumentationAgent
 
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.DefaultChannel
 
doStart() - Method in class org.apache.camel.processor.DelegateProcessor
 
doStart() - Method in class org.apache.camel.processor.Enricher
 
doStart() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doStart() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
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.OnCompletionProcessor
 
doStart() - Method in class org.apache.camel.processor.PollEnricher
 
doStart() - Method in class org.apache.camel.processor.RecipientList
 
doStart() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
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.processor.WireTapProcessor
 
doStop() - Method in class org.apache.camel.component.bean.BeanProcessor
 
doStop() - Method in class org.apache.camel.component.seda.SedaComponent
 
doStop() - Method in class org.apache.camel.component.seda.SedaConsumer
 
doStop() - Method in class org.apache.camel.component.seda.SedaProducer
 
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.ConsumerCache
 
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.DefaultProducerTemplate
 
doStop() - Method in class org.apache.camel.impl.DefaultScheduledPollConsumer
 
doStop() - Method in class org.apache.camel.impl.DefaultServicePool
 
doStop() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
doStop() - Method in class org.apache.camel.impl.MainSupport
 
doStop() - Method in class org.apache.camel.impl.ProcessorPollingConsumer
 
doStop() - Method in class org.apache.camel.impl.ProducerCache
 
doStop() - Method in class org.apache.camel.impl.RouteService
 
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.DefaultInstrumentationAgent
 
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.DefaultChannel
 
doStop() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
doStop() - Method in class org.apache.camel.processor.DelegateProcessor
 
doStop() - Method in class org.apache.camel.processor.Enricher
 
doStop() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doStop() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
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.OnCompletionProcessor
 
doStop() - Method in class org.apache.camel.processor.PollEnricher
 
doStop() - Method in class org.apache.camel.processor.RecipientList
 
doStop() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
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.ThreadsProcessor
 
doStop() - Method in class org.apache.camel.processor.TryProcessor
 
doStop() - Method in class org.apache.camel.processor.WireTapProcessor
 
dotOutputDir - Variable in class org.apache.camel.impl.MainSupport
 
doTry() - Method in class org.apache.camel.model.ProcessorDefinition
Creates a try/catch block
drawRoutes(CamelContext) - Method in class org.apache.camel.view.GraphGeneratorSupport
 

E

eager(boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets whether to eagerly add the key to the idempotent repository or wait until the exchange is complete.
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 expressions and predicates
ELExpression() - Constructor for class org.apache.camel.model.language.ELExpression
 
ELExpression(String) - Constructor for class org.apache.camel.model.language.ELExpression
 
enableTrace() - Method in class org.apache.camel.impl.MainSupport
 
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.OnCompletionDefinition
 
end() - Method in class org.apache.camel.model.ProcessorDefinition
Ends the current block
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 - Variable in class org.apache.camel.component.file.GenericFileConsumer
 
endpoint - Variable in class org.apache.camel.component.file.GenericFileProducer
 
Endpoint - Interface in org.apache.camel
An endpoint implements the Message Endpoint pattern and represents an endpoint that can send and receive message exchanges
endpoint - Variable in class org.apache.camel.model.SendDefinition
 
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 or ProducerTemplate 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
EndpointStrategy - Interface in org.apache.camel.spi
Endpoint strategy with callback invoked when an Endpoint is about to be registered to the endopoint registry in CamelContext.
endsWith(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
endsWith(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
enrich(String, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri.
enrich(String) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri.
EnrichDefinition - Class in org.apache.camel.model
Represents an XML <enrich/> element
EnrichDefinition() - Constructor for class org.apache.camel.model.EnrichDefinition
 
EnrichDefinition(String) - Constructor for class org.apache.camel.model.EnrichDefinition
 
EnrichDefinition(AggregationStrategy, String) - Constructor for class org.apache.camel.model.EnrichDefinition
 
Enricher - Class in org.apache.camel.processor
A content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producer and second by aggregating input data and additional data.
Enricher(Producer) - Constructor for class org.apache.camel.processor.Enricher
Creates a new Enricher.
Enricher(AggregationStrategy, Producer) - Constructor for class org.apache.camel.processor.Enricher
Creates a new Enricher.
entrySet() - Method in class org.apache.camel.util.CaseInsensitiveMap
 
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.converter.stream.CachedOutputStream
 
equals(Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
equals(Object) - Method in class org.apache.camel.impl.DefaultEndpoint
 
equals(Object) - Method in class org.apache.camel.impl.ReportingTypeConverterLoader.TypeMapping
 
equals(Object) - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
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.ProcessorDefinition
Installs the given error handler builder.
ErrorHandler - Interface in org.apache.camel.processor
An interface used to represent an error handler
ERRORHANDLER_HANDLED - Static variable in interface org.apache.camel.Exchange
 
ErrorHandlerBuilder - Interface in org.apache.camel.builder
A builder of a Error Handler
ErrorHandlerBuilderRef - Class in org.apache.camel.builder
Represents a proxy to an error handler builder which is resolved by named reference
ErrorHandlerBuilderRef(String) - Constructor for class org.apache.camel.builder.ErrorHandlerBuilderRef
 
ErrorHandlerBuilderSupport - Class in org.apache.camel.builder
Base class for builders of error handling.
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(Exchange, Class<T>) - Method in class org.apache.camel.builder.ValueBuilder
 
evaluate(Exchange) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
evaluate(Exchange, Class<T>) - Method in interface org.apache.camel.Expression
Returns the value of the expression on the given exchange
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.impl.ExpressionAdapter
 
evaluate(Exchange) - Method in class org.apache.camel.impl.ExpressionSupport
 
evaluate(Exchange) - Method in class org.apache.camel.language.bean.BeanExpression
 
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.language.bean.BeanExpression
 
evaluate(Exchange) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
evaluate(Exchange, Class<T>) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
evaluateAs(Exchange, QName) - Method in class org.apache.camel.builder.xml.XPathBuilder
Evaluates the expression as the given result type
evaluateValuePredicate(Object) - Static method in class org.apache.camel.util.ObjectHelper
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 - Class in org.apache.camel.impl
A DefaultRoute which starts with an Event Driven Consumer
EventDrivenConsumerRoute(Endpoint, Processor) - Constructor for class org.apache.camel.impl.EventDrivenConsumerRoute
 
EventDrivenPollingConsumer - 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) - Constructor for class org.apache.camel.impl.EventDrivenPollingConsumer
 
EventDrivenPollingConsumer(Endpoint, BlockingQueue<Exchange>) - Constructor for class org.apache.camel.impl.EventDrivenPollingConsumer
 
EXCEPTION_CAUGHT - Static variable in interface org.apache.camel.Exchange
 
exceptionClasses(List<Class>) - Method in class org.apache.camel.model.CatchDefinition
Sets the exceptionClasses of the CatchType
exceptionClasses(Class) - Method in class org.apache.camel.model.CatchDefinition
Sets the exception class that the CatchType want to catch
ExceptionHandler - Interface in org.apache.camel.spi
A Strategy pattern for handling exceptions; particularly in asynchronous processes such as consumers
exceptionMessage() - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for the exception message on an exchange
exceptionMessage() - Method in class org.apache.camel.builder.BuilderSupport
Returns a exception expression value builder
ExceptionPolicyKey - Class in org.apache.camel.processor.exceptionpolicy
Exception policy key is a compound key for storing: exception class + when => exception type.
ExceptionPolicyKey(Class, WhenDefinition) - Constructor for class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
exceptionPolicyStrategy - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
exceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the exception policy to use
exceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
Sets the exception policy to use
ExceptionPolicyStrategy - Interface in org.apache.camel.processor.exceptionpolicy
A strategy to determine which OnExceptionDefinition should handle the thrown exception.
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
 
ExchangeException - Annotation Type in org.apache.camel
Marks a parameter as being the exception set on an exchange
exchangeExceptionExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for an exception set on the exchange
exchangeExceptionExpression(Class<Exception>) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for an exception set on the exchange

Is used to get the caused exception that typically have been wrapped in some sort of Camel wrapper exception

exchangeExceptionMessageExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for an exception message set on the exchange
exchangeExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns the expression for the exchange
ExchangeFormatter - Interface in org.apache.camel.spi
A plugin used to turn an Exchange into a String representation usually to be used for logging or tracing purposes.
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
ExchangePatternProcessor - Class in org.apache.camel.processor
 
ExchangePatternProcessor() - Constructor for class org.apache.camel.processor.ExchangePatternProcessor
 
ExchangePatternProcessor(ExchangePattern) - Constructor for class org.apache.camel.processor.ExchangePatternProcessor
 
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
 
exclude - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
exclusiveReadLockStrategy - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
exclusiveReadLockStrategy - Variable in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
 
executorService(ExecutorService) - Method in class org.apache.camel.model.MulticastDefinition
Setting the executor service for executing the multicasting action.
executorService(ExecutorService) - Method in class org.apache.camel.model.SplitDefinition
Setting the executor service for executing the splitting action.
executorService(ExecutorService) - Method in class org.apache.camel.model.ThreadsDefinition
Setting the executor service for executing the multicasting action.
executorService - Variable in class org.apache.camel.processor.ThreadsProcessor
 
ExecutorServiceHelper - Class in org.apache.camel.util.concurrent
Helper for ExecutorService to construct executors using a thread factory that create thread names with Camel prefix.
existsFile(String) - Method in class org.apache.camel.component.file.FileOperations
 
existsFile(String) - Method in interface org.apache.camel.component.file.GenericFileOperations
Determines whether the files exists or not
expectedBodiesReceived(List) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint in the specified order
expectedBodiesReceived(Object...) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint
expectedBodiesReceivedInAnyOrder(List) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint in any order
expectedBodiesReceivedInAnyOrder(Object...) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body values are received by this endpoint in any order
expectedBodyReceived() - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given body value 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
 
expectedFileExists(String) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expection that a file exists with the given name
expectedFileExists(String, String) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expection that a file exists with the given name

Will wait at most 5 seconds while checking for the existence of the file.

expectedHeaderReceived(String, Object) - 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
expectedPropertyReceived(String, Object) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds an expectation that the given property name & value are received by this endpoint
expects(Runnable) - Method in class org.apache.camel.component.mock.MockEndpoint
Adds the expectation which will be invoked when enough messages are received
expectsAscending(Expression) - 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
expectsAscending() - 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) - 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
expectsDescending() - 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) - 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
expectsNoDuplicates() - 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 - 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() - Method in class org.apache.camel.model.FilterDefinition
Set the expression that this FilterType will use
expression() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Set the expression that IdempotentConsumerType will use
expression() - Method in class org.apache.camel.model.LoopDefinition
Set the expression that LoopType will use
expression() - Method in class org.apache.camel.model.RecipientListDefinition
Set the expression that RecipientListType will use
expression(ExpressionDefinition) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the expression to use for reordering
expression() - Method in class org.apache.camel.model.SetBodyDefinition
Set the expression that SetBodyType class will use
expression() - Method in class org.apache.camel.model.SetHeaderDefinition
Set the expression that SetHeaderType will use
expression() - Method in class org.apache.camel.model.SetOutHeaderDefinition
Set the expression that SetOutHeaderType will use
expression() - Method in class org.apache.camel.model.SetPropertyDefinition
Set the expression that SetPropertyType will use
expression() - Method in class org.apache.camel.model.SplitDefinition
Set the expression that the splitter will use
expression() - Method in class org.apache.camel.model.TransformDefinition
Set the expression that TransformType will use
expression() - Method in class org.apache.camel.model.WhenDefinition
Set the expression that WhenType will use
ExpressionAdapter - Class in org.apache.camel.impl
A helper class for developers wishing to implement an Expression using Java code with a minimum amount of code to write so that the developer only needs to implement one of the ExpressionAdapter.evaluate(org.apache.camel.Exchange, Class) or ExpressionAdapter.evaluate(org.apache.camel.Exchange, Class) methods.
ExpressionAdapter() - Constructor for class org.apache.camel.impl.ExpressionAdapter
 
ExpressionBuilder - Class in org.apache.camel.builder
A helper class for working with expressions.
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 - Class in org.apache.camel.util
An implementation of Comparator which takes an Expression which is evaluated on each exchange to compare
ExpressionComparator(Expression) - Constructor for class org.apache.camel.util.ExpressionComparator
 
ExpressionDefinition - Class in org.apache.camel.model.language
A useful base class for an expression
ExpressionDefinition() - Constructor for class org.apache.camel.model.language.ExpressionDefinition
 
ExpressionDefinition(String) - Constructor for class org.apache.camel.model.language.ExpressionDefinition
 
ExpressionDefinition(Predicate) - Constructor for class org.apache.camel.model.language.ExpressionDefinition
 
ExpressionDefinition(Expression) - Constructor for class org.apache.camel.model.language.ExpressionDefinition
 
ExpressionEvaluationException - Exception in org.apache.camel
An exception thrown if evaluation of the expression failed.
ExpressionEvaluationException(Expression, Exchange, Throwable) - Constructor for exception org.apache.camel.ExpressionEvaluationException
 
ExpressionIllegalSyntaxException - Exception in org.apache.camel
An exception thrown if the expression contains illegal syntax.
ExpressionIllegalSyntaxException(String) - Constructor for exception org.apache.camel.ExpressionIllegalSyntaxException
 
ExpressionIllegalSyntaxException(String, Throwable) - Constructor for exception org.apache.camel.ExpressionIllegalSyntaxException
 
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(ExpressionDefinition) - 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 - Interface in org.apache.camel.processor.resequencer
A SequenceElementComparator that compares Exchanges based on the result of an expression evaluation.
ExpressionSubElementDefinition - Class in org.apache.camel.model
Represents an expression sub element
ExpressionSubElementDefinition() - Constructor for class org.apache.camel.model.ExpressionSubElementDefinition
 
ExpressionSubElementDefinition(Expression) - Constructor for class org.apache.camel.model.ExpressionSubElementDefinition
 
ExpressionSubElementDefinition(Predicate) - Constructor for class org.apache.camel.model.ExpressionSubElementDefinition
 
ExpressionSupport - Class in org.apache.camel.impl
A useful base class for Predicate and Expression implementations
ExpressionSupport() - Constructor for class org.apache.camel.impl.ExpressionSupport
 
extendedFilter(HeaderFilterStrategy.Direction, String, Object, Exchange) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
 
extension - Variable in class org.apache.camel.view.GraphGeneratorSupport
 
extractBodyAsString(Message) - Static method in class org.apache.camel.util.MessageHelper
Extracts the given body and returns it as a String, that can be used for logging etc.
extractBodyForLogging(Message) - Static method in class org.apache.camel.util.MessageHelper
Extracts the body for logging purpose.
extractBreadCrumb(TraceInterceptor, ProcessorDefinition, Exchange) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
Creates the breadcrumb based on whether this was a trace of an exchange coming out of or into a processing step.
extractFutureBody(Future, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
extractFutureBody(Future, long, TimeUnit, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
extractFutureBody(Future, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Gets the response body from the future handle, will wait until the response is ready.
extractFutureBody(Future, long, TimeUnit, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Gets the response body from the future handle, will wait at most the given time for the response to be ready.
extractFutureBody(CamelContext, Future, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
Extracts the body from the given future, that represents a handle to an asynchronous exchange.
extractFutureBody(CamelContext, Future, long, TimeUnit, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
Extracts the body from the given future, that represents a handle to an asynchronous exchange.
extractProperties(Map, String) - Static method in class org.apache.camel.util.IntrospectionSupport
 
extractResultBody(Exchange) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
Extracts the body from the given result.
extractResultBody(Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
extractResultBody(Exchange, ExchangePattern) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
extractResultBody(Exchange, ExchangePattern) - Static method in class org.apache.camel.util.ExchangeHelper
Extracts the body from the given exchange.

F

FactoryFinder - Interface in org.apache.camel.spi
Finder to find factories from the resource classpath, usually META-INF/services/org/apache/camel/.
FactoryFinderResolver - Interface in org.apache.camel.spi
Represents a resolver of FactoryFinder to
fail(Object) - Method in class org.apache.camel.component.mock.MockEndpoint
 
failedExchange() - Method in class org.apache.camel.management.PerformanceCounter
This method is called when an exchange has been processed and failed.
FailedToCreateConsumerException - Exception in org.apache.camel
Thrown if Camel failed to create a consumer for a given endpoint.
FailedToCreateConsumerException(Endpoint, Throwable) - Constructor for exception org.apache.camel.FailedToCreateConsumerException
 
FailedToCreateProducerException - Exception in org.apache.camel
Thrown if Camel failed to create a producer for a given endpoint.
FailedToCreateProducerException(Endpoint, Throwable) - Constructor for exception org.apache.camel.FailedToCreateProducerException
 
failover() - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses fail over load balancer
failover(Class...) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses fail over load balancer
FailOverLoadBalancer - Class in org.apache.camel.processor.loadbalancer
This FailOverLoadBalancer will failover to use next processor when an exception occured
FailOverLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
FailOverLoadBalancer(List<Class>) - Constructor for class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
FailoverLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
 
FailoverLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
FAILURE_HANDLED - Static variable in interface org.apache.camel.Exchange
 
failureProcessor - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
FallbackConverter - Annotation Type in org.apache.camel
An annotation used to mark methods to indicate code capable of being a fallback converter which are then auto-discovered using the Type Conversion Support.
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
file(String) - Static method in class org.apache.camel.language.simple.FileLanguage
 
FILE_EXCHANGE_FILE - Static variable in class org.apache.camel.component.file.FileComponent
GenericFile property on Camel Exchanges.
FILE_LOCAL_WORK_PATH - Static variable in interface org.apache.camel.Exchange
 
FILE_NAME - Static variable in interface org.apache.camel.Exchange
 
FILE_NAME_ONLY - Static variable in interface org.apache.camel.Exchange
 
FILE_NAME_PRODUCED - Static variable in interface org.apache.camel.Exchange
 
FILE_PARENT - Static variable in interface org.apache.camel.Exchange
 
FILE_PATH - Static variable in interface org.apache.camel.Exchange
 
fileAbsoluteExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
fileAbsolutePathExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
FileBinding - Class in org.apache.camel.component.file
File binding with the File type.
FileBinding() - Constructor for class org.apache.camel.component.file.FileBinding
 
FileChangedExclusiveReadLockStrategy - Class in org.apache.camel.component.file.strategy
Acquires exclusive read lock to the given file by checking whether the file is being changed by scanning the files at different intervals.
FileChangedExclusiveReadLockStrategy() - Constructor for class org.apache.camel.component.file.strategy.FileChangedExclusiveReadLockStrategy
 
FileComponent - Class in org.apache.camel.component.file
File component.
FileComponent() - Constructor for class org.apache.camel.component.file.FileComponent
 
FileConsumer - Class in org.apache.camel.component.file
File consumer.
FileConsumer(GenericFileEndpoint<File>, Processor, GenericFileOperations<File>) - Constructor for class org.apache.camel.component.file.FileConsumer
 
FileEndpoint - Class in org.apache.camel.component.file
File endpoint.
FileEndpoint() - Constructor for class org.apache.camel.component.file.FileEndpoint
 
FileEndpoint(String, Component) - Constructor for class org.apache.camel.component.file.FileEndpoint
 
fileExist - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
FileExpressionBuilder - Class in org.apache.camel.builder
A helper class for working with expressions based on files.
fileExpressionResult - Variable in class org.apache.camel.component.file.GenericFileConsumer
 
fileExtensionExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
FileIdempotentRepository - Class in org.apache.camel.processor.idempotent
A file based implementation of IdempotentRepository.
FileIdempotentRepository() - Constructor for class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
FileIdempotentRepository(File, Map<String, Object>) - Constructor for class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
fileIdempotentRepository(File) - Static method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Creates a new file based repository using a LRUCache as 1st level cache with a default of 1000 entries in the cache.
fileIdempotentRepository(File, int) - Static method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Creates a new file based repository using a LRUCache as 1st level cache.
fileIdempotentRepository(File, int, long) - Static method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Creates a new file based repository using a LRUCache as 1st level cache.
fileIdempotentRepository(File, Map<String, Object>) - Static method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Creates a new file based repository using the given Map as 1st level cache.
FileInputStreamCache - Class in org.apache.camel.converter.stream
 
FileInputStreamCache(File, CachedOutputStream) - Constructor for class org.apache.camel.converter.stream.FileInputStreamCache
 
FileLanguage - Class in org.apache.camel.language.simple
File language is an extension to Simple language to add file specific expressions.
FileLanguage() - Constructor for class org.apache.camel.language.simple.FileLanguage
 
fileLastModifiedExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
FileLockExclusiveReadLockStrategy - Class in org.apache.camel.component.file.strategy
Acquires exclusive read lock to the given file.
FileLockExclusiveReadLockStrategy() - Constructor for class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
 
fileName - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
fileNameExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
fileNameNoExtensionExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
fileOnlyNameExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
fileOnlyNameNoExtensionExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
FileOperations - Class in org.apache.camel.component.file
File operations for File.
FileOperations() - Constructor for class org.apache.camel.component.file.FileOperations
 
FileOperations(FileEndpoint) - Constructor for class org.apache.camel.component.file.FileOperations
 
fileParentExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
filePathExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
FileProcessStrategyFactory - Class in org.apache.camel.component.file.strategy
 
fileSizeExpression() - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
FileUtil - Class in org.apache.camel.util
File utilities
filter - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
filter() - Method in class org.apache.camel.model.ProcessorDefinition
Message Filter EIP: 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.ProcessorDefinition
Message Filter EIP: Creates a predicate which is applied and only if it is true then the exchange is forwarded to the destination
filter(ExpressionDefinition) - Method in class org.apache.camel.model.ProcessorDefinition
Message Filter EIP: Creates a predicate expression which only if it is true then the exchange is forwarded to the destination
filter(String, String) - Method in class org.apache.camel.model.ProcessorDefinition
Message Filter EIP: Creates a predicate language expression which only if it is true then the exchange is forwarded to the destination
filter(OnExceptionDefinition, Class, Throwable) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
Strategy to filter the given type exception class with the thrown exception
FilterDefinition - Class in org.apache.camel.model
Represents an XML <filter/> element
FilterDefinition() - Constructor for class org.apache.camel.model.FilterDefinition
 
FilterDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.FilterDefinition
 
FilterDefinition(Predicate) - Constructor for class org.apache.camel.model.FilterDefinition
 
FILTERED - Static variable in interface org.apache.camel.Exchange
 
filterList(List, Object...) - Static method in class org.apache.camel.util.CollectionHelper
Filters the given list to skip instanceof filter objects.
FilterProcessor - Class in org.apache.camel.processor
The processor which implements the Message Filter EIP pattern.
FilterProcessor(Predicate, Processor) - Constructor for class org.apache.camel.processor.FilterProcessor
 
finalizeSettings() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
FinallyDefinition - Class in org.apache.camel.model
Represents an XML <finally/> element
FinallyDefinition() - Constructor for class org.apache.camel.model.FinallyDefinition
 
finallyProcessor - Variable in class org.apache.camel.processor.TryProcessor
 
find(PackageScanFilter, String, Set<Class>) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
find(PackageScanFilter, String, ClassLoader, Set<Class>) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findAnnotated(Class<? extends Annotation>, String...) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findAnnotated(Set<Class<? extends Annotation>>, String...) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findAnnotated(Class<? extends Annotation>, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Attempts to discover classes that are annotated with to the annotation.
findAnnotated(Set<Class<? extends Annotation>>, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Attempts to discover classes that are annotated with to the annotation.
findByFilter(PackageScanFilter, String...) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findByFilter(PackageScanFilter, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Attemsp to discover classes filter by the provided filter
findClass(String) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
findClass(String, String) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
findClass(String) - Method in interface org.apache.camel.spi.FactoryFinder
Finds the given factory class using the the key to lookup.
findClass(String, String) - Method in interface org.apache.camel.spi.FactoryFinder
Finds the given factory class using the the key to lookup.
findImplementations(Class, String...) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
findImplementations(Class, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Attempts to discover classes that are assignable to the type provided.
findLanguage(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
findLanguageResolver(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
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
findMethodsWithAnnotation(Class<?>, Class<? extends Annotation>, boolean) - Static method in class org.apache.camel.util.ObjectHelper
Returns a list of methods which are annotated with the given annotation
findOneWayAnnotation(Method) - Method in class org.apache.camel.component.bean.MethodInfo
Finds the oneway annotation in priority order; look for method level annotations first, then the class level annotations, then super class annotations then interface annotations
findOneWayAnnotation(List<Class<?>>) - Method in class org.apache.camel.component.bean.MethodInfo
Finds the first annotation on the given list of classes
findOneWayAnnotationOnMethod(List<Class<?>>, Method) - Method in class org.apache.camel.component.bean.MethodInfo
Finds the first annotation on the base methods defined in the list of classes
findOrCreateCamelTemplate() - Method in class org.apache.camel.impl.MainSupport
 
findOrCreateMBeanServer() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
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
 
FlatpackDataFormat - Class in org.apache.camel.model.dataformat
Represents a Flatpack DataFormat.
FlatpackDataFormat() - Constructor for class org.apache.camel.model.dataformat.FlatpackDataFormat
 
flatten - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
flush() - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
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
format(Exchange) - Method in class org.apache.camel.component.log.LogFormatter
 
format(Exchange) - Method in class org.apache.camel.impl.DefaultExchangeFormatter
 
format(TraceInterceptor, ProcessorDefinition, Exchange) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
format(TraceInterceptor, ProcessorDefinition, Exchange) - Method in interface org.apache.camel.processor.interceptor.TraceFormatter
Formats a log message at given point of interception.
format(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
format(Exchange) - Method in interface org.apache.camel.spi.ExchangeFormatter
Generates a string representation of the exchange
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.builder.RouteBuilder
Creates a new route from the given URIs 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.RouteDefinition
Creates an input to the route
from(Endpoint) - Method in class org.apache.camel.model.RouteDefinition
Creates an input to the route
from(String...) - Method in class org.apache.camel.model.RouteDefinition
Creates inputs to the route
from(Endpoint...) - Method in class org.apache.camel.model.RouteDefinition
Creates inputs to the route
from(String) - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route from the given URI input
from(Endpoint) - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route from the given endpoint
from(String...) - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route from the given URI inputs
from(Endpoint...) - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route from the given endpoints
fromCharArray(char[]) - Static method in class org.apache.camel.converter.ObjectConverter
 
FromDefinition - Class in org.apache.camel.model
Represents an XML <from/> element
FromDefinition() - Constructor for class org.apache.camel.model.FromDefinition
 
FromDefinition(String) - Constructor for class org.apache.camel.model.FromDefinition
 
FromDefinition(Endpoint) - Constructor for class org.apache.camel.model.FromDefinition
 
fromF(String, Object...) - Method in class org.apache.camel.builder.RouteBuilder
Creates a new route from the given URI input
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
FutureTypeConverter - Class in org.apache.camel.impl.converter
Future type converter.
FutureTypeConverter(TypeConverter) - Constructor for class org.apache.camel.impl.converter.FutureTypeConverter
 

G

generateDot(String, CamelContext, int) - Method in class org.apache.camel.impl.MainSupport
 
generateFile(PrintWriter, Map<String, List<RouteDefinition>>) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
generateFile(PrintWriter, Map<String, List<RouteDefinition>>) - Method in class org.apache.camel.view.RouteDotGenerator
 
generateFile(PrintWriter, Map<String, List<RouteDefinition>>) - 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
generateSanitizedId(String) - Static method in class org.apache.camel.util.UuidGenerator
Ensures that the id is friendly for a URL or file system
GenericFile<T> - Class in org.apache.camel.component.file
Generic File.
GenericFile() - Constructor for class org.apache.camel.component.file.GenericFile
 
GenericFileBinding<T> - Interface in org.apache.camel.component.file
Binding between the generic file and the body content.
GenericFileComponent<T> - Class in org.apache.camel.component.file
Base class file component.
GenericFileComponent() - Constructor for class org.apache.camel.component.file.GenericFileComponent
 
GenericFileComponent(CamelContext) - Constructor for class org.apache.camel.component.file.GenericFileComponent
 
GenericFileConfiguration - Class in org.apache.camel.component.file
 
GenericFileConfiguration() - Constructor for class org.apache.camel.component.file.GenericFileConfiguration
 
GenericFileConsumer<T> - Class in org.apache.camel.component.file
Base class for remote file consumers.
GenericFileConsumer(GenericFileEndpoint<T>, Processor, GenericFileOperations<T>) - Constructor for class org.apache.camel.component.file.GenericFileConsumer
 
GenericFileConverter - Class in org.apache.camel.component.file
A set of converter methods for working with generic file types
GenericFileDefaultBinding<T> - Class in org.apache.camel.component.file
Default binding for generic file.
GenericFileDefaultBinding() - Constructor for class org.apache.camel.component.file.GenericFileDefaultBinding
 
GenericFileDefaultSorter - Class in org.apache.camel.component.file
Default file sorter.
GenericFileDeleteProcessStrategy<T> - Class in org.apache.camel.component.file.strategy
 
GenericFileDeleteProcessStrategy() - Constructor for class org.apache.camel.component.file.strategy.GenericFileDeleteProcessStrategy
 
GenericFileEndpoint<T> - Class in org.apache.camel.component.file
Generic FileEndpoint
GenericFileEndpoint() - Constructor for class org.apache.camel.component.file.GenericFileEndpoint
 
GenericFileEndpoint(String, Component) - Constructor for class org.apache.camel.component.file.GenericFileEndpoint
 
GenericFileExclusiveReadLockStrategy<T> - Interface in org.apache.camel.component.file
Strategy for acquiring exclusive read locks for files to be consumed.
GenericFileExist - Enum in org.apache.camel.component.file
Represent the kinds of options when writing a file and what to do in case of an existing file exists.
GenericFileExpressionRenamer<T> - Class in org.apache.camel.component.file.strategy
 
GenericFileExpressionRenamer() - Constructor for class org.apache.camel.component.file.strategy.GenericFileExpressionRenamer
 
GenericFileExpressionRenamer(Expression) - Constructor for class org.apache.camel.component.file.strategy.GenericFileExpressionRenamer
 
GenericFileFilter<T> - Interface in org.apache.camel.component.file
A filter for GenericFile.
GenericFileMessage<T> - Class in org.apache.camel.component.file
Generic file message
GenericFileMessage() - Constructor for class org.apache.camel.component.file.GenericFileMessage
 
GenericFileMessage(GenericFile<T>) - Constructor for class org.apache.camel.component.file.GenericFileMessage
 
GenericFileNoOpProcessStrategy<T> - Class in org.apache.camel.component.file.strategy
 
GenericFileNoOpProcessStrategy() - Constructor for class org.apache.camel.component.file.strategy.GenericFileNoOpProcessStrategy
 
GenericFileOnCompletion<T> - Class in org.apache.camel.component.file
On completion strategy that performs the nessasary work after the Exchange has been processed.
GenericFileOnCompletion(GenericFileEndpoint<T>, GenericFileOperations<T>, GenericFile<T>) - Constructor for class org.apache.camel.component.file.GenericFileOnCompletion
 
GenericFileOperationFailedException - Exception in org.apache.camel.component.file
Exception thrown in case of last file operation failed.
GenericFileOperationFailedException(String) - Constructor for exception org.apache.camel.component.file.GenericFileOperationFailedException
 
GenericFileOperationFailedException(String, Throwable) - Constructor for exception org.apache.camel.component.file.GenericFileOperationFailedException
 
GenericFileOperationFailedException(int, String) - Constructor for exception org.apache.camel.component.file.GenericFileOperationFailedException
 
GenericFileOperationFailedException(int, String, Throwable) - Constructor for exception org.apache.camel.component.file.GenericFileOperationFailedException
 
GenericFileOperationFailedException(int, String, String) - Constructor for exception org.apache.camel.component.file.GenericFileOperationFailedException
 
GenericFileOperationFailedException(int, String, String, Throwable) - Constructor for exception org.apache.camel.component.file.GenericFileOperationFailedException
 
GenericFileOperations<T> - Interface in org.apache.camel.component.file
 
GenericFileProcessStrategy<T> - Interface in org.apache.camel.component.file
Represents a pluggable strategy when processing files.
GenericFileProcessStrategyFactory - Class in org.apache.camel.component.file.strategy
 
GenericFileProcessStrategySupport<T> - Class in org.apache.camel.component.file.strategy
 
GenericFileProcessStrategySupport() - Constructor for class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
 
GenericFileProducer<T> - Class in org.apache.camel.component.file
Generic file producer
GenericFileProducer(GenericFileEndpoint<T>, GenericFileOperations<T>) - Constructor for class org.apache.camel.component.file.GenericFileProducer
 
GenericFileRenameExclusiveReadLockStrategy<T> - Class in org.apache.camel.component.file.strategy
Acquires exclusive read lock to the given file.
GenericFileRenameExclusiveReadLockStrategy() - Constructor for class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
 
GenericFileRenameProcessStrategy<T> - Class in org.apache.camel.component.file.strategy
 
GenericFileRenameProcessStrategy() - Constructor for class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
GenericFileRenamer<T> - Interface in org.apache.camel.component.file.strategy
Used for renaming files.
get() - Method in interface org.apache.camel.spi.Provider
Returns the newly constructed instance
get(Object) - Method in class org.apache.camel.util.CaseInsensitiveMap
 
get(Object) - Method in class org.apache.camel.util.DefaultTimeoutMap
 
get(Object) - Method in interface org.apache.camel.util.TimeoutMap
Looks up the value in the map by the given key.
get() - Method in class org.apache.camel.util.ValueHolder
 
getAbbreviation() - Method in class org.apache.camel.impl.MainSupport.Option
 
getAbsoluteFilePath() - Method in class org.apache.camel.component.file.GenericFile
 
getAction() - Method in class org.apache.camel.processor.ThroughputLogger
 
getAfterFinallyUri() - Method in class org.apache.camel.model.AOPDefinition
 
getAfterUri() - Method in class org.apache.camel.model.AOPDefinition
 
getAggregated() - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
getAggregationCollection() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.AggregateDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.MulticastDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getAggregationStrategy() - Method in class org.apache.camel.model.SplitDefinition
 
getAggregationStrategy() - Method in interface org.apache.camel.processor.aggregate.AggregationCollection
Gets the aggregation strategy
getAggregationStrategy() - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
getAggregationStrategy() - Method in class org.apache.camel.processor.MulticastProcessor
 
getAggregationStrategyRef() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getAndIncrement(ProcessorDefinition) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getAndIncrement(ProcessorDefinition) - Method in interface org.apache.camel.spi.TraceableUnitOfWork
A private counter that increments, is used to as book keeping how far this exchange have been intercepted by the general intercept().
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
 
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
getBackOffMultiplier() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getBackOffMultiplier() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getBatchConfig() - Method in class org.apache.camel.model.ResequenceDefinition
 
getBatchConfig(BatchResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
 
getBatchSize() - Method in class org.apache.camel.model.AggregateDefinition
 
getBatchSize() - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
getBatchSize() - Method in class org.apache.camel.processor.BatchProcessor
 
getBatchSizeFromConsumer() - Method in class org.apache.camel.model.AggregateDefinition
 
getBatchTimeout() - Method in class org.apache.camel.model.AggregateDefinition
 
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 exception org.apache.camel.component.bean.MethodNotFoundException
 
getBean() - Method in class org.apache.camel.component.bean.RegistryBean
 
getBean() - Method in exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
getBeanHolder() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
getBeanInfo() - Method in interface org.apache.camel.component.bean.BeanHolder
 
getBeanInfo() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
 
getBeanInfo(Class<?>) - Method in class org.apache.camel.component.bean.MethodInfoCache
 
getBeanInfo() - Method in class org.apache.camel.component.bean.RegistryBean
 
getBeanName() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
getBeanType() - Method in class org.apache.camel.model.BeanDefinition
 
getBeforeUri() - Method in class org.apache.camel.model.AOPDefinition
 
getBeginRenamer() - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
getBinding() - Method in class org.apache.camel.component.file.GenericFile
 
getBinding(Exchange, Class<T>) - Static method in class org.apache.camel.util.ExchangeHelper
Extracts the Exchange.BINDING of the given type or null if not present
getBlockingQueue(String, Map) - Method in class org.apache.camel.component.vm.VmComponent
 
getBody(GenericFile<File>) - Method in class org.apache.camel.component.file.FileBinding
 
getBody() - Method in class org.apache.camel.component.file.GenericFile
 
getBody(GenericFile<T>) - Method in interface org.apache.camel.component.file.GenericFileBinding
Gets the body of the file
getBody(GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileDefaultBinding
 
getBody() - Method in class org.apache.camel.impl.MessageSupport
 
getBody(Class<T>) - Method in class org.apache.camel.impl.MessageSupport
 
getBody(Class<T>, Object) - 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

The body can be null if no body is set

getBody(Class<T>) - Method in interface org.apache.camel.Message
Returns the body as the specified type
getBody() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getBody() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
 
getBodyAsString(Message) - Method in class org.apache.camel.component.log.LogFormatter
 
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
 
getBodyType() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getBodyType() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
 
getBodyTypeAsString(Message) - Method in class org.apache.camel.component.log.LogFormatter
 
getBodyTypeName(Message) - Static method in class org.apache.camel.util.MessageHelper
Gets the given body class type name as a String.
getBreadCrumbID(Exchange) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
getBreadCrumbLength() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
getBufferSize() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getCache() - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
getCache() - Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
 
getCamelContext() - Method in interface org.apache.camel.CamelContextAware
Get the CamelContext
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.CamelPostProcessorHelper
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultComponent
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultEndpoint
 
getCamelContext() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getCamelContext() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
getCamelContext() - Method in class org.apache.camel.impl.RouteService
 
getCamelContext() - Method in class org.apache.camel.model.RouteDefinition
 
getCamelContext() - Method in class org.apache.camel.model.RoutesDefinition
 
getCamelContext() - Method in interface org.apache.camel.spi.RouteContext
Gets the camel context
getCamelContextMap() - Method in class org.apache.camel.impl.MainSupport
 
getCamelContexts() - Method in class org.apache.camel.impl.MainSupport
 
getCamelTemplate() - Method in class org.apache.camel.impl.MainSupport
Returns a ProducerTemplate from the Spring ApplicationContext instances or lazily creates a new one dynamically
getCapacity() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getCapacity() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's capacity.
getCatchClauses() - Method in class org.apache.camel.model.TryDefinition
 
getCausedByException() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getCausedByException() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
Gets the caused by exception (ie Exchange#getException().
getChannels() - Method in class org.apache.camel.impl.DefaultRoute
 
getCharset() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getCharset() - Method in class org.apache.camel.model.dataformat.StringDataFormat
 
getClassLoader(Class...) - Static method in class org.apache.camel.component.bean.ProxyHelper
Returns the class loader of the first interface or throws IllegalArgumentException if there are no interfaces specified
getClassLoaders() - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
getClassLoaders() - Method in interface org.apache.camel.spi.PackageScanClassResolver
Gets the ClassLoader instances that should be used when scanning for classes.
getClassResolver() - Method in interface org.apache.camel.CamelContext
Returns the class resolver to be used for loading/lookup of classes.
getClassResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getCode() - Method in exception org.apache.camel.component.file.GenericFileOperationFailedException
Return the file failure code (if any)
getCollectionRef() - Method in class org.apache.camel.model.AggregateDefinition
 
getCollisionAvoidanceFactor() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getCollisionAvoidanceFactor() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getCollisionAvoidancePercent() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getCommitRenamer() - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
getComparator() - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
getComparator() - Method in class org.apache.camel.model.SortDefinition
 
getComparatorRef() - Method in class org.apache.camel.model.SortDefinition
 
getCompletionPredicate() - Method in class org.apache.camel.model.AggregateDefinition
 
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
 
getComponentNames() - Method in interface org.apache.camel.CamelContext
Gets a readonly list of names of the components currently registered
getComponentNames() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getComponentResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getComponents() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getCompressionLevel() - Method in class org.apache.camel.model.dataformat.ZipDataFormat
 
getConcurrentConsumers() - Method in class org.apache.camel.component.seda.SedaEndpoint
 
getConfiguration() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getConnectorPort() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getConsumeDelay() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getConsumer(Endpoint) - Method in class org.apache.camel.impl.ConsumerCache
 
getConsumerProperties() - Method in class org.apache.camel.impl.ScheduledPollEndpoint
 
getConsumers() - Method in class org.apache.camel.component.direct.DirectEndpoint
 
getConsumers() - Method in class org.apache.camel.component.seda.SedaEndpoint
Returns the current active consumers on this endpoint
getContentEncoding(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Returns the MIME content encoding on the input message or null if one is not defined
getContentEncoding(Message) - Static method in class org.apache.camel.util.MessageHelper
Returns the MIME content encoding on the message or null if none defined
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
getContentType(Message) - Static method in class org.apache.camel.util.MessageHelper
Returns the MIME content type on the message or null if none 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.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.DefaultProducerTemplate
 
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.impl.ReportingTypeConverterLoader.TypeMapping
 
getCorrelationExpression() - Method in class org.apache.camel.model.AggregateDefinition
 
getCorrelationExpression() - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
getCorrelationExpression() - Method in interface org.apache.camel.processor.aggregate.AggregationCollection
Gets the correlation expression
getCorrelationExpression() - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
getCorrelationExpression() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getCreateConnector() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getCurrentDirectory() - Method in class org.apache.camel.component.file.FileOperations
 
getCurrentDirectory() - Method in interface org.apache.camel.component.file.GenericFileOperations
Gets the current remote directory
getData() - Method in class org.apache.camel.converter.jaxp.BytesSource
 
getDataFormat(String) - Method in class org.apache.camel.impl.DefaultRouteContext
 
getDataFormat(RouteContext, DataFormatDefinition, String) - Static method in class org.apache.camel.model.DataFormatDefinition
Factory method to create the data format
getDataFormat(RouteContext) - Method in class org.apache.camel.model.DataFormatDefinition
 
getDataFormat() - Method in class org.apache.camel.model.DataFormatDefinition
 
getDataFormat(String) - Method in interface org.apache.camel.spi.RouteContext
Get a DataFormatType by ref name
getDataFormatName() - Method in class org.apache.camel.model.DataFormatDefinition
 
getDataFormats() - Method in interface org.apache.camel.CamelContext
Gets the data formats that can be referenced in the routes.
getDataFormats() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getDataFormats() - Method in class org.apache.camel.model.dataformat.DataFormatsDefinition
 
getDataFormatType() - Method in class org.apache.camel.model.MarshalDefinition
 
getDataFormatType() - Method in class org.apache.camel.model.UnmarshalDefinition
 
getDataObjectType() - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
getDataSet() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getDeadLetter() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getDeadLetter() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Returns the dead letter that message exchanges will be sent to if the redelivery attempts fail
getDeadLetterUri() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
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 (1000) 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
getDefaultEndpoint() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
getDefaultFactoryFinder() - Method in interface org.apache.camel.CamelContext
Gets the default FactoryFinder which will be used for the loading the factory class from META-INF
getDefaultFactoryFinder() - Method in class org.apache.camel.impl.DefaultCamelContext
 
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
Gets an expression used for evaluation with the current Exchange and its result is used as parameter value for the given type
getDefaultTraceFormatter() - Method in class org.apache.camel.processor.interceptor.Tracer
 
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.processor.interceptor.Delayer
 
getDelayer() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getDelayer() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getDelayer() - Method in class org.apache.camel.model.RouteDefinition
 
getDelayer(CamelContext) - Static method in class org.apache.camel.processor.interceptor.Delayer
A helper method to return the Delayer instance for a given CamelContext if one is enabled
getDelayer() - Method in interface org.apache.camel.RuntimeConfiguration
Gets the delay value
getDelayPattern() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getDelegate() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
getDelimiter() - Method in class org.apache.camel.model.RecipientListDefinition
 
getDescription() - Method in class org.apache.camel.impl.MainSupport.Option
 
getDescription() - Method in class org.apache.camel.management.ManagedRoute
 
getDescription() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
 
getDestination() - Method in class org.apache.camel.processor.interceptor.Tracer
 
getDestination() - Method in class org.apache.camel.processor.SendProcessor
 
getDestinationUri() - Method in class org.apache.camel.processor.interceptor.Tracer
 
getDir() - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getDirectory() - Method in class org.apache.camel.component.file.GenericFileConfiguration
 
getDisableRedelivery() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getDocument(Exchange) - 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
 
getDotOutputDir() - Method in class org.apache.camel.impl.MainSupport
 
getDuration() - Method in class org.apache.camel.impl.MainSupport
 
getElementType() - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
getElementTypeName() - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
getEncoding() - Method in class org.apache.camel.converter.jaxp.StringSource
 
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 name to an Endpoint of the specified type.
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.DefaultRoute
 
getEndpoint() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getEndpoint() - Method in class org.apache.camel.impl.PollingConsumerSupport
 
getEndpoint() - Method in exception org.apache.camel.impl.ProxyInstantiationException
 
getEndpoint() - Method in class org.apache.camel.management.ManagedEndpoint
 
getEndpoint() - Method in class org.apache.camel.model.FromDefinition
 
getEndpoint() - Method in class org.apache.camel.model.SendDefinition
 
getEndpoint() - Method in interface org.apache.camel.Producer
Gets the endpoint this producer sends to.
getEndpoint() - Method in interface org.apache.camel.Route
Gets the inbound endpoint
getEndpoint() - Method in interface org.apache.camel.spi.RouteContext
Gets the endpoint
getEndpointId(Endpoint) - Method in class org.apache.camel.management.CamelNamingStrategy
 
getEndpointInjection(String, String, String, boolean) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
getEndpointInjection(CamelContext, String, String, String, boolean) - Static method in class org.apache.camel.util.CamelContextHelper
Evaluates the @EndpointInject annotation using the given context
getEndpointKey() - Method in interface org.apache.camel.Endpoint
Returns a string key of this endpoint.
getEndpointKey(String, Endpoint) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getEndpointKey() - Method in class org.apache.camel.impl.DefaultEndpoint
 
getEndpointKey() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
getEndpointMap() - Method in interface org.apache.camel.CamelContext
Returns a new Map containing all of the active endpoints with the key of the map being their unique key.
getEndpointMap() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getEndpointPath() - Method in class org.apache.camel.component.file.GenericFile
 
getEndpoints() - Method in interface org.apache.camel.CamelContext
Returns the collection of all registered endpoints.
getEndpoints(String) - Method in interface org.apache.camel.CamelContext
Returns the collection of all registered endpoints for a uri or an empty collection.
getEndpoints() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getEndpoints(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getEndpoints(CamelContext, Class<T>) - Method in class org.apache.camel.util.CamelContextHelper
Returns a list of all endpoints of the given type
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.impl.InterceptSendToEndpoint
 
getEndpointUri() - Method in class org.apache.camel.management.ManagedRoute
 
getEnvironment() - Method in class org.apache.camel.util.jndi.JndiContext
 
getErrorHandler() - Method in interface org.apache.camel.Channel
Gets the ErrorHandler this Channel uses.
getErrorHandler() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getErrorHandler() - Method in class org.apache.camel.processor.DefaultChannel
 
getErrorHandler() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
getErrorHandlerBuilder() - Method in class org.apache.camel.builder.BuilderSupport
 
getErrorHandlerBuilder() - Method in interface org.apache.camel.CamelContext
Gets the default error handler builder which is inherited by the routes
getErrorHandlerBuilder() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getErrorHandlerBuilder() - Method in class org.apache.camel.model.ProcessorDefinition
 
getErrorHandlerBuilder() - Method in class org.apache.camel.model.RoutesDefinition
 
getErrorHandlerRef() - Method in class org.apache.camel.model.ProcessorDefinition
 
getErrorHandlers() - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Gets the error handlers
getErrorHandlers() - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
getErrors() - Method in class org.apache.camel.impl.ReportingTypeConverterRegistry
 
getErrors() - Method in exception org.apache.camel.processor.validation.SchemaValidationException
Returns the validation errors
getException() - Method in interface org.apache.camel.Exchange
Returns the exception associated with this exchange
getException(Class<T>) - Method in interface org.apache.camel.Exchange
Returns the exception associated with this exchange.
getException() - Method in class org.apache.camel.impl.DefaultExchange
 
getException(Class<T>) - Method in class org.apache.camel.impl.DefaultExchange
 
getException() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getExceptionClass() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
getExceptionClasses() - Method in class org.apache.camel.model.CatchDefinition
 
getExceptionClasses() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getExceptionHandler() - Method in class org.apache.camel.component.file.GenericFileOnCompletion
 
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
 
getExceptionHandler() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's exception handler.
getExceptionPolicy(Exchange, Throwable) - Method in class org.apache.camel.processor.ErrorHandlerSupport
Attempts to find the best suited OnExceptionDefinition to be used for handling the given thrown exception.
getExceptionPolicy(Map<ExceptionPolicyKey, OnExceptionDefinition>, Exchange, Throwable) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
 
getExceptionPolicy(Map<ExceptionPolicyKey, OnExceptionDefinition>, Exchange, Throwable) - Method in interface org.apache.camel.processor.exceptionpolicy.ExceptionPolicyStrategy
Resolves the OnExceptionDefinition that should handle the thrown exception.
getExceptionPolicyStrategy() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the exception policy strategy to use for resolving the OnExceptionDefinition to use for a given thrown exception
getExceptionPolicyStrategy() - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Gets the exception policy strategy
getExceptionPolicyStrategy() - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
getExceptions() - Method in class org.apache.camel.model.CatchDefinition
 
getExceptions() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
getExceptions() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getExceptions() - Method in class org.apache.camel.processor.CatchProcessor
 
getExceptions() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
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 exception org.apache.camel.ExpectedBodyTypeException
 
getExchange() - Method in exception org.apache.camel.ExpressionEvaluationException
 
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
getExchangeById(Iterable<Exchange>, String) - Static method in class org.apache.camel.util.ExchangeHelper
Returns the first exchange in the given collection of exchanges which has the same exchange ID as the one given or null if none could be found
getExchangeId() - Method in interface org.apache.camel.Exchange
Returns the exchange id (unique)
getExchangeId() - Method in class org.apache.camel.impl.DefaultExchange
 
getExchangeId() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getExchangeId() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
 
getExchangePattern() - Method in class org.apache.camel.impl.DefaultEndpoint
 
getExchangePattern() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getExchangePattern() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
 
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.browse.BrowseEndpoint
 
getExchanges() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getExchanges() - Method in class org.apache.camel.component.seda.SedaEndpoint
Returns the current pending exchanges
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
getExclude() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getExcludes() - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
 
getExcludes() - Method in class org.apache.camel.model.PackageScanDefinition
 
getExclusiveReadLockStrategy() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getExclusiveReadLockStrategy() - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
 
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
 
getExecutorService() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getExecutorService() - Method in class org.apache.camel.model.MulticastDefinition
 
getExecutorService() - Method in class org.apache.camel.model.SplitDefinition
 
getExecutorService() - Method in class org.apache.camel.model.ThreadsDefinition
 
getExecutorService() - Method in class org.apache.camel.processor.MulticastProcessor
 
getExecutorService() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getExecutorService() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getExecutorService() - Method in class org.apache.camel.processor.WireTapProcessor
 
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 class org.apache.camel.component.file.strategy.GenericFileExpressionRenamer
 
getExpression() - Method in exception org.apache.camel.ExpressionEvaluationException
 
getExpression() - Method in exception org.apache.camel.ExpressionIllegalSyntaxException
 
getExpression() - Method in class org.apache.camel.model.AggregateDefinition
 
getExpression() - Method in class org.apache.camel.model.ExpressionNode
 
getExpression() - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
getExpression() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getExpression() - Method in class org.apache.camel.model.SortDefinition
 
getExpression() - Method in exception org.apache.camel.processor.idempotent.NoMessageIdException
The expression which was used
getExpression() - Method in class org.apache.camel.processor.LoopProcessor
 
getExpression() - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
getExpression() - Method in class org.apache.camel.processor.Splitter
 
getExpressionFromAnnotation(Annotation) - Method in class org.apache.camel.component.bean.DefaultAnnotationExpressionFactory
 
getExpressionList() - Method in class org.apache.camel.model.ResequenceDefinition
 
getExpressionNameSpacePrefix(Annotation) - Method in class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
 
getExpressions() - Method in class org.apache.camel.model.ResequenceDefinition
 
getExpressionType() - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
getExpressionType() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getExpressionValue() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
getFactoryFinder(String) - Method in interface org.apache.camel.CamelContext
Gets the FactoryFinder which will be used for the loading the factory class from META-INF in the given path
getFactoryFinder(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getFailureProcessor() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
getFailureProcessor() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getFailureRenamer() - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
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
getFile() - Method in class org.apache.camel.component.file.FileEndpoint
 
getFile() - Method in class org.apache.camel.component.file.GenericFile
 
getFileExist() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getFileLength() - Method in class org.apache.camel.component.file.GenericFile
 
getFileName() - Method in class org.apache.camel.component.file.GenericFile
 
getFileName() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getFileNameOnly() - Method in class org.apache.camel.component.file.GenericFile
 
getFileSeparator() - Method in class org.apache.camel.component.file.FileEndpoint
 
getFileSeparator() - Method in class org.apache.camel.component.file.GenericFile
 
getFileSeparator() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getFileSeparator() - Method in class org.apache.camel.component.file.GenericFileProducer
 
getFileStore() - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
getFilter() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getFilters() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getFinallyClause() - Method in class org.apache.camel.model.TryDefinition
 
getFirstExchangeCompletionTime() - Method in class org.apache.camel.management.PerformanceCounter
 
getFirstExchangeFailureTime() - Method in class org.apache.camel.management.PerformanceCounter
 
getFormat() - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
getFormatter() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
getFormatter() - Method in class org.apache.camel.processor.interceptor.Tracer
 
getFragment() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getFrom() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getFrom() - Method in interface org.apache.camel.spi.RouteContext
Gets the from type
getFromClassMappings() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
getFromEndpoint() - Method in interface org.apache.camel.Exchange
Returns the endpoint which originated this message exchange if a consumer on an endpoint created the message exchange otherwise this property will be null
getFromEndpoint() - Method in class org.apache.camel.impl.DefaultExchange
 
getFromEndpointUri() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getFromEndpointUri() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
Uri of the endpoint that started the Exchange currently being traced.
getFromType() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
getFromType() - Method in class org.apache.camel.impl.ReportingTypeConverterLoader.TypeMapping
 
getFromType() - Method in exception org.apache.camel.NoTypeConversionAvailableException
Returns the required from type.
getFullName() - Method in class org.apache.camel.impl.MainSupport.Option
 
getFunctionResolver() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getGeneratedFileName(Message) - Method in class org.apache.camel.component.file.GenericFileEndpoint
Return the file name that will be auto-generated for the given message if none is provided
getGenericFile() - Method in class org.apache.camel.component.file.GenericFileMessage
 
getGenericFileProcessStrategy() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getGroup() - Method in class org.apache.camel.model.RouteDefinition
The group that this route belongs to; could be the name of the RouteBuilder class or be explicitly configured in the XML.
getGroupExchanges() - Method in class org.apache.camel.model.AggregateDefinition
 
getGroupSize() - Method in class org.apache.camel.processor.ThroughputLogger
 
getHandled() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getHandledPolicy() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getHandledPolicy() - Method in class org.apache.camel.model.CatchDefinition
 
getHandledPolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getHandleFault(CamelContext) - Static method in class org.apache.camel.processor.interceptor.HandleFault
A helper method to return the HandleFault instance for a given CamelContext if one is enabled
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
getHeaderFilterStrategy() - Method in class org.apache.camel.impl.HeaderFilterStrategyComponent
 
getHeaderFilterStrategy() - Method in interface org.apache.camel.spi.HeaderFilterStrategyAware
Gets the header filter strategy used
getHeaderFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getHeaderName() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getHeaderName() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getHeaderName() - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
getHeaderName() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getHeaderName() - Method in class org.apache.camel.model.SetHeaderDefinition
 
getHeaderName() - Method in class org.apache.camel.model.SetOutHeaderDefinition
 
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
getHeaders() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getHeaders() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
 
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.impl.DefaultUnitOfWork
 
getId() - Method in class org.apache.camel.impl.RouteService
 
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.ExpressionDefinition
Gets the value of the id property.
getId() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Gets the value of the id property.
getId() - Method in interface org.apache.camel.spi.UnitOfWork
Returns the unique ID of this unit of work, lazily creating one if it does not yet have one
getIdempotentRepository() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getIdempotentRepository() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getIgnoreJAXBElement() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getImagePrefix() - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getIn() - Method in interface org.apache.camel.Exchange
Returns the inbound request message
getIn() - Method in class org.apache.camel.impl.DefaultExchange
 
getInclude() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getIncludes() - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
 
getIncludes() - Method in class org.apache.camel.model.PackageScanDefinition
 
getIndex() - Method in class org.apache.camel.component.bean.ParameterInfo
 
getIndex() - Method in class org.apache.camel.impl.ReportingTypeConverterLoader.TypeMapping
 
getInFilter() - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Gets the "in" direction filter set.
getInFilterPattern() - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Gets the "in" direction filter regular expression Pattern.
getInformation() - Method in class org.apache.camel.impl.MainSupport.Option
 
getInformation() - Method in class org.apache.camel.impl.MainSupport.ParameterOption
 
getInitialContext(Hashtable) - Method in class org.apache.camel.util.jndi.CamelInitialContextFactory
Creates a new context with the given environment.
getInitialDelay() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
getInjectionValue(Class<?>, String, String, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Creates the object to be injected for an EndpointInject or Produce injection point
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 class org.apache.camel.impl.DefaultCamelContext
 
getInjector() - Method in class org.apache.camel.impl.ReportingTypeConverterRegistry
 
getInjector() - Method in interface org.apache.camel.spi.TypeConverterRegistry
Gets the injector
getInProgressRepository() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getInputFactory() - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
getInputs() - Method in class org.apache.camel.model.RouteDefinition
 
getInputStream() - Method in class org.apache.camel.converter.jaxp.BytesSource
 
getInputStream() - Method in class org.apache.camel.converter.jaxp.StringSource
 
getInputStream() - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
getInputStream() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
 
getInputStream() - Method in class org.apache.camel.converter.stream.StreamSourceCache
 
getInputTransformer() - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
getInstance() - Static method in class org.apache.camel.impl.DefaultExchangeFormatter
 
getInterceptedProcessor(int) - Method in class org.apache.camel.model.InterceptDefinition
 
getInterceptFroms() - Method in class org.apache.camel.model.RoutesDefinition
 
getInterceptorLogic() - Method in interface org.apache.camel.Intercept
 
getIntercepts() - Method in class org.apache.camel.model.RoutesDefinition
 
getInterceptSendTos() - Method in class org.apache.camel.model.RoutesDefinition
 
getInterceptStrategies() - Method in interface org.apache.camel.CamelContext
Gets the interceptor strategies
getInterceptStrategies() - Method in interface org.apache.camel.Channel
Gets the list of InterceptStrategy registered to this Channel.
getInterceptStrategies() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getInterceptStrategies() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getInterceptStrategies() - Method in class org.apache.camel.model.ProcessorDefinition
 
getInterceptStrategies() - Method in class org.apache.camel.processor.DefaultChannel
 
getInterceptStrategies() - Method in interface org.apache.camel.spi.RouteContext
This method retrieves the InterceptStrategy instances this route context.
getInteruptedExceptionHandler() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
getKey() - Method in class org.apache.camel.model.config.PropertyDefinition
 
getKey() - Method in class org.apache.camel.util.TimeoutMapEntry
 
getKeys() - Method in class org.apache.camel.util.DefaultTimeoutMap
 
getKeys() - Method in interface org.apache.camel.util.TimeoutMap
Returns a copy of the keys in the map
getLabel(Exchange) - Method in class org.apache.camel.impl.DefaultRouteNode
 
getLabel() - Method in class org.apache.camel.model.AOPDefinition
 
getLabel() - Method in class org.apache.camel.model.BeanDefinition
 
getLabel() - Method in class org.apache.camel.model.CatchDefinition
 
getLabel() - Method in class org.apache.camel.model.ChoiceDefinition
 
getLabel() - Method in class org.apache.camel.model.DelayDefinition
 
getLabel() - Method in class org.apache.camel.model.ExpressionNode
 
getLabel() - Method in class org.apache.camel.model.FromDefinition
 
getLabel() - Method in class org.apache.camel.model.InterceptDefinition
 
getLabel() - Method in class org.apache.camel.model.InterceptFromDefinition
 
getLabel() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
getLabel(List<ExpressionDefinition>) - Static method in class org.apache.camel.model.language.ExpressionDefinition
 
getLabel() - Method in class org.apache.camel.model.language.ExpressionDefinition
Returns some descriptive text to describe this node
getLabel() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getLabel() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getLabel() - Method in class org.apache.camel.model.OtherwiseDefinition
 
getLabel() - Method in class org.apache.camel.model.PolicyDefinition
 
getLabel() - Method in class org.apache.camel.model.ProcessDefinition
 
getLabel() - Method in class org.apache.camel.model.ProcessorDefinition
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.RemoveHeaderDefinition
 
getLabel() - Method in class org.apache.camel.model.ResequenceDefinition
 
getLabel() - Method in class org.apache.camel.model.SendDefinition
 
getLabel() - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
getLabel() - Method in class org.apache.camel.model.SetHeaderDefinition
 
getLabel() - Method in class org.apache.camel.model.StopDefinition
 
getLabel() - Method in class org.apache.camel.model.ThreadsDefinition
 
getLabel() - Method in class org.apache.camel.model.ThrottleDefinition
 
getLabel() - Method in class org.apache.camel.model.TransactedDefinition
 
getLabel(Exchange) - Method in interface org.apache.camel.RouteNode
Gets a label about this node to be used for tracing or tooling etc.
getLabel(List<ExpressionDefinition>) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getLabel(ExpressionDefinition) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getLang() - Method in class org.apache.camel.model.DescriptionDefinition
 
getLanguage() - Method in class org.apache.camel.builder.ExpressionClause
 
getLanguage() - Method in class org.apache.camel.model.language.ConstantExpression
 
getLanguage() - Method in class org.apache.camel.model.language.ELExpression
 
getLanguage() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
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.MvelExpression
 
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.PropertyExpression
 
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.TokenizerExpression
 
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
 
getLanguageNames() - Method in interface org.apache.camel.CamelContext
Gets a readonly list with the names of the languages currently registered.
getLanguageNames() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getLanguageResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getLastExchangeCompletionTime() - Method in class org.apache.camel.management.PerformanceCounter
 
getLastExchangeFailureTime() - Method in class org.apache.camel.management.PerformanceCounter
 
getLastModified() - Method in class org.apache.camel.component.file.GenericFile
 
getLastNode() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getLastNode() - Method in interface org.apache.camel.spi.TraceableUnitOfWork
Gets the last node, is null if no last exists.
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
 
getLifecycleStrategy() - Method in class org.apache.camel.impl.RouteService
 
getLoadBalancer() - Method in class org.apache.camel.component.browse.BrowseEndpoint
 
getLoadBalancer(RouteContext, LoadBalancerDefinition, String) - Static method in class org.apache.camel.model.LoadBalancerDefinition
 
getLoadBalancer(RouteContext) - Method in class org.apache.camel.model.LoadBalancerDefinition
 
getLoadBalancerType() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getLocalWorkDirectory() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getLog() - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
getLog() - Method in class org.apache.camel.impl.DefaultComponentResolver
 
getLog() - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
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.DefaultErrorHandlerBuilder
 
getLogger() - Method in class org.apache.camel.component.log.LogEndpoint
 
getLogger() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
getLogger() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
getLoggingLevel(Map) - Method in class org.apache.camel.component.log.LogComponent
Gets the logging level, will default to use INFO if no level parameter provided.
getLogLevel() - Method in class org.apache.camel.processor.interceptor.Tracer
 
getLogName() - Method in class org.apache.camel.processor.interceptor.Tracer
 
getLogStackTrace() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getMandatoryBody() - Method in class org.apache.camel.impl.MessageSupport
 
getMandatoryBody(Class<T>) - Method in class org.apache.camel.impl.MessageSupport
 
getMandatoryBody() - Method in interface org.apache.camel.Message
Returns the body of the message as a POJO
getMandatoryBody(Class<T>) - Method in interface org.apache.camel.Message
Returns the mandatory body as the specified type
getMandatoryDefaultEndpoint() - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
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
getMandatoryEndpoint(CamelContext, String, Class<T>) - Static method in class org.apache.camel.util.CamelContextHelper
Returns the mandatory endpoint for the given URI and type 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
 
getMaxCacheSize() - Method in class org.apache.camel.util.LRUCache
Returns the maxCacheSize.
getMaxChars() - Method in class org.apache.camel.component.log.LogFormatter
 
getMaxChars() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
getMaxFileStoreSize() - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
getMaximumRedeliveries() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getMaximumRedeliveries() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getMaximumRedeliveryDelay() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getMaximumRedeliveryDelay() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getMaximumRequestsPerPeriod() - Method in class org.apache.camel.model.ThrottleDefinition
 
getMaximumRequestsPerPeriod() - Method in class org.apache.camel.processor.Throttler
 
getMaxMessagesPerPoll() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getMaxProcessingTimeMillis() - Method in class org.apache.camel.management.PerformanceCounter
 
getMBeanObjectDomainName() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getMBeanObjectDomainName() - Method in interface org.apache.camel.spi.InstrumentationAgent
Get domain name for Camel MBeans.
getMBeanServer() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getMBeanServer() - Method in interface org.apache.camel.spi.InstrumentationAgent
Get the MBeanServer which hosts managed objects.
getMBeanServerDefaultDomain() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getMeanProcessingTimeMillis() - Method in class org.apache.camel.management.PerformanceCounter
 
getMessage() - Method in class org.apache.camel.model.RollbackDefinition
 
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.IdempotentConsumerDefinition
 
getMessageIdRepositoryRef() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getMethod() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
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 class org.apache.camel.impl.ReportingTypeConverterLoader.TypeMapping
 
getMethod() - Method in exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
getMethod() - Method in class org.apache.camel.model.BeanDefinition
 
getMethod() - Method in class org.apache.camel.model.language.MethodCallExpression
 
getMethodInfo(Method) - Method in class org.apache.camel.component.bean.BeanInfo
Returns the MethodInfo for the given method if it exists or null if there is no metadata available for the given method
getMethodInfo(Method) - Method in class org.apache.camel.component.bean.MethodInfoCache
 
getMethodName() - Method in exception org.apache.camel.component.bean.MethodNotFoundException
 
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
getMinProcessingTimeMillis() - Method in class org.apache.camel.management.PerformanceCounter
 
getMinRate() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getMove() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getMoveFailed() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
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 class org.apache.camel.component.bean.RegistryBean
 
getName() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getName() - Method in exception org.apache.camel.NoSuchBeanException
 
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
 
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.InstrumentationLifecycleStrategy
 
getNewExchangeExpression() - Method in class org.apache.camel.model.WireTapDefinition
 
getNewExchangeExpression() - Method in class org.apache.camel.processor.WireTapProcessor
 
getNewExchangeProcessor() - Method in class org.apache.camel.model.WireTapDefinition
 
getNewExchangeProcessor() - Method in class org.apache.camel.processor.WireTapProcessor
 
getNewExchangeProcessorRef() - Method in class org.apache.camel.model.WireTapDefinition
 
getNextProcessor() - Method in interface org.apache.camel.Channel
Gets the next Processor to route to (not wrapped)
getNextProcessor() - Method in class org.apache.camel.processor.DefaultChannel
 
getNode() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
getNodeCounter(String) - Static method in class org.apache.camel.impl.DefaultNodeIdFactory
Returns the counter for the given node key, lazily creating one if necessary
getNodeData(Object) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getNodeFactory() - Method in class org.apache.camel.model.ProcessorDefinition
 
getNodeIdFactory() - Method in interface org.apache.camel.CamelContext
Gets the node id factory
getNodeIdFactory() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getNodeLength() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
getNodeMessage(RouteNode, Exchange) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
getNodes() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getNodes() - Method in interface org.apache.camel.spi.TraceableUnitOfWork
Gets the current list of nodes, representing the route path the current Exchange has currently taken.
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(RouteContext, ProcessorDefinition) - Method in class org.apache.camel.management.CamelNamingStrategy
Implements the naming strategy for a ProcessorDefinition.
getOnCompleteOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOnCompletions() - Method in class org.apache.camel.model.RoutesDefinition
 
getOnExceptions() - Method in class org.apache.camel.model.RoutesDefinition
 
getOnFailureOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOnlyRegisterProcessorWithCustomId() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getOnRedelivery() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getOnRedelivery() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOnRedeliveryRef() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOnWhen() - Method in class org.apache.camel.model.CatchDefinition
 
getOnWhen() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOnWhen() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOperationText() - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
getOperatorText(SimpleLangaugeOperator) - Method in enum org.apache.camel.language.simple.SimpleLangaugeOperator
 
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.OnExceptionDefinition
 
getOrFindTypeConverter(Class, Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
getOriginalInMessage() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getOriginalInMessage() - Method in interface org.apache.camel.spi.UnitOfWork
Gets the original IN Message this Unit of Work was started with.
getOtherwise() - Method in class org.apache.camel.model.ChoiceDefinition
 
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() - Method in class org.apache.camel.impl.DefaultExchange
 
getOutBatchSize() - Method in class org.apache.camel.model.AggregateDefinition
 
getOutBatchSize() - Method in class org.apache.camel.processor.BatchProcessor
 
getOutBody() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getOutBody() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
 
getOutBodyFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getOutBodyType() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getOutBodyType() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
 
getOutFilter() - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Gets the "out" direction filter set.
getOutFilterPattern() - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Gets the "out" direction filter regular expression Pattern.
getOutHeaderFunction() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getOutHeaders() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getOutput() - Method in interface org.apache.camel.Channel
Gets the wrapped output that at runtime should be delegated to.
getOutput() - Method in class org.apache.camel.processor.DefaultChannel
 
getOutput() - Method in class org.apache.camel.processor.LoggingErrorHandler
Returns the output processor
getOutput() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Returns the output processor
getOutputFactory() - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
getOutputs() - Method in class org.apache.camel.model.AggregateDefinition
 
getOutputs() - Method in class org.apache.camel.model.CatchDefinition
 
getOutputs() - Method in class org.apache.camel.model.ChoiceDefinition
 
getOutputs() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getOutputs() - Method in class org.apache.camel.model.ExpressionNode
 
getOutputs() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getOutputs() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getOutputs() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getOutputs() - Method in class org.apache.camel.model.OutputDefinition
 
getOutputs() - Method in class org.apache.camel.model.ProcessorDefinition
 
getOutputs() - Method in class org.apache.camel.model.ResequenceDefinition
 
getOutputs() - Method in class org.apache.camel.model.RollbackDefinition
 
getOutputs() - Method in class org.apache.camel.model.RouteDefinition
 
getOutputs() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getOutputs() - Method in class org.apache.camel.model.SendDefinition
 
getOutputs() - Method in class org.apache.camel.model.SortDefinition
 
getOutputs() - Method in class org.apache.camel.model.StopDefinition
 
getOutputs() - Method in class org.apache.camel.model.ThrottleDefinition
 
getOutputs() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getOutputsWithoutCatches() - Method in class org.apache.camel.model.TryDefinition
 
getOutputTransformer() - Method in class org.apache.camel.component.dataset.DataSetSupport
 
getPackages() - Method in class org.apache.camel.model.PackageScanDefinition
 
getPackageScanClassResolver() - Method in interface org.apache.camel.CamelContext
Returns the package scanning class resolver
getPackageScanClassResolver() - Method in class org.apache.camel.impl.DefaultCamelContext
 
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
 
getParamsAsMap() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getParent() - Method in class org.apache.camel.component.file.GenericFile
 
getParent() - Method in class org.apache.camel.model.ProcessorDefinition
 
getPassPhrase() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getPath() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getPattern() - Method in class org.apache.camel.component.bean.MethodInfo
Returns the ExchangePattern that should be used when invoking this method.
getPattern() - Method in interface org.apache.camel.Exchange
Returns the ExchangePattern (MEP) of this exchange.
getPattern() - Method in class org.apache.camel.impl.DefaultExchange
 
getPattern() - Method in class org.apache.camel.model.InOnlyDefinition
 
getPattern() - Method in class org.apache.camel.model.InOutDefinition
 
getPattern() - Method in class org.apache.camel.model.SendDefinition
 
getPattern() - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
getPattern() - Method in class org.apache.camel.model.ToDefinition
 
getPattern() - Method in class org.apache.camel.model.WireTapDefinition
 
getPatternAnnotation(AnnotatedElement) - Method in class org.apache.camel.component.bean.MethodInfo
Returns the pattern annotation on the given annotated element; either as a direct annotation or on an annotation which is also annotated
getPatternAnnotation(AnnotatedElement, int) - Method in class org.apache.camel.component.bean.MethodInfo
Returns the pattern annotation on the given annotated element; either as a direct annotation or on an annotation which is also annotated
getPeriod() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
getPollStrategy() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
getPoolSize() - Method in class org.apache.camel.model.ThreadsDefinition
 
getPredicate() - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
getPredicate() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
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
 
getPreMove() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.XMLBeansDataFormat
 
getPrettyPrint() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
getPreviousNode() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getPreviousNode() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
Gets the previous node.
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.DefaultRouteNode
 
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.DelegateProcessor
 
getProcessor() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getProcessor() - Method in class org.apache.camel.processor.StreamResequencer
Returns the next processor.
getProcessor() - Method in interface org.apache.camel.RouteNode
Gets the actual processor this node represents.
getProcessorDefinition() - Method in interface org.apache.camel.Channel
Gets the defintion of the next processor
getProcessorDefinition() - Method in class org.apache.camel.impl.DefaultRouteNode
 
getProcessorDefinition() - Method in class org.apache.camel.processor.DefaultChannel
 
getProcessorDefinition() - Method in interface org.apache.camel.RouteNode
Gets the model definition that represents this node
getProcessors() - Method in class org.apache.camel.model.LoadBalancerDefinition
 
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
getProcessStrategy() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getProduceDelay() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
getProducer(Endpoint) - Method in class org.apache.camel.impl.ProducerCache
 
getProducerCache(Exchange) - Method in class org.apache.camel.processor.RecipientList
 
getProducerCache(Exchange) - Method in class org.apache.camel.processor.RoutingSlip
 
getProducerCache(Exchange) - Method in class org.apache.camel.processor.SendProcessor
 
getProducers() - Method in class org.apache.camel.component.seda.SedaEndpoint
Returns the current active producers on this endpoint
getProducerServicePool() - Method in interface org.apache.camel.CamelContext
Gets the service pool for Producer pooling.
getProducerServicePool() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getProperties() - Method in interface org.apache.camel.CamelContext
Gets the properties that can be referenced in the camel context
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.DefaultCamelContext
 
getProperties() - Method in class org.apache.camel.impl.DefaultExchange
 
getProperties() - Method in class org.apache.camel.impl.DefaultRoute
 
getProperties() - Method in class org.apache.camel.model.config.PropertiesDefinition
 
getProperties() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getProperties() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
 
getProperties() - Method in interface 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 class org.apache.camel.model.RemovePropertyDefinition
 
getPropertyName() - Method in class org.apache.camel.model.SetPropertyDefinition
 
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
 
getQueueKey(String) - Method in class org.apache.camel.component.seda.SedaComponent
 
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
 
getReadLock() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getReadLockTimeout() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getReason() - Method in exception org.apache.camel.component.file.GenericFileOperationFailedException
Return the file failure reason (if any)
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
 
getRedeliverDelay() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getRedeliveryDelay() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getRedeliveryPolicy() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
getRedeliveryPolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getRedeliveryPolicy() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
getRef() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
getRef() - Method in class org.apache.camel.model.BeanDefinition
 
getRef() - Method in class org.apache.camel.model.FromDefinition
 
getRef() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getRef() - Method in class org.apache.camel.model.MarshalDefinition
 
getRef() - Method in class org.apache.camel.model.PolicyDefinition
 
getRef() - Method in class org.apache.camel.model.ProcessDefinition
 
getRef() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getRef() - Method in class org.apache.camel.model.RouteBuilderDefinition
 
getRef() - Method in class org.apache.camel.model.SendDefinition
 
getRef() - Method in class org.apache.camel.model.TransactedDefinition
 
getRef() - Method in class org.apache.camel.model.UnmarshalDefinition
 
getRegex() - Method in class org.apache.camel.model.language.TokenizerExpression
 
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
 
getRegistryPort() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getRelativeFilePath() - Method in class org.apache.camel.component.file.GenericFile
 
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
 
getResolvedEndpoint(String, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
getResourcePath() - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
getResourcePath() - Method in interface org.apache.camel.spi.FactoryFinder
Gets the resource classpath.
getResources(ClassLoader, String) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
Strategy to get the resources by the given classloader.
getResources(ClassLoader, String) - Method in class org.apache.camel.impl.WebSpherePacakageScanClassResolver
Overloaded to handle specific problem with getting resources on the IBM WebSphere platform.
getResourceUri() - Method in class org.apache.camel.model.PollEnrichDefinition
 
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
 
getResultMessage(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Returns the message where to write results in an exchange-pattern-sensitive way.
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.language.xpath.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
 
getRetriesExhaustedLogLevel() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getRetriesExhaustedLogLevel() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getRetryAttemptedLogLevel() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getRetryAttemptedLogLevel() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
getRetryUntil() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getRetryUntilPolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getRoute() - Method in class org.apache.camel.impl.DefaultRouteContext
 
getRoute() - Method in class org.apache.camel.management.ManagedRoute
 
getRoute() - Method in interface org.apache.camel.spi.RouteContext
Get the route type
getRouteBuilders() - Method in class org.apache.camel.impl.MainSupport
 
getRouteCollection() - Method in class org.apache.camel.builder.RouteBuilder
 
getRouteContexts() - Method in class org.apache.camel.impl.RouteService
 
getRouteDefinition() - Method in class org.apache.camel.impl.RouteService
 
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
 
getRouteDefinitions() - Method in class org.apache.camel.impl.MainSupport
 
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 class org.apache.camel.impl.RouteService
 
getRoutes() - Method in interface org.apache.camel.model.RouteContainer
Returns the routes
getRoutes() - Method in class org.apache.camel.model.RoutesDefinition
 
getRouteServices() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getRoutesOutputFile() - Method in class org.apache.camel.impl.MainSupport
 
getRouteStatus(RouteDefinition) - Method in interface org.apache.camel.CamelContext
Returns the current status of the given route
getRouteStatus(RouteDefinition) - Method in class org.apache.camel.impl.DefaultCamelContext
 
getRouteStatus(String) - Method in class org.apache.camel.impl.DefaultCamelContext
Returns the status of the service of the given ID or null if there is no service created yet
getRoutesText(CamelContext) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getRouteText(RouteDefinition) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
getScanner(Exchange, Object) - Static method in class org.apache.camel.util.ObjectHelper
Creates a Scanner for scanning the given value.
getScheduledExecutorService() - Method in class org.apache.camel.impl.DefaultComponent
 
getScheduledExecutorService() - Method in class org.apache.camel.impl.DefaultEndpoint
 
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.component.file.FileEndpoint
 
getScheme() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getScheme() - Method in class org.apache.camel.util.URISupport.CompositeData
 
getSecondLastNode() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
getSecondLastNode() - Method in interface org.apache.camel.spi.TraceableUnitOfWork
Gets the 2nd last node, is null if no last exists.
getSecureTag() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
getSeparator() - Method in class org.apache.camel.util.CollectionStringBuffer
 
getSequenceSender() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the sequence sender.
getService() - Method in class org.apache.camel.management.ManagedService
 
getServices() - Method in class org.apache.camel.impl.DefaultRoute
 
getServices() - Method in interface org.apache.camel.Route
Returns the additional services required for this particular route
getServicesForRoute() - Method in class org.apache.camel.impl.DefaultRoute
 
getServicesForRoute() - Method in interface org.apache.camel.Route
This property map is used to associate information about the route.
getServiceUrlPath() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getShortExchangeId() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getShortExchangeId() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
Gets the exchange id without the leading hostname
getShortName() - Method in class org.apache.camel.model.AggregateDefinition
 
getShortName() - Method in class org.apache.camel.model.AOPDefinition
 
getShortName() - Method in class org.apache.camel.model.BeanDefinition
 
getShortName() - Method in class org.apache.camel.model.CatchDefinition
 
getShortName() - Method in class org.apache.camel.model.ChoiceDefinition
 
getShortName() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getShortName() - Method in class org.apache.camel.model.DelayDefinition
 
getShortName() - Method in class org.apache.camel.model.EnrichDefinition
 
getShortName() - Method in class org.apache.camel.model.ExpressionNode
 
getShortName() - Method in class org.apache.camel.model.FilterDefinition
 
getShortName() - Method in class org.apache.camel.model.FinallyDefinition
 
getShortName() - Method in class org.apache.camel.model.FromDefinition
 
getShortName() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
getShortName() - Method in class org.apache.camel.model.InOnlyDefinition
 
getShortName() - Method in class org.apache.camel.model.InOutDefinition
 
getShortName() - Method in class org.apache.camel.model.InterceptDefinition
 
getShortName() - Method in class org.apache.camel.model.InterceptFromDefinition
 
getShortName() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
getShortName() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
getShortName() - Method in class org.apache.camel.model.LoopDefinition
 
getShortName() - Method in class org.apache.camel.model.MarshalDefinition
 
getShortName() - Method in class org.apache.camel.model.MulticastDefinition
 
getShortName() - Method in class org.apache.camel.model.OnCompletionDefinition
 
getShortName() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getShortName() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Returns a short name for this node which can be useful for ID generation or referring to related resources like images
getShortName() - Method in class org.apache.camel.model.OtherwiseDefinition
 
getShortName() - Method in class org.apache.camel.model.PipelineDefinition
 
getShortName() - Method in class org.apache.camel.model.PolicyDefinition
 
getShortName() - Method in class org.apache.camel.model.PollEnrichDefinition
 
getShortName() - Method in class org.apache.camel.model.ProcessDefinition
 
getShortName() - Method in class org.apache.camel.model.RecipientListDefinition
 
getShortName() - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
getShortName() - Method in class org.apache.camel.model.RemovePropertyDefinition
 
getShortName() - Method in class org.apache.camel.model.ResequenceDefinition
 
getShortName() - Method in class org.apache.camel.model.RollbackDefinition
 
getShortName() - Method in class org.apache.camel.model.RouteDefinition
 
getShortName() - Method in class org.apache.camel.model.RoutesDefinition
 
getShortName() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getShortName() - Method in class org.apache.camel.model.SetBodyDefinition
 
getShortName() - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
getShortName() - Method in class org.apache.camel.model.SetHeaderDefinition
 
getShortName() - Method in class org.apache.camel.model.SetOutHeaderDefinition
 
getShortName() - Method in class org.apache.camel.model.SetPropertyDefinition
 
getShortName() - Method in class org.apache.camel.model.SortDefinition
 
getShortName() - Method in class org.apache.camel.model.SplitDefinition
 
getShortName() - Method in class org.apache.camel.model.StopDefinition
 
getShortName() - Method in class org.apache.camel.model.ThreadsDefinition
 
getShortName() - Method in class org.apache.camel.model.ThrottleDefinition
 
getShortName() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
getShortName() - Method in class org.apache.camel.model.ToDefinition
 
getShortName() - Method in class org.apache.camel.model.TransactedDefinition
 
getShortName() - Method in class org.apache.camel.model.TransformDefinition
 
getShortName() - Method in class org.apache.camel.model.TryDefinition
 
getShortName() - Method in class org.apache.camel.model.UnmarshalDefinition
 
getShortName() - Method in class org.apache.camel.model.WhenDefinition
 
getShortName() - Method in class org.apache.camel.model.WireTapDefinition
 
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 singleton 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
 
getSize() - Method in class org.apache.camel.component.seda.SedaEndpoint
 
getSkipSendToOriginalEndpoint() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
getSleepForEmptyTest() - Method in class org.apache.camel.component.mock.MockEndpoint
 
getSortBy() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getSorter() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getSource(Exchange) - Method in class org.apache.camel.builder.xml.XsltBuilder
Converts the inbound body to a Source
getStaticPart() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getStatus() - Method in class org.apache.camel.impl.ServiceSupport
Returns the current status
getStatus() - Method in class org.apache.camel.model.RouteDefinition
Returns the status of the route if it has been registered with a CamelContext
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.AggregateDefinition
 
getStreamCache() - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
getStreamCaching(CamelContext) - Static method in class org.apache.camel.processor.interceptor.StreamCaching
A helper method to return the StreamCaching instance for a given CamelContext if one is enabled
getStreamConfig() - Method in class org.apache.camel.model.ResequenceDefinition
 
getSystemProperty(String, String) - Static method in class org.apache.camel.util.ObjectHelper
A helper method to access a system property, catching any security exceptions
getSystemProperty(String, Boolean) - Static method in class org.apache.camel.util.ObjectHelper
A helper method to access a boolean system property, catching any security exceptions
getSystemProperty(String) - Static method in class org.apache.camel.util.SystemHelper
Looks up the given system property name returning null if any exceptions occur
getTemplate() - Method in class org.apache.camel.builder.xml.XsltBuilder
 
getTempPrefix() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
getText() - Method in class org.apache.camel.builder.xml.XPathBuilder
 
getText() - Method in class org.apache.camel.converter.jaxp.StringSource
 
getText() - Method in class org.apache.camel.model.DescriptionDefinition
 
getThis() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
getThreadName(String) - Static method in class org.apache.camel.util.concurrent.ExecutorServiceHelper
Creates a new thread name with the given prefix
getTime() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
getTimeout() - Method in class org.apache.camel.component.file.strategy.FileChangedExclusiveReadLockStrategy
 
getTimeout() - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
 
getTimeout() - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
 
getTimeout() - Method in class org.apache.camel.component.seda.SedaEndpoint
 
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.model.PollEnrichDefinition
 
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
Returns this resequencer's timeout.
getTimeout() - Method in class org.apache.camel.util.TimeoutMapEntry
 
getTimeoutHandlers() - Method in class org.apache.camel.processor.resequencer.Timeout
Returns the timeout handler that has been registered for notification.
getTimePeriodMillis() - Method in class org.apache.camel.model.ThrottleDefinition
 
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
 
getTimestamp() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getTimestamp() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
Gets the timestamp when the interception occured
getTimeUnit() - Method in class org.apache.camel.impl.MainSupport
 
getTimeUnit() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
getTimeUnit() - Method in class org.apache.camel.util.Time
 
getToClassMappings(Class) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
getToken() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getToken() - Method in class org.apache.camel.model.language.TokenizerExpression
 
getToNode() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
getToNode() - Method in interface org.apache.camel.processor.interceptor.TraceEventMessage
Gets the current node that just have been intercepted and processed

Is never null.

getTotalProcessingTimeMillis() - Method in class org.apache.camel.management.PerformanceCounter
 
getToType() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
getToType() - Method in class org.apache.camel.impl.ReportingTypeConverterLoader.TypeMapping
 
getToType() - Method in exception org.apache.camel.NoTypeConversionAvailableException
Returns the required to type
getTraceFilter() - Method in class org.apache.camel.processor.interceptor.Tracer
 
getTraceLabel() - Method in class org.apache.camel.processor.Aggregator
 
getTraceLabel() - Method in class org.apache.camel.processor.CatchProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Delayer
 
getTraceLabel() - Method in class org.apache.camel.processor.FilterProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.LoopProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.MulticastProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Pipeline
 
getTraceLabel() - Method in class org.apache.camel.processor.Resequencer
 
getTraceLabel() - Method in class org.apache.camel.processor.RollbackProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RoutingSlip
 
getTraceLabel() - Method in class org.apache.camel.processor.SendProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Splitter
 
getTraceLabel() - Method in class org.apache.camel.processor.StreamResequencer
 
getTraceLabel() - Method in class org.apache.camel.processor.Throttler
 
getTraceLabel() - Method in interface org.apache.camel.processor.Traceable
Gets the trace label used for logging when tracing is enabled.
getTraceLabel() - Method in class org.apache.camel.processor.TransformProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.TryProcessor
 
getTracer(CamelContext) - Static method in class org.apache.camel.processor.interceptor.Tracer
A helper method to return the Tracer instance if one is enabled
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.impl.ProxyInstantiationException
 
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 class org.apache.camel.management.InstrumentationProcessor
 
getType() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
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 class org.apache.camel.processor.ConvertBodyProcessor
 
getTypeClass() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
getTypeConversions() - Method in class org.apache.camel.impl.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
 
getTypeConverterLoaders() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
getTypeConverterRegistry() - Method in interface org.apache.camel.CamelContext
Returns the type converter registry where type converters can be added or looked up
getTypeConverterRegistry() - Method in class org.apache.camel.impl.DefaultCamelContext
 
getTypeMappings() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
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
 
getUnmarshalType() - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
getUri() - Method in exception org.apache.camel.FailedToCreateConsumerException
 
getUri() - Method in exception org.apache.camel.FailedToCreateProducerException
 
getUri() - Method in class org.apache.camel.management.ManagedEndpoint
 
getUri() - Method in class org.apache.camel.model.FromDefinition
 
getUri() - Method in class org.apache.camel.model.InterceptFromDefinition
 
getUri() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
getUri() - Method in class org.apache.camel.model.SendDefinition
 
getUri() - Method in exception org.apache.camel.NoFactoryAvailableException
 
getUri() - Method in exception org.apache.camel.NoSuchEndpointException
 
getUri() - Method in exception org.apache.camel.ResolveEndpointFailedException
 
getUriDelimiter() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
getUriOrRef() - Method in class org.apache.camel.model.FromDefinition
Returns the endpoint URI or the name of the reference to it
getUriOrRef() - Method in class org.apache.camel.model.SendDefinition
Returns the endpoint URI or the name of the reference to it
getUseCollisionAvoidance() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getUseExponentialBackOff() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
getUseOriginalMessagePolicy() - Method in class org.apache.camel.model.OnExceptionDefinition
 
getUsePlatformMBeanServer() - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
getValue() - Method in class org.apache.camel.model.config.PropertyDefinition
 
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
 
getVersion() - Method in class org.apache.camel.impl.ServiceSupport
Returns the version of this service
getWaitForTaskToComplete() - Method in class org.apache.camel.component.seda.SedaEndpoint
 
getWaitForTaskToComplete() - Method in class org.apache.camel.model.ThreadsDefinition
 
getWarnings() - Method in exception org.apache.camel.processor.validation.SchemaValidationException
Returns the validation warnings
getWhen() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
getWhenClauses() - Method in class org.apache.camel.model.ChoiceDefinition
 
getWsdlUri() - Method in enum org.apache.camel.ExchangePattern
Returns the WSDL URI for this message exchange pattern
getXmlCipherAlgorithm() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
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 expressions 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.RouteDefinition
Set the group name for this route
GROUP_PATTERN - Static variable in class org.apache.camel.language.simple.SimpleLanguageSupport
 
GROUP_PROPERTY - Static variable in interface org.apache.camel.Route
 
GROUPED_EXCHANGE - Static variable in interface org.apache.camel.Exchange
 
GroupedExchangeAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate all exchanges into a single combined Exchange holding all the aggregated exchanges in a List as a exchange property with the key Exchange.GROUPED_EXCHANGE.
GroupedExchangeAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategy
 
groupExchanges() - Method in class org.apache.camel.model.AggregateDefinition
Enables grouped exchanges, so the aggregator will group all aggregated exchanges into a single combined Exchange holding all the aggregated exchanges in a List as a exchange property with the key Exchange.GROUPED_EXCHANGE.
gzip() - Method in class org.apache.camel.builder.DataFormatClause
Uses the GZIP deflater data format
GzipDataFormat - Class in org.apache.camel.impl
 
GzipDataFormat() - Constructor for class org.apache.camel.impl.GzipDataFormat
 
GzipDataFormat - Class in org.apache.camel.model.dataformat
Represents the GZip DataFormat
GzipDataFormat() - Constructor for class org.apache.camel.model.dataformat.GzipDataFormat
 

H

handled(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets whether the exchange should be marked as handled or not.
handled(Predicate) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets whether the exchange should be marked as handled or not.
handled(Expression) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets whether the exchange should be marked as handled or not.
handled(boolean) - Method in class org.apache.camel.model.CatchDefinition
Sets whether the exchange should be marked as handled or not.
handled(Predicate) - Method in class org.apache.camel.model.CatchDefinition
Sets whether the exchange should be marked as handled or not.
handled(Expression) - Method in class org.apache.camel.model.CatchDefinition
Sets whether the exchange should be marked as handled or not.
handled(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should be marked as handled or not.
handled(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should be marked as handled or not.
handled(Expression) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets whether the exchange should be marked as handled or not.
handled(boolean) - Method in class org.apache.camel.model.TryDefinition
Sets whether the exchange should be marked as handled or not.
handled(Predicate) - Method in class org.apache.camel.model.TryDefinition
Sets whether the exchange should be marked as handled or not.
handled(Expression) - Method in class org.apache.camel.model.TryDefinition
Sets whether the exchange should be marked as handled or not.
handledPolicy - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
handledPolicy - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
handleErrors(Exchange, Schema, Result) - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
handleErrors(Exchange, Object) - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
handleErrors(Exchange, Schema, Result) - 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.component.file.GenericFileOnCompletion
 
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, RedeliveryErrorHandler.RedeliveryData) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
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
handleFailedWrite(Exchange, Exception) - Method in class org.apache.camel.component.file.GenericFileProducer
If we fail writing out a file, we will call this method.
handleFault() - Method in class org.apache.camel.model.RouteDefinition
Enable handle fault for this route.
HandleFault - Class in org.apache.camel.processor.interceptor
InterceptStrategy implementation to handle faults as exceptions on a RouteContext
HandleFault() - Constructor for class org.apache.camel.processor.interceptor.HandleFault
 
handleFault(Exchange) - Method in class org.apache.camel.processor.interceptor.HandleFaultInterceptor
Handles the fault message by converting it to an Exception
HandleFaultInterceptor - Class in org.apache.camel.processor.interceptor
 
HandleFaultInterceptor() - Constructor for class org.apache.camel.processor.interceptor.HandleFaultInterceptor
 
HandleFaultInterceptor(Processor) - Constructor for class org.apache.camel.processor.interceptor.HandleFaultInterceptor
 
handleInteruptedException(InterruptedException) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
Handler - Annotation Type in org.apache.camel
Marks a method on a POJO as being the preferred method to invoke when Camel looks for methods to invoke using the BeanEndpoint.
handles(Exchange) - Method in class org.apache.camel.processor.CatchProcessor
Whether this catch processor handles the exception it have caught
handleSleepInteruptedException(InterruptedException) - Method in class org.apache.camel.processor.DelayProcessorSupport
Called when a sleep is interupted; allows derived classes to handle this case differently
handoverSynchronization(Exchange) - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
handoverSynchronization(Exchange) - Method in interface org.apache.camel.spi.UnitOfWork
Handover all the registered synchronizations to the target Exchange.
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(AnnotatedElement, Class<? extends Annotation>, boolean) - Static method in class org.apache.camel.util.ObjectHelper
Checks if a Class or Method are annotated with the given annotation
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 whether this message has attachments.
hasBodyParameter() - Method in class org.apache.camel.component.bean.MethodInfo
 
hasCustomAnnotation() - Method in class org.apache.camel.component.bean.MethodInfo
 
hasCustomIdAssigned() - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Returns whether a custom id has been assigned
hasEndpoint(String) - Method in interface org.apache.camel.CamelContext
Is the given endpoint already registered?
hasEndpoint(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
hasExceptionParameter() - Method in class org.apache.camel.component.bean.MethodInfo
 
hasFaultMessage(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Tests whether the exchange has a fault message set and that its not null.
hasHandlerAnnotation() - Method in class org.apache.camel.component.bean.MethodInfo
 
hashCode() - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
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.impl.ReportingTypeConverterLoader.TypeMapping
 
hashCode() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
hasHeaders() - Method in class org.apache.camel.impl.DefaultMessage
 
hasHeaders() - Method in interface org.apache.camel.Message
Returns whether has any headers has been set.
hasInterceptorStrategy(Class) - Method in class org.apache.camel.processor.DefaultChannel
 
hasNext() - Method in interface org.apache.camel.Navigate
Are there more outputs?
hasNext() - Method in class org.apache.camel.processor.BatchProcessor
 
hasNext() - Method in class org.apache.camel.processor.ChoiceProcessor
 
hasNext() - Method in class org.apache.camel.processor.CompositeProcessor
 
hasNext() - Method in class org.apache.camel.processor.DefaultChannel
 
hasNext() - Method in class org.apache.camel.processor.DelegateProcessor
 
hasNext() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
hasNext() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
hasNext() - Method in class org.apache.camel.processor.MulticastProcessor
 
hasNext() - Method in class org.apache.camel.processor.StreamResequencer
 
hasNext() - Method in class org.apache.camel.processor.TryProcessor
 
hasOut() - Method in interface org.apache.camel.Exchange
Returns whether an OUT message has been set or not.
hasOut() - Method in class org.apache.camel.impl.DefaultExchange
 
hasPopulatedHeaders() - Method in class org.apache.camel.impl.DefaultMessage
Returns true if the headers have been mutated in some way
hasProperties() - Method in interface org.apache.camel.Exchange
Returns whether any properties has been set
hasProperties() - Method in class org.apache.camel.impl.DefaultExchange
 
hasProperties(Map, String) - Static method in class org.apache.camel.util.IntrospectionSupport
 
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(String) - Static method in class org.apache.camel.language.header.HeaderLanguage
 
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
 
HeaderFilterStrategy - Interface in org.apache.camel.spi
Interface to allow plug-able implementation to filter header to and from Camel message.
HeaderFilterStrategy.Direction - Enum in org.apache.camel.spi
 
HeaderFilterStrategyAware - Interface in org.apache.camel.spi
An interface to represent an object which can make use of injected HeaderFilterStrategy.
HeaderFilterStrategyComponent - Class in org.apache.camel.impl
 
HeaderFilterStrategyComponent() - Constructor for class org.apache.camel.impl.HeaderFilterStrategyComponent
 
HeaderFilterStrategyComponent(CamelContext) - Constructor for class org.apache.camel.impl.HeaderFilterStrategyComponent
 
HeaderLanguage - Class in org.apache.camel.language.header
A language for header expressions.
HeaderLanguage() - Constructor for class org.apache.camel.language.header.HeaderLanguage
 
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.
hl7() - Method in class org.apache.camel.builder.DataFormatClause
Uses the HL7 data format
hl7(boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the HL7 data format
HL7DataFormat - Class in org.apache.camel.model.dataformat
Represents a HL7 DataFormat.
HL7DataFormat() - Constructor for class org.apache.camel.model.dataformat.HL7DataFormat
 
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
 
HTTP_BASE_URI - Static variable in interface org.apache.camel.Exchange
 
HTTP_CHARACTER_ENCODING - Static variable in interface org.apache.camel.Exchange
 
HTTP_METHOD - Static variable in interface org.apache.camel.Exchange
 
HTTP_PATH - Static variable in interface org.apache.camel.Exchange
 
HTTP_QUERY - Static variable in interface org.apache.camel.Exchange
 
HTTP_RESPONSE_CODE - Static variable in interface org.apache.camel.Exchange
 
HTTP_URI - Static variable in interface org.apache.camel.Exchange
 
HTTP_URL - Static variable in interface org.apache.camel.Exchange
 

I

id(String) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Sets the id of this node
id(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sets the id of this node
id - Variable in class org.apache.camel.view.NodeData
 
ID_PROPERTY - Static variable in interface org.apache.camel.Route
 
idempotent - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
idempotentConsumer() - Method in class org.apache.camel.model.ProcessorDefinition
Idempotent consumer EIP: Creates an IdempotentConsumer to avoid duplicate messages
idempotentConsumer(Expression, IdempotentRepository) - Method in class org.apache.camel.model.ProcessorDefinition
Idempotent consumer EIP: Creates an IdempotentConsumer to avoid duplicate messages
idempotentConsumer(IdempotentRepository) - Method in class org.apache.camel.model.ProcessorDefinition
Idempotent consumer EIP: Creates an IdempotentConsumer to avoid duplicate messages
IdempotentConsumer - Class in org.apache.camel.processor.idempotent
An implementation of the Idempotent Consumer pattern.
IdempotentConsumer(Expression, IdempotentRepository, boolean, Processor) - Constructor for class org.apache.camel.processor.idempotent.IdempotentConsumer
 
IdempotentConsumerDefinition - Class in org.apache.camel.model
Represents an XML <idempotentConsumer/> element
IdempotentConsumerDefinition() - Constructor for class org.apache.camel.model.IdempotentConsumerDefinition
 
IdempotentConsumerDefinition(Expression, IdempotentRepository) - Constructor for class org.apache.camel.model.IdempotentConsumerDefinition
 
IdempotentOnCompletion - Class in org.apache.camel.processor.idempotent
On completion strategy for IdempotentConsumer.
IdempotentOnCompletion(IdempotentRepository, String, boolean) - Constructor for class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
idempotentRepository - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
IdempotentRepository<E> - Interface in org.apache.camel.spi
Access to a repository of Message IDs to implement the Idempotent Consumer pattern.
IdentifiedType - Class in org.apache.camel.model
The unique identifier for a bean.
IdentifiedType() - Constructor for class org.apache.camel.model.IdentifiedType
 
idOrCreate(NodeIdFactory) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Gets the node id, creating one if not already set.
ifStartsWithReturnRemainder(String, String) - Method in class org.apache.camel.impl.DefaultComponent
Returns the reminder of the text if it starts with the prefix.
ifStartsWithReturnRemainder(String, String) - Method in class org.apache.camel.language.simple.SimpleLanguageSupport
 
image - Variable in class org.apache.camel.view.NodeData
 
in(Predicate...) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to return true if any of the predicates matches.
in(Object...) - Method in class org.apache.camel.builder.ValueBuilder
 
in(Predicate...) - Method in class org.apache.camel.builder.ValueBuilder
 
IN_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
include - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
increment() - Method in class org.apache.camel.management.Counter
 
initChannel(ProcessorDefinition, RouteContext) - Method in interface org.apache.camel.Channel
Initializes the channel.
initChannel(ProcessorDefinition, RouteContext) - Method in class org.apache.camel.processor.DefaultChannel
 
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
InOnly - Annotation Type in org.apache.camel
Marks methods as being ExchangePattern.InOnly for one way asynchronous invocation when using Bean Integration or Spring Remoting to overload the default value which is ExchangePattern.InOut for request/reply if no annotations are used.
inOnly() - Method in class org.apache.camel.model.ProcessorDefinition
ExchangePattern: set the exchange's ExchangePattern ExchangePattern to be InOnly
inOnly(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoint using an Event Message or InOnly exchange pattern
inOnly(Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoint using an Event Message or InOnly exchange pattern
inOnly(String...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Event Message or InOnly exchange pattern
inOnly(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Event Message or InOnly exchange pattern
inOnly(Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Event Message or InOnly exchange pattern
InOnlyDefinition - Class in org.apache.camel.model
Represents an XML <inOnly/> element
InOnlyDefinition() - Constructor for class org.apache.camel.model.InOnlyDefinition
 
InOnlyDefinition(String) - Constructor for class org.apache.camel.model.InOnlyDefinition
 
InOnlyDefinition(Endpoint) - Constructor for class org.apache.camel.model.InOnlyDefinition
 
InOut - Annotation Type in org.apache.camel
Marks a method as being ExchangePattern.InOut when a class or interface has been annotated with InOnly when using Bean Integration or Spring Remoting.
inOut() - Method in class org.apache.camel.model.ProcessorDefinition
ExchangePattern: set the exchange's ExchangePattern ExchangePattern to be InOut
inOut(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoint using an Request Reply or InOut exchange pattern
inOut(Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoint using an Request Reply or InOut exchange pattern
inOut(String...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Request Reply or InOut exchange pattern
inOut(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Request Reply or InOut exchange pattern
inOut(Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the message to the given endpoints using an Request Reply or InOut exchange pattern
InOutDefinition - Class in org.apache.camel.model
Represents an XML <inOut/> element
InOutDefinition() - Constructor for class org.apache.camel.model.InOutDefinition
 
InOutDefinition(String) - Constructor for class org.apache.camel.model.InOutDefinition
 
InOutDefinition(Endpoint) - Constructor for class org.apache.camel.model.InOutDefinition
 
inProgressRepository - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
InputStreamCache - Class in org.apache.camel.converter.stream
 
InputStreamCache(byte[]) - Constructor for class org.apache.camel.converter.stream.InputStreamCache
 
insert(E) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Inserts the given element into this resequencer.
insertSpacesBetweenCamelCase(String) - Static method in class org.apache.camel.view.NodeData
Lets insert a space before each upper case letter after a lowercase
INSTANCE - Static variable in class org.apache.camel.impl.DefaultExchangeFormatter
 
InstanceMethodFallbackTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter implementation which instantiates an object so that an instance method can be used as a fallback type converter
InstanceMethodFallbackTypeConverter(CachingInjector, Method, TypeConverterRegistry) - Constructor for class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
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
Camel JMX service agent
InstrumentationInterceptStrategy - Class in org.apache.camel.management
This strategy class wraps targeted processors with a InstrumentationProcessor.
InstrumentationInterceptStrategy(Map<ProcessorDefinition, PerformanceCounter>) - Constructor for class org.apache.camel.management.InstrumentationInterceptStrategy
 
InstrumentationLifecycleStrategy - Class in org.apache.camel.management
JMX agent that registeres Camel lifecycle events in JMX.
InstrumentationLifecycleStrategy() - Constructor for class org.apache.camel.management.InstrumentationLifecycleStrategy
 
InstrumentationLifecycleStrategy(InstrumentationAgent) - Constructor for class org.apache.camel.management.InstrumentationLifecycleStrategy
 
InstrumentationLifecycleStrategy(InstrumentationAgent, CamelContext) - Constructor for class org.apache.camel.management.InstrumentationLifecycleStrategy
Constructor for camel context that has been started.
InstrumentationProcessor - Class in org.apache.camel.management
JMX enabled processor that uses the Counter for instrumenting processing of exchanges.
InstrumentationProcessor() - Constructor for class org.apache.camel.management.InstrumentationProcessor
 
InstrumentationProcessor(PerformanceCounter) - Constructor for class org.apache.camel.management.InstrumentationProcessor
 
intercept() - Method in class org.apache.camel.builder.RouteBuilder
Adds a route for an interceptor that intercepts every processing step.
Intercept - Interface in org.apache.camel
An interface which provides the processing logic as a pluggable processor
intercept() - Method in class org.apache.camel.model.RoutesDefinition
Creates and adds an interceptor that is triggered on every step in the route processing.
InterceptDefinition - Class in org.apache.camel.model
Represents an XML <intercept/> element
InterceptDefinition() - Constructor for class org.apache.camel.model.InterceptDefinition
 
intercepted - Variable in class org.apache.camel.model.InterceptDefinition
 
INTERCEPTED_ENDPOINT - Static variable in interface org.apache.camel.Exchange
 
InterceptEndpointProcessor - Class in org.apache.camel.processor
Endpoint intercept processor so we know the processor is supposed to intercept an andpoint.
InterceptEndpointProcessor(String) - Constructor for class org.apache.camel.processor.InterceptEndpointProcessor
 
InterceptEndpointProcessor(String, Processor) - Constructor for class org.apache.camel.processor.InterceptEndpointProcessor
 
interceptFrom() - Method in class org.apache.camel.builder.RouteBuilder
Adds a route for an interceptor that intercepts incoming messages on any inputs in this route
interceptFrom(String) - Method in class org.apache.camel.builder.RouteBuilder
Adds a route for an interceptor that intercepts incoming messages on the given endpoint.
interceptFrom() - Method in class org.apache.camel.model.RoutesDefinition
Creates and adds an interceptor that is triggered when an exchange is received as input to any routes (eg from all the from)
interceptFrom(String) - Method in class org.apache.camel.model.RoutesDefinition
Creates and adds an interceptor that is triggered when an exchange is received as input to the route defined with the given endpoint (eg from the from)
InterceptFromDefinition - Class in org.apache.camel.model
Represents an XML <interceptFrom/> element
InterceptFromDefinition() - Constructor for class org.apache.camel.model.InterceptFromDefinition
 
InterceptFromDefinition(String) - Constructor for class org.apache.camel.model.InterceptFromDefinition
 
interceptSendToEndpoint(String) - Method in class org.apache.camel.builder.RouteBuilder
Applies a route for an interceptor if an exchange is send to the given endpoint
InterceptSendToEndpoint - Class in org.apache.camel.impl
This is an endpoint when sending to it, is intercepted and is routed in a detour
InterceptSendToEndpoint(Endpoint, boolean) - Constructor for class org.apache.camel.impl.InterceptSendToEndpoint
Intercepts sending to the given endpoint
interceptSendToEndpoint(String) - Method in class org.apache.camel.model.RoutesDefinition
Creates and adds an interceptor that is triggered when an exchange is send to the given endpoint
InterceptSendToEndpointDefinition - Class in org.apache.camel.model
Represents an XML <interceptToEndpoint/> element
InterceptSendToEndpointDefinition() - Constructor for class org.apache.camel.model.InterceptSendToEndpointDefinition
 
InterceptSendToEndpointDefinition(String) - Constructor for class org.apache.camel.model.InterceptSendToEndpointDefinition
 
InterceptStrategy - Interface in org.apache.camel.spi
The purpose of this interface is to allow an implementation to wrap processors in a route with interceptors.
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
Introspects the given class
introspect(Class, Method) - Method in class org.apache.camel.component.bean.BeanInfo
Introspects the given method
IntrospectionSupport - Class in org.apache.camel.util
Helper for introspections of beans.
InvalidPayloadException - Exception in org.apache.camel
Is thrown if the payload from the exchange could not be retrieve because of being null, wrong class type etc.
InvalidPayloadException(Exchange, Class<?>) - Constructor for exception org.apache.camel.InvalidPayloadException
 
InvalidPayloadException(Exchange, Class<?>, Message) - Constructor for exception org.apache.camel.InvalidPayloadException
 
InvalidPayloadException(Exchange, Class<?>, Message, Throwable) - Constructor for exception org.apache.camel.InvalidPayloadException
 
InvalidPayloadRuntimeException - Exception in org.apache.camel
Runtime version of the InvalidPayloadException.
InvalidPayloadRuntimeException(Exchange, Class<?>) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
 
InvalidPayloadRuntimeException(Exchange, Class<?>, Message) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
 
InvalidPayloadRuntimeException(Exchange, Class<?>, Message, Throwable) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
 
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
 
InvertingPackageScanFilter - Class in org.apache.camel.impl.scan
Package scan filter for inverting the match result of a subfilter.
InvertingPackageScanFilter(PackageScanFilter) - Constructor for class org.apache.camel.impl.scan.InvertingPackageScanFilter
 
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
IO helper class.
isAbsolute(String) - Method in class org.apache.camel.component.file.FileEndpoint
 
isAbsolute(String) - Method in class org.apache.camel.component.file.GenericFile
 
isAbsolute() - Method in class org.apache.camel.component.file.GenericFile
 
isAbsolute(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
isAbstract() - Method in class org.apache.camel.impl.DefaultRouteNode
 
isAbstract() - Method in interface org.apache.camel.RouteNode
Whether this node is abstract (no real processor under the cover).
isActive() - Method in class org.apache.camel.processor.Throttler.TimeSlot
 
isAggregateDot() - Method in class org.apache.camel.impl.MainSupport
 
isAllowMultipleConsumers() - Method in class org.apache.camel.component.direct.DirectEndpoint
 
isAllowNullValues() - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
 
isApplicable(Class) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
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.GenericFileEndpoint
 
isAutoCreateComponents() - Method in class org.apache.camel.impl.DefaultCamelContext
 
isBatchConsumer() - Method in class org.apache.camel.processor.BatchProcessor
 
isCache() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
isCausedByRollbackExchangeException(Throwable) - Method in class org.apache.camel.impl.LoggingExceptionHandler
 
isCollection(Object) - Static method in class org.apache.camel.converter.ObjectConverter
 
isDaemon() - Method in class org.apache.camel.component.timer.TimerEndpoint
 
isDelete() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
isDone(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Strategy to determine if the exchange is done so we can continue
isEager() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
isEmpty(Object) - Static method in class org.apache.camel.util.ObjectHelper
Tests whether the value is null or an empty string.
isEnabled() - Method in class org.apache.camel.processor.interceptor.Delayer
 
isEnabled() - Method in class org.apache.camel.processor.interceptor.Tracer
 
isEqualTo(Expression, Expression) - 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
isErrorHandlerBuilderConfigued() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
Returns whether a specific error handler builder has been configured or not.
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
 
isFailOnNullBody() - Method in class org.apache.camel.builder.xml.XsltBuilder
 
isFailureHandled(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
 
isFastStop() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
isFault() - Method in class org.apache.camel.impl.DefaultMessage
 
isFault() - Method in interface org.apache.camel.Message
Returns true if this message represents a fault
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
 
isFlatten() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
isFull() - Method in class org.apache.camel.processor.Throttler.TimeSlot
 
isGreaterThan(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isGreaterThan(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isGreaterThanOrEqualTo(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isGreaterThanOrEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isGroupExchanges() - Method in class org.apache.camel.processor.BatchProcessor
 
isHandleFault() - Method in class org.apache.camel.impl.DefaultCamelContext
 
isHandleFault() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isHandleFault() - Method in class org.apache.camel.model.RouteDefinition
 
isHandleFault() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether tracing enabled
isIdempotent() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
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
isInProgress(GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileConsumer
Is the given file already in progress.
isInstanceOf(Expression, 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
isLenientProperties() - Method in interface org.apache.camel.Endpoint
Should all properties be known or does the endpoint allow unknown options?

lenient = false means that the endpoint should validate that all given options is known and configured properly.

isLenientProperties() - Method in class org.apache.camel.impl.DefaultEndpoint
 
isLenientProperties() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
isLessThan(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isLessThan(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isLessThanOrEqualTo(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isLessThanOrEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isLogStackTrace() - Method in class org.apache.camel.processor.interceptor.Tracer
 
isLogStackTrace() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isLowerCase() - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Gets the isLowercase property which is a boolean to determinte whether header names should be converted to lowercase before checking it the filter Set.
isMatched(GenericFile<T>, boolean) - Method in class org.apache.camel.component.file.GenericFileConsumer
Strategy to perform file matching based on endpoint configuration.
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(ProcessorDefinition) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
isMultiline() - Method in class org.apache.camel.component.log.LogFormatter
 
isMultiParameterArray() - Method in class org.apache.camel.component.bean.BeanEndpoint
 
isMultiParameterArray() - Method in class org.apache.camel.component.bean.BeanProcessor
 
isNoop() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
isNotEmpty(Object) - Static method in class org.apache.camel.util.ObjectHelper
Tests whether the value is not null or an empty string.
isNotEqualTo(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNotEqualTo(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
isNotNull(Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNotNull() - Method in class org.apache.camel.builder.ValueBuilder
 
isNull(Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
isNull() - Method in class org.apache.camel.builder.ValueBuilder
 
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
isOverridingMethod(Method, Method) - Static method in class org.apache.camel.util.ObjectHelper
Tests whether the target method overrides the source method.
isParallelProcessing() - Method in class org.apache.camel.model.MulticastDefinition
 
isParallelProcessing() - Method in class org.apache.camel.model.SplitDefinition
 
isParallelProcessing() - Method in class org.apache.camel.processor.MulticastProcessor
 
isRecursive() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
isReferenceParameter(String) - Static method in class org.apache.camel.util.EndpointHelper
Is the given parameter a reference parameter (starting with a # char)
isRegex() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isReturnTypeVoid() - Method in class org.apache.camel.component.bean.MethodInfo
 
isRollbackOnly() - Method in interface org.apache.camel.Exchange
Returns true if this exchange is marked for rollback
isRollbackOnly() - Method in class org.apache.camel.impl.DefaultExchange
 
isRouteAdded() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isRouteAdded() - Method in interface org.apache.camel.spi.RouteContext
Returns the isRouteAdded flag
isRunAllowed() - Method in class org.apache.camel.impl.ServiceSupport
Helper methods so the service knows if it should keep running.
isSecureTagContents() - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
isShowAll() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowBody() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowBody() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowBodyType() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowBodyType() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowBreadCrumb() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowCaughtException() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowException() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowException() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowExchangeId() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowExchangeId() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowExchangePattern() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowHeaders() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowHeaders() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowNode() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowOut() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowOutBody() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowOutBodyType() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowOutHeaders() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowProperties() - Method in class org.apache.camel.component.log.LogFormatter
 
isShowProperties() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowShortExchangeId() - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
isShowStackTrace() - Method in class org.apache.camel.component.log.LogFormatter
 
isSingleton() - Method in class org.apache.camel.component.browse.BrowseEndpoint
 
isSingleton() - Method in class org.apache.camel.component.direct.DirectEndpoint
 
isSingleton() - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
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 class org.apache.camel.impl.DefaultProducer
 
isSingleton() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
isSingleton() - Method in class org.apache.camel.impl.ProcessorEndpoint
 
IsSingleton - Interface in org.apache.camel
Used for defining if a given class is singleton or not.
isSingleton() - Method in interface org.apache.camel.IsSingleton
Wheter this class supports being singleton or not.
isSingleton() - Method in class org.apache.camel.language.bean.BeanLanguage
 
isSingleton() - Method in class org.apache.camel.language.constant.ConstantLanguage
 
isSingleton() - Method in class org.apache.camel.language.header.HeaderLanguage
 
isSingleton() - Method in class org.apache.camel.language.property.PropertyLanguage
 
isSingleton() - Method in class org.apache.camel.language.simple.FileLanguage
 
isSingleton() - Method in class org.apache.camel.language.simple.SimpleLanguage
 
isSingleton() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isSingleton() - Method in class org.apache.camel.language.xpath.XPathLanguage
 
isSingleton() - Method in class org.apache.camel.management.ManagedEndpoint
 
isStartable() - Method in class org.apache.camel.model.RouteDefinition
 
isStartable() - Method in enum org.apache.camel.ServiceStatus
 
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
 
isStoppable() - Method in class org.apache.camel.model.RouteDefinition
 
isStoppable() - Method in enum org.apache.camel.ServiceStatus
 
isStopped() - Method in class org.apache.camel.impl.ServiceSupport
 
isStopping() - Method in class org.apache.camel.impl.ServiceSupport
 
isStreamCache() - Method in class org.apache.camel.model.RouteDefinition
 
isStreamCaching() - Method in class org.apache.camel.impl.DefaultCamelContext
 
isStreamCaching() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isStreamCaching() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether stream cache is enabled
isStreaming() - Method in class org.apache.camel.model.MulticastDefinition
 
isStreaming() - Method in class org.apache.camel.model.SplitDefinition
The splitter should use streaming -- exchanges are being sent as the data for them becomes available.
isStreaming() - Method in class org.apache.camel.processor.MulticastProcessor
Is the multicast processor working in streaming mode? In streaming mode: we use Iterable to ensure we can send messages as soon as the data becomes available for parallel processing, we start aggregating responses as they get send back to the processor; this means the AggregationStrategy has to take care of handling out-of-order arrival of exchanges
isSystemProperty(String) - Static method in class org.apache.camel.util.SystemHelper
Looks up the given system property boolean value.
isTrace() - Method in class org.apache.camel.impl.MainSupport
 
isTrace() - Method in class org.apache.camel.model.RouteDefinition
 
isTraceExceptions() - Method in class org.apache.camel.processor.interceptor.Tracer
 
isTraceInterceptors() - Method in class org.apache.camel.processor.interceptor.Tracer
 
isTraceOutExchanges() - Method in class org.apache.camel.processor.interceptor.Tracer
 
isTracing() - Method in class org.apache.camel.impl.DefaultCamelContext
 
isTracing() - Method in class org.apache.camel.impl.DefaultRouteContext
 
isTracing() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether tracing enabled
isTransacted() - Method in interface org.apache.camel.Exchange
Returns true if this exchange is transacted
isTransacted() - Method in class org.apache.camel.impl.DefaultExchange
 
isUseCollisionAvoidance() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isUseDom() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
isUseExponentialBackOff() - Method in class org.apache.camel.processor.RedeliveryPolicy
 
isUseFixedDelay() - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
isUseJpa() - Method in class org.apache.camel.processor.interceptor.Tracer
 
isUseOriginalMessage() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
isValid() - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
isValidate() - Method in class org.apache.camel.model.dataformat.HL7DataFormat
 
isValidConverterMethod(Method) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
isValidFallbackConverterMethod(Method) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
isValidFile(GenericFile<T>, boolean) - Method in class org.apache.camel.component.file.GenericFileConsumer
Strategy for validating if the given remote file should be included or not
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
Validates wheter the given method is a valid candidate for Camel Bean Binding.
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.
isWebSphereClassLoader(ClassLoader) - Static method in class org.apache.camel.impl.WebSpherePacakageScanClassResolver
Is the classloader from IBM and thus the WebSphere platform?
iterator(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Creates an iterator over the value
iterator() - Method in interface org.apache.camel.processor.aggregate.AggregationCollection
Gets the iterator to iterate this collection.
iterator() - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
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 expressions 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
JAXB_CONTEXT_PACKAGES - Static variable in class org.apache.camel.model.Constants
 
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
 
JmxSystemPropertyKeys - Class in org.apache.camel.management
This module contains jmx related system property key constants.
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
 
json() - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format using the XStream json library
json(JsonLibrary) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format
json(JsonLibrary, Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Uses the JSON data format
JsonDataFormat - Class in org.apache.camel.model.dataformat
 
JsonDataFormat() - Constructor for class org.apache.camel.model.dataformat.JsonDataFormat
 
JsonDataFormat(JsonLibrary) - Constructor for class org.apache.camel.model.dataformat.JsonDataFormat
 
JsonLibrary - Enum in org.apache.camel.model.dataformat
Represents the concrete Json libraries Camel supports.
jxpath(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a JXPath expression
JXPathExpression - Class in org.apache.camel.model.language
For JXPath expressions and predicates
JXPathExpression() - Constructor for class org.apache.camel.model.language.JXPathExpression
 
JXPathExpression(String) - Constructor for class org.apache.camel.model.language.JXPathExpression
 

K

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_NODE_ID - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
KEY_ROUTE - 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_RESOLVER_RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultLanguageResolver
 
LANGUAGE_RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultLanguageResolver
 
LanguageAnnotation - Annotation Type in org.apache.camel.language
Base annotation for languages.
LanguageExpression - Annotation Type in org.apache.camel.language
Base annotation for language expressions.
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
 
languageFactory - Variable in class org.apache.camel.impl.DefaultLanguageResolver
 
languageResolver - Variable in class org.apache.camel.impl.DefaultLanguageResolver
 
LanguageResolver - Interface in org.apache.camel.spi
A pluggable strategy for resolving different languages in a loosely coupled manner
level(LoggingLevel) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
LifecycleStrategy - Interface in org.apache.camel.spi
Strategy for lifecycle notifications.
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
 
listFiles() - Method in class org.apache.camel.component.file.FileOperations
 
listFiles(String) - Method in class org.apache.camel.component.file.FileOperations
 
listFiles() - Method in interface org.apache.camel.component.file.GenericFileOperations
List the files in the current directory
listFiles(String) - Method in interface org.apache.camel.component.file.GenericFileOperations
List the files in the given remote directory
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(LoadBalancer) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses a custom load balancer
loadBalance() - Method in class org.apache.camel.model.ProcessorDefinition
Load Balancer EIP: Creates a loadbalance
loadBalance(LoadBalancer) - Method in class org.apache.camel.model.ProcessorDefinition
Load Balancer EIP: Creates a loadbalance
LoadBalanceDefinition - Class in org.apache.camel.model
Represents an XML <loadBalance/> element
LoadBalanceDefinition() - Constructor for class org.apache.camel.model.LoadBalanceDefinition
 
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
 
LoadBalancerDefinition - Class in org.apache.camel.model
Represents an XML <loadBalancer/> element
LoadBalancerDefinition() - Constructor for class org.apache.camel.model.LoadBalancerDefinition
 
LoadBalancerDefinition(LoadBalancer) - Constructor for class org.apache.camel.model.LoadBalancerDefinition
 
LoadBalancerDefinition(String) - Constructor for class org.apache.camel.model.LoadBalancerDefinition
 
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
 
loadClass(String, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
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
loadContent(Exchange, GenericFile<File>) - Method in class org.apache.camel.component.file.FileBinding
 
loadContent(Exchange, GenericFile<T>) - Method in interface org.apache.camel.component.file.GenericFileBinding
Loads the content from the file into memory
loadContent(Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileDefaultBinding
 
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
 
loadFallbackTypeConverters() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
loadResourceAsStream(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
loadResourceAsStream(String) - Method in interface org.apache.camel.spi.ClassResolver
Loads the given resource as a stream
loadResourceAsStream(String) - Static method in class org.apache.camel.util.ObjectHelper
Attempts to load the given resource as a stream using the thread context class loader or the class loader used to load this class
loadSchema() - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
loadStore() - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Loads the given file store into the 1st level cache
localWorkDirectory - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
log(Log) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the log used for caught exceptions
log(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the log used for caught exceptions
log(Class) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the log used for caught exceptions
log(Log) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
log - Variable in class org.apache.camel.component.file.GenericFileComponent
 
log - Variable in class org.apache.camel.component.file.GenericFileConsumer
 
log - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
log - Variable in class org.apache.camel.component.file.GenericFileProducer
 
log - Variable in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
 
log - Variable in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
log - Variable in class org.apache.camel.impl.DefaultPollingConsumerPollStrategy
 
log - Variable in class org.apache.camel.impl.DefaultServicePool
 
LOG - Static variable in class org.apache.camel.impl.MainSupport
 
log - Variable in class org.apache.camel.language.simple.SimpleLanguageSupport
 
log - Variable in class org.apache.camel.model.ProcessorDefinition
 
log - Variable in class org.apache.camel.processor.DelayProcessorSupport
 
log - Variable in class org.apache.camel.processor.ErrorHandlerSupport
 
log(String, LoggingLevel) - Method in class org.apache.camel.processor.Logger
 
log(String) - Method in class org.apache.camel.processor.Logger
 
log(String, Throwable, LoggingLevel) - Method in class org.apache.camel.processor.Logger
 
log(String, Throwable) - Method in class org.apache.camel.processor.Logger
 
LOG - Static variable in class org.apache.camel.processor.SendProcessor
 
log - Variable in class org.apache.camel.view.GraphGeneratorSupport
 
LOG_DEBUG_BODY_MAX_CHARS - Static variable in interface org.apache.camel.Exchange
 
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
 
LogEndpoint - Class in org.apache.camel.component.log
Log endpoint.
LogEndpoint() - Constructor for class org.apache.camel.component.log.LogEndpoint
 
LogEndpoint(String, Component) - Constructor for class org.apache.camel.component.log.LogEndpoint
 
LogEndpoint(String, Component, Logger) - Constructor for class org.apache.camel.component.log.LogEndpoint
 
logError(Exchange, Throwable) - Method in class org.apache.camel.processor.LoggingErrorHandler
 
logException(Exchange, Throwable) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
logExchange(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
LogFormatter - Class in org.apache.camel.component.log
Log formatter to format the logging output.
LogFormatter() - Constructor for class org.apache.camel.component.log.LogFormatter
 
loggedIn - Variable in class org.apache.camel.component.file.GenericFileConsumer
 
logger - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logger(Logger) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
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
 
Logger(Log, ExchangeFormatter) - Constructor for class org.apache.camel.processor.Logger
 
logger - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
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, will log at ERROR level by default.
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.DefaultErrorHandlerBuilder
Sets the logging level of exceptions caught
LoggingLevel - Enum in org.apache.camel
Used to configure the logging levels
logMessage(Exchange) - Method in class org.apache.camel.processor.Logger
 
logMessage(Exchange, String) - 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
 
logStackTrace(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
logStackTrace(boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets wheter stack traces should be logged, can be used to reduce verbose.
logStackTrace - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
logStackTrace(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
lookup(Class, Class) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
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.DefaultRouteContext
 
lookup(String, Class<T>) - Method in class org.apache.camel.impl.JndiRegistry
 
lookup(String) - Method in class org.apache.camel.impl.JndiRegistry
 
lookup(Class, Class) - Method in class org.apache.camel.impl.ReportingTypeConverterRegistry
 
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(String, Class<T>) - Method in interface org.apache.camel.spi.RouteContext
lookup an object by name and type
lookup(Class, Class) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Performs a lookup for a given type converter.
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
lookupByType(Class<T>) - Method in class org.apache.camel.impl.DefaultRouteContext
 
lookupByType(Class<T>) - Method in class org.apache.camel.impl.JndiRegistry
 
lookupByType(Class<T>) - Method in interface org.apache.camel.spi.Registry
Looks up services in the registry by their type.
lookupByType(Class<T>) - Method in interface org.apache.camel.spi.RouteContext
lookup objects by type
lookupEndpoint(String, Map) - Method in class org.apache.camel.component.ref.RefComponent
Looks up an endpoint for a given name.
lookupErrorHandlerBuilder(RouteContext) - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
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
loop() - Method in class org.apache.camel.model.ProcessorDefinition
Loop EIP: Creates a loop allowing to process the a message a number of times and possibly process them in a different way.
loop(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Loop EIP: Creates a loop allowing to process the a message a number of times and possibly process them in a different way.
loop(int) - Method in class org.apache.camel.model.ProcessorDefinition
Loop EIP: Creates a loop allowing to process the a message a number of times and possibly process them in a different way.
LOOP_INDEX - Static variable in interface org.apache.camel.Exchange
 
LOOP_SIZE - Static variable in interface org.apache.camel.Exchange
 
LoopDefinition - Class in org.apache.camel.model
Represents an XML <loop/> element
LoopDefinition() - Constructor for class org.apache.camel.model.LoopDefinition
 
LoopDefinition(Expression) - Constructor for class org.apache.camel.model.LoopDefinition
 
LoopDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.LoopDefinition
 
LoopProcessor - Class in org.apache.camel.processor
The processor which sends messages in a loop.
LoopProcessor(Expression, Processor) - Constructor for class org.apache.camel.processor.LoopProcessor
 
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

MainSupport - Class in org.apache.camel.impl
 
MainSupport() - Constructor for class org.apache.camel.impl.MainSupport
 
MainSupport.Option - Class in org.apache.camel.impl
 
MainSupport.Option(String, String, String) - Constructor for class org.apache.camel.impl.MainSupport.Option
 
MainSupport.ParameterOption - Class in org.apache.camel.impl
 
MainSupport.ParameterOption(String, String, String, String) - Constructor for class org.apache.camel.impl.MainSupport.ParameterOption
 
makeProcessor(RouteContext) - Method in class org.apache.camel.model.ProcessorDefinition
Creates the processor and wraps it in any necessary interceptors and error handlers
ManagedEndpoint - Class in org.apache.camel.management
 
ManagedEndpoint(Endpoint) - 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.converter.ArrayTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.ArrayTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.EnumTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.EnumTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.FutureTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.FutureTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.PropertyEditorTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.PropertyEditorTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.ToStringTypeConverter
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.ToStringTypeConverter
 
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(Class<T>, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type in the context of an exchange

Used when conversion requires extra information from the current exchange (such as encoding).

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 exception if not found.
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 or throws exception if not found.
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 IllegalArgumentException if not found.
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 or throws IllegalArgumentException if not found.
MAP - Static variable in enum org.apache.camel.ExchangePattern
 
MarkerFileExclusiveReadLockStrategy - Class in org.apache.camel.component.file.strategy
Acquires read lock to the given file using a marker file so other Camel consumers wont acquire the same file.
MarkerFileExclusiveReadLockStrategy() - Constructor for class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
 
marshal(Exchange) - Static method in class org.apache.camel.impl.DefaultExchangeHolder
Creates a payload object with the information from the given exchange.
marshal(Exchange, Object, OutputStream) - Method in class org.apache.camel.impl.GzipDataFormat
 
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.impl.ZipDataFormat
 
marshal() - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Marshals the in body using a DataFormat expression to define the format of the output which will be added to the out body.
marshal(DataFormatDefinition) - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: 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.ProcessorDefinition
DataFormat: 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.ProcessorDefinition
DataFormat: 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.
MarshalDefinition - Class in org.apache.camel.model
Marshals to a binary payload using the given DataFormatDefinition
MarshalDefinition() - Constructor for class org.apache.camel.model.MarshalDefinition
 
MarshalDefinition(DataFormatDefinition) - Constructor for class org.apache.camel.model.MarshalDefinition
 
MarshalDefinition(String) - Constructor for class org.apache.camel.model.MarshalDefinition
 
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
 
marshalRoutesUsingJaxb(String, List<RouteDefinition>) - Method in class org.apache.camel.view.ModelFileGenerator
Write the specified 'routeTypes' to 'fileName' as XML using JAXB.
matchContext(String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
Does the given context match this camel context
matchEndpoint(String, String) - Static method in class org.apache.camel.util.EndpointHelper
Matches the endpoint with the given pattern.
matches(Exchange) - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
matches(Exchange, Object, Object) - Method in class org.apache.camel.builder.BinaryPredicateSupport
 
matches(Expression) - Method in class org.apache.camel.builder.ValueBuilder
 
matches(Exchange) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
matches(Exchange) - Method in class org.apache.camel.impl.ExpressionSupport
 
matches(Class) - Method in class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
 
matches(Class) - Method in class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
 
matches(Class) - Method in class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
matches(Class) - Method in class org.apache.camel.impl.scan.CompositePackageScanFilter
 
matches(Class) - Method in class org.apache.camel.impl.scan.InvertingPackageScanFilter
 
matches(Class) - Method in class org.apache.camel.impl.scan.PatternBasedPackageScanFilter
Tests if a given class matches the patterns in this filter.
matches(Exchange) - Method in class org.apache.camel.language.bean.BeanExpression
 
matches(Exchange) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
matches(Exchange) - Method in interface org.apache.camel.Predicate
Evaluates the predicate on the message exchange and returns true if this exchange matches the predicate
matches(Class) - Method in interface org.apache.camel.spi.PackageScanFilter
Does the given class match
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
matchesWhen(Exchange) - Method in class org.apache.camel.processor.CatchProcessor
Strategy method for matching the exception type with the current exchange.
matchesWhen(OnExceptionDefinition, Exchange) - Method in class org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy
Strategy method for matching the exception type with the current exchange.
maximumRedeliveries(int) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
maximumRedeliveries(int) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the maximum redeliveries 5 = default value 0 = no redeliveries -1 = redeliver forever
maximumRedeliveries(int) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the maximum redeliveries 5 = default value 0 = no redeliveries -1 = redeliver forever
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
maximumRedeliveryDelay(long) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
maximumRedeliveryDelay(long) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the maximum delay between redelivery
maximumRedeliveryDelay(long) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the maximum delay between redelivery
maximumRedeliveryDelay - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
maximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum redelivery delay if using exponential back off.
maximumRequestsPerPeriod(Long) - Method in class org.apache.camel.model.ThrottleDefinition
Sets the time period during which the maximum request count per period
maxMessagesPerPoll - Variable in class org.apache.camel.component.file.GenericFileConsumer
 
maxMessagesPerPoll - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
MBEAN_DOMAIN - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
MemoryIdempotentRepository - Class in org.apache.camel.processor.idempotent
A memory based implementation of IdempotentRepository.
MemoryIdempotentRepository() - Constructor for class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
 
MemoryIdempotentRepository(Map<String, Object>) - Constructor for class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
 
memoryIdempotentRepository() - Static method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
Creates a new memory based repository using a LRUCache with a default of 1000 entries in the cache.
memoryIdempotentRepository(int) - Static method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
Creates a new memory based repository using a LRUCache.
memoryIdempotentRepository(Map<String, Object>) - Static method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
Creates a new memory based repository using the given Map to use to store the processed message ids.
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

See DefaultMessage for how headers is represented in Camel using a CaseInsensitiveMap.

message(Object, List<SAXParseException>, List<SAXParseException>, List<SAXParseException>) - Static method in exception org.apache.camel.processor.validation.SchemaValidationException
 
MessageHelper - Class in org.apache.camel.util
Some helper methods when working with Message.
messageIdExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an Expression for the inbound message id
messageIdRepository(IdempotentRepository) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets the the message id repository for the IdempotentConsumerType
messageIdRepositoryRef(String) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
Sets the reference name of the message id repository
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(Class) - 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(Class, String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an expression using the method(String) - Method in class org.apache.camel.model.BeanDefinition
Sets the calling method name of camel bean
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 expressions and predicates using the bean language
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
 
MethodCallExpression(Class) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodCallExpression(Class, String) - Constructor for class org.apache.camel.model.language.MethodCallExpression
 
MethodInfo - Class in org.apache.camel.component.bean
Information about a method to be used for invocation.
MethodInfo(CamelContext, Class, Method, List<ParameterInfo>, List<ParameterInfo>, boolean, boolean) - Constructor for class org.apache.camel.component.bean.MethodInfo
 
MethodInfoCache - Class in org.apache.camel.component.bean
Represents a cache of MethodInfo objects to avoid the expense of introspection for each invocation of a method via a proxy
MethodInfoCache(CamelContext) - Constructor for class org.apache.camel.component.bean.MethodInfoCache
 
MethodInfoCache(CamelContext, int, int) - Constructor for class org.apache.camel.component.bean.MethodInfoCache
 
MethodInfoCache(CamelContext, Map<Class, BeanInfo>, Map<Method, MethodInfo>) - Constructor for class org.apache.camel.component.bean.MethodInfoCache
 
MethodInvocation - Interface in org.apache.camel.component.bean
Information used by Camel to perform method invocation.
MethodNotFoundException - Exception in org.apache.camel.component.bean
 
MethodNotFoundException(Exchange, Object, String) - Constructor for exception org.apache.camel.component.bean.MethodNotFoundException
 
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
 
mkDir(File) - Static method in class org.apache.camel.util.FileUtil
 
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
 
MockEndpoint() - Constructor for class org.apache.camel.component.mock.MockEndpoint
 
ModelFileGenerator - Class in org.apache.camel.view
 
ModelFileGenerator(JAXBContext) - Constructor for class org.apache.camel.view.ModelFileGenerator
 
move - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
moveFailed - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
multicast() - Method in class org.apache.camel.model.ProcessorDefinition
Multicast EIP: 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.ProcessorDefinition
Multicast EIP: 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.ProcessorDefinition
Multicast EIP: 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_INDEX - Static variable in interface org.apache.camel.Exchange
 
MulticastDefinition - Class in org.apache.camel.model
Represents an XML <multicast/> element
MulticastDefinition() - Constructor for class org.apache.camel.model.MulticastDefinition
 
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, ExecutorService, boolean) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
mvel(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a MVEL expression
MvelExpression - Class in org.apache.camel.model.language
For MVEL expressions and predicates
MvelExpression() - Constructor for class org.apache.camel.model.language.MvelExpression
 
MvelExpression(String) - Constructor for class org.apache.camel.model.language.MvelExpression
 

N

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
 
navigate() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
Navigate<T> - Interface in org.apache.camel
Implementations support navigating a graph where you can traverse forward and each next returns a List of outputs of type T that can contain 0..n nodes.
navigate() - Method in interface org.apache.camel.Route
Returns a navigator to navigate this route by navigating all the Processors.
needToNormalize() - Method in class org.apache.camel.component.file.GenericFileConfiguration
 
newContext() - Method in class org.apache.camel.util.jndi.JndiContext
 
newFixedThreadPool(int, String, boolean) - Static method in class org.apache.camel.util.concurrent.ExecutorServiceHelper
 
newInstance() - Method in class org.apache.camel.component.file.GenericFileMessage
 
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(String) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
newInstance() - Method in class org.apache.camel.impl.DefaultMessage
 
newInstance(CamelContext, String) - Static method in class org.apache.camel.impl.DefaultProducerTemplate
 
newInstance() - Method in class org.apache.camel.impl.MessageSupport
Returns a new instance
newInstance(Class) - Static method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
newInstance(Class, WhenDefinition) - Static method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
newInstance(List<Processor>) - Static method in class org.apache.camel.processor.Pipeline
 
newInstance(String) - Method in interface org.apache.camel.spi.FactoryFinder
Creates a new class instance using the key to lookup
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(Class<T>, Object) - Method in interface org.apache.camel.spi.Injector
Instantiates a new instance of the given object 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(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.
newInstance(Class<T>) - Method in class org.apache.camel.util.ReflectionInjector
 
newInstance(Class<T>, Object) - Method in class org.apache.camel.util.ReflectionInjector
 
newInstances(String, Injector, Class<T>) - Method in class org.apache.camel.impl.DefaultFactoryFinder
 
newInstances(String, Injector, Class<T>) - Method in interface org.apache.camel.spi.FactoryFinder
Creates a new class instance using the key to lookup
newScheduledThreadPool(int, String, boolean) - Static method in class org.apache.camel.util.concurrent.ExecutorServiceHelper
 
newSingleThreadExecutor(String, boolean) - Static method in class org.apache.camel.util.concurrent.ExecutorServiceHelper
 
newStringFromBytes(byte[]) - Static method in class org.apache.camel.util.IOHelper
Use this function instead of new String(byte[]) to avoid surprises from non-standard default encodings.
newStringFromBytes(byte[], int, int) - Static method in class org.apache.camel.util.IOHelper
Use this function instead of new String(byte[], int, int) to avoid surprises from non-standard default encodings.
next() - Method in interface org.apache.camel.Channel
 
next() - Method in interface org.apache.camel.Navigate
Next group of outputs
next() - Method in class org.apache.camel.processor.BatchProcessor
 
next() - Method in class org.apache.camel.processor.ChoiceProcessor
 
next() - Method in class org.apache.camel.processor.CompositeProcessor
 
next() - Method in class org.apache.camel.processor.DefaultChannel
 
next() - Method in class org.apache.camel.processor.DelegateProcessor
 
next() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
next() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
next() - Method in class org.apache.camel.processor.MulticastProcessor
 
next() - Method in class org.apache.camel.processor.StreamResequencer
 
next() - Method in class org.apache.camel.processor.Throttler.TimeSlot
 
next() - Method in class org.apache.camel.processor.TryProcessor
 
nextSlot() - Method in class org.apache.camel.processor.Throttler
 
nextThreadCounter() - Static method in class org.apache.camel.util.concurrent.ExecutorServiceHelper
 
NIOConverter - Class in org.apache.camel.converter
Some core java.nio based Type Converters
nodeCounters - Static variable in class org.apache.camel.impl.DefaultNodeIdFactory
 
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
 
NodeIdFactory - Interface in org.apache.camel.spi
Factory to generate unique ids for model nodes.
noDelayer() - Method in class org.apache.camel.model.RouteDefinition
Disable delayer for this route.
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
Thrown if no factory resource is available for the given URI
NoFactoryAvailableException(String) - Constructor for exception org.apache.camel.NoFactoryAvailableException
 
NoFactoryAvailableException(String, Throwable) - Constructor for exception org.apache.camel.NoFactoryAvailableException
 
noHandleFault() - Method in class org.apache.camel.model.RouteDefinition
Disable handle fault for this route.
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
 
noop - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
NoPolicy - Class in org.apache.camel.impl
Represents an Policy which adds no interceptors.
NoPolicy() - Constructor for class org.apache.camel.impl.NoPolicy
 
normalizeClassName(String) - Static method in class org.apache.camel.util.ObjectHelper
Cleans the string to pure java identifier so we can use it for loading class names.
normalizePath(String) - Method in class org.apache.camel.component.file.GenericFile
 
normalizePath(String) - Method in class org.apache.camel.component.file.GenericFileProducer
 
normalizePath(String) - Static method in class org.apache.camel.util.FileUtil
Normalizes the path to cater for Windows and other platforms
normalizePathToProtocol(String) - Method in class org.apache.camel.component.file.GenericFile
Fixes the path separator to be according to the protocol
normalizeUri(String) - Static method in class org.apache.camel.util.URISupport
Normalizes the uri by reordering the parameters so they are sorted and thus we can use the uris for endpoint matching.
noSpecificLanguageFound(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
 
noStreamCaching() - Method in class org.apache.camel.model.RouteDefinition
Disable stream caching for this route.
noStreamCaching(List<InterceptStrategy>) - Static method in class org.apache.camel.processor.interceptor.StreamCaching
Remove the StreamCachingInterceptor 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
 
NoSuchBeanException(String, Throwable) - 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) - Static method in class org.apache.camel.builder.PredicateBuilder
A helper method to return the logical not of the given predicate
not(Predicate) - Method in class org.apache.camel.builder.ValueBuilder
 
notEmpty(String, String) - Static method in class org.apache.camel.util.ObjectHelper
Asserts whether the string is not empty.
notEmpty(String, String, Object) - Static method in class org.apache.camel.util.ObjectHelper
Asserts whether the string is not empty.
notNull(Object, String) - Static method in class org.apache.camel.util.ObjectHelper
Asserts whether the value is not null
notNull(Object, String, Object) - Static method in class org.apache.camel.util.ObjectHelper
Asserts whether the value is not null
noTracing() - Method in class org.apache.camel.model.RouteDefinition
Disable tracing for this route.
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
 
NoTypeConversionAvailableException(Object, Class, Throwable) - 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
ognl(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an OGNL expression
OgnlExpression - Class in org.apache.camel.model.language
For OGNL expressions and predicates
OgnlExpression() - Constructor for class org.apache.camel.model.language.OgnlExpression
 
OgnlExpression(String) - Constructor for class org.apache.camel.model.language.OgnlExpression
 
ON_COMPLETION - Static variable in interface org.apache.camel.Exchange
 
onAggregation(Object, Exchange) - Method in interface 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.DefaultAggregationCollection
 
onAggregation(Object, Exchange) - Method in class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 
onComplete(Exchange) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
 
onComplete(Exchange) - Method in class org.apache.camel.impl.SynchronizationAdapter
 
onComplete(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
onComplete(Exchange) - Method in interface org.apache.camel.spi.Synchronization
Called when the processing of the message exchange is complete
onCompletedMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
A strategy method to allow derived classes to overload the behavior of processing a completed message
onCompleteOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
Will only synchronize when the Exchange completed succesfully (no errors).
onCompletion() - Method in class org.apache.camel.builder.RouteBuilder
On completion callback for doing custom routing when the Exchange is complete.
onCompletion(Exchange) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
 
onCompletion() - Method in class org.apache.camel.model.ProcessorDefinition
Adds a onComplection Synchronization hook that invoke this route as a callback when the Exchange has finished being processed.
onCompletion() - Method in class org.apache.camel.model.RoutesDefinition
Adds an on completion
OnCompletionDefinition - Class in org.apache.camel.model
Represents an XML <onCompletion/> element
OnCompletionDefinition() - Constructor for class org.apache.camel.model.OnCompletionDefinition
 
OnCompletionProcessor - Class in org.apache.camel.processor
 
OnCompletionProcessor(Processor, boolean, boolean, Predicate) - Constructor for class org.apache.camel.processor.OnCompletionProcessor
 
onContextStart(CamelContext) - Method in class org.apache.camel.impl.DefaultLifecycleStrategy
 
onContextStart(CamelContext) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
onContextStart(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on starting a CamelContext.
onDone(Exchange) - Method in class org.apache.camel.impl.SynchronizationAdapter
 
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) - Method in class org.apache.camel.impl.DefaultLifecycleStrategy
 
onEndpointAdd(Endpoint) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
If the endpoint is an instance of ManagedResource then register it with the mbean server, if it is not then wrap the endpoint in a ManagedEndpoint and register that with the mbean server.
onEndpointAdd(Endpoint) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding an Endpoint.
onException(Class) - Method in class org.apache.camel.builder.RouteBuilder
Exception clause for catching certain exceptions and handling them.
onException(Class...) - Method in class org.apache.camel.builder.RouteBuilder
Exception clause for catching certain exceptions and handling them.
onException(Class) - Method in class org.apache.camel.model.OnExceptionDefinition
 
onException(Class) - Method in class org.apache.camel.model.ProcessorDefinition
Exception clause for cathing certain exceptions and handling them.
onException(Class) - Method in class org.apache.camel.model.RoutesDefinition
Adds an on exception
OnExceptionDefinition - Class in org.apache.camel.model
Represents an XML <onException/> element
OnExceptionDefinition() - Constructor for class org.apache.camel.model.OnExceptionDefinition
 
OnExceptionDefinition(List<Class>) - Constructor for class org.apache.camel.model.OnExceptionDefinition
 
OnExceptionDefinition(Class) - Constructor for class org.apache.camel.model.OnExceptionDefinition
 
onExchange(Exchange) - Method in class org.apache.camel.component.browse.BrowseEndpoint
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
 
onFailedMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
A strategy method to allow derived classes to overload the behavior of processing a failed message
onFailure(Exchange) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
 
onFailure(Exchange) - Method in class org.apache.camel.impl.SynchronizationAdapter
 
onFailure(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
onFailure(Exchange) - Method in interface org.apache.camel.spi.Synchronization
Called when the processing of the message exchange has failed for some reason.
onFailureOnly() - Method in class org.apache.camel.model.OnCompletionDefinition
Will only synchronize when the Exchange ended with failure (exception or FAULT message).
ONLY_REGISTER_PROCESSOR_WITH_CUSTOM_ID - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
onlyPath(String) - Static method in class org.apache.camel.util.FileUtil
Returns only the leading path (returns null if no path)
onNewPredicate(Predicate) - Method in class org.apache.camel.builder.ValueBuilder
A strategy method to allow derived classes to deal with the newly created predicate in different ways
onNewPredicate(Predicate) - Method in class org.apache.camel.component.mock.AssertionClause.PredicateValueBuilder
 
onRedelivery - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
onRedelivery(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets a processor that should be processed before a redelivey attempt.
onRedelivery(Processor) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets a processor that should be processed before a redelivey attempt.
onRouteContextCreate(RouteContext) - Method in class org.apache.camel.impl.DefaultLifecycleStrategy
 
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.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.management.InstrumentationLifecycleStrategy
 
onServiceAdd(CamelContext, Service) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding a Service.
onWhen(Predicate) - Method in class org.apache.camel.model.CatchDefinition
Sets an additional predicate that should be true before the onCatch is triggered.
onWhen() - Method in class org.apache.camel.model.CatchDefinition
Creates an expression to configure an additional predicate that should be true before the onCatch is triggered.
onWhen(Predicate) - Method in class org.apache.camel.model.OnCompletionDefinition
Sets an additional predicate that should be true before the onCompletion is triggered.
onWhen() - Method in class org.apache.camel.model.OnCompletionDefinition
Creates an expression to configure an additional predicate that should be true before the onCompletion is triggered.
onWhen(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets an additional predicate that should be true before the onException is triggered.
onWhen() - Method in class org.apache.camel.model.OnExceptionDefinition
Creates an expression to configure an additional predicate that should be true before the onException is triggered.
onWhen(Predicate) - Method in class org.apache.camel.model.TryDefinition
Sets an additional predicate that should be true before the onCatch is triggered.
onWhen() - Method in class org.apache.camel.model.TryDefinition
Creates an expression to configure an additional predicate that should be true before the onCatch is triggered.
operations - Variable in class org.apache.camel.component.file.GenericFileConsumer
 
operations - Variable in class org.apache.camel.component.file.GenericFileProducer
 
OptionalIdentifiedDefinition<T extends OptionalIdentifiedDefinition> - Class in org.apache.camel.model
Allows an element to have an optional ID specified
OptionalIdentifiedDefinition() - Constructor for class org.apache.camel.model.OptionalIdentifiedDefinition
 
or(Predicate, Predicate) - 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 JAXB POJOs for the XML Configuration of the routing rules.
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.browse - package org.apache.camel.component.browse
The Browse 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.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.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
The Ref Component for lookup of existing endpoints bound in the Registry.
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.impl.scan - package org.apache.camel.impl.scan
 
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.constant - package org.apache.camel.language.constant
Camel Constant language.
org.apache.camel.language.header - package org.apache.camel.language.header
Camel Header language.
org.apache.camel.language.property - package org.apache.camel.language.property
Camel Property language.
org.apache.camel.language.simple - package org.apache.camel.language.simple
Camel Simple language.
org.apache.camel.language.tokenizer - package org.apache.camel.language.tokenizer
 
org.apache.camel.language.xpath - package org.apache.camel.language.xpath
Camel XPath language support.
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.concurrent - package org.apache.camel.util.concurrent
Concurrent utility classes
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.ChoiceDefinition
Sets the otherwise node
OtherwiseDefinition - Class in org.apache.camel.model
Represents an XML <otherwise/> element
OtherwiseDefinition() - Constructor for class org.apache.camel.model.OtherwiseDefinition
 
OUT_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
outBatchSize(int) - Method in class org.apache.camel.model.AggregateDefinition
Sets the out batch size for number of exchanges sent
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
output - Variable in class org.apache.camel.model.InterceptDefinition
 
output - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
outputBytes() - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the output as being a byte[]
OutputDefinition<Type extends ProcessorDefinition> - Class in org.apache.camel.model
A useful base class for output types
OutputDefinition() - Constructor for class org.apache.camel.model.OutputDefinition
 
outputDOM() - Method in class org.apache.camel.builder.xml.XsltBuilder
Sets the output as being a DOM
outputRoutesToFile() - Method in class org.apache.camel.impl.MainSupport
 
outputs - Variable in class org.apache.camel.model.OutputDefinition
 
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

P

PackageHelper - Class in org.apache.camel.util
Some helper methods for working with Java packages and versioning.
PackageScanClassResolver - Interface in org.apache.camel.spi
A resolver that can find resources based on package scanning.
PackageScanDefinition - Class in org.apache.camel.model
PackageScanDefinition represents a <package-scan/> element.
PackageScanDefinition() - Constructor for class org.apache.camel.model.PackageScanDefinition
 
PackageScanFilter - Interface in org.apache.camel.spi
Filter that can be used with the PackageScanClassResolver resolver.
parallelProcessing() - Method in class org.apache.camel.model.MulticastDefinition
Uses the ExecutorService to do the multicasting work
parallelProcessing() - Method in class org.apache.camel.model.SplitDefinition
Doing the splitting work in parallel
parallelProcessing(boolean) - Method in class org.apache.camel.model.SplitDefinition
Set the splitting action's thread model
parameter(String, Object) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
ParameterInfo - Class in org.apache.camel.component.bean
Parameter information to be used for method invocation.
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 interface org.apache.camel.Route
 
parseArguments(String[]) - Method in class org.apache.camel.impl.MainSupport
Parses the command line arguments
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
 
PATTERN - Static variable in class org.apache.camel.language.simple.SimpleLanguageSupport
 
pattern(ExchangePattern) - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
Pattern - Annotation Type in org.apache.camel
Marks a method as having a specific kind of ExchangePattern for use with Bean Integration or Spring Remoting to overload the default value which is ExchangePattern.InOut for request/reply if no annotations are used.
pattern - Variable in class org.apache.camel.processor.SendProcessor
 
PatternBasedPackageScanFilter - Class in org.apache.camel.impl.scan
PatternBasedPackageScanFilter uses an underlying AntPathMatcher to filter scanned files according to include and exclude patterns.
PatternBasedPackageScanFilter() - Constructor for class org.apache.camel.impl.scan.PatternBasedPackageScanFilter
 
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 expressions 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.ProcessorDefinition
Pipes and Filters EIP: 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.ProcessorDefinition
Pipes and Filters EIP: 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.ProcessorDefinition
Pipes and Filters EIP: 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
 
PipelineDefinition - Class in org.apache.camel.model
Represents an XML <pipeline/> element which can be used to define an explicit pipeline; or to define a specific pipeline within a <multicast> block
PipelineDefinition() - Constructor for class org.apache.camel.model.PipelineDefinition
 
policy(Policy) - Method in class org.apache.camel.model.ProcessorDefinition
Apply a Policy.
policy(String) - Method in class org.apache.camel.model.ProcessorDefinition
Apply a Policy.
Policy - Interface in org.apache.camel.spi
A strategy capable of applying interceptors to a processor
PolicyDefinition - Class in org.apache.camel.model
Represents an XML <policy/> element
PolicyDefinition() - Constructor for class org.apache.camel.model.PolicyDefinition
 
PolicyDefinition(Policy) - Constructor for class org.apache.camel.model.PolicyDefinition
 
poll() - Method in class org.apache.camel.component.file.GenericFileConsumer
Poll for files
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
poll() - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
 
poll(long, TimeUnit) - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
 
pollDirectory(String, List<GenericFile<File>>) - Method in class org.apache.camel.component.file.FileConsumer
 
pollDirectory(String, List<GenericFile<T>>) - Method in class org.apache.camel.component.file.GenericFileConsumer
Polls the given directory for files to process
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.
pollEnrich(String) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, long, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
pollEnrich(String, long) - Method in class org.apache.camel.model.ProcessorDefinition
The Content Enricher EIP enriches an exchange with additional data obtained from a resourceUri using a PollingConsumer to poll the endpoint.
PollEnrichDefinition - Class in org.apache.camel.model
Represents an XML <pollEnrich/> element
PollEnrichDefinition() - Constructor for class org.apache.camel.model.PollEnrichDefinition
 
PollEnrichDefinition(AggregationStrategy, String, long) - Constructor for class org.apache.camel.model.PollEnrichDefinition
 
PollEnricher - Class in org.apache.camel.processor
A content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producer and second by aggregating input data and additional data.
PollEnricher(PollingConsumer) - Constructor for class org.apache.camel.processor.PollEnricher
Creates a new PollEnricher.
PollEnricher(AggregationStrategy, PollingConsumer, long) - Constructor for class org.apache.camel.processor.PollEnricher
Creates a new PollEnricher.
PollingConsumer - Interface in org.apache.camel
Represents a Polling Consumer where the caller polls for messages when it is ready.
PollingConsumerPollStrategy - Interface in org.apache.camel
Strategy for a PollingConsumer when polling an Endpoint.
PollingConsumerSupport - Class in org.apache.camel.impl
A useful base class for implementations of PollingConsumer
PollingConsumerSupport(Endpoint) - Constructor for class org.apache.camel.impl.PollingConsumerSupport
 
pool - Variable in class org.apache.camel.impl.DefaultServicePool
 
poolSize(int) - Method in class org.apache.camel.model.ThreadsDefinition
Setting the core pool size for the underlying ExecutorService.
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
populateHeaders(GenericFileMessage<T>) - Method in class org.apache.camel.component.file.GenericFile
Populates the GenericFileMessage relevant headers
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() - 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
postProcesCamelContext(CamelContext) - Method in class org.apache.camel.impl.MainSupport
 
postProcessContext() - Method in class org.apache.camel.impl.MainSupport
 
preChceckPoll(Exchange) - Method in class org.apache.camel.processor.PollEnricher
Strategy to pre check polling.
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) - 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 - 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, AggregationStrategy, Predicate) - Constructor for class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 
PredicateAssertHelper - Class in org.apache.camel.util
A helper for doing Predicate assertions.
PredicateBuilder - Class in org.apache.camel.builder
A helper class for working with predicates
preMove - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
prepareAggregation(Exchange, Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
Prepares the exchanges for aggregation.
prepareExchange(Exchange) - Method in class org.apache.camel.processor.OnCompletionProcessor
Prepares the Exchange to send as onCompletion.
prepareExchangeAfterFailure(Exchange, RedeliveryErrorHandler.RedeliveryData) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
prepareExchangeForFailover(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
Prepares the exchange for failover
prepareExchangeForRedelivery(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
prepend(Expression, Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
Prepends the String evaluations of the two expressions together
prepend(Object) - Method in class org.apache.camel.builder.ValueBuilder
Prepends the string evaluation of this expression with the given value
prePollCheck() - Method in class org.apache.camel.component.file.GenericFileConsumer
Override if required.
preWriteCheck() - Method in class org.apache.camel.component.file.GenericFileProducer
Perform any actions that need to occur before we write such as connecting to an FTP server etc.
printNode(PrintWriter, NodeData, ProcessorDefinition) - Method in class org.apache.camel.view.RouteDotGenerator
 
printNode(PrintWriter, NodeData) - Method in class org.apache.camel.view.RouteDotGenerator
 
printNode(PrintWriter, NodeData, ProcessorDefinition) - Method in class org.apache.camel.view.XmlGraphGenerator
 
printNode(PrintWriter, NodeData) - Method in class org.apache.camel.view.XmlGraphGenerator
 
printRoute(PrintWriter, RouteDefinition, FromDefinition) - Method in class org.apache.camel.view.RouteDotGenerator
 
printRoute(PrintWriter, RouteDefinition, NodeData) - Method in class org.apache.camel.view.XmlGraphGenerator
 
printRoutes(PrintWriter, Map<String, List<RouteDefinition>>) - Method in class org.apache.camel.view.RouteDotGenerator
 
printRoutes(PrintWriter, String, List<RouteDefinition>) - Method in class org.apache.camel.view.RouteDotGenerator
 
printRoutes(PrintWriter, Map<String, List<RouteDefinition>>) - Method in class org.apache.camel.view.XmlGraphGenerator
 
printRoutes(PrintWriter, String, List<RouteDefinition>) - Method in class org.apache.camel.view.XmlGraphGenerator
 
proceed() - Method in interface org.apache.camel.component.bean.MethodInvocation
 
proceed(Exchange) - Method in class org.apache.camel.processor.DelegateProcessor
Proceed with the underlying delegated processor
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) - Method in class org.apache.camel.component.file.GenericFileProducer
 
process(Exchange) - Method in class org.apache.camel.component.seda.CollectionProducer
 
process(Exchange) - Method in class org.apache.camel.component.seda.SedaProducer
 
process(Exchange) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
process(Exchange) - Method in class org.apache.camel.impl.ProducerTemplateProcessor
 
process(Exchange) - Method in class org.apache.camel.management.InstrumentationProcessor
 
process(Exchange) - Method in class org.apache.camel.model.LoadBalancerDefinition
 
process(Processor) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: 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.BatchProcessor
Enqueues an exchange for later batch processing.
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) - Method in class org.apache.camel.processor.DeadLetterChannel
 
process(Exchange) - Method in class org.apache.camel.processor.DefaultChannel
 
process(Exchange) - Method in class org.apache.camel.processor.DefaultErrorHandler
 
process(Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
process(Exchange) - Method in class org.apache.camel.processor.DelegateProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.Enricher
Enriches the input data (exchange) by first obtaining additional data from an endpoint represented by an endpoint producer and second by aggregating input data and additional data.
process(Exchange) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.FilterProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
process(Exchange) - Method in class org.apache.camel.processor.interceptor.HandleFaultInterceptor
 
process(Exchange) - Method in class org.apache.camel.processor.interceptor.StreamCachingInterceptor
 
process(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
process(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
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, Throwable) - Method in class org.apache.camel.processor.Logger
 
process(Exchange, String) - 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.LoopProcessor
 
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.OnCompletionProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.Pipeline
 
process(Exchange) - Method in class org.apache.camel.processor.PollEnricher
Enriches the input data (exchange) by first obtaining additional data from an endpoint represented by an endpoint producer and second by aggregating input data and additional data.
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.RedeliveryErrorHandler
 
process(Exchange) - Method in class org.apache.camel.processor.RollbackProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.RoutingSlip
 
process(Exchange) - Method in class org.apache.camel.processor.SendProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.SortProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.StopProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.StreamResequencer
 
process(Exchange) - Method in class org.apache.camel.processor.ThreadsProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.ThroughputLogger
 
process(Exchange) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
Set the exception 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) - Method in class org.apache.camel.processor.UnmarshalProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.WireTapProcessor
 
processBatch(Queue) - Method in interface org.apache.camel.BatchConsumer
Processes the list of Exchange in a batch.
processBatch(Queue) - Method in class org.apache.camel.component.file.GenericFileConsumer
 
ProcessDefinition - Class in org.apache.camel.model
Represents an XML <process/> element
ProcessDefinition() - Constructor for class org.apache.camel.model.ProcessDefinition
 
ProcessDefinition(Processor) - Constructor for class org.apache.camel.model.ProcessDefinition
 
processErrorHandler(Exchange, RedeliveryErrorHandler.RedeliveryData) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Processes the exchange decorated with this dead letter channel.
processExchange(Exchange) - Method in class org.apache.camel.component.file.GenericFileConsumer
Processes the exchange
processExchange(Exchange) - Method in class org.apache.camel.component.file.GenericFileProducer
Perform the work to process the fileExchange
processExchange(Exchange) - Method in class org.apache.camel.processor.BatchProcessor
Strategy Method to process an exchange in the batch.
processExchange(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Strategy to process the given exchange to the destinated output.
processFinally(Exchange) - Method in class org.apache.camel.processor.TryProcessor
 
processNext(Exchange) - Method in class org.apache.camel.processor.DelegateProcessor
 
processNext(Exchange) - Method in class org.apache.camel.processor.UnitOfWorkProcessor
 
processOption(String, LinkedList<String>) - Method in class org.apache.camel.impl.MainSupport.Option
 
Processor - Interface in org.apache.camel
A processor is used to implement the Event Driven Consumer and Message Translator patterns and to process message exchanges.
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
ProcessorDefinition<Type extends ProcessorDefinition> - Class in org.apache.camel.model
Base class for processor types that most XML types extend.
ProcessorDefinition() - Constructor for class org.apache.camel.model.ProcessorDefinition
 
ProcessorEndpoint - Class in org.apache.camel.impl
An endpoint which allows exchanges to be sent into it which just invokes a given Processor.
ProcessorEndpoint() - Constructor for class org.apache.camel.impl.ProcessorEndpoint
 
ProcessorEndpoint(String) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
 
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
 
ProcessorEndpoint(String, Component) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
 
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
 
processRef(String) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds the custom processor reference to this destination which could be a final destination, or could be a transformation in a pipeline
processStrategy - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
processStrategyCommit(GenericFileProcessStrategy<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
Strategy when the file was processed and a commit should be executed.
processStrategyRollback(GenericFileProcessStrategy<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
Strategy when the file was not processed and a rollback should be executed.
procesWireTap(Producer, Exchange) - Method in class org.apache.camel.processor.WireTapProcessor
Wiretaps the exchange.
Produce - Annotation Type in org.apache.camel
Marks a field or property as being a producer to an Endpoint either via its URI or via the name of the endpoint reference which is then resolved in a registry such as the Spring Application Context.
Producer - Interface in org.apache.camel
Provides a channel on which clients can create and invoke message exchanges on an Endpoint
ProducerCache - Class in org.apache.camel.impl
Cache containing created Producer.
ProducerCache(ServicePool<Endpoint, Producer>) - Constructor for class org.apache.camel.impl.ProducerCache
 
ProducerCache(ServicePool<Endpoint, Producer>, Map<String, Producer>) - Constructor for class org.apache.camel.impl.ProducerCache
 
producerCache - Variable in class org.apache.camel.processor.SendProcessor
 
ProducerCallback<T> - Interface in org.apache.camel
Callback for sending a exchange message to a endpoint using a producer.
ProducerTemplate - Interface in org.apache.camel
Template (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and sending Message instances in an Exchange to an Endpoint.
ProducerTemplateProcessor - Class in org.apache.camel.impl
A simple processor which just sends the message exchange to the default endpoint of the ProducerTemplate
ProducerTemplateProcessor(ProducerTemplate) - Constructor for class org.apache.camel.impl.ProducerTemplateProcessor
 
PROPAGATION_REQUIRED - Static variable in class org.apache.camel.model.TransactedDefinition
 
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
PropertiesDefinition - Class in org.apache.camel.model.config
Represents the XML type for a collection of DataFormats.
PropertiesDefinition() - Constructor for class org.apache.camel.model.config.PropertiesDefinition
 
propertiesExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the properties of exchange
property(String) - Static method in class org.apache.camel.builder.Builder
Returns a predicate and value builder for properties on an exchange
property(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns a value builder for the given property
property(String) - Method in class org.apache.camel.builder.ExpressionClause
An expression of an exchange property of the given name
property(String) - Method in class org.apache.camel.component.mock.AssertionClause
Returns a predicate and value builder for property on an exchange
property(String) - Static method in class org.apache.camel.language.property.PropertyLanguage
 
Property - Annotation Type in org.apache.camel
Marks a parameter as being an injection point of a property of an Exchange
PropertyDefinition - Class in org.apache.camel.model.config
 
PropertyDefinition() - Constructor for class org.apache.camel.model.config.PropertyDefinition
 
PropertyEditorTypeConverter - Class in org.apache.camel.impl.converter
Uses the 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 of exchange with the given name
PropertyExpression - Class in org.apache.camel.model.language
An expression which extracts the named exchange property
PropertyExpression() - Constructor for class org.apache.camel.model.language.PropertyExpression
 
PropertyExpression(String) - Constructor for class org.apache.camel.model.language.PropertyExpression
 
PropertyLanguage - Class in org.apache.camel.language.property
A language for property expressions.
PropertyLanguage() - Constructor for class org.apache.camel.language.property.PropertyLanguage
 
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
ProxyInstantiationException - Exception in org.apache.camel.impl
A proxy creation failed trying to create a proxy of a given type and on an given endpoint
ProxyInstantiationException(Class<?>, Endpoint, Throwable) - Constructor for exception org.apache.camel.impl.ProxyInstantiationException
 
purge() - Method in class org.apache.camel.util.DefaultTimeoutMap
 
purge() - Method in interface org.apache.camel.util.TimeoutMap
Purges any old entries from the map
put(String, Object) - Method in class org.apache.camel.util.CaseInsensitiveMap
 
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
putAll(Map<? extends String, ?>) - Method in class org.apache.camel.util.CaseInsensitiveMap
 
python(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Python expression
PythonExpression - Class in org.apache.camel.model.language
For Python expressions and predicates
PythonExpression() - Constructor for class org.apache.camel.model.language.PythonExpression
 
PythonExpression(String) - Constructor for class org.apache.camel.model.language.PythonExpression
 

Q

queue - Variable in class org.apache.camel.component.seda.CollectionProducer
 
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.LoadBalanceDefinition
Uses random load balancer
RandomLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements the random load balancing policy
RandomLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
RandomLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Represents an XML <random/> element
RandomLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.RandomLoadBalancerDefinition
 
randomNumberGenerator - Static variable in class org.apache.camel.processor.RedeliveryPolicy
 
RANGE_PATTERN - Static variable in class org.apache.camel.language.simple.SimpleLanguageSupport
 
read() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
 
ReaderCache - Class in org.apache.camel.converter.stream
StreamCache implementation for Cache the Reader Readers
ReaderCache(String) - Constructor for class org.apache.camel.converter.stream.ReaderCache
 
readExternal(ObjectInput) - Method in class org.apache.camel.component.bean.BeanInvocation
 
readExternal(ObjectInput) - Method in class org.apache.camel.converter.jaxp.StringSource
 
readLock - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
readLockTimeout - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
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(String) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receive(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receive(String, long) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receive(Endpoint, long) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receive(Endpoint) - Method in class org.apache.camel.impl.ConsumerCache
 
receive(Endpoint, long) - Method in class org.apache.camel.impl.ConsumerCache
 
receive(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receive(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receive(String, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receive(Endpoint, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
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
receiveBody(String) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receiveBody(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receiveBody(String, long) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receiveBody(Endpoint, long) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receiveBody(String, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receiveBody(Endpoint, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receiveBody(String, long, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receiveBody(Endpoint, long, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receiveBody(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(String, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(Endpoint, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(String, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(Endpoint, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(String, long, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBody(Endpoint, long, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBodyNoWait(String) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveBodyNoWait(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveBodyNoWait(String, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveBodyNoWait(Endpoint, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveBodyNoWait(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBodyNoWait(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBodyNoWait(String, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveBodyNoWait(Endpoint, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveNoWait(String) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveNoWait(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveNoWait(Endpoint) - Method in class org.apache.camel.impl.ConsumerCache
 
receiveNoWait(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
receiveNoWait(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
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.ProcessorDefinition
Recipient List EIP: Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
recipientList() - Method in class org.apache.camel.model.ProcessorDefinition
Recipient List EIP: Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
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() - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientList(Expression) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientList - Annotation Type in org.apache.camel
Indicates that this method is to be used as a Dynamic Recipient List routing the incoming message to one or more endpoints.
RecipientListDefinition - Class in org.apache.camel.model
Represents an XML <recipientList/> element
RecipientListDefinition() - Constructor for class org.apache.camel.model.RecipientListDefinition
 
RecipientListDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.RecipientListDefinition
 
RecipientListDefinition(Expression) - Constructor for class org.apache.camel.model.RecipientListDefinition
 
recordTime(Exchange, double) - Method in class org.apache.camel.management.InstrumentationProcessor
 
recursive - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
redeliverDelay(long) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
redeliverDelay(long) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the delay
redeliverDelay - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
redeliverDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the delay in milliseconds
REDELIVERED - Static variable in interface org.apache.camel.Exchange
 
REDELIVERY_COUNTER - Static variable in interface org.apache.camel.Exchange
 
redeliveryDelay(long) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the fixed delay between redeliveries
redeliveryDelay(long) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the fixed delay between redeliveries
RedeliveryErrorHandler - Class in org.apache.camel.processor
Base redeliverable error handler that also supports a final dead letter queue in case all redelivery attempts fail.
RedeliveryErrorHandler(Processor, Logger, Processor, RedeliveryPolicy, Predicate, Processor, String, boolean) - Constructor for class org.apache.camel.processor.RedeliveryErrorHandler
 
RedeliveryErrorHandler.RedeliveryData - Class in org.apache.camel.processor
 
RedeliveryErrorHandler.RedeliveryData() - Constructor for class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryData
 
redeliveryPolicy - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
redeliveryPolicy - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
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
 
RedeliveryPolicyDefinition - Class in org.apache.camel.model
Represents an XML <redeliveryPolicy/> element
RedeliveryPolicyDefinition() - Constructor for class org.apache.camel.model.RedeliveryPolicyDefinition
 
redeliveryProcessor - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
ref(String) - Method in class org.apache.camel.model.BeanDefinition
Sets the ref String on camel bean
ref - Variable in class org.apache.camel.model.PolicyDefinition
 
ref(String) - Method in class org.apache.camel.model.PolicyDefinition
Sets a reference to use for lookup the policy in the registry.
ref(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Use redelivery policy looked up in the registry
ref - Variable in class org.apache.camel.model.SendDefinition
 
ref - Variable in class org.apache.camel.model.TransactedDefinition
 
ref(String) - Method in class org.apache.camel.model.TransactedDefinition
Sets a reference to use for lookup the policy in the registry.
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.util
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.util.ReflectionInjector
 
regex(Expression, 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, 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, String, String) - Static method in class org.apache.camel.builder.Builder
Returns an expression that replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(Expression, String, Expression) - Static method in class org.apache.camel.builder.Builder
Returns an expression that replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(Expression, String, String) - Method in class org.apache.camel.builder.BuilderSupport
Returns an expression value builder that replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(Expression, String, Expression) - Method in class org.apache.camel.builder.BuilderSupport
Returns an expression value builder that replaces all occurrences of the regular expression with the given replacement
regexReplaceAll(Expression, 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, String, Expression) - 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 occurrences of the regular expression with the given replacement
regexReplaceAll(String, Expression) - Method in class org.apache.camel.builder.ValueBuilder
Replaces all occurrences of the regular expression with the given replacement
regexTokenize(String) - Method in class org.apache.camel.builder.ValueBuilder
Tokenizes the string conversion of this expression using the given regular expression
regexTokenizeExpression(Expression, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a tokenize expression which will tokenize the string with the given regex
register(Object, ObjectName) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
register(Object, ObjectName, boolean) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
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.
registerEndpoint(String, Endpoint) - Method in interface org.apache.camel.spi.EndpointStrategy
Register the endpoint.
registerFallbackTypeConverter(TypeConverterRegistry, TypeConverter) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
registerProcessor(ProcessorDefinition) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
Should the given processor be registered.
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.impl.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
REGISTRY_PORT - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
RegistryBean - Class in org.apache.camel.component.bean
An implementation of a BeanHolder which will look up a bean from the registry and act as a cache of its metadata
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
 
registryExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the Registry
release(Key, Service) - Method in class org.apache.camel.impl.DefaultServicePool
 
release(Key, Service) - Method in interface org.apache.camel.spi.ServicePool
Releases the service back to the pool
releaseExclusiveReadLock(GenericFileOperations<T>, GenericFile<T>, Exchange) - Method in interface org.apache.camel.component.file.GenericFileExclusiveReadLockStrategy
Releases the exclusive read lock granted by the acquireExclusiveReadLock method.
releaseExclusiveReadLock(GenericFileOperations<File>, GenericFile<File>, Exchange) - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
 
releaseExclusiveReadLock(GenericFileOperations<T>, GenericFile<T>, Exchange) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
 
releaseExclusiveReadLock(GenericFileOperations<File>, GenericFile<File>, Exchange) - Method in class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
 
remove(String) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
remove(String) - Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
 
remove(E) - Method in interface org.apache.camel.spi.IdempotentRepository
Removes the key from the repository.
remove(Object) - Method in class org.apache.camel.util.CaseInsensitiveMap
 
remove(Object) - Method in class org.apache.camel.util.DefaultTimeoutMap
 
remove(Object) - Method in interface org.apache.camel.util.TimeoutMap
Removes the object with the given key
removeAllOnCompletionDefinition(ProcessorDefinition) - Method in class org.apache.camel.model.OnCompletionDefinition
Removes all existing OnCompletionDefinition from the defintion.
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
 
removeDir(File) - Static method in class org.apache.camel.util.FileUtil
 
removeEldestEntry(Map.Entry) - Method in class org.apache.camel.util.LRUCache
 
removeEndpoints(String) - Method in interface org.apache.camel.CamelContext
Removes all endpoints with the given URI
removeEndpoints(String) - Method in class org.apache.camel.impl.DefaultCamelContext
 
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.ProcessorDefinition
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.ProcessorDefinition
Adds a processor which removes the header on the IN message
RemoveHeaderDefinition - Class in org.apache.camel.model
Represents an XML <removeHeader/> element
RemoveHeaderDefinition() - Constructor for class org.apache.camel.model.RemoveHeaderDefinition
 
RemoveHeaderDefinition(String) - Constructor for class org.apache.camel.model.RemoveHeaderDefinition
 
removeProcessor(Processor) - Method in class org.apache.camel.model.LoadBalancerDefinition
 
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.ProcessorDefinition
Adds a processor which removes the exchange property
removePropertyChangeListener(PropertyChangeListener) - Method in class org.apache.camel.component.browse.BrowseEndpoint
 
RemovePropertyDefinition - Class in org.apache.camel.model
Represents an XML <removeProperty/> element
RemovePropertyDefinition() - Constructor for class org.apache.camel.model.RemovePropertyDefinition
 
RemovePropertyDefinition(String) - Constructor for class org.apache.camel.model.RemovePropertyDefinition
 
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
 
removeRouteDefinition(String) - Method in class org.apache.camel.impl.DefaultCamelContext
Removes the route definition with the given key.
removeRouteDefinition(RouteDefinition) - Method in class org.apache.camel.impl.DefaultCamelContext
 
removeRouteDefinitions(Collection<RouteDefinition>) - Method in interface org.apache.camel.CamelContext
Removes a collection of route definitions from the context - stopping any previously running routes if any of them are actively running
removeRouteDefinitions(Collection<RouteDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
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(String, String) - Method in class org.apache.camel.component.file.FileOperations
 
renameFile(String, String) - Method in interface org.apache.camel.component.file.GenericFileOperations
Renames the file
renameFile(Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileExpressionRenamer
 
renameFile(Exchange, GenericFile<T>) - Method in interface org.apache.camel.component.file.strategy.GenericFileRenamer
Renames the given file
ReportingTypeConverterLoader - Class in org.apache.camel.impl
Type converter loader that is capable of reporting the loaded type converters.
ReportingTypeConverterLoader(PackageScanClassResolver) - Constructor for class org.apache.camel.impl.ReportingTypeConverterLoader
 
ReportingTypeConverterLoader.TypeMapping - Class in org.apache.camel.impl
Represents a mapping from one type (which can be null) to another Used by the camel-maven-plugin.
ReportingTypeConverterLoader.TypeMapping(Class, Class, Class, Method) - Constructor for class org.apache.camel.impl.ReportingTypeConverterLoader.TypeMapping
 
ReportingTypeConverterRegistry - Class in org.apache.camel.impl
Registry for reporting type converters.
ReportingTypeConverterRegistry() - Constructor for class org.apache.camel.impl.ReportingTypeConverterRegistry
 
request(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
request(String, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
request(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor Uses an ExchangePattern.InOut message exchange pattern.
request(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor Uses an ExchangePattern.InOut message exchange pattern.
requestBody(Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(Endpoint, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBody(Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint and returns the result content Uses an ExchangePattern.InOut message exchange pattern.
requestBody(Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint and returns the result content Uses an ExchangePattern.InOut message exchange pattern.
requestBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBody(Endpoint, Object, Class<T>) - 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.
requestBody(String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - 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.
requestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
requestBodyAndHeaders(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.
requestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values.
requestBodyAndHeaders(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.
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values.
resequence() - Method in class org.apache.camel.model.ProcessorDefinition
Resequencer EIP: Creates a resequencer allowing you to reorganize messages based on some comparator.
resequence(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Resequencer EIP: Creates a resequencer allowing you to reorganize messages based on some comparator.
resequence(List<Expression>) - Method in class org.apache.camel.model.ProcessorDefinition
Resequencer EIP: Creates a resequencer allowing you to reorganize messages based on some comparator.
ResequenceDefinition - Class in org.apache.camel.model
Represents an XML <resequence/> element
ResequenceDefinition() - Constructor for class org.apache.camel.model.ResequenceDefinition
 
ResequenceDefinition(List<Expression>) - Constructor for class org.apache.camel.model.ResequenceDefinition
 
resequencer(Expression...) - Method in class org.apache.camel.model.ProcessorDefinition
Resequencer EIP: Creates a splitter allowing you to reorganise messages based on some comparator.
Resequencer - Class in org.apache.camel.processor
An implementation of the Resequencer which can reorder messages within a batch.
Resequencer(Processor, Expression) - Constructor for class org.apache.camel.processor.Resequencer
 
Resequencer(Processor, List<Expression>) - Constructor for class org.apache.camel.processor.Resequencer
 
Resequencer(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.
reset() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
reset() - Method in class org.apache.camel.component.mock.MockEndpoint
 
reset() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
 
reset() - Method in class org.apache.camel.converter.stream.ReaderCache
 
reset() - Method in class org.apache.camel.converter.stream.SourceCache
 
reset() - Method in class org.apache.camel.converter.stream.StreamSourceCache
 
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
reset() - Method in interface org.apache.camel.StreamCache
Resets the StreamCache for a new stream consumption.
resetStreamCache(Message) - Static method in class org.apache.camel.util.MessageHelper
If the message body contains a StreamCache instance, reset the cache to enable reading from it again.
resolve(CamelContext, String) - Static method in class org.apache.camel.component.mock.MockEndpoint
A helper method to resolve the mock endpoint of the given URI on the given context
resolveClass(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveClass(String, Class<T>) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveClass(String, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveClass(String, Class<T>, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveClass(String) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveClass(String, Class<T>) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveClass(String, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveClass(String, Class<T>, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
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
resolveDefaultFactoryFinder(ClassResolver) - Method in class org.apache.camel.impl.DefaultFactoryFinderResolver
 
resolveDefaultFactoryFinder(ClassResolver) - Method in interface org.apache.camel.spi.FactoryFinderResolver
Creates a new default factory finder using a default resource path.
resolveEndpoint(String) - Method in class org.apache.camel.impl.DefaultRouteContext
 
resolveEndpoint(String, String) - Method in class org.apache.camel.impl.DefaultRouteContext
 
resolveEndpoint(RouteContext) - Method in class org.apache.camel.model.FromDefinition
 
resolveEndpoint(String) - Method in class org.apache.camel.model.RouteDefinition
 
resolveEndpoint(RouteContext) - Method in class org.apache.camel.model.SendDefinition
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.RecipientList
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.RoutingSlip
 
resolveEndpoint(String) - Method in interface org.apache.camel.spi.RouteContext
Resolves an endpoint from the URI
resolveEndpoint(String, String) - Method in interface org.apache.camel.spi.RouteContext
Resolves an endpoint from either a URI or a named reference
resolveEndpoint(Exchange, 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 cannot be resolved via URI
ResolveEndpointFailedException(String, Throwable) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
 
ResolveEndpointFailedException(String, String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
 
ResolveEndpointFailedException(String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
 
resolveFactoryFinder(ClassResolver, String) - Method in class org.apache.camel.impl.DefaultFactoryFinderResolver
 
resolveFactoryFinder(ClassResolver, String) - Method in interface org.apache.camel.spi.FactoryFinderResolver
Creates a new factory finder.
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
Resolves the given language.
resolveMandatoryClass(String) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveMandatoryClass(String, Class<T>) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveMandatoryClass(String, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveMandatoryClass(String, Class<T>, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
 
resolveMandatoryClass(String) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveMandatoryClass(String, Class<T>) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveMandatoryClass(String, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveMandatoryClass(String, Class<T>, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveMandatoryEndpoint(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
resolveMandatoryEndpoint(String) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
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.IdempotentConsumerDefinition
Strategy method to resolve the IdempotentRepository to use
resolvePolicy(RouteContext) - Method in class org.apache.camel.model.PolicyDefinition
 
resolvePolicy(RouteContext) - Method in class org.apache.camel.model.TransactedDefinition
 
resolver - Variable in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
resolveVariable(QName) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultComponentResolver
 
ResultHandler - Interface in org.apache.camel.builder.xml
A strategy for handling XSLT results
ResultHandlerFactory - Interface in org.apache.camel.builder.xml
Factory for ResultHandler
resultType(Class<?>) - Method in class org.apache.camel.builder.xml.XPathBuilder
Sets the expression result type to boolean
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the logging level to use when retries has exhausted
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the logging level to use when retries has exhausted
retriesExhaustedLogLevel - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries have been exhausted.
retrieveFile(String, Exchange) - Method in class org.apache.camel.component.file.FileOperations
 
retrieveFile(String, Exchange) - Method in interface org.apache.camel.component.file.GenericFileOperations
Retrieves the file
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the logging level to use for logging retry attempts
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Sets the logging level to use for logging retry attempts
retryAttemptedLogLevel - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
retryUntil(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the retry until predicate.
retryUntil(Expression) - Method in class org.apache.camel.model.OnExceptionDefinition
Sets the retry until expression.
rollback(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in interface org.apache.camel.component.file.GenericFileProcessStrategy
Releases any file locks and possibly deletes or moves the file after unsuccessful processing
rollback(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
 
rollback(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
rollback(Consumer, Endpoint, int, Exception) - Method in class org.apache.camel.impl.DefaultPollingConsumerPollStrategy
 
rollback() - Method in class org.apache.camel.model.ProcessorDefinition
Marks the exchange for rollback only.
rollback(String) - Method in class org.apache.camel.model.ProcessorDefinition
Marks the exchange for rollback only.
rollback(Consumer, Endpoint, int, Exception) - Method in interface org.apache.camel.PollingConsumerPollStrategy
Called when poll failed
ROLLBACK_ONLY - Static variable in interface org.apache.camel.Exchange
 
RollbackDefinition - Class in org.apache.camel.model
Represents an XML <rollback/> element
RollbackDefinition() - Constructor for class org.apache.camel.model.RollbackDefinition
 
RollbackDefinition(String) - Constructor for class org.apache.camel.model.RollbackDefinition
 
RollbackExchangeException - Exception in org.apache.camel
Exception used for forcing an Exchange to be rolled back.
RollbackExchangeException(Exchange) - Constructor for exception org.apache.camel.RollbackExchangeException
 
RollbackExchangeException(Exchange, Throwable) - Constructor for exception org.apache.camel.RollbackExchangeException
 
RollbackExchangeException(String, Exchange) - Constructor for exception org.apache.camel.RollbackExchangeException
 
RollbackExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.RollbackExchangeException
 
RollbackProcessor - Class in org.apache.camel.processor
Processor for marking an Exchange to rollback.
RollbackProcessor() - Constructor for class org.apache.camel.processor.RollbackProcessor
 
RollbackProcessor(String) - Constructor for class org.apache.camel.processor.RollbackProcessor
 
roundRobin() - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses round robin load balancer
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
 
RoundRobinLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Represents an XML <roundRobin/> element
RoundRobinLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.RoundRobinLoadBalancerDefinition
 
route() - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route
route(RouteDefinition) - Method in class org.apache.camel.model.RoutesDefinition
Creates a new route using the given route
Route - Interface in org.apache.camel
 
ROUTE_STOP - Static variable in interface org.apache.camel.Exchange
 
RouteBuilder - Class in org.apache.camel.builder
A Java DSL which is used to build DefaultRoute 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
 
RouteBuilderDefinition - Class in org.apache.camel.model
Represents an XML <routeBuilderRef/> element
RouteBuilderDefinition() - Constructor for class org.apache.camel.model.RouteBuilderDefinition
 
RouteBuilderDefinition(String) - Constructor for class org.apache.camel.model.RouteBuilderDefinition
 
RouteContainer - Interface in org.apache.camel.model
Container to hold Route.
RouteContext - Interface in org.apache.camel.spi
The context used to activate new routing rules
RouteDefinition - Class in org.apache.camel.model
Represents an XML <route/> element
RouteDefinition() - Constructor for class org.apache.camel.model.RouteDefinition
 
RouteDefinition(String) - Constructor for class org.apache.camel.model.RouteDefinition
 
RouteDefinition(Endpoint) - Constructor for class org.apache.camel.model.RouteDefinition
 
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
 
RouteNode - Interface in org.apache.camel
Represents a model of a node in the runtime route path.
RoutesBuilder - Interface in org.apache.camel
A routes builder is capable of building routes using the builder and model classes.
RoutesDefinition - Class in org.apache.camel.model
Represents a collection of routes
RoutesDefinition() - Constructor for class org.apache.camel.model.RoutesDefinition
 
RouteService - Class in org.apache.camel.impl
Represents the runtime objects for a given RouteDefinition so that it can be stopped independently of other routes
RouteService(DefaultCamelContext, RouteDefinition, List<RouteContext>, Collection<Route>) - Constructor for class org.apache.camel.impl.RouteService
 
routingSlip(String, String) - Method in class org.apache.camel.model.ProcessorDefinition
Routing Slip EIP: Creates a routing slip allowing you to route a message consecutively through a series of processing steps where the sequence of steps is not known at design time and can vary for each message.
routingSlip(String) - Method in class org.apache.camel.model.ProcessorDefinition
Routing Slip EIP: Creates a routing slip allowing you to route a message consecutively through a series of processing steps where the sequence of steps is not known at design time and can vary for each message.
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
 
RoutingSlipDefinition - Class in org.apache.camel.model
Represents an XML <routingSlip/> element
RoutingSlipDefinition() - Constructor for class org.apache.camel.model.RoutingSlipDefinition
 
RoutingSlipDefinition(String) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
 
RoutingSlipDefinition(String, String) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
 
rss() - Method in class org.apache.camel.builder.DataFormatClause
Uses the RSS data format
RssDataFormat - Class in org.apache.camel.model.dataformat
Represents a RSS DataFormat.
RssDataFormat() - Constructor for class org.apache.camel.model.dataformat.RssDataFormat
 
ruby(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates a Ruby expression
RubyExpression - Class in org.apache.camel.model.language
For Ruby expressions 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.MainSupport
Runs this process with the given arguments
run(String[]) - Method in class org.apache.camel.impl.MainSupport
Parses the command line arguments then runs the program
run() - Method in class org.apache.camel.impl.ScheduledPollConsumer
Invoked whenever we should be polled
run() - Method in class org.apache.camel.processor.resequencer.Timeout
Notifies the timeout handler 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
Exception thrown if invocation of bean failed.
RuntimeBeanExpressionException(Exchange, String, String, Throwable) - Constructor for exception org.apache.camel.language.bean.RuntimeBeanExpressionException
 
RuntimeCamelException - Exception in org.apache.camel
Base class for all Camel unchecked exceptions.
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
 
RuntimeConfiguration - Interface in org.apache.camel
Various runtime configuration used by CamelContext and RouteContext for cross cutting functions such as tracing, delayer, stream cache and the likes.
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(String, Exchange, Throwable) - 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 - Class in org.apache.camel.impl
A useful base class for any consumer which is polling based
ScheduledPollConsumer(DefaultEndpoint, Processor) - Constructor for class org.apache.camel.impl.ScheduledPollConsumer
 
ScheduledPollConsumer(Endpoint, Processor, ScheduledExecutorService) - Constructor for class org.apache.camel.impl.ScheduledPollConsumer
 
ScheduledPollEndpoint - 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
 
ScheduledPollEndpoint() - 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
 
secureXML() - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
secureXML(String, boolean, String, String) - Method in class org.apache.camel.builder.DataFormatClause
Uses the XML Security data format
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
A Consumer for the SEDA component.
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() - Constructor for class org.apache.camel.component.seda.SedaEndpoint
 
SedaEndpoint(String, Component, BlockingQueue<Exchange>) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
 
SedaEndpoint(String, Component, BlockingQueue<Exchange>, int) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
 
SedaEndpoint(String, BlockingQueue<Exchange>) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
 
SedaEndpoint(String, BlockingQueue<Exchange>, int) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
 
SedaProducer - Class in org.apache.camel.component.seda
 
SedaProducer(SedaEndpoint, BlockingQueue<Exchange>, WaitForTaskToComplete, long) - Constructor for class org.apache.camel.component.seda.SedaProducer
 
send(String, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(String, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(String, ExchangePattern, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, ExchangePattern, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
send(Endpoint, Exchange) - Method in class org.apache.camel.impl.ProducerCache
Sends the exchange to the given endpoint
send(Endpoint, Processor) - Method in class org.apache.camel.impl.ProducerCache
Sends an exchange to an endpoint using a supplied Processor to populate the exchange
send(Endpoint, ExchangePattern, Processor) - Method in class org.apache.camel.impl.ProducerCache
Sends an exchange to an endpoint using a supplied Processor to populate the exchange
send(Exchange) - 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 processor
send(String, Exchange) - 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 processor
send(String, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor
send(Endpoint, Exchange) - Method in interface org.apache.camel.ProducerTemplate
Sends the exchange to the given endpoint
send(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor
send(Endpoint, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor
sendBody(Endpoint, ExchangePattern, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(String, ExchangePattern, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBody(Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBody(Endpoint, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint with the given ExchangePattern returning any result output body

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBody(String, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeader(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
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

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

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

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

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

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

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

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

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

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(String, ExchangePattern, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(Endpoint, ExchangePattern, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
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

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

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

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

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

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeaders(String, ExchangePattern, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeaders(Endpoint, ExchangePattern, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
sendBodyAndProperty(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(String, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

SendDefinition<Type extends ProcessorDefinition> - Class in org.apache.camel.model
Base class for sending to an endpoint with an optional ExchangePattern
SendDefinition() - Constructor for class org.apache.camel.model.SendDefinition
 
SendDefinition(String) - Constructor for class org.apache.camel.model.SendDefinition
 
sendElement(E) - Method in interface org.apache.camel.processor.resequencer.SequenceSender
Sends the given element.
sendElement(Exchange) - Method in class org.apache.camel.processor.StreamResequencer
Sends the exchange to the next processor.
sendExchange(Endpoint, ExchangePattern, Processor, Exchange) - Method in class org.apache.camel.impl.ProducerCache
 
sendMessages(long, long) - Method in class org.apache.camel.component.dataset.DataSetConsumer
 
SendProcessor - Class in org.apache.camel.processor
Processor for forwarding exchanges to an endpoint destination.
SendProcessor(Endpoint) - Constructor for class org.apache.camel.processor.SendProcessor
 
SendProcessor(Endpoint, ExchangePattern) - Constructor for class org.apache.camel.processor.SendProcessor
 
sendTimerExchange() - Method in class org.apache.camel.component.timer.TimerConsumer
 
sendTo(String) - Static method in class org.apache.camel.builder.Builder
Returns an expression processing the exchange to the given endpoint uri.
sendTo(String) - Method in class org.apache.camel.builder.BuilderSupport
Returns an expression processing the exchange to the given endpoint uri
sendToRecipientList(Exchange, Object) - Method in class org.apache.camel.processor.RecipientList
Sends the given exchange to the recipient list
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<E> - Interface in org.apache.camel.processor.resequencer
An interface used by the ResequencerEngine.deliver() and ResequencerEngine.deliverNext() methods to send out re-ordered elements.
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
SERVICE_URL_PATH - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
ServiceHelper - Class in org.apache.camel.util
A collection of helper methods for working with Service objects
ServicePool<Key,Service> - Interface in org.apache.camel.spi
A service pool is like a connection pool but can pool any kind of objects.
ServicePoolAware - Interface in org.apache.camel
Marker interface to indicate this service can be pooled using a ServicePool.
ServiceStatus - Enum in org.apache.camel
Reresents the status of a Service instance
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.ValueHolder
 
setAbsolute(boolean) - Method in class org.apache.camel.component.file.GenericFile
 
setAbsoluteFilePath(String) - Method in class org.apache.camel.component.file.GenericFile
 
setAction(String) - Method in class org.apache.camel.processor.ThroughputLogger
 
setAgent(InstrumentationAgent) - Method in class org.apache.camel.management.InstrumentationLifecycleStrategy
 
setAggregateDot(boolean) - Method in class org.apache.camel.impl.MainSupport
 
setAggregationCollection(AggregationCollection) - Method in class org.apache.camel.model.AggregateDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.AggregateDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.MulticastDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.SplitDefinition
 
setAggregationStrategy(AggregationStrategy) - Method in interface org.apache.camel.processor.aggregate.AggregationCollection
Sets the aggregation strategy to be used
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.Enricher
Sets the aggregation strategy for this enricher.
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.PollEnricher
Sets the aggregation strategy for this poll enricher.
setAllowMultipleConsumers(boolean) - Method in class org.apache.camel.component.direct.DirectEndpoint
 
setAllowNullValues(boolean) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
 
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
setAutoCreate(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setAutoCreateComponents(boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setBackOffMultiplier(Double) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
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.ResequenceDefinition
 
setBatchConsumer(boolean) - Method in class org.apache.camel.processor.BatchProcessor
 
setBatchSize(Integer) - Method in class org.apache.camel.model.AggregateDefinition
 
setBatchSize(int) - Method in class org.apache.camel.model.config.BatchResequencerConfig
 
setBatchSize(int) - Method in class org.apache.camel.processor.BatchProcessor
Sets the in batch size.
setBatchSizeFromConsumer(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setBatchTimeout(Long) - Method in class org.apache.camel.model.AggregateDefinition
 
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.BeanDefinition
 
setBeanHolder(BeanHolder) - Method in class org.apache.camel.component.bean.BeanEndpoint
 
setBeanName(String) - Method in class org.apache.camel.component.bean.BeanEndpoint
 
setBeanType(Class) - Method in class org.apache.camel.model.BeanDefinition
 
setBeginRenamer(GenericFileRenamer<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
setBinding(GenericFileBinding<T>) - Method in class org.apache.camel.component.file.GenericFile
 
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(GenericFile<File>, Object) - Method in class org.apache.camel.component.file.FileBinding
 
setBody(Object) - Method in class org.apache.camel.component.file.GenericFile
 
setBody(GenericFile<T>, Object) - Method in interface org.apache.camel.component.file.GenericFileBinding
Sets the body from the given file
setBody(GenericFile<T>, Object) - Method in class org.apache.camel.component.file.GenericFileDefaultBinding
 
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.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the IN message
setBody(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the IN message
setBody(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
SetBodyDefinition - Class in org.apache.camel.model
Represents an XML <setBody/> element.
SetBodyDefinition() - Constructor for class org.apache.camel.model.SetBodyDefinition
 
SetBodyDefinition(Expression) - Constructor for class org.apache.camel.model.SetBodyDefinition
 
setBodyFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setBodyType(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setBreadCrumbLength(int) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setBufferSize(int) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setCache(boolean) - Method in class org.apache.camel.component.bean.BeanEndpoint
 
setCache(Map<String, Object>) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
setCache(Map<String, Object>) - Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
 
setCacheSize(int) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Sets the cache size
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
Sets the camel context.
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
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.impl.InterceptSendToEndpoint
 
setCamelContext(CamelContext) - Method in class org.apache.camel.model.RouteDefinition
 
setCamelContext(CamelContext) - Method in class org.apache.camel.model.RoutesDefinition
 
setCapacity(int) - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
setCapacity(int) - Method in class org.apache.camel.processor.StreamResequencer
 
setCausedByException(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setChannels(List<Channel>) - Method in class org.apache.camel.impl.DefaultRoute
 
setCharset(String) - Method in class org.apache.camel.model.ConvertBodyDefinition
 
setCharset(String) - Method in class org.apache.camel.model.dataformat.StringDataFormat
 
setClassLoaders(Set<ClassLoader>) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
 
setClassLoaders(Set<ClassLoader>) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Sets the ClassLoader instances that should be used when scanning for classes.
setClassResolver(ClassResolver) - Method in interface org.apache.camel.CamelContext
Sets the class resolver to be use
setClassResolver(ClassResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setCollectionRef(String) - Method in class org.apache.camel.model.AggregateDefinition
 
setCollisionAvoidanceFactor(Double) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setCollisionAvoidanceFactor(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the factor used for collision avoidance if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setCollisionAvoidancePercent(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the percentage used for collision avoidance if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setCommitRenamer(GenericFileRenamer<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
setComparator(ExpressionResultComparator) - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
setComparator(Comparator) - Method in class org.apache.camel.model.SortDefinition
 
setComparatorRef(String) - Method in class org.apache.camel.model.SortDefinition
 
setCompletionPredicate(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
 
setComponentResolver(ComponentResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setCompressionLevel(int) - Method in class org.apache.camel.model.dataformat.ZipDataFormat
 
setConcurrentConsumers(int) - Method in class org.apache.camel.component.seda.SedaEndpoint
 
setConfiguration(GenericFileConfiguration) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setConnectorPort(Integer) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
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
 
setCorrelationExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
 
setCorrelationExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
setCorrelationExpression(Expression) - Method in interface org.apache.camel.processor.aggregate.AggregationCollection
Sets the correlation expression to be used
setCorrelationExpression(Expression) - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
setCounter(PerformanceCounter) - Method in class org.apache.camel.management.InstrumentationProcessor
 
setCreateConnector(Boolean) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
setDaemon(boolean) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setDataFormat(DataFormat) - Method in class org.apache.camel.model.DataFormatDefinition
 
setDataFormatName(String) - Method in class org.apache.camel.model.DataFormatDefinition
 
setDataFormats(Map<String, DataFormatDefinition>) - Method in interface org.apache.camel.CamelContext
Sets the data formats that can be referenced in the routes.
setDataFormats(Map<String, DataFormatDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setDataFormats(List<DataFormatDefinition>) - Method in class org.apache.camel.model.dataformat.DataFormatsDefinition
 
setDataFormatType(DataFormatDefinition) - Method in class org.apache.camel.model.MarshalDefinition
 
setDataFormatType(DataFormatDefinition) - Method in class org.apache.camel.model.UnmarshalDefinition
 
setDataObjectType(Class<?>) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
setDataSet(DataSet) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
setDeadLetter(Endpoint) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setDeadLetterUri(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setDefaultAggregationStrategy() - Method in class org.apache.camel.processor.Enricher
Sets the default aggregation strategy for this enricher.
setDefaultAggregationStrategy() - Method in class org.apache.camel.processor.PollEnricher
Sets the default aggregation strategy for this poll enricher.
setDefaultBody(Object) - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
setDefaultEndpoint(Endpoint) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
setDefaultEndpointUri(String) - Method in class org.apache.camel.impl.DefaultProducerTemplate
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.processor.interceptor.Delayer
 
setDelayer(long) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setDelayer(long) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setDelayer(Long) - Method in class org.apache.camel.model.RouteDefinition
 
setDelayer(long) - Method in interface org.apache.camel.RuntimeConfiguration
Sets a delay value in millis that a message is delayed at every step it takes in the route path, to slow things down to better helps you to see what goes

Is disabled by default

setDelayPattern(String) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets an optional delay pattern to use insted of fixed delay.
setDelete(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setDelimiter(String) - Method in class org.apache.camel.model.RecipientListDefinition
 
setDescription(DescriptionDefinition) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
 
setDestination(Endpoint) - Method in class org.apache.camel.processor.interceptor.Tracer
See Tracer.setDestinationUri(String)
setDestinationUri(String) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets an optional destination to send the traced Exchange.
setDetour(Processor) - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
setDir(String) - Method in class org.apache.camel.view.GraphGeneratorSupport
Sets the destination directory in which to create the diagrams
setDirectory(String) - Method in class org.apache.camel.component.file.GenericFileConfiguration
 
setDisableRedelivery(Boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
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
 
setDotOutputDir(String) - Method in class org.apache.camel.impl.MainSupport
Sets the output directory of the generated DOT Files to show the visual representation of the routes.
setDuration(long) - Method in class org.apache.camel.impl.MainSupport
Sets the duration to run the application for in milliseconds until it should be terminated.
setEager(Boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setElementType(Class<?>) - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
setElementTypeName(String) - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
setEnabled(boolean) - Method in class org.apache.camel.processor.interceptor.Delayer
 
setEnabled(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
 
setEndpoint(GenericFileEndpoint) - Method in class org.apache.camel.component.file.FileOperations
 
setEndpoint(GenericFileEndpoint) - Method in interface org.apache.camel.component.file.GenericFileOperations
Sets the endpoint as some implementations need access to the endpoint and how its configured.
setEndpoint(Endpoint) - Method in class org.apache.camel.impl.DefaultRoute
 
setEndpoint(Endpoint) - Method in class org.apache.camel.model.FromDefinition
 
setEndpoint(Endpoint) - Method in class org.apache.camel.model.SendDefinition
 
setEndpoint(Endpoint) - Method in interface org.apache.camel.Route
Sets the inbound endpoint
setEndpointHeaderFilterStrategy(Endpoint) - Method in class org.apache.camel.impl.HeaderFilterStrategyComponent
 
setEndpointPath(String) - Method in class org.apache.camel.component.file.GenericFile
 
setEndpointUri(String) - Method in class org.apache.camel.impl.DefaultEndpoint
 
setEndpointUriIfNotSpecified(String) - Method in class org.apache.camel.impl.DefaultEndpoint
Sets the endpointUri if it has not been specified yet via some kind of dependency injection mechanism.
setErrorHandler(Processor) - Method in interface org.apache.camel.Channel
Sets the ErrorHandler this Channel uses.
setErrorHandler(Processor) - Method in class org.apache.camel.processor.DefaultChannel
 
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 interface org.apache.camel.CamelContext
Sets the default error handler builder which is inherited by the routes
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.impl.DefaultCamelContext
Sets the default error handler builder which is inherited by the routes
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.model.ProcessorDefinition
Sets the error handler to use with processors created by this builder
setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.model.RoutesDefinition
 
setErrorHandlerBuilderIfNull(ErrorHandlerBuilder) - Method in class org.apache.camel.model.ProcessorDefinition
Sets the error handler if one is not already set
setErrorHandlerRef(String) - Method in class org.apache.camel.model.ProcessorDefinition
Sets the bean ref name of the error handler builder to use on this route
setErrorHandlers(List<OnExceptionDefinition>) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Adds the error handlers for the given list of exception types
setErrorHandlers(List<OnExceptionDefinition>) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
setException(Exception) - Method in interface org.apache.camel.Exchange
Sets the exception associated with this exchange
setException(Exception) - Method in class org.apache.camel.impl.DefaultExchange
 
setException(Exception) - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
setExceptionClasses(List<Class>) - Method in class org.apache.camel.model.CatchDefinition
 
setExceptionClasses(List<Class>) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
 
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 OnExceptionDefinition to use for handling thrown exceptions.
setExceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setExceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Sets the exception policy strategy to use for resolving the OnExceptionDefinition to use for a given thrown exception
setExceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
 
setExceptions(List<String>) - Method in class org.apache.camel.model.CatchDefinition
 
setExceptions(List<String>) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
setExceptions(List<String>) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setExchange(Exchange) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
 
setExchange(Exchange) - Method in class org.apache.camel.impl.MessageSupport
 
setExchangeId(String) - Method in interface org.apache.camel.Exchange
Set the exchange id
setExchangeId(String) - Method in class org.apache.camel.impl.DefaultExchange
 
setExchangeId(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setExchangePattern(ExchangePattern) - Method in class org.apache.camel.impl.DefaultEndpoint
 
setExchangePattern(ExchangePattern) - Method in class org.apache.camel.model.ProcessorDefinition
ExchangePattern: set the ExchangePattern ExchangePattern into the exchange
setExchangePattern(ExchangePattern) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
setExchangePattern(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
SetExchangePatternDefinition - Class in org.apache.camel.model
Represents an XML <setExchangePattern/> element
SetExchangePatternDefinition() - Constructor for class org.apache.camel.model.SetExchangePatternDefinition
 
SetExchangePatternDefinition(ExchangePattern) - Constructor for class org.apache.camel.model.SetExchangePatternDefinition
 
setExclude(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setExcludes(String[]) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
 
setExcludes(String) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
Sets excludes using a single string where each element can be separated with comma
setExclusiveReadLockStrategy(GenericFileExclusiveReadLockStrategy) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setExclusiveReadLockStrategy(GenericFileExclusiveReadLockStrategy<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
 
setExecutor(ScheduledExecutorService) - Method in class org.apache.camel.util.DefaultTimeoutMap
Sets the executor used to schedule purge events of inactive requests
setExecutorService(ExecutorService) - Method in class org.apache.camel.impl.DefaultComponent
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.impl.DefaultEndpoint
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.impl.DefaultProducerTemplate
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.MulticastDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.SplitDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.model.ThreadsDefinition
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.processor.MulticastProcessor
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.processor.OnCompletionProcessor
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.processor.WireTapProcessor
 
setExecutorService(ExecutorService) - Method in interface org.apache.camel.ProducerTemplate
Sets the executor service to use for async messaging.
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(Expression) - Method in class org.apache.camel.component.file.strategy.GenericFileExpressionRenamer
 
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.AggregateDefinition
 
setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.ExpressionNode
 
setExpression(Expression) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
setExpression(String) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
setExpression(Expression) - Method in class org.apache.camel.model.LoopDefinition
 
setExpression(Expression) - Method in class org.apache.camel.model.SortDefinition
 
setExpression(Expression) - 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(ExpressionDefinition) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.model.language.ExpressionDefinition
Allows derived classes to set a lazily created expressionType instance such as if using the ExpressionClause
setExpressionValue(Expression) - Method in class org.apache.camel.model.language.ExpressionDefinition
 
setFactoryFinderResolver(FactoryFinderResolver) - Method in interface org.apache.camel.CamelContext
Sets the factory finder resolver to use.
setFactoryFinderResolver(FactoryFinderResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setFailOnNullBody(boolean) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
setFailureHandled(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
 
setFailureProcessor(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setFailureRenamer(GenericFileRenamer<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
 
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(boolean) - Method in class org.apache.camel.impl.DefaultMessage
 
setFault(boolean) - Method in interface org.apache.camel.Message
Sets the fault flag on this message
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.ProcessorDefinition
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.ProcessorDefinition
Adds a processor which sets the header on the FAULT message
setFile(File) - Method in class org.apache.camel.component.file.FileEndpoint
 
setFile(T) - Method in class org.apache.camel.component.file.GenericFile
 
setFileExist(GenericFileExist) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setFileLength(long) - Method in class org.apache.camel.component.file.GenericFile
 
setFileName(String) - Method in class org.apache.camel.component.file.GenericFile
 
setFileName(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setFileName(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
Sets the file expression based on FileLanguage
setFileNameOnly(String) - Method in class org.apache.camel.component.file.GenericFile
 
setFileStore(File) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
 
setFilter(GenericFileFilter<T>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setFixedRate(boolean) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setFlatten(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setFormat(String) - Method in class org.apache.camel.model.dataformat.ArtixDSDataFormat
 
setFormatter(TraceFormatter) - Method in class org.apache.camel.processor.interceptor.Tracer
 
setFormatter(ExchangeFormatter) - Method in class org.apache.camel.processor.Logger
 
setFromEndpoint(Endpoint) - Method in interface org.apache.camel.Exchange
Sets the endpoint which originated this message exchange.
setFromEndpoint(Endpoint) - Method in class org.apache.camel.impl.DefaultExchange
 
setFromEndpointUri(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setFunctionResolver(XPathFunctionResolver) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setGenericFile(GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileMessage
 
setGroup(String) - Method in class org.apache.camel.model.RouteDefinition
 
setGroupExchanges(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
 
setGroupExchanges(boolean) - Method in class org.apache.camel.processor.BatchProcessor
 
setGroupSize(int) - Method in class org.apache.camel.processor.ThroughputLogger
 
setHandled(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the handled using a boolean and thus easier to use for Spring XML configuration as well
setHandled(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setHandledPolicy(Predicate) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setHandledPolicy(Predicate) - Method in class org.apache.camel.model.CatchDefinition
 
setHandledPolicy(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setHandleFault(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setHandleFault(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setHandleFault(Boolean) - Method in class org.apache.camel.model.RouteDefinition
 
setHandleFault(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether handle fault is enabled or not (default is disabled).
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.ProcessorDefinition
Adds a processor which sets the header on the IN message
setHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the header on the IN message
SetHeaderDefinition - Class in org.apache.camel.model
Represents an XML <setHeader/> element
SetHeaderDefinition() - Constructor for class org.apache.camel.model.SetHeaderDefinition
 
SetHeaderDefinition(String, ExpressionDefinition) - Constructor for class org.apache.camel.model.SetHeaderDefinition
 
SetHeaderDefinition(String, Expression) - Constructor for class org.apache.camel.model.SetHeaderDefinition
 
SetHeaderDefinition(String, String) - Constructor for class org.apache.camel.model.SetHeaderDefinition
 
setHeaderFilterStrategy(HeaderFilterStrategy) - Method in class org.apache.camel.impl.HeaderFilterStrategyComponent
 
setHeaderFilterStrategy(HeaderFilterStrategy) - Method in interface org.apache.camel.spi.HeaderFilterStrategyAware
Sets the header filter strategy to use
setHeaderFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setHeaderName(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setHeaderName(String) - Method in class org.apache.camel.model.language.TokenizerExpression
 
setHeaderName(String) - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
setHeaderName(String) - Method in class org.apache.camel.model.RoutingSlipDefinition
 
setHeaderName(String) - Method in class org.apache.camel.model.SetHeaderDefinition
 
setHeaderName(String) - Method in class org.apache.camel.model.SetOutHeaderDefinition
 
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
setHeaders(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
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.ExpressionDefinition
Sets the value of the id property.
setId(String) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
Sets the value of the id property.
setIdempotent(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setIdempotentRepository(IdempotentRepository) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setIgnoreJAXBElement(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
setImagePrefix(String) - Method in class org.apache.camel.view.GraphGeneratorSupport
 
setIn(Message) - Method in interface org.apache.camel.Exchange
Sets the inbound message instance
setIn(Message) - Method in class org.apache.camel.impl.DefaultExchange
 
setInclude(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setIncludes(String[]) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
 
setIncludes(String) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
Sets includes using a single string where each element can be separated with comma
setInFilter(Set<String>) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Sets the "in" direction filter set.
setInFilterPattern(String) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Sets the "in" direction filter regular expression Pattern.
setInitialDelay(long) - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
setInjector(Injector) - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
setInjector(Injector) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setInjector(Injector) - Method in class org.apache.camel.impl.ReportingTypeConverterRegistry
 
setInjector(Injector) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Sets the injector to be used for creating new instances during type convertions.
setInProgressRepository(IdempotentRepository<String>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setInputFactory(XMLInputFactory) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
setInputs(List<FromDefinition>) - Method in class org.apache.camel.model.RouteDefinition
 
setInputStream(InputStream) - Method in class org.apache.camel.converter.stream.StreamSourceCache
 
setInputTransformer(Processor) - Method in class org.apache.camel.component.dataset.SimpleDataSet
 
setInterceptFroms(List<InterceptFromDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setInterceptorLogic(Processor) - Method in interface org.apache.camel.Intercept
 
setIntercepts(List<InterceptDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setInterceptSendTos(List<InterceptSendToEndpointDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setInterceptStrategies(List<InterceptStrategy>) - Method in interface org.apache.camel.spi.RouteContext
This method sets the InterceptStrategy instances on this route context.
setInteruptedExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
 
setIsRouteAdded(boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setIsRouteAdded(boolean) - Method in interface org.apache.camel.spi.RouteContext
If this flag is true, ProcessorDefinition.addRoutes(RouteContext, java.util.Collection) will not add processor to addEventDrivenProcessor to the RouteContext and it will prevent from adding an EventDrivenRoute.
setJndiContext(Context) - Method in class org.apache.camel.impl.DefaultCamelContext
Sets the registry to the given JNDI context
setKey(String) - Method in class org.apache.camel.model.config.PropertyDefinition
 
setLang(String) - Method in class org.apache.camel.model.DescriptionDefinition
 
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
 
setLastModified(long) - Method in class org.apache.camel.component.file.GenericFile
 
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
 
setLoadBalancerType(LoadBalancerDefinition) - Method in class org.apache.camel.model.LoadBalanceDefinition
 
setLocalWorkDirectory(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
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.DefaultErrorHandlerBuilder
 
setLogger(Logger) - Method in class org.apache.camel.component.log.LogEndpoint
 
setLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets the logging level to output tracing.
setLogName(String) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets the logging name to use.
setLogName(String) - Method in class org.apache.camel.processor.Logger
 
setLogStackTrace(Boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setLogStackTrace(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets whether thrown exception stacktrace should be traced, if disabled then only the exception message is logged
setLogStackTrace(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets wheter stack traces should be logged or not
setLowerCase(boolean) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Sets the isLowercase property which is a boolean to determinte whether header names should be converted to lowercase before checking it the filter Set.
setMaxChars(int) - Method in class org.apache.camel.component.log.LogFormatter
 
setMaxChars(int) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setMaxFileStoreSize(long) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Sets the maximum filesize for the file store in bytes.
setMaximumRedeliveries(Integer) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setMaximumRedeliveries(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered.
setMaximumRedeliveryDelay(Long) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setMaximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the maximum redelivery delay if using exponential back off.
setMaximumRequestsPerPeriod(Long) - Method in class org.apache.camel.model.ThrottleDefinition
 
setMaximumRequestsPerPeriod(long) - Method in class org.apache.camel.processor.Throttler
Sets the maximum number of requests per time period
setMaxMessagesPerPoll(int) - Method in interface org.apache.camel.BatchConsumer
Sets a maximum number of messages as a limit to poll at each polling.
setMaxMessagesPerPoll(int) - Method in class org.apache.camel.component.file.GenericFileConsumer
 
setMaxMessagesPerPoll(int) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setMBeanObjectDomainName(String) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
setMBeanServerDefaultDomain(String) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
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(IdempotentRepository) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setMessageIdRepositoryRef(String) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
setMethod(String) - Method in class org.apache.camel.component.bean.BeanEndpoint
 
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.BeanDefinition
 
setMethod(String) - Method in class org.apache.camel.model.language.MethodCallExpression
 
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
setMinimumResultWaitTime(long) - Method in class org.apache.camel.component.mock.MockEndpoint
Sets the minimum expected amount of time (in millis) the MockEndpoint.assertIsSatisfied() will wait on a latch until it is satisfied
setMinRate(int) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
setMove(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setMove(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
Sets the move expression based on FileLanguage
setMoveFailed(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
Sets the move failure expression based on FileLanguage
setMoveFailed(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setMultiline(boolean) - Method in class org.apache.camel.component.log.LogFormatter
If enabled then each information is outputted on a newline.
setMultiParameterArray(boolean) - Method in class org.apache.camel.component.bean.BeanEndpoint
 
setMultiParameterArray(boolean) - Method in class org.apache.camel.component.bean.BeanProcessor
 
setName(String) - Method in class org.apache.camel.component.bean.MethodBean
 
setName(String) - Method in class org.apache.camel.impl.DefaultCamelContext
Sets the name of the this context.
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.InstrumentationLifecycleStrategy
 
setNewExchangeExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.WireTapDefinition
 
setNewExchangeExpression(Expression) - Method in class org.apache.camel.model.WireTapDefinition
 
setNewExchangeExpression(Expression) - Method in class org.apache.camel.processor.WireTapProcessor
 
setNewExchangeProcessor(Processor) - Method in class org.apache.camel.model.WireTapDefinition
 
setNewExchangeProcessor(Processor) - Method in class org.apache.camel.processor.WireTapProcessor
 
setNewExchangeProcessorRef(String) - Method in class org.apache.camel.model.WireTapDefinition
 
setNextProcessor(Processor) - Method in interface org.apache.camel.Channel
Sets the processor that the channel should route the Exchange to.
setNextProcessor(Processor) - Method in class org.apache.camel.processor.DefaultChannel
 
setNodeFactory(NodeFactory) - Method in class org.apache.camel.model.ProcessorDefinition
 
setNodeIdFactory(NodeIdFactory) - Method in interface org.apache.camel.CamelContext
Uses a custom node id factory when generating auto assigned ids to the nodes in the route definitions
setNodeIdFactory(NodeIdFactory) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setNodeLength(int) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setNoop(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setNumberFormat(NumberFormat) - Method in class org.apache.camel.processor.ThroughputLogger
 
setNumberOfHashGroups(int) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
setOnCompleteOnly(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOnCompletions(List<OnCompletionDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setOnExceptions(List<OnExceptionDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setOnFailureOnly(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOnlyRegisterProcessorWithCustomId(Boolean) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
setOnRedelivery(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setOnRedelivery(Processor) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOnRedeliveryRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.CatchDefinition
 
setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOtherwise(OtherwiseDefinition) - Method in class org.apache.camel.model.ChoiceDefinition
 
setOut(Message) - Method in interface org.apache.camel.Exchange
Sets the outbound message
setOut(Message) - Method in class org.apache.camel.impl.DefaultExchange
 
setOutBatchSize(Integer) - Method in class org.apache.camel.model.AggregateDefinition
 
setOutBatchSize(int) - Method in class org.apache.camel.processor.BatchProcessor
Sets the out batch size.
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(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setOutBodyFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setOutBodyType(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setOutFilter(Set<String>) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Sets the "out" direction filter set.
setOutFilterPattern(String) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
Sets the "out" direction filter regular expression Pattern.
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.ProcessorDefinition
Adds a processor which sets the header on the OUT message
setOutHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the header on the OUT message
SetOutHeaderDefinition - Class in org.apache.camel.model
Represents an XML <setOutHeader/> element
SetOutHeaderDefinition() - Constructor for class org.apache.camel.model.SetOutHeaderDefinition
 
SetOutHeaderDefinition(String, ExpressionDefinition) - Constructor for class org.apache.camel.model.SetOutHeaderDefinition
 
SetOutHeaderDefinition(String, Expression) - Constructor for class org.apache.camel.model.SetOutHeaderDefinition
 
setOutHeaderFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
setOutHeaders(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setOutput(Processor) - Method in interface org.apache.camel.Channel
Sets the wrapped output that at runtime should be delegated to.
setOutput(Processor) - Method in class org.apache.camel.processor.DefaultChannel
 
setOutputFactory(XMLOutputFactory) - Method in class org.apache.camel.converter.jaxp.StaxConverter
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.AggregateDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.CatchDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.ExpressionNode
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.LoadBalanceDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.OnCompletionDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.OutputDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.ResequenceDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.RouteDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.ThrottleDefinition
 
setOutputs(List<ProcessorDefinition>) - Method in class org.apache.camel.model.TryDefinition
 
setOutputTransformer(Processor) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
setPackages(String[]) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
setPackageScanClassResolver(PackageScanClassResolver) - Method in interface org.apache.camel.CamelContext
Sets the package scanning class resolver to use
setPackageScanClassResolver(PackageScanClassResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setParallelProcessing(boolean) - Method in class org.apache.camel.model.MulticastDefinition
 
setParallelProcessing(boolean) - Method in class org.apache.camel.model.SplitDefinition
 
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(ProcessorDefinition<? extends ProcessorDefinition>) - Method in class org.apache.camel.model.ProcessorDefinition
 
setPassPhrase(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
setPattern(ExchangePattern) - Method in interface org.apache.camel.Exchange
Allows the ExchangePattern (MEP) of this exchange to be customized.
setPattern(ExchangePattern) - Method in class org.apache.camel.impl.DefaultExchange
 
setPattern(ExchangePattern) - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
setPattern(ExchangePattern) - Method in class org.apache.camel.model.ToDefinition
Sets the optional ExchangePattern used to invoke this endpoint
setPeriod(long) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setPollStrategy(PollingConsumerPollStrategy) - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
setPoolSize(Integer) - Method in class org.apache.camel.model.ThreadsDefinition
 
setPredicate(Predicate) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
 
setPreloadSize(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Sets how many messages should be preloaded (sent) before the route completes its initialization
setPreMove(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setPreMove(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
Sets the pre move expression based on FileLanguage
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
 
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.XMLBeansDataFormat
 
setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
 
setPreviousNode(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setProcessor(Processor) - Method in class org.apache.camel.impl.ProcessorEndpoint
 
setProcessor(Processor) - Method in class org.apache.camel.processor.DelegateProcessor
 
setProcessStrategy(GenericFileProcessStrategy<T>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setProduceDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
Allows a delay to be specified which causes producers to pause - to simulate slow producers
setProducerServicePool(ServicePool<Endpoint, Producer>) - Method in interface org.apache.camel.CamelContext
Sets a pluggable service pool to use for Producer pooling.
setProducerServicePool(ServicePool<Endpoint, Producer>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setProperties(Map<String, String>) - Method in interface org.apache.camel.CamelContext
Sets the properties that can be referenced in the camel context
setProperties(Map<String, String>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
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(List<PropertyDefinition>) - Method in class org.apache.camel.model.config.PropertiesDefinition
 
setProperties(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setProperties(CamelContext, Object, Map) - Static method in class org.apache.camel.util.EndpointHelper
Sets the regular properties on the given bean
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.DataFormatDefinition
Sets a named property on the data format instance using introspection
setProperty(Object, String, Object) - Method in class org.apache.camel.model.language.ExpressionDefinition
Sets a named property on the object instance using introspection
setProperty(Object, String, Object) - Method in class org.apache.camel.model.LoadBalancerDefinition
Sets a named property on the data format instance using introspection
setProperty(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Adds a processor which sets the exchange property
setProperty(String) - Method in class org.apache.camel.model.ProcessorDefinition
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
 
SetPropertyDefinition - Class in org.apache.camel.model
Represents an XML <setProperty/> element
SetPropertyDefinition() - Constructor for class org.apache.camel.model.SetPropertyDefinition
 
SetPropertyDefinition(String, ExpressionDefinition) - Constructor for class org.apache.camel.model.SetPropertyDefinition
 
SetPropertyDefinition(String, Expression) - Constructor for class org.apache.camel.model.SetPropertyDefinition
 
SetPropertyDefinition(String, String) - Constructor for class org.apache.camel.model.SetPropertyDefinition
 
setPropertyName(String) - Method in class org.apache.camel.model.RemovePropertyDefinition
 
setPropertyName(String) - Method in class org.apache.camel.model.SetPropertyDefinition
 
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.component.seda.SedaEndpoint
 
setReadLock(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setReadLockTimeout(long) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setRecursive(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setRedeliverDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the delay in milliseconds
setRedeliveryDelay(Long) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Sets the redelivery policy
setRedeliveryPolicy(RedeliveryPolicyDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setRef(String) - Method in class org.apache.camel.model.BeanDefinition
 
setRef(String) - Method in class org.apache.camel.model.FromDefinition
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.LoadBalanceDefinition
 
setRef(String) - Method in class org.apache.camel.model.MarshalDefinition
 
setRef(String) - Method in class org.apache.camel.model.PolicyDefinition
 
setRef(String) - Method in class org.apache.camel.model.ProcessDefinition
 
setRef(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setRef(String) - Method in class org.apache.camel.model.RouteBuilderDefinition
 
setRef(String) - Method in class org.apache.camel.model.SendDefinition
 
setRef(String) - Method in class org.apache.camel.model.TransactedDefinition
 
setRef(String) - Method in class org.apache.camel.model.UnmarshalDefinition
 
setReferenceProperties(CamelContext, Object, Map) - Static method in class org.apache.camel.util.EndpointHelper
Sets the reference properties on the given bean

This is convention over configuration, setting all reference parameters (using EndpointHelper.isReferenceParameter(String) by looking it up in registry and setting it on the bean if possible.

setRegex(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setRegex(boolean) - Method in class org.apache.camel.model.language.TokenizerExpression
 
setRegistry(Registry) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setRegistryPort(Integer) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
setRelativeFilePath(String) - Method in class org.apache.camel.component.file.GenericFile
 
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.dataset.DataSetEndpoint
Sets a custom progress reporter
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.language.xpath.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
setRetriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setRetriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries have been exhausted.
setRetryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setRetryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
setRetryUntil(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setRetryUntilPolicy(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setRouteBuilders(List<RouteBuilder>) - Method in class org.apache.camel.impl.MainSupport
 
setRouteCollection(RoutesDefinition) - Method in class org.apache.camel.builder.RouteBuilder
 
setRoutes(List<Route>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setRoutes(List<RouteDefinition>) - Method in interface org.apache.camel.model.RouteContainer
Sets the routes to use
setRoutes(List<RouteDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
 
setRoutesOutputFile(String) - Method in class org.apache.camel.impl.MainSupport
 
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
 
setSecureTag(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
setSecureTagContents(boolean) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
setSeparator(String) - Method in class org.apache.camel.util.CollectionStringBuffer
 
setSequenceSender(SequenceSender<E>) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Sets the sequence sender.
setServer(MBeanServer) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
setServices(List<Service>) - Method in class org.apache.camel.impl.DefaultRoute
 
setServices(List<Service>) - Method in interface org.apache.camel.Route
Sets the sources for this route
setServiceUrlPath(String) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
setShortExchangeId(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setShowAll(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowBody(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowBody(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowBodyType(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowBodyType(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowBreadCrumb(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowCaughtException(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowException(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowException(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowExchangeId(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowExchangeId(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowExchangePattern(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowHeaders(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowHeaders(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowNode(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowOut(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowOutBody(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowOutBodyType(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowOutHeaders(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowProperties(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setShowProperties(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowShortExchangeId(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
 
setShowStackTrace(boolean) - Method in class org.apache.camel.component.log.LogFormatter
 
setSize(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
 
setSize(int) - Method in class org.apache.camel.component.seda.SedaEndpoint
 
setSkipSendToOriginalEndpoint(Boolean) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
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
setSortBy(Comparator<Exchange>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setSortBy(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setSortBy(String, boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setSorter(Comparator<GenericFile<T>>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
 
setStrategyRef(String) - Method in class org.apache.camel.model.AggregateDefinition
 
setStreamCache(Boolean) - Method in class org.apache.camel.model.RouteDefinition
 
setStreamCaching(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setStreamCaching(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setStreamCaching(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether stream caching is enabled or not (default is disabled).
setStreamConfig(StreamResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
 
setStreaming(boolean) - Method in class org.apache.camel.model.MulticastDefinition
 
setStreaming(boolean) - Method in class org.apache.camel.model.SplitDefinition
 
setTemplate(Templates) - Method in class org.apache.camel.builder.xml.XsltBuilder
 
setTempPrefix(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
Enables and uses temporary prefix when writing files, after write it will be renamed to the correct name.
setText(String) - Method in class org.apache.camel.model.DescriptionDefinition
 
setTime(Date) - Method in class org.apache.camel.component.timer.TimerEndpoint
 
setTimeout(long) - Method in interface org.apache.camel.component.file.GenericFileExclusiveReadLockStrategy
Sets an optional timeout period.
setTimeout(long) - Method in class org.apache.camel.component.file.strategy.FileChangedExclusiveReadLockStrategy
Sets an optional timeout period.
setTimeout(long) - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
Sets an optional timeout period.
setTimeout(long) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
Sets an optional timeout period.
setTimeout(long) - Method in class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
 
setTimeout(long) - Method in class org.apache.camel.component.seda.SedaEndpoint
 
setTimeout(long) - Method in class org.apache.camel.model.config.StreamResequencerConfig
 
setTimeout(long) - Method in class org.apache.camel.processor.PollEnricher
Sets the timeout to use when polling.
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
 
setTimeoutHandler(TimeoutHandler) - Method in class org.apache.camel.processor.resequencer.Timeout
Sets a timeout handler for receiving timeout notifications.
setTimePeriodMillis(long) - Method in class org.apache.camel.model.ThrottleDefinition
 
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
 
setTimestamp(Date) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setTimeUnit(TimeUnit) - Method in class org.apache.camel.impl.MainSupport
Sets the time unit duration
setTimeUnit(TimeUnit) - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
setToken(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setToken(String) - Method in class org.apache.camel.model.language.TokenizerExpression
 
setToNode(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
setTrace(Boolean) - Method in class org.apache.camel.model.RouteDefinition
 
setTraceExceptions(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets whether thrown exceptions should be traced
setTraceFilter(Predicate) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets a predicate to be used as filter when tracing
setTraceInterceptors(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets whether interceptors should be traced or not
setTraceOutExchanges(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets whether exchanges coming out of processors should be traced
setTracing(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setTracing(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
 
setTracing(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether tracing is enabled or not (default is disabled).
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.management.InstrumentationProcessor
 
setType(String) - Method in class org.apache.camel.model.ConvertBodyDefinition
 
setType(BindyType) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
 
setType(String) - Method in class org.apache.camel.model.language.XQueryExpression
 
setType(Class<? extends Policy>) - Method in class org.apache.camel.model.PolicyDefinition
Sets a policy type that this defition should scope within.
setType(Class<? extends Policy>) - Method in class org.apache.camel.model.TransactedDefinition
Sets a policy type that this defition should scope within.
setTypeClass(Class) - Method in class org.apache.camel.model.ConvertBodyDefinition
 
setTypeConverter(TypeConverter) - Method in class org.apache.camel.impl.DefaultCamelContext
 
setTypeConverter(TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterAware
Injects the root type converter.
setTypeConverterRegistry(TypeConverterRegistry) - Method in class org.apache.camel.impl.DefaultCamelContext
 
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
 
setUnmarshalType(Class<?>) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
 
setUri(String) - Method in class org.apache.camel.model.FromDefinition
Sets the URI of the endpoint to use
setUri(String) - Method in class org.apache.camel.model.InterceptFromDefinition
 
setUri(String) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
setUri(String) - Method in class org.apache.camel.model.SendDefinition
 
setUriDelimiter(String) - Method in class org.apache.camel.model.RoutingSlipDefinition
 
setUseCollisionAvoidance(Boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setUseCollisionAvoidance(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables/disables collision avoidance which adds some randomization to the backoff timings to reduce contention probability
setUseDom(boolean) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
Sets whether DOMSource and DOMResult should be used, or SaxSource and SaxResult.
setUseExponentialBackOff(Boolean) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
setUseExponentialBackOff(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables/disables exponential backoff using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
setUseFixedDelay(boolean) - Method in class org.apache.camel.impl.ScheduledPollConsumer
 
setUseJpa(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
Sets whether we should use a JpaTraceEventMessage instead of an ordinary DefaultTraceEventMessage

Use this to allow persistence of trace events into a database using JPA.

setUseOriginalMessage(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
setUseOriginalMessagePolicy(Boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
 
setUsePlatformMBeanServer(Boolean) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
setValidate(Boolean) - Method in class org.apache.camel.model.dataformat.HL7DataFormat
 
setValue(String) - Method in class org.apache.camel.model.config.PropertyDefinition
 
setValue(Object) - Method in class org.apache.camel.util.TimeoutMapEntry
 
setWaitForTaskToComplete(WaitForTaskToComplete) - Method in class org.apache.camel.component.seda.SedaEndpoint
 
setWaitForTaskToComplete(WaitForTaskToComplete) - Method in class org.apache.camel.model.ThreadsDefinition
 
setWhenClauses(List<WhenDefinition>) - Method in class org.apache.camel.model.ChoiceDefinition
 
setXmlCipherAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
setXPathFactory(XPathFactory) - Method in class org.apache.camel.builder.xml.XPathBuilder
 
shape - Variable in class org.apache.camel.view.NodeData
 
shouldFailOver(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
Should the given failed Exchange failover?
shouldHandleException(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
Strategy whether the exchange has an exception that we should try to handle.
shouldLogException(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
Returns true if the given exchange should be logged when an exception was thrown
shouldLogExchange(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
Returns true if the given exchange should be logged in the trace list
shouldLogNode(ProcessorDefinition) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
Returns true if the given node should be logged in the trace list
shouldRedeliver(Exchange, int, Predicate) - 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?
shouldTraceOutExchanges() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
Returns whether exchanges coming out of processors should be traced
showOptions() - Method in class org.apache.camel.impl.MainSupport
Displays the command line options
showOptionsHeader() - Method in class org.apache.camel.impl.MainSupport
Displays the header message for the command line options
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(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
 
simpleExpression(String) - Static method in class org.apache.camel.builder.FileExpressionBuilder
 
SimpleExpression - Class in org.apache.camel.model.language
For expressions 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
 
SimpleLangaugeOperator - Enum in org.apache.camel.language.simple
Operators supported by simple language == : equlas > : greather than >= : greather than or equals < : less than <= : less than or equals != : not contains : tested for if it contains the value not contains : tested for if it does not contain the value regex : matching a regular expression not regex : not matching a regular expression in : tested for in a list of values separated by comma not in : tested for not in a list of values separated by comma is : tested for if type is an instanceof the given type not is: tested for not if type is an instanceof the given type range : tested for if it is within the provided range not range : tested for not if it is within the provided range and : and operator to combine two groups of expressions or : or operator to combine two groups of expressions

The and and or operator is special as they are used as optional operator to combine two expressions.

SimpleLanguage - Class in org.apache.camel.language.simple
A simple language which maps simple property style notations to access headers and bodies.
SimpleLanguage() - Constructor for class org.apache.camel.language.simple.SimpleLanguage
 
SimpleLanguageSupport - Class in org.apache.camel.language.simple
Abstract base class for Simple languages.
SimpleLanguageSupport() - Constructor for class org.apache.camel.language.simple.SimpleLanguageSupport
 
simpleName(Class) - Static method in class org.apache.camel.util.IntrospectionSupport
 
size() - Method in class org.apache.camel.impl.DefaultProducerServicePool
 
size(int) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the in batch size for number of exchanges received
size() - Method in interface org.apache.camel.processor.aggregate.AggregationCollection
Gets the size of this collection
size() - Method in class org.apache.camel.processor.aggregate.DefaultAggregationCollection
 
size() - Method in class org.apache.camel.processor.aggregate.PredicateAggregationCollection
 
size() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the number of elements currently maintained by this resequencer.
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
Returns the size of the map
skipSendToOriginalEndpoint() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
Skip sending the Exchange to the original intended endpoint
sleep(long) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
sleep(long, int) - Method in class org.apache.camel.processor.RedeliveryPolicy
Calculates the new redelivery delay based on the last one then sleeps for the necessary amount of time
sort(Comparator) - Method in class org.apache.camel.builder.ValueBuilder
Sorts the current value using the given comparator.
sort(Expression, Comparator) - Method in class org.apache.camel.model.ProcessorDefinition
Sorts the expression using the given comparator
sort(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Sorts the expression using a default sorting based on toString representation.
sortBody(Comparator) - Method in class org.apache.camel.model.ProcessorDefinition
Sorts the IN message body using the given comparator.
sortBody() - Method in class org.apache.camel.model.ProcessorDefinition
Sorts the IN message body using a default sorting based on toString representation.
sortBy - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
sortByFileLanguage(CamelContext, String, boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
Returns a new sory by file language expression
sortByFileLanguage(CamelContext, String, boolean, boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
Returns a new sory by file language expression
sortByFileLanguage(CamelContext, String, boolean, boolean, Comparator<Exchange>) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
Returns a new sort by file language expression
sortByLastModified(boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
Returns a new sort by last modified (newest first)
sortByName(boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
Returns a new sort by name
sortByPathName(boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
Returns a new sort by path name
sortBySize(boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
Returns a new sort by file size (smallest first)
SortDefinition - Class in org.apache.camel.model
Represents an XML <sort/> element
SortDefinition() - Constructor for class org.apache.camel.model.SortDefinition
 
SortDefinition(Expression) - Constructor for class org.apache.camel.model.SortDefinition
 
SortDefinition(Expression, Comparator) - Constructor for class org.apache.camel.model.SortDefinition
 
sorter - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
sortExpression(Expression, Comparator) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a sort expression which will sort the expression with the given comparator.
SortProcessor - Class in org.apache.camel.processor
A processor that sorts the expression using a comparator
SortProcessor(Expression, Comparator) - Constructor for class org.apache.camel.processor.SortProcessor
 
SourceCache - Class in org.apache.camel.converter.stream
StreamCache implementation for StringSources
SourceCache() - Constructor for class org.apache.camel.converter.stream.SourceCache
 
SourceCache(String) - Constructor for class org.apache.camel.converter.stream.SourceCache
 
split() - Method in class org.apache.camel.model.ProcessorDefinition
Splitter EIP: Creates a splitter allowing you split a message into a number of pieces and process them individually.
split(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Splitter EIP: Creates a splitter allowing you split a message into a number of pieces and process them individually.
split(Expression, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
Splitter EIP: Creates a splitter allowing you split a message into a number of pieces and process them individually.
SPLIT_INDEX - Static variable in interface org.apache.camel.Exchange
 
SPLIT_SIZE - Static variable in interface org.apache.camel.Exchange
 
SplitDefinition - Class in org.apache.camel.model
Represents an XML <split/> element
SplitDefinition() - Constructor for class org.apache.camel.model.SplitDefinition
 
SplitDefinition(Expression) - Constructor for class org.apache.camel.model.SplitDefinition
 
SplitDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.SplitDefinition
 
splitOnCharacter(String, String, int) - Static method in class org.apache.camel.util.ObjectHelper
 
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, ExecutorService, boolean) - Constructor for class org.apache.camel.processor.Splitter
 
sql(String) - Method in class org.apache.camel.builder.ExpressionClause
Evaluates an SQL expression
SqlExpression - Class in org.apache.camel.model.language
For SQL expressions and predicates
SqlExpression() - Constructor for class org.apache.camel.model.language.SqlExpression
 
SqlExpression(String) - Constructor for class org.apache.camel.model.language.SqlExpression
 
start() - Method in class org.apache.camel.component.browse.BrowseEndpoint
 
start() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
start() - Method in class org.apache.camel.component.direct.DirectConsumer
 
start() - Method in class org.apache.camel.impl.DefaultCamelContext
 
start() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
start() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
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.resequencer.ResequencerEngine
 
start() - Method in interface org.apache.camel.Service
Starts the service
startChildService(Service) - Method in class org.apache.camel.impl.RouteService
 
startRoute(RouteDefinition) - Method in interface org.apache.camel.CamelContext
Starts the given route if it has been previously stopped
startRoute(RouteDefinition) - Method in class org.apache.camel.impl.DefaultCamelContext
 
startRouteDefinitions(Collection<RouteDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
 
startRouteService(RouteService) - Method in class org.apache.camel.impl.DefaultCamelContext
Starts the given route service
startService(Service) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
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
startsWith(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
 
startsWith(Object) - Method in class org.apache.camel.builder.ValueBuilder
 
StaticMethodFallbackTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter implementation which invokes a static method as a fallback type converter from a type to another type
StaticMethodFallbackTypeConverter(Method, TypeConverterRegistry) - Constructor for class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
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) - Method in class org.apache.camel.model.LoadBalanceDefinition
Uses sticky load balancer
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) - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
StickyLoadBalancer(Expression, QueueLoadBalancer) - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
StickyLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Represents an XML <sticky/> element
StickyLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
stop() - Method in class org.apache.camel.component.browse.BrowseEndpoint
 
stop() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
stop() - Method in class org.apache.camel.component.direct.DirectConsumer
 
stop() - Method in class org.apache.camel.impl.DefaultConsumerTemplate
 
stop() - Method in class org.apache.camel.impl.DefaultUnitOfWork
 
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.model.ProcessorDefinition
Stops continue routing the current Exchange and marks it as completed.
stop() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Stops this resequencer (i.e.
stop() - Method in interface org.apache.camel.Service
Stops the service
stopChildService(Service) - Method in class org.apache.camel.impl.RouteService
 
StopDefinition - Class in org.apache.camel.model
Represents an XML <stop/> element
StopDefinition() - Constructor for class org.apache.camel.model.StopDefinition
 
StopProcessor - Class in org.apache.camel.processor
Stops continue processing the route and marks it as complete.
StopProcessor() - Constructor for class org.apache.camel.processor.StopProcessor
 
stopRoute(RouteDefinition) - Method in interface org.apache.camel.CamelContext
Stops the given route.
stopRoute(RouteDefinition) - Method in class org.apache.camel.impl.DefaultCamelContext
 
stopRoute(String) - Method in class org.apache.camel.impl.DefaultCamelContext
Stops the route denoted by the given RouteType id
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
storeFile(String, Exchange) - Method in class org.apache.camel.component.file.FileOperations
 
storeFile(String, Exchange) - Method in interface org.apache.camel.component.file.GenericFileOperations
Stores the content as a new remote file (upload)
strategyRef(String) - Method in class org.apache.camel.model.AggregateDefinition
Sets the aggregate strategy to use
stream() - Method in class org.apache.camel.model.ResequenceDefinition
Configures the stream-based resequencing algorithm using the default configuration.
stream(StreamResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
Configures the stream-based resequencing algorithm using the given StreamResequencerConfig.
StreamCache - Interface in org.apache.camel
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 (eg multicasting, retrying)
StreamCacheConverter() - Constructor for class org.apache.camel.converter.stream.StreamCacheConverter
 
streamCaching() - Method in class org.apache.camel.model.RouteDefinition
Enable stream caching for this route.
StreamCaching - Class in org.apache.camel.processor.interceptor
InterceptStrategy implementation to configure stream caching on a RouteContext
StreamCaching() - Constructor for class org.apache.camel.processor.interceptor.StreamCaching
 
StreamCachingInterceptor - Class in org.apache.camel.processor.interceptor
DelegateProcessor 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
 
streaming() - Method in class org.apache.camel.model.MulticastDefinition
Aggregates the responses as the are done (e.g.
streaming() - Method in class org.apache.camel.model.SplitDefinition
Enables streaming.
StreamResequencer - Class in org.apache.camel.processor
A resequencer that re-orders a (continuous) stream of Exchanges.
StreamResequencer(Processor, SequenceElementComparator<Exchange>) - 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 (1000) 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) - 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
Factory for StreamResultHandler
StreamResultHandlerFactory() - Constructor for class org.apache.camel.builder.xml.StreamResultHandlerFactory
 
StreamSourceCache - Class in org.apache.camel.converter.stream
StreamCache implementation for Cache the StreamSource StreamSources
StreamSourceCache(StreamSource, Exchange) - Constructor for class org.apache.camel.converter.stream.StreamSourceCache
 
StreamSourceConverter - Class in org.apache.camel.converter.jaxp
A converter from StreamSource objects
StreamSourceConverter() - Constructor for class org.apache.camel.converter.jaxp.StreamSourceConverter
 
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
Factory for StringResultHandler
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() - Constructor for class org.apache.camel.converter.jaxp.StringSource
 
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
 
stripExt(String) - Static method in class org.apache.camel.util.FileUtil
 
stripLeadingSeparator(String) - Static method in class org.apache.camel.util.FileUtil
Strip any leading separators
stripPath(String) - Static method in class org.apache.camel.util.FileUtil
Strips any leading paths
stripPrefix(String, String) - Static method in class org.apache.camel.util.URISupport
 
stripScheme(URI) - Static method in class org.apache.camel.util.URISupport
 
stripTrailingSeparator(String) - Static method in class org.apache.camel.util.FileUtil
Strip any trailing separators
submit(Callable) - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
 
submit(Runnable, Object) - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
 
SubmitOrderedCompletionService<V> - Class in org.apache.camel.util.concurrent
A CompletionService that orders the completed tasks in the same order as they where submitted.
SubmitOrderedCompletionService(Executor) - Constructor for class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
 
subscribeMethod(Method, Object, String, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
 
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.
supportTransacted() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
supportTransacted() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
supportTransacted() - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
Whether this error handler supports transacted exchanges.
supportTransacted() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
supportTransacted() - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
 
supportTransacted() - Method in class org.apache.camel.builder.NoErrorHandlerBuilder
 
supportTransacted() - Method in class org.apache.camel.processor.ErrorHandlerSupport
Whether this error handler supports transacted exchanges or not.
supportTransacted() - Method in class org.apache.camel.processor.LoggingErrorHandler
 
supportTransacted() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
 
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
SynchronizationAdapter - Class in org.apache.camel.impl
Simple Synchronization adapter with empty methods for easier overriding of single methods.
SynchronizationAdapter() - Constructor for class org.apache.camel.impl.SynchronizationAdapter
 
SYSTEM_PROPERTIES_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
 
SystemHelper - Class in org.apache.camel.util
A helper class for various System related methods
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
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

take() - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
 
TEMP_DIR - Static variable in class org.apache.camel.converter.stream.CachedOutputStream
 
tempPrefix - Variable in class org.apache.camel.component.file.GenericFileEndpoint
 
threads() - Method in class org.apache.camel.model.ProcessorDefinition
Leverages a thread pool for multi threading processing exchanges.
threads(int) - Method in class org.apache.camel.model.ProcessorDefinition
Leverages a thread pool for multi threading processing exchanges.
ThreadsDefinition - Class in org.apache.camel.model
Represents an XML <threads/> element
ThreadsDefinition() - Constructor for class org.apache.camel.model.ThreadsDefinition
 
ThreadsProcessor - Class in org.apache.camel.processor
Threads processor that leverage a thread pool for processing exchanges.
ThreadsProcessor(Processor, ExecutorService, WaitForTaskToComplete) - Constructor for class org.apache.camel.processor.ThreadsProcessor
 
THRESHOLD - Static variable in class org.apache.camel.converter.stream.CachedOutputStream
 
throttle(long) - Method in class org.apache.camel.model.ProcessorDefinition
Throttler EIP: Creates a throttler allowing you to ensure that a specific endpoint does not get overloaded, or that we don't exceed an agreed SLA with some external service.
ThrottleDefinition - Class in org.apache.camel.model
Represents an XML <throttle/> element
ThrottleDefinition() - Constructor for class org.apache.camel.model.ThrottleDefinition
 
ThrottleDefinition(long) - Constructor for class org.apache.camel.model.ThrottleDefinition
 
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
 
Throttler.TimeSlot - Class in org.apache.camel.processor
 
Throttler.TimeSlot() - Constructor for class org.apache.camel.processor.Throttler.TimeSlot
 
Throttler.TimeSlot(long) - Constructor for class org.apache.camel.processor.Throttler.TimeSlot
 
ThroughputLogger - Class in org.apache.camel.processor
A logger for logging message throughput.
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(Exception) - Method in class org.apache.camel.model.ProcessorDefinition
Sets the exception on the Exchange
ThrowExceptionDefinition - Class in org.apache.camel.model
Represents an XML <throwException/> element
ThrowExceptionDefinition() - Constructor for class org.apache.camel.model.ThrowExceptionDefinition
 
ThrowExceptionProcessor - Class in org.apache.camel.processor
The processor which implements the ThrowException DSL
ThrowExceptionProcessor(Exception) - Constructor for class org.apache.camel.processor.ThrowExceptionProcessor
 
tidyMarkup(Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
Return WellFormed HTML (an XML Document) either String or Node
tidyMarkup() - Method in class org.apache.camel.builder.DataFormatClause
Return TidyMarkup in the default format as Node
TidyMarkupDataFormat - Class in org.apache.camel.model.dataformat
Represents a wellformed HTML document (XML well Formed) DataFormat
TidyMarkupDataFormat() - Constructor for class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
TidyMarkupDataFormat(Class<?>) - Constructor for class org.apache.camel.model.dataformat.TidyMarkupDataFormat
 
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(long) - Method in class org.apache.camel.model.ResequenceDefinition
Sets the timeout
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 and 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.ThrottleDefinition
Sets the time period during which the maximum request count is valid for
TIMER_FIRED_TIME - Static variable in interface org.apache.camel.Exchange
 
TIMER_NAME - Static variable in interface org.apache.camel.Exchange
 
TIMER_PERIOD - Static variable in interface org.apache.camel.Exchange
 
TIMER_TIME - Static variable in interface org.apache.camel.Exchange
 
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
The timer consumer.
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() - Constructor for class org.apache.camel.component.timer.TimerEndpoint
 
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.ProcessorDefinition
Sends the exchange to the given endpoint
to(Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to the given endpoint
to(ExchangePattern, String) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange with certain exchange pattern to the given endpoint
to(ExchangePattern, Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange with certain exchange pattern to the given endpoint
to(String...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(ExchangePattern, String...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(ExchangePattern, Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
to(ExchangePattern, Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to a list of endpoints
toArray(Collection) - Static method in class org.apache.camel.converter.CollectionConverter
Converts a collection to an array
toArrayList(Iterator) - Static method in class org.apache.camel.converter.CollectionConverter
Converts an Iterator to a ArrayList
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
toBoolean(Object) - Static method in class org.apache.camel.util.ObjectHelper
 
toByte(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toByteArray(File) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(Reader) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(BufferedReader) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(ByteArrayOutputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(Source, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
Converts the given input Source into bytes
toByteArray(ByteBuffer) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteArray(String, Exchange) - 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, Exchange) - 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
 
ToDefinition - Class in org.apache.camel.model
Represents an XML <to/> element
ToDefinition() - Constructor for class org.apache.camel.model.ToDefinition
 
ToDefinition(String) - Constructor for class org.apache.camel.model.ToDefinition
 
ToDefinition(Endpoint) - Constructor for class org.apache.camel.model.ToDefinition
 
ToDefinition(String, ExchangePattern) - Constructor for class org.apache.camel.model.ToDefinition
 
ToDefinition(Endpoint, ExchangePattern) - Constructor for class org.apache.camel.model.ToDefinition
 
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).
toDOMSource(InputStream) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
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
toExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression processing the exchange to the given endpoint uri
toF(String, Object...) - Method in class org.apache.camel.model.ProcessorDefinition
Sends the exchange to the given endpoint
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, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(BufferedReader, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(byte[]) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(ByteArrayOutputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(StreamSource) - Method in class org.apache.camel.converter.jaxp.StreamSourceConverter
 
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(String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenizeExpression(Expression, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns a tokenize expression which will tokenize the string with the given token
TokenizeLanguage - Class in org.apache.camel.language.tokenizer
A language for tokenizer expressions.
TokenizeLanguage() - Constructor for class org.apache.camel.language.tokenizer.TokenizeLanguage
 
TokenizerExpression - Class in org.apache.camel.model.language
For expressions and predicates using a body or header tokenzier
TokenizerExpression() - Constructor for class org.apache.camel.model.language.TokenizerExpression
 
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
toList(Iterable) - Static method in class org.apache.camel.converter.CollectionConverter
Converts an Iterable into a List
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.LoadBalanceDefinition
Uses topic load balancer
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
 
TopicLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
Represents an XML <topic/> element
TopicLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.TopicLoadBalancerDefinition
 
toPredicate(Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
Converts the given expression into an Predicate
toProcessor(Predicate) - Method in class org.apache.camel.converter.CamelConverter
 
toProcessor(Expression) - Method in class org.apache.camel.converter.CamelConverter
 
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
 
toReader(StreamSource) - Method in class org.apache.camel.converter.jaxp.StreamSourceConverter
 
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
toResult(Source, Result, Properties) - 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[], Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
 
toStreamSource(ByteBuffer, Exchange) - 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.BinaryPredicateSupport
 
toString() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
 
toString() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
toString() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
 
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.ParameterInfo
 
toString() - Method in class org.apache.camel.component.bean.RegistryBean
 
toString() - Method in class org.apache.camel.component.file.GenericFile
 
toString() - Method in class org.apache.camel.component.file.GenericFileConfiguration
 
toString() - Method in class org.apache.camel.component.file.GenericFileMessage
 
toString() - Method in class org.apache.camel.component.file.GenericFileOnCompletion
 
toString() - Method in class org.apache.camel.component.seda.SedaConsumer
 
toString(byte[], Exchange) - 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(ByteArrayOutputStream) - 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, Exchange) - Static method in class org.apache.camel.converter.NIOConverter
 
toString(Integer) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString(Long) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString(Boolean) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString() - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
toString() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter.TypeMapping
 
toString() - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
toString() - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
toString() - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
toString() - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
toString() - Method in class org.apache.camel.impl.DefaultCamelContext
 
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.DefaultExchangeHolder
 
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.DefaultRoute
 
toString() - Method in class org.apache.camel.impl.DefaultRouteNode
 
toString() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
 
toString() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
 
toString() - Method in class org.apache.camel.impl.PollingConsumerSupport
 
toString() - Method in class org.apache.camel.impl.ProducerTemplateProcessor
 
toString() - Method in class org.apache.camel.impl.ReportingTypeConverterLoader.TypeMapping
 
toString() - Method in class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
 
toString() - Method in class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
 
toString() - Method in class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
toString() - Method in class org.apache.camel.impl.scan.InvertingPackageScanFilter
 
toString() - Method in class org.apache.camel.language.bean.BeanExpression
 
toString() - Method in enum org.apache.camel.language.simple.SimpleLangaugeOperator
 
toString() - Method in class org.apache.camel.management.InstrumentationInterceptStrategy
 
toString() - Method in class org.apache.camel.management.InstrumentationProcessor
 
toString() - Method in class org.apache.camel.model.AggregateDefinition
 
toString() - Method in class org.apache.camel.model.AOPDefinition
 
toString() - Method in class org.apache.camel.model.BeanDefinition
 
toString() - Method in class org.apache.camel.model.CatchDefinition
 
toString() - Method in class org.apache.camel.model.ChoiceDefinition
 
toString() - Method in class org.apache.camel.model.ConvertBodyDefinition
 
toString() - Method in class org.apache.camel.model.DelayDefinition
 
toString() - Method in class org.apache.camel.model.EnrichDefinition
 
toString() - Method in class org.apache.camel.model.FilterDefinition
 
toString() - Method in class org.apache.camel.model.FinallyDefinition
 
toString() - Method in class org.apache.camel.model.FromDefinition
 
toString() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
 
toString() - Method in class org.apache.camel.model.InOnlyDefinition
 
toString() - Method in class org.apache.camel.model.InOutDefinition
 
toString() - Method in class org.apache.camel.model.InterceptDefinition
 
toString() - Method in class org.apache.camel.model.InterceptFromDefinition
 
toString() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
 
toString() - Method in class org.apache.camel.model.language.ExpressionDefinition
 
toString() - Method in class org.apache.camel.model.language.MethodCallExpression
 
toString() - Method in class org.apache.camel.model.language.TokenizerExpression
 
toString() - Method in class org.apache.camel.model.LoadBalanceDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.RandomLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.RoundRobinLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.loadbalancer.TopicLoadBalancerDefinition
 
toString() - Method in class org.apache.camel.model.LoopDefinition
 
toString() - Method in class org.apache.camel.model.MarshalDefinition
 
toString() - Method in class org.apache.camel.model.MulticastDefinition
 
toString() - Method in class org.apache.camel.model.OnCompletionDefinition
 
toString() - Method in class org.apache.camel.model.OnExceptionDefinition
 
toString() - Method in class org.apache.camel.model.OtherwiseDefinition
 
toString() - Method in class org.apache.camel.model.PolicyDefinition
 
toString() - Method in class org.apache.camel.model.PollEnrichDefinition
 
toString() - Method in class org.apache.camel.model.ProcessDefinition
 
toString() - Method in class org.apache.camel.model.RecipientListDefinition
 
toString() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
 
toString() - Method in class org.apache.camel.model.RemoveHeaderDefinition
 
toString() - Method in class org.apache.camel.model.RemovePropertyDefinition
 
toString() - Method in class org.apache.camel.model.ResequenceDefinition
 
toString() - Method in class org.apache.camel.model.RollbackDefinition
 
toString() - Method in class org.apache.camel.model.RouteBuilderDefinition
 
toString() - Method in class org.apache.camel.model.RouteDefinition
 
toString() - Method in class org.apache.camel.model.RoutesDefinition
 
toString() - Method in class org.apache.camel.model.RoutingSlipDefinition
 
toString() - Method in class org.apache.camel.model.SetBodyDefinition
 
toString() - Method in class org.apache.camel.model.SetExchangePatternDefinition
 
toString() - Method in class org.apache.camel.model.SetHeaderDefinition
 
toString() - Method in class org.apache.camel.model.SetOutHeaderDefinition
 
toString() - Method in class org.apache.camel.model.SetPropertyDefinition
 
toString() - Method in class org.apache.camel.model.SortDefinition
 
toString() - Method in class org.apache.camel.model.SplitDefinition
 
toString() - Method in class org.apache.camel.model.StopDefinition
 
toString() - Method in class org.apache.camel.model.ThreadsDefinition
 
toString() - Method in class org.apache.camel.model.ThrottleDefinition
 
toString() - Method in class org.apache.camel.model.ThrowExceptionDefinition
 
toString() - Method in class org.apache.camel.model.ToDefinition
 
toString() - Method in class org.apache.camel.model.TransactedDefinition
 
toString() - Method in class org.apache.camel.model.TransformDefinition
 
toString() - Method in class org.apache.camel.model.TryDefinition
 
toString() - Method in class org.apache.camel.model.UnmarshalDefinition
 
toString() - Method in class org.apache.camel.model.WhenDefinition
 
toString() - Method in class org.apache.camel.model.WireTapDefinition
 
toString() - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
toString() - Method in class org.apache.camel.processor.Aggregator
 
toString() - Method in class org.apache.camel.processor.AOPProcessor
 
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.ConvertBodyProcessor
 
toString() - Method in class org.apache.camel.processor.DeadLetterChannel
 
toString() - Method in class org.apache.camel.processor.DefaultChannel
 
toString() - Method in class org.apache.camel.processor.DefaultErrorHandler
 
toString() - Method in class org.apache.camel.processor.Delayer
 
toString() - Method in class org.apache.camel.processor.DelegateProcessor
 
toString() - Method in class org.apache.camel.processor.Enricher
 
toString() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
 
toString() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
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.idempotent.IdempotentOnCompletion
 
toString() - Method in class org.apache.camel.processor.InterceptEndpointProcessor
 
toString() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
 
toString() - Method in class org.apache.camel.processor.interceptor.Delayer
 
toString() - Method in class org.apache.camel.processor.interceptor.DelayInterceptor
 
toString() - Method in class org.apache.camel.processor.interceptor.HandleFault
 
toString() - Method in class org.apache.camel.processor.interceptor.HandleFaultInterceptor
 
toString() - Method in class org.apache.camel.processor.interceptor.StreamCaching
 
toString() - Method in class org.apache.camel.processor.interceptor.StreamCachingInterceptor
 
toString() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
toString() - Method in class org.apache.camel.processor.interceptor.Tracer
 
toString() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
toString() - Method in class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
toString() - Method in class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
toString() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
toString() - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
 
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.LoopProcessor
 
toString() - Method in class org.apache.camel.processor.MarshalProcessor
 
toString() - Method in class org.apache.camel.processor.MulticastProcessor
 
toString() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
toString() - Method in class org.apache.camel.processor.Pipeline
 
toString() - Method in class org.apache.camel.processor.PollEnricher
 
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.RollbackProcessor
 
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.SortProcessor
 
toString() - Method in class org.apache.camel.processor.Splitter
 
toString() - Method in class org.apache.camel.processor.StopProcessor
 
toString() - Method in class org.apache.camel.processor.StreamResequencer
 
toString() - Method in class org.apache.camel.processor.ThreadsProcessor
 
toString() - Method in class org.apache.camel.processor.Throttler
 
toString() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
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.processor.UnitOfWorkProcessor
 
toString() - Method in class org.apache.camel.processor.UnmarshalProcessor
 
toString() - Method in class org.apache.camel.processor.WireTapProcessor
 
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.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
 
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_EVENT - Static variable in interface org.apache.camel.Exchange
 
TRACE_EVENT_EXCHANGE - Static variable in interface org.apache.camel.Exchange
 
TRACE_EVENT_NODE_ID - Static variable in interface org.apache.camel.Exchange
 
TRACE_EVENT_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
 
Traceable - Interface in org.apache.camel.processor
Traceable processors allowing easeir tracing using constructed labels to help identify the processor and where its defined in the route model.
TraceableUnitOfWork - Interface in org.apache.camel.spi
A Unit of work that is also traceable with the TraceInterceptor so we can trace the excact route path a given Exchange has been processed.
TraceEventMessage - Interface in org.apache.camel.processor.interceptor
A trace event message that contains decomposited information about the traced Exchange at the point of interception.
traceExchange(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
 
TraceFormatter - Interface in org.apache.camel.processor.interceptor
Formatter to format trace logs when tracing Exchange during routing.
TraceInterceptor - Class in org.apache.camel.processor.interceptor
An interceptor for debugging and tracing routes
TraceInterceptor(ProcessorDefinition, Processor, TraceFormatter, Tracer) - Constructor for class org.apache.camel.processor.interceptor.TraceInterceptor
 
TraceInterceptor(ProcessorDefinition, Processor, Tracer) - Constructor for class org.apache.camel.processor.interceptor.TraceInterceptor
 
Tracer - Class in org.apache.camel.processor.interceptor
An interceptor strategy for tracing routes
Tracer() - Constructor for class org.apache.camel.processor.interceptor.Tracer
 
tracing() - Method in class org.apache.camel.model.RouteDefinition
Enable tracing for this route.
TRANSACTED - Static variable in interface org.apache.camel.Exchange
 
transacted() - Method in class org.apache.camel.model.ProcessorDefinition
Marks this route as transacted and uses the default transacted policy found in the registry.
transacted(String) - Method in class org.apache.camel.model.ProcessorDefinition
Marks this route as transacted.
TransactedDefinition - Class in org.apache.camel.model
Represents an XML <transacted/> element
TransactedDefinition() - Constructor for class org.apache.camel.model.TransactedDefinition
 
TransactedDefinition(Policy) - Constructor for class org.apache.camel.model.TransactedDefinition
 
TransactedPolicy - Interface in org.apache.camel.spi
A marker for defining the policy to be used for applying transaction to routes.
transform(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the OUT message
transform() - Method in class org.apache.camel.model.ProcessorDefinition
Message Translator EIP: Adds a processor which sets the body on the OUT message
TransformDefinition - Class in org.apache.camel.model
Represents an XML <transform/> element
TransformDefinition() - Constructor for class org.apache.camel.model.TransformDefinition
 
TransformDefinition(Expression) - Constructor for class org.apache.camel.model.TransformDefinition
 
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
 
trunkStore() - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
Trunks the file store when the max store size is hit by rewriting the 1st level cache to the file store.
TryDefinition - Class in org.apache.camel.model
Represents an XML <try/> element
TryDefinition() - Constructor for class org.apache.camel.model.TryDefinition
 
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
 
tryProcessor - Variable in class org.apache.camel.processor.TryProcessor
 
type - Variable in class org.apache.camel.model.PolicyDefinition
 
type - Variable in class org.apache.camel.model.TransactedDefinition
 
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
TYPE_CONSUMER - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
TYPE_CONTEXT - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
TYPE_ENDPOINT - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
TYPE_PROCESSOR - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
TYPE_ROUTE - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
typeCoerceCompare(TypeConverter, Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
A helper method for comparing objects ordering in which it uses type coerce to coerce types between the left and right values.
typeCoerceEquals(TypeConverter, Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
A helper method for comparing objects for equality in which it uses type coerce to coerce types between the left and right values.
typeCoerceNotEquals(TypeConverter, Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
A helper method for comparing objects for equality in which it uses type coerce to coerce types between the left and right values.
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
typeConverterExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
Returns an expression for the type converter
TypeConverterLoader - Interface in org.apache.camel.impl.converter
A pluggable strategy to load type converters into a registry from some kind of mechanism
TypeConverterRegistry - Interface in org.apache.camel.spi
Registry for type converters.

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(Processor) - Constructor for class org.apache.camel.processor.UnitOfWorkProcessor
 
unmarshal(Exchange, DefaultExchangeHolder) - Static method in class org.apache.camel.impl.DefaultExchangeHolder
Transfers the information from the payload to the exchange.
unmarshal(Exchange, InputStream) - Method in class org.apache.camel.impl.GzipDataFormat
 
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.impl.ZipDataFormat
 
unmarshal() - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: Unmarshals the in body using a DataFormat expression to define the format of the input message and the output will be set on the out message body.
unmarshal(DataFormatDefinition) - Method in class org.apache.camel.model.ProcessorDefinition
DataFormat: 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.ProcessorDefinition
DataFormat: 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.ProcessorDefinition
DataFormat: 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.
UnmarshalDefinition - Class in org.apache.camel.model
Unmarshals the binary payload using the given DataFormatDefinition
UnmarshalDefinition() - Constructor for class org.apache.camel.model.UnmarshalDefinition
 
UnmarshalDefinition(DataFormatDefinition) - Constructor for class org.apache.camel.model.UnmarshalDefinition
 
UnmarshalDefinition(String) - Constructor for class org.apache.camel.model.UnmarshalDefinition
 
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
 
unregister(ObjectName) - Method in class org.apache.camel.management.DefaultInstrumentationAgent
 
unregister(ObjectName) - Method in interface org.apache.camel.spi.InstrumentationAgent
Unregisters object based upon registered name
UnsafeUriCharactersEncoder - Class in org.apache.camel.util
Encoder for unsafe URI characters.
updateExpireTime(TimeoutMapEntry) - Method in class org.apache.camel.util.DefaultTimeoutMap
 
updateNewExchange(Exchange, int, Iterable<MulticastProcessor.ProcessorExchangePair>) - Method in class org.apache.camel.processor.MulticastProcessor
 
updateNewExchange(Exchange, int, Iterable<MulticastProcessor.ProcessorExchangePair>) - Method in class org.apache.camel.processor.Splitter
 
uri - Variable in class org.apache.camel.model.InterceptFromDefinition
 
uri - Variable in class org.apache.camel.model.SendDefinition
 
URISupport - Class in org.apache.camel.util
URI utilities.
URISupport.CompositeData - Class in org.apache.camel.util
Holder to get parts of the URI.
URISupport.CompositeData() - Constructor for class org.apache.camel.util.URISupport.CompositeData
 
url - Variable in class org.apache.camel.view.NodeData
 
USE_PLATFORM_MBS - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
 
useCollisionAvoidance() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
useCollisionAvoidance() - Method in class org.apache.camel.model.OnExceptionDefinition
Turn on collision avoidance.
useCollisionAvoidance() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Turn on collision avoidance.
useCollisionAvoidance - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
useCollisionAvoidance() - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables collision avoidance which adds some randomization to the backoff timings to reduce contention probability
useExponentialBackOff() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
useExponentialBackOff() - Method in class org.apache.camel.model.OnExceptionDefinition
Turn on exponential backk off
useExponentialBackOff() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
Turn on exponential backk off
useExponentialBackOff - Variable in class org.apache.camel.processor.RedeliveryPolicy
 
useExponentialBackOff() - Method in class org.apache.camel.processor.RedeliveryPolicy
Enables exponential backoff 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.
UseLatestAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
useOriginalBody() - Method in class org.apache.camel.model.OnExceptionDefinition
Will use the original input body when an Exchange is moved to the dead letter queue.
useOriginalMessage - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
 
useOriginalMessage() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
Will use the original input Message when an Exchange is moved to the dead letter queue.
useOriginalMessagePolicy - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
 
UuidGenerator - Class in org.apache.camel.util
Generator for Globally unique Strings.
UuidGenerator(String) - Constructor for class org.apache.camel.util.UuidGenerator
 
UuidGenerator() - Constructor for class org.apache.camel.util.UuidGenerator
 

V

validateParameters(String, Map, String) - Method in class org.apache.camel.impl.DefaultComponent
Strategy for validation of parameters, that was not able to be resolved to any endpoint options.
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
Validator error handler.
VALUE_UNKNOWN - Static variable in class org.apache.camel.management.CamelNamingStrategy
 
VALUE_UNKNOWN - Static variable in class org.apache.camel.management.ManagedRoute
 
ValueBuilder - Class in org.apache.camel.builder
A builder of expressions or predicates based on values.
ValueBuilder(Expression) - Constructor for class org.apache.camel.builder.ValueBuilder
 
ValueHolder<V> - Class in org.apache.camel.util
Holder object for a given value.
ValueHolder() - Constructor for class org.apache.camel.util.ValueHolder
 
ValueHolder(V) - Constructor for class org.apache.camel.util.ValueHolder
 
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.component.file.GenericFileExist
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.language.simple.SimpleLangaugeOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.LoggingLevel
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.model.dataformat.BindyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.model.dataformat.JsonLibrary
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.ServiceStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.spi.HeaderFilterStrategy.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.WaitForTaskToComplete
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.component.file.GenericFileExist
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.language.simple.SimpleLangaugeOperator
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.camel.LoggingLevel
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.model.dataformat.BindyType
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.JsonLibrary
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.camel.ServiceStatus
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.camel.spi.HeaderFilterStrategy.Direction
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.camel.WaitForTaskToComplete
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(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
 
waitForCompleteLatch() - Method in class org.apache.camel.component.mock.MockEndpoint
 
waitForCompleteLatch(long) - Method in class org.apache.camel.component.mock.MockEndpoint
 
waitForTaskToComplete(WaitForTaskToComplete) - Method in class org.apache.camel.model.ThreadsDefinition
Setting to whether to wait for async tasks to be complete before continuing original route.
waitForTaskToComplete - Variable in class org.apache.camel.processor.ThreadsProcessor
 
WaitForTaskToComplete - Enum in org.apache.camel
Represent the kinds of options for wait for tasks to complete.
waitUntil(long, Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
Wait until the given system time before continuing
waitUntilCompleted() - Method in class org.apache.camel.impl.MainSupport
 
warning(SAXParseException) - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
 
WebSpherePacakageScanClassResolver - Class in org.apache.camel.impl
WebSphere specific resolver to handle loading annotated resources in JAR files.
WebSpherePacakageScanClassResolver(String) - Constructor for class org.apache.camel.impl.WebSpherePacakageScanClassResolver
Constructor.
when(Predicate) - Method in class org.apache.camel.model.ChoiceDefinition
Sets the predicate for the when node
when() - Method in class org.apache.camel.model.ChoiceDefinition
Creates an expression for the when node
when(Predicate) - Method in class org.apache.camel.model.InterceptDefinition
Applies this interceptor only if the given predicate is true
when(Predicate) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
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.
WhenDefinition - Class in org.apache.camel.model
Represents an XML <when/> element
WhenDefinition() - Constructor for class org.apache.camel.model.WhenDefinition
 
WhenDefinition(Predicate) - Constructor for class org.apache.camel.model.WhenDefinition
 
WhenDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.WhenDefinition
 
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.
wireTap(String) - Method in class org.apache.camel.model.ProcessorDefinition
WireTap EIP: Sends 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 using ExchangePattern.InOnly.
wireTap(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
WireTap EIP: Sends a new Exchange to the destination using ExchangePattern.InOnly.
wireTap(String, Processor) - Method in class org.apache.camel.model.ProcessorDefinition
WireTap EIP: Sends a new Exchange to the destination using ExchangePattern.InOnly.
WireTapDefinition - Class in org.apache.camel.model
Represents an XML <wireTap/> element
WireTapDefinition() - Constructor for class org.apache.camel.model.WireTapDefinition
 
WireTapDefinition(String) - Constructor for class org.apache.camel.model.WireTapDefinition
 
WireTapDefinition(Endpoint) - Constructor for class org.apache.camel.model.WireTapDefinition
 
WireTapProcessor - Class in org.apache.camel.processor
Processor for wire tapping exchanges to an endpoint destination.
WireTapProcessor(Endpoint) - Constructor for class org.apache.camel.processor.WireTapProcessor
 
WireTapProcessor(Endpoint, ExchangePattern) - Constructor for class org.apache.camel.processor.WireTapProcessor
 
wrap(RouteContext, Processor) - Method in class org.apache.camel.impl.NoPolicy
 
wrap(RouteContext, Processor) - Method in interface org.apache.camel.spi.Policy
Wraps any applicable interceptors around the given processor
wrapCamelExecutionException(Exchange, Throwable) - Static method in class org.apache.camel.util.ObjectHelper
Wraps the caused exception in a CamelExecutionException if its not already such an exception.
wrapChannel(RouteContext, Processor) - Method in class org.apache.camel.model.ProcessorDefinition
 
wrapProcessor(RouteContext, Processor) - Method in class org.apache.camel.model.ProcessorDefinition
Wraps the child processor in whatever necessary interceptors and error handlers
wrapProcessorInInterceptors(CamelContext, ProcessorDefinition, Processor, Processor) - Method in class org.apache.camel.management.InstrumentationInterceptStrategy
 
wrapProcessorInInterceptors(CamelContext, ProcessorDefinition, Processor, Processor) - Method in class org.apache.camel.processor.interceptor.Delayer
 
wrapProcessorInInterceptors(CamelContext, ProcessorDefinition, Processor, Processor) - Method in class org.apache.camel.processor.interceptor.HandleFault
 
wrapProcessorInInterceptors(CamelContext, ProcessorDefinition, Processor, Processor) - Method in class org.apache.camel.processor.interceptor.StreamCaching
 
wrapProcessorInInterceptors(CamelContext, ProcessorDefinition, Processor, Processor) - Method in class org.apache.camel.processor.interceptor.Tracer
 
wrapProcessorInInterceptors(CamelContext, ProcessorDefinition, Processor, Processor) - Method in interface org.apache.camel.spi.InterceptStrategy
This method is invoked by ProcessorDefinition.wrapProcessor(RouteContext, Processor) to give the implementor an opportunity to wrap the target processor in a route.
wrapRuntimeCamelException(Throwable) - Static method in class org.apache.camel.util.ObjectHelper
Wraps the caused exception in a RuntimeCamelException if its not already such an exception.
write(byte[], int, int) - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
write(byte[]) - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
write(int) - Method in class org.apache.camel.converter.stream.CachedOutputStream
 
writeExternal(ObjectOutput) - Method in class org.apache.camel.component.bean.BeanInvocation
 
writeExternal(ObjectOutput) - Method in class org.apache.camel.converter.jaxp.StringSource
 
writeFile(Exchange, String) - Method in class org.apache.camel.component.file.GenericFileProducer
 
writeTo(OutputStream) - Method in class org.apache.camel.converter.stream.FileInputStreamCache
 
writeTo(OutputStream) - Method in class org.apache.camel.converter.stream.InputStreamCache
 
writeTo(OutputStream) - Method in class org.apache.camel.converter.stream.ReaderCache
 
writeTo(OutputStream) - Method in class org.apache.camel.converter.stream.SourceCache
 
writeTo(OutputStream) - Method in class org.apache.camel.converter.stream.StreamSourceCache
 
writeTo(OutputStream) - Method in interface org.apache.camel.StreamCache
Writes the stream to the given output

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
 
XMLSecurityDataFormat - Class in org.apache.camel.model.dataformat
Represents as XML Security Encrypter/Decrypter DataFormat
XMLSecurityDataFormat() - Constructor for class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
XMLSecurityDataFormat(String, boolean) - Constructor for class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
XMLSecurityDataFormat(String, boolean, String) - Constructor for class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
XMLSecurityDataFormat(String, boolean, String, String) - Constructor for class org.apache.camel.model.dataformat.XMLSecurityDataFormat
 
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(String, Class) - 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
Factory for the XPath expression annotations.
XPathAnnotationExpressionFactory() - Constructor for class org.apache.camel.component.bean.XPathAnnotationExpressionFactory
 
XPathBuilder - 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 expressions 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.language.xpath
XPath language.
XPathLanguage() - Constructor for class org.apache.camel.language.xpath.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 expressions and predicates
XQueryExpression() - Constructor for class org.apache.camel.model.language.XQueryExpression
 
XQueryExpression(String) - Constructor for class org.apache.camel.model.language.XQueryExpression
 
xslt(Templates) - Static method in class org.apache.camel.builder.xml.XsltBuilder
Creates an XSLT processor using the given templates 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(Templates) - 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
 

Z

zip() - Method in class org.apache.camel.builder.DataFormatClause
Uses the ZIP deflater data format
zip(int) - Method in class org.apache.camel.builder.DataFormatClause
Uses the ZIP deflater data format
ZipDataFormat - Class in org.apache.camel.impl
 
ZipDataFormat() - Constructor for class org.apache.camel.impl.ZipDataFormat
 
ZipDataFormat(int) - Constructor for class org.apache.camel.impl.ZipDataFormat
 
ZipDataFormat - Class in org.apache.camel.model.dataformat
Represents the ZIP XML DataFormat
ZipDataFormat() - Constructor for class org.apache.camel.model.dataformat.ZipDataFormat
 
ZipDataFormat(int) - Constructor for class org.apache.camel.model.dataformat.ZipDataFormat
 

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

Apache CAMEL