Package

cognite

spark

Permalink

package spark

Visibility
  1. Public
  2. All

Type Members

  1. case class AggregationFilter(aggregation: String) extends Product with Serializable

    Permalink
  2. class AssetsRelation extends SdkV1Relation[Asset] with InsertableRelation

    Permalink
  3. case class CdfPartition(index: Int) extends Partition with Product with Serializable

    Permalink
  4. case class CdpApiErrorPayload(code: Int, message: String) extends Product with Serializable

    Permalink
  5. trait CdpConnector extends AnyRef

    Permalink
  6. case class CdpRdd[A](sparkContext: SparkContext, toRow: (A) ⇒ Row, getSinglePartitionBaseUri: Uri, config: RelationConfig, urlsWithFilters: Seq[Uri], cursors: Iterator[(Option[String], Option[Int])])(implicit evidence$1: Decoder[A]) extends RDD[Row] with CdpConnector with Product with Serializable

    Permalink
  7. case class CdpRddPartition(cursor: Option[String], size: Option[Int], index: Int, urlsWithFilters: Seq[Uri]) extends Partition with Product with Serializable

    Permalink
  8. abstract class CdpRelation[T <: Product] extends BaseRelation with TableScan with Serializable with PrunedFilteredScan with CdpConnector

    Permalink
  9. case class Chunk[A, B](chunk: Seq[A], cursor: Option[B]) extends Product with Serializable

    Permalink
  10. case class Data[A](data: A) extends Product with Serializable

    Permalink
  11. case class DataPointsFilter(id: Option[Long], externalId: Option[String], aggregates: Option[Seq[String]], granularity: Option[String]) extends Product with Serializable

    Permalink
  12. case class DataPointsItem(id: Option[Long], externalId: Option[String], timestamp: Timestamp, value: Double, aggregation: Option[String], granularity: Option[String]) extends Product with Serializable

    Permalink
  13. abstract class DataPointsRelationV1[A] extends BaseRelation with TableScan with PrunedFilteredScan with Serializable with InsertableRelation

    Permalink
  14. class DefaultSource extends RelationProvider with CreatableRelationProvider with SchemaRelationProvider with DataSourceRegister with CdpConnector

    Permalink
  15. case class DeleteItem(id: Long) extends Product with Serializable

    Permalink
  16. abstract class DeleteSchema extends AnyRef

    Permalink
  17. case class Error[A](error: A) extends Product with Serializable

    Permalink
  18. class EventsRelation extends SdkV1Relation[Event] with InsertableRelation

    Permalink
  19. class FilesRelation extends SdkV1Relation[File] with InsertableRelation

    Permalink
  20. case class InsertDataPointsItem(id: Option[Long], externalId: Option[String], timestamp: Instant, value: Double) extends Product with Serializable

    Permalink
  21. trait InsertSchema extends AnyRef

    Permalink
  22. case class Items[A](items: Seq[A]) extends Product with Serializable

    Permalink
  23. case class ItemsWithCursor[A](items: Seq[A], nextCursor: Option[String] = None) extends Product with Serializable

    Permalink
  24. abstract class Limit extends Ordered[Limit] with Serializable

    Permalink
  25. abstract class LimitLong extends Ordered[LimitLong] with Serializable

    Permalink
  26. case class Login(user: String, loggedIn: Boolean, project: String, projectId: Long) extends Product with Serializable

    Permalink
  27. sealed case class Max(value: Instant) extends Limit with Product with Serializable

    Permalink
  28. sealed case class MaxLong(value: Long) extends LimitLong with Product with Serializable

    Permalink
  29. sealed case class Min(value: Instant) extends Limit with Product with Serializable

    Permalink
  30. sealed case class MinLong(value: Long) extends LimitLong with Product with Serializable

    Permalink
  31. case class ModelItem(id: Long, name: String, createdTime: Long) extends Product with Serializable

    Permalink
  32. case class ModelRevisionItem(id: Long, fileId: Long, published: Boolean, rotation: Option[Seq[Double]], camera: Map[String, Seq[Double]], status: String, thumbnailThreedFileId: Option[Long], thumbnailUrl: Option[String], sceneThreedFiles: Option[Seq[Map[String, Long]]], sceneThreedFileId: Option[Long], assetMappingCount: Long, createdTime: Long) extends Product with Serializable

    Permalink
  33. case class ModelRevisionMappingItem(nodeId: Long, assetId: Long, treeIndex: Option[Long], subtreeSize: Option[Long]) extends Product with Serializable

    Permalink
  34. case class NextCursorIterator[A](url: Uri, config: RelationConfig, hasDataWrapper: Boolean)(implicit evidence$1: Decoder[A]) extends Iterator[(Option[String], Option[Int])] with CdpConnector with Product with Serializable

    Permalink
  35. final case class NoPushdown() extends PushdownExpression with Product with Serializable

    Permalink
  36. case class NonNullableSetter[A](set: A) extends Product with Serializable

    Permalink
  37. case class NumericDataPointsRdd(sparkContext: SparkContext, config: RelationConfig, getIOs: (GenericClient[IO, Nothing]) ⇒ Seq[(DataPointsFilter, IO[Map[String, Seq[DataPoint]]])], toRow: (DataPointsItem) ⇒ Row) extends RDD[Row] with Product with Serializable

    Permalink
  38. class NumericDataPointsRelationV1 extends DataPointsRelationV1[DataPointsItem]

    Permalink
  39. final case class PushdownAnd(left: PushdownExpression, right: PushdownExpression) extends PushdownExpression with Product with Serializable

    Permalink
  40. sealed trait PushdownExpression extends AnyRef

    Permalink
  41. final case class PushdownFilter(fieldName: String, value: String) extends PushdownExpression with Product with Serializable

    Permalink
  42. final case class PushdownFilters(filters: Seq[PushdownExpression]) extends PushdownExpression with Product with Serializable

    Permalink
  43. case class RawItem(key: String, lastUpdatedTime: Long, columns: JsonObject) extends Product with Serializable

    Permalink
  44. case class RawItemForPost(key: String, columns: JsonObject) extends Product with Serializable

    Permalink
  45. class RawTableRelation extends BaseRelation with InsertableRelation with TableScan with PrunedFilteredScan with CdpConnector with Serializable

    Permalink
  46. case class RelationConfig(auth: Auth, project: String, batchSize: Option[Int], limit: Option[Int], partitions: Int, maxRetries: Int, collectMetrics: Boolean, metricsPrefix: String, baseUrl: String, onConflict: OnConflict.Value, applicationId: String) extends Product with Serializable

    Permalink
  47. case class SdkV1Rdd[A](sparkContext: SparkContext, config: RelationConfig, toRow: (A) ⇒ Row, numPartitions: Int, getStreams: (GenericClient[IO, Nothing], Option[Int], Int) ⇒ Seq[Stream[IO, A]]) extends RDD[Row] with Product with Serializable

    Permalink
  48. abstract class SdkV1Relation[A <: Product] extends BaseRelation with CdpConnector with Serializable with TableScan with PrunedFilteredScan

    Permalink
  49. case class Setter[A](set: A, setNull: Boolean) extends Product with Serializable

    Permalink
  50. case class StringDataPointsFilter(id: Option[Long], externalId: Option[String]) extends Product with Serializable

    Permalink
  51. case class StringDataPointsItem(id: Option[Long], externalId: Option[String], timestamp: Timestamp, value: String) extends Product with Serializable

    Permalink
  52. case class StringDataPointsRdd(sparkContext: SparkContext, config: RelationConfig, getIOs: (GenericClient[IO, Nothing]) ⇒ Seq[(StringDataPointsFilter, IO[Seq[StringDataPoint]])], toRow: (StringDataPointsItem) ⇒ Row) extends RDD[Row] with Product with Serializable

    Permalink
  53. class StringDataPointsRelationV1 extends DataPointsRelationV1[StringDataPointsItem]

    Permalink
  54. class ThreeDModelRevisionMappingsRelation extends SdkV1Relation[ThreeDAssetMapping]

    Permalink
  55. class ThreeDModelRevisionNodesRelation extends SdkV1Relation[ThreeDNode]

    Permalink
  56. class ThreeDModelRevisionsRelation extends SdkV1Relation[ThreeDRevision]

    Permalink
  57. class ThreeDModelsRelation extends SdkV1Relation[ThreeDModel]

    Permalink
  58. class TimeSeriesRelation extends SdkV1Relation[TimeSeries] with InsertableRelation

    Permalink
  59. trait UpdateSchema extends AnyRef

    Permalink
  60. trait UpsertSchema extends AnyRef

    Permalink

Value Members

  1. object Batch

    Permalink
  2. object CdpConnector

    Permalink
  3. object Constants

    Permalink
  4. object OnConflict extends Enumeration

    Permalink
  5. object PushdownUtilities

    Permalink
  6. object RawTableRelation extends Serializable

    Permalink
  7. object Setter extends Serializable

    Permalink
  8. object TimeSeriesRelation extends DeleteSchema with UpsertSchema with InsertSchema with Serializable

    Permalink

Ungrouped