Class

org.apache.hadoop.hbase.spark.HBaseDStreamFunctions

GenericHBaseDStreamFunctions

Related Doc: package HBaseDStreamFunctions

Permalink

implicit class GenericHBaseDStreamFunctions[T] extends AnyRef

These are implicit methods for a DStream that contains any type of data.

T

Type T

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. GenericHBaseDStreamFunctions
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new GenericHBaseDStreamFunctions(dStream: DStream[T])

    Permalink

    dStream

    This is for dStreams of any type

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. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  6. val dStream: DStream[T]

    Permalink

    This is for dStreams of any type

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  9. def finalize(): Unit

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

    Permalink
    Definition Classes
    AnyRef → Any
  11. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  12. def hbaseBulkDelete(hc: HBaseContext, tableName: TableName, f: (T) ⇒ Delete, batchSize: Int): Unit

    Permalink

    Implicit method that gives easy access to HBaseContext's bulk Delete.

    Implicit method that gives easy access to HBaseContext's bulk Delete. This will not return a new DStream.

    hc

    The hbaseContext object to identify which HBase cluster connection to use

    tableName

    The tableName that the deletes will be sent to

    f

    The function that will convert the DStream value into a HBase Delete Object

    batchSize

    The number of Deletes to be sent in a single batch

  13. def hbaseBulkGet(hc: HBaseContext, tableName: TableName, batchSize: Int, f: (T) ⇒ Get): DStream[(ImmutableBytesWritable, Result)]

    Permalink

    Implicit method that gives easy access to HBaseContext's bulk get.

    Implicit method that gives easy access to HBaseContext's bulk get. This will return a new DStream. Think about it as a DStream map function. In that every DStream value will get a new value out of HBase. That new value will populate the newly generated DStream.

    hc

    The hbaseContext object to identify which HBase cluster connection to use

    tableName

    The tableName that the put will be sent to

    batchSize

    How many gets to execute in a single batch

    f

    The function that will turn the RDD values in HBase Get objects

    returns

    A resulting DStream with type R objects

  14. def hbaseBulkGet[R](hc: HBaseContext, tableName: TableName, batchSize: Int, f: (T) ⇒ Get, convertResult: (Result) ⇒ R)(implicit arg0: ClassTag[R]): DStream[R]

    Permalink

    Implicit method that gives easy access to HBaseContext's bulk get.

    Implicit method that gives easy access to HBaseContext's bulk get. This will return a new DStream. Think about it as a DStream map function. In that every DStream value will get a new value out of HBase. That new value will populate the newly generated DStream.

    R

    The type of Object that will be coming out of the resulting DStream

    hc

    The hbaseContext object to identify which HBase cluster connection to use

    tableName

    The tableName that the put will be sent to

    batchSize

    How many gets to execute in a single batch

    f

    The function that will turn the RDD values in HBase Get objects

    convertResult

    The function that will convert a HBase Result object into a value that will go into the resulting DStream

    returns

    A resulting DStream with type R objects

  15. def hbaseBulkPut(hc: HBaseContext, tableName: TableName, f: (T) ⇒ Put): Unit

    Permalink

    Implicit method that gives easy access to HBaseContext's bulk put.

    Implicit method that gives easy access to HBaseContext's bulk put. This will not return a new Stream. Think of it like a foreach

    hc

    The hbaseContext object to identify which HBase cluster connection to use

    tableName

    The tableName that the put will be sent to

    f

    The function that will turn the DStream values into HBase Put objects.

  16. def hbaseForeachPartition(hc: HBaseContext, f: (Iterator[T], Connection) ⇒ Unit): Unit

    Permalink

    Implicit method that gives easy access to HBaseContext's foreachPartition method.

    Implicit method that gives easy access to HBaseContext's foreachPartition method. This will ack very much like a normal DStream foreach method but for the fact that you will now have a HBase connection while iterating through the values.

    hc

    The hbaseContext object to identify which HBase cluster connection to use

    f

    This function will get an iterator for a Partition of an DStream along with a connection object to HBase

  17. def hbaseMapPartitions[R](hc: HBaseContext, f: (Iterator[T], Connection) ⇒ Iterator[R])(implicit arg0: ClassTag[R]): DStream[R]

    Permalink

    Implicit method that gives easy access to HBaseContext's mapPartitions method.

    Implicit method that gives easy access to HBaseContext's mapPartitions method. This will ask very much like a normal DStream map partitions method but for the fact that you will now have a HBase connection while iterating through the values

    R

    This is the type of objects that will go into the resulting DStream

    hc

    The hbaseContext object to identify which HBase cluster connection to use

    f

    This function will get an iterator for a Partition of an DStream along with a connection object to HBase

    returns

    A resulting DStream of type R

  18. final def isInstanceOf[T0]: Boolean

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

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

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

    Permalink
    Definition Classes
    AnyRef
  22. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    AnyRef → Any
  24. final def wait(): Unit

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

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

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

Inherited from AnyRef

Inherited from Any

Ungrouped