Packages

case class Write[K1, K2, T](keyFieldPrimary: String, keyFieldSecondary: Option[String], compression: CompressionCodecName = ParquetTypeFileOperations.DefaultCompression, configuration: Configuration = new Configuration(), numBuckets: Integer = null, numShards: Int = SortedBucketIO.DEFAULT_NUM_SHARDS, filenamePrefix: String = SortedBucketIO.DEFAULT_FILENAME_PREFIX, hashType: HashType = SortedBucketIO.DEFAULT_HASH_TYPE, outputDirectory: ResourceId = null, tempDirectory: ResourceId = null, filenameSuffix: String = DefaultSuffix, sorterMemoryMb: Int = SortedBucketIO.DEFAULT_SORTER_MEMORY_MB, keyCacheSize: Int = 0)(implicit evidence$23: ClassTag[K1], evidence$24: ClassTag[K2], evidence$25: ClassTag[T], evidence$26: Coder[T], evidence$27: ParquetType[T]) extends SortedBucketIO.Write[K1, K2, T] with Product with Serializable

Source
ParquetTypeSortedBucketIO.scala
Linear Supertypes
Product, Equals, SortedBucketIO.Write[K1, K2, T], PTransform[PCollection[T], WriteResult], HasDisplayData, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Write
  2. Product
  3. Equals
  4. Write
  5. PTransform
  6. HasDisplayData
  7. Serializable
  8. AnyRef
  9. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new Write(keyFieldPrimary: String, keyFieldSecondary: Option[String], compression: CompressionCodecName = ParquetTypeFileOperations.DefaultCompression, configuration: Configuration = new Configuration(), numBuckets: Integer = null, numShards: Int = SortedBucketIO.DEFAULT_NUM_SHARDS, filenamePrefix: String = SortedBucketIO.DEFAULT_FILENAME_PREFIX, hashType: HashType = SortedBucketIO.DEFAULT_HASH_TYPE, outputDirectory: ResourceId = null, tempDirectory: ResourceId = null, filenameSuffix: String = DefaultSuffix, sorterMemoryMb: Int = SortedBucketIO.DEFAULT_SORTER_MEMORY_MB, keyCacheSize: Int = 0)(implicit arg0: ClassTag[K1], arg1: ClassTag[K2], arg2: ClassTag[T], arg3: Coder[T], arg4: ParquetType[T])

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[PCollection[T], 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]) @native()
  7. val compression: CompressionCodecName
  8. val configuration: Configuration
  9. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  10. def expand(input: PCollection[T]): WriteResult
    Definition Classes
    Write → PTransform
    Annotations
    @SuppressWarnings() @Override()
  11. val filenamePrefix: String
  12. val filenameSuffix: String
  13. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable])
  14. def getAdditionalInputs(): Map[TupleTag[_ <: AnyRef], PValue]
    Definition Classes
    PTransform
  15. def getAnnotations(): Map[String, Array[Byte]]
    Definition Classes
    PTransform
  16. def getBucketMetadata(): BucketMetadata[K1, K2, T]
    Definition Classes
    Write → Write
  17. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  18. def getFileOperations(): FileOperations[T]
    Definition Classes
    Write → Write
  19. def getFilenamePrefix(): String
    Definition Classes
    Write → Write
  20. def getFilenameSuffix(): String
    Definition Classes
    Write → Write
  21. def getHashType(): HashType
    Definition Classes
    Write → Write
  22. def getKeyCacheSize(): Int
    Definition Classes
    Write → Write
  23. def getKeyClassPrimary(): Class[K1]
    Definition Classes
    Write → Write
  24. def getKeyClassSecondary(): Class[K2]
    Definition Classes
    Write → Write
  25. def getKindString(): String
    Attributes
    protected[transforms]
    Definition Classes
    PTransform
  26. def getName(): String
    Definition Classes
    PTransform
  27. def getNumBuckets(): Integer
    Definition Classes
    Write → Write
  28. def getNumShards(): Int
    Definition Classes
    Write → Write
  29. def getOutputDirectory(): ResourceId
    Definition Classes
    Write → Write
  30. def getResourceHints(): ResourceHints
    Definition Classes
    PTransform
  31. def getSorterMemoryMb(): Int
    Definition Classes
    Write → Write
  32. def getTempDirectory(): ResourceId
    Definition Classes
    Write → Write
  33. val hashType: HashType
  34. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  35. val keyCacheSize: Int
  36. val keyFieldPrimary: String
  37. val keyFieldSecondary: Option[String]
  38. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  39. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  40. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  41. val numBuckets: Integer
  42. val numShards: Int
  43. def onKeyedCollection(valueCoder: Coder[T], verifyKeyExtraction: Boolean): PreKeyedWrite[K1, T]
    Definition Classes
    Write
  44. val outputDirectory: ResourceId
  45. def populateDisplayData(builder: Builder): Unit
    Definition Classes
    PTransform → HasDisplayData
  46. def productElementNames: Iterator[String]
    Definition Classes
    Product
  47. def setDisplayData(displayData: List[ItemSpec[_ <: AnyRef]]): PTransform[PCollection[T], WriteResult]
    Definition Classes
    PTransform
  48. def setResourceHints(resourceHints: ResourceHints): PTransform[PCollection[T], WriteResult]
    Definition Classes
    PTransform
  49. val sorterMemoryMb: Int
  50. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  51. val tempDirectory: ResourceId
  52. def to(outputDirectory: String): Write[K1, K2, T]
  53. def toString(): String
    Definition Classes
    PTransform → AnyRef → Any
    Annotations
    @SideEffectFree()
  54. def validate(options: PipelineOptions, inputs: Map[TupleTag[_ <: AnyRef], PCollection[_ <: AnyRef]], outputs: Map[TupleTag[_ <: AnyRef], PCollection[_ <: AnyRef]]): Unit
    Definition Classes
    PTransform
  55. def validate(options: PipelineOptions): Unit
    Definition Classes
    PTransform
  56. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  57. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  58. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  59. def withCompression(compression: CompressionCodecName): Write[K1, K2, T]
  60. def withConfiguration(configuration: Configuration): Write[K1, K2, T]
  61. def withFilenamePrefix(filenamePrefix: String): Write[K1, K2, T]
  62. def withHashType(hashType: HashType): Write[K1, K2, T]
  63. def withKeyCacheOfSize(keyCacheSize: Int): Write[K1, K2, T]
  64. def withNumBuckets(numBuckets: Int): Write[K1, K2, T]
  65. def withNumShards(numShards: Int): Write[K1, K2, T]
  66. def withSorterMemoryMb(sorterMemoryMb: Int): Write[K1, K2, T]
  67. def withSuffix(filenameSuffix: String): Write[K1, K2, T]
  68. def withTempDirectory(tempDirectory: String): Write[K1, K2, T]

Deprecated Value Members

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

Inherited from Product

Inherited from Equals

Inherited from SortedBucketIO.Write[K1, K2, T]

Inherited from PTransform[PCollection[T], WriteResult]

Inherited from HasDisplayData

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped