Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- apply(Exchange) - Method in class org.apache.camel.component.reactive.streams.util.BodyConverter
- attachCallback(Exchange, DispatchCallback<Exchange>) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
- attachCamelConsumer(String, ReactiveStreamsConsumer) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Used by Camel to associate the subscriber of the stream with the given name to a specific Camel consumer.
- attachCamelConsumer(String, ReactiveStreamsConsumer) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- attachCamelProducer(String, ReactiveStreamsProducer) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Used by Camel to associate the publisher of the stream with the given name to a specific Camel producer.
- attachCamelProducer(String, ReactiveStreamsProducer) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- attachConsumer(ReactiveStreamsConsumer) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- attachProducer(ReactiveStreamsProducer) - Method in class org.apache.camel.component.reactive.streams.engine.CamelPublisher
B
- BodyConverter<T> - Class in org.apache.camel.component.reactive.streams.util
- BUFFER - Enum constant in enum class org.apache.camel.component.reactive.streams.ReactiveStreamsBackpressureStrategy
-
Buffers all onNext values until the downstream consumes it.
- buildUri(String, Map<String, Object>, boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointUriFactory
C
- CamelPublisher - Class in org.apache.camel.component.reactive.streams.engine
-
The Camel publisher.
- CamelPublisher(ExecutorService, CamelContext, String) - Constructor for class org.apache.camel.component.reactive.streams.engine.CamelPublisher
- camelPublishers() - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- CamelReactiveStreams - Class in org.apache.camel.component.reactive.streams.api
-
This is the main entry-point for getting Camel streams associate to reactive-streams endpoints.
- CamelReactiveStreamsService - Interface in org.apache.camel.component.reactive.streams.api
-
The interface to which any implementation of the reactive-streams engine should comply.
- CamelReactiveStreamsServiceFactory - Interface in org.apache.camel.component.reactive.streams.api
- camelSubscribers() - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- CamelSubscription - Class in org.apache.camel.component.reactive.streams.engine
-
Represents a contract between a Camel published and an external subscriber.
- CamelSubscription(String, ExecutorService, CamelPublisher, String, ReactiveStreamsBackpressureStrategy, Subscriber<? super Exchange>) - Constructor for class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- cancel() - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- checkAndFlush() - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- close() - Method in class org.apache.camel.component.reactive.streams.engine.CamelPublisher
- close() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponentConfigurer
- configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointConfigurer
- ConvertingPublisher<R> - Class in org.apache.camel.component.reactive.streams.util
-
A publisher that converts Camel
Exchange
s into the given type. - ConvertingPublisher(Publisher<Exchange>, Class<R>) - Constructor for class org.apache.camel.component.reactive.streams.util.ConvertingPublisher
- ConvertingSubscriber<R> - Class in org.apache.camel.component.reactive.streams.util
-
A subscriber that converts items of the given type into Camel
Exchange
s. - ConvertingSubscriber(Subscriber<Exchange>, CamelContext, Class<R>) - Constructor for class org.apache.camel.component.reactive.streams.util.ConvertingSubscriber
- convertToExchange(CamelContext, Object) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
- convertToPublisher(Class<?>, Exchange, Object, TypeConverterRegistry) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConverter
- createConsumer(Processor) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- createProducer() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
D
- DEFAULT_SERVICE_NAME - Static variable in class org.apache.camel.component.reactive.streams.ReactiveStreamsConstants
- DefaultCamelReactiveStreamsService - Class in org.apache.camel.component.reactive.streams.engine
-
The default implementation of the reactive streams service.
- DefaultCamelReactiveStreamsService(CamelContext, ReactiveStreamsEngineConfiguration) - Constructor for class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- DefaultCamelReactiveStreamsServiceFactory - Class in org.apache.camel.component.reactive.streams.engine
- DefaultCamelReactiveStreamsServiceFactory() - Constructor for class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsServiceFactory
- DelayedMonoPublisher<T> - Class in org.apache.camel.component.reactive.streams.engine
-
Publish a single item as soon as it's available.
- DelayedMonoPublisher(ExecutorService) - Constructor for class org.apache.camel.component.reactive.streams.engine.DelayedMonoPublisher
- detachCallback(Exchange) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
- detachCamelConsumer(String) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Used by Camel to detach the existing consumer from the given stream.
- detachCamelConsumer(String) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- detachCamelProducer(String) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Used by Camel to detach the existing producer from the given stream.
- detachCamelProducer(String) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- detachConsumer() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- detachProducer() - Method in class org.apache.camel.component.reactive.streams.engine.CamelPublisher
- discardBuffer(List<Exchange>) - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- DispatchCallback<T> - Interface in org.apache.camel.component.reactive.streams.api
-
A callback used to signal when a item coming from a Camel route has been delivered to the external stream processor.
- doInit() - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- doRequest(String, Exchange) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- doStart() - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- doStart() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- doStart() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConsumer
- doStart() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsProducer
- doStop() - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- doStop() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- doStop() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConsumer
- doStop() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsProducer
F
- findInstance(CamelContext, String, Class<T>) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
- flush() - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- forType(Class<C>) - Static method in class org.apache.camel.component.reactive.streams.util.BodyConverter
- from(String) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Creates a new stream from the endpoint URI (used as Camel Consumer) and returns the associated
Publisher
. - from(String) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- from(String, Class<T>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Creates a new stream of the given type from the endpoint URI (used as Camel Consumer) and returns the associated
Publisher
. - from(String, Class<T>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- fromStream(String) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Returns the publisher associated to the given stream name.
- fromStream(String) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- fromStream(String, Class<T>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Returns the publisher associated to the given stream name.
- fromStream(String, Class<T>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
G
- get(CamelContext) - Static method in class org.apache.camel.component.reactive.streams.api.CamelReactiveStreams
- getBackpressureStrategy() - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- getBackpressureStrategy() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- getBackpressureStrategy() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- getBufferSize() - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- getCallback(Exchange) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
- getCamelContext() - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- getCamelContext() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConverter
- getCamelContext() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConverterLoader
- getConcurrentConsumers() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- getConsumer() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- getData() - Method in class org.apache.camel.component.reactive.streams.engine.DelayedMonoPublisher
- getEndpoint() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConsumer
- getEndpoint() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsProducer
- getException() - Method in class org.apache.camel.component.reactive.streams.engine.DelayedMonoPublisher
- getExchangesRefillLowWatermark() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- getId() - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- getId() - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- getInflightCount() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- getMaxInflightExchanges() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- getName() - Method in exception class org.apache.camel.component.reactive.streams.ReactiveStreamsDiscardedException
- getOptionType(String, boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponentConfigurer
- getOptionType(String, boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointConfigurer
- getOptionValue(Object, String, boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponentConfigurer
- getOptionValue(Object, String, boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointConfigurer
- getReactiveStreamsEngineConfiguration() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- getReactiveStreamsService() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
-
Lazy creation of the CamelReactiveStreamsService
- getRequested() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- getServiceType() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- getStream() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- getStreamName() - Method in exception class org.apache.camel.component.reactive.streams.ReactiveStreamsNoActiveSubscriptionsException
- getSubscriptions() - Method in class org.apache.camel.component.reactive.streams.engine.CamelPublisher
- getThreadPoolMaxSize() - Method in class org.apache.camel.component.reactive.streams.engine.ReactiveStreamsEngineConfiguration
- getThreadPoolMaxSize() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- getThreadPoolMinSize() - Method in class org.apache.camel.component.reactive.streams.engine.ReactiveStreamsEngineConfiguration
- getThreadPoolMinSize() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- getThreadPoolName() - Method in class org.apache.camel.component.reactive.streams.engine.ReactiveStreamsEngineConfiguration
- getThreadPoolName() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
I
- invokeDispatchCallback(Exchange) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
- invokeDispatchCallback(Exchange, Throwable) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
- isEnabled(String) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointUriFactory
- isForwardOnComplete() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- isForwardOnError() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- isLenientProperties() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointUriFactory
- isRemote() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
L
- LATEST - Enum constant in enum class org.apache.camel.component.reactive.streams.ReactiveStreamsBackpressureStrategy
-
Keeps only the latest onNext value, overwriting any previous value if the downstream can't keep up.
- load(TypeConverterRegistry) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConverterLoader
M
- MonoPublisher<T> - Class in org.apache.camel.component.reactive.streams.util
-
A publisher that publish a given item, then completes.
- MonoPublisher(T) - Constructor for class org.apache.camel.component.reactive.streams.util.MonoPublisher
- multiValuePrefixes() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointUriFactory
N
- newInstance(CamelContext, ReactiveStreamsEngineConfiguration) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsServiceFactory
-
Creates a new instance of the
ReactiveStreamsEngineConfiguration
- newInstance(CamelContext, ReactiveStreamsEngineConfiguration) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsServiceFactory
O
- OLDEST - Enum constant in enum class org.apache.camel.component.reactive.streams.ReactiveStreamsBackpressureStrategy
-
Keeps only the oldest onNext value, discarding any future value until it's consumed by the downstream subscriber.
- onComplete() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- onComplete() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConsumer
- onComplete() - Method in class org.apache.camel.component.reactive.streams.util.ConvertingSubscriber
- onError(Throwable) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- onError(Throwable) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConsumer
- onError(Throwable) - Method in class org.apache.camel.component.reactive.streams.util.ConvertingSubscriber
- onNext(Exchange) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- onNext(R) - Method in class org.apache.camel.component.reactive.streams.util.ConvertingSubscriber
- onSubscribe(Subscription) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- onSubscribe(Subscription) - Method in class org.apache.camel.component.reactive.streams.util.ConvertingSubscriber
- org.apache.camel.component.reactive.streams - package org.apache.camel.component.reactive.streams
- org.apache.camel.component.reactive.streams.api - package org.apache.camel.component.reactive.streams.api
- org.apache.camel.component.reactive.streams.engine - package org.apache.camel.component.reactive.streams.engine
- org.apache.camel.component.reactive.streams.util - package org.apache.camel.component.reactive.streams.util
P
- process(String, Class<T>, Function<? super Publisher<T>, ?>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Adds a processing step at the specified endpoint uri (usually a "direct:name") that delegates to the given reactive processor.
- process(String, Class<T>, Function<? super Publisher<T>, ?>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- process(String, Function<? super Publisher<Exchange>, ?>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Adds a processing step at the specified endpoint uri (usually a "direct:name") that delegates to the given reactive processor.
- process(String, Function<? super Publisher<Exchange>, ?>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConsumer
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsProducer
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.reactive.streams.util.UnwrapStreamProcessor
- processed(T, Throwable) - Method in interface org.apache.camel.component.reactive.streams.api.DispatchCallback
-
Signals the delivery of the item.
- propertyNames() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointUriFactory
- publish(Exchange) - Method in class org.apache.camel.component.reactive.streams.engine.CamelPublisher
- publish(Exchange) - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
R
- REACTIVE_STREAMS_CALLBACK - Static variable in class org.apache.camel.component.reactive.streams.ReactiveStreamsConstants
- REACTIVE_STREAMS_EVENT_TYPE - Static variable in class org.apache.camel.component.reactive.streams.ReactiveStreamsConstants
-
Every exchange consumed by Camel has this header set to indicate if the exchange contains an item (value="onNext"), an error (value="onError") or a completion event (value="onComplete").
- ReactiveStreamsBackpressureStrategy - Enum Class in org.apache.camel.component.reactive.streams
-
A list of possible backpressure strategy to use when the emission of upstream items cannot respect backpressure.
- ReactiveStreamsCamelSubscriber - Class in org.apache.camel.component.reactive.streams
-
The Camel subscriber.
- ReactiveStreamsCamelSubscriber(String) - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- ReactiveStreamsComponent - Class in org.apache.camel.component.reactive.streams
-
The Camel reactive-streams component.
- ReactiveStreamsComponent() - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
- ReactiveStreamsComponentConfigurer - Class in org.apache.camel.component.reactive.streams
-
Generated by camel build tools - do NOT edit this file!
- ReactiveStreamsComponentConfigurer() - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsComponentConfigurer
- ReactiveStreamsConstants - Class in org.apache.camel.component.reactive.streams
-
Useful constants used in the Camel Reactive Streams component.
- ReactiveStreamsConsumer - Class in org.apache.camel.component.reactive.streams
-
The Camel reactive-streams consumer.
- ReactiveStreamsConsumer(ReactiveStreamsEndpoint, Processor, CamelReactiveStreamsService) - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsConsumer
- ReactiveStreamsConverter - Class in org.apache.camel.component.reactive.streams
- ReactiveStreamsConverter() - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsConverter
- ReactiveStreamsConverterLoader - Class in org.apache.camel.component.reactive.streams
-
Generated by camel build tools - do NOT edit this file!
- ReactiveStreamsConverterLoader() - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsConverterLoader
- ReactiveStreamsDiscardedException - Exception Class in org.apache.camel.component.reactive.streams
- ReactiveStreamsDiscardedException(String, Exchange, String) - Constructor for exception class org.apache.camel.component.reactive.streams.ReactiveStreamsDiscardedException
- ReactiveStreamsEndpoint - Class in org.apache.camel.component.reactive.streams
-
Exchange messages with reactive stream processing libraries compatible with the reactive streams standard.
- ReactiveStreamsEndpoint(String, ReactiveStreamsComponent) - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
- ReactiveStreamsEndpointConfigurer - Class in org.apache.camel.component.reactive.streams
-
Generated by camel build tools - do NOT edit this file!
- ReactiveStreamsEndpointConfigurer() - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointConfigurer
- ReactiveStreamsEndpointUriFactory - Class in org.apache.camel.component.reactive.streams
-
Generated by camel build tools - do NOT edit this file!
- ReactiveStreamsEndpointUriFactory() - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointUriFactory
- ReactiveStreamsEngineConfiguration - Class in org.apache.camel.component.reactive.streams.engine
-
Configuration parameters for the Camel internal reactive-streams engine.
- ReactiveStreamsEngineConfiguration() - Constructor for class org.apache.camel.component.reactive.streams.engine.ReactiveStreamsEngineConfiguration
- ReactiveStreamsHelper - Class in org.apache.camel.component.reactive.streams
- ReactiveStreamsNoActiveSubscriptionsException - Exception Class in org.apache.camel.component.reactive.streams
- ReactiveStreamsNoActiveSubscriptionsException(String, String) - Constructor for exception class org.apache.camel.component.reactive.streams.ReactiveStreamsNoActiveSubscriptionsException
- ReactiveStreamsProducer - Class in org.apache.camel.component.reactive.streams
-
The Camel reactive-streams producer.
- ReactiveStreamsProducer(ReactiveStreamsEndpoint, String, CamelReactiveStreamsService) - Constructor for class org.apache.camel.component.reactive.streams.ReactiveStreamsProducer
- refill() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsCamelSubscriber
- request(long) - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- resolveReactiveStreamsService(CamelContext, String, ReactiveStreamsEngineConfiguration) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
-
Helper to lookup/create an instance of
CamelReactiveStreamsService
- resolveServiceFactory(CamelContext, String) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsHelper
S
- SCHEME - Static variable in class org.apache.camel.component.reactive.streams.ReactiveStreamsConstants
- secretPropertyNames() - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpointUriFactory
- sendCamelExchange(String, Exchange) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Used by Camel to send the exchange to all active subscriptions on the given stream.
- sendCamelExchange(String, Exchange) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- SERVICE_PATH - Static variable in class org.apache.camel.component.reactive.streams.ReactiveStreamsConstants
- setBackpressureStrategy(ReactiveStreamsBackpressureStrategy) - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- setBackpressureStrategy(ReactiveStreamsBackpressureStrategy) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
-
The backpressure strategy to use when pushing events to a slow subscriber.
- setBackpressureStrategy(ReactiveStreamsBackpressureStrategy) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
-
The backpressure strategy to use when pushing events to a slow subscriber.
- setCamelContext(CamelContext) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConverter
- setCamelContext(CamelContext) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsConverterLoader
- setConcurrentConsumers(int) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
-
Number of threads used to process exchanges in the Camel route.
- setData(T) - Method in class org.apache.camel.component.reactive.streams.engine.DelayedMonoPublisher
- setException(Throwable) - Method in class org.apache.camel.component.reactive.streams.engine.DelayedMonoPublisher
- setExchangesRefillLowWatermark(double) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
-
Set the low watermark of requested exchanges to the active subscription as percentage of the maxInflightExchanges.
- setForwardOnComplete(boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
-
Determines if onComplete events should be pushed to the Camel route.
- setForwardOnError(boolean) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
-
Determines if onError events should be pushed to the Camel route.
- setMaxInflightExchanges(Integer) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
-
Maximum number of exchanges concurrently being processed by Camel.
- setReactiveStreamsEngineConfiguration(ReactiveStreamsEngineConfiguration) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
-
To use an existing reactive stream engine configuration.
- setServiceType(String) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
-
Set the type of the underlying reactive streams implementation to use.
- setStream(String) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsEndpoint
-
Name of the stream channel used by the endpoint to exchange messages.
- setThreadPoolMaxSize(int) - Method in class org.apache.camel.component.reactive.streams.engine.ReactiveStreamsEngineConfiguration
-
The maximum number of threads used by the reactive streams internal engine.
- setThreadPoolMaxSize(int) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
-
The maximum number of threads used by the reactive streams internal engine.
- setThreadPoolMinSize(int) - Method in class org.apache.camel.component.reactive.streams.engine.ReactiveStreamsEngineConfiguration
-
The minimum number of threads used by the reactive streams internal engine.
- setThreadPoolMinSize(int) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
-
The minimum number of threads used by the reactive streams internal engine.
- setThreadPoolName(String) - Method in class org.apache.camel.component.reactive.streams.engine.ReactiveStreamsEngineConfiguration
-
The name of the thread pool used by the reactive streams internal engine.
- setThreadPoolName(String) - Method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
-
The name of the thread pool used by the reactive streams internal engine.
- signalCompletion() - Method in class org.apache.camel.component.reactive.streams.engine.CamelSubscription
- streamSubscriber(String) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Returns the subscriber associated to the given stream name.
- streamSubscriber(String) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- streamSubscriber(String, Class<T>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Returns the subscriber associated to the given stream name.
- streamSubscriber(String, Class<T>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- subscribe(Subscriber<? super Exchange>) - Method in class org.apache.camel.component.reactive.streams.engine.CamelPublisher
- subscribe(Subscriber<? super Exchange>) - Method in class org.apache.camel.component.reactive.streams.engine.UnwrappingPublisher
- subscribe(Subscriber<? super R>) - Method in class org.apache.camel.component.reactive.streams.util.ConvertingPublisher
- subscribe(Subscriber<? super T>) - Method in class org.apache.camel.component.reactive.streams.engine.DelayedMonoPublisher
- subscribe(Subscriber<? super T>) - Method in class org.apache.camel.component.reactive.streams.util.MonoPublisher
- subscriber(String) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Creates a new route that pushes data to the endpoint URI and returns the associated
Subscriber
. - subscriber(String) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- subscriber(String, Class<T>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Creates a new route that pushes data to the endpoint URI and returns the associated
Subscriber
. - subscriber(String, Class<T>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
T
- to(String) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Creates a new route that uses the endpoint URI as producer, and returns a function that pushes the data into the route and returns the
Publisher
that holds the resulting exchange or the error. - to(String) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- to(String, Class<T>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Creates a new route that uses the endpoint URI as producer, and returns a function that pushes the data into the route and returns the
Publisher
that holds the exchange output or an error. - to(String, Class<T>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- to(String, Object) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Creates a new route that uses the endpoint URI as producer, pushes the given data to the route and returns a
Publisher
that will eventually return the resulting exchange or an error. - to(String, Object) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- to(String, Object, Class<T>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Creates a new route that uses the endpoint URI as producer, pushes the given data to the route and returns a
Publisher
that will eventually return the exchange output or an error. - to(String, Object, Class<T>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- toStream(String) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Returns a function that pushes data into the specified Camel stream and returns a Publisher (mono) holding the resulting exchange or an error.
- toStream(String) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- toStream(String, Class<T>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Returns a function that pushes data into the specified Camel stream and returns a Publisher (mono) holding the exchange output or an error.
- toStream(String, Class<T>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- toStream(String, Object) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Pushes the given data into the specified Camel stream and returns a Publisher (mono) holding the resulting exchange or an error.
- toStream(String, Object) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
- toStream(String, Object, Class<T>) - Method in interface org.apache.camel.component.reactive.streams.api.CamelReactiveStreamsService
-
Pushes the given data into the specified Camel stream and returns a Publisher (mono) holding the exchange output or an error.
- toStream(String, Object, Class<T>) - Method in class org.apache.camel.component.reactive.streams.engine.DefaultCamelReactiveStreamsService
U
- unsubscribe(CamelSubscription) - Method in class org.apache.camel.component.reactive.streams.engine.CamelPublisher
- UnwrappingPublisher - Class in org.apache.camel.component.reactive.streams.engine
-
A publisher that extracts the item from the payload as soon as it is delivered to the subscriber.
- UnwrappingPublisher(Publisher<Exchange>) - Constructor for class org.apache.camel.component.reactive.streams.engine.UnwrappingPublisher
- UnwrapStreamProcessor - Class in org.apache.camel.component.reactive.streams.util
-
A Processor that converts a Publisher into its content asynchronously.
- UnwrapStreamProcessor() - Constructor for class org.apache.camel.component.reactive.streams.util.UnwrapStreamProcessor
- update(Deque<T>, T) - Method in enum class org.apache.camel.component.reactive.streams.ReactiveStreamsBackpressureStrategy
-
Updates the buffer and returns a list of discarded elements (if any).
V
- valueOf(String) - Static method in enum class org.apache.camel.component.reactive.streams.ReactiveStreamsBackpressureStrategy
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.apache.camel.component.reactive.streams.ReactiveStreamsBackpressureStrategy
-
Returns an array containing the constants of this enum class, in the order they are declared.
W
- withServiceType(String) - Static method in class org.apache.camel.component.reactive.streams.ReactiveStreamsComponent
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form