Class

org.qcri.rheem.api

FlatMapDataQuantaBuilder

Related Doc: package api

Permalink

class FlatMapDataQuantaBuilder[In, Out] extends BasicDataQuantaBuilder[FlatMapDataQuantaBuilder[In, Out], Out]

DataQuantaBuilder implementation for org.qcri.rheem.basic.operators.FlatMapOperators.

Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. FlatMapDataQuantaBuilder
  2. BasicDataQuantaBuilder
  3. DataQuantaBuilder
  4. Logging
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new FlatMapDataQuantaBuilder(inputDataQuanta: DataQuantaBuilder[_, In], udf: SerializableFunction[In, Iterable[Out]])(implicit javaPlanBuilder: JavaPlanBuilder)

    Permalink

    inputDataQuanta

    DataQuantaBuilder for the input DataQuanta

    udf

    UDF for the org.qcri.rheem.basic.operators.FlatMapOperator

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 asEdges[T <: EdgeDataQuantaBuilder[T]]: EdgeDataQuantaBuilder[T]

    Permalink

    Enriches the set of operations to Edge-based ones.

    Enriches the set of operations to Edge-based ones. This instances must deal with data quanta of type Edge, though. Because of Java's type erasure, we need to leave it up to you whether this operation is applicable.

    returns

    a EdgeDataQuantaBuilder

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

    Permalink
    Definition Classes
    Any
  6. def asRecords[T <: RecordDataQuantaBuilder[T]]: RecordDataQuantaBuilder[T]

    Permalink

    Enriches the set of operations to Record-based ones.

    Enriches the set of operations to Record-based ones. This instances must deal with data quanta of type Record, though. Because of Java's type erasure, we need to leave it up to you whether this operation is applicable.

    returns

    a RecordDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  7. def build: DataQuanta[Out]

    Permalink

    Create the DataQuanta built by this instance.

    Create the DataQuanta built by this instance. Note the configuration being done in dataQuanta().

    returns

    the created and partially configured DataQuanta

    Attributes
    protected
    Definition Classes
    FlatMapDataQuantaBuilderBasicDataQuantaBuilder
  8. def cartesian[ThatOut](that: DataQuantaBuilder[_, ThatOut]): CartesianDataQuantaBuilder[Out, ThatOut]

    Permalink

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.CartesianOperator.

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.CartesianOperator.

    returns

    a CartesianDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  9. implicit def classTag: ClassTag[Out]

    Permalink

    Provide a ClassTag for the constructed DataQuanta.

    Provide a ClassTag for the constructed DataQuanta.

    returns

    the ClassTag

    Attributes
    protected[org.qcri.rheem.api]
    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  10. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  11. def coGroup[ThatOut, Key](thisKeyUdf: SerializableFunction[Out, Key], that: DataQuantaBuilder[_, ThatOut], thatKeyUdf: SerializableFunction[ThatOut, Key]): CoGroupDataQuantaBuilder[Out, ThatOut, Key]

    Permalink

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.CoGroupOperator.

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.CoGroupOperator.

    thisKeyUdf

    the key extraction UDF for this instance

    that

    the other DataQuantaBuilder to join with

    thatKeyUdf

    the key extraction UDF for that instance

    returns

    a CoGroupDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  12. def collect(): Collection[Out]

    Permalink

    Feed the built DataQuanta into a LocalCallbackSink that collects all data quanta locally.

    Feed the built DataQuanta into a LocalCallbackSink that collects all data quanta locally. This triggers execution of the constructed RheemPlan.

    returns

    the collected data quanta

    Definition Classes
    DataQuantaBuilder
  13. def count: CountDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.CountOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.CountOperator.

    returns

    a CountDataQuantaBuilder representing the org.qcri.rheem.basic.operators.CountOperator's output

    Definition Classes
    DataQuantaBuilder
  14. def customOperator[T](operator: Operator): CustomOperatorDataQuantaBuilder[T]

    Permalink

    Feed the built DataQuanta into a custom Operator with a single org.qcri.rheem.core.plan.rheemplan.InputSlot and a single OutputSlot.

    Feed the built DataQuanta into a custom Operator with a single org.qcri.rheem.core.plan.rheemplan.InputSlot and a single OutputSlot.

    T

    the type of the output DataQuanta

    operator

    the custom Operator

    returns

    a CustomOperatorDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  15. def dataQuanta(): DataQuanta[Out]

    Permalink

    Get or create the DataQuanta built by this instance.

    Get or create the DataQuanta built by this instance.

    returns

    the DataQuanta

    Attributes
    protected[org.qcri.rheem.api]
    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  16. def distinct: DistinctDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.DistinctOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.DistinctOperator.

    returns

    a DistinctDataQuantaBuilder representing the org.qcri.rheem.basic.operators.DistinctOperator's output

    Definition Classes
    DataQuantaBuilder
  17. def doWhile[Conv](conditionUdf: SerializablePredicate[Collection[Conv]], bodyBuilder: Function[DataQuantaBuilder[_, Out], Tuple[DataQuantaBuilder[_, Out], DataQuantaBuilder[_, Conv]]]): DoWhileDataQuantaBuilder[Out, Conv]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.DoWhileOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.DoWhileOperator.

    returns

    a DoWhileDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  18. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  20. def filter(udf: SerializablePredicate[Out]): FilterDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.FilterOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.FilterOperator.

    udf

    filter UDF

    returns

    a FilterDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  21. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  22. def flatMap[NewOut](udf: SerializableFunction[Out, Iterable[NewOut]]): FlatMapDataQuantaBuilder[Out, NewOut]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.FlatMapOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.FlatMapOperator.

    udf

    the UDF for the org.qcri.rheem.basic.operators.FlatMapOperator

    returns

    a FlatMapDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  23. def forEach(f: Consumer[Out]): Unit

    Permalink

    Feed the built DataQuanta into a JavaFunction that runs locally.

    Feed the built DataQuanta into a JavaFunction that runs locally. This triggers execution of the constructed RheemPlan.

    f

    the JavaFunction

    returns

    the collected data quanta

    Definition Classes
    DataQuantaBuilder
  24. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  25. def getOutputTypeTrap: TypeTrap

    Permalink

    Retrieve an intialization value for outputTypeTrap.

    Retrieve an intialization value for outputTypeTrap.

    returns

    the TypeTrap

    Attributes
    protected
    Definition Classes
    BasicDataQuantaBuilder
  26. def group(): GlobalGroupDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.GlobalMaterializedGroupOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.GlobalMaterializedGroupOperator.

    returns

    a GlobalGroupDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  27. def groupByKey[Key](keyUdf: SerializableFunction[Out, Key]): GroupByDataQuantaBuilder[Key, Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.MaterializedGroupByOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.MaterializedGroupByOperator.

    keyUdf

    the key UDF for the org.qcri.rheem.basic.operators.MaterializedGroupByOperator

    returns

    a GroupByDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  28. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  29. def intersect(that: DataQuantaBuilder[_, Out]): IntersectDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.IntersectOperator.

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.IntersectOperator.

    that

    the other DataQuantaBuilder to intersect with

    returns

    an IntersectDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  30. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  31. implicit def javaPlanBuilder: JavaPlanBuilder

    Permalink

    Provide a JavaPlanBuilder to which this instance is associated.

    Provide a JavaPlanBuilder to which this instance is associated.

    Attributes
    protected[org.qcri.rheem.api]
    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  32. def join[ThatOut, Key](thisKeyUdf: SerializableFunction[Out, Key], that: DataQuantaBuilder[_, ThatOut], thatKeyUdf: SerializableFunction[ThatOut, Key]): JoinDataQuantaBuilder[Out, ThatOut, Key]

    Permalink

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.JoinOperator.

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.JoinOperator.

    thisKeyUdf

    the key extraction UDF for this instance

    that

    the other DataQuantaBuilder to join with

    thatKeyUdf

    the key extraction UDF for that instance

    returns

    a JoinDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  33. def keyBy[Key](keyExtractor: SerializableFunction[Out, Key]): KeyedDataQuantaBuilder[Out, Key]

    Permalink

    Annotates a key to this instance.

    Annotates a key to this instance.

    keyExtractor

    extracts the key from the data quanta

    returns

    a KeyedDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  34. def logger(): Logger

    Permalink
    Definition Classes
    Logging
  35. def map[NewOut](udf: SerializableFunction[Out, NewOut]): MapDataQuantaBuilder[Out, NewOut]

    Permalink

    Feed the built DataQuanta into a MapOperator.

    Feed the built DataQuanta into a MapOperator.

    udf

    the UDF for the MapOperator

    returns

    a MapDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  36. def mapPartitions[NewOut](udf: SerializableFunction[Iterable[Out], Iterable[NewOut]]): MapPartitionsDataQuantaBuilder[Out, NewOut]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.MapPartitionsOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.MapPartitionsOperator.

    udf

    the UDF for the org.qcri.rheem.basic.operators.MapPartitionsOperator

    returns

    a MapPartitionsDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  37. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  38. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  40. val outputTypeTrap: TypeTrap

    Permalink

    The type of the DataQuanta to be built.

    The type of the DataQuanta to be built.

    Attributes
    protected[org.qcri.rheem.api]
    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  41. def project[NewOut](fieldNames: Array[String]): ProjectionDataQuantaBuilder[Out, Nothing]

    Permalink

    Feed the built DataQuanta into a MapOperator with a org.qcri.rheem.basic.function.ProjectionDescriptor.

    Feed the built DataQuanta into a MapOperator with a org.qcri.rheem.basic.function.ProjectionDescriptor.

    fieldNames

    field names for the org.qcri.rheem.basic.function.ProjectionDescriptor

    returns

    a MapDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  42. def reduce(udf: SerializableBinaryOperator[Out]): GlobalReduceDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a GlobalReduceOperator.

    Feed the built DataQuanta into a GlobalReduceOperator.

    udf

    the UDF for the GlobalReduceOperator

    returns

    a GlobalReduceDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  43. def reduceByKey[Key](keyUdf: SerializableFunction[Out, Key], udf: SerializableBinaryOperator[Out]): ReduceByDataQuantaBuilder[Key, Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.ReduceByOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.ReduceByOperator.

    keyUdf

    the key UDF for the org.qcri.rheem.basic.operators.ReduceByOperator

    udf

    the UDF for the org.qcri.rheem.basic.operators.ReduceByOperator

    returns

    a ReduceByDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  44. def repeat(numRepetitions: Int, bodyBuilder: Function[DataQuantaBuilder[_, Out], DataQuantaBuilder[_, Out]]): RepeatDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.RepeatOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.RepeatOperator.

    returns

    a DoWhileDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  45. def sample(sampleSizeFunction: IntUnaryOperator): SampleDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.SampleOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.SampleOperator.

    sampleSizeFunction

    the absolute size of the sample as a function of the current iteration number

    returns

    a SampleDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  46. def sample(sampleSize: Int): SampleDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.SampleOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.SampleOperator.

    sampleSize

    the absolute size of the sample

    returns

    a SampleDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  47. def sort[Key](keyUdf: SerializableFunction[Out, Key]): SortDataQuantaBuilder[Out, Key]

    Permalink

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.SortOperator.

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.SortOperator.

    keyUdf

    the key extraction UDF for this instance

    returns

    a SortDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  48. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  49. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  50. def union(that: DataQuantaBuilder[_, Out]): UnionDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.UnionAllOperator.

    Feed the built DataQuanta of this and the given instance into a org.qcri.rheem.basic.operators.UnionAllOperator.

    that

    the other DataQuantaBuilder to union with

    returns

    a UnionDataQuantaBuilder

    Definition Classes
    DataQuantaBuilder
  51. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  54. def withBroadcast[Sender <: DataQuantaBuilder[_, _]](sender: Sender, broadcastName: String): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Register a broadcast with the DataQuanta to be built

    Register a broadcast with the DataQuanta to be built

    sender

    a DataQuantaBuilder constructing the broadcasted DataQuanta

    broadcastName

    the name of the broadcast

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  55. def withCardinalityEstimator(cardinalityEstimator: CardinalityEstimator): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Set a CardinalityEstimator for the currently built DataQuanta.

    Set a CardinalityEstimator for the currently built DataQuanta.

    cardinalityEstimator

    the CardinalityEstimator

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  56. def withExperiment(experiment: Experiment): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Set an Experiment for the currently built org.qcri.rheem.core.api.Job.

    Set an Experiment for the currently built org.qcri.rheem.core.api.Job.

    experiment

    the Experiment

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  57. def withName(name: String): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Set a name for the DataQuanta and its associated org.qcri.rheem.core.plan.rheemplan.Operators.

    Set a name for the DataQuanta and its associated org.qcri.rheem.core.plan.rheemplan.Operators.

    name

    the name

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  58. def withOutputClass(cls: Class[Out]): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Explicitly set an output Class for the currently built DataQuanta.

    Explicitly set an output Class for the currently built DataQuanta. Note that it is not always necessary to set it and that it can be inferred in some situations.

    cls

    the output Class

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  59. def withOutputType(outputType: DataSetType[Out]): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Explicitly set an output DataSetType for the currently built DataQuanta.

    Explicitly set an output DataSetType for the currently built DataQuanta. Note that it is not always necessary to set it and that it can be inferred in some situations.

    outputType

    the output DataSetType

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  60. def withSelectivity(lowerEstimate: Double, upperEstimate: Double, confidence: Double): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Specify the selectivity of the UDF.

    Specify the selectivity of the UDF.

    lowerEstimate

    the lower bound of the expected selectivity

    upperEstimate

    the upper bound of the expected selectivity

    confidence

    the probability of the actual selectivity being within these bounds

    returns

    this instance

  61. def withTargetPlatform(platform: Platform): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Add a target Platform on which the currently built DataQuanta should be calculated.

    Add a target Platform on which the currently built DataQuanta should be calculated. Can be invoked multiple times to set multiple possilbe target Platforms or not at all to impose no restrictions.

    platform

    the CardinalityEstimator

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  62. def withUdfJar(path: String): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Register a JAR file with the currently built org.qcri.rheem.core.api.Job.

    Register a JAR file with the currently built org.qcri.rheem.core.api.Job.

    path

    the path of the JAR file

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  63. def withUdfJarOf(cls: Class[_]): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Register the JAR file containing the given Class with the currently built org.qcri.rheem.core.api.Job.

    Register the JAR file containing the given Class with the currently built org.qcri.rheem.core.api.Job.

    cls

    the Class

    returns

    this instance

    Definition Classes
    BasicDataQuantaBuilderDataQuantaBuilder
  64. def withUdfLoad(udfLoadProfileEstimator: LoadProfileEstimator): FlatMapDataQuantaBuilder[In, Out]

    Permalink

    Set a LoadProfileEstimator for the load of the UDF.

    Set a LoadProfileEstimator for the load of the UDF.

    udfLoadProfileEstimator

    the LoadProfileEstimator

    returns

    this instance

  65. def writeTextFile(url: String, formatterUdf: SerializableFunction[Out, String], jobName: String, udfLoadProfileEstimator: LoadProfileEstimator): Unit

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.TextFileSink.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.TextFileSink. This triggers execution of the constructed RheemPlan.

    url

    the URL of the file to be written

    returns

    the collected data quanta

    Definition Classes
    DataQuantaBuilder
  66. def writeTextFile(url: String, formatterUdf: SerializableFunction[Out, String], jobName: String): Unit

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.TextFileSink.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.TextFileSink. This triggers execution of the constructed RheemPlan.

    url

    the URL of the file to be written

    jobName

    optional name for the RheemPlan

    returns

    the collected data quanta

    Definition Classes
    DataQuantaBuilder
  67. def zipWithId: ZipWithIdDataQuantaBuilder[Out]

    Permalink

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.ZipWithIdOperator.

    Feed the built DataQuanta into a org.qcri.rheem.basic.operators.ZipWithIdOperator.

    returns

    a ZipWithIdDataQuantaBuilder representing the org.qcri.rheem.basic.operators.ZipWithIdOperator's output

    Definition Classes
    DataQuantaBuilder

Inherited from BasicDataQuantaBuilder[FlatMapDataQuantaBuilder[In, Out], Out]

Inherited from DataQuantaBuilder[FlatMapDataQuantaBuilder[In, Out], Out]

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped