Package

org.apache.spark.sql.aliyun

logservice

Permalink

package logservice

Visibility
  1. Public
  2. All

Type Members

  1. class ConfigCommandOptions extends AnyRef

    Permalink
  2. case class Loghub(logProject: String, logStore: String) extends Product with Serializable

    Permalink
  3. case class LoghubContinuousInputPartition(logProject: String, logStore: String, shardId: Int, offset: Int, sourceOptions: Map[String, String], schemaFieldNames: Array[String], defaultSchema: Boolean) extends ContinuousInputPartition[InternalRow] with Product with Serializable

    Permalink
  4. class LoghubContinuousInputPartitionReader extends ContinuousInputPartitionReader[InternalRow] with Logging

    Permalink
  5. class LoghubContinuousReader extends ContinuousReader with Logging

    Permalink
  6. abstract class LoghubData extends Serializable

    Permalink
  7. abstract class LoghubGroupWriter extends AnyRef

    Permalink
  8. sealed trait LoghubOffsetRangeLimit extends AnyRef

    Permalink
  9. class LoghubOffsetReader extends Logging

    Permalink
  10. class LoghubRelation extends BaseRelation with TableScan with InsertableRelation with Serializable with Logging

    Permalink
  11. case class LoghubShard(logProject: String, logStore: String, shard: Int) extends Product with Serializable

    Permalink
  12. case class LoghubShardOffset(logProject: String, logStore: String, shard: Int, offset: Int, cursor: String) extends PartitionOffset with Product with Serializable

    Permalink
  13. class LoghubSource extends Source with Logging with Serializable

    Permalink
  14. case class LoghubSourceOffset(shardToOffsets: Map[LoghubShard, (Int, String)]) extends Offset with Product with Serializable

    Permalink
  15. class LoghubSourceProvider extends DataSourceRegister with StreamSourceProvider with StreamSinkProvider with SchemaRelationProvider with RelationProvider with CreatableRelationProvider with ContinuousReadSupport with Logging

    Permalink
  16. class LoghubSourceRDD extends RDD[InternalRow] with Logging

    Permalink
  17. class LoghubWriterTask extends LoghubGroupWriter

    Permalink
  18. class RawLoghubData extends LoghubData

    Permalink
  19. class SchemaLoghubData extends LoghubData with Logging with Serializable

    Permalink
  20. case class SpecificOffsetRangeLimit(partitionOffsets: Map[LoghubShard, (Int, String)]) extends LoghubOffsetRangeLimit with Product with Serializable

    Permalink

Value Members

  1. object EarliestOffsetRangeLimit extends LoghubOffsetRangeLimit with Product with Serializable

    Permalink
  2. object LatestOffsetRangeLimit extends LoghubOffsetRangeLimit with Product with Serializable

    Permalink
  3. object LoghubOffsetRangeLimit

    Permalink
  4. object LoghubOffsetReader extends Logging with Serializable

    Permalink
  5. object LoghubSource extends Serializable

    Permalink
  6. object LoghubSourceOffset extends Serializable

    Permalink
  7. object LoghubSourceProvider

    Permalink
  8. object LoghubWriter

    Permalink
  9. object UpdateSourceConfig

    Permalink
  10. object Utils extends Logging

    Permalink

Ungrouped