Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- accept(CamelContext) - Method in class org.apache.camel.spi.CamelContextTracker
-
Called to determine whether this tracker should accept the given context.
- accept(CamelContext) - Method in interface org.apache.camel.spi.CamelContextTracker.Filter
- ACCEPT_CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- acceptDebugger(Exchange) - Method in interface org.apache.camel.NamedNode
-
Whether this node can accept debugging the current exchange.
- acquire() - Method in interface org.apache.camel.spi.PooledObjectFactory
-
Acquires an object from the pool (if any)
- acquirePollingConsumer(Endpoint) - Method in interface org.apache.camel.spi.ConsumerCache
-
Acquires a pooled polling consumer which you must release back again after usage using the
ConsumerCache.releasePollingConsumer(Endpoint, PollingConsumer)
method. - acquireProducer(Endpoint) - Method in interface org.apache.camel.spi.ProducerCache
-
Acquires a pooled producer which you must release back again after usage using the
ProducerCache.releaseProducer(org.apache.camel.Endpoint, org.apache.camel.AsyncProducer)
method. - activate() - Method in interface org.apache.camel.spi.Breakpoint
-
Activates this breakpoint
- activateAllBreakpoints() - Method in interface org.apache.camel.spi.Debugger
-
Activate all breakpoints.
- Active - Enum constant in enum class org.apache.camel.spi.Breakpoint.State
- ACTIVE_SPAN - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- ACTIVE_SPAN - Static variable in interface org.apache.camel.Exchange
- adapt(Class<T>) - Method in interface org.apache.camel.spi.RouteController
-
Adapts this
RouteController
to the specialized type. - adapterFactoryService() - Method in interface org.apache.camel.resume.ResumeAware
-
Allows the implementation to provide custom adapter factories.
- add(String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Adds the key to the repository.
- add(String, Exchange) - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Adds the exchange to the repository.
- add(K, Object) - Method in interface org.apache.camel.resume.cache.ResumeCache
-
Adds a value to the cache
- add(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.AggregationRepository
-
Add the given
Exchange
under the correlation key. - add(CamelContext, String, Exchange, Exchange) - Method in interface org.apache.camel.spi.OptimisticLockingAggregationRepository
-
Add the given
Exchange
under the correlation key. - add(ContextEvents, Clock) - Method in class org.apache.camel.clock.ContextClock
- add(Exchange) - Method in interface org.apache.camel.spi.InflightRepository
-
Adds the exchange to the inflight registry to the total counter
- add(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Adds the key to the repository.
- add(Exchange, String) - Method in interface org.apache.camel.spi.InflightRepository
-
Adds the exchange to the inflight registry associated to the given route
- add(OffsetKey<?>, Offset<?>) - Method in interface org.apache.camel.resume.Cacheable
-
Adds an offset key and value to the cache
- add(T, Clock) - Method in interface org.apache.camel.clock.EventClock
-
Add the event to be tracked
- addAdvice(CamelInternalProcessorAdvice<?>) - Method in interface org.apache.camel.spi.InternalProcessor
-
Adds an
CamelInternalProcessorAdvice
advice to the list of advices to execute by this internal processor. - addAllSniHostNames(List<String>) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
- addBootstrap(BootstrapCloseable) - Method in interface org.apache.camel.ExtendedCamelContext
-
Adds a
BootstrapCloseable
task. - addBootstrapConfigurerClearer(Runnable) - Static method in class org.apache.camel.spi.ConfigurerStrategy
- addBreakpoint(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Adds a breakpoint for the given node
- addBreakpoint(Breakpoint) - Method in interface org.apache.camel.spi.Debugger
-
Add the given breakpoint
- addBreakpoint(Breakpoint, Condition...) - Method in interface org.apache.camel.spi.Debugger
-
Add the given breakpoint
- addBulkTypeConverters(BulkTypeConverters) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Registers a new set of type converters that are bulked together into a single
BulkTypeConverters
class. - addCamelBeanPostProjectInjector(CamelBeanPostProcessorInjector) - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
-
Adds a custom bean post injector
- addChildUnitOfWorkProcessorAdvice(CamelContext, Processor, Route, UnitOfWork) - Method in interface org.apache.camel.spi.InternalProcessorFactory
- addCipherSuite(String) - Method in class org.apache.camel.support.jsse.CipherSuitesParameters
- addClassLoader(ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Adds a custom class loader to use.
- addClassLoader(ClassLoader) - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
Adds the class loader to the existing loaders
- addClassLoader(ClassLoader) - Method in interface org.apache.camel.spi.PackageScanResourceResolver
-
Adds the class loader to the existing loaders
- addComponent(String, Component) - Method in interface org.apache.camel.CamelContext
-
Adds a component to the context.
- addConditionalBreakpoint(String, String, String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Adds a conditional breakpoint for the given node
- addContextPlugin(Class<T>, T) - Method in interface org.apache.camel.ExtendedCamelContext
-
Allows installation of custom plugins to the Camel context.
- addContextPlugin(Class<T>, T) - Method in interface org.apache.camel.spi.PluginManager
-
Allows installation of custom plugins to the Camel context.
- addConverter(TypeConvertible<?, ?>, TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Adds a type convertible pair to the registry
- addDefaults(ThreadPoolProfile) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Overwrites each attribute that is null with the attribute from defaultProfile
- addDefaultValue(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addDefaultValue(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addDeprecated(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addDeprecated(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addEndpoint(String, Endpoint) - Method in interface org.apache.camel.CamelContext
-
Adds and starts the endpoint to the
EndpointRegistry
using the given URI. - addErrorHandler(ErrorHandlerFactory, NamedNode) - Method in interface org.apache.camel.Route
-
Adds error handler for the given exception type
- addErrorHandlerFactoryReference(ErrorHandlerFactory, ErrorHandlerFactory) - Method in interface org.apache.camel.Route
-
Link the error handlers from a factory to another
- addEventListener(CamelClusterEventListener) - Method in interface org.apache.camel.cluster.CamelClusterView
-
Add an event listener.
- addEventNotifier(EventNotifier) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Adds the event notifier to use.
- addExchangeFactory(ExchangeFactory) - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Adds the
ExchangeFactory
to be managed. - addExclude(String) - Method in class org.apache.camel.support.jsse.FilterParameters
- addFallbackTypeConverter(TypeConverter, boolean) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Registers a new fallback type converter
- addFilter(PackageScanFilter) - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
Add a filter that will be applied to all scan operations
- addHealthCheck(HealthCheck) - Method in interface org.apache.camel.health.WritableHealthCheckRepository
-
Adds a
HealthCheck
to the repository. - addIncapable(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addIncapable(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInclude(String) - Method in class org.apache.camel.support.jsse.FilterParameters
- addInitialProperty(String, String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Adds an initial property which will be added before any property locations are loaded.
- addInterceptStrategy(InterceptStrategy) - Method in interface org.apache.camel.ExtendedCamelContext
-
Adds the given interceptor strategy
- addInvalidArray(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidArray(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidBoolean(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidBoolean(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidDuration(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidDuration(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidEnum(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidEnum(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidEnumChoices(String, String[]) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidEnumChoices(String, String[]) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidEnumSuggestions(String, String[]) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidEnumSuggestions(String, String[]) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidInteger(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidInteger(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidMap(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidMap(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidNumber(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidNumber(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addInvalidReference(String, String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addInvalidReference(String, String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addLenient(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addLifecycleStrategy(LifecycleStrategy) - Method in interface org.apache.camel.CamelContext
-
Adds the given lifecycle strategy to be used.
- addListener(TimeoutMap.Listener<K, V>) - Method in interface org.apache.camel.TimeoutMap
-
Assign the (singular)
TimeoutMap.Listener
- addLocation(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Adds the list of locations to the current locations, where to load properties.
- addLogListener(LogListener) - Method in interface org.apache.camel.ExtendedCamelContext
-
Adds a
LogListener
. - addManagementInterceptStrategy(ManagementInterceptStrategy.InstrumentationProcessor) - Method in interface org.apache.camel.spi.InternalProcessor
-
Add advice for JMX management for the route
- addNotConsumerOnly(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addNotProducerOnly(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addOnCompletion(Synchronization) - Method in interface org.apache.camel.ExchangeExtension
-
Adds a
Synchronization
to be invoked as callback when this exchange is completed. - addOverrideProperty(String, String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Adds a special override property that take precedence and will use first, if a property exist.
- addPropertiesFunction(PropertiesFunction) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Registers the
PropertiesFunction
as a function to this component. - addPropertiesLookupListener(PropertiesLookupListener) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Adds the
PropertiesLookupListener
. - addPropertiesSource(PropertiesSource) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Adds a custom
PropertiesSource
to use as source for loading and/or looking up property values. - addPrototypeService(Object) - Method in interface org.apache.camel.CamelContext
-
Adds a service to this CamelContext (prototype scope).
- addReifierClearer(Runnable) - Static method in class org.apache.camel.spi.ReifierStrategy
- addRequired(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addRequired(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addRestService(Consumer, boolean, String, String, String, String, String, String, String, String, String, String, String) - Method in interface org.apache.camel.spi.RestRegistry
-
Adds a new REST service to the registry.
- addRoute(String) - Method in interface org.apache.camel.spi.InflightRepository
-
Adds the route from the in flight registry.
- addRoute(Route) - Method in interface org.apache.camel.ExtendedCamelContext
-
Internal API for adding routes.
- addRouteConfigurationsToCamelContext(CamelContext) - Method in interface org.apache.camel.RouteConfigurationsBuilder
-
Adds the route configurations from this builder to the CamelContext.
- addRouteFromTemplate(String, String, String, Map<String, Object>) - Method in interface org.apache.camel.CamelContext
-
Adds a new route from a given route template.
- addRouteFromTemplate(String, String, String, RouteTemplateContext) - Method in interface org.apache.camel.CamelContext
-
Adds a new route from a given route template.
- addRouteFromTemplate(String, String, Map<String, Object>) - Method in interface org.apache.camel.CamelContext
-
Adds a new route from a given route template.
- addRouteInflightRepositoryAdvice(InflightRepository, String) - Method in interface org.apache.camel.spi.InternalProcessor
-
Adds advice for tracking inflight exchanges for the given route
- addRouteLifecycleAdvice() - Method in interface org.apache.camel.spi.InternalProcessor
-
Add advice for setting up
UnitOfWork
with the lifecycle of the route. - addRoutePolicyAdvice(List<RoutePolicy>) - Method in interface org.apache.camel.spi.InternalProcessor
-
Adds advice for handling
RoutePolicy
for the route - addRoutePolicyFactory(RoutePolicyFactory) - Method in interface org.apache.camel.CamelContext
-
Adds the given route policy factory
- addRoutes(RoutesBuilder) - Method in interface org.apache.camel.CamelContext
-
Adds a collection of routes to this CamelContext using the given builder to build them.
- addRoutesConfigurations(RouteConfigurationsBuilder) - Method in interface org.apache.camel.CamelContext
-
Adds the routes configurations (global configuration for all routes) from the routes builder.
- addRoutesToCamelContext(CamelContext) - Method in interface org.apache.camel.RoutesBuilder
-
Adds the routes from this Route Builder to the CamelContext.
- addService(Object) - Method in interface org.apache.camel.CamelContext
-
Adds a service to this CamelContext, which allows this CamelContext to control the lifecycle, ensuring the service is stopped when the CamelContext stops.
- addService(Object, boolean) - Method in interface org.apache.camel.CamelContext
-
Adds a service to this CamelContext.
- addService(Object, boolean, boolean) - Method in interface org.apache.camel.CamelContext
-
Adds a service to this CamelContext.
- addService(Service) - Method in interface org.apache.camel.Route
-
Adds a service to this route
- addService(Service, boolean) - Method in interface org.apache.camel.Route
-
Adds a service to this route
- addSingleStepBreakpoint(Breakpoint) - Method in interface org.apache.camel.spi.Debugger
-
Add the given breakpoint which will be used in single step mode
- addSingleStepBreakpoint(Breakpoint, Condition...) - Method in interface org.apache.camel.spi.Debugger
-
Add the given breakpoint which will be used in single step mode
- addSpoolRule(StreamCachingStrategy.SpoolRule) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Adds the
StreamCachingStrategy.SpoolRule
rule to be used. - addStartupListener(StartupListener) - Method in interface org.apache.camel.CamelContext
-
Adds the given listener to be invoked when
CamelContext
have just been started. - addSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
-
Adds a synchronization hook
- addSyntaxError(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addSyntaxError(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addTemplatedRoutes(RoutesBuilder) - Method in interface org.apache.camel.CamelContext
-
Adds the templated routes from the routes builder.
- addTemplatedRoutesToCamelContext(CamelContext) - Method in interface org.apache.camel.RoutesBuilder
-
Adds the templated routes from this Route Builder to the CamelContext.
- addThreadFactoryListener(ExecutorServiceManager.ThreadFactoryListener) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Adds a custom
ExecutorServiceManager.ThreadFactoryListener
to use - addTypeConverter(Class<?>, Class<?>, TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Registers a new type converter.
- addTypeConverters(Object) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Registers all the type converters from the instance, each converter must be implemented as a method and annotated with
Converter
. - addUnitOfWorkProcessorAdvice(CamelContext, Processor, Route) - Method in interface org.apache.camel.spi.InternalProcessorFactory
- addUnknown(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addUnknown(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addUnknownComponent(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addUnknownComponent(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- addUnknownSuggestions(String, String[]) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- addUnknownSuggestions(String, String[]) - Method in class org.apache.camel.catalog.EndpointValidationResult
- after(Exchange, T) - Method in interface org.apache.camel.spi.CamelInternalProcessorAdvice
-
Callback executed after processing a step in the route.
- after(Exchange, T) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
- afterConsume(C) - Method in interface org.apache.camel.resume.ConsumerListener
-
This is an event that runs after data consumption if and only if the consumer has been paused.
- afterPoll() - Method in interface org.apache.camel.PollingConsumerPollingStrategy
-
Callback invoked after the poll.
- afterProcess(Exchange, Processor, NamedNode, long) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Callback invoked after a breakpoint
- afterProcess(Exchange, Processor, NamedNode, long) - Method in interface org.apache.camel.spi.Breakpoint
-
Callback invoked when the breakpoint was hit and the
Exchange
has been processed (after). - afterProcess(Exchange, Processor, NamedNode, long) - Method in interface org.apache.camel.spi.Debugger
-
Callback invoked when an
Exchange
has been processed which allows implementators to notify breakpoints. - afterProcess(Processor, Exchange, AsyncCallback, boolean) - Method in interface org.apache.camel.spi.UnitOfWork
-
Strategy for work to be executed after the processing
- afterProcess(P) - Method in interface org.apache.camel.resume.ConsumerListener
-
This is an event that runs after data processing.
- afterPropertiesConfigured(CamelContext) - Method in interface org.apache.camel.AfterPropertiesConfigured
-
Callback invoked after the element have configured its properties.
- afterPropertiesConfigured(CamelContext) - Method in interface org.apache.camel.spi.UnitOfWorkFactory
- AfterPropertiesConfigured - Interface in org.apache.camel
-
To perform optional initialization on an element after its properties has been configured.
- afterRoute(Exchange, Route) - Method in interface org.apache.camel.spi.UnitOfWork
-
Invoked when this unit of work is done being routed by the given route.
- aggregate(Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
-
Aggregates an old and new exchange together to create a single combined exchange
- aggregate(Exchange, Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
-
Aggregates an old and new exchange together to create a single combined exchange.
- AGGREGATED_COLLECTION_GUARD - Static variable in interface org.apache.camel.Exchange
- AGGREGATED_COMPLETED_BY - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- AGGREGATED_COMPLETED_BY - Static variable in interface org.apache.camel.Exchange
- AGGREGATED_CORRELATION_KEY - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- AGGREGATED_CORRELATION_KEY - Static variable in interface org.apache.camel.Exchange
- AGGREGATED_SIZE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- AGGREGATED_SIZE - Static variable in interface org.apache.camel.Exchange
- AGGREGATED_TIMEOUT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- AGGREGATED_TIMEOUT - Static variable in interface org.apache.camel.Exchange
- AGGREGATION_COMPLETE_ALL_GROUPS - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- AGGREGATION_COMPLETE_ALL_GROUPS - Static variable in interface org.apache.camel.Exchange
- AGGREGATION_COMPLETE_ALL_GROUPS_INCLUSIVE - Static variable in interface org.apache.camel.Exchange
- AGGREGATION_COMPLETE_CURRENT_GROUP - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- AGGREGATION_COMPLETE_CURRENT_GROUP - Static variable in interface org.apache.camel.Exchange
- AGGREGATION_STRATEGY - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- AGGREGATION_STRATEGY - Static variable in interface org.apache.camel.Exchange
- AggregationRepository - Interface in org.apache.camel.spi
-
Access to a repository to store aggregated exchanges to support pluggable implementations.
- aggregationStrategy() - Element in annotation interface org.apache.camel.RecipientList
-
Sets a reference to the AggregationStrategy to be used to assemble the replies from the recipients, into a single outgoing message from the RecipientList.
- AggregationStrategy - Interface in org.apache.camel
-
A strategy for aggregating two exchanges together into a single exchange.
- AI - Enum constant in enum class org.apache.camel.Category
- algorithm - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
- algorithm - Variable in class org.apache.camel.support.jsse.SecureRandomParameters
- algorithm - Variable in class org.apache.camel.support.jsse.TrustManagersParameters
- AliasedX509ExtendedKeyManager - Class in org.apache.camel.support.jsse
-
KeyManager to select a key with desired alias while delegating processing to specified KeyManager Can be used both with server and client sockets
- AliasedX509ExtendedKeyManager(String, X509KeyManager) - Constructor for class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
-
Construct KeyManager instance
- aliases() - Element in annotation interface org.apache.camel.spi.ApiParams
-
Returns the method alias(s) of this api method.
- ALL - Enum constant in enum class org.apache.camel.health.HealthCheck.Kind
- allLocalIp - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestHostNameResolver
- allowHandover() - Method in interface org.apache.camel.spi.SynchronizationVetoable
-
Whether or not handover this synchronization is allowed.
- allowNull() - Element in annotation interface org.apache.camel.Converter
-
Whether returning null is a valid response.
- allowNull() - Method in interface org.apache.camel.spi.BulkTypeConverters
- allowNull() - Method in interface org.apache.camel.TypeConverter
-
Whether the type converter allows returning null as a valid response.
- AlreadyStoppedException - Exception Class in org.apache.camel
-
Exception thrown in situations when a
Service
has already been stopped. - AlreadyStoppedException() - Constructor for exception class org.apache.camel.AlreadyStoppedException
- alternativeSyntax() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
If the endpoint supports specifying username and/or password in the UserInfo part of the URI, then the alternative syntax can represent this such as: ftp:userName:password@host:port/directoryName ssh:username:password@host:port
- Always - Enum constant in enum class org.apache.camel.WaitForTaskToComplete
- AnnotationBasedProcessorFactory - Interface in org.apache.camel.spi
-
Factory to create
Processor
for annotation based EIPs. - annotations() - Element in annotation interface org.apache.camel.spi.Metadata
-
Annotations data for Camel concepts such as components, EIP, etc.
- AnnotationScanTypeConverters - Interface in org.apache.camel.spi
-
A
TypeConverter
which is capable of annotation scanning forConverter
classes and add these as type converters. - any() - Static method in interface org.apache.camel.spi.ComponentCustomizer.Policy
-
A simple allow-all policy.
- any() - Static method in interface org.apache.camel.spi.DataFormatCustomizer.Policy
-
A simple allow-all policy.
- any() - Static method in interface org.apache.camel.spi.LanguageCustomizer.Policy
-
A simple allow-all policy.
- ANY - Static variable in class org.apache.camel.spi.DataType
- ANY_TYPE_URN - Static variable in class org.apache.camel.spi.DataType
- API - Enum constant in enum class org.apache.camel.Category
- apiDocAsJson() - Method in interface org.apache.camel.spi.RestRegistry
-
Outputs the Rest services API documentation in JSON (requires camel-openapi-java on classpath)
- ApiEndpoint - Interface in org.apache.camel
-
Marks the
Endpoint
as an endpoint from an API based component. - ApiMethod - Annotation Interface in org.apache.camel.spi
-
Represents an API method as part of a parent API.
- apiMethods() - Element in annotation interface org.apache.camel.spi.ApiParam
-
The API methods that the API provides of this configuration class.
- apiMethods() - Element in annotation interface org.apache.camel.spi.ApiParams
-
The API methods that the API provides of this configuration class.
- apiName() - Element in annotation interface org.apache.camel.spi.ApiParams
-
The API name (grouping) of this configuration class.
- ApiParam - Annotation Interface in org.apache.camel.spi
-
Used for annotating a
UriParam
parameter that its for use by API based endpoints. - ApiParams - Annotation Interface in org.apache.camel.spi
-
Used to annotate a nested configuration parameter type (such as a nested Configuration object) which can then be used on a API based component, endpoint.
- apiSyntax() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
The name of the properties that is used in the endpoint URI to select which API name (method) to use.
- applicableFor() - Element in annotation interface org.apache.camel.spi.Metadata
-
Indicates the list of schemes for which this metadata is applicable.
- APPLICATION_OCTET_STREAM_MIME_TYPE - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- apply(String) - Method in interface org.apache.camel.spi.PropertiesFunction
-
Applies the function.
- apply(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceLoadBalancerFunction
-
Deprecated.
- apply(Exchange, List<ServiceDefinition>) - Method in interface org.apache.camel.cloud.ServiceFilter
-
Deprecated.Chooses service candidates to use
- 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 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.
- asAttribute(String) - Static method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
Convert a string to an
ComponentVerifierExtension.VerificationError.Attribute
- asCode(String) - Static method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
Convert a string to an
ComponentVerifierExtension.VerificationError.Code
- asDate() - Method in interface org.apache.camel.clock.Clock
-
Get the creation date/time as regular Java Date instance
- asDate(ContextEvents, Date) - Method in class org.apache.camel.clock.ContextClock
-
Get the time for the event as a Date object
- asDuration() - Method in interface org.apache.camel.clock.Clock
-
Get the elapsed duration for this clock in the standard Java Duration
- asEndpointUri(String, Map<String, String>, boolean) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
-
Creates an endpoint uri in Java style from the information from the properties
- AsEndpointUri - Annotation Interface in org.apache.camel.spi
-
Indicates that the Camel string/expression should be used as an endpoint uri.
- asEnum(String) - Static method in enum class org.apache.camel.ExchangePattern
- asExchangePropertyKey(String) - Static method in enum class org.apache.camel.ExchangePropertyKey
- asJSon() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The event message as an org.apache.camel.util.json.JsonObject object.
- AsPredicate - Annotation Interface in org.apache.camel.spi
-
Indicates that the Camel language/expression should be used as predicate.
- assemble(MBeanServer, Object, ObjectName) - Method in interface org.apache.camel.spi.ManagementMBeanAssembler
-
Assemble the
ModelMBean
. - ASYNC_WAIT - Static variable in interface org.apache.camel.Exchange
- AsyncCallback - Interface in org.apache.camel
-
The callback interface for an
AsyncProcessor
so that it can notify you when anExchange
is done. - AsyncEndpoint - Interface in org.apache.camel
-
Marks the
Endpoint
as support asynchronous non-blocking routing in its consumer and producer. - AsyncProcessor - Interface in org.apache.camel
-
An asynchronous processor which can process an
Exchange
in an asynchronous fashion and signal completion by invoking theAsyncCallback
. - AsyncProcessorAwaitManager - Interface in org.apache.camel.spi
-
A manager to handle async routing engine, when
Exchange
s are being handed over from one thread to another, while the callee thread is blocked waiting for the other threads to complete, before it can continue. - AsyncProcessorAwaitManager.AwaitThread - Interface in org.apache.camel.spi
-
Information about the thread and exchange that are inflight.
- AsyncProcessorAwaitManager.Statistics - Interface in org.apache.camel.spi
-
Utilization statistics of this manager.
- AsyncProducer - Interface in org.apache.camel
-
Asynchronous producer
- asyncRequest() - Method in interface org.apache.camel.FluentProducerTemplate
-
Sends asynchronously to the given endpoint (InOut).
- asyncRequest(Class<T>) - Method in interface org.apache.camel.FluentProducerTemplate
-
Sends asynchronously to the given endpoint (InOut).
- 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 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 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() - Method in interface org.apache.camel.FluentProducerTemplate
-
Sends asynchronously to the given endpoint (InOnly).
- 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 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.
- asyncSendExchange(Endpoint, ExchangePattern, Processor, Processor, Exchange, CompletableFuture<Exchange>) - Method in interface org.apache.camel.spi.ProducerCache
-
Asynchronously sends an exchange to an endpoint using a supplied
Processor
to populate the exchange - asZonedCreationDateTime() - Method in interface org.apache.camel.clock.Clock
-
Get the creation date/time as with time-zone information
- attach() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Attach the debugger which will resume the message processing in case the suspend mode is enabled.
- attribute(String) - Method in interface org.apache.camel.cloudevents.CloudEvent
-
Find attribute by id.
- attributes() - Method in interface org.apache.camel.cloudevents.CloudEvent
-
List of supported attributes.
- attributes() - Method in enum class org.apache.camel.cloudevents.CloudEvents
- AUTHENTICATION - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
Authentication failed
- AUTHENTICATION - Static variable in interface org.apache.camel.Exchange
- AUTHENTICATION_FAILURE_POLICY_ID - Static variable in interface org.apache.camel.Exchange
- AuthorizationPolicy - Interface in org.apache.camel.spi
-
A marker for defining the policy to be used for applying authorization to routes.
- auto - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestBindingMode
- autowired() - Element in annotation interface org.apache.camel.spi.Metadata
-
Whether to parameter can be configured as autowired
- AutowiredLifecycleStrategy - Interface in org.apache.camel.spi
-
Marker interface for
LifecycleStrategy
that are used for auto-wiring components, data formats and languages. - AVRO - Enum constant in enum class org.apache.camel.spi.MimeType
- AVRO_BINARY - Enum constant in enum class org.apache.camel.spi.MimeType
- AVRO_JAVA_OBJECT - Enum constant in enum class org.apache.camel.spi.MimeType
- AVRO_STRUCT - Enum constant in enum class org.apache.camel.spi.MimeType
- awaitTermination(ExecutorService, long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Awaits the termination of the thread pool.
- aws() - Method in class org.apache.camel.vault.VaultConfiguration
-
AWS Vault Configuration
- AwsVaultConfiguration - Class in org.apache.camel.vault
-
Configuration for access to AWS Secret.
- AwsVaultConfiguration() - Constructor for class org.apache.camel.vault.AwsVaultConfiguration
- azure() - Method in class org.apache.camel.vault.VaultConfiguration
-
Azure Vault Configuration
- AzureVaultConfiguration - Class in org.apache.camel.vault
-
Configuration for access to Azure Key Vault.
- AzureVaultConfiguration() - Constructor for class org.apache.camel.vault.AzureVaultConfiguration
B
- BacklogDebugger - Interface in org.apache.camel.spi
-
A
Debugger
that has easy debugging functionality which can be used from JMX withinvalid reference
org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
- BacklogTracer - Interface in org.apache.camel.spi
-
Backlog tracer that captures the last N messages during routing in a backlog.
- BacklogTracerEventMessage - Interface in org.apache.camel.spi
-
Represents a traced message by the BacklogTracer.
- BaseService - Class in org.apache.camel.support.service
-
A useful base class which ensures that a service is only initialized once and provides some helper methods for enquiring of its status.
- BaseService() - Constructor for class org.apache.camel.support.service.BaseService
- BaseSSLContextParameters - Class in org.apache.camel.support.jsse
-
Represents configuration options that can be applied in the client-side or server-side context depending on what they are applied to.
- BaseSSLContextParameters() - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters
- BaseSSLContextParameters.Configurer<T> - Interface in org.apache.camel.support.jsse
-
Configures a
T
based on the related configuration options. - BaseSSLContextParameters.SSLContextDecorator - Class in org.apache.camel.support.jsse
-
Makes a decorated
SSLContext
appear as a normalSSLContext
. - BaseSSLContextParameters.SSLContextSpiDecorator - Class in org.apache.camel.support.jsse
-
Class needed to provide decoration of an existing
SSLContext
. - BaseSSLContextParameters.SSLServerSocketFactoryDecorator - Class in org.apache.camel.support.jsse
-
A decorator that enables the application of configuration options to be applied to created sockets even after this factory has been created and turned over to client code.
- BaseSSLContextParameters.SSLSocketFactoryDecorator - Class in org.apache.camel.support.jsse
-
A decorator that enables the application of configuration options to be applied to created sockets even after this factory has been created and turned over to client code.
- BATCH_COMPLETE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- BATCH_COMPLETE - Static variable in interface org.apache.camel.Exchange
- BATCH_INDEX - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- BATCH_INDEX - Static variable in interface org.apache.camel.Exchange
- BATCH_SIZE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- 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
- BEAN_METHOD_NAME - Static variable in interface org.apache.camel.Exchange
- BeanConfigInject - Annotation Interface in org.apache.camel
-
Used to indicate an injection point of a configuration bean (obtained from the
Registry
, or a new instance is created) into a POJO. - BeanInject - Annotation Interface in org.apache.camel
-
Used to indicate an injection point of a bean obtained from the
Registry
, into a POJO. - BeanIntrospection - Interface in org.apache.camel.spi
-
Used for introspecting beans properties via Java reflection; such as extracting current property values, or updating one or more properties etc.
- BeanIntrospection.ClassInfo - Class in org.apache.camel.spi
-
Structure of an introspected class.
- BeanIntrospection.MethodInfo - Class in org.apache.camel.spi
-
Structure of an introspected method.
- beanPostProcess() - Element in annotation interface org.apache.camel.BindToRegistry
-
Whether to perform bean post-processing (dependency injection) on the bean
- BeanProcessorFactory - Interface in org.apache.camel.spi
-
Factory for creating a
Processor
that can invoke a method on a bean and supporting using Camel bean parameter bindings. - BeanProxyFactory - Interface in org.apache.camel.spi
-
A factory for creating a
Proxy
for a bean. - BeanRepository - Interface in org.apache.camel.spi
-
Represents a bean repository used to lookup components by name and type.
- BeanScope - Enum Class in org.apache.camel
- before(Exchange) - Method in interface org.apache.camel.spi.CamelInternalProcessorAdvice
-
Callback executed before processing a step in the route.
- before(Exchange) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
- beforeHandover(Exchange) - Method in interface org.apache.camel.spi.SynchronizationVetoable
-
A method to perform optional housekeeping when a Synchronization is being handed over.
- beforePoll(long) - Method in interface org.apache.camel.PollingConsumerPollingStrategy
-
Callback invoked before the poll.
- beforeProcess(Exchange, Processor, NamedNode) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Callback invoked before hitting a breakpoint
- beforeProcess(Exchange, Processor, NamedNode) - Method in interface org.apache.camel.spi.Breakpoint
-
Callback invoked when the breakpoint was hit and the
Exchange
is about to be processed (before). - beforeProcess(Exchange, Processor, NamedNode) - Method in interface org.apache.camel.spi.Debugger
-
Callback invoked when an
Exchange
is about to be processed which allows implementators to notify breakpoints. - beforeProcess(Processor, Exchange, AsyncCallback) - Method in interface org.apache.camel.spi.UnitOfWork
-
Strategy for work to be executed before processing.
- beforeRoute(Exchange, Route) - Method in interface org.apache.camel.spi.UnitOfWork
-
Invoked when this unit of work is about to be routed by the given route.
- beforeWrap(Route, NamedNode) - Method in interface org.apache.camel.spi.Policy
-
Hook invoked before the wrap.
- begin(Consumer, Endpoint) - Method in interface org.apache.camel.spi.PollingConsumerPollStrategy
-
Called when poll is about to begin
- beginStep(Class<?>, String, String) - Method in interface org.apache.camel.spi.StartupStepRecorder
-
Beings a new step.
- beginTransactedBy(Object) - Method in interface org.apache.camel.spi.UnitOfWork
-
Mark this UnitOfWork as being transacted by the given transaction key.
- BIGDATA - Enum constant in enum class org.apache.camel.Category
- BINARY - Enum constant in enum class org.apache.camel.spi.MimeType
- BinaryPredicate - Interface in org.apache.camel
-
A predicate which evaluates a binary expression.
- bind(String, Class<?>, Object) - Method in interface org.apache.camel.RouteTemplateContext
-
Binds the bean to the repository (if possible).
- bind(String, Class<?>, Object) - Method in interface org.apache.camel.spi.Registry
-
Binds the bean to the repository (if possible).
- bind(String, Class<?>, Object, String, String) - Method in interface org.apache.camel.spi.Registry
-
Binds the bean to the repository (if possible).
- bind(String, Class<?>, Supplier<Object>) - Method in interface org.apache.camel.RouteTemplateContext
-
Binds the bean (via a supplier) to the repository (if possible).
- bind(String, Class<?>, Supplier<Object>) - Method in interface org.apache.camel.spi.Registry
-
Binds the bean (via a supplier) to the repository (if possible).
- bind(String, Object) - Method in interface org.apache.camel.RouteTemplateContext
-
Binds the bean to the repository (if possible).
- bind(String, Object) - Method in interface org.apache.camel.spi.Registry
-
Binds the bean to the repository (if possible).
- bind(String, Object, String, String) - Method in interface org.apache.camel.spi.Registry
-
Binds the bean to the repository (if possible).
- bindAsPrototype(String, Class<?>, Supplier<Object>) - Method in interface org.apache.camel.RouteTemplateContext
-
Binds the bean (via a supplier) to the repository (if possible).
- bindAsPrototype(String, Class<?>, Supplier<Object>) - Method in interface org.apache.camel.spi.Registry
-
Binds the bean (via a supplier) to the repository (if possible).
- binding() - Element in annotation interface org.apache.camel.Produce
-
Whether to use bean parameter binding
- BINDING - Static variable in interface org.apache.camel.Exchange
- BindToRegistry - Annotation Interface in org.apache.camel
-
Used for binding a bean to the registry.
- BLOCKCHAIN - Enum constant in enum class org.apache.camel.Category
- body() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationError
-
Returns the value of the
body
record component. - Body - Annotation Interface in org.apache.camel
-
Marks a parameter as being the body of an inbound
Message
- bootstrap() - Element in annotation interface org.apache.camel.spi.Configurer
-
Whether this configurer is only used during bootstrap
- BootstrapCloseable - Interface in org.apache.camel.spi
-
A marker interface for a service, or other kind of process that is only used during bootstrapping Camel.
- BREADCRUMB_ID - Static variable in interface org.apache.camel.Exchange
- Breakpoint - Interface in org.apache.camel.spi
-
Breakpoint
are used by theDebugger
API. - BREAKPOINT_ALL_ROUTES - Static variable in interface org.apache.camel.spi.BacklogDebugger
-
Special breakpoint id token to automatically add breakpoint for every route.
- Breakpoint.State - Enum Class in org.apache.camel.spi
-
State of the breakpoint as either active or suspended.
- Brief - Enum constant in enum class org.apache.camel.StartupSummaryLevel
- 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. - BrowsableVariableRepository - Interface in org.apache.camel.spi
-
A
VariableRepository
that can browse the variables. - browse() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
A read-only browser of the
AsyncProcessorAwaitManager.AwaitThread
s that are currently inflight. - browse() - Method in interface org.apache.camel.spi.InflightRepository
-
A read-only browser of the
InflightRepository.InflightExchange
s that are currently inflight. - browse(int, boolean) - Method in interface org.apache.camel.spi.InflightRepository
-
A read-only browser of the
InflightRepository.InflightExchange
s that are currently inflight. - browse(String) - Method in interface org.apache.camel.spi.InflightRepository
-
A read-only browser of the
InflightRepository.InflightExchange
s that are currently inflight that started from the given route. - browse(String, int, boolean) - Method in interface org.apache.camel.spi.InflightRepository
-
A read-only browser of the
InflightRepository.InflightExchange
s that are currently inflight that started from the given route. - build() - Method in interface org.apache.camel.Builder
- build() - Method in interface org.apache.camel.CamelContextLifecycle
-
Builds the CamelContext.
- build() - Method in class org.apache.camel.health.HealthCheckResultBuilder
- build() - Method in interface org.apache.camel.resume.ResumeStrategyConfigurationBuilder
-
Builds the resume strategy configuration
- build() - Method in interface org.apache.camel.Service
-
Optional build phase which is executed by frameworks that supports pre-building projects (pre-compile) which allows special optimizations such as camel-quarkus.
- build() - Method in class org.apache.camel.support.service.BaseService
- build(ThrowingBiConsumer<String, T, Exception>) - Method in class org.apache.camel.spi.ComponentCustomizer.Builder
- build(ThrowingBiConsumer<String, T, Exception>) - Method in class org.apache.camel.spi.DataFormatCustomizer.Builder
- build(ThrowingBiConsumer<String, T, Exception>) - Method in class org.apache.camel.spi.LanguageCustomizer.Builder
- build(ThrowingConsumer<T, Exception>) - Method in class org.apache.camel.spi.ComponentCustomizer.Builder
- build(ThrowingConsumer<T, Exception>) - Method in class org.apache.camel.spi.DataFormatCustomizer.Builder
- build(ThrowingConsumer<T, Exception>) - Method in class org.apache.camel.spi.LanguageCustomizer.Builder
- builder() - Static method in interface org.apache.camel.spi.ComponentCustomizer
-
Create a generic
ComponentCustomizer.Builder
. - builder() - Static method in interface org.apache.camel.spi.DataFormatCustomizer
-
Create a generic
DataFormatCustomizer.Builder
. - builder() - Static method in interface org.apache.camel.spi.LanguageCustomizer
-
Create a generic
LanguageCustomizer.Builder
. - builder(Class<T>) - Static method in interface org.apache.camel.spi.ComponentCustomizer
-
Create a typed
ComponentCustomizer.Builder
that can process a concrete component type instance. - builder(Class<T>) - Static method in interface org.apache.camel.spi.DataFormatCustomizer
-
Create a typed
DataFormatCustomizer.Builder
that can process a concrete data format type instance. - builder(Class<T>) - Static method in interface org.apache.camel.spi.LanguageCustomizer
-
Create a typed
LanguageCustomizer.Builder
that can process a concrete language type instance. - Builder<T> - Interface in org.apache.camel
- Builder(Class<T>) - Constructor for class org.apache.camel.spi.ComponentCustomizer.Builder
- Builder(Class<T>) - Constructor for class org.apache.camel.spi.DataFormatCustomizer.Builder
- Builder(Class<T>) - Constructor for class org.apache.camel.spi.LanguageCustomizer.Builder
- buildService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Builds the given
value
if it's aService
or a collection of it. - buildService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Builds each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - buildUri(String, Map<String, Object>) - Method in interface org.apache.camel.spi.EndpointUriFactory
-
Assembles an endpoint uri for the given component name with the given parameters.
- buildUri(String, Map<String, Object>, boolean) - Method in interface org.apache.camel.spi.EndpointUriFactory
-
Assembles an endpoint uri for the given component name with the given parameters.
- BUILT - Static variable in class org.apache.camel.support.service.BaseService
- BulkTypeConverters - Interface in org.apache.camel.spi
-
Bulk type converters that often comes out of the box with Apache Camel.
- BYTES - Static variable in interface org.apache.camel.resume.Serializable
C
- cache(Object) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Caches the value aas a
StreamCache
. - cache(Exchange) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Caches the body aas a
StreamCache
. - cache(Message) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Caches the body aas a
StreamCache
. - CACHE - Enum constant in enum class org.apache.camel.Category
- Cacheable - Interface in org.apache.camel.resume
-
Used to identify objects that can cache their resume state or data
- Cacheable.FillPolicy - Enum Class in org.apache.camel.resume
-
The cache fill policy can be used to determine how this cache should be filled with data.
- cacheClass(Class<?>) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Introspects the given class.
- cacheSize() - Element in annotation interface org.apache.camel.DynamicRouter
-
Sets the maximum size used by the
ProducerCache
which is used to cache and reuse producers when using this dynamic router, when uris are reused. - cacheSize() - Element in annotation interface org.apache.camel.RecipientList
-
Sets the maximum size used by the
ProducerCache
which is used to cache and reuse producers when using this recipient list, when uris are reused. - cacheSize() - Element in annotation interface org.apache.camel.RoutingSlip
-
Sets the maximum size used by the
ProducerCache
which is used to cache and reuse producers when using this routing slip, when uris are reused. - call() - Method in interface org.apache.camel.health.HealthCheck
-
Invoke the check.
- call(Map<String, Object>) - Method in interface org.apache.camel.health.HealthCheck
-
Invoke the check.
- call(DevConsole.MediaType) - Method in interface org.apache.camel.console.DevConsole
-
Invokes and gets the output from this console.
- call(DevConsole.MediaType, Map<String, Object>) - Method in interface org.apache.camel.console.DevConsole
-
Invokes and gets the output from this console.
- callLiveness() - Method in interface org.apache.camel.health.HealthCheck
-
Invoke the check as liveness check.
- callReadiness() - Method in interface org.apache.camel.health.HealthCheck
-
Invoke the check as readiness check.
- CAMEL_CLOUD_EVENT_CONTENT_TYPE - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_DATA_CONTENT_ENCODING - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_DATA_CONTENT_TYPE - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_EXTENSIONS - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_ID - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_SCHEMA_URL - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_SOURCE - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_SUBJECT - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_TIME - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_TYPE - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_TYPE_VERSION - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_CLOUD_EVENT_VERSION - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- CAMEL_LANGCHAIN4J_EMBEDDING_VECTOR - Static variable in interface org.apache.camel.ai.CamelLangchain4jAttributes
- CamelAuthorizationException - Exception Class in org.apache.camel
-
An exception thrown for either authentication or authorization errors occurring in a Camel exchange.
- CamelAuthorizationException(String, Exchange) - Constructor for exception class org.apache.camel.CamelAuthorizationException
- CamelAuthorizationException(String, Exchange, Throwable) - Constructor for exception class org.apache.camel.CamelAuthorizationException
- CamelBeanPostProcessor - Interface in org.apache.camel.spi
-
Bean post processor.
- CamelBeanPostProcessorInjector - Interface in org.apache.camel.spi
-
Used for custom injection when doing
CamelBeanPostProcessor
bean post-processing. - CamelClusterEventListener - Interface in org.apache.camel.cluster
-
Marker interface for cluster events
- CamelClusterEventListener.Leadership - Interface in org.apache.camel.cluster
- CamelClusterEventListener.Membership - Interface in org.apache.camel.cluster
- CamelClusterMember - Interface in org.apache.camel.cluster
- CamelClusterService - Interface in org.apache.camel.cluster
- CamelClusterService.Selector - Interface in org.apache.camel.cluster
- CamelClusterView - Interface in org.apache.camel.cluster
-
Represents the View of the cluster at some given period of time.
- CamelConfiguration - Interface in org.apache.camel
-
Configuration class for Camel applications.
- CamelContext - Interface in org.apache.camel
-
Interface used to represent the CamelContext 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 the
CamelContext
- CamelContextCustomizer - Interface in org.apache.camel.spi
-
To apply custom configurations to
CamelContext
instances. - CamelContextInitialized - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextInitializing - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextLifecycle - Interface in org.apache.camel
-
Lifecycle API for
CamelContext
. - CamelContextNameStrategy - Interface in org.apache.camel.spi
-
Strategy for assigning name to a
CamelContext
. - CamelContextReloaded - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextReloadFailure - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextReloading - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextResumed - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextResumeFailure - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextResuming - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextStarted - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextStarting - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextStartupFailure - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextStopFailure - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextStopped - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextStopping - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextSuspended - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextSuspending - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CamelContextTracker - Class in org.apache.camel.spi
-
A
CamelContext
creation and destruction tracker. - CamelContextTracker() - Constructor for class org.apache.camel.spi.CamelContextTracker
- CamelContextTracker(CamelContextTracker.Filter) - Constructor for class org.apache.camel.spi.CamelContextTracker
- CamelContextTracker.Filter - Interface in org.apache.camel.spi
- CamelDependencyInjectionAnnotationFactory - Interface in org.apache.camel.spi
-
A factory which performs the task from Camel dependency injection annotations on a field, property or method parameter of a specified type.
- CamelEvent - Interface in org.apache.camel.spi
-
This interface is implemented by all events.
- CamelEvent.CamelContextEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextInitializedEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextInitializingEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextReloadedEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextReloadFailureEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextReloadingEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextResumedEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextResumeFailureEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextResumingEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextRoutesStartedEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextRoutesStartingEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextRoutesStoppedEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextRoutesStoppingEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextStartedEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextStartingEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextStartupFailureEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextStopFailureEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextStoppedEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextStoppingEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextSuspendedEvent - Interface in org.apache.camel.spi
- CamelEvent.CamelContextSuspendingEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeAsyncProcessingStartedEvent - Interface in org.apache.camel.spi
-
Special event only in use for camel-tracing / camel-opentelemetry.
- CamelEvent.ExchangeCompletedEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeCreatedEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeFailedEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeFailureEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeFailureHandledEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeFailureHandlingEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeRedeliveryEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeSendingEvent - Interface in org.apache.camel.spi
- CamelEvent.ExchangeSentEvent - Interface in org.apache.camel.spi
- CamelEvent.FailureEvent - Interface in org.apache.camel.spi
-
This interface is implemented by all events that contain an exception and is used to retrieve the exception in a universal way.
- CamelEvent.RouteAddedEvent - Interface in org.apache.camel.spi
- CamelEvent.RouteEvent - Interface in org.apache.camel.spi
- CamelEvent.RouteReloadedEvent - Interface in org.apache.camel.spi
- CamelEvent.RouteRemovedEvent - Interface in org.apache.camel.spi
- CamelEvent.RouteStartedEvent - Interface in org.apache.camel.spi
- CamelEvent.RouteStartingEvent - Interface in org.apache.camel.spi
- CamelEvent.RouteStoppedEvent - Interface in org.apache.camel.spi
- CamelEvent.RouteStoppingEvent - Interface in org.apache.camel.spi
- CamelEvent.ServiceEvent - Interface in org.apache.camel.spi
- CamelEvent.ServiceStartupFailureEvent - Interface in org.apache.camel.spi
- CamelEvent.ServiceStopFailureEvent - Interface in org.apache.camel.spi
- CamelEvent.StepCompletedEvent - Interface in org.apache.camel.spi
- CamelEvent.StepEvent - Interface in org.apache.camel.spi
- CamelEvent.StepFailedEvent - Interface in org.apache.camel.spi
- CamelEvent.StepStartedEvent - Interface in org.apache.camel.spi
- CamelEvent.Type - Enum Class in org.apache.camel.spi
- CamelException - Exception Class in org.apache.camel
-
Base class for all Camel checked exceptions typically thrown by a
Processor
- CamelException() - Constructor for exception class org.apache.camel.CamelException
- CamelException(String) - Constructor for exception class org.apache.camel.CamelException
- CamelException(String, Throwable) - Constructor for exception class org.apache.camel.CamelException
- CamelException(Throwable) - Constructor for exception class org.apache.camel.CamelException
- CamelExchangeException - Exception Class in org.apache.camel
-
An exception caused by a specific message
Exchange
- CamelExchangeException(String, Exchange) - Constructor for exception class org.apache.camel.CamelExchangeException
- CamelExchangeException(String, Exchange, Throwable) - Constructor for exception class org.apache.camel.CamelExchangeException
- CamelExecutionException - Exception Class in org.apache.camel
-
Exception occurred during execution/processing of an
Exchange
. - CamelExecutionException(String, Exchange) - Constructor for exception class org.apache.camel.CamelExecutionException
- CamelExecutionException(String, Exchange, Throwable) - Constructor for exception class org.apache.camel.CamelExecutionException
- CamelInternalProcessorAdvice<T> - Interface in org.apache.camel.spi
-
An advice (before and after) to execute cross-cutting functionality in the Camel routing engine.
- CamelLangchain4jAttributes - Interface in org.apache.camel.ai
-
Common Langchain4j Attributes shared by multiple components
- CamelLogger - Class in org.apache.camel.spi
-
A logger which logs to a slf4j
Logger
. - CamelLogger() - Constructor for class org.apache.camel.spi.CamelLogger
- CamelLogger(String) - Constructor for class org.apache.camel.spi.CamelLogger
- CamelLogger(String, LoggingLevel) - Constructor for class org.apache.camel.spi.CamelLogger
- CamelLogger(String, LoggingLevel, String) - Constructor for class org.apache.camel.spi.CamelLogger
- CamelLogger(Logger) - Constructor for class org.apache.camel.spi.CamelLogger
- CamelLogger(Logger, LoggingLevel) - Constructor for class org.apache.camel.spi.CamelLogger
- CamelLogger(Logger, LoggingLevel, String) - Constructor for class org.apache.camel.spi.CamelLogger
- CamelMetricsService - Interface in org.apache.camel.spi
-
A Camel metrics service is a factory for micrometer metrics.
- CamelPreemptiveClusterService - Interface in org.apache.camel.cluster
- CamelPreemptiveClusterView - Interface in org.apache.camel.cluster
-
A
CamelPreemptiveClusterView
is aCamelClusterView
that can be externally disabled by another controller. - CamelTracingService - Interface in org.apache.camel.spi
-
A Camel tracing service is a factory for telemetry tracers.
- CamelUnitOfWorkException - Exception Class in org.apache.camel
-
A
UnitOfWork
failed with a number of caused exceptions. - CamelUnitOfWorkException(Exchange, List<Exception>) - Constructor for exception class org.apache.camel.CamelUnitOfWorkException
- canIntercept() - Method in interface org.apache.camel.spi.InterceptableProcessor
-
Whether the processor can be intercepted or not.
- canPreComplete() - Method in interface org.apache.camel.AggregationStrategy
-
Indicates if this aggregation strategy uses pre-completion mode.
- capacity() - Method in interface org.apache.camel.resume.cache.ResumeCache
-
Gets the cache pool size
- CatalogCamelContext - Interface in org.apache.camel
-
Catalog level interface for the
CamelContext
- category() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
To associate this endpoint with category(ies).
- Category - Enum Class in org.apache.camel
-
This enum set various categories options into the UriEndpoint.
- changeOutput(Processor) - Method in interface org.apache.camel.spi.ErrorHandlerRedeliveryCustomizer
-
Allows to change the output of the error handler which are used when optimising the JMX instrumentation to use either an advice or wrapped processor when calling a processor.
- Channel - Interface in org.apache.camel
-
Channel acts as a channel between
Processor
s in the route graph. - CHARSET_NAME - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CHARSET_NAME - Static variable in interface org.apache.camel.Exchange
- CHAT - Enum constant in enum class org.apache.camel.Category
- CHECK_ENABLED - Static variable in interface org.apache.camel.health.HealthCheck
- CHECK_GROUP - Static variable in interface org.apache.camel.health.HealthCheck
- CHECK_ID - Static variable in interface org.apache.camel.health.HealthCheck
- CHECK_KIND - Static variable in interface org.apache.camel.health.HealthCheck
- choose(List<ServiceDefinition>) - Method in interface org.apache.camel.cloud.ServiceChooser
-
Deprecated.Chooses one of the service to use
- chooseClientAlias(String[], Principal[], Socket) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
- chooseEngineClientAlias(String[], Principal[], SSLEngine) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
- chooseEngineServerAlias(String, Principal[], SSLEngine) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
- chooseServerAlias(String, Principal[], Socket) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
- CipherSuitesParameters - Class in org.apache.camel.support.jsse
-
Represents a list of TLS/SSL cipher suite names.
- CipherSuitesParameters() - Constructor for class org.apache.camel.support.jsse.CipherSuitesParameters
- CIRCUIT_BREAKER_RESPONSE_FROM_FALLBACK - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CIRCUIT_BREAKER_RESPONSE_REJECTED - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CIRCUIT_BREAKER_RESPONSE_SHORT_CIRCUITED - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CIRCUIT_BREAKER_RESPONSE_SUCCESSFUL_EXECUTION - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CIRCUIT_BREAKER_RESPONSE_TIMED_OUT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CIRCUIT_BREAKER_STATE - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- CircuitBreakerConstants - Interface in org.apache.camel.spi
- CLAIM_CHECK_REPOSITORY - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CLAIM_CHECK_REPOSITORY - Static variable in interface org.apache.camel.Exchange
- ClaimCheckRepository - Interface in org.apache.camel.spi
-
Access to a repository of keys to implement the Claim Check pattern.
- ClassInfo() - Constructor for class org.apache.camel.spi.BeanIntrospection.ClassInfo
- 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, Spring Boot, Quarkus, JBang etc.
- clazz - Variable in class org.apache.camel.spi.BeanIntrospection.ClassInfo
- cleanUp() - Method in interface org.apache.camel.ConsumerTemplate
-
Cleanup the cache (purging stale entries)
- cleanUp() - Method in interface org.apache.camel.FluentProducerTemplate
-
Cleanup the cache (purging stale entries)
- cleanUp() - Method in interface org.apache.camel.ProducerTemplate
-
Cleanup the cache (purging stale entries)
- cleanUp() - Method in interface org.apache.camel.spi.ConsumerCache
-
Cleanup the cache (purging stale entries)
- cleanUp() - Method in interface org.apache.camel.spi.EndpointRegistry
-
Cleanup the cache (purging stale entries)
- cleanUp() - Method in interface org.apache.camel.spi.ProducerCache
-
Cleanup the cache (purging stale entries)
- cleanUp() - Method in interface org.apache.camel.spi.TransformerRegistry
-
Cleanup the cache (purging stale entries)
- cleanUp() - Method in interface org.apache.camel.spi.ValidatorRegistry
-
Cleanup the cache (purging stale entries)
- clear() - Method in interface org.apache.camel.spi.BacklogTracer
-
Clears the backlog of traced messages.
- clear() - Method in interface org.apache.camel.spi.BrowsableVariableRepository
-
Removes all variables
- clear() - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Clear the repository.
- clear() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
-
Clears all information.
- clear() - Method in interface org.apache.camel.spi.FactoryFinder
-
Clear the resolver state from previous scans.
- clear() - Method in interface org.apache.camel.spi.IdempotentRepository
-
Clear the repository.
- clear() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Clears the registry
- clearBootstrapConfigurers() - Static method in class org.apache.camel.spi.ConfigurerStrategy
-
Clears the bootstrap configurers map.
- clearCache() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Clears the introspection cache.
- clearCache() - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
Clears and frees the internal cache.
- clearReifiers() - Static method in class org.apache.camel.spi.ReifierStrategy
-
DANGER: Clears the refifiers map.
- clearRouteModel() - Method in interface org.apache.camel.Route
-
Clears the route model when its no longer needed.
- CliConnector - Interface in org.apache.camel.spi
-
Local
CliConnector
that allows Camel CLI to manage local running Camel integrations. - CliConnectorFactory - Interface in org.apache.camel.spi
-
Factory for creating connector to CLI tooling.
- clientAuthentication - Variable in class org.apache.camel.support.jsse.SSLContextServerParameters
- ClientAuthentication - Enum Class in org.apache.camel.support.jsse
-
Represents the options for the client authentication settings of a server socket.
- Clock - Interface in org.apache.camel.clock
-
A clock abstraction used to track pass of time
- clone() - Method in class org.apache.camel.spi.ThreadPoolProfile
- cloneBuilder() - Method in interface org.apache.camel.ErrorHandlerFactory
-
Clones this factory so each route has its private builder to use, to avoid changes from one route to influence the others.
- close() - Method in interface org.apache.camel.CamelContextLifecycle
-
Closes (Shutdown) the CamelContext, which means it cannot be started again.
- close() - Method in interface org.apache.camel.Service
-
Delegates to
Service.stop()
so it can be used in try-with-resources expression. - close() - Method in class org.apache.camel.spi.CamelContextTracker
-
Closes the tracker so it not longer tracks.
- CLOSE_CLIENT_SCOPE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CLOSE_CLIENT_SCOPE - Static variable in interface org.apache.camel.Exchange
- CLOUD - Enum constant in enum class org.apache.camel.Category
- CloudEvent - Interface in org.apache.camel.cloudevents
- CloudEvent.Attribute - Interface in org.apache.camel.cloudevents
- CloudEvents - Enum Class in org.apache.camel.cloudevents
- CloudServiceFactory - Annotation Interface in org.apache.camel.spi.annotations
- CLUSTERING - Enum constant in enum class org.apache.camel.Category
- CMS - Enum constant in enum class org.apache.camel.Category
- commit(Consumer, Endpoint, int) - Method in interface org.apache.camel.spi.PollingConsumerPollStrategy
-
Called when poll is completed successfully
- Committed - Enum constant in enum class org.apache.camel.spi.StreamCachingStrategy.SpoolUsedHeapMemoryLimit
- compareTo(CamelContextCustomizer) - Method in interface org.apache.camel.spi.CamelContextCustomizer
- COMPILE_SCRIPT - Static variable in interface org.apache.camel.Exchange
- CompilePostProcessor - Interface in org.apache.camel.spi
-
Allows to plugin custom post processors that are processed after the DSL has loaded the source and compiled into a Java object.
- CompileStrategy - Interface in org.apache.camel.spi
-
Strategy for runtime compiled languages and DSLs.
- CompleteAllTasks - Enum constant in enum class org.apache.camel.ShutdownRunningTask
- CompleteCurrentTaskOnly - Enum constant in enum class org.apache.camel.ShutdownRunningTask
- Component - Interface in org.apache.camel
- Component - Annotation Interface in org.apache.camel.spi.annotations
- ComponentAware - Interface in org.apache.camel
-
An interface to represent an object which wishes to be injected with a
Component
. - ComponentCustomizer - Interface in org.apache.camel.spi
-
To apply custom configurations to
Component
instances. - ComponentCustomizer.Builder<T> - Class in org.apache.camel.spi
-
A fluent builder to create a
ComponentCustomizer
instance. - ComponentCustomizer.Policy - Interface in org.apache.camel.spi
-
Used as additional filer mechanism to control if customizers need to be applied or not.
- ComponentExtension - Interface in org.apache.camel.component.extension
-
Marker interface for component extensions.
- componentJSonSchema(String) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
-
Returns the component information as JSON format.
- ComponentNameResolver - Interface in org.apache.camel.spi
-
Discovers which components are available on the classpath.
- 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
invalid reference
org.apache.camel.impl.DefaultComponentResolver
- ComponentVerifierExtension - Interface in org.apache.camel.component.extension
-
Defines the interface used for validating component/endpoint parameters.
- ComponentVerifierExtension.Result - Interface in org.apache.camel.component.extension
-
The result of a verification
- ComponentVerifierExtension.Result.Status - Enum Class in org.apache.camel.component.extension
-
Status of the verification
- ComponentVerifierExtension.Scope - Enum Class in org.apache.camel.component.extension
-
The scope defines how the parameters should be verified.
- ComponentVerifierExtension.VerificationError - Interface in org.apache.camel.component.extension
-
This interface represents a detailed error in case when the verification fails.
- ComponentVerifierExtension.VerificationError.Attribute - Interface in org.apache.camel.component.extension
-
Interface defining an attribute which is a key for the detailed error messages.
- ComponentVerifierExtension.VerificationError.Code - Interface in org.apache.camel.component.extension
-
Interface defining an error code.
- ComponentVerifierExtension.VerificationError.ExceptionAttribute - Interface in org.apache.camel.component.extension
-
Attributes for details about an exception that was raised
- ComponentVerifierExtension.VerificationError.GroupAttribute - Interface in org.apache.camel.component.extension
-
Group related details
- ComponentVerifierExtension.VerificationError.HttpAttribute - Interface in org.apache.camel.component.extension
-
HTTP related error details
- ComponentVerifierExtension.VerificationError.StandardCode - Interface in org.apache.camel.component.extension
-
Standard set of error codes
- computeIfAbsent(K, Function<? super K, ? super Object>) - Method in interface org.apache.camel.resume.cache.ResumeCache
-
If the specified key is not present, compute its value from the mapping function (like Java's standard Map one)
- computeIfEnabled(LongSupplier, LongConsumer) - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
- computeIfPresent(K, BiFunction<? super K, ? super Object, ? super Object>) - Method in interface org.apache.camel.resume.cache.ResumeCache
-
If the specified key is present, compute a new value from the mapping function (like Java's standard Map one)
- Condition - Interface in org.apache.camel.spi
-
A condition to define when a given
Exchange
matches when is being routed. - Configuration - Annotation Interface in org.apache.camel
-
Marks the class as a
CamelConfiguration
class. - CONFIGURATION_ID_PROPERTY - Static variable in interface org.apache.camel.Route
- ConfigurationPropertiesValidationResult - Class in org.apache.camel.catalog
-
Details result of validating configuration properties (eg application.properties for camel-main).
- ConfigurationPropertiesValidationResult() - Constructor for class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- configure(String, Component) - Method in interface org.apache.camel.spi.ComponentCustomizer
-
Customize the specified
Component
. - configure(String, DataFormat) - Method in interface org.apache.camel.spi.DataFormatCustomizer
-
Customize the specified
DataFormat
. - configure(String, Language) - Method in interface org.apache.camel.spi.LanguageCustomizer
-
Customize the specified
Language
. - configure(CamelContext) - Method in interface org.apache.camel.CamelConfiguration
-
Method that allows to do custom configuration during Camel startup.
- configure(CamelContext) - Method in interface org.apache.camel.spi.CamelContextCustomizer
-
Configure the
CamelContext
. - configure(CamelContext, Object, String, Object, boolean) - Method in interface org.apache.camel.spi.PropertyConfigurer
-
Configures the property
- configure(Tokenizer.Configuration) - Method in interface org.apache.camel.spi.Tokenizer
-
Configures this tokenizer using the provided configuration options.
- configure(T) - Method in interface org.apache.camel.support.jsse.BaseSSLContextParameters.Configurer
-
Configures a
T
based on the related configuration options. - configureExchange(Exchange) - Method in interface org.apache.camel.Endpoint
-
Configures a newly created
Exchange
. - configureProperties(Map<String, Object>) - Method in interface org.apache.camel.Endpoint
-
Configure properties on this endpoint.
- Configurer - Annotation Interface in org.apache.camel.spi
-
An annotation used to mark classes to indicate code capable of configuring its options via a getter/setters that can be called via Camels
PropertyConfigurer
. - ConfigurerResolver - Interface in org.apache.camel.spi
-
A pluggable strategy for resolving different configurers in a loosely coupled manner
- ConfigurerStrategy - Class in org.apache.camel.spi
-
Strategy for configurers.
- ConfigurerStrategy() - Constructor for class org.apache.camel.spi.ConfigurerStrategy
- configureSessionContext(SSLSessionContext, String) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Configures a
SSLSessionContext
, client or server, with the supplied session timeout. - configureSSLContext(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Configures the actual
SSLContext
itself with direct setter calls. - configureSSLContext(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
- configureSSLContext(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
- configureSSLContext(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
- confirm(String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Confirms the key, after the exchange has been processed successfully.
- confirm(CamelContext, String) - Method in interface org.apache.camel.spi.AggregationRepository
-
Confirms the completion of the
Exchange
. - confirm(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Confirms the key, after the exchange has been processed successfully.
- confirmWithResult(CamelContext, String) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Confirms the completion of the
Exchange
with a result. - CONNECTIVITY - Enum constant in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Scope
-
Reach out to the backend and verify that a connection can be established.
- CONSOLE_GROUP - Static variable in interface org.apache.camel.console.DevConsole
- CONSOLE_ID - Static variable in interface org.apache.camel.console.DevConsole
- ConstantProvider - Annotation Interface in org.apache.camel.spi.annotations
-
Internal annotation to mark a class as having constant fields for the source code generator.
- Consume - Annotation Interface in org.apache.camel
- Consumer - Interface in org.apache.camel
-
A consumer of message exchanges from an
Endpoint
. - ConsumerCache - Interface in org.apache.camel.spi
-
Cache containing created
PollingConsumer
. - ConsumerListener<C,
P> - Interface in org.apache.camel.resume -
An interface for listening to consumer events and allow proxying between a consumer predicate and the Camel component.
- ConsumerListenerAware<T> - Interface in org.apache.camel.resume
-
An interface to represent an object which wishes to support listening for consumer events using the
ConsumerListener
. - consumerOnly() - Element in annotation interface org.apache.camel.spi.ApiParams
-
Whether this API can only be used as a consumer.
- consumerOnly() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
Whether this endpoint can only be used as a consumer.
- consumerPrefix() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
The configuration parameter name prefix used on parameter names to separate the endpoint properties from the consumer properties
- ConsumerTemplate - Interface in org.apache.camel
- consumes() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns the value of the
consumes
record component. - CONTAINER - Enum constant in enum class org.apache.camel.Category
- contains(String) - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Returns true if this repository contains the specified key.
- contains(String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Returns true if this repository contains the specified element.
- contains(K, Object) - Method in interface org.apache.camel.resume.cache.ResumeCache
-
Whether the cache contains the key with the given entry value
- contains(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Returns true if this repository contains the specified element.
- containsKey(Object) - Method in interface org.apache.camel.spi.EndpointRegistry
-
Whether the given endpoint is stored in the registry
- containsOnCompletion(Synchronization) - Method in interface org.apache.camel.ExchangeExtension
-
Checks if the passed
Synchronization
instance is already contained on this exchange. - containsSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
-
Checks if the passed synchronization hook is already part of this unit of work.
- CONTENT_ENCODING - Static variable in interface org.apache.camel.Exchange
- CONTENT_LENGTH - Static variable in interface org.apache.camel.Exchange
- CONTENT_SCHEMA - Static variable in interface org.apache.camel.Exchange
- CONTENT_SCHEMA_TYPE - Static variable in interface org.apache.camel.Exchange
- CONTENT_TYPE - Static variable in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
- CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
- ContentTypeAware - Interface in org.apache.camel.spi
-
Represents an object that can have an associated content type.
- CONTEXT - Static variable in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
- ContextClock - Class in org.apache.camel.clock
-
An event clock that tracks the pass of time for different types of context-related events (see
ContextEvents
) - ContextClock() - Constructor for class org.apache.camel.clock.ContextClock
- contextCreated(CamelContext) - Method in class org.apache.camel.spi.CamelContextTracker
-
Called when a context is created.
- contextDestroyed(CamelContext) - Method in class org.apache.camel.spi.CamelContextTracker
-
Called when a context has been shutdown.
- ContextEvents - Enum Class in org.apache.camel
-
Context events that can be traced by an
EventClock
- ContextOnly - Enum constant in enum class org.apache.camel.ManagementMBeansLevel
- ContextReloadStrategy - Interface in org.apache.camel.spi
-
SPI strategy for reloading
CamelContext
. - Contract - Class in org.apache.camel.spi
- Contract() - Constructor for class org.apache.camel.spi.Contract
- Converter - Annotation Interface 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
- convertTo(Class<?>, Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
-
Converts the value to the specified type in the context of an exchange
- convertTo(Class<T>, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
- 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.spi.BulkTypeConverters
- 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
- COOKIE_HANDLER - Static variable in interface org.apache.camel.Exchange
- 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 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(Exchange) - Method in interface org.apache.camel.StreamCache
-
Create a copy of the stream.
- copyFrom(Message) - Method in interface org.apache.camel.Message
-
Copies the contents of the other message into this message
- copyFromWithNewBody(Message, Object) - Method in interface org.apache.camel.Message
-
Copies the contents (except the body) of the other message into this message and uses the provided new body instead
- copyInternalProperties(Exchange) - Method in interface org.apache.camel.ExchangeExtension
-
To copy the internal properties from this exchange to the target exchange
- copySafeCopyPropertiesTo(ExchangeExtension) - Method in interface org.apache.camel.ExchangeExtension
-
Copy the safe copy properties from this exchange to the target exchange
- CORE - Enum constant in enum class org.apache.camel.Category
- CORRELATION_ID - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- CORRELATION_ID - Static variable in interface org.apache.camel.Exchange
- CORS_ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class org.apache.camel.spi.RestConfiguration
- CORS_ACCESS_CONTROL_ALLOW_METHODS - Static variable in class org.apache.camel.spi.RestConfiguration
- CORS_ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.apache.camel.spi.RestConfiguration
- CORS_ACCESS_CONTROL_MAX_AGE - Static variable in class org.apache.camel.spi.RestConfiguration
- create(boolean) - Method in interface org.apache.camel.spi.ExchangeFactory
-
Gets a new
Exchange
- create(CamelContext, Map<String, Object>) - Method in interface org.apache.camel.spi.ManagementStrategyFactory
-
Creates the
ManagementStrategy
. - create(Endpoint, boolean) - Method in interface org.apache.camel.spi.ExchangeFactory
-
Gets a new
Exchange
- create(Endpoint, ExchangePattern) - Method in interface org.apache.camel.spi.ProcessorExchangeFactory
-
Gets a new
Exchange
- createApiConsumer(CamelContext, Processor, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestApiConsumerFactory
-
Creates a new REST API Event Driven Consumer, which provides API listing of the REST services
- createApiProcessor(CamelContext, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestApiProcessorFactory
-
Creates a new REST API Processor , which provides API listing of the REST services
- createAsyncProducer() - Method in interface org.apache.camel.Endpoint
-
Creates a new producer which is used send messages into the endpoint Important: Do not do any initialization in the constructor of the
Producer
. - createBeanProcessor(CamelContext, Object, Method) - Method in interface org.apache.camel.spi.BeanProcessorFactory
-
Creates the bean processor from the existing bean instance
- createBeanProcessor(CamelContext, Object, String, Class<?>, String, String, BeanScope) - Method in interface org.apache.camel.spi.BeanProcessorFactory
-
Creates the bean processor from a given set of parameters that can refer to the bean via an existing bean, a reference to a bean, or its class name etc.
- createBindToRegistryFactory(String, Object, Class<?>, String, boolean, String, String) - Method in interface org.apache.camel.spi.CamelDependencyInjectionAnnotationFactory
-
The task for binding the bean to the registry (eg
annotation
- createCamelContextInitializedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel has been initialized successfully. - createCamelContextInitializingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel is initializing. - createCamelContextReloaded(CamelContext, Object) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forCamelContext
has been reloaded successfully. - createCamelContextReloadFailure(CamelContext, Object, Throwable) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forCamelContext
failed reload. - createCamelContextReloading(CamelContext, Object) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forCamelContext
being reloaded. - createCamelContextResumedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel has been resumed successfully. - createCamelContextResumeFailureEvent(CamelContext, Throwable) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel failing to resume - createCamelContextResumingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel is resuming. - createCamelContextRoutesStartedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel routes started. - createCamelContextRoutesStartingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel routes starting. - createCamelContextRoutesStoppedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel routes stopped. - createCamelContextRoutesStoppingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel routes stopping. - createCamelContextStartedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel has been started successfully. - createCamelContextStartingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel is starting. - createCamelContextStartupFailureEvent(CamelContext, Throwable) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel failing to start - createCamelContextStopFailureEvent(CamelContext, Throwable) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel failing to stop cleanly - createCamelContextStoppedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel has been stopped successfully. - createCamelContextStoppingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel is stopping. - createCamelContextSuspendedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel has been suspended successfully. - createCamelContextSuspendingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for Camel is suspending. - createCamelExchangeAsyncProcessingStartedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
asynchronous processing has been started. - createChannel(CamelContext) - Method in interface org.apache.camel.spi.InternalProcessorFactory
- createChildProcessor(Route, NamedNode, boolean) - Method in interface org.apache.camel.spi.ProcessorFactory
-
Creates the child processor.
- createChildUnitOfWork(Exchange) - Method in interface org.apache.camel.spi.UnitOfWork
-
Create a child unit of work, which is associated to this unit of work as its parent.
- createConnector() - Method in interface org.apache.camel.spi.CliConnectorFactory
-
Creates the connector which will be added as a
Service
toCamelContext
as the lifecycle to start and stop the connector. - createConsumer(CamelContext, Processor, String, String, String, String, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestConsumerFactory
-
Creates a new REST Event Driven Consumer, which consumes messages from the endpoint using the given processor
- createConsumer(CamelContext, Processor, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestOpenApiConsumerFactory
-
Creates a new REST Event Driven Consumer, which consumes messages from the endpoint using the given processor
- 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 Important: Do not do any initialization in the constructor of the
Consumer
. - createConsumerTemplate() - Method in interface org.apache.camel.CamelContext
-
Creates a new
ConsumerTemplate
which is started and therefore ready to use right away. - createConsumerTemplate(int) - Method in interface org.apache.camel.CamelContext
-
Creates a new
ConsumerTemplate
which is started and therefore ready to use right away. - createCopy(Exchange) - Method in interface org.apache.camel.spi.ProcessorExchangeFactory
-
Gets a copy of the given
Exchange
- createCopyWithProperties(CamelContext) - Method in interface org.apache.camel.ExchangeExtension
-
Create a new exchange copied from this, with the context set to the given context
- createCorrelatedCopy(Exchange, boolean) - Method in interface org.apache.camel.spi.ProcessorExchangeFactory
-
Gets a copy of the given
Exchange
and the copy is correlated to the source - CREATED_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- createDataFormat(String) - Method in interface org.apache.camel.CamelContext
-
Creates a new instance of the given data format given its name.
- createDataFormat(String, CamelContext) - Method in interface org.apache.camel.spi.DataFormatResolver
-
Creates the given data format given its name.
- createDataFormat(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the data format from the model.
- createDebugger(CamelContext) - Method in interface org.apache.camel.spi.DebuggerFactory
-
Creates the debugger.
- createDefaultErrorHandler() - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the default error handler.
- createDynamicRouter(CamelContext, DynamicRouter) - Method in interface org.apache.camel.spi.AnnotationBasedProcessorFactory
-
Creates dynamic router processor from the configured annotation.
- 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, Map<String, Object>) - 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.
- createErrorHandler(Route, ErrorHandlerFactory, Processor) - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the error handler using the factory for the route processor.
- createErrorHandler(Route, Processor) - Method in interface org.apache.camel.ExtendedCamelContext
-
Internal API for creating error handler.
- createErrorHandler(Route, Processor) - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the error handler for the route processor.
- createExceptionMessage(String, Exchange, Throwable) - Static method in exception class org.apache.camel.CamelExchangeException
-
Creates an exception message with the provided details.
- createExchange() - Method in interface org.apache.camel.Endpoint
-
Create a new exchange for communicating with this endpoint.
- createExchange(boolean) - Method in interface org.apache.camel.Consumer
-
Creates an
Exchange
that was consumed. - 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 anExchangePattern.InOnly
orExchangePattern.InOut
exchange - createExchangeCompletedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
has been completed successfully - createExchangeCreatedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
has been created - createExchangeFailedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
has failed - createExchangeFailureHandledEvent(Exchange, Processor, boolean, String) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
has failed but was handled by the Camel error handlers such as an dead letter channel, or a doTry .. doCatch block. - createExchangeFailureHandlingEvent(Exchange, Processor, boolean, String) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
has failed but is being handled by the Camel error handlers such as an dead letter channel, or a doTry .. doCatch block. - createExchangeRedeliveryEvent(Exchange, int) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
is about to be redelivered - createExchangeSendingEvent(Exchange, Endpoint) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
is about to be sent to the endpoint (eg before). - createExchangeSentEvent(Exchange, Endpoint, long) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when anExchange
has completely been sent to the endpoint (eg after). - createExpression(String) - Method in interface org.apache.camel.spi.Language
-
Creates an expression based on only the given string input
- createExpression(String, Object[]) - Method in interface org.apache.camel.spi.Language
-
Creates an expression based on the input with properties
- createExpression(CamelContext) - Method in interface org.apache.camel.ExpressionFactory
-
Creates an expression
- createExpression(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the expression from the model.
- createFluentProducerTemplate() - Method in interface org.apache.camel.CamelContext
-
Creates a new
FluentProducerTemplate
which is started and therefore ready to use right away. - createFluentProducerTemplate(int) - Method in interface org.apache.camel.CamelContext
-
Creates a new
FluentProducerTemplate
which is started and therefore ready to use right away. - createFrom(Transformer) - Static method in class org.apache.camel.spi.TransformerKey
-
Create the transformer key for the given transformer either using the transformer name or it's specified from/to data type name.
- createId(NamedNode) - Method in interface org.apache.camel.spi.NodeIdFactory
-
Creates an id for the given model definition.
- createInterceptSendToEndpoint(CamelContext, Endpoint, boolean, Processor, Processor) - Method in interface org.apache.camel.spi.InterceptEndpointFactory
-
Creates an endpoint when intercepting sending to an endpoint (detour).
- createInterceptSendToEndpointProcessor(InterceptSendToEndpoint, Endpoint, AsyncProducer, boolean) - Method in interface org.apache.camel.spi.InternalProcessorFactory
- createKeyManagers() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
Creates
KeyManager
s based on this instance's configuration and theKeyStore
produced by the configuration returned fromKeyManagersParameters.getKeyStore()
. - createKeyStore() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
Creates a
KeyStoreParameters
instance based off of the configuration state of this instance. - createLifecycle(CamelContext) - Method in interface org.apache.camel.spi.ManagementStrategyFactory
-
Creates the associated
LifecycleStrategy
that the management strategy uses. - createMessage(Object, Class<?>) - Static method in exception class org.apache.camel.NoTypeConversionAvailableException
-
Returns an error message for no type converter available.
- createMessage(Object, Class<?>, Throwable) - Static method in exception class org.apache.camel.NoTypeConversionAvailableException
-
Returns an error message for no type converter available with the cause.
- createMessage(Object, Class<?>, Throwable) - Static method in exception class org.apache.camel.TypeConversionException
-
Returns an error message for type conversion failed.
- createMessage(String, Exchange) - Static method in exception class org.apache.camel.RuntimeExchangeException
- 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()
orPollingConsumer.receive(long)
whenever it is ready to do so rather than using the Event Based Consumer returned byEndpoint.createConsumer(Processor)
Important: Do not do any initialization in the constructor of thePollingConsumer
. - createPostProcessor(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in interface org.apache.camel.spi.SendDynamicAware
-
Creates an optional post
Processor
that will be executed afterwards when the message has been sent dynamic. - createPredicate(String) - Method in interface org.apache.camel.spi.Language
-
Creates a predicate based on only the given string input
- createPredicate(String, Object[]) - Method in interface org.apache.camel.spi.Language
-
Creates an expression based on the input with properties
- createPredicate(CamelContext) - Method in interface org.apache.camel.PredicateFactory
-
Creates a predicate
- createPredicate(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the predicate from the model.
- createPreProcessor(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in interface org.apache.camel.spi.SendDynamicAware
- createProcessor(String) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy
- createProcessor(CamelContext, String, Object[]) - Method in interface org.apache.camel.spi.ProcessorFactory
-
Creates a processor by the name of the definition.
- createProcessor(NamedNode, Processor) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy
- createProcessor(Route, NamedNode) - Method in interface org.apache.camel.spi.ProcessorFactory
-
Creates the processor.
- createProducer() - Method in interface org.apache.camel.Endpoint
-
Creates a new producer which is used send messages into the endpoint.
- createProducer(CamelContext, String, String, String, String, String, String, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestProducerFactory
-
Creates a new REST producer.
- createProducer(Endpoint) - Method in interface org.apache.camel.spi.DeferServiceFactory
-
Creates the
Producer
which is deferred started untilCamelContext
is being started. - createProducerTemplate() - Method in interface org.apache.camel.CamelContext
-
Creates a new
ProducerTemplate
which is started and therefore ready to use right away. - createProducerTemplate(int) - Method in interface org.apache.camel.CamelContext
-
Creates a new
ProducerTemplate
which is started and therefore ready to use right away. - createProxy(Endpoint, boolean, Class<T>...) - Method in interface org.apache.camel.spi.BeanProxyFactory
-
Creates a proxy bean facaded with the interfaces that when invoked will send the data as a message to a Camel endpoint.
- createRecipientList(CamelContext, RecipientList) - Method in interface org.apache.camel.spi.AnnotationBasedProcessorFactory
-
Creates recipient list processor from the configured annotation.
- createRegistry() - Method in interface org.apache.camel.spi.RestRegistryFactory
-
Create a new
RestRegistry
. - createRoute(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the route from the model.
- createRoute(CamelContext, NamedNode, String, String, Endpoint, Resource) - Method in interface org.apache.camel.spi.RouteFactory
-
Creates the route which should be configured afterwards with more configurations.
- createRouteAddedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forRoute
has been added successfully. - createRoutePolicy(CamelContext, String, NamedNode) - Method in interface org.apache.camel.spi.RoutePolicyFactory
-
Creates a new
RoutePolicy
which will be assigned to the given route. - createRouteReloaded(Route, int, int) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forRoute
has been reloaded successfully. - createRouteRemovedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forRoute
has been removed successfully. - createRouteStartedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forRoute
has been started successfully. - createRouteStartingEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forRoute
is starting. - createRouteStoppedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forRoute
has been stopped successfully. - createRouteStoppingEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
forRoute
is stopping. - createRoutingSlip(CamelContext, RoutingSlip) - Method in interface org.apache.camel.spi.AnnotationBasedProcessorFactory
-
Creates routing slip processor from the configured annotation.
- createSecureRandom() - Method in class org.apache.camel.support.jsse.SecureRandomParameters
-
Returns a
SecureRandom
instance initialized using the configured algorithm and provider, if specified. - createServerSocket() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
- createServerSocket(int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
- createServerSocket(int, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
- createServerSocket(int, int, InetAddress) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
- createServiceStartupFailureEvent(CamelContext, Object, Throwable) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for a Service failed to start cleanly - createServiceStopFailureEvent(CamelContext, Object, Throwable) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
for a Service failed to stop cleanly - createSharedCamelInternalProcessor(CamelContext) - Method in interface org.apache.camel.spi.InternalProcessorFactory
- createSocket() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- createSocket(String, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- createSocket(String, int, InetAddress, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- createSocket(InetAddress, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- createSocket(Socket, String, int, boolean) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- createSSLContext(CamelContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
Creates an
SSLContext
based on the related configuration options of this instance. - createStepCompletedEvent(Exchange, String) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when a step has been completed successfully - createStepFailedEvent(Exchange, String) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when a step has failed - createStepStartedEvent(Exchange, String) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when a step has been started - createTransformer(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the transformer from the model.
- createTrustManagers() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
Creates
TrustManager
s based on this instance's configuration and theKeyStore
produced by the configuration returned fromTrustManagersParameters.getKeyStore()
. - createUnitOfWork(Exchange) - Method in interface org.apache.camel.spi.UnitOfWorkFactory
-
Creates a new
UnitOfWork
- createUnitOfWorkProducer(Producer) - Method in interface org.apache.camel.spi.InternalProcessorFactory
- createValidator(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
-
Creates the validator from the model.
- createWrapProcessor(Processor, Processor) - Method in interface org.apache.camel.spi.InternalProcessorFactory
- Custom - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- CUSTOM_ID_PROPERTY - Static variable in interface org.apache.camel.Route
- CUSTOM_LOG_MASK_REF - Static variable in interface org.apache.camel.spi.MaskingFormatter
D
- DATA_AWARE - Enum constant in enum class org.apache.camel.trait.message.MessageTrait
-
Whether the message can store a data type.
- DATABASE - Enum constant in enum class org.apache.camel.Category
- Dataformat - Annotation Interface in org.apache.camel.spi.annotations
- 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.
- DataFormatContentTypeHeader - Interface in org.apache.camel.spi
-
Special accessor for a DataFormat
- DataFormatCustomizer - Interface in org.apache.camel.spi
-
To apply custom configurations to
DataFormat
instances. - DataFormatCustomizer.Builder<T> - Class in org.apache.camel.spi
-
A fluent builder to create a
DataFormatCustomizer
instance. - DataFormatCustomizer.Policy - Interface in org.apache.camel.spi
-
Used as additional filer mechanism to control if customizers need to be applied or not.
- DataFormatFactory - Interface in org.apache.camel.spi
-
A factory to create
DataFormat
. - DataFormatName - Interface in org.apache.camel.spi
-
The name of the
DataFormat
which allows to know which kind of data format the implementation is. - DataFormatResolver - Interface in org.apache.camel.spi
-
Represents a resolver of data formats.
- DATASET_INDEX - Static variable in interface org.apache.camel.Exchange
- DataType - Class in org.apache.camel.spi
-
Represents the data type URN which is used for message data type contract.
- DataType(Class<?>) - Constructor for class org.apache.camel.spi.DataType
- DataType(String) - Constructor for class org.apache.camel.spi.DataType
- DataTypeAware - Interface in org.apache.camel.spi
- DataTypeTransformer - Annotation Interface in org.apache.camel.spi
-
Annotation to configure a data type transformer with either specifying its name or from/to data types.
- DEBUG - Enum constant in enum class org.apache.camel.LoggingLevel
- Debugger - Interface in org.apache.camel.spi
-
A debugger which allows tooling to attach breakpoints which is being invoked when
Exchange
s is being routed. - DebuggerFactory - Interface in org.apache.camel.spi
-
Factory for creating
Debugger
. - Default - Enum constant in enum class org.apache.camel.ManagementMBeansLevel
- Default - Enum constant in enum class org.apache.camel.ManagementStatisticsLevel
- Default - Enum constant in enum class org.apache.camel.ShutdownRoute
- Default - Enum constant in enum class org.apache.camel.StartupSummaryLevel
- DEFAULT_CAMEL_CLOUD_EVENT_SOURCE - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- DEFAULT_CAMEL_CLOUD_EVENT_TYPE - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- DEFAULT_CHARSET_PROPERTY - Static variable in interface org.apache.camel.Exchange
- DEFAULT_CIPHER_SUITES_FILTER_EXCLUDE - Static variable in class org.apache.camel.support.jsse.BaseSSLContextParameters
- DEFAULT_CIPHER_SUITES_FILTER_INCLUDE - Static variable in class org.apache.camel.support.jsse.BaseSSLContextParameters
- DEFAULT_NAME - Static variable in interface org.apache.camel.resume.ResumeStrategy
- DEFAULT_PATH - Static variable in interface org.apache.camel.spi.FactoryFinder
- DEFAULT_REST_CONFIGURATION_ID - Static variable in class org.apache.camel.spi.RestConfiguration
- DEFAULT_SCHEME - Static variable in class org.apache.camel.spi.DataType
- DEFAULT_SECURE_SOCKET_PROTOCOL - Static variable in class org.apache.camel.support.jsse.SSLContextParameters
- DEFAULT_SECURE_SOCKET_PROTOCOLS_FILTER_EXCLUDE - Static variable in class org.apache.camel.support.jsse.BaseSSLContextParameters
- DEFAULT_SECURE_SOCKET_PROTOCOLS_FILTER_INCLUDE - Static variable in class org.apache.camel.support.jsse.BaseSSLContextParameters
- DEFAULT_SPOOL_THRESHOLD - Static variable in interface org.apache.camel.StreamCache
- defaultConsumerCallback(Exchange, boolean) - Method in interface org.apache.camel.Consumer
-
The default callback to use with the consumer when calling the processor using asynchronous routing.
- defaultValue() - Element in annotation interface org.apache.camel.PropertyInject
-
Default value to use if the property does not exist or has no value
- defaultValue() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- defaultValue() - Element in annotation interface org.apache.camel.spi.Metadata
-
To define a default value.
- defaultValue() - Element in annotation interface org.apache.camel.spi.UriParam
-
The default value of the parameter.
- defaultValue() - Element in annotation interface org.apache.camel.spi.UriPath
-
The default value of the parameter.
- defaultValueNote() - Element in annotation interface org.apache.camel.spi.UriParam
-
A special note about the default value.
- defaultValueNote() - Element in annotation interface org.apache.camel.spi.UriPath
-
A special note about the default value.
- Defer - Enum constant in enum class org.apache.camel.ShutdownRoute
- DeferredContextBinding - Annotation Interface in org.apache.camel
-
Used to indicate that if the target type is
CamelContextAware
, the context does not need to be mandatory injected during bean post processing but can be injected later on as example during Camel Context configuration. - DeferServiceFactory - Interface in org.apache.camel.spi
-
Factory to create services such as
Producer
s and defer starting the created service, untilCamelContext
has been started. - deferShutdown(ShutdownRunningTask) - Method in interface org.apache.camel.spi.ShutdownAware
-
To defer shutdown during first phase of shutdown.
- deferStartService(Object, boolean) - Method in interface org.apache.camel.CamelContext
-
Defers starting the service until
CamelContext
is (almost started) or started and has initialized all its prior services and routes. - DelegateEndpoint - Interface in org.apache.camel
-
An interface to represent an
Endpoint
which are delegated. - DelegateProcessor - Interface in org.apache.camel
-
Interface to be used for processors that delegate to the real processor
- delimiter() - Element in annotation interface org.apache.camel.DynamicRouter
-
Sets the uri delimiter to use
- delimiter() - Element in annotation interface org.apache.camel.RecipientList
-
Delimiter used if the Expression returned multiple endpoints.
- delimiter() - Element in annotation interface org.apache.camel.RoutingSlip
-
Sets the uri delimiter to use
- DependencyStrategy - Interface in org.apache.camel.spi
-
Strategy when 3rd party dependencies are detected during loading routes.
- deprecated() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- deprecated() - Element in annotation interface org.apache.camel.spi.annotations.YamlType
- deprecationNote() - Element in annotation interface org.apache.camel.spi.Metadata
-
Additional description that can explain the user about the deprecation and give reference to what to use instead.
- deregister(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceRegistry
-
Deprecated.Remove the service definition.
- description() - Element in annotation interface org.apache.camel.spi.annotations.DevConsole
-
Description of the console
- description() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- description() - Element in annotation interface org.apache.camel.spi.annotations.YamlType
- description() - Element in annotation interface org.apache.camel.spi.ApiMethod
-
Returns a description of this api method or api parameter.
- description() - Element in annotation interface org.apache.camel.spi.ApiParam
-
Returns a description of this parameter.
- description() - Element in annotation interface org.apache.camel.spi.ApiParams
-
Returns a description of the API.
- description() - Element in annotation interface org.apache.camel.spi.DataTypeTransformer
-
A human-readable description of what this transformer can do.
- description() - Element in annotation interface org.apache.camel.spi.Metadata
-
Returns a description of this entity.
- description() - Element in annotation interface org.apache.camel.spi.UriParam
-
Returns a description of this parameter.
- description() - Element in annotation interface org.apache.camel.spi.UriPath
-
Returns a description of this uri path
- DESCRIPTION_PROPERTY - Static variable in interface org.apache.camel.Route
- Deserializable - Interface in org.apache.camel.resume
- deserialize(ByteBuffer, ByteBuffer) - Method in interface org.apache.camel.resume.Deserializable
-
Deserializes resume data (invalid data may be ignored)
- deserializeKey(ByteBuffer) - Method in interface org.apache.camel.resume.Deserializable
-
Deserializes the key data
- deserializeObject(ByteBuffer) - Method in interface org.apache.camel.resume.Deserializable
-
Deserializes an arbitrary resumable object within a byte buffer
- deserializeValue(ByteBuffer) - Method in interface org.apache.camel.resume.Deserializable
-
Deserializes the value of resumable data
- DESTINATION_OVERRIDE_URL - Static variable in interface org.apache.camel.Exchange
- destroyMethod() - Element in annotation interface org.apache.camel.BindToRegistry
-
The optional name of a method to call on the bean instance during destruction.
- detach() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Detach the debugger which will suspend the message processing in case the suspend mode is enabled.
- detail(String) - Method in class org.apache.camel.health.HealthCheckResultBuilder
- detail(String, Object) - Method in class org.apache.camel.health.HealthCheckResultBuilder
- details(Map<String, Object>) - Method in class org.apache.camel.health.HealthCheckResultBuilder
- determineIfRedeliveryIsEnabled() - Method in interface org.apache.camel.spi.ErrorHandlerRedeliveryCustomizer
-
Determines if redelivery is enabled by checking if any of the redelivery policy settings may allow redeliveries.
- DevConsole - Interface in org.apache.camel.console
-
Developer Console
- DevConsole - Annotation Interface in org.apache.camel.spi.annotations
-
Marks a class as a custom developer console.
- DevConsole.MediaType - Enum Class in org.apache.camel.console
- DevConsoleRegistry - Interface in org.apache.camel.console
-
A registry for dev console.
- DevConsoleResolver - Interface in org.apache.camel.console
-
A pluggable strategy for resolving dev consoles in a loosely coupled manner
- DISABLE_HTTP_STREAM_CACHE - Static variable in interface org.apache.camel.Exchange
- disableBreakpoint(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Disables a breakpoint
- disableDebugger() - Method in interface org.apache.camel.spi.BacklogDebugger
-
To disable the debugger
- disableJMX() - Method in interface org.apache.camel.CamelContext
-
Disables using JMX as
ManagementStrategy
. - DiscoverableService - Interface in org.apache.camel.cloud
-
Deprecated.
- displayName() - Element in annotation interface org.apache.camel.spi.annotations.DevConsole
-
Display name (title)
- displayName() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- displayName() - Element in annotation interface org.apache.camel.spi.annotations.YamlType
- displayName() - Element in annotation interface org.apache.camel.spi.Metadata
-
A human display name of the parameter.
- displayName() - Element in annotation interface org.apache.camel.spi.UriParam
-
A human display name of the parameter.
- displayName() - Element in annotation interface org.apache.camel.spi.UriPath
-
A human display name of the parameter.
- disposeModel() - Method in interface org.apache.camel.ExtendedCamelContext
-
Deprecated.noop, do not use
- doBuild() - Method in class org.apache.camel.support.service.BaseService
-
Optional build phase of the service.
- DOCUMENT - Enum constant in enum class org.apache.camel.Category
- DOCUMENT_BUILDER_FACTORY - Static variable in interface org.apache.camel.Exchange
- documentElement() - Element in annotation interface org.apache.camel.spi.annotations.ExternalSchemaElement
-
In JAXB, when an element is annotated with
@XmlAnyElement
, the actual objects used are ofElement
class. - doFail(Exception) - Method in class org.apache.camel.support.service.BaseService
-
Implementations override this method to perform any action upon failure.
- doInAsyncProducer(AsyncProducer, Exchange, AsyncCallback) - Method in interface org.apache.camel.spi.ProducerCache.AsyncProducerCallback
-
Performs operation on the given producer to send the given exchange.
- doInAsyncProducer(Endpoint, Exchange, AsyncCallback, ProducerCache.AsyncProducerCallback) - Method in interface org.apache.camel.spi.ProducerCache
-
Sends an exchange to an endpoint using a supplied callback supporting the asynchronous routing engine.
- doInit() - Method in class org.apache.camel.support.service.BaseService
-
Initialize the service.
- doLifecycleChange() - Method in class org.apache.camel.support.service.BaseService
-
Implementations may return an object that will be closed when the lifecycle action is completed.
- doLog(String) - Method in class org.apache.camel.spi.CamelLogger
-
Logs the message without checking the
CamelLogger.shouldLog()
method first. - done() - Method in interface org.apache.camel.PooledExchange
-
When the exchange is done being used.
- done(boolean) - Method in interface org.apache.camel.AsyncCallback
-
This method is invoked once the
Exchange
is done. - 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
- doneUoW(Exchange) - Method in interface org.apache.camel.ConsumerTemplate
- doResume() - Method in class org.apache.camel.support.service.BaseService
-
Implementations override this method to support customized suspend/resume.
- doShutdown() - Method in class org.apache.camel.support.service.BaseService
-
Implementations override this method to perform customized shutdown.
- doStart() - Method in class org.apache.camel.support.service.BaseService
-
Implementations override this method to support customized start/stop.
- doStop() - Method in class org.apache.camel.support.service.BaseService
-
Implementations override this method to support customized start/stop.
- doSuspend() - Method in class org.apache.camel.support.service.BaseService
-
Implementations override this method to support customized suspend/resume.
- down() - Method in class org.apache.camel.health.HealthCheckResultBuilder
- DOWN - Enum constant in enum class org.apache.camel.health.HealthCheck.State
- DslProperty - Annotation Interface in org.apache.camel.spi.annotations
-
Internal annotation used to include fields otherwise excluded because annotate with XmlTransient.
- dumpAllTracedMessages() - Method in interface org.apache.camel.spi.BacklogTracer
-
Dumps all tracing data
- dumpAllTracedMessagesAsJSon() - Method in interface org.apache.camel.spi.BacklogTracer
-
Dumps all tracing data as JSon
- dumpAllTracedMessagesAsXml() - Method in interface org.apache.camel.spi.BacklogTracer
-
Dumps all tracing data as XML
- dumpBeansAsXml(CamelContext, List<Object>) - Method in interface org.apache.camel.spi.ModelToXMLDumper
-
Dumps the beans as XML
- dumpBeansAsYaml(CamelContext, List<Object>) - Method in interface org.apache.camel.spi.ModelToYAMLDumper
-
Dumps the beans as YAML
- dumpModelAsXml(CamelContext, NamedNode) - Method in interface org.apache.camel.spi.ModelToXMLDumper
-
Dumps the definition as XML
- dumpModelAsXml(CamelContext, NamedNode, boolean, boolean) - Method in interface org.apache.camel.spi.ModelToXMLDumper
-
Dumps the definition as XML
- dumpModelAsYaml(CamelContext, NamedNode) - Method in interface org.apache.camel.spi.ModelToYAMLDumper
-
Dumps the definition as YAML
- dumpModelAsYaml(CamelContext, NamedNode, boolean, boolean, boolean) - Method in interface org.apache.camel.spi.ModelToYAMLDumper
-
Dumps the definition as YAML
- dumpRoutes(String) - Method in interface org.apache.camel.spi.DumpRoutesStrategy
-
Dump routes
- DumpRoutesStrategy - Interface in org.apache.camel.spi
-
Strategy for dumping routes during startup dump all loaded routes (incl rests and route templates).
- dumpTracedMessages(String) - Method in interface org.apache.camel.spi.BacklogTracer
-
Dumps tracing data for the given route id / node id
- dumpTracedMessagesAsJSon(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
To dump the debugged messages from the give node id in JSon format.
- dumpTracedMessagesAsJSon(String) - Method in interface org.apache.camel.spi.BacklogTracer
-
Dumps tracing data for the given route id / node id as JSon
- dumpTracedMessagesAsXml(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
To dump the debugged messages from the give node id in XML format.
- dumpTracedMessagesAsXml(String) - Method in interface org.apache.camel.spi.BacklogTracer
-
Dumps tracing data for the given route id / node id as XML
- DUPLICATE_MESSAGE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- DUPLICATE_MESSAGE - Static variable in interface org.apache.camel.Exchange
- DynamicAwareEntry(String, String, Map<String, Object>, Map<String, Object>) - Constructor for class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
- DynamicRouter - Annotation Interface in org.apache.camel
-
Indicates that this method is to be used as a Dynamic Router routing the incoming message through a series of processing steps.
- dynamicSize() - Method in interface org.apache.camel.spi.EndpointRegistry
-
Number of endpoints in the dynamic registry
- dynamicSize() - Method in interface org.apache.camel.spi.TransformerRegistry
-
Number of transformers in the dynamic registry
- dynamicSize() - Method in interface org.apache.camel.spi.ValidatorRegistry
-
Number of validators in the dynamic registry
E
- elapsed() - Method in interface org.apache.camel.clock.Clock
-
The elapsed time since the creation of the clock
- elapsed() - Method in class org.apache.camel.clock.ContextClock
- elapsed(ContextEvents, long) - Method in class org.apache.camel.clock.ContextClock
-
Get the elapsed time for the event
- EmbeddedHttpService - Interface in org.apache.camel.spi
-
Information about embedded HTTP server such as when using the camel-platform-http component, that integrates with the Spring Boot or Quarkus HTTP server.
- enableBreakpoint(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Enables a breakpoint
- enableDebugger() - Method in interface org.apache.camel.spi.BacklogDebugger
-
To enable the debugger
- 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_URI - Static variable in interface org.apache.camel.health.HealthCheck
- EndpointAware - Interface in org.apache.camel
- EndpointConsumerResolver - Interface in org.apache.camel
-
An interface to represent an object that can be resolved as a consumer
Endpoint
- EndpointInject - Annotation Interface in org.apache.camel
- endpointLenientProperties(String) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
-
Parses the endpoint uri and constructs a key/value properties of only the lenient properties (eg custom options)
- EndpointProducerResolver - Interface in org.apache.camel
-
An interface to represent an object that can be resolved as a producer
Endpoint
- endpointProperties(String) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
-
Parses the endpoint uri and constructs a key/value properties of each option.
- EndpointRegistry - Interface in org.apache.camel.spi
-
Registry to cache endpoints in memory.
- EndpointServiceLocation - Interface in org.apache.camel.spi
-
Used for getting information about location to (hosted or external) network services.
- EndpointServiceRegistry - Interface in org.apache.camel.spi
-
Registry for
EndpointServiceLocation
to make it easy to find information about usage of external services such as databases, message brokers, cloud systems, that Camel is connecting to. - EndpointServiceRegistry.EndpointService - Interface in org.apache.camel.spi
-
Details about the endpoint service
- EndpointStrategy - Interface in org.apache.camel.spi
-
Endpoint strategy with callback invoked when an
Endpoint
is about to be registered to the endpoint registry inCamelContext
. - EndpointUriFactory - Interface in org.apache.camel.spi
- EndpointUtilizationStatistics - Interface in org.apache.camel.spi
-
Various statistics about endpoint utilization, such as from EIP patterns that uses dynamic endpoints.
- EndpointValidationResult - Class in org.apache.camel.catalog
-
Details result of validating endpoint uri.
- EndpointValidationResult() - Constructor for class org.apache.camel.catalog.EndpointValidationResult
- EndpointValidationResult(String) - Constructor for class org.apache.camel.catalog.EndpointValidationResult
- endStep() - Method in interface org.apache.camel.StartupStep
-
Ends the step.
- endStep(StartupStep) - Method in interface org.apache.camel.spi.StartupStepRecorder
-
Ends the step
- endTransactedBy(Object) - Method in interface org.apache.camel.spi.UnitOfWork
-
Mark this UnitOfWork as not transacted anymore by the given transaction definition.
- engineCreateSSLEngine() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
- engineCreateSSLEngine(String, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
- engineGetClientSessionContext() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
- engineGetServerSessionContext() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
- engineGetServerSocketFactory() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
- engineGetSocketFactory() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
- engineInit(KeyManager[], TrustManager[], SecureRandom) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
- enums() - Element in annotation interface org.apache.camel.spi.Metadata
-
Allows to define enums this options accepts.
- enums() - Element in annotation interface org.apache.camel.spi.UriParam
-
Allows to define enums this options accepts.
- enums() - Element in annotation interface org.apache.camel.spi.UriPath
-
Allows to define enums this options accepts.
- equals(Object) - Method in class org.apache.camel.spi.Contract
- equals(Object) - Method in class org.apache.camel.spi.DataType
- equals(Object) - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationError
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.apache.camel.spi.TypeConvertible
- equals(Object) - Method in class org.apache.camel.ValueHolder
- error() - Method in class org.apache.camel.health.HealthCheckResultBuilder
- error(Throwable) - Method in class org.apache.camel.health.HealthCheckResultBuilder
- ERROR - Enum constant in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Result.Status
-
Error occurred during the verification
- ERROR - Enum constant in enum class org.apache.camel.LoggingLevel
- ErrorHandler - Interface in org.apache.camel.spi
-
An interface used to represent an error handler
- ERRORHANDLER_BRIDGE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- ERRORHANDLER_BRIDGE - Static variable in interface org.apache.camel.Exchange
- ERRORHANDLER_CIRCUIT_DETECTED - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- ERRORHANDLER_CIRCUIT_DETECTED - Static variable in interface org.apache.camel.Exchange
- ERRORHANDLER_HANDLED - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- ErrorHandlerAware - Interface in org.apache.camel.spi
-
An interface for
Processor
aware of itsErrorHandler
which are wrapped via theChannel
during route initialization, or specially used byRecipientList
EIP annotation. - ErrorHandlerFactory - Interface in org.apache.camel
-
Factory for creating
ErrorHandler
s. - ErrorHandlerRedeliveryCustomizer - Interface in org.apache.camel.spi
-
Customizer for
ErrorHandler
which supports redeliveries. - evalEntry(Object, Object) - Method in interface org.apache.camel.resume.ResumeAction
-
Runs an action on an resumable (entry)
- evaluate(String, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.spi.ScriptingLanguage
-
Evaluates the script
- evaluate(Exchange, Class<T>) - Method in interface org.apache.camel.Expression
-
Returns the value of the expression on the given exchange
- EVALUATE_EXPRESSION_RESULT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- EVALUATE_EXPRESSION_RESULT - Static variable in interface org.apache.camel.Exchange
- EventClock<T> - Interface in org.apache.camel.clock
-
A specialized clock that tracks the pass of time for one or more types of events
- EventFactory - Interface in org.apache.camel.spi
-
Factory to create
events
that are emitted when such an event occur. - EventNotifier - Interface in org.apache.camel.spi
-
Notifier to send
events
. - Evict - Enum constant in enum class org.apache.camel.TimeoutMap.Listener.Type
- EXCEPTION - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
An exception occurred
- EXCEPTION_CAUGHT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- EXCEPTION_CAUGHT - Static variable in interface org.apache.camel.Exchange
- EXCEPTION_CLASS - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.ExceptionAttribute
-
The exception class
- EXCEPTION_HANDLED - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- EXCEPTION_HANDLED - Static variable in interface org.apache.camel.Exchange
- EXCEPTION_INSTANCE - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.ExceptionAttribute
-
The exception object that has been thrown.
- ExceptionHandler - Interface in org.apache.camel.spi
-
A Strategy pattern for handling exceptions; particularly in asynchronous processes such as consumers.
- Exchange - Interface in org.apache.camel
- ExchangeAsyncProcessingStarted - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ExchangeCompleted - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ExchangeConstantProvider - Class in org.apache.camel
-
Generated by camel build tools - do NOT edit this file!
- ExchangeConstantProvider() - Constructor for class org.apache.camel.ExchangeConstantProvider
- ExchangeCreated - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ExchangeException - Annotation Interface in org.apache.camel
-
Marks a parameter as being the exception set on an exchange
- ExchangeExtension - Interface in org.apache.camel
- ExchangeFactory - Interface in org.apache.camel.spi
- ExchangeFactoryManager - Interface in org.apache.camel.spi
-
Manages
ExchangeFactory
. - ExchangeFailed - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ExchangeFailureHandled - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ExchangeFailureHandling - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- 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. - ExchangePattern - Enum Class in org.apache.camel
-
Represents the kind of message exchange pattern
- ExchangeProperties - Annotation Interface in org.apache.camel
-
Marks a parameter as being an injection point of the exchange properties of an
Exchange
- ExchangeProperty - Annotation Interface in org.apache.camel
-
Marks a parameter as being an injection point of a property of an
Exchange
- ExchangePropertyKey - Enum Class in org.apache.camel
-
An enum of common and known keys for exchange properties used by camel-core.
- ExchangeRedelivery - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ExchangeSending - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ExchangeSent - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ExchangeTimedOutException - Exception Class in org.apache.camel
-
An exception thrown if an InOut exchange times out receiving the OUT message
- ExchangeTimedOutException(Exchange, long) - Constructor for exception class org.apache.camel.ExchangeTimedOutException
- ExchangeTimedOutException(Exchange, long, String) - Constructor for exception class org.apache.camel.ExchangeTimedOutException
- exclude - Variable in class org.apache.camel.support.jsse.FilterParameters
- excludeProperties() - Element in annotation interface org.apache.camel.spi.Metadata
-
To exclude one or more properties.
- executeFromQueue() - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Executes the next task (if supported by the reactive executor implementation)
- executorService() - Element in annotation interface org.apache.camel.RecipientList
-
Refers to a custom Thread Pool to be used for parallel processing.
- ExecutorServiceManager - Interface in org.apache.camel.spi
-
Strategy to create thread pools.
- ExecutorServiceManager.ThreadFactoryListener - Interface in org.apache.camel.spi
-
Listener when a new
ThreadFactory
is created, which allows to plugin custom behaviour. - exists() - Method in interface org.apache.camel.spi.Resource
-
Whether this resource exists.
- ExpectedBodyTypeException - Exception Class in org.apache.camel
-
Thrown if the body could not be converted to the required type
- ExpectedBodyTypeException(Exchange, Class<?>) - Constructor for exception class org.apache.camel.ExpectedBodyTypeException
- Experimental - Annotation Interface in org.apache.camel
-
An experimental user-facing API.
- Expression - Interface in org.apache.camel
-
An expression provides a plugin strategy for evaluating expressions on a message exchange.
- ExpressionEvaluationException - Exception Class in org.apache.camel
-
An exception thrown if evaluation of the expression failed.
- ExpressionEvaluationException(Expression, String, Exchange, Throwable) - Constructor for exception class org.apache.camel.ExpressionEvaluationException
- ExpressionEvaluationException(Expression, Exchange, Throwable) - Constructor for exception class org.apache.camel.ExpressionEvaluationException
- ExpressionFactory - Interface in org.apache.camel
-
A factory for creating
Expression
- ExpressionFactoryAware - Interface in org.apache.camel.spi
-
When an instance is aware of
ExpressionFactory
. - ExpressionIllegalSyntaxException - Exception Class in org.apache.camel
-
An exception thrown if the expression contains illegal syntax.
- ExpressionIllegalSyntaxException(String) - Constructor for exception class org.apache.camel.ExpressionIllegalSyntaxException
- ExpressionIllegalSyntaxException(String, Throwable) - Constructor for exception class org.apache.camel.ExpressionIllegalSyntaxException
- ExpressionResultTypeAware - Interface in org.apache.camel.spi
-
Represents an
Expression
orPredicate
that supports a result type. - extended() - Element in annotation interface org.apache.camel.spi.Configurer
-
Whether this configurer should include extended configurer methods.
- Extended - Enum constant in enum class org.apache.camel.ManagementStatisticsLevel
- ExtendedCamelContext - Interface in org.apache.camel
-
Extended
CamelContext
which contains the methods and APIs that are not primary intended for Camel end users but for SPI, custom components, or more advanced used-cases with Camel. - ExtendedPropertyConfigurerGetter - Interface in org.apache.camel.spi
-
A marker interface to identify the object as being a configurer which can provide details about the options the configurer supports.
- ExtendedRoutesBuilderLoader - Interface in org.apache.camel.spi
-
An extended
RoutesBuilderLoader
that is capable of loading from multiple resources in one unit (such as compiling them together). - ExtendedStartupListener - Interface in org.apache.camel
-
Extended
StartupListener
that is invoked when theCamelContext
is fully started. - extendsScheme() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
Used when an endpoint is extending another endpoint
- EXTERNAL_REDELIVERED - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- ExternalSchemaElement - Annotation Interface in org.apache.camel.spi.annotations
-
Annotation to be used for JAXB property (field or method) annotated with
@XmlAnyElement
to highlight which actual elements do we expect (not to be enforced by JAXB, but by Camel itself). - 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(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.
- extractProperties(String, boolean) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Loads the properties from the default locations and extract properties by the given prefix.
F
- FACTORY - Static variable in interface org.apache.camel.catalog.RuntimeCamelCatalog
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.console.DevConsoleRegistry
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.health.HealthCheckRegistry
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.AnnotationBasedProcessorFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.BeanProcessorFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.BeanProxyFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.CliConnectorFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.Debugger
- FACTORY - Static variable in interface org.apache.camel.spi.DeferServiceFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.DumpRoutesStrategy
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ExchangeFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ExecutorServiceManager.ThreadFactoryListener
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.HeadersMapFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.InternalProcessorFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.MockSendToEndpointStrategyFactory
- FACTORY - Static variable in interface org.apache.camel.spi.ModelineFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ModelJAXBContextFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ModelReifierFactory
-
Service factory key for custom factories.
- FACTORY - Static variable in interface org.apache.camel.spi.ModelToXMLDumper
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ModelToYAMLDumper
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ProcessorExchangeFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ProcessorFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.PropertiesComponent
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ReactiveExecutor
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ResourceLoader
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.RestBindingJaxbDataFormatFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.RestClientRequestValidator
- FACTORY - Static variable in interface org.apache.camel.spi.RestRegistryFactory
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.RoutesLoader
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.StartupStepRecorder
-
Service factory key.
- FACTORY - Static variable in interface org.apache.camel.spi.ThreadPoolFactory
-
Service factory key.
- FACTORY_PATH - Static variable in interface org.apache.camel.spi.ResourceResolver
-
Service factory base path for scheme specific resolver.
- FACTORY_PATH - Static variable in interface org.apache.camel.spi.RoutesBuilderLoader
-
Service factory base path for language specific loaders.
- 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 for
FactoryFinder
- fail(Exception) - Method in class org.apache.camel.support.service.BaseService
- Fail - Enum constant in enum class org.apache.camel.TypeConverterExists
- FAILED - Static variable in class org.apache.camel.support.service.BaseService
- FailedToCreateConsumerException - Exception Class in org.apache.camel
-
Thrown if Camel failed to create a consumer for a given endpoint.
- FailedToCreateConsumerException(String, Throwable) - Constructor for exception class org.apache.camel.FailedToCreateConsumerException
- FailedToCreateConsumerException(Endpoint, String) - Constructor for exception class org.apache.camel.FailedToCreateConsumerException
- FailedToCreateConsumerException(Endpoint, String, Throwable) - Constructor for exception class org.apache.camel.FailedToCreateConsumerException
- FailedToCreateConsumerException(Endpoint, Throwable) - Constructor for exception class org.apache.camel.FailedToCreateConsumerException
- FailedToCreateProducerException - Exception Class in org.apache.camel
-
Thrown if Camel failed to create a producer for a given endpoint.
- FailedToCreateProducerException(Endpoint, Throwable) - Constructor for exception class org.apache.camel.FailedToCreateProducerException
- FailedToCreateRouteException - Exception Class in org.apache.camel
-
Exception when failing to create a
Route
. - FailedToCreateRouteException(String, String, String, Throwable) - Constructor for exception class org.apache.camel.FailedToCreateRouteException
- FailedToCreateRouteException(String, String, Throwable) - Constructor for exception class org.apache.camel.FailedToCreateRouteException
- FailedToCreateRouteFromTemplateException - Exception Class in org.apache.camel
-
Exception when failing to create a
Route
from a RouteTemplateDefinition. - FailedToCreateRouteFromTemplateException(String, String, String) - Constructor for exception class org.apache.camel.FailedToCreateRouteFromTemplateException
- FailedToCreateRouteFromTemplateException(String, String, String, Throwable) - Constructor for exception class org.apache.camel.FailedToCreateRouteFromTemplateException
- FailedToStartComponentException - Exception Class in org.apache.camel
-
Exception when failing to start a
Component
. - FailedToStartComponentException(String, String, Throwable) - Constructor for exception class org.apache.camel.FailedToStartComponentException
- FailedToStartRouteException - Exception Class in org.apache.camel
-
Exception when failing to start a
Route
. - FailedToStartRouteException(String, String) - Constructor for exception class org.apache.camel.FailedToStartRouteException
- FailedToStartRouteException(String, String, Throwable) - Constructor for exception class org.apache.camel.FailedToStartRouteException
- FAILURE_COUNT - Static variable in interface org.apache.camel.health.HealthCheck
- FAILURE_ENDPOINT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- FAILURE_ENDPOINT - Static variable in interface org.apache.camel.Exchange
- FAILURE_ERROR_COUNT - Static variable in interface org.apache.camel.health.HealthCheck
- FAILURE_HANDLED - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- FAILURE_HANDLED - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- FAILURE_ROUTE_ID - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- FAILURE_ROUTE_ID - Static variable in interface org.apache.camel.Exchange
- FAILURE_START_TIME - Static variable in interface org.apache.camel.health.HealthCheck
- FAILURE_TIME - Static variable in interface org.apache.camel.health.HealthCheck
- fallback() - Element in annotation interface org.apache.camel.Converter
-
Whether this converter is a regular converter or a fallback converter.
- fallbackCanPromote() - Element in annotation interface org.apache.camel.Converter
-
Whether this fallback converter can be promoted to a first class type converter.
- FATAL_FALLBACK_ERROR_HANDLER - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- FATAL_FALLBACK_ERROR_HANDLER - Static variable in interface org.apache.camel.Exchange
- FILE - Enum constant in enum class org.apache.camel.Category
- FILE_CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
- FILE_EXCHANGE_FILE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- FILE_EXCHANGE_FILE - Static variable in interface org.apache.camel.Exchange
- FILE_LAST_MODIFIED - Static variable in interface org.apache.camel.Exchange
- FILE_LENGTH - Static variable in interface org.apache.camel.Exchange
- FILE_LOCAL_WORK_PATH - Static variable in interface org.apache.camel.Exchange
- FILE_LOCK_CHANNEL_FILE - Static variable in interface org.apache.camel.Exchange
- FILE_LOCK_EXCLUSIVE_LOCK - Static variable in interface org.apache.camel.Exchange
- FILE_LOCK_FILE_ACQUIRED - Static variable in interface org.apache.camel.Exchange
- FILE_LOCK_FILE_NAME - Static variable in interface org.apache.camel.Exchange
- FILE_LOCK_RANDOM_ACCESS_FILE - Static variable in interface org.apache.camel.Exchange
- FILE_NAME - Static variable in interface org.apache.camel.Exchange
- FILE_NAME_CONSUMED - 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
- filter(String) - Method in interface org.apache.camel.Route
-
Returns a list of all the
Processor
s from this route that has id's matching the pattern - filter(Collection<String>, Collection<String>, Collection<String>, FilterParameters.Patterns, FilterParameters.Patterns, boolean) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Filters the values in
availableValues
returning only the values that are explicitly listed inexplicitValues
(returns them regardless of if they appear inavailableValues
or not) ifexplicitValues
is notnull
or according to the following rules: Match the include patterns inpatterns
and don't match the exclude patterns inpatterns
if patterns is notnull
. Match the include patterns indefaultPatterns
and don't match the exclude patterns indefaultPatterns
if patterns isnull
andapplyDefaults
is true. Are provided in currentValues if if patterns isnull
andapplyDefaults
is false. - filter(Collection<String>, Collection<String>, List<Pattern>, List<Pattern>) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Filters the values in
availableValues
returning only the values that are explicitly listed inexplicitValues
(returns them regardless of if they appear inavailableValues
or not) ifexplicitValues
is notnull
or as match the patterns inincludePatterns
and do not match the patterns inexcludePatterns
ifexplicitValues
isnull
. - FILTER_MATCHED - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- FILTER_NON_XML_CHARS - Static variable in interface org.apache.camel.Exchange
- FilterParameters - Class in org.apache.camel.support.jsse
-
Represents a set of regular expression based filter patterns for including and excluding content of some type.
- FilterParameters() - Constructor for class org.apache.camel.support.jsse.FilterParameters
- FilterParameters.Patterns - Class in org.apache.camel.support.jsse
-
An immutable collection of compiled includes and excludes filter
Pattern
s. - 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 interface org.apache.camel.spi.PackageScanClassResolver
-
Attempts to discover classes filter by the provided filter
- findByType(Class<T>) - Method in interface org.apache.camel.spi.BeanRepository
-
Finds beans in the registry by their type.
- findByTypeWithName(Class<T>) - Method in interface org.apache.camel.spi.BeanRepository
-
Finds beans in the registry by their type.
- findClass(String) - Method in interface org.apache.camel.spi.FactoryFinder
-
Finds the given factory class using the key to lookup.
- findImplementations(Class<?>, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
Attempts to discover classes that are assignable to the type provided (exclude abstract classes).
- findOptionalClass(String) - Method in interface org.apache.camel.spi.FactoryFinder
-
Finds the optional factory class using the key to lookup.
- findResources(String) - Method in interface org.apache.camel.spi.PackageScanResourceResolver
-
Finds the resources from the given location.
- findRoutesBuilders(Collection<Resource>) - Method in interface org.apache.camel.spi.RoutesLoader
-
Find
RoutesBuilder
from the give list ofResource
. - findRoutesBuilders(Collection<Resource>, boolean) - Method in interface org.apache.camel.spi.RoutesLoader
-
Find
RoutesBuilder
from the give list ofResource
. - findRoutesBuilders(Resource...) - Method in interface org.apache.camel.spi.RoutesLoader
-
Find
RoutesBuilder
from the give list ofResource
. - findSetterMethods(Class<?>, String, boolean, boolean, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Find all the setter methods on the class
- findSingleByType(Class<T>) - Method in interface org.apache.camel.spi.BeanRepository
-
Finds the bean by type, if there is exactly only one instance of the bean
- firstVersion() - Element in annotation interface org.apache.camel.spi.Metadata
-
The first version this functionality was added to Apache Camel.
- firstVersion() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
The first version this endpoint was added to Apache Camel.
- FluentProducerTemplate - Interface in org.apache.camel
- forEach(BiFunction<? super K, ? super Object, Boolean>) - Method in interface org.apache.camel.resume.cache.ResumeCache
-
Performs the given action for each member of the cache
- format() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- format(String) - Method in interface org.apache.camel.spi.MaskingFormatter
-
Format a given string.
- format(Exchange) - Method in interface org.apache.camel.spi.ExchangeFormatter
-
Generates a string representation of the exchange
- forType(Class<T>, ThrowingConsumer<T, Exception>) - Static method in interface org.apache.camel.spi.ComponentCustomizer
-
Create a
ComponentCustomizer
that can process a concrete component type instance. - forType(Class<T>, ThrowingConsumer<T, Exception>) - Static method in interface org.apache.camel.spi.DataFormatCustomizer
-
Create a
DataFormatCustomizer
that can process a concrete data format type instance. - forType(Class<T>, ThrowingConsumer<T, Exception>) - Static method in interface org.apache.camel.spi.LanguageCustomizer
-
Create a
DataFormatCustomizer
that can process a concrete language type instance. - fromSpecVersion(String) - Static method in enum class org.apache.camel.cloudevents.CloudEvents
- fromString(String) - Static method in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Scope
-
Get an instance of this scope from a string representation
- fromType() - Element in annotation interface org.apache.camel.spi.DataTypeTransformer
-
Data type representing the input of the transformation.
- functionsClass() - Element in annotation interface org.apache.camel.spi.annotations.Language
-
The class that contains all the name of functions that are supported by the language.
G
- gcp() - Method in class org.apache.camel.vault.VaultConfiguration
-
GCP Vault Configuration
- GcpVaultConfiguration - Class in org.apache.camel.vault
-
Configuration for access to GCP Secret Manager.
- GcpVaultConfiguration() - Constructor for class org.apache.camel.vault.GcpVaultConfiguration
- generateBulkLoader() - Element in annotation interface org.apache.camel.Converter
-
Whether to let the Camel compiler plugin to generate java source code for fast loading of the type converters, bulked together into a single class for optimal performance.
- generateConfigurer() - Element in annotation interface org.apache.camel.spi.Configurer
-
Whether to let the Camel compiler plugin to generate java source code for fast configuration.
- generateConfigurer() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
Generates source code for fast configuring of the endpoint properties which uses direct method invocation of getter/setters.
- GeneratedPropertyConfigurer - Interface in org.apache.camel.spi
-
A auto generated
PropertyConfigurer
for fast configuration of Camel components invalid input: '&' endpoints. - generateExchangeUuid() - Method in interface org.apache.camel.spi.UuidGenerator
-
Generates an UUID string representation to be used as exchange id.
- generateLoader() - Element in annotation interface org.apache.camel.Converter
-
Whether to let the Camel compiler plugin to generate java source code for fast loading of the type converters.
- generateUuid() - Method in interface org.apache.camel.spi.UuidGenerator
-
Generates an UUID string representation.
- GENERIC - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
Generic error which is explained in more details with
ComponentVerifierExtension.VerificationError.getDetails()
- get() - Method in class org.apache.camel.ValueHolder
- get(String) - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Gets the exchange from the repository.
- get(K) - Method in interface org.apache.camel.resume.cache.ResumeCache
-
Gets the offset entry for the key
- get(K) - Method in interface org.apache.camel.TimeoutMap
-
Looks up the value in the map by the given key.
- get(K, Class<T>) - Method in interface org.apache.camel.resume.cache.ResumeCache
-
Gets the offset entry for the key
- get(CamelContext) - Static method in interface org.apache.camel.console.DevConsoleRegistry
-
Returns an optional
DevConsoleRegistry
, by default no registry is present, and it must be explicit activated. - get(CamelContext) - Static method in interface org.apache.camel.health.HealthCheckRegistry
-
Returns an optional
HealthCheckRegistry
, by default no registry is present, and it must be explicit activated. - get(CamelContext, String) - Method in interface org.apache.camel.spi.AggregationRepository
-
Gets the given exchange with the correlation key
- get(ContextEvents) - Method in class org.apache.camel.clock.ContextClock
- get(RouteTemplateContext) - Method in interface org.apache.camel.RouteTemplateContext.BeanSupplier
- get(T) - Method in interface org.apache.camel.clock.EventClock
-
Get the clock for the event
- getAccessKey() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- getAcquiredCounter() - Method in interface org.apache.camel.spi.PooledObjectFactory.Statistics
-
Number of exchanges acquired (reused) when using pooled factory.
- getAdapter() - Method in interface org.apache.camel.resume.ResumeStrategy
-
Gets an adapter for resuming operations
- getAdapter(Class<T>) - Method in interface org.apache.camel.resume.ResumeStrategy
-
Gets and adapter for resuming operations
- getAdvice(Class<T>) - Method in interface org.apache.camel.spi.InternalProcessor
-
Gets the advice with the given type.
- getAfter() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
-
The processor (optional) for routing after sending to the original endpoint.
- getAlgorithm() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
- getAlgorithm() - Method in class org.apache.camel.support.jsse.SecureRandomParameters
- getAlgorithm() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
- getAllEndpoints(boolean) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Gets all the endpoint uris captured during runtime routing that are in-use of the routes.
- getAllOptions(Object) - Method in interface org.apache.camel.spi.ExtendedPropertyConfigurerGetter
-
Provides a map of which options the cofigurer supports and their class type.
- getAllowClasses() - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
To filter stream caching of a given set of allowed/denied classes.
- getAllowCoreThreadTimeOut() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets whether to allow core threads to timeout
- getAllowPassthrough() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns a flag indicating if default values should be applied in the event that no other property of the instance configures a particular aspect of the entity produced by the instance.
- getAllowPassthrough() - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
- getAllowPassthrough() - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
- getAllProperties() - Method in interface org.apache.camel.Exchange
-
Returns all (both internal and custom) properties associated with the exchange
- getAndRemove(String) - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Gets and removes the exchange from the repository.
- getApiComponent() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the name of the Camel component to use as the REST API (such as swagger or openapi).
- getApiContextPath() - Method in class org.apache.camel.spi.RestConfiguration
- getApiContextRouteId() - Method in class org.apache.camel.spi.RestConfiguration
- getApiHost() - Method in class org.apache.camel.spi.RestConfiguration
- getApiProperties() - Method in class org.apache.camel.spi.RestConfiguration
- getApplicationContextClassLoader() - Method in interface org.apache.camel.CamelContext
-
Gets the application CamelContext class loader which may be helpful for running camel in other containers
- getAtRouteId() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
The id of the route where the exchange currently is being processed
- getAttempt() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeRedeliveryEvent
- getAttemptCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Number of type conversion attempts
- getAttribute(String) - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
-
Returns an attribute associated with this meta data by name.
- getAttribute(String, Class<T>) - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
-
Returns an attribute associated with this meta data by name and specifying the type required.
- getAttributes() - Method in interface org.apache.camel.cloud.ServiceRegistry
-
Deprecated.Attributes associated to the service.
- getAttributes() - Method in interface org.apache.camel.cluster.CamelClusterService
-
Attributes associated to the service.
- getAttributes() - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
- getAutowiredNames() - Method in interface org.apache.camel.spi.PropertyConfigurerGetter
-
Gets the names of the autowired options.
- getAwsVaultConfiguration() - Method in class org.apache.camel.vault.VaultConfiguration
- getAzureVaultConfiguration() - Method in class org.apache.camel.vault.VaultConfiguration
- getBacklogSize() - Method in interface org.apache.camel.spi.BacklogTracer
-
Number of messages to keep in the backlog.
- getBackOffDelay() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getBackOffMaxAttempts() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getBackOffMaxDelay() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getBackOffMaxElapsedTime() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getBackOffMultiplier() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getBasePackageScan() - Method in interface org.apache.camel.ExtendedCamelContext
-
Package name to use as base (offset) for classpath scanning of RouteBuilder,
TypeConverter
,CamelConfiguration
classes, and also classes annotated withConverter
, orBindToRegistry
. - getBasePath() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the base path to the REST service
- getBaseUrl() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the base url to the REST service
- getBefore() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
-
The processor for routing in a detour before sending to the original endpoint.
- getBeginTime() - Method in interface org.apache.camel.StartupStep
-
Gets the begin time (optional).
- getBindingMode() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the binding mode used by the REST consumer
- getBindingPackageScan() - Method in class org.apache.camel.spi.RestConfiguration
- getBlobAccessKey() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getBlobAccountName() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getBlobContainerName() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getBlockedThread() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
-
The thread which is blocked waiting for other threads to signal the callback.
- getBody() - Method in interface org.apache.camel.Message
-
Returns the body of the message as a POJO
- getBody() - Method in interface org.apache.camel.WrappedFile
-
Gets the content of the file.
- getBody(Class<T>) - Method in interface org.apache.camel.Message
-
Returns the body as the specified type
- getBodyMaxChars() - Method in interface org.apache.camel.spi.BacklogDebugger
-
To limit the message body to a maximum size in the traced message.
- getBodyMaxChars() - Method in interface org.apache.camel.spi.BacklogTracer
-
Maximum number of bytes to keep for the message body (to prevent storing very big payloads)
- getBootstrapFactoryFinder() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the bootstrap FactoryFinder which will be used for the loading the factory class from META-INF.
- getBootstrapFactoryFinder(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the bootstrap FactoryFinder which will be used for the loading the factory class from META-INF in the given path.
- getBreakpoints() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Gets all the breakpoint (node ids)
- getBreakpoints() - Method in interface org.apache.camel.spi.Debugger
-
Gets a list of all the breakpoints
- getBufferSize() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- getCache() - Method in interface org.apache.camel.resume.Cacheable
-
Gets the cache in resume adapters and objects that cache their data
- getCachedClassesCounter() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Number of classes in the introspection cache.
- getCacheFillPolicy() - Method in class org.apache.camel.resume.ResumeStrategyConfiguration
-
Gets the
Cacheable.FillPolicy
for the cache used in the strategy - getCacheMemoryAverageSize() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Gets the average number of bytes per cached stream for in-memory stream caches.
- getCacheMemoryCounter() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Gets the counter for number of in-memory
StreamCache
created. - getCacheMemorySize() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Gets the total accumulated number of bytes which has been stream cached for in-memory stream caches.
- getCacheSpoolAverageSize() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Gets the average number of bytes per cached stream for spooled (not in-memory) stream caches.
- getCacheSpoolCounter() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Gets the counter for number of spooled (not in-memory)
StreamCache
created. - getCacheSpoolSize() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Gets the total accumulated number of bytes which has been stream cached for spooled stream caches.
- getCamelContext() - Method in interface org.apache.camel.ConsumerTemplate
-
Get the
CamelContext
- getCamelContext() - Method in interface org.apache.camel.Endpoint
-
Returns the context which created the endpoint
- getCamelContext() - Method in interface org.apache.camel.FluentProducerTemplate
-
Get the
CamelContext
- getCamelContext() - Method in interface org.apache.camel.ProducerTemplate
-
Get the
CamelContext
- getCamelContext() - Method in interface org.apache.camel.Route
-
Gets the camel context
- getCamelContext() - Method in interface org.apache.camel.spi.HasCamelContext
-
Returns the camel context.
- getCamelContext() - Method in class org.apache.camel.spi.Transformer
- getCamelContext() - Method in class org.apache.camel.spi.Validator
- getCamelContext() - Method in class org.apache.camel.support.jsse.JsseParameters
- getCamelContextExtension() - Method in interface org.apache.camel.CamelContext
-
Gets the
ExtendedCamelContext
that contains the extension points for internal context APIs. - getCapacity() - Method in interface org.apache.camel.spi.ConsumerCache
-
Gets the maximum cache size (capacity).
- getCapacity() - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
The capacity the pool (for each consumer) uses for storing exchanges.
- getCapacity() - Method in interface org.apache.camel.spi.PooledObjectFactory
-
The capacity the pool uses for storing objects.
- getCapacity() - Method in interface org.apache.camel.spi.ProducerCache
-
Gets the maximum cache size (capacity).
- getCause() - Method in interface org.apache.camel.spi.CamelEvent.FailureEvent
- getCauses() - Method in exception class org.apache.camel.CamelUnitOfWorkException
- getCertAlias() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getCertificateChain(String) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
- getCheck() - Method in interface org.apache.camel.health.HealthCheck.Result
-
The
HealthCheck
associated to this response. - getCheck(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Returns the check identified by the given
id
if available. - getCheck(String) - Method in interface org.apache.camel.health.HealthCheckRepository
-
Returns the check identified by the given
id
if available. - getCheckIDs() - Method in interface org.apache.camel.health.HealthCheckRegistry
-
A collection of health check IDs.
- getChildServices(Service) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Gathers all child services by navigating the service to recursively gather all child services.
- getChildServices(Service, boolean) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Gathers all child services by navigating the service to recursively gather all child services.
- getCipherSuite() - Method in class org.apache.camel.support.jsse.CipherSuitesParameters
-
Returns a live reference to the list of cipher suite names.
- getCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the optional explicitly configured cipher suites for this configuration.
- getCipherSuitesFilter() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the optional cipher suite filter for this configuration.
- getClassLoader(String) - Method in interface org.apache.camel.spi.ClassResolver
-
Gets a custom class loader by its name
- getClassLoaders() - Method in interface org.apache.camel.spi.ClassResolver
-
Gets the custom class loaders.
- getClassLoaders() - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
Gets the ClassLoader instances that should be used when scanning for classes.
- getClassLoaders() - Method in interface org.apache.camel.spi.PackageScanResourceResolver
-
Gets the ClassLoader instances that should be used when scanning for resources.
- getClassResolver() - Method in interface org.apache.camel.CamelContext
-
Returns the class resolver to be used for loading/lookup of classes.
- getClientAliases(String, Principal[]) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
- getClientAuthentication() - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
- getClientId() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getClientParameters() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getClientSecret() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getClock() - Method in interface org.apache.camel.CamelContext
-
Gets a clock instance that keeps track of time for relevant CamelContext events
- getClock() - Method in interface org.apache.camel.Exchange
-
Gets
Clock
that holds time information about the exchange - getClusterService() - Method in interface org.apache.camel.cluster.CamelClusterView
- getCode() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
The overall error code, which can be either a
ComponentVerifierExtension.VerificationError.StandardCode
or a custom code. - getCollectionValueType(Object, String, boolean) - Method in interface org.apache.camel.spi.PropertyConfigurerGetter
-
This method can be used to retrieve the class type for an option if the option is a collection kind (list, map, or array).
- getComponent() - Method in interface org.apache.camel.ComponentAware
-
Get the
Component
- getComponent() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
The Camel component for this endpoint service (such as jms, kafka, aws-s3).
- getComponent() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the name of the Camel component to use as the REST consumer
- getComponent(Class<T>) - Method in interface org.apache.camel.ComponentAware
-
Get the
Component
as the specified type. - getComponent(String) - Method in interface org.apache.camel.CamelContext
-
Gets a component from the CamelContext by name.
- getComponent(String, boolean) - Method in interface org.apache.camel.CamelContext
-
Gets a component from the CamelContext by name.
- getComponent(String, boolean, boolean) - Method in interface org.apache.camel.CamelContext
-
Gets a component from the CamelContext by name.
- getComponent(String, Class<T>) - Method in interface org.apache.camel.CamelContext
-
Gets a component from the CamelContext by name and specifying the expected type of component.
- getComponentJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the component information as JSON format.
- getComponentName() - Method in exception class org.apache.camel.FailedToStartComponentException
- getComponentNames() - Method in interface org.apache.camel.CamelContext
-
Gets a readonly list of names of the components currently registered
- getComponentParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
-
Returns the JSON schema representation of the component and endpoint parameters for the given component name.
- getComponentProperties() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets additional options on component level
- getComponentPropertyConfigurer() - Method in interface org.apache.camel.Component
-
Gets the component
PropertyConfigurer
. - getConfigurationId() - Method in interface org.apache.camel.Route
-
Gets the route configuration id(s) the route has been applied with.
- getConfigurer() - Method in interface org.apache.camel.RouteTemplateContext
-
Gets the custom configurer.
- getConsole(String) - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Returns the dev console identified by the given
id
if available. - getConsoleIDs() - Method in interface org.apache.camel.console.DevConsoleRegistry
-
A collection of dev console IDs.
- getConsumer() - Method in interface org.apache.camel.Route
-
Gets the inbound
Consumer
- getConsumer() - Method in interface org.apache.camel.spi.ExchangeFactory
-
The consumer using this factory.
- getConsumer() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the consumer of the REST service
- getConsumerCounter() - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Number of consumers currently being managed
- getConsumerListener() - Method in interface org.apache.camel.resume.ConsumerListenerAware
-
Gets the
ConsumerListener
instance - getConsumerProperties() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets additional options on consumer level
- getConsumes() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Optional details about what media-types the REST service accepts
- getContentType() - Method in interface org.apache.camel.spi.ContentTypeAware
-
The content type.
- getContext() - Method in interface org.apache.camel.Exchange
-
Returns the container so that a processor can resolve endpoints from URIs
- getContext() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextEvent
- getContext() - Method in exception class org.apache.camel.VetoCamelContextStartException
- getContextPath() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the configured context-path
- getContextPlugin(Class<T>) - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets a plugin of the given type.
- getContextPlugin(Class<T>) - Method in interface org.apache.camel.spi.PluginManager
-
Gets a plugin of the given type.
- getControlledRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Return the list of routes controlled by this controller.
- getCorsHeaders() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the CORS headers to use if CORS has been enabled.
- getCreated() - Method in interface org.apache.camel.clock.Clock
-
The point in time the clock was created
- getCreated() - Method in class org.apache.camel.clock.ContextClock
- getCreated() - Method in interface org.apache.camel.Exchange
-
Deprecated.
- getCreatedCounter() - Method in interface org.apache.camel.spi.PooledObjectFactory.Statistics
-
Number of new exchanges created.
- getCurrentCacheSize() - Method in interface org.apache.camel.ConsumerTemplate
-
Gets an approximated size of the current cached resources in the backing cache pools.
- getCurrentCacheSize() - Method in interface org.apache.camel.FluentProducerTemplate
-
Gets an approximated size of the current cached resources in the backing cache pools.
- getCurrentCacheSize() - Method in interface org.apache.camel.ProducerTemplate
-
Gets an approximated size of the current cached resources in the backing cache pools.
- getDataFormatJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the data format information as JSON format.
- getDataFormatName() - Method in interface org.apache.camel.spi.DataFormatName
-
The name of the data format
- getDataFormatNames() - Method in interface org.apache.camel.CamelContext
-
Gets a readonly list of names of the data formats currently registered
- getDataFormatParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
-
Returns the JSON schema representation of the
DataFormat
parameters for the given data format name. - getDataFormatProperties() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets additional options on data format level
- getDataType() - Method in interface org.apache.camel.spi.DataTypeAware
-
Get the data type of the message.
- getDate() - Method in interface org.apache.camel.spi.RouteError
-
The date and time when this error happened
- getDeadLetterUri() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureEvent
- getDeadLetterUri() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Gets the dead letter channel
- getDebugCounter() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Number of breakpoint that has been hit
- getDebugger() - Method in interface org.apache.camel.CamelContext
-
Gets the current
Debugger
- getDefaultCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
- getDefaultCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- getDefaultCipherSuitesFilter() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
- getDefaultConsumerCallback() - Method in interface org.apache.camel.ExchangeExtension
-
Callback used by
Consumer
if the consumer is completing the exchange processing with default behaviour. - getDefaultEndpoint() - Method in interface org.apache.camel.FluentProducerTemplate
-
Get the default endpoint to use if none is specified
- getDefaultEndpoint() - Method in interface org.apache.camel.ProducerTemplate
-
Get the default endpoint to use if none is specified
- getDefaultFactoryFinder() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the default FactoryFinder which will be used for the loading the factory class from META-INF
- getDefaultName() - Method in interface org.apache.camel.Component
-
Gets the default name of the component.
- getDefaultSecureSocketProcotolFilter() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
- getDefaultThreadPoolProfile() - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Gets the default thread pool profile
- getDefaultValues() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getDefaultValues() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getDelayer() - Method in interface org.apache.camel.RuntimeConfiguration
-
Gets the delay value
- getDelegate() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
- getDelegate() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- getDenyClasses() - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
To filter stream caching of a given set of allowed/denied classes.
- getDeprecated() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getDeprecated() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getDescription() - Method in interface org.apache.camel.CamelContext
-
Gets the description of this CamelContext.
- getDescription() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
A human readable description of the error in plain english
- getDescription() - Method in interface org.apache.camel.console.DevConsole
-
Short description of this console.
- getDescription() - Method in interface org.apache.camel.ExtendedCamelContext
- getDescription() - Method in interface org.apache.camel.Route
-
Gets the route description (if any has been configured).
- getDescription() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Optional description about this rest service.
- getDescription() - Method in interface org.apache.camel.StartupStep
-
Description of the step
- getDescriptionText() - Method in interface org.apache.camel.NamedNode
-
Returns the description text or null if there is no description text associated with this node
- getDetail(String) - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
Get a single detail for a given attribute
- getDetail(ComponentVerifierExtension.VerificationError.Attribute) - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
Get a single detail for a given attribute
- getDetails() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
Details about the failed verification.
- getDetails() - Method in interface org.apache.camel.health.HealthCheck.Result
-
A key/value combination of details.
- getDevConsoleJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the dev console information as JSON format.
- getDevConsoleParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
-
Returns the JSON schema representation of the
DevConsole
parameters for the given dev-console name. - getDirection() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
Direction of the service.
- getDirection() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
-
Whether the endpoint is used as input our output
- getDiscardedCounter() - Method in interface org.apache.camel.spi.PooledObjectFactory.Statistics
-
Number of exchanges discarded (thrown away) such as if no space in cache pool.
- getDisplayName() - Method in interface org.apache.camel.console.DevConsole
-
Display name of this console.
- getDumpRoutes() - Method in interface org.apache.camel.CamelContext
-
If dumping is enabled then Camel will during startup dump all loaded routes (incl rests and route templates) represented as XML DSL into the log.
- getDuration() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
The duration in millis the exchange has been inflight
- getDuration() - Method in interface org.apache.camel.StartupStep
-
Gets the duration the step took (optional)
- getEipParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
-
Returns the JSON schema representation of the EIP parameters for the given EIP name.
- getElapsed() - Method in interface org.apache.camel.MessageHistory
-
Gets the elapsed time in millis processing the node took (this is 0 until the node processing is done)
- getElapsed() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Time elapsed for processing the given node (in millis).
- getElapsed() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
The elapsed time in millis processing the exchange at the current node
- getElapsedSinceCreated() - Method in interface org.apache.camel.MessageHistory
-
The elapsed time since created.
- getEndpoint() - Method in interface org.apache.camel.cloud.ServiceHealth
-
Deprecated.The health enpoint exposed by the service.
- getEndpoint() - Method in interface org.apache.camel.DelegateEndpoint
-
Gets the delegated
Endpoint
. - getEndpoint() - Method in interface org.apache.camel.EndpointAware
-
Gets the endpoint associated with an object.
- getEndpoint() - Method in exception class org.apache.camel.ProxyInstantiationException
- getEndpoint() - Method in interface org.apache.camel.Route
-
Gets the input endpoint for this route.
- getEndpoint() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSendingEvent
- getEndpoint() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSentEvent
- getEndpoint(String) - Method in interface org.apache.camel.CamelContext
-
Resolves the given name to an
Endpoint
of the specified type. - getEndpoint(String, Class<T>) - Method in interface org.apache.camel.CamelContext
-
Resolves the given name to an
Endpoint
of the specified type. - getEndpoint(String, Map<String, Object>) - Method in interface org.apache.camel.CamelContext
-
Resolves the given name to an
Endpoint
of the specified type. - getEndpoint(NormalizedEndpointUri) - Method in interface org.apache.camel.ExtendedCamelContext
-
Resolves the given name to an
Endpoint
of the specified type. - getEndpoint(NormalizedEndpointUri, Map<String, Object>) - Method in interface org.apache.camel.ExtendedCamelContext
-
Resolves the given name to an
Endpoint
of the specified type. - getEndpointBaseUri() - Method in interface org.apache.camel.Endpoint
-
Returns the string representation of the base endpoint URI (without query parameters).
- getEndpointKey() - Method in interface org.apache.camel.Endpoint
-
Returns a string key of this endpoint.
- getEndpointProperties() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets additional options on endpoint level
- getEndpointPropertyConfigurer() - Method in interface org.apache.camel.Component
-
Gets the endpoint
PropertyConfigurer
. - getEndpointRegistry() - Method in interface org.apache.camel.CamelContext
-
Gets the
EndpointRegistry
- getEndpointRuntimeStatisticsEnabled() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets whether endpoint runtime statistics is enabled
- getEndpoints() - Method in interface org.apache.camel.CamelContext
-
Returns a read-only
Collection
of all of the endpoints from theEndpointRegistry
- getEndpointServiceMetadata() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Optional endpoint metadata that is relevant to the service as key value pairs.
- getEndpointServiceProtocol() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Get the endpoint protocol the service is using such as http, amqp, tcp.
- getEndpointServiceRegistry() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the
EndpointServiceRegistry
to use. - getEndpointServiceUrl() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Gets the endpoint remote address such as URL, hostname, connection-string, or cloud region, that are component specific.
- getEndpointsPerRoute(String, boolean) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Gets all the endpoint uris captured from the given route during runtime routing that are in-use of the routes.
- getEndpointStatistics() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Gets details about all the endpoint captured from the given route during runtime routing that are in-use of the routes.
- getEndpointUri() - Method in interface org.apache.camel.Endpoint
-
Returns the string representation of the endpoint URI
- getEndpointUri() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The endpoint uri if this trace is either from a route input (from), or the exchange was sent to an endpoint such as (to, toD, wireTap) etc.
- getEndpointUri() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
The endpoint uri of this endpoint service.
- getEndpointUriFactory(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the
EndpointUriFactory
for the given component name. - getEndpointUrl() - Method in interface org.apache.camel.NamedRoute
-
Gets the route endpoint url.
- getEndpointUtilizationStatistics() - Method in interface org.apache.camel.spi.ConsumerCache
-
Gets the endpoint statistics
- getEndpointUtilizationStatistics() - Method in interface org.apache.camel.spi.ProducerCache
-
Gets the endpoint statistics
- getEnumChoices(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getEnumChoices(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
- getEnvironmentVariable(String) - Method in interface org.apache.camel.RouteTemplateContext
-
Gets the environment variable parameter that matches the given property name.
- getError() - Method in class org.apache.camel.catalog.LanguageValidationResult
- getError() - Method in interface org.apache.camel.health.HealthCheck.Result
-
An error associated to the result, used to provide the error associated to unhealthy services.
- getErrorHandler() - Method in interface org.apache.camel.Channel
-
Gets the
ErrorHandler
this Channel uses. - getErrorHandler() - Method in interface org.apache.camel.spi.ErrorHandlerAware
-
Gets the error handler
- getErrorHandlerFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the default error handler builder which is inherited by the routes
- getErrorHandlerFactory() - Method in interface org.apache.camel.Route
- getErrorHandlerHandled() - Method in interface org.apache.camel.ExchangeExtension
-
Whether the exchange has been handled by the error handler.
- getErrorHandlers(ErrorHandlerFactory) - Method in interface org.apache.camel.Route
-
Gets the error handlers
- getErrors() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.Result
-
Collection of errors happened for the verification.
- getEventDrivenProcessors() - Method in interface org.apache.camel.Route
-
This method retrieves the event driven Processors on this route context.
- getEventFactory() - Method in interface org.apache.camel.spi.ManagementStrategy
-
Gets the event factory
- getEventhubConnectionString() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getEventNotifiers() - Method in interface org.apache.camel.spi.ManagementStrategy
-
Gets the event notifiers.
- getEventTime(Exchange) - Method in interface org.apache.camel.cloudevents.CloudEvent
-
Construct event time from given Camel exchange.
- getException() - Method in interface org.apache.camel.Exchange
-
Returns the exception associated with this exchange
- getException() - Method in interface org.apache.camel.spi.RouteError
-
Gets the error.
- getException(Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns the exception associated with this exchange.
- getExceptionAsJSon() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The exception as JSon (exception type, message and stacktrace)
- getExceptionAsXml() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The exception as XML (exception type, message and stacktrace)
- getExceptionMessage(Throwable) - Static method in exception class org.apache.camel.FailedToCreateRouteException
- getExchange() - Method in exception class org.apache.camel.CamelExchangeException
-
Returns the exchange which caused the exception
- getExchange() - Method in exception class org.apache.camel.ExpectedBodyTypeException
- getExchange() - Method in exception class org.apache.camel.ExpressionEvaluationException
- getExchange() - Method in interface org.apache.camel.Message
-
Returns the exchange this message is related to
- getExchange() - Method in exception class org.apache.camel.RuntimeExchangeException
-
Returns the exchange which caused the exception
- getExchange() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
-
The exchange being processed by the other thread.
- getExchange() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeEvent
- getExchange() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
The exchange being inflight
- getExchangeExtension() - Method in interface org.apache.camel.Exchange
-
Gets the
ExchangeExtension
that contains the extension points for internal exchange APIs. - getExchangeFactories() - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Returns a read-only view of the managed factories.
- getExchangeFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the exchange factory to use.
- getExchangeFactoryManager() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the exchange factory manager to use.
- getExchangeFormatter() - Method in interface org.apache.camel.spi.Tracer
-
To use a custom exchange formatter for formatting the output of the
Exchange
in the trace logs. - getExchangeId() - Method in interface org.apache.camel.Exchange
-
Returns the exchange id (unique)
- getExchangeId() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The exchange id
- getExchangePattern() - Method in interface org.apache.camel.Endpoint
-
Returns the default exchange pattern to use when creating an exchange.
- getExchanges() - Method in interface org.apache.camel.spi.BrowsableEndpoint
-
Return the exchanges available on this endpoint
- getExclude() - Method in class org.apache.camel.support.jsse.FilterParameters
-
Returns a live copy of the list of patterns to exclude.
- getExcludePattern() - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Pattern to exclude health checks from being invoked by Camel when checking healths.
- getExcludePatterns() - Method in class org.apache.camel.support.jsse.FilterParameters
-
Returns a list of compiled
Pattern
s based on the values of the exclude list. - getExcludeRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getExcludes() - Method in class org.apache.camel.support.jsse.FilterParameters.Patterns
- getExecutorServiceManager() - Method in interface org.apache.camel.CamelContext
-
Gets the current
ExecutorServiceManager
- getExhaustedRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Return the list of routes that have failed all attempts to startup and are now exhausted.
- getExpectedBodyType() - Method in exception class org.apache.camel.ExpectedBodyTypeException
- getExposureLevel() - Method in interface org.apache.camel.health.HealthCheckRegistry
-
The exposure level
- getExpression() - Method in exception class org.apache.camel.ExpressionEvaluationException
- getExpression() - Method in exception class org.apache.camel.ExpressionIllegalSyntaxException
- getExpressionFactory() - Method in interface org.apache.camel.spi.ExpressionFactoryAware
-
Gets the
ExpressionFactory
. - getExpressionText() - Method in interface org.apache.camel.spi.ExpressionResultTypeAware
-
Gets the expression or predicate as text
- getExtension(Class<T>) - Method in interface org.apache.camel.Component
-
Gets the extension of the given type.
- getFactoryFinder(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the FactoryFinder which will be used for the loading the factory class from META-INF in the given path
- getFailedCounter() - Method in interface org.apache.camel.spi.ReloadStrategy
-
Number of reloads failed.
- getFailedCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Number of failed attempts during type conversion
- getFailureHandler() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureEvent
- getFallbackTimeout() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Fallback Timeout in seconds (300 seconds as default) when block the message processing in Camel.
- getFile() - Method in interface org.apache.camel.WrappedFile
-
Gets the file.
- getFileName() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getFillPolicy() - Method in interface org.apache.camel.resume.Cacheable
-
Gets the for this cache instance
- getFrom() - Method in class org.apache.camel.spi.Transformer
-
Get 'from' data type.
- getFrom() - Method in class org.apache.camel.spi.TransformerKey
- getFrom() - Method in class org.apache.camel.spi.TypeConvertible
-
Gets the class instance that defines the "from" type (that is: Class<F>.class)
- 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 his property will be null.
- getFromEndpoint() - Method in interface org.apache.camel.ExchangeExtension
-
Returns the endpoint which originated this message exchange.
- getFromRouteId() - Method in interface org.apache.camel.Exchange
-
Returns the route id which originated this message exchange if a route consumer on an endpoint created the message exchange, otherwise his property will be null.
- getFromRouteId() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
The id of the route where the exchange originates (started)
- getFromType() - Method in exception class org.apache.camel.NoTypeConversionAvailableException
-
Returns the required from type.
- getFromType() - Method in exception class org.apache.camel.TypeConversionException
-
Returns the required from type.
- getFromType() - Method in exception class org.apache.camel.TypeConverterExistsException
- getFullName() - Method in class org.apache.camel.spi.DataType
- getGcpVaultConfiguration() - Method in class org.apache.camel.vault.VaultConfiguration
- getGlobalEndpointConfiguration() - Method in interface org.apache.camel.CamelContext
-
Gets the global endpoint configuration, where you can configure common endpoint options.
- getGlobalOption(String) - Method in interface org.apache.camel.CamelContext
-
Gets the global option value that can be referenced in the camel context
- getGlobalOptions() - Method in interface org.apache.camel.CamelContext
-
Gets global options that can be referenced in the camel context.
- getGroup() - Method in interface org.apache.camel.console.DevConsole
-
The group of this console.
- getGroup() - Method in interface org.apache.camel.Route
-
Gets the route group
- getGroup() - Method in interface org.apache.camel.spi.HasGroup
-
Returns the group
- getHashicorpVaultConfiguration() - Method in class org.apache.camel.vault.VaultConfiguration
- 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
- getHeader(String, Object) - Method in interface org.apache.camel.Message
-
Accesses a specific header
- getHeader(String, Object, Class<T>) - Method in interface org.apache.camel.Message
-
Returns a header associated with this message by name and specifying the type required
- getHeader(String, Supplier<Object>) - Method in interface org.apache.camel.Message
-
Accesses a specific header
- getHeader(String, Supplier<Object>, 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 interface org.apache.camel.spi.HeaderFilterStrategyAware
-
Gets the header filter strategy used
- getHeaderName() - Method in exception class org.apache.camel.NoSuchHeaderException
- getHeaderName() - Method in exception class org.apache.camel.NoSuchHeaderOrPropertyException
- getHeaders() - Method in interface org.apache.camel.Message
-
Returns all the headers associated with the message.
- getHeadersMapFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the
HeadersMapFactory
to use. - getHealth() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.Gets the health.
- getHealthCheck() - Method in interface org.apache.camel.health.HealthCheckAware
-
Gets the
HealthCheck
- getHealthCheck(CamelContext, String) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Gets the
HealthCheck
by the given id (will resolve from classpath if necessary) - getHealthCheck(CamelContext, String, Class<T>) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Gets the
HealthCheck
by the given id (will resolve from classpath if necessary) - getHealthCheckRegistry(CamelContext) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Gets the
HealthCheckRegistry
. - getHealthCheckRepository(CamelContext, String) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Gets the
HealthCheckRepository
by the given id (will resolve from classpath if necessary) - getHealthCheckRepository(CamelContext, String, Class<T>) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Gets the
HealthCheckRepository
by the given id (will resolve from classpath if necessary) - getHistoryNodeId() - Method in interface org.apache.camel.ExchangeExtension
-
Gets the history node id (the current processor that will process the exchange)
- getHistoryNodeLabel() - Method in interface org.apache.camel.ExchangeExtension
-
Gets the history node label (the current processor that will process the exchange)
- getHistoryNodeSource() - Method in interface org.apache.camel.ExchangeExtension
-
Gets the history node source:line-number where the node is located in the source code (the current processor that will process the exchange).
- getHitCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Number of successful conversions
- getHits() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
Usage of the endpoint service, such as how many messages it has received / sent to
- getHits() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
-
Usage of the endpoint, such as how many messages it has received / sent to
- getHost() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.Gets the IP or hostname of the server hosting the service.
- getHost() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the hostname to use by the REST consumer
- getHost() - Method in class org.apache.camel.vault.HashicorpVaultConfiguration
- getHostNameResolver() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the resolver to use for resolving hostname
- getHttpResponseCode() - Method in interface org.apache.camel.spi.HttpResponseAware
-
The HTTP status code
- getHttpResponseStatus() - Method in interface org.apache.camel.spi.HttpResponseAware
-
The HTTP status line
- getId() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.Gets the service id.
- getId() - Method in interface org.apache.camel.console.DevConsole
-
The ID of this console.
- getId() - Method in interface org.apache.camel.NamedNode
-
Gets the value of the id property.
- getId() - Method in interface org.apache.camel.Route
-
Gets the route id
- getId() - Method in interface org.apache.camel.spi.HasId
-
Returns the id
- getId() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets the id of this profile
- getId() - Method in interface org.apache.camel.spi.VariableRepository
-
The id of this repository.
- getId() - Method in interface org.apache.camel.StartupStep
-
The id of the step
- getIn() - Method in interface org.apache.camel.Exchange
-
Returns the inbound request message
- getIn(Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns the inbound request message as the given type
- getIncapable() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getIncapable() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInclude() - Method in interface org.apache.camel.spi.DumpRoutesStrategy
- getInclude() - Method in class org.apache.camel.support.jsse.FilterParameters
-
Returns a live copy of the list of patterns to include.
- getIncludeHostName() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets whether host name is included in MBean names.
- getIncludePatterns() - Method in class org.apache.camel.support.jsse.FilterParameters
-
Returns a list of compiled
Pattern
s based on the values of the include list. - getIncludeRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getIncludes() - Method in class org.apache.camel.support.jsse.FilterParameters.Patterns
- getIndex() - Method in class org.apache.camel.catalog.LanguageValidationResult
- getIndex() - Method in interface org.apache.camel.spi.CamelEvent.RouteReloadedEvent
-
The route index in this batch (starts from 1)
- getInflightRepository() - Method in interface org.apache.camel.CamelContext
-
Gets the inflight repository
- getInitialBreakpoints() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Allows to pre-configure breakpoints (node ids) to use with debugger on startup.
- getInitialDelay() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getInitialState() - Method in interface org.apache.camel.health.HealthCheckRegistry
-
The initial state of health-checks.
- getInjector() - Method in interface org.apache.camel.CamelContext
-
Returns the injector used to instantiate objects by type
- getInjector() - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Gets the injector
- getInOrNull(Class<T>) - Method in interface org.apache.camel.ExchangeExtension
-
If there is an existing inbound message of the given type then return it as-is, otherwise return null.
- getInput() - Method in interface org.apache.camel.NamedRoute
-
Gets the route input
- getInput() - Method in interface org.apache.camel.spi.RouteStartupOrder
-
Gets the input to this route
- getInputStream() - Method in interface org.apache.camel.spi.Resource
-
Returns an
InputStream
that reads from the underlying resource. - getInputType() - Method in class org.apache.camel.spi.Contract
- getInterceptStrategies() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the interceptor strategies
- getInterceptStrategies() - Method in interface org.apache.camel.Route
-
This method retrieves the InterceptStrategy instances this route context.
- getInternalLock() - Method in class org.apache.camel.support.service.BaseService
- getInternalProperties() - Method in interface org.apache.camel.ExchangeExtension
-
Gets the internal properties from this exchange.
- getInternalRouteController() - Method in interface org.apache.camel.ExtendedCamelContext
-
Internal
RouteController
that are only used internally by Camel to perform basic route operations. - getInType() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Optional detail about input binding to a FQN class name.
- getInvalidArray() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidArray() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvalidBoolean() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidBoolean() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvalidDuration() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidDuration() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvalidEnum() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidEnum() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvalidEnumChoices() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidEnumChoices() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvalidInteger() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidInteger() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvalidMap() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidMap() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvalidNumber() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidNumber() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvalidReference() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getInvalidReference() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getInvokedCounter() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Number of times bean introspection has been invoked
- getJsonDataFormat() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the name of the json data format.
- getKeepAliveTime() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets the keep alive time for inactive threads
- getKeyManagers() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getKeyPassword() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
- getKeys() - Method in interface org.apache.camel.spi.AggregationRepository
-
Gets the keys currently in the repository.
- getKeyStore() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
- getKeyStore() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
- getKubernetesVaultConfiguration() - Method in class org.apache.camel.vault.VaultConfiguration
- getLabel() - Method in interface org.apache.camel.NamedNode
-
Returns a label to describe this node such as the expression if some kind of expression node
- getLanguage() - Method in exception class org.apache.camel.NoSuchLanguageException
- getLanguageJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the language information as JSON format.
- getLanguageNames() - Method in interface org.apache.camel.CamelContext
-
Gets a readonly list with the names of the languages currently registered.
- getLanguageParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
-
Returns the JSON schema representation of the
Language
parameters for the given language name. - getLastError() - Method in interface org.apache.camel.Route
-
Gets the last error that happened during changing the route lifecycle, i.e. such as when an exception was thrown during starting the route.
- getLastOffset() - Method in interface org.apache.camel.resume.Resumable
-
Gets the last offset
- getLeader() - Method in interface org.apache.camel.cluster.CamelClusterView
-
Provides the leader member if elected.
- getLeft() - Method in interface org.apache.camel.BinaryPredicate
-
Gets the left hand side expression
- getLenient() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getLenientProperties() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
- getLevel() - Method in class org.apache.camel.spi.CamelLogger
- getLevel() - Method in interface org.apache.camel.StartupStep
-
The step level (sub step of previous steps)
- getLifecycleStrategies() - Method in interface org.apache.camel.CamelContext
-
Returns the lifecycle strategies used to handle lifecycle notifications
- getLimit() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Maximum number of endpoints to keep in the cache per route.
- getLineNumber() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getLineNumber() - Method in interface org.apache.camel.LineNumberAware
-
The line number of this entity.
- getLoadStatisticsEnabled() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets whether load statistics is enabled
- getLocalBeanRepository() - Method in interface org.apache.camel.RouteTemplateContext
-
Gets the local bean repository for the route template when creating the new route
- getLocalBeanRepository() - Method in interface org.apache.camel.spi.LocalBeanRepositoryAware
-
Gets the local bean repository (if any in use)
- getLocalMember() - Method in interface org.apache.camel.cluster.CamelClusterView
-
Provides the local member.
- getLocalProperties() - Method in interface org.apache.camel.spi.PropertiesComponent
-
Gets a list of properties that are local for the current thread only (ie thread local), or null if not currently in use.
- getLocalPropertiesAsMap() - Method in interface org.apache.camel.spi.PropertiesComponent
-
Gets a list of properties that are local for the current thread only (ie thread local), or null if not currently in use.
- getLocation() - Method in interface org.apache.camel.LineNumberAware
-
The location of the entity.
- getLocation() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The location of the trace (source code name:line) if possible.
- getLocation() - Method in interface org.apache.camel.spi.Resource
-
The location of the resource.
- getLocations() - Method in interface org.apache.camel.spi.PropertiesComponent
-
Gets the configured properties locations.
- getLog() - Method in class org.apache.camel.spi.CamelLogger
- getLoggingLevel() - Method in interface org.apache.camel.spi.BacklogDebugger
-
The debugger logging level to use when logging activity.
- getLoggingLevel() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Logging level used for logging introspection usage.
- getLoggingLevel() - Method in interface org.apache.camel.spi.RouteController
-
Gets the logging level used for logging route activity (such as starting and stopping routes).
- getLoggingLevel() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Gets the logging level used for logging shutdown activity (such as starting and stopping routes).
- getLogListeners() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets a list of
LogListener
(can be null if empty). - getMainJsonSchema() - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the camel-main json schema
- getManagedObjectForCamelContext(CamelContext) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForCamelHealth(CamelContext, HealthCheckRegistry) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForClusterService(CamelContext, CamelClusterService) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForComponent(CamelContext, Component, String) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForConsumer(CamelContext, Consumer) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForDataFormat(CamelContext, DataFormat) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForEndpoint(CamelContext, Endpoint) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForEventNotifier(CamelContext, EventNotifier) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForProcessor(CamelContext, Processor, NamedNode, Route) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForProducer(CamelContext, Producer) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForRoute(CamelContext, Route) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForRouteController(CamelContext, RouteController) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForService(CamelContext, Service) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagedObjectForThreadPool(CamelContext, ThreadPoolExecutor, String, String, String, String) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
- getManagementAgent() - Method in interface org.apache.camel.spi.ManagementStrategy
-
Gets the management agent
- getManagementInterceptStrategy() - Method in interface org.apache.camel.Route
-
Gets the special managed intercept strategy if any
- getManagementMBeanAssembler() - Method in interface org.apache.camel.ExtendedCamelContext
-
Returns the management mbean assembler
- getManagementName() - Method in interface org.apache.camel.CamelContext
-
Gets the name this
CamelContext
was registered in JMX. - getManagementNamePattern() - Method in interface org.apache.camel.spi.ManagementAgent
-
The naming pattern for creating the CamelContext management name.
- getManagementNameStrategy() - Method in interface org.apache.camel.CamelContext
-
Gets the current management name strategy
- getManagementObjectNameStrategy() - Method in interface org.apache.camel.spi.ManagementStrategy
-
Gets the naming strategy to use
- getManagementObjectStrategy() - Method in interface org.apache.camel.spi.ManagementStrategy
-
Gets the object strategy to use
- getManagementStrategy() - Method in interface org.apache.camel.CamelContext
-
Gets the management strategy
- 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
- getMarker() - Method in class org.apache.camel.spi.CamelLogger
- getMask() - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to remove detected sensitive information (such as passwords) from MBean names and attributes.
- getMaxDepth() - Method in interface org.apache.camel.spi.StartupStepRecorder
-
To filter our sub steps at a maximum depth
- getMaxDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
The highest duration time in millis.
- getMaximumCacheSize() - Method in interface org.apache.camel.ConsumerTemplate
-
Gets the maximum cache size used.
- getMaximumCacheSize() - Method in interface org.apache.camel.FluentProducerTemplate
-
Gets the maximum cache size used in the backing cache pools.
- getMaximumCacheSize() - Method in interface org.apache.camel.ProducerTemplate
-
Gets the maximum cache size used in the backing cache pools.
- getMaximumCacheSize() - Method in interface org.apache.camel.spi.EndpointRegistry
-
Maximum number of entries to store in the dynamic registry
- getMaximumCacheSize() - Method in interface org.apache.camel.spi.TransformerRegistry
-
Maximum number of entries to store in the dynamic registry
- getMaximumCacheSize() - Method in interface org.apache.camel.spi.ValidatorRegistry
-
Maximum number of entries to store in the dynamic registry
- getMaximumRedeliveries() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Gets the maximum redelivery attempts to do before a recovered
Exchange
is doomed as exhausted and moved to the dead letter channel. - getMaxPoolSize() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets the maximum pool size
- getMaxQueueSize() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets the maximum number of tasks in the work queue.
- getMBeanObjectDomainName() - Method in interface org.apache.camel.spi.ManagementAgent
-
Get domain name for Camel MBeans.
- getMBeanServer() - Method in interface org.apache.camel.spi.ManagementAgent
-
Get the MBeanServer which hosts managed objects.
- getMBeanServerDefaultDomain() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets the default domain on the MBean server
- getMBeansLevel() - Method in interface org.apache.camel.spi.ManagementAgent
-
§ Gets the mbeans registration level
- getMDCLoggingKeysPattern() - Method in interface org.apache.camel.CamelContext
-
Gets the pattern used for determine which custom MDC keys to propagate during message routing when the routing engine continues routing asynchronously for the given message.
- getMeanDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
The average duration time in millis.
- getMembers() - Method in interface org.apache.camel.cluster.CamelClusterView
-
Provides the list of members of the cluster.
- getMessage() - Method in interface org.apache.camel.Exchange
-
Returns the current message
- getMessage() - Method in interface org.apache.camel.health.HealthCheck.Result
-
A message associated to the result, used to provide more information for unhealthy services.
- getMessage() - Method in interface org.apache.camel.MessageHistory
-
A read-only copy of the message at the point of this history (if this has been enabled).
- getMessage() - Method in exception class org.apache.camel.PropertyBindingException
- getMessage(Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns the current message as the given type
- getMessageAsJSon() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The content of the message as JSon (body and headers)
- getMessageAsXml() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The content of the message as XML (body and headers)
- getMessageHistoryFactory() - Method in interface org.apache.camel.CamelContext
-
Gets the current
MessageHistoryFactory
- getMessageId() - Method in interface org.apache.camel.Message
-
Returns the id of the message.
- getMessageTimestamp() - Method in interface org.apache.camel.Message
-
Returns the timestamp that this messages originates from.
- getMetadata() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.Gets a key/value metadata associated with the service.
- getMetadata() - Method in interface org.apache.camel.cloud.ServiceHealth
-
Deprecated.Gets a key/value metadata associated with the service.
- getMetaData() - Method in interface org.apache.camel.health.HealthCheck
-
Return metadata associated with this
HealthCheck
. - getMethod() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the HTTP method (GET, POST, PUT etc)
- getMinDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
The lowest duration time in millis.
- getMissCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Number of attempts which cannot be converted as no suitable type converter exists
- getModelJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the model information as JSON format.
- getName() - Method in interface org.apache.camel.CamelContext
-
Gets the name (id) of this CamelContext.
- getName() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.Gets the service name.
- getName() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.Attribute
-
Bean style accessor to name; This is required for framework like Jackson using bean convention for object serialization.
- getName() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.Code
-
Bean style accessor to name.
- getName() - Method in enum class org.apache.camel.ExchangePropertyKey
- getName() - Method in interface org.apache.camel.ExtendedCamelContext
- getName() - Method in exception class org.apache.camel.NoSuchBeanException
- getName() - Method in interface org.apache.camel.spi.CamelContextNameStrategy
-
Gets the name
- getName() - Method in class org.apache.camel.spi.DataType
- getName() - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
Gets the name
- getName() - Method in interface org.apache.camel.spi.PropertiesFunction
-
Name of the function which is used as name: to let the properties component know it is a function.
- getName() - Method in interface org.apache.camel.spi.PropertiesSource
-
Name of properties source
- getName() - Method in class org.apache.camel.spi.Transformer
-
Get the transformer name that represents the supported data type model.
- getName() - Method in interface org.apache.camel.StartupStep
-
Name of the step
- getNamePattern() - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
Gets the custom name pattern.
- getNamespace() - Method in interface org.apache.camel.cluster.CamelClusterView
- getNamespaces() - Method in interface org.apache.camel.cluster.CamelClusterService
-
Return the namespaces handled by this service.
- getNamespaces() - Method in interface org.apache.camel.spi.NamespaceAware
-
Gets the XML Namespaces
- getNameStrategy() - Method in interface org.apache.camel.CamelContext
-
Gets the current name strategy
- getNextName() - Method in interface org.apache.camel.spi.CamelContextNameStrategy
-
Gets the next calculated name, if this strategy is not using fixed names.
- getNextName() - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
Gets the next calculated name, if this strategy is not using fixed names.
- getNextProcessor() - Method in interface org.apache.camel.Channel
-
Gets the next
Processor
to route to (not wrapped) - getNode() - Method in interface org.apache.camel.MessageHistory
-
Gets the node at the point of this history.
- getNodeId() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
-
The id of the node from the route where the exchange was processed when the thread was set to block.
- getNodeId() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
The id of the node from the route where the exchange currently is being processed
- getNodePattern() - Method in interface org.apache.camel.spi.MessageHistoryFactory
-
An optional pattern to filter which nodes to trace in this message history.
- getNodePrefixId() - Method in interface org.apache.camel.NamedNode
-
Gets the node prefix id.
- getNodePrefixId() - Method in interface org.apache.camel.NamedRoute
-
Gets the node prefix id.
- getNodePrefixId() - Method in interface org.apache.camel.Route
-
Gets the node prefix id
- getNonControlledRouteIds() - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Returns the route ids of routes which are non controlled (such as routes that was excluded)
- getNoopCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Number of noop attempts (no type conversion was needed)
- getNotConsumerOnly() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getNotProducerOnly() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getNumberOfErrors() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getNumberOfErrors() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getNumberOfWarnings() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getNumberOfWarnings() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getObjectName(Object) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForCamelContext(String, String) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForCamelContext(CamelContext) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForCamelHealth(CamelContext) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForClusterService(CamelContext, CamelClusterService) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForComponent(Component, String) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForConsumer(CamelContext, Consumer) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForDataFormat(CamelContext, DataFormat) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForEndpoint(Endpoint) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForEventNotifier(CamelContext, EventNotifier) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForProcessor(CamelContext, Processor, NamedNode) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForProducer(CamelContext, Producer) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForRoute(Route) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForRouteController(CamelContext, RouteController) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForService(CamelContext, Service) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForStep(CamelContext, Processor, NamedNode) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForThreadPool(CamelContext, ThreadPoolExecutor, String, String) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getObjectNameForTracer(CamelContext, Service) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
- getOffsetKey() - Method in interface org.apache.camel.resume.Resumable
-
Gets the offset key (i.e.: the addressable part of the resumable object)
- getOnCompletions() - Method in interface org.apache.camel.Route
- getOnException(String) - Method in interface org.apache.camel.Route
- getOnExceptions() - Method in interface org.apache.camel.Route
- getOnlyRegisterProcessorWithCustomId() - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to only register processors which has a custom id assigned.
- getOperator() - Method in interface org.apache.camel.BinaryPredicate
-
Gets the operator
- getOptionKey() - Method in exception class org.apache.camel.PropertyBindingException
- getOptionPrefix() - Method in exception class org.apache.camel.PropertyBindingException
- getOptionType(String, boolean) - Method in interface org.apache.camel.spi.PropertyConfigurerGetter
-
Gets the option class type.
- getOptionValue(Object, String, boolean) - Method in interface org.apache.camel.spi.PropertyConfigurerGetter
-
Gets the property value
- getOrder() - Method in interface org.apache.camel.cloud.ServiceRegistry
-
Deprecated.
- getOrder() - Method in interface org.apache.camel.cluster.CamelClusterService
- getOrder() - Method in interface org.apache.camel.health.HealthCheck
- getOrder() - Method in interface org.apache.camel.Ordered
-
Gets the order.
- getOrder() - Method in interface org.apache.camel.spi.BulkTypeConverters
- getOrder() - Method in interface org.apache.camel.spi.CamelContextCustomizer
- getOrder() - Method in interface org.apache.camel.spi.ComponentCustomizer
- getOrder() - Method in interface org.apache.camel.spi.DataFormatCustomizer
- getOrder() - Method in interface org.apache.camel.spi.LanguageCustomizer
- getOrElseProperty(Object, String, Object, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Gets the property or else returning the default value.
- getOriginalEndpoint() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
-
The original endpoint which was intercepted.
- getOriginalInMessage() - Method in interface org.apache.camel.spi.UnitOfWork
-
Gets the original IN
Message
this Unit of Work was started with. - getOriginalUri() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
- getOtherJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the other (miscellaneous) information as JSON format.
- getOut() - Method in interface org.apache.camel.Exchange
-
Deprecated.
- getOut(Class<T>) - Method in interface org.apache.camel.Exchange
-
Deprecated.
- getOutput() - Method in interface org.apache.camel.Channel
-
Gets the wrapped output that at runtime should be delegated to.
- getOutput() - Method in interface org.apache.camel.spi.DumpRoutesStrategy
- getOutput() - Method in interface org.apache.camel.spi.ErrorHandlerRedeliveryCustomizer
-
Returns the output processor
- getOutputType() - Method in class org.apache.camel.spi.Contract
- getOutType() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Optional detail about output binding to a FQN class name.
- getOwner() - Method in exception class org.apache.camel.InvalidPropertyException
- getParameterKeys() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
A set of input parameter names which fails the verification.
- getParameters() - Method in interface org.apache.camel.RouteTemplateContext
-
The parameters to use for the route template when creating the new route
- getParent() - Method in interface org.apache.camel.NamedNode
-
Returns the parent
- getParentId() - Method in interface org.apache.camel.StartupStep
-
The id of the parent step
- getPassword() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
- getPattern() - Method in interface org.apache.camel.Exchange
-
Returns the
ExchangePattern
(MEP) of this exchange. - getPattern(List<String>) - Method in class org.apache.camel.support.jsse.FilterParameters
-
Compiles
Pattern
s for each expression inpatternStrings
. - getPatterns() - Method in class org.apache.camel.support.jsse.FilterParameters
-
Returns an immutable collection of compiled filter patterns based on the state of this instance at the time of invocation.
- getPayload() - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
-
Returns the payload of the meta data as a POJO.
- getPayload(Class<T>) - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
-
Returns the payload of the meta data as specified type.
- getPayloadForTrait(MessageTrait) - Method in interface org.apache.camel.Message
-
Gets the payload for the
MessageTrait
- getPendingExchangesSize() - Method in interface org.apache.camel.spi.ShutdownAware
-
Gets the number of pending exchanges.
- getPhase() - Method in interface org.apache.camel.spi.RouteError
-
Gets the phase associated with the error.
- getPojoBeanJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the pojo bean information as JSON format.
- getPojoBeanParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
-
Returns the JSON schema representation of the pojo bean parameters for the given bean name.
- getPolicyId() - Method in exception class org.apache.camel.CamelAuthorizationException
- getPooledCounter() - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Number of currently exchanges being pooled (if pooled is in use)
- getPoolSize() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets the core pool size (threads to keep minimum in pool)
- getPort() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.Gets the port number of the server hosting the service.
- getPort() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the port to use by the REST consumer
- getPort() - Method in class org.apache.camel.vault.HashicorpVaultConfiguration
- getPredicateFactory() - Method in interface org.apache.camel.spi.PredicateFactoryAware
-
Gets the
PredicateFactory
. - getPrivateKey(String) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
- getProcessingThreadName() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The name of the thread that is processing the message, when this event was captured.
- getProcessor() - Method in interface org.apache.camel.Consumer
-
The processor that will process the
Exchange
that was consumed. - getProcessor() - Method in interface org.apache.camel.DelegateProcessor
-
Gets the delegated
Processor
. - getProcessor() - Method in interface org.apache.camel.Route
-
Gets the
Processor
- getProcessor() - Method in interface org.apache.camel.spi.ProcessorExchangeFactory
-
The processor using this factory.
- getProcessor(String) - Method in interface org.apache.camel.CamelContext
-
Gets the processor from any of the routes which with the given id
- getProcessor(String, Class<T>) - Method in interface org.apache.camel.CamelContext
-
Gets the processor from any of the routes which with the given id
- getProcessorExchangeFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the processor exchange factory to use.
- getProducerApiDoc() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the location of the api document (swagger api) the REST producer will use to validate the REST uri and query parameters are valid accordingly to the api document.
- getProducerComponent() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the name of the Camel component to use as the REST producer
- getProduces() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Optional details about what media-types the REST service returns
- getProfile() - Method in interface org.apache.camel.ExtendedCamelContext
-
The profile Camel should run as (dev,test,prod).
- getProfileName() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- getProjectId() - Method in class org.apache.camel.vault.GcpVaultConfiguration
- getProperties() - Method in interface org.apache.camel.Exchange
-
Returns the properties associated with the exchange
- getProperties() - Method in interface org.apache.camel.Route
-
This property map is used to associate information about the route.
- getProperties() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
- getProperties(Object, Map<String, Object>, String) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Will inspect the target for properties.
- getProperties(Object, Map<String, Object>, String, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Will inspect the target for properties.
- getPropertiesComponent() - Method in interface org.apache.camel.CamelContext
-
Returns the configured properties component or create one if none has been configured.
- getPropertiesFunction(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Gets the
PropertiesFunction
by the given name - getPropertiesSource(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Gets the custom
PropertiesSource
by the name - getPropertiesSourceFactory() - Method in interface org.apache.camel.spi.PropertiesComponent
-
Gets the
PropertiesSourceFactory
. - getPropertiesSources() - Method in interface org.apache.camel.spi.PropertiesComponent
-
Gets the properties sources
- getProperty(String) - Method in interface org.apache.camel.Exchange
-
Returns a property associated with this exchange by name
- getProperty(String) - Method in interface org.apache.camel.RouteTemplateContext
-
Gets the property with the given name
- getProperty(String) - Method in interface org.apache.camel.spi.PropertiesSource
-
Gets the property with the name
- getProperty(String, Class<?>) - Method in interface org.apache.camel.RouteTemplateContext
-
Gets the property with the given 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, Object, 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, String) - Method in interface org.apache.camel.spi.PropertiesSource
-
Gets the property with the name
- getProperty(ExchangePropertyKey) - Method in interface org.apache.camel.Exchange
-
Returns a property associated with this exchange by the key
- getProperty(ExchangePropertyKey, Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns a property associated with this exchange by the key and specifying the type required
- getProperty(ExchangePropertyKey, Object, Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns a property associated with this exchange by name and specifying the type required
- getPropertyConfigurer(Object) - Method in interface org.apache.camel.spi.PropertyConfigurerAware
-
Gets the configurer.
- getPropertyGetter(Class<?>, String, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Gets the getter method for the property.
- getPropertyName() - Method in exception class org.apache.camel.InvalidPropertyException
- getPropertyName() - Method in exception class org.apache.camel.NoSuchHeaderOrPropertyException
- getPropertyName() - Method in exception class org.apache.camel.NoSuchPropertyException
- getPropertyName() - Method in exception class org.apache.camel.PropertyBindingException
- getPropertySetter(Class<?>, String) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Gets the setter method for the property.
- getPrototypeEndpoint(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Resolves the given name to an
Endpoint
of the specified type (scope is prototype). - getPrototypeEndpoint(NormalizedEndpointUri) - Method in interface org.apache.camel.ExtendedCamelContext
-
Resolves the given name to an
Endpoint
of the specified type (scope is prototype). - getProvider() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
- getProvider() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
- getProvider() - Method in class org.apache.camel.support.jsse.SecureRandomParameters
- getProvider() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getProvider() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
- getQueueSize() - Method in interface org.apache.camel.spi.BacklogTracer
-
Number of traced messages in the backlog
- getReactiveExecutor() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the
ReactiveExecutor
to use. - getReader() - Method in interface org.apache.camel.spi.Resource
-
Returns a
Reader
that reads from the underlying resource using UTF-8 as charset. - getReader(Charset) - Method in interface org.apache.camel.spi.Resource
- getReadOnlyMap() - Method in interface org.apache.camel.spi.EndpointRegistry
-
Gets a read-only map of the endpoints currently in the registry.
- getReadOnlyValues() - Method in interface org.apache.camel.spi.EndpointRegistry
-
Gets a read-only collection of the endpoints currently in the registry.
- getRecordingDir() - Method in interface org.apache.camel.spi.StartupStepRecorder
- getRecordingProfile() - Method in interface org.apache.camel.spi.StartupStepRecorder
- getRecoveryInterval() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Gets the interval between recovery scans in millis.
- getRecoveryIntervalInMillis() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Deprecated.use getRecoveryInterval
- getRefreshPeriod() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- getRefreshPeriod() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getRefreshPeriod() - Method in class org.apache.camel.vault.GcpVaultConfiguration
- getRegion() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- getRegisterAlways() - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to always register mbeans.
- getRegisterNewRoutes() - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to register mbeans when starting a new route
- getRegisterRoutesCreateByKamelet() - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to register mbeans for routes created by a Kamelet
- getRegisterRoutesCreateByTemplate() - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to register mbeans for routes created by a route templates (not Kamelets)
- getRegistry() - Method in interface org.apache.camel.CamelContext
-
Returns the registry used to lookup components by name and type such as SimpleRegistry, Spring ApplicationContext, JNDI, or the OSGi Service Registry.
- getRegistry() - Method in interface org.apache.camel.ExtendedCamelContext
- getRegistry(Class<T>) - Method in interface org.apache.camel.CamelContext
-
Returns the registry used to lookup components by name and as the given type
- getRejectedExecutionHandler() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets the handler for tasks which cannot be executed by the thread pool.
- getRejectedPolicy() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets the policy for tasks which cannot be executed by the thread pool.
- getReleasedCounter() - Method in interface org.apache.camel.spi.PooledObjectFactory.Statistics
-
Number of exchanges released back to pool
- getReloadCounter() - Method in interface org.apache.camel.spi.ReloadStrategy
-
Number of reloads succeeded.
- getRepository(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Returns the repository identified by the given
id
if available. - getRequired() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getRequired() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getResource() - Method in interface org.apache.camel.spi.ResourceAware
-
Gets the
Resource
. - getResource() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
- getResourcePath() - Method in interface org.apache.camel.spi.FactoryFinder
-
Gets the resource classpath.
- getResourceReload() - Method in interface org.apache.camel.spi.ResourceReloadStrategy
-
Gets the resource listener that is triggered on reload.
- getRestartException(String) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Gets the last exception that caused the route to not startup for the given route
- getRestartingRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Return the list of routes that are currently under restarting by this controller.
- getRestartingRouteState(String) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Gets the state of the backoff for the given route if its managed and under restarting.
- getRestConfiguration() - Method in interface org.apache.camel.CamelContext
-
Gets the default REST configuration
- getRestRegistry() - Method in interface org.apache.camel.CamelContext
-
Gets the
RestRegistry
to use - getResultType() - Method in interface org.apache.camel.spi.ExpressionResultTypeAware
-
Gets the result type
- getResumeCache() - Method in class org.apache.camel.resume.ResumeStrategyConfiguration
- getResumeStrategy() - Method in interface org.apache.camel.resume.ResumeAware
-
Gets the
ResumeStrategy
instance - getResumeStrategyConfiguration() - Method in interface org.apache.camel.resume.ResumeStrategy
- getRight() - Method in interface org.apache.camel.BinaryPredicate
-
Gets the right hand side expression
- getRoute() - Method in interface org.apache.camel.Channel
-
Gets the
Route
- getRoute() - Method in interface org.apache.camel.Route
-
Get the route type.
- getRoute() - Method in interface org.apache.camel.RouteAware
-
Gets the
Route
- getRoute() - Method in interface org.apache.camel.spi.CamelEvent.RouteEvent
- getRoute() - Method in interface org.apache.camel.spi.RouteStartupOrder
-
Gets the route
- getRoute() - Method in interface org.apache.camel.spi.UnitOfWork
-
Gets the
Route
that thisUnitOfWork
currently is being routed through. - getRoute(String) - Method in interface org.apache.camel.CamelContext
-
Gets the route with the given id
- getRouteController() - Method in interface org.apache.camel.CamelContext
-
Gets the
RouteController
- getRouteController() - Method in interface org.apache.camel.Route
-
Gets the
RouteController
for this route. - getRouteDescription() - Method in interface org.apache.camel.Route
-
Gets the route description
- getRouteId() - Method in exception class org.apache.camel.FailedToCreateRouteException
- getRouteId() - Method in exception class org.apache.camel.FailedToCreateRouteFromTemplateException
- getRouteId() - Method in exception class org.apache.camel.FailedToStartRouteException
- getRouteId() - Method in interface org.apache.camel.MessageHistory
-
Gets the route id at the point of this history.
- getRouteId() - Method in interface org.apache.camel.NamedRoute
-
Gets the route id.
- getRouteId() - Method in interface org.apache.camel.Route
-
Gets the route id
- getRouteId() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
-
The id of the route where the exchange was processed when the thread was set to block.
- getRouteId() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Route id
- getRouteId() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
The route id where this service is used as route consumer, or used in the route by a send processor.
- getRouteId() - Method in interface org.apache.camel.spi.RouteIdAware
-
Gets the route id
- getRouteId() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
-
The route id (if the endpoint is associated with a route)
- getRouteMessage(String) - Static method in exception class org.apache.camel.FailedToCreateRouteException
- getRoutePolicyFactories() - Method in interface org.apache.camel.CamelContext
-
Gets the route policy factories
- getRoutePolicyList() - Method in interface org.apache.camel.Route
-
Gets the route policy List
- getRoutes() - Method in interface org.apache.camel.CamelContext
-
Returns the current routes in this CamelContext
- getRoutesLoader(String) - Method in interface org.apache.camel.spi.RoutesLoader
-
Looks up a
RoutesBuilderLoader
in the registry or fallback to a factory finder mechanism if none found. - getRoutesSize() - Method in interface org.apache.camel.CamelContext
-
Returns the total number of routes in this CamelContext
- getRouteStartupOrder() - Method in interface org.apache.camel.ExtendedCamelContext
-
Returns the order in which the route inputs was started.
- getRouteStatus(String) - Method in interface org.apache.camel.spi.RouteController
-
Returns the current status of the given route
- getRouteSynchronization() - Method in interface org.apache.camel.spi.Synchronization
-
Get an optional
SynchronizationRouteAware
for this synchronization - getRuntime() - Method in interface org.apache.camel.spi.CliConnectorFactory
-
What runtime platform is in use, such as camel-jbang, camel-spring-boot, or camel-quarkus etc.
- getRuntimeCamelCatalog() - Method in interface org.apache.camel.ExtendedCamelContext
-
Deprecated.
- getRuntimeEndpointRegistry() - Method in interface org.apache.camel.CamelContext
-
Gets the
RuntimeEndpointRegistry
to use, or null if none is in use. - getRuntimeStartClass() - Method in interface org.apache.camel.spi.CliConnectorFactory
-
The main class used by the runtime to start.
- getRuntimeVersion() - Method in interface org.apache.camel.spi.CliConnectorFactory
-
What runtime platform version is in use.
- getSafeCopyProperty(String, Class<T>) - Method in interface org.apache.camel.ExchangeExtension
-
To get a property that was copied specially (thread safe with deep cloning).
- getScheme() - Method in class org.apache.camel.spi.DataType
- getScheme() - Method in interface org.apache.camel.spi.EmbeddedHttpService
-
HTTP or HTTPS
- getScheme() - Method in interface org.apache.camel.spi.Resource
-
The scheme of the resource such as file, classpath, http
- getScheme() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the scheme to use by the REST consumer
- getScheme() - Method in interface org.apache.camel.spi.SendDynamicAware
-
Gets the component name
- getScheme() - Method in class org.apache.camel.vault.HashicorpVaultConfiguration
- getScope() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.Result
-
Scope of the verification.
- getSecretKey() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- getSecrets() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- getSecrets() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getSecrets() - Method in class org.apache.camel.vault.GcpVaultConfiguration
- getSecrets() - Method in class org.apache.camel.vault.KubernetesVaultConfiguration
- getSecureRandom() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getSecureSocketProtocol() - Method in class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
-
Returns a live reference to the list of secure socket protocol names.
- getSecureSocketProtocol() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getSecureSocketProtocols() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the explicitly configured secure socket protocol names for this configuration.
- getSecureSocketProtocolsFilter() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the optional secure socket protocol filter for this configuration.
- getServerAliases(String, Principal[]) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
- getServerParameters() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getServerPort() - Method in interface org.apache.camel.spi.EmbeddedHttpService
-
Port number such as 8080, 443, or something else.
- getService() - Method in interface org.apache.camel.spi.CamelEvent.ServiceEvent
- getServiceAccountKey() - Method in class org.apache.camel.vault.GcpVaultConfiguration
- getServiceChooser() - Method in interface org.apache.camel.cloud.ServiceChooserAware
-
Deprecated.Get the
ServiceChooser
- getServiceDiscovery() - Method in interface org.apache.camel.cloud.ServiceDiscoveryAware
-
Deprecated.Get the
ServiceDiscovery
- getServiceFilter() - Method in interface org.apache.camel.cloud.ServiceFilterAware
-
Deprecated.Get the
ServiceFilter
- getServiceMetadata() - Method in interface org.apache.camel.spi.EndpointServiceLocation
-
Optional metadata that is relevant to the service as key value pairs.
- getServiceMetadata() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
Optional metadata that is relevant to the service as key value pairs.
- getServiceProperties() - Method in interface org.apache.camel.cloud.DiscoverableService
-
Deprecated.Get the service properties.
- getServiceProtocol() - Method in interface org.apache.camel.spi.EndpointServiceLocation
-
Get the protocol the service is using such as http, amqp, tcp.
- getServiceProtocol() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
Get the protocol the service is using such as http, amqp, tcp.
- getServices() - Method in interface org.apache.camel.ExtendedCamelContext
-
Returns an unmodifiable list of the services registered currently in this
CamelContext
. - getServices() - Method in interface org.apache.camel.Route
-
Returns the services for this particular route
- getServices() - Method in interface org.apache.camel.spi.RouteStartupOrder
-
Gets the services to this route.
- getServices(String) - Method in interface org.apache.camel.cloud.ServiceDiscovery
-
Deprecated.Gets the list of services.
- getServiceUrl() - Method in interface org.apache.camel.spi.EndpointServiceLocation
-
Gets the remote address such as URL, hostname, connection-string, or cloud region, that are component specific.
- getServiceUrl() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
Gets the remote address such as URL, hostname, or connection-string that are component specific
- getSessionTimeout() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the optional
SSLSessionContext
timeout time forSSLSession
s in seconds. - getShortError() - Method in class org.apache.camel.catalog.LanguageValidationResult
- getShortName() - Method in interface org.apache.camel.NamedNode
-
Returns a short name for this node which can be useful for ID generation or referring to related resources like images
- getShutdownAwaitTermination() - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Gets the time to wait for thread pools to shutdown orderly, when invoking the
ShutdownableService.shutdown()
method. - getShutdownRoute() - Method in interface org.apache.camel.RuntimeConfiguration
-
Gets the option to use when shutting down the route.
- getShutdownRunningTask() - Method in interface org.apache.camel.RuntimeConfiguration
-
Gets the ShutdownRunningTask option in use when shutting down a route.
- getShutdownStrategy() - Method in interface org.apache.camel.CamelContext
-
Gets the current shutdown strategy.
- getSize() - Method in interface org.apache.camel.spi.PooledObjectFactory
-
The current number of objects in the pool
- getSNIHostNames() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
- getSNIHostNames() - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
- getSource() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextEvent
- getSource() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeEvent
- getSource() - Method in interface org.apache.camel.spi.CamelEvent
- getSource() - Method in interface org.apache.camel.spi.CamelEvent.RouteEvent
- getSource() - Method in interface org.apache.camel.spi.CamelEvent.ServiceEvent
- getSource() - Method in interface org.apache.camel.spi.ConsumerCache
-
Gets the source which uses this cache
- getSource() - Method in interface org.apache.camel.spi.ProducerCache
-
Gets the source which uses this cache
- getSourceLocation() - Method in interface org.apache.camel.Route
-
The source:line-number where the route input is located in the source code
- getSourceLocationShort() - Method in interface org.apache.camel.Route
-
The source:line-number in short format that can be used for logging or summary purposes.
- getSourceResource() - Method in interface org.apache.camel.Route
-
Gets the source resource that this route is located from
- getSpoolCipher() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- getSpoolDirectory() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- getSpoolThreshold() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- getSpoolUsedHeapMemoryLimit() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- getSpoolUsedHeapMemoryThreshold() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- getSqsQueueUrl() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- getSSLContextParameters() - Method in interface org.apache.camel.CamelContext
-
Gets the global SSL context parameters if configured.
- getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the list of configurers to apply to an
SSLEngine
in order to fully configure it in compliance with the provided configuration options. - getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
-
This implementation returns the empty list as the enabled cipher suites and protocols are not client and server side specific in an
SSLEngine
. - getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
-
This implementation allows for configuration of the need and want settings for client authentication, but ignores the enabled cipher suites and protocols as they are not client and server side specific in an
SSLEngine
. - getSSLServerSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the list of configurers to apply to an
SSLServerSocketFactory
in order to fully configure it in compliance with the provided configuration options. - getSSLServerSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
-
This class has no bearing on
SSLServerSocketFactory
instances and therefore provides no configurers for that purpose. - getSSLServerSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getSSLServerSocketFactorySSLServerSocketConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the list of configurers to apply to an
SSLServerSocket
in order to fully configure it in compliance with the provided configuration options. - getSSLServerSocketFactorySSLServerSocketConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
- getSSLSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the list of configurers to apply to an
SSLSocketFactory
in order to fully configure it in compliance with the provided configuration options. - getSSLSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getSSLSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
-
This class has no bearing on
SSLSocketFactory
instances and therefore provides no configurers for that purpose. - getSSLSocketFactorySSLSocketConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns the list of configurers to apply to an
SSLSocket
in order to fully configure it in compliance with the provided configuration options. - getStartedEventNotifiers() - Method in interface org.apache.camel.spi.ManagementStrategy
-
Gets all the started event notifiers, which is ready to be used.
- getStartupOrder() - Method in interface org.apache.camel.Route
-
Gets the route startup order
- getStartupOrder() - Method in interface org.apache.camel.spi.RouteStartupOrder
-
Get the order this route should be started.
- getStartupRecorderDuration() - Method in interface org.apache.camel.spi.StartupStepRecorder
-
How long time to run the startup recorder.
- getStartupStepRecorder() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the
StartupStepRecorder
to use. - getStartupSummaryLevel() - Method in interface org.apache.camel.CamelContext
-
Controls the level of information logged during startup (and shutdown) of
CamelContext
. - getState() - Method in interface org.apache.camel.health.HealthCheck.Result
-
The state of the service.
- getState() - Method in interface org.apache.camel.spi.Breakpoint
-
Gets the state of this break
- getState() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the state of the REST service (started, stopped, etc)
- getState(K) - Method in interface org.apache.camel.spi.StateRepository
-
Gets the state value for the given key.
- getStatistics() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
Gets the utilization statistics of this manager
- getStatistics() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
-
Gets the endpoint utilization statistics.
- getStatistics() - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Aggregated statistics for all the managed exchange factories
- getStatistics() - Method in interface org.apache.camel.spi.PooledObjectFactory
-
Gets the usage statistics
- getStatistics() - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Gets the utilization statistics.
- getStatistics() - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Gets the utilization statistics of this type converter registry
- getStatisticsLevel() - Method in interface org.apache.camel.spi.ManagementAgent
-
§ Gets the statistics level
- getStatus() - Method in interface org.apache.camel.CamelContextLifecycle
-
Get the status of this CamelContext
- getStatus() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.Result
-
Result of the validation as status.
- getStatus() - Method in interface org.apache.camel.StatefulService
-
Returns the current status
- getStatus() - Method in class org.apache.camel.support.service.BaseService
- getStatusPhase() - Method in interface org.apache.camel.ExtendedCamelContext
-
The
CamelContext
have additional phases that are not defined inServiceStatus
and this method provides the phase ordinal value. - getStepId() - Method in interface org.apache.camel.spi.CamelEvent.StepEvent
- getStreamCachingStrategy() - Method in interface org.apache.camel.CamelContext
-
Gets the
StreamCachingStrategy
to use. - getSubscriptionName() - Method in class org.apache.camel.vault.GcpVaultConfiguration
- getSupportedCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
- getSupportedCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- getSupportedExtension() - Method in interface org.apache.camel.spi.RoutesBuilderLoader
-
The supported file extension.
- getSupportedExtensions() - Method in interface org.apache.camel.Component
-
Gets a list of supported extensions.
- getSupportedScheme() - Method in interface org.apache.camel.spi.ResourceResolver
-
The supported resource scheme.
- getSuspendedBreakpointMessage(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Gets the trace event for the suspended exchange at the given breakpoint id or null if there is none at that id.
- getSuspendedBreakpointNodeIds() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Gets node ids for all current suspended exchanges at breakpoints
- getSuspendedExchange(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Gets the exchanged suspended at the given breakpoint id or null if there is none at that id.
- getSyntaxError() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getSyntaxError() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getTarget() - Method in exception class org.apache.camel.PropertyBindingException
- getTaskByType(Class<T>) - Method in interface org.apache.camel.spi.PeriodTaskScheduler
-
Gets an existing task by a given type, assuming there is only one task of the given type.
- getTemplateId() - Method in exception class org.apache.camel.FailedToCreateRouteFromTemplateException
- getTenantId() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getterOrSetterShorthandName - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
- getTestExcludeRoutes() - Method in interface org.apache.camel.ExtendedCamelContext
-
Used during unit-testing where it is possible to specify a set of routes to exclude from discovery
- getText() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getText() - Method in class org.apache.camel.catalog.LanguageValidationResult
- getThreadNamePattern() - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Gets the thread name pattern to use
- getThreadPoolFactory() - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Gets the
ThreadPoolFactory
to use for creating the thread pools. - getThreadPoolProfile(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Gets the thread pool profile by the given id
- getThreadPoolSize() - Method in interface org.apache.camel.spi.SupervisingRouteController
- getThreadsBlocked() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
Total number of threads that has been blocked
- getThreadsInterrupted() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
Total number of threads that has been forced interrupted
- getTime() - Method in interface org.apache.camel.MessageHistory
-
Gets the point in time the message history was created
- getTimeout() - Method in exception class org.apache.camel.ExchangeTimedOutException
-
Return the timeout which expired in milliseconds
- getTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Gets the timeout.
- getTimestamp() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Timestamp of the traced event
- getTimestamp() - Method in interface org.apache.camel.spi.CamelEvent
-
Timestamp for each event, when the event occurred.
- getTimeTaken() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSentEvent
- getTimeUnit() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Gets the time unit used
- getTimeUnit() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Gets the time unit used for keep alive time
- getTo() - Method in class org.apache.camel.spi.Transformer
-
Get 'to' data type.
- getTo() - Method in class org.apache.camel.spi.TransformerKey
- getTo() - Method in class org.apache.camel.spi.TypeConvertible
-
Gets the class instance that defines the "to" type (that is: Class<F>.class).
- getToken() - Method in class org.apache.camel.vault.HashicorpVaultConfiguration
- getToNode() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Node id where the message is being routed to
- getTotal() - Method in interface org.apache.camel.spi.CamelEvent.RouteReloadedEvent
-
Total number of routes being reloaded in this batch
- getTotalDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
The total duration time in millis.
- getToType() - Method in exception class org.apache.camel.NoTypeConversionAvailableException
-
Returns the required to type
- getToType() - Method in exception class org.apache.camel.TypeConversionException
-
Returns the required to type
- getToType() - Method in exception class org.apache.camel.TypeConverterExistsException
- getTraceCounter() - Method in interface org.apache.camel.spi.BacklogTracer
-
Gets the trace counter (total number of traced messages)
- getTraceCounter() - Method in interface org.apache.camel.spi.Tracer
-
Number of traced messages
- getTraceFilter() - Method in interface org.apache.camel.spi.BacklogTracer
-
Filter for tracing messages
- getTraceLabel() - Method in interface org.apache.camel.Traceable
-
Gets the trace label used for logging when tracing is enabled.
- getTracePattern() - Method in interface org.apache.camel.spi.BacklogTracer
-
Filter for tracing by route or node id
- getTracePattern() - Method in interface org.apache.camel.spi.Tracer
-
Tracing pattern to match which node EIPs to trace.
- getTracer() - Method in interface org.apache.camel.CamelContext
-
Gets the current
Tracer
- getTracingLoggingFormat() - Method in interface org.apache.camel.CamelContext
-
To use a custom tracing logging format.
- getTracingPattern() - Method in interface org.apache.camel.RuntimeConfiguration
-
Tracing pattern to match which node EIPs to trace.
- getTransformerJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Returns the transformer information as JSON format.
- getTransformerParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
-
Returns the JSON schema representation of the
DataTypeTransformer
parameters for the given transformer name. - getTransformerRegistry() - Method in interface org.apache.camel.CamelContext
-
Gets the
TransformerRegistry
- getTrustManager() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
- getTrustManagers() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- getType() - Method in exception class org.apache.camel.InvalidPayloadException
-
The expected type of the body
- getType() - Method in exception class org.apache.camel.InvalidPayloadRuntimeException
-
The expected type of the body
- getType() - Method in exception class org.apache.camel.NoSuchHeaderException
- getType() - Method in exception class org.apache.camel.NoSuchHeaderOrPropertyException
- getType() - Method in exception class org.apache.camel.NoSuchPropertyException
- getType() - Method in exception class org.apache.camel.NoSuchVariableException
- getType() - Method in exception class org.apache.camel.ProxyInstantiationException
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextInitializedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextInitializingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextReloadedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextReloadFailureEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextReloadingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextResumedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextResumeFailureEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextResumingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextRoutesStartedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextRoutesStartingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextRoutesStoppedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextRoutesStoppingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStartedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStartingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStartupFailureEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStopFailureEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStoppedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStoppingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextSuspendedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextSuspendingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeAsyncProcessingStartedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeCompletedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeCreatedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureHandledEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureHandlingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeRedeliveryEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSendingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSentEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteAddedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteReloadedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteRemovedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteStartedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteStartingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteStoppedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteStoppingEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ServiceStartupFailureEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.ServiceStopFailureEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.StepCompletedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.StepFailedEvent
- getType() - Method in interface org.apache.camel.spi.CamelEvent.StepStartedEvent
- getType() - Method in class org.apache.camel.spi.Validator
-
Get 'from' data type.
- getType() - Method in class org.apache.camel.spi.ValidatorKey
- getType() - Method in interface org.apache.camel.StartupStep
-
The source class type of the step
- getType() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
- getTypeConverter() - Method in interface org.apache.camel.CamelContext
-
Returns the type converter used to coerce types from one type to another.
- getTypeConverterExists() - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
What should happen when attempting to add a duplicate type converter.
- getTypeConverterExistsLoggingLevel() - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
The logging level to use when logging that a type converter already exists when attempting to add a duplicate type converter.
- getTypeConverterRegistry() - Method in interface org.apache.camel.CamelContext
-
Returns the type converter registry where type converters can be added or looked up
- getUid() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Unique id of the traced message
- 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
- getUnknown() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getUnknown() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getUnknownComponent() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getUnknownComponent() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getUnknownSuggestions() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- getUnknownSuggestions() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getUpdateRouteEnabled() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets whether updating routes via JMX is allowed (is default disabled).
- getUptime() - Method in interface org.apache.camel.CamelContext
-
Gets the uptime for this context.
- getUptime() - Method in interface org.apache.camel.Route
-
Gets the uptime in a human-readable format
- getUptimeMillis() - Method in interface org.apache.camel.Route
-
Gets the uptime in milliseconds
- getUri() - Method in class org.apache.camel.catalog.EndpointValidationResult
- getUri() - Method in exception class org.apache.camel.FailedToCreateConsumerException
- getUri() - Method in exception class org.apache.camel.FailedToCreateProducerException
- getUri() - Method in exception class org.apache.camel.NoFactoryAvailableException
- getUri() - Method in exception class org.apache.camel.NoSuchEndpointException
- getUri() - Method in exception class org.apache.camel.ResolveEndpointFailedException
- getUri() - Method in interface org.apache.camel.spi.NormalizedEndpointUri
-
Gets the normalized uri
- getUri() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
-
The endpoint uri
- getUri() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
- getURI() - Method in interface org.apache.camel.spi.Resource
-
The
URI
of the resource. - getUriTemplate() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the uri template
- getUrl() - Method in exception class org.apache.camel.LoadPropertiesException
- getUrl() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the absolute url to the REST service (baseUrl + uriTemplate)
- getURL() - Method in interface org.apache.camel.spi.Resource
-
The
URL
for the resource ornull
if the URL can not be computed. - getUseHostIPAddress() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets whether host IP Address to be used instead of host name.
- getUsePlatformMBeanServer() - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to use the platform MBean Server.
- getUuidGenerator() - Method in interface org.apache.camel.CamelContext
-
Gets the current
UuidGenerator
- getValidatorRegistry() - Method in interface org.apache.camel.CamelContext
-
Gets the
ValidatorRegistry
- getValue() - Method in enum class org.apache.camel.Category
-
Returns the string representation of this value
- getValue() - Method in exception class org.apache.camel.NoTypeConversionAvailableException
-
Returns the value which could not be converted
- getValue() - Method in exception class org.apache.camel.PropertyBindingException
- getValue() - Method in interface org.apache.camel.resume.Offset
-
Gets the offset value
- getValue() - Method in interface org.apache.camel.resume.OffsetKey
-
Gets the key value
- getValue() - Method in interface org.apache.camel.StaticExpression
-
Gets the constant value
- getValue() - Method in exception class org.apache.camel.TypeConversionException
-
Returns the value which could not be converted
- getValue(Class<V>) - Method in interface org.apache.camel.resume.Offset
-
Gets the offset value converting it to the given type
- getVariable(String) - Method in interface org.apache.camel.CamelContext
-
To get a variable by name.
- getVariable(String) - Method in interface org.apache.camel.Exchange
-
Returns a variable by name
- getVariable(String) - Method in interface org.apache.camel.VariableAware
-
Returns a variable by name.
- getVariable(String, Class<T>) - Method in interface org.apache.camel.CamelContext
-
To get a variable by name and covert to the given type.
- getVariable(String, Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns a variable by name and specifying the type required
- getVariable(String, Object, Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns a variable by name and specifying the type required
- getVariableName() - Method in exception class org.apache.camel.NoSuchVariableException
- getVariableRepository(String) - Method in interface org.apache.camel.spi.VariableRepositoryFactory
-
Gets the
VariableRepository
for the given id - getVariables() - Method in interface org.apache.camel.Exchange
-
Returns the variables from the current exchange
- getVariables() - Method in interface org.apache.camel.spi.BrowsableVariableRepository
-
Gets all the variables in a Map
- getVaultConfiguration() - Method in interface org.apache.camel.CamelContext
-
Gets the vault configuration
- getVaultName() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- getVersion() - Method in interface org.apache.camel.CamelContext
-
Gets the version of the this CamelContext.
- getView(String) - Method in interface org.apache.camel.cluster.CamelClusterService
-
Get a view of the cluster bound to a namespace creating it if needed.
- getView(String) - Method in interface org.apache.camel.cluster.CamelPreemptiveClusterService
- getWaitDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
-
Time in millis the thread has been blocked waiting for the signal.
- getWorkDir() - Method in interface org.apache.camel.spi.CompileStrategy
-
Work directory for compiler.
- getWrapped() - Method in interface org.apache.camel.spi.WrapAwareProcessor
-
Gets the wrapped
Processor
- getXmlDataFormat() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the name of the xml data format.
- GLOBAL_VARIABLE_REPOSITORY_ID - Static variable in interface org.apache.camel.spi.VariableRepositoryFactory
-
Registry bean id for global
VariableRepository
. - GlobalEndpointConfiguration - Interface in org.apache.camel
-
Global endpoint configurations which can be set as defaults when Camel creates new
Endpoint
s. - GlobalSSLContextParametersSupplier - Interface in org.apache.camel.support.jsse
-
A global
Supplier
ofSSLContextParameters
to be used in Camel registry. - group() - Element in annotation interface org.apache.camel.spi.annotations.DevConsole
-
The group of the dev console
- GROUP_NAME - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.GroupAttribute
-
Group name
- GROUP_OPTIONS - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.GroupAttribute
-
Options for the group
- GROUP_PROPERTY - Static variable in interface org.apache.camel.Route
- GroupAware - Interface in org.apache.camel.spi
-
To allow objects to be injected with an group.
- GROUPED_EXCHANGE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- GROUPED_EXCHANGE - Static variable in interface org.apache.camel.Exchange
H
- handleException(String, Throwable) - Method in interface org.apache.camel.spi.ExceptionHandler
-
Handles the given exception
- handleException(String, Exchange, Throwable) - Method in interface org.apache.camel.spi.ExceptionHandler
-
Handles the given exception
- handleException(Throwable) - Method in interface org.apache.camel.spi.ExceptionHandler
-
Handles the given exception
- Handler - Annotation Interface 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
invalid reference
BeanEndpoint
- handoverCompletions() - Method in interface org.apache.camel.ExchangeExtension
-
Handover all the on completions from this exchange
- handoverCompletions(Exchange) - Method in interface org.apache.camel.ExchangeExtension
-
Handover all the on completions from this exchange to the target exchange.
- handoverSynchronization(Exchange) - Method in interface org.apache.camel.spi.UnitOfWork
-
Handover all the registered synchronizations to the target
Exchange
. - handoverSynchronization(Exchange, Predicate<Synchronization>) - Method in interface org.apache.camel.spi.UnitOfWork
-
Handover all the registered synchronizations to the target
Exchange
. - hasBreakpoint(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Does the node have a breakpoint
- HasCamelContext - Interface in org.apache.camel.spi
-
A simple marker interface for an object which holds a
CamelContext
. - hasComponent(String) - Method in interface org.apache.camel.CamelContext
-
Is the given component already registered?
- hasDataType() - Method in interface org.apache.camel.spi.DataTypeAware
-
Whether any data type has been configured
- hasEndpoint(String) - Method in interface org.apache.camel.CamelContext
-
Is the given endpoint already registered in the
EndpointRegistry
- hasEndpoint(NormalizedEndpointUri) - Method in interface org.apache.camel.ExtendedCamelContext
-
Is the given endpoint already registered in the
EndpointRegistry
- hasEnvironmentVariable(String) - Method in interface org.apache.camel.RouteTemplateContext
-
Whether the route template has an environment variable parameter that matches the given parameter name.
- hasErrors() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- hasErrors() - Method in class org.apache.camel.catalog.EndpointValidationResult
- hasException() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Was there an exception thrown during processing
- hasGetterAndSetter - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
- HasGroup - Interface in org.apache.camel.spi
-
A simple marker interface for an object which has belongs to a group Group which is useful for group related operation such as clustering, JMX style API
- hashCode() - Method in class org.apache.camel.spi.Contract
- hashCode() - Method in class org.apache.camel.spi.DataType
- hashCode() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationError
-
Returns a hash code value for this object.
- hashCode() - Method in class org.apache.camel.spi.TypeConvertible
- hashCode() - Method in class org.apache.camel.ValueHolder
- hasHeaders() - Method in interface org.apache.camel.Message
-
Returns whether any headers have been set.
- HasHealthChecks - Interface in org.apache.camel.health
-
An interface to represent an object which provides
HealthCheck
- hashicorp() - Method in class org.apache.camel.vault.VaultConfiguration
-
Hashicorp Vault Configuration
- HashicorpVaultConfiguration - Class in org.apache.camel.vault
-
Configuration for access to Hashicorp Vault Secrets.
- HashicorpVaultConfiguration() - Constructor for class org.apache.camel.vault.HashicorpVaultConfiguration
- HasId - Interface in org.apache.camel.spi
-
A simple marker interface for an object which has a unique ID which is useful for referring to objects in REST or JMX style APIs
- hasMessageId() - Method in interface org.apache.camel.Message
-
Whether the message has any message ID assigned.
- hasNext() - Method in interface org.apache.camel.Navigate
-
Are there more outputs?
- hasOut() - Method in interface org.apache.camel.Exchange
-
Deprecated.
- hasParameter(String) - Method in interface org.apache.camel.RouteTemplateContext
-
Whether the route template has a parameter with the given name
- hasProperties() - Method in interface org.apache.camel.Exchange
-
Returns whether any properties have been set
- hasPropertiesFunction(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Is there a
PropertiesFunction
with the given name? - hasService(Class<T>) - Method in interface org.apache.camel.CamelContext
-
Has the given service type already been added to this CamelContext?
- hasService(Object) - Method in interface org.apache.camel.CamelContext
-
Has the given service already been added to this CamelContext?
- hasService(Predicate<Service>) - Method in interface org.apache.camel.CamelContext
-
Finds the first service matching the filter
- hasServices(Class<T>) - Method in interface org.apache.camel.CamelContext
-
Has the given service type already been added to this CamelContext?
- hasState() - Method in interface org.apache.camel.spi.CamelInternalProcessorAdvice
-
Whether this advice has state or not.
- hasTimeoutOccurred() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Deprecated.
- hasTrait(MessageTrait) - Method in interface org.apache.camel.Message
-
Checks whether the message has a given
MessageTrait
- hasUnhealthyRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Indicates if the route controller has routes that are currently unhealthy such as they have not yet been successfully started, and if being supervised then the route can either be pending restarts or failed all restart attempts and are exhausted.
- hasVariables() - Method in interface org.apache.camel.Exchange
-
Returns whether any variables have been set on the current exchange
- hasVariables() - Method in interface org.apache.camel.spi.BrowsableVariableRepository
-
Are there any variables in the repository.
- hasWarnings() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- hasWarnings() - Method in class org.apache.camel.catalog.EndpointValidationResult
- header(Exchange, String) - Static method in exception class org.apache.camel.NoSuchHeaderOrPropertyException
- Header - Annotation Interface in org.apache.camel
-
Marks a parameter as being a header on an inbound
Message
- HeaderFilterStrategy - Interface in org.apache.camel.spi
-
Interface to allow plug-able implementation to filter header to and from Camel message.
- HeaderFilterStrategy.Direction - Enum Class in org.apache.camel.spi
-
The direction is either IN or OUT.
- HeaderFilterStrategyAware - Interface in org.apache.camel.spi
-
An interface to represent an object which can make use of injected
HeaderFilterStrategy
. - Headers - Annotation Interface in org.apache.camel
-
Marks a parameter as being an injection point of the headers of an inbound
Message
- headersClass() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
The class that contains all the name of headers that are supported by the consumer and/or producer.
- HeadersMapFactory - Interface in org.apache.camel.spi
- headersNameProvider() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
The name of the field to get or the name of the method without parameters to invoke to get the name of the headers defined in an enum.
- HEALTH - Enum constant in enum class org.apache.camel.Category
- HealthCheck - Interface in org.apache.camel.health
-
Health check
- HealthCheck - Annotation Interface in org.apache.camel.spi.annotations
-
Marks a class as a custom health-check or health-check repository.
- HealthCheck.Kind - Enum Class in org.apache.camel.health
- HealthCheck.Result - Interface in org.apache.camel.health
-
Response to a health check invocation.
- HealthCheck.State - Enum Class in org.apache.camel.health
- HealthCheckAware - Interface in org.apache.camel.health
-
An interface to represent an object which wishes to be injected with the
HealthCheck
- HealthCheckHelper - Class in org.apache.camel.health
-
Helper for invoking
HealthCheck
's. - HealthCheckRegistry - Interface in org.apache.camel.health
-
A registry for health checks.
- HealthCheckRepository - Interface in org.apache.camel.health
-
A repository for health checks.
- HealthCheckResolver - Interface in org.apache.camel.health
-
A pluggable strategy for resolving health checks in a loosely coupled manner
- HealthCheckResultBuilder - Class in org.apache.camel.health
-
A builder helper to create a
HealthCheck
result. - HealthCheckResultStrategy - Interface in org.apache.camel.health
-
A strategy that allows SPI to process
HealthCheck
results and enrich and manipulate the result. - HIGHEST - Static variable in interface org.apache.camel.Ordered
-
The highest precedence
- HostedService - Interface in org.apache.camel.spi
-
To use for identifying
Consumer
which can host a service, such as a TCP network server, or an embedded HTTP server. - http() - Method in interface org.apache.camel.cloudevents.CloudEvent.Attribute
-
The name of the http header.
- HTTP - Enum constant in enum class org.apache.camel.Category
- HTTP_BASE_URI - Static variable in interface org.apache.camel.Exchange
- HTTP_CHARACTER_ENCODING - Static variable in interface org.apache.camel.Exchange
- HTTP_CHUNKED - Static variable in interface org.apache.camel.Exchange
- HTTP_CODE - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.HttpAttribute
-
The erroneous HTTP code that occurred
- HTTP_HOST - 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_PORT - Static variable in interface org.apache.camel.Exchange
- HTTP_PROTOCOL_VERSION - Static variable in interface org.apache.camel.Exchange
- HTTP_QUERY - Static variable in interface org.apache.camel.Exchange
- HTTP_RAW_QUERY - Static variable in interface org.apache.camel.Exchange
- HTTP_REDIRECT - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.HttpAttribute
-
If given as details, specifies that a redirect happened and the content of this detail is the redirect URL
- HTTP_RESPONSE_CODE - Static variable in interface org.apache.camel.Exchange
- HTTP_RESPONSE_CODE - Static variable in interface org.apache.camel.health.HealthCheck
- HTTP_RESPONSE_TEXT - Static variable in interface org.apache.camel.Exchange
- HTTP_SCHEME - Static variable in interface org.apache.camel.Exchange
- HTTP_SERVLET_REQUEST - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- HTTP_SERVLET_RESPONSE - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- HTTP_TEXT - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.HttpAttribute
-
HTTP response's body
- HTTP_URI - Static variable in interface org.apache.camel.Exchange
- HTTP_URL - Static variable in interface org.apache.camel.Exchange
- httpAttribute(String) - Method in interface org.apache.camel.cloudevents.CloudEvent
-
Mandatory find http attribute by id.
- HttpResponseAware - Interface in org.apache.camel.spi
-
Represents an object which is aware of HTTP responses.
I
- id() - Method in interface org.apache.camel.cloudevents.CloudEvent.Attribute
-
The ID of the attributes, can be used to look it up.
- ID_PROPERTY - Static variable in interface org.apache.camel.Route
- IdAware - Interface in org.apache.camel.spi
-
To allow objects to be injected with an id, such as EIP
Processor
s which has been defined from Camel routes. - IdempotentRepository - Interface in org.apache.camel.spi
-
Access to a repository of Message IDs to implement the Idempotent Consumer pattern.
- IfReplyExpected - Enum constant in enum class org.apache.camel.WaitForTaskToComplete
- Ignore - Enum constant in enum class org.apache.camel.TypeConverterExists
- ignoreInvalidEndpoints() - Element in annotation interface org.apache.camel.DynamicRouter
-
Whether to ignore the invalidate endpoint exception when try to create a producer with that endpoint
- ignoreInvalidEndpoints() - Element in annotation interface org.apache.camel.RecipientList
-
Whether to ignore the invalidate endpoint exception when try to create a producer with that endpoint
- ignoreInvalidEndpoints() - Element in annotation interface org.apache.camel.RoutingSlip
-
Whether to ignore the invalid endpoint exception when try to create a producer with that endpoint
- ignoreOnLoadError() - Element in annotation interface org.apache.camel.Converter
-
Whether to ignore the type converter if it cannot be loaded for some reason.
- ILLEGAL_PARAMETER - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
A given parameter is illegal
- ILLEGAL_PARAMETER_GROUP_COMBINATION - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
A combination of parameters is illegal.
- ILLEGAL_PARAMETER_VALUE - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
A parameter value is not valid
- IN - Enum constant in enum class org.apache.camel.spi.HeaderFilterStrategy.Direction
- include - Variable in class org.apache.camel.support.jsse.FilterParameters
- includeProperties() - Element in annotation interface org.apache.camel.spi.Metadata
-
To include one or more properties.
- INCOMPLETE_PARAMETER_GROUP - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
A group of parameters is not complete in order to be valid
- InflightRepository - Interface in org.apache.camel.spi
-
A repository which tracks in flight
Exchange
s. - InflightRepository.InflightExchange - Interface in org.apache.camel.spi
-
Information about the inflight exchange.
- INFO - Enum constant in enum class org.apache.camel.LoggingLevel
- init() - Method in interface org.apache.camel.CamelContextLifecycle
-
Initializes the CamelContext.
- init() - Method in interface org.apache.camel.Service
-
Initialize the service
- init() - Method in class org.apache.camel.support.service.BaseService
- init(CamelContext) - Method in interface org.apache.camel.Expression
-
Initialize the expression with the given camel context
- init(CamelContext) - Method in interface org.apache.camel.Predicate
-
Initialize the predicate with the given camel context
- initChannel(Route, NamedNode, NamedNode, List<InterceptStrategy>, Processor, NamedRoute, boolean) - Method in interface org.apache.camel.Channel
-
Initializes the channel.
- Initialized - Enum constant in enum class org.apache.camel.ServiceStatus
- INITIALIZED - Static variable in class org.apache.camel.support.service.BaseService
- initializeServices() - Method in interface org.apache.camel.Route
-
A strategy callback allowing special initialization when services are initializing.
- Initializing - Enum constant in enum class org.apache.camel.ServiceStatus
- INITIALIZING - Static variable in class org.apache.camel.support.service.BaseService
- initMethod() - Element in annotation interface org.apache.camel.BindToRegistry
-
The optional name of a method to call on the bean instance during initialization.
- initPredicate(CamelContext) - Method in interface org.apache.camel.Predicate
-
Initialize as a predicate with the given camel context
- initRoutesBuilderLoader(RoutesBuilderLoader) - Method in interface org.apache.camel.spi.RoutesLoader
-
Initializes the discovered
RoutesBuilderLoader
before its started and used for the first time. - initService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Initializes the given
value
if it's aService
or a collection of it. - initService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Initializes each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - 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 Quarkus to perform dependency injection.
- inline() - Element in annotation interface org.apache.camel.spi.annotations.YamlType
- inMemory() - Method in interface org.apache.camel.StreamCache
-
Whether this
StreamCache
is in memory only or spooled to persistent storage such as files. - InOnly - Enum constant in enum class org.apache.camel.ExchangePattern
- InOnly - Annotation Interface in org.apache.camel
-
Marks methods as being
ExchangePattern.InOnly
for one way asynchronous invocation when using Bean Integration to overload the default value which isExchangePattern.InOut
for request/reply if no annotations are used. - InOut - Enum constant in enum class org.apache.camel.ExchangePattern
- InOut - Annotation Interface in org.apache.camel
-
Marks a method as being
ExchangePattern.InOut
when a class or interface has been annotated withInOnly
when using Bean Integration. - inputLanguage() - Element in annotation interface org.apache.camel.spi.Metadata
-
If the option is some specific language such as SQL, XSLT, XML, JavaScript or something else.
- INTERCEPT_SEND_TO_ENDPOINT_WHEN_MATCHED - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- INTERCEPT_SEND_TO_ENDPOINT_WHEN_MATCHED - Static variable in interface org.apache.camel.Exchange
- InterceptableProcessor - Interface in org.apache.camel.spi
-
To control whether a
Processor
can be intercepted viaInterceptStrategy
. - INTERCEPTED_ENDPOINT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- INTERCEPTED_ENDPOINT - Static variable in interface org.apache.camel.Exchange
- InterceptEndpointFactory - Interface in org.apache.camel.spi
-
A factory to create
Endpoint
which are intercepted. - InterceptSendToEndpoint - Interface in org.apache.camel.spi
-
This is an endpoint when sending to it, is intercepted and is routed in a detour, with the following flow: before, send to original endpoint (can be skipped), after (optional).
- 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.
- INTERNAL - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
Internal error while performing the verification
- InternalProcessor - Interface in org.apache.camel.spi
-
Internal
Processor
that Camel routing engine used during routing for cross cutting functionality such as: ExecuteUnitOfWork
Keeping track which route currently is being routed ExecuteRoutePolicy
Gather JMX performance statics Tracing Debugging Message History Stream CachingTransformer
... and more. - InternalProcessorFactory - Interface in org.apache.camel.spi
-
A factory used internally by Camel to create
Processor
and other internal building blocks. - interrupt(String) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
To interrupt an exchange which may seem as stuck, to force the exchange to continue, allowing any blocking thread to be released.
- interrupt(Exchange) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
To interrupt an exchange which may seem as stuck, to force the exchange to continue, allowing any blocking thread to be released.
- INTERRUPTED - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- InvalidPayloadException - Exception Class in org.apache.camel
-
Is thrown if the payload from the exchange could not be retrieved because of being null, wrong class type etc.
- InvalidPayloadException(Exchange, Class<?>) - Constructor for exception class org.apache.camel.InvalidPayloadException
- InvalidPayloadException(Exchange, Class<?>, Message) - Constructor for exception class org.apache.camel.InvalidPayloadException
- InvalidPayloadException(Exchange, Class<?>, Message, Throwable) - Constructor for exception class org.apache.camel.InvalidPayloadException
- InvalidPayloadRuntimeException - Exception Class in org.apache.camel
-
Runtime version of the
InvalidPayloadException
. - InvalidPayloadRuntimeException(Exchange, Class<?>) - Constructor for exception class org.apache.camel.InvalidPayloadRuntimeException
- InvalidPayloadRuntimeException(Exchange, Class<?>, Throwable) - Constructor for exception class org.apache.camel.InvalidPayloadRuntimeException
- InvalidPayloadRuntimeException(Exchange, Class<?>, Message) - Constructor for exception class org.apache.camel.InvalidPayloadRuntimeException
- InvalidPayloadRuntimeException(Exchange, Class<?>, Message, Throwable) - Constructor for exception class org.apache.camel.InvalidPayloadRuntimeException
- InvalidPropertyException - Exception Class in org.apache.camel
-
An exception caused when an invalid property name is used on an object
- InvalidPropertyException(Object, String) - Constructor for exception class org.apache.camel.InvalidPropertyException
- InvalidPropertyException(Object, String, Class<?>) - Constructor for exception class org.apache.camel.InvalidPropertyException
- INVOCATION_COUNT - Static variable in interface org.apache.camel.health.HealthCheck
- INVOCATION_TIME - Static variable in interface org.apache.camel.health.HealthCheck
- invoke(Object, String, Exchange, AsyncCallback) - Method in interface org.apache.camel.spi.InvokeOnHeaderStrategy
-
Invoke the method based on the header key
- invoke(CamelContext) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes all the checks and returns a collection of results.
- invoke(CamelContext, String) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes all the checks and returns a collection of results.
- invoke(CamelContext, String, Map<String, Object>) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invoke a check by id.
- invoke(CamelContext, Function<HealthCheck, Map<String, Object>>) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes the checks and returns a collection of results.
- invoke(CamelContext, Function<HealthCheck, Map<String, Object>>, Predicate<HealthCheck>, String) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes the checks and returns a collection of results.
- invoke(CamelContext, Predicate<HealthCheck>) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes the checks and returns a collection of results.
- invokeLiveness(CamelContext) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes the liveness checks and returns a collection of results.
- invokeLiveness(CamelContext, String) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes the liveness checks and returns a collection of results.
- InvokeOnHeader - Annotation Interface in org.apache.camel.spi
-
Marks a method as being invoked for a specific header value.
- InvokeOnHeaderStrategy - Interface in org.apache.camel.spi
-
Pluggable strategy for invoking
InvokeOnHeader
. - invokeReadiness(CamelContext) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes the readiness checks and returns a collection of results.
- invokeReadiness(CamelContext, String) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes the readiness checks and returns a collection of results.
- IOT - Enum constant in enum class org.apache.camel.Category
- IS_REDELIVERY - Enum constant in enum class org.apache.camel.trait.message.RedeliveryTraitPayload
-
When a message supports redelivery, this indicates that this message is in a redelivery state
- isAcceptDebugger() - Method in interface org.apache.camel.MessageHistory
-
Used specially during debugging where some EIP nodes are not accepted for debugging and are essentially skipped.
- isAccepted() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- isAllowUseOriginalMessage() - Method in interface org.apache.camel.RuntimeConfiguration
-
Gets whether access to the original message from Camel's error handler, or from
UnitOfWork.getOriginalInMessage()
is allowed. - isAnySpoolRules() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- isAnyType(DataType) - Static method in class org.apache.camel.spi.DataType
- isApiVendorExtension() - Method in class org.apache.camel.spi.RestConfiguration
- isAssignableMatch(TypeConvertible<?, ?>) - Method in class org.apache.camel.spi.TypeConvertible
-
Tests whether the types defined in this type convertable pair are assignable from another type convertable pair
- isAutoRelease() - Method in interface org.apache.camel.PooledExchange
-
Whether this exchange was created to auto release when its unit of work is done
- isAutoStartup() - Method in interface org.apache.camel.Route
-
Gets whether the route should automatically start when Camel starts.
- isAutoStartup() - Method in interface org.apache.camel.RuntimeConfiguration
-
Gets whether the object should automatically start when Camel starts.
- isAutowiredEnabled() - Method in interface org.apache.camel.Component
-
Whether autowiring is enabled.
- isAutowiredEnabled() - Method in interface org.apache.camel.GlobalEndpointConfiguration
- isAutowiredEnabled() - Method in interface org.apache.camel.RuntimeConfiguration
-
Whether autowiring is enabled.
- isAzureIdentityEnabled() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- isBacklogTracing() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether backlog tracing is enabled.
- isBacklogTracingStandby() - Method in interface org.apache.camel.CamelContext
-
Whether to set backlog tracing on standby.
- isBacklogTracingTemplates() - Method in interface org.apache.camel.CamelContext
-
Whether backlog tracing should trace inner details from route templates (or kamelets).
- isBatchAllowed() - Method in interface org.apache.camel.BatchConsumer
-
Whether processing the batch is still allowed.
- isBeforeAfterProcess() - Method in interface org.apache.camel.spi.UnitOfWork
-
Whether the unit of work should call the before/after process methods or not.
- isBodyIncludeFiles() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether to include the message body of file based messages.
- isBodyIncludeFiles() - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include message body from files
- isBodyIncludeStreams() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether to include the message body of stream based messages.
- isBodyIncludeStreams() - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include message body from streams
- isBridgeErrorHandler() - Method in interface org.apache.camel.GlobalEndpointConfiguration
- isBuild() - Method in class org.apache.camel.support.service.BaseService
- isCaseInsensitive() - Method in interface org.apache.camel.spi.HeadersMapFactory
-
Whether the created
Map
are case insensitive or not. - isCaseInsensitiveHeaders() - Method in interface org.apache.camel.RuntimeConfiguration
-
Whether to use case sensitive or insensitive headers.
- isClientRequestValidation() - Method in class org.apache.camel.spi.RestConfiguration
- isContractFirst() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Is the rest service based on code-first or contract-first
- isCopyMessage() - Method in interface org.apache.camel.spi.MessageHistoryFactory
-
Whether to make a copy of the message in the
MessageHistory
. - isCreatedByKamelet() - Method in interface org.apache.camel.Route
-
Whether this route was created from a Kamelet.
- isCreatedByRestDsl() - Method in interface org.apache.camel.Route
-
Whether this route is a Rest DSL route.
- isCreatedByRouteTemplate() - Method in interface org.apache.camel.Route
-
Whether this route was created from a route template (or a Kamelet).
- isCreatedFromRest() - Method in interface org.apache.camel.NamedRoute
-
Is the route created from Rest DSL
- isCreatedFromTemplate() - Method in interface org.apache.camel.NamedRoute
-
Is the route created from template;
- isCustomId() - Method in interface org.apache.camel.Route
-
Whether the route id is custom assigned or auto assigned
- isDeadLetterChannel() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureEvent
- isDebugging() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether debugging is enabled.
- isDebugStandby() - Method in interface org.apache.camel.CamelContext
-
Whether to set backlog debugger on standby.
- isDefaultCredentialsProvider() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- isDefaultOrExtended() - Method in enum class org.apache.camel.ManagementStatisticsLevel
- isDefaultProfile() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Whether this profile is the default profile (there can only be one).
- isDevConsole() - Method in interface org.apache.camel.CamelContext
-
Whether to enable developer console (requires camel-console on classpath).
- isDisabled() - Method in interface org.apache.camel.cluster.CamelPreemptiveClusterView
-
Check if the view is disabled.
- isDisabled() - Method in interface org.apache.camel.spi.EventNotifier
-
Checks whether notification is disabled for all events
- isDone() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Whether the message is done processing the given node
- isDynamic(String) - Method in interface org.apache.camel.spi.EndpointRegistry
-
Whether the given endpoint is stored in the dynamic cache
- isDynamic(String) - Method in interface org.apache.camel.spi.TransformerRegistry
-
Whether the given transformer is stored in the dynamic cache
- isDynamic(DataType) - Method in interface org.apache.camel.spi.ValidatorRegistry
-
Whether the given
Validator
is stored in the dynamic cache - isDynamic(DataType, DataType) - Method in interface org.apache.camel.spi.TransformerRegistry
-
Whether the given
Transformer
is stored in the dynamic cache - isEmpty() - Method in class org.apache.camel.spi.Contract
- isEmpty() - Method in class org.apache.camel.spi.ThreadPoolProfile
- isEnableCORS() - Method in class org.apache.camel.spi.RestConfiguration
-
To specify whether to enable CORS which means Camel will automatic include CORS in the HTTP headers in the response.
- isEnabled() - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Whether dev console is enabled globally
- isEnabled() - Method in interface org.apache.camel.health.HealthCheck
-
Whether this health check is enabled
- isEnabled() - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Whether Health Check is enabled globally
- isEnabled() - Method in interface org.apache.camel.health.HealthCheckRepository
-
Set if the checks associated to this repository is enabled or not.
- isEnabled() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether the debugger is enabled
- isEnabled() - Method in interface org.apache.camel.spi.BacklogTracer
-
Is the tracer enabled.
- isEnabled() - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
- isEnabled() - Method in interface org.apache.camel.spi.CliConnectorFactory
-
Whether CLI connector is enabled.
- isEnabled() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Whether gathering runtime usage is enabled or not.
- isEnabled() - Method in interface org.apache.camel.spi.StartupStepRecorder
-
Whether recording is enabled
- isEnabled() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- isEnabled() - Method in interface org.apache.camel.spi.Tracer
-
Whether the tracer is enabled
- isEnabled(String) - Method in interface org.apache.camel.spi.EndpointUriFactory
-
Checks whether this factory supports the given component name
- isEnabled(String, Component) - Method in interface org.apache.camel.spi.ComponentCustomizer
-
Checks whether this customizer should be applied to the given
Component
. - isEnabled(String, DataFormat) - Method in interface org.apache.camel.spi.DataFormatCustomizer
-
Checks whether this customizer should be applied to the given
DataFormat
. - isEnabled(String, Language) - Method in interface org.apache.camel.spi.LanguageCustomizer
-
Checks whether this customizer should be applied to the given
Language
. - isEnabled(LoggingLevel) - Method in enum class org.apache.camel.LoggingLevel
-
Is the given logging level equal or higher than the current level.
- isEnabled(CamelEvent) - Method in interface org.apache.camel.spi.EventNotifier
-
Checks whether notification for the given event is enabled.
- isEnableNoContentResponse() - Method in class org.apache.camel.spi.RestConfiguration
- isErrorHandlerHandled() - Method in interface org.apache.camel.ExchangeExtension
-
Whether the exchange has been handled by the error handler.
- isErrorHandlerHandledSet() - Method in interface org.apache.camel.ExchangeExtension
-
Whether the error handler handled flag has been set.
- isEventNotificationApplicable() - Method in interface org.apache.camel.ExtendedCamelContext
-
Whether exchange event notification is applicable (possible).
- isEventNotifierEnabled() - Method in interface org.apache.camel.FluentProducerTemplate
-
Whether the
EventNotifier
should be used by thisProducerTemplate
to send events about theExchange
being sent. - isEventNotifierEnabled() - Method in interface org.apache.camel.ProducerTemplate
-
Whether the
EventNotifier
should be used by thisProducerTemplate
to send events about theExchange
being sent. - isEventNotifierEnabled() - Method in interface org.apache.camel.spi.ProducerCache
-
Whether
EventNotifier
is enabled - isExcluded(HealthCheck) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Whether the given health check has been excluded
- isExtended() - Method in enum class org.apache.camel.ManagementStatisticsLevel
- isExtendedStatistics() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Whether to gather extended statistics for introspection usage.
- isExternalRedelivered() - Method in interface org.apache.camel.Exchange
-
Returns true if this exchange is an external initiated redelivered message (such as a JMS broker).
- isFailed() - Method in interface org.apache.camel.Exchange
-
Returns true if this exchange failed due to an exception
- isFailed() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Did the message fail during processing (i.e. was an exception thrown)
- isFailureHandled() - Method in interface org.apache.camel.ExchangeExtension
-
Returns whether the exchange has been failure handed
- isFirst() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Whether this is a new incoming message and this is the first trace.
- isFixedName() - Method in interface org.apache.camel.spi.CamelContextNameStrategy
-
Whether the name will be fixed, or allow re-calculation such as by using an unique counter.
- isFixedName() - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
Whether the name will be fixed, or allow re-calculation such as by using an unique counter.
- isForceShutdown() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Whether the shutdown strategy is forcing to shutdown
- isFromRemoteEndpoint() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
Whether the endpoint is remote where the exchange originates (started)
- isFull() - Method in interface org.apache.camel.resume.cache.ResumeCache
-
Checks whether the cache is full
- isGeneratedIds() - Method in interface org.apache.camel.spi.DumpRoutesStrategy
- isGetter - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
- isHealthy() - Method in interface org.apache.camel.cloud.ServiceHealth
-
Deprecated.States if the service is healthy or not
- isHostedService() - Method in interface org.apache.camel.spi.EndpointServiceRegistry.EndpointService
-
Is this service hosted (in this Camel application).
- isHostedService() - Method in interface org.apache.camel.spi.HostedService
-
Is this service hosted (in this Camel application).
- isIgnoreCamelContextEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreCamelContextInitEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreExchangeAsyncProcessingStartedEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreExchangeCompletedEvent() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreExchangeCreatedEvent() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreExchangeEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreExchangeFailedEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreExchangeRedeliveryEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreExchangeSendingEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreExchangeSentEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreLoadingError() - Method in interface org.apache.camel.spi.RoutesLoader
-
Whether to ignore route loading and compilation errors (use this with care!)
- isIgnoreRouteEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreServiceEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isIgnoreStepEvents() - Method in interface org.apache.camel.spi.EventNotifier
- isInCapable() - Method in enum class org.apache.camel.ExchangePattern
-
Return true if there can be an IN message
- isIncludeException() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Trace messages to include exception if the message failed
- isIncludeException() - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include exception if the message failed
- isIncludeExchangeProperties() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether to include the exchange properties in the traced message
- isIncludeExchangeProperties() - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include exchange properties
- isIncludeExchangeVariables() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether to include the exchange variables in the traced message
- isIncludeExchangeVariables() - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include exchange variables
- isInflightBrowseEnabled() - Method in interface org.apache.camel.spi.InflightRepository
-
Whether the inflight repository should allow browsing each inflight exchange.
- isInit() - Method in class org.apache.camel.support.service.BaseService
- isInitialized() - Method in enum class org.apache.camel.ServiceStatus
- isInitializing() - Method in enum class org.apache.camel.ServiceStatus
- isInlineRoutes() - Method in class org.apache.camel.spi.RestConfiguration
- isInstanceOf(Map<String, Object>) - Method in interface org.apache.camel.spi.HeadersMapFactory
-
Whether the given
Map
implementation is created by this factory? - isInterrupted() - Method in interface org.apache.camel.ExchangeExtension
-
Whether the exchange was interrupted (InterruptException) during routing.
- isInterruptThreadsWhileStopping() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
Whether to interrupt any blocking threads during stopping.
- isJavaType() - Method in class org.apache.camel.spi.DataType
- isJavaType(DataType) - Static method in class org.apache.camel.spi.DataType
- isLast() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Whether this is the last trace of the message (its complete).
- isLazyStartProducer() - Method in interface org.apache.camel.GlobalEndpointConfiguration
- isLeader() - Method in interface org.apache.camel.cluster.CamelClusterMember
- isLeader(String) - Method in interface org.apache.camel.cluster.CamelClusterService
-
Check if the service is the leader on the given namespace.
- isLenientProperties() - Method in interface org.apache.camel.Endpoint
-
Should all properties be known or does the endpoint allow unknown options?
- isLenientProperties() - Method in interface org.apache.camel.spi.EndpointUriFactory
-
Whether the endpoint is lenient or not.
- isLenientProperties() - Method in interface org.apache.camel.spi.SendDynamicAware
-
Whether the endpoint is lenient or not.
- isLiveness() - Method in interface org.apache.camel.health.HealthCheck
-
Whether this health check can be used for liveness checks Liveness check is not default, and must be explicit enabled.
- isLoadHealthChecks() - Method in interface org.apache.camel.CamelContext
-
Whether to load custom health checks by scanning classpath.
- isLoadTypeConverters() - Method in interface org.apache.camel.CamelContext
-
Whether to load custom type converters by scanning classpath.
- isLocal() - Method in interface org.apache.camel.cluster.CamelClusterMember
- isLog() - Method in interface org.apache.camel.spi.DumpRoutesStrategy
- isLogExhaustedMessageBody() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether to log exhausted message body with message history.
- isLogInflightExchangesOnTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Whether to log information about the inflight
Exchange
s which are still running during a shutdown which didn't complete without the given timeout. - isLogMask() - Method in interface org.apache.camel.RuntimeConfiguration
-
Gets whether security mask for Logging is enabled or not.
- isManaged(Object) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Determines if an object or name is managed.
- isManagedName(Object) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Determines if an object or name is managed.
- isMessageHistory() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether message history is enabled
- isModeline() - Method in interface org.apache.camel.CamelContext
-
Whether camel-k style modeline is also enabled when not using camel-k.
- isMultipleConsumersSupported() - Method in interface org.apache.camel.MultipleConsumersSupport
-
Are multiple consumers supported?
- isNew() - Method in class org.apache.camel.support.service.BaseService
- isNotifyEvent() - Method in interface org.apache.camel.ExchangeExtension
-
Whether the exchange is currently used as event notification.
- isOutCapable() - Method in enum class org.apache.camel.ExchangePattern
-
Return true if there can be an OUT message
- isPooled() - Method in interface org.apache.camel.spi.PooledObjectFactory
-
Whether the factory is pooled.
- isProcessors() - Method in enum class org.apache.camel.ManagementMBeansLevel
- isProfileCredentialsProvider() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- isReadiness() - Method in interface org.apache.camel.health.HealthCheck
-
Whether this health check can be used for readiness checks.
- isRecording() - Method in interface org.apache.camel.spi.StartupStepRecorder
-
Whether to start flight recorder recording.
- isRedeliveryExhausted() - Method in interface org.apache.camel.ExchangeExtension
-
Whether the exchange has exhausted (attempted all) its redeliveries and still failed.
- isRefreshEnabled() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- isRefreshEnabled() - Method in class org.apache.camel.vault.AzureVaultConfiguration
- isRefreshEnabled() - Method in class org.apache.camel.vault.GcpVaultConfiguration
- isRefreshEnabled() - Method in class org.apache.camel.vault.KubernetesVaultConfiguration
- isRegistered(ObjectName) - Method in interface org.apache.camel.spi.ManagementAgent
-
Is the given object registered
- isReloadingRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Indicates whether current thread is reloading route(s).
- isRemote() - Method in interface org.apache.camel.Endpoint
-
Whether this endpoint can connect to remote system, such as cloud providers, messaging brokers, databases.
- isRemoteEndpoint() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Whether the endpoint is remote.
- isRemoveOnDump() - Method in interface org.apache.camel.spi.BacklogTracer
-
Remove the currently traced messages when dump methods are invoked
- isRemoveSpoolDirectoryWhenStopping() - Method in interface org.apache.camel.spi.StreamCachingStrategy
- isReservedKey(String) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Is the given key a reserved key used by Camel to store metadata in health check response details.
- isResolvePlaceholders() - Method in interface org.apache.camel.spi.DumpRoutesStrategy
- isRest() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Whether this event was from a route that is created from Rest DSL.
- isResultsUp(Collection<HealthCheck.Result>, boolean) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Checks the overall status of the results.
- isRethrowException() - Method in exception class org.apache.camel.VetoCamelContextStartException
-
Whether to rethrow this exception when starting CamelContext, to cause an exception to be thrown from the start method.
- isRollbackOnly() - Method in interface org.apache.camel.Exchange
-
Returns true if this exchange is marked for rollback
- isRollbackOnlyLast() - Method in interface org.apache.camel.Exchange
-
Returns true if this exchange is marked for rollback (only last transaction section)
- isRoutes() - Method in enum class org.apache.camel.ManagementMBeansLevel
- isRouteStop() - Method in interface org.apache.camel.Exchange
-
Returns true if this exchange is marked to stop and not continue routing.
- isRunAllowed() - Method in interface org.apache.camel.CamelContextLifecycle
-
Helper methods so the CamelContext knows if it should keep running.
- isRunAllowed() - Method in interface org.apache.camel.StatefulService
-
Helper methods so the service knows if it should keep running.
- isRunAllowed() - Method in class org.apache.camel.support.service.BaseService
- isSchedulerStarted() - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Whether the scheduler has been started.
- isSetter - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
- isSetupRoutes() - Method in interface org.apache.camel.ExtendedCamelContext
-
Indicates whether current thread is setting up route(s) as part of starting Camel.
- isShutdown() - Method in class org.apache.camel.support.service.BaseService
- isShutdownNowOnTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Whether to force shutdown of all consumers when a timeout occurred.
- isShutdownRoutesInReverseOrder() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Whether to shutdown routes in reverse order than they were started.
- isSingleStepIncludeStartEnd() - Method in interface org.apache.camel.spi.BacklogDebugger
-
In single step mode, then when the exchange is created and completed, then simulate a breakpoint at start and end, that allows to suspend and watch the incoming/complete exchange at the route (you can see message body as response, failed exception etc).
- isSingleStepMode() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Is the debugger currently in single step mode
- isSingleton() - Method in interface org.apache.camel.IsSingleton
-
Whether this class supports being singleton or not.
- IsSingleton - Interface in org.apache.camel
-
Used for defining if a given class is singleton or not.
- isSingletonProducer() - Method in interface org.apache.camel.Endpoint
-
Whether this endpoint creates singleton producers
- isSkip() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
-
Whether to skip sending to the original endpoint.
- isSkipBindingOnErrorCode() - Method in class org.apache.camel.spi.RestConfiguration
-
Whether to skip binding output if there is a custom HTTP error code, and instead use the response body as-is.
- isSourceLocationEnabled() - Method in interface org.apache.camel.CamelContext
-
Whether to capture precise source location:line-number for all EIPs in Camel routes.
- isSpoolEnabled() - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Is spooling to disk enabled.
- isStandby() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether the debugger is standby.
- isStandby() - Method in interface org.apache.camel.spi.BacklogTracer
-
Whether the tracer is standby.
- isStandby() - Method in interface org.apache.camel.spi.Tracer
-
Whether the tracer is standby.
- isStartable() - Method in enum class org.apache.camel.ServiceStatus
- isStarted() - Method in interface org.apache.camel.CamelContextLifecycle
-
Whether the CamelContext is started
- isStarted() - Method in enum class org.apache.camel.ServiceStatus
- isStarted() - Method in interface org.apache.camel.StatefulService
-
Whether the service is started
- isStarted() - Method in class org.apache.camel.support.service.BaseService
- isStarted(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service starting or already started?
- isStarted(StatefulService) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service starting or already started?
- isStarting() - Method in interface org.apache.camel.CamelContextLifecycle
-
Whether the CamelContext is starting
- isStarting() - Method in enum class org.apache.camel.ServiceStatus
- isStarting() - Method in interface org.apache.camel.StatefulService
-
Whether the service is starting
- isStarting() - Method in class org.apache.camel.support.service.BaseService
- isStartingOrStarted() - Method in class org.apache.camel.support.service.BaseService
-
Is the service in progress of being suspended or already suspended
- isStartingRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Indicates whether the route controller is doing initial starting of the routes.
- isStartingRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Whether the route controller is currently starting routes for the first time.
- isStatic(String) - Method in interface org.apache.camel.spi.EndpointRegistry
-
Whether the given endpoint is stored in the static cache
- isStatic(String) - Method in interface org.apache.camel.spi.TransformerRegistry
-
Whether the given transformer is stored in the static cache
- isStatic(DataType) - Method in interface org.apache.camel.spi.ValidatorRegistry
-
Whether the given
Validator
is stored in the static cache - isStatic(DataType, DataType) - Method in interface org.apache.camel.spi.TransformerRegistry
-
Whether the given transformer is stored in the static cache
- isStatisticsEnabled() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
Whether statistics is enabled.
- isStatisticsEnabled() - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Whether statistics is enabled.
- isStatisticsEnabled() - Method in interface org.apache.camel.spi.PooledObjectFactory
-
Whether statistics is enabled.
- isStatisticsEnabled() - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Whether statistics is enabled
- isStatisticsEnabled() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Whether statistics is enabled.
- isStoppable() - Method in enum class org.apache.camel.ServiceStatus
- isStopped() - Method in interface org.apache.camel.CamelContextLifecycle
-
Whether the CamelContext is stopped
- isStopped() - Method in enum class org.apache.camel.ServiceStatus
- isStopped() - Method in interface org.apache.camel.StatefulService
-
Whether the service is stopped
- isStopped() - Method in class org.apache.camel.support.service.BaseService
- isStopped(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service stopping or already stopped?
- isStopped(StatefulService) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service stopping or already stopped?
- isStopping() - Method in interface org.apache.camel.CamelContextLifecycle
-
Whether the CamelContext is stopping
- isStopping() - Method in enum class org.apache.camel.ServiceStatus
- isStopping() - Method in interface org.apache.camel.StatefulService
-
Whether the service is stopping
- isStopping() - Method in class org.apache.camel.support.service.BaseService
- isStoppingOrStopped() - Method in class org.apache.camel.support.service.BaseService
-
Is the service in progress of being stopped or already stopped
- isStreamCacheDisabled() - Method in interface org.apache.camel.ExchangeExtension
-
Is stream caching disabled on the given exchange
- isStreamCaching() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether stream cache is enabled
- isSuccess() - Method in class org.apache.camel.catalog.EndpointValidationResult
- isSuccess() - Method in class org.apache.camel.catalog.LanguageValidationResult
- isSuccess() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- isSupervising() - Method in interface org.apache.camel.spi.RouteController
-
Whether this route controller is a regular or supervising controller.
- isSupportedExtension(String) - Method in interface org.apache.camel.spi.RoutesBuilderLoader
-
Whether the file extension is supported
- isSuppressLoggingOnTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Whether Camel should try to suppress logging during shutdown and timeout was triggered, meaning forced shutdown is happening.
- isSuspendable() - Method in enum class org.apache.camel.ServiceStatus
- isSuspended() - Method in interface org.apache.camel.CamelContextLifecycle
-
Whether the CamelContext is suspended
- isSuspended() - Method in enum class org.apache.camel.ServiceStatus
- isSuspended() - Method in class org.apache.camel.support.service.BaseService
- isSuspended() - Method in interface org.apache.camel.SuspendableService
-
Tests whether the service is suspended or not.
- isSuspended(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service suspending or already suspended?
- isSuspended(StatefulService) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service suspending or already suspended?
- isSuspending() - Method in interface org.apache.camel.CamelContextLifecycle
-
Whether the CamelContext is suspending
- isSuspending() - Method in enum class org.apache.camel.ServiceStatus
- isSuspending() - Method in interface org.apache.camel.StatefulService
-
Whether the service is suspending
- isSuspending() - Method in class org.apache.camel.support.service.BaseService
- isSuspendingOrSuspended() - Method in class org.apache.camel.support.service.BaseService
-
Is the service in progress of being suspended or already suspended
- isSuspendMode() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether the debugger should suspend on startup, and wait for a remote debugger to attach.
- isTemplate() - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Whether this event was from a route that is created from route template or kamelet.
- isThreadedAsyncMode() - Method in interface org.apache.camel.ProducerTemplate
-
Reports if async* methods will dispatch processing from the calling thread (false) or through executor (true).
- isTimeoutOccurred() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Whether a timeout has occurred during a shutdown.
- isTimestampEnabled() - Method in interface org.apache.camel.spi.EventFactory
-
Whether to include timestamp for each event, when the event occurred.
- isTraceBeforeAndAfterRoute() - Method in interface org.apache.camel.spi.Tracer
-
Whether to include tracing of before/after routes to trace the input and responses of routes.
- isTraceRests() - Method in interface org.apache.camel.spi.BacklogTracer
-
Whether to support tracing messages and outputting as JSon.
- isTraceRests() - Method in interface org.apache.camel.spi.Tracer
-
Whether to trace routes that is created from Rest DSL.
- isTraceTemplates() - Method in interface org.apache.camel.spi.BacklogTracer
-
Whether to trace routes that is created from route templates or kamelets.
- isTraceTemplates() - Method in interface org.apache.camel.spi.Tracer
-
Whether tracing should trace inner details from route templates (or kamelets).
- isTracing() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether tracing enabled To use tracing then either turn on tracing standby or enable tracing to make tracing possible.
- isTracingStandby() - Method in interface org.apache.camel.CamelContext
-
Whether to set tracing on standby.
- isTracingTemplates() - Method in interface org.apache.camel.CamelContext
-
Whether tracing should trace inner details from route templates (or kamelets).
- isTransacted() - Method in interface org.apache.camel.Exchange
-
Returns true if this exchange is transacted
- isTransacted() - Method in interface org.apache.camel.spi.UnitOfWork
-
Are we transacted?
- isTransactedBy(Object) - Method in interface org.apache.camel.spi.UnitOfWork
-
Are we already transacted by the given transaction key?
- isTypeConverterStatisticsEnabled() - Method in interface org.apache.camel.CamelContext
-
Whether or not type converter statistics is enabled.
- isUnbindEnabled() - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
-
Can be used to unbind any existing beans before binding a bean to the registry.
- isUnhealthy() - Method in interface org.apache.camel.spi.RouteError
-
Whether the route is regarded as unhealthy.
- isUnhealthyOnExhausted() - Method in interface org.apache.camel.spi.SupervisingRouteController
- isUnhealthyOnRestarting() - Method in interface org.apache.camel.spi.SupervisingRouteController
- isUriAsParameters() - Method in interface org.apache.camel.spi.DumpRoutesStrategy
- isUseBreadcrumb() - Method in interface org.apache.camel.CamelContext
-
Whether or not breadcrumb is enabled.
- isUseDataType() - Method in interface org.apache.camel.CamelContext
-
Whether to enable using data type on Camel messages.
- isUseDefaultInstance() - Method in class org.apache.camel.vault.GcpVaultConfiguration
- isUseGlobalSslContextParameters() - Method in interface org.apache.camel.SSLContextParametersAware
-
Determine if the implementing object is using global SSL context parameters.
- isUseMDCLogging() - Method in interface org.apache.camel.CamelContext
-
Whether or not MDC logging is being enabled.
- isUseRecovery() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Whether or not recovery is enabled or not
- isUseSqsNotification() - Method in class org.apache.camel.vault.AwsVaultConfiguration
- isUseXForwardHeaders() - Method in class org.apache.camel.spi.RestConfiguration
-
Whether to use X-Forward headers to set host etc. for OpenApi.
- isValidateInput() - Method in class org.apache.camel.spi.Contract
- isValidateOutput() - Method in class org.apache.camel.spi.Contract
- isVetoStarted() - Method in interface org.apache.camel.CamelContext
-
If CamelContext during the start procedure was vetoed, and therefore causing Camel to not start.
J
- JAVA_OBJECT - Enum constant in enum class org.apache.camel.spi.MimeType
- JAVA_TYPE - Static variable in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
- JAVA_TYPE_SCHEME - Static variable in class org.apache.camel.spi.DataType
- javaType() - Element in annotation interface org.apache.camel.spi.Metadata
-
To re-associate the preferred Java type of this parameter.
- javaType() - Element in annotation interface org.apache.camel.spi.UriParam
-
To re-associate the preferred Java type of this parameter.
- javaType() - Element in annotation interface org.apache.camel.spi.UriPath
-
To re-associate the preferred Java type of this parameter.
- JDK_SERVICE - Static variable in annotation interface org.apache.camel.spi.annotations.ServiceFactory
- JdkService - Annotation Interface in org.apache.camel.spi.annotations
- json - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestBindingMode
- json() - Method in interface org.apache.camel.cloudevents.CloudEvent.Attribute
-
The name of the json field.
- JSON - Enum constant in enum class org.apache.camel.console.DevConsole.MediaType
- JSON - Enum constant in enum class org.apache.camel.spi.MimeType
- json_xml - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestBindingMode
- jsonAttribute(String) - Method in interface org.apache.camel.cloudevents.CloudEvent
-
Mandatory find json attribute by id.
- JSonSchemaResolver - Interface in org.apache.camel.catalog
-
Pluggable resolver to load JSON schema files for components, data formats, languages etc.
- JsseParameters - Class in org.apache.camel.support.jsse
-
Base class that provides optional integration with core Camel capabilities.
- JsseParameters() - Constructor for class org.apache.camel.support.jsse.JsseParameters
K
- KAMELET_PROPERTY - Static variable in interface org.apache.camel.Route
- keepOnlyChangeProperties(Properties) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Filters the given list of properties, by removing properties that are already loaded and have same key and value.
- KeyManagersParameters - Class in org.apache.camel.support.jsse
-
A representation of configuration options for creating and loading
KeyManager
instance(s). - KeyManagersParameters() - Constructor for class org.apache.camel.support.jsse.KeyManagersParameters
- keyPassword - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
- keyStore - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
- keyStore - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
- keyStore - Variable in class org.apache.camel.support.jsse.TrustManagersParameters
- KeyStoreParameters - Class in org.apache.camel.support.jsse
-
A representation of configuration options for creating and loading a
KeyStore
instance. - KeyStoreParameters() - Constructor for class org.apache.camel.support.jsse.KeyStoreParameters
- kubernetes() - Method in class org.apache.camel.vault.VaultConfiguration
-
Kubernetes Vault Configuration
- KubernetesVaultConfiguration - Class in org.apache.camel.vault
-
Configuration for access to Kubernetes Secrets
- KubernetesVaultConfiguration() - Constructor for class org.apache.camel.vault.KubernetesVaultConfiguration
L
- label() - Element in annotation interface org.apache.camel.spi.Metadata
-
To define one or more labels.
- label() - Element in annotation interface org.apache.camel.spi.UriParam
-
To associate this parameter with label(s).
- label() - Element in annotation interface org.apache.camel.spi.UriPath
-
To associate this path value with label(s).
- Language - Interface in org.apache.camel.spi
-
Represents a language to be used for
Expression
orPredicate
instances - Language - Annotation Interface in org.apache.camel.spi.annotations
- LANGUAGE_SCRIPT - Static variable in interface org.apache.camel.Exchange
- LanguageCustomizer - Interface in org.apache.camel.spi
-
To apply custom configurations to
Language
instances. - LanguageCustomizer.Builder<T> - Class in org.apache.camel.spi
-
A fluent builder to create a
LanguageCustomizer
instance. - LanguageCustomizer.Policy - Interface in org.apache.camel.spi
-
Used as additional filer mechanism to control if customizers need to be applied or not.
- LanguageResolver - Interface in org.apache.camel.spi
-
A pluggable strategy for resolving different languages in a loosely coupled manner
- LanguageValidationResult - Class in org.apache.camel.catalog
-
Validation result of parsing a language expression or predicate
- LanguageValidationResult(String) - Constructor for class org.apache.camel.catalog.LanguageValidationResult
- largeInput() - Element in annotation interface org.apache.camel.spi.Metadata
-
Whether the option can be large input such as a SQL query, XSLT template, or scripting code.
- lazy() - Element in annotation interface org.apache.camel.BindToRegistry
-
Whether to create the bean instance lazy (on-demand) instead of creating eager.
- lazyAddContextPlugin(Class<T>, Supplier<T>) - Method in interface org.apache.camel.ExtendedCamelContext
-
Allows lazy installation of custom plugins to the Camel context.
- lazyAddContextPlugin(Class<T>, Supplier<T>) - Method in interface org.apache.camel.spi.PluginManager
-
Allows lazy installation of custom plugins to the Camel context.
- leadershipChanged(CamelClusterView, CamelClusterMember) - Method in interface org.apache.camel.cluster.CamelClusterEventListener.Leadership
-
Notify a change in the leadership for a particular cluster.
- length() - Method in interface org.apache.camel.StreamCache
-
Gets the length of the cached stream.
- lenientProperties() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
Should all properties be known or does the endpoint allow unknown options?
- LifecycleStrategy - Interface in org.apache.camel.spi
-
Strategy for lifecycle notifications.
- LineNumberAware - Interface in org.apache.camel
-
An entity that can point to a given line number from a source
Resource
such as YAML and XML DSL parsers. - listAllEndpointServices() - Method in interface org.apache.camel.spi.EndpointServiceRegistry
-
List all endpoint services from this registry.
- listAllRestServices() - Method in interface org.apache.camel.spi.RestRegistry
-
List all REST services from this registry.
- LIVENESS - Enum constant in enum class org.apache.camel.health.HealthCheck.Kind
- load(TransformerRegistry) - Method in interface org.apache.camel.spi.TransformerLoader
-
A pluggable strategy to load transformers into a given registry.
- load(TypeConverterRegistry) - Method in interface org.apache.camel.spi.TypeConverterLoader
-
A pluggable strategy to load type converters into a registry from some kind of mechanism
- LoadablePropertiesSource - Interface in org.apache.camel.spi
-
A source for properties that can be loaded all at once during initialization, such as loading .properties files.
- loadAllResourcesAsURL(String) - Method in interface org.apache.camel.spi.ClassResolver
-
Loads the given resources as a URL from all bundles/classloaders
- loadCache() - Method in interface org.apache.camel.resume.ResumeStrategy
-
Loads the cache with the data currently available in this strategy
- loadDevConsoles() - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Loads custom dev consoles by scanning classpath.
- loadDevConsoles(boolean) - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Loads custom dev consoles by scanning classpath.
- loadHealthChecks() - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Loads custom health checks by scanning classpath.
- loadProperties() - Method in interface org.apache.camel.spi.LoadablePropertiesSource
-
Loads the properties from the source
- loadProperties() - Method in interface org.apache.camel.spi.PropertiesComponent
-
Loads the properties from the default locations and sources.
- loadProperties(Predicate<String>) - Method in interface org.apache.camel.spi.LoadablePropertiesSource
-
Loads the properties from the source filtering them out according to a predicate.
- loadProperties(Predicate<String>) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Loads the properties from the default locations and sources filtering them out according to a predicate.
- loadProperties(Predicate<String>, Function<String, String>) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Loads the properties from the default locations and sources filtering them out according to a predicate, and maps the key using the key mapper.
- loadPropertiesAsMap() - Method in interface org.apache.camel.spi.PropertiesComponent
-
Loads the properties from the default locations and sources.
- loadPropertiesAsMap(Predicate<String>) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Loads the properties from the default locations and sources filtering them out according to a predicate.
- LoadPropertiesException - Exception Class in org.apache.camel
-
Represents a failure to open a Properties file at a given URL
- LoadPropertiesException(URL, Exception) - Constructor for exception class org.apache.camel.LoadPropertiesException
- loadResourceAsStream(String) - Method in interface org.apache.camel.spi.ClassResolver
-
Loads the given resource as a stream
- loadResourceAsURL(String) - Method in interface org.apache.camel.spi.ClassResolver
-
Loads the given resource as a URL
- loadResourcesAsURL(String) - Method in interface org.apache.camel.spi.ClassResolver
-
Loads the given resources as a URL from the current bundle/classloader
- loadRoutes(Collection<Resource>) - Method in interface org.apache.camel.spi.RoutesLoader
- loadRoutes(Resource...) - Method in interface org.apache.camel.spi.RoutesLoader
- loadRoutesBuilder(Resource) - Method in interface org.apache.camel.spi.RoutesBuilderLoader
-
Loads
RoutesBuilder
fromResource
. - loadRoutesBuilders(Collection<Resource>) - Method in interface org.apache.camel.spi.ExtendedRoutesBuilderLoader
-
Loads
RoutesBuilder
from multipleResource
s. - loadRouteTemplate(Resource) - Method in interface org.apache.camel.spi.RouteTemplateLoaderListener
-
About to load route template (kamelet) from the given resource.
- LocalBeanRepositoryAware - Interface in org.apache.camel.spi
-
Allows a
BeanRepository
to temporary have a local repository take precedence, such as when creating route templates to give more flexibility. - localHostName - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestHostNameResolver
- localIp - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestHostNameResolver
- LOCATION - Static variable in interface org.apache.camel.spi.RouteTemplateParameterSource
- lock - Variable in class org.apache.camel.support.service.BaseService
- log(String) - Method in class org.apache.camel.spi.CamelLogger
-
Logs the message with checking the
CamelLogger.shouldLog()
method first. - log(String, Throwable) - Method in class org.apache.camel.spi.CamelLogger
- log(String, Throwable, LoggingLevel) - Method in class org.apache.camel.spi.CamelLogger
- log(String, LoggingLevel) - Method in class org.apache.camel.spi.CamelLogger
- log(Logger, LoggingLevel, String) - Static method in class org.apache.camel.spi.CamelLogger
- log(Logger, LoggingLevel, String, Throwable) - Static method in class org.apache.camel.spi.CamelLogger
- log(Logger, LoggingLevel, Marker, String) - Static method in class org.apache.camel.spi.CamelLogger
- log(Logger, LoggingLevel, Marker, String, Throwable) - Static method in class org.apache.camel.spi.CamelLogger
- LOG_DEBUG_BODY_MAX_CHARS - Static variable in interface org.apache.camel.Exchange
- LOG_DEBUG_BODY_STREAMS - Static variable in interface org.apache.camel.Exchange
- LOG_EIP_NAME - Static variable in interface org.apache.camel.Exchange
- LoggingLevel - Enum Class in org.apache.camel
-
Used to configure the logging levels
- LogListener - Interface in org.apache.camel.spi
-
An event listener SPI for logging.
- lookup(Class<?>, Class<?>) - Method in interface org.apache.camel.spi.BulkTypeConverters
-
Performs a lookup for a given type converter.
- lookup(Class<?>, Class<?>) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Performs a lookup for a given type converter.
- lookup(String) - Static method in class org.apache.camel.ExchangeConstantProvider
- lookupByName(String) - Method in interface org.apache.camel.spi.BeanRepository
-
Looks up a bean in the registry based purely on name, returning the bean or null if it could not be found.
- lookupByNameAndType(String, Class<T>) - Method in interface org.apache.camel.spi.BeanRepository
-
Looks up a bean in the registry, returning the bean or null if it could not be found.
- lookupDevConsole(String) - Method in interface org.apache.camel.console.DevConsoleResolver
-
Lookup existing resolved
DevConsole
. - lookupFirst(String) - Method in interface org.apache.camel.spi.PropertiesFunction
-
Whether the value should be looked up as a regular properties first, before applying this function.
- LOOP_INDEX - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- LOOP_INDEX - Static variable in interface org.apache.camel.Exchange
- LOOP_SIZE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- LOOP_SIZE - Static variable in interface org.apache.camel.Exchange
- LOWEST - Static variable in interface org.apache.camel.Ordered
-
The lowest precedence
M
- MAIL - Enum constant in enum class org.apache.camel.Category
- MANAGEMENT - Enum constant in enum class org.apache.camel.Category
- ManagementAgent - Interface in org.apache.camel.spi
-
Camel JMX service agent
- ManagementInterceptStrategy - Interface in org.apache.camel.spi
-
A specialized
InterceptStrategy
which is used for JMX management for EIPs. - ManagementInterceptStrategy.InstrumentationProcessor<T> - Interface in org.apache.camel.spi
- ManagementMBeanAssembler - Interface in org.apache.camel.spi
-
An assembler to assemble a
RequiredModelMBean
which can be used to register the object in JMX. - ManagementMBeansLevel - Enum Class in org.apache.camel
-
Level of mbeans for registration
- ManagementNameStrategy - Interface in org.apache.camel.spi
-
Strategy for assigning the name part of the
ObjectName
for a managedCamelContext
. - ManagementObjectNameStrategy - Interface in org.apache.camel.spi
-
Strategy for computing
ObjectName
names for the various beans that Camel register for management. - ManagementObjectStrategy - Interface in org.apache.camel.spi
-
Strategy for creating the managed object for the various beans Camel register for management.
- ManagementStatisticsLevel - Enum Class in org.apache.camel
-
Level of granularity for performance statistics enabled
- ManagementStrategy - Interface in org.apache.camel.spi
-
Strategy for management.
- ManagementStrategyFactory - Interface in org.apache.camel.spi
-
Service Factory for ManagementStrategy
- manageObject(Object) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Adds a managed object allowing the ManagementStrategy implementation to record or expose the object as it sees fit.
- manageProcessor(NamedNode) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Filter whether the processor should be managed or not.
- mandatoryAttribute(String) - Method in interface org.apache.camel.cloudevents.CloudEvent
-
Mandatory find attribute by id.
- mandatoryConvertTo(Class<?>, Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
-
Converts the value to the specified type in the context of an exchange
- mandatoryConvertTo(Class<T>, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
- 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.spi.BulkTypeConverters
- 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
- mandatoryFindSingleByType(Class<T>) - Method in interface org.apache.camel.spi.BeanRepository
-
Finds the bean by type, if there is exactly only one instance of the bean
- marshal(Exchange, Object, OutputStream) - Method in interface org.apache.camel.spi.DataFormat
-
Marshals the object to the given Stream.
- MaskingFormatter - Interface in org.apache.camel.spi
-
A plugin used to mask a log String, for example security information like password or passphrase.
- matches(Class<?>) - Method in interface org.apache.camel.spi.PackageScanFilter
-
Does the given class match
- matches(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.Check if a service definition matches.
- 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(TypeConvertible<?, ?>) - Method in class org.apache.camel.spi.TypeConvertible
-
Tests whether there is a conversion match from this TypeConvertible to the given TypeConvertible.
- matchesOneOf(String, List<Pattern>) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Returns true if and only if the value is matched by one or more of the supplied patterns.
- matchesPrimitive(TypeConvertible<?, ?>) - Method in class org.apache.camel.spi.TypeConvertible
-
Tests whether there is a conversion match from this TypeConvertible to the given TypeConvertible when the "to" type of the tested TypeConvertible is a primitive type.
- matchesReturningFailureMessage(Exchange) - Method in interface org.apache.camel.BinaryPredicate
-
Evaluates the predicate on the message exchange and returns null if this exchange matches the predicate.
- matchEvent(Exchange, CamelEvent.ExchangeEvent) - Method in interface org.apache.camel.spi.Condition
-
Does the condition match
- matchProcess(Exchange, Processor, NamedNode, boolean) - Method in interface org.apache.camel.spi.Condition
-
Does the condition match
- Max - Enum constant in enum class org.apache.camel.spi.StreamCachingStrategy.SpoolUsedHeapMemoryLimit
- maxCapacity() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
-
Maximum number of elements that we can have information about
- MAXIMIZING - Enum constant in enum class org.apache.camel.resume.Cacheable.FillPolicy
-
With MAXIMIZING, entities try to maximize cache usage and fill it with as much data as possible
- MAXIMUM_CACHE_POOL_SIZE - Static variable in interface org.apache.camel.Exchange
- MAXIMUM_ENDPOINT_CACHE_SIZE - Static variable in interface org.apache.camel.Exchange
- MAXIMUM_SIMPLE_CACHE_SIZE - Static variable in interface org.apache.camel.Exchange
- MAXIMUM_TRANSFORMER_CACHE_SIZE - Static variable in interface org.apache.camel.Exchange
- MAXIMUM_VALIDATOR_CACHE_SIZE - Static variable in interface org.apache.camel.Exchange
- MDC_BREADCRUMB_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
- MDC_CAMEL_CONTEXT_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
- MDC_CORRELATION_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
- MDC_EXCHANGE_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
- MDC_MESSAGE_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
- MDC_ROUTE_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
- MDC_STEP_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
- MDC_TRANSACTION_KEY - Static variable in interface org.apache.camel.spi.UnitOfWork
- memberAdded(CamelClusterView, CamelClusterMember) - Method in interface org.apache.camel.cluster.CamelClusterEventListener.Membership
-
Notify a change (addition) in the cluster composition.
- memberRemoved(CamelClusterView, CamelClusterMember) - Method in interface org.apache.camel.cluster.CamelClusterEventListener.Membership
-
Notify a change (removal) in the cluster composition.
- message() - Method in class org.apache.camel.health.HealthCheckResultBuilder
- message(String) - Method in class org.apache.camel.health.HealthCheckResultBuilder
- Message - Interface in org.apache.camel
- MESSAGE_HISTORY - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- MESSAGE_HISTORY - Static variable in interface org.apache.camel.Exchange
- MESSAGE_HISTORY_HEADER_FORMAT - Static variable in interface org.apache.camel.Exchange
- MESSAGE_HISTORY_OUTPUT_FORMAT - Static variable in interface org.apache.camel.Exchange
- MESSAGE_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
- MessageHistory - Interface in org.apache.camel
-
Represents the history of a Camel
Message
how it was routed by the Camel routing engine. - MessageHistoryFactory - Interface in org.apache.camel.spi
-
A factory to create
MessageHistory
instances. - MessageTrait - Enum Class in org.apache.camel.trait.message
-
Message traits are runtime traits that can be associated with a message (for instance, the redelivery state, a data type, etc).
- MESSAGING - Enum constant in enum class org.apache.camel.Category
- meta(Map<String, Object>) - Method in interface org.apache.camel.component.extension.MetaDataExtension
- Metadata - Annotation Interface in org.apache.camel.spi
-
Meta data for EIPs, components, data formats and other Camel concepts
- MetaDataExtension - Interface in org.apache.camel.component.extension
- MetaDataExtension.MetaData - Interface in org.apache.camel.component.extension
- metadataOnly() - Element in annotation interface org.apache.camel.spi.Configurer
-
Whether to only include fields that are have @Metadata annotations.
- method - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
- MethodInfo() - Constructor for class org.apache.camel.spi.BeanIntrospection.MethodInfo
- methodName() - Element in annotation interface org.apache.camel.spi.ApiMethod
-
The name of the api method.
- methods - Variable in class org.apache.camel.spi.BeanIntrospection.ClassInfo
- MimeType - Enum Class in org.apache.camel.spi
-
Mime types known to Camel data types and its transformers.
- MINIMIZING - Enum constant in enum class org.apache.camel.resume.Cacheable.FillPolicy
-
With MINIMIZING, entities should fill it with as little data as reasonable.
- MISS_VALUE - Static variable in interface org.apache.camel.TypeConverter
- MISSING_PARAMETER - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
A mandatory parameter is missing
- MOBILE - Enum constant in enum class org.apache.camel.Category
- mock(String, boolean) - Method in interface org.apache.camel.spi.MockSendToEndpointStrategyFactory
-
Mock sending to endpoint
- MockSendToEndpointStrategyFactory - Interface in org.apache.camel.spi
-
Factory for intercepting sending to endpoint pattern and sending to mock component.
- ModelineFactory - Interface in org.apache.camel.spi
-
Factory for parsing camel-k modeline when running Camel standalone with DSLs.
- ModelJAXBContextFactory - Interface in org.apache.camel.spi
-
Factory to abstract the creation of the Model's jakarta.xml.bind.JAXBContext.
- ModelReifierFactory - Interface in org.apache.camel.spi
-
Factory that uses reifiers to build an entity from a given model.
- ModelToXMLDumper - Interface in org.apache.camel.spi
-
SPI for dumping model definitions into XML representation.
- ModelToYAMLDumper - Interface in org.apache.camel.spi
-
SPI for dumping model definitions into YAML representation.
- MONITORING - Enum constant in enum class org.apache.camel.Category
- MULTICAST_COMPLETE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- MULTICAST_COMPLETE - Static variable in interface org.apache.camel.Exchange
- MULTICAST_INDEX - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- MULTICAST_INDEX - Static variable in interface org.apache.camel.Exchange
- MultipleConsumersSupport - Interface in org.apache.camel
-
Endpoint
can optionally implement this interface to indicate whether or not it supports multiple consumers. - multiValue() - Element in annotation interface org.apache.camel.spi.UriParam
-
If the parameter can be configured multiple times, such as configuring options to a Map type.
- multiValuePrefixes() - Method in interface org.apache.camel.spi.EndpointUriFactory
-
Returns the prefixes of the multi-valued properties this endpoint supports.
N
- name() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.Attribute
-
Name of the attribute.
- name() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.Code
-
Name of the code.
- name() - Element in annotation interface org.apache.camel.spi.annotations.DevConsole
-
The ID of the dev console.
- name() - Element in annotation interface org.apache.camel.spi.annotations.DslProperty
- name() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- name() - Element in annotation interface org.apache.camel.spi.DataTypeTransformer
-
Data type transformer name.
- name() - Method in interface org.apache.camel.spi.Tokenizer
-
Returns the name of this tokenizer, which can be used for identification or logging purposes.
- name() - Element in annotation interface org.apache.camel.spi.UriParam
-
Returns the name of the parameter.
- name() - Element in annotation interface org.apache.camel.spi.UriPath
-
Returns the name of the uri path.
- NAME - Static variable in interface org.apache.camel.console.DevConsoleRegistry
-
Service factory name.
- NAME - Static variable in interface org.apache.camel.health.HealthCheckRegistry
-
Service factory name.
- NamedNode - Interface in org.apache.camel
-
Represents a node in the
invalid reference
routes
- NamedRoute - Interface in org.apache.camel
-
Represents a node in the
invalid reference
routes
- names() - Element in annotation interface org.apache.camel.spi.annotations.ExternalSchemaElement
-
Names of external XML element we expect
- names() - Method in interface org.apache.camel.spi.BrowsableVariableRepository
-
The variable names
- namespace() - Element in annotation interface org.apache.camel.spi.annotations.ExternalSchemaElement
-
XSD namespace of XML elements expected
- 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
- navigate() - Method in interface org.apache.camel.Route
-
Returns a navigator to navigate this route by navigating all the
Processor
s. - 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. - NETWORKING - Enum constant in enum class org.apache.camel.Category
- Never - Enum constant in enum class org.apache.camel.WaitForTaskToComplete
- NEW - Static variable in class org.apache.camel.support.service.BaseService
- newCachedThreadPool(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new cached thread pool.
- newCachedThreadPool(ThreadFactory) - Method in interface org.apache.camel.spi.ThreadPoolFactory
-
Creates a new cached thread pool
- newClasspathPropertiesSource(String) - Method in interface org.apache.camel.spi.PropertiesSourceFactory
-
New classpath based
PropertiesSource
- newConfiguration() - Method in interface org.apache.camel.spi.Tokenizer
-
Creates a new configuration for this tokenizer, with default values.
- newDefaultScheduledThreadPool(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new scheduled thread pool using the default thread pool profile.
- newDefaultThreadPool(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new thread pool using the default thread pool profile.
- newExchangeFactory(Consumer) - Method in interface org.apache.camel.spi.ExchangeFactory
-
Creates a new
ExchangeFactory
that is private for the given consumer. - newFilePropertiesSource(String) - Method in interface org.apache.camel.spi.PropertiesSourceFactory
-
New file based
PropertiesSource
- newFixedThreadPool(Object, String, int) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new fixed thread pool (the pool will not grow or shrink but has a fixed number of threads constantly).
- newInstance() - Method in interface org.apache.camel.spi.DataFormatFactory
-
Creates a new DataFormat instance.
- 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 (bean post processing)
- newInstance(Class<T>, boolean) - 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 (bean post processing if enabled)
- newInstance(Class<T>, Class<?>, String) - Method in interface org.apache.camel.spi.Injector
-
Instantiates a new instance of the given type by using the factory class (this will not perform bean post processing)
- newInstance(Class<T>, String) - Method in interface org.apache.camel.spi.Injector
-
Instantiates a new instance of the given type by using the factory method (this will not perform bean post processing)
- newInstance(String) - Method in interface org.apache.camel.spi.FactoryFinder
-
Creates a new class instance using the key to lookup
- newInstance(String) - Method in interface org.apache.camel.spi.PeriodTaskResolver
-
Creates a new class instance using the key to lookup
- newInstance(String, Class<T>) - Method in interface org.apache.camel.spi.FactoryFinder
-
Creates a new class instance using the key to lookup
- newInstance(String, Class<T>) - Method in interface org.apache.camel.spi.PeriodTaskResolver
-
Creates a new class instance using the key to lookup
- newInstance(CamelContext) - Method in interface org.apache.camel.cloud.ServiceFactory
-
Deprecated.Creates an instance of a service.
- newJAXBContext() - Method in interface org.apache.camel.spi.ModelJAXBContextFactory
-
Creates a new jakarta.xml.bind.JAXBContext used for loading the Camel model
- newMap() - Method in interface org.apache.camel.spi.HeadersMapFactory
-
Creates a new empty
Map
- newMap(Map<String, Object>) - Method in interface org.apache.camel.spi.HeadersMapFactory
-
Creates a new
Map
and copies over all the content from the existing map. - newMessageHistory(String, NamedNode, Exchange) - Method in interface org.apache.camel.spi.MessageHistoryFactory
-
Creates a new
MessageHistory
- newPredicateException(Exchange, Predicate, String) - Method in interface org.apache.camel.spi.PredicateExceptionFactory
-
Allows to return a specific exception for the given predicate in case it failed
- newProcessorExchangeFactory(Processor) - Method in interface org.apache.camel.spi.ProcessorExchangeFactory
-
Creates a new
ProcessorExchangeFactory
that is private for the given consumer. - newProxyClient(ObjectName, Class<T>) - Method in interface org.apache.camel.spi.ManagementAgent
-
Creates a new proxy client
- newRefPropertiesSource(String) - Method in interface org.apache.camel.spi.PropertiesSourceFactory
-
New ref based
PropertiesSource
- newScheduledThreadPool(Object, String, int) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new scheduled thread pool.
- newScheduledThreadPool(Object, String, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new scheduled thread pool using a profile id
- newScheduledThreadPool(Object, String, ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new scheduled thread pool using a profile
- newScheduledThreadPool(ThreadPoolProfile, ThreadFactory) - Method in interface org.apache.camel.spi.ThreadPoolFactory
-
Create a scheduled thread pool using the given thread pool profile
- newSingleThreadExecutor(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new single-threaded thread pool.
- newSingleThreadScheduledExecutor(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new single-threaded thread pool.
- newThread(String, Runnable) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new daemon thread with the given name.
- newThreadPool(Object, String, int, int) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new thread pool.
- newThreadPool(Object, String, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new thread pool using using the given profile id
- newThreadPool(Object, String, ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a new thread pool using the given profile
- newThreadPool(ThreadPoolProfile, ThreadFactory) - Method in interface org.apache.camel.spi.ThreadPoolFactory
-
Create a thread pool using the given thread pool profile
- next() - Method in interface org.apache.camel.Navigate
-
Next group of outputs
- NODE_PREFIX_ID_PROPERTY - Static variable in interface org.apache.camel.Route
- NodeIdFactory - Interface in org.apache.camel.spi
-
Factory to generate unique ids for model nodes.
- nodeProcessingDone() - Method in interface org.apache.camel.MessageHistory
-
Used for signalling that processing of the node is done.
- nodes() - Element in annotation interface org.apache.camel.spi.annotations.YamlType
- NoFactoryAvailableException - Exception Class in org.apache.camel
-
Thrown if no factory resource is available for the given URI
- NoFactoryAvailableException(String) - Constructor for exception class org.apache.camel.NoFactoryAvailableException
- NoFactoryAvailableException(String, Throwable) - Constructor for exception class org.apache.camel.NoFactoryAvailableException
- NON_REDELIVERY - Enum constant in enum class org.apache.camel.trait.message.RedeliveryTraitPayload
-
When a message supports redelivery, this indicates that this message is in a non-redelivery state
- none - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestHostNameResolver
- none() - Static method in interface org.apache.camel.spi.ComponentCustomizer.Policy
-
A simple deny-all policy.
- none() - Static method in interface org.apache.camel.spi.DataFormatCustomizer.Policy
-
A simple deny-all policy.
- none() - Static method in interface org.apache.camel.spi.LanguageCustomizer.Policy
-
A simple deny-all policy.
- NONE - Enum constant in enum class org.apache.camel.support.jsse.ClientAuthentication
-
No client authentication required or requested.
- NonManagedService - Interface in org.apache.camel
-
A marker to indicate the
Service
should not be registered in JMX for management. - normalize(K) - Method in interface org.apache.camel.spi.TransformerResolver
-
Normalize transformer key to conform with factory finder resource path.
- NormalizedEndpointUri - Interface in org.apache.camel.spi
-
An Uri which has been normalized.
- normalizeUri(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Normalizes the given uri.
- NoSuchBeanException - Exception Class in org.apache.camel
-
A runtime exception if a given bean could not be found in the
Registry
- NoSuchBeanException(String) - Constructor for exception class org.apache.camel.NoSuchBeanException
- NoSuchBeanException(String, int) - Constructor for exception class org.apache.camel.NoSuchBeanException
- NoSuchBeanException(String, String) - Constructor for exception class org.apache.camel.NoSuchBeanException
- NoSuchBeanException(String, String, Throwable) - Constructor for exception class org.apache.camel.NoSuchBeanException
- NoSuchBeanException(String, Throwable) - Constructor for exception class org.apache.camel.NoSuchBeanException
- NoSuchBeanTypeException - Exception Class in org.apache.camel
-
A runtime exception if a given bean type could not be found in the
Registry
- NoSuchBeanTypeException(Class<?>) - Constructor for exception class org.apache.camel.NoSuchBeanTypeException
- NoSuchBeanTypeException(Class<?>, int) - Constructor for exception class org.apache.camel.NoSuchBeanTypeException
- NoSuchEndpointException - Exception Class in org.apache.camel
-
A runtime exception thrown if a routing processor such as a recipient list is unable to resolve an
Endpoint
from a URI. - NoSuchEndpointException(String) - Constructor for exception class org.apache.camel.NoSuchEndpointException
- NoSuchEndpointException(String, String) - Constructor for exception class org.apache.camel.NoSuchEndpointException
- NoSuchHeaderException - Exception Class in org.apache.camel
-
An exception caused when a mandatory header is not available on a message
Exchange
- NoSuchHeaderException(String, Exchange, String) - Constructor for exception class org.apache.camel.NoSuchHeaderException
- NoSuchHeaderException(Exchange, String, Class<?>) - Constructor for exception class org.apache.camel.NoSuchHeaderException
- NoSuchHeaderOrPropertyException - Exception Class in org.apache.camel
- NoSuchHeaderOrPropertyException(Exchange, String, String, Class<?>) - Constructor for exception class org.apache.camel.NoSuchHeaderOrPropertyException
- NoSuchLanguageException - Exception Class in org.apache.camel
-
A runtime exception thrown if an attempt is made to resolve an unknown language definition.
- NoSuchLanguageException(String) - Constructor for exception class org.apache.camel.NoSuchLanguageException
- NoSuchPropertyException - Exception Class in org.apache.camel
-
An exception caused when a mandatory property is not available on a message
Exchange
- NoSuchPropertyException(Exchange, String) - Constructor for exception class org.apache.camel.NoSuchPropertyException
- NoSuchPropertyException(Exchange, String, Class<?>) - Constructor for exception class org.apache.camel.NoSuchPropertyException
- NoSuchVariableException - Exception Class in org.apache.camel
-
An exception caused when a mandatory variable is not available
- NoSuchVariableException(Exchange, String) - Constructor for exception class org.apache.camel.NoSuchVariableException
- NoSuchVariableException(Exchange, String, Class<?>) - Constructor for exception class org.apache.camel.NoSuchVariableException
- notify(CamelEvent) - Method in interface org.apache.camel.spi.EventNotifier
-
Notifies the given event
- notify(CamelEvent) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Management events provide a single model for capturing information about execution points in the application code.
- NOTIFY_EVENT - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- NotifyBuilderMatcher - Interface in org.apache.camel.spi
-
Allows to be used in combination with NotifyBuilder as external predicate implementations to compute if the exchange matches.
- notifyBuilderMatches() - Method in interface org.apache.camel.spi.NotifyBuilderMatcher
-
Whether the predicate matches
- notifyBuilderOnExchange(Exchange) - Method in interface org.apache.camel.spi.NotifyBuilderMatcher
-
When an exchange was received
- notifyBuilderReset() - Method in interface org.apache.camel.spi.NotifyBuilderMatcher
-
Reset state
- notifyContextCreated(CamelContext) - Static method in class org.apache.camel.spi.CamelContextTracker
- notifyContextDestroyed(CamelContext) - Static method in class org.apache.camel.spi.CamelContextTracker
- NoTypeConversionAvailableException - Exception Class in org.apache.camel
-
An exception thrown if a value could not be converted to the required type
- NoTypeConversionAvailableException(Object, Class<?>) - Constructor for exception class org.apache.camel.NoTypeConversionAvailableException
- NoTypeConversionAvailableException(Object, Class<?>, Throwable) - Constructor for exception class org.apache.camel.NoTypeConversionAvailableException
O
- of(String) - Static method in enum class org.apache.camel.spi.MimeType
- off - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestBindingMode
- Off - Enum constant in enum class org.apache.camel.ManagementStatisticsLevel
- Off - Enum constant in enum class org.apache.camel.StartupSummaryLevel
- OFF - Enum constant in enum class org.apache.camel.LoggingLevel
- Offset<T> - Interface in org.apache.camel.resume
-
Generic offset without a concrete type
- OFFSET - Static variable in interface org.apache.camel.Exchange
- OffsetKey<K> - Interface in org.apache.camel.resume
-
An interface to represent offset keys (addressable for an offset)
- OK - Enum constant in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Result.Status
-
Verification succeeded
- oldest(String) - Method in interface org.apache.camel.spi.InflightRepository
-
Gets the oldest
InflightRepository.InflightExchange
that are currently inflight that started from the given route. - on(HealthCheck) - Static method in class org.apache.camel.health.HealthCheckResultBuilder
- ON_COMPLETION - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- ON_COMPLETION - Static variable in interface org.apache.camel.Exchange
- ON_COMPLETION_ROUTE_IDS - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- ON_COMPLETION_ROUTE_IDS - Static variable in interface org.apache.camel.Exchange
- onAfterRoute(Route, Exchange) - Method in interface org.apache.camel.spi.SynchronizationRouteAware
-
Invoked after the
Exchange
has been routed by the given route. - onBeforeRoute(Route, Exchange) - Method in interface org.apache.camel.spi.SynchronizationRouteAware
-
Invoked before the
Exchange
is being routed by the given route. - OnCamelContextEvent - Interface in org.apache.camel.spi
-
Marker interface used to make it easy to discover
CamelContext
related event handlers from the registry. - onCamelContextFullyStarted(CamelContext, boolean) - Method in interface org.apache.camel.StartupListener
-
Callback invoked when the
CamelContext
has been fully started. - OnCamelContextInitialized - Interface in org.apache.camel.spi
-
Notification on an initialized a
CamelContext
. - OnCamelContextInitializing - Interface in org.apache.camel.spi
-
Notification on initializing a
CamelContext
. - onCamelContextStarted(CamelContext, boolean) - Method in interface org.apache.camel.StartupListener
-
Callback invoked when the
CamelContext
is about to be fully started (not started yet). - OnCamelContextStarted - Interface in org.apache.camel.spi
-
Notification on a started
CamelContext
. - onCamelContextStarting(CamelContext, boolean) - Method in interface org.apache.camel.StartupListener
-
Callback invoked when the
CamelContext
is being started. - OnCamelContextStarting - Interface in org.apache.camel.spi
-
Notification on starting a
CamelContext
. - OnCamelContextStopped - Interface in org.apache.camel.spi
-
Notification on a stopped
CamelContext
. - OnCamelContextStopping - Interface in org.apache.camel.spi
-
Notification on stopping a
CamelContext
. - onComplete(Exchange) - Method in interface org.apache.camel.spi.Synchronization
-
Called when the processing of the message exchange is complete
- onCompletion(Exchange) - Method in interface org.apache.camel.AggregationStrategy
-
The aggregated
Exchange
has completed Important: This method must not throw any exceptions. - onCompletion(Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
-
The aggregated
Exchange
has completed Important: This method must not throw any exceptions. - onComponentAdd(String, Component) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on adding an
Component
. - onComponentRemove(String, Component) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on removing an
Component
. - onContextInitialized(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on initialized
CamelContext
. - onContextInitialized(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextInitialized
- onContextInitializing(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on initializing a
CamelContext
. - onContextInitializing(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextInitializing
- onContextStarted(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on started
CamelContext
. - onContextStarted(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStarted
- onContextStarting(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on starting a
CamelContext
. - onContextStarting(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStarting
- onContextStopped(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on stopped
CamelContext
. - onContextStopped(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStopped
- onContextStopping(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on stopping a
CamelContext
. - onContextStopping(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStopping
- onDataFormatCreated(String, DataFormat) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on
DataFormat
being resolved from theRegistry
- onDependency(String) - Method in interface org.apache.camel.spi.DependencyStrategy
-
A dependency was detected
- onDone(Exchange) - Method in interface org.apache.camel.PooledExchange.OnDoneTask
- onDone(PooledExchange.OnDoneTask) - Method in interface org.apache.camel.PooledExchange
-
Registers a task to run when this exchange is done.
- Oneline - Enum constant in enum class org.apache.camel.StartupSummaryLevel
- onEndpointAdd(Endpoint) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on adding an
Endpoint
. - onEndpointRemove(Endpoint) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on removing an
Endpoint
. - oneOf() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- onEvent(Exchange, CamelEvent.ExchangeEvent) - Method in interface org.apache.camel.spi.Debugger
-
Callback invoked when an
Exchange
is being processed which allows implementators to notify breakpoints. - onEvent(Exchange, CamelEvent.ExchangeEvent, NamedNode) - Method in interface org.apache.camel.spi.Breakpoint
- onExchangeBegin(Route, Exchange) - Method in interface org.apache.camel.spi.RoutePolicy
- onExchangeDone(Route, Exchange) - Method in interface org.apache.camel.spi.RoutePolicy
- onFailure(Exchange) - Method in interface org.apache.camel.spi.Synchronization
-
Called when the processing of the message exchange has failed for some reason.
- onFieldInject(Field, Object, String) - Method in interface org.apache.camel.spi.CamelBeanPostProcessorInjector
-
Field injection
- onHit(String) - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
-
Callback when an endpoint is being utilized by an
Processor
EIP such as sending a message to a dynamic endpoint. - onInit() - Method in interface org.apache.camel.PollingConsumerPollingStrategy
-
Callback invoked when the consumer is initialized such as when the
PollingConsumer
starts. - onInit(Consumer) - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Initializes this
ScheduledPollConsumerScheduler
with the associatedConsumer
. - onInit(Route) - Method in interface org.apache.camel.spi.RoutePolicy
-
Callback invoked when the
Route
is being initialized - onLanguageCreated(String, Language) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on a
Language
instance being resolved. - onLog(Exchange, CamelLogger, String) - Method in interface org.apache.camel.spi.LogListener
-
Invoked right before Log component or Log EIP logs.
- onLookup(String, String, String, String) - Method in interface org.apache.camel.PropertiesLookupListener
-
Triggers when the given property was found.
- onMethodInject(Method, Object, String) - Method in interface org.apache.camel.spi.CamelBeanPostProcessorInjector
-
Method injection
- onNewThreadFactory(ThreadFactory) - Method in interface org.apache.camel.spi.ExecutorServiceManager.ThreadFactoryListener
-
Listener when Camel has created a new
ThreadFactory
to be used by thisExecutorServiceManager
. - onOptimisticLockFailure(Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
-
Callback when the aggregated
Exchange
fails to add in theOptimisticLockingAggregationRepository
because of anOptimisticLockingAggregationRepository.OptimisticLockingException
. - onPrepare() - Element in annotation interface org.apache.camel.RecipientList
- onPrepare(Exchange) - Method in interface org.apache.camel.spi.UnitOfWork
-
Prepares this unit of work with the given input
Exchange
- onReload(Object) - Method in interface org.apache.camel.spi.ReloadStrategy
-
Trigger reload.
- onReload(String, Properties) - Method in interface org.apache.camel.spi.PropertiesReload
-
Callback when the properties is re-loaded.
- onReload(String, Resource) - Method in interface org.apache.camel.spi.ResourceReload
-
Callback when the resource is re-loaded.
- onRemove(Route) - Method in interface org.apache.camel.spi.RoutePolicy
-
Callback invoked when the
Route
is being removed fromCamelContext
- onResume(Route) - Method in interface org.apache.camel.spi.RoutePolicy
-
Callback invoked when the
Route
is being resumed - onRouteContextCreate(Route) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on creating
Route
(s). - onRoutesAdd(Collection<Route>) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on adding
Route
(s). - onRoutesRemove(Collection<Route>) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on removing
Route
(s). - onServiceAdd(CamelContext, Service, Route) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on adding a
Service
. - onServiceRemove(CamelContext, Service, Route) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on removing a
Service
. - onStart(Route) - Method in interface org.apache.camel.spi.RoutePolicy
-
Callback invoked when the
Route
is being started - onStop(Route) - Method in interface org.apache.camel.spi.RoutePolicy
-
Callback invoked when the
Route
is being stopped - onSuspend(Route) - Method in interface org.apache.camel.spi.RoutePolicy
-
Callback invoked when the
Route
is being suspended - onThreadPoolAdd(CamelContext, ThreadPoolExecutor, String, String, String, String) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on adding a thread pool.
- onThreadPoolRemove(CamelContext, ThreadPoolExecutor) - Method in interface org.apache.camel.spi.LifecycleStrategy
-
Notification on removing a thread pool.
- onTimer() - Method in interface org.apache.camel.TimerListener
-
Notification invoked.
- onUpdate(Throwable) - Method in interface org.apache.camel.resume.ResumeStrategy.UpdateCallBack
-
The method to execute after the last offset is updated
- open() - Method in class org.apache.camel.spi.CamelContextTracker
-
Opens the tracker to start tracking when new
CamelContext
is created or destroyed. - OptimisticLockingAggregationRepository - Interface in org.apache.camel.spi
-
A specialized
AggregationRepository
which also supports optimistic locking. - OptimisticLockingAggregationRepository.OptimisticLockingException - Exception Class in org.apache.camel.spi
-
Exception
used by anAggregationRepository
to indicate that an optimistic update error has occurred and that the operation should be retried by the caller. - OptimisticLockingException() - Constructor for exception class org.apache.camel.spi.OptimisticLockingAggregationRepository.OptimisticLockingException
- optional() - Element in annotation interface org.apache.camel.spi.ApiParam
-
Whether the parameter is optional (in some rare circumstances the parameter may be required)
- optional(String) - Method in interface org.apache.camel.spi.PropertiesFunction
-
If the property value cannot be found should the property be regarded as optional and ignore missing value.
- OPTIONAL_TOKEN - Static variable in interface org.apache.camel.spi.PropertiesComponent
-
The token for marking a placeholder as optional
- optionalPrefix() - Element in annotation interface org.apache.camel.spi.UriParam
-
If the parameter can be configured with an optional prefix.
- order() - Element in annotation interface org.apache.camel.Converter
-
To be used for ordering converter methods when source code generating bulk loaders.
- order() - Element in annotation interface org.apache.camel.spi.annotations.YamlType
- Ordered - Interface in org.apache.camel
-
Interface to be implemented by objects that should be orderable, such as with a
Collection
. - org.apache.camel - package org.apache.camel
-
The core Camel API.
- org.apache.camel.ai - package org.apache.camel.ai
- org.apache.camel.catalog - package org.apache.camel.catalog
-
Camel Catalog API
- org.apache.camel.clock - package org.apache.camel.clock
- org.apache.camel.cloud - package org.apache.camel.cloud
-
Camel cloud
- org.apache.camel.cloudevents - package org.apache.camel.cloudevents
- org.apache.camel.cluster - package org.apache.camel.cluster
-
Camel Cluster support
- org.apache.camel.component.extension - package org.apache.camel.component.extension
-
Component extension
- org.apache.camel.console - package org.apache.camel.console
- org.apache.camel.health - package org.apache.camel.health
-
Camel Health Check support
- org.apache.camel.resume - package org.apache.camel.resume
- org.apache.camel.resume.cache - package org.apache.camel.resume.cache
- org.apache.camel.spi - package org.apache.camel.spi
-
Service Provider Interfaces used by the Camel runtime which are plugin strategies.
- org.apache.camel.spi.annotations - package org.apache.camel.spi.annotations
-
SPI annotations for plugins
- org.apache.camel.support.jsse - package org.apache.camel.support.jsse
-
A collection of utility classes for configuring a JSSE SSLContext and other JSSE classes.
- org.apache.camel.support.service - package org.apache.camel.support.service
-
Base service classes
- org.apache.camel.trait.message - package org.apache.camel.trait.message
- org.apache.camel.vault - package org.apache.camel.vault
- OUT - Enum constant in enum class org.apache.camel.spi.HeaderFilterStrategy.Direction
- Override - Enum constant in enum class org.apache.camel.TypeConverterExists
- OVERRULE_FILE_NAME - Static variable in interface org.apache.camel.Exchange
P
- PackageScanClassResolver - Interface in org.apache.camel.spi
-
A resolver that can find classes based on package scanning.
- PackageScanFilter - Interface in org.apache.camel.spi
-
Filter that can be used with the
PackageScanClassResolver
resolver. - PackageScanResourceResolver - Interface in org.apache.camel.spi
-
A resolver that can find resources based on package scanning.
- parallelAggregate() - Element in annotation interface org.apache.camel.RecipientList
-
If enabled then the aggregate method on AggregationStrategy can be called concurrently.
- parallelProcessing() - Element in annotation interface org.apache.camel.RecipientList
-
If enabled then sending messages to the recipients occurs concurrently.
- parameters(String) - Method in interface org.apache.camel.spi.RouteTemplateParameterSource
-
The parameters for the given route
- PARAMETERS - Enum constant in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Scope
-
Only validate the parameters for their syntactic soundness.
- PARENT_PROPERTY - Static variable in interface org.apache.camel.Route
- PARENT_UNIT_OF_WORK - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- PARENT_UNIT_OF_WORK - Static variable in interface org.apache.camel.Exchange
- parseModeline(Resource) - Method in interface org.apache.camel.spi.ModelineFactory
-
Parses the resources to discover camel-k modeline snippets which is parsed and processed.
- parsePropertyValue(String) - Method in class org.apache.camel.support.jsse.JsseParameters
-
Parses the value using the Camel Property Placeholder capabilities if a context is provided.
- parsePropertyValues(List<String>) - Method in class org.apache.camel.support.jsse.JsseParameters
-
Parses the values using the Camel Property Placeholder capabilities if a context is provided.
- parseUri(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Parses the input text and resolve all property placeholders from within the text.
- parseUri(String, boolean) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Parses the input text and resolve all property placeholders from within the text.
- password - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
- Pattern - Annotation Interface in org.apache.camel
-
Marks a method as having a specific kind of
ExchangePattern
for use with Bean Integration to overload the default value which isExchangePattern.InOut
for request/reply if no annotations are used. - Patterns(List<Pattern>, List<Pattern>) - Constructor for class org.apache.camel.support.jsse.FilterParameters.Patterns
- PeriodicTask - Annotation Interface in org.apache.camel.spi.annotations
- PeriodTaskResolver - Interface in org.apache.camel.spi
-
Finder to find
PeriodicTask
tasks. - PeriodTaskScheduler - Interface in org.apache.camel.spi
-
A shared scheduler to run small period tasks, such as updating internal statistics, or for custom components to have a background task.
- PluginManager - Interface in org.apache.camel.spi
-
A manager for internal plugins.
- Policy - Interface in org.apache.camel.spi
-
A strategy capable of applying interceptors to a processor.
- PollingConsumer - Interface in org.apache.camel
-
Represents a Polling Consumer where the caller polls for messages when it is ready.
- PollingConsumerPollingStrategy - Interface in org.apache.camel
-
Strategy that allows
Consumer
s to influence thePollingConsumer
. - PollingConsumerPollStrategy - Interface in org.apache.camel.spi
-
Strategy for a
PollingConsumer
when polling anEndpoint
. - PooledExchange - Interface in org.apache.camel
-
Pooled
Exchange
which contains the methods and APIs that are not intended for Camel end users but used internally by Camel for optimizing memory footprint by reusing exchanges created byConsumer
s viaExchangeFactory
. - PooledExchange.OnDoneTask - Interface in org.apache.camel
-
Task to execute when the exchange is done.
- PooledObjectFactory<T> - Interface in org.apache.camel.spi
-
Factory for pooled objects or tasks.
- PooledObjectFactory.Statistics - Interface in org.apache.camel.spi
-
Utilization statistics of the this factory.
- pop() - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Pops the repository and returns the latest.
- popRoute() - Method in interface org.apache.camel.spi.UnitOfWork
-
When finished being routed under the current
Route
it should be removed. - position() - Method in interface org.apache.camel.StreamCache
-
Read position
- postCompile(CamelContext, String, Class<?>, byte[], Object) - Method in interface org.apache.camel.spi.CompilePostProcessor
-
Invoked after the class has been compiled
- postInitChannel() - Method in interface org.apache.camel.Channel
-
Post initializes the channel.
- postProcessAfterInitialization(Object, String) - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
-
Apply this post processor to the given new bean instance after any bean initialization callbacks (like
afterPropertiesSet
or a custom init-method). - postProcessBeforeInitialization(Object, String) - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
-
Apply this post processor to the given new bean instance before any bean initialization callbacks (like
afterPropertiesSet
or a custom init-method). - preComplete(Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
-
Determines if the aggregation should complete the current group, and start a new group, or the aggregation should continue using the current group.
- predicate() - Element in annotation interface org.apache.camel.Consume
-
Optional predicate (using simple language) to only consume if the predicate matches .
- Predicate - Interface in org.apache.camel
-
Evaluates a binary predicate on the message exchange.
- PredicateExceptionFactory - Interface in org.apache.camel.spi
-
A factory that can be used to create a specific exception when a
Predicate
returning false, which can be used by camel-validator and other components. - PredicateFactory - Interface in org.apache.camel
-
A factory for creating
Predicate
- PredicateFactoryAware - Interface in org.apache.camel.spi
-
When an instance is aware of
PredicateFactory
. - prefix() - Element in annotation interface org.apache.camel.spi.UriParam
-
If the parameter must be configured with a prefix.
- prefix() - Element in annotation interface org.apache.camel.spi.UriParams
-
Returns the prefix used to access nested properties of this configuration object
- PREFIX_OPTIONAL_TOKEN - Static variable in interface org.apache.camel.spi.PropertiesComponent
-
The prefix and optional tokens
- PREFIX_TOKEN - Static variable in interface org.apache.camel.spi.PropertiesComponent
-
The prefix token.
- prepare(Exchange, String, String) - Method in interface org.apache.camel.spi.SendDynamicAware
-
Prepares for using optimised dynamic to by parsing the uri and returning an entry of details that are used for creating the pre and post processors, and the static uri.
- prepareShutdown(boolean, boolean) - Method in interface org.apache.camel.spi.ShutdownPrepared
-
Prepares for stop/shutdown.
- preParseRoute(Resource) - Method in interface org.apache.camel.spi.RoutesBuilderLoader
-
Pre-parses the
RoutesBuilder
fromResource
. - preParseRoute(Resource, boolean) - Method in interface org.apache.camel.spi.RoutesLoader
-
Pre-parses the
RoutesBuilder
fromResource
. - preParseRoutes(Collection<Resource>) - Method in interface org.apache.camel.spi.ExtendedRoutesBuilderLoader
-
Pre-parses the
RoutesBuilder
from multipleResource
s. - process(AsyncProcessor, Exchange) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
Process the given exchange synchronously.
- process(Exchange) - Method in interface org.apache.camel.Processor
-
Processes the message exchange
- process(Exchange) - Method in interface org.apache.camel.spi.SharedInternalProcessor
- process(Exchange, String, ServiceLoadBalancerFunction<T>) - Method in interface org.apache.camel.cloud.ServiceLoadBalancer
-
Deprecated.
- process(Exchange, AsyncCallback) - Method in interface org.apache.camel.AsyncProcessor
-
Processes the message exchange.
- process(Exchange, AsyncCallback, AsyncProcessor, Processor) - Method in interface org.apache.camel.spi.SharedInternalProcessor
-
Asynchronous API
- process(Exchange, AsyncProcessor, Processor) - Method in interface org.apache.camel.spi.SharedInternalProcessor
-
Synchronous API
- processAsync(Exchange) - Method in interface org.apache.camel.AsyncProcessor
- processBatch(Queue<Object>) - Method in interface org.apache.camel.BatchConsumer
-
Processes the list of
Exchange
objects in a batch. - 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.
- ProcessorExchangeFactory - Interface in org.apache.camel.spi
- ProcessorFactory - Interface in org.apache.camel.spi
-
A factory to create
Processor
based on theinvalid reference
definition
- processResult(HealthCheck, Map<String, Object>, HealthCheckResultBuilder) - Method in interface org.apache.camel.health.HealthCheckResultStrategy
-
Processes and allows manipulation of the result from the
HealthCheck
invocation. - Produce - Annotation Interface in org.apache.camel
- Producer - Interface in org.apache.camel
-
Provides a channel on which clients can create and invoke message exchanges on an
Endpoint
. - ProducerCache - Interface in org.apache.camel.spi
-
Cache containing created
Producer
. - ProducerCache.AsyncProducerCallback - Interface in org.apache.camel.spi
-
Callback for sending a exchange message to a endpoint using an
AsyncProcessor
capable producer. - producerOnly() - Element in annotation interface org.apache.camel.spi.ApiParams
-
Whether this API can only be used as a producer.
- producerOnly() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
Whether this endpoint can only be used as a producer.
- ProducerTemplate - Interface in org.apache.camel
- produces() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns the value of the
produces
record component. - properties() - Element in annotation interface org.apache.camel.spi.annotations.YamlType
- PropertiesComponent - Interface in org.apache.camel.spi
-
Component for property placeholders and loading properties from sources (such as .properties file from classpath or file system)
- PropertiesFunction - Interface in org.apache.camel.spi
-
A function that is applied instead of looking up a property placeholder.
- PropertiesFunction - Annotation Interface in org.apache.camel.spi.annotations
- PropertiesLookupListener - Interface in org.apache.camel
-
Listener to trigger when the properties component is looking up and found a property.
- PropertiesReload - Interface in org.apache.camel.spi
-
Listener for re-loading a
Properties
such as a Camel route. - PropertiesSource - Interface in org.apache.camel.spi
-
A source for properties.
- PropertiesSourceFactory - Interface in org.apache.camel.spi
-
Factory for creating out of the box
PropertiesSource
. - property() - Element in annotation interface org.apache.camel.Consume
-
Use the field or getter on the bean to provide the uri to consume from
- property() - Element in annotation interface org.apache.camel.EndpointInject
-
Use the field or getter on the bean to provide the uri of the endpoint
- property() - Element in annotation interface org.apache.camel.Produce
-
Use the field or getter on the bean to provide the uri to produce to
- property(Exchange, String) - Static method in exception class org.apache.camel.NoSuchHeaderOrPropertyException
- PropertyBindingException - Exception Class in org.apache.camel
-
Error binding property to a bean.
- PropertyBindingException(Object, String, Object) - Constructor for exception class org.apache.camel.PropertyBindingException
- PropertyBindingException(Object, String, Object, String, String, Throwable) - Constructor for exception class org.apache.camel.PropertyBindingException
- PropertyBindingException(Object, String, Object, Throwable) - Constructor for exception class org.apache.camel.PropertyBindingException
- PropertyBindingException(Object, Throwable) - Constructor for exception class org.apache.camel.PropertyBindingException
- PropertyConfigurer - Interface in org.apache.camel.spi
-
A marker interface to identify the object as being configurable via a configurer class.
- PropertyConfigurerAware - Interface in org.apache.camel.spi
-
An interface to represent an object which is capable of configuring via
PropertyConfigurer
. - PropertyConfigurerGetter - Interface in org.apache.camel.spi
-
A marker interface to identify the object as being a configurer which can provide details about the options the configurer supports.
- PropertyInject - Annotation Interface in org.apache.camel
-
Used to indicate an injection point of a property placeholder into a POJO.
- propertyNames() - Method in interface org.apache.camel.spi.EndpointUriFactory
-
Returns all the names this endpoint supports.
- PROTOBUF - Enum constant in enum class org.apache.camel.spi.MimeType
- PROTOBUF_BINARY - Enum constant in enum class org.apache.camel.spi.MimeType
- PROTOBUF_JAVA_OBJECT - Enum constant in enum class org.apache.camel.spi.MimeType
- PROTOBUF_STRUCT - Enum constant in enum class org.apache.camel.spi.MimeType
- Prototype - Enum constant in enum class org.apache.camel.BeanScope
- provider - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
- provider - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
- provider - Variable in class org.apache.camel.support.jsse.SecureRandomParameters
- provider - Variable in class org.apache.camel.support.jsse.TrustManagersParameters
- ProxyInstantiationException - Exception Class in org.apache.camel
-
Exception indicating a failure while trying to create a proxy of a given type and on a given endpoint
- ProxyInstantiationException(Class<?>, Endpoint, Throwable) - Constructor for exception class org.apache.camel.ProxyInstantiationException
- purge() - Method in interface org.apache.camel.spi.ConsumerCache
-
Purges this cache
- purge() - Method in interface org.apache.camel.spi.EndpointRegistry
-
Purges the cache (removes endpoints from the dynamic cache)
- purge() - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Purges the internal caches (if pooled)
- purge() - Method in interface org.apache.camel.spi.PooledObjectFactory
-
Purges the internal cache (if pooled)
- purge() - Method in interface org.apache.camel.spi.ProducerCache
-
Purges this cache
- purge() - Method in interface org.apache.camel.spi.TransformerRegistry
-
Purges the cache (removes transformers from the dynamic cache)
- purge() - Method in interface org.apache.camel.spi.ValidatorRegistry
-
Purges the cache (removes validators from the dynamic cache)
- push(Exchange) - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Pushes the exchange on top of the repository.
- pushRoute(Route) - Method in interface org.apache.camel.spi.UnitOfWork
-
Pushes the
Route
that thisUnitOfWork
currently is being routed through. - put(K, V, long) - Method in interface org.apache.camel.TimeoutMap
-
Adds the key value pair into the map such that some time after the given timeout the entry will be evicted
- Put - Enum constant in enum class org.apache.camel.TimeoutMap.Listener.Type
- putIfAbsent(K, V, long) - Method in interface org.apache.camel.TimeoutMap
-
Adds the key value pair into the map if the specified key is not already associated with a value such that some time after the given timeout the entry will be evicted.
Q
- queryAllowedValues() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns the value of the
queryAllowedValues
record component. - queryDefaultValues() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns the value of the
queryDefaultValues
record component.
R
- ReactiveExecutor - Interface in org.apache.camel.spi
-
SPI to plugin different reactive engines in the Camel routing engine.
- READINESS - Enum constant in enum class org.apache.camel.health.HealthCheck.Kind
- reason(Exchange, String) - Static method in exception class org.apache.camel.NoSuchHeaderException
- reason(Exchange, String) - Static method in exception class org.apache.camel.NoSuchPropertyException
- 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.
- receive(String) - 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) - 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.spi.ConsumerCache
-
Waits until a message is available and then returns it.
- 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, long) - Method in interface org.apache.camel.spi.ConsumerCache
-
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(String, long) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response or the timeout occurs
- 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(String, Class<T>) - 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(Endpoint, 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, 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, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBodyNoWait(String) - 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) - 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.
- RECEIVED_TIMESTAMP - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- RECEIVED_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
- 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.
- 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 interface org.apache.camel.spi.ConsumerCache
-
Attempts to receive a message exchange immediately without waiting and returning null if a message exchange is not available yet.
- RECIPIENT_LIST_ENDPOINT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- RECIPIENT_LIST_ENDPOINT - Static variable in interface org.apache.camel.Exchange
- RecipientList - Annotation Interface 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.
- recover(CamelContext, String) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Recovers the exchange with the given exchange id
- RecoverableAggregationRepository - Interface in org.apache.camel.spi
-
A specialized
AggregationRepository
which also supports recovery. - REDELIVERED - Static variable in interface org.apache.camel.Exchange
- REDELIVERY - Enum constant in enum class org.apache.camel.trait.message.MessageTrait
-
The redelivery trait for the message.
- REDELIVERY_COUNTER - Static variable in interface org.apache.camel.Exchange
- REDELIVERY_DELAY - Static variable in interface org.apache.camel.Exchange
- REDELIVERY_EXHAUSTED - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- REDELIVERY_MAX_COUNTER - Static variable in interface org.apache.camel.Exchange
- RedeliveryTraitPayload - Enum Class in org.apache.camel.trait.message
-
Some messages can carry redelivery details which might affect routing (i.e; JMS messages).
- register(Object) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Registers a
HealthCheck
orHealthCheckRepository
. - register(Object, ObjectName) - Method in interface org.apache.camel.spi.ManagementAgent
-
Registers object with management infrastructure with a specific name.
- register(Object, ObjectName, boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Registers object with management infrastructure with a specific name.
- register(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceRegistry
-
Deprecated.Register the service definition.
- register(DevConsole) - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Registers a
DevConsole
. - registerDestroyMethod(String, String) - Method in interface org.apache.camel.RouteTemplateContext
-
Registers an optional destroy method to invoke on the bean when stopping Camel.
- registerEndpoint(String, Endpoint) - Method in interface org.apache.camel.spi.EndpointStrategy
-
Register the endpoint.
- registerEndpointCallback(EndpointStrategy) - Method in interface org.apache.camel.ExtendedCamelContext
-
Registers a
callback
to allow you to do custom logic when anEndpoint
is about to be registered to theEndpointRegistry
. - registerThreadPoolProfile(ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Registers the given thread pool profile
- Registry - Interface in org.apache.camel.spi
-
Represents a
BeanRepository
which may also be capable of binding beans to its repository. - ReifierStrategy - Class in org.apache.camel.spi
-
Strategy for reifiers.
- ReifierStrategy() - Constructor for class org.apache.camel.spi.ReifierStrategy
- release(Exchange) - Method in interface org.apache.camel.spi.ExchangeFactory
-
Releases the exchange back into the pool
- release(Exchange) - Method in interface org.apache.camel.spi.ProcessorExchangeFactory
-
Releases the exchange back into the pool
- release(T) - Method in interface org.apache.camel.spi.PooledObjectFactory
-
Releases the object back to the pool
- releaseExchange(Exchange, boolean) - Method in interface org.apache.camel.Consumer
-
Releases the
Exchange
when its completed processing and no longer needed. - releasePollingConsumer(Endpoint, PollingConsumer) - Method in interface org.apache.camel.spi.ConsumerCache
-
Releases an acquired polling consumer back after usage.
- releaseProducer(Endpoint, AsyncProducer) - Method in interface org.apache.camel.spi.ProducerCache
-
Releases an acquired producer back after usage.
- releaseView(CamelClusterView) - Method in interface org.apache.camel.cluster.CamelClusterService
-
Release a view if it has no references.
- reloadAllRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Reloads all the routes
- reloadProperties(String) - Method in interface org.apache.camel.spi.LoadablePropertiesSource
-
Re-loads the properties from the file location
- reloadProperties(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Reload properties from the given location patterns.
- ReloadStrategy - Interface in org.apache.camel.spi
-
SPI strategy for reloading.
- remote() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
Whether the component does remote communication such as connecting to an external system over the network.
- remove(String) - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
-
To remove an endpoint from tracking information about its utilization
- remove(String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Removes the key from the repository.
- remove(K) - Method in interface org.apache.camel.TimeoutMap
-
Removes the object with the given key
- remove(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.AggregationRepository
-
Removes the exchange with the given correlation key, which should happen when an
Exchange
is completed - remove(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.OptimisticLockingAggregationRepository
-
Removes the given Exchange when both the supplied key and Exchange are present in the repository.
- remove(Exchange) - Method in interface org.apache.camel.spi.InflightRepository
-
Removes the exchange from the inflight registry to the total counter
- remove(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Removes the key from the repository.
- remove(Exchange, String) - Method in interface org.apache.camel.spi.InflightRepository
-
Removes the exchange from the inflight registry removing association to the given route
- Remove - Enum constant in enum class org.apache.camel.TimeoutMap.Listener.Type
- REMOVE - Enum constant in enum class org.apache.camel.spi.RouteError.Phase
- removeAllBreakpoints() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Remove all breakpoints
- removeAllRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Stops and removes all the routes
- removeBreakpoint(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Removes the breakpoint
- removeBreakpoint(Breakpoint) - Method in interface org.apache.camel.spi.Debugger
-
Removes the given breakpoint
- removeComponent(String) - Method in interface org.apache.camel.CamelContext
-
Removes a previously added component.
- removeEndpoint(Endpoint) - Method in interface org.apache.camel.CamelContext
-
Removes the endpoint from the
EndpointRegistry
. - removeEndpoints(String) - Method in interface org.apache.camel.CamelContext
-
Removes all endpoints with the given URI from the
EndpointRegistry
. - removeEventListener(CamelClusterEventListener) - Method in interface org.apache.camel.cluster.CamelClusterView
-
Remove the event listener.
- removeEventNotifier(EventNotifier) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Removes the event notifier
- removeExchangeFactory(ExchangeFactory) - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Removes the
ExchangeFactory
from being managed (such as when a route is stopped/removed) or during shutdown. - removeExchangePropertyOnBreakpoint(String, String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Removes the exchange property at the given breakpoint
- removeExchangeVariableOnBreakpoint(String, String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Removes the variable on the suspended breakpoint at the given node id
- removeFilter(PackageScanFilter) - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
Removes the filter
- removeHeader(String) - Method in interface org.apache.camel.Message
-
Removes the named header from this message
- removeHeaders(String) - Method in interface org.apache.camel.Message
-
Removes the headers from this message
- removeHeaders(String, String...) - Method in interface org.apache.camel.Message
-
Removes the headers from this message that match the given pattern, except for the ones matching one or more excludePatterns
- removeHealthCheck(HealthCheck) - Method in interface org.apache.camel.health.WritableHealthCheckRepository
-
Removes a
HealthCheck
from the repository. - removeMessageBodyOnBreakpoint(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Removes the message body (set as null) at the given breakpoint
- removeMessageHeaderOnBreakpoint(String, String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Removes the message header at the given breakpoint
- removeProperties(String) - Method in interface org.apache.camel.Exchange
-
Remove all the properties associated with the exchange matching a specific pattern
- removeProperties(String, String...) - Method in interface org.apache.camel.Exchange
-
Removes the properties from this exchange that match the given pattern, except for the ones matching one or more excludePatterns
- removeProperty(String) - Method in interface org.apache.camel.Exchange
-
Removes the given property on the exchange
- removeProperty(ExchangePropertyKey) - Method in interface org.apache.camel.Exchange
-
Removes the given property on the exchange
- removeRestService(Consumer) - Method in interface org.apache.camel.spi.RestRegistry
-
Removes the REST service from the registry
- removeRoute(String) - Method in interface org.apache.camel.CamelContext
-
Removes the given route (the route must be stopped before it can be removed).
- removeRoute(String) - Method in interface org.apache.camel.spi.InflightRepository
-
Removes the route from the in flight registry.
- removeRoute(Route) - Method in interface org.apache.camel.ExtendedCamelContext
-
Internal API for removing routes.
- removeRouteTemplates(String) - Method in interface org.apache.camel.CamelContext
-
Removes the route templates matching the pattern
- removeService(Object) - Method in interface org.apache.camel.CamelContext
-
Removes a service from this CamelContext.
- removeSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
-
Removes a synchronization hook
- removeTypeConverter(Class<?>, Class<?>) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Removes the type converter
- removeVariable(String) - Method in interface org.apache.camel.Exchange
-
Removes the given variable If the name is * then all variables from the current exchange is removed, and null is returned.
- removeVariable(String) - Method in interface org.apache.camel.spi.VariableRepository
-
Removes the given variable
- request() - Method in interface org.apache.camel.FluentProducerTemplate
-
Send to an endpoint (InOut) returning any result output body.
- request(Class<T>) - Method in interface org.apache.camel.FluentProducerTemplate
-
Send to an endpoint (InOut).
- 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. - 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 - Enum constant in enum class org.apache.camel.BeanScope
- 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(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.
- 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.
- requestBodyAndHeader(Object, String, 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. - 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.
- 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.
- requestBodyAndHeaders(Object, Map<String, 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. - 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.
- REQUIRE - Enum constant in enum class org.apache.camel.support.jsse.ClientAuthentication
-
Client authentication required.
- required() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- required() - Element in annotation interface org.apache.camel.spi.Metadata
-
To define that this entity is required.
- requiredBody() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns the value of the
requiredBody
record component. - requiredHeaders() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns the value of the
requiredHeaders
record component. - requiredQueryParameters() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns the value of the
requiredQueryParameters
record component. - reset() - Method in interface org.apache.camel.Message
-
Clears the message from user data, so the message can be reused.
- reset() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
Reset the counters
- reset() - Method in interface org.apache.camel.spi.PooledObjectFactory.Statistics
-
Reset the counters
- reset() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Reset the statistic counters
- reset() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Reset the counters
- reset() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Reset the counters
- reset() - Method in interface org.apache.camel.spi.UnitOfWork
-
Clears the unit of work from user data, so it may be reused.
- reset() - Method in interface org.apache.camel.StreamCache
-
Resets the StreamCache for a new stream consumption.
- reset(long) - Method in interface org.apache.camel.PooledExchange
-
Deprecated.
- resetCounters() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Reset the statistics counters.
- resetCounters() - Method in interface org.apache.camel.spi.ReloadStrategy
-
Reset the counters.
- resetDebugCounter() - Method in interface org.apache.camel.spi.BacklogDebugger
-
Rests the debug counter
- resetStatistics() - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Reset the statistics
- resetStatistics() - Method in interface org.apache.camel.spi.PooledObjectFactory
-
Reset the statistics
- resetTraceCounter() - Method in interface org.apache.camel.spi.BacklogTracer
-
Reset the tracing counter
- resetTraceCounter() - Method in interface org.apache.camel.spi.Tracer
-
Reset trace counter
- resolve(String) - Method in interface org.apache.camel.spi.ResourceResolver
-
Resolve a
Resource
from a give uri. - resolve(K, CamelContext) - Method in interface org.apache.camel.spi.TransformerResolver
-
Attempts to resolve the transformer for the given key.
- resolve(CamelContext) - Method in interface org.apache.camel.EndpointConsumerResolver
-
Resolves this object as an endpoint.
- resolve(CamelContext) - Method in interface org.apache.camel.EndpointProducerResolver
-
Resolves this object as an endpoint.
- resolve(CamelContext, Class<T>) - Method in interface org.apache.camel.EndpointConsumerResolver
-
Resolves this object as an endpoint.
- resolve(CamelContext, Class<T>) - Method in interface org.apache.camel.EndpointProducerResolver
-
Resolves this object as an endpoint.
- resolveBootstrapFactoryFinder(ClassResolver) - Method in interface org.apache.camel.spi.FactoryFinderResolver
-
Creates a new bootstrap factory finder using a default resource path.
- resolveBootstrapFactoryFinder(ClassResolver, String) - Method in interface org.apache.camel.spi.FactoryFinderResolver
-
Creates a new factory finder.
- resolveById(String) - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Resolves
DevConsole
by id. - resolveById(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Resolves
HealthCheck
orHealthCheckRepository
by id. - 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, Class<T>, ClassLoader) - 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
- resolveComponent(String, CamelContext) - Method in interface org.apache.camel.spi.ComponentResolver
-
Attempts to resolve the component for the given URI
- resolveDataFormat(String) - Method in interface org.apache.camel.CamelContext
-
Resolve an existing data format, or creates a new by the given its name
- resolveDefaultFactoryFinder(ClassResolver) - Method in interface org.apache.camel.spi.FactoryFinderResolver
-
Creates a new default factory finder using a default resource path.
- resolveDevConsole(String) - Method in interface org.apache.camel.console.DevConsoleResolver
-
Resolves the given
DevConsole
. - ResolveEndpointFailedException - Exception Class in org.apache.camel
-
A runtime exception thrown if an
Endpoint
cannot be resolved via URI - ResolveEndpointFailedException(String) - Constructor for exception class org.apache.camel.ResolveEndpointFailedException
- ResolveEndpointFailedException(String, String) - Constructor for exception class org.apache.camel.ResolveEndpointFailedException
- ResolveEndpointFailedException(String, Throwable) - Constructor for exception class org.apache.camel.ResolveEndpointFailedException
- resolveFactory(String, CamelContext) - Method in interface org.apache.camel.spi.UriFactoryResolver
-
Resolves the given
EndpointUriFactory
. - resolveFactoryFinder(ClassResolver, String) - Method in interface org.apache.camel.spi.FactoryFinderResolver
-
Creates a new factory finder.
- resolveHealthCheck(String) - Method in interface org.apache.camel.health.HealthCheckResolver
-
Resolves the given
HealthCheck
. - resolveHealthCheckRepository(String) - Method in interface org.apache.camel.health.HealthCheckResolver
-
Resolves the given
HealthCheckRepository
. - resolveLanguage(String) - Method in interface org.apache.camel.CamelContext
-
Resolves a language for creating expressions
- resolveLanguage(String, CamelContext) - Method in interface org.apache.camel.spi.LanguageResolver
-
Resolves the given language.
- resolveManagementName(String, String, boolean) - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
Creates a new management name with the given pattern.
- 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, Class<T>, ClassLoader) - 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
- resolveNames(CamelContext) - Method in interface org.apache.camel.spi.ComponentNameResolver
-
Discovers which components are available on the classpath.
- resolveProperty(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Looks up the property with the given key
- resolvePropertyConfigurer(String, CamelContext) - Method in interface org.apache.camel.spi.ConfigurerResolver
-
Resolves the given configurer.
- resolvePropertyPlaceholders(String) - Method in interface org.apache.camel.CamelContext
-
Parses the given text and resolve any property placeholders - using {{key}}.
- resolvePropertyPlaceholders(String, boolean) - Method in interface org.apache.camel.ExtendedCamelContext
-
Parses the given text and resolve any property placeholders - using {{key}}.
- resolveRawParameterValues() - Method in interface org.apache.camel.spi.SendDynamicAware
-
Whether to traverses the given parameters, and resolve any parameter values which uses the RAW token syntax: key=RAW(value).
- resolveResource(String) - Method in interface org.apache.camel.spi.ResourceLoader
-
Loads
Resource
from uri. - resolveResource(String) - Method in class org.apache.camel.support.jsse.JsseParameters
-
Attempts to load a resource using a number of different approaches.
- resolveStaticUri(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in interface org.apache.camel.spi.SendDynamicAware
- resolveThreadName(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a full thread name
- resolveTransformer(String) - Method in interface org.apache.camel.CamelContext
-
Resolve a transformer given a scheme
- resolveTransformer(DataType, DataType) - Method in interface org.apache.camel.CamelContext
-
Resolve a transformer given from/to data type.
- resolveTransformer(TransformerKey) - Method in interface org.apache.camel.spi.TransformerRegistry
-
Lookup a
Transformer
in the registry which supports the transformation for the data types represented by the key. - resolveValidator(DataType) - Method in interface org.apache.camel.CamelContext
-
Resolve a validator given from/to data type.
- resolveValidator(ValidatorKey) - Method in interface org.apache.camel.spi.ValidatorRegistry
-
Lookup a
Validator
in the registry which supports the validation for the data type represented by the key. - resource - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
- Resource - Interface in org.apache.camel.spi
-
Describe a resource, such as a file or class path resource.
- RESOURCE_PATH - Static variable in interface org.apache.camel.spi.ConfigurerResolver
- RESOURCE_PATH - Static variable in interface org.apache.camel.spi.PeriodTaskResolver
- ResourceAware - Interface in org.apache.camel.spi
-
An interface to represent an object which wishes to be injected with the
Resource
- ResourceLoader - Interface in org.apache.camel.spi
-
SPI for loading resources.
- ResourceReload - Interface in org.apache.camel.spi
-
Listener for re-loading a
Resource
such as a Camel route. - ResourceReloadStrategy - Interface in org.apache.camel.spi
-
SPI strategy for reloading
Resource
in an existing runningCamelContext
- ResourceResolver - Interface in org.apache.camel.spi
-
SPI for loading resources.
- ResourceResolver - Annotation Interface in org.apache.camel.spi.annotations
- RESPONSE_FROM_FALLBACK - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
- RESPONSE_REJECTED - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
- RESPONSE_SHORT_CIRCUITED - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
- RESPONSE_SUCCESSFUL_EXECUTION - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
- RESPONSE_TIMED_OUT - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
- REST - Enum constant in enum class org.apache.camel.Category
- REST_HTTP_QUERY - Static variable in interface org.apache.camel.Exchange
- REST_HTTP_URI - Static variable in interface org.apache.camel.Exchange
- REST_OPENAPI - Static variable in interface org.apache.camel.Exchange
- REST_PROPERTY - Static variable in interface org.apache.camel.Route
- RestApiConsumerFactory - Interface in org.apache.camel.spi
-
Allows SPI to plugin a
RestApiConsumerFactory
that creates the CamelConsumer
responsible for handling incoming HTTP GET requests from clients that request to access the REST API documentation. - RestApiProcessorFactory - Interface in org.apache.camel.spi
-
Allows SPI to plugin a
RestApiProcessorFactory
that creates the CamelProcessor
responsible for servicing and generating the REST API documentation. - RestBindingJaxbDataFormatFactory - Interface in org.apache.camel.spi
-
SPI for setting up XML data format (JAXB) for rest-dsl.
- RestClientRequestValidator - Interface in org.apache.camel.spi
-
Used for validating incoming client requests with Camel Rest DSL.
- RestClientRequestValidator.ValidationContext - Record Class in org.apache.camel.spi
-
Validation context to use during validation
- RestClientRequestValidator.ValidationError - Record Class in org.apache.camel.spi
-
Validation error
- RestConfiguration - Class in org.apache.camel.spi
-
Configuration use by
RestConsumerFactory
andRestApiConsumerFactory
for Camel components to support the Camelinvalid reference
rest
- RestConfiguration() - Constructor for class org.apache.camel.spi.RestConfiguration
- RestConfiguration.RestBindingMode - Enum Class in org.apache.camel.spi
- RestConfiguration.RestHostNameResolver - Enum Class in org.apache.camel.spi
- RestConsumerFactory - Interface in org.apache.camel.spi
-
Allows SPI to plugin a
RestConsumerFactory
that creates the CamelConsumer
responsible for handling incoming HTTP requests from clients that request to access REST services which has been created using the rest-dsl. - RestOpenApiConsumerFactory - Interface in org.apache.camel.spi
-
Allows SPI to plugin a
RestOpenApiConsumerFactory
that creates the CamelConsumer
responsible for handling incoming HTTP requests from clients that request to access REST services which has been created using the rest-dsl for an entire open-api specification. - RestProducerFactory - Interface in org.apache.camel.spi
-
Allows SPI to plugin a
RestProducerFactory
that creates the CamelProducer
responsible for performing HTTP requests to call a remote REST service. - RestRegistry - Interface in org.apache.camel.spi
-
A registry of all REST services running within the
CamelContext
which have been defined and created using the Rest DSL. - RestRegistry.RestService - Interface in org.apache.camel.spi
-
Details about the REST service
- RestRegistryFactory - Interface in org.apache.camel.spi
-
A factory for
RestRegistry
. - Resumable - Interface in org.apache.camel.resume
-
This provides an interface for resumable objects.
- resume() - Method in interface org.apache.camel.CamelContextLifecycle
-
Resumes the CamelContext.
- resume() - Method in interface org.apache.camel.resume.ResumeAdapter
-
Execute the resume logic for the adapter
- resume() - Method in class org.apache.camel.support.service.BaseService
-
Important: You should override the lifecycle methods that start with do, eg
BaseService.doStart()
,BaseService.doStop()
, etc. where you implement your logic. - resume() - Method in interface org.apache.camel.SuspendableService
-
Resumes the service.
- RESUME - Enum constant in enum class org.apache.camel.spi.RouteError.Phase
- RESUME_ADAPTER_FACTORY - Static variable in interface org.apache.camel.resume.ResumeAdapter
- ResumeAction - Interface in org.apache.camel.resume
-
Provides and interface for integrations to run actions during resume
- ResumeActionAware - Interface in org.apache.camel.resume
-
Provides an interface for adapters and other resume-related code to allow them to offer a way to set actions to be executed during the resume process.
- ResumeAdapter - Interface in org.apache.camel.resume
-
A resume adapter provides the component-specific logic that plugs the more generic strategic with the lower level requirements of the component being used.
- resumeAll() - Method in interface org.apache.camel.spi.BacklogDebugger
-
To resume all suspended breakpoints.
- ResumeAware<T> - Interface in org.apache.camel.resume
-
An interface to represent an object which wishes to support resume operations using a
ResumeStrategy
. - resumeBreakpoint(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Resume the breakpoint
- resumeBreakpoint(String, boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Resume the breakpoint in step mode
- ResumeCache<K> - Interface in org.apache.camel.resume.cache
-
This cache stored the resumed data from a
ResumeStrategy
. - resumeRoute(String) - Method in interface org.apache.camel.spi.RouteController
-
Resumes the given route if it has been previously suspended
- resumeService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Resumes the given
service
. - resumeServices(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Resumes each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - ResumeStrategy - Interface in org.apache.camel.resume
-
Defines a strategy for handling resume operations.
- ResumeStrategy.UpdateCallBack - Interface in org.apache.camel.resume
-
A callback that can be executed after the last offset is updated
- ResumeStrategyConfiguration - Class in org.apache.camel.resume
-
Basic configuration holder for resume strategies
- ResumeStrategyConfiguration() - Constructor for class org.apache.camel.resume.ResumeStrategyConfiguration
- ResumeStrategyConfigurationBuilder<T,
Y> - Interface in org.apache.camel.resume -
Provides a basic interface for implementing component-specific configuration builder
- resumeStrategyService() - Method in class org.apache.camel.resume.ResumeStrategyConfiguration
-
Allows the implementation to provide custom strategy service factories.
- retrieveGlobalSslContextParameters() - Method in interface org.apache.camel.SSLContextParametersAware
-
Returns the global
SSLContextParameters
if enabled on the implementing object, null otherwise. - REUSE_SCRIPT_ENGINE - Static variable in interface org.apache.camel.Exchange
- revision() - Element in annotation interface org.apache.camel.Experimental
- rollback(Consumer, Endpoint, int, Exception) - Method in interface org.apache.camel.spi.PollingConsumerPollStrategy
-
Called when poll failed
- ROLLBACK_ONLY - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- ROLLBACK_ONLY_LAST - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- RollbackExchangeException - Exception Class in org.apache.camel
-
Exception used for forcing an Exchange to be rolled back.
- RollbackExchangeException(String, Exchange) - Constructor for exception class org.apache.camel.RollbackExchangeException
- RollbackExchangeException(String, Exchange, Throwable) - Constructor for exception class org.apache.camel.RollbackExchangeException
- RollbackExchangeException(Exchange) - Constructor for exception class org.apache.camel.RollbackExchangeException
- RollbackExchangeException(Exchange, Throwable) - Constructor for exception class org.apache.camel.RollbackExchangeException
- ROOT_TAG - Static variable in interface org.apache.camel.spi.BacklogTracerEventMessage
- Route - Interface in org.apache.camel
-
A Route defines the processing used on an inbound message exchange from a specific
Endpoint
within aCamelContext
. - ROUTE_STOP - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- ROUTE_VARIABLE_REPOSITORY_ID - Static variable in interface org.apache.camel.spi.VariableRepositoryFactory
-
Registry bean id for route
VariableRepository
. - RouteAdded - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RouteAware - Interface in org.apache.camel
- RouteConfigurationsBuilder - Interface in org.apache.camel
-
A route configurations builder is capable of building route configurations using the builder and model classes.
- RouteController - Interface in org.apache.camel.spi
-
Controller for managing the lifecycle of all the
Route
's. - RouteError - Interface in org.apache.camel.spi
-
The last error that happened during changing the route lifecycle, i.e. such as when an exception was thrown during starting the route.
- RouteError.Phase - Enum Class in org.apache.camel.spi
- RouteFactory - Interface in org.apache.camel.spi
-
A factory to create
Route
- RouteIdAware - Interface in org.apache.camel.spi
-
To allow objects to be injected with the route id
- routeIds() - Method in interface org.apache.camel.spi.RouteTemplateParameterSource
-
Gets the route id's as a set.
- RoutePolicy - Interface in org.apache.camel.spi
-
Policy for a
Route
which allows controlling the route at runtime. - RoutePolicyFactory - Interface in org.apache.camel.spi
-
A factory to create
RoutePolicy
and assign to routes automatic. - RouteReloaded - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RouteRemoved - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RoutesBuilder - Interface in org.apache.camel
-
A routes builder is capable of building routes using the builder and model classes.
- RoutesBuilderLoader - Interface in org.apache.camel.spi
-
SPI for loading
RoutesBuilder
from aResource
. - RoutesLoader - Interface in org.apache.camel.spi
-
SPI for loading
RoutesBuilder
from a list ofResource
. - RoutesLoader - Annotation Interface in org.apache.camel.spi.annotations
- RoutesOnly - Enum constant in enum class org.apache.camel.ManagementMBeansLevel
- RoutesOnly - Enum constant in enum class org.apache.camel.ManagementStatisticsLevel
- RoutesStarted - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RoutesStarting - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RoutesStopped - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RoutesStopping - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- routeStackLevel() - Method in interface org.apache.camel.spi.UnitOfWork
-
Gets the
Route
level-of-depth that thisUnitOfWork
currently is being routed through. - routeStackLevel(boolean, boolean) - Method in interface org.apache.camel.spi.UnitOfWork
-
Gets the
Route
level-of-depth that thisUnitOfWork
currently is being routed through. - RouteStarted - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RouteStarting - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RouteStartupOrder - Interface in org.apache.camel.spi
-
Information about a route to be started where we want to control the order in which they are started by
CamelContext
. - RouteStopped - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RouteStopping - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- RouteTemplateContext - Interface in org.apache.camel
-
The context used during creating a
Route
from a route template. - RouteTemplateContext.BeanSupplier<T> - Interface in org.apache.camel
-
Used for template beans to supply the local bean the route template should use when creating route(s).
- RouteTemplateLoaderListener - Interface in org.apache.camel.spi
-
Listener when route templates is loaded from a
Resource
. - RouteTemplateParameterSource - Interface in org.apache.camel.spi
-
Source for parameters used when creating routes from route templates.
- RoutingSlip - Annotation Interface in org.apache.camel
-
Indicates that this method is to be used as a Routing Slip routing the incoming message through a series of processing steps.
- RPC - Enum constant in enum class org.apache.camel.Category
- run() - Method in interface org.apache.camel.AsyncCallback
-
Optimized for the reactive executor engine to be able to schedule this callback in its engine.
- RuntimeCamelCatalog - Interface in org.apache.camel.catalog
-
Runtime catalog which limited API needed by components that supports
ComponentVerifierExtension
. - RuntimeCamelException - Exception Class in org.apache.camel
-
Base class for all Camel unchecked exceptions.
- RuntimeCamelException() - Constructor for exception class org.apache.camel.RuntimeCamelException
- RuntimeCamelException(String) - Constructor for exception class org.apache.camel.RuntimeCamelException
- RuntimeCamelException(String, Throwable) - Constructor for exception class org.apache.camel.RuntimeCamelException
- RuntimeCamelException(Throwable) - Constructor for exception class org.apache.camel.RuntimeCamelException
- RuntimeConfiguration - Interface in org.apache.camel
-
Various runtime configuration options used by
CamelContext
andRoute
for cross cutting functions such as tracing, delayer, stream cache and the like. - RuntimeEndpointRegistry - Interface in org.apache.camel.spi
-
A registry which listen for runtime usage of
Endpoint
during routing in Camel. - RuntimeEndpointRegistry.Statistic - Interface in org.apache.camel.spi
-
Statistics gathered about the endpoint.
- RuntimeExchangeException - Exception Class in org.apache.camel
-
A runtime exception caused by a specific message
Exchange
- RuntimeExchangeException(String, Exchange) - Constructor for exception class org.apache.camel.RuntimeExchangeException
- RuntimeExchangeException(String, Exchange, Throwable) - Constructor for exception class org.apache.camel.RuntimeExchangeException
- RuntimeExpressionException - Exception Class in org.apache.camel
-
Thrown if an expression evaluation fails
- RuntimeExpressionException(String) - Constructor for exception class org.apache.camel.RuntimeExpressionException
- RuntimeExpressionException(String, Throwable) - Constructor for exception class org.apache.camel.RuntimeExpressionException
- RuntimeExpressionException(Throwable) - Constructor for exception class org.apache.camel.RuntimeExpressionException
- RuntimeTransformException - Exception Class in org.apache.camel
-
Thrown if a message transformation fails
- RuntimeTransformException(String) - Constructor for exception class org.apache.camel.RuntimeTransformException
- RuntimeTransformException(String, Throwable) - Constructor for exception class org.apache.camel.RuntimeTransformException
- RuntimeTransformException(Throwable) - Constructor for exception class org.apache.camel.RuntimeTransformException
S
- SAAS - Enum constant in enum class org.apache.camel.Category
- safeCopy() - Method in interface org.apache.camel.SafeCopyProperty
-
Implementations should implement this method to return a deep copy of the object which can be mutated independently of the original object.
- SafeCopyProperty - Interface in org.apache.camel
-
An interface that allows safe copy (deep clone) of property value object when creating copy of Exchange objects.
- SAGA_LONG_RUNNING_ACTION - Static variable in interface org.apache.camel.Exchange
- SAXPARSER_FACTORY - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- scan(CamelContext) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Scans the repository for
Exchange
s to be recovered - scanTypeConverters() - Method in interface org.apache.camel.spi.AnnotationScanTypeConverters
-
Scan for
Converter
classes and add those as type converters. - schedule(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to be run (fairly)
- ScheduledPollConsumerScheduler - Interface in org.apache.camel.spi
-
A pluggable scheduler for
invalid reference
org.apache.camel.support.ScheduledPollConsumer
- scheduledTask(Runnable) - Method in interface org.apache.camel.spi.PeriodTaskScheduler
-
Schedules the task once so the task keeps running always.
- scheduleMain(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to be prioritized and run asap
- schedulePeriodTask(Runnable, long) - Method in interface org.apache.camel.spi.PeriodTaskScheduler
-
Schedules the period task.
- scheduleQueue(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to be run later from the queue (current thread) This is used for routing
Exchange
using transactions. - SCHEDULER_POLLED_MESSAGES - Static variable in interface org.apache.camel.Exchange
- scheduleSync(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to run synchronously (current thread)
- scheduleTask(Runnable) - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Schedules the task to run.
- SCHEDULING - Enum constant in enum class org.apache.camel.Category
- scheme() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
Represents the URI scheme name of this endpoint.
- SCRIPT - Enum constant in enum class org.apache.camel.Category
- ScriptingLanguage - Interface in org.apache.camel.spi
-
Represents a
Language
which is a general purpose scripting languages such as groovy, joor and others. - SEARCH - Enum constant in enum class org.apache.camel.Category
- secret() - Element in annotation interface org.apache.camel.spi.Metadata
-
Whether the option is secret/sensitive information such as a password.
- secret() - Element in annotation interface org.apache.camel.spi.UriParam
-
Whether the option is secret/sensitive information such as a password.
- secret() - Element in annotation interface org.apache.camel.spi.UriPath
-
Whether the option is secret/sensitive information such as a password.
- secretPropertyNames() - Method in interface org.apache.camel.spi.EndpointUriFactory
-
Returns the names of the secret properties this endpoint supports.
- SecureRandomParameters - Class in org.apache.camel.support.jsse
- SecureRandomParameters() - Constructor for class org.apache.camel.support.jsse.SecureRandomParameters
- SecureSocketProtocolsParameters - Class in org.apache.camel.support.jsse
-
Represents a list of TLS/SSL cipher suite names.
- SecureSocketProtocolsParameters() - Constructor for class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
- SECURITY - Enum constant in enum class org.apache.camel.Category
- select(Collection<ServiceRegistry>) - Method in interface org.apache.camel.cloud.ServiceRegistry.Selector
-
Deprecated.Select a specific ServiceRegistry instance among a collection.
- select(Collection<CamelClusterService>) - Method in interface org.apache.camel.cluster.CamelClusterService.Selector
-
Select a specific CamelClusterService instance among a collection.
- send() - Method in interface org.apache.camel.FluentProducerTemplate
-
Send to an endpoint (InOnly)
- send(String, Exchange) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the exchange to the given endpoint
- send(String, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
- send(String, 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, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
- send(Endpoint, ExchangePattern, Processor, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
- send(Endpoint, Exchange, Processor) - Method in interface org.apache.camel.spi.ProducerCache
-
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(Exchange) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the exchange to the default endpoint
Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange usingExchange.getException()
. - send(Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to the default endpoint using a supplied processor
Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange usingExchange.getException()
. - sendBody(Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint
- sendBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint
- sendBody(String, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body
- sendBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint
- sendBody(Endpoint, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
- sendBodyAndHeader(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint with a specified header and header value
- sendBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
- sendBodyAndHeader(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
- sendBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
- sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
- sendBodyAndHeaders(Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint with the specified headers and header values
- sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
- sendBodyAndHeaders(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
- 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
- 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
- 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
- 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
- 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
- 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
- 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
- SendDynamic - Annotation Interface in org.apache.camel.spi.annotations
- SendDynamicAware - Interface in org.apache.camel.spi
- SendDynamicAware.DynamicAwareEntry - Class in org.apache.camel.spi
-
An entry of detailed information from the recipient uri, which allows the
SendDynamicAware
implementation to prepare pre- and post- processor and the static uri to be used for the optimised dynamic to. - separator() - Element in annotation interface org.apache.camel.PropertyInject
-
Used for splitting the property value into an array/list of values.
- Serializable - Interface in org.apache.camel.resume
-
An interface that represents resumable objects that can be serialized to a medium
- serialize() - Method in interface org.apache.camel.resume.Offset
- serialize() - Method in interface org.apache.camel.resume.OffsetKey
- serialize() - Method in interface org.apache.camel.resume.Serializable
-
Serializes this offset into a buffer of bytes
- serialize(Object) - Method in interface org.apache.camel.resume.Serializable
-
Serializes this offset into a buffer of bytes
- SERVERLESS - Enum constant in enum class org.apache.camel.Category
- Service - Interface in org.apache.camel
-
Represents the core lifecycle API for services which can be initialized, started and stopped
- SERVICE_CALL_CONTEXT_PATH - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
Deprecated.
- SERVICE_CALL_SCHEME - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
Deprecated.
- SERVICE_CALL_URI - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
Deprecated.
- SERVICE_HOST - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
Deprecated.
- SERVICE_META - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
Deprecated.
- SERVICE_META_HOST - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.
- SERVICE_META_ID - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.
- SERVICE_META_NAME - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.
- SERVICE_META_PATH - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.
- SERVICE_META_PORT - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.
- SERVICE_META_PREFIX - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.
- SERVICE_META_PROTOCOL - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.
- SERVICE_META_ZONE - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
Deprecated.
- SERVICE_NAME - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
Deprecated.
- SERVICE_PORT - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
Deprecated.
- ServiceCallConstants - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceChooser - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceChooserAware - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceChooserFactory - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceDefinition - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceDiscovery - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceDiscoveryAware - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceDiscoveryFactory - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceExpressionFactory - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceFactory<T> - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceFactory - Annotation Interface in org.apache.camel.spi.annotations
- ServiceFilter - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceFilterAware - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceFilterFactory - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceHealth - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceHelper - Class in org.apache.camel.support.service
-
A collection of helper methods for working with
Service
objects. - ServiceLoadBalancer - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceLoadBalancerFactory - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceLoadBalancerFunction<T> - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceRegistry - Interface in org.apache.camel.cloud
-
Deprecated.
- ServiceRegistry.Selector - Interface in org.apache.camel.cloud
-
Deprecated.A selector used to pick up a service among a list.
- ServiceStartupFailure - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ServiceStatus - Enum Class in org.apache.camel
-
Represents the status of a
Service
instance - ServiceStopFailure - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- ServiceSupport - Class in org.apache.camel.support.service
-
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.support.service.ServiceSupport
- setAcceptableSchemes(String) - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
To specify a set of accepted schemas to use for loading resources as URL connections (besides http and https schemas)
- setAcceptableSchemes(String) - Method in interface org.apache.camel.spi.PackageScanResourceResolver
-
To specify a set of accepted schemas to use for loading resources as URL connections (besides http and https schemas)
- setAcceptDebugger(boolean) - Method in interface org.apache.camel.MessageHistory
-
Used specially during debugging where some EIP nodes are not accepted for debugging and are essentially skipped.
- setAccepted(boolean) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- setAccessKey(String) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
The AWS access key
- setAdapter(ResumeAdapter) - Method in interface org.apache.camel.resume.ResumeStrategy
-
Sets an adapter for resuming operations with this strategy
- setAfter(Processor) - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
-
Sets the processor (optional) for routing after sending to the original endpoint.
- setAlgorithm(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
The algorithm name for the
KeyManagerFactory
used to create theKeyManager
s represented by this object's configuration. - setAlgorithm(String) - Method in class org.apache.camel.support.jsse.SecureRandomParameters
-
Sets the Random Number Generator (RNG) algorithm identifier for the
SecureRandom
factory method used to create theSecureRandom
represented by this object's configuration. - setAlgorithm(String) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
Sets optional algorithm name for the
TrustManagerFactory
used to create theTrustManager
s represented by this object's configuration. - setAllowClasses(Class<?>...) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
To filter stream caching of a given set of allowed/denied classes.
- setAllowClasses(String) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
To filter stream caching of a given set of allowed/denied classes.
- setAllowCoreThreadTimeOut(Boolean) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets whether to allow core threads to timeout
- setAllowUseOriginalMessage(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether to allow access to the original message from Camel's error handler, or from
UnitOfWork.getOriginalInMessage()
. - setAnySpoolRules(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets whether if just any of the
StreamCachingStrategy.SpoolRule
rules returns true thenStreamCachingStrategy.shouldSpoolCache(long)
returns true. - setApiComponent(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the name of the Camel component to use as the REST API (such as swagger or openapi)
- setApiContextPath(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets a leading API context-path the REST API services will be using.
- setApiContextRouteId(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the route id to use for the route that services the REST API.
- setApiHost(String) - Method in class org.apache.camel.spi.RestConfiguration
-
To use a specific hostname for the API documentation (such as swagger or openapi)
- setApiProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets additional options on api level
- setApiVendorExtension(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
Whether vendor extension is enabled in the Rest APIs.
- setApplicationContextClassLoader(ClassLoader) - Method in interface org.apache.camel.CamelContext
-
Sets the application CamelContext class loader
- setAutoRelease(boolean) - Method in interface org.apache.camel.PooledExchange
-
Whether this exchange was created to auto release when its unit of work is done
- setAutoStartup(Boolean) - Method in interface org.apache.camel.Route
-
Sets whether the route should automatically start when Camel starts.
- setAutoStartup(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether the object should automatically start when Camel starts.
- setAutowiredEnabled(boolean) - Method in interface org.apache.camel.GlobalEndpointConfiguration
-
Whether autowiring is enabled.
- setAutowiredEnabled(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Whether autowiring is enabled.
- setAwsVaultConfiguration(AwsVaultConfiguration) - Method in class org.apache.camel.vault.VaultConfiguration
- setAzureIdentityEnabled(boolean) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
Whether the Azure Identity Authentication should be used or not.
- setAzureVaultConfiguration(AzureVaultConfiguration) - Method in class org.apache.camel.vault.VaultConfiguration
- setBacklogSize(int) - Method in interface org.apache.camel.spi.BacklogTracer
-
Number of messages to keep in the backlog (should be between 1 - 1000).
- setBacklogTracing(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether backlog tracing is enabled or not (default is disabled).
- setBacklogTracingStandby(boolean) - Method in interface org.apache.camel.CamelContext
-
Whether to set backlog tracing on standby.
- setBacklogTracingTemplates(boolean) - Method in interface org.apache.camel.CamelContext
-
Whether backlog tracing should trace inner details from route templates (or kamelets).
- setBackOffDelay(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Backoff delay in millis when restarting a route that failed to startup.
- setBackOffMaxAttempts(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Backoff maximum number of attempts to restart a route that failed to startup.
- setBackOffMaxDelay(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Backoff maximum delay in millis when restarting a route that failed to startup.
- setBackOffMaxElapsedTime(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Backoff maximum elapsed time in millis, after which the backoff should be considered exhausted and no more attempts should be made.
- setBackOffMultiplier(double) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Backoff multiplier to use for exponential backoff.
- setBasePackageScan(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Package name to use as base (offset) for classpath scanning of RouteBuilder,
TypeConverter
,CamelConfiguration
classes, and also classes annotated withConverter
, orBindToRegistry
. - setBefore(Processor) - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
-
Sets the processor for routing in a detour before sending to the original endpoint.
- setBindingMode(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the binding mode to be used by the REST consumer
- setBindingMode(RestConfiguration.RestBindingMode) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the binding mode to be used by the REST consumer
- setBindingPackageScan(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Package name to use as base (offset) for classpath scanning of POJO classes are located when using binding mode is enabled for JSon or XML.
- setBlobAccessKey(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The Eventhubs Blob Access Key for CheckpointStore purpose
- setBlobAccountName(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The Eventhubs Blob Account Name for CheckpointStore purpose
- setBlobContainerName(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The Eventhubs Blob Container Name for CheckpointStore purpose
- 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(Object, DataType) - Method in interface org.apache.camel.spi.DataTypeAware
-
Set the message body with data type.
- setBodyIncludeFiles(boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether to include the message body of file based messages.
- setBodyIncludeFiles(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include message body from files
- setBodyIncludeStreams(boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether to include the message body of stream based messages.
- setBodyIncludeStreams(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include message body from streams
- setBodyMaxChars(int) - Method in interface org.apache.camel.spi.BacklogDebugger
-
To limit the message body to a maximum size in the traced message.
- setBodyMaxChars(int) - Method in interface org.apache.camel.spi.BacklogTracer
-
Maximum number of bytes to keep for the message body (to prevent storing very big payloads)
- setBootstrapFactoryFinder(FactoryFinder) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the bootstrap FactoryFinder which will be used for the loading the factory class from META-INF.
- setBridgeErrorHandler(boolean) - Method in interface org.apache.camel.GlobalEndpointConfiguration
-
Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler.
- setBufferSize(int) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets the buffer size to use when allocating in-memory buffers used for in-memory stream caches.
- setCache(ResumeCache<?>) - Method in interface org.apache.camel.resume.Cacheable
-
Sets the cache in resume adapters and objects that cache their data
- setCacheFillPolicy(Cacheable.FillPolicy) - Method in class org.apache.camel.resume.ResumeStrategyConfiguration
-
Sets the
Cacheable.FillPolicy
for the cache used in the strategy - setCamelContext(CamelContext) - Method in interface org.apache.camel.CamelContextAware
-
Injects the
CamelContext
- setCamelContext(CamelContext) - Method in interface org.apache.camel.Endpoint
-
Sets the camel context.
- setCamelContext(CamelContext) - Method in class org.apache.camel.spi.Transformer
- setCamelContext(CamelContext) - Method in class org.apache.camel.spi.Validator
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.jsse.JsseParameters
-
Sets the optional
CamelContext
used for integration with core capabilities such as Camel Property Placeholders andClassResolver
. - setCapacity(int) - Method in interface org.apache.camel.spi.PooledObjectFactory
-
The capacity the pool uses for storing objects.
- setCaseInsensitiveHeaders(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Whether to use case sensitive or insensitive headers.
- setCertAlias(String) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
An optional certificate alias to use.
- setCipherSuite(List<String>) - Method in class org.apache.camel.support.jsse.CipherSuitesParameters
-
Sets the cipher suite.
- setCipherSuites(CipherSuitesParameters) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Sets the optional explicitly configured cipher suites for this configuration.
- setCipherSuitesFilter(FilterParameters) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Sets the optional cipher suite filter for this JSSE configuration.
- setClassLoader(ClassLoader) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
-
Sets an extra class loader to use first for loading resources.
- setClassResolver(ClassResolver) - Method in interface org.apache.camel.CamelContext
-
Sets the class resolver to be use
- setClientAuthentication(String) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
-
Sets the configuration options for server-side client-authentication requirements.
- setClientId(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The client Id for accessing Azure Key Vault
- setClientParameters(SSLContextClientParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
The optional configuration options to be applied purely to the client side settings of the
SSLContext
. - setClientRequestValidation(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
Whether to enable validation of the client request to check: 1) Content-Type header matches what the Rest DSL consumes; returns HTTP Status 415 if validation error. 2) Accept header matches what the Rest DSL produces; returns HTTP Status 406 if validation error. 3) Missing required data (query parameters, HTTP headers, body); returns HTTP Status 400 if validation error. 4) Parsing error of the message body (JSon, XML or Auto binding mode must be enabled); returns HTTP Status 400 if validation error.
- setClientSecret(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The client Secret for accessing Azure Key Vault
- setComponent(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the name of the Camel component to use as the REST consumer
- setComponent(Component) - Method in interface org.apache.camel.ComponentAware
-
Injects the
Component
- setComponentProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets additional options on component level
- setConfigurer(Consumer<RouteTemplateContext>) - Method in interface org.apache.camel.RouteTemplateContext
-
Sets a custom configurer which allows to do configuration while the route template is being used to create a route.
- setConsumerListener(ConsumerListener<?, ?>) - Method in interface org.apache.camel.Route
-
Sets the consumer listener for the route
- setConsumerListener(T) - Method in interface org.apache.camel.resume.ConsumerListenerAware
-
Injects the
ConsumerListener
instance into the object - setConsumerProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets additional options on consumer level
- setContentType(String) - Method in interface org.apache.camel.spi.ContentTypeAware
-
Sets the content type.
- setContentTypeHeader(boolean) - Method in interface org.apache.camel.spi.DataFormatContentTypeHeader
-
Whether the data format should set the Content-Type header with the type from the data format if the data format is capable of doing so.
- setContextPath(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets a leading context-path the REST services will be using.
- setCopyMessage(boolean) - Method in interface org.apache.camel.spi.MessageHistoryFactory
-
Sets whether to make a copy of the message in the
MessageHistory
. - setCorsHeaders(Map<String, String>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the CORS headers to use if CORS has been enabled.
- setCounter(Object) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
- setDataFormatProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets additional options on data format level
- setDataType(DataType) - Method in interface org.apache.camel.spi.DataTypeAware
-
Set the data type of the message.
- setDeadLetterUri(String) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets an optional dead letter channel which exhausted recovered
Exchange
should be send to. - setDebugger(Debugger) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
Debugger
- setDebugging(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether debugging (will use backlog if no custom debugger has been configured) is enabled or not (default is disabled).
- setDebugStandby(boolean) - Method in interface org.apache.camel.CamelContext
-
Whether to set backlog debugger on standby.
- setDefaultConsumerCallback(AsyncCallback) - Method in interface org.apache.camel.ExchangeExtension
-
Callback used by
Consumer
if the consumer is completing the exchange processing with default behaviour. - setDefaultCredentialsProvider(boolean) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
Define if we want to use the AWS Default Credentials Provider or not
- setDefaultEndpoint(Endpoint) - Method in interface org.apache.camel.FluentProducerTemplate
-
Sets the default endpoint to use if none is specified
- setDefaultEndpoint(Endpoint) - Method in interface org.apache.camel.ProducerTemplate
-
Sets the default endpoint to use if none is specified
- setDefaultEndpointUri(String) - Method in interface org.apache.camel.FluentProducerTemplate
-
Sets the default endpoint uri to use if none is specified
- setDefaultEndpointUri(String) - Method in interface org.apache.camel.ProducerTemplate
-
Sets the default endpoint uri to use if none is specified
- setDefaultFactoryFinder(FactoryFinder) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the default FactoryFinder which will be used for the loading the factory class from META-INF
- setDefaultProfile(Boolean) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets whether this profile is the default profile (there can only be one).
- setDefaultThreadPoolProfile(ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Sets the default thread pool profile
- 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, slowing the process down to better observe what is occurring
- setDenyClasses(Class<?>...) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
To filter stream caching of a given set of allowed/denied classes.
- setDenyClasses(String) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
To filter stream caching of a given set of allowed/denied classes.
- setDescription(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the description of this Camel application.
- setDevConsole(Boolean) - Method in interface org.apache.camel.CamelContext
-
Whether to enable developer console (requires camel-console on classpath) The developer console is only for assisting during development.
- setDisabled(boolean) - Method in interface org.apache.camel.cluster.CamelPreemptiveClusterView
-
Enable or disables a view.
- setDumpRoutes(String) - Method in interface org.apache.camel.CamelContext
-
If dumping is enabled then Camel will during startup dump all loaded routes (incl rests and route templates) represented as XML/YAML DSL into the log.
- setEnableCORS(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
To specify whether to enable CORS which means Camel will automatic include CORS in the HTTP headers in the response.
- setEnabled(boolean) - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Whether dev console is enabled globally
- setEnabled(boolean) - Method in interface org.apache.camel.health.HealthCheck
-
Used for enabling or disabling this health check
- setEnabled(boolean) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Whether Health Check is enabled globally
- setEnabled(boolean) - Method in interface org.apache.camel.health.HealthCheckRepository
-
Set if the checks associated to this repository is enabled or not.
- setEnabled(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
To turn on or off the tracer
- setEnabled(boolean) - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
-
Can be used to turn off bean post processing.
- setEnabled(boolean) - Method in interface org.apache.camel.spi.CliConnectorFactory
-
To enable CLI connector.
- setEnabled(boolean) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Sets whether gathering runtime usage is enabled or not.
- setEnabled(boolean) - Method in interface org.apache.camel.spi.StartupStepRecorder
-
Whether recording is enabled
- setEnabled(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets whether the stream caching is enabled.
- setEnabled(boolean) - Method in interface org.apache.camel.spi.Tracer
-
Whether the tracer is enabled
- setEnableNoContentResponse(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
Whether to return HTTP 204 with an empty body when a response contains an empty JSON object or XML root object.
- setEncoding(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Encoding to use when loading properties file from the file system or classpath.
- setEndpointProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets additional options on endpoint level
- setEndpointRuntimeStatisticsEnabled(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets whether endpoint runtime statistics is enabled (gathers runtime usage of each incoming and outgoing endpoints).
- setEndpointServiceRegistry(EndpointServiceRegistry) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets a custom
EndpointServiceRegistry
to be used. - setError(String) - Method in class org.apache.camel.catalog.LanguageValidationResult
- setErrorHandler(Processor) - Method in interface org.apache.camel.Channel
-
Sets the
ErrorHandler
this Channel uses. - setErrorHandler(Processor) - Method in interface org.apache.camel.spi.ErrorHandlerAware
-
Sets the error handler
- setErrorHandlerFactory(ErrorHandlerFactory) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the default error handler builder which is inherited by the routes
- setErrorHandlerFactory(ErrorHandlerFactory) - Method in interface org.apache.camel.Route
- setErrorHandlerHandled(Boolean) - Method in interface org.apache.camel.ExchangeExtension
-
Used to signal that this exchange has been handled by the error handler.
- setEventFactory(EventFactory) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the event factory to use
- setEventhubConnectionString(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The Eventhubs connection String for Key Vault Secret events notifications
- setEventNotificationApplicable(boolean) - Method in interface org.apache.camel.ExtendedCamelContext
-
Used as internal optimization in Camel to flag whether exchange event notification is applicable or not.
- setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.FluentProducerTemplate
-
Sets whether the
EventNotifier
should be used by thisProducerTemplate
to send events about theExchange
being sent. - setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.ProducerTemplate
-
Sets whether the
EventNotifier
should be used by thisProducerTemplate
to send events about theExchange
being sent. - setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.spi.ProducerCache
-
Sets whether
EventNotifier
is enabled - setException(Throwable) - Method in interface org.apache.camel.Exchange
-
Sets the exception associated with this exchange
- setException(Throwable) - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
The tracing caused an exception which can be captured
- setExchangeFactory(ExchangeFactory) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets a custom exchange factory to use.
- setExchangeFactoryManager(ExchangeFactoryManager) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets a custom exchange factory manager to use.
- setExchangeFormatter(ExchangeFormatter) - Method in interface org.apache.camel.spi.Tracer
-
To use a custom exchange formatter for formatting the output of the
Exchange
in the trace logs. - setExchangeId(String) - Method in interface org.apache.camel.Exchange
-
Set the exchange id
- setExchangePropertyOnBreakpoint(String, String, Object) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Sets the exchange property at the given breakpoint
- setExchangePropertyOnBreakpoint(String, String, Object, Class<?>) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Updates the exchange property at the given breakpoint
- setExchangeVariableOnBreakpoint(String, String, Object) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Updates/adds the variable (uses same type as old variableName value) on the suspended breakpoint at the given node id
- setExchangeVariableOnBreakpoint(String, String, Object, Class<?>) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Updates/adds the variable (with a new type) on the suspended breakpoint at the given node id
- setExcludePattern(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Pattern to exclude health checks from being invoked by Camel when checking healths.
- setExcludeRoutes(String) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Pattern for filtering routes to be excluded as supervised.
- setExecutorService(ExecutorService) - Method in interface org.apache.camel.ProducerTemplate
-
Sets a custom executor service to use for async messaging.
- setExecutorServiceManager(ExecutorServiceManager) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
ExecutorServiceManager
- setExposureLevel(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Sets the level of details to exposure as result of invoking health checks.
- setExtendedStatistics(boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Whether to gather extended statistics for introspection usage.
- setFailureHandled(boolean) - Method in interface org.apache.camel.ExchangeExtension
-
Sets whether the exchange has been failure handled
- setFallbackTimeout(long) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Fallback Timeout in seconds (300 seconds as default) when block the message processing in Camel.
- setFileName(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- setFrom(String) - Method in class org.apache.camel.spi.Transformer
-
Set 'from' data type.
- setFromEndpoint(Endpoint) - Method in interface org.apache.camel.ExchangeExtension
-
Sets the endpoint which originated this message exchange.
- setFromRouteId(String) - Method in interface org.apache.camel.ExchangeExtension
-
Sets the route id which originated this message exchange.
- setGcpVaultConfiguration(GcpVaultConfiguration) - Method in class org.apache.camel.vault.VaultConfiguration
- setGeneratedId(String) - Method in interface org.apache.camel.spi.IdAware
-
Sets the id which has been auto generated
- setGeneratedIds(boolean) - Method in interface org.apache.camel.spi.DumpRoutesStrategy
-
Whether to include auto generated IDs in the dumped output.
- setGlobalOptions(Map<String, String>) - Method in interface org.apache.camel.CamelContext
-
Sets global options that can be referenced in the camel context
- setGroup(String) - Method in interface org.apache.camel.spi.GroupAware
-
Sets the group
- setHashicorpVaultConfiguration(HashicorpVaultConfiguration) - Method in class org.apache.camel.vault.VaultConfiguration
- setHeader(String, Object) - Method in interface org.apache.camel.Message
-
Sets a header on the message
- setHeaderFilterStrategy(HeaderFilterStrategy) - Method in interface org.apache.camel.spi.HeaderFilterStrategyAware
-
Sets the header filter strategy to use
- setHeaders(Map<String, Object>) - Method in interface org.apache.camel.Message
-
Set all the headers associated with this message
- setHeadersMapFactory(HeadersMapFactory) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets a custom
HeadersMapFactory
to be used. - setHealthCheck(HealthCheck) - Method in interface org.apache.camel.health.HealthCheckAware
-
Injects the
HealthCheck
- setHistoryNodeId(String) - Method in interface org.apache.camel.ExchangeExtension
-
Sets the history node id (the current processor that will process the exchange)
- setHistoryNodeLabel(String) - Method in interface org.apache.camel.ExchangeExtension
-
Sets the history node label (the current processor that will process the exchange)
- setHistoryNodeSource(String) - Method in interface org.apache.camel.ExchangeExtension
-
Sets the history node source:line-number where the node is located in the source code (the current processor that will process the exchange).
- setHost(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the hostname to use by the REST consumer
- setHost(String) - Method in class org.apache.camel.vault.HashicorpVaultConfiguration
-
Host to access hashicorp vault
- setHostNameResolver(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the resolver to use for resolving hostname
- setHostNameResolver(RestConfiguration.RestHostNameResolver) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the resolver to use for resolving hostname
- setHttpResponseCode(int) - Method in interface org.apache.camel.spi.HttpResponseAware
-
Sets the HTTP status code
- setHttpResponseStatus(String) - Method in interface org.apache.camel.spi.HttpResponseAware
-
Sets the HTTP status line
- setId(String) - Method in interface org.apache.camel.spi.IdAware
-
Sets the id
- setId(String) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the id of this profile
- setIgnoreCamelContextEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreCamelContextInitEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreExchangeAsyncProcessingStartedEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreExchangeCompletedEvent(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreExchangeCreatedEvent(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreExchangeEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreExchangeFailedEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreExchangeRedeliveryEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreExchangeSendingEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreExchangeSentEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreLoadingError(boolean) - Method in interface org.apache.camel.spi.RoutesLoader
-
Whether to ignore route loading and compilation errors (use this with care!)
- setIgnoreMissingLocation(boolean) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Whether to silently ignore if a location cannot be located, such as a properties file not found.
- setIgnoreMissingProperty(boolean) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Whether to silently ignore if a property cannot be resolved (i.e. all properties is marked as optional), and return the value as-is.
- setIgnoreRouteEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreServiceEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIgnoreStepEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
- setIn(Message) - Method in interface org.apache.camel.Exchange
-
Sets the inbound message instance
- setInclude(String) - Method in interface org.apache.camel.spi.DumpRoutesStrategy
-
Controls what to include in output.
- setIncludeException(boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Trace messages to include exception if the message failed
- setIncludeException(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include exception if the message failed
- setIncludeExchangeProperties(boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether to include the exchange properties in the traced message
- setIncludeExchangeProperties(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include exchange properties
- setIncludeExchangeVariables(boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether to include the exchange variables in the traced message
- setIncludeExchangeVariables(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Trace messages to include exchange variables
- setIncludeHostName(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets whether to include host name in the
ManagementObjectNameStrategy
. - setIncludeRoutes(String) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Pattern for filtering routes to be included as supervised.
- setIndex(int) - Method in class org.apache.camel.catalog.LanguageValidationResult
- setInflightBrowseEnabled(boolean) - Method in interface org.apache.camel.spi.InflightRepository
-
Whether the inflight repository should allow browsing each inflight exchange.
- setInflightRepository(InflightRepository) - Method in interface org.apache.camel.CamelContext
-
Sets a custom inflight repository to use
- setInitialBreakpoints(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Allows to pre-configure breakpoints (node ids) to use with debugger on startup.
- setInitialDelay(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Initial delay in milli seconds before the route controller starts, after CamelContext has been started.
- setInitialProperties(Properties) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Sets initial properties which will be added before any property locations are loaded.
- setInitialState(HealthCheck.State) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
The initial state of health-checks (readiness).
- setInjector(Injector) - Method in interface org.apache.camel.CamelContext
-
Sets the injector to use
- setInjector(Injector) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Sets the injector to be used for creating new instances during type conversions.
- setInlineRoutes(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
Inline routes in rest-dsl which are linked using direct endpoints.
- setInputType(Class<?>) - Method in class org.apache.camel.spi.Contract
-
Set the input data type with Java class.
- setInputType(String) - Method in class org.apache.camel.spi.Contract
-
Set the input data type.
- setInterruptable(boolean) - Method in interface org.apache.camel.ExchangeExtension
-
To control whether the exchange can accept being interrupted currently.
- setInterrupted(boolean) - Method in interface org.apache.camel.ExchangeExtension
-
Used to signal that this exchange was interrupted (InterruptException) during routing.
- setInterruptThreadsWhileStopping(boolean) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
Sets whether to interrupt any blocking threads during stopping.
- setJsonDataFormat(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets a custom json data format to be used
- setKeepAliveTime(Long) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the keep alive time for inactive threads
- setKeyManagers(KeyManagersParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
Sets the optional key manager configuration for creating the
KeyManager
s used in constructing anSSLContext
. - setKeyPassword(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
The password for recovering keys in the key store.
- setKeyStore(KeyStore) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
To use an existing KeyStore instead of loading.
- setKeyStore(KeyStoreParameters) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
The key store configuration used to create the
KeyStore
that theKeyManager
s produced by this object's configuration expose. - setKeyStore(KeyStoreParameters) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
Sets the key store configuration used to create the
KeyStoreParameters
that theTrustManager
s produced by this object's configuration expose. - setKubernetesVaultConfiguration(KubernetesVaultConfiguration) - Method in class org.apache.camel.vault.VaultConfiguration
- setLastError(RouteError) - Method in interface org.apache.camel.Route
-
Sets the last error that happened during changing the route lifecycle, i.e. such as when an exception was thrown during starting the route.
- setLazyStartProducer(boolean) - Method in interface org.apache.camel.GlobalEndpointConfiguration
-
Whether the producer should be started lazy (on the first message).
- setLevel(LoggingLevel) - Method in class org.apache.camel.spi.CamelLogger
- setLimit(int) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Sets the maximum number of endpoints to keep in the cache per route.
- setLineNumber(int) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- setLineNumber(int) - Method in interface org.apache.camel.LineNumberAware
-
Sets the line number of this entity. parsing the source file and provide the line number representing this node.
- setLoadHealthChecks(Boolean) - Method in interface org.apache.camel.CamelContext
-
Whether to load custom health checks by scanning classpath.
- setLoadStatisticsEnabled(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets whether load statistics is enabled (gathers load statistics using a background thread per CamelContext).
- setLoadTypeConverters(Boolean) - Method in interface org.apache.camel.CamelContext
-
Whether to load custom type converters by scanning classpath.
- setLocalBeanRepository(BeanRepository) - Method in interface org.apache.camel.spi.LocalBeanRepositoryAware
-
Sets a special local bean repository (ie thread local) that take precedence and will use first, if a bean exists.
- setLocalProperties(Properties) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Sets a special list of local properties (ie thread local) that take precedence and will use first, if a property exist.
- setLocation(String) - Method in interface org.apache.camel.LineNumberAware
-
Sets the location of the entity (source file name, i.e. foo.java, bar.xml, etc.)
- setLocation(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
A list of locations to load properties.
- setLog(boolean) - Method in interface org.apache.camel.spi.DumpRoutesStrategy
-
Whether to log route dumps to Logger
- setLog(Logger) - Method in class org.apache.camel.spi.CamelLogger
- setLogExhaustedMessageBody(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether to log exhausted message body with message history.
- setLoggingLevel(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
The debugger logging level to use when logging activity.
- setLoggingLevel(LoggingLevel) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Logging level used for logging introspection usage.
- setLoggingLevel(LoggingLevel) - Method in interface org.apache.camel.spi.RouteController
-
Sets the logging level used for logging route activity (such as starting and stopping routes).
- setLoggingLevel(LoggingLevel) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Sets the logging level used for logging shutdown activity (such as starting and stopping routes).
- setLogInflightExchangesOnTimeout(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Sets whether to log information about the inflight
Exchange
s which are still running during a shutdown which didn't complete without the given timeout. - setLogMask(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether security mask for Logging is enabled or not (default is disabled).
- setLogName(String) - Method in class org.apache.camel.spi.CamelLogger
- setManagementAgent(ManagementAgent) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the management agent to use
- setManagementInterceptStrategy(ManagementInterceptStrategy) - Method in interface org.apache.camel.Route
-
Sets a special intercept strategy for management.
- setManagementMBeanAssembler(ManagementMBeanAssembler) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the assembler to assemble a
RequiredModelMBean
- setManagementName(String) - Method in interface org.apache.camel.CamelContext
-
Sets the name this
CamelContext
will be registered in JMX. - setManagementNamePattern(String) - Method in interface org.apache.camel.spi.ManagementAgent
-
The naming pattern for creating the CamelContext management name.
- setManagementNameStrategy(ManagementNameStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom management name strategy
- setManagementObjectNameStrategy(ManagementObjectNameStrategy) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the naming strategy to use
- setManagementObjectStrategy(ManagementObjectStrategy) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the object strategy to use
- setManagementStrategy(ManagementStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets the management strategy to use
- setMarker(String) - Method in class org.apache.camel.spi.CamelLogger
- setMarker(Marker) - Method in class org.apache.camel.spi.CamelLogger
- setMask(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to remove detected sensitive information (such as passwords) from MBean names and attributes.
- setMaxDepth(int) - Method in interface org.apache.camel.spi.StartupStepRecorder
-
To filter our sub steps at a maximum depth
- setMaximumCacheSize(int) - Method in interface org.apache.camel.ConsumerTemplate
-
Sets a custom maximum cache size.
- setMaximumCacheSize(int) - Method in interface org.apache.camel.FluentProducerTemplate
-
Sets a custom maximum cache size to use in the backing cache pools.
- setMaximumCacheSize(int) - Method in interface org.apache.camel.ProducerTemplate
-
Sets a custom maximum cache size to use in the backing cache pools.
- setMaximumRedeliveries(int) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets an optional limit of the number of redelivery attempt of recovered
Exchange
should be attempted, before its exhausted. - setMaxMessagesPerPoll(int) - Method in interface org.apache.camel.BatchConsumer
-
Sets a maximum number of messages as a limit to poll at each polling.
- setMaxOverlap(int) - Method in interface org.apache.camel.spi.Tokenizer.Configuration
-
Sets the maximum overlap between tokens, where an overlap is defined as the number of characters that are common between two adjacent segments.
- setMaxPoolSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the maximum pool size
- setMaxQueueSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the maximum number of tasks in the work queue.
- setMaxTokens(int) - Method in interface org.apache.camel.spi.Tokenizer.Configuration
-
Sets the maximum number of tokens to be produced by the tokenizer.
- setMBeanObjectDomainName(String) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the object domain name
- setMBeanServer(MBeanServer) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets a custom mbean server to use
- setMBeanServerDefaultDomain(String) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the default domain on the MBean server
- setMBeansLevel(ManagementMBeansLevel) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the mbeans registration level
- setMDCLoggingKeysPattern(String) - Method in interface org.apache.camel.CamelContext
-
Sets the pattern used for determine which custom MDC keys to propagate during message routing when the routing engine continues routing asynchronously for the given message.
- setMessage(Message) - Method in interface org.apache.camel.Exchange
-
Replace the current message instance.
- setMessageBodyOnBreakpoint(String, Object) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Updates the message body at the given breakpoint
- setMessageBodyOnBreakpoint(String, Object, Class<?>) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Updates the message body at the given breakpoint
- setMessageHeaderOnBreakpoint(String, String, Object) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Sets the message header at the given breakpoint
- setMessageHeaderOnBreakpoint(String, String, Object, Class<?>) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Sets the message header at the given breakpoint
- setMessageHistory(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether message history is enabled or not (default is disabled).
- setMessageHistoryFactory(MessageHistoryFactory) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
MessageHistoryFactory
- setMessageId(String) - Method in interface org.apache.camel.Message
-
Sets the id of the message
- setModeline(Boolean) - Method in interface org.apache.camel.CamelContext
-
Whether camel-k style modeline is also enabled when not using camel-k.
- setName(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the name (id) of this context.
- setName(String) - Method in class org.apache.camel.spi.Transformer
-
Set the name for this transformer.
- setName(String, String) - Method in class org.apache.camel.spi.Transformer
-
Set the scheme and/or name for this transformer.
- setNamePattern(String) - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
Sets a custom name pattern, which will be used instead of any default patterns.
- setNamespaces(Map<String, String>) - Method in interface org.apache.camel.spi.NamespaceAware
-
Injects the XML Namespaces of prefix -> uri mappings
- setNameStrategy(CamelContextNameStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom name strategy
- setNestedPlaceholder(boolean) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Whether to support nested property placeholders.
- setNodePattern(String) - Method in interface org.apache.camel.spi.MessageHistoryFactory
-
An optional pattern to filter which nodes to trace in this message history.
- setNotifyEvent(boolean) - Method in interface org.apache.camel.ExchangeExtension
-
Sets whether the exchange is currently used as event notification and if so then this should not generate additional events.
- setOnCompletion(String, Processor) - Method in interface org.apache.camel.Route
- setOnException(String, Processor) - Method in interface org.apache.camel.Route
- setOnlyRegisterProcessorWithCustomId(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to only register processors which has a custom id assigned.
- setOut(Message) - Method in interface org.apache.camel.Exchange
-
Deprecated.
- setOutput(String) - Method in interface org.apache.camel.spi.DumpRoutesStrategy
-
Whether to save route dumps to an output file.
- setOutputType(Class<?>) - Method in class org.apache.camel.spi.Contract
-
Set the output data type with Java class.
- setOutputType(String) - Method in class org.apache.camel.spi.Contract
-
Set the output data type.
- setOverrideProperties(Properties) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Sets a special list of override properties that take precedence and will use first, if a property exist.
- setParameter(String, Object) - Method in interface org.apache.camel.RouteTemplateContext
-
Sets a parameter
- setParentUnitOfWork(UnitOfWork) - Method in interface org.apache.camel.spi.UnitOfWork
-
Sets the parent unit of work.
- setPassword(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
The password for reading/opening/verifying the key store.
- setPattern(ExchangePattern) - Method in interface org.apache.camel.Exchange
-
Allows the
ExchangePattern
(MEP) of this exchange to be customized. - setPayloadForTrait(MessageTrait, Object) - Method in interface org.apache.camel.Message
-
Sets the payload for the
MessageTrait
- setPoolSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the core pool size (threads to keep minimum in pool)
- setPort(int) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the port to use by the REST consumer
- setPort(String) - Method in class org.apache.camel.vault.HashicorpVaultConfiguration
-
Port to access hashicorp vault
- setProcessor(Processor) - Method in interface org.apache.camel.Route
-
Sets the
Processor
- setProcessor(Processor) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
- setProcessorExchangeFactory(ProcessorExchangeFactory) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets a custom processor exchange factory to use.
- setProducerApiDoc(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the location of the api document (swagger api) the REST producer will use to validate the REST uri and query parameters are valid accordingly to the api document.
- setProducerComponent(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the name of the Camel component to use as the REST producer
- setProfile(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the profile Camel should run as (dev,test,prod).
- setProfileCredentialsProvider(boolean) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
Define if we want to use the AWS Profile Credentials Provider or not
- setProfileName(String) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
Define the profile name to use if Profile Credentials Provider is selected
- setProjectId(String) - Method in class org.apache.camel.vault.GcpVaultConfiguration
-
The GCP Project ID
- setProperties(Map<String, Object>) - Method in interface org.apache.camel.ExchangeExtension
-
Sets the properties on the exchange
- setPropertiesComponent(PropertiesComponent) - Method in interface org.apache.camel.CamelContext
-
Sets a custom properties component to be used.
- setProperty(String, Object) - Method in interface org.apache.camel.Exchange
-
Sets a property on the exchange
- setProperty(CamelContext, Object, String, Object) - Method in interface org.apache.camel.spi.BeanIntrospection
-
This method supports three modes to set a property: 1.
- setProperty(CamelContext, TypeConverter, Object, String, Object, String, boolean, boolean, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
-
This method supports three modes to set a property: 1.
- setProperty(ExchangePropertyKey, Object) - Method in interface org.apache.camel.Exchange
-
Sets a property on the exchange
- setProvider(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
The provider identifier for the
KeyManagerFactory
used to create theKeyManager
s represented by this object's configuration. - setProvider(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
The provider identifier for instantiating the key store.
- setProvider(String) - Method in class org.apache.camel.support.jsse.SecureRandomParameters
-
Sets the optional provider identifier for the
SecureRandom
factory method used to create theSecureRandom
represented by this object's configuration. - setProvider(String) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
Sets the optional provider identifier to use when constructing an
SSLContext
. - setProvider(String) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
Sets the optional provider identifier for the
TrustManagerFactory
used to create theTrustManager
s represented by this object's configuration. - setReactiveExecutor(ReactiveExecutor) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets a custom
ReactiveExecutor
to be used. - setRecording(boolean) - Method in interface org.apache.camel.spi.StartupStepRecorder
-
Whether to start flight recorder recording.
- setRecordingDir(String) - Method in interface org.apache.camel.spi.StartupStepRecorder
-
Directory to store the recording.
- setRecordingProfile(String) - Method in interface org.apache.camel.spi.StartupStepRecorder
-
To use a specific Java Flight Recorder profile configuration, such as default or profile.
- setRecoveryInterval(long) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets the interval between recovery scans
- setRecoveryInterval(long, TimeUnit) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Deprecated.use setRecoveryInterval
- setRedeliveryExhausted(boolean) - Method in interface org.apache.camel.ExchangeExtension
-
Used to signal that this exchange has exhausted (attempted all) its redeliveries and still failed.
- setRefreshEnabled(boolean) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
Whether to automatically reload Camel upon secrets being updated in AWS.
- setRefreshEnabled(boolean) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
Whether to automatically reload Camel upon secrets being updated in Azure.
- setRefreshEnabled(boolean) - Method in class org.apache.camel.vault.GcpVaultConfiguration
-
Whether to automatically reload Camel upon secrets being updated in AWS.
- setRefreshEnabled(boolean) - Method in class org.apache.camel.vault.KubernetesVaultConfiguration
-
Whether to automatically reload Camel upon secrets being updated in Kubernetes Cluster.
- setRefreshPeriod(long) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
The period (millis) between checking AWS for updated secrets.
- setRefreshPeriod(long) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The period (millis) between checking Azure for updated secrets.
- setRefreshPeriod(long) - Method in class org.apache.camel.vault.GcpVaultConfiguration
-
The period (millis) between checking Google for updated secrets.
- setRegion(String) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
The AWS region
- setRegisterAlways(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to always register mbeans.
- setRegisterNewRoutes(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to register mbeans when starting a new route
- setRegisterRoutesCreateByKamelet(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to register mbeans for routes created by a Kamelet
- setRegisterRoutesCreateByTemplate(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to register mbeans for routes created by a route templates (not Kamelets)
- setRegistry(Registry) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the registry Camel should use for looking up beans by name or type.
- setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the handler for tasks which cannot be executed by the thread pool.
- setRemoveOnDump(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Remove the currently traced messages when dump methods are invoked
- setRemoveSpoolDirectoryWhenStopping(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Whether to remove the temporary directory when stopping.
- setResolvePlaceholders(boolean) - Method in interface org.apache.camel.spi.DumpRoutesStrategy
-
Whether to resolve property placeholders in the dumped output.
- setResource(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
The keystore to load.
- setResource(Resource) - Method in interface org.apache.camel.spi.ResourceAware
-
Sets the
Resource
. - setResourceReload(ResourceReload) - Method in interface org.apache.camel.spi.ResourceReloadStrategy
-
Sets the resource listener to trigger on reload.
- setRestConfiguration(RestConfiguration) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
RestConfiguration
- setRestRegistry(RestRegistry) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
RestRegistry
to use. - setResumableCheck(Predicate<?>) - Method in interface org.apache.camel.resume.ConsumerListener
-
This sets the predicate responsible for evaluating whether the processing can resume or not.
- setResumeAction(ResumeAction) - Method in interface org.apache.camel.resume.ResumeActionAware
-
Sets an action that will be executed during resume
- setResumeCache(ResumeCache<?>) - Method in class org.apache.camel.resume.ResumeStrategyConfiguration
- setResumeStrategy(ResumeStrategy) - Method in interface org.apache.camel.Route
-
Sets the resume strategy for the route
- setResumeStrategy(T) - Method in interface org.apache.camel.resume.ResumeAware
-
Injects the
ResumeStrategy
instance into the object - setResumeStrategyConfiguration(ResumeStrategyConfiguration) - Method in interface org.apache.camel.resume.ResumeStrategy
- setRollbackOnly(boolean) - Method in interface org.apache.camel.Exchange
-
Sets whether to mark this exchange for rollback
- setRollbackOnlyLast(boolean) - Method in interface org.apache.camel.Exchange
-
Sets whether to mark this exchange for rollback (only last transaction section)
- setRoute(Route) - Method in interface org.apache.camel.RouteAware
-
Injects the
Route
- setRouteController(RouteController) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
RouteController
to use - setRouteController(RouteController) - Method in interface org.apache.camel.Route
-
Sets the
RouteController
for this route. - setRouteId(String) - Method in interface org.apache.camel.spi.RouteIdAware
-
Sets the route id
- setRouteOnAdvices(Route) - Method in interface org.apache.camel.spi.InternalProcessor
-
To make it possible for advices to access the created route.
- setRouteStop(boolean) - Method in interface org.apache.camel.Exchange
-
Sets whether this exchange is marked to stop and not continue routing.
- setRuntime(String) - Method in interface org.apache.camel.spi.CliConnectorFactory
-
What runtime platform is in use, such as camel-jbang, camel-spring-boot, or camel-quarkus etc.
- setRuntimeEndpointRegistry(RuntimeEndpointRegistry) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
RuntimeEndpointRegistry
to use. - setRuntimeStartClass(String) - Method in interface org.apache.camel.spi.CliConnectorFactory
-
The main class used by the runtime to start.
- setRuntimeVersion(String) - Method in interface org.apache.camel.spi.CliConnectorFactory
-
What runtime platform version is in use.
- setSafeCopyProperty(String, SafeCopyProperty) - Method in interface org.apache.camel.ExchangeExtension
-
To set a property that must be copied specially (thread safe with deep cloning).
- setScheme(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the scheme to use by the REST consumer
- setScheme(String) - Method in interface org.apache.camel.spi.SendDynamicAware
-
Sets the component name.
- setScheme(String) - Method in class org.apache.camel.vault.HashicorpVaultConfiguration
-
Scheme to access hashicorp vault
- setSecretKey(String) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
The AWS secret key
- setSecrets(String) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
Specify the secret names (or pattern) to check for updates.
- setSecrets(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
Specify the secret names (or pattern) to check for updates.
- setSecrets(String) - Method in class org.apache.camel.vault.GcpVaultConfiguration
-
Specify the secret names (or pattern) to check for updates.
- setSecrets(String) - Method in class org.apache.camel.vault.KubernetesVaultConfiguration
-
Specify the secret names (or pattern) to check for updates.
- setSecureRandom(SecureRandomParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
Sets the optional secure random configuration options to use for constructing the
SecureRandom
used in the creation of anSSLContext
. - setSecureSocketProtocol(String) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
Sets the optional protocol for the secure sockets created by the
SSLContext
represented by this instance's configuration. - setSecureSocketProtocol(List<String>) - Method in class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
-
Sets the list of secure socket protocol names.
- setSecureSocketProtocols(SecureSocketProtocolsParameters) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Sets the explicitly configured secure socket protocol names for this configuration.
- setSecureSocketProtocolsFilter(FilterParameters) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Sets the optional secure socket protocol filter for this JSSE configuration.
- setServerParameters(SSLContextServerParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
The optional configuration options to be applied purely to the server side settings of the
SSLContext
. - setServiceAccountKey(String) - Method in class org.apache.camel.vault.GcpVaultConfiguration
-
The Service Account Key location
- setServiceChooser(ServiceChooser) - Method in interface org.apache.camel.cloud.ServiceChooserAware
-
Deprecated.Injects the
ServiceChooser
- setServiceDiscovery(ServiceDiscovery) - Method in interface org.apache.camel.cloud.ServiceDiscoveryAware
-
Deprecated.Injects the
ServiceDiscovery
- setServiceFilter(ServiceFilter) - Method in interface org.apache.camel.cloud.ServiceFilterAware
-
Deprecated.Injects the
ServiceFilter
- setSessionTimeout(String) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
Sets the optional
SSLSessionContext
timeout time forSSLSession
s in seconds. - setShortError(String) - Method in class org.apache.camel.catalog.LanguageValidationResult
- setShutdownAwaitTermination(long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Sets the time to wait for thread pools to shutdown orderly, when invoking the
ShutdownableService.shutdown()
method. - setShutdownNowOnTimeout(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Sets whether to force shutdown of all consumers when a timeout occurred and thus not all consumers was shutdown within that period.
- setShutdownRoute(ShutdownRoute) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets the ShutdownRoute option for routes.
- setShutdownRoutesInReverseOrder(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Sets whether routes should be shutdown in reverse or the same order as they were started.
- setShutdownRunningTask(ShutdownRunningTask) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets the ShutdownRunningTask option to use when shutting down a route.
- setShutdownStrategy(ShutdownStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom shutdown strategy
- setSingleStepIncludeStartEnd(boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
In single step mode, then when the exchange is created and completed, then simulate a breakpoint at start and end, that allows to suspend and watch the incoming/complete exchange at the route (you can see message body as response, failed exception etc).
- setSkipBindingOnErrorCode(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
Whether to skip binding output if there is a custom HTTP error code, and instead use the response body as-is.
- setSniHostName(String) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
- setSourceLocationEnabled(Boolean) - Method in interface org.apache.camel.CamelContext
-
Whether to capture precise source location:line-number for all EIPs in Camel routes.
- setSpoolCipher(String) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets a cipher name to use when spooling to disk to write with encryption.
- setSpoolDirectory(File) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets the spool (temporary) directory to use for overflow and spooling to disk.
- setSpoolDirectory(String) - Method in interface org.apache.camel.spi.StreamCachingStrategy
- setSpoolEnabled(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Enables spooling to disk.
- setSpoolThreshold(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Threshold in bytes when overflow to disk is activated.
- setSpoolUsedHeapMemoryLimit(StreamCachingStrategy.SpoolUsedHeapMemoryLimit) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets what the upper bounds should be when
StreamCachingStrategy.setSpoolUsedHeapMemoryThreshold(int)
is in use. - setSpoolUsedHeapMemoryThreshold(int) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets a percentage (1-99) of used heap memory threshold to activate spooling to disk.
- setSqsQueueUrl(String) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
In case of usage of SQS notification this field will specified the Queue URL to use
- setSSLContextParameters(SSLContextParameters) - Method in interface org.apache.camel.CamelContext
-
Sets the global SSL context parameters.
- setStandby(boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether the debugger is standby.
- setStandby(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Whether the tracer is standby.
- setStandby(boolean) - Method in interface org.apache.camel.spi.Tracer
-
Whether the tracer is standby.
- setStartupOrder(Integer) - Method in interface org.apache.camel.Route
-
Sets the route startup order
- setStartupRecorderDuration(long) - Method in interface org.apache.camel.spi.StartupStepRecorder
-
How long time to run the startup recorder.
- setStartupStepRecorder(StartupStepRecorder) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the
StartupStepRecorder
to use. - setStartupSummaryLevel(StartupSummaryLevel) - Method in interface org.apache.camel.CamelContext
-
Controls the level of information logged during startup (and shutdown) of
CamelContext
. - setState(K, V) - Method in interface org.apache.camel.spi.StateRepository
-
Sets the state value for the given key.
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
Sets whether statistics is enabled.
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.ExchangeFactoryManager
-
Whether statistics is enabled.
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.PooledObjectFactory
-
Whether statistics is enabled.
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
To enable statistics
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Sets whether statistics is enabled.
- setStatisticsLevel(ManagementStatisticsLevel) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the statistics level
- setStreamCacheDisabled(boolean) - Method in interface org.apache.camel.ExchangeExtension
-
Used to force disabling stream caching which some components can do in special use-cases.
- setStreamCaching(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether stream caching is enabled or not (default is enabled).
- setStreamCachingStrategy(StreamCachingStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
StreamCachingStrategy
to use. - setSubscriptionName(String) - Method in class org.apache.camel.vault.GcpVaultConfiguration
-
Define the Google Pubsub subscription Name to be used when checking for updates
- setSuppressLoggingOnTimeout(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Whether Camel should try to suppress logging during shutdown and timeout was triggered, meaning forced shutdown is happening.
- setSuspendMode(boolean) - Method in interface org.apache.camel.spi.BacklogDebugger
-
Whether the debugger should suspend on startup, and wait for a remote debugger to attach.
- setTenantId(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The Tenant Id for accessing Azure Key Vault
- setText(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
- setThreadedAsyncMode(boolean) - Method in interface org.apache.camel.ProducerTemplate
-
Reports if async* methods will dispatch processing from the calling thread (false) or through executor (true).
- setThreadNamePattern(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Sets the thread name pattern used for creating the full thread name.
- setThreadPoolFactory(ThreadPoolFactory) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Sets a custom
ThreadPoolFactory
to use - setThreadPoolSize(int) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
The number of threads used by the scheduled thread pool that are used for restarting routes.
- setTimeout(long) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Set a timeout to wait for the shutdown to complete.
- setTimestamp(long) - Method in interface org.apache.camel.spi.CamelEvent
- setTimestampEnabled(boolean) - Method in interface org.apache.camel.spi.EventFactory
-
Whether to include timestamp for each event, when the event occurred.
- setTimeUnit(TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Set the time unit to use
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the time unit used for keep alive time
- setTo(String) - Method in class org.apache.camel.spi.Transformer
-
Set 'to' data type.
- setToken(String) - Method in class org.apache.camel.vault.HashicorpVaultConfiguration
-
Token to access hashicorp vault
- setTraceBeforeAndAfterRoute(boolean) - Method in interface org.apache.camel.spi.Tracer
-
Whether to include tracing of before/after routes to trace the input and responses of routes.
- setTraceFilter(String) - Method in interface org.apache.camel.spi.BacklogTracer
-
Filter for tracing messages
- setTracePattern(String) - Method in interface org.apache.camel.spi.BacklogTracer
-
Filter for tracing by route or node id
- setTracePattern(String) - Method in interface org.apache.camel.spi.Tracer
-
Tracing pattern to match which node EIPs to trace.
- setTracer(Tracer) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
Tracer
- setTraceRests(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Whether to trace routes that is created from route templates or kamelets.
- setTraceRests(boolean) - Method in interface org.apache.camel.spi.Tracer
-
Whether to trace routes that is created from route templates or kamelets.
- setTraceTemplates(boolean) - Method in interface org.apache.camel.spi.BacklogTracer
-
Whether to trace routes that is created from route templates or kamelets.
- setTraceTemplates(boolean) - Method in interface org.apache.camel.spi.Tracer
-
Whether tracing should trace inner details from route templates (or kamelets).
- setTracing(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether tracing enabled To use tracing then either turn on tracing standby or enable tracing to make tracing possible.
- setTracingLoggingFormat(String) - Method in interface org.apache.camel.CamelContext
-
To use a custom tracing logging format.
- setTracingPattern(String) - Method in interface org.apache.camel.RuntimeConfiguration
-
Tracing pattern to match which node EIPs to trace.
- setTracingStandby(boolean) - Method in interface org.apache.camel.CamelContext
-
Whether to set tracing on standby.
- setTracingTemplates(boolean) - Method in interface org.apache.camel.CamelContext
-
Whether tracing should trace inner details from route templates (or kamelets).
- setTransacted(boolean) - Method in interface org.apache.camel.ExchangeExtension
-
Sets whether the exchange is routed in a transaction.
- setTrustManager(TrustManager) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
To use an existing configured trust manager instead of using
TrustManagerFactory
to get theTrustManager
. - setTrustManagers(TrustManagersParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
Sets the optional trust manager configuration for creating the
TrustManager
s used in constructing anSSLContext
. - setType(String) - Method in interface org.apache.camel.spi.Tokenizer.Configuration
-
Sets the type of tokenization being performed by this tokenizer.
- setType(String) - Method in class org.apache.camel.spi.Validator
-
Set data type.
- setType(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
The type of the key store to create and load.
- setTypeConverterExists(TypeConverterExists) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
What should happen when attempting to add a duplicate type converter.
- setTypeConverterExistsLoggingLevel(LoggingLevel) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
The logging level to use when logging that a type converter already exists when attempting to add a duplicate type converter.
- setTypeConverterRegistry(TypeConverterRegistry) - Method in interface org.apache.camel.CamelContext
-
Configures the type converter registry to use, where type converters can be added or looked up.
- setTypeConverterStatisticsEnabled(Boolean) - Method in interface org.apache.camel.CamelContext
-
Sets whether or not type converter statistics is enabled.
- setUnbindEnabled(boolean) - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
- setUnhealthyOnExhausted(boolean) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Whether to mark the route as unhealthy (down) when all restarting attempts (backoff) have failed and the route is not successfully started and the route manager is giving up.
- setUnhealthyOnRestarting(boolean) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Whether to mark the route as unhealthy (down) when the route failed to initially start, and is being controlled for restarting (backoff).
- setUnitOfWork(UnitOfWork) - Method in interface org.apache.camel.ExchangeExtension
-
Sets the unit of work that this exchange belongs to; which may map to zero, one or more physical transactions
- setUpdateRouteEnabled(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets whether updating routes via JMX is allowed (is default disabled).
- setupJaxb(CamelContext, RestConfiguration, String, Class<?>, String, Class<?>, DataFormat, DataFormat) - Method in interface org.apache.camel.spi.RestBindingJaxbDataFormatFactory
-
Setup XML data format
- setupManagement(Map<String, Object>) - Method in interface org.apache.camel.ExtendedCamelContext
-
Setup management according to whether JMX is enabled or disabled.
- setupManagement(CamelContext, ManagementStrategy, LifecycleStrategy) - Method in interface org.apache.camel.spi.ManagementStrategyFactory
-
Setup the management on the
CamelContext
. - setupRoutes(boolean) - Method in interface org.apache.camel.ExtendedCamelContext
-
Method to signal to
CamelContext
that the process to initialize setup routes is in progress. - setUriAsParameters(boolean) - Method in interface org.apache.camel.spi.DumpRoutesStrategy
-
When dumping to YAML format, then this option controls whether endpoint URIs should be expanded into a key/value parameters.
- setUseBreadcrumb(Boolean) - Method in interface org.apache.camel.CamelContext
-
Set whether breadcrumb is enabled.
- setUseDataType(Boolean) - Method in interface org.apache.camel.CamelContext
-
Whether to enable using data type on Camel messages.
- setUseDefaultInstance(boolean) - Method in class org.apache.camel.vault.GcpVaultConfiguration
-
Define if we want to use the GCP Client Default Instance or not
- setUseGlobalSslContextParameters(boolean) - Method in interface org.apache.camel.SSLContextParametersAware
-
Enable usage of global SSL context parameters.
- setUseHostIPAddress(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets whether to use host IP Address
- setUseMDCLogging(Boolean) - Method in interface org.apache.camel.CamelContext
-
Set whether MDC is enabled.
- setUsePlatformMBeanServer(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to use the platform MBean Server.
- setUseRecovery(boolean) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets whether or not recovery is enabled
- setUseSqsNotification(boolean) - Method in class org.apache.camel.vault.AwsVaultConfiguration
-
Whether to use AWS SQS for secrets updates notification, this will require setting up Eventbridge/Cloudtrail/SQS communication
- setUseXForwardHeaders(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
Whether to use X-Forward headers to set host etc. for OpenApi.
- setUuidGenerator(UuidGenerator) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
UuidGenerator
(should only be set once) - setValidateInput(boolean) - Method in class org.apache.camel.spi.Contract
-
Whether to validate the input
- setValidateOutput(boolean) - Method in class org.apache.camel.spi.Contract
-
Whether to validate the output
- setValue(Object) - Method in interface org.apache.camel.StaticExpression
-
Sets the constant value
- setValue(K) - Method in interface org.apache.camel.resume.OffsetKey
-
Sets the key value
- setVariable(String, Object) - Method in interface org.apache.camel.CamelContext
-
Sets a variable
- setVariable(String, Object) - Method in interface org.apache.camel.Exchange
-
Sets a variable on the exchange
- setVariable(String, Object) - Method in interface org.apache.camel.VariableAware
-
Sets a variable
- setVaultConfiguration(VaultConfiguration) - Method in interface org.apache.camel.CamelContext
-
Sets a custom
VaultConfiguration
- setVaultName(String) - Method in class org.apache.camel.vault.AzureVaultConfiguration
-
The vault Name in Azure Key Vault
- setWorkDir(String) - Method in interface org.apache.camel.spi.CompileStrategy
-
Work directory for compiler.
- setXmlDataFormat(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets a custom xml data format to be used.
- SharedInternalProcessor - Interface in org.apache.camel.spi
-
A Shared (thread safe) internal
Processor
that Camel routing engine used during routing for cross cutting functionality such as: ExecuteUnitOfWork
Keeping track which route currently is being routed ExecuteRoutePolicy
Gather JMX performance statics Tracing Debugging Message History Stream CachingTransformer
... and more. - shareUnitOfWork() - Element in annotation interface org.apache.camel.RecipientList
-
Shares the
UnitOfWork
with the parent and each of the sub messages. - shouldLog() - Method in class org.apache.camel.spi.CamelLogger
- shouldLog(Logger, LoggingLevel) - Static method in class org.apache.camel.spi.CamelLogger
- shouldSpoolCache(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Determines if the stream should be spooled or not.
- shouldSpoolCache(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy.SpoolRule
-
Determines if the stream should be spooled or not.
- shouldTrace(NamedNode) - Method in interface org.apache.camel.spi.Tracer
-
Whether or not to trace the given processor definition.
- shutdown() - Method in interface org.apache.camel.CamelContextLifecycle
-
Shutdown the CamelContext, which means it cannot be started again.
- shutdown() - Method in interface org.apache.camel.ShutdownableService
-
Shutdown the service, which means it cannot be started again.
- shutdown() - Method in class org.apache.camel.support.service.BaseService
-
Important: You should override the lifecycle methods that start with do, eg
BaseService.doStart()
,BaseService.doStop()
, etc. where you implement your logic. - shutdown(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Shutdown the given executor service (not graceful).
- shutdown(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Shutdown the routes
- shutdown(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Shutdown the routes using a specified timeout instead of the default timeout values
- shutdown(CamelContext, RouteStartupOrder, long, TimeUnit, boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Shutdown the route using a specified timeout instead of the default timeout values and supports abortAfterTimeout mode
- SHUTDOWN - Enum constant in enum class org.apache.camel.spi.RouteError.Phase
- SHUTDOWN - Static variable in class org.apache.camel.support.service.BaseService
- ShutdownableService - Interface in org.apache.camel
-
A
Service
which is capable of being shut down. - ShutdownAware - Interface in org.apache.camel.spi
-
Allows
Consumer
to fine grained control on shutdown which mostly have to cater for in-memory based components. - shutdownForced(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Shutdown the routes, forcing shutdown being more aggressive, if timeout occurred.
- shutdownGraceful(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Shutdown the given executor service graceful at first, and then aggressively if the await termination timeout was hit.
- shutdownGraceful(ExecutorService, long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Shutdown the given executor service graceful at first, and then aggressively if the await termination timeout was hit.
- shutdownNow(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Shutdown now the given executor service aggressively.
- ShutdownPrepared - Interface in org.apache.camel.spi
-
Allows a
Service
to prepare for shutdown. - ShutdownRoute - Enum Class in org.apache.camel
-
Represents the options available when shutting down routes.
- ShutdownRunningTask - Enum Class in org.apache.camel
-
Represents the kind of options for what to do with the current task when shutting down.
- ShutdownStrategy - Interface in org.apache.camel.spi
-
Pluggable shutdown strategy executed during shutdown of Camel and the active routes.
- SHUTTING_DOWN - Static variable in class org.apache.camel.support.service.BaseService
- signatures() - Element in annotation interface org.apache.camel.spi.ApiMethod
-
Returns the method signature(s) of this api method.
- sigterm() - Method in interface org.apache.camel.spi.CliConnector
-
Signal to terminate Camel and the JVM.
- simple(String, String, String) - Static method in interface org.apache.camel.cloudevents.CloudEvent.Attribute
- SimpleExecutorService - Interface in org.apache.camel.spi
-
Marker interface to signal that a
ExecutorService
is simple and tasks are either only submitted viaExecutorService.submit(Runnable)
or executed viaExecutor.execute(Runnable)
methods. - Singleton - Enum constant in enum class org.apache.camel.BeanScope
- size() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
Number of threads that are blocked waiting for other threads to trigger the callback when they are done processing the exchange.
- size() - Method in interface org.apache.camel.spi.BrowsableVariableRepository
-
Number of variables
- size() - Method in interface org.apache.camel.spi.BulkTypeConverters
-
Number of type converters included
- size() - Method in interface org.apache.camel.spi.ConsumerCache
-
Returns the current size of the cache
- size() - Method in interface org.apache.camel.spi.EndpointServiceRegistry
-
Number of endpoint services in the registry.
- size() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
-
Current number of endpoints we have information about
- size() - Method in interface org.apache.camel.spi.InflightRepository
-
Current size of inflight exchanges.
- size() - Method in interface org.apache.camel.spi.ProducerCache
-
Returns the current size of the cache
- size() - Method in interface org.apache.camel.spi.RestRegistry
-
Number of rest services in the registry.
- size() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Number of endpoints currently in the cache.
- size() - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Number of type converters in the registry.
- size() - Method in interface org.apache.camel.TimeoutMap
-
Returns the size of the map
- size(String) - Method in interface org.apache.camel.spi.InflightRepository
-
Current size of inflight exchanges which are from the given route.
- skip() - Element in annotation interface org.apache.camel.spi.Metadata
-
Whether to skip this option
- SKIP_GZIP_ENCODING - Static variable in interface org.apache.camel.Exchange
- SKIP_WWW_FORM_URLENCODED - Static variable in interface org.apache.camel.Exchange
- SLIP_ENDPOINT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- SLIP_ENDPOINT - Static variable in interface org.apache.camel.Exchange
- SLIP_PRODUCER - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- SLIP_PRODUCER - Static variable in interface org.apache.camel.Exchange
- SOAP_ACTION - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- SOCIAL - Enum constant in enum class org.apache.camel.Category
- SPLIT_COMPLETE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- SPLIT_COMPLETE - Static variable in interface org.apache.camel.Exchange
- SPLIT_INDEX - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- SPLIT_INDEX - Static variable in interface org.apache.camel.Exchange
- SPLIT_SIZE - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- SPLIT_SIZE - Static variable in interface org.apache.camel.Exchange
- SSLContextClientParameters - Class in org.apache.camel.support.jsse
-
Configuration model for client side JSSE options.
- SSLContextClientParameters() - Constructor for class org.apache.camel.support.jsse.SSLContextClientParameters
- SSLContextDecorator(BaseSSLContextParameters.SSLContextSpiDecorator) - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextDecorator
- SSLContextParameters - Class in org.apache.camel.support.jsse
-
Represents
SSLContext
configuration options used in instantiating anSSLContext
instance. - SSLContextParameters() - Constructor for class org.apache.camel.support.jsse.SSLContextParameters
- SSLContextParametersAware - Interface in org.apache.camel
-
Indicates that an object is able to use the global
SSLContextParameters
if configured. - SSLContextServerParameters - Class in org.apache.camel.support.jsse
- SSLContextServerParameters() - Constructor for class org.apache.camel.support.jsse.SSLContextServerParameters
- SSLContextSpiDecorator(SSLContext, List<BaseSSLContextParameters.Configurer<SSLEngine>>, List<BaseSSLContextParameters.Configurer<SSLSocketFactory>>, List<BaseSSLContextParameters.Configurer<SSLServerSocketFactory>>) - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
- SSLServerSocketFactoryDecorator(SSLServerSocketFactory, List<BaseSSLContextParameters.Configurer<SSLServerSocket>>) - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
- SSLSocketFactoryDecorator(SSLSocketFactory, List<BaseSSLContextParameters.Configurer<SSLSocket>>) - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
- start() - Method in interface org.apache.camel.CamelContextLifecycle
-
Starts the
CamelContext
(important: the start method is not blocked, see more details in theinvalid reference
Main
- start() - Method in interface org.apache.camel.Service
-
Starts the service
- start() - Method in class org.apache.camel.support.service.BaseService
-
Important: You should override the lifecycle methods that start with do, eg
BaseService.doStart()
,BaseService.doStop()
, etc. where you implement your logic. - START - Enum constant in enum class org.apache.camel.ContextEvents
-
Start event
- START - Enum constant in enum class org.apache.camel.spi.RouteError.Phase
- startAllRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Starts all the routes which currently is not started.
- Started - Enum constant in enum class org.apache.camel.ServiceStatus
- STARTED - Static variable in class org.apache.camel.support.service.BaseService
- Starting - Enum constant in enum class org.apache.camel.ServiceStatus
- STARTING - Static variable in class org.apache.camel.support.service.BaseService
- startRoute(String) - Method in interface org.apache.camel.spi.RouteController
-
Starts the given route if it has been previously stopped
- startRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Started routes
- startRoutes(boolean) - Method in interface org.apache.camel.spi.SupervisingRouteController
-
Started routes
- startScheduler() - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Starts the scheduler.
- startService(Iterable<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Starts the given
value
if it's aService
or a collection of it. - startService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Starts the given
value
if it's aService
or a collection of it. - startService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Starts each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - startService(Service) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Starts the given
value
if it's aService
or a collection of it. - startSingleStepExchange(String, Breakpoint) - Method in interface org.apache.camel.spi.Debugger
-
Starts the single step debug mode for the given exchange
- StartupListener - Interface in org.apache.camel
-
Allows objects to be notified when
CamelContext
has almost done all work when starting. - StartupStep - Interface in org.apache.camel
-
Recording state of steps during startup to capture execution time, and being able to emit events to diagnostic tools such as Java Flight Recorder.
- StartupStepRecorder - Interface in org.apache.camel.spi
-
To record
StartupStep
during startup to allow to capture diagnostic information to help troubleshoot Camel applications via various tooling such as Java Flight Recorder. - StartupSummaryLevel - Enum Class in org.apache.camel
-
Controls the level of information logged during startup (and shutdown) of
CamelContext
. - startView(String) - Method in interface org.apache.camel.cluster.CamelClusterService
-
Force start of the view associated to the give namespace.
- state() - Method in class org.apache.camel.health.HealthCheckResultBuilder
- state(HealthCheck.State) - Method in class org.apache.camel.health.HealthCheckResultBuilder
- StatefulService - Interface in org.apache.camel
-
A
Service
which has all the lifecycle events and offers details about its current state. - StateRepository<K,
V> - Interface in org.apache.camel.spi -
This
StateRepository
holds a set of key/value pairs for defining a particular state of a component. - StaticExpression - Interface in org.apache.camel
-
Marked if the
Expression
orPredicate
is based from a constant value (ie is static). - StaticService - Interface in org.apache.camel
-
Marker for indicating the
Service
is a static service (only one instance perCamelContext
). - staticSize() - Method in interface org.apache.camel.spi.EndpointRegistry
-
Number of endpoints in the static registry.
- staticSize() - Method in interface org.apache.camel.spi.TransformerRegistry
-
Number of transformers in the static registry.
- staticSize() - Method in interface org.apache.camel.spi.ValidatorRegistry
-
Number of validators in the static registry.
- status - Variable in class org.apache.camel.support.service.BaseService
- statusCode() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationError
-
Returns the value of the
statusCode
record component. - step() - Method in interface org.apache.camel.spi.BacklogDebugger
-
To step (into) to next node when in single step mode.
- STEP_ID - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- STEP_ID - Static variable in interface org.apache.camel.Exchange
- stepBreakpoint() - Method in interface org.apache.camel.spi.BacklogDebugger
-
To start single step mode from the current suspended breakpoint.
- stepBreakpoint(String) - Method in interface org.apache.camel.spi.BacklogDebugger
-
To start single step mode from a suspended breakpoint at the given node.
- StepCompleted - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- StepFailed - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- stepOver() - Method in interface org.apache.camel.spi.BacklogDebugger
-
To step over to next node when in single step mode.
- steps() - Method in interface org.apache.camel.spi.StartupStepRecorder
-
Some records will capture all steps which can be accessed on demand.
- StepStarted - Enum constant in enum class org.apache.camel.spi.CamelEvent.Type
- stop() - Method in interface org.apache.camel.CamelContextLifecycle
-
Stop and shutdown the
CamelContext
(will stop all routes/components/endpoints etc and clear internal state/cache). - stop() - Method in interface org.apache.camel.Service
-
Stops the service
- stop() - Method in class org.apache.camel.support.service.BaseService
-
Important: You should override the lifecycle methods that start with do, eg
BaseService.doStart()
,BaseService.doStop()
, etc. where you implement your logic. - STOP - Enum constant in enum class org.apache.camel.spi.RouteError.Phase
- stopAllRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Stops all the routes
- stopAndShutdownService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops and shutdowns the given
service
, rethrowing the first exception caught. - stopAndShutdownService(ShutdownableService) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops and shutdowns the given
service
, rethrowing the first exception caught. - stopAndShutdownServices(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops and shutdowns each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - stopAndShutdownServices(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops and shutdowns each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - stopOnException() - Element in annotation interface org.apache.camel.RecipientList
-
Will now stop further processing if an exception or failure occurred during processing of an
Exchange
and the caused exception will be thrown. - Stopped - Enum constant in enum class org.apache.camel.ServiceStatus
- STOPPED - Static variable in class org.apache.camel.support.service.BaseService
- Stopping - Enum constant in enum class org.apache.camel.ServiceStatus
- STOPPING - Static variable in class org.apache.camel.support.service.BaseService
- stopRoute(String) - Method in interface org.apache.camel.spi.RouteController
-
Stops the given route using
ShutdownStrategy
. - stopRoute(String, long, TimeUnit) - Method in interface org.apache.camel.spi.RouteController
-
Stops the given route using
ShutdownStrategy
with a specified timeout. - stopRoute(String, long, TimeUnit, boolean) - Method in interface org.apache.camel.spi.RouteController
-
Stops the given route using
ShutdownStrategy
with a specified timeout and optional abortAfterTimeout mode. - stopRoute(String, Throwable) - Method in interface org.apache.camel.spi.RouteController
-
Stops and marks the given route as failed (health check is DOWN) due to a caused exception.
- stopService(Iterable<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops the given
value
, rethrowing the first exception caught. - stopService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops the given
value
, rethrowing the first exception caught. - stopService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - stopService(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - stopService(Service) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops the given
value
, rethrowing the first exception caught. - stopSingleStepExchange(String) - Method in interface org.apache.camel.spi.Debugger
-
Stops the single step debug mode for the given exchange.
- stopView(String) - Method in interface org.apache.camel.cluster.CamelClusterService
-
Force stop of the view associated to the give namespace.
- stream() - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Returns a sequential
Stream
with the knownDevConsole
as its source. - stream() - Method in interface org.apache.camel.health.HasHealthChecks
-
Returns a sequential
Stream
with the knownHealthCheck
as its source. - stream() - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Returns a sequential
Stream
with the knownHealthCheck
as its source. - STREAM_CACHE_UNIT_OF_WORK - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- STREAM_CACHE_UNIT_OF_WORK - Static variable in interface org.apache.camel.Exchange
- StreamCache - Interface in org.apache.camel
-
Tagging interface to indicate that a type is capable of caching the underlying data stream.
- StreamCacheException - Exception Class in org.apache.camel
- StreamCacheException(Object, Throwable) - Constructor for exception class org.apache.camel.StreamCacheException
- StreamCachingStrategy - Interface in org.apache.camel.spi
-
Strategy for using stream caching.
- StreamCachingStrategy.SpoolRule - Interface in org.apache.camel.spi
-
Rule for determine if stream caching should be spooled to disk or kept in-memory.
- StreamCachingStrategy.SpoolUsedHeapMemoryLimit - Enum Class in org.apache.camel.spi
-
Used for selecting if the memory limit is committed or maximum heap memory setting.
- StreamCachingStrategy.Statistics - Interface in org.apache.camel.spi
-
Utilization statistics of stream caching.
- streaming() - Element in annotation interface org.apache.camel.RecipientList
-
If enabled then Camel will process replies out-of-order, eg in the order they come back.
- STRUCT - Enum constant in enum class org.apache.camel.spi.MimeType
- SUCCESS_COUNT - Static variable in interface org.apache.camel.health.HealthCheck
- SUCCESS_START_TIME - Static variable in interface org.apache.camel.health.HealthCheck
- SUCCESS_TIME - Static variable in interface org.apache.camel.health.HealthCheck
- SUFFIX_TOKEN - Static variable in interface org.apache.camel.spi.PropertiesComponent
-
The suffix token.
- suggestEndpointOptions(Set<String>, String) - Method in interface org.apache.camel.catalog.SuggestionStrategy
-
Provides a list of valid option names for a did you mean function.
- SuggestionStrategy - Interface in org.apache.camel.catalog
-
Strategy to provide suggestions for unknown endpoint options
- summaryErrorMessage(boolean) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
-
A human readable summary of the validation errors.
- summaryErrorMessage(boolean) - Method in class org.apache.camel.catalog.EndpointValidationResult
-
A human readable summary of the validation errors.
- summaryErrorMessage(boolean, boolean, boolean) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
-
A human readable summary of the validation errors.
- summaryErrorMessage(boolean, boolean, boolean) - Method in class org.apache.camel.catalog.EndpointValidationResult
-
A human readable summary of the validation errors.
- SUPERVISED - Static variable in interface org.apache.camel.Route
- supervising() - Method in interface org.apache.camel.spi.RouteController
-
Enables supervising
RouteController
. - SupervisingRouteController - Interface in org.apache.camel.spi
-
A supervising capable
RouteController
that delays the startup of the routes after the camel context startup and takes control of starting the routes in a safe manner. - supportFileReference() - Element in annotation interface org.apache.camel.spi.Metadata
-
Whether the option can refer to a file by using file: or classpath: as prefix and specify the location of the file.
- supportMediaType(DevConsole.MediaType) - Method in interface org.apache.camel.console.DevConsole
-
Whether this console supports the given media type.
- supportsAutoWiring() - Method in interface org.apache.camel.spi.Injector
-
Whether the injector supports creating new instances using auto-wiring.
- supportsSuspension() - Method in interface org.apache.camel.Route
-
Whether or not the route supports suspension (suspend and resume)
- supportTransacted() - Method in interface org.apache.camel.ErrorHandlerFactory
-
Whether this error handler supports transacted exchanges.
- suspend() - Method in interface org.apache.camel.CamelContextLifecycle
-
Suspends the CamelContext.
- suspend() - Method in interface org.apache.camel.spi.Breakpoint
-
Suspend this breakpoint
- suspend() - Method in class org.apache.camel.support.service.BaseService
-
Important: You should override the lifecycle methods that start with do, eg
BaseService.doStart()
,BaseService.doStop()
, etc. where you implement your logic. - suspend() - Method in interface org.apache.camel.SuspendableService
-
Suspends the service.
- suspend(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Suspends the routes
- suspend(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Suspends the routes using a specified timeout instead of the default timeout values
- SUSPEND - Enum constant in enum class org.apache.camel.spi.RouteError.Phase
- SUSPEND_MODE_ENV_VAR_NAME - Static variable in interface org.apache.camel.spi.BacklogDebugger
-
The name of the OS environment variable that contains the value of the flag indicating whether the
BacklogDebugger
should suspend processing the messages and wait for a debugger to attach or not. - SUSPEND_MODE_SYSTEM_PROP_NAME - Static variable in interface org.apache.camel.spi.BacklogDebugger
-
The name of the system property that contains the value of the flag indicating whether the
BacklogDebugger
should suspend processing the messages and wait for a debugger to attach or not. - Suspendable - Interface in org.apache.camel
-
Marker interface to indicate a custom component has custom implementation for suspending the
SuspendableService
service. - SuspendableService - Interface in org.apache.camel
-
A
Service
which is also capable of suspending and resuming. - suspendAllBreakpoints() - Method in interface org.apache.camel.spi.Debugger
-
Suspends all breakpoints.
- Suspended - Enum constant in enum class org.apache.camel.ServiceStatus
- Suspended - Enum constant in enum class org.apache.camel.spi.Breakpoint.State
- SUSPENDED - Static variable in class org.apache.camel.support.service.BaseService
- Suspending - Enum constant in enum class org.apache.camel.ServiceStatus
- SUSPENDING - Static variable in class org.apache.camel.support.service.BaseService
- suspendRoute(String) - Method in interface org.apache.camel.spi.RouteController
-
Suspends the given route using
ShutdownStrategy
. - suspendRoute(String, long, TimeUnit) - Method in interface org.apache.camel.spi.RouteController
-
Suspends the given route using
ShutdownStrategy
with a specified timeout. - suspendService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Suspends the given
service
. - suspendServices(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Suspends each element of the given
services
ifservices
itself is notnull
, otherwise this method would return immediately. - Synchronization - Interface in org.apache.camel.spi
-
Provides a hook for custom
Processor
orComponent
instances to respond to completed or failed processing of anExchange
rather like Spring's TransactionSynchronization - SynchronizationRouteAware - Interface in org.apache.camel.spi
-
An extension to
Synchronization
which provides route awareness capabilities. - SynchronizationVetoable - Interface in org.apache.camel.spi
-
A vetoable
Synchronization
. - syntax() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
Represent the URI syntax the endpoint must use.
T
- TEMPLATE_ID - Static variable in interface org.apache.camel.spi.RouteTemplateParameterSource
- TEMPLATE_PROPERTY - Static variable in interface org.apache.camel.Route
- test(Object) - Static method in interface org.apache.camel.IsSingleton
-
Test if the given
instance
is a singleton or not. - test(CamelContext) - Method in interface org.apache.camel.spi.CamelContextTracker.Filter
- TESTING - Enum constant in enum class org.apache.camel.Category
- TEXT - Enum constant in enum class org.apache.camel.console.DevConsole.MediaType
- TEXT - Enum constant in enum class org.apache.camel.spi.MimeType
- TEXT_PLAIN_MIME_TYPE - Static variable in interface org.apache.camel.cloudevents.CloudEvent
- ThreadPoolFactory - Interface in org.apache.camel.spi
-
Creates ExecutorService and ScheduledExecutorService objects that work with a thread pool for a given ThreadPoolProfile and ThreadFactory.
- ThreadPoolProfile - Class in org.apache.camel.spi
-
A profile which defines thread pool settings.
- ThreadPoolProfile() - Constructor for class org.apache.camel.spi.ThreadPoolProfile
-
Creates a new thread pool profile, with no id set.
- ThreadPoolProfile(String) - Constructor for class org.apache.camel.spi.ThreadPoolProfile
-
Creates a new thread pool profile
- timeout() - Element in annotation interface org.apache.camel.RecipientList
-
Sets a total timeout specified in millis, when using parallel processing.
- timeout(Exchange, int, int, long) - Method in interface org.apache.camel.AggregationStrategy
-
A timeout occurred.
- TimeoutMap<K,
V> - Interface in org.apache.camel -
Represents a map of values which timeout after a period of inactivity.
- TimeoutMap.Listener<K,
V> - Interface in org.apache.camel - TimeoutMap.Listener.Type - Enum Class in org.apache.camel
- timeoutMapEvent(TimeoutMap.Listener.Type, K, V) - Method in interface org.apache.camel.TimeoutMap.Listener
-
Callback when the map changes content
- TIMER_COUNTER - Static variable in interface org.apache.camel.Exchange
- 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
- TimerListener - Interface in org.apache.camel
-
Listener for receiving timer events.
- TIMESTAMP_FORMAT - Static variable in interface org.apache.camel.spi.BacklogTracerEventMessage
- title() - Element in annotation interface org.apache.camel.spi.Metadata
-
An optional human readable title of this entity, to be used instead of a computed title.
- title() - Element in annotation interface org.apache.camel.spi.UriEndpoint
-
A human-readable title of this entity, such as the component name of the this endpoint.
- to(String) - Method in interface org.apache.camel.FluentProducerTemplate
-
Endpoint to send to
- to(Endpoint) - Method in interface org.apache.camel.FluentProducerTemplate
-
Endpoint to send to
- to(EndpointProducerResolver) - Method in interface org.apache.camel.FluentProducerTemplate
-
Endpoint to send to
- TO_ENDPOINT - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- TO_ENDPOINT - Static variable in interface org.apache.camel.Exchange
- toF(String, Object...) - Method in interface org.apache.camel.FluentProducerTemplate
-
Endpoint to send to.
- toJSon(int) - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Dumps the event message as JSon.
- tokenize(Exchange) - Method in interface org.apache.camel.spi.Tokenizer
-
Tokenizes the data in the provided Exchange using the current configuration options.
- Tokenizer - Interface in org.apache.camel.spi
-
An interface for tokenizing text data.
- Tokenizer - Annotation Interface in org.apache.camel.spi.annotations
- Tokenizer.Configuration - Interface in org.apache.camel.spi
-
A nested interface representing the configuration options for this tokenizer.
- toString() - Method in class org.apache.camel.health.HealthCheckResultBuilder
- toString() - Method in class org.apache.camel.spi.CamelLogger
- toString() - Method in class org.apache.camel.spi.Contract
- toString() - Method in class org.apache.camel.spi.DataType
- toString() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Returns a string representation of this record class.
- toString() - Method in record class org.apache.camel.spi.RestClientRequestValidator.ValidationError
-
Returns a string representation of this record class.
- toString() - Method in class org.apache.camel.spi.ThreadPoolProfile
- toString() - Method in class org.apache.camel.spi.Transformer
- toString() - Method in class org.apache.camel.spi.TransformerKey
- toString() - Method in class org.apache.camel.spi.TypeConvertible
- toString() - Method in class org.apache.camel.spi.Validator
- toString() - Method in class org.apache.camel.spi.ValidatorKey
- toString() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextDecorator
- toString() - Method in class org.apache.camel.support.jsse.CipherSuitesParameters
- toString() - Method in class org.apache.camel.support.jsse.FilterParameters.Patterns
- toString() - Method in class org.apache.camel.support.jsse.FilterParameters
- toString() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
- toString() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
- toString() - Method in class org.apache.camel.support.jsse.SecureRandomParameters
- toString() - Method in class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
- toString() - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
- toString() - Method in class org.apache.camel.support.jsse.SSLContextParameters
- toString() - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
- toString() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
- toType() - Element in annotation interface org.apache.camel.spi.DataTypeTransformer
-
Data type representing the result of the transformation.
- toXml(int) - Method in interface org.apache.camel.spi.BacklogTracerEventMessage
-
Dumps the event message as XML using the
BacklogTracerEventMessage.ROOT_TAG
as root tag. - TRACE - Enum constant in enum class org.apache.camel.LoggingLevel
- TRACE_EVENT - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- TRACE_EVENT_EXCHANGE - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- TRACE_EVENT_NODE_ID - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- TRACE_EVENT_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- Traceable - Interface in org.apache.camel
-
Traceable processors allowing easier tracing using constructed labels to help identify the processor and where it's defined in the route model.
- traceAfterNode(NamedNode, Exchange) - Method in interface org.apache.camel.spi.Tracer
-
Trace after the given node
- traceAfterRoute(NamedRoute, Exchange) - Method in interface org.apache.camel.spi.Tracer
-
Trace after the route (eg output from route)
- traceBeforeNode(NamedNode, Exchange) - Method in interface org.apache.camel.spi.Tracer
-
Trace before the given node
- traceBeforeRoute(NamedRoute, Exchange) - Method in interface org.apache.camel.spi.Tracer
-
Trace before the route (eg input to route)
- Tracer - Interface in org.apache.camel.spi
-
SPI for tracing messages.
- traceSentNode(NamedNode, Exchange, Endpoint, long) - Method in interface org.apache.camel.spi.Tracer
-
Trace when an Exchange was sent to a given endpoint
- TRACING_HEADER_FORMAT - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- TRACING_OUTPUT_FORMAT - Static variable in interface org.apache.camel.Exchange
-
Deprecated.
- TransactedPolicy - Interface in org.apache.camel.spi
-
A marker for defining the policy to be used for applying transaction to routes.
- TRANSACTION_CONTEXT_DATA - Static variable in interface org.apache.camel.Exchange
- TRANSFER_ENCODING - Static variable in interface org.apache.camel.Exchange
- transform(Message, DataType, DataType) - Method in class org.apache.camel.spi.Transformer
-
Perform data transformation with specified from/to type.
- TRANSFORMATION - Enum constant in enum class org.apache.camel.Category
- Transformer - Class in org.apache.camel.spi
-
Transformer performs message transformation according to the declared data type.
- Transformer() - Constructor for class org.apache.camel.spi.Transformer
- Transformer(String) - Constructor for class org.apache.camel.spi.Transformer
- TransformerKey - Class in org.apache.camel.spi
-
Key used in
TransformerRegistry
ininvalid reference
org.apache.camel.impl.engine.AbstractCamelContext
- TransformerKey(String) - Constructor for class org.apache.camel.spi.TransformerKey
- TransformerKey(DataType) - Constructor for class org.apache.camel.spi.TransformerKey
- TransformerKey(DataType, DataType) - Constructor for class org.apache.camel.spi.TransformerKey
- TransformerLoader - Interface in org.apache.camel.spi
-
A pluggable strategy to load data types into a
TransformerRegistry
. - TransformerRegistry - Interface in org.apache.camel.spi
-
Registry to cache transformers in memory.
- TransformerResolver<K> - Interface in org.apache.camel.spi
-
Resolves data type transformers from given transformer key.
- trustManager - Variable in class org.apache.camel.support.jsse.TrustManagersParameters
- TrustManagersParameters - Class in org.apache.camel.support.jsse
- TrustManagersParameters() - Constructor for class org.apache.camel.support.jsse.TrustManagersParameters
- TRY_ROUTE_BLOCK - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- TRY_ROUTE_BLOCK - Static variable in interface org.apache.camel.Exchange
- tryConvertTo(Class<?>, Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
-
Tries to convert the value to the specified type, returning null if not possible to convert.
- tryConvertTo(Class<T>, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
- tryConvertTo(Class<T>, Object) - Method in interface org.apache.camel.TypeConverter
-
Tries to convert the value to the specified type, returning null if not possible to convert.
- tryConvertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
- tryConvertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.TypeConverter
-
Tries to convert the value to the specified type in the context of an exchange, returning null if not possible to convert.
- trySetCamelContext(T, CamelContext) - Static method in interface org.apache.camel.CamelContextAware
-
Set the
CamelContext
context if the object is an instance ofCamelContextAware
. - trySetComponent(T, Component) - Static method in interface org.apache.camel.Component
-
Set the
Component
context if the component is an instance ofComponentAware
. - trySetLineNumberAware(T, LineNumberAware) - Static method in interface org.apache.camel.LineNumberAware
-
Set the
LineNumberAware
if the object is an instance ofLineNumberAware
. - trySetResource(T, Resource) - Static method in interface org.apache.camel.spi.ResourceAware
-
Set the
Resource
resource if the object is an instance ofResourceAware
. - type - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
- type() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- type() - Method in enum class org.apache.camel.spi.MimeType
- TYPE_FILE - Static variable in interface org.apache.camel.resume.Serializable
- TYPE_INTEGER - Static variable in interface org.apache.camel.resume.Serializable
- TYPE_LONG - Static variable in interface org.apache.camel.resume.Serializable
- TYPE_STRING - Static variable in interface org.apache.camel.resume.Serializable
- TypeConversionException - Exception Class in org.apache.camel
-
Exception when failing during type conversion.
- TypeConversionException(Object, Class<?>, Throwable) - Constructor for exception class org.apache.camel.TypeConversionException
- 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
- TypeConverterExists - Enum Class in org.apache.camel
-
What to do if attempting to add a duplicate type converter
- TypeConverterExistsException - Exception Class in org.apache.camel
-
Exception when failing to add type converters due there is already an existing type converter.
- TypeConverterExistsException(Class<?>, Class<?>) - Constructor for exception class org.apache.camel.TypeConverterExistsException
- TypeConverterLoader - Interface in org.apache.camel.spi
-
A pluggable strategy to load type converters into a
TypeConverterRegistry
from some kind of mechanism. - TypeConverterLoaderException - Exception Class in org.apache.camel
-
Exception when failing to load type converters.
- TypeConverterLoaderException(String) - Constructor for exception class org.apache.camel.TypeConverterLoaderException
- TypeConverterLoaderException(String, Throwable) - Constructor for exception class org.apache.camel.TypeConverterLoaderException
- TypeConverterRegistry - Interface in org.apache.camel.spi
-
Registry for type converters.
- TypeConverterRegistry.Statistics - Interface in org.apache.camel.spi
-
Utilization statistics of the registry.
- TypeConverters - Interface in org.apache.camel
-
A tagging interface to mark this class implements type converters using the
Converter
annotations. - TypeConvertible<F,
T> - Class in org.apache.camel.spi -
Holds a type convertible pair.
- TypeConvertible(Class<F>, Class<T>) - Constructor for class org.apache.camel.spi.TypeConvertible
-
Constructs a new type convertible pair.
- types() - Element in annotation interface org.apache.camel.spi.annotations.YamlType
U
- unbind(String) - Method in interface org.apache.camel.spi.Registry
-
Removes the bean from the repository (if possible).
- UNDEFINED_REDELIVERY - Enum constant in enum class org.apache.camel.trait.message.RedeliveryTraitPayload
-
The default redelivery payload, as most messages don't support redeliveries
- UNIT_OF_WORK_EXHAUSTED - Enum constant in enum class org.apache.camel.ExchangePropertyKey
- UNIT_OF_WORK_EXHAUSTED - Static variable in interface org.apache.camel.Exchange
- UnitOfWork - Interface in org.apache.camel.spi
-
An object representing the unit of work processing an
Exchange
which allows the use ofSynchronization
hooks. - UnitOfWorkFactory - Interface in org.apache.camel.spi
-
Factory to create
UnitOfWork
. - unknown() - Method in class org.apache.camel.health.HealthCheckResultBuilder
- UNKNOWN - Enum constant in enum class org.apache.camel.health.HealthCheck.State
- UNKNOWN_PARAMETER - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
A given parameter is not known to the component
- unmanageObject(Object) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Removes the managed object.
- unmarshal(Exchange, InputStream) - Method in interface org.apache.camel.spi.DataFormat
-
Unmarshals the given stream into an object.
- unmarshal(Exchange, Object) - Method in interface org.apache.camel.spi.DataFormat
-
Unmarshals the given body into an object.
- unregister(Object) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Unregisters a
HealthCheck
orHealthCheckRepository
. - unregister(ObjectName) - Method in interface org.apache.camel.spi.ManagementAgent
-
Unregisters object based upon registered name
- unregister(DevConsole) - Method in interface org.apache.camel.console.DevConsoleRegistry
-
Unregisters a
DevConsole
. - unscheduleTask() - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Attempts to unschedules the last task which was scheduled.
- UNSUPPORTED - Enum constant in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Result.Status
-
Verification is not supported.
- UNSUPPORTED - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
The verification is not supported
- UNSUPPORTED_COMPONENT - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
The requested
Component
is not supported - UNSUPPORTED_SCOPE - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
The requested
ComponentVerifierExtension.Scope
is not supported - unwrap(Class<T>) - Method in interface org.apache.camel.cluster.CamelClusterService
-
Access the underlying concrete CamelClusterService implementation to provide access to further features.
- unwrap(Class<T>) - Method in interface org.apache.camel.cluster.CamelClusterView
-
Access the underlying concrete CamelClusterView implementation to provide access to further features.
- unwrap(Class<T>) - Method in interface org.apache.camel.component.extension.ComponentExtension
-
Access the underlying concrete ComponentExtension implementation to provide access to further features.
- unwrap(Object) - Method in interface org.apache.camel.spi.BeanRepository
-
Strategy to wrap the value to be stored in the registry.
- up() - Method in class org.apache.camel.health.HealthCheckResultBuilder
- UP - Enum constant in enum class org.apache.camel.health.HealthCheck.State
- update(T) - Method in interface org.apache.camel.resume.Offset
-
Sets the current offset value
- updateLastOffset(OffsetKey<?>, Offset<?>) - Method in interface org.apache.camel.resume.ResumeStrategy
-
Updates the last processed offset
- updateLastOffset(OffsetKey<?>, Offset<?>, ResumeStrategy.UpdateCallBack) - Method in interface org.apache.camel.resume.ResumeStrategy
-
Updates the last processed offset
- updateLastOffset(T) - Method in interface org.apache.camel.resume.ResumeStrategy
-
Updates the last processed offset
- updateLastOffset(T, ResumeStrategy.UpdateCallBack) - Method in interface org.apache.camel.resume.ResumeStrategy
-
Updates the last processed offset
- updateRouteConfigurationsToCamelContext(CamelContext) - Method in interface org.apache.camel.RouteConfigurationsBuilder
-
Adds or updates the route configurations from this builder to the CamelContext.
- updateRoutes(Collection<Resource>) - Method in interface org.apache.camel.spi.RoutesLoader
-
Loads or updates existing
RoutesBuilder
from the give list ofResource
into the currentCamelContext
. - updateRoutes(Resource...) - Method in interface org.apache.camel.spi.RoutesLoader
-
Loads or updates existing
RoutesBuilder
from the give list ofResource
into the currentCamelContext
. - updateRoutesToCamelContext(CamelContext) - Method in interface org.apache.camel.RoutesBuilder
-
Adds or updates the routes from this Route Builder to the CamelContext.
- UriEndpoint - Annotation Interface in org.apache.camel.spi
-
Represents an annotated Camel Endpoint which can have its properties (and the properties on its consumer) injected from the Camel URI path and its query parameters
- UriFactoryResolver - Interface in org.apache.camel.spi
-
A pluggable strategy for resolving different URI factories in a loosely coupled manner.
- UriParam - Annotation Interface in org.apache.camel.spi
-
Represents an injection point of a Camel Uri parameter value on an Endpoint or Consumer, usually configured via a URI style query parameter in a URI
- UriParams - Annotation Interface in org.apache.camel.spi
-
Used to annotate a nested configuration parameter type (such as a nested Configuration object) which can then be used on a Component, Endpoint and/or Consumer and then be configured via Camel URI query arguments.
- UriPath - Annotation Interface in org.apache.camel.spi
-
Represents an injection point of a Camel Uri path value (the remaining part of a Camel URI without any query arguments)
- useRawUri() - Method in interface org.apache.camel.Component
-
Whether to use raw or encoded uri, when creating endpoints.
- UuidGenerator - Interface in org.apache.camel.spi
-
Generator to generate UUID strings.
V
- v1_0 - Enum constant in enum class org.apache.camel.cloudevents.CloudEvents
- v1_0_1 - Enum constant in enum class org.apache.camel.cloudevents.CloudEvents
- v1_0_2 - Enum constant in enum class org.apache.camel.cloudevents.CloudEvents
- validate(Exchange, RestClientRequestValidator.ValidationContext) - Method in interface org.apache.camel.spi.RestClientRequestValidator
-
Validates the incoming client request
- validate(Message, DataType) - Method in class org.apache.camel.spi.Validator
-
Perform data validation with specified type.
- validateProperties(String, Map<String, String>) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
-
Validates the properties for the given scheme against component and endpoint
- VALIDATION - Enum constant in enum class org.apache.camel.Category
- ValidationContext(String, String, boolean, Map<String, String>, Map<String, String>, Set<String>, Set<String>) - Constructor for record class org.apache.camel.spi.RestClientRequestValidator.ValidationContext
-
Creates an instance of a
ValidationContext
record class. - ValidationError(int, String) - Constructor for record class org.apache.camel.spi.RestClientRequestValidator.ValidationError
-
Creates an instance of a
ValidationError
record class. - ValidationException - Exception Class in org.apache.camel
-
The base class for any validation exception, such as
invalid reference
org.apache.camel.support.processor.validation.SchemaValidationException
- ValidationException(String, Exchange, Throwable) - Constructor for exception class org.apache.camel.ValidationException
- ValidationException(Exchange, String) - Constructor for exception class org.apache.camel.ValidationException
- Validator - Class in org.apache.camel.spi
-
Validator performs message content validation according to the declared data type.
- Validator() - Constructor for class org.apache.camel.spi.Validator
- ValidatorKey - Class in org.apache.camel.spi
-
Key used in
ValidatorRegistry
inCamelContext
, to ensure a consistent lookup. - ValidatorKey(DataType) - Constructor for class org.apache.camel.spi.ValidatorKey
- ValidatorRegistry - Interface in org.apache.camel.spi
-
Registry to cache validators in memory.
- value() - Element in annotation interface org.apache.camel.BeanConfigInject
-
Name of the root property (prefix)
- value() - Element in annotation interface org.apache.camel.BeanInject
-
Name of the bean
- value() - Element in annotation interface org.apache.camel.BindToRegistry
-
The name of the bean
- value() - Element in annotation interface org.apache.camel.Configuration
-
The name of the configuration bean
- value() - Element in annotation interface org.apache.camel.Consume
-
The uri to consume from
- value() - Element in annotation interface org.apache.camel.EndpointInject
-
The uri of the endpoint
- value() - Element in annotation interface org.apache.camel.ExchangeProperty
-
Name of the property
- value() - Element in annotation interface org.apache.camel.Header
-
Name of header
- value() - Element in annotation interface org.apache.camel.Pattern
-
Specifies the exchange pattern to be used for this method
- value() - Element in annotation interface org.apache.camel.Produce
-
The uri to produce to
- value() - Element in annotation interface org.apache.camel.PropertyInject
-
Name of the property
- value() - Element in annotation interface org.apache.camel.spi.annotations.CloudServiceFactory
- value() - Element in annotation interface org.apache.camel.spi.annotations.Component
- value() - Element in annotation interface org.apache.camel.spi.annotations.ConstantProvider
- value() - Element in annotation interface org.apache.camel.spi.annotations.Dataformat
- value() - Element in annotation interface org.apache.camel.spi.annotations.HealthCheck
-
The ID of the health check.
- value() - Element in annotation interface org.apache.camel.spi.annotations.JdkService
- value() - Element in annotation interface org.apache.camel.spi.annotations.Language
- value() - Element in annotation interface org.apache.camel.spi.annotations.PeriodicTask
- value() - Element in annotation interface org.apache.camel.spi.annotations.PropertiesFunction
- value() - Element in annotation interface org.apache.camel.spi.annotations.ResourceResolver
- value() - Element in annotation interface org.apache.camel.spi.annotations.RoutesLoader
- value() - Element in annotation interface org.apache.camel.spi.annotations.SendDynamic
- value() - Element in annotation interface org.apache.camel.spi.annotations.ServiceFactory
- value() - Element in annotation interface org.apache.camel.spi.annotations.Tokenizer
- value() - Element in annotation interface org.apache.camel.spi.InvokeOnHeader
-
Name of header.
- value() - Element in annotation interface org.apache.camel.Variable
-
Name of variable
- ValueHolder<V> - Class in org.apache.camel
-
Holder object for a given value.
- ValueHolder(V) - Constructor for class org.apache.camel.ValueHolder
- valueOf(String) - Static method in enum class org.apache.camel.BeanScope
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.Category
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.cloudevents.CloudEvents
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Result.Status
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Scope
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.console.DevConsole.MediaType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.ContextEvents
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.ExchangePattern
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.ExchangePropertyKey
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.health.HealthCheck.Kind
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.health.HealthCheck.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.LoggingLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.ManagementMBeansLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.ManagementStatisticsLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.resume.Cacheable.FillPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.ServiceStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.ShutdownRoute
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.ShutdownRunningTask
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.spi.Breakpoint.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.spi.CamelEvent.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.spi.HeaderFilterStrategy.Direction
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.spi.MimeType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.spi.RestConfiguration.RestBindingMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.spi.RestConfiguration.RestHostNameResolver
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.spi.RouteError.Phase
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.spi.StreamCachingStrategy.SpoolUsedHeapMemoryLimit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.StartupSummaryLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.support.jsse.ClientAuthentication
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.TimeoutMap.Listener.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.trait.message.MessageTrait
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.trait.message.RedeliveryTraitPayload
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.TypeConverterExists
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.WaitForTaskToComplete
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.apache.camel.BeanScope
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.Category
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.cloudevents.CloudEvents
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Result.Status
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.component.extension.ComponentVerifierExtension.Scope
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.console.DevConsole.MediaType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.ContextEvents
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.ExchangePattern
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.ExchangePropertyKey
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.health.HealthCheck.Kind
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.health.HealthCheck.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.LoggingLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.ManagementMBeansLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.ManagementStatisticsLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.resume.Cacheable.FillPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.ServiceStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.ShutdownRoute
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.ShutdownRunningTask
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- values() - Static method in enum class org.apache.camel.spi.Breakpoint.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.spi.CamelEvent.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.spi.HeaderFilterStrategy.Direction
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.spi.MimeType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.spi.RestConfiguration.RestBindingMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.spi.RestConfiguration.RestHostNameResolver
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.spi.RouteError.Phase
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.spi.StreamCachingStrategy.SpoolUsedHeapMemoryLimit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.StartupSummaryLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.support.jsse.ClientAuthentication
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.TimeoutMap.Listener.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.trait.message.MessageTrait
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.trait.message.RedeliveryTraitPayload
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.TypeConverterExists
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.WaitForTaskToComplete
-
Returns an array containing the constants of this enum class, in the order they are declared.
- Variable - Annotation Interface in org.apache.camel
-
Marks a parameter as being a variable
- VariableAware - Interface in org.apache.camel
-
An interface to represent an object that supports variables.
- VariableRepository - Interface in org.apache.camel.spi
-
Repository for storing and accessing variables.
- VariableRepositoryFactory - Interface in org.apache.camel.spi
-
Factory for
VariableRepository
. - Variables - Annotation Interface in org.apache.camel
-
Marks a parameter as being an injection point of the variables
- VaultConfiguration - Class in org.apache.camel.vault
-
Base configuration for access to Vaults.
- VaultConfiguration() - Constructor for class org.apache.camel.vault.VaultConfiguration
- Verbose - Enum constant in enum class org.apache.camel.StartupSummaryLevel
- verify(ComponentVerifierExtension.Scope, Map<String, Object>) - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension
-
Verify the given parameters against a provided scope.
- version() - Method in interface org.apache.camel.cloudevents.CloudEvent
-
The CloudEvent spec version.
- version() - Method in enum class org.apache.camel.cloudevents.CloudEvents
- VetoCamelContextStartException - Exception Class in org.apache.camel
-
An exception to veto starting
CamelContext
. - VetoCamelContextStartException(String, Throwable, CamelContext) - Constructor for exception class org.apache.camel.VetoCamelContextStartException
- VetoCamelContextStartException(String, Throwable, CamelContext, boolean) - Constructor for exception class org.apache.camel.VetoCamelContextStartException
- VetoCamelContextStartException(String, CamelContext) - Constructor for exception class org.apache.camel.VetoCamelContextStartException
- VetoCamelContextStartException(String, CamelContext, boolean) - Constructor for exception class org.apache.camel.VetoCamelContextStartException
W
- WaitForTaskToComplete - Enum Class in org.apache.camel
-
Represent the kinds of options for wait for tasks to complete.
- WANT - Enum constant in enum class org.apache.camel.support.jsse.ClientAuthentication
-
Client authentication requested.
- warmUp() - Method in interface org.apache.camel.Route
-
Callback preparing the route to be started, by warming up the route.
- WARN - Enum constant in enum class org.apache.camel.LoggingLevel
- WEBSERVICE - Enum constant in enum class org.apache.camel.Category
- withBody(Object) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the message body Important: You can either only use either withExchange, or withProcessor or a combination of withBody/withHeaders to construct the message to be sent.
- withBodyAs(Object, Class<?>) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the message body after converting it to the given type Important: You can either only use either withExchange, or withProcessor or a combination of withBody/withHeaders to construct the message to be sent.
- withCacheFillPolicy(Cacheable.FillPolicy) - Method in interface org.apache.camel.resume.ResumeStrategyConfigurationBuilder
-
Sets the
Cacheable.FillPolicy
for the cache used in the strategy - withCondition(BiPredicate<String, Component>) - Method in class org.apache.camel.spi.ComponentCustomizer.Builder
- withCondition(BiPredicate<String, DataFormat>) - Method in class org.apache.camel.spi.DataFormatCustomizer.Builder
- withCondition(BiPredicate<String, Language>) - Method in class org.apache.camel.spi.LanguageCustomizer.Builder
- withDefaultEndpoint(String) - Method in interface org.apache.camel.FluentProducerTemplate
-
Sets the default endpoint
- withDefaultEndpoint(Endpoint) - Method in interface org.apache.camel.FluentProducerTemplate
-
Sets the default endpoint
- withDefaultEndpoint(EndpointProducerResolver) - Method in interface org.apache.camel.FluentProducerTemplate
-
Sets the default endpoint
- withExchange(Supplier<Exchange>) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the exchangeSupplier which will be invoke to get the exchange to be used for send.
- withExchange(Exchange) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the exchange to use for send.
- withExchangeProperties(Map<String, Object>) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the exchange properties Important: You can either only use either withExchange, or withProcessor or a combination of withBody/withHeaders to construct the message to be sent.
- withExchangeProperty(String, Object) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the exchange property Important: You can either only use either withExchange, or withProcessor or a combination of withBody/withHeaders to construct the message to be sent.
- withHeader(String, Object) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the header Important: You can either only use either withExchange, or withProcessor or a combination of withBody/withHeaders to construct the message to be sent.
- withHeaders(Map<String, Object>) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the headers Important: You can either only use either withExchange, or withProcessor or a combination of withBody/withHeaders to construct the message to be sent.
- withOrder(int) - Method in class org.apache.camel.spi.ComponentCustomizer.Builder
- withOrder(int) - Method in class org.apache.camel.spi.DataFormatCustomizer.Builder
- withOrder(int) - Method in class org.apache.camel.spi.LanguageCustomizer.Builder
- withProcessor(Supplier<Processor>) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the processorSupplier which will be invoke to get the processor to be used for send/request.
- withProcessor(Processor) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the processor to use for send/request.
- withResumeCache(ResumeCache<?>) - Method in interface org.apache.camel.resume.ResumeStrategyConfigurationBuilder
-
Sets the local resume cache instance to use in the strategy
- withTemplateCustomizer(Consumer<ProducerTemplate>) - Method in interface org.apache.camel.FluentProducerTemplate
-
To customize the producer template for advanced usage like to set the executor service to use.
- withVariable(String, Object) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the exchange property Important: You can either only use either withExchange, or withProcessor or a combination of withBody/withHeaders to construct the message to be sent.
- withVariables(Map<String, Object>) - Method in interface org.apache.camel.FluentProducerTemplate
-
Set the variables Important: You can either only use either withExchange, or withProcessor or a combination of withBody/withHeaders to construct the message to be sent.
- WORKFLOW - Enum constant in enum class org.apache.camel.Category
- wrap(Object) - Method in interface org.apache.camel.spi.Registry
-
Strategy to wrap the value to be stored in the registry.
- wrap(Route, Processor) - Method in interface org.apache.camel.spi.Policy
-
Wraps any applicable interceptors around the given processor.
- WrapAwareProcessor - Interface in org.apache.camel.spi
-
An interface to represent an object which wraps a
Processor
. - wrapCamelExecutionException(Exchange, Throwable) - Static method in exception class org.apache.camel.CamelExecutionException
-
Wraps the caused exception in a
CamelExecutionException
if its not already such an exception. - wrapItem() - Element in annotation interface org.apache.camel.spi.annotations.YamlProperty
- WrappedFile<T> - Interface in org.apache.camel
-
Wraps a file.
- wrapProcessorInInterceptors(CamelContext, NamedNode, Processor, Processor) - Method in interface org.apache.camel.spi.InterceptStrategy
-
Give implementor an opportunity to wrap the target processor in a route.
- wrapRuntimeCamelException(Throwable) - Static method in exception class org.apache.camel.RuntimeCamelException
-
Wraps the caused exception in a
RuntimeCamelException
if its not already such an exception. - wrapRuntimeException(Throwable) - Static method in exception class org.apache.camel.RuntimeCamelException
-
Wraps the caused exception in a
RuntimeCamelException
if its not already a runtime exception. - WritableHealthCheckRepository - Interface in org.apache.camel.health
-
An interface to represent an object which wishes to be injected with the
HealthCheck
- writeTo(OutputStream) - Method in interface org.apache.camel.StreamCache
-
Writes the stream to the given output
X
- xml - Enum constant in enum class org.apache.camel.spi.RestConfiguration.RestBindingMode
- XSLT_ERROR - Static variable in interface org.apache.camel.Exchange
- XSLT_FATAL_ERROR - Static variable in interface org.apache.camel.Exchange
- XSLT_FILE_NAME - Static variable in interface org.apache.camel.Exchange
- XSLT_WARNING - Static variable in interface org.apache.camel.Exchange
Y
- YamlIn - Annotation Interface in org.apache.camel.spi.annotations
- YamlOut - Annotation Interface in org.apache.camel.spi.annotations
- YamlProperty - Annotation Interface in org.apache.camel.spi.annotations
- YamlType - Annotation Interface in org.apache.camel.spi.annotations
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form