Packages

object EColl extends SimpleMapOps with CollectOps with FilterOps with GenericMapOps with ScanOps with MapConcatOps with SortOps with GroupByOps with Group2Ops with JoinOps with Join2Ops with TakeOps with FoldOps with GroupedOps with ReduceOps with DistinctOps with FactoryMethods with FlatjoinSupport with Constants with Framing with ECollSerializers with Serializable

Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. EColl
  2. Serializable
  3. Serializable
  4. ECollSerializers
  5. Framing
  6. Constants
  7. FlatjoinSupport
  8. FactoryMethods
  9. StrictLogging
  10. DistinctOps
  11. ReduceOps
  12. GroupedOps
  13. FoldOps
  14. TakeOps
  15. Join2Ops
  16. JoinOps
  17. Group2Ops
  18. GroupByOps
  19. SortOps
  20. MapConcatOps
  21. ScanOps
  22. GenericMapOps
  23. FilterOps
  24. CollectOps
  25. SimpleMapOps
  26. AnyRef
  27. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

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. val BufferSize: Long
    Definition Classes
    Constants
  5. val ElemBufferSize: Int
    Definition Classes
    Constants
  6. val Eol: ByteString
    Attributes
    protected
    Definition Classes
    Constants
  7. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  8. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  9. def collect[A, B](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[A, Option[B]])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[EColl[A], EColl[B]]
    Definition Classes
    CollectOps
  10. def concatenate[T](ecolls: Seq[EColl[T]], name: Option[String] = None)(implicit tsc: TaskSystemComponents): Future[EColl[T]]
    Definition Classes
    FactoryMethods
  11. def decodeFileForFlatJoin[T](decoder: Deserializer[T], stringKey: StringKey[T], parallelism: Int)(ecoll: SharedFile)(implicit ec: ExecutionContext, tsc: TaskSystemComponents): Source[(String, T), _]
    Definition Classes
    Framing
  12. def decodeFrame: Flow[ByteString, ByteString, NotUsed]
    Definition Classes
    Framing
  13. implicit def decoder[A]: Decoder[EColl[A]]
    Definition Classes
    ECollSerializers
  14. def distinct[A](taskID: String, taskVersion: Int, outName: Option[String] = None)(implicit arg0: SerDe[A]): Partial[EColl[A], EColl[A]]
    Definition Classes
    DistinctOps
  15. implicit def encoder[A]: Encoder[EColl[A]]
    Definition Classes
    ECollSerializers
  16. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  17. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  18. def filter[A](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[A, Boolean])(implicit arg0: SerDe[A]): Partial[EColl[A], EColl[A]]
    Definition Classes
    FilterOps
  19. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  20. implicit def flatJoinFormat[T](implicit arg0: Deserializer[T], arg1: Serializer[T]): Format[T]
    Definition Classes
    FlatjoinSupport
  21. def fold[A, B](taskID: String, taskVersion: Int)(fun: Spore[(B, A), B])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[(EColl[A], B), EColl[B]]
    Definition Classes
    FoldOps
  22. def foldConstant[A, B](taskID: String, taskVersion: Int, zero: B)(fun: Spore[(B, A), B])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[EColl[A], EColl[B]]
    Definition Classes
    FoldOps
  23. def foldWithFirst[A, B](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[(B, A), B])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[(EColl[A], EColl[B]), EColl[B]]
    Definition Classes
    FoldOps
  24. def fromIterator[T](it: Iterator[T], name: Option[String] = None, parallelism: Int = 1)(implicit arg0: Serializer[T], tsc: TaskSystemComponents): Future[EColl[T]]
    Definition Classes
    FactoryMethods
  25. def fromSource[T](source: Source[T, _], name: Option[String] = None, parallelism: Int = 1)(implicit encoder: Serializer[T], tsc: TaskSystemComponents): Future[EColl[T]]
    Definition Classes
    FactoryMethods
  26. def genericMap[A, B, C](taskID: String, taskVersion: Int, parallelize: Boolean, outName: Option[String] = None)(fun: Spore[(Source[A, NotUsed], Option[B], ComputationEnvironment, SerDe[A], SerDe[B]), Source[C, NotUsed]])(implicit arg0: SerDe[A], arg1: SerDe[B], arg2: SerDe[C]): Partial[(EColl[A], Option[EColl[B]]), EColl[C]]
    Definition Classes
    GenericMapOps
  27. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  28. def group2[AA, A, BB, B, C](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(preTransformA: Spore[AA, List[A]], preTransformB: Spore[BB, List[B]], keyA: Spore[A, String], keyB: Spore[B, String], postTransform: Spore[Seq[(Option[A], Option[B])], List[C]])(implicit arg0: SerDe[AA], arg1: SerDe[BB], arg2: SerDe[C], sr: SerDe[(Option[A], Option[B])]): Partial[(EColl[AA], EColl[BB]), EColl[C]]
    Definition Classes
    Group2Ops
  29. def groupBy[A](taskID: String, taskVersion: Int)(maxParallelJoins: Spore[Unit, Option[Int]], numberOfShards: Spore[Unit, Option[Int]], fun: Spore[A, String])(implicit arg0: SerDe[A], w: SerDe[Seq[A]]): Partial[EColl[A], EColl[Seq[A]]]
    Definition Classes
    GroupByOps
  30. def groupByAndAggregate[A, B](taskID: String, taskVersion: Int, outName: Option[String] = None)(maxParallelJoins: Spore[Unit, Option[Int]], numberOfShards: Spore[Unit, Option[Int]], fun: Spore[A, String], aggregate: Spore[Seq[A], B])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[EColl[A], EColl[B]]
    Definition Classes
    GroupByOps
  31. def groupByPresorted[A](taskID: String, taskVersion: Int)(fun: Spore[A, String])(implicit arg0: SerDe[A], w: SerDe[Seq[A]]): Partial[EColl[A], EColl[Seq[A]]]
    Definition Classes
    GroupByOps
  32. def groupByPresortedAndAggregate[A, B](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[A, String], aggregate: Spore[Seq[A], B])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[EColl[A], EColl[B]]
    Definition Classes
    GroupByOps
  33. def grouped[A](taskID: String, taskVersion: Int, outName: Option[String] = None)(implicit arg0: SerDe[A], r: SerDe[Int], rs: SerDe[Seq[A]]): Partial[(EColl[A], Int), EColl[Seq[A]]]
    Definition Classes
    GroupedOps
  34. def groupedTotal[A](taskID: String, taskVersion: Int)(implicit arg0: SerDe[A], r: SerDe[Int], rs: SerDe[Seq[A]]): Partial[EColl[A], EColl[Seq[A]]]
    Definition Classes
    GroupedOps
  35. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  36. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  37. def join[A](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(key: Spore[A, String])(implicit arg0: SerDe[A], sr: SerDe[Seq[Option[A]]]): Partial[List[(EColl[A], Boolean)], EColl[Seq[Option[A]]]]
    Definition Classes
    JoinOps
  38. def join2Inner[A, B](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(keyA: Spore[A, String], keyB: Spore[B, String])(implicit arg0: SerDe[A], arg1: SerDe[B], sr: SerDe[(A, B)], sr2: SerDe[(Option[A], Option[B])]): Partial[(EColl[A], EColl[B]), EColl[(A, B)]]
    Definition Classes
    Join2Ops
  39. def join2InnerTx[AA, A, BB, B, C](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(preTransformA: Spore[AA, List[A]], preTransformB: Spore[BB, List[B]], keyA: Spore[A, String], keyB: Spore[B, String], postTransform: Spore[Seq[(A, B)], List[C]])(implicit arg0: SerDe[AA], arg1: SerDe[BB], arg2: SerDe[C], sr: SerDe[(Option[A], Option[B])]): Partial[(EColl[AA], EColl[BB]), EColl[C]]
    Definition Classes
    Join2Ops
  40. def join2LeftOuter[A, B](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(keyA: Spore[A, String], keyB: Spore[B, String])(implicit arg0: SerDe[A], arg1: SerDe[B], sr: SerDe[(Option[A], B)], sr2: SerDe[(Option[A], Option[B])]): Partial[(EColl[A], EColl[B]), EColl[(Option[A], B)]]
    Definition Classes
    Join2Ops
  41. def join2LeftOuterTx[AA, A, BB, B, C](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(preTransformA: Spore[AA, List[A]], preTransformB: Spore[BB, List[B]], keyA: Spore[A, String], keyB: Spore[B, String], postTransform: Spore[Seq[(Option[A], B)], List[C]])(implicit arg0: SerDe[AA], arg1: SerDe[BB], arg2: SerDe[C], sr: SerDe[(Option[A], Option[B])]): Partial[(EColl[AA], EColl[BB]), EColl[C]]
    Definition Classes
    Join2Ops
  42. def join2Outer[A, B](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(keyA: Spore[A, String], keyB: Spore[B, String])(implicit arg0: SerDe[A], arg1: SerDe[B], sr: SerDe[(Option[A], Option[B])]): Partial[(EColl[A], EColl[B]), EColl[(Option[A], Option[B])]]
    Definition Classes
    Join2Ops
  43. def join2OuterTx[AA, A, BB, B, C](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(preTransformA: Spore[AA, List[A]], preTransformB: Spore[BB, List[B]], keyA: Spore[A, String], keyB: Spore[B, String], postTransform: Spore[Seq[(Option[A], Option[B])], List[C]])(implicit arg0: SerDe[AA], arg1: SerDe[BB], arg2: SerDe[C], sr: SerDe[(Option[A], Option[B])]): Partial[(EColl[AA], EColl[BB]), EColl[C]]
    Definition Classes
    Join2Ops
  44. def join2RightOuter[A, B](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(keyA: Spore[A, String], keyB: Spore[B, String])(implicit arg0: SerDe[A], arg1: SerDe[B], sr: SerDe[(A, Option[B])], sr2: SerDe[(Option[A], Option[B])]): Partial[(EColl[A], EColl[B]), EColl[(A, Option[B])]]
    Definition Classes
    Join2Ops
  45. def join2RightOuterTx[AA, A, BB, B, C](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(preTransformA: Spore[AA, List[A]], preTransformB: Spore[BB, List[B]], keyA: Spore[A, String], keyB: Spore[B, String], postTransform: Spore[Seq[(A, Option[B])], List[C]])(implicit arg0: SerDe[AA], arg1: SerDe[BB], arg2: SerDe[C], sr: SerDe[(Option[A], Option[B])]): Partial[(EColl[AA], EColl[BB]), EColl[C]]
    Definition Classes
    Join2Ops
  46. def join2ThenMap[AA, A, BB, B, C](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(preTransformA: Spore[AA, List[A]], preTransformB: Spore[BB, List[B]], keyA: Spore[A, String], keyB: Spore[B, String], postTransform: Spore[Seq[(Option[A], Option[B])], List[C]])(implicit arg0: SerDe[AA], arg1: SerDe[BB], arg2: SerDe[C], sr: SerDe[(Option[A], Option[B])]): Partial[((EColl[AA], Boolean), (EColl[BB], Boolean)), EColl[C]]
    Definition Classes
    Join2Ops
  47. def joinThenMap[A, B](taskID: String, taskVersion: Int, maxParallelJoins: Option[Int], numberOfShards: Option[Int], outName: Option[String] = None)(key: Spore[A, String], transform: Spore[Seq[Seq[Option[A]]], List[B]])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[List[(EColl[A], Boolean)], EColl[B]]
    Definition Classes
    JoinOps
  48. val logger: Logger
    Attributes
    protected
    Definition Classes
    StrictLogging
  49. def map[A, B](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[A, B])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[EColl[A], EColl[B]]
    Definition Classes
    SimpleMapOps
  50. def mapConcat[A, B](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[A, Seq[B]])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[EColl[A], EColl[B]]
    Definition Classes
    MapConcatOps
  51. def mapWith[A, B, C](taskID: String, taskVersion: Int, parallelize: Boolean)(fun: Spore[(Source[A, NotUsed], B, ComputationEnvironment, SerDe[A], SerDe[B]), Source[C, NotUsed]])(implicit arg0: SerDe[A], arg1: SerDe[B], arg2: SerDe[C]): Partial[(EColl[A], B), EColl[C]]
    Definition Classes
    GenericMapOps
  52. def mapWithContext[A, B, C](taskID: String, taskVersion: Int, parallelize: Boolean)(fun: Spore[(Source[A, NotUsed], ComputationEnvironment, SerDe[A], SerDe[B]), Source[C, NotUsed]])(implicit arg0: SerDe[A], arg1: SerDe[B], arg2: SerDe[C]): Partial[(EColl[A], EColl[B]), EColl[C]]
    Definition Classes
    GenericMapOps
  53. def mapWithFirst[A, B, C](taskID: String, taskVersion: Int, parallelize: Boolean)(fun: Spore[(Source[A, NotUsed], B, ComputationEnvironment, SerDe[A], SerDe[B]), Source[C, NotUsed]])(implicit arg0: SerDe[A], arg1: SerDe[B], arg2: SerDe[C]): Partial[(EColl[A], EColl[B]), EColl[C]]
    Definition Classes
    GenericMapOps
  54. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  55. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  56. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  57. def reduce[A](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[(A, A), A])(implicit arg0: SerDe[A]): Partial[EColl[A], EColl[A]]
    Definition Classes
    ReduceOps
  58. def scan[A, B](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[(B, A), B])(implicit arg0: SerDe[A], arg1: SerDe[B]): Partial[(EColl[A], EColl[B]), EColl[B]]
    Definition Classes
    ScanOps
  59. def single[T](t: T, name: Option[String] = None)(implicit encoder: Serializer[T], tsc: TaskSystemComponents): Future[EColl[T]]
    Definition Classes
    FactoryMethods
  60. def sink[T](name: Option[String] = None, parallelism: Int = 1)(implicit encoder: Serializer[T], tsc: TaskSystemComponents): Sink[T, Future[EColl[T]]]
    Definition Classes
    FactoryMethods
  61. def sortBy[A](taskID: String, taskVersion: Int, outName: Option[String] = None)(fun: Spore[A, String])(implicit arg0: SerDe[A]): Partial[EColl[A], EColl[A]]
    Definition Classes
    SortOps
  62. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  63. def take[A](taskID: String, taskVersion: Int, outName: Option[String] = None)(implicit arg0: SerDe[A], r: SerDe[Long]): Partial[(EColl[A], Long), EColl[A]]
    Definition Classes
    TakeOps
  64. def toString(): String
    Definition Classes
    AnyRef → Any
  65. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  66. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  67. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()

Inherited from Serializable

Inherited from Serializable

Inherited from ECollSerializers

Inherited from Framing

Inherited from Constants

Inherited from FlatjoinSupport

Inherited from FactoryMethods

Inherited from StrictLogging

Inherited from DistinctOps

Inherited from ReduceOps

Inherited from GroupedOps

Inherited from FoldOps

Inherited from TakeOps

Inherited from Join2Ops

Inherited from JoinOps

Inherited from Group2Ops

Inherited from GroupByOps

Inherited from SortOps

Inherited from MapConcatOps

Inherited from ScanOps

Inherited from GenericMapOps

Inherited from FilterOps

Inherited from CollectOps

Inherited from SimpleMapOps

Inherited from AnyRef

Inherited from Any

Ungrouped