web-dev-qa-db-ja.com

複数の先物を待つ方法

いくつかの先物があり、eitherそれらのいずれかが失敗するまで待つ必要があるとしますまたはそれらはすべて成功します。

例:3つの先物があるとします:f1f2f3

  • f1が成功し、f2が失敗した場合、f3を待機しません(そして、クライアントにfailureを返します)。

  • f2f1の実行中にf3が失敗した場合、それらを待機しません(そしてfailureを返します)

  • f1が成功し、f2が成功した場合、f3を待ち続けます。

どのように実装しますか?

82
Michael

代わりに次のようにfor-comprehensionを使用できます。

val fut1 = Future{...}
val fut2 = Future{...}
val fut3 = Future{...}

val aggFut = for{
  f1Result <- fut1
  f2Result <- fut2
  f3Result <- fut3
} yield (f1Result, f2Result, f3Result)

この例では、先物1、2、3が並行して開始されます。次に、理解のために、結果1、2、3が使用可能になるまで待機します。 1または2のいずれかが失敗すると、3を待つことはなくなります。 3つすべてが成功した場合、aggFut valは、3つの先物の結果に対応する3つのスロットを持つタプルを保持します。

たとえば、fut2が最初に失敗した場合に待機を停止する動作が必要な場合は、少し注意が必要です。上記の例では、fut1が完了するのを待ってからfut2が失敗したことに気付く必要があります。それを解決するには、次のようなものを試すことができます:

  val fut1 = Future{Thread.sleep(3000);1}
  val fut2 = Promise.failed(new RuntimeException("boo")).future
  val fut3 = Future{Thread.sleep(1000);3}

  def processFutures(futures:Map[Int,Future[Int]], values:List[Any], prom:Promise[List[Any]]):Future[List[Any]] = {
    val fut = if (futures.size == 1) futures.head._2
    else Future.firstCompletedOf(futures.values)

    fut onComplete{
      case Success(value) if (futures.size == 1)=> 
        prom.success(value :: values)

      case Success(value) =>
        processFutures(futures - value, value :: values, prom)

      case Failure(ex) => prom.failure(ex)
    }
    prom.future
  }

  val aggFut = processFutures(Map(1 -> fut1, 2 -> fut2, 3 -> fut3), List(), Promise[List[Any]]())
  aggFut onComplete{
    case value => println(value)
  }

これは正しく動作しますが、問題は、正常に完了したときにどのFutureMapから削除するかを知ることから生じます。結果を、その結果を生成したFutureと適切に相関させる方法がある限り、このようなものは機能します。 Mapから完了したFutureを再帰的に削除し、残りのFuturesFuture.firstCompletedOfを呼び出し、残りがなくなるまで結果を収集します。それはきれいではありませんが、あなたが話している振る舞いが本当に必要な場合、これ、または同様のものが動作する可能性があります。

78
cmbaxter

Promiseを使用して、最初の失敗、または最後に完了した集約成功のいずれかを送信できます。

def sequenceOrBailOut[A, M[_] <: TraversableOnce[_]](in: M[Future[A]] with TraversableOnce[Future[A]])(implicit cbf: CanBuildFrom[M[Future[A]], A, M[A]], executor: ExecutionContext): Future[M[A]] = {
  val p = Promise[M[A]]()

  // the first Future to fail completes the promise
  in.foreach(_.onFailure{case i => p.tryFailure(i)})

  // if the whole sequence succeeds (i.e. no failures)
  // then the promise is completed with the aggregated success
  Future.sequence(in).foreach(p trySuccess _)

  p.future
}

次に、ブロックする場合は、結果のAwaitFutureを使用するか、単にmapを他の何かに使用します。

理解の場合との違いは、ここでは最初に失敗するエラーが発生するのに対して、理解の場合は、入力コレクションのトラバーサル順で最初のエラーが発生することです(別のエラーが最初に失敗した場合でも)。例えば:

val f1 = Future { Thread.sleep(1000) ; 5 / 0 }
val f2 = Future { 5 }
val f3 = Future { None.get }

Future.sequence(List(f1,f2,f3)).onFailure{case i => println(i)}
// this waits one second, then prints "Java.lang.ArithmeticException: / by zero"
// the first to fail in traversal order

そして:

val f1 = Future { Thread.sleep(1000) ; 5 / 0 }
val f2 = Future { 5 }
val f3 = Future { None.get }

sequenceOrBailOut(List(f1,f2,f3)).onFailure{case i => println(i)}
// this immediately prints "Java.util.NoSuchElementException: None.get"
// the 'actual' first to fail (usually...)
// and it returns early (it does not wait 1 sec)
32
gourlaysama

これがアクターを使用しないソリューションです。

import scala.util._
import scala.concurrent._
import Java.util.concurrent.atomic.AtomicInteger

// Nondeterministic.
// If any failure, return it immediately, else return the final success.
def allSucceed[T](fs: Future[T]*): Future[T] = {
  val remaining = new AtomicInteger(fs.length)

  val p = promise[T]

  fs foreach {
    _ onComplete {
      case s @ Success(_) => {
        if (remaining.decrementAndGet() == 0) {
          // Arbitrarily return the final success
          p tryComplete s
        }
      }
      case f @ Failure(_) => {
        p tryComplete f
      }
    }
  }

  p.future
}
7
FranklinChen

この目的のために、私はAkkaアクターを使用します。 for-comprehensionとは異なり、futureのいずれかが失敗するとすぐに失敗するため、その意味でもう少し効率的です。

class ResultCombiner(futs: Future[_]*) extends Actor {

  var origSender: ActorRef = null
  var futsRemaining: Set[Future[_]] = futs.toSet

  override def receive = {
    case () =>
      origSender = sender
      for(f <- futs)
        f.onComplete(result => self ! if(result.isSuccess) f else false)
    case false =>
      origSender ! SomethingFailed
    case f: Future[_] =>
      futsRemaining -= f
      if(futsRemaining.isEmpty) origSender ! EverythingSucceeded
  }

}

sealed trait Result
case object SomethingFailed extends Result
case object EverythingSucceeded extends Result

次に、アクターを作成し、アクターにメッセージを送信して(返信先を確認できるように)、返信を待ちます。

val actor = actorSystem.actorOf(Props(new ResultCombiner(f1, f2, f3)))
try {
  val f4: Future[Result] = actor ? ()
  implicit val timeout = new Timeout(30 seconds) // or whatever
  Await.result(f4, timeout.duration).asInstanceOf[Result] match {
    case SomethingFailed => println("Oh noes!")
    case EverythingSucceeded => println("It all worked!")
  }
} finally {
  // Avoid memory leaks: destroy the actor
  actor ! PoisonPill
}
5
Robin Green

これは先物だけで行うことができます。これが1つの実装です。実行が早く終了しないことに注意してください!その場合、あなたはもっと洗練された何かをする必要があります(そしておそらくあなた自身で割り込みを実装します)。しかし、うまくいかないものを待ち続けたくない場合は、最初のものが終了するまで待ち続け、何も残っていないか例外が発生したときに停止することが重要です:

import scala.annotation.tailrec
import scala.util.{Try, Success, Failure}
import scala.concurrent._
import scala.concurrent.duration.Duration
import ExecutionContext.Implicits.global

@tailrec def awaitSuccess[A](fs: Seq[Future[A]], done: Seq[A] = Seq()): 
Either[Throwable, Seq[A]] = {
  val first = Future.firstCompletedOf(fs)
  Await.ready(first, Duration.Inf).value match {
    case None => awaitSuccess(fs, done)  // Shouldn't happen!
    case Some(Failure(e)) => Left(e)
    case Some(Success(_)) =>
      val (complete, running) = fs.partition(_.isCompleted)
      val answers = complete.flatMap(_.value)
      answers.find(_.isFailure) match {
        case Some(Failure(e)) => Left(e)
        case _ =>
          if (running.length > 0) awaitSuccess(running, answers.map(_.get) ++: done)
          else Right( answers.map(_.get) ++: done )
      }
  }
}

すべてが正常に機能する場合の動作の例を次に示します。

scala> awaitSuccess(Seq(Future{ println("Hi!") }, 
  Future{ Thread.sleep(1000); println("Fancy meeting you here!") },
  Future{ Thread.sleep(2000); println("Bye!") }
))
Hi!
Fancy meeting you here!
Bye!
res1: Either[Throwable,Seq[Unit]] = Right(List((), (), ()))

しかし、何かがうまくいかないとき:

scala> awaitSuccess(Seq(Future{ println("Hi!") }, 
  Future{ Thread.sleep(1000); throw new Exception("boo"); () }, 
  Future{ Thread.sleep(2000); println("Bye!") }
))
Hi!
res2: Either[Throwable,Seq[Unit]] = Left(Java.lang.Exception: boo)

scala> Bye!
5
Rex Kerr

この質問には回答しましたが、値クラスソリューション(値クラスは2.10で追加されました)を投稿しています。気軽に批判してください。

  implicit class Sugar_PimpMyFuture[T](val self: Future[T]) extends AnyVal {
    def concurrently = ConcurrentFuture(self)
  }
  case class ConcurrentFuture[A](future: Future[A]) extends AnyVal {
    def map[B](f: Future[A] => Future[B]) : ConcurrentFuture[B] = ConcurrentFuture(f(future))
    def flatMap[B](f: Future[A] => ConcurrentFuture[B]) : ConcurrentFuture[B] = concurrentFutureFlatMap(this, f) // work around no nested class in value class
  }
  def concurrentFutureFlatMap[A,B](outer: ConcurrentFuture[A], f: Future[A] => ConcurrentFuture[B]) : ConcurrentFuture[B] = {
    val p = Promise[B]()
    val inner = f(outer.future)
    inner.future onFailure { case t => p.tryFailure(t) }
    outer.future onFailure { case t => p.tryFailure(t) }
    inner.future onSuccess { case b => p.trySuccess(b) }
    ConcurrentFuture(p.future)
  }

ConcurrentFutureは、デフォルトのFuture map/flatMapをdo-this-then-that-then-the-then-all-and-fail-if-any-failに変更するオーバーヘッドのないFutureラッパーです。使用法:

def func1 : Future[Int] = Future { println("f1!");throw new RuntimeException; 1 }
def func2 : Future[String] = Future { Thread.sleep(2000);println("f2!");"f2" }
def func3 : Future[Double] = Future { Thread.sleep(2000);println("f3!");42.0 }

val f : Future[(Int,String,Double)] = {
  for {
    f1 <- func1.concurrently
    f2 <- func2.concurrently
    f3 <- func3.concurrently
  } yield for {
   v1 <- f1
   v2 <- f2
   v3 <- f3
  } yield (v1,v2,v3)
}.future
f.onFailure { case t => println("future failed $t") }

上記の例では、f1、f2、およびf3が同時に実行され、いずれかの順序で障害が発生した場合、タプルの将来はすぐに失敗します。

4
lancegatlin

TwitterのFuture APIを調べてみてください。特にFuture.collectメソッド。それはあなたが望むものを正確に行います: https://Twitter.github.io/scala_school/finagle.html

ソースコードFuture.scalaはここから入手できます。 https://github.com/Twitter/util/blob/master/util-core/src/main/scala/com/Twitter/util/Future.scala

4
JBakouny

これを使用できます:

val l = List(1, 6, 8)

val f = l.map{
  i => future {
    println("future " +i)
    Thread.sleep(i* 1000)
    if (i == 12)
      throw new Exception("6 is not legal.")
    i
  }
}

val f1 = Future.sequence(f)

f1 onSuccess{
  case l => {
    logInfo("onSuccess")
    l.foreach(i => {

      logInfo("h : " + i)

    })
  }
}

f1 onFailure{
  case l => {
    logInfo("onFailure")
  }
2
igreenfield