A RetroSearch Logo

Home - News ( United States | United Kingdom | Italy | Germany ) - Football scores

Search Query:

Showing content from https://spark.apache.org/docs/latest/api/scala/org/apache/spark/rdd/JdbcRDD.html below:

Spark 4.0.0 ScalaDoc - org.apache.spark.rdd.JdbcRDD

class JdbcRDD[T] extends RDD[T] with Logging



Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. JdbcRDD
  2. RDD
  3. Logging
  4. Serializable
  5. AnyRef
  6. Any
Visibility
  1. Public
  2. Protected
Type Members
  1.  implicit class LogStringContext extends AnyRef
Value Members
  1.  final def !=(arg0: Any): Boolean
  2.  final def ##: Int
  3.  def ++(other: RDD[T]): RDD[T]
  4.  final def ==(arg0: Any): Boolean
  5.  def aggregate[U](zeroValue: U)(seqOp: (U, T) => U, combOp: (U, U) => U)(implicit arg0: ClassTag[U]): U
  6.  final def asInstanceOf[T0]: T0
  7.  def barrier(): RDDBarrier[T]
  8.  def cache(): JdbcRDD.this.type
  9.  def cartesian[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[(T, U)]
  10.  def checkpoint(): Unit
  11.  def cleanShuffleDependencies(blocking: Boolean = false): Unit
  12.  def clearDependencies(): Unit
  13.  def clone(): AnyRef
  14.  def coalesce(numPartitions: Int, shuffle: Boolean = false, partitionCoalescer: Option[PartitionCoalescer] = Option.empty)(implicit ord: Ordering[T] = null): RDD[T]
  15.  def collect[U](f: PartialFunction[T, U])(implicit arg0: ClassTag[U]): RDD[U]
  16.  def collect(): Array[T]
  17.  def compute(thePart: Partition, context: TaskContext): Iterator[T]
  18.  def context: SparkContext
  19.  def count(): Long
  20.  def countApprox(timeout: Long, confidence: Double = 0.95): PartialResult[BoundedDouble]
  21.  def countApproxDistinct(relativeSD: Double = 0.05): Long
  22.  def countApproxDistinct(p: Int, sp: Int): Long
  23.  def countByValue()(implicit ord: Ordering[T] = null): Map[T, Long]
  24.  def countByValueApprox(timeout: Long, confidence: Double = 0.95)(implicit ord: Ordering[T] = null): PartialResult[Map[T, BoundedDouble]]
  25.  final def dependencies: Seq[Dependency[_]]
  26.  def distinct(): RDD[T]
  27.  def distinct(numPartitions: Int)(implicit ord: Ordering[T] = null): RDD[T]
  28.  final def eq(arg0: AnyRef): Boolean
  29.  def equals(arg0: AnyRef): Boolean
  30.  def filter(f: (T) => Boolean): RDD[T]
  31.  def first(): T
  32.  def firstParent[U](implicit arg0: ClassTag[U]): RDD[U]
  33.  def flatMap[U](f: (T) => IterableOnce[U])(implicit arg0: ClassTag[U]): RDD[U]
  34.  def fold(zeroValue: T)(op: (T, T) => T): T
  35.  def foreach(f: (T) => Unit): Unit
  36.  def foreachPartition(f: (Iterator[T]) => Unit): Unit
  37.  def getCheckpointFile: Option[String]
  38.  final def getClass(): Class[_ <: AnyRef]
  39.  def getDependencies: Seq[Dependency[_]]
  40.  final def getNumPartitions: Int
  41.  def getOutputDeterministicLevel: DeterministicLevel.Value
  42.  def getPartitions: Array[Partition]
  43.  def getPreferredLocations(split: Partition): Seq[String]
  44.  def getResourceProfile(): ResourceProfile
  45.  def getStorageLevel: StorageLevel
  46.  def glom(): RDD[Array[T]]
  47.  def groupBy[K](f: (T) => K, p: Partitioner)(implicit kt: ClassTag[K], ord: Ordering[K] = null): RDD[(K, Iterable[T])]
  48.  def groupBy[K](f: (T) => K, numPartitions: Int)(implicit kt: ClassTag[K]): RDD[(K, Iterable[T])]
  49.  def groupBy[K](f: (T) => K)(implicit kt: ClassTag[K]): RDD[(K, Iterable[T])]
  50.  def hashCode(): Int
  51.  val id: Int
  52.  def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
  53.  def initializeLogIfNecessary(isInterpreter: Boolean): Unit
  54.  def intersection(other: RDD[T], numPartitions: Int): RDD[T]
  55.  def intersection(other: RDD[T], partitioner: Partitioner)(implicit ord: Ordering[T] = null): RDD[T]
  56.  def intersection(other: RDD[T]): RDD[T]
  57.  lazy val isBarrier_: Boolean
  58.  def isCheckpointed: Boolean
  59.  def isEmpty(): Boolean
  60.  final def isInstanceOf[T0]: Boolean
  61.  def isTraceEnabled(): Boolean
  62.  final def iterator(split: Partition, context: TaskContext): Iterator[T]
  63.  def keyBy[K](f: (T) => K): RDD[(K, T)]
  64.  def localCheckpoint(): JdbcRDD.this.type
  65.  def log: Logger
  66.  def logDebug(msg: => String, throwable: Throwable): Unit
  67.  def logDebug(entry: LogEntry, throwable: Throwable): Unit
  68.  def logDebug(entry: LogEntry): Unit
  69.  def logDebug(msg: => String): Unit
  70.  def logError(msg: => String, throwable: Throwable): Unit
  71.  def logError(entry: LogEntry, throwable: Throwable): Unit
  72.  def logError(entry: LogEntry): Unit
  73.  def logError(msg: => String): Unit
  74.  def logInfo(msg: => String, throwable: Throwable): Unit
  75.  def logInfo(entry: LogEntry, throwable: Throwable): Unit
  76.  def logInfo(entry: LogEntry): Unit
  77.  def logInfo(msg: => String): Unit
  78.  def logName: String
  79.  def logTrace(msg: => String, throwable: Throwable): Unit
  80.  def logTrace(entry: LogEntry, throwable: Throwable): Unit
  81.  def logTrace(entry: LogEntry): Unit
  82.  def logTrace(msg: => String): Unit
  83.  def logWarning(msg: => String, throwable: Throwable): Unit
  84.  def logWarning(entry: LogEntry, throwable: Throwable): Unit
  85.  def logWarning(entry: LogEntry): Unit
  86.  def logWarning(msg: => String): Unit
  87.  def map[U](f: (T) => U)(implicit arg0: ClassTag[U]): RDD[U]
  88.  def mapPartitions[U](f: (Iterator[T]) => Iterator[U], preservesPartitioning: Boolean = false)(implicit arg0: ClassTag[U]): RDD[U]
  89.  def mapPartitionsWithEvaluator[U](evaluatorFactory: PartitionEvaluatorFactory[T, U])(implicit arg0: ClassTag[U]): RDD[U]
  90.  def mapPartitionsWithIndex[U](f: (Int, Iterator[T]) => Iterator[U], preservesPartitioning: Boolean = false)(implicit arg0: ClassTag[U]): RDD[U]
  91.  def max()(implicit ord: Ordering[T]): T
  92.  def min()(implicit ord: Ordering[T]): T
  93.  var name: String
  94.  final def ne(arg0: AnyRef): Boolean
  95.  final def notify(): Unit
  96.  final def notifyAll(): Unit
  97.  def parent[U](j: Int)(implicit arg0: ClassTag[U]): RDD[U]
  98.  val partitioner: Option[Partitioner]
  99.  final def partitions: Array[Partition]
  100.  def persist(): JdbcRDD.this.type
  101.  def persist(newLevel: StorageLevel): JdbcRDD.this.type
  102.  def pipe(command: Seq[String], env: Map[String, String] = Map(), printPipeContext: ((String) => Unit) => Unit = null, printRDDElement: (T, (String) => Unit) => Unit = null, separateWorkingDir: Boolean = false, bufferSize: Int = 8192, encoding: String = Codec.defaultCharsetCodec.name): RDD[String]
  103.  def pipe(command: String, env: Map[String, String]): RDD[String]
  104.  def pipe(command: String): RDD[String]
  105.  final def preferredLocations(split: Partition): Seq[String]
  106.  def randomSplit(weights: Array[Double], seed: Long = Utils.random.nextLong): Array[RDD[T]]
  107.  def reduce(f: (T, T) => T): T
  108.  def repartition(numPartitions: Int)(implicit ord: Ordering[T] = null): RDD[T]
  109.  def sample(withReplacement: Boolean, fraction: Double, seed: Long = Utils.random.nextLong): RDD[T]
  110.  def saveAsObjectFile(path: String): Unit
  111.  def saveAsTextFile(path: String, codec: Class[_ <: CompressionCodec]): Unit
  112.  def saveAsTextFile(path: String): Unit
  113.  def setName(_name: String): JdbcRDD.this.type
  114.  def sortBy[K](f: (T) => K, ascending: Boolean = true, numPartitions: Int = this.partitions.length)(implicit ord: Ordering[K], ctag: ClassTag[K]): RDD[T]
  115.  def sparkContext: SparkContext
  116.  def subtract(other: RDD[T], p: Partitioner)(implicit ord: Ordering[T] = null): RDD[T]
  117.  def subtract(other: RDD[T], numPartitions: Int): RDD[T]
  118.  def subtract(other: RDD[T]): RDD[T]
  119.  final def synchronized[T0](arg0: => T0): T0
  120.  def take(num: Int): Array[T]
  121.  def takeOrdered(num: Int)(implicit ord: Ordering[T]): Array[T]
  122.  def takeSample(withReplacement: Boolean, num: Int, seed: Long = Utils.random.nextLong): Array[T]
  123.  def toDebugString: String
  124.  def toJavaRDD(): JavaRDD[T]
  125.  def toLocalIterator: Iterator[T]
  126.  def toString(): String
  127.  def top(num: Int)(implicit ord: Ordering[T]): Array[T]
  128.  def treeAggregate[U](zeroValue: U, seqOp: (U, T) => U, combOp: (U, U) => U, depth: Int, finalAggregateOnExecutor: Boolean)(implicit arg0: ClassTag[U]): U
  129.  def treeAggregate[U](zeroValue: U)(seqOp: (U, T) => U, combOp: (U, U) => U, depth: Int = 2)(implicit arg0: ClassTag[U]): U
  130.  def treeReduce(f: (T, T) => T, depth: Int = 2): T
  131.  def union(other: RDD[T]): RDD[T]
  132.  def unpersist(blocking: Boolean = false): JdbcRDD.this.type
  133.  final def wait(arg0: Long, arg1: Int): Unit
  134.  final def wait(arg0: Long): Unit
  135.  final def wait(): Unit
  136.  def withLogContext(context: Map[String, String])(body: => Unit): Unit
  137.  def withResources(rp: ResourceProfile): JdbcRDD.this.type
  138.  def zip[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[(T, U)]
  139.  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]
  140.  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]
  141.  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]
  142.  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]
  143.  def zipPartitions[B, V](rdd2: RDD[B])(f: (Iterator[T], Iterator[B]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]
  144.  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]
  145.  def zipPartitionsWithEvaluator[U](rdd2: RDD[T], evaluatorFactory: PartitionEvaluatorFactory[T, U])(implicit arg0: ClassTag[U]): RDD[U]
  146.  def zipWithIndex(): RDD[(T, Long)]
  147.  def zipWithUniqueId(): RDD[(T, Long)]
Deprecated Value Members
  1.  def finalize(): Unit

Inherited from Logging

Inherited from AnyRef

Inherited from Any


RetroSearch is an open source project built by @garambo | Open a GitHub Issue

Search and Browse the WWW like it's 1997 | Search results from DuckDuckGo

HTML: 3.2 | Encoding: UTF-8 | Version: 0.7.4