Packages

c

org.apache.spark.sql.execution.datasources.xskipper

InMemoryDataSkippingIndex

class InMemoryDataSkippingIndex extends InMemoryFileIndex

Linear Supertypes
InMemoryFileIndex, PartitioningAwareFileIndex, Logging, FileIndex, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. InMemoryDataSkippingIndex
  2. InMemoryFileIndex
  3. PartitioningAwareFileIndex
  4. Logging
  5. FileIndex
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new InMemoryDataSkippingIndex(sparkSession: SparkSession, rootPathsSpecified: Seq[Path], parameters: Map[String, String], userSpecifiedSchema: Option[StructType], fileStatusCache: FileStatusCache = NoopCache, userSpecifiedPartitionSpec: Option[PartitionSpec] = None, metadataOpsTimeNs: Option[Long] = None, tableIdentifiers: Seq[String], fileFilters: Seq[DataSkippingFileFilter], metadataFilterFactories: Seq[MetadataFilterFactory], clauseTranslators: Seq[ClauseTranslator], backend: MetadataStoreManagerType)

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def allFiles(): Seq[FileStatus]
    Definition Classes
    PartitioningAwareFileIndex
  5. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  6. def clone(): AnyRef
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @native() @throws( ... )
  7. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  8. def equals(other: Any): Boolean
    Definition Classes
    InMemoryFileIndex → AnyRef → Any
  9. def finalize(): Unit
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  10. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  11. val hadoopConf: Configuration
    Attributes
    protected
    Definition Classes
    PartitioningAwareFileIndex
  12. def hashCode(): Int
    Definition Classes
    InMemoryFileIndex → AnyRef → Any
  13. def inferPartitioning(): PartitionSpec
    Attributes
    protected
    Definition Classes
    PartitioningAwareFileIndex
  14. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
    Attributes
    protected
    Definition Classes
    Logging
  15. def initializeLogIfNecessary(isInterpreter: Boolean): Unit
    Attributes
    protected
    Definition Classes
    Logging
  16. def inputFiles: Array[String]
    Definition Classes
    PartitioningAwareFileIndex → FileIndex
  17. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  18. def isTraceEnabled(): Boolean
    Attributes
    protected
    Definition Classes
    Logging
  19. def leafDirToChildrenFiles: Map[Path, Array[FileStatus]]
    Attributes
    protected
    Definition Classes
    InMemoryFileIndex → PartitioningAwareFileIndex
  20. def leafFiles: LinkedHashMap[Path, FileStatus]
    Attributes
    protected
    Definition Classes
    InMemoryFileIndex → PartitioningAwareFileIndex
  21. def listFiles(partitionFilters: Seq[Expression], dataFilters: Seq[Expression]): Seq[PartitionDirectory]
    Definition Classes
    InMemoryDataSkippingIndex → PartitioningAwareFileIndex → FileIndex
  22. def listLeafFiles(paths: Seq[Path]): LinkedHashSet[FileStatus]
    Definition Classes
    InMemoryFileIndex
  23. def log: Logger
    Attributes
    protected
    Definition Classes
    Logging
  24. def logDebug(msg: ⇒ String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  25. def logDebug(msg: ⇒ String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  26. def logError(msg: ⇒ String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  27. def logError(msg: ⇒ String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  28. def logInfo(msg: ⇒ String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  29. def logInfo(msg: ⇒ String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  30. def logName: String
    Attributes
    protected
    Definition Classes
    Logging
  31. def logTrace(msg: ⇒ String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  32. def logTrace(msg: ⇒ String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  33. def logWarning(msg: ⇒ String, throwable: Throwable): Unit
    Attributes
    protected
    Definition Classes
    Logging
  34. def logWarning(msg: ⇒ String): Unit
    Attributes
    protected
    Definition Classes
    Logging
  35. def matchGlobPattern(file: FileStatus): Boolean
    Attributes
    protected
    Definition Classes
    PartitioningAwareFileIndex
  36. val metadataOpsTimeNs: Option[Long]
    Definition Classes
    InMemoryFileIndex → FileIndex
  37. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  38. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  39. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  40. def partitionSchema: StructType
    Definition Classes
    PartitioningAwareFileIndex → FileIndex
  41. def partitionSpec(): PartitionSpec
    Definition Classes
    InMemoryFileIndex → PartitioningAwareFileIndex
  42. lazy val pathGlobFilter: Option[GlobFilter]
    Attributes
    protected
    Definition Classes
    PartitioningAwareFileIndex
  43. lazy val recursiveFileLookup: Boolean
    Attributes
    protected
    Definition Classes
    PartitioningAwareFileIndex
  44. def refresh(): Unit
    Definition Classes
    InMemoryFileIndex → FileIndex
  45. val rootPaths: Seq[Path]
    Definition Classes
    InMemoryFileIndex → FileIndex
  46. def sizeInBytes: Long
    Definition Classes
    PartitioningAwareFileIndex → FileIndex
  47. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  48. def toString(): String
    Definition Classes
    AnyRef → Any
  49. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  50. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  51. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @throws( ... )

Inherited from InMemoryFileIndex

Inherited from PartitioningAwareFileIndex

Inherited from Logging

Inherited from FileIndex

Inherited from AnyRef

Inherited from Any

Ungrouped