Package

org.apache.spark.sql.redis

stream

Permalink

package stream

Visibility
  1. Public
  2. All

Type Members

  1. case class RedisConsumerConfig(streamKey: String, groupName: String, consumerName: String, batchSize: Int, block: Int) extends Product with Serializable

    Permalink
  2. case class RedisConsumerOffset(groupName: String, offset: String) extends Product with Serializable

    Permalink
  3. class RedisSource extends Source with Logging

    Permalink

  4. case class RedisSourceConfig(consumerConfigs: Seq[RedisConsumerConfig], start: Option[RedisSourceOffset]) extends Product with Serializable

    Permalink

  5. case class RedisSourceOffset(offsets: Map[String, RedisConsumerOffset]) extends Offset with Product with Serializable

    Permalink

    offsets

    A map of offset by stream key

  6. case class RedisSourceOffsetRange(start: Option[String], end: String, config: RedisConsumerConfig) extends Product with Serializable

    Permalink
  7. class RedisSourceRdd extends RDD[StreamEntry]

    Permalink

    RDD of EntryID -> StreamEntry.fields

  8. case class RedisSourceRddPartition(index: Int, offsetRange: RedisSourceOffsetRange) extends Partition with Product with Serializable

    Permalink
  9. class RedisStreamProvider extends DataSourceRegister with StreamSourceProvider with Logging

    Permalink

  10. class RedisStreamReader extends Logging with Serializable

    Permalink

Value Members

  1. object RedisSource

    Permalink
  2. object RedisSourceConfig extends Serializable

    Permalink
  3. object RedisSourceOffset extends Serializable

    Permalink
  4. object RedisSourceTypes

    Permalink

Ungrouped