Package

cognite.spark

v1

Permalink

package v1

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. v1
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
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 AssetSubtree(root: AssetsIngestSchema, nodes: Vector[AssetsIngestSchema]) extends Product with Serializable

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

    Permalink
  6. final 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, labels: Option[Seq[String]] = None) extends Product with Serializable

    Permalink
  7. final case class AssetsReadSchema(externalId: Option[String] = None, name: String, parentId: Option[Long] = None, parentExternalId: Option[String] = 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: Option[Long] = Some(0), aggregates: Option[Map[String, Long]] = None, dataSetId: Option[Long] = None, labels: Option[Seq[String]] = None) extends Product with Serializable

    Permalink
  8. class AssetsRelation extends SdkV1Relation[AssetsReadSchema, Long] with InsertableRelation with WritableRelation

    Permalink
  9. final case class AssetsUpsertSchema(id: Option[Long] = None, name: Option[String] = None, description: OptionalField[String] = FieldNotSpecified, source: OptionalField[String] = FieldNotSpecified, externalId: OptionalField[String] = FieldNotSpecified, metadata: Option[Map[String, String]] = None, parentId: Option[Long] = None, parentExternalId: Option[String] = None, dataSetId: OptionalField[Long] = FieldNotSpecified, labels: Option[Seq[String]] = None) extends WithNullableExtenalId with WithId[Option[Long]] with Product with Serializable

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

    Permalink
  11. final case class CdfDoesNotSupportException(message: String) extends CdfSparkException with Product with Serializable

    Permalink
  12. class CdfInternalSparkException extends CdfSparkException

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

    Permalink
  14. abstract class CdfRelation extends BaseRelation with Serializable

    Permalink
  15. sealed trait CdfSparkAuth extends Serializable

    Permalink
  16. class CdfSparkException extends Exception

    Permalink
  17. class CdfSparkIllegalArgumentException extends CdfSparkException

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

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

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

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

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

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

    Permalink
  24. class DefaultSource extends RelationProvider with CreatableRelationProvider with SchemaRelationProvider with DataSourceRegister with Serializable

    Permalink
  25. final case class DeleteDataPointsItem(id: Option[Long], externalId: Option[String], exclusiveBegin: Option[Instant], inclusiveBegin: Option[Instant], exclusiveEnd: Option[Instant], inclusiveEnd: Option[Instant]) extends Product with Serializable

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

    Permalink
  27. abstract class DeleteSchema extends AnyRef

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

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

    Permalink
  30. final 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
  31. final 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
  32. class EventsRelation extends SdkV1Relation[Event, Long] with InsertableRelation with WritableRelation

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

    Permalink
  34. final case class FilesInsertSchema(name: String, source: Option[String] = None, externalId: Option[String] = None, mimeType: Option[String] = None, metadata: Option[Map[String, String]] = None, assetIds: Option[Seq[Long]] = None, dataSetId: Option[Long] = None, sourceCreatedTime: Option[Instant] = None, sourceModifiedTime: Option[Instant] = None, securityCategories: Option[Seq[Long]] = None) extends Product with Serializable

    Permalink
  35. final case class FilesReadSchema(id: Long = 0, name: String, source: Option[String] = None, externalId: Option[String] = None, mimeType: Option[String] = None, metadata: Option[Map[String, String]] = None, assetIds: Option[Seq[Long]] = None, uploaded: Boolean = false, uploadedTime: Option[Instant] = None, createdTime: Instant = Instant.ofEpochMilli(0), lastUpdatedTime: Instant = Instant.ofEpochMilli(0), sourceCreatedTime: Option[Instant] = None, sourceModifiedTime: Option[Instant] = None, securityCategories: Option[Seq[Long]] = None, uploadUrl: Option[String] = None, dataSetId: Option[Long] = None) extends Product with Serializable

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

    Permalink
  37. final case class FilesUpsertSchema(id: Option[Long] = None, name: Option[String] = None, externalId: OptionalField[String] = FieldNotSpecified, source: OptionalField[String] = FieldNotSpecified, metadata: Option[Map[String, String]] = None, assetIds: Option[Seq[Long]] = None, dataSetId: OptionalField[Long] = FieldNotSpecified, mimeType: OptionalField[String] = FieldNotSpecified, sourceCreatedTime: OptionalField[Instant] = FieldNotSpecified, sourceModifiedTime: OptionalField[Instant] = FieldNotSpecified, securityCategories: Option[Seq[Long]] = None) extends WithNullableExtenalId with WithId[Option[Long]] with Product with Serializable

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

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

    Permalink
  40. trait InsertSchema extends AnyRef

    Permalink
  41. final case class InvalidNodeReferenceException(nodeIds: Seq[String], referencedFrom: Seq[String]) extends CdfSparkException with Product with Serializable

    Permalink
  42. final case class InvalidRootChangeException(assetIds: Seq[String], subtreeId: String, rootId: Long) extends CdfSparkException with Product with Serializable

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

    Permalink
  44. final case class LabelDeleteSchema(externalId: String) extends Product with Serializable

    Permalink
  45. final case class LabelInsertSchema(externalId: String, name: String, description: Option[String]) extends Product with Serializable

    Permalink
  46. final case class LabelReadSchema(externalId: Option[String], name: Option[String], description: Option[String], createdTime: Option[Instant]) extends Product with Serializable

    Permalink
  47. class LabelsRelation extends SdkV1Relation[Label, String] with InsertableRelation with WritableRelation

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

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

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

    Permalink
  51. class MetricsBackend[F[_], +S] extends SttpBackend[F, S]

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

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

    Permalink
  54. final 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
  55. final case class NoPushdown() extends PushdownExpression with Product with Serializable

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

    Permalink
  57. final case class NonUniqueAssetId(id: String) extends CdfSparkException with Product with Serializable

    Permalink
  58. final case class NumericDataPointsRdd(sparkContext: SparkContext, config: RelationConfig, ids: Seq[Long], externalIds: Seq[String], timestampLimits: (Instant, Instant), aggregations: Array[AggregationFilter], granularities: Seq[Granularity], increaseReadMetrics: (Int) ⇒ Unit, rowIndices: Array[Int]) extends RDD[Row] with Product with Serializable

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

    Permalink
  60. final case class ProjectedSequenceRow(rowNumber: Long, values: Array[Any]) extends Product with Serializable

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

    Permalink
  62. sealed trait PushdownExpression extends AnyRef

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

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

    Permalink
  65. sealed trait Range extends AnyRef

    Permalink
  66. class RateLimitingBackend[F[_], +P] extends SttpBackend[F, P]

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

    Permalink
  68. final case class RelationConfig(auth: CdfSparkAuth, clientTag: Option[String], applicationName: Option[String], projectName: String, batchSize: Option[Int], limitPerPartition: Option[Int], partitions: Int, maxRetries: Int, maxRetryDelaySeconds: Int, collectMetrics: Boolean, collectTestMetrics: Boolean, metricsPrefix: String, baseUrl: String, onConflict: OnConflict.Value, applicationId: String, parallelismPerPartition: Int, ignoreUnknownIds: Boolean, deleteMissingAssets: Boolean, subtrees: AssetSubtreeOption, ignoreNullFields: Boolean, rawEnsureParent: Boolean) extends Product with Serializable

    Permalink
  69. final case class RelationshipsDeleteSchema(externalId: String) extends Product with Serializable

    Permalink
  70. final case class RelationshipsInsertSchema(externalId: String, sourceExternalId: String, sourceType: String, targetExternalId: String, targetType: String, startTime: Option[Instant] = None, endTime: Option[Instant] = None, confidence: Option[Double] = None, labels: Option[Seq[String]] = None, dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  71. final case class RelationshipsReadSchema(externalId: String, sourceExternalId: String, sourceType: String, targetExternalId: String, targetType: String, startTime: Option[Instant] = None, endTime: Option[Instant] = None, confidence: Option[Double] = None, labels: Option[Seq[String]] = None, createdTime: Instant = Instant.ofEpochMilli(0), lastUpdatedTime: Instant = Instant.ofEpochMilli(0), dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  72. class RelationshipsRelation extends SdkV1Relation[RelationshipsReadSchema, String] with InsertableRelation with WritableRelation

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

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

    Permalink
  75. final case class SequenceInsertSchema(externalId: Option[String] = None, name: Option[String] = None, description: Option[String] = None, assetId: Option[Long] = None, metadata: Option[Map[String, String]] = None, columns: Seq[SequenceColumnCreate], dataSetId: Option[Long] = None) extends Product with Serializable

    Permalink
  76. final case class SequenceReadSchema(id: Long = 0, name: Option[String] = None, description: Option[String] = None, assetId: Option[Long] = None, externalId: Option[String] = None, metadata: Option[Map[String, String]] = None, columns: Seq[SequenceColumn], createdTime: Instant = Instant.ofEpochMilli(0), lastUpdatedTime: Instant = Instant.ofEpochMilli(0), dataSetId: Option[Long] = None) extends WithExternalId with WithId[Long] with Product with Serializable

    Permalink
  77. final case class SequenceRowDeleteSchema(rowNumber: Long) extends Product with Serializable

    Permalink
  78. final case class SequenceRowFilter(inclusiveStart: Option[Long] = None, exclusiveEnd: Option[Long] = None) extends Product with Serializable

    Permalink
  79. case class SequenceRowWithExternalId(externalId: CogniteExternalId, sequenceRow: SequenceRow) extends Product with Serializable

    Permalink
  80. class SequenceRowsRelation extends CdfRelation with WritableRelation with PrunedFilteredScan

    Permalink
  81. final case class SequenceUpdateSchema(id: Option[Long] = None, externalId: OptionalField[String] = FieldNotSpecified, name: OptionalField[String] = FieldNotSpecified, description: OptionalField[String] = FieldNotSpecified, assetId: OptionalField[Long] = FieldNotSpecified, metadata: Option[Map[String, String]] = None, columns: Option[Seq[SequenceColumnCreate]] = None, dataSetId: OptionalField[Long] = FieldNotSpecified) extends WithNullableExtenalId with WithId[Option[Long]] with Product with Serializable

    Permalink
  82. class SequencesRelation extends SdkV1Relation[SequenceReadSchema, Long] with InsertableRelation with WritableRelation

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

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

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

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

    Permalink
  87. class StringDataPointsRelationV1 extends DataPointsRelationV1[StringDataPointsItem] with WritableRelation

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

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

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

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

    Permalink
  92. final 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
  93. final 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
  94. class TimeSeriesRelation extends SdkV1Relation[TimeSeries, Long] with WritableRelation with InsertableRelation

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

    Permalink
  96. trait UpdateSchema extends AnyRef

    Permalink
  97. trait UpsertSchema extends AnyRef

    Permalink
  98. trait WithNullableExtenalId extends WithExternalIdGeneric[OptionalField]

    Permalink
  99. trait WritableRelation extends AnyRef

    Permalink
  100. final case class WrongDatapointTypeException(id: Long, externalId: Option[String], shouldBeString: Boolean) extends CdfSparkException with Product with Serializable

    Permalink

Value Members

  1. object AssetHierarchyBuilder extends Serializable

    Permalink
  2. object AssetSubtreeOption extends Enumeration

    Permalink
  3. object AssetsRelation extends UpsertSchema with Serializable

    Permalink
  4. object AssetsUpsertSchema extends Serializable

    Permalink
  5. object CdfSparkAuth extends Serializable

    Permalink
  6. object CdpConnector

    Permalink
  7. object Constants

    Permalink
  8. object DataPointsRelationV1 extends Serializable

    Permalink
  9. object DefaultSource extends Serializable

    Permalink
  10. object EventsRelation extends UpsertSchema with Serializable

    Permalink
  11. object FilesRelation extends UpsertSchema with Serializable

    Permalink
  12. object FilesUpsertSchema extends Serializable

    Permalink
  13. object Granularity extends Serializable

    Permalink
  14. object LabelsRelation extends Serializable

    Permalink
  15. object NumericDataPointsRelation extends UpsertSchema

    Permalink
  16. object OnConflict extends Enumeration

    Permalink
  17. object PushdownUtilities

    Permalink
  18. object RateLimitingBackend

    Permalink
  19. object RawTableRelation extends Serializable

    Permalink
  20. object RelationshipsRelation extends Serializable

    Permalink
  21. object SequenceRelation extends UpsertSchema

    Permalink
  22. object SequenceRowsRelation extends Serializable

    Permalink
  23. object StreamIterator

    Permalink
  24. object StringDataPointsRelation extends UpsertSchema

    Permalink
  25. object TimeSeriesRelation extends UpsertSchema with Serializable

    Permalink
  26. object TimeSeriesUpsertSchema extends Serializable

    Permalink
  27. object WrongDatapointTypeException extends Serializable

    Permalink
  28. implicit def anyToSetter[T]: Transformer[T, Option[Setter[T]]]

    Permalink
    Annotations
    @SuppressWarnings()
  29. implicit def encodeNonNullableSetter[T](implicit encodeT: Encoder[T]): Encoder[NonNullableSetter[T]]

    Permalink
  30. implicit def encodeSetter[T](implicit encodeT: Encoder[T]): Encoder[Setter[T]]

    Permalink
  31. implicit def optionToNonNullableSetter[T]: Transformer[Option[T], Option[NonNullableSetter[T]]]

    Permalink
  32. implicit def optionToSetter[T](implicit arg0: Manifest[T]): Transformer[Option[T], Option[Setter[T]]]

    Permalink
    Annotations
    @SuppressWarnings()
  33. implicit def sequenceToSequenceColumnCreate: Transformer[SequenceColumn, SequenceColumnCreate]

    Permalink
  34. implicit def toNonNullableSetter[T]: Transformer[T, NonNullableSetter[T]]

    Permalink
  35. implicit def toOptionNonNullableSetter[T]: Transformer[T, Option[NonNullableSetter[T]]]

    Permalink
  36. package udf

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped