org.apache.spark.sql.catalyst

ScalaReflection

object ScalaReflection extends ScalaReflection

A default version of ScalaReflection that uses the runtime universe.

Linear Supertypes
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. ScalaReflection
  2. ScalaReflection
  3. AnyRef
  4. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. case class Schema(dataType: DataType, nullable: Boolean) extends Product with Serializable

    Definition Classes
    ScalaReflection

Value Members

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

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. def attributesFor[T](implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[T]): Seq[Attribute]

    Returns a Sequence of attributes for the given case class type.

    Returns a Sequence of attributes for the given case class type.

    Definition Classes
    ScalaReflection
  8. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. def constructorFor[T](implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[T]): Expression

    Returns an expression that can be used to construct an object of type T given an input row with a compatible schema.

    Returns an expression that can be used to construct an object of type T given an input row with a compatible schema. Fields of the row will be extracted using UnresolvedAttributes of the same name as the constructor arguments. Nested classes will have their fields accessed using UnresolvedExtractValue.

    When used on a primitive type, the constructor will instead default to extracting the value from ordinal 0 (since there are no names to map to). The actual location can be moved by calling resolve/bind with a new schema.

  10. def dataTypeFor[T](implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[T]): DataType

    Returns the Spark SQL DataType for a given scala type.

    Returns the Spark SQL DataType for a given scala type. Where this is not an exact mapping to a native type, an ObjectType is returned. Special handling is also used for Arrays including those that hold primitive types.

    Unlike schemaFor, this function doesn't do any massaging of types into the Spark SQL type system. As a result, ObjectType will be returned for things like boxed Integers

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

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

    Definition Classes
    AnyRef → Any
  13. def extractorsFor[T](inputObject: Expression)(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[T]): CreateNamedStruct

    Returns expressions for extracting all the fields from the given type.

    Returns expressions for extracting all the fields from the given type.

    If the given type is not supported, i.e. there is no encoder can be built for this type, an UnsupportedOperationException will be thrown with detailed error message to explain the type path walked so far and which class we are not supporting. There are 4 kinds of type path: * the root type: root class: "abc.xyz.MyClass" * the value type of Option: option value class: "abc.xyz.MyClass" * the element type of Array or Seq: array element class: "abc.xyz.MyClass" * the field of Product: field (class: "abc.xyz.MyClass", name: "myField")

  14. def finalize(): Unit

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

    Definition Classes
    AnyRef → Any
  16. def getClassFromType(tpe: scala.reflect.api.JavaUniverse.Type): Class[_]

  17. def getClassNameFromType(tpe: scala.reflect.api.JavaUniverse.Type): String

    Returns the full class name for a type.

    Returns the full class name for a type.

    Definition Classes
    ScalaReflection
  18. def getConstructorParameters(cls: Class[_]): Seq[(String, scala.reflect.api.JavaUniverse.Type)]

    Returns the parameter names and types for the primary constructor of this class.

    Returns the parameter names and types for the primary constructor of this class.

    Note that it only works for scala classes with primary constructor, and currently doesn't support inner class.

  19. def getConstructorParameters(tpe: scala.reflect.api.JavaUniverse.Type): Seq[(String, scala.reflect.api.JavaUniverse.Type)]

    Returns the parameter names and types for the primary constructor of this type.

    Returns the parameter names and types for the primary constructor of this type.

    Note that it only works for scala classes with primary constructor, and currently doesn't support inner class.

    Definition Classes
    ScalaReflection
  20. def getParameterTypes(func: AnyRef): Seq[Class[_]]

    Returns classes of input parameters of scala function object.

    Returns classes of input parameters of scala function object.

    Definition Classes
    ScalaReflection
  21. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  22. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  23. def isNativeType(dt: DataType): Boolean

    Returns true if the value of this data type is same between internal and external.

  24. def localTypeOf[T](implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[T]): scala.reflect.api.JavaUniverse.Type

    Return the Scala Type for T in the current classloader mirror.

    Return the Scala Type for T in the current classloader mirror.

    Use this method instead of the convenience method universe.typeOf, which assumes that all types can be found in the classloader that loaded scala-reflect classes. That's not necessarily the case when running using Eclipse launchers or even Sbt console or test (without fork := true).

    Definition Classes
    ScalaReflection
    See also

    SPARK-5281

  25. def mirror: scala.reflect.api.JavaUniverse.Mirror

    The mirror used to access types in the universe

    The mirror used to access types in the universe

    Definition Classes
    ScalaReflectionScalaReflection
  26. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  27. final def notify(): Unit

    Definition Classes
    AnyRef
  28. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  29. def schemaFor(tpe: scala.reflect.api.JavaUniverse.Type): Schema

    Returns a catalyst DataType and its nullability for the given Scala Type using reflection.

    Returns a catalyst DataType and its nullability for the given Scala Type using reflection.

    Definition Classes
    ScalaReflection
  30. def schemaFor[T](implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[T]): Schema

    Returns a catalyst DataType and its nullability for the given Scala Type using reflection.

    Returns a catalyst DataType and its nullability for the given Scala Type using reflection.

    Definition Classes
    ScalaReflection
  31. def silentSchemaFor(tpe: scala.reflect.api.JavaUniverse.Type): Schema

    Returns a catalyst DataType and its nullability for the given Scala Type using reflection.

    Returns a catalyst DataType and its nullability for the given Scala Type using reflection.

    Unlike schemaFor, this method won't throw exception for un-supported type, it will return NullType silently instead.

    Definition Classes
    ScalaReflection
  32. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  33. def toString(): String

    Definition Classes
    AnyRef → Any
  34. val universe: scala.reflect.runtime.universe.type

    The universe we work in (runtime or macro)

    The universe we work in (runtime or macro)

    Definition Classes
    ScalaReflectionScalaReflection
  35. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from ScalaReflection

Inherited from AnyRef

Inherited from Any

Ungrouped