Class/Object

org.zouzias.spark.lucenerdd

LuceneRDD

Related Docs: object LuceneRDD | package lucenerdd

Permalink

class LuceneRDD[T] extends RDD[T] with LuceneRDDConfigurable

Spark RDD with Lucene's query capabilities (term, prefix, fuzzy, phrase query)

Linear Supertypes
LuceneRDDConfigurable, Configurable, RDD[T], Logging, Serializable, Serializable, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. LuceneRDD
  2. LuceneRDDConfigurable
  3. Configurable
  4. RDD
  5. Logging
  6. Serializable
  7. Serializable
  8. AnyRef
  9. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new LuceneRDD(partitionsRDD: RDD[AbstractLuceneRDDPartition[T]], indexAnalyzer: String, queryAnalyzer: String, indexAnalyzerPerField: Map[String, String], queryAnalyzerPerField: Map[String, String], similarity: String)(implicit arg0: ClassTag[T])

    Permalink

    partitionsRDD

    Partitions of RDD

    indexAnalyzer

    Analyzer during indexing time

    queryAnalyzer

    Analyzer during query time

    similarity

    Query similarity (TF-IDF / BM25)

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. def ++(other: RDD[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  4. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  5. lazy val Config: Config

    Permalink
    Definition Classes
    Configurable
  6. val DefaultFacetNum: Int

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  7. val DefaultTopK: Int

    Permalink

    Default value for topK queries

    Default value for topK queries

    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  8. val MaxDefaultTopKValue: Int

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  9. val StringFieldsDefaultAnalyzed: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  10. val StringFieldsIndexOptions: IndexOptions

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  11. val StringFieldsListToBeNotAnalyzed: List[String]

    Permalink

    List of string fields *not* to be analyzed

    List of string fields *not* to be analyzed

    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  12. val StringFieldsOmitNorms: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  13. val StringFieldsStoreTermPositions: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  14. val StringFieldsStoreTermVector: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  15. def aggregate[U](zeroValue: U)(seqOp: (U, T) ⇒ U, combOp: (U, U) ⇒ U)(implicit arg0: ClassTag[U]): U

    Permalink
    Definition Classes
    RDD
  16. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  17. def barrier(): RDDBarrier[T]

    Permalink
    Definition Classes
    RDD
    Annotations
    @Experimental() @Since( "2.4.0" )
  18. def cache(): LuceneRDD.this.type

    Permalink
    Definition Classes
    LuceneRDD → RDD
  19. def cartesian[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[(T, U)]

    Permalink
    Definition Classes
    RDD
  20. def checkpoint(): Unit

    Permalink
    Definition Classes
    RDD
  21. def clearDependencies(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    RDD
  22. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  23. def close(): Unit

    Permalink
  24. def coalesce(numPartitions: Int, shuffle: Boolean, partitionCoalescer: Option[PartitionCoalescer])(implicit ord: Ordering[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  25. def collect[U](f: PartialFunction[T, U])(implicit arg0: ClassTag[U]): RDD[U]

    Permalink
    Definition Classes
    RDD
  26. def collect(): Array[T]

    Permalink
    Definition Classes
    RDD
  27. def compute(part: Partition, context: TaskContext): Iterator[T]

    Permalink

    RDD compute method.

    RDD compute method.

    Definition Classes
    LuceneRDD → RDD
  28. def context: SparkContext

    Permalink
    Definition Classes
    RDD
  29. def count(): Long

    Permalink
    Definition Classes
    LuceneRDD → RDD
  30. def countApprox(timeout: Long, confidence: Double): PartialResult[BoundedDouble]

    Permalink
    Definition Classes
    RDD
  31. def countApproxDistinct(relativeSD: Double): Long

    Permalink
    Definition Classes
    RDD
  32. def countApproxDistinct(p: Int, sp: Int): Long

    Permalink
    Definition Classes
    RDD
  33. def countByValue()(implicit ord: Ordering[T]): Map[T, Long]

    Permalink
    Definition Classes
    RDD
  34. def countByValueApprox(timeout: Long, confidence: Double)(implicit ord: Ordering[T]): PartialResult[Map[T, BoundedDouble]]

    Permalink
    Definition Classes
    RDD
  35. def dedup[T1](searchQueryGen: (T1) ⇒ String, topK: Int = DefaultTopK, linkerMethod: String = getLinkerMethod)(implicit arg0: ClassTag[T1]): RDD[(T1, Array[Row])]

    Permalink

    Deduplication of self

    Deduplication of self

    searchQueryGen

    Search query mapper function

    topK

    Number of results to deduplication

    linkerMethod

    Method to perform linkage

  36. final def dependencies: Seq[Dependency[_]]

    Permalink
    Definition Classes
    RDD
  37. def distinct(): RDD[T]

    Permalink
    Definition Classes
    RDD
  38. def distinct(numPartitions: Int)(implicit ord: Ordering[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  39. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  41. def exists(elem: T): Boolean

    Permalink
  42. def exists(doc: Map[String, String]): Boolean

    Permalink

    Lucene generic query

  43. def fields(): Set[String]

    Permalink

    Return all document fields

  44. def filter(pred: (T) ⇒ Boolean): LuceneRDD[T]

    Permalink
    Definition Classes
    LuceneRDD → RDD
  45. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  46. def first(): T

    Permalink
    Definition Classes
    RDD
  47. def firstParent[U](implicit arg0: ClassTag[U]): RDD[U]

    Permalink
    Attributes
    protected[org.apache.spark]
    Definition Classes
    RDD
  48. def flatMap[U](f: (T) ⇒ TraversableOnce[U])(implicit arg0: ClassTag[U]): RDD[U]

    Permalink
    Definition Classes
    RDD
  49. def fold(zeroValue: T)(op: (T, T) ⇒ T): T

    Permalink
    Definition Classes
    RDD
  50. def foreach(f: (T) ⇒ Unit): Unit

    Permalink
    Definition Classes
    RDD
  51. def foreachPartition(f: (Iterator[T]) ⇒ Unit): Unit

    Permalink
    Definition Classes
    RDD
  52. def fuzzyQuery(fieldName: String, query: String, maxEdits: Int, topK: Int = DefaultTopK): LuceneRDDResponse

    Permalink

    Lucene fuzzy query

    Lucene fuzzy query

    fieldName

    Name of field

    query

    Query text

    maxEdits

    Fuzziness, edit distance

    topK

    Number of documents to return

  53. def getCheckpointFile: Option[String]

    Permalink
    Definition Classes
    RDD
  54. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  55. def getDependencies: Seq[Dependency[_]]

    Permalink
    Attributes
    protected
    Definition Classes
    RDD
  56. val getLinkerMethod: String

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDDConfigurable
  57. final def getNumPartitions: Int

    Permalink
    Definition Classes
    RDD
    Annotations
    @Since( "1.6.0" )
  58. def getOutputDeterministicLevel: apache.spark.rdd.DeterministicLevel.Value

    Permalink
    Attributes
    protected
    Definition Classes
    RDD
    Annotations
    @DeveloperApi()
  59. def getPartitions: Array[Partition]

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDD → RDD
  60. def getPreferredLocations(s: Partition): Seq[String]

    Permalink
    Attributes
    protected
    Definition Classes
    LuceneRDD → RDD
  61. def getStorageLevel: StorageLevel

    Permalink
    Definition Classes
    RDD
  62. def glom(): RDD[Array[T]]

    Permalink
    Definition Classes
    RDD
  63. def groupBy[K](f: (T) ⇒ K, p: Partitioner)(implicit kt: ClassTag[K], ord: Ordering[K]): RDD[(K, Iterable[T])]

    Permalink
    Definition Classes
    RDD
  64. def groupBy[K](f: (T) ⇒ K, numPartitions: Int)(implicit kt: ClassTag[K]): RDD[(K, Iterable[T])]

    Permalink
    Definition Classes
    RDD
  65. def groupBy[K](f: (T) ⇒ K)(implicit kt: ClassTag[K]): RDD[(K, Iterable[T])]

    Permalink
    Definition Classes
    RDD
  66. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  67. val id: Int

    Permalink
    Definition Classes
    RDD
  68. val indexAnalyzer: String

    Permalink

    Analyzer during indexing time

    Analyzer during indexing time

    Attributes
    protected
  69. val indexAnalyzerPerField: Map[String, String]

    Permalink
    Attributes
    protected
  70. def indexStats(): RDD[IndexStatistics]

    Permalink
  71. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  72. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  73. def intersection(other: RDD[T], numPartitions: Int): RDD[T]

    Permalink
    Definition Classes
    RDD
  74. def intersection(other: RDD[T], partitioner: Partitioner)(implicit ord: Ordering[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  75. def intersection(other: RDD[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  76. lazy val isBarrier_: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    RDD
  77. def isCheckpointed: Boolean

    Permalink
    Definition Classes
    RDD
  78. def isEmpty(): Boolean

    Permalink
    Definition Classes
    RDD
  79. final def isInstanceOf[T0]: Boolean

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  81. final def iterator(split: Partition, context: TaskContext): Iterator[T]

    Permalink
    Definition Classes
    RDD
  82. def keyBy[K](f: (T) ⇒ K): RDD[(K, T)]

    Permalink
    Definition Classes
    RDD
  83. def link[T1](other: RDD[T1], searchQueryGen: (T1) ⇒ String, topK: Int = DefaultTopK, linkerMethod: String = getLinkerMethod)(implicit arg0: ClassTag[T1]): RDD[(T1, Array[Row])]

    Permalink

    Entity linkage via Lucene query over all elements of an RDD.

    Entity linkage via Lucene query over all elements of an RDD.

    T1

    A type

    other

    RDD to be linked

    searchQueryGen

    Function that generates a search query for each element of other

    linkerMethod

    Method to perform linkage, default value from configuration

    returns

    an RDD of Tuple2 that contains the linked search Lucene documents in the second Note: Currently the query strings of the other RDD are collected to the driver and broadcast to the workers.

  84. def linkByQuery[T1](other: RDD[T1], searchQueryGen: (T1) ⇒ Query, topK: Int = DefaultTopK, linkerMethod: String = getLinkerMethod)(implicit arg0: ClassTag[T1]): RDD[(T1, Array[Row])]

    Permalink

    Entity linkage via Lucene query over all elements of an RDD.

    Entity linkage via Lucene query over all elements of an RDD.

    T1

    A type

    other

    RDD to be linked

    searchQueryGen

    Function that generates a Lucene Query object for each element of other

    linkerMethod

    Method to perform linkage

    returns

    an RDD of Tuple2 that contains the linked search Lucene Document in the second position

  85. def linkDataFrame(other: DataFrame, searchQueryGen: (Row) ⇒ String, topK: Int = DefaultTopK, linkerMethod: String = getLinkerMethod): RDD[(Row, Array[Row])]

    Permalink

    Entity linkage via Lucene query over all elements of an RDD.

    Entity linkage via Lucene query over all elements of an RDD.

    other

    DataFrame to be linked

    searchQueryGen

    Function that generates a search query for each element of other

    linkerMethod

    Method to perform linkage

    returns

    an RDD of Tuple2 that contains the linked search Lucene documents in the second

  86. def localCheckpoint(): LuceneRDD.this.type

    Permalink
    Definition Classes
    RDD
  87. def log: Logger

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  99. def map[U](f: (T) ⇒ U)(implicit arg0: ClassTag[U]): RDD[U]

    Permalink
    Definition Classes
    RDD
  100. def mapPartitions[U](f: (Iterator[T]) ⇒ Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]

    Permalink
    Definition Classes
    RDD
  101. def mapPartitionsWithIndex[U](f: (Int, Iterator[T]) ⇒ Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]

    Permalink
    Definition Classes
    RDD
  102. def max()(implicit ord: Ordering[T]): T

    Permalink
    Definition Classes
    RDD
  103. def min()(implicit ord: Ordering[T]): T

    Permalink
    Definition Classes
    RDD
  104. def moreLikeThis(fieldName: String, query: String, minTermFreq: Int, minDocFreq: Int, topK: Int = DefaultTopK): LuceneRDDResponse

    Permalink

    Lucene's More Like This (MLT) functionality

    Lucene's More Like This (MLT) functionality

    fieldName

    Field name

    query

    Query text

    minTermFreq

    Minimum term frequency

    minDocFreq

    Minimum document frequency

    topK

    Number of returned documents

  105. var name: String

    Permalink
    Definition Classes
    RDD
  106. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  109. def parent[U](j: Int)(implicit arg0: ClassTag[U]): RDD[U]

    Permalink
    Attributes
    protected[org.apache.spark]
    Definition Classes
    RDD
  110. def partitionMapper(f: (AbstractLuceneRDDPartition[T]) ⇒ LuceneRDDResponsePartition): LuceneRDDResponse

    Permalink

    Maps partition results

    Maps partition results

    f

    Function to apply on each partition / distributed index

    Attributes
    protected
  111. val partitioner: Option[Partitioner]

    Permalink
    Definition Classes
    RDD
  112. final def partitions: Array[Partition]

    Permalink
    Definition Classes
    RDD
  113. val partitionsRDD: RDD[AbstractLuceneRDDPartition[T]]

    Permalink

    Partitions of RDD

    Partitions of RDD

    Attributes
    protected
  114. def persist(newLevel: StorageLevel): LuceneRDD.this.type

    Permalink
    Definition Classes
    LuceneRDD → RDD
  115. def persist(): LuceneRDD.this.type

    Permalink
    Definition Classes
    RDD
  116. def phraseQuery(fieldName: String, query: String, topK: Int = DefaultTopK): LuceneRDDResponse

    Permalink

    Lucene phrase Query

    Lucene phrase Query

    fieldName

    Name of field

    query

    Query text

    topK

    Number of documents to return

  117. def pipe(command: Seq[String], env: Map[String, String], printPipeContext: ((String) ⇒ Unit) ⇒ Unit, printRDDElement: (T, (String) ⇒ Unit) ⇒ Unit, separateWorkingDir: Boolean, bufferSize: Int, encoding: String): RDD[String]

    Permalink
    Definition Classes
    RDD
  118. def pipe(command: String, env: Map[String, String]): RDD[String]

    Permalink
    Definition Classes
    RDD
  119. def pipe(command: String): RDD[String]

    Permalink
    Definition Classes
    RDD
  120. final def preferredLocations(split: Partition): Seq[String]

    Permalink
    Definition Classes
    RDD
  121. def prefixQuery(fieldName: String, query: String, topK: Int = DefaultTopK): LuceneRDDResponse

    Permalink

    Lucene prefix query

    Lucene prefix query

    fieldName

    Name of field

    query

    Prefix query text

    topK

    Number of documents to return

  122. def query(searchString: String, topK: Int = DefaultTopK): LuceneRDDResponse

    Permalink

    Generic query using Lucene's query parser

    Generic query using Lucene's query parser

    searchString

    Query String

  123. val queryAnalyzer: String

    Permalink

    Analyzer during query time

    Analyzer during query time

    Attributes
    protected
  124. val queryAnalyzerPerField: Map[String, String]

    Permalink
    Attributes
    protected
  125. def randomSplit(weights: Array[Double], seed: Long): Array[RDD[T]]

    Permalink
    Definition Classes
    RDD
  126. def reduce(f: (T, T) ⇒ T): T

    Permalink
    Definition Classes
    RDD
  127. def repartition(numPartitions: Int)(implicit ord: Ordering[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  128. def sample(withReplacement: Boolean, fraction: Double, seed: Long): RDD[T]

    Permalink
    Definition Classes
    RDD
  129. def saveAsObjectFile(path: String): Unit

    Permalink
    Definition Classes
    RDD
  130. def saveAsTextFile(path: String, codec: Class[_ <: CompressionCodec]): Unit

    Permalink
    Definition Classes
    RDD
  131. def saveAsTextFile(path: String): Unit

    Permalink
    Definition Classes
    RDD
  132. def setName(_name: String): LuceneRDD.this.type

    Permalink

    Set the name for the RDD; By default set to "LuceneRDD"

    Set the name for the RDD; By default set to "LuceneRDD"

    Definition Classes
    LuceneRDD → RDD
  133. val similarity: String

    Permalink

    Query similarity (TF-IDF / BM25)

    Query similarity (TF-IDF / BM25)

    Attributes
    protected
  134. def sortBy[K](f: (T) ⇒ K, ascending: Boolean, numPartitions: Int)(implicit ord: Ordering[K], ctag: ClassTag[K]): RDD[T]

    Permalink
    Definition Classes
    RDD
  135. def sparkContext: SparkContext

    Permalink
    Definition Classes
    RDD
  136. def subtract(other: RDD[T], p: Partitioner)(implicit ord: Ordering[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  137. def subtract(other: RDD[T], numPartitions: Int): RDD[T]

    Permalink
    Definition Classes
    RDD
  138. def subtract(other: RDD[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  139. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  140. def take(num: Int): Array[T]

    Permalink
    Definition Classes
    RDD
  141. def takeOrdered(num: Int)(implicit ord: Ordering[T]): Array[T]

    Permalink
    Definition Classes
    RDD
  142. def takeSample(withReplacement: Boolean, num: Int, seed: Long): Array[T]

    Permalink
    Definition Classes
    RDD
  143. def termQuery(fieldName: String, query: String, topK: Int = DefaultTopK): LuceneRDDResponse

    Permalink

    Lucene term query

    Lucene term query

    fieldName

    Name of field

    query

    Term to search on

    topK

    Number of documents to return

  144. def termVectors(fieldName: String, idFieldName: Option[String] = None): RDD[TermVectorEntry]

    Permalink

    Return Term vector for a Lucene field

    Return Term vector for a Lucene field

    fieldName

    Field name for term vectors

    idFieldName

    Lucene field that contains unique id: default set to None, in which case id equals (docId, partitionId)

    returns

    RDD of term vector entries, i.e., (document id, term as String, term frequency in document)

  145. def toDebugString: String

    Permalink
    Definition Classes
    RDD
  146. def toJavaRDD(): JavaRDD[T]

    Permalink
    Definition Classes
    RDD
  147. def toLocalIterator: Iterator[T]

    Permalink
    Definition Classes
    RDD
  148. def toString(): String

    Permalink
    Definition Classes
    RDD → AnyRef → Any
  149. def top(num: Int)(implicit ord: Ordering[T]): Array[T]

    Permalink
    Definition Classes
    RDD
  150. def treeAggregate[U](zeroValue: U)(seqOp: (U, T) ⇒ U, combOp: (U, U) ⇒ U, depth: Int)(implicit arg0: ClassTag[U]): U

    Permalink
    Definition Classes
    RDD
  151. def treeReduce(f: (T, T) ⇒ T, depth: Int): T

    Permalink
    Definition Classes
    RDD
  152. def union(other: RDD[T]): RDD[T]

    Permalink
    Definition Classes
    RDD
  153. def unpersist(blocking: Boolean = true): LuceneRDD.this.type

    Permalink
    Definition Classes
    LuceneRDD → RDD
  154. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  157. def zip[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[(T, U)]

    Permalink
    Definition Classes
    RDD
  158. def zipPartitions[B, C, D, V](rdd2: RDD[B], rdd3: RDD[C], rdd4: RDD[D])(f: (Iterator[T], Iterator[B], Iterator[C], Iterator[D]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[D], arg3: ClassTag[V]): RDD[V]

    Permalink
    Definition Classes
    RDD
  159. def zipPartitions[B, C, D, V](rdd2: RDD[B], rdd3: RDD[C], rdd4: RDD[D], preservesPartitioning: Boolean)(f: (Iterator[T], Iterator[B], Iterator[C], Iterator[D]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[D], arg3: ClassTag[V]): RDD[V]

    Permalink
    Definition Classes
    RDD
  160. def zipPartitions[B, C, V](rdd2: RDD[B], rdd3: RDD[C])(f: (Iterator[T], Iterator[B], Iterator[C]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[V]): RDD[V]

    Permalink
    Definition Classes
    RDD
  161. def zipPartitions[B, C, V](rdd2: RDD[B], rdd3: RDD[C], preservesPartitioning: Boolean)(f: (Iterator[T], Iterator[B], Iterator[C]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[V]): RDD[V]

    Permalink
    Definition Classes
    RDD
  162. def zipPartitions[B, V](rdd2: RDD[B])(f: (Iterator[T], Iterator[B]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]

    Permalink
    Definition Classes
    RDD
  163. def zipPartitions[B, V](rdd2: RDD[B], preservesPartitioning: Boolean)(f: (Iterator[T], Iterator[B]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]

    Permalink
    Definition Classes
    RDD
  164. def zipWithIndex(): RDD[(T, Long)]

    Permalink
    Definition Classes
    RDD
  165. def zipWithUniqueId(): RDD[(T, Long)]

    Permalink
    Definition Classes
    RDD

Inherited from LuceneRDDConfigurable

Inherited from Configurable

Inherited from RDD[T]

Inherited from Logging

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped