Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- acquiredOnThread() - Method in class io.github.pellse.concurrent.CoreLock.NoopLock
- acquiredOnThread() - Method in record class io.github.pellse.concurrent.CoreLock.ReadLock
-
Returns the value of the
acquiredOnThread
record component. - acquiredOnThread() - Method in record class io.github.pellse.concurrent.CoreLock.WriteLock
-
Returns the value of the
acquiredOnThread
record component. - acquiredOnThread() - Method in interface io.github.pellse.concurrent.Lock
- acquireReadLock() - Method in class io.github.pellse.concurrent.CASLockStrategy
- acquireReadLock() - Method in interface io.github.pellse.concurrent.LockStrategy
- acquireReadLock() - Method in class io.github.pellse.concurrent.StampedLockStrategy
- acquireWriteLock() - Method in class io.github.pellse.concurrent.CASLockStrategy
- acquireWriteLock() - Method in interface io.github.pellse.concurrent.LockStrategy
- acquireWriteLock() - Method in class io.github.pellse.concurrent.StampedLockStrategy
- adapterCache(Function<Iterable<ID>, Mono<Map<ID, RRC>>>, BiFunction<Iterable<ID>, Cache.FetchFunction<ID, RRC>, Mono<Map<ID, RRC>>>, Function<Map<ID, RRC>, Mono<?>>, Function<Map<ID, RRC>, Mono<?>>) - Static method in interface io.github.pellse.assembler.caching.Cache
- adapterCache(Function<Iterable<ID>, Mono<Map<ID, RRC>>>, BiFunction<Iterable<ID>, Cache.FetchFunction<ID, RRC>, Mono<Map<ID, RRC>>>, Function<Map<ID, RRC>, Mono<?>>, Function<Map<ID, RRC>, Mono<?>>, BiFunction<Map<ID, RRC>, Map<ID, RRC>, Mono<?>>) - Static method in interface io.github.pellse.assembler.caching.Cache
- addLifeCycleEventListener(LifeCycleEventListener) - Method in interface io.github.pellse.assembler.LifeCycleEventSource
- AfterTaskExecutionEvent(Lock<?>, T) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.AfterTaskExecutionEvent
-
Creates an instance of a
AfterTaskExecutionEvent
record class. - also(T, Consumer<T>...) - Static method in interface io.github.pellse.util.ObjectUtils
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function10
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function11
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function12
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function3
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function4
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function5
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function6
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function7
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function8
- andThen(Function<? super R, ? extends V>) - Method in interface io.github.pellse.util.function.Function9
- apply(Iterable<? extends ID>, Scheduler) - Method in interface io.github.pellse.assembler.caching.Cache.FetchFunction
- apply(Function<T, K>, UnaryOperator<Mono<Map<K, RRC>>>) - Method in interface io.github.pellse.assembler.Rule
- apply(Function<T, K>, Scheduler) - Method in interface io.github.pellse.assembler.Rule
- apply(T1, T2, T3) - Method in interface io.github.pellse.util.function.CheckedFunction3
- apply(T1, T2, T3) - Method in interface io.github.pellse.util.function.Function3
- apply(T1, T2, T3, T4) - Method in interface io.github.pellse.util.function.Function4
- apply(T1, T2, T3, T4, T5) - Method in interface io.github.pellse.util.function.Function5
- apply(T1, T2, T3, T4, T5, T6) - Method in interface io.github.pellse.util.function.Function6
- apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface io.github.pellse.util.function.Function7
- apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface io.github.pellse.util.function.Function8
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface io.github.pellse.util.function.Function9
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in interface io.github.pellse.util.function.Function10
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in interface io.github.pellse.util.function.Function11
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in interface io.github.pellse.util.function.Function12
- applyWithHandler(T1, T2, T3, Consumer<? super E>) - Method in interface io.github.pellse.util.function.CheckedFunction3
- asCollection(Iterable<E>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- assemble(Iterable<T>) - Method in interface io.github.pellse.assembler.Assembler
- assemble(Function<TC, Publisher<R>>, Assembler<R, V>) - Static method in interface io.github.pellse.assembler.Assembler
- assemble(Publisher<T>) - Method in interface io.github.pellse.assembler.Assembler
- Assembler<T,
R> - Interface in io.github.pellse.assembler - AssemblerAdapter<T,
K, - Interface in io.github.pellse.assemblerR> - AssemblerBuilder - Interface in io.github.pellse.assembler
- AssemblerBuilder.Builder<T,
R> - Interface in io.github.pellse.assembler - AssemblerBuilder.WithCorrelationIdResolverBuilder<R> - Interface in io.github.pellse.assembler
- AssemblerBuilder.WithRulesBuilder<T,
K, - Interface in io.github.pellse.assemblerR> - assemblerOf(Class<R>) - Static method in interface io.github.pellse.assembler.AssemblerBuilder
- async() - Static method in interface io.github.pellse.assembler.caching.AsyncCacheFactory
- async(Cache<ID, RRC>) - Static method in interface io.github.pellse.assembler.caching.AsyncCacheFactory
- async(CacheFactory<ID, R, RRC, CTX>) - Static method in interface io.github.pellse.assembler.caching.AsyncCacheFactory
- AsyncCacheFactory - Interface in io.github.pellse.assembler.caching
B
- BatchRule<T,
RRC> - Interface in io.github.pellse.assembler - BatchRule.BatchRuleBuilder<T,
K> - Interface in io.github.pellse.assembler - BeforeTaskExecutionEvent(Lock<?>) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.BeforeTaskExecutionEvent
-
Creates an instance of a
BeforeTaskExecutionEvent
record class. - BiLongPredicate<T> - Interface in io.github.pellse.util.function
- build() - Method in interface io.github.pellse.assembler.AssemblerBuilder.Builder
- build() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
- build() - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.StreamTableFactoryDelegateBuilder
- build() - Method in class io.github.pellse.concurrent.ReactiveGuard.ReactiveGuardBuilder
- build(int) - Method in interface io.github.pellse.assembler.AssemblerBuilder.Builder
- build(int, int) - Method in interface io.github.pellse.assembler.AssemblerBuilder.Builder
- build(Scheduler) - Method in interface io.github.pellse.assembler.AssemblerBuilder.Builder
- Builder(Flux<U>, WindowingStrategy<U>, ErrorHandler, Scheduler, LifeCycleEventSource, CacheFactory.CacheTransformer<?, R, ?, ?>) - Constructor for record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Creates an instance of a
Builder
record class. - buildQueryFunction(RuleMapperSource<T, TC, K, ID, EID, R, RRC, CTX>, CTX) - Static method in interface io.github.pellse.assembler.QueryUtils
- buildQueryFunction(Function<TC, Publisher<R>>, CTX) - Static method in interface io.github.pellse.assembler.QueryUtils
- buildQueryFunction(Function<TC, Publisher<R>>, Scheduler, CTX) - Static method in interface io.github.pellse.assembler.QueryUtils
C
- cache() - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cache(Function<Iterable<ID>, Mono<Map<ID, RRC>>>, BiFunction<Iterable<ID>, Cache.FetchFunction<ID, RRC>, Mono<Map<ID, RRC>>>, Function<Map<ID, RRC>, Mono<?>>, Function<Map<ID, RRC>, Mono<?>>) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- Cache<ID,
RRC> - Interface in io.github.pellse.assembler.caching - Cache.CacheUpdater<ID,
RRC> - Interface in io.github.pellse.assembler.caching - Cache.FetchFunction<ID,
RRC> - Interface in io.github.pellse.assembler.caching - CacheContext<ID,
R, - Interface in io.github.pellse.assembler.cachingRRC, CTX> - CacheContext.OneToManyCacheContext<ID,
EID, - Record Class in io.github.pellse.assembler.cachingR, RC> - CacheContext.OneToOneCacheContext<ID,
R> - Record Class in io.github.pellse.assembler.caching - cached(CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, Function<CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cached(RuleMapperSource<T, TC, K, ID, ID, R, R, RuleMapperContext.OneToOneContext<T, TC, K, ID, R>>, CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, Function<CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cached(RuleMapperSource<T, TC, K, ID, ID, R, R, RuleMapperContext.OneToOneContext<T, TC, K, ID, R>>, Function<CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cached(Function<CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cached(Function<TC, Publisher<R>>, CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, Function<CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cached(Function<TC, Publisher<R>>, Function<CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>, CacheFactory<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cachedMany(CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, Function<CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cachedMany(RuleMapperSource<T, TC, K, ID, EID, R, RC, RuleMapperContext.OneToManyContext<T, TC, K, ID, EID, R, RC>>, CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, Function<CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cachedMany(RuleMapperSource<T, TC, K, ID, EID, R, RC, RuleMapperContext.OneToManyContext<T, TC, K, ID, EID, R, RC>>, Function<CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cachedMany(Function<CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cachedMany(Function<TC, Publisher<R>>, CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, Function<CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- cachedMany(Function<TC, Publisher<R>>, Function<CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>>...) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- CacheEvent<R> - Interface in io.github.pellse.assembler.caching
- CacheEvent.Removed<R> - Record Class in io.github.pellse.assembler.caching
- CacheEvent.Updated<R> - Record Class in io.github.pellse.assembler.caching
- CacheFactory<ID,
R, - Interface in io.github.pellse.assembler.cachingRRC, CTX> - CacheFactory.CacheTransformer<ID,
R, - Interface in io.github.pellse.assembler.cachingRRC, CTX> - CacheFactory.QueryFunctionException - Exception Class in io.github.pellse.assembler.caching
- cacheTransformer() - Method in interface io.github.pellse.assembler.caching.CacheContext
- cacheTransformer() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Returns the value of the
cacheTransformer
record component. - cacheTransformer() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToOneCacheContext
-
Returns the value of the
cacheTransformer
record component. - cacheTransformer() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Returns the value of the
cacheTransformer
record component. - cacheTransformer(CacheFactory.CacheTransformer<?, R, ?, ?>) - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
- cacheTransformer(CacheFactory.CacheTransformer<?, R, ?, ?>) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- call(Consumer<T>) - Static method in interface io.github.pellse.assembler.caching.ObservableCacheFactory
- call(Function<List<ID>, Publisher<R>>) - Static method in interface io.github.pellse.assembler.RuleMapperSource
- call(Function<T, ID>, Function<List<ID>, Publisher<R>>) - Static method in interface io.github.pellse.assembler.RuleMapperSource
- call(U, Consumer<U>) - Static method in interface io.github.pellse.assembler.caching.ObservableCacheFactory
- call(U, V, BiConsumer<U, V>) - Static method in interface io.github.pellse.assembler.caching.ObservableCacheFactory
- CASLockStrategy - Class in io.github.pellse.concurrent
- CASLockStrategy() - Constructor for class io.github.pellse.concurrent.CASLockStrategy
- CASLockStrategy(long, Duration) - Constructor for class io.github.pellse.concurrent.CASLockStrategy
- checkedApply(T1, T2, T3) - Method in interface io.github.pellse.util.function.CheckedFunction3
- CheckedFunction3<T1,
T2, - Interface in io.github.pellse.util.functionT3, R, E> - collectionFactory() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Returns the value of the
collectionFactory
record component. - collectionFactory() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
collectionFactory
record component. - collectionType() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
collectionType
record component. - CollectionUtils - Interface in io.github.pellse.util.collection
- computeAll(Iterable<ID>, Cache.FetchFunction<ID, RRC>) - Method in interface io.github.pellse.assembler.caching.Cache
- concat(C, C) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- concurrent() - Static method in interface io.github.pellse.assembler.caching.ConcurrentCacheFactory
- concurrent() - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- concurrent(LockStrategy) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCacheFactory
- concurrent(LockStrategy) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- concurrent(LockStrategy, Scheduler) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCacheFactory
- concurrent(LockStrategy, Scheduler) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- concurrent(ReactiveGuard.ReactiveGuardBuilder) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCacheFactory
- concurrent(ReactiveGuard.ReactiveGuardBuilder) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- concurrent(ReactiveGuard.ReactiveGuardBuilder, Scheduler) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCacheFactory
- concurrent(ReactiveGuard.ReactiveGuardBuilder, Scheduler) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- concurrent(BiConsumer<ReactiveGuardEvent, Optional<Lock<?>>>) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCacheFactory
- concurrent(BiConsumer<ReactiveGuardEvent, Optional<Lock<?>>>) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- concurrent(Consumer<ReactiveGuardEvent>) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCacheFactory
- concurrent(Consumer<ReactiveGuardEvent>) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- concurrent(Scheduler) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCacheFactory
- concurrent(Scheduler) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- concurrentCache(Cache<ID, RRC>) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCache
- concurrentCache(Cache<ID, RRC>, LockStrategy) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCache
- concurrentCache(Cache<ID, RRC>, LockStrategy, Scheduler) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCache
- concurrentCache(Cache<ID, RRC>, ReactiveGuard.ReactiveGuardBuilder) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCache
- concurrentCache(Cache<ID, RRC>, ReactiveGuard.ReactiveGuardBuilder, Scheduler) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCache
- concurrentCache(Cache<ID, RRC>, Scheduler) - Static method in interface io.github.pellse.assembler.caching.ConcurrentCache
- ConcurrentCache<ID,
RRC> - Interface in io.github.pellse.assembler.caching - ConcurrentCacheFactory - Interface in io.github.pellse.assembler.caching
- concurrentLifeCycleEventListener(LifeCycleEventListener) - Static method in interface io.github.pellse.assembler.LifeCycleEventSource
- convert(Collection<R>) - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
- convertSubQueryMappers(Publisher<T>, Function<Iterable<T>, Stream<Publisher<? extends Map<K, ?>>>>, BiFunction<Iterable<T>, List<Map<K, ?>>, Stream<R>>) - Method in interface io.github.pellse.assembler.AssemblerAdapter
- CoreLock<L> - Interface in io.github.pellse.concurrent
- CoreLock.NoopLock - Class in io.github.pellse.concurrent
- CoreLock.ReadLock - Record Class in io.github.pellse.concurrent
- CoreLock.WriteLock - Record Class in io.github.pellse.concurrent
- create(CTX) - Method in interface io.github.pellse.assembler.caching.CacheFactory
- createReactiveGuard() - Static method in interface io.github.pellse.concurrent.ReactiveGuard
- createReactiveGuard(LockStrategy) - Static method in interface io.github.pellse.concurrent.ReactiveGuard
- createRule(Function<R, ID>, Function<T, ID>, RuleMapper<T, List<T>, K, ID, R, RRC>) - Method in interface io.github.pellse.assembler.BatchRule.BatchRuleBuilder
- createRule(Function<R, ID>, Function<T, ID>, Supplier<TC>, MapFactory<ID, RRC>, RuleMapper<T, TC, K, ID, R, RRC>) - Method in interface io.github.pellse.assembler.BatchRule.BatchRuleBuilder
- createRule(Function<R, ID>, Function<T, ID>, Supplier<TC>, RuleMapper<T, TC, K, ID, R, RRC>) - Method in interface io.github.pellse.assembler.BatchRule.BatchRuleBuilder
- createRule(Function<R, K>, RuleMapper<T, List<T>, K, K, R, RRC>) - Method in interface io.github.pellse.assembler.BatchRule.BatchRuleBuilder
- createRule(Function<R, K>, Supplier<TC>, MapFactory<K, RRC>, RuleMapper<T, TC, K, K, R, RRC>) - Method in interface io.github.pellse.assembler.BatchRule.BatchRuleBuilder
- createRule(Function<R, K>, Supplier<TC>, RuleMapper<T, TC, K, K, R, RRC>) - Method in interface io.github.pellse.assembler.BatchRule.BatchRuleBuilder
- createSinkMap(Iterable<T>) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
D
- dataSource() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Returns the value of the
dataSource
record component. - DEFAULT_TIMEOUT - Static variable in interface io.github.pellse.concurrent.ReactiveGuard
- defaultCacheTransformer() - Static method in interface io.github.pellse.assembler.caching.CacheFactory.CacheTransformer
- defaultCacheTransformer() - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- defaultMapFactory() - Static method in interface io.github.pellse.assembler.MapFactory
- defaultReactiveGuardListener() - Static method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- defaultResultProvider() - Method in interface io.github.pellse.assembler.RuleMapperContext
- defaultResultProvider() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
- defaultResultProvider() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Returns the value of the
defaultResultProvider
record component. - DefaultRuleContext(Function<T, K>, Function<R, ID>, Function<T, ID>, Supplier<TC>, MapFactory<ID, RRC>) - Constructor for record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Creates an instance of a
DefaultRuleContext
record class. - defaultScheduler() - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- defer() - Static method in interface io.github.pellse.assembler.caching.DeferCacheFactory
- defer(Cache<ID, RRC>) - Static method in interface io.github.pellse.assembler.caching.DeferCacheFactory
- defer(CacheFactory<ID, R, RRC, CTX>) - Static method in interface io.github.pellse.assembler.caching.DeferCacheFactory
- DeferCacheFactory - Interface in io.github.pellse.assembler.caching
- delegate() - Method in interface io.github.pellse.concurrent.Lock
- delegate() - Method in interface io.github.pellse.util.DelegateAware
- DelegateAware<T> - Interface in io.github.pellse.util
- diff(Iterable<? extends E>, Iterable<? extends E>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- diff(Map<K, V>, Map<K, V>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- DO_NOTHING - Static variable in interface io.github.pellse.util.ObjectUtils
- doNothing() - Static method in interface io.github.pellse.util.ObjectUtils
E
- EMPTY_SOURCE - Static variable in interface io.github.pellse.assembler.RuleMapperSource
- emptySource() - Static method in interface io.github.pellse.assembler.RuleMapperSource
- equals(Object) - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToOneCacheContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.caching.CacheEvent.Removed
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.caching.CacheEvent.Updated
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorMap
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorStop
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.CoreLock.ReadLock
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.CoreLock.WriteLock
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.AfterTaskExecutionEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.BeforeTaskExecutionEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquiredEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquisitionFailedEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseCancelledEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleasedEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseFailedEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockUpgradedEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionCancelledEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionFailedEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionTimeoutEvent
-
Indicates whether some other object is "equal to" this one.
- error() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquisitionFailedEvent
-
Returns the value of the
error
record component. - errorConsumer() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
-
Returns the value of the
errorConsumer
record component. - errorConsumer() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
-
Returns the value of the
errorConsumer
record component. - errorHandler() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Returns the value of the
errorHandler
record component. - errorHandler(ErrorHandler) - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
- errorHandler(ErrorHandler) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.ConfigBuilder
- errorHandler(BiConsumer<Throwable, Object>) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.ConfigBuilder
- errorHandler(Consumer<Throwable>) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.ConfigBuilder
- ErrorHandler - Interface in io.github.pellse.assembler
- ErrorHandler.OnErrorContinue<E> - Record Class in io.github.pellse.assembler
- ErrorHandler.OnErrorMap - Record Class in io.github.pellse.assembler
- ErrorHandler.OnErrorResume - Record Class in io.github.pellse.assembler
- ErrorHandler.OnErrorStop - Record Class in io.github.pellse.assembler
- errorPredicate() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
-
Returns the value of the
errorPredicate
record component. - errorPredicate() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
-
Returns the value of the
errorPredicate
record component. - eventListener(ReactiveGuardEventListener<Object>) - Method in class io.github.pellse.concurrent.ReactiveGuard.ReactiveGuardBuilder
- eventSource() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Returns the value of the
eventSource
record component. - exceptionHandler() - Method in interface io.github.pellse.util.function.CheckedFunction3
- exceptionHandler() - Method in interface io.github.pellse.util.function.InterruptedFunction3
- executeWithLock(Supplier<T>, AtomicBoolean) - Static method in interface io.github.pellse.util.lock.LockSupplier
F
- from(Function<TC, Publisher<R>>) - Static method in interface io.github.pellse.assembler.RuleMapperSource
- Function10<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, T5, T6, T7, T8, T9, T10, R> - Function11<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, T5, T6, T7, T8, T9, T10, T11, R> - Function12<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, T5, T6, T7, T8, T9, T10, T11, T12, R> - Function3<T1,
T2, - Interface in io.github.pellse.util.functionT3, R> - Function4<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, R> - Function5<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, T5, R> - Function6<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, T5, T6, R> - Function7<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, T5, T6, T7, R> - Function8<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, T5, T6, T7, T8, R> - Function9<T1,
T2, - Interface in io.github.pellse.util.functionT3, T4, T5, T6, T7, T8, T9, R>
G
- get(Supplier<R>) - Static method in interface io.github.pellse.util.ObjectUtils
- get(K) - Method in interface io.github.pellse.util.lookup.LookupTable
- get(R) - Static method in interface io.github.pellse.util.ObjectUtils
- getAll(Iterable<ID>) - Method in interface io.github.pellse.assembler.caching.Cache
H
- hashCode() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToOneCacheContext
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.caching.CacheEvent.Removed
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.caching.CacheEvent.Updated
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorMap
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorStop
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.CoreLock.ReadLock
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.CoreLock.WriteLock
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.AfterTaskExecutionEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.BeforeTaskExecutionEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquiredEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquisitionFailedEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseCancelledEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleasedEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseFailedEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockUpgradedEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionCancelledEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionFailedEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionTimeoutEvent
-
Returns a hash code value for this object.
I
- idComparator() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Returns the value of the
idComparator
record component. - idComparator() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
idComparator
record component. - idResolver() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Returns the value of the
idResolver
record component. - idResolver() - Method in interface io.github.pellse.assembler.RuleMapperContext
- idResolver() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
idResolver
record component. - idResolver() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
- ifNotNull(T, Consumer<T>) - Static method in interface io.github.pellse.util.ObjectUtils
- initializeResultMap(Collection<ID>, Map<ID, RRC>, Function<ID, RRC>) - Static method in interface io.github.pellse.assembler.QueryUtils
- innerIdResolver() - Method in record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Returns the value of the
innerIdResolver
record component. - innerIdResolver() - Method in interface io.github.pellse.assembler.RuleContext
- innerIdResolver() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
innerIdResolver
record component. - innerIdResolver() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Returns the value of the
innerIdResolver
record component. - InterruptedFunction3<T1,
T2, - Interface in io.github.pellse.util.functionT3, R> - io.github.pellse.assembler - package io.github.pellse.assembler
- io.github.pellse.assembler.caching - package io.github.pellse.assembler.caching
- io.github.pellse.concurrent - package io.github.pellse.concurrent
- io.github.pellse.util - package io.github.pellse.util
- io.github.pellse.util.collection - package io.github.pellse.util.collection
- io.github.pellse.util.function - package io.github.pellse.util.function
- io.github.pellse.util.lock - package io.github.pellse.util.lock
- io.github.pellse.util.lookup - package io.github.pellse.util.lookup
- io.github.pellse.util.reactive - package io.github.pellse.util.reactive
- isEmpty(Iterable<?>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- isEmpty(Map<?, ?>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- isEmptySource(RuleMapperSource<T, TC, K, ID, EID, R, RRC, CTX>) - Static method in interface io.github.pellse.assembler.RuleMapperSource
- isNotEmpty(Iterable<?>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- isNotEmpty(Map<?, ?>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- isSafeEqual(T1, Function<? super T1, ? extends U>, T2, Function<? super T2, ? extends U>) - Static method in interface io.github.pellse.util.ObjectUtils
- isSafeEqual(T, T, Function<? super T, ? extends U>) - Static method in interface io.github.pellse.util.ObjectUtils
- isVirtualThreadSupported() - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
L
- lifeCycleEventAdapter(T, Function<T, U>, Consumer<U>) - Static method in interface io.github.pellse.assembler.LifeCycleEventSource
- lifeCycleEventBroadcaster() - Static method in interface io.github.pellse.assembler.LifeCycleEventBroadcaster
- LifeCycleEventBroadcaster - Interface in io.github.pellse.assembler
- LifeCycleEventListener - Interface in io.github.pellse.assembler
- lifeCycleEventSource(LifeCycleEventSource) - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
- lifeCycleEventSource(LifeCycleEventSource) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.LifeCycleEventSourceBuilder
- LifeCycleEventSource - Interface in io.github.pellse.assembler
- lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.AfterTaskExecutionEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.BeforeTaskExecutionEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquiredEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseCancelledEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleasedEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseFailedEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockUpgradedEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionCancelledEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionFailedEvent
-
Returns the value of the
lock
record component. - lock() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionTimeoutEvent
-
Returns the value of the
lock
record component. - Lock<L> - Interface in io.github.pellse.concurrent
- LOCK_ACQUISITION_EXCEPTION - Static variable in interface io.github.pellse.concurrent.LockStrategy
- LockAcquiredEvent(Lock<?>) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquiredEvent
-
Creates an instance of a
LockAcquiredEvent
record class. - LockAcquisitionFailedEvent(Throwable) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquisitionFailedEvent
-
Creates an instance of a
LockAcquisitionFailedEvent
record class. - lockingStrategy(LockStrategy) - Method in class io.github.pellse.concurrent.ReactiveGuard.ReactiveGuardBuilder
- LockReleaseCancelledEvent(Lock<?>) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseCancelledEvent
-
Creates an instance of a
LockReleaseCancelledEvent
record class. - LockReleasedEvent(Lock<?>) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleasedEvent
-
Creates an instance of a
LockReleasedEvent
record class. - LockReleaseFailedEvent(Lock<?>, Throwable) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseFailedEvent
-
Creates an instance of a
LockReleaseFailedEvent
record class. - lockReleaser() - Method in class io.github.pellse.concurrent.CoreLock.NoopLock
- lockReleaser() - Method in record class io.github.pellse.concurrent.CoreLock.ReadLock
-
Returns the value of the
lockReleaser
record component. - lockReleaser() - Method in record class io.github.pellse.concurrent.CoreLock.WriteLock
-
Returns the value of the
lockReleaser
record component. - lockReleaser() - Method in interface io.github.pellse.concurrent.Lock
- LockStrategy - Interface in io.github.pellse.concurrent
- LockStrategy.LockAcquisitionException - Exception Class in io.github.pellse.concurrent
- LockSupplier - Interface in io.github.pellse.util.lock
- LockUpgradedEvent(Lock<?>) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.LockUpgradedEvent
-
Creates an instance of a
LockUpgradedEvent
record class. - log() - Method in class io.github.pellse.concurrent.CoreLock.NoopLock
- log() - Method in interface io.github.pellse.concurrent.Lock
- logger - Static variable in interface io.github.pellse.assembler.caching.StreamTableFactory
- lookupTable() - Static method in interface io.github.pellse.util.lookup.LookupTable
- LookupTable<K,
V> - Interface in io.github.pellse.util.lookup - lookupTableFrom(Iterable<T>, Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in interface io.github.pellse.util.lookup.LookupTable
M
- mapCollector() - Method in interface io.github.pellse.assembler.caching.CacheContext
- mapCollector() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Returns the value of the
mapCollector
record component. - mapCollector() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToOneCacheContext
-
Returns the value of the
mapCollector
record component. - mapCollector() - Method in interface io.github.pellse.assembler.RuleMapperContext
- mapCollector() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
- mapCollector() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
- mapFactory() - Method in record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Returns the value of the
mapFactory
record component. - mapFactory() - Method in interface io.github.pellse.assembler.RuleContext
- mapFactory() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
mapFactory
record component. - mapFactory() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Returns the value of the
mapFactory
record component. - MapFactory<ID,
R> - Interface in io.github.pellse.assembler - mapMerger() - Method in interface io.github.pellse.assembler.caching.CacheContext
- mapMerger() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Returns the value of the
mapMerger
record component. - mapMerger() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToOneCacheContext
-
Returns the value of the
mapMerger
record component. - mapMerger() - Method in interface io.github.pellse.assembler.RuleMapperContext
- mapMerger() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
- mapMerger() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
- mapper() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorMap
-
Returns the value of the
mapper
record component. - mapper(CacheFactory<ID, R, RRC, CTX>, Function<CTX, BiFunction<ID, RRC, RRC>>) - Static method in interface io.github.pellse.assembler.caching.MapperCacheFactory
- mapper(Function<CTX, BiFunction<ID, RRC, RRC>>) - Static method in interface io.github.pellse.assembler.caching.MapperCacheFactory
- MapperCacheFactory - Interface in io.github.pellse.assembler.caching
- MAX_WINDOW_SIZE - Static variable in interface io.github.pellse.assembler.caching.StreamTableFactory
- maxWindowSize(int) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.WindowingStrategyBuilder
- maxWindowSizeAndTime(int, Duration) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.WindowingStrategyBuilder
- maxWindowTime(Duration) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.WindowingStrategyBuilder
- merge(Map<ID, RRC>, Map<ID, RRC>) - Method in interface io.github.pellse.assembler.caching.MergeStrategy
- mergeMaps(Map<K, List<V>>, Map<K, List<V>>, Function<? super V, ID>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- mergeMaps(Map<K, V>...) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- mergeMaps(Map<K, VC>, Map<K, VC>, Function<? super V, ID>, Function<Collection<V>, VC>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- MergeStrategy<ID,
RRC> - Interface in io.github.pellse.assembler.caching
N
- newMap(Consumer<Map<K, V>>...) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- newMap(Map<K, V>, Consumer<Map<K, V>>...) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- newMap(Map<K, V>, Supplier<M>, Consumer<Map<K, V>>...) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- nonNull(Predicate<T>) - Static method in interface io.github.pellse.util.ObjectUtils
- nullToEmpty(Supplier<T>) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- nullToEmpty(T) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- nullToEmptyMap(Map<K, V>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- nullToEmptyMap(T, Supplier<T>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- nullToEmptySource(RuleMapperSource<T, TC, K, ID, EID, R, RRC, CTX>) - Static method in interface io.github.pellse.assembler.RuleMapperSource
O
- ObjectUtils - Interface in io.github.pellse.util
- observableCache(Consumer<Map<ID, RRC>>, Consumer<Map<ID, RRC>>, Consumer<Map<ID, RRC>>, Consumer<Map<ID, RRC>>, BiConsumer<Map<ID, RRC>, Map<ID, RRC>>) - Static method in interface io.github.pellse.assembler.caching.ObservableCacheFactory
- ObservableCacheFactory - Interface in io.github.pellse.assembler.caching
- of(Function10<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, R>) - Static method in interface io.github.pellse.util.function.Function10
- of(Function11<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, R>) - Static method in interface io.github.pellse.util.function.Function11
- of(Function12<T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, R>) - Static method in interface io.github.pellse.util.function.Function12
- of(Function3<T1, T2, T3, R>) - Static method in interface io.github.pellse.util.function.Function3
- of(Function4<T1, T2, T3, T4, R>) - Static method in interface io.github.pellse.util.function.Function4
- of(Function5<T1, T2, T3, T4, T5, R>) - Static method in interface io.github.pellse.util.function.Function5
- of(Function6<T1, T2, T3, T4, T5, T6, R>) - Static method in interface io.github.pellse.util.function.Function6
- of(Function7<T1, T2, T3, T4, T5, T6, T7, R>) - Static method in interface io.github.pellse.util.function.Function7
- of(Function8<T1, T2, T3, T4, T5, T6, T7, T8, R>) - Static method in interface io.github.pellse.util.function.Function8
- of(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, R>) - Static method in interface io.github.pellse.util.function.Function9
- onAfterTaskExecution(Lock<?>, T) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onBeforeTaskExecution(Lock<?>) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onErrorContinue() - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
- onErrorContinue(BiConsumer<Throwable, Object>) - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
- onErrorContinue(Consumer<Throwable>) - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
- onErrorContinue(Predicate<E>, BiConsumer<Throwable, Object>) - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
- OnErrorContinue(Predicate<E>, BiConsumer<Throwable, Object>) - Constructor for record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
-
Creates an instance of a
OnErrorContinue
record class. - onErrorMap(Function<? super Throwable, ? extends Throwable>) - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorMap
- OnErrorMap(Function<? super Throwable, ? extends Throwable>) - Constructor for record class io.github.pellse.assembler.ErrorHandler.OnErrorMap
-
Creates an instance of a
OnErrorMap
record class. - onErrorResume() - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
- onErrorResume(Consumer<Throwable>) - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
- onErrorResume(Predicate<Throwable>, Consumer<Throwable>) - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
- OnErrorResume(Predicate<Throwable>, Consumer<Throwable>) - Constructor for record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
-
Creates an instance of a
OnErrorResume
record class. - onErrorStop() - Static method in record class io.github.pellse.assembler.ErrorHandler.OnErrorStop
- OnErrorStop() - Constructor for record class io.github.pellse.assembler.ErrorHandler.OnErrorStop
-
Creates an instance of a
OnErrorStop
record class. - oneToMany(Function<R, EID>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToMany(Function<R, EID>, RuleMapperSource<T, TC, K, ID, EID, R, List<R>, RuleMapperContext.OneToManyContext<T, TC, K, ID, EID, R, List<R>>>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToMany(Function<R, EID>, RuleMapperSource<T, TC, K, ID, EID, R, RC, RuleMapperContext.OneToManyContext<T, TC, K, ID, EID, R, RC>>, Supplier<RC>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToMany(Function<R, EID>, Function<TC, Publisher<R>>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToMany(Function<R, EID>, Function<TC, Publisher<R>>, Supplier<RC>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToManyAsSet(Function<R, EID>, RuleMapperSource<T, TC, K, ID, EID, R, Set<R>, RuleMapperContext.OneToManyContext<T, TC, K, ID, EID, R, Set<R>>>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToManyAsSet(Function<R, EID>, Function<TC, Publisher<R>>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToManyCache(CacheContext.OneToManyCacheContext<ID, EID, R, RC>, Cache<ID, RC>) - Static method in interface io.github.pellse.assembler.caching.Cache
- OneToManyCacheContext(Function<R, EID>, IntFunction<Collector<R, ?, Map<ID, RC>>>, BiFunction<Map<ID, RC>, Map<ID, RC>, Map<ID, RC>>, Comparator<R>, Supplier<RC>, CacheFactory.CacheTransformer<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>) - Constructor for record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Creates an instance of a
OneToManyCacheContext
record class. - oneToManyCacheTransformer(CacheFactory.CacheTransformer<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>) - Static method in interface io.github.pellse.assembler.caching.CacheFactory.CacheTransformer
- oneToManyCacheTransformer(CacheFactory.CacheTransformer<Object, R, Collection<R>, CacheContext.OneToManyCacheContext<Object, Object, R, Collection<R>>>) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- OneToManyContext(RuleContext<T, TC, K, ID, R, RC>, Function<R, EID>, Comparator<R>, Supplier<RC>) - Constructor for record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
- OneToManyContext(Function<T, K>, Function<R, ID>, Function<T, ID>, Supplier<TC>, MapFactory<ID, RC>, Function<R, EID>, Comparator<R>, Supplier<RC>, Class<RC>) - Constructor for record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Creates an instance of a
OneToManyContext
record class. - oneToOne() - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToOne(RuleMapperSource<T, TC, K, ID, ID, R, R, RuleMapperContext.OneToOneContext<T, TC, K, ID, R>>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToOne(RuleMapperSource<T, TC, K, ID, ID, R, R, RuleMapperContext.OneToOneContext<T, TC, K, ID, R>>, Function<ID, R>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToOne(Function<TC, Publisher<R>>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToOne(Function<TC, Publisher<R>>, Function<ID, R>) - Static method in interface io.github.pellse.assembler.RuleMapper
- oneToOneCache(Cache<ID, R>) - Static method in interface io.github.pellse.assembler.caching.Cache
- OneToOneCacheContext(IntFunction<Collector<R, ?, Map<ID, R>>>, BiFunction<Map<ID, R>, Map<ID, R>, Map<ID, R>>, CacheFactory.CacheTransformer<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>) - Constructor for record class io.github.pellse.assembler.caching.CacheContext.OneToOneCacheContext
-
Creates an instance of a
OneToOneCacheContext
record class. - oneToOneCacheTransformer(CacheFactory.CacheTransformer<ID, R, R, CacheContext.OneToOneCacheContext<ID, R>>) - Static method in interface io.github.pellse.assembler.caching.CacheFactory.CacheTransformer
- oneToOneCacheTransformer(CacheFactory.CacheTransformer<Object, R, R, CacheContext.OneToOneCacheContext<Object, R>>) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.CacheTransformerBuilder
- OneToOneContext(RuleContext<T, TC, K, ID, R, R>, Function<ID, R>) - Constructor for record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
- OneToOneContext(Function<T, K>, Function<R, ID>, Function<T, ID>, Supplier<TC>, MapFactory<ID, R>, Function<ID, R>) - Constructor for record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Creates an instance of a
OneToOneContext
record class. - onLockAcquired(Lock<?>) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onLockAcquisitionFailed(Throwable) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onLockReleaseCancelled(Lock<?>) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onLockReleased(Lock<?>) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onLockReleaseFailed(Lock<?>, Throwable) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onLockUpgraded(CoreLock.WriteLock) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onTaskExecutionCancelled(Lock<?>) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onTaskExecutionFailed(Lock<?>, Throwable) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- onTaskExecutionTimeout(Lock<?>) - Method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- optimizedCache(Cache<ID, RRC>) - Static method in interface io.github.pellse.assembler.caching.Cache
- or(Predicate<T>, Predicate<T>) - Static method in interface io.github.pellse.util.ObjectUtils
- outerIdResolver() - Method in record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Returns the value of the
outerIdResolver
record component. - outerIdResolver() - Method in interface io.github.pellse.assembler.RuleContext
- outerIdResolver() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
outerIdResolver
record component. - outerIdResolver() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Returns the value of the
outerIdResolver
record component. - outerLock() - Method in class io.github.pellse.concurrent.CoreLock.NoopLock
- outerLock() - Method in record class io.github.pellse.concurrent.CoreLock.ReadLock
-
Returns the value of the
outerLock
record component. - outerLock() - Method in record class io.github.pellse.concurrent.CoreLock.WriteLock
-
Returns the value of the
outerLock
record component. - outerLock() - Method in interface io.github.pellse.concurrent.Lock
P
- pipe(RuleMapperSource<T, TC, K, ID, EID, R, RRC, CTX>, Function<? super RuleMapperSource<T, TC, K, ID, EID, R, RRC, CTX>, ? extends RuleMapperSource<T, TC, K, ID, EID, R, RRC, CTX>>...) - Static method in interface io.github.pellse.assembler.RuleMapperSource
- publishFluxOn(Scheduler) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- publishMonoOn(Scheduler) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- put(K, V) - Method in interface io.github.pellse.util.lookup.LookupTable
- putAll(Map<ID, RRC>) - Method in interface io.github.pellse.assembler.caching.Cache
Q
- QueryFunctionException(Throwable) - Constructor for exception class io.github.pellse.assembler.caching.CacheFactory.QueryFunctionException
- QueryUtils - Interface in io.github.pellse.assembler
R
- ReactiveGuard - Interface in io.github.pellse.concurrent
- ReactiveGuard.ReactiveGuardBuilder - Class in io.github.pellse.concurrent
- ReactiveGuard.ReactiveWriteGuard<U> - Interface in io.github.pellse.concurrent
- reactiveGuardBuilder() - Static method in interface io.github.pellse.concurrent.ReactiveGuard
- ReactiveGuardBuilder() - Constructor for class io.github.pellse.concurrent.ReactiveGuard.ReactiveGuardBuilder
- ReactiveGuardEvent - Interface in io.github.pellse.concurrent
- ReactiveGuardEvent.AfterTaskExecutionEvent<T> - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.BeforeTaskExecutionEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.LockAcquiredEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.LockAcquisitionFailedEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.LockReleaseCancelledEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.LockReleasedEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.LockReleaseFailedEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.LockUpgradedEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.TaskExecutionCancelledEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.TaskExecutionFailedEvent - Record Class in io.github.pellse.concurrent
- ReactiveGuardEvent.TaskExecutionTimeoutEvent - Record Class in io.github.pellse.concurrent
- reactiveGuardEventAdapter(BiConsumer<ReactiveGuardEvent, Optional<Lock<?>>>) - Static method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- reactiveGuardEventAdapter(Consumer<ReactiveGuardEvent>) - Static method in interface io.github.pellse.concurrent.ReactiveGuardEventListener
- ReactiveGuardEventListener<T> - Interface in io.github.pellse.concurrent
- ReactiveUtils - Interface in io.github.pellse.util.reactive
- readAll(Iterable<? extends K>, Map<K, V>, Function<V, V1>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- readAll(Iterable<? extends K>, Map<K, V>, Supplier<M>, Function<V, V1>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- readAll(Iterable<K>, Map<K, V>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- ReadLock(long, CoreLock<?>, Consumer<CoreLock.ReadLock>, Thread) - Constructor for record class io.github.pellse.concurrent.CoreLock.ReadLock
-
Creates an instance of a
ReadLock
record class. - release() - Method in interface io.github.pellse.concurrent.Lock
- releaseReadLock(CoreLock.ReadLock) - Method in class io.github.pellse.concurrent.CASLockStrategy
- releaseReadLock(CoreLock.ReadLock) - Method in interface io.github.pellse.concurrent.LockStrategy
- releaseReadLock(CoreLock.ReadLock) - Method in class io.github.pellse.concurrent.StampedLockStrategy
- releaseWriteLock(CoreLock.WriteLock) - Method in class io.github.pellse.concurrent.CASLockStrategy
- releaseWriteLock(CoreLock.WriteLock) - Method in interface io.github.pellse.concurrent.LockStrategy
- releaseWriteLock(CoreLock.WriteLock) - Method in class io.github.pellse.concurrent.StampedLockStrategy
- removeAll(Map<ID, RRC>) - Method in interface io.github.pellse.assembler.caching.Cache
- Removed(R) - Constructor for record class io.github.pellse.assembler.caching.CacheEvent.Removed
-
Creates an instance of a
Removed
record class. - removeDuplicates(Collection<V>, Function<? super V, K>, Function<Collection<V>, VC>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- resolve(Map<T, Mono<RRC>>) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- rule(Function<R, ID>, Function<T, ID>, RuleMapper<T, List<T>, K, ID, R, RRC>) - Static method in interface io.github.pellse.assembler.Rule
- rule(Function<R, ID>, Function<T, ID>, Supplier<TC>, MapFactory<ID, RRC>, RuleMapper<T, TC, K, ID, R, RRC>) - Static method in interface io.github.pellse.assembler.Rule
- rule(Function<R, ID>, Function<T, ID>, Supplier<TC>, RuleMapper<T, TC, K, ID, R, RRC>) - Static method in interface io.github.pellse.assembler.Rule
- rule(Function<R, K>, RuleMapper<T, List<T>, K, K, R, RRC>) - Static method in interface io.github.pellse.assembler.Rule
- rule(Function<R, K>, Supplier<TC>, MapFactory<K, RRC>, RuleMapper<T, TC, K, K, R, RRC>) - Static method in interface io.github.pellse.assembler.Rule
- rule(Function<R, K>, Supplier<TC>, RuleMapper<T, TC, K, K, R, RRC>) - Static method in interface io.github.pellse.assembler.Rule
- Rule<T,
K, - Interface in io.github.pellse.assemblerRRC> - ruleBuilder(Function<Function<T, K>, RuleContext<T, TC, K, ID, R, RRC>>, RuleMapper<T, TC, K, ID, R, RRC>) - Static method in interface io.github.pellse.assembler.Rule
- ruleContext(Function<R, ID>, Function<T, ID>) - Static method in interface io.github.pellse.assembler.RuleContext
- ruleContext(Function<R, ID>, Function<T, ID>, Supplier<TC>) - Static method in interface io.github.pellse.assembler.RuleContext
- ruleContext(Function<R, ID>, Function<T, ID>, Supplier<TC>, MapFactory<ID, RRC>) - Static method in interface io.github.pellse.assembler.RuleContext
- ruleContext(Function<R, K>) - Static method in interface io.github.pellse.assembler.RuleContext
- ruleContext(Function<R, K>, Supplier<TC>) - Static method in interface io.github.pellse.assembler.RuleContext
- ruleContext(Function<R, K>, Supplier<TC>, MapFactory<K, RRC>) - Static method in interface io.github.pellse.assembler.RuleContext
- RuleContext<T,
TC, - Interface in io.github.pellse.assemblerK, ID, R, RRC> - RuleContext.DefaultRuleContext<T,
TC, - Record Class in io.github.pellse.assemblerK, ID, R, RRC> - RuleMapper<T,
TC, - Interface in io.github.pellse.assemblerK, ID, R, RRC> - RuleMapperContext<T,
TC, - Interface in io.github.pellse.assemblerK, ID, EID, R, RRC> - RuleMapperContext.OneToManyContext<T,
TC, - Record Class in io.github.pellse.assemblerK, ID, EID, R, RC> - RuleMapperContext.OneToOneContext<T,
TC, - Record Class in io.github.pellse.assemblerK, ID, R> - RuleMapperSource<T,
TC, - Interface in io.github.pellse.assemblerK, ID, EID, R, RRC, CTX> - run(Runnable) - Static method in interface io.github.pellse.util.ObjectUtils
- run(T, Consumer<T>...) - Static method in interface io.github.pellse.util.ObjectUtils
- runIf(T, Predicate<T>, Consumer<T>) - Static method in interface io.github.pellse.util.ObjectUtils
S
- safeApply(C, Function<C, Publisher<R>>) - Static method in interface io.github.pellse.assembler.QueryUtils
- scheduleFluxOn(Scheduler, BiFunction<Flux<T>, Scheduler, Flux<T>>) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- scheduleMonoOn(Scheduler, BiFunction<Mono<T>, Scheduler, Mono<T>>) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- scheduler() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Returns the value of the
scheduler
record component. - scheduler(Supplier<Scheduler>) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- scheduler(Scheduler) - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
- scheduler(Scheduler) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.SchedulerBuilder
- serialize() - Static method in interface io.github.pellse.assembler.caching.SerializeCacheFactory
- serialize(Cache<ID, RRC>) - Static method in interface io.github.pellse.assembler.caching.SerializeCacheFactory
- serialize(CacheFactory<ID, R, RRC, CTX>) - Static method in interface io.github.pellse.assembler.caching.SerializeCacheFactory
- SerializeCacheFactory - Interface in io.github.pellse.assembler.caching
- size(Iterable<?>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- sneakyThrow(Throwable) - Static method in interface io.github.pellse.util.ObjectUtils
- sortBy() - Static method in interface io.github.pellse.assembler.caching.SortByCacheFactory
- sortBy(CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>) - Static method in interface io.github.pellse.assembler.caching.SortByCacheFactory
- sortBy(CacheFactory<ID, R, RC, CacheContext.OneToManyCacheContext<ID, EID, R, RC>>, Comparator<R>) - Static method in interface io.github.pellse.assembler.caching.SortByCacheFactory
- sortBy(Comparator<R>) - Static method in interface io.github.pellse.assembler.caching.SortByCacheFactory
- SortByCacheFactory - Interface in io.github.pellse.assembler.caching
- StampedLockStrategy - Class in io.github.pellse.concurrent
- StampedLockStrategy() - Constructor for class io.github.pellse.concurrent.StampedLockStrategy
- StampedLockStrategy(Duration) - Constructor for class io.github.pellse.concurrent.StampedLockStrategy
- start() - Method in interface io.github.pellse.assembler.LifeCycleEventListener
- stop() - Method in interface io.github.pellse.assembler.LifeCycleEventListener
- streamFlattener() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
- streamFlattener() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
- streamFlattener() - Method in interface io.github.pellse.assembler.RuleMapperContext
- streamTable(Supplier<Flux<R>>) - Static method in interface io.github.pellse.assembler.caching.StreamTableFactory
- streamTable(Supplier<Flux<U>>, Predicate<U>, Function<U, R>) - Static method in interface io.github.pellse.assembler.caching.StreamTableFactory
- streamTable(Flux<R>) - Static method in interface io.github.pellse.assembler.caching.StreamTableFactory
- streamTable(Flux<U>, WindowingStrategy<U>, ErrorHandler, LifeCycleEventSource, Scheduler, Function<CacheFactory<ID, R, RRC, CTX>, CacheFactory<ID, R, RRC, CTX>>) - Static method in interface io.github.pellse.assembler.caching.StreamTableFactory
- streamTable(Flux<U>, Predicate<U>, Function<U, R>) - Static method in interface io.github.pellse.assembler.caching.StreamTableFactory
- streamTableBuilder(Flux<R>) - Static method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder
- streamTableBuilder(Flux<R>, Predicate<R>) - Static method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder
- streamTableBuilder(Flux<U>, Predicate<U>, Function<U, R>) - Static method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder
- StreamTableFactory - Interface in io.github.pellse.assembler.caching
- StreamTableFactoryBuilder - Interface in io.github.pellse.assembler.caching
- StreamTableFactoryBuilder.Builder<R,
U> - Record Class in io.github.pellse.assembler.caching - StreamTableFactoryBuilder.CacheTransformerBuilder<R> - Interface in io.github.pellse.assembler.caching
- StreamTableFactoryBuilder.ConfigBuilder<R> - Interface in io.github.pellse.assembler.caching
- StreamTableFactoryBuilder.LifeCycleEventSourceBuilder<R> - Interface in io.github.pellse.assembler.caching
- StreamTableFactoryBuilder.SchedulerBuilder<R> - Interface in io.github.pellse.assembler.caching
- StreamTableFactoryBuilder.StreamTableFactoryDelegateBuilder<R> - Interface in io.github.pellse.assembler.caching
- StreamTableFactoryBuilder.WindowingStrategyBuilder<R,
U> - Interface in io.github.pellse.assembler.caching - subscribeFluxOn(Scheduler) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- subscribeMonoOn(Scheduler) - Static method in interface io.github.pellse.util.reactive.ReactiveUtils
- subtractFromMap(Map<K, List<V>>, Map<K, List<V>>, Function<? super V, ID>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- subtractFromMap(Map<K, VC>, Map<K, VC>, Function<? super V, ID>, Supplier<VC>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
T
- t() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseFailedEvent
-
Returns the value of the
t
record component. - t() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionFailedEvent
-
Returns the value of the
t
record component. - TaskExecutionCancelledEvent(Lock<?>) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionCancelledEvent
-
Creates an instance of a
TaskExecutionCancelledEvent
record class. - TaskExecutionFailedEvent(Lock<?>, Throwable) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionFailedEvent
-
Creates an instance of a
TaskExecutionFailedEvent
record class. - TaskExecutionTimeoutEvent(Lock<?>) - Constructor for record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionTimeoutEvent
-
Creates an instance of a
TaskExecutionTimeoutEvent
record class. - test(T, long) - Method in interface io.github.pellse.util.function.BiLongPredicate
- then(T, Function<T, R>) - Static method in interface io.github.pellse.util.ObjectUtils
- timeoutScheduler(Scheduler) - Method in class io.github.pellse.concurrent.ReactiveGuard.ReactiveGuardBuilder
- toCacheEvent(Predicate<T>, Function<T, R>) - Static method in interface io.github.pellse.assembler.caching.CacheEvent
- toFlux(Iterable<T>) - Method in interface io.github.pellse.assembler.BatchRule
- toFluxErrorHandler() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
- toFluxErrorHandler() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorMap
- toFluxErrorHandler() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
- toFluxErrorHandler() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorStop
- toFluxErrorHandler() - Method in interface io.github.pellse.assembler.ErrorHandler
- toHashMap(Iterable<T>, Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- toJavaMap(Iterable<T>, Function<? super T, ? extends K>, Function<? super T, ? extends V>, IntFunction<M>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- token() - Method in class io.github.pellse.concurrent.CoreLock.NoopLock
- token() - Method in record class io.github.pellse.concurrent.CoreLock.ReadLock
-
Returns the value of the
token
record component. - token() - Method in record class io.github.pellse.concurrent.CoreLock.WriteLock
-
Returns the value of the
token
record component. - token() - Method in interface io.github.pellse.concurrent.Lock
- toLinkedHashMap(Iterable<T>, Function<? super T, ? extends K>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- toLinkedHashMap(Iterable<T>, Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- toLinkedHashMap(Map<K, V>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- toMapSupplier(int, MapFactory<ID, R>) - Static method in interface io.github.pellse.assembler.QueryUtils
- toMono(Iterable<T>) - Method in interface io.github.pellse.assembler.BatchRule
- toMono(Consumer<Map<ID, RRC>>) - Static method in interface io.github.pellse.assembler.caching.CacheFactory
- topLevelCollectionFactory() - Method in record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Returns the value of the
topLevelCollectionFactory
record component. - topLevelCollectionFactory() - Method in interface io.github.pellse.assembler.RuleContext
- topLevelCollectionFactory() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
topLevelCollectionFactory
record component. - topLevelCollectionFactory() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Returns the value of the
topLevelCollectionFactory
record component. - topLevelIdResolver() - Method in record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Returns the value of the
topLevelIdResolver
record component. - topLevelIdResolver() - Method in interface io.github.pellse.assembler.RuleContext
- topLevelIdResolver() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns the value of the
topLevelIdResolver
record component. - topLevelIdResolver() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Returns the value of the
topLevelIdResolver
record component. - toPublisher(Function<TC, Iterable<R>>) - Static method in interface io.github.pellse.assembler.QueryUtils
- toResultMap(Collection<T>, Map<ID, RRC>, Function<T, ID>, Function<ID, RRC>) - Static method in interface io.github.pellse.assembler.QueryUtils
- toStream(C) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- toString() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToManyCacheContext
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.caching.CacheContext.OneToOneCacheContext
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.caching.CacheEvent.Removed
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.caching.CacheEvent.Updated
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorContinue
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorMap
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorResume
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.ErrorHandler.OnErrorStop
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.RuleContext.DefaultRuleContext
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToManyContext
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.assembler.RuleMapperContext.OneToOneContext
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.CoreLock.ReadLock
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.CoreLock.WriteLock
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.AfterTaskExecutionEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.BeforeTaskExecutionEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquiredEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockAcquisitionFailedEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseCancelledEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleasedEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockReleaseFailedEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.LockUpgradedEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionCancelledEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionFailedEvent
-
Returns a string representation of this record class.
- toString() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.TaskExecutionTimeoutEvent
-
Returns a string representation of this record class.
- toString(Object, List<Map.Entry<String, ?>>) - Static method in interface io.github.pellse.util.ObjectUtils
- toString(Object, Map.Entry<String, ?>...) - Static method in interface io.github.pellse.util.ObjectUtils
- toWriteLock(Lock<?>) - Method in class io.github.pellse.concurrent.CASLockStrategy
- toWriteLock(Lock<?>) - Method in interface io.github.pellse.concurrent.LockStrategy
- toWriteLock(Lock<?>) - Method in class io.github.pellse.concurrent.StampedLockStrategy
- transform(Iterable<? extends T>, Function<T, R>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- transformMap(Map<K, V>, BiFunction<K, V, K1>, BiFunction<K, V, V1>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- transformMapKeys(Map<K, V>, BiFunction<K, V, K1>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- transformMapKeys(Map<K, V>, Function<K, K1>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- transformMapValues(Map<K, V>, BiFunction<K, V, V1>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- transformMapValues(Map<K, V>, Function<V, V1>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
- translate(Iterable<? extends E>, Supplier<C>) - Static method in interface io.github.pellse.util.collection.CollectionUtils
U
- updateAll(Map<ID, RRC>, Map<ID, RRC>) - Method in interface io.github.pellse.assembler.caching.Cache
- updateCache(Cache<ID, RRC>, Map<ID, RRC>, Map<ID, RRC>) - Method in interface io.github.pellse.assembler.caching.Cache.CacheUpdater
- Updated(R) - Constructor for record class io.github.pellse.assembler.caching.CacheEvent.Updated
-
Creates an instance of a
Updated
record class.
V
- value() - Method in record class io.github.pellse.assembler.caching.CacheEvent.Removed
-
Returns the value of the
value
record component. - value() - Method in record class io.github.pellse.assembler.caching.CacheEvent.Updated
-
Returns the value of the
value
record component. - value() - Method in interface io.github.pellse.assembler.caching.CacheEvent
- value() - Method in record class io.github.pellse.concurrent.ReactiveGuardEvent.AfterTaskExecutionEvent
-
Returns the value of the
value
record component.
W
- windowingStrategy() - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
-
Returns the value of the
windowingStrategy
record component. - windowingStrategy(WindowingStrategy<U>) - Method in record class io.github.pellse.assembler.caching.StreamTableFactoryBuilder.Builder
- windowingStrategy(WindowingStrategy<U>) - Method in interface io.github.pellse.assembler.caching.StreamTableFactoryBuilder.WindowingStrategyBuilder
- WindowingStrategy<R> - Interface in io.github.pellse.assembler
- withCorrelationIdResolver(Function<T, K>) - Static method in interface io.github.pellse.assembler.AssemblerBuilder
- withCorrelationIdResolver(Function<T, K>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithCorrelationIdResolverBuilder
- withIdResolver(Function<T, K>) - Static method in interface io.github.pellse.assembler.BatchRule
- withLock(Supplier<Mono<T>>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withLock(Supplier<Mono<T>>, Duration, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withLock(Supplier<Mono<T>>, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withLock(Supplier<Mono<U>>) - Method in interface io.github.pellse.concurrent.ReactiveGuard.ReactiveWriteGuard
- withLock(Supplier<T>, AtomicBoolean) - Static method in interface io.github.pellse.util.lock.LockSupplier
- withLock(Mono<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withLock(Mono<T>, Duration, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withLock(Mono<T>, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withLock(Mono<U>) - Method in interface io.github.pellse.concurrent.ReactiveGuard.ReactiveWriteGuard
- withReadLock(Function<ReactiveGuard.ReactiveWriteGuard<T>, Mono<T>>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withReadLock(Function<ReactiveGuard.ReactiveWriteGuard<T>, Mono<T>>, Duration, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withReadLock(Function<ReactiveGuard.ReactiveWriteGuard<T>, Mono<T>>, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withReadLock(Supplier<Mono<T>>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withReadLock(Supplier<Mono<T>>, Duration, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withReadLock(Supplier<Mono<T>>, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withReadLock(Mono<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withReadLock(Mono<T>, Duration, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withReadLock(Mono<T>, Supplier<T>) - Method in interface io.github.pellse.concurrent.ReactiveGuard
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Rule<T, K, E4>, Rule<T, K, E5>, Rule<T, K, E6>, Rule<T, K, E7>, Rule<T, K, E8>, Rule<T, K, E9>, Rule<T, K, E10>, Rule<T, K, E11>, Function12<T, E1, E2, E3, E4, E5, E6, E7, E8, E9, E10, E11, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Rule<T, K, E4>, Rule<T, K, E5>, Rule<T, K, E6>, Rule<T, K, E7>, Rule<T, K, E8>, Rule<T, K, E9>, Rule<T, K, E10>, Function11<T, E1, E2, E3, E4, E5, E6, E7, E8, E9, E10, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Rule<T, K, E4>, Rule<T, K, E5>, Rule<T, K, E6>, Rule<T, K, E7>, Rule<T, K, E8>, Rule<T, K, E9>, Function10<T, E1, E2, E3, E4, E5, E6, E7, E8, E9, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Rule<T, K, E4>, Rule<T, K, E5>, Rule<T, K, E6>, Rule<T, K, E7>, Rule<T, K, E8>, Function9<T, E1, E2, E3, E4, E5, E6, E7, E8, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Rule<T, K, E4>, Rule<T, K, E5>, Rule<T, K, E6>, Rule<T, K, E7>, Function8<T, E1, E2, E3, E4, E5, E6, E7, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Rule<T, K, E4>, Rule<T, K, E5>, Rule<T, K, E6>, Function7<T, E1, E2, E3, E4, E5, E6, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Rule<T, K, E4>, Rule<T, K, E5>, Function6<T, E1, E2, E3, E4, E5, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Rule<T, K, E4>, Function5<T, E1, E2, E3, E4, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Rule<T, K, E3>, Function4<T, E1, E2, E3, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, Rule<T, K, E2>, Function3<T, E1, E2, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(Rule<T, K, E1>, BiFunction<T, E1, R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- withRules(List<Rule<T, K, ?>>, BiFunction<T, Object[], R>) - Method in interface io.github.pellse.assembler.AssemblerBuilder.WithRulesBuilder
- WriteLock(long, CoreLock<?>, Consumer<CoreLock.WriteLock>, Thread) - Constructor for record class io.github.pellse.concurrent.CoreLock.WriteLock
-
Creates an instance of a
WriteLock
record class.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form