Liking cljdoc? Tell your friends :D

beicon.core


behavior-subjectcljs

(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

buffercljs

(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-timecljs

(buffer-time ms ob)
(buffer-time ms start ob)
(buffer-time ms start max ob)

Buffers the source Observable values for a specific time period.

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

buffer-untilcljs

(buffer-until notifier ob)

Buffers the source Observable values until notifier emits.

Buffers the source Observable values until notifier emits.
sourceraw docstring

cancel!cljs

source

catchcljs

(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-latestcljs

(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

concatcljs

(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

concat-allcljs

(concat-all ob)
source

connect!cljs

(connect! ob)

Connect the connectable observable.

Connect the connectable observable.
sourceraw docstring

createcljs

(create sf)

Creates an observable sequence from a specified subscribe method implementation.

Creates an observable sequence from a specified subscribe method
implementation.
sourceraw docstring

debouncecljs

(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

dedupecljs

(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'cljs

(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

delaycljs

(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-whencljs

(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?cljs

(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

dispose!cljs

(dispose! v)

Dispose resources acquired by the subscription.

Dispose resources acquired by the subscription.
sourceraw docstring

docljs

source

emptycljs

(empty)

Returns an observable sequence that is already in end state.

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

endcljs

Mark a value as a final value of the stream.

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

end!cljs

(end! b)

Ends the given bus stream.

Ends the given bus stream.
sourceraw docstring

errorcljs

source

error!cljs

(error! b e)

Pushes the given error to the bus stream.

Pushes the given error to the bus stream.
sourceraw docstring

filtercljs

(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

finalizecljs

(finalize f ob)

Returns an Observable that mirrors the source Observable, but will call a specified function when the source terminates on complete or error.

Returns an Observable that mirrors the source Observable, but will
call a specified function when the source terminates on complete or
error.
sourceraw docstring

firstcljs

(first ob)
(first f ob)
(first f default ob)

Return an observable that only has the first value of the provided observable. You can optionally pass a predicate and default value.

Return an observable that only has the first value of the provided
observable. You can optionally pass a predicate and default value.
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-mapcljs

source

fmapcljs

source

fork-joincljs

source

fromcljs

(from v)

Creates an observable from js arrays, clojurescript collections, and promise instance.

Creates an observable from js arrays, clojurescript collections, and
promise instance.
sourceraw docstring

from-atomcljs

(from-atom atm)
source

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

IDisposablecljsprotocol

-disposecljs

(-dispose _)

dispose resources.

dispose resources.
source

ignorecljs

(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

intervalcljs

(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

IObservableValuecljsprotocol

-next?cljs

(-next? _)

Returns true if is end value.

Returns true if is end value.

-error?cljs

(-error? _)

Returns true if is end value.

Returns true if is end value.

-end?cljs

(-end? _)

Returns true if is end value.

Returns true if is end value.
source

ISubscribercljsprotocol

Backpressure aware subscriber abstraction.

Backpressure aware subscriber abstraction.

-on-endcljs

(-on-end _)

Subscription termination notification hook.

Subscription termination notification hook.

-on-errorcljs

(-on-error _ error)

Subscription error notification hook.

Subscription error notification hook.

-on-initcljs

(-on-init _ s)

Subscription initialization hook.

Subscription initialization hook.

-on-nextcljs

(-on-next _ s value)

Subscription data notification hook.

Subscription data notification hook.
sourceraw docstring

lastcljs

(last ob)
(last f ob)
(last f default ob)

Return an observable that only has the last value of the provided observable. You can optionally pass a predicate and default value.

Return an observable that only has the last value of the provided
observable. You can optionally pass a predicate and default value.
sourceraw docstring

logcljs

(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

mapcljs

(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

map-indexedcljs

(map-indexed f ob)
source

mapcatcljs

(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

mapcat-indexedcljs

(mapcat-indexed f ob)
source

mergecljs

(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)
(merge-all concurrency 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-mapcljs

(merge-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.

In other languages is called: flatMap or mergeMap.

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.

In other languages is called: flatMap or mergeMap.
sourceraw docstring

Observablecljs

source

observable?cljs

(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-oncljs

(observe-on schd ob)
source

Observercljs

source

ofcljs

(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-completecljs

A semantic alias for on-end.

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

on-endcljs

(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-errorcljs

(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-nextcljs

A semantic alias for on-value.

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

on-valuecljs

(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

pipecljs

(pipe ob f)
(pipe ob f1 f2)
(pipe ob f1 f2 f3)
(pipe ob f1 f2 f3 f4)
(pipe ob f1 f2 f3 f4 & rest)
source

pr-logcljs

(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

publishcljs

(publish ob)

Create a connectable (hot) observable from other observable.

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

push!cljs

(push! b v)

Pushes the given value to the bus stream.

Pushes the given value to the bus stream.
sourceraw docstring

racecljs

(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

rangecljs

(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

reducecljs

(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

retrycljs

(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

samplecljs

(sample ms ob)

Samples the observable sequence at each interval.

Samples the observable sequence at each interval.
sourceraw docstring

sample-whencljs

(sample-when other ob)

Samples the observable sequence at each interval.

Samples the observable sequence at each interval.
sourceraw docstring

scancljs

(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

schedulercljs

(scheduler type)

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.
sourceraw docstring

scheduler?cljs

(scheduler? v)

Check if the provided value is Scheduler instance.

Check if the provided value is Scheduler instance.
sourceraw docstring

sharecljs

(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

skipcljs

(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-untilcljs

(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-whilecljs

(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

sub!cljs

source

Subjectcljs

source

subjectcljs

(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?cljs

(subject? b)

Check if the provided value is Subject instance.

Check if the provided value is Subject instance.
sourceraw docstring

subscribecljs

(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.
sourceraw docstring

subscribe-oncljs

(subscribe-on schd ob)
source

subscribe-withcljs

(subscribe-with ob observer)

Subscribes an observer or subscriber to the observable sequence.

Subscribes an observer or subscriber to the observable sequence.
sourceraw docstring

Subscribercljs

source

takecljs

(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-untilcljs

(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-whilecljs

(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

tapcljs

(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

throttlecljs

(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

throwcljs

(throw e)
source

timeoutcljs

(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

timercljs

(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-atomcljs

(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-observablecljs

(to-observable ob)

Coerce a object to an observable instance.

Coerce a object to an observable instance.
sourceraw docstring

transformcljs

(transform xform ob)

Transform the observable sequence using transducers.

Transform the observable sequence using transducers.
sourceraw docstring

unsub!cljs

source

with-latestcljs

(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

zipcljs

(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