Class/Object

io.smartdatalake.workflow.dataobject

KafkaTopicDataObject

Related Docs: object KafkaTopicDataObject | package dataobject

Permalink

case class KafkaTopicDataObject(id: DataObjectId, topicName: String, connectionId: ConnectionId, keyType: KafkaColumnType = KafkaColumnType.String, valueType: KafkaColumnType = KafkaColumnType.String, schemaMin: Option[StructType] = None, selectCols: Seq[String] = Seq("key", "value"), datePartitionCol: Option[DatePartitionColumnDef] = None, batchReadConsecutivePartitionsAsRanges: Boolean = false, batchReadMaxOffsetsPerTask: Option[Int] = None, dataSourceOptions: Map[String, String] = Map(), metadata: Option[DataObjectMetadata] = None)(implicit instanceRegistry: InstanceRegistry) extends DataObject with CanCreateDataFrame with CanCreateStreamingDataFrame with CanWriteDataFrame with CanHandlePartitions with SchemaValidation with Product with Serializable

DataObject of type KafkaTopic. Provides details to an action to read from Kafka Topics using either org.apache.spark.sql.DataFrameReader or org.apache.spark.sql.streaming.DataStreamReader

topicName

The name of the topic to read

keyType

Optional type the key column should be converted to. If none is given it will remain a bytearray / binary.

valueType

Optional type the value column should be converted to. If none is given it will remain a bytearray / binary.

schemaMin

An optional, minimal schema that this DataObject must have to pass schema validation on reading and writing.

selectCols

Columns to be selected when reading the DataFrame. Available columns are key, value, topic, partition, offset, timestamp, timestampType. If key/valueType is AvroSchemaRegistry the key/value column are convert to a complex type according to the avro schema. To expand it select "value.*". Default is to select key and value.

datePartitionCol

definition of date partition column to extract formatted timestamp into column. This is used to list existing partition and is added as additional column on batch read.

batchReadConsecutivePartitionsAsRanges

Set to true if consecutive partitions should be combined as one range of offsets when batch reading from topic. This results in less tasks but can be a performance problem when reading many partitions. (default=false)

batchReadMaxOffsetsPerTask

Set number of offsets per Spark task when batch reading from topic.

dataSourceOptions

Options for the Kafka stream reader (see https://spark.apache.org/docs/latest/structured-streaming-kafka-integration.html). These options override connection.kafkaOptions.

Linear Supertypes
Serializable, Serializable, Product, Equals, SchemaValidation, CanHandlePartitions, CanWriteDataFrame, CanCreateStreamingDataFrame, CanCreateDataFrame, DataObject, SmartDataLakeLogger, ParsableFromConfig[DataObject], SdlConfigObject, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. KafkaTopicDataObject
  2. Serializable
  3. Serializable
  4. Product
  5. Equals
  6. SchemaValidation
  7. CanHandlePartitions
  8. CanWriteDataFrame
  9. CanCreateStreamingDataFrame
  10. CanCreateDataFrame
  11. DataObject
  12. SmartDataLakeLogger
  13. ParsableFromConfig
  14. SdlConfigObject
  15. AnyRef
  16. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new KafkaTopicDataObject(id: DataObjectId, topicName: String, connectionId: ConnectionId, keyType: KafkaColumnType = KafkaColumnType.String, valueType: KafkaColumnType = KafkaColumnType.String, schemaMin: Option[StructType] = None, selectCols: Seq[String] = Seq("key", "value"), datePartitionCol: Option[DatePartitionColumnDef] = None, batchReadConsecutivePartitionsAsRanges: Boolean = false, batchReadMaxOffsetsPerTask: Option[Int] = None, dataSourceOptions: Map[String, String] = Map(), metadata: Option[DataObjectMetadata] = None)(implicit instanceRegistry: InstanceRegistry)

    Permalink

    topicName

    The name of the topic to read

    keyType

    Optional type the key column should be converted to. If none is given it will remain a bytearray / binary.

    valueType

    Optional type the value column should be converted to. If none is given it will remain a bytearray / binary.

    schemaMin

    An optional, minimal schema that this DataObject must have to pass schema validation on reading and writing.

    selectCols

    Columns to be selected when reading the DataFrame. Available columns are key, value, topic, partition, offset, timestamp, timestampType. If key/valueType is AvroSchemaRegistry the key/value column are convert to a complex type according to the avro schema. To expand it select "value.*". Default is to select key and value.

    datePartitionCol

    definition of date partition column to extract formatted timestamp into column. This is used to list existing partition and is added as additional column on batch read.

    batchReadConsecutivePartitionsAsRanges

    Set to true if consecutive partitions should be combined as one range of offsets when batch reading from topic. This results in less tasks but can be a performance problem when reading many partitions. (default=false)

    batchReadMaxOffsetsPerTask

    Set number of offsets per Spark task when batch reading from topic.

    dataSourceOptions

    Options for the Kafka stream reader (see https://spark.apache.org/docs/latest/structured-streaming-kafka-integration.html). These options override connection.kafkaOptions.

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 addFieldIfNotExisting(writeSchema: StructType, colName: String, dataType: DataType): StructType

    Permalink
    Attributes
    protected
    Definition Classes
    CanCreateDataFrame
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. val batchReadConsecutivePartitionsAsRanges: Boolean

    Permalink

    Set to true if consecutive partitions should be combined as one range of offsets when batch reading from topic.

    Set to true if consecutive partitions should be combined as one range of offsets when batch reading from topic. This results in less tasks but can be a performance problem when reading many partitions. (default=false)

  7. val batchReadMaxOffsetsPerTask: Option[Int]

    Permalink

    Set number of offsets per Spark task when batch reading from topic.

  8. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. val connectionId: ConnectionId

    Permalink
  10. def createEmptyPartition(partitionValues: PartitionValues)(implicit session: SparkSession): Unit

    Permalink
    Definition Classes
    CanHandlePartitions
  11. final def createMissingPartitions(partitionValues: Seq[PartitionValues])(implicit session: SparkSession): Unit

    Permalink
    Definition Classes
    CanHandlePartitions
  12. def createReadSchema(writeSchema: StructType)(implicit session: SparkSession): StructType

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanCreateDataFrame
  13. val dataSourceOptions: Map[String, String]

    Permalink

    Options for the Kafka stream reader (see https://spark.apache.org/docs/latest/structured-streaming-kafka-integration.html).

    Options for the Kafka stream reader (see https://spark.apache.org/docs/latest/structured-streaming-kafka-integration.html). These options override connection.kafkaOptions.

  14. val datePartitionCol: Option[DatePartitionColumnDef]

    Permalink

    definition of date partition column to extract formatted timestamp into column.

    definition of date partition column to extract formatted timestamp into column. This is used to list existing partition and is added as additional column on batch read.

  15. def deletePartitions(partitionValues: Seq[PartitionValues])(implicit session: SparkSession): Unit

    Permalink
    Definition Classes
    CanHandlePartitions
  16. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  17. val expectedPartitionsCondition: Option[String]

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanHandlePartitions
  18. def factory: FromConfigFactory[DataObject]

    Permalink

    <invalid inheritdoc annotation>

    <invalid inheritdoc annotation>

    Definition Classes
    KafkaTopicDataObject → ParsableFromConfig
  19. final def filterExpectedPartitionValues(partitionValues: Seq[PartitionValues])(implicit session: SparkSession): Seq[PartitionValues]

    Permalink
    Definition Classes
    CanHandlePartitions
  20. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  21. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  22. def getConnection[T <: Connection](connectionId: ConnectionId)(implicit registry: InstanceRegistry, ct: ClassTag[T], tt: scala.reflect.api.JavaUniverse.TypeTag[T]): T

    Permalink
    Attributes
    protected
    Definition Classes
    DataObject
  23. def getConnectionReg[T <: Connection](connectionId: ConnectionId, registry: InstanceRegistry)(implicit ct: ClassTag[T], tt: scala.reflect.api.JavaUniverse.TypeTag[T]): T

    Permalink
    Attributes
    protected
    Definition Classes
    DataObject
  24. def getDataFrame(partitionValues: Seq[PartitionValues] = Seq())(implicit session: SparkSession, context: ActionPipelineContext): DataFrame

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanCreateDataFrame
  25. def getStreamingDataFrame(options: Map[String, String], schema: Option[StructType])(implicit session: SparkSession): DataFrame

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanCreateStreamingDataFrame
  26. val id: DataObjectId

    Permalink
    Definition Classes
    KafkaTopicDataObject → DataObject → SdlConfigObject
  27. def init(df: DataFrame, partitionValues: Seq[PartitionValues])(implicit session: SparkSession): Unit

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanWriteDataFrame
  28. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  29. val keyType: KafkaColumnType

    Permalink

    Optional type the key column should be converted to.

    Optional type the key column should be converted to. If none is given it will remain a bytearray / binary.

  30. def listPartitions(implicit session: SparkSession): Seq[PartitionValues]

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanHandlePartitions
  31. lazy val logger: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    SmartDataLakeLogger
  32. val metadata: Option[DataObjectMetadata]

    Permalink
    Definition Classes
    KafkaTopicDataObject → DataObject
  33. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  36. val partitions: Seq[String]

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanHandlePartitions
  37. def postRead(partitionValues: Seq[PartitionValues])(implicit session: SparkSession, context: ActionPipelineContext): Unit

    Permalink
    Definition Classes
    DataObject
  38. def postWrite(partitionValues: Seq[PartitionValues])(implicit session: SparkSession, context: ActionPipelineContext): Unit

    Permalink
    Definition Classes
    DataObject
  39. def preRead(partitionValues: Seq[PartitionValues])(implicit session: SparkSession, context: ActionPipelineContext): Unit

    Permalink
    Definition Classes
    DataObject
  40. def preWrite(implicit session: SparkSession, context: ActionPipelineContext): Unit

    Permalink
    Definition Classes
    DataObject
  41. def prepare(implicit session: SparkSession): Unit

    Permalink
    Definition Classes
    KafkaTopicDataObject → DataObject
  42. val schemaMin: Option[StructType]

    Permalink

    An optional, minimal schema that this DataObject must have to pass schema validation on reading and writing.

    An optional, minimal schema that this DataObject must have to pass schema validation on reading and writing.

    Definition Classes
    KafkaTopicDataObject → SchemaValidation
  43. val selectCols: Seq[String]

    Permalink

    Columns to be selected when reading the DataFrame.

    Columns to be selected when reading the DataFrame. Available columns are key, value, topic, partition, offset, timestamp, timestampType. If key/valueType is AvroSchemaRegistry the key/value column are convert to a complex type according to the avro schema. To expand it select "value.*". Default is to select key and value.

  44. def streamingOptions: Map[String, String]

    Permalink
    Definition Classes
    CanWriteDataFrame
  45. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  46. def toStringShort: String

    Permalink
    Definition Classes
    DataObject
  47. val topicName: String

    Permalink

    The name of the topic to read

  48. def validateSchemaMin(df: DataFrame): Unit

    Permalink
    Definition Classes
    SchemaValidation
  49. val valueType: KafkaColumnType

    Permalink

    Optional type the value column should be converted to.

    Optional type the value column should be converted to. If none is given it will remain a bytearray / binary.

  50. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  53. def writeDataFrame(df: DataFrame, partitionValues: Seq[PartitionValues] = Seq(), isRecursiveInput: Boolean = false)(implicit session: SparkSession): Unit

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanWriteDataFrame
  54. def writeStreamingDataFrame(df: DataFrame, trigger: Trigger, options: Map[String, String], checkpointLocation: String, queryName: String, outputMode: OutputMode)(implicit session: SparkSession): StreamingQuery

    Permalink
    Definition Classes
    KafkaTopicDataObject → CanWriteDataFrame

Inherited from Serializable

Inherited from Serializable

Inherited from Product

Inherited from Equals

Inherited from SchemaValidation

Inherited from CanHandlePartitions

Inherited from CanWriteDataFrame

Inherited from CanCreateStreamingDataFrame

Inherited from CanCreateDataFrame

Inherited from DataObject

Inherited from SmartDataLakeLogger

Inherited from ParsableFromConfig[DataObject]

Inherited from SdlConfigObject

Inherited from AnyRef

Inherited from Any

Ungrouped