Packages

c

org.mongodb.scala

ChangeStreamObservable

case class ChangeStreamObservable[TResult](wrapped: ChangeStreamPublisher[TResult]) extends Observable[ChangeStreamDocument[TResult]] with Product with Serializable

Observable for change streams.

Note: The ChangeStreamDocument class will not be applicable for all change stream outputs. If using custom pipelines that radically change the result, the the ChangeStreamObservable#withDocumentClass method should be used to provide an alternative document format.

TResult

The type of the result.

wrapped

the underlying java ChangeStreamIterable

Since

2.2

Note

Requires MongoDB 3.6 or greater

Linear Supertypes
Serializable, Product, Equals, Observable[ChangeStreamDocument[TResult]], Publisher[ChangeStreamDocument[TResult]], AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ChangeStreamObservable
  2. Serializable
  3. Product
  4. Equals
  5. Observable
  6. Publisher
  7. AnyRef
  8. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new ChangeStreamObservable(wrapped: ChangeStreamPublisher[TResult])

    wrapped

    the underlying java ChangeStreamIterable

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def andThen[U](pf: PartialFunction[Try[ChangeStreamDocument[TResult]], U]): Observable[ChangeStreamDocument[TResult]]

    Applies the side-effecting function to the final result of this Observable and, returns a new Observable with the result of this Observable.

    Applies the side-effecting function to the final result of this Observable and, returns a new Observable with the result of this Observable.

    This method allows one to enforce that the callbacks are executed in a specified order.

    Note that if one of the chained andThen callbacks throws an exception, that exception is not propagated to the subsequent andThen callbacks. Instead, the subsequent andThen callbacks are given the original value of this Observable.

    The following example prints out 10:

    Observable(1 to 10) andThen {
     case r => sys.error("runtime exception")
    } andThen {
     case Success(x) => print(x)
     case Failure(t) => print("Failure")
    }
    U

    the result type of the

    pf

    the partial function to pattern match against

    returns

    an

    Definition Classes
    Observable
  5. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  6. def batchSize(batchSize: Int): ChangeStreamObservable[TResult]

    Sets the number of documents to return per batch.

    Sets the number of documents to return per batch.

    batchSize

    the batch size

    returns

    this

  7. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native() @HotSpotIntrinsicCandidate()
  8. def collation(collation: Collation): ChangeStreamObservable[TResult]

    Sets the collation options

    Sets the collation options

    A null value represents the server default.

    collation

    the collation options to use

    returns

    this

  9. def collect[S](): SingleObservable[Seq[ChangeStreamDocument[TResult]]]

    Collects all the values of the Observable into a list and returns a new Observable with that list.

    Collects all the values of the Observable into a list and returns a new Observable with that list.

    Example:

    val listOfNumbers = Observable(1 to 100).collect()
    returns

    an Observable that emits a single item, the result of accumulator.

    Definition Classes
    Observable
    Note

    If the Observable is large then this will consume lots of memory! If the underlying Observable is infinite this Observable will never complete.

    See also

    Uses foldLeft underneath

  10. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  11. def fallbackTo[U >: ChangeStreamDocument[TResult]](that: Observable[U]): Observable[U]

    Creates a new Observable which returns the results of this Observable, if there is an error, it will then fallback to returning the results of the alternative "that" Observable.

    Creates a new Observable which returns the results of this Observable, if there is an error, it will then fallback to returning the results of the alternative "that" Observable.

    If both Observables fail, the resulting Observable holds the throwable object of the first Observable.

    Example:

    val fallBackObservable = Observable(1 to 100) fallbackTo Observable(200 to 300)

    Ensuring results from a Single Observer

    fallbackTo can potentially emit results from either Observer. This often isn't desirable, so to ensure only a single Observable issues results combine with the collect method eg:

    val results = Observable(1 to 100).collect() fallbackTo Observable(200 to 300).collect()
    U

    the type of the returned Observable

    that

    the Observable to fallback to if this Observable fails

    returns

    an Observable that will fallback to the that Observable should this Observable complete with an onError.

    Definition Classes
    Observable
  12. def filter(predicate: (ChangeStreamDocument[TResult]) => Boolean): Observable[ChangeStreamDocument[TResult]]

    Creates a new Observable by filtering the value of the current Observable with a predicate.

    Creates a new Observable by filtering the value of the current Observable with a predicate.

    If the current Observable fails, then the resulting Observable also fails.

    Example:

    val oddValues = Observable(1 to 100) filter { _ % 2 == 1 }
    predicate

    the function that is applied to each result emitted if it matches that result is passes to the returned Observable

    returns

    an Observable only containing items matching that match the predicate

    Definition Classes
    Observable
  13. def first(): SingleObservable[ChangeStreamDocument[TResult]]

    Helper to return a single observable limited to the first result.

    Helper to return a single observable limited to the first result.

    returns

    a single observable which will the first result.

    Since

    4.0

  14. def flatMap[S](mapFunction: (ChangeStreamDocument[TResult]) => Observable[S]): Observable[S]

    Creates a new Observable by applying a function to each emitted result of the Observable.

    Creates a new Observable by applying a function to each emitted result of the Observable. If the Observable calls errors then then the new Observable will also contain this exception.

    As each emitted item passed to onNext returns an Observable, we tightly control the requests to the parent Observable. The requested amount is then passed to the child Observable and only when that is completed does the parent become available for requesting more data.

    Example:

    def f = Observable(1 to 10)
    def g = Observable(100 to 100)
    val h = for {
      x: Int <- f // returns Observable(1 to 10)
      y: Int <- g // returns Observable(100 to 100)
    } yield x + y

    is translated to:

    f flatMap { (x: Int) => g map { (y: Int) => x + y } }
    S

    the resulting type of each item in the Observable

    mapFunction

    function that transforms a each result of the receiver into an Observable and passes each result of that Observable to the returned Observable.

    returns

    an Observable with transformed results and / or error.

    Definition Classes
    Observable
  15. def foldLeft[S](initialValue: S)(accumulator: (S, ChangeStreamDocument[TResult]) => S): SingleObservable[S]

    Creates a new Observable that contains the single result of the applied accumulator function.

    Creates a new Observable that contains the single result of the applied accumulator function.

    The first item emitted by the Observable is passed to the supplied accumulator function alongside the initial value, then all other emitted items are passed along with the previous result of the accumulator function.

    Example:

    val countingObservable = Observable(1 to 100) foldLeft(0)((v, i) => v + 1)
    initialValue

    the initial (seed) accumulator value

    accumulator

    an accumulator function to be invoked on each item emitted by the source Observable, the result of which will be used in the next accumulator call.

    returns

    an Observable that emits a single item, the result of accumulator.

    Definition Classes
    Observable
    Note

    If this function is used to collect results into a collection then it could use lots of memory! If the underlying Observable is infinite this Observable will never complete.

  16. def foreach[U](doOnEach: (ChangeStreamDocument[TResult]) => U): Unit

    Applies a function applied to each emitted result.

    Applies a function applied to each emitted result.

    Automatically requests all results

    U

    the resulting type after the transformation

    doOnEach

    the anonymous function applied to each emitted item

    Definition Classes
    Observable
  17. def fullDocument(fullDocument: FullDocument): ChangeStreamObservable[TResult]

    Sets the fullDocument value.

    Sets the fullDocument value.

    fullDocument

    the fullDocument

    returns

    this

  18. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  19. def head(): Future[ChangeStreamDocument[TResult]]

    Returns the head of the Observable in a scala.concurrent.Future.

    Returns the head of the Observable in a scala.concurrent.Future.

    returns

    the head result of the Observable.

    Definition Classes
    Observable
  20. def headOption(): Future[Option[ChangeStreamDocument[TResult]]]

    Returns the head option of the Observable in a scala.concurrent.Future.

    Returns the head option of the Observable in a scala.concurrent.Future.

    returns

    the head option result of the Observable.

    Definition Classes
    Observable
    Since

    2.2

  21. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  22. def map[S](mapFunction: (ChangeStreamDocument[TResult]) => S): Observable[S]

    Creates a new Observable by applying a function to each emitted result of the Observable.

    Creates a new Observable by applying a function to each emitted result of the Observable. If the Observable calls errors then then the new Observable will also contain this exception.

    Example:

    def f = Observable(1 to 10)
    def g = Observable(100 to 100)
    val h = for {
      x: Int <- f // returns Observable(1 to 10)
      y: Int <- g // returns Observable(100 to 100)
    } yield x + y

    is translated to:

    f flatMap { (x: Int) => g map { (y: Int) => x + y } }
    S

    the resulting type of each item in the Observable

    mapFunction

    function that transforms a each result of the receiver and passes the result to the returned Observable

    returns

    an Observable with transformed results and / or error.

    Definition Classes
    Observable
  23. def maxAwaitTime(duration: Duration): ChangeStreamObservable[TResult]

    Sets the maximum await execution time on the server for this operation.

    Sets the maximum await execution time on the server for this operation.

    Max Time

    duration

    the duration

    returns

    this

  24. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  25. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  26. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  27. def observeOn(context: ExecutionContext): Observable[ChangeStreamDocument[TResult]]

    Use a specific execution context for future operations

    Use a specific execution context for future operations

    context

    the execution context

    returns

    an Observable that uses the specified execution context

    Definition Classes
    Observable
  28. def productElementNames: Iterator[String]
    Definition Classes
    Product
  29. def recover[U >: ChangeStreamDocument[TResult]](pf: PartialFunction[Throwable, U]): Observable[U]

    Creates a new Observable that will handle any matching throwable that this Observable might contain.

    Creates a new Observable that will handle any matching throwable that this Observable might contain. If there is no match, or if this Observable contains a valid result then the new Observable will contain the same.

    Example:

    mongoExceptionObservable recover { case e: MongoException => 0 } // final result: 0
    mongoExceptionObservable recover { case e: NotFoundException => 0 } // result: exception
    U

    the type of the returned Observable

    pf

    the partial function used to pattern match against the onError throwable

    returns

    an Observable that will handle any matching throwable and not error.

    Definition Classes
    Observable
  30. def recoverWith[U >: ChangeStreamDocument[TResult]](pf: PartialFunction[Throwable, Observable[U]]): Observable[U]

    Creates a new Observable that will handle any matching throwable that this Observable might contain by assigning it a value of another Observable.

    Creates a new Observable that will handle any matching throwable that this Observable might contain by assigning it a value of another Observable.

    If there is no match, or if this Observable contains a valid result then the new Observable will contain the same result.

    Example:

    successfulObservable recoverWith { case e: ArithmeticException => observableB } // result: successfulObservable
    mongoExceptionObservable recoverWith { case t: Throwable => observableB } // result: observableB

    Ensuring results from a Single Observer

    recoverWith can potentially emit results from either Observer. This often isn't desirable, so to ensure only a single Observable issues results combine with the collect method eg:

    val results = Observable(1 to 100)
      .collect()
      .recoverWith({ case t: Throwable => Observable(200 to 300).collect() })
      .subscribe((i: Seq[Int]) => print(results))
    U

    the type of the returned Observable

    pf

    the partial function used to pattern match against the onError throwable

    returns

    an Observable that will handle any matching throwable and not error but recover with a new observable

    Definition Classes
    Observable
  31. def resumeAfter(resumeToken: Document): ChangeStreamObservable[TResult]

    Sets the logical starting point for the new change stream.

    Sets the logical starting point for the new change stream.

    resumeToken

    the resume token

    returns

    this

  32. def startAfter(startAfter: Document): ChangeStreamObservable[TResult]

    Sets the logical starting point for the new change stream.

    Sets the logical starting point for the new change stream.

    This will allow users to watch collections that have been dropped and recreated or newly renamed collections without missing any notifications.

    startAfter

    the resume token

    returns

    this

    Since

    2.7

    Note

    Requires MongoDB 4.2 or greater

    ,

    The server will report an error if both startAfter and resumeAfter are specified.

    See also

    Change stream start after

  33. def startAtOperationTime(startAtOperationTime: BsonTimestamp): ChangeStreamObservable[TResult]

    The change stream will only provide changes that occurred at or after the specified timestamp.

    The change stream will only provide changes that occurred at or after the specified timestamp.

    Any command run against the server will return an operation time that can be used here. The default value is an operation time obtained from the server before the change stream was created.

    startAtOperationTime

    the start at operation time

    returns

    this

    Since

    2.4

    Note

    Requires MongoDB 4.0 or greater

  34. def subscribe(observer: Observer[_ >: ChangeStreamDocument[TResult]]): Unit

    Request Observable to start streaming data.

    Request Observable to start streaming data.

    This is a "factory method" and can be called multiple times, each time starting a new Subscription. Each Subscription will work for only a single Observer.

    If the Observable rejects the subscription attempt or otherwise fails it will signal the error via Observer.onError.

    observer

    the Observer that will consume signals from this Observable

    Definition Classes
    ChangeStreamObservableObservable
  35. def subscribe(doOnNext: (ChangeStreamDocument[TResult]) => Any, doOnError: (Throwable) => Any, doOnComplete: () => Any): Unit

    Subscribes to the Observable and requests Long.MaxValue.

    Subscribes to the Observable and requests Long.MaxValue.

    Uses the default or overridden onNext, onError, onComplete partial functions.

    doOnNext

    anonymous function to apply to each emitted element.

    doOnError

    anonymous function to apply if there is an error.

    doOnComplete

    anonymous function to apply on completion.

    Definition Classes
    Observable
  36. def subscribe(doOnError: (Throwable) => Any, doOnComplete: () => Any): Unit

    Subscribes to the Observable and requests Long.MaxValue.

    Subscribes to the Observable and requests Long.MaxValue.

    doOnError

    anonymous function to apply if there is an error.

    doOnComplete

    anonymous function to apply on completion.

    Definition Classes
    Observable
  37. def subscribe(doOnNext: (ChangeStreamDocument[TResult]) => Any, doOnError: (Throwable) => Any): Unit

    Subscribes to the Observable and requests Long.MaxValue.

    Subscribes to the Observable and requests Long.MaxValue.

    doOnNext

    anonymous function to apply to each emitted element.

    doOnError

    anonymous function to apply if there is an error.

    Definition Classes
    Observable
  38. def subscribe(doOnNext: (ChangeStreamDocument[TResult]) => Any): Unit

    Subscribes to the Observable and requests Long.MaxValue.

    Subscribes to the Observable and requests Long.MaxValue.

    doOnNext

    anonymous function to apply to each emitted element.

    Definition Classes
    Observable
  39. def subscribe(observer: Subscriber[_ >: ChangeStreamDocument[TResult]]): Unit

    Handles the automatic boxing of a Java Observable so it conforms to the interface.

    Handles the automatic boxing of a Java Observable so it conforms to the interface.

    observer

    the Observer that will consume signals from this Observable

    Definition Classes
    Observable → Publisher
    Note

    Users should not have to implement this method but rather use the Scala Observable.

  40. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  41. def transform[S](mapFunction: (ChangeStreamDocument[TResult]) => S, errorMapFunction: (Throwable) => Throwable): Observable[S]

    Creates a new Observable by applying the resultFunction function to each emitted result.

    Creates a new Observable by applying the resultFunction function to each emitted result. If there is an error and onError is called the errorFunction function is applied to the failed result.

    S

    the resulting type of each item in the Observable

    mapFunction

    function that transforms a each result of the receiver and passes the result to the returned Observable

    errorMapFunction

    function that transforms a failure of the receiver into a failure of the returned observer

    returns

    an Observable with transformed results and / or error.

    Definition Classes
    Observable
  42. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  43. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  44. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  45. def withDocumentClass[T](clazz: Class[T]): Observable[T]

    Returns an Observable containing the results of the change stream based on the document class provided.

    Returns an Observable containing the results of the change stream based on the document class provided.

    T

    the result type

    clazz

    the class to use for the raw result.

    returns

    an Observable

  46. final def withFilter(p: (ChangeStreamDocument[TResult]) => Boolean): Observable[ChangeStreamDocument[TResult]]

    Used by for-comprehensions.

    Used by for-comprehensions.

    Definition Classes
    Observable
  47. def zip[U](that: Observable[U]): Observable[(ChangeStreamDocument[TResult], U)]

    Zips the values of this and that Observable, and creates a new Observable holding the tuple of their results.

    Zips the values of this and that Observable, and creates a new Observable holding the tuple of their results.

    If this Observable fails, the resulting Observable is failed with the throwable stored in this. Otherwise, if that Observable fails, the resulting Observable is failed with the throwable stored in that.

    It will only emit as many items as the number of items emitted by the source Observable that emits the fewest items.

    U

    the type of the that Observable

    that

    the Observable to zip with

    returns

    a new zipped Observable

    Definition Classes
    Observable

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated @deprecated
    Deprecated

    (Since version ) see corresponding Javadoc for more information.

Inherited from Serializable

Inherited from Product

Inherited from Equals

Inherited from Observable[ChangeStreamDocument[TResult]]

Inherited from Publisher[ChangeStreamDocument[TResult]]

Inherited from AnyRef

Inherited from Any

Ungrouped