Package

com.cognite.spark

datasource

Permalink

package datasource

Visibility
  1. Public
  2. All

Type Members

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

    Permalink
  2. case class AssetConflict(duplicates: Seq[SourceAndResourceId]) extends Product with Serializable

    Permalink
  3. case class AssetsItem(id: Long, path: Option[Seq[Long]], depth: Option[Long], name: String, parentId: Option[Long], description: Option[String], types: Option[Seq[Type]], metadata: Option[Map[String, String]], source: Option[String], sourceId: Option[String], createdTime: Option[Long], lastUpdatedTime: Option[Long]) extends Product with Serializable

    Permalink
  4. class AssetsRelation extends CdpRelation[AssetsItem] with InsertableRelation

    Permalink
  5. class AssetsRelationV1 extends SdkV1Relation[Asset, Assets[IO], AssetsItem] with InsertableRelation

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

    Permalink
  7. case class CdpApiException(url: Uri, code: Int, message: String) extends Throwable with Product with Serializable

    Permalink
  8. trait CdpConnector extends AnyRef

    Permalink
  9. case class CdpEventByIdsRddPartition(index: Int, uri: Uri, eventIds: Seq[EventId]) extends Partition with Product with Serializable

    Permalink
  10. case class CdpEventsByIdsRdd(sparkContext: SparkContext, toRow: (EventItem) ⇒ Row, config: RelationConfig, uri: Uri, eventIds: Seq[EventId]) extends RDD[Row] with CdpConnector with Product with Serializable

    Permalink
  11. 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
  12. case class CdpRddPartition(cursor: Option[String], size: Option[Int], index: Int, urlsWithFilters: Seq[Uri]) extends Partition with Product with Serializable

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

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

    Permalink
  15. case class CursorsCursorIterator(url: Uri, config: RelationConfig) extends Iterator[(Option[String], Option[Int])] with CdpConnector with Product with Serializable

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

    Permalink
  17. sealed case class DataPoint(timestamp: Long, value: Option[Double], average: Option[Double], max: Option[Double], min: Option[Double], count: Option[Double], sum: Option[Double], stepInterpolation: Option[Double], continuousVariance: Option[Double], discreteVariance: Option[Double], totalVariation: Option[Double]) extends Serializable with Product

    Permalink
  18. sealed case class DataPointTimestamp(timestamp: Long) extends Product with Serializable

    Permalink
  19. sealed case class DataPointsDataItems[A](items: Seq[A]) extends Product with Serializable

    Permalink
  20. sealed case class DataPointsItem(name: String, datapoints: Array[DataPoint]) extends Product with Serializable

    Permalink
  21. abstract case class DataPointsRdd(sparkContext: SparkContext, getSinglePartitionBaseUri: Uri, config: RelationConfig) extends RDD[Row] with CdpConnector with Product with Serializable

    Permalink
  22. case class DataPointsRddPartition(name: String, startTime: Long, endTime: Long, index: Int) extends Partition with Product with Serializable

    Permalink
  23. abstract class DataPointsRelation extends BaseRelation with InsertableRelation with TableScan with PrunedFilteredScan with CdpConnector with Serializable

    Permalink
  24. sealed case class DataPointsTimestampItem(name: String, datapoints: Array[DataPointTimestamp]) extends Product with Serializable

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

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

    Permalink
  27. abstract class DeleteSchema extends AnyRef

    Permalink
  28. case class DoubleIsTooLargeForJSON(field: Long) extends Throwable with Product with Serializable

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

    Permalink
  30. case class EventConflict(duplicates: Seq[IdSourceAndResourceId]) extends Product with Serializable

    Permalink
  31. case class EventId(id: Long) extends Product with Serializable

    Permalink
  32. case class EventItem(id: Option[Long], startTime: Option[Long], endTime: Option[Long], description: Option[String], type: Option[String], subtype: Option[String], metadata: Option[Map[String, String]], assetIds: Option[Seq[Long]], source: Option[String], sourceId: Option[String], createdTime: Option[Long], lastUpdatedTime: Option[Long]) extends Product with Serializable

    Permalink
  33. class EventsRelation extends CdpRelation[EventItem] with InsertableRelation with PrunedFilteredScan

    Permalink
  34. case class FieldData(id: Long, name: String, valueType: String, value: String) extends Product with Serializable

    Permalink
  35. case class FieldDescription(id: Long, name: String, description: String, valueType: String) extends Product with Serializable

    Permalink
  36. case class FileItem(id: Option[Long], fileName: String, directory: Option[String], source: Option[String], sourceId: Option[String], fileType: Option[String], metadata: Option[Map[String, String]], assetIds: Option[Seq[Long]], uploaded: Option[Boolean], uploadedAt: Option[Long], createdTime: Option[Long], lastUpdatedTime: Option[Long]) extends Product with Serializable

    Permalink
  37. class FilesRelation extends SdkV1Relation[File, Files[IO], FileItem] with InsertableRelation

    Permalink
  38. sealed case class GranularityFilter(amount: Option[Long], unit: String) extends Product with Serializable

    Permalink
  39. case class IdSourceAndResourceId(id: Long, source: String, sourceId: String) extends Product with Serializable

    Permalink
  40. trait InsertSchema extends AnyRef

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

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

    Permalink
  43. sealed case class LatestDataPoint(data: DataPointsDataItems[DataPointTimestamp]) extends Product with Serializable

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

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

    Permalink
  46. sealed case class Max(value: Long) extends Limit with Product with Serializable

    Permalink
  47. sealed case class Min(value: Long) extends Limit with Product with Serializable

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

    Permalink
  49. 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
  50. case class ModelRevisionMappingItem(nodeId: Long, assetId: Long, treeIndex: Option[Long], subtreeSize: Option[Long]) extends Product with Serializable

    Permalink
  51. case class ModelRevisionNodeItem(id: Long, treeIndex: Long, parentId: Option[Long], depth: Long, name: String, subtreeSize: Long, metadata: Map[String, String], boundingBox: Option[Map[String, Seq[Double]]], sectorId: Option[Long]) extends Product with Serializable

    Permalink
  52. sealed case class NameFilter(name: String) extends Product with Serializable

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

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

    Permalink
  56. class NumericDataPointsRdd extends DataPointsRdd

    Permalink
  57. class NumericDataPointsRelation extends DataPointsRelation

    Permalink
  58. case class PostAssetsItem(name: String, parentId: Option[Long], description: Option[String], types: Option[Seq[PostType]], source: Option[String], sourceId: Option[String], metadata: Option[Map[String, String]]) extends Product with Serializable

    Permalink
  59. case class PostEventItem(startTime: Option[Long], endTime: Option[Long], description: Option[String], type: Option[String], subtype: Option[String], metadata: Option[Map[String, String]], assetIds: Option[Seq[Long]], source: Option[String], sourceId: Option[String]) extends Product with Serializable

    Permalink
  60. case class PostField(id: Long, value: String) extends Product with Serializable

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

    Permalink
  62. case class PostTimeSeriesItem(name: String, legacyName: String, isString: Boolean, metadata: Option[Map[String, String]], unit: Option[String], assetId: Option[Long], isStep: Option[Boolean], description: Option[String], securityCategories: Option[Seq[Long]]) extends Product with Serializable

    Permalink
  63. case class PostTimeSeriesItemBase(name: String, isString: Boolean, metadata: Option[Map[String, String]], unit: Option[String], assetId: Option[Long], isStep: Option[Boolean], description: Option[String], securityCategories: Option[Seq[Long]]) extends Product with Serializable

    Permalink
  64. case class PostType(id: Long, fields: Seq[PostField]) extends Product with Serializable

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

    Permalink
  66. sealed trait PushdownExpression extends AnyRef

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

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

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

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

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

    Permalink
  72. 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
  73. case class SdkPartition(cursor: Option[String], size: Option[Int], index: Int) extends Partition with Product with Serializable

    Permalink
  74. case class SdkV1Rdd[A](sparkContext: SparkContext, config: RelationConfig, cursors: Iterator[(Option[String], Option[Int])], toRow: (A) ⇒ Row, clientToResource: (GenericClient[IO, Nothing]) ⇒ Readable[A, IO]) extends RDD[Row] with Product with Serializable

    Permalink
  75. abstract class SdkV1Relation[A, T <: Readable[A, IO], C] extends BaseRelation with CdpConnector with Serializable with TableScan

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

    Permalink
  77. case class SourceAndResourceId(source: Option[String], sourceId: Option[String]) extends Product with Serializable

    Permalink
  78. class StringDataPointsRdd extends DataPointsRdd

    Permalink
  79. class StringDataPointsRelation extends DataPointsRelation

    Permalink
  80. class ThreeDModelRevisionMappingsRelation extends SdkV1Relation[ThreeDAssetMapping, ThreeDAssetMappings[IO], ModelRevisionMappingItem]

    Permalink
  81. class ThreeDModelRevisionNodesRelation extends CdpRelation[ModelRevisionNodeItem]

    Permalink
  82. case class ThreeDModelRevisionSectorsItem(id: Int, parentId: Option[Int], path: String, depth: Int, boundingBox: Map[String, Seq[Double]], threedFileId: Long, threedFiles: Seq[Map[String, Long]]) extends Product with Serializable

    Permalink
  83. class ThreeDModelRevisionSectorsRelation extends CdpRelation[ThreeDModelRevisionSectorsItem]

    Permalink
  84. class ThreeDModelRevisionsRelation extends SdkV1Relation[ThreeDRevision, ThreeDRevisions[IO], ModelRevisionItem]

    Permalink
  85. class ThreeDModelsRelation extends SdkV1Relation[ThreeDModel, ThreeDModels[IO], ModelItem]

    Permalink
  86. case class TimeSeriesConflict(notFound: Seq[Long]) extends Product with Serializable

    Permalink
  87. case class TimeSeriesItem(name: String, isString: Boolean, metadata: Option[Map[String, String]], unit: Option[String], assetId: Option[Long], isStep: Option[Boolean], description: Option[String], securityCategories: Option[Seq[Long]], id: Option[Long], createdTime: Option[Long], lastUpdatedTime: Option[Long]) extends Product with Serializable

    Permalink
  88. case class TimeSeriesNotFound(notFound: Seq[String]) extends Product with Serializable

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

    Permalink
  90. class TimeSeriesRelation extends CdpRelation[TimeSeriesItem] with InsertableRelation

    Permalink
  91. case class Type(id: Long, name: String, fields: Seq[FieldData]) extends Product with Serializable

    Permalink
  92. case class TypeDescription(id: Long, name: String, description: String, fields: Seq[FieldDescription]) extends Product with Serializable

    Permalink
  93. case class UpdateAssetsItem(id: Option[Long], name: Option[NonNullableSetter[String]], description: Option[Setter[String]], metadata: Option[Setter[Map[String, String]]], source: Option[Setter[String]], sourceId: Option[Setter[String]]) extends Product with Serializable

    Permalink
  94. case class UpdateAssetsItemBase(id: Option[Long], name: Option[String], description: Option[String], metadata: Option[Map[String, String]], source: Option[String], sourceId: Option[String]) extends Product with Serializable

    Permalink
  95. case class UpdateEventItem(id: Option[Long], startTime: Option[Setter[Long]], endTime: Option[Setter[Long]], description: Option[Setter[String]], type: Option[Setter[String]], subtype: Option[Setter[String]], metadata: Option[Setter[Map[String, String]]], assetIds: Option[Map[String, Seq[Long]]], source: Option[Setter[String]], sourceId: Option[Setter[String]]) extends Product with Serializable

    Permalink
  96. trait UpdateSchema extends AnyRef

    Permalink
  97. case class UpdateTimeSeriesBase(name: Option[String], isString: Option[Boolean], metadata: Option[Map[String, String]], unit: Option[String], assetId: Option[Long], isStep: Option[Boolean], description: Option[String], securityCategories: Option[Seq[Long]], id: Option[Long]) extends Product with Serializable

    Permalink
  98. case class UpdateTimeSeriesItem(id: Long, name: Option[Setter[String]], metadata: Option[Setter[Map[String, String]]], unit: Option[Setter[String]], assetId: Option[Setter[Long]], description: Option[Setter[String]], securityCategories: Option[Map[String, Option[Seq[Long]]]], isString: Option[Setter[Boolean]], isStep: Option[Setter[Boolean]]) extends Product with Serializable

    Permalink
  99. trait UpsertSchema extends AnyRef

    Permalink

Value Members

  1. object AssetsRelation extends DeleteSchema with InsertSchema with UpdateSchema with Serializable

    Permalink
  2. object Batch

    Permalink
  3. object CdpConnector

    Permalink
  4. object Constants

    Permalink
  5. object DataPointsRdd extends Serializable

    Permalink
  6. object EventsRelation extends DeleteSchema with UpsertSchema with InsertSchema with UpdateSchema with Serializable

    Permalink
  7. object Limit extends Enumeration with Serializable

    Permalink
  8. object NumericDataPointsRdd extends Serializable

    Permalink
  9. object OnConflict extends Enumeration

    Permalink
  10. object PostEventItem extends Serializable

    Permalink
  11. object PostTimeSeriesItem extends Serializable

    Permalink
  12. object PushdownUtilities

    Permalink
  13. object RawTableRelation extends Serializable

    Permalink
  14. object Setter extends Serializable

    Permalink
  15. object TimeSeriesRelation extends DeleteSchema with UpsertSchema with InsertSchema with UpdateSchema with Serializable

    Permalink
  16. object UpdateAssetsItem extends Serializable

    Permalink
  17. object UpdateAssetsItemBase extends Serializable

    Permalink
  18. object UpdateEventItem extends Serializable

    Permalink
  19. object UpdateTimeSeriesItem extends Serializable

    Permalink

Ungrouped