org.apache.spark.streaming

examples

package examples

Visibility
  1. Public
  2. All

Type Members

  1. class FeederActor extends Actor

    Sends the random content to every receiver subscribed with 1/2 second delay.

  2. final class JavaFlumeEventCount extends AnyRef

  3. final class JavaKafkaWordCount extends AnyRef

  4. final class JavaNetworkWordCount extends AnyRef

  5. final class JavaQueueStream extends AnyRef

  6. class SampleActorReceiver[T] extends Actor with Receiver

    A sample actor as receiver, is also simplest.

  7. case class SubscribeReceiver(receiverActor: ActorRef) extends Product with Serializable

  8. case class UnsubscribeReceiver(receiverActor: ActorRef) extends Product with Serializable

Value Members

  1. object ActorWordCount

    A sample word count program demonstrating the use of plugging in Actor as Receiver Usage: ActorWordCount <master> <hostname> <port> <master> is the Spark master URL.

  2. object FeederActor

    A sample feeder actor

  3. object FlumeEventCount

    Produces a count of events received from Flume.

  4. object HdfsWordCount

    Counts words in new text files created in the given directory Usage: HdfsWordCount <master> <directory> <master> is the Spark master URL.

  5. object KafkaWordCount

    Consumes messages from one or more topics in Kafka and does wordcount.

  6. object KafkaWordCountProducer

  7. object MQTTPublisher

    A simple Mqtt publisher for demonstration purposes, repeatedly publishes Space separated String Message "hello mqtt demo for spark streaming"

  8. object MQTTWordCount

    A sample wordcount with MqttStream stream

  9. object NetworkWordCount

    Counts words in text encoded with UTF8 received from the network every second.

  10. object QueueStream

  11. object RawNetworkGrep

    Receives text from multiple rawNetworkStreams and counts how many '\n' delimited lines have the word 'the' in them.

  12. object RecoverableNetworkWordCount

    Counts words in text encoded with UTF8 received from the network every second.

  13. object SimpleZeroMQPublisher

    A simple publisher for demonstration purposes, repeatedly publishes random Messages every one second.

  14. object StatefulNetworkWordCount

    Counts words cumulatively in UTF8 encoded, '\n' delimited text received from the network every second.

  15. object StreamingExamples extends Logging

    Utility functions for Spark Streaming examples.

  16. object TwitterAlgebirdCMS

    Illustrates the use of the Count-Min Sketch, from Twitter's Algebird library, to compute windowed and global Top-K estimates of user IDs occurring in a Twitter stream.

  17. object TwitterAlgebirdHLL

    Illustrates the use of the HyperLogLog algorithm, from Twitter's Algebird library, to compute a windowed and global estimate of the unique user IDs occurring in a Twitter stream.

  18. object TwitterPopularTags

    Calculates popular hashtags (topics) over sliding 10 and 60 second windows from a Twitter stream.

  19. object ZeroMQWordCount

    A sample wordcount with ZeroMQStream stream

  20. package clickstream

Ungrouped