- 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.
- acquirePollingConsumer(Endpoint) - Method in interface org.apache.camel.spi.ConsumerCache
-
- acquireProducer(Endpoint) - Method in interface org.apache.camel.spi.ProducerCache
-
- activate() - Method in interface org.apache.camel.spi.Breakpoint
-
Activates this breakpoint
- activateAllBreakpoints() - Method in interface org.apache.camel.spi.Debugger
-
Activate all breakpoints.
- adapt(Class<T>) - Method in interface org.apache.camel.CamelContext
-
- add(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.AggregationRepository
-
Add the given
Exchange
under the correlation key.
- add(String, Exchange) - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Adds the exchange to the repository.
- add(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.IdempotentRepository
-
Adds the key to the repository.
- 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.InflightRepository
-
Adds the exchange to the inflight registry associated to the given route
- add(CamelContext, String, Exchange, Exchange) - Method in interface org.apache.camel.spi.OptimisticLockingAggregationRepository
-
Add the given
Exchange
under the correlation key.
- addAdvice(CamelInternalProcessorAdvice<?>) - Method in interface org.apache.camel.spi.RouteContext
-
- addAllSniHostNames(List<String>) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
-
- 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
- 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.
- 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.runtimecatalog.EndpointValidationResult
-
- addDeprecated(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addEndpoint(String, Endpoint) - Method in interface org.apache.camel.CamelContext
-
- addErrorHandler(ErrorHandlerFactory, NamedNode) - Method in interface org.apache.camel.spi.RouteContext
-
Adds error handler for the given exception type
- addErrorHandlerFactoryReference(ErrorHandlerFactory, ErrorHandlerFactory) - Method in interface org.apache.camel.spi.RouteContext
-
Link the error handlers from a factory to another
- addEventDrivenProcessor(Processor) - Method in interface org.apache.camel.spi.RouteContext
-
Adds an event driven processor
- 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.
- 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
- addIncapable(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addInterceptStrategy(InterceptStrategy) - Method in interface org.apache.camel.ExtendedCamelContext
-
Adds the given interceptor strategy
- addInterceptStrategy(InterceptStrategy) - Method in interface org.apache.camel.spi.RouteContext
-
Adds a InterceptStrategy to this route context
- addInvalidBoolean(String, String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addInvalidEnum(String, String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addInvalidEnumChoices(String, String[]) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addInvalidEnumSuggestions(String, String[]) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addInvalidInteger(String, String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addInvalidNumber(String, String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addInvalidReference(String, String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addLenient(String) - Method in class org.apache.camel.runtimecatalog.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
-
- 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
-
- addNotConsumerOnly(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addNotProducerOnly(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addOnCompletion(Synchronization) - Method in interface org.apache.camel.Exchange
-
Adds a
Synchronization
to be invoked as callback when
this exchange is completed.
- 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.
- addProperty(String, Object) - Method in interface org.apache.camel.spi.RouteContext
-
- addRepository(HealthCheckRepository) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Add an Health Check repository.
- addRequired(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addRestConfiguration(RestConfiguration) - Method in interface org.apache.camel.CamelContext
-
Deprecated.
- addRestService(Consumer, 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.
- 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.
- 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
- addSingleStepBreakpoint(Breakpoint) - Method in interface org.apache.camel.spi.Debugger
-
Add the given breakpoint which will be used in single step mode
The debugger will single step the first message arriving.
- addSingleStepBreakpoint(Breakpoint, Condition...) - Method in interface org.apache.camel.spi.Debugger
-
Add the given breakpoint which will be used in single step mode
The debugger will single step the first message arriving.
- addSpoolRule(StreamCachingStrategy.SpoolRule) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
- addStartupListener(StartupListener) - Method in interface org.apache.camel.CamelContext
-
Adds the given listener to be invoked when
CamelContext
have just been started.
- addStateChangeListener(BiConsumer<HealthCheck.State, HealthCheck>) - Method in interface org.apache.camel.health.HealthCheckService
-
Add a listener to invoke when the state of a check change.
- addSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
-
Adds a synchronization hook
- addSyntaxError(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addTypeConverter(Class<?>, Class<?>, TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Registers a new type converter.
- addTypeConverters(TypeConverters) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Registers all the type converters from the class, each converter must be implemented as a method and annotated with
Converter
.
- addUnknown(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addUnknownComponent(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- addUnknownSuggestions(String, String[]) - Method in class org.apache.camel.runtimecatalog.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
-
- 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.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 optional work to be executed after the processing
- AfterPropertiesConfigured - Interface in org.apache.camel
-
To perform optional initialization on an element after its properties has been configured.
- afterPropertiesConfigured(CamelContext) - Method in interface org.apache.camel.AfterPropertiesConfigured
-
Callback invoked after the element have configured its properties.
- 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
Important: In the aggregate method, do not create a new exchange instance to return,
instead return either the old or new exchange from the input parameters; favor returning the old exchange whenever possible.
- 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 - Static variable in interface org.apache.camel.Exchange
-
- AGGREGATED_CORRELATION_KEY - Static variable in interface org.apache.camel.Exchange
-
- AGGREGATED_SIZE - Static variable in interface org.apache.camel.Exchange
-
- AGGREGATED_TIMEOUT - Static variable in interface org.apache.camel.Exchange
-
- 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 - Static variable in interface org.apache.camel.Exchange
-
- 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 - Interface in org.apache.camel
-
A strategy for aggregating two exchanges together into a single exchange.
- algorithm - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
-
- algorithm - Variable in class org.apache.camel.support.jsse.SecureRandomParameters
-
The Random Number Generator algorithm identifier for the
SecureRandom
factory method used to create the
SecureRandom
represented by this object's configuration.
- 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
- allowHandover() - Method in interface org.apache.camel.spi.SynchronizationVetoable
-
Whether or not handover this synchronization is allowed.
- allowNull() - Method in interface org.apache.camel.TypeConverter
-
Whether the type converter allows returning null as a valid response.
- AlreadyStoppedException - Exception in org.apache.camel
-
Exception thrown in situations when a
Service
has already been stopped.
- AlreadyStoppedException() - Constructor for exception org.apache.camel.AlreadyStoppedException
-
- AnnotationBasedProcessorFactory - Interface in org.apache.camel.spi
-
Factory to create
Processor
for annotation based EIPs.
- apiDocAsJson() - Method in interface org.apache.camel.spi.RestRegistry
-
Outputs the Rest services API documentation in JSon (requires camel-swagger-java on classpath)
- apply(List<ServiceDefinition>) - Method in interface org.apache.camel.cloud.ServiceFilter
-
Chooses one of the service to use
- apply(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceLoadBalancerFunction
-
- 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
-
- asCode(String) - Static method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
- asEndpointUri(String, Map<String, String>, boolean) - Method in interface org.apache.camel.runtimecatalog.RuntimeCamelCatalog
-
Creates an endpoint uri in Java style from the information from the properties
- asEndpointUriXml(String, Map<String, String>, boolean) - Method in interface org.apache.camel.runtimecatalog.RuntimeCamelCatalog
-
Creates an endpoint uri in XML style (eg escape & as &l;) from the information from the properties
- asEnum(String) - Static method in enum org.apache.camel.ExchangePattern
-
- assemble(MBeanServer, Object, ObjectName) - Method in interface org.apache.camel.spi.ManagementMBeanAssembler
-
- ASYNC_WAIT - Static variable in interface org.apache.camel.Exchange
-
- AsyncCallback - Interface in org.apache.camel
-
- asyncCallback(String, Exchange, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an asynchronous exchange to the given endpoint.
- asyncCallback(Endpoint, Exchange, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an asynchronous exchange to the given endpoint.
- asyncCallback(String, Processor, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an asynchronous exchange to the given endpoint using a supplied processor.
- asyncCallback(Endpoint, Processor, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an asynchronous exchange to the given endpoint using a supplied processor.
- asyncCallbackRequestBody(String, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an asynchronous body to the given endpoint.
- asyncCallbackRequestBody(Endpoint, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an asynchronous body to the given endpoint.
- asyncCallbackSendBody(String, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an asynchronous body to the given endpoint.
- asyncCallbackSendBody(Endpoint, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an asynchronous body to the given endpoint.
- 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 the
AsyncCallback
.
- 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 the 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
- 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.
- awaitTermination(ExecutorService, long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Awaits the termination of the thread pool.
- cache(Exchange) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
- cacheClass(Class<?>) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Introspects the given class.
- 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(String) - Method in interface org.apache.camel.health.HealthCheckService
-
- call(String, Map<String, Object>) - Method in interface org.apache.camel.health.HealthCheckService
-
Invokes the check identified by the given id
with the given
options
.
- callback(AsyncCallback) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the callback to be run
- CamelAuthorizationException - Exception in org.apache.camel
-
An exception thrown for either authentication or authorization errors occurring
in a Camel exchange.
- CamelAuthorizationException(String, Exchange) - Constructor for exception org.apache.camel.CamelAuthorizationException
-
- CamelAuthorizationException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.CamelAuthorizationException
-
- CamelBeanPostProcessor - Interface in org.apache.camel.spi
-
Bean post processor.
- 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.
- 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
- CamelContextNameStrategy - Interface in org.apache.camel.spi
-
- CamelContextTracker - Class in org.apache.camel.spi
-
- 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
-
- CamelEvent - Interface in org.apache.camel.spi
-
This interface is implemented by all events.
- CamelEvent.CamelContextEvent - 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.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.RouteRemovedEvent - Interface in org.apache.camel.spi
-
- CamelEvent.RouteStartedEvent - Interface in org.apache.camel.spi
-
- CamelEvent.RouteStoppedEvent - 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 in org.apache.camel.spi
-
- CamelException - Exception in org.apache.camel
-
Base class for all Camel checked exceptions typically thrown by a
Processor
- CamelException() - Constructor for exception org.apache.camel.CamelException
-
- CamelException(String) - Constructor for exception org.apache.camel.CamelException
-
- CamelException(String, Throwable) - Constructor for exception org.apache.camel.CamelException
-
- CamelException(Throwable) - Constructor for exception org.apache.camel.CamelException
-
- CamelExchangeException - Exception in org.apache.camel
-
An exception caused by a specific message
Exchange
- CamelExchangeException(String, Exchange) - Constructor for exception org.apache.camel.CamelExchangeException
-
- CamelExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.CamelExchangeException
-
- CamelExecutionException - Exception in org.apache.camel
-
Exception occurred during execution/processing of an
Exchange
.
- CamelExecutionException(String, Exchange) - Constructor for exception org.apache.camel.CamelExecutionException
-
- CamelExecutionException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.CamelExecutionException
-
- CamelInternalProcessorAdvice<T> - Interface in org.apache.camel.spi
-
An advice (before and after) to execute cross cutting functionality in the Camel routing engine.
- 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(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
-
- 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
-
- CamelUnitOfWorkException - Exception in org.apache.camel
-
A
UnitOfWork
failed with a number of caused exceptions.
- CamelUnitOfWorkException(Exchange, List<Exception>) - Constructor for exception org.apache.camel.CamelUnitOfWorkException
-
- canPreComplete() - Method in interface org.apache.camel.AggregationStrategy
-
Indicates if this aggregation strategy uses pre-completion mode.
- CatalogCamelContext - Interface in org.apache.camel
-
- Channel - Interface in org.apache.camel
-
Channel acts as a channel between
Processor
s in the route graph.
- CHARSET_NAME - Static variable in interface org.apache.camel.Exchange
-
- choose(List<ServiceDefinition>) - Method in interface org.apache.camel.cloud.ServiceChooser
-
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_STATE - Static variable in interface org.apache.camel.Exchange
-
- CircuitBreakerConstants - Interface in org.apache.camel.spi
-
- 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, web container, j2ee container and OSGi platforms.
- 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() - 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.ClaimCheckRepository
-
Clear the repository.
- clear() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
-
Clears all information.
- clear() - Method in interface org.apache.camel.spi.IdempotentRepository
-
Clear the repository.
- clear() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Clears the registry
- clearAll() - Method in interface org.apache.camel.FluentProducerTemplate
-
Remove the body and headers.
- clearBody() - Method in interface org.apache.camel.FluentProducerTemplate
-
Remove the body.
- clearCache() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Clears the introspection cache.
- clearCache() - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
Clears the internal cache.
- clearHeaders() - Method in interface org.apache.camel.FluentProducerTemplate
-
Remove the headers.
- ClientAuthentication - Enum in org.apache.camel.support.jsse
-
Represents the options for the client authentication settings of a server socket.
- clientAuthentication - Variable in class org.apache.camel.support.jsse.SSLContextServerParameters
-
The optional configuration options for server-side client-authentication requirements.
- clone() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
- 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.
- commit(Consumer, Endpoint, int) - Method in interface org.apache.camel.spi.PollingConsumerPollStrategy
-
Called when poll is completed successfully
- commit() - Method in interface org.apache.camel.spi.RouteContext
-
For completing the route creation, creating a single event driven route
for the current from endpoint with any processors required
- COMPILE_SCRIPT - Static variable in interface org.apache.camel.Exchange
-
- complete(HealthCheckConfiguration) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
-
- Component - Interface in org.apache.camel
-
- ComponentAware - Interface in org.apache.camel
-
An interface to represent an object which wishes to be injected with
a
Component
.
- ComponentCustomizer<T extends Component> - Interface in org.apache.camel.spi
-
- ComponentExtension - Interface in org.apache.camel.component.extension
-
Marker interface for component extensions.
- componentJSonSchema(String) - Method in interface org.apache.camel.runtimecatalog.RuntimeCamelCatalog
-
Returns the component information as JSon format.
- 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 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 in org.apache.camel.component.extension
-
Status of the verification
- ComponentVerifierExtension.Scope - Enum 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
- Condition - Interface in org.apache.camel.spi
-
A condition to define when a given
Exchange
matches when is being routed.
- configure(CamelContext, Object, String, Object, boolean) - Method in interface org.apache.camel.spi.GeneratedPropertyConfigurer
-
Configures the property
- configureProperties(Map<String, Object>) - Method in interface org.apache.camel.Endpoint
-
Configure properties on this endpoint.
- configureSessionContext(SSLSessionContext, String) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
- 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
-
- configureSSLEngine(SSLEngine) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
-
Configures an
SSLEngine
based on the configurers in instance.
- configureSSLServerSocketFactory(SSLServerSocketFactory) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
-
- configureSSLSocketFactory(SSLSocketFactory) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
-
- confirm(CamelContext, String) - Method in interface org.apache.camel.spi.AggregationRepository
-
Confirms the completion of the
Exchange
.
- confirm(String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Confirms the key, after the exchange has been processed successfully.
- confirm(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Confirms the key, after the exchange has been processed successfully.
- Consume - Annotation Type in org.apache.camel
-
Subscribes a method to an
Endpoint
either via its
URI or via the name of the endpoint reference
which is then resolved in a registry such as the Spring Application Context.
- Consumer - Interface in org.apache.camel
-
A consumer of message exchanges from an
Endpoint
- ConsumerCache - Interface in org.apache.camel.spi
-
- ConsumerTemplate - Interface in org.apache.camel
-
- 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(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Returns true if this repository contains the specified element.
- containsOnCompletion(Synchronization) - Method in interface org.apache.camel.Exchange
-
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_TYPE - Static variable in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
-
- CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
-
- CONTEXT - Static variable in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
-
- 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.
- Contract - Class in org.apache.camel.spi
-
A Contract which represents the input type and/or output type of the
Endpoint
or
Processor
.
- Contract() - Constructor for class org.apache.camel.spi.Contract
-
- Converter - Annotation Type in org.apache.camel
-
An annotation used to mark classes and methods to indicate code capable of
converting from a type to another type which are then auto-discovered using
the
Type
Conversion Support
- convertTo(Class<T>, Object) - Method in interface org.apache.camel.TypeConverter
-
Converts the value to the specified type
- convertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.TypeConverter
-
Converts the value to the specified type in the context of an exchange
Used when conversion requires extra information from the current
exchange (such as encoding).
- 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 class org.apache.camel.health.HealthCheckConfiguration
-
- 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
-
- 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
The returned
Message
copy will have its
Exchange
set
to the same
Exchange
instance as from the source.
- 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(CamelContext, Map<String, Object>) - Method in interface org.apache.camel.spi.ManagementStrategyFactory
-
- createApiConsumer(CamelContext, Processor, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestApiConsumerFactory
-
- createApiProcessor(CamelContext, String, String, boolean, 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
- 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, boolean) - 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.
- 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
-
- createCamelContextResumingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
- createCamelContextRoutesStartedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
- createCamelContextRoutesStartingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
- createCamelContextRoutesStoppedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
- createCamelContextRoutesStoppingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
-
- 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
-
- createCamelContextStartupFailureEvent(CamelContext, Throwable) - Method in interface org.apache.camel.spi.EventFactory
-
- 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
-
- 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
-
- createChildProcessor(RouteContext, 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.
- createConsumer(Processor) - Method in interface org.apache.camel.Endpoint
-
- 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
- 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.
- CREATED_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
-
- createDataFormat(String) - Method in interface org.apache.camel.CamelContext
-
Creates 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.
- 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(RouteContext, Processor) - Method in interface org.apache.camel.ErrorHandlerFactory
-
Creates the error handler
- createExceptionMessage(String, Exchange, Throwable) - Static method in exception 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(ExchangePattern) - Method in interface org.apache.camel.Endpoint
-
- createExchangeCompletedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
-
- createExchangeCreatedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
-
- createExchangeFailedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
-
- createExchangeFailureHandledEvent(Exchange, Processor, boolean, String) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when an
Exchange
has failed
but was handled by the Camel error handlers such as an dead letter channel, or a doTry ..
- createExchangeFailureHandlingEvent(Exchange, Processor, boolean, String) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when an
Exchange
has failed
but is being handled by the Camel error handlers such as an dead letter channel, or a doTry ..
- createExchangeRedeliveryEvent(Exchange, int) - Method in interface org.apache.camel.spi.EventFactory
-
- createExchangeSendingEvent(Exchange, Endpoint) - Method in interface org.apache.camel.spi.EventFactory
-
- createExchangeSentEvent(Exchange, Endpoint, long) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when an
Exchange
has completely been sent to the endpoint (eg after).
- createExpression(CamelContext) - Method in interface org.apache.camel.ExpressionFactory
-
Creates an expression
- createExpression(String) - Method in interface org.apache.camel.spi.Language
-
Creates an expression based on the given string input
- createFluentProducerTemplate() - Method in interface org.apache.camel.CamelContext
-
- createFluentProducerTemplate(int) - Method in interface org.apache.camel.CamelContext
-
- createId(NamedNode) - Method in interface org.apache.camel.spi.NodeIdFactory
-
Creates an id for the given model definition.
- createKeyManagers() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
- 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
-
- createMessage(Object, Class<?>) - Static method in exception org.apache.camel.NoTypeConversionAvailableException
-
Returns an error message for no type converter available.
- createMessage(Object, Class<?>, Throwable) - Static method in exception org.apache.camel.NoTypeConversionAvailableException
-
Returns an error message for no type converter available with the cause.
- createMessage(String, Exchange) - Static method in exception org.apache.camel.RuntimeExchangeException
-
- createMessage(Object, Class<?>, Throwable) - Static method in exception org.apache.camel.TypeConversionException
-
Returns an error message for type conversion failed.
- createMulticast(Collection<Processor>, ExecutorService, boolean) - Method in interface org.apache.camel.ExtendedCamelContext
-
Creates a new multicast processor which sends an exchange to all the processors.
- createPollingConsumer() - Method in interface org.apache.camel.Endpoint
-
- 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 the given string input
- createPreProcessor(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in interface org.apache.camel.spi.SendDynamicAware
-
Creates the pre
Processor
that will prepare the
Exchange
with dynamic details from the given recipient.
- createProcessor(NamedNode, Processor) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy
-
- createProcessor(String) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy
-
- createProcessor(RouteContext, NamedNode) - Method in interface org.apache.camel.spi.ProcessorFactory
-
Creates the processor.
- createProcessor(CamelContext, String, Map<String, Object>) - Method in interface org.apache.camel.spi.ProcessorFactory
-
Creates a processor by the name of the definition.
- createProducer() - Method in interface org.apache.camel.Endpoint
-
Creates a new producer which is used send messages into the endpoint
- createProducer(Endpoint) - Method in interface org.apache.camel.spi.DeferServiceFactory
-
- 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.
- 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
-
- createRouteAddedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
- createRoutePolicy(CamelContext, String, NamedNode) - Method in interface org.apache.camel.spi.RoutePolicyFactory
-
Creates a new
RoutePolicy
which will be assigned to the given route.
- createRouteRemovedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
- createRouteStartedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
- createRouteStoppedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
-
- 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, int, InetAddress) - 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) - 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
- createSocket() - 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
-
- 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
-
- 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
-
- createStepStartedEvent(Exchange, String) - Method in interface org.apache.camel.spi.EventFactory
-
Creates an
CamelEvent
when a step has been started
- createTrustManagers() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
- createUnitOfWork(Exchange) - Method in interface org.apache.camel.spi.UnitOfWorkFactory
-
- CUSTOM_ID_PROPERTY - Static variable in interface org.apache.camel.Route
-
- CUSTOM_LOG_MASK_REF - Static variable in interface org.apache.camel.spi.MaskingFormatter
-
- customize(T) - Method in interface org.apache.camel.spi.ComponentCustomizer
-
- customize(T) - Method in interface org.apache.camel.spi.DataFormatCustomizer
-
- customize(T) - Method in interface org.apache.camel.spi.LanguageCustomizer
-
- GeneratedPropertyConfigurer - Interface in org.apache.camel.spi
-
A auto generated
PropertyConfigurer
for fast configuration of Camel components & endpoints.
- generateUuid() - Method in interface org.apache.camel.spi.UuidGenerator
-
Generates a UUID string representation.
- GENERIC - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
-
- 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
This method is always invoked for any incoming exchange in the aggregator.
- get(String) - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Gets the exchange from the repository.
- get(K) - Method in interface org.apache.camel.TimeoutMap
-
Looks up the value in the map by the given key.
- get() - Method in class org.apache.camel.ValueHolder
-
- 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.
- 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
-
- getAndRemove(String) - Method in interface org.apache.camel.spi.ClaimCheckRepository
-
Gets and removes the exchange from the repository.
- getAnnotationBasedProcessorFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
- 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)
- getApiContextIdPattern() - Method in class org.apache.camel.spi.RestConfiguration
-
- 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
- getAsyncProcessorAwaitManager() - Method in interface org.apache.camel.ExtendedCamelContext
-
- getAtRouteId() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
The id of the route where the exchange currently is being processed
Is
null if message history is disabled.
- 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
-
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
-
- 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
- getBeanIntrospection() - Method in interface org.apache.camel.ExtendedCamelContext
-
- getBeanPostProcessor() - Method in interface org.apache.camel.ExtendedCamelContext
-
Returns the bean post processor used to do any bean customization.
- getBeanProcessorFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
- getBeanProxyFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
- getBefore() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
-
The processor for routing in a detour before sending to the original endpoint.
- getBindingMode() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the binding mode used by the REST consumer
- 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
The body can be
null if no body is set.
- getBody(Class<T>) - Method in interface org.apache.camel.Message
-
Returns the body as the specified type
Notice if the message body is stream based then calling this method multiple times may lead to the stream not being able to be re-read again.
- getBody() - Method in interface org.apache.camel.WrappedFile
-
Gets the content of the file.
- 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
-
- getCachedClassesCounter() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Number of classes in the introspection cache.
- 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.CamelContextAware
-
- getCamelContext() - Method in interface org.apache.camel.ConsumerTemplate
-
- getCamelContext() - Method in interface org.apache.camel.Endpoint
-
Returns the context which created the endpoint
- getCamelContext() - Method in interface org.apache.camel.FluentProducerTemplate
-
- getCamelContext() - Method in interface org.apache.camel.ProducerTemplate
-
- 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 interface org.apache.camel.spi.RouteContext
-
Gets 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
-
- getCapacity() - Method in interface org.apache.camel.spi.ConsumerCache
-
- 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 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
-
- getCheck(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
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.
- 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
-
- getClientParameters() - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
- getClusterService() - Method in interface org.apache.camel.cluster.CamelClusterView
-
- getCode() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
- 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.
- getComponent() - Method in interface org.apache.camel.ComponentAware
-
- getComponent(Class<T>) - Method in interface org.apache.camel.ComponentAware
-
- getComponent() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the name of the Camel component to use as the REST consumer
- getComponentJSonSchema(String) - Method in interface org.apache.camel.runtimecatalog.JSonSchemaResolver
-
Returns the component information as JSon format.
- 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
-
- getConfiguration() - Method in interface org.apache.camel.health.HealthCheck
-
Return the configuration associated with this
HealthCheck
.
- getConnectorPort() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets the port clients must use to connect
- getConsumer() - Method in interface org.apache.camel.Route
-
- getConsumer() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the consumer of the REST service
- 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
- 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 org.apache.camel.VetoCamelContextStartException
-
- getContextPath() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the configured context-path
- 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.
- getCreateConnector() - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether connector is created, allowing clients to connect remotely
- getCreated() - Method in interface org.apache.camel.Exchange
-
Gets the timestamp when this exchange was 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.runtimecatalog.JSonSchemaResolver
-
Returns the data format information as JSon format.
- getDataFormatName() - Method in interface org.apache.camel.spi.DataFormatName
-
The name of the data format
- 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
- getDataFormatResolver() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the current data format resolver
- getDataType() - Method in interface org.apache.camel.spi.DataTypeAware
-
Get the data type of the message.
- getDeadLetterUri() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureEvent
-
- getDeadLetterUri() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Gets the dead letter channel
- getDebugger() - Method in interface org.apache.camel.CamelContext
-
- 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
-
- 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
- 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.runtimecatalog.EndpointValidationResult
-
- getDeferServiceFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
- getDelayer() - Method in interface org.apache.camel.RuntimeConfiguration
-
Gets the delay value
- getDelegate() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
-
- getDelegate() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
-
- getDelegate() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
-
- getDeprecated() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- 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.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.
- 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(ComponentVerifierExtension.VerificationError.Attribute) - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
Get a single detail for a given attribute
- getDetail(String) - 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
-
An key/value combination of details.
- getDirection() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
-
Whether the endpoint is used as input our output
The returned value can either be
in or
out
- getDuration() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
-
The duration in millis the exchange has been inflight
- 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.InflightRepository.InflightExchange
-
The elapsed time in millis processing the exchange at the current node
- getEndpoint(String) - 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(String, Class<T>) - Method in interface org.apache.camel.CamelContext
-
Resolves the given name to an
Endpoint
of the specified type.
- getEndpoint() - Method in interface org.apache.camel.cloud.ServiceHealth
-
The health enpoint exposed by the service.
- getEndpoint() - Method in interface org.apache.camel.DelegateEndpoint
-
- getEndpoint() - Method in interface org.apache.camel.EndpointAware
-
Gets the endpoint associated with an object.
- getEndpoint() - Method in exception org.apache.camel.ProxyInstantiationException
-
- getEndpoint() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSendingEvent
-
- getEndpoint() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSentEvent
-
- getEndpointKey() - Method in interface org.apache.camel.Endpoint
-
Returns a string key of this endpoint.
- getEndpointMap() - Method in interface org.apache.camel.CamelContext
-
- getEndpointProperties() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets additional options on endpoint level
- getEndpointPropertyConfigurer() - Method in interface org.apache.camel.Component
-
- getEndpointRegistry() - Method in interface org.apache.camel.CamelContext
-
- getEndpointRuntimeStatisticsEnabled() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets whether endpoint runtime statistics is enabled
- getEndpoints() - Method in interface org.apache.camel.CamelContext
-
- 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
- getEndpointUrl() - Method in interface org.apache.camel.NamedRoute
-
Gets the route endpoint url.
- getEndpointUtilizationStatistics() - Method in interface org.apache.camel.spi.ConsumerCache
-
- getEndpointUtilizationStatistics() - Method in interface org.apache.camel.spi.ProducerCache
-
Gets the endpoint statistics
- getEnumChoices(String) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- 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.
- getError() - Method in class org.apache.camel.runtimecatalog.LanguageValidationResult
-
- getErrorHandler() - Method in interface org.apache.camel.Channel
-
Gets the org.apache.camel.processor.ErrorHandler
this Channel uses.
- getErrorHandlerExecutorService() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the default shared thread pool for error handlers which
leverages this for asynchronous redelivery tasks.
- 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.spi.RouteContext
-
- getErrorHandlers(ErrorHandlerFactory) - Method in interface org.apache.camel.spi.RouteContext
-
Gets the error handlers
- getErrors() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.Result
-
Collection of errors happened for the verification.
- getEventFactory() - Method in interface org.apache.camel.spi.ManagementStrategy
-
Gets the event factory
- getEventNotifiers() - Method in interface org.apache.camel.spi.ManagementStrategy
-
Gets the event notifiers.
- getEvicted() - Method in interface org.apache.camel.spi.ConsumerCache
-
- getEvicted() - Method in interface org.apache.camel.spi.ProducerCache
-
Gets the cache evicted statistic
Will return
-1 if it cannot determine this if a custom cache was used.
- getException() - Method in interface org.apache.camel.Exchange
-
Returns the exception associated with this exchange
- getException(Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns the exception associated with this exchange.
- getException() - Method in interface org.apache.camel.spi.RouteError
-
Gets the error.
- getExceptionMessage(Throwable) - Static method in exception org.apache.camel.FailedToCreateRouteException
-
- getExchange() - Method in exception org.apache.camel.CamelExchangeException
-
Returns the exchange which caused the exception
- getExchange() - Method in exception org.apache.camel.ExpectedBodyTypeException
-
- getExchange() - Method in exception org.apache.camel.ExpressionEvaluationException
-
- getExchange() - Method in interface org.apache.camel.Message
-
Returns the exchange this message is related to
- getExchange() - Method in exception org.apache.camel.RuntimeExchangeException
-
Returns the exchange which caused the exception
Can be
null
- 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
- 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)
- 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.
- 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.
- getExcludes() - Method in class org.apache.camel.support.jsse.FilterParameters.Patterns
-
- getExecutorService() - Method in interface org.apache.camel.ExecutorServiceAware
-
Gets the executor service
- getExecutorServiceManager() - Method in interface org.apache.camel.CamelContext
-
- getExecutorServiceRef() - Method in interface org.apache.camel.ExecutorServiceAware
-
Gets the reference to lookup in the
Registry
for the executor service to be used.
- getExpectedBodyType() - Method in exception org.apache.camel.ExpectedBodyTypeException
-
- getExpression() - Method in exception org.apache.camel.ExpressionEvaluationException
-
- getExpression() - Method in exception org.apache.camel.ExpressionIllegalSyntaxException
-
- 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.CamelContext
-
Gets the extension of the given type.
- 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
- getFactoryFinderResolver() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the factory finder resolver to use
- 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
-
- getFailureThreshold() - Method in class org.apache.camel.health.HealthCheckConfiguration
-
- getFile() - Method in interface org.apache.camel.WrappedFile
-
Gets the file.
- getFrom() - Method in class org.apache.camel.spi.Transformer
-
Get 'from' data type.
- getFromEndpoint() - Method in interface org.apache.camel.Exchange
-
Returns the endpoint which originated this message exchange if a consumer on an endpoint
created the message exchange, otherwise this property will be null
- 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 this 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 org.apache.camel.NoTypeConversionAvailableException
-
Returns the required from type.
- getFromType() - Method in exception org.apache.camel.TypeConversionException
-
Returns the required from type.
- getFromType() - Method in exception org.apache.camel.TypeConverterExistsException
-
- 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
Important: This has nothing to do with property placeholders, and is just a plain set of key/value pairs
which are used to configure global options on CamelContext, such as a maximum debug logging length etc.
- getGlobalOptions() - Method in interface org.apache.camel.CamelContext
-
Gets global options that can be referenced in the camel context.
- getGroup(HealthCheck) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Get the group of the given check or an empty string if the group is not set.
- getGroup() - Method in interface org.apache.camel.Route
-
Gets the route group
- getGroup() - Method in interface org.apache.camel.spi.HasGroup
-
Returns the group
- getHeader(String) - Method in interface org.apache.camel.Message
-
Accesses a specific header
- getHeader(String, Object) - Method in interface org.apache.camel.Message
-
Accesses a specific header
- getHeader(String, Supplier<Object>) - 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, 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>, 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 org.apache.camel.NoSuchHeaderException
-
- getHeaders() - Method in interface org.apache.camel.Message
-
Returns all of the headers associated with the message.
- getHeadersMapFactory() - Method in interface org.apache.camel.CamelContext
-
- getHealth() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Gets the health.
- getHitCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Number of successful conversions
- getHits() - Method in interface org.apache.camel.spi.ConsumerCache
-
- getHits() - Method in interface org.apache.camel.spi.ProducerCache
-
Gets the cache hits statistic
Will return
-1 if it cannot determine this if a custom cache was used.
- getHits() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
-
- getHost() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
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
- getHostNameResolver() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the resolver to use for resolving hostname
- getId() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Gets the service id.
- 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.UnitOfWork
-
Returns the unique ID of this unit of work, lazily creating one if it does not yet have one
- 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.runtimecatalog.EndpointValidationResult
-
- 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.
- getIncludes() - Method in class org.apache.camel.support.jsse.FilterParameters.Patterns
-
- getIndex() - Method in class org.apache.camel.runtimecatalog.LanguageValidationResult
-
- getInflightRepository() - Method in interface org.apache.camel.CamelContext
-
Gets the inflight repository
- 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
- getInputs() - Method in interface org.apache.camel.spi.RouteStartupOrder
-
Gets the input to this route (often only one consumer)
- 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.spi.RouteContext
-
This method retrieves the InterceptStrategy instances this route context.
- getInterval() - Method in class org.apache.camel.health.HealthCheckConfiguration
-
- getInType() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Optional detail about input binding to a FQN class name.
- getInvalidBoolean() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getInvalidEnum() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getInvalidEnumChoices() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getInvalidInteger() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getInvalidNumber() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getInvalidReference() - Method in class org.apache.camel.runtimecatalog.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.
- getJSonSchemaResolver() - Method in interface org.apache.camel.runtimecatalog.RuntimeCamelCatalog
-
- 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
-
- 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 org.apache.camel.NoSuchLanguageException
-
- getLanguageJSonSchema(String) - Method in interface org.apache.camel.runtimecatalog.JSonSchemaResolver
-
Returns the language information as JSon format.
- getLanguageNames() - Method in interface org.apache.camel.CamelContext
-
- 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.spi.RouteContext
-
Gets the last error.
- 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.runtimecatalog.EndpointValidationResult
-
- getLenientProperties() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
-
- getLevel() - Method in class org.apache.camel.spi.CamelLogger
-
- 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.
- getLoadStatisticsEnabled() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets whether load statistics is enabled
- getLocalMember() - Method in interface org.apache.camel.cluster.CamelClusterView
-
Provides the local member.
- 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.BeanIntrospection
-
Logging level used for logging introspection usage.
- getLogListeners() - Method in interface org.apache.camel.ExtendedCamelContext
-
- getManagedObjectForCamelContext(CamelContext) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
-
- getManagedObjectForCamelHealth(CamelContext) - 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
-
- getManagedObjectForErrorHandler(CamelContext, RouteContext, Processor, ErrorHandlerFactory) - 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) - 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.spi.RouteContext
-
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
-
- 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
Notice if the message body is stream based then calling this method multiple times may lead to the stream not being able to be re-read again.
- getMandatoryBody(Class<T>) - Method in interface org.apache.camel.Message
-
Returns the mandatory body as the specified type
Notice if the message body is stream based then calling this method multiple times may lead to the stream not being able to be re-read again.
- 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.
- 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
- 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(Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns the current message as the given type
- 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 org.apache.camel.PropertyBindingException
-
- getMessageHistoryFactory() - Method in interface org.apache.camel.CamelContext
-
- getMessageId() - Method in interface org.apache.camel.Message
-
Returns the id of the message
- getMetadata() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
Gets a key/value metadata associated with the service.
- getMetadata() - Method in interface org.apache.camel.cloud.ServiceHealth
-
Gets a key/value metadata associated with the service.
- getMetaData() - Method in interface org.apache.camel.health.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
- getMisses() - Method in interface org.apache.camel.spi.ConsumerCache
-
- getMisses() - Method in interface org.apache.camel.spi.ProducerCache
-
Gets the cache misses statistic
Will return
-1 if it cannot determine this if a custom cache was used.
- getModel() - Method in class org.apache.camel.spi.DataType
-
- getModel() - Method in class org.apache.camel.spi.Transformer
-
Get a data model which is supported by this transformer.
- getModelJAXBContextFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
Returns the JAXB Context factory used to create Models.
- getModelJSonSchema(String) - Method in interface org.apache.camel.runtimecatalog.JSonSchemaResolver
-
Returns the model information as JSon format.
- getName() - Method in interface org.apache.camel.CamelContext
-
Gets the name (id) of the this CamelContext.
- getName() - Method in interface org.apache.camel.cloud.ServiceDefinition
-
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 exception org.apache.camel.NoSuchBeanException
-
- getName() - Method in interface org.apache.camel.spi.CamelContextNameStrategy
-
- getName() - Method in class org.apache.camel.spi.DataType
-
- getName() - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
- getName() - Method in interface org.apache.camel.spi.PropertiesSource
-
Name of properties source
- 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
Is
null if message history is disabled.
- getNodeIdFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
Gets the node id factory
- getNodePattern() - Method in interface org.apache.camel.spi.MessageHistoryFactory
-
- 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.runtimecatalog.EndpointValidationResult
-
- getNotProducerOnly() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getNumberOfErrors() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getNumberOfWarnings() - Method in class org.apache.camel.runtimecatalog.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
-
- getObjectNameForErrorHandler(RouteContext, Processor, ErrorHandlerFactory) - 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) - 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
-
- getOnCompletion(String) - Method in interface org.apache.camel.spi.RouteContext
-
- getOnException(String) - Method in interface org.apache.camel.spi.RouteContext
-
- 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 org.apache.camel.PropertyBindingException
-
- getOptionPrefix() - Method in exception org.apache.camel.PropertyBindingException
-
- getOrder() - Method in interface org.apache.camel.cloud.ServiceRegistry
-
- 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.
- 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.runtimecatalog.JSonSchemaResolver
-
Returns the other (miscellaneous) information as JSon format.
- getOut() - Method in interface org.apache.camel.Exchange
-
- getOut(Class<T>) - Method in interface org.apache.camel.Exchange
-
- getOutput() - Method in interface org.apache.camel.Channel
-
Gets the wrapped output that at runtime should be delegated to.
- 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 org.apache.camel.InvalidPropertyException
-
- getPackageScanClassResolver() - Method in interface org.apache.camel.ExtendedCamelContext
-
Returns the package scanning class resolver
- getPackageScanResourceResolver() - Method in interface org.apache.camel.ExtendedCamelContext
-
Returns the package scanning resource resolver
- getParameterKeys() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
-
A set of input parameter names which fails the verification.
- getParent() - Method in interface org.apache.camel.NamedNode
-
Returns the parent
- getPassword() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
- getPattern() - Method in interface org.apache.camel.Exchange
-
- getPattern(List<String>) - Method in class org.apache.camel.support.jsse.FilterParameters
-
Compiles Pattern
s for each expression in patternStrings
.
- 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.
- 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.
- getPolicyId() - Method in exception org.apache.camel.CamelAuthorizationException
-
- 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
-
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
- getPrivateKey(String) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
-
- 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
- getProcessor() - Method in interface org.apache.camel.Consumer
-
- getProcessor() - Method in interface org.apache.camel.DelegateProcessor
-
- getProcessor() - Method in interface org.apache.camel.Route
-
- getProcessorDefinition() - Method in interface org.apache.camel.Channel
-
Gets the definition of the next processor
- getProcessorFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
- 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
- getProperties() - Method in interface org.apache.camel.Exchange
-
Returns all of 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(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.
- getProperties() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
-
- getPropertiesComponent() - Method in interface org.apache.camel.CamelContext
-
Returns the configured properties component or create one if none has been configured.
- getProperty(String) - Method in interface org.apache.camel.Exchange
-
Returns a property associated with this exchange by name
- getProperty(String, Object) - Method in interface org.apache.camel.Exchange
-
Returns a property associated with this exchange by name
- getProperty(String, Class<T>) - Method in interface org.apache.camel.Exchange
-
Returns a property associated with this exchange by name and specifying
the type required
- getProperty(String, 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) - Method in interface org.apache.camel.spi.PropertiesSource
-
Gets the property with the name
- 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 org.apache.camel.InvalidPropertyException
-
- getPropertyName() - Method in exception org.apache.camel.NoSuchPropertyException
-
- getPropertyName() - Method in exception org.apache.camel.PropertyBindingException
-
- 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
-
- getReactiveExecutor() - Method in interface org.apache.camel.CamelContext
-
- getReadPropertyPlaceholderOptions(CamelContext) - Method in interface org.apache.camel.spi.PropertyPlaceholderConfigurer
-
Gets the options which supports property placeholders and can be resolved.
- getRecoveryIntervalInMillis() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Gets the interval between recovery scans in millis.
- 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
This option is default
true.
- 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(Class<T>) - Method in interface org.apache.camel.CamelContext
-
Returns the registry used to lookup components by name and as the given type
- getRegistryPort() - Method in interface org.apache.camel.spi.ManagementAgent
-
- 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.
- getRepositories() - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Get a collection of health check repositories.
- getRequired() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getResource() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
- getResourcePath() - Method in interface org.apache.camel.spi.FactoryFinder
-
Gets the resource classpath.
- getRestConfiguration() - Method in interface org.apache.camel.CamelContext
-
Gets the default REST configuration
- getRestConfiguration(String, boolean) - Method in interface org.apache.camel.CamelContext
-
Gets the REST configuration for the given component
- getRestConfigurations() - Method in interface org.apache.camel.CamelContext
-
Deprecated.
- getRestRegistry() - Method in interface org.apache.camel.CamelContext
-
- getResults() - Method in interface org.apache.camel.health.HealthCheckService
-
Return a list of the known checks status.
- getResultType() - Method in interface org.apache.camel.spi.ExpressionResultTypeAware
-
Gets the result type
- getRight() - Method in interface org.apache.camel.BinaryPredicate
-
Gets the right hand side expression
- getRoute(String) - Method in interface org.apache.camel.CamelContext
-
Gets the route with the given id
- getRoute() - Method in interface org.apache.camel.RouteAware
-
- getRoute() - Method in interface org.apache.camel.spi.CamelEvent.RouteEvent
-
- getRoute() - Method in interface org.apache.camel.spi.RouteContext
-
Get the route type
- getRoute() - Method in interface org.apache.camel.spi.RouteStartupOrder
-
Gets the route
- getRouteContext() - Method in interface org.apache.camel.Channel
-
- getRouteContext() - Method in interface org.apache.camel.Route
-
Gets the route context
- getRouteContext() - Method in interface org.apache.camel.spi.UnitOfWork
-
- getRouteController() - Method in interface org.apache.camel.CamelContext
-
- getRouteController() - Method in interface org.apache.camel.spi.RouteContext
-
- getRouteId() - Method in exception org.apache.camel.FailedToCreateRouteException
-
- getRouteId() - Method in exception 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.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.RestRegistry.RestService
-
Gets the id of the route this rest service will be using.
- getRouteId() - Method in interface org.apache.camel.spi.RouteContext
-
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 org.apache.camel.FailedToCreateRouteException
-
- getRoutePolicyFactories() - Method in interface org.apache.camel.CamelContext
-
Gets the route policy factories
- getRoutePolicyList() - Method in interface org.apache.camel.spi.RouteContext
-
Gets the route policy List
- getRoutes() - Method in interface org.apache.camel.CamelContext
-
Returns the current 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
- getRuntimeEndpointRegistry() - Method in interface org.apache.camel.CamelContext
-
- 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
- getScope() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.Result
-
Scope of the verification.
- 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
-
- getService() - Method in interface org.apache.camel.spi.CamelEvent.ServiceEvent
-
- getServiceChooser() - Method in interface org.apache.camel.cloud.ServiceChooserAware
-
- getServiceDiscovery() - Method in interface org.apache.camel.cloud.ServiceDiscoveryAware
-
- getServiceFilter() - Method in interface org.apache.camel.cloud.ServiceFilterAware
-
- getServiceProperties() - Method in interface org.apache.camel.cloud.DiscoverableService
-
Get the service properties.
- getServices(String) - Method in interface org.apache.camel.cloud.ServiceDiscovery
-
Gets the list of services.
- 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.
- getServiceUrlPath() - Method in interface org.apache.camel.spi.ManagementAgent
-
Gets the service url
- getSessionTimeout() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
- getShortError() - Method in class org.apache.camel.runtimecatalog.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
-
- 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
- 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
-
- getSource() - Method in interface org.apache.camel.spi.ProducerCache
-
Gets the source which uses this cache
- 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
-
- 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
-
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.SSLContextParameters
-
- getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
-
Returns the list of configurers to apply to an
SSLEngine
in order
to fully configure it in compliance with the provided configuration options.
- 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.
- getStartupOrder() - Method in interface org.apache.camel.spi.RouteContext
-
- getStartupOrder() - Method in interface org.apache.camel.spi.RouteStartupOrder
-
Get the order this route should be started.
- 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.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.CamelContext
-
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.ServiceSupport
-
- getStepId() - Method in interface org.apache.camel.spi.CamelEvent.StepEvent
-
- getStreamCachingStrategy() - Method in interface org.apache.camel.CamelContext
-
- getSupportedCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
-
- getSupportedCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
-
- getSupportedExtensions() - Method in interface org.apache.camel.Component
-
Gets a list of supported extensions.
- getSyntaxError() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getTarget() - Method in exception org.apache.camel.PropertyBindingException
-
- getterOrSetterShorthandName - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
-
- getText() - Method in class org.apache.camel.runtimecatalog.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
-
- getThreadPoolProfile(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Gets the thread pool profile by the given id
- 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 timestamp at the point of this history.
- getTimeout() - Method in exception org.apache.camel.ExchangeTimedOutException
-
Return the timeout which expired in milliseconds
- getTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Gets the timeout.
- 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.
- getTotalDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
The total duration time in millis.
- getToType() - Method in exception org.apache.camel.NoTypeConversionAvailableException
-
Returns the required to type
- getToType() - Method in exception org.apache.camel.TypeConversionException
-
Returns the required to type
- getToType() - Method in exception org.apache.camel.TypeConverterExistsException
-
- getTraceCounter() - Method in interface org.apache.camel.spi.Tracer
-
Number of traced 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.Tracer
-
Tracing pattern to match which node EIPs to trace.
- getTracer() - Method in interface org.apache.camel.CamelContext
-
- getTracingPattern() - Method in interface org.apache.camel.RuntimeConfiguration
-
Tracing pattern to match which node EIPs to trace.
- getTransformerRegistry() - Method in interface org.apache.camel.CamelContext
-
- getTrustManager() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
- getTrustManagers() - Method in class org.apache.camel.support.jsse.SSLContextParameters
-
- getType() - Method in exception org.apache.camel.InvalidPayloadException
-
The expected type of the body
- getType() - Method in exception org.apache.camel.InvalidPayloadRuntimeException
-
The expected type of the body
- getType() - Method in exception org.apache.camel.NoSuchHeaderException
-
- getType() - Method in exception org.apache.camel.NoSuchPropertyException
-
- getType() - Method in exception org.apache.camel.ProxyInstantiationException
-
- 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.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.RouteRemovedEvent
-
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteStartedEvent
-
- getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteStoppedEvent
-
- 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.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
- 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
- getUnitOfWorkFactory() - Method in interface org.apache.camel.ExtendedCamelContext
-
- getUnknown() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getUnknownComponent() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getUnknownSuggestions() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getUptime() - Method in interface org.apache.camel.CamelContext
-
Gets the uptime in a human readable format
- getUptime() - Method in interface org.apache.camel.Route
-
Gets the uptime in a human readable format
- getUptimeMillis() - Method in interface org.apache.camel.CamelContext
-
Gets the uptime in milli seconds
- getUptimeMillis() - Method in interface org.apache.camel.Route
-
Gets the uptime in milliseconds
- getUri() - Method in exception org.apache.camel.FailedToCreateConsumerException
-
- getUri() - Method in exception org.apache.camel.FailedToCreateProducerException
-
- getUri() - Method in exception org.apache.camel.NoFactoryAvailableException
-
- getUri() - Method in exception org.apache.camel.NoSuchEndpointException
-
- getUri() - Method in exception org.apache.camel.ResolveEndpointFailedException
-
- getUri() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- getUri() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
-
The endpoint uri
- getUri() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
-
- getUriTemplate() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the uri template
- getUrl() - Method in exception org.apache.camel.LoadPropertiesException
-
- getUrl() - Method in interface org.apache.camel.spi.RestRegistry.RestService
-
Gets the absolute url to the REST service (baseUrl + uriTemplate)
- 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
-
- getValidatorRegistry() - Method in interface org.apache.camel.CamelContext
-
- getValue() - Method in exception org.apache.camel.NoTypeConversionAvailableException
-
Returns the value which could not be converted
- getValue() - Method in exception org.apache.camel.PropertyBindingException
-
- getValue() - Method in exception org.apache.camel.TypeConversionException
-
Returns the value which could not be converted
- 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.
- getWaitDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
-
Time in millis the thread has been blocked waiting for the signal.
- getWritePropertyPlaceholderOptions(CamelContext) - Method in interface org.apache.camel.spi.PropertyPlaceholderConfigurer
-
To update an existing property using the function with the key/value and returning the changed value
This will be all the string based options.
- getXmlDataFormat() - Method in class org.apache.camel.spi.RestConfiguration
-
Gets the name of the xml data format.
- 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
of SSLContextParameters
to be used in Camel registry.
- 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 - Static variable in interface org.apache.camel.Exchange
-
- 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
-
- 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
- include - Variable in class org.apache.camel.support.jsse.FilterParameters
-
- 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.
- init() - Method in interface org.apache.camel.Service
-
Initialize the service
- init() - Method in class org.apache.camel.support.service.ServiceSupport
-
- INITIALIZED - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- initService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Initializes the given
value
if it's a
Service
or a collection of it.
- 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 CDI to perform dependency injection.
- inMemory() - Method in interface org.apache.camel.StreamCache
-
Whether this
StreamCache
is in memory only or
spooled to persistent storage such as files.
- InOnly - Annotation Type in org.apache.camel
-
- InOut - Annotation Type in org.apache.camel
-
- INTERCEPT_SEND_TO_ENDPOINT_WHEN_MATCHED - Static variable in interface org.apache.camel.Exchange
-
- INTERCEPTED_ENDPOINT - Static variable in interface org.apache.camel.Exchange
-
- 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
- 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
-
- interval(Duration) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
-
- interval(Long) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
-
- interval(String) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
-
- InvalidPayloadException - Exception 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 org.apache.camel.InvalidPayloadException
-
- InvalidPayloadException(Exchange, Class<?>, Message) - Constructor for exception org.apache.camel.InvalidPayloadException
-
- InvalidPayloadException(Exchange, Class<?>, Message, Throwable) - Constructor for exception org.apache.camel.InvalidPayloadException
-
- InvalidPayloadRuntimeException - Exception in org.apache.camel
-
- InvalidPayloadRuntimeException(Exchange, Class<?>) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
-
- InvalidPayloadRuntimeException(Exchange, Class<?>, Throwable) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
-
- InvalidPayloadRuntimeException(Exchange, Class<?>, Message) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
-
- InvalidPayloadRuntimeException(Exchange, Class<?>, Message, Throwable) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
-
- InvalidPropertyException - Exception in org.apache.camel
-
An exception caused when an invalid property name is used on an object
- InvalidPropertyException(Object, String) - Constructor for exception org.apache.camel.InvalidPropertyException
-
- InvalidPropertyException(Object, String, Class<?>) - Constructor for exception org.apache.camel.InvalidPropertyException
-
- invoke(CamelContext) - 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>>) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes the checks and returns a collection of results.
- invoke(CamelContext, HealthCheckFilter) - 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>>, HealthCheckFilter) - Static method in class org.apache.camel.health.HealthCheckHelper
-
Invokes 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.
- InvokeOnHeader - Annotation Type in org.apache.camel.spi
-
Marks a method as being invoked for a specific header value.
- InvokeOnHeaders - Annotation Type in org.apache.camel.spi
-
Marks a method as being invoked for a specific header value.
- isAllowUseOriginalMessage() - Method in interface org.apache.camel.RuntimeConfiguration
-
- isAnySpoolRules() - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
- isApiContextListing() - Method in class org.apache.camel.spi.RestConfiguration
-
- isApiVendorExtension() - Method in class org.apache.camel.spi.RestConfiguration
-
- isAutoStartup() - Method in interface org.apache.camel.RuntimeConfiguration
-
Gets whether the object should automatically start when Camel starts.
- isAutoStartup() - Method in interface org.apache.camel.spi.RouteContext
-
Gets whether the route should automatically start when Camel starts.
- isBacklogTracing() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether backlog tracing enabled
- isBasicPropertyBinding() - Method in interface org.apache.camel.GlobalEndpointConfiguration
-
- isBatchAllowed() - Method in interface org.apache.camel.BatchConsumer
-
Whether processing the batch is still allowed.
- isBridgeErrorHandler() - Method in interface org.apache.camel.GlobalEndpointConfiguration
-
- isBuild() - Method in class org.apache.camel.support.service.ServiceSupport
-
- isCaseInsensitive() - Method in interface org.apache.camel.spi.HeadersMapFactory
-
Whether the created
Map
are case insensitive or not.
- isClientRequestValidation() - Method in class org.apache.camel.spi.RestConfiguration
-
- isCopyMessage() - Method in interface org.apache.camel.spi.MessageHistoryFactory
-
- isDeadLetterChannel() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureEvent
-
- isDebugging() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether debugging enabled
- isDefaultOrExtended() - Method in enum 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).
- isDisabled() - Method in interface org.apache.camel.spi.EventNotifier
-
Checks whether notification is disabled for all events
- 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, DataType) - 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
- isEmpty() - Method in class org.apache.camel.spi.Contract
-
- 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 class org.apache.camel.health.HealthCheckConfiguration
-
- isEnabled(LoggingLevel) - Method in enum 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.
- 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.StreamCachingStrategy
-
- isEnabled() - Method in interface org.apache.camel.spi.Tracer
-
Whether the tracer is enabled
- isEventNotifierEnabled() - Method in interface org.apache.camel.FluentProducerTemplate
-
- isEventNotifierEnabled() - Method in interface org.apache.camel.ProducerTemplate
-
- isEventNotifierEnabled() - Method in interface org.apache.camel.spi.ProducerCache
-
- isExtended() - Method in enum 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 either an exception or fault
- 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.
- isGetter - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
-
- isHealthy() - Method in interface org.apache.camel.cloud.ServiceHealth
-
States if the service is healthy or not
- isIgnoreCamelContextEvents() - 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
-
- 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 org.apache.camel.ExchangePattern
-
Return true if there can be an IN message
- isInit() - Method in class org.apache.camel.support.service.ServiceSupport
-
- isInstanceOf(Map<String, Object>) - Method in interface org.apache.camel.spi.HeadersMapFactory
-
Whether the given
Map
implementation is created by this factory?
- 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
-
- 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?
lenient = false means that the endpoint should validate that all
given options is known and configured properly.
- 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
-
- 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
- isMultipleConsumersSupported() - Method in interface org.apache.camel.MultipleConsumersSupport
-
Are multiple consumers supported?
- isNew() - Method in class org.apache.camel.support.service.ServiceSupport
-
- isOutCapable() - Method in enum org.apache.camel.ExchangePattern
-
Return true if there can be an OUT message
- isRegistered(ObjectName) - Method in interface org.apache.camel.spi.ManagementAgent
-
Is the given object registered
- isRemoveSpoolDirectoryWhenStopping() - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
- isRethrowException() - Method in exception 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
- isRouteAdded() - Method in interface org.apache.camel.spi.RouteContext
-
Returns the isRouteAdded flag
- 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.ServiceSupport
-
- 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 from spring/blueprint.
- isShutdown() - Method in class org.apache.camel.support.service.ServiceSupport
-
- 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 where started.
- IsSingleton - Interface in org.apache.camel
-
Used for defining if a given class is singleton or not.
- isSingleton() - Method in interface org.apache.camel.IsSingleton
-
Whether this class supports being singleton or not.
- 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.
- isStartable() - Method in enum org.apache.camel.ServiceStatus
-
- isStarted() - Method in enum org.apache.camel.ServiceStatus
-
- isStarted() - Method in interface org.apache.camel.StatefulService
-
Whether the service is started
- isStarted(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service starting or already started?
- isStarted() - Method in class org.apache.camel.support.service.ServiceSupport
-
- isStarting() - Method in enum 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.ServiceSupport
-
- isStartingOrStarted() - Method in class org.apache.camel.support.service.ServiceSupport
-
Is the service in progress of being suspended or already suspended
- isStartingRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Indicates whether current thread is starting route(s).
- 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, DataType) - 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
- isStatisticsEnabled() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
-
Whether statistics is enabled.
- isStatisticsEnabled() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Whether statistics is enabled.
- isStatisticsEnabled() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Whether statistics is enabled.
- isStoppable() - Method in enum org.apache.camel.ServiceStatus
-
- isStopped() - Method in enum org.apache.camel.ServiceStatus
-
- isStopped() - Method in interface org.apache.camel.StatefulService
-
Whether the service is stopped
- isStopped(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service stopping or already stopped?
- isStopped() - Method in class org.apache.camel.support.service.ServiceSupport
-
- isStopping() - Method in enum 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.ServiceSupport
-
- isStoppingOrStopped() - Method in class org.apache.camel.support.service.ServiceSupport
-
Is the service in progress of being stopped or already stopped
- isStreamCaching() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether stream cache is enabled
- isSuccess() - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
- isSuccess() - Method in class org.apache.camel.runtimecatalog.LanguageValidationResult
-
- 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 org.apache.camel.ServiceStatus
-
- isSuspended() - Method in enum org.apache.camel.ServiceStatus
-
- isSuspended(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Is the given service suspending or already suspended?
- isSuspended() - Method in class org.apache.camel.support.service.ServiceSupport
-
- isSuspended() - Method in interface org.apache.camel.SuspendableService
-
Tests whether the service is suspended or not.
- isSuspending() - Method in enum 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.ServiceSupport
-
- isSuspendingOrSuspended() - Method in class org.apache.camel.support.service.ServiceSupport
-
Is the service in progress of being suspended or already suspended
- isThreadedAsyncMode() - Method in interface org.apache.camel.ProducerTemplate
-
Reports if async* methods will dispath processing from the calling thread (false) or through executor (true).
- 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.
- isTracing() - Method in interface org.apache.camel.RuntimeConfiguration
-
Returns whether tracing enabled
- isTransacted() - Method in interface org.apache.camel.Exchange
-
Returns true if this exchange is transacted
- isTransacted() - Method in 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.
- 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.
- 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
- isUseXForwardHeaders() - Method in class org.apache.camel.spi.RestConfiguration
-
WWhether to use X-Forward headers to set host etc.
- 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.
- ReactiveExecutor - Interface in org.apache.camel.spi
-
SPI to plugin different reactive engines in the Camel routing engine.
- reason(Exchange, String) - Static method in exception org.apache.camel.NoSuchHeaderException
-
- reason(Exchange, String) - Static method in exception org.apache.camel.NoSuchPropertyException
-
- receive(String) - Method in interface org.apache.camel.ConsumerTemplate
-
- receive(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response.
- receive(String, long) - Method in interface org.apache.camel.ConsumerTemplate
-
- receive(Endpoint, long) - Method in interface org.apache.camel.ConsumerTemplate
-
- 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(Endpoint) - Method in interface org.apache.camel.spi.ConsumerCache
-
- receive(Endpoint, long) - Method in interface org.apache.camel.spi.ConsumerCache
-
- receiveBody(String) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBody(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBody(String, long) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
or the timeout occurs
- receiveBody(Endpoint, long) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
or the timeout occurs
- receiveBody(String, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBody(Endpoint, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBody(String, long, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
or the timeout occurs
- receiveBody(Endpoint, long, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
or the timeout occurs
- receiveBodyNoWait(String) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveBodyNoWait(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveBodyNoWait(String, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveBodyNoWait(Endpoint, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- RECEIVED_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
-
- 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() - 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(Endpoint) - Method in interface org.apache.camel.spi.ConsumerCache
-
- RECIPIENT_LIST_ENDPOINT - Static variable in interface org.apache.camel.Exchange
-
- RecipientList - Annotation Type in org.apache.camel
-
Indicates that this method is to be used as a
Dynamic Recipient List routing the incoming message
to one or more endpoints.
- 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
-
- REDELIVERED - Static variable in interface org.apache.camel.Exchange
-
- 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
-
- REDELIVERY_MAX_COUNTER - Static variable in interface org.apache.camel.Exchange
-
- register(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceRegistry
-
Register the service definition.
- register(HealthCheck) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
- 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.
- registerEndpoint(String, Endpoint) - Method in interface org.apache.camel.spi.EndpointStrategy
-
Register the endpoint.
- registerEndpointCallback(EndpointStrategy) - Method in interface org.apache.camel.ExtendedCamelContext
-
- 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.
- releasePollingConsumer(Endpoint, PollingConsumer) - Method in interface org.apache.camel.spi.ConsumerCache
-
- 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.
- 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
Important: This method is
not invoked if only one exchange was completed, and therefore
the exchange does not need to be added to a repository, as its completed immediately.
- 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(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Removes the key from 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.InflightRepository
-
Removes the exchange from the inflight registry removing association to the given route
- 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(K) - Method in interface org.apache.camel.TimeoutMap
-
Removes the object with the given key
- 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
-
- removeEndpoints(String) - Method in interface org.apache.camel.CamelContext
-
- 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
- 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
- removeProperties(String) - Method in interface org.apache.camel.Exchange
-
Remove all of 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 ore more excludePatterns
- removeProperty(String) - Method in interface org.apache.camel.Exchange
-
Removes the given property on the exchange
- removeRepository(HealthCheckRepository) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Remove an Health Check repository.
- 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.
- removeService(Object) - Method in interface org.apache.camel.CamelContext
-
Removes a service from this CamelContext.
- removeStateChangeListener(BiConsumer<HealthCheck.State, HealthCheck>) - Method in interface org.apache.camel.health.HealthCheckService
-
Remove the state change listener.
- 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
- 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(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
Uses an
ExchangePattern.InOut
message exchange pattern.
- request(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
Uses an
ExchangePattern.InOut
message exchange pattern.
- requestBody(Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint and returns the result content
Uses an
ExchangePattern.InOut
message exchange pattern.
- requestBody(Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint and returns the result content
Uses an
ExchangePattern.InOut
message exchange pattern.
- requestBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBody(Endpoint, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBody(String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeader(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(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in 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(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(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.
- reset() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.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.StreamCache
-
Resets the StreamCache for a new stream consumption.
- resetCacheStatistics() - Method in interface org.apache.camel.spi.ConsumerCache
-
- resetCacheStatistics() - Method in interface org.apache.camel.spi.ProducerCache
-
Resets the cache statistics
- resetCounters() - Method in interface org.apache.camel.spi.BeanIntrospection
-
Reset the statistics counters.
- resetTraceCounter() - Method in interface org.apache.camel.spi.Tracer
-
Reset trace counter
- resolveClass(String) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveClass(String, Class<T>) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveClass(String, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveClass(String, Class<T>, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveComponent(String, CamelContext) - Method in 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 a data format given its name
- resolveDataFormat(String, CamelContext) - Method in interface org.apache.camel.spi.DataFormatResolver
-
Resolves the given data format given its name.
- resolveDefaultFactoryFinder(ClassResolver) - Method in interface org.apache.camel.spi.FactoryFinderResolver
-
Creates a new default factory finder using a default resource path.
- resolveEndpoint(String) - Method in interface org.apache.camel.spi.RouteContext
-
Resolves an endpoint from the URI
- resolveEndpoint(String, String) - Method in interface org.apache.camel.spi.RouteContext
-
Resolves an endpoint from either a URI or a named reference
- ResolveEndpointFailedException - Exception in org.apache.camel
-
A runtime exception thrown if an
Endpoint
cannot be resolved via URI
- ResolveEndpointFailedException(String, Throwable) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
-
- ResolveEndpointFailedException(String, String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
-
- ResolveEndpointFailedException(String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
-
- resolveFactoryFinder(ClassResolver, String) - Method in interface org.apache.camel.spi.FactoryFinderResolver
-
Creates a new factory finder.
- resolveLanguage(String) - Method in interface org.apache.camel.CamelContext
-
Resolves a language for creating expressions
- resolveLanguage(String, 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, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveMandatoryClass(String, Class<T>, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveProperty(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Looks up the property with the given key
- resolvePropertyPlaceholders(String) - Method in interface org.apache.camel.CamelContext
-
Parses the given text and resolve any property placeholders - using {{key}}.
- resolveResource(String) - Method in class org.apache.camel.support.jsse.JsseParameters
-
Attempts to loads a resource using a number of different approaches.
- resolveStaticUri(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in interface org.apache.camel.spi.SendDynamicAware
-
Resolves the static part of the uri that are used for creating a single
Endpoint
and
Producer
that will be reused for processing the optimised toD.
- 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(K) - 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(K) - 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
-
The optional file path, class path resource, or URL of the resource
used to load the key store.
- 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_HTTP_QUERY - Static variable in interface org.apache.camel.Exchange
-
- REST_HTTP_URI - 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 Camel
Consumer
responsible
for handling incoming HTTP GET requests from clients that request to access the REST API documentation.
- RestApiProcessorFactory - Interface in org.apache.camel.spi
-
- RestConfiguration - Class in org.apache.camel.spi
-
- RestConfiguration() - Constructor for class org.apache.camel.spi.RestConfiguration
-
- RestConfiguration.RestBindingMode - Enum in org.apache.camel.spi
-
- RestConfiguration.RestHostNameResolver - Enum in org.apache.camel.spi
-
- RestConsumerFactory - Interface in org.apache.camel.spi
-
Allows SPI to plugin a
RestConsumerFactory
that creates the Camel
Consumer
responsible
for handling incoming HTTP requests from clients that request to access REST services which has been created using
the
rest-dsl.
- RestProducerFactory - Interface in org.apache.camel.spi
-
Allows SPI to plugin a
RestProducerFactory
that creates the Camel
Producer
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
-
- resume() - Method in class org.apache.camel.support.service.ServiceSupport
-
- resume() - Method in interface org.apache.camel.SuspendableService
-
Resumes the service.
- resumeRoute(String) - Method in interface org.apache.camel.spi.RouteController
-
Resumes the given route if it has been previously suspended
If the route does
not support suspension the route will be started instead
- 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
if services
itself is
not null
, otherwise this method would return immediately.
- retrieveGlobalSslContextParameters() - Method in interface org.apache.camel.SSLContextParametersAware
-
- REUSE_SCRIPT_ENGINE - Static variable in interface org.apache.camel.Exchange
-
- 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
-
- ROLLBACK_ONLY_LAST - Static variable in interface org.apache.camel.Exchange
-
- RollbackExchangeException - Exception in org.apache.camel
-
Exception used for forcing an Exchange to be rolled back.
- RollbackExchangeException(Exchange) - Constructor for exception org.apache.camel.RollbackExchangeException
-
- RollbackExchangeException(Exchange, Throwable) - Constructor for exception org.apache.camel.RollbackExchangeException
-
- RollbackExchangeException(String, Exchange) - Constructor for exception org.apache.camel.RollbackExchangeException
-
- RollbackExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.RollbackExchangeException
-
- Route - Interface in org.apache.camel
-
- ROUTE_STOP - Static variable in interface org.apache.camel.Exchange
-
- RouteAware - Interface in org.apache.camel
-
An interface to represent an object which wishes to be injected with
a
Route
such as
Consumer
which is the consumer for a route.
- RouteContext - Interface in org.apache.camel.spi
-
The context used to activate new routing rules
- RouteController - Interface in org.apache.camel.spi
-
Controller for managing the lifecycle of all the
Route
's.
- RouteError - Interface in org.apache.camel.spi
-
- RouteError.Phase - Enum in org.apache.camel.spi
-
- 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.
- RoutesBuilder - Interface in org.apache.camel
-
A routes builder is capable of building routes using the builder and model classes.
- 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
.
- RoutingSlip - Annotation Type 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.
- RuntimeCamelCatalog - Interface in org.apache.camel.runtimecatalog
-
Runtime based CamelCatalog which are included in camel-core that can provided limit CamelCatalog capabilities
- RuntimeCamelException - Exception in org.apache.camel
-
Base class for all Camel unchecked exceptions.
- RuntimeCamelException() - Constructor for exception org.apache.camel.RuntimeCamelException
-
- RuntimeCamelException(String) - Constructor for exception org.apache.camel.RuntimeCamelException
-
- RuntimeCamelException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeCamelException
-
- RuntimeCamelException(Throwable) - Constructor for exception org.apache.camel.RuntimeCamelException
-
- RuntimeConfiguration - Interface in org.apache.camel
-
Various runtime configuration options used by
CamelContext
and
RouteContext
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 in org.apache.camel
-
A runtime exception caused by a specific message
Exchange
- RuntimeExchangeException(String, Exchange) - Constructor for exception org.apache.camel.RuntimeExchangeException
-
- RuntimeExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.RuntimeExchangeException
-
- RuntimeExpressionException - Exception in org.apache.camel
-
Thrown if an expression evaluation fails
- RuntimeExpressionException(String) - Constructor for exception org.apache.camel.RuntimeExpressionException
-
- RuntimeExpressionException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeExpressionException
-
- RuntimeExpressionException(Throwable) - Constructor for exception org.apache.camel.RuntimeExpressionException
-
- RuntimeTransformException - Exception in org.apache.camel
-
Thrown if a message transformation fails
- RuntimeTransformException(String) - Constructor for exception org.apache.camel.RuntimeTransformException
-
- RuntimeTransformException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeTransformException
-
- RuntimeTransformException(Throwable) - Constructor for exception org.apache.camel.RuntimeTransformException
-
- SAGA_LONG_RUNNING_ACTION - Static variable in interface org.apache.camel.Exchange
-
- SAXPARSER_FACTORY - Static variable in interface org.apache.camel.Exchange
-
- scan(CamelContext) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Scans the repository for
Exchange
s to be recovered
- schedule(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to be run
- schedule(Runnable, String) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to be run
- ScheduledPollConsumerScheduler - Interface in org.apache.camel.spi
-
A pluggable scheduler for org.apache.camel.support.ScheduledPollConsumer
consumers.
- scheduleMain(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to be prioritized and run asap
- scheduleMain(Runnable, String) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to be prioritized and run asap
- 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
- scheduleSync(Runnable, String) - Method in interface org.apache.camel.spi.ReactiveExecutor
-
Schedules the task to run synchronously
- scheduleTask(Runnable) - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Schedules the task to run.
- 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
-
- select(Collection<ServiceRegistry>) - Method in interface org.apache.camel.cloud.ServiceRegistry.Selector
-
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(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 using
Exchange.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 using
Exchange.getException()
.
- send(String, Exchange) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the exchange to the given 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 using
Exchange.getException()
.
- send(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an 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 using
Exchange.getException()
.
- send(String, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an 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 using
Exchange.getException()
.
- send(Endpoint, Exchange) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the exchange to the given 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 using
Exchange.getException()
.
- send(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an 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 using
Exchange.getException()
.
- send(Endpoint, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an 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 using
Exchange.getException()
.
- send(Endpoint, ExchangePattern, Processor, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an 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 using
Exchange.getException()
.
- send(Endpoint, Exchange, Processor) - Method in interface org.apache.camel.spi.ProducerCache
-
Sends the exchange to the given endpoint.
- sendBody(Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBody(Endpoint, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint with the given
ExchangePattern
returning any result output body
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBody(String, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(String, ExchangePattern, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(Endpoint, ExchangePattern, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(String, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- SendDynamicAware - Interface in org.apache.camel.spi
-
Used for components that can optimise the usage of
org.apache.camel.processor.SendDynamicProcessor
(toD)
to reuse a static
Endpoint
and
Producer
that supports
using headers to provide the dynamic parts.
- 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.
- 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
-
- SERVICE_CALL_SCHEME - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
- SERVICE_CALL_URI - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
- SERVICE_HOST - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
- SERVICE_META - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
- SERVICE_META_HOST - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
- SERVICE_META_ID - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
- SERVICE_META_NAME - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
- SERVICE_META_PATH - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
- SERVICE_META_PORT - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
- SERVICE_META_PREFIX - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
- SERVICE_META_PROTOCOL - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
- SERVICE_META_ZONE - Static variable in interface org.apache.camel.cloud.ServiceDefinition
-
- SERVICE_NAME - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
- SERVICE_PORT - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
-
- ServiceCallConstants - Interface in org.apache.camel.cloud
-
- ServiceChooser - Interface in org.apache.camel.cloud
-
Allows SPIs to implement custom Service Chooser.
- ServiceChooserAware - Interface in org.apache.camel.cloud
-
An interface to represent an object which wishes to be injected with
a
ServiceChooser
- ServiceChooserFactory - Interface in org.apache.camel.cloud
-
A factory to create ServiceChooser
- ServiceDefinition - Interface in org.apache.camel.cloud
-
Represents a Service.
- ServiceDiscovery - Interface in org.apache.camel.cloud
-
Allows SPIs to implement custom Service Discovery.
- ServiceDiscoveryAware - Interface in org.apache.camel.cloud
-
An interface to represent an object which wishes to be injected with
a
ServiceDiscovery
- ServiceDiscoveryFactory - Interface in org.apache.camel.cloud
-
A factory to create ServiceDiscovery
- ServiceExpressionFactory - Interface in org.apache.camel.cloud
-
A factory to create Expression
- ServiceFactory<T> - Interface in org.apache.camel.cloud
-
- ServiceFilter - Interface in org.apache.camel.cloud
-
Allows SPIs to implement custom Service Filter.
- ServiceFilterAware - Interface in org.apache.camel.cloud
-
An interface to represent an object which wishes to be injected with
a
ServiceFilter
- ServiceFilterFactory - Interface in org.apache.camel.cloud
-
A factory to create ServiceFilter
- ServiceHealth - Interface in org.apache.camel.cloud
-
- 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
-
Represents a Load Balancer.
- ServiceLoadBalancerFactory - Interface in org.apache.camel.cloud
-
A factory to create LoadBalancer
- ServiceLoadBalancerFunction<T> - Interface in org.apache.camel.cloud
-
Represents a load balancer function to be executed by the LoadBalancer.
- ServiceRegistry - Interface in org.apache.camel.cloud
-
- ServiceRegistry.Selector - Interface in org.apache.camel.cloud
-
A selector used to pick up a service among a list.
- ServiceStatus - Enum in org.apache.camel
-
Represents the status of a
Service
instance
- 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)
- setAlgorithm(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
- 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 the
SecureRandom
represented by this object's configuration.
- setAlgorithm(String) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
- 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
-
- setAnySpoolRules(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
- 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)
- setApiContextIdPattern(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Optional CamelContext id pattern to only allow Rest APIs from rest services within CamelContext's which name matches the pattern.
- setApiContextListing(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets whether listing of all available CamelContext's with REST services in the JVM is enabled.
- 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 an specific hostname for the API documentation (eg swagger)
This can be used to override the generated host with this configured hostname
- 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
- setAsyncProcessorAwaitManager(AsyncProcessorAwaitManager) - Method in interface org.apache.camel.ExtendedCamelContext
-
- setAutoStartup(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether the object should automatically start when Camel starts.
- setAutoStartup(Boolean) - Method in interface org.apache.camel.spi.RouteContext
-
Sets whether the route should automatically start when Camel starts.
- setBacklogTracing(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether backlog tracing is enabled or not (default is disabled).
- setBasicPropertyBinding(boolean) - Method in interface org.apache.camel.GlobalEndpointConfiguration
-
Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities.
- setBeanIntrospection(BeanIntrospection) - Method in interface org.apache.camel.ExtendedCamelContext
-
- setBindingMode(RestConfiguration.RestBindingMode) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the binding mode to be used by the REST consumer
- setBindingMode(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the binding mode to be used by the REST consumer
- 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.
- 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.
- setCamelContext(CamelContext) - Method in interface org.apache.camel.CamelContextAware
-
- 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 and
ClassResolver
.
- 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.
- 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.
- 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 whether the Content-Type and Accept headers from
the client is supported by the Rest-DSL configuration of its consumes/produces settings.
- setComponent(Component) - Method in interface org.apache.camel.ComponentAware
-
- setComponent(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the name of the Camel component to use as the REST consumer
- setComponentProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets additional options on component level
- setConnectorPort(Integer) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the port clients must use to connect
- setConsumerProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets additional options on consumer level
- 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
-
- 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
-
- setCreateConnector(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether connector should be created, allowing clients to connect remotely
- setDataFormatProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets additional options on data format level
- setDataFormatResolver(DataFormatResolver) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets a custom data format resolver
- 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
-
- setDebugging(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether debugging is enabled or not (default is enabled).
- 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
- 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
Is disabled by default
- 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 class org.apache.camel.health.HealthCheckConfiguration
-
Set if the check associated to this configuration is enabled or not.
- 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.StreamCachingStrategy
-
Sets whether the stream caching is enabled.
- setEnabled(boolean) - Method in interface org.apache.camel.spi.Tracer
-
Whether the tracer is enabled
- setEncoding(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Encoding to use when loading properties file from the file system or classpath.
- setEndpoint(Endpoint) - Method in interface org.apache.camel.spi.RouteContext
-
- 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).
- setError(String) - Method in class org.apache.camel.runtimecatalog.LanguageValidationResult
-
- 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.spi.RouteContext
-
- setEventFactory(EventFactory) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the event factory to use
- setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.FluentProducerTemplate
-
- setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.ProducerTemplate
-
- setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.spi.ProducerCache
-
- setException(Throwable) - Method in interface org.apache.camel.Exchange
-
- 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
- setExecutorService(ExecutorService) - Method in interface org.apache.camel.ExecutorServiceAware
-
Sets the executor service to be used.
- 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
-
- setExecutorServiceRef(String) - Method in interface org.apache.camel.ExecutorServiceAware
-
Sets a reference to lookup in the
Registry
for the executor service to be used.
- setExtendedStatistics(boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Whether to gather extended statistics for introspection usage.
- setExtension(Class<T>, T) - Method in interface org.apache.camel.CamelContext
-
Allows to install custom extensions to the Camel context.
- setFactoryFinderResolver(FactoryFinderResolver) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the factory finder resolver to use.
- setFailureThreshold(Integer) - Method in class org.apache.camel.health.HealthCheckConfiguration
-
Set the number of failure before reporting the service as un-healthy.
- setFrom(String) - Method in class org.apache.camel.spi.Transformer
-
Set 'from' data type.
- setFromEndpoint(Endpoint) - Method in interface org.apache.camel.Exchange
-
Sets the endpoint which originated this message exchange.
- setFromRouteId(String) - Method in interface org.apache.camel.Exchange
-
Sets the route id which originated this message exchange.
- setGlobalOptions(Map<String, String>) - Method in interface org.apache.camel.CamelContext
-
Sets global options that can be referenced in the camel context
Important: This has nothing to do with property placeholders, and is just a plain set of key/value pairs
which are used to configure global options on CamelContext, such as a maximum debug logging length etc.
- setGroup(String) - Method in interface org.apache.camel.spi.GroupAware
-
Sets the group
- 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
Important: If you want to copy headers from another
Message
to this
Message
, then
use
getHeaders().putAll(other) to copy the headers, where
other is the other headers.
- setHeadersMapFactory(HeadersMapFactory) - Method in interface org.apache.camel.CamelContext
-
- setHealthCheckOptions(String, Map<String, Object>) - Method in interface org.apache.camel.health.HealthCheckService
-
Sets the options to be used when invoking the check identified by the
given id.
- setHost(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the hostname to use by the REST consumer
- setHostNameResolver(RestConfiguration.RestHostNameResolver) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the resolver to use for resolving hostname
- setHostNameResolver(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets the resolver to use for resolving hostname
- 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
-
- 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
-
- 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.
- 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
- setIncludeHostName(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
- setIndex(int) - Method in class org.apache.camel.runtimecatalog.LanguageValidationResult
-
- setInflightRepository(InflightRepository) - Method in interface org.apache.camel.CamelContext
-
Sets a custom inflight repository to use
- setInitialProperties(Properties) - Method in interface org.apache.camel.spi.PropertiesComponent
-
Sets initial properties which will be added before any property locations are loaded.
- 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.
- setInputType(String) - Method in class org.apache.camel.spi.Contract
-
Set the input data type.
- setInputType(Class<?>) - Method in class org.apache.camel.spi.Contract
-
Set the input data type with Java class.
- setInterceptStrategies(List<InterceptStrategy>) - Method in interface org.apache.camel.spi.RouteContext
-
This method sets the InterceptStrategy instances on this route context.
- setInterruptThreadsWhileStopping(boolean) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
-
Sets whether to interrupt any blocking threads during stopping.
- setInterval(Duration) - Method in class org.apache.camel.health.HealthCheckConfiguration
-
Set the check interval.
- setInterval(String) - Method in class org.apache.camel.health.HealthCheckConfiguration
-
Set the check interval in a human readable format.
- setIsRouteAdded(boolean) - Method in interface org.apache.camel.spi.RouteContext
-
If this flag is true, org.apache.camel.reifier.ProcessorReifier#addRoutes(RouteContext)
will not add processor to addEventDrivenProcessor to the RouteContext and it
will prevent from adding an EventDrivenRoute.
- setJsonDataFormat(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets a custom json data format to be used
Important: This option is only for setting a custom name of the data format, not to refer to an existing data format instance.
- setJSonSchemaResolver(JSonSchemaResolver) - Method in interface org.apache.camel.runtimecatalog.RuntimeCamelCatalog
-
- 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 an
SSLContext
.
- setKeyPassword(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
Sets the optional password for recovering keys in the key store.
- setKeyStore(KeyStoreParameters) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
Sets the key store configuration used to create the
KeyStore
that the
KeyManager
s produced by this object's configuration expose.
- setKeyStore(KeyStoreParameters) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
- setLastError(RouteError) - Method in interface org.apache.camel.spi.RouteContext
-
Sets the last error.
- 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.
- 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.
- setLocation(String) - Method in interface org.apache.camel.spi.PropertiesComponent
-
A list of locations to load properties.
- 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(LoggingLevel) - Method in interface org.apache.camel.spi.BeanIntrospection
-
Logging level used for logging introspection usage.
- 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.spi.RouteContext
-
Sets a special intercept strategy for management.
- setManagementName(String) - Method in interface org.apache.camel.CamelContext
-
- 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(Marker) - Method in class org.apache.camel.spi.CamelLogger
-
- setMarker(String) - 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.
- 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.
- 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.
- 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
- 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.
- setMessageHistory(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether message history is enabled or not (default is enabled).
- setMessageHistoryFactory(MessageHistoryFactory) - Method in interface org.apache.camel.CamelContext
-
- setMessageId(String) - Method in interface org.apache.camel.Message
-
Sets the id of the message
- setModel(String) - Method in class org.apache.camel.spi.Transformer
-
Set data model.
- setModelJAXBContextFactory(ModelJAXBContextFactory) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets a custom JAXB Context factory to be used
- setName(String) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the name (id) of the this context.
- 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
- setNodeIdFactory(NodeIdFactory) - Method in interface org.apache.camel.ExtendedCamelContext
-
Uses a custom node id factory when generating auto assigned ids to the nodes in the route definitions
- setNodePattern(String) - Method in interface org.apache.camel.spi.MessageHistoryFactory
-
An optional pattern to filter which nodes to trace in this message history.
- setOnCompletion(String, Processor) - Method in interface org.apache.camel.spi.RouteContext
-
- setOnException(String, Processor) - Method in interface org.apache.camel.spi.RouteContext
-
- 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
-
- setOutputType(String) - Method in class org.apache.camel.spi.Contract
-
Set the output data type.
- setOutputType(Class<?>) - Method in class org.apache.camel.spi.Contract
-
Set the output data type with Java class.
- 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.
- setPackageScanClassResolver(PackageScanClassResolver) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the package scanning class resolver to use
- setPackageScanResourceResolver(PackageScanResourceResolver) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the package scanning resource resolver to use
- 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
-
Set the optional password for reading/opening/verifying the key store.
- setPattern(ExchangePattern) - Method in interface org.apache.camel.Exchange
-
- 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
- setProcessor(Processor) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
-
- setProcessorFactory(ProcessorFactory) - Method in interface org.apache.camel.ExtendedCamelContext
-
- 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
- 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.
- setProvider(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
-
Sets the optional provider identifier for the
KeyManagerFactory
used to create
the
KeyManager
s represented by this object's configuration.
- setProvider(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
Sets the optional 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 the
SecureRandom
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
-
- setReactiveExecutor(ReactiveExecutor) - Method in interface org.apache.camel.CamelContext
-
- setRecoveryInterval(long, TimeUnit) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets the interval between recovery scans
- setRecoveryInterval(long) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets the interval between recovery scans
- 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
This option is default
true.
- setRegistry(Registry) - Method in interface org.apache.camel.ExtendedCamelContext
-
Sets the registry Camel should use for looking up beans by name or type.
- setRegistryPort(Integer) - Method in interface org.apache.camel.spi.ManagementAgent
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the handler for tasks which cannot be executed by the thread pool.
- setRemoveSpoolDirectoryWhenStopping(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Whether to remove the temporary directory when stopping.
- setRepositories(Collection<HealthCheckRepository>) - Method in interface org.apache.camel.health.HealthCheckRegistry
-
Set the health check repositories to use..
- setResource(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
Sets the optional file path, class path resource, or URL of the resource
used to load the key store.
- setRestConfiguration(RestConfiguration) - Method in interface org.apache.camel.CamelContext
-
- setRestRegistry(RestRegistry) - Method in interface org.apache.camel.CamelContext
-
- setRoute(Route) - Method in interface org.apache.camel.RouteAware
-
- setRouteController(RouteController) - Method in interface org.apache.camel.CamelContext
-
- setRouteController(RouteController) - Method in interface org.apache.camel.spi.RouteContext
-
- setRoutePolicyList(List<RoutePolicy>) - Method in interface org.apache.camel.spi.RouteContext
-
Sets a custom route policy List
- setRuntimeEndpointRegistry(RuntimeEndpointRegistry) - Method in interface org.apache.camel.CamelContext
-
- 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.
- 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 an
SSLContext
.
- setSecureSocketProtocol(List<String>) - Method in class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
-
Sets the list of secure socket protocol names.
- 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.
- 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
.
- setServiceChooser(ServiceChooser) - Method in interface org.apache.camel.cloud.ServiceChooserAware
-
- setServiceDiscovery(ServiceDiscovery) - Method in interface org.apache.camel.cloud.ServiceDiscoveryAware
-
- setServiceFilter(ServiceFilter) - Method in interface org.apache.camel.cloud.ServiceFilterAware
-
- setServiceUrlPath(String) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the service url
- setSessionTimeout(String) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
-
- setShortError(String) - Method in class org.apache.camel.runtimecatalog.LanguageValidationResult
-
- setShutdownAwaitTermination(long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
- 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 where 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
- 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
-
- 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
-
- 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
-
- 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.
- setSSLContextParameters(SSLContextParameters) - Method in interface org.apache.camel.CamelContext
-
Sets the global SSL context parameters.
- setStartupOrder(Integer) - Method in interface org.apache.camel.spi.RouteContext
-
- 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.StreamCachingStrategy.Statistics
-
Sets whether statistics is enabled.
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Sets whether statistics is enabled.
- setStatisticsLevel(ManagementStatisticsLevel) - Method in interface org.apache.camel.spi.ManagementAgent
-
- setStreamCaching(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether stream caching is enabled or not (default is disabled).
- setStreamCachingStrategy(StreamCachingStrategy) - Method in interface org.apache.camel.CamelContext
-
- 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.
- setThreadedAsyncMode(boolean) - Method in interface org.apache.camel.ProducerTemplate
-
Reports if async* methods will dispath 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
-
- setTimeout(long) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Set an timeout to wait for the shutdown to complete.
- 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.
- 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.
- 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
-
- setTracing(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether tracing is enabled or not (default is disabled).
- setTracingPattern(String) - Method in interface org.apache.camel.RuntimeConfiguration
-
Tracing pattern to match which node EIPs to trace.
- setTrustManager(TrustManager) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
-
- 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 an
SSLContext
.
- setType(String) - Method in class org.apache.camel.spi.Validator
-
Set data type.
- setType(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
-
Sets 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.
- setUnitOfWork(UnitOfWork) - Method in interface org.apache.camel.Exchange
-
Sets the unit of work that this exchange belongs to; which may map to
zero, one or more physical transactions
- setUnitOfWorkFactory(UnitOfWorkFactory) - Method in interface org.apache.camel.ExtendedCamelContext
-
- 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
-
- setupRoutes(boolean) - Method in interface org.apache.camel.ExtendedCamelContext
-
Method to signal to
CamelContext
that the process to initialize setup routes is in progress.
- 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.
- 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
- setUseXForwardHeaders(boolean) - Method in class org.apache.camel.spi.RestConfiguration
-
WWhether to use X-Forward headers to set host etc.
- setUuidGenerator(UuidGenerator) - Method in interface org.apache.camel.CamelContext
-
- 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
- setXmlDataFormat(String) - Method in class org.apache.camel.spi.RestConfiguration
-
Sets a custom xml data format to be used.
- 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.ShutdownableService
-
Shutdown the service, which means it cannot be started again.
- 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 - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- shutdown() - Method in class org.apache.camel.support.service.ServiceSupport
-
- 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 in org.apache.camel
-
Represents the options available when shutting down routes.
- ShutdownRunningTask - Enum 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 routes.
- SHUTTINGDOWN - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- 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.ConsumerCache
-
- 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(String) - Method in interface org.apache.camel.spi.InflightRepository
-
Current size of inflight exchanges which are from the given route.
- 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
- 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 - Static variable in interface org.apache.camel.Exchange
-
- SLIP_PRODUCER - Static variable in interface org.apache.camel.Exchange
-
- SOAP_ACTION - Static variable in interface org.apache.camel.Exchange
-
- SPLIT_COMPLETE - Static variable in interface org.apache.camel.Exchange
-
- SPLIT_INDEX - Static variable in interface org.apache.camel.Exchange
-
- 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 an
SSLContext
instance.
- SSLContextParameters() - Constructor for class org.apache.camel.support.jsse.SSLContextParameters
-
- SSLContextParametersAware - Interface in org.apache.camel
-
- 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.CamelContext
-
Starts the
CamelContext
(
important: the start method is not blocked, see more details
here).
- start() - Method in interface org.apache.camel.Service
-
Starts the service
- start() - Method in class org.apache.camel.support.service.ServiceSupport
-
- startAllRoutes() - Method in interface org.apache.camel.spi.RouteController
-
Starts all the routes which currently is not started.
- STARTED - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- STARTING - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- startRoute(String) - Method in interface org.apache.camel.spi.RouteController
-
Starts the given route if it has been previously stopped
- startScheduler() - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Starts the scheduler.
- startService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Starts the given
value
if it's a
Service
or a collection of it.
- startService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Starts each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- 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.
- 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.
- StaticService - Interface in org.apache.camel
-
- 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.ServiceSupport
-
- STEP_ID - Static variable in interface org.apache.camel.Exchange
-
- stop() - Method in interface org.apache.camel.CamelContext
-
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.ServiceSupport
-
- stopAndShutdownService(Object) - 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
if services
itself is
not null
, 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
if services
itself is not null
, otherwise this method would return immediately.
- STOPPED - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- STOPPING - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- stopRoute(String) - Method in interface org.apache.camel.spi.RouteController
-
- stopRoute(String, long, TimeUnit) - Method in interface org.apache.camel.spi.RouteController
-
- 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.
- stopService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- stopService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops the given value
, rethrowing the first exception caught.
- stopService(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
-
Stops each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- 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.health.HealthCheckRepository
-
Returns a sequential
Stream
with the known
HealthCheck
as its source.
- 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.
- StreamCachingStrategy - Interface in org.apache.camel.spi
-
- 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 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.
- SUFFIX_TOKEN - Static variable in interface org.apache.camel.spi.PropertiesComponent
-
The suffix token.
- summaryErrorMessage(boolean) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
A human readable summary of the validation errors.
- summaryErrorMessage(boolean, boolean, boolean) - Method in class org.apache.camel.runtimecatalog.EndpointValidationResult
-
A human readable summary of the validation errors.
- 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)
- suspend() - Method in interface org.apache.camel.spi.Breakpoint
-
Suspend this breakpoint
- 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() - Method in class org.apache.camel.support.service.ServiceSupport
-
- suspend() - Method in interface org.apache.camel.SuspendableService
-
Suspends the service.
- 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 - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- SUSPENDING - Static variable in class org.apache.camel.support.service.ServiceSupport
-
- suspendRoute(String) - Method in interface org.apache.camel.spi.RouteController
-
- suspendRoute(String, long, TimeUnit) - Method in interface org.apache.camel.spi.RouteController
-
- 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
if services
itself is
not null
, otherwise this method would return immediately.
- Synchronization - Interface in org.apache.camel.spi
-
- SynchronizationRouteAware - Interface in org.apache.camel.spi
-
- SynchronizationVetoable - Interface in org.apache.camel.spi
-