Package

org.apache.spark.sql

streaming

Permalink

package streaming

Visibility
  1. Public
  2. All

Type Members

  1. final class DirectKafkaStreamRelation extends StreamBaseRelation with Logging with Serializable

    Permalink
  2. class DirectKafkaStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  3. final class FileStreamRelation extends StreamBaseRelation

    Permalink
  4. final class FileStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  5. class HashTagToRowsConverter extends StreamToRowsConverter with Serializable

    Permalink
  6. final class KafkaStreamRelation extends StreamBaseRelation

    Permalink
  7. class KafkaStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  8. case class LogicalDStreamPlan(output: Seq[Attribute], stream: DStream[InternalRow])(streamingSnappy: SnappyStreamingContext) extends LogicalPlan with MultiInstanceRelation with Product with Serializable

    Permalink
  9. class MyStreamConverter extends StreamConverter with Serializable

    Permalink
  10. case class PhysicalDStreamPlan(output: Seq[Attribute], rowStream: DStream[InternalRow]) extends SparkPlan with StreamPlan with Product with Serializable

    Permalink

    A PhysicalPlan wrapper of SchemaDStream, inject the validTime and generate an effective RDD of current batchDuration.

  11. trait RabbitMQDecoder[T] extends AnyRef

    Permalink
  12. final class RabbitMQInputDStream[T, D] extends ReceiverInputDStream[T]

    Permalink
  13. final class RabbitMQReceiver[T, D] extends Receiver[T] with Logging

    Permalink
  14. final class RabbitMQStreamRelation extends StreamBaseRelation

    Permalink
  15. final class RabbitMQStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  16. final class RabbitMQStringDecoder extends RabbitMQDecoder[String]

    Permalink
  17. final class RawSocketStreamRelation extends StreamBaseRelation

    Permalink
  18. final class RawSocketStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  19. class SchemaDStream extends DStream[Row]

    Permalink

    A SQL based DStream with support for schema/Product This class offers the ability to manipulate SQL query on DStreams It is similar to SchemaRDD, which offers the similar functions Internally, RDD of each batch duration is treated as a small table and CQs are evaluated on those small tables Some of the abstraction and code is borrowed from the project: https://github.com/Intel-bigdata/spark-streamingsql

  20. final class SocketStreamRelation extends StreamBaseRelation

    Permalink
  21. final class SocketStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  22. abstract class StreamBaseRelation extends BaseRelation with ParentRelation with StreamPlan with TableScan with DestroyRelation with Serializable with Logging

    Permalink
  23. trait StreamConverter extends Serializable

    Permalink
  24. trait StreamPlan extends AnyRef

    Permalink
  25. trait StreamPlanProvider extends SchemaRelationProvider

    Permalink
  26. trait StreamToRowsConverter extends Serializable

    Permalink
  27. final class TextSocketStreamRelation extends StreamBaseRelation

    Permalink
  28. final class TextSocketStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  29. class TweetToHashtagRow extends StreamToRowsConverter with Serializable

    Permalink
  30. class TweetToRetweetRow extends StreamToRowsConverter with Serializable

    Permalink
  31. class TweetToRowsConverter extends StreamToRowsConverter with Serializable

    Permalink
  32. final class TwitterStreamRelation extends StreamBaseRelation

    Permalink
  33. final class TwitterStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  34. case class WindowLogicalPlan(windowDuration: Duration, slideDuration: Option[Duration], child: LogicalPlan, transformed: Boolean = false) extends UnaryNode with Product with Serializable

    Permalink
  35. case class WindowPhysicalPlan(windowDuration: Duration, slide: Option[Duration], child: SparkPlan) extends SparkPlan with UnaryExecNode with StreamPlan with Product with Serializable

    Permalink

Value Members

  1. object RabbitMQUtils

    Permalink
  2. object StreamSqlHelper

    Permalink
  3. package twitter

    Permalink

    Twitter feed receiver for spark streaming.

Ungrouped