Class/Object

org.apache.spark.streaming

SnappyStreamingContext

Related Docs: object SnappyStreamingContext | package streaming

Permalink

class SnappyStreamingContext extends StreamingContext with Serializable

Main entry point for SnappyData extensions to Spark Streaming. A SnappyStreamingContext extends Spark's org.apache.spark.streaming.StreamingContext to provides an ability to manipulate SQL like query on org.apache.spark.streaming.dstream.DStream. You can apply schema and register continuous SQL queries(CQ) over the data streams. A single shared SnappyStreamingContext makes it possible to re-use Executors across client connections or applications.

Self Type
SnappyStreamingContext
Linear Supertypes
Serializable, Serializable, StreamingContext, internal.Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SnappyStreamingContext
  2. Serializable
  3. Serializable
  4. StreamingContext
  5. Logging
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SnappyStreamingContext(path: String, sparkContext: SparkContext)

    Permalink

    Recreate a SnappyStreamingContext from a checkpoint file using an existing SparkContext.

    Recreate a SnappyStreamingContext from a checkpoint file using an existing SparkContext.

    path

    Path to the directory that was specified as the checkpoint directory

    sparkContext

    Existing SparkContext

  2. new SnappyStreamingContext(path: String)

    Permalink

    Recreate a SnappyStreamingContext from a checkpoint file.

    Recreate a SnappyStreamingContext from a checkpoint file.

    path

    Path to the directory that was specified as the checkpoint directory

  3. new SnappyStreamingContext(path: String, hadoopConf: Configuration)

    Permalink

    Recreate a SnappyStreamingContext from a checkpoint file.

    Recreate a SnappyStreamingContext from a checkpoint file.

    path

    Path to the directory that was specified as the checkpoint directory

    hadoopConf

    Optional, configuration object if necessary for reading from HDFS compatible filesystems

  4. new SnappyStreamingContext(conf: SparkConf, batchDuration: Duration)

    Permalink

    Create a SnappyStreamingContext by providing the configuration necessary for a new SparkContext.

    Create a SnappyStreamingContext by providing the configuration necessary for a new SparkContext.

    conf

    a org.apache.spark.SparkConf object specifying Spark parameters

    batchDuration

    the time interval at which streaming data will be divided into batches

  5. new SnappyStreamingContext(snappySession: SnappySession, batchDuration: Duration)

    Permalink
  6. new SnappyStreamingContext(sparkContext: SparkContext, batchDuration: Duration)

    Permalink

    Create a SnappyStreamingContext using an existing SparkContext.

    Create a SnappyStreamingContext using an existing SparkContext.

    sparkContext

    existing SparkContext

    batchDuration

    the time interval at which streaming data will be divided into batches

  7. new SnappyStreamingContext(sc_: SparkContext, cp_: Checkpoint, batchDur_: Duration, reuseSnappySession: Option[SnappySession] = None, currentSnappySession: Option[SnappySession] = None)

    Permalink
    Attributes
    protected[org.apache.spark]

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. def addStreamingListener(streamingListener: StreamingListener): Unit

    Permalink
    Definition Classes
    StreamingContext
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def awaitTermination(): Unit

    Permalink
    Definition Classes
    StreamingContext
  7. def awaitTerminationOrTimeout(timeout: Long): Boolean

    Permalink
    Definition Classes
    StreamingContext
  8. def binaryRecordsStream(directory: String, recordLength: Int): DStream[Array[Byte]]

    Permalink
    Definition Classes
    StreamingContext
  9. def checkpoint(directory: String): Unit

    Permalink
    Definition Classes
    StreamingContext
  10. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  11. def createSchemaDStream(rowStream: DStream[Row], schema: StructType): SchemaDStream

    Permalink
  12. def createSchemaDStream[A <: Product](stream: DStream[A])(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A]): SchemaDStream

    Permalink

    Creates a SchemaDStream from an DStream of Product (e.g.

    Creates a SchemaDStream from an DStream of Product (e.g. case classes).

  13. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  15. def fileStream[K, V, F <: InputFormat[K, V]](directory: String, filter: (Path) ⇒ Boolean, newFilesOnly: Boolean, conf: Configuration)(implicit arg0: ClassTag[K], arg1: ClassTag[V], arg2: ClassTag[F]): InputDStream[(K, V)]

    Permalink
    Definition Classes
    StreamingContext
  16. def fileStream[K, V, F <: InputFormat[K, V]](directory: String, filter: (Path) ⇒ Boolean, newFilesOnly: Boolean)(implicit arg0: ClassTag[K], arg1: ClassTag[V], arg2: ClassTag[F]): InputDStream[(K, V)]

    Permalink
    Definition Classes
    StreamingContext
  17. def fileStream[K, V, F <: InputFormat[K, V]](directory: String)(implicit arg0: ClassTag[K], arg1: ClassTag[V], arg2: ClassTag[F]): InputDStream[(K, V)]

    Permalink
    Definition Classes
    StreamingContext
  18. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  19. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  20. def getSchemaDStream(tableName: String): SchemaDStream

    Permalink
  21. def getState(): StreamingContextState

    Permalink
    Definition Classes
    StreamingContext
    Annotations
    @DeveloperApi()
  22. def hashCode(): Int

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  38. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  41. def queueStream[T](queue: Queue[RDD[T]], oneAtATime: Boolean, defaultRDD: RDD[T])(implicit arg0: ClassTag[T]): InputDStream[T]

    Permalink
    Definition Classes
    StreamingContext
  42. def queueStream[T](queue: Queue[RDD[T]], oneAtATime: Boolean)(implicit arg0: ClassTag[T]): InputDStream[T]

    Permalink
    Definition Classes
    StreamingContext
  43. def rawSocketStream[T](hostname: String, port: Int, storageLevel: StorageLevel)(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]

    Permalink
    Definition Classes
    StreamingContext
  44. def receiverStream[T](receiver: Receiver[T])(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]

    Permalink
    Definition Classes
    StreamingContext
  45. def registerCQ(queryStr: String): SchemaDStream

    Permalink

    Registers and executes given SQL query and returns SchemaDStream to consume the results

    Registers and executes given SQL query and returns SchemaDStream to consume the results

    queryStr

    the query to register

  46. def registerStreamTables(): Unit

    Permalink
  47. def remember(duration: Duration): Unit

    Permalink
    Definition Classes
    StreamingContext
  48. val snappyContext: SnappyContext

    Permalink
  49. val snappySession: SnappySession

    Permalink
  50. def socketStream[T](hostname: String, port: Int, converter: (InputStream) ⇒ Iterator[T], storageLevel: StorageLevel)(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]

    Permalink
    Definition Classes
    StreamingContext
  51. def socketTextStream(hostname: String, port: Int, storageLevel: StorageLevel): ReceiverInputDStream[String]

    Permalink
    Definition Classes
    StreamingContext
  52. def sparkContext: SparkContext

    Permalink
    Definition Classes
    StreamingContext
  53. def sql(sqlText: String): DataFrame

    Permalink
  54. def start(): Unit

    Permalink

    Start the execution of the streams.

    Start the execution of the streams. Also registers population of AQP tables from stream tables if present.

    Definition Classes
    SnappyStreamingContext → StreamingContext
    Exceptions thrown

    IllegalStateException if the StreamingContext is already stopped

  55. def stop(stopSparkContext: Boolean, stopGracefully: Boolean): Unit

    Permalink
    Definition Classes
    SnappyStreamingContext → StreamingContext
  56. def stop(stopSparkContext: Boolean): Unit

    Permalink
    Definition Classes
    StreamingContext
  57. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  58. def textFileStream(directory: String): DStream[String]

    Permalink
    Definition Classes
    StreamingContext
  59. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  60. def transform[T](dstreams: Seq[DStream[_]], transformFunc: (Seq[RDD[_]], Time) ⇒ RDD[T])(implicit arg0: ClassTag[T]): DStream[T]

    Permalink
    Definition Classes
    StreamingContext
  61. def union[T](streams: Seq[DStream[T]])(implicit arg0: ClassTag[T]): DStream[T]

    Permalink
    Definition Classes
    StreamingContext
  62. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from Serializable

Inherited from Serializable

Inherited from StreamingContext

Inherited from internal.Logging

Inherited from AnyRef

Inherited from Any

Ungrouped