Liking cljdoc? Tell your friends :D

beicon.core


behavior-subjectclj/s

(behavior-subject v)

Bus that emits the most recent item it has observed and all subsequent observed items to each subscribed Observer.

Bus that emits the most recent item it has observed and
all subsequent observed items to each subscribed Observer.
sourceraw docstring

BehaviorSubjectcljs

source

bufferclj/s

(buffer n ob)
(buffer n skip ob)

Projects each element of an observable sequence into zero or more buffers which are produced based on element count information.

Projects each element of an observable sequence into zero
or more buffers which are produced based on element count
information.
sourceraw docstring

buffer-timeclj/s

(buffer-time ms ob)

Buffers the source Observable values for a specific time period.

Buffers the source Observable values for a specific time period.
sourceraw docstring

cancel!clj/s

(cancel! v)

Dispose resources acquired by the subscription.

Dispose resources acquired by the subscription.
sourceraw docstring

catchclj/s

(catch handler ob)
(catch pred handler ob)

Continues an observable sequence that is terminated by an exception with the next observable sequence.

Continues an observable sequence that is terminated
by an exception with the next observable sequence.
sourceraw docstring

combine-latestclj/s

(combine-latest other ob)
(combine-latest f other ob)

Combines multiple Observables to create an Observable whose values are calculated from the latest values of each of its input Observables.

Combines multiple Observables to create an Observable
whose values are calculated from the latest values of
each of its input Observables.
sourceraw docstring

concatclj/s

(concat & more)

Concatenates all of the specified observable sequences, as long as the previous observable sequence terminated successfully.

Concatenates all of the specified observable
sequences, as long as the previous observable
sequence terminated successfully.
sourceraw docstring

connect!clj/s

(connect! ob)

Connect the connectable observable.

Connect the connectable observable.
sourceraw docstring

createclj/s≠

clj
(create factory)
cljs
(create sf)

Creates an observable sequence from a specified subscribe method implementation.

Creates an observable sequence from a specified
subscribe method implementation.
source (clj)source (cljs)raw docstring

debounceclj/s

(debounce ms ob)

Emits an item from the source Observable after a particular timespan has passed without the Observable omitting any other items.

Emits an item from the source Observable after a
particular timespan has passed without the Observable
omitting any other items.
sourceraw docstring

dedupeclj/s

(dedupe ob)
(dedupe f ob)

Returns an observable sequence that contains only distinct contiguous elements.

Returns an observable sequence that contains only
distinct contiguous elements.
sourceraw docstring

dedupe'clj/s

(dedupe' ob)
(dedupe' f ob)

Returns an observable sequence that contains only d istinct elements. Usage of this operator should be considered carefully due to the maintenance of an internal lookup structure which can grow large.

Returns an observable sequence that contains only d
istinct elements.
Usage of this operator should be considered carefully
due to the maintenance of an internal lookup structure
which can grow large.
sourceraw docstring

delayclj/s

(delay ms ob)

Time shifts the observable sequence by dueTime. The relative time intervals between the values are preserved.

Time shifts the observable sequence by dueTime. The relative
time intervals between the values are preserved.
sourceraw docstring

delay-whenclj/s

(delay-when sf ob)
(delay-when sd sf ob)

Time shifts the observable sequence based on a subscription delay and a delay selector function for each element.

Time shifts the observable sequence based on a subscription
delay and a delay selector function for each element.
sourceraw docstring

Disposablecljs

source

disposable?clj/s

(disposable? v)

Check if the provided object is disposable (jvm) or subscription (js).

Check if the provided object is disposable (jvm) or subscription (js).
sourceraw docstring

doclj/s

An idiomatic alias for tap.

An idiomatic alias for `tap`.
sourceraw docstring

emptyclj/s

(empty)

Returns an observable sequence that is already in end state.

Returns an observable sequence that is already
in end state.
sourceraw docstring

endclj/s

Mark a value as a final value of the stream.

Mark a value as a final value of the stream.
sourceraw docstring

end!clj/s

(end! b)

Ends the given bus stream.

Ends the given bus stream.
sourceraw docstring

error!clj/s

(error! b e)

Pushes the given error to the bus stream.

Pushes the given error to the bus stream.
sourceraw docstring

filterclj/s

(filter f ob)

Filters the elements of an observable sequence based on a predicate.

Filters the elements of an observable sequence
based on a predicate.
sourceraw docstring

fjoincljs

(fjoin & items)

Runs all observable sequences in parallel and collect their last elements.

Runs all observable sequences in parallel and collect
their last elements.
sourceraw docstring

flat-mapclj/s

(flat-map ob)
(flat-map f ob)

Projects each element of an observable sequence to an observable sequence and merges the resulting observable sequences or Promises or array/iterable into one observable sequence.

Projects each element of an observable sequence to
an observable sequence and merges the resulting
observable sequences or Promises or array/iterable
into one observable sequence.
sourceraw docstring

flowable?clj

(flowable? ob)

Check if the provided value is Flowable instance.

Check if the provided value is Flowable instance.
sourceraw docstring

fork-joincljs

Alias to fjoin.

Alias to fjoin.
sourceraw docstring

from-atomclj/s

(from-atom atm)
source

from-collclj/s

(from-coll coll)

Generates an observable sequence from collection.

Generates an observable sequence from collection.
sourceraw docstring

from-eventcljs

(from-event et ev)

Creates an Observable by attaching an event listener to an event target

Creates an Observable by attaching an event listener to an event target
sourceraw docstring

from-futureclj

(from-future p)

Creates an observable from a future.

Creates an observable from a future.
sourceraw docstring

from-promisecljs

(from-promise p)

Creates an observable from a promise.

Creates an observable from a promise.
sourceraw docstring

from-publisherclj

(from-publisher v)

Converts an arbitrary Reactive-Streams Publisher into a Flowable if not already a Flowable.

Converts an arbitrary Reactive-Streams Publisher into a
Flowable if not already a Flowable.
sourceraw docstring

generateclj

(generate next)
(generate next setup)
(generate next setup dispose)

Returns a cold, synchronous, stateful and backpressure-aware generator of values.

Returns a cold, synchronous, stateful and backpressure-aware
generator of values.
sourceraw docstring

ICancellableclj/s≠protocol

-cancelclj/s

(-cancel _)

dispose resources.

dispose resources.
source

ignoreclj/s

(ignore ob)

Ignores all elements in an observable sequence leaving only the termination messages.

Ignores all elements in an observable sequence leaving
only the termination messages.
sourceraw docstring

intervalclj/s

(interval ms)

Returns an observable sequence that produces a value after each period.

Returns an observable sequence that produces a
value after each period.
sourceraw docstring

IObservableValueclj/s≠protocol

-end?clj/s

(-end? _)

Returns true if is end value.

Returns true if is end value.

-error?clj/s

(-error? _)

Returns true if is end value.

Returns true if is end value.

-next?clj/s

(-next? _)

Returns true if is end value.

Returns true if is end value.
source

ISubscriberclj/s≠protocol

Backpressure aware subscriber abstraction.

Backpressure aware subscriber abstraction.

-on-endclj/s

(-on-end _)

Subscription termination notification hook.

Subscription termination notification hook.

-on-errorclj/s

(-on-error _ error)

Subscription error notification hook.

Subscription error notification hook.

-on-initclj/s

(-on-init _ s)

Subscription initialization hook.

Subscription initialization hook.

-on-nextclj/s

(-on-next _ s value)

Subscription data notification hook.

Subscription data notification hook.
sourceraw docstring

ISubscriptionclj/s≠protocol

-requestclj/s

(-request _ n)

request 1 or n items to the subscription.

request 1 or n items to the subscription.
source

justclj/s

(just v)

Returns an observable sequence that contains a single element.

Returns an observable sequence that contains
a single element.
sourceraw docstring

logclj/s

(log ob)
(log prefix ob)

Print all values passed through the given observable sequence.

Print all values passed through the given
observable sequence.
sourceraw docstring

mapclj/s

(map f ob)

Apply a function to each element of an observable sequence.

Apply a function to each element of an observable
sequence.
sourceraw docstring

mapcatclj/s

(mapcat f ob)

Projects each element of an observable sequence to an observable sequence and concatenates the resulting observable sequences or Promises or array/iterable into one observable sequence.

Projects each element of an observable sequence to an observable
sequence and concatenates the resulting observable sequences or
Promises or array/iterable into one observable sequence.
sourceraw docstring

mergeclj/s

(merge & more)

Merges all the observable sequences and Promises into a single observable sequence.

Merges all the observable sequences and Promises
into a single observable sequence.
sourceraw docstring

merge-allcljs

(merge-all ob)

Merges an observable sequence of observable sequences into an observable sequence.

Merges an observable sequence of observable
sequences into an observable sequence.
sourceraw docstring

merge-mapclj/s

An idiomatic alias for flat-map.

An idiomatic alias for flat-map.
sourceraw docstring

neverclj/s

Alias to 'empty'.

Alias to 'empty'.
sourceraw docstring

Observablecljs

source

observable?clj/s

(observable? ob)

Return true if ob is a instance of Rx.Observable.

Return true if `ob` is a instance
of Rx.Observable.
sourceraw docstring

observe-onclj/s

(observe-on schd ob)
source

Observercljs

source

observer?clj/s

(observer? o)

Check if the provided value is Observer instance.

Check if the provided value is Observer instance.
sourceraw docstring

ofclj/s

(of a)
(of a b)
(of a b c)
(of a b c d)
(of a b c d e)
(of a b c d e f)
(of a b c d e f & more)

Converts arguments to an observable sequence.

Converts arguments to an observable sequence.
sourceraw docstring

on-completeclj/s

A semantic alias for on-end.

A semantic alias for `on-end`.
sourceraw docstring

on-endclj/s

(on-end ob f)

Subscribes a function to invoke upon graceful termination of the observable sequence.

Subscribes a function to invoke upon graceful termination
of the observable sequence.
sourceraw docstring

on-errorclj/s

(on-error ob f)

Subscribes a function to invoke upon exceptional termination of the observable sequence.

Subscribes a function to invoke upon exceptional termination
of the observable sequence.
sourceraw docstring

on-nextclj/s

A semantic alias for on-value.

A semantic alias for `on-value`.
sourceraw docstring

on-valueclj/s

(on-value ob f)

Subscribes a function to invoke for each element in the observable sequence.

Subscribes a function to invoke for each element
in the observable sequence.
sourceraw docstring

onceclj/s

(once v)

An alias to just.

An alias to `just`.
sourceraw docstring

pipecljs

(pipe ob op)
source

pr-logclj/s

(pr-log ob)
(pr-log prefix ob)

Print all values passed through the given observable sequence using pr-str.

Print all values passed through the given
observable sequence using pr-str.
sourceraw docstring

publishclj/s

(publish ob)

Create a connectable (hot) observable from other observable.

Create a connectable (hot) observable
from other observable.
sourceraw docstring

push!clj/s

(push! b v)

Pushes the given value to the bus stream.

Pushes the given value to the bus stream.
sourceraw docstring

raceclj/s

(race a b)
(race a b & more)

Create an observable that surfaces any of the given sequences, whichever reacted first.

Create an observable that surfaces any of the given
sequences, whichever reacted first.
sourceraw docstring

rangeclj/s

(range b)
(range a b)

Generates an observable sequence that repeats the given element.

Generates an observable sequence that repeats the
given element.
sourceraw docstring

reduceclj/s

(reduce f ob)
(reduce f seed ob)

Applies an accumulator function over an observable sequence, returning the result of the aggregation as a single element in the result sequence.

Applies an accumulator function over an observable
sequence, returning the result of the aggregation as a
single element in the result sequence.
sourceraw docstring

request!clj/s

(request! s n)
source

retryclj/s

(retry ob)
(retry n ob)

Given an optional number of retries and an observable, repeats the source observable the specified number of times or until it terminates. If no number of retries is given, it will be retried indefinitely.

Given an optional number of retries and an observable,
repeats the source observable the specified number of
times or until it terminates. If no number of retries
is given, it will be retried indefinitely.
sourceraw docstring

rxcljs

source

rxopcljs

source

sampleclj/s

(sample ms ob)

Samples the observable sequence at each interval.

Samples the observable sequence at each interval.
sourceraw docstring

sample-whenclj/s

(sample-when other ob)

Samples the observable sequence at each interval.

Samples the observable sequence at each interval.
sourceraw docstring

scanclj/s

(scan f ob)
(scan f seed ob)

Applies an accumulator function over an observable sequence and returns each intermediate result. Same as reduce but with intermediate results

Applies an accumulator function over an observable
sequence and returns each intermediate result.
Same as reduce but with intermediate results
sourceraw docstring

Schedulercljs

source

schedulerclj/s≠

(scheduler type)
clj

Get the scheduler instance by type. The possible types are: :computation, :io, :single, :thread and :trampoline.

Get the scheduler instance by type. The possible
types are: `:computation`, `:io`, `:single`,
`:thread` and `:trampoline`.
cljs

Get the scheduler instance by type. The posible types are: :asap, :async, :queue. Old :trampoline type is renamed as :queue and is deprecated.

Get the scheduler instance by type.
The posible types are: `:asap`, `:async`, `:queue`.
Old `:trampoline` type is renamed as `:queue` and is deprecated.
source (clj)source (cljs)raw docstring

scheduler?clj/s

(scheduler? v)

Check if the provided value is Scheduler instance.

Check if the provided value is Scheduler instance.
sourceraw docstring

shareclj/s

(share ob)

Returns an observable sequence that shares a single subscription to the underlying sequence.

Returns an observable sequence that shares a single
subscription to the underlying sequence.
sourceraw docstring

single?clj

(single? o)

Check if the provided value is Single instance.

Check if the provided value is Single instance.
sourceraw docstring

skipclj/s

(skip n ob)

Bypasses a specified number of elements in an observable sequence and then returns the remaining elements.

Bypasses a specified number of elements in an
observable sequence and then returns the remaining
elements.
sourceraw docstring

skip-untilclj/s

(skip-until pob ob)

Returns the values from the source observable sequence only after the other observable sequence produces a value.

Returns the values from the source observable sequence
only after the other observable sequence produces a value.
sourceraw docstring

skip-whileclj/s

(skip-while f ob)

Bypasses elements in an observable sequence as long as a specified condition is true and then returns the remaining elements.

Bypasses elements in an observable sequence as long
as a specified condition is true and then returns the
remaining elements.
sourceraw docstring

Subjectcljs

source

subjectclj/s

(subject)

Subject that, once an Observer has subscribed, emits all subsequently observed items to the subscriber.

Subject that, once an Observer has subscribed, emits all
subsequently observed items to the subscriber.
sourceraw docstring

subject?clj/s

(subject? b)

Check if the provided value is Subject instance.

Check if the provided value is Subject instance.
sourceraw docstring

subscribeclj/s≠

clj
(subscribe ob nf)
(subscribe ob nf ef)
(subscribe ob nf ef cf)
(subscribe ob nf ef cf sf)
cljs
(subscribe ob nf)
(subscribe ob nf ef)
(subscribe ob nf ef cf)

Subscribes an observer to the observable sequence.

Subscribes an observer to the observable sequence.
source (clj)source (cljs)raw docstring

subscribe-onclj/s

(subscribe-on schd ob)
source

subscribe-withclj/s≠

clj
(subscribe-with ob subscriber)

Subscribes an observer or subscriber to the observable/flowable sequence.

Subscribes an observer or subscriber to the observable/flowable sequence.
cljs
(subscribe-with ob observer)

Subscribes an observer or subscriber to the observable sequence.

Subscribes an observer or subscriber to the observable sequence.
source (clj)source (cljs)raw docstring

Subscribercljs

source

takeclj/s

(take n ob)

Bypasses a specified number of elements in an observable sequence and then returns the remaining elements.

Bypasses a specified number of elements in an
observable sequence and then returns the remaining
elements.
sourceraw docstring

take-untilclj/s

(take-until other ob)

Returns the values from the source observable sequence until the other observable sequence or Promise produces a value.

Returns the values from the source observable sequence until
the other observable sequence or Promise produces a value.
sourceraw docstring

take-whileclj/s

(take-while f ob)

Returns elements from an observable sequence as long as a specified predicate returns true.

Returns elements from an observable sequence as long as a
specified predicate returns true.
sourceraw docstring

tapclj/s

(tap f ob)
(tap f g ob)
(tap f g e ob)

Invokes an action for each element in the observable sequence.

Invokes an action for each element in the
observable sequence.
sourceraw docstring

throttleclj/s

(throttle ms ob)

Returns an observable sequence that emits only the first item emitted by the source Observable during sequential time windows of a specified duration.

Returns an observable sequence that emits only the
first item emitted by the source Observable during
sequential time windows of a specified duration.
sourceraw docstring

throwclj/s

(throw e)
source

timeoutclj/s

(timeout ms ob)
(timeout ms other ob)

Returns the source observable sequence or the other observable sequence if dueTime elapses.

Returns the source observable sequence or the other
observable sequence if dueTime elapses.
sourceraw docstring

timerclj/s

(timer delay)
(timer delay period)

Returns an observable sequence that produces a value after ms has elapsed and then after each period.

Returns an observable sequence that produces a value after
`ms` has elapsed and then after each period.
sourceraw docstring

to-atomclj/s

(to-atom ob)
(to-atom ob a)
(to-atom ob a f)

Materialize the observable sequence into an atom.

Materialize the observable sequence into an atom.
sourceraw docstring

to-flowableclj

(to-flowable ob)
(to-flowable strategy ob)

Convert an observable into backpressure-aware Flowable instance.

Convert an observable into backpressure-aware Flowable instance.
sourceraw docstring

to-serializedclj

(to-serialized s)

Converts an Subject into a Serialized Subject if not already Serialized.

Converts an Subject into a Serialized Subject if not
already Serialized.
sourceraw docstring

transformclj/s

(transform xform ob)

Transform the observable sequence using transducers.

Transform the observable sequence using transducers.
sourceraw docstring

with-latestclj/s

(with-latest f other source)

Merges the specified observable sequences into one observable sequence by using the selector function only when the source observable sequence (the instance) produces an element.

Merges the specified observable sequences into
one observable sequence by using the selector
function only when the source observable sequence
(the instance) produces an element.
sourceraw docstring

zipclj/s

(zip & items)

Merges the specified observable sequences or Promises (cljs) into one observable sequence.

Merges the specified observable sequences or Promises (cljs) into one
observable sequence.
sourceraw docstring

cljdoc is a website building & hosting documentation for Clojure/Script libraries

× close