c

org.apache.beam.sdk.extensions.smb

SortedBucketTransform

class SortedBucketTransform[FinalKeyT, FinalValueT] extends PTransform[PBegin, WriteResult]

A PTransform that encapsulates both a SortedBucketSource and SortedBucketSink operation, with a user-supplied transform function mapping merged CoGbkResults to their final writable outputs.

Source
SortedBucketTransform.java
Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SortedBucketTransform
  2. PTransform
  3. HasDisplayData
  4. Serializable
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new SortedBucketTransform(sources: List[BucketedInput[_ <: AnyRef]], keyFn: Function[ComparableKeyBytes, FinalKeyT], keyComparator: Comparator[ComparableKeyBytes], targetParallelism: TargetParallelism, transformFn: TransformFn[FinalKeyT, FinalValueT], sideInputTransformFn: TransformFnWithSideInputContext[FinalKeyT, FinalValueT], outputDirectory: ResourceId, tempDirectory: ResourceId, sides: Iterable[PCollectionView[_ <: AnyRef]], newBucketMetadataFn: NewBucketMetadataFn[_ <: AnyRef, _ <: AnyRef, FinalValueT], fileOperations: FileOperations[FinalValueT], filenameSuffix: String, filenamePrefix: String)

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. def addAnnotation(annotationType: String, annotation: Array[Byte]): PTransform[PBegin, WriteResult]
    Definition Classes
    PTransform
  5. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  6. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @HotSpotIntrinsicCandidate() @native()
  7. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  8. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  9. final def expand(begin: PBegin): WriteResult
    Definition Classes
    SortedBucketTransform → PTransform
    Annotations
    @Override()
  10. def getAdditionalInputs(): Map[TupleTag[_ <: AnyRef], PValue]
    Definition Classes
    PTransform
  11. def getAnnotations(): Map[String, Array[Byte]]
    Definition Classes
    PTransform
  12. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @HotSpotIntrinsicCandidate() @native()
  13. def getKindString(): String
    Attributes
    protected[transforms]
    Definition Classes
    PTransform
  14. def getName(): String
    Definition Classes
    PTransform
  15. def getResourceHints(): ResourceHints
    Definition Classes
    PTransform
  16. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @HotSpotIntrinsicCandidate() @native()
  17. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  18. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  19. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @HotSpotIntrinsicCandidate() @native()
  20. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @HotSpotIntrinsicCandidate() @native()
  21. def populateDisplayData(builder: Builder): Unit
    Definition Classes
    PTransform → HasDisplayData
  22. def setDisplayData(displayData: List[ItemSpec[_ <: AnyRef]]): PTransform[PBegin, WriteResult]
    Definition Classes
    PTransform
  23. def setResourceHints(resourceHints: ResourceHints): PTransform[PBegin, WriteResult]
    Definition Classes
    PTransform
  24. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  25. def toString(): String
    Definition Classes
    PTransform → AnyRef → Any
    Annotations
    @SideEffectFree()
  26. def validate(options: PipelineOptions, inputs: Map[TupleTag[_ <: AnyRef], PCollection[_ <: AnyRef]], outputs: Map[TupleTag[_ <: AnyRef], PCollection[_ <: AnyRef]]): Unit
    Definition Classes
    PTransform
  27. def validate(options: PipelineOptions): Unit
    Definition Classes
    PTransform
  28. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  29. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  30. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated

    (Since version 9)

  2. def getDefaultOutputCoder[T <: AnyRef](input: PBegin, output: PCollection[T]): Coder[T]
    Definition Classes
    PTransform
    Annotations
    @throws(classOf[org.apache.beam.sdk.coders.CannotProvideCoderException]) @Deprecated
    Deprecated
  3. def getDefaultOutputCoder(input: PBegin): Coder[_ <: AnyRef]
    Attributes
    protected[transforms]
    Definition Classes
    PTransform
    Annotations
    @throws(classOf[org.apache.beam.sdk.coders.CannotProvideCoderException]) @Deprecated
    Deprecated
  4. def getDefaultOutputCoder(): Coder[_ <: AnyRef]
    Attributes
    protected[transforms]
    Definition Classes
    PTransform
    Annotations
    @throws(classOf[org.apache.beam.sdk.coders.CannotProvideCoderException]) @Deprecated
    Deprecated

Inherited from PTransform[PBegin, WriteResult]

Inherited from HasDisplayData

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped