implicit final class DeprecatedExtensions[+A] extends AnyVal with ObservableDeprecatedMethods[A]
Exposes extension methods for deprecated Observable methods.
- Alphabetic
- By Inheritance
- DeprecatedExtensions
- ObservableDeprecatedMethods
- AnyVal
- Any
- Hide All
- Show All
- Public
- All
Instance Constructors
- new DeprecatedExtensions(self: Observable[A])
Value Members
-
final
def
!=(arg0: Any): Boolean
- Definition Classes
- Any
-
final
def
##(): Int
- Definition Classes
- Any
-
final
def
==(arg0: Any): Boolean
- Definition Classes
- Any
-
final
def
asInstanceOf[T0]: T0
- Definition Classes
- Any
-
def
getClass(): Class[_ <: AnyVal]
- Definition Classes
- AnyVal → Any
-
final
def
isInstanceOf[T0]: Boolean
- Definition Classes
- Any
-
val
self: Observable[A]
- Definition Classes
- DeprecatedExtensions → ObservableDeprecatedMethods
-
def
toString(): String
- Definition Classes
- Any
Deprecated Value Members
-
def
countF: Observable[Long]
DEPRECATED — renamed to Observable.count in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.count in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to count (no F suffix)
-
def
delaySubscription(timespan: FiniteDuration): Observable[A]
DEPRECATED - renamed to delayExecution.
DEPRECATED - renamed to delayExecution.
The reason for the deprecation is making the name more consistent with Task.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to Observable!.delayExecution
-
def
delaySubscriptionWith(trigger: Observable[Any]): Observable[A]
DEPRECATED - renamed to delayExecutionWith.
DEPRECATED - renamed to delayExecutionWith.
The reason for the deprecation is making the name more consistent with delayExecution.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to Observable!.delayExecutionWith
-
def
doAfterSubscribe(cb: () ⇒ Unit): Observable[A]
DEPRECATED — signature changed to use Task.
DEPRECATED — signature changed to use Task.
Switch to:
Note that via the magic of monix.eval.TaskLike which supports
Function0
conversions, you can still use side effectful callbacks in doAfterSubscribeF, but it isn't recommended:import monix.reactive._ Observable.range(0, 10).doAfterSubscribeF { () => println("Look ma! Side-effectful callbacks!") }
The switch to
Task
is to encourage referential transparency, so use it.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to doAfterSubscribe or doAfterSubscribeF
-
def
doAfterTerminate(cb: (Option[Throwable]) ⇒ Unit): Observable[A]
DEPRECATED — this function has no direct replacement.
DEPRECATED — this function has no direct replacement.
Switching to Observable.guaranteeCase is recommended.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to guaranteeCase
-
def
doAfterTerminateEval[F[_]](cb: (Option[Throwable]) ⇒ F[Unit])(implicit F: TaskLike[F]): Observable[A]
DEPRECATED — this function has no direct replacement.
DEPRECATED — this function has no direct replacement.
Switching to Observable.guaranteeCaseF is recommended.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to guaranteeCaseF
-
def
doAfterTerminateTask(cb: (Option[Throwable]) ⇒ Task[Unit]): Observable[A]
DEPRECATED — this function has no direct replacement.
DEPRECATED — this function has no direct replacement.
Switching to Observable.guaranteeCase is recommended.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to guaranteeCase
-
def
doOnComplete(cb: () ⇒ Unit): Observable[A]
DEPRECATED - signature changed to usage of
Task
.DEPRECATED - signature changed to usage of
Task
. You can switch to:NOTE that you can still use side effectful functions with
doOnCompleteF
, via the magic of monix.eval.TaskLike, but it's no longer recommended:import monix.reactive._ // Needed for the Comonad[Function0] instance Observable.range(0, 100) .doOnCompleteF(() => println("Completed!"))
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Signature changed, switch to doOnCompleteF
-
def
doOnCompleteEval[F[_]](effect: F[Unit])(implicit F: TaskLike[F]): Observable[A]
DEPRECATED — renamed to doOnCompleteF.
DEPRECATED — renamed to doOnCompleteF.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnCompleteF
-
def
doOnCompleteTask(task: Task[Unit]): Observable[A]
DEPRECATED — renamed to doOnComplete.
DEPRECATED — renamed to doOnComplete.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnComplete
-
def
doOnEarlyStop(cb: () ⇒ Unit): Observable[A]
DEPRECATED — signature changed, please see:
DEPRECATED — signature changed, please see:
NOTE you can still get the same behavior via
doOnEarlyStopF
, becauseFunction0
implementscats.Comonad
andTask
conversions fromComonad
are allowed, although frankly in this casedoOnEarlyStop
:import monix.reactive._ // This is possible, but it's better to work with // pure functions, so use Task or IO ;-) Observable.range(0, 1000).take(10).doOnEarlyStopF { // Via the magic of `TaskLike`, we are allowed to use `Function0` () => println("Stopped!") }
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Signature changed to usage of Task
-
def
doOnEarlyStopEval[F[_]](effect: F[Unit])(implicit F: TaskLike[F]): Observable[A]
DEPRECATED — renamed to doOnEarlyStopF.
DEPRECATED — renamed to doOnEarlyStopF.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnEarlyStopF
-
def
doOnEarlyStopTask(task: Task[Unit]): Observable[A]
DEPRECATED — renamed to doOnEarlyStop.
DEPRECATED — renamed to doOnEarlyStop.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnEarlyStopF
-
def
doOnError(cb: (Throwable) ⇒ Unit): Observable[A]
DEPRECATED — Signature changed, see doOnError.
DEPRECATED — Signature changed, see doOnError.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Signature changed to use Task
-
def
doOnErrorEval[F[_]](cb: (Throwable) ⇒ F[Unit])(implicit F: TaskLike[F]): Observable[A]
DEPRECATED — renamed to doOnErrorF.
DEPRECATED — renamed to doOnErrorF.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnErrorF
-
def
doOnErrorTask(cb: (Throwable) ⇒ Task[Unit]): Observable[A]
DEPRECATED — renamed to doOnError.
DEPRECATED — renamed to doOnError.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnError
-
def
doOnNext(cb: (A) ⇒ Unit): Observable[A]
DEPRECATED — signature for function changed to use monix.eval.Task.
DEPRECATED — signature for function changed to use monix.eval.Task.
import monix.eval._ import monix.reactive._ Observable.range(0, 100).doOnNext { a => Task(println(s"Next: $$a")) }
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Signature changed to use Task
-
def
doOnNextAck(cb: (A, Ack) ⇒ Unit): Observable[A]
DEPRECATED — signature changed to use monix.eval.Task.
DEPRECATED — signature changed to use monix.eval.Task.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Signature changed to use Task
-
def
doOnNextAckEval[F[_]](cb: (A, Ack) ⇒ F[Unit])(implicit F: TaskLike[F]): Observable[A]
DEPRECATED — renamed to Observable.doOnNextAckF.
DEPRECATED — renamed to Observable.doOnNextAckF.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnNextAckF
-
def
doOnNextAckTask(cb: (A, Ack) ⇒ Task[Unit]): Observable[A]
DEPRECATED — renamed to Observable.doOnNextAck.
DEPRECATED — renamed to Observable.doOnNextAck.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnNextAck
-
def
doOnNextEval[F[_]](cb: (A) ⇒ F[Unit])(implicit F: TaskLike[F]): Observable[A]
DEPRECATED — renamed to Observable.doOnNextF.
DEPRECATED — renamed to Observable.doOnNextF.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnNextF
-
def
doOnNextTask(cb: (A) ⇒ Task[Unit]): Observable[A]
DEPRECATED — renamed to Observable.doOnNext.
DEPRECATED — renamed to Observable.doOnNext.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnNext
-
def
doOnStart(cb: (A) ⇒ Unit): Observable[A]
DEPRECATED — signature changed to use monix.eval.Task
DEPRECATED — signature changed to use monix.eval.Task
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Signature changed to use Task
-
def
doOnStartEval[F[_]](cb: (A) ⇒ F[Unit])(implicit F: Effect[F]): Observable[A]
DEPRECATED — renamed to Observable.doOnStartF
DEPRECATED — renamed to Observable.doOnStartF
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnStartF
-
def
doOnStartTask(cb: (A) ⇒ Task[Unit]): Observable[A]
DEPRECATED — renamed to Observable.doOnStart
DEPRECATED — renamed to Observable.doOnStart
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to doOnStart
-
def
doOnSubscribe(cb: () ⇒ Unit): Observable[A]
DEPRECATED — signature changed to use Task.
DEPRECATED — signature changed to use Task.
Switch to:
Note that via the magic of monix.eval.TaskLike which supports
Function0
conversions, you can still use side effectful callbacks in doOnSubscribeF, but it isn't recommended:import monix.reactive._ Observable.range(0, 10).doOnSubscribeF { () => println("Look ma! Side-effectful callbacks!") }
The switch to
Task
is to encourage referential transparency, so use it.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to doOnStart or doOnStartF
-
def
doOnSubscriptionCancel(cb: () ⇒ Unit): Observable[A]
DEPRECATED - you can switch to:
DEPRECATED - you can switch to:
NOTE that you can still use side effectful functions with
doOnSubscriptionCancelF
, via the magic of monix.eval.TaskLike, but it's no longer recommended:import monix.reactive._ Observable.range(0, Int.MaxValue) .doOnEarlyStopF(() => println("Cancelled!"))
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Signature changed, switch to doOnSubscriptionCancelF
-
def
doOnTerminate(cb: (Option[Throwable]) ⇒ Unit): Observable[A]
DEPRECATED — switch to:
DEPRECATED — switch to:
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to guaranteeCase
-
def
doOnTerminateEval[F[_]](cb: (Option[Throwable]) ⇒ F[Unit])(implicit F: TaskLike[F]): Observable[A]
DEPRECATED — a much better version of
doOnTerminateEval
is guaranteeCaseF.DEPRECATED — a much better version of
doOnTerminateEval
is guaranteeCaseF.Example:
import cats.effect.{ExitCase, IO} import monix.reactive._ Observable.range(0, 1000).guaranteeCaseF { case ExitCase.Error(e) => IO(println(s"Error raised: $$e")) case ExitCase.Completed => IO(println("Stream completed normally")) case ExitCase.Canceled => IO(println("Stream was cancelled")) }
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to guaranteeCaseF
-
def
doOnTerminateTask(cb: (Option[Throwable]) ⇒ Task[Unit]): Observable[A]
DEPRECATED — a much better version of
doOnTerminateTask
is guaranteeCase.DEPRECATED — a much better version of
doOnTerminateTask
is guaranteeCase.Example:
import cats.effect.ExitCase import monix.eval._ import monix.reactive._ Observable.range(0, 1000).guaranteeCase { case ExitCase.Error(e) => Task(println(s"Error raised: $$e")) case ExitCase.Completed => Task(println("Stream completed normally")) case ExitCase.Canceled => Task(println("Stream was cancelled")) }
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to guaranteeCase
-
def
executeWithFork: Observable[A]
DEPRECATED - renamed to executeAsync.
DEPRECATED - renamed to executeAsync.
The reason for the deprecation is the repurposing of the word "fork" in Task.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to Observable!.executeAsync
-
def
existsF(p: (A) ⇒ Boolean): Observable[Boolean]
DEPRECATED — renamed to Observable.forall in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.forall in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to exists (no F suffix)
-
def
findF(p: (A) ⇒ Boolean): Observable[A]
DEPRECATED — renamed to Observable.find in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.find in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to find (no F suffix)
-
def
firstOrElseF[B >: A](default: ⇒ B): Observable[B]
DEPRECATED — renamed to Observable.firstOrElse in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.firstOrElse in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to firstOrElse (no F suffix)
-
def
foldF[AA >: A](implicit A: Monoid[AA]): Observable[AA]
DEPRECATED — renamed to Observable.fold in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.fold in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to find (no F suffix)
-
def
foldLeftF[R](seed: ⇒ R)(op: (R, A) ⇒ R): Observable[R]
DEPRECATED — renamed to Observable.foldLeft in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.foldLeft in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to foldLeft (no F suffix)
-
def
foldWhileLeftF[S](seed: ⇒ S)(op: (S, A) ⇒ Either[S, S]): Observable[S]
DEPRECATED — renamed to Observable.foldWhileLeft in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.foldWhileLeft in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to foldWhileLeft (no F suffix)
-
def
forAllF(p: (A) ⇒ Boolean): Observable[Boolean]
DEPRECATED — renamed to Observable.forall in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.forall in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to forall (no camel case in forall, no F suffix)
-
def
forAllL(p: (A) ⇒ Boolean): Task[Boolean]
DEPRECATED — renamed to Observable.forallL in an effort to unify the naming conventions with
Iterant
and Scala's standard library.DEPRECATED — renamed to Observable.forallL in an effort to unify the naming conventions with
Iterant
and Scala's standard library.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to forallL (no camel case in forall)
-
def
headF: Observable[A]
DEPRECATED — renamed to Observable.head in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.head in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to head (no F suffix)
-
def
headOrElseF[B >: A](default: ⇒ B): Observable[B]
DEPRECATED — renamed to Observable.headOrElse in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.headOrElse in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to headOrElse (no F suffix)
-
def
isEmptyF: Observable[Boolean]
DEPRECATED — renamed to Observable.isEmpty in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.isEmpty in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to isEmpty (no F suffix)
-
def
lastF: Observable[A]
DEPRECATED — renamed to Observable.forall in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.forall in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to last (no F suffix)
-
def
mapFuture[B](f: (A) ⇒ Future[B]): Observable[B]
DEPRECATED — switch to Observable.mapEvalF, which is the generic version that supports usage with
Future
via the magic of monix.eval.TaskLike.DEPRECATED — switch to Observable.mapEvalF, which is the generic version that supports usage with
Future
via the magic of monix.eval.TaskLike.The replacement is direct, a simple rename:
import scala.concurrent._ import scala.concurrent.duration._ import monix.execution.FutureUtils.extensions._ import monix.reactive._ Observable.range(0, 100).mapEvalF { a => import monix.execution.Scheduler.Implicits.global Future.delayedResult(1.second)(a) }
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Switch to mapEvalF
-
def
mapTask[B](f: (A) ⇒ Task[B]): Observable[B]
DEPRECATED — renamed to Observable.mapEval.
DEPRECATED — renamed to Observable.mapEval.
- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to mapEval
-
def
maxByF[K](key: (A) ⇒ K)(implicit K: Order[K]): Observable[A]
DEPRECATED — renamed to Observable.maxBy in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.maxBy in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to maxBy (no F suffix)
-
def
maxF[AA >: A](implicit A: Order[AA]): Observable[AA]
DEPRECATED — renamed to Observable.max in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.max in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to max (no F suffix)
-
def
minByF[K](key: (A) ⇒ K)(implicit K: Order[K]): Observable[A]
DEPRECATED — renamed to Observable.minBy in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.minBy in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to minBy (no F suffix)
-
def
minF[AA >: A](implicit A: Order[AA]): Observable[AA]
DEPRECATED — renamed to Observable.min in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.min in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to min (no F suffix)
-
def
nonEmptyF: Observable[Boolean]
DEPRECATED — renamed to Observable.nonEmpty in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.nonEmpty in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to nonEmpty (no F suffix)
-
def
scanTask[S](seed: Task[S])(op: (S, A) ⇒ Task[S]): Observable[S]
DEPRECATED — renamed to Observable.scanEval.
DEPRECATED — renamed to Observable.scanEval.
Renaming was done for naming consistency. Functions that use Task parameters in
Observable
no longer have aTask
suffix.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to scanEval
-
def
scanTask0[S](seed: Task[S])(op: (S, A) ⇒ Task[S]): Observable[S]
DEPRECATED — renamed to Observable.scanEval0.
DEPRECATED — renamed to Observable.scanEval0.
Renaming was done for naming consistency. Functions that use Task parameters in
Observable
no longer have aTask
suffix.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to scanEval0
-
def
sumF[AA >: A](implicit A: Numeric[AA]): Observable[AA]
DEPRECATED — renamed to Observable.sum in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.DEPRECATED — renamed to Observable.sum in an effort to unify the naming conventions with
Iterant
, Scala's standard library and Cats-Effect.The
F
suffix now represents working with higher-kinded types, e.g.F[_]
, with restrictions like ObservableLike, TaskLike,cats.effect.Sync
, etc.- Definition Classes
- ObservableDeprecatedMethods
- Annotations
- @deprecated
- Deprecated
(Since version 3.0.0) Renamed to sum (no F suffix)