public class ZeroMQUtils
extends Object
Constructor and Description |
---|
ZeroMQUtils() |
Modifier and Type | Method and Description |
---|---|
static <T> JavaReceiverInputDStream<T> |
createStream(JavaStreamingContext jssc,
String publisherUrl,
akka.zeromq.Subscribe subscribe,
Function<byte[][],Iterable<T>> bytesToObjects)
Create an input stream that receives messages pushed by a zeromq publisher.
|
static <T> JavaReceiverInputDStream<T> |
createStream(JavaStreamingContext jssc,
String publisherUrl,
akka.zeromq.Subscribe subscribe,
Function<byte[][],Iterable<T>> bytesToObjects,
StorageLevel storageLevel)
Create an input stream that receives messages pushed by a zeromq publisher.
|
static <T> JavaReceiverInputDStream<T> |
createStream(JavaStreamingContext jssc,
String publisherUrl,
akka.zeromq.Subscribe subscribe,
Function<byte[][],Iterable<T>> bytesToObjects,
StorageLevel storageLevel,
akka.actor.SupervisorStrategy supervisorStrategy)
Create an input stream that receives messages pushed by a zeromq publisher.
|
static <T> ReceiverInputDStream<T> |
createStream(StreamingContext ssc,
String publisherUrl,
akka.zeromq.Subscribe subscribe,
scala.Function1<scala.collection.Seq<akka.util.ByteString>,scala.collection.Iterator<T>> bytesToObjects,
StorageLevel storageLevel,
akka.actor.SupervisorStrategy supervisorStrategy,
scala.reflect.ClassTag<T> evidence$1)
Create an input stream that receives messages pushed by a zeromq publisher.
|
public static <T> ReceiverInputDStream<T> createStream(StreamingContext ssc, String publisherUrl, akka.zeromq.Subscribe subscribe, scala.Function1<scala.collection.Seq<akka.util.ByteString>,scala.collection.Iterator<T>> bytesToObjects, StorageLevel storageLevel, akka.actor.SupervisorStrategy supervisorStrategy, scala.reflect.ClassTag<T> evidence$1)
ssc
- StreamingContext objectpublisherUrl
- Url of remote zeromq publishersubscribe
- Topic to subscribe tobytesToObjects
- A zeroMQ stream publishes sequence of frames for each topic
and each frame has sequence of byte thus it needs the converter
(which might be deserializer of bytes) to translate from sequence
of sequence of bytes, where sequence refer to a frame
and sub sequence refer to its payload.storageLevel
- RDD storage level. Defaults to StorageLevel.MEMORY_AND_DISK_SER_2.public static <T> JavaReceiverInputDStream<T> createStream(JavaStreamingContext jssc, String publisherUrl, akka.zeromq.Subscribe subscribe, Function<byte[][],Iterable<T>> bytesToObjects, StorageLevel storageLevel, akka.actor.SupervisorStrategy supervisorStrategy)
jssc
- JavaStreamingContext objectpublisherUrl
- Url of remote ZeroMQ publishersubscribe
- Topic to subscribe tobytesToObjects
- A zeroMQ stream publishes sequence of frames for each topic and each
frame has sequence of byte thus it needs the converter(which might be
deserializer of bytes) to translate from sequence of sequence of bytes,
where sequence refer to a frame and sub sequence refer to its payload.storageLevel
- Storage level to use for storing the received objectspublic static <T> JavaReceiverInputDStream<T> createStream(JavaStreamingContext jssc, String publisherUrl, akka.zeromq.Subscribe subscribe, Function<byte[][],Iterable<T>> bytesToObjects, StorageLevel storageLevel)
jssc
- JavaStreamingContext objectpublisherUrl
- Url of remote zeromq publishersubscribe
- Topic to subscribe tobytesToObjects
- A zeroMQ stream publishes sequence of frames for each topic and each
frame has sequence of byte thus it needs the converter(which might be
deserializer of bytes) to translate from sequence of sequence of bytes,
where sequence refer to a frame and sub sequence refer to its payload.storageLevel
- RDD storage level.public static <T> JavaReceiverInputDStream<T> createStream(JavaStreamingContext jssc, String publisherUrl, akka.zeromq.Subscribe subscribe, Function<byte[][],Iterable<T>> bytesToObjects)
jssc
- JavaStreamingContext objectpublisherUrl
- Url of remote zeromq publishersubscribe
- Topic to subscribe tobytesToObjects
- A zeroMQ stream publishes sequence of frames for each topic and each
frame has sequence of byte thus it needs the converter(which might
be deserializer of bytes) to translate from sequence of sequence of
bytes, where sequence refer to a frame and sub sequence refer to its
payload.