Class

org.qcri.rheem.api

JoinDataQuantaBuilder

Related Doc: package api

Permalink

class JoinDataQuantaBuilder[In0, In1, Key] extends BasicDataQuantaBuilder[JoinDataQuantaBuilder[In0, In1, Key], Tuple2[In0, In1]]

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

Linear Supertypes
BasicDataQuantaBuilder[JoinDataQuantaBuilder[In0, In1, Key], Tuple2[In0, In1]], DataQuantaBuilder[JoinDataQuantaBuilder[In0, In1, Key], Tuple2[In0, In1]], Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. JoinDataQuantaBuilder
  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 JoinDataQuantaBuilder(inputDataQuanta0: DataQuantaBuilder[_, In0], inputDataQuanta1: DataQuantaBuilder[_, In1], keyUdf0: SerializableFunction[In0, Key], keyUdf1: SerializableFunction[In1, Key])(implicit javaPlanBuilder: JavaPlanBuilder)

    Permalink

    inputDataQuanta0

    DataQuantaBuilder for the first input DataQuanta

    inputDataQuanta1

    DataQuantaBuilder for the first input DataQuanta

    keyUdf0

    first key extraction UDF for the org.qcri.rheem.basic.operators.JoinOperator

    keyUdf1

    first key extraction UDF for the org.qcri.rheem.basic.operators.JoinOperator

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 assemble[NewOut](udf: SerializableBiFunction[In0, In1, NewOut]): MapDataQuantaBuilder[Tuple2[In0, In1], NewOut]

    Permalink

    Assemble the joined elements to new elements.

    Assemble the joined elements to new elements.

    udf

    produces a joined element from two joinable elements

    returns

    a new DataQuantaBuilder representing the assembled join product

  8. def build: DataQuanta[Tuple2[In0, In1]]

    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
    JoinDataQuantaBuilderBasicDataQuantaBuilder
  9. def cartesian[ThatOut](that: DataQuantaBuilder[_, ThatOut]): CartesianDataQuantaBuilder[Tuple2[In0, In1], 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
  10. implicit def classTag: ClassTag[Tuple2[In0, In1]]

    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
  11. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  12. def coGroup[ThatOut, Key](thisKeyUdf: SerializableFunction[Tuple2[In0, In1], Key], that: DataQuantaBuilder[_, ThatOut], thatKeyUdf: SerializableFunction[ThatOut, Key]): CoGroupDataQuantaBuilder[Tuple2[In0, In1], 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
  13. def collect(): Collection[Tuple2[In0, In1]]

    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
  14. def count: CountDataQuantaBuilder[Tuple2[In0, In1]]

    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
  15. 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
  16. def dataQuanta(): DataQuanta[Tuple2[In0, In1]]

    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
  17. def distinct: DistinctDataQuantaBuilder[Tuple2[In0, In1]]

    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
  18. def doWhile[Conv](conditionUdf: SerializablePredicate[Collection[Conv]], bodyBuilder: Function[DataQuantaBuilder[_, Tuple2[In0, In1]], Tuple[DataQuantaBuilder[_, Tuple2[In0, In1]], DataQuantaBuilder[_, Conv]]]): DoWhileDataQuantaBuilder[Tuple2[In0, In1], 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
  19. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  21. def filter(udf: SerializablePredicate[Tuple2[In0, In1]]): FilterDataQuantaBuilder[Tuple2[In0, In1]]

    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
  22. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  23. def flatMap[NewOut](udf: SerializableFunction[Tuple2[In0, In1], Iterable[NewOut]]): FlatMapDataQuantaBuilder[Tuple2[In0, In1], 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
  24. def forEach(f: Consumer[Tuple2[In0, In1]]): 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
  25. final def getClass(): Class[_]

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

    Permalink

    Retrieve an intialization value for outputTypeTrap.

    Retrieve an intialization value for outputTypeTrap.

    returns

    the TypeTrap

    Attributes
    protected
    Definition Classes
    BasicDataQuantaBuilder
  27. def group(): GlobalGroupDataQuantaBuilder[Tuple2[In0, In1]]

    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
  28. def groupByKey[Key](keyUdf: SerializableFunction[Tuple2[In0, In1], Key]): GroupByDataQuantaBuilder[Key, Tuple2[In0, In1]]

    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
  29. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  30. def intersect(that: DataQuantaBuilder[_, Tuple2[In0, In1]]): IntersectDataQuantaBuilder[Tuple2[In0, In1]]

    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
  31. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  32. 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
  33. def join[ThatOut, Key](thisKeyUdf: SerializableFunction[Tuple2[In0, In1], Key], that: DataQuantaBuilder[_, ThatOut], thatKeyUdf: SerializableFunction[ThatOut, Key]): JoinDataQuantaBuilder[Tuple2[In0, In1], 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
  34. def keyBy[Key](keyExtractor: SerializableFunction[Tuple2[In0, In1], Key]): KeyedDataQuantaBuilder[Tuple2[In0, In1], 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
  35. implicit var keyTag: ClassTag[Key]

    Permalink

    ClassTag or surrogate of Key

  36. def logger(): Logger

    Permalink
    Definition Classes
    Logging
  37. def map[NewOut](udf: SerializableFunction[Tuple2[In0, In1], NewOut]): MapDataQuantaBuilder[Tuple2[In0, In1], 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
  38. def mapPartitions[NewOut](udf: SerializableFunction[Iterable[Tuple2[In0, In1]], Iterable[NewOut]]): MapPartitionsDataQuantaBuilder[Tuple2[In0, In1], 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
  39. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  42. 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
  43. def project[NewOut](fieldNames: Array[String]): ProjectionDataQuantaBuilder[Tuple2[In0, In1], 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
  44. def reduce(udf: SerializableBinaryOperator[Tuple2[In0, In1]]): GlobalReduceDataQuantaBuilder[Tuple2[In0, In1]]

    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
  45. def reduceByKey[Key](keyUdf: SerializableFunction[Tuple2[In0, In1], Key], udf: SerializableBinaryOperator[Tuple2[In0, In1]]): ReduceByDataQuantaBuilder[Key, Tuple2[In0, In1]]

    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
  46. def repeat(numRepetitions: Int, bodyBuilder: Function[DataQuantaBuilder[_, Tuple2[In0, In1]], DataQuantaBuilder[_, Tuple2[In0, In1]]]): RepeatDataQuantaBuilder[Tuple2[In0, In1]]

    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
  47. def sample(sampleSizeFunction: IntUnaryOperator): SampleDataQuantaBuilder[Tuple2[In0, In1]]

    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
  48. def sample(sampleSize: Int): SampleDataQuantaBuilder[Tuple2[In0, In1]]

    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
  49. def sort[Key](keyUdf: SerializableFunction[Tuple2[In0, In1], Key]): SortDataQuantaBuilder[Tuple2[In0, In1], 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
  50. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    AnyRef → Any
  52. def union(that: DataQuantaBuilder[_, Tuple2[In0, In1]]): UnionDataQuantaBuilder[Tuple2[In0, In1]]

    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
  53. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  56. def withBroadcast[Sender <: DataQuantaBuilder[_, _]](sender: Sender, broadcastName: String): JoinDataQuantaBuilder[In0, In1, Key]

    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
  57. def withCardinalityEstimator(cardinalityEstimator: CardinalityEstimator): JoinDataQuantaBuilder[In0, In1, Key]

    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
  58. def withExperiment(experiment: Experiment): JoinDataQuantaBuilder[In0, In1, Key]

    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
  59. def withName(name: String): JoinDataQuantaBuilder[In0, In1, Key]

    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
  60. def withOutputClass(cls: Class[Tuple2[In0, In1]]): JoinDataQuantaBuilder[In0, In1, Key]

    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
  61. def withOutputType(outputType: DataSetType[Tuple2[In0, In1]]): JoinDataQuantaBuilder[In0, In1, Key]

    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
  62. def withTargetPlatform(platform: Platform): JoinDataQuantaBuilder[In0, In1, Key]

    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
  63. def withThatKeyUdfCpuEstimator(udfCpuEstimator: LoadEstimator): JoinDataQuantaBuilder[In0, In1, Key]

    Permalink

    Set a LoadEstimator for the CPU load of the second key extraction UDF.

    Set a LoadEstimator for the CPU load of the second key extraction UDF. Currently effectless.

    udfCpuEstimator

    the LoadEstimator

    returns

    this instance

  64. def withThatKeyUdfRamEstimator(udfRamEstimator: LoadEstimator): JoinDataQuantaBuilder[In0, In1, Key]

    Permalink

    Set a LoadEstimator for the RAM load of the second key extraction UDF.

    Set a LoadEstimator for the RAM load of the second key extraction UDF. Currently effectless.

    udfRamEstimator

    the LoadEstimator

    returns

    this instance

  65. def withThisKeyUdfCpuEstimator(udfCpuEstimator: LoadEstimator): JoinDataQuantaBuilder[In0, In1, Key]

    Permalink

    Set a LoadEstimator for the CPU load of the first key extraction UDF.

    Set a LoadEstimator for the CPU load of the first key extraction UDF. Currently effectless.

    udfCpuEstimator

    the LoadEstimator

    returns

    this instance

  66. def withThisKeyUdfRamEstimator(udfRamEstimator: LoadEstimator): JoinDataQuantaBuilder[In0, In1, Key]

    Permalink

    Set a LoadEstimator for the RAM load of first the key extraction UDF.

    Set a LoadEstimator for the RAM load of first the key extraction UDF. Currently effectless.

    udfRamEstimator

    the LoadEstimator

    returns

    this instance

  67. def withUdfJar(path: String): JoinDataQuantaBuilder[In0, In1, Key]

    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
  68. def withUdfJarOf(cls: Class[_]): JoinDataQuantaBuilder[In0, In1, Key]

    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
  69. def writeTextFile(url: String, formatterUdf: SerializableFunction[Tuple2[In0, In1], 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
  70. def writeTextFile(url: String, formatterUdf: SerializableFunction[Tuple2[In0, In1], 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
  71. def zipWithId: ZipWithIdDataQuantaBuilder[Tuple2[In0, In1]]

    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[JoinDataQuantaBuilder[In0, In1, Key], Tuple2[In0, In1]]

Inherited from DataQuantaBuilder[JoinDataQuantaBuilder[In0, In1, Key], Tuple2[In0, In1]]

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped