org.apache.spark

sql

package sql

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

Type Members

  1. type ArrayType = sql.catalyst.types.ArrayType

    Annotations
    @DeveloperApi()
  2. trait CassandraAwarePlanner extends AnyRef

    Attributes
    protected
  3. class CassandraAwareSQLContext extends SQLContext with CassandraAwareSQLContextFunctions

  4. trait CassandraCatalog extends Catalog with Logging

    Attributes
    protected
  5. case class CassandraRelation(host: String, nativePort: String, rpcPort: String, keyspace: String, table: String, sqlContext: SQLContext, cassandraUsername: Option[String] = scala.None, cassandraPassword: Option[String] = scala.None, mayUseStartgate: Boolean = false, conf: Option[Configuration] = scala.None) extends LeafNode with MultiInstanceRelation with Product with Serializable

  6. class CassandraSchemaRDD extends SchemaRDD

  7. case class CassandraTableScan(output: Seq[Attribute], relation: CassandraRelation, filters: Seq[Expression]) extends SparkPlan with LeafNode with Logging with Product with Serializable

  8. type DataType = sql.catalyst.types.DataType

    Annotations
    @DeveloperApi()
  9. type MapType = sql.catalyst.types.MapType

    Annotations
    @DeveloperApi()
  10. case class PushdownFilters(filtersToPushdown: Seq[Expression], filtersToRetain: Seq[Expression]) extends Product with Serializable

  11. type Row = sql.catalyst.expressions.Row

    Annotations
    @DeveloperApi()
  12. case class SaveToCassandra(host: String, nativePort: String, rpcPort: String, keyspace: String, table: String, username: Option[String], password: Option[String], child: LogicalPlan) extends UnaryNode with Product with Serializable

  13. case class SerCassandraDataType(dataType: Name, param1: Option[Name], param2: Option[Name]) extends Product with Serializable

  14. type StructField = sql.catalyst.types.StructField

    Annotations
    @DeveloperApi()
  15. type StructType = sql.catalyst.types.StructType

    Annotations
    @DeveloperApi()
  16. case class WriteToCassandra(relation: CassandraRelation, child: SparkPlan) extends SparkPlan with UnaryNode with SparkHadoopMapReduceUtil with Product with Serializable

Value Members

  1. val ArrayType: sql.catalyst.types.ArrayType.type

  2. val BinaryType: sql.catalyst.types.BinaryType.type

  3. val BooleanType: sql.catalyst.types.BooleanType.type

  4. val ByteType: sql.catalyst.types.ByteType.type

  5. object CassandraPushdownHandler extends PushdownHandler

  6. object CassandraSparkDataConvertor

  7. val DecimalType: sql.catalyst.types.DecimalType.type

  8. val DoubleType: sql.catalyst.types.DoubleType.type

  9. val FloatType: sql.catalyst.types.FloatType.type

  10. val IntegerType: sql.catalyst.types.IntegerType.type

  11. val LongType: sql.catalyst.types.LongType.type

  12. val MapType: sql.catalyst.types.MapType.type

  13. val Row: sql.catalyst.expressions.Row.type

  14. object SerCassandraDataType extends Serializable

  15. val ShortType: sql.catalyst.types.ShortType.type

  16. object StargatePushdownHandler extends PushdownHandler with Logging

  17. val StringType: sql.catalyst.types.StringType.type

  18. val StructField: sql.catalyst.types.StructField.type

  19. val StructType: sql.catalyst.types.StructType.type

  20. val TimestampType: sql.catalyst.types.TimestampType.type

Inherited from AnyRef

Inherited from Any

Ungrouped