Package

org.apache.spark.sql

streaming

Permalink

package streaming

Visibility
  1. Public
  2. All

Type Members

  1. class DefaultSnappySinkCallback extends SnappySinkCallback

    Permalink
  2. final class DirectKafkaStreamRelation extends StreamBaseRelation with Logging with Serializable

    Permalink
  3. class DirectKafkaStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  4. final class FileStreamRelation extends StreamBaseRelation

    Permalink
  5. final class FileStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  6. class HashTagToRowsConverter extends StreamToRowsConverter with Serializable

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

    Permalink
  8. class MyStreamConverter extends StreamConverter with Serializable

    Permalink
  9. 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.

  10. trait RabbitMQDecoder[T] extends AnyRef

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

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

    Permalink
  13. final class RabbitMQStreamRelation extends StreamBaseRelation

    Permalink
  14. final class RabbitMQStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  15. final class RabbitMQStringDecoder extends RabbitMQDecoder[String]

    Permalink
  16. final class RawSocketStreamRelation extends StreamBaseRelation

    Permalink
  17. final class RawSocketStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  18. 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

  19. trait SnappySinkCallback extends AnyRef

    Permalink

    Should be implemented by clients who wants to override default behavior provided by DefaultSnappySinkCallback.

    Should be implemented by clients who wants to override default behavior provided by DefaultSnappySinkCallback.

    In order to override the default callback behavior the qualified name of the implementing class needs to be passed against sinkCallback option while defining stream query.

  20. case class SnappyStoreSink(snappySession: SnappySession, parameters: Map[String, String], sinkCallback: SnappySinkCallback) extends Sink with Product with Serializable

    Permalink
  21. class SnappyStoreSinkProvider extends StreamSinkProvider with DataSourceRegister

    Permalink
  22. final class SocketStreamRelation extends StreamBaseRelation

    Permalink
  23. final class SocketStreamSource extends StreamPlanProvider with DataSourceRegister

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

    Permalink
  25. trait StreamConverter extends Serializable

    Permalink
  26. trait StreamPlan extends AnyRef

    Permalink
  27. trait StreamPlanProvider extends SchemaRelationProvider

    Permalink
  28. trait StreamToRowsConverter extends Serializable

    Permalink
  29. final class TextSocketStreamRelation extends StreamBaseRelation

    Permalink
  30. final class TextSocketStreamSource extends StreamPlanProvider with DataSourceRegister

    Permalink
  31. class TweetToHashtagRow extends StreamToRowsConverter with Serializable

    Permalink
  32. class TweetToRetweetRow extends StreamToRowsConverter with Serializable

    Permalink
  33. class TweetToRowsConverter extends StreamToRowsConverter with Serializable

    Permalink
  34. final class TwitterStreamRelation extends StreamBaseRelation

    Permalink
  35. final class TwitterStreamSource extends StreamPlanProvider with DataSourceRegister

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

    Permalink
  37. 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 DefaultSnappySinkCallback

    Permalink
  2. object DirectKafkaStreamRelation extends Serializable

    Permalink
  3. object RabbitMQUtils

    Permalink
  4. object StreamSqlHelper

    Permalink
  5. package twitter

    Permalink

    Twitter feed receiver for spark streaming.

Ungrouped