Class

org.apache.spark.sql.streaming

SchemaDStream

Related Doc: package streaming

Permalink

class SchemaDStream extends DStream[Row]

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

Linear Supertypes
DStream[Row], internal.Logging, Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SchemaDStream
  2. DStream
  3. Logging
  4. Serializable
  5. Serializable
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SchemaDStream(ssc: SnappyStreamingContext, logicalPlan: LogicalPlan)

    Permalink
  2. new SchemaDStream(snsc: SnappyStreamingContext, queryExecution: QueryExecution)

    Permalink

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. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  5. val baseScope: Option[String]

    Permalink
    Attributes
    protected[org.apache.spark.streaming]
    Definition Classes
    DStream
  6. def cache(): SchemaDStream

    Permalink

    Persist RDDs of this SchemaDStream with the default storage level (MEMORY_ONLY_SER)

    Persist RDDs of this SchemaDStream with the default storage level (MEMORY_ONLY_SER)

    Definition Classes
    SchemaDStream → DStream
  7. def checkpoint(interval: Duration): SchemaDStream

    Permalink

    Enable periodic checkpointing of RDDs of this SchemaDStream

    Enable periodic checkpointing of RDDs of this SchemaDStream

    interval

    Time interval after which generated RDD will be checkpointed

    Definition Classes
    SchemaDStream → DStream
  8. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. def columns: Array[String]

    Permalink

    Returns all column names as an array.

  10. def compute(validTime: Time): Option[RDD[Row]]

    Permalink

    Method that generates a RDD for the given time

    Method that generates a RDD for the given time

    Definition Classes
    SchemaDStream → DStream
  11. def context: StreamingContext

    Permalink
    Definition Classes
    DStream
  12. def count(): DStream[Long]

    Permalink
    Definition Classes
    DStream
  13. def countByValue(numPartitions: Int)(implicit ord: Ordering[Row]): DStream[(Row, Long)]

    Permalink
    Definition Classes
    DStream
  14. def countByValueAndWindow(windowDuration: Duration, slideDuration: Duration, numPartitions: Int)(implicit ord: Ordering[Row]): DStream[(Row, Long)]

    Permalink
    Definition Classes
    DStream
  15. def countByWindow(windowDuration: Duration, slideDuration: Duration): DStream[Long]

    Permalink
    Definition Classes
    DStream
  16. def createRDDWithLocalProperties[U](time: Time, displayInnerRDDOps: Boolean)(body: ⇒ U): U

    Permalink
    Attributes
    protected[org.apache.spark.streaming]
    Definition Classes
    DStream
  17. def dependencies: List[DStream[InternalRow]]

    Permalink

    List of parent DStreams on which this SchemaDStream depends on

    List of parent DStreams on which this SchemaDStream depends on

    Definition Classes
    SchemaDStream → DStream
  18. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  19. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  20. def filter(filterFunc: (Row) ⇒ Boolean): SchemaDStream

    Permalink

    Return a new SchemaDStream containing only the elements that satisfy a predicate.

    Return a new SchemaDStream containing only the elements that satisfy a predicate.

    Definition Classes
    SchemaDStream → DStream
  21. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  22. def flatMap[U](flatMapFunc: (Row) ⇒ TraversableOnce[U])(implicit arg0: ClassTag[U]): DStream[U]

    Permalink

    Return a new DStream by applying a function to all elements of this SchemaDStream, and then flattening the results

    Return a new DStream by applying a function to all elements of this SchemaDStream, and then flattening the results

    Definition Classes
    SchemaDStream → DStream
  23. def foreachDataFrame(foreachFunc: (DataFrame, Time) ⇒ Unit, needsConversion: Boolean): Unit

    Permalink

    Apply a function to each DataFrame in this SchemaDStream.

    Apply a function to each DataFrame in this SchemaDStream. This is an output operator, so 'this' SchemaDStream will be registered as an output stream and therefore materialized.

  24. def foreachDataFrame(foreachFunc: (DataFrame, Time) ⇒ Unit): Unit

    Permalink

    Apply a function to each DataFrame in this SchemaDStream.

    Apply a function to each DataFrame in this SchemaDStream. This is an output operator, so 'this' SchemaDStream will be registered as an output stream and therefore materialized.

  25. def foreachDataFrame(foreachFunc: VoidFunction2[DataFrame, Time]): Unit

    Permalink

    Apply a function to each DataFrame in this SchemaDStream.

    Apply a function to each DataFrame in this SchemaDStream. This is an output operator, so 'this' SchemaDStream will be registered as an output stream and therefore materialized.

  26. def foreachDataFrame(foreachFunc: VoidFunction[DataFrame], needsConversion: Boolean): Unit

    Permalink

    Apply a function to each DataFrame in this SchemaDStream.

    Apply a function to each DataFrame in this SchemaDStream. This is an output operator, so 'this' SchemaDStream will be registered as an output stream and therefore materialized.

  27. def foreachDataFrame(foreachFunc: VoidFunction[DataFrame]): Unit

    Permalink

    Apply a function to each DataFrame in this SchemaDStream.

    Apply a function to each DataFrame in this SchemaDStream. This is an output operator, so 'this' SchemaDStream will be registered as an output stream and therefore materialized.

  28. def foreachDataFrame(foreachFunc: (DataFrame) ⇒ Unit, needsConversion: Boolean): Unit

    Permalink

    Apply a function to each DataFrame in this SchemaDStream.

    Apply a function to each DataFrame in this SchemaDStream. This is an output operator, so 'this' SchemaDStream will be registered as an output stream and therefore materialized.

  29. def foreachDataFrame(foreachFunc: (DataFrame) ⇒ Unit): Unit

    Permalink

    Apply a function to each DataFrame in this SchemaDStream.

    Apply a function to each DataFrame in this SchemaDStream. This is an output operator, so 'this' SchemaDStream will be registered as an output stream and therefore materialized.

  30. def foreachRDD(foreachFunc: (RDD[Row], Time) ⇒ Unit): Unit

    Permalink
    Definition Classes
    DStream
  31. def foreachRDD(foreachFunc: (RDD[Row]) ⇒ Unit): Unit

    Permalink
    Definition Classes
    DStream
  32. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  33. def glom(): DStream[Array[Row]]

    Permalink

    Return a new DStream in which each RDD is generated by applying glom() to each RDD of this SchemaDStream.

    Return a new DStream in which each RDD is generated by applying glom() to each RDD of this SchemaDStream. Applying glom() to an RDD coalesces all elements within each partition into an array.

    Definition Classes
    SchemaDStream → DStream
  34. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  35. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  36. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  37. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  38. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  39. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  40. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  41. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  42. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  43. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  44. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  45. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  46. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  47. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  48. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  49. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  50. val logicalPlan: LogicalPlan

    Permalink
  51. def map[U](mapFunc: (Row) ⇒ U)(implicit arg0: ClassTag[U]): DStream[U]

    Permalink

    Return a new DStream by applying a function to all elements of this SchemaDStream.

    Return a new DStream by applying a function to all elements of this SchemaDStream.

    Definition Classes
    SchemaDStream → DStream
  52. def mapPartitions[U](mapPartFunc: (Iterator[Row]) ⇒ Iterator[U], preservePartitioning: Boolean = false)(implicit arg0: ClassTag[U]): DStream[U]

    Permalink

    Return a new DStream in which each RDD is generated by applying mapPartitions() to each RDDs of this SchemaDStream.

    Return a new DStream in which each RDD is generated by applying mapPartitions() to each RDDs of this SchemaDStream. Applying mapPartitions() to an RDD applies a function to each partition of the RDD.

    Definition Classes
    SchemaDStream → DStream
  53. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  56. def persist(): SchemaDStream

    Permalink

    Persist RDDs of this SchemaDStream with the default storage level (MEMORY_ONLY_SER)

    Persist RDDs of this SchemaDStream with the default storage level (MEMORY_ONLY_SER)

    Definition Classes
    SchemaDStream → DStream
  57. def persist(level: StorageLevel): SchemaDStream

    Permalink

    Persist the RDDs of this SchemaDStream with the given storage level

    Persist the RDDs of this SchemaDStream with the given storage level

    Definition Classes
    SchemaDStream → DStream
  58. def print(num: Int): Unit

    Permalink
    Definition Classes
    DStream
  59. def print(): Unit

    Permalink
    Definition Classes
    DStream
  60. def printSchema(): Unit

    Permalink
  61. val queryExecution: QueryExecution

    Permalink
  62. def reduce(reduceFunc: (Row, Row) ⇒ Row): DStream[Row]

    Permalink
    Definition Classes
    DStream
  63. def reduceByWindow(reduceFunc: (Row, Row) ⇒ Row, invReduceFunc: (Row, Row) ⇒ Row, windowDuration: Duration, slideDuration: Duration): DStream[Row]

    Permalink
    Definition Classes
    DStream
  64. def reduceByWindow(reduceFunc: (Row, Row) ⇒ Row, windowDuration: Duration, slideDuration: Duration): DStream[Row]

    Permalink
    Definition Classes
    DStream
  65. def registerAsTable(tableName: String): Unit

    Permalink

    Registers this SchemaDStream as a table in the catalog.

  66. def repartition(numPartitions: Int): SchemaDStream

    Permalink

    Return a new SchemaDStream with an increased or decreased level of parallelism.

    Return a new SchemaDStream with an increased or decreased level of parallelism. Each RDD in the returned SchemaDStream has exactly numPartitions partitions.

    Definition Classes
    SchemaDStream → DStream
  67. def saveAsObjectFiles(prefix: String, suffix: String): Unit

    Permalink
    Definition Classes
    DStream
  68. def saveAsTextFiles(prefix: String, suffix: String): Unit

    Permalink
    Definition Classes
    DStream
  69. def schema: StructType

    Permalink

    Returns the schema of this SchemaDStream (represented by a StructType).

  70. def slice(fromTime: Time, toTime: Time): Seq[RDD[Row]]

    Permalink
    Definition Classes
    DStream
  71. def slice(interval: Interval): Seq[RDD[Row]]

    Permalink
    Definition Classes
    DStream
  72. def slideDuration: Duration

    Permalink

    Time interval after which the SchemaDStream generates a RDD

    Time interval after which the SchemaDStream generates a RDD

    Definition Classes
    SchemaDStream → DStream
  73. val snsc: SnappyStreamingContext

    Permalink
  74. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  75. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  76. def transform[U](transformFunc: (RDD[Row], Time) ⇒ RDD[U])(implicit arg0: ClassTag[U]): DStream[U]

    Permalink

    Return a new DStream in which each RDD is generated by applying a function on each RDD of 'this' SchemaDStream.

    Return a new DStream in which each RDD is generated by applying a function on each RDD of 'this' SchemaDStream.

    Definition Classes
    SchemaDStream → DStream
  77. def transform[U](transformFunc: (RDD[Row]) ⇒ RDD[U])(implicit arg0: ClassTag[U]): DStream[U]

    Permalink

    Return a new DStream in which each RDD is generated by applying a function on each RDD of 'this' SchemaDStream.

    Return a new DStream in which each RDD is generated by applying a function on each RDD of 'this' SchemaDStream.

    Definition Classes
    SchemaDStream → DStream
  78. def transformWith[U, V](other: DStream[U], transformFunc: (RDD[Row], RDD[U], Time) ⇒ RDD[V])(implicit arg0: ClassTag[U], arg1: ClassTag[V]): DStream[V]

    Permalink

    Return a new DStream in which each RDD is generated by applying a function on each RDD of 'this' DStream and 'other' DStream.

    Return a new DStream in which each RDD is generated by applying a function on each RDD of 'this' DStream and 'other' DStream.

    Definition Classes
    SchemaDStream → DStream
  79. def transformWith[U, V](other: DStream[U], transformFunc: (RDD[Row], RDD[U]) ⇒ RDD[V])(implicit arg0: ClassTag[U], arg1: ClassTag[V]): DStream[V]

    Permalink

    Return a new DStream in which each RDD is generated by applying a function on each RDD of 'this' SchemaDStream and 'other' SchemaDStream.

    Return a new DStream in which each RDD is generated by applying a function on each RDD of 'this' SchemaDStream and 'other' SchemaDStream.

    Definition Classes
    SchemaDStream → DStream
  80. def union(that: DStream[Row]): DStream[Row]

    Permalink
    Definition Classes
    DStream
  81. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  84. def window(windowDuration: Duration, slideDuration: Duration): DStream[Row]

    Permalink
    Definition Classes
    DStream
  85. def window(windowDuration: Duration): DStream[Row]

    Permalink
    Definition Classes
    DStream

Inherited from DStream[Row]

Inherited from internal.Logging

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped