Object

io.scalajs.npm.rx.Rx

Observable

Related Doc: package Rx

Permalink

object Observable extends Object with ObservableClass

Annotations
@native() @JSName( "Observable" )
Linear Supertypes
ObservableClass, Object, Any, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Observable
  2. ObservableClass
  3. Object
  4. Any
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. def amb[T](args: |[Array[Observable[T]], Observable[T]]*): Observable[T]

    Permalink

    Propagates the observable sequence or Promise that reacts first.

    Propagates the observable sequence or Promise that reacts first. "amb" stands for ambiguous.

    args

    (Array|arguments): Observable sources or Promises competing to react first either as an array or arguments.

    returns

    An observable sequence that surfaces any of the given sequences, whichever reacted first.

    Definition Classes
    ObservableClass
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def case[T](selector: Function, sources: Any = js.native, elseSource: |[Observable[T], Scheduler] = js.native): Observable[T]

    Permalink

    Uses selector to determine which source in sources to use.

    Uses selector to determine which source in sources to use. There is an alias 'switchCase' for browsers < IE9.

    selector

    (Function): The function which extracts the value for to test in a case statement.

    sources

    (Object): A object which has keys which correspond to the case statement labels.

    elseSource

    [elseSource|scheduler] (Observable | Scheduler): The observable sequence that will be run if the sources are not matched. If this is not provided, it defaults to Rx.Observable.empty with the specified scheduler.

    returns

    An observable sequence which is determined by a case statement.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.case(selector, sources, [elseSource|scheduler])

  7. def catch[T](args: |[Array[Observable[T]], Observable[T]]*): Observable[T]

    Permalink

    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.

    args

    (Array | arguments): Observable sequences to catch exceptions for.

    returns

    An observable sequence containing elements from consecutive source sequences until a source sequence terminates successfully.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.catch(...args)

  8. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. def concat[T](args: |[Array[Observable[T]], Observable[T]]*): Observable[T]

    Permalink

    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.

    args

    (Array | arguments): Observable sequences or Promises to concatenate.

    returns

    (Observable): An observable sequence that contains the elements of each given sequence, in sequential order.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.concat(...args)

  10. def create[T](subscribe: Function0[T]): Observable[T]

    Permalink

    Creates an observable sequence from a specified subscribe method implementation.

    Creates an observable sequence from a specified subscribe method implementation. This is an alias for the createWithDisposable method

    subscribe

    (Function): Implementation of the resulting observable sequence's subscribe method, optionally returning a function that will be wrapped in a disposable object. This could also be a disposable object.

    returns

    (Observable): The observable sequence with the specified implementation for the subscribe method.

    Definition Classes
    ObservableClass
  11. def defer[T](observableFactory: Function0[T]): Observable[T]

    Permalink

    Returns an observable sequence that invokes the specified factory function whenever a new observer subscribes.

    Returns an observable sequence that invokes the specified factory function whenever a new observer subscribes.

    observableFactory

    (Function): Observable factory function to invoke for each observer that subscribes to the resulting sequence.

    returns

    (Observable): An observable sequence whose observers trigger an invocation of the given observable factory function.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.defer(observableFactory)

  12. def empty[T](scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Returns an empty observable sequence, using the specified scheduler to send out the single OnCompleted message.

    Returns an empty observable sequence, using the specified scheduler to send out the single OnCompleted message.

    scheduler

    [scheduler=Rx.Scheduler.immediate] (Scheduler): Scheduler to send the termination call on.

    returns

    (Observable): An observable sequence with no elements.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.empty([scheduler])

  13. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  14. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  15. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  16. def for[T](sources: Array[Observable[T]], resultSelector: Function, thisArg: Any = js.native): Observable[T]

    Permalink

    Concatenates the observable sequences or Promises obtained by running the specified result selector for each element in source.

    Concatenates the observable sequences or Promises obtained by running the specified result selector for each element in source. There is an alias for this method called forIn for browsers < IE9

    sources

    (Array): An array of values to turn into an observable sequence.

    resultSelector

    (Function): A function to apply to each item in the sources array to turn it into an observable sequence. The resultSelector is called with the following information:

    • the value of the element
    • the index of the element
    • the Observable object being subscribed
    thisArg

    (Any): Object to use as this when executing resultSelector.

    returns

    (Observable): An observable sequence from the concatenated observable sequences or Promises.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.for(sources, resultSelector, [thisArg])

  17. def forkJoin[T](args: |[Array[Observable[T]], Observable[T]]*): Observable[T]

    Permalink

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

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

    args

    (Arguments | Array): An array or arguments of Observable sequences or Promises to collect the last elements for.

    returns

    (Observable): An observable sequence with an array collecting the last elements of all the input sequences or the result of the result selector if specified.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.forkJoin(...args, [resultSelector])

  18. def forkJoin[T](args: Array[Observable[T]], resultSelector: Function): Observable[T]

    Permalink

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

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

    args

    (Arguments | Array): An array or arguments of Observable sequences or Promises to collect the last elements for.

    resultSelector

    (Function): The result selector from all the values produced. If not specified, forkJoin will return the results as an array.

    returns

    (Observable): An observable sequence with an array collecting the last elements of all the input sequences or the result of the result selector if specified.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.forkJoin(...args, [resultSelector])

  19. def from[T](iterable: |[Array[Observable[T]], Iterator[Observable[T]]], mapFn: Function = js.native, thisArg: Any = js.native, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    This method creates a new Observable sequence from an array-like or iterable object.

    This method creates a new Observable sequence from an array-like or iterable object.

    iterable

    (Array | Arguments | Iterable): An array-like or iterable object to convert to an Observable sequence.

    mapFn

    (Function): Map function to call on every element of the array.

    thisArg

    (Any): The context to use calling the mapFn if provided.

    scheduler

    [scheduler=Rx.Scheduler.currentThread] (Scheduler): Scheduler to run the enumeration of the input sequence on.

    returns

    (Observable): The observable sequence whose elements are pulled from the given iterable sequence.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.from(iterable, [mapFn], [thisArg], [scheduler])

  20. def fromCallback[T](func: Function, context: Any = js.native, selector: Function = js.native): Observable[T]

    Permalink

    Converts a callback function to an observable sequence.

    Converts a callback function to an observable sequence.

    func

    (Function): Function with a callback as the last parameter to convert to an Observable sequence.

    context

    (Any): The context for the func parameter to be executed. If not specified, defaults to undefined.

    selector

    (Function): A selector which takes the arguments from the callback to produce a single item to yield on next.

    returns

    (Function): A function, when executed with the required parameters minus the callback, produces an Observable sequence with a single value of the arguments to the callback as an array if no selector given, else the object created by the selector function.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.fromCallback(func, [context], [selector])

  21. def fromEvent(element: Any, eventName: String, selector: Function = js.native, options: ListenerOptions = js.native): Observable[Event]

    Permalink

    Creates an observable sequence by adding an event listener to the matching DOMElement, jQuery element, Zepto Element, Angular element, Ember.js element or EventEmitter.

    Creates an observable sequence by adding an event listener to the matching DOMElement, jQuery element, Zepto Element, Angular element, Ember.js element or EventEmitter.

    Note that this uses the library approaches for jQuery, Zepto, Backbone.Marionette, AngularJS and Ember.js and falls back to native binding if not present. If you are using AMD you may need to include these libraries as dependencies of RxJs in your requirejs configuration file. RxJs will attempt to detect their presence when deciding which library to use.

    element

    (Any): The DOMElement, NodeList, jQuery element, Zepto Element, Angular element, Ember.js element or EventEmitter to attach a listener. For Backbone.Marionette this would be the application or an EventAggregator object.

    eventName

    (String): The event name to attach the observable sequence.

    selector

    (Function): A selector which takes the arguments from the event emitter so that you can return a single object.

    options

    (Object): An object of event listener options.

    returns

    (Observable): An observable sequence of events from the specified element and the specified event.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.fromEvent(element, eventName, [selector], [options])

  22. def fromEventPattern[T](addHandler: Function, removeHandler: Function = js.native, selector: Function = js.native): Observable[T]

    Permalink

    Creates an observable sequence by using the addHandler and removeHandler functions to add and remove the handlers, with an optional selector function to project the event arguments.

    Creates an observable sequence by using the addHandler and removeHandler functions to add and remove the handlers, with an optional selector function to project the event arguments.

    addHandler

    (Function): The DOMElement, NodeList or EventEmitter to attach a listener.

    removeHandler

    (Function): The optional function to remove a handler from an emitter.

    selector

    (Function): A selector which takes the arguments from the event handler to produce a single item to yield on next.

    returns

    (Observable): An observable sequence of events from the specified element and the specified event.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.fromEventPattern(addHandler, [removeHandler], [selector])

  23. def fromNodeCallback[T](func: Function, context: Any = js.native, selector: Function = js.native): Observable[T]

    Permalink

    Converts a Node.js callback style function to an observable sequence.

    Converts a Node.js callback style function to an observable sequence. This must be in function (err, ...) format.

    func

    (Function): Function with a callback as the last parameter to convert to an Observable sequence.

    context

    (Any): The context for the func parameter to be executed. If not specified, defaults to undefined.

    selector

    (Function): A selector which takes the arguments from callback sans the error to produce a single item to yield on next.

    returns

    (Function): A function which when applied, returns an observable sequence with the callback arguments as an array if no selector given, else the object created by the selector function on success, or an error if the first parameter is not falsy.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.fromNodeCallback(func, [context], [selector])

  24. def fromPromise[T](promise: |[Promise[T], Function]): Observable[T]

    Permalink

    Converts a Promises/A+ spec compliant Promise and/or ES2015 compliant Promise or a factory function which returns said Promise to an Observable sequence.

    Converts a Promises/A+ spec compliant Promise and/or ES2015 compliant Promise or a factory function which returns said Promise to an Observable sequence.

    promise

    (Promise|Function): Promises/A+ spec compliant Promise to an Observable sequence or a function which returns a Promise.

    returns

    (Observable): An Observable sequence which wraps the existing promise success and failure.

    Definition Classes
    ObservableClass
  25. def generate[T](initialState: T, condition: Function, iterate: Function, resultSelector: Function, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Generates an observable sequence in a manner similar to a for loop, using an optional scheduler to enumerate the values.

    Generates an observable sequence in a manner similar to a for loop, using an optional scheduler to enumerate the values.

    initialState

    (Any): Initial state.

    condition

    (Function): Condition to terminate generation (upon returning false).

    iterate

    (Function): Iteration step function.

    resultSelector

    (Function): Selector function for results produced in the sequence.

    scheduler

    [scheduler=Rx.Scheduler.currentThread] (Scheduler): Scheduler on which to run the generator loop. If not provided, defaults to Scheduler.currentThread.

    returns

    (Observable): The generated sequence.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.generate(initialState, condition, iterate, resultSelector, [scheduler])

  26. def generateWithAbsoluteTime[T](initialState: T, condition: Function, iterate: Function, resultSelector: Function, timeSelector: Function, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Generates an observable sequence by iterating a state from an initial state until the condition fails.

    Generates an observable sequence by iterating a state from an initial state until the condition fails.

    initialState

    (Any): Initial state.

    condition

    (Function): Condition to terminate generation (upon returning false).

    iterate

    (Function): Iteration step function.

    resultSelector

    (Function): Selector function for results produced in the sequence.

    timeSelector

    (Function): Time selector function to control the speed of values being produced each iteration, returning Date values.

    scheduler

    [scheduler=Rx.Scheduler.timeout] (Scheduler): Scheduler on which to run the generator loop. If not provided, defaults to Scheduler.timeout.

    returns

    (Observable): The generated sequence.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.generateWithAbsoluteTime(initialState, condition, iterate, resultSelector, timeSelector, [scheduler])

  27. def generateWithRelativeTime[T](initialState: T, condition: Function, iterate: Function, resultSelector: Function, timeSelector: Function, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Generates an observable sequence by iterating a state from an initial state until the condition fails.

    Generates an observable sequence by iterating a state from an initial state until the condition fails.

    initialState

    (Any): Initial state.

    condition

    (Function): Condition to terminate generation (upon returning false).

    iterate

    (Function): Iteration step function.

    resultSelector

    (Function): Selector function for results produced in the sequence.

    timeSelector

    (Function): Time selector function to control the speed of values being produced each iteration, returning integer values denoting milliseconds.

    scheduler

    [scheduler=Rx.Scheduler.timeout] (Scheduler): Scheduler on which to run the generator loop. If not provided, defaults to Scheduler.timeout.

    returns

    (Observable): The generated sequence.

    Definition Classes
    ObservableClass
  28. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  29. def hasOwnProperty(v: String): Boolean

    Permalink
    Definition Classes
    Object
  30. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  31. def if[T](condition: Function, thenSource: Observable[T], elseSource: |[Observable[T], Scheduler] = js.native): Observable[T]

    Permalink

    Determines whether an observable collection contains values.

    Determines whether an observable collection contains values. There is an alias for this method called ifThen for browsers < IE9

    condition

    (Function): The condition which determines if the thenSource or elseSource will be run.

    thenSource

    (Observable): thenSource The observable sequence that will be run if the condition function returns true.

    elseSource

    (Observable|Scheduler): The observable sequence that will be run if the condition function returns false. If this is not provided, it defaults to Rx.Observabe.Empty with the specified scheduler.

    returns

    (Observable): The generated sequence.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.if(condition, thenSource, [elseSource])

  32. def interval[T](period: Period, scheduler: Scheduler = js.native): Observable[T]

    Permalink

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

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

    period

    (Number): Period for producing the values in the resulting sequence (specified as an integer denoting milliseconds).

    scheduler

    Scheduler=Rx.Scheduler.timeout): Scheduler to run the timer on. If not specified, Rx.Scheduler.timeout is used.

    returns

    (Observable): An observable sequence that produces a value after each period. Each value produced will default to a Number denoting its order in the timeline. (e.g. 0, 1, 2...)

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.interval(period, [scheduler])

  33. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  34. def isPrototypeOf(v: Object): Boolean

    Permalink
    Definition Classes
    Object
  35. def just[T](value: T, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Returns an observable sequence that contains a single element, using the specified scheduler to send out observer messages.

    Returns an observable sequence that contains a single element, using the specified scheduler to send out observer messages.

    There is an alias called returnValue for browsers < IE9 and a regular alias called just.

    value

    (Any): Single element in the resulting observable sequence.

    scheduler

    [scheduler=Rx.Scheduler.immediate] (Scheduler): Scheduler to send the single element on. If not specified, defaults to Scheduler.immediate.

    returns

    (Observable): An observable sequence with the single element.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.just(value, [scheduler])

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/return.md

  36. def merge[T](args: |[Array[Observable[T]], Observable[T]]*): Observable[T]

    Permalink

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

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

    args

    (Array|arguments): Observable sequences to merge into a single sequence.

    returns

    (Observable): An observable sequence that produces a value after each period.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.merge([scheduler], ...args)

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/merge.md

  37. def merge[T](scheduler: Scheduler, args: |[Array[Observable[T]], Observable[T]]*): Observable[T]

    Permalink

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

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

    scheduler

    (Scheduler=Rx.Scheduler.immediate): Scheduler to run the timer on. If not specified, Rx.Scheduler.immediate is used.

    args

    (Array|arguments): Observable sequences to merge into a single sequence.

    returns

    (Observable): An observable sequence that produces a value after each period.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.merge([scheduler], ...args)

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/merge.md

  38. def mergeDelayError[T](args: |[Array[Observable[T]], Observable[T]]*): Observable[T]

    Permalink

    Flattens an Observable that emits Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.

    Flattens an Observable that emits Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.

    This behaves like Observable.prototype.mergeAll except that if any of the merged Observables notify of an error via the Observer's onError, mergeDelayError will refrain from propagating that error notification until all of the merged Observables have finished emitting items.

    args

    (Array|arguments): Arguments or an array of Observable sequences to merge.

    returns

    (Observable): An Observable that emits all of the items emitted by the Observables emitted by the Observable

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.mergeDelayError(...args)

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/mergedelayerror.md

  39. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  40. def never[T](): Observable[T]

    Permalink

    Returns a non-terminating observable sequence, which can be used to denote an infinite duration (e.g.

    Returns a non-terminating observable sequence, which can be used to denote an infinite duration (e.g. when using reactive joins).

    returns

    (Observable): An observable sequence whose observers will never get called.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.never()

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/never.md

  41. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  42. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  43. def of[T](args: T*): Observable[T]

    Permalink

    Converts arguments to an observable sequence.

    Converts arguments to an observable sequence.

    args

    (Arguments): A list of arguments to turn into an Observable sequence.

    returns

    (Observable): The observable sequence whose elements are pulled from the given arguments.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.of(...args)

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/of.md

  44. def of[T](args: Array[T]): Observable[T]

    Permalink

    Converts arguments to an observable sequence.

    Converts arguments to an observable sequence.

    args

    (Arguments): A list of arguments to turn into an Observable sequence.

    returns

    (Observable): The observable sequence whose elements are pulled from the given arguments.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.of(...args)

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/of.md

  45. def ofWithScheduler[T](args: |[Array[Any], Any]*): Observable[T]

    Permalink

    Converts arguments to an observable sequence, using an optional scheduler to enumerate the arguments.

    Converts arguments to an observable sequence, using an optional scheduler to enumerate the arguments.

    args

    (Arguments): A list of arguments to turn into an Observable sequence.

    returns

    (Observable): The observable sequence whose elements are pulled from the given arguments.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.ofWithScheduler([scheduler], ...args)

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/ofwithscheduler.md

  46. def ofWithScheduler[T](scheduler: Scheduler, args: |[Array[Any], Any]*): Observable[T]

    Permalink

    Converts arguments to an observable sequence, using an optional scheduler to enumerate the arguments.

    Converts arguments to an observable sequence, using an optional scheduler to enumerate the arguments.

    scheduler

    (Scheduler): An optional scheduler used to enumerate the arguments.

    args

    (Arguments): A list of arguments to turn into an Observable sequence.

    returns

    (Observable): The observable sequence whose elements are pulled from the given arguments.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.ofWithScheduler([scheduler], ...args)

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/ofwithscheduler.md

  47. def onErrorResumeNext[T](args: |[Array[Observable[T]], Observable[T]]*): Observable[T]

    Permalink

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

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

    args

    (Array|arguments): Observable sequences to concatenate.

    returns

    (Observable): An observable sequence that concatenates the source sequences, even if a sequence terminates exceptionally.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.onErrorResumeNext(...args)

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/onerrorresumenext.md

  48. def pairs[T](obj: Any, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Convert an object into an observable sequence of [key, value] pairs using an optional Scheduler to enumerate the object.

    Convert an object into an observable sequence of [key, value] pairs using an optional Scheduler to enumerate the object.

    obj

    (Object): The object to inspect and turn into an Observable sequence.

    scheduler

    (Scheduler): Scheduler to run the enumeration of the input sequence on. If not specified, defaults to Rx.Scheduler.currentThread

    returns

    (Observable): An observable sequence of [key, value] pairs from the object.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.pairs(obj, [scheduler])

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/pairs.md

  49. def propertyIsEnumerable(v: String): Boolean

    Permalink
    Definition Classes
    Object
  50. def range(start: Int, count: Int, scheduler: Scheduler = js.native): RangeObservable[Int]

    Permalink

    Generates an observable sequence of integral numbers within a specified range, using the specified scheduler to send out observer messages.

    Generates an observable sequence of integral numbers within a specified range, using the specified scheduler to send out observer messages.

    start

    (Number): The value of the first integer in the sequence.

    count

    (Number): The number of sequential integers to generate.

    scheduler

    [scheduler=Rx.Scheduler.currentThread] (Scheduler): Scheduler to run the generator loop on. If not specified, defaults to Scheduler.currentThread.

    returns

    (Observable): An observable sequence that contains a range of sequential integral numbers.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.range(start, count, [scheduler])

  51. def repeat[T](value: T, repeatCount: Int = 1, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Generates an observable sequence that repeats the given element the specified number of times, using the specified scheduler to send out observer messages.

    Generates an observable sequence that repeats the given element the specified number of times, using the specified scheduler to send out observer messages.

    value

    (Any): Element to repeat.

    repeatCount

    [repeatCount=-1] (Number):Number of times to repeat the element. If not specified, repeats indefinitely.

    scheduler

    [scheduler=Rx.Scheduler.immediate] (Scheduler): Scheduler to run the producer loop on. If not specified, defaults to Scheduler.immediate.

    returns

    (Observable): An observable sequence that repeats the given element the specified number of times.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.repeat(value, [repeatCount], [scheduler])

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/repeat.md

  52. def return[T](value: T, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Returns an observable sequence that contains a single element, using the specified scheduler to send out observer messages.

    Returns an observable sequence that contains a single element, using the specified scheduler to send out observer messages.

    There is an alias called returnValue for browsers < IE9 and a regular alias called just.

    value

    (Any): Single element in the resulting observable sequence.

    scheduler

    [scheduler=Rx.Scheduler.immediate] (Scheduler): Scheduler to send the single element on. If not specified, defaults to Scheduler.immediate.

    returns

    (Observable): An observable sequence with the single element.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.return(value, [scheduler])

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/return.md

  53. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  54. def throw[T](exception: Error, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Returns an observable sequence that terminates with an exception, using the specified scheduler to send out the single onError message.

    Returns an observable sequence that terminates with an exception, using the specified scheduler to send out the single onError message.

    exception

    the given exception

    scheduler

    [scheduler=Rx.Scheduler.immediate] (Scheduler): Scheduler to send the exceptional termination call on. If not specified, defaults to the immediate scheduler.

    returns

    (Observable): The observable sequence that terminates exceptionally with the specified exception object.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.throw(exception, [scheduler])

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/throw.md

  55. def throwError[T](exception: Error, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Returns an observable sequence that terminates with an exception, using the specified scheduler to send out the single onError message.

    Returns an observable sequence that terminates with an exception, using the specified scheduler to send out the single onError message.

    exception

    the given exception

    scheduler

    [scheduler=Rx.Scheduler.immediate] (Scheduler): Scheduler to send the exceptional termination call on. If not specified, defaults to the immediate scheduler.

    returns

    (Observable): The observable sequence that terminates exceptionally with the specified exception object.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.throwError(exception, [scheduler])

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/throw.md

  56. def timer[T](dueTime: |[RelativeTime, Date], period: |[Period, Scheduler] = js.native, scheduler: Scheduler = js.native): Observable[T]

    Permalink

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

    Returns an observable sequence that produces a value after dueTime has elapsed and then after each period. Note for rx.lite.js, only relative time is supported.

    dueTime

    (Date|Number): Absolute (specified as a Date object) or relative time (specified as an integer denoting milliseconds) at which to produce the first value.

    period

    [period|scheduler=Rx.Scheduler.timeout] (Number|Scheduler): Period to produce subsequent values (specified as an integer denoting milliseconds), or the scheduler to run the timer on. If not specified, the resulting timer is not recurring.

    scheduler

    [scheduler=Rx.Scheduler.timeout] (Scheduler): Scheduler to run the timer on. If not specified, the timeout scheduler is used.

    returns

    (Observable): An observable sequence that produces a value after due time has elapsed and then each period.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.timer(dueTime, [period], [scheduler])

  57. def toAsync(func: Function, context: Any = js.native, scheduler: Scheduler = js.native): Function

    Permalink

    Converts the function into an asynchronous function.

    Converts the function into an asynchronous function. Each invocation of the resulting asynchronous function causes an invocation of the original synchronous function on the specified scheduler.

    func

    (Function): Function to convert to an asynchronous function.

    context

    (Any): The context for the func parameter to be executed. If not specified, defaults to undefined.

    scheduler

    [scheduler=Rx.Scheduler.timeout] (Scheduler): Scheduler to run the function on. If not specified, defaults to Scheduler.timeout.

    returns

    (Function): Asynchronous function.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.toAsync(func, [context], [scheduler])

  58. def toLocaleString(): String

    Permalink
    Definition Classes
    Object
  59. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  60. def valueOf(): Any

    Permalink
    Definition Classes
    Object
  61. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  62. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  63. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  64. def zip[T](args: |[Array[Observer], Observable[T]]*): Observable[T]

    Permalink

    Merges the specified observable sequences or Promises into one observable sequence by using the selector function whenever all of the observable sequences or an array have produced an element at a corresponding index.

    Merges the specified observable sequences or Promises into one observable sequence by using the selector function whenever all of the observable sequences or an array have produced an element at a corresponding index.

    args

    (Arguments | Array): Arguments or an array of observable sequences.

    returns

    (Observable): An observable sequence containing the result of combining elements of the sources using the specified result selector function.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.prototype.zip(...args, [resultSelector])

  65. def zip[T](args: Array[Observer], resultSelector: Function = js.native): Observable[T]

    Permalink

    Merges the specified observable sequences or Promises into one observable sequence by using the selector function whenever all of the observable sequences or an array have produced an element at a corresponding index.

    Merges the specified observable sequences or Promises into one observable sequence by using the selector function whenever all of the observable sequences or an array have produced an element at a corresponding index.

    args

    (Arguments | Array): Arguments or an array of observable sequences.

    resultSelector

    (Function): A function which takes the inputs at the specified index and combines them together. If omitted, a list with the elements of the observable sequences at corresponding indexes will be yielded.

    returns

    (Observable): An observable sequence containing the result of combining elements of the sources using the specified result selector function.

    Definition Classes
    ObservableClass
    Example:
    1. Rx.Observable.prototype.zip(...args, [resultSelector])

Deprecated Value Members

  1. def fromArray[T](array: Array[Observable[T]], scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Converts an array to an observable sequence, using an optional scheduler to enumerate the array.

    Converts an array to an observable sequence, using an optional scheduler to enumerate the array.

    array

    (Array): An array to convert to an Observable sequence.

    scheduler

    [scheduler=Rx.Scheduler.currentThread] (Scheduler): Scheduler to run the enumeration of the input sequence on.

    returns

    (Observable): The observable sequence whose elements are pulled from the given enumerable sequence.

    Definition Classes
    ObservableClass
    Annotations
    @deprecated
    Deprecated

    (Since version 4.0) Use Rx.Observable.from instead

    Example:
    1. Rx.Observable.fromArray(array, [scheduler])

  2. def ifThen[T](condition: Function, thenSource: Observable[T], elseSource: |[Observable[T], Scheduler] = js.native): Observable[T]

    Permalink

    Determines whether an observable collection contains values.

    Determines whether an observable collection contains values. There is an alias for this method called ifThen for browsers < IE9

    condition

    (Function): The condition which determines if the thenSource or elseSource will be run.

    thenSource

    (Observable): thenSource The observable sequence that will be run if the condition function returns true.

    elseSource

    (Observable|Scheduler): The observable sequence that will be run if the condition function returns false. If this is not provided, it defaults to Rx.Observabe.Empty with the specified scheduler.

    returns

    (Observable): The generated sequence.

    Definition Classes
    ObservableClass
    Annotations
    @deprecated
    Deprecated

    (Since version 4.0) Use Rx.Observable.if instead

    Example:
    1. Rx.Observable.ifThen(condition, thenSource, [elseSource])

  3. def throwException[T](exception: Error, scheduler: Scheduler = js.native): Observable[T]

    Permalink

    Returns an observable sequence that terminates with an exception, using the specified scheduler to send out the single onError message.

    Returns an observable sequence that terminates with an exception, using the specified scheduler to send out the single onError message.

    exception

    the given exception

    scheduler

    [scheduler=Rx.Scheduler.immediate] (Scheduler): Scheduler to send the exceptional termination call on. If not specified, defaults to the immediate scheduler.

    returns

    (Observable): The observable sequence that terminates exceptionally with the specified exception object.

    Definition Classes
    ObservableClass
    Annotations
    @deprecated
    Deprecated

    (Since version 4.0) Use RX.Observable.throwError instead

    Example:
    1. Rx.Observable.throwException(exception, [scheduler])

    See also

    https://github.com/Reactive-Extensions/RxJS/blob/master/doc/api/core/operators/throw.md

Inherited from ObservableClass

Inherited from Object

Inherited from Any

Inherited from AnyRef

Inherited from Any

Ungrouped