Package

cognite.spark

v1

Permalink

package v1

Visibility
  1. Public
  2. All

Type Members

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

    Permalink
  2. final case class AggregationRange(id: Either[Long, String], start: Instant, end: Instant, count: Option[Long], granularity: Granularity, aggregation: String) extends Range with Product with Serializable

    Permalink
  3. class AssetHierarchyBuilder extends CdfRelation

    Permalink
  4. final case class AssetsIngestSchema(externalId: String, parentExternalId: String, source: Option[String], name: String, description: Option[String], metadata: Option[Map[String, String]], dataSetId: Option[Long]) extends Product with Serializable

    Permalink
  5. case class AssetsInsertSchema(name: String, parentId: Option[Long] = None, description: Option[String] = None, source: Option[String] = None, externalId: Option[String] = None, metadata: Option[Map[String, String]] = None, parentExternalId: Option[String] = None, dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  6. case class AssetsReadSchema(externalId: Option[String] = None, name: String, parentId: Option[Long] = None, description: Option[String] = None, metadata: Option[Map[String, String]] = None, source: Option[String] = None, id: Long = 0, createdTime: Instant = Instant.ofEpochMilli(0), lastUpdatedTime: Instant = Instant.ofEpochMilli(0), rootId: Long = 0, aggregates: Option[Map[String, Long]] = None, dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  7. class AssetsRelation extends SdkV1Relation[Asset, Long] with InsertableRelation with WritableRelation

    Permalink
  8. case class AssetsUpsertSchema(id: Option[Long] = None, name: Option[String] = None, description: Option[String] = None, source: Option[String] = None, externalId: Option[String] = None, metadata: Option[Map[String, String]] = None, parentId: Option[Long] = None, parentExternalId: Option[String] = None, dataSetId: Option[Long] = None) extends WithExternalId with WithId[Option[Long]] with Product with Serializable

    Permalink
  9. final case class Bucket(index: Int, ranges: Seq[Range]) extends Partition with Product with Serializable

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

    Permalink
  11. abstract class CdfRelation extends BaseRelation with Serializable

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

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

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

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

    Permalink
  16. final case class DataPointsRange(id: Either[Long, String], start: Instant, end: Instant, count: Option[Long]) extends Range with Product with Serializable

    Permalink
  17. abstract class DataPointsRelationV1[A] extends CdfRelation with TableScan with PrunedFilteredScan with Serializable with InsertableRelation

    Permalink
  18. class DefaultSource extends RelationProvider with CreatableRelationProvider with SchemaRelationProvider with DataSourceRegister

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

    Permalink
  20. abstract class DeleteSchema extends AnyRef

    Permalink
  21. final case class EmptyExternalIdException(message: String = ...) extends Exception with Product with Serializable

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

    Permalink
  23. case class EventsInsertSchema(startTime: Option[Instant] = None, endTime: Option[Instant] = None, description: Option[String] = None, type: Option[String] = None, subtype: Option[String] = None, metadata: Option[Map[String, String]] = None, assetIds: Option[Seq[Long]] = None, source: Option[String] = None, externalId: Option[String] = None, dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  24. case class EventsReadSchema(id: Long = 0, startTime: Option[Instant] = None, endTime: Option[Instant] = None, description: Option[String] = None, type: Option[String] = None, subtype: Option[String] = None, metadata: Option[Map[String, String]] = None, assetIds: Option[Seq[Long]] = None, source: Option[String] = None, externalId: Option[String] = None, createdTime: Instant = Instant.ofEpochMilli(0), lastUpdatedTime: Instant = Instant.ofEpochMilli(0), dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  25. class EventsRelation extends SdkV1Relation[Event, Long] with InsertableRelation with WritableRelation

    Permalink
  26. case class EventsUpsertSchema(id: Option[Long] = None, startTime: Option[Instant] = None, endTime: Option[Instant] = None, description: Option[String] = None, type: Option[String] = None, subtype: Option[String] = None, metadata: Option[Map[String, String]] = None, assetIds: Option[Seq[Long]] = None, source: Option[String] = None, externalId: Option[String] = None, dataSetId: Option[Long] = None) extends WithExternalId with WithId[Option[Long]] with Product with Serializable

    Permalink
  27. class FilesRelation extends SdkV1Relation[File, Long] with InsertableRelation

    Permalink
  28. final case class Granularity(amountOption: Option[Long], unit: ChronoUnit, isLongFormat: Boolean = false) extends Product with Serializable

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

    Permalink
  30. trait InsertSchema extends AnyRef

    Permalink
  31. final case class InvalidTreeException(message: String = ...) extends Exception with Product with Serializable

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

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

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

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

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

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

    Permalink
  38. 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
  39. final case class MultipleRootsException(message: String = "Tree has more than one root.") extends Exception with Product with Serializable

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

    Permalink
  41. final case class NoRootException(message: String = ...) extends Exception with Product with Serializable

    Permalink
  42. case class NumericDataPointsRdd(sparkContext: SparkContext, config: RelationConfig, ids: Seq[Long], externalIds: Seq[String], timestampLimits: (Instant, Instant), aggregations: Array[AggregationFilter], granularities: Seq[Granularity], toRow: (DataPointsItem) ⇒ Row) extends RDD[Row] with Product with Serializable

    Permalink
  43. class NumericDataPointsRelationV1 extends DataPointsRelationV1[DataPointsItem] with WritableRelation

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

    Permalink
  45. sealed trait PushdownExpression extends AnyRef

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

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

    Permalink
  48. sealed trait Range extends AnyRef

    Permalink
  49. class RawTableRelation extends BaseRelation with InsertableRelation with TableScan with PrunedFilteredScan with Serializable

    Permalink
  50. case class RelationConfig(auth: Auth, projectName: String, batchSize: Option[Int], limitPerPartition: Option[Int], partitions: Int, maxRetries: Int, collectMetrics: Boolean, metricsPrefix: String, baseUrl: String, onConflict: OnConflict.Value, applicationId: String, parallelismPerPartition: Int, ignoreUnknownIds: Boolean, deleteMissingAssets: Boolean, ignoreDisconnectedAssets: Boolean, legacyNameSource: LegacyNameSource.Value) extends Product with Serializable

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

    Permalink
  52. abstract class SdkV1Relation[A <: Product, I] extends CdfRelation with Serializable with TableScan with PrunedFilteredScan

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

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

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

    Permalink
  56. 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
  57. class StringDataPointsRelationV1 extends DataPointsRelationV1[StringDataPointsItem] with WritableRelation

    Permalink
  58. class ThreeDModelRevisionMappingsRelation extends SdkV1Relation[ThreeDAssetMapping, String]

    Permalink
  59. class ThreeDModelRevisionNodesRelation extends SdkV1Relation[ThreeDNode, Long]

    Permalink
  60. class ThreeDModelRevisionsRelation extends SdkV1Relation[ThreeDRevision, Long]

    Permalink
  61. class ThreeDModelsRelation extends SdkV1Relation[ThreeDModel, Long]

    Permalink
  62. case class TimeSeriesInsertSchema(externalId: Option[String] = None, name: Option[String] = None, isString: Boolean = false, metadata: Option[Map[String, String]] = None, unit: Option[String] = None, assetId: Option[Long] = None, isStep: Boolean = false, description: Option[String] = None, securityCategories: Option[Seq[Long]] = None, dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  63. case class TimeSeriesReadSchema(name: Option[String] = None, isString: Boolean = false, metadata: Option[Map[String, String]] = None, unit: Option[String] = None, assetId: Option[Long] = None, isStep: Boolean = false, description: Option[String] = None, securityCategories: Option[Seq[Long]] = None, id: Long = 0, externalId: Option[String] = None, createdTime: Instant = Instant.ofEpochMilli(0), lastUpdatedTime: Instant = Instant.ofEpochMilli(0), dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  64. class TimeSeriesRelation extends SdkV1Relation[TimeSeries, Long] with WritableRelation with InsertableRelation

    Permalink
  65. case class TimeSeriesUpsertSchema(id: Option[Long] = None, name: Option[String] = None, externalId: Option[String] = None, metadata: Option[Map[String, String]] = None, unit: Option[String] = None, assetId: Option[Long] = None, description: Option[String] = None, securityCategories: Option[Seq[Long]] = None, isStep: Option[Boolean] = None, isString: Option[Boolean] = None, dataSetId: Option[Long] = None) extends WithExternalId with WithId[Option[Long]] with Product with Serializable

    Permalink
  66. trait UpdateSchema extends AnyRef

    Permalink
  67. trait UpsertSchema extends AnyRef

    Permalink
  68. trait WritableRelation extends AnyRef

    Permalink

Value Members

  1. object AssetHierarchyBuilder extends Serializable

    Permalink
  2. object AssetsIngestSchema extends Serializable

    Permalink
  3. object AssetsRelation extends UpsertSchema with Serializable

    Permalink
  4. object CdpConnector

    Permalink
  5. object Constants

    Permalink
  6. object DataPointsRelationV1 extends Serializable

    Permalink
  7. object DefaultSource

    Permalink
  8. object EventsRelation extends UpsertSchema with Serializable

    Permalink
  9. object Granularity extends Serializable

    Permalink
  10. object LegacyNameSource extends Enumeration

    Permalink
  11. object NumericDataPointsRelation extends UpsertSchema

    Permalink
  12. object OnConflict extends Enumeration

    Permalink
  13. object PushdownUtilities

    Permalink
  14. object RawTableRelation extends Serializable

    Permalink
  15. object StringDataPointsRelation extends UpsertSchema

    Permalink
  16. object TimeSeriesRelation extends UpsertSchema with Serializable

    Permalink

Ungrouped