Packages

p

geotrellis

raster

package raster

Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. raster
  2. Implicits
  3. Implicits
  4. Implicits
  5. Implicits
  6. Implicits
  7. Implicits
  8. Implicits
  9. Implicits
  10. Implicits
  11. Implicits
  12. Implicits
  13. Implicits
  14. Implicits
  15. Implicits
  16. Implicits
  17. Implicits
  18. Implicits
  19. Implicits
  20. Implicits
  21. Implicits
  22. Implicits
  23. Implicits
  24. HistogramJsonFormats
  25. Implicits
  26. Implicits
  27. Implicits
  28. Implicits
  29. Implicits
  30. Implicits
  31. Implicits
  32. AnyRef
  33. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. class ArrayMultibandTile extends MultibandTile with MacroMultibandCombiners

    The ArrayMultibandTile type.

  2. abstract class ArrayTile extends Tile with Serializable

    ArrayTile provides access and update to the grid data of a tile.

    ArrayTile provides access and update to the grid data of a tile. Designed to be a near drop-in replacement for Array in many cases.

  3. final case class BitArrayTile(array: Array[Byte], cols: Int, rows: Int) extends MutableArrayTile with Product with Serializable

    ArrayTile based on an Array[Byte] as a bitmask; values are 0 and 1.

    ArrayTile based on an Array[Byte] as a bitmask; values are 0 and 1. Thus, there are 8 boolean (0 / 1) values per byte in the array. For example, Array(11, 9) corresponds to (0 0 0 0 1 0 1 1), (0 0 0 0 1 0 0 1) which means that we have 5 cells set to 1 and 11 cells set to 0.

    Note that unlike the other array-based raster data objects we need to be explicitly told our size, since length=7 and length=8 will both need to allocate an Array[Byte] with length=1.

  4. sealed trait BitCells extends DataType

    The BitCells type, derived from DataType

  5. case class BitConstantTile(v: Boolean, cols: Int, rows: Int) extends ConstantTile with Product with Serializable

    The BitConstantTile type.

  6. case class BufferTile(sourceTile: Tile, gridBounds: GridBounds[Int]) extends Tile with Product with Serializable

    When combined with another BufferTile the two tiles will be aligned on (0, 0) pixel of tile center.

    When combined with another BufferTile the two tiles will be aligned on (0, 0) pixel of tile center. The operation will be carried over all overlapping pixels. For instance: combining a tile padded with 5 pixels on all sides with tile padded with 3 pixels on all sides will result in buffer tile with 3 pixel padding on all sides.

    When combined with another BufferTile the operation will be executed over the maximum shared in

    Behaves like a regular tile within the gridBounds. The access to the buffer is achieved through the direct access to the sourceTile or via the mapTile function that maps over the sourceTile.

  7. implicit final class ByteArrayFiller extends AnyVal
  8. abstract class ByteArrayTile extends MutableArrayTile

    ArrayTile based on Array[Byte] (each cell as a Byte).

  9. sealed trait ByteCells extends DataType

    The ByteCells type, derived from DataType

  10. final case class ByteConstantNoDataArrayTile(arr: Array[Byte], cols: Int, rows: Int) extends ByteArrayTile with Product with Serializable

    A ByteConstantNoDataArrayTile, created from the given array, with the given number of columns and rows.

    A ByteConstantNoDataArrayTile, created from the given array, with the given number of columns and rows.

    arr

    The array of bytes from which to initialize the tile

    cols

    The number of columns

    rows

    The number of rows

  11. case class ByteConstantTile(v: Byte, cols: Int, rows: Int, cellType: ByteCells with NoDataHandling = ByteConstantNoDataCellType) extends ConstantTile with Product with Serializable

    The ByteConstantTile type.

  12. final case class ByteRawArrayTile(arr: Array[Byte], cols: Int, rows: Int) extends ByteArrayTile with Product with Serializable

    A ByteRawArrayTile, created from the given array, with the given number of columns and rows.

    A ByteRawArrayTile, created from the given array, with the given number of columns and rows.

    arr

    The array of bytes from which to initialize the tile

    cols

    The number of columns

    rows

    The number of rows

  13. final case class ByteUserDefinedNoDataArrayTile(arr: Array[Byte], cols: Int, rows: Int, cellType: ByteUserDefinedNoDataCellType) extends ByteArrayTile with UserDefinedByteNoDataConversions with Product with Serializable

    A ByteUserDefinedNoDataArrayTile, created from the given array, with the given number of columns and rows.

    A ByteUserDefinedNoDataArrayTile, created from the given array, with the given number of columns and rows.

    arr

    The array of bytes from which to initialize the tile

    cols

    The number of columns

    rows

    The number of rows

    cellType

    The cellType whose NODATA value is to be used

  14. case class ByteUserDefinedNoDataCellType(noDataValue: Byte) extends DataType with ByteCells with UserDefinedNoData[Byte] with Product with Serializable
  15. trait CellFeatures[R, D] extends AnyRef

    Type class to convert a raster into features of cell geometries

  16. abstract class CellGrid[N] extends GridIntegral[N]

    A grid composed of cells with specific value types

  17. trait CellSet extends AnyRef

    A lighweight wrapper around performing foreach calculations on a set of cell coordinates

  18. case class CellSize(width: Double, height: Double) extends Product with Serializable

    A case class containing the width and height of a cell.

    A case class containing the width and height of a cell.

    width

    The width of a cell

    height

    The height of a cell

  19. type CellType = DataType with NoDataHandling
  20. class CellTypeEncodingBench extends AnyRef
    Annotations
    @BenchmarkMode() @State() @OutputTimeUnit()
  21. type ColorMap = raster.render.ColorMap
  22. case class CompositeTile(tiles: Seq[Tile], tileLayout: TileLayout) extends Tile with Product with Serializable

    The CompositeTile type.

  23. sealed trait Connectivity extends AnyRef

    An encoding of the connectivity of vector tiles.

  24. sealed trait ConstantNoData[T] extends HasNoData[T]

    The ConstantNoData type, derived from NoDataHandling.

  25. abstract class ConstantTile extends Tile

    The trait underlying constant tile types.

  26. case class ConvertTargetCellType(cellType: CellType) extends TargetCellType with Product with Serializable
  27. case class CroppedTile(sourceTile: Tile, gridBounds: GridBounds[Int]) extends Tile with Product with Serializable

    The CroppedTile type.

  28. type DI = DummyImplicit
  29. sealed abstract class DataType extends Serializable

    The DataType type.

  30. class DelayedConversionMultibandTile extends MultibandTile with MacroMultibandCombiners

    [DelayedConversionTile]] represents a tile that wraps an inner tile, and for any operation that returns a Tile, returns an ArrayTile with a cell type of the target cell type.

  31. trait DelayedConversionMultibandTileMethods extends MethodExtensions[MultibandTile]
  32. class DelayedConversionTile extends Tile

    [DelayedConversionTile]] represents a tile that wraps an inner tile, and for any operation that returns a Tile, returns an ArrayTile with a cell type of the target cell type.

    [DelayedConversionTile]] represents a tile that wraps an inner tile, and for any operation that returns a Tile, returns an ArrayTile with a cell type of the target cell type.

    Note

    get and getDouble don't do what you think you do.

  33. trait DelayedConversionTileMethods extends MethodExtensions[Tile]
  34. abstract class DelegatingTile extends Tile

    A tile that wraps another tile.

    A tile that wraps another tile. Originally intended for delayed reading, but useful in other special use cases.

    Since

    8/22/18

  35. case class Dimensions[N](cols: N, rows: N)(implicit evidence$1: Integral[N]) extends Product2[N, N] with Serializable with Product
  36. implicit final class DoubleArrayFiller extends AnyVal
  37. abstract class DoubleArrayTile extends MutableArrayTile

    ArrayTile based on Array[Double] (each cell as a Double).

  38. sealed trait DoubleCells extends DataType

    The DoubleCells type, derived from DataType

  39. final case class DoubleConstantNoDataArrayTile(arr: Array[Double], cols: Int, rows: Int) extends DoubleArrayTile with Product with Serializable

    The DoubleConstantNoDataArrayTile, derived from DoubleArrayTile.

  40. case class DoubleConstantTile(v: Double, cols: Int, rows: Int, cellType: DoubleCells with NoDataHandling = DoubleConstantNoDataCellType) extends ConstantTile with Product with Serializable

    The DoubleConstantTile type.

  41. final case class DoubleRawArrayTile(arr: Array[Double], cols: Int, rows: Int) extends DoubleArrayTile with Product with Serializable

    The DoubleRawArrayTile, derived from DoubleArrayTile.

  42. type DoubleTileMapper = macros.DoubleTileMapper
  43. type DoubleTileVisitor = macros.DoubleTileVisitor
  44. final case class DoubleUserDefinedNoDataArrayTile(arr: Array[Double], cols: Int, rows: Int, cellType: DoubleUserDefinedNoDataCellType) extends DoubleArrayTile with UserDefinedDoubleNoDataConversions with Product with Serializable

    The DoubleUserDefinedNoDataArrayTile, derived from DoubleArrayTile.

  45. case class DoubleUserDefinedNoDataCellType(noDataValue: Double) extends DataType with DoubleCells with UserDefinedNoData[Double] with Product with Serializable
  46. type FastMapHistogram = raster.histogram.FastMapHistogram
  47. sealed trait FixedNoDataEncoding extends raster.CellTypeEncoding.CellTypeEncoding

    Base trait for encoding CellTypes with fixed or no NoData values.

  48. implicit final class FloatArrayFiller extends AnyVal
  49. abstract class FloatArrayTile extends MutableArrayTile

    ArrayTile based on Array[Float] (each cell as a Float).

  50. sealed trait FloatCells extends DataType
  51. final case class FloatConstantNoDataArrayTile(arr: Array[Float], cols: Int, rows: Int) extends FloatArrayTile with Product with Serializable

    The FloatConstantNoDataArrayTile derived from FloatArrayTile.

  52. case class FloatConstantTile(v: Float, cols: Int, rows: Int, cellType: FloatCells with NoDataHandling = FloatConstantNoDataCellType) extends ConstantTile with Product with Serializable

    The FloatConstantTile type.

  53. final case class FloatRawArrayTile(arr: Array[Float], cols: Int, rows: Int) extends FloatArrayTile with Product with Serializable

    The FloatRawArrayTile derived from FloatArrayTile.

  54. final case class FloatUserDefinedNoDataArrayTile(arr: Array[Float], cols: Int, rows: Int, cellType: FloatUserDefinedNoDataCellType) extends FloatArrayTile with UserDefinedFloatNoDataConversions with Product with Serializable

    The FloatUserDefinedNoDataArrayTile derived from FloatArrayTile.

  55. case class FloatUserDefinedNoDataCellType(noDataValue: Float) extends DataType with FloatCells with UserDefinedNoData[Float] with Product with Serializable
  56. class GenericRasterBench extends AnyRef
    Annotations
    @BenchmarkMode() @State()
  57. case class GeoAttrsError(msg: String) extends Exception with Product with Serializable

    GeoAttrsError exception.

  58. trait Grid[N] extends Serializable
  59. case class GridBounds[N](colMin: N, rowMin: N, colMax: N, rowMax: N)(implicit evidence$1: Integral[N]) extends Product with Serializable

    Represents grid coordinates of a subsection of a RasterExtent.

    Represents grid coordinates of a subsection of a RasterExtent. These coordinates are inclusive.

  60. class GridBoxingBench extends AnyRef

    See issue https://github.com/locationtech/geotrellis/issues/3427

    See issue https://github.com/locationtech/geotrellis/issues/3427

    Annotations
    @BenchmarkMode() @State() @OutputTimeUnit()
  61. class GridExtent[N] extends GridIntegral[N]

    Represents an abstract grid over geographic extent.

    Represents an abstract grid over geographic extent. Critically while the number of cell rows and columns is implied by the constructor arguments, they are intentionally not expressed to avoid Int overflow for large grids.

    The constructor will throw java.lang.IllegalArgumentException if the provided extent and cell size do not match the provided cols and rows (dimensions).

  62. abstract class GridIntegral[N] extends Grid[N]
  63. sealed trait HasNoData[T] extends NoDataHandling

    Base trait for all cell type having a NoData value

  64. type Histogram[T <: AnyVal] = raster.histogram.Histogram[T]
  65. trait Implicits extends raster.costdistance.Implicits with raster.crop.Implicits with raster.density.Implicits with raster.distance.Implicits with raster.equalization.Implicits with raster.hydrology.Implicits with raster.interpolation.Implicits with raster.io.json.Implicits with raster.mapalgebra.focal.Implicits with raster.mapalgebra.focal.hillshade.Implicits with raster.mapalgebra.local.Implicits with raster.mapalgebra.zonal.Implicits with raster.mask.Implicits with raster.matching.Implicits with raster.merge.Implicits with raster.prototype.Implicits with raster.rasterize.Implicits with raster.regiongroup.Implicits with raster.render.Implicits with raster.reproject.Implicits with raster.resample.Implicits with raster.sigmoidal.Implicits with raster.split.Implicits with raster.summary.Implicits with raster.summary.polygonal.Implicits with raster.transform.Implicits with raster.vectorize.Implicits with raster.viewshed.Implicits
  66. implicit class SinglebandRasterAnyRefMethods extends AnyRef
    Definition Classes
    Implicits
  67. implicit class TilePercentileExtensions extends AnyRef
    Definition Classes
    Implicits
  68. implicit class TileTupleExtensions extends AnyRef
    Definition Classes
    Implicits
  69. implicit class TraversableTileExtensions extends AnyRef
    Definition Classes
    Implicits
  70. implicit class withCellFeaturesMethods[R] extends Methods[R]
    Definition Classes
    Implicits
  71. implicit class withMultibandTileMethods extends MethodExtensions[MultibandTile] with DelayedConversionMultibandTileMethods
    Definition Classes
    Implicits
  72. implicit class withTileMethods extends MethodExtensions[Tile] with DelayedConversionTileMethods
    Definition Classes
    Implicits
  73. implicit final class IntArrayFiller extends AnyVal
  74. abstract class IntArrayTile extends MutableArrayTile

    ArrayTile based on Array[Int] (each cell as an Int).

  75. sealed trait IntCells extends DataType

    The IntCells type, derived from DataType

  76. final case class IntConstantNoDataArrayTile(arr: Array[Int], cols: Int, rows: Int) extends IntArrayTile with Product with Serializable

    The IntConstantNoDataArrayTile derived from IntArrayTile.

  77. case class IntConstantTile(v: Int, cols: Int, rows: Int, cellType: IntCells with NoDataHandling = IntConstantNoDataCellType) extends ConstantTile with Product with Serializable

    The IntConstantTile type.

  78. final case class IntRawArrayTile(arr: Array[Int], cols: Int, rows: Int) extends IntArrayTile with Product with Serializable

    The IntRawArrayTile derived from IntArrayTile.

  79. type IntTileMapper = macros.IntTileMapper
  80. type IntTileVisitor = macros.IntTileVisitor
  81. final case class IntUserDefinedNoDataArrayTile(arr: Array[Int], cols: Int, rows: Int, cellType: IntUserDefinedNoDataCellType) extends IntArrayTile with UserDefinedIntNoDataConversions with Product with Serializable

    The IntUserDefinedNoDataArrayTile derived from IntArrayTile.

  82. case class IntUserDefinedNoDataCellType(noDataValue: Int) extends DataType with IntCells with UserDefinedNoData[Int] with Product with Serializable
  83. case class InterpretAsTargetCellType(cellType: CellType) extends TargetCellType with Product with Serializable
  84. trait IterableTile extends MacroIterableTile

    Trait to supply foreach(|Double) methods.

  85. trait MacroGeotiffMultibandCombiners extends AnyRef
  86. trait MacroMultibandCombiners extends AnyRef
  87. trait MappableTile[T <: MappableTile[T]] extends MacroMappableTile[T]

    The MappableTile trait.

  88. case class MosaicMetadata(name: SourceName, crs: CRS, bandCount: Int, cellType: CellType, gridExtent: GridExtent[Long], resolutions: List[CellSize], list: NonEmptyList[RasterMetadata]) extends RasterMetadata with Product with Serializable
  89. abstract class MosaicRasterSource extends RasterSource

    Single threaded instance of a reader for reading windows out of collections of rasters

  90. type MultibandRaster = Raster[MultibandTile]
  91. abstract class MultibandTile extends CellGrid[Int] with MacroCombinableMultibandTile[Tile] with MacroCombineFunctions[Tile, MultibandTile]
  92. abstract class MutableArrayTile extends ArrayTile

    MutableArrayTile is an ArrayTile whose cells can be written to (mutated).

  93. type MutableHistogram[T <: AnyVal] = raster.histogram.MutableHistogram[T]
  94. type Neighborhood = raster.mapalgebra.focal.Neighborhood
  95. sealed trait NoDataHandling extends AnyRef

    Base trait for all cell types associated with handling NoData values or not.

  96. sealed trait NoNoData extends NoDataHandling

    Base trait for all "raw" cell types, not having a NoData value.

  97. case class PaddedTile(chunk: Tile, colOffset: Int, rowOffset: Int, cols: Int, rows: Int) extends Tile with Product with Serializable
  98. class PixelInterleaveBandArrayTile extends ArrayTile

    This Tile type allows for an ArrayTile that contains pixel values as a pixel interleaved set (meaning each column has one value for each band in a row) to be viewed as a Tile for a specific band.

  99. sealed abstract class PixelSampleType extends AnyRef

    The base class for the two concrete PixelSampleTypes.

  100. case class ProjectedRaster[T <: CellGrid[Int]](raster: Raster[T], crs: CRS) extends Product with Serializable

    The ProjectedRaster type.

  101. class ProjectedRasterExtent extends RasterExtent
  102. trait ProjectedRasterLike extends AnyRef

    Conformance interface for entities that are tile-like with a projected extent.

  103. case class Raster[+T <: CellGrid[Int]](tile: T, extent: Extent) extends CellGrid[Int] with Product2[T, Extent] with Product with Serializable

    The Raster type.

  104. case class RasterExtent(extent: Extent, cellwidth: Double, cellheight: Double, cols: Int, rows: Int) extends GridExtent[Int] with Product with Serializable

    RasterExtent objects represent the geographic extent (envelope) of a raster.

    RasterExtent objects represent the geographic extent (envelope) of a raster.

    The Raster extent has two coordinate concepts involved: map coordinates and grid coordinates. Map coordinates are what the Extent class uses, and specifies points using an X coordinate and a Y coordinate. The X coordinate is oriented along west to east such that the larger the X coordinate, the more eastern the point. The Y coordinate is along south to north such that the larger the Y coordinate, the more Northern the point.

    This contrasts with the grid coordinate system. The grid coordinate system does not actually reference points on the map, but instead a cell of the raster that represents values for some square area of the map. The column axis is similar in that the number gets larger as one goes from west to east; however, the row axis is inverted from map coordinates: as the row number increases, the cell is heading south. The top row is labeled as 0, and the next 1, so that the highest indexed row is the southern most row of the raster. A cell has a height and a width that is in terms of map units. You can think of it as each cell is itself an extent, with width cellwidth and height cellheight. When a cell needs to be represented or thought of as a point, the center of the cell will be used. So when gridToMap is called, what is returned is the center point, in map coordinates.

    Map points are considered to be 'inside' the cell based on these rules:

    • If the point is inside the area of the cell, it is included in the cell.
    • If the point lies on the north or west border of the cell, it is included in the cell.
    • If the point lies on the south or east border of the cell, it is not included in the cell, it is included in the next southern or eastern cell, respectively.

    Note that based on these rules, the eastern and southern borders of an Extent are not actually considered to be part of the RasterExtent.

  105. trait RasterMetadata extends Serializable
  106. abstract class RasterRegion extends CellGrid[Int] with ProjectedRasterLike with Serializable

    Reference to a pixel region in a RasterSource that may be read at a later time.

  107. abstract class RasterSource extends CellGrid[Long] with RasterMetadata

    Single threaded instance of a reader that is able to read windows from larger raster.

    Single threaded instance of a reader that is able to read windows from larger raster. Some initilization step is expected to provide metadata about source raster

  108. trait RasterSourceProvider extends AnyRef
  109. case class ReadingSource(source: RasterSource, sourceToTargetBand: Map[Int, Int]) extends Serializable with Product
  110. type ResampleMethod = raster.resample.ResampleMethod
  111. sealed trait ResampleTarget extends AnyRef

    A strategy to use when constructing a grid that will be used during resampling

    A strategy to use when constructing a grid that will be used during resampling

    Various tradeoffs exist when attempting to resize an image. Subclasses of ResampleTarget encode these various tradeoffs in terms of the proportions/alignment desired at the end of resampling. E.g. TargetCellSize tells any resampling function to resample in such a way as to approximately match the specified CellSize in any resulting operations.

  112. abstract class SegmentCombiner extends AnyRef

    This trait is how subclasses define the necessary pieces that allow us to abstract over each of the combine functions

  113. implicit final class ShortArrayFiller extends AnyVal
  114. abstract class ShortArrayTile extends MutableArrayTile

    ArrayTile based on Array[Short] (each cell as a Short).

  115. sealed trait ShortCells extends DataType

    The ShortCells type, derived from DataType

  116. final case class ShortConstantNoDataArrayTile(arr: Array[Short], cols: Int, rows: Int) extends ShortArrayTile with Product with Serializable

    ShortConstantNoDataArrayTile derived from ShortArrayTile.

  117. case class ShortConstantTile(v: Short, cols: Int, rows: Int, cellType: ShortCells with NoDataHandling = ShortConstantNoDataCellType) extends ConstantTile with Product with Serializable

    The ShortConstantTile type.

  118. final case class ShortRawArrayTile(arr: Array[Short], cols: Int, rows: Int) extends ShortArrayTile with Product with Serializable

    ShortRawArrayTile derived from ShortArrayTile.

  119. final case class ShortUserDefinedNoDataArrayTile(arr: Array[Short], cols: Int, rows: Int, cellType: ShortUserDefinedNoDataCellType) extends ShortArrayTile with UserDefinedShortNoDataConversions with Product with Serializable

    ShortUserDefinedNoDataArrayTile derived from ShortArrayTile.

  120. case class ShortUserDefinedNoDataCellType(noDataValue: Short) extends DataType with ShortCells with UserDefinedNoData[Short] with Product with Serializable
  121. type SinglebandRaster = Raster[Tile]
  122. trait SourceName extends Serializable

    Represents the path to data or name of the data that is to be read.

  123. trait SourcePath extends SourceName

    Represents the path to data that is to be read.

  124. case class SpecifiedUserDefinedNoDataEncoding[N](base: UserDefinedNoDataEncoding, noData: N) extends UserDefinedNoDataEncoding with Product with Serializable

    On-demand cell type encoding for specific user defined no data values.

  125. type StreamingHistogram = raster.histogram.StreamingHistogram
  126. case class StringName(value: String) extends SourceName with Product with Serializable
  127. case class TargetAlignment(grid: GridExtent[_]) extends ResampleTarget with Product with Serializable

    Snap to a target grid - useful prior to comparison between rasters as a means of ensuring clear correspondence between underlying cell values

  128. type TargetCell = raster.mapalgebra.focal.TargetCell
  129. case class TargetCellSize(cellSize: CellSize) extends ResampleTarget with Product with Serializable

    Resample, aiming for a grid which has the provided CellSize

    Resample, aiming for a grid which has the provided CellSize

    Note

    Targetting a specific size for each cell in the grid has consequences for the Extent because e.g. an extent's width *must* be evenly divisible by the width of the cells within it. Consequently, we have two options: either modify the resolution to accomodate the output extent or modify the overall extent to preserve the desired output resolution. Fine grained constraints on both resolution and extent will currently need to be managed manually.

  130. sealed trait TargetCellType extends AnyRef
  131. case class TargetDimensions(cols: Long, rows: Long) extends ResampleTarget with Product with Serializable

    Resample, aiming for a specific number of cell columns/rows

  132. case class TargetRegion(region: GridExtent[_]) extends ResampleTarget with Product with Serializable

    Resample, sampling values into a user-supplied GridExtent

  133. abstract class Tile extends CellGrid[Int] with IterableTile with MappableTile[Tile]

    Base trait for a Tile.

  134. case class TileExtents(extent: Extent, tileLayout: TileLayout) extends Product with Serializable

    The TileExtents type.

  135. case class TileFeature[+T <: CellGrid[Int], D](tile: T, data: D) extends CellGrid[Int] with Product with Serializable

    The TileFeature Type.

    The TileFeature Type. This is used for packaging a CellGrid (a Tile or MultibandTile) together with some metadata.

    tile

    The CellGrid-derived tile

    data

    The additional metadata

  136. case class TileLayout(layoutCols: Int, layoutRows: Int, tileCols: Int, tileRows: Int) extends Product with Serializable

    layoutCols

    number of columns in the layout, East to West

    layoutRows

    number of rows in the layout grid, North to South

    tileCols

    number of pixel columns in each tile, East to West

    tileRows

    number of pixel rows in each tile, North to South

  137. sealed class TileOrMultibandTile[T] extends AnyRef
  138. abstract class UByteArrayTile extends MutableArrayTile

    ArrayTile based on Array[Byte] (each cell as a Byte).

  139. sealed trait UByteCells extends DataType

    The UByteCells type, derived from DataType

  140. final case class UByteConstantNoDataArrayTile(arr: Array[Byte], cols: Int, rows: Int) extends UByteArrayTile with Product with Serializable

    UByteConstantNoDataArrayTile derived from UByteArrayTile.

  141. case class UByteConstantTile(v: Byte, cols: Int, rows: Int, cellType: UByteCells with NoDataHandling = UByteConstantNoDataCellType) extends ConstantTile with Product with Serializable

    The UByteConstantTile type.

  142. final case class UByteRawArrayTile(arr: Array[Byte], cols: Int, rows: Int) extends UByteArrayTile with Product with Serializable

    UByteRawArrayTile derived from UByteArrayTile.

  143. final case class UByteUserDefinedNoDataArrayTile(arr: Array[Byte], cols: Int, rows: Int, cellType: UByteUserDefinedNoDataCellType) extends UByteArrayTile with UserDefinedByteNoDataConversions with Product with Serializable

    UByteUserDefinedNoDataArrayTile derived from UByteArrayTile.

  144. case class UByteUserDefinedNoDataCellType(noDataValue: Byte) extends DataType with UByteCells with UserDefinedNoData[Byte] with Product with Serializable
  145. abstract class UShortArrayTile extends MutableArrayTile

    ArrayTile based on Array[Short] (each cell as a Short).

  146. sealed trait UShortCells extends DataType

    The UShortCells type, derived from DataType

  147. class UShortConstantNoDataArrayTile extends UShortArrayTile

    UShortConstantNoDataArrayTile derived from UShortArrayTile.

  148. case class UShortConstantTile(v: Short, cols: Int, rows: Int, cellType: UShortCells with NoDataHandling = UShortConstantNoDataCellType) extends ConstantTile with Product with Serializable

    The UShortConstantTile type.

  149. class UShortRawArrayTile extends UShortArrayTile

    UShortRawArrayTile derived from UShortArrayTile.

  150. class UShortUserDefinedNoDataArrayTile extends UShortArrayTile with UserDefinedShortNoDataConversions

    UShortUserDefinedNoDataArrayTile derived from UShortArrayTile.

  151. case class UShortUserDefinedNoDataCellType(noDataValue: Short) extends DataType with UShortCells with UserDefinedNoData[Short] with Product with Serializable
  152. trait UserDefinedByteNoDataConversions extends AnyRef
  153. trait UserDefinedDoubleNoDataConversions extends AnyRef
  154. trait UserDefinedFloatNoDataConversions extends AnyRef
  155. trait UserDefinedIntNoDataConversions extends AnyRef
  156. sealed trait UserDefinedNoData[T] extends HasNoData[T]

    The UserDefinedNoData type, derived from NoDataHandling.

  157. sealed trait UserDefinedNoDataEncoding extends raster.CellTypeEncoding.CellTypeEncoding

    Base trait for encoding CellTypes with user defined NoData values.

  158. trait UserDefinedShortNoDataConversions extends AnyRef
  159. case class WideDoubleNoData(asDouble: Double) extends WidenedNoData with Product with Serializable

    NoData stored as a Double

  160. case class WideIntNoData(asInt: Int) extends WidenedNoData with Product with Serializable

    NoData value stored as an Int.

  161. sealed trait WidenedNoData extends AnyRef

    Container for NoData value using wider word size than declared to handled unsigned number rollover.

  162. implicit class withTileCostDistanceMethods extends CostDistanceMethods
    Definition Classes
    Implicits
  163. implicit class withMultibandRasterTileFeatureCropMethods[D] extends RasterTileFeatureCropMethods[MultibandTile, D]
    Definition Classes
    Implicits
  164. implicit class withMultibandTileCropMethods extends MultibandTileCropMethods
    Definition Classes
    Implicits
  165. implicit class withMultibandTileFeatureCropMethods[D] extends TileFeatureCropMethods[MultibandTile, D]
    Definition Classes
    Implicits
  166. implicit class withMultibandTileRasterCropMethods extends RasterCropMethods[MultibandTile]
    Definition Classes
    Implicits
  167. implicit class withSinglebandRasterTileFeatureCropMethods[D] extends RasterTileFeatureCropMethods[Tile, D]
    Definition Classes
    Implicits
  168. implicit class withSinglebandTileCropMethods extends SinglebandTileCropMethods
    Definition Classes
    Implicits
  169. implicit class withSinglebandTileFeatureCropMethods[D] extends TileFeatureCropMethods[Tile, D]
    Definition Classes
    Implicits
  170. implicit class withSinglebandTileRasterCropMethods extends RasterCropMethods[Tile]
    Definition Classes
    Implicits
  171. implicit class withDoubleKernelDensityMethods extends DoubleKernelDensityMethods
    Definition Classes
    Implicits
  172. implicit class withIntKernelDensityMethods extends IntKernelDensityMethods
    Definition Classes
    Implicits
  173. implicit class withEuclideanDistanceTileArrayCoordinateMethods extends EuclideanDistanceTileCoordinateArrayMethods
    Definition Classes
    Implicits
  174. implicit class withEuclideanDistanceTileArrayMethods extends EuclideanDistanceTileArrayMethods
    Definition Classes
    Implicits
  175. implicit class withEuclideanDistanceTileCoordinateMethods extends EuclideanDistanceTileCoordinateMethods
    Definition Classes
    Implicits
  176. implicit class withEuclideanDistanceTileMethods extends EuclideanDistanceTileMethods
    Definition Classes
    Implicits
  177. implicit class withEuclideanDistanceTileMultiPointMethods extends EuclideanDistanceTileMultiPointMethods
    Definition Classes
    Implicits
  178. implicit class withMultibandTileEqualizationMethods extends MultibandEqualizationMethods
    Definition Classes
    Implicits
  179. implicit class withTileEqualizationMethods extends SinglebandEqualizationMethods
    Definition Classes
    Implicits
  180. implicit class withTileHydrologyMethods extends HydrologyMethods
    Definition Classes
    Implicits
  181. implicit class withInverseDistanceWeightedMethods[D] extends InverseDistanceWeightedMethods[D]
    Definition Classes
    Implicits
  182. implicit class withKrigingInterpolationMethods extends MethodExtensions[Traversable[PointFeature[Double]]] with SimpleKrigingMethods with OrdinaryKrigingMethods with UniversalKrigingMethods with GeoKrigingMethods
    Definition Classes
    Implicits
  183. implicit class withTileFocalMethods extends FocalMethods
    Definition Classes
    Implicits
  184. implicit class HillshadeTuple extends AnyRef
    Definition Classes
    Implicits
  185. implicit class withTileHillshadeMethods extends HillshadeMethods
    Definition Classes
    Implicits
  186. implicit class withTileLocalMethods extends LocalMethods
    Definition Classes
    Implicits
  187. implicit class withTileSeqLocalMethods extends LocalSeqMethods
    Definition Classes
    Implicits
  188. implicit class withTileZonalMethods extends ZonalMethods
    Definition Classes
    Implicits
  189. implicit class withMultibandRasterMaskMethods extends RasterMaskMethods[MultibandTile]
    Definition Classes
    Implicits
  190. implicit class withMultibandRasterTileFeatureMaskMethods[D] extends RasterTileFeatureMaskMethods[MultibandTile, D]
    Definition Classes
    Implicits
  191. implicit class withMultibandTileFeatureMaskMethods[D] extends TileFeatureMaskMethods[MultibandTile, D]
    Definition Classes
    Implicits
  192. implicit class withMultibandTileMaskMethods extends MultibandTileMaskMethods
    Definition Classes
    Implicits
  193. implicit class withSinglebandRasterMaskMethods extends RasterMaskMethods[Tile]
    Definition Classes
    Implicits
  194. implicit class withSinglebandRasterTileFeatureMaskMethods[D] extends RasterTileFeatureMaskMethods[Tile, D]
    Definition Classes
    Implicits
  195. implicit class withSinglebandTileFeatureMaskMethods[D] extends TileFeatureMaskMethods[Tile, D]
    Definition Classes
    Implicits
  196. implicit class withSinglebandTileMaskMethods extends SinglebandTileMaskMethods
    Definition Classes
    Implicits
  197. implicit class withMultibandTileMatchingMethods extends MultibandMatchingMethods
    Definition Classes
    Implicits
  198. implicit class withTileMatchingMethods extends SinglebandMatchingMethods
    Definition Classes
    Implicits
  199. implicit class withMultibandMergeMethods extends MultibandTileMergeMethods
    Definition Classes
    Implicits
  200. implicit class withMultibandRasterMergeMethod extends RasterMergeMethods[MultibandTile]
    Definition Classes
    Implicits
  201. implicit class withMultibandRasterTileFeatureMergeMethods[D] extends RasterTileFeatureMergeMethods[MultibandTile, D]
    Definition Classes
    Implicits
  202. implicit class withMultibandTileFeatureMergeMethods[D] extends TileFeatureMergeMethods[MultibandTile, D]
    Definition Classes
    Implicits
  203. implicit class withSinglebandMergeMethods extends SinglebandTileMergeMethods
    Definition Classes
    Implicits
  204. implicit class withSinglebandRasterMergeMethod extends RasterMergeMethods[Tile]
    Definition Classes
    Implicits
  205. implicit class withSinglebandRasterTileFeatureMergeMethods[D] extends RasterTileFeatureMergeMethods[Tile, D]
    Definition Classes
    Implicits
  206. implicit class withSinglebandTileFeatureMergeMethods[D] extends TileFeatureMergeMethods[Tile, D]
    Definition Classes
    Implicits
  207. implicit class withMultibandTileFeaturePrototypeMethods[D] extends MultibandTileFeaturePrototypeMethods[D]
    Definition Classes
    Implicits
  208. implicit class withMultibandTilePrototypeMethods extends MultibandTilePrototypeMethods
    Definition Classes
    Implicits
  209. implicit class withSinglebandTileFeaturePrototypeMethods[D] extends SinglebandTileFeaturePrototypeMethods[D]
    Definition Classes
    Implicits
  210. implicit class withSinglebandTilePrototypeMethods extends SinglebandTilePrototypeMethods
    Definition Classes
    Implicits
  211. implicit class withFeatureDoubleRasterizeMethods extends FeatureDoubleRasterizeMethods[Geometry]
    Definition Classes
    Implicits
  212. implicit class withFeatureIntRasterizeMethods extends FeatureIntRasterizeMethods[Geometry]
    Definition Classes
    Implicits
  213. implicit class withGeometryRasterizeMethods extends GeometryRasterizeMethods
    Definition Classes
    Implicits
  214. implicit class withRasterExtentRasterizeMethods extends RasterExtentRasterizeMethods[RasterExtent]
    Definition Classes
    Implicits
  215. implicit class withSinglebandRegionGroupMethdos extends RegionGroupMethods
    Definition Classes
    Implicits
  216. implicit class RGBA extends AnyRef
    Definition Classes
    Implicits
  217. implicit class withMultibandRenderMethods extends MultibandColorMethods with MultibandJpgRenderMethods with MultibandPngRenderMethods
    Definition Classes
    Implicits
  218. implicit class withSinglebandRenderMethods extends ColorMethods with JpgRenderMethods with PngRenderMethods with AsciiRenderMethods
    Definition Classes
    Implicits
  219. implicit class withMultibandProjectedRasterReprojectMethods extends ProjectedRasterReprojectMethods[MultibandTile]
    Definition Classes
    Implicits
  220. implicit class withMultibandRasterReprojectMethods extends MultibandRasterReprojectMethods
    Definition Classes
    Implicits
  221. implicit class withMultibandRasterTileFeatureReprojectMethods[D] extends RasterTileFeatureReprojectMethods[MultibandTile, D]
    Definition Classes
    Implicits
  222. implicit class withMultibandReprojectMethods extends MultibandTileReprojectMethods
    Definition Classes
    Implicits
  223. implicit class withMultibandTileFeatureReprojectMethods[D] extends TileFeatureReprojectMethods[MultibandTile, D]
    Definition Classes
    Implicits
  224. implicit class withSinglebandProjectedRasterReprojectMethods extends ProjectedRasterReprojectMethods[Tile]
    Definition Classes
    Implicits
  225. implicit class withSinglebandRasterReprojectMethods extends SinglebandRasterReprojectMethods
    Definition Classes
    Implicits
  226. implicit class withSinglebandRasterTileFeatureReprojectMethods[D] extends RasterTileFeatureReprojectMethods[Tile, D]
    Definition Classes
    Implicits
  227. implicit class withSinglebandReprojectMethods extends SinglebandTileReprojectMethods
    Definition Classes
    Implicits
  228. implicit class withSinglebandTileFeatureReprojectMethods[D] extends TileFeatureReprojectMethods[Tile, D]
    Definition Classes
    Implicits
  229. implicit class withMultibandRasterResampleMethods extends MultibandRasterResampleMethods
    Definition Classes
    Implicits
  230. implicit class withMultibandResampleMethods extends MultibandTileResampleMethods
    Definition Classes
    Implicits
  231. implicit class withSinglebandRasterResampleMethods extends SinglebandRasterResampleMethods
    Definition Classes
    Implicits
  232. implicit class withSinglebandResampleMethods extends SinglebandTileResampleMethods
    Definition Classes
    Implicits
  233. implicit class withMultibandTileSigmoidalMethods extends MultibandSigmoidalMethods
    Definition Classes
    Implicits
  234. implicit class withSinglebandTileSigmoidalMethods extends SinglebandSigmoidalMethods
    Definition Classes
    Implicits
  235. implicit class withMultibandRasterSplitMethods extends RasterSplitMethods[MultibandTile] with MultibandRasterSplitMethods
    Definition Classes
    Implicits
  236. implicit class withMultibandTileFeatureSplitMethods[D] extends TileFeatureSplitMethods[MultibandTile, D] with MultibandTileFeatureSplitMethods[D]
    Definition Classes
    Implicits
  237. implicit class withMultibandTileSplitMethods[D] extends MultibandTileSplitMethods
    Definition Classes
    Implicits
  238. implicit class withRasterExtentSplitMethods extends RasterExtentSplitMethods
    Definition Classes
    Implicits
  239. implicit class withSinglebandRasterSplitMethods extends RasterSplitMethods[Tile] with SinglebandRasterSplitMethods
    Definition Classes
    Implicits
  240. implicit class withSinglebandTileFeatureSplitMethods[D] extends TileFeatureSplitMethods[Tile, D] with SinglebandTileFeatureSplitMethods[D]
    Definition Classes
    Implicits
  241. implicit class withSinglebandTileSplitMethods[D] extends SinglebandTileSplitMethods
    Definition Classes
    Implicits
  242. implicit class withMultibandSummaryMethods extends MultibandTileSummaryMethods
    Definition Classes
    Implicits
  243. implicit class withSinglebandSummaryMethods extends SinglebandTileSummaryMethods
    Definition Classes
    Implicits
  244. implicit class withMultibandRasterTransformMethods extends RasterTransformMethods[MultibandTile] with MultibandRasterTransformMethods
    Definition Classes
    Implicits
  245. implicit class withMultibandTileTransformTileMethods extends MultibandTileTransformMethods
    Definition Classes
    Implicits
  246. implicit class withSinglebandRasterTransformMethods extends RasterTransformMethods[Tile] with SinglebandRasterTransformMethods
    Definition Classes
    Implicits
  247. implicit class withTileTransformMethods extends TransformTileMethods
    Definition Classes
    Implicits
  248. implicit class withSinglebandRasterVectorizeMethods extends SinglebandRasterVectorizeMethods
    Definition Classes
    Implicits
  249. implicit class withSinglebandVectorizeMethods extends TileVectorizeMethods
    Definition Classes
    Implicits
  250. implicit class withTileViewshedMethods extends ViewshedMethods
    Definition Classes
    Implicits

Value Members

  1. val CellValue: raster.rasterize.CellValue.type
  2. val ColorMap: raster.render.ColorMap.type
  3. val ColorMapOptions: Options.type
  4. val ColorMaps: raster.render.ColorMaps.type
  5. val ColorRamp: raster.render.ColorRamp.type
  6. val ColorRamps: raster.render.ColorRamps.type
  7. val CropOptions: Options.type
  8. val DoubleHistogram: raster.histogram.DoubleHistogram.type
  9. val FastMapHistogram: raster.histogram.FastMapHistogram.type
  10. val IntHistogram: raster.histogram.IntHistogram.type
  11. val JpgSettings: Settings.type
  12. final val NODATA: Int(-2147483648)
  13. val PngColorEncoding: raster.render.png.PngColorEncoding.type
  14. val PngSettings: Settings.type
  15. val RGB: raster.render.RGB.type
  16. val RasterizerOptions: Options.type
  17. val SplitOptions: Options.type
  18. val Stitcher: raster.stitch.Stitcher.type
  19. val StreamingHistogram: raster.histogram.StreamingHistogram.type
  20. val TargetCell: raster.mapalgebra.focal.TargetCell.type
  21. val ZFactor: raster.mapalgebra.focal.ZFactor.type
  22. macro def b2d(n: Byte): Double
  23. macro def b2f(n: Byte): Float
  24. macro def b2i(n: Byte): Int
  25. macro def b2s(n: Byte): Short
  26. macro def b2ub(n: Byte): Byte
  27. macro def b2us(n: Byte): Short
  28. final val byteNODATA: Byte(-128)
  29. implicit val cellTypeDecoder: Decoder[CellType]
    Definition Classes
    Implicits
  30. implicit val cellTypeEncoder: Encoder[CellType]
    Definition Classes
    Implicits
  31. macro def d2b(n: Double): Byte
  32. macro def d2f(n: Double): Float
  33. macro def d2i(n: Double): Int
  34. macro def d2s(n: Double): Short
  35. macro def d2ub(n: Double): Byte
  36. macro def d2us(n: Double): Short
  37. final val doubleNODATA: Double(NaN)
  38. macro def f2b(n: Float): Byte
  39. macro def f2d(n: Float): Double
  40. macro def f2i(n: Float): Int
  41. macro def f2s(n: Float): Short
  42. macro def f2ub(n: Float): Byte
  43. macro def f2us(n: Float): Short
  44. final val floatNODATA: Float(NaN)
  45. implicit val histogramDoubleDecoder: Decoder[raster.histogram.Histogram[Double]]
    Definition Classes
    HistogramJsonFormats
  46. implicit val histogramDoubleEncoder: Encoder[raster.histogram.Histogram[Double]]
    Definition Classes
    HistogramJsonFormats
  47. implicit val histogramIntDecoder: Decoder[raster.histogram.Histogram[Int]]
    Definition Classes
    HistogramJsonFormats
  48. implicit val histogramIntEncoder: Encoder[raster.histogram.Histogram[Int]]
    Definition Classes
    HistogramJsonFormats
  49. macro def i2b(n: Int): Byte
  50. macro def i2d(n: Int): Double
  51. macro def i2f(n: Int): Float
  52. macro def i2s(n: Int): Short
  53. macro def i2ub(n: Int): Byte
  54. macro def i2us(n: Int): Short
  55. macro def isData(d: Double): Boolean
  56. macro def isData(f: Float): Boolean
  57. macro def isData(i: Int): Boolean
  58. macro def isNoData(d: Double): Boolean
  59. macro def isNoData(f: Float): Boolean
  60. macro def isNoData(i: Int): Boolean
  61. implicit def rasterHasRasterExtent[T <: CellGrid[Int]]: GetComponent[Raster[T], RasterExtent]
    Definition Classes
    Implicits
  62. macro def s2b(n: Short): Byte
  63. macro def s2d(n: Short): Double
  64. macro def s2f(n: Short): Float
  65. macro def s2i(n: Short): Int
  66. macro def s2ub(n: Short): Byte
  67. macro def s2us(n: Short): Short
  68. final val shortNODATA: Short(-32768)
  69. implicit val streamingHistogramDecoder: Decoder[raster.histogram.StreamingHistogram]
    Definition Classes
    HistogramJsonFormats
  70. implicit val streamingHistogramEncoder: Encoder[raster.histogram.StreamingHistogram]
    Definition Classes
    HistogramJsonFormats
  71. macro def ub2b(n: Byte): Byte
  72. macro def ub2d(n: Byte): Double
  73. macro def ub2f(n: Byte): Float
  74. macro def ub2i(n: Byte): Int
  75. macro def ub2s(n: Byte): Short
  76. macro def ub2us(n: Byte): Short
  77. final val ubyteNODATA: Byte
  78. macro def us2b(n: Short): Byte
  79. macro def us2d(n: Short): Double
  80. macro def us2f(n: Short): Float
  81. macro def us2i(n: Short): Int
  82. macro def us2s(n: Short): Short
  83. macro def us2ub(n: Short): Byte
  84. final val ushortNODATA: Short
  85. object ArrayMultibandTile extends Serializable

    The companion object for the ArrayMultibandTile type.

  86. object ArrayTile extends Serializable

    An object housing apply methods which produce ArrayTiles.

  87. object BitArrayTile extends Serializable

    The companion object for the BitArrayTile type.

  88. object BitCellType extends DataType with BitCells with NoNoData with Product with Serializable

    The BitCellType type, derived from BitCells and NoNoData.

  89. object BitConstantTile extends Serializable

    The companion object for the BitConstantTile type.

  90. object BufferTile extends Serializable
  91. object ByteArrayTile extends Serializable

    The companion object for the ByteArrayTile type.

  92. object ByteCellType extends DataType with ByteCells with NoNoData with Product with Serializable
  93. object ByteCells extends Serializable
  94. object ByteConstantNoDataCellType extends DataType with ByteCells with ConstantNoData[Byte] with Product with Serializable
  95. object ByteConstantTile extends Serializable
  96. object CellFeatures
  97. object CellSize extends Serializable

    The companion object for the CellSize type.

  98. object CellType
  99. object CellTypeEncoding

    Enumeration of tokens used to represent the different types of cell encodings and their associated no-data values in GeoTrellis.

    Enumeration of tokens used to represent the different types of cell encodings and their associated no-data values in GeoTrellis. Used primarily for serialization to/from String, and pattern-matching operations.

  100. object CompositeTile extends Serializable

    The companion object for the CompositeTile type.

  101. object ConstantTile extends Serializable
  102. object CroppedTile extends Serializable

    The companion object for the CroppedTile type.

  103. object DefaultTarget extends ResampleTarget with Product with Serializable

    The default resample target is used during reprojection.

    The default resample target is used during reprojection. A heuristic will be used to determine the best target proportions

    Note

    If used as target of resample operation it acts as identity operation.

  104. object Dimensions extends Serializable
  105. object DoubleArrayTile extends Serializable

    The companion object for the DoubleArrayTile type.

  106. object DoubleCellType extends DataType with DoubleCells with NoNoData with Product with Serializable
  107. object DoubleCells extends Serializable
  108. object DoubleConstantNoDataCellType extends DataType with DoubleCells with ConstantNoData[Double] with Product with Serializable
  109. object DoubleConstantTile extends Serializable
  110. object EightNeighbors extends Connectivity with Product with Serializable

    Eight-way connectivity.

  111. object EmptyName extends SourceName with Product with Serializable
  112. object FloatArrayTile extends Serializable

    The companion object for the FloatArrayTile type.

  113. object FloatCellType extends DataType with FloatCells with NoNoData with Product with Serializable
  114. object FloatCells extends Serializable
  115. object FloatConstantNoDataCellType extends DataType with FloatCells with ConstantNoData[Float] with Product with Serializable
  116. object FloatConstantTile extends Serializable
  117. object FourNeighbors extends Connectivity with Product with Serializable

    Four-way connectivity.

  118. object GenericRasterBench
  119. object GeoAttrsError extends Serializable
  120. object GridBounds extends Serializable

    The companion object for the GridBounds type.

  121. object GridExtent extends Serializable
  122. object Implicits extends Implicits
  123. object IntArrayTile extends Serializable

    The companion object for the IntArray type.

  124. object IntCellType extends DataType with IntCells with NoNoData with Product with Serializable
  125. object IntCells extends Serializable
  126. object IntConstantNoDataCellType extends DataType with IntCells with ConstantNoData[Int] with Product with Serializable
  127. object IntConstantTile extends Serializable
  128. object MosaicRasterSource extends Serializable
  129. object MultibandTile extends Serializable
  130. object Neighborhoods
  131. object PixelInterleaveBandArrayTile extends Serializable
  132. object PixelIsArea extends PixelSampleType with Product with Serializable

    Type encoding the fact that pixels should be treated as suitably-tiny extents.

  133. object PixelIsPoint extends PixelSampleType with Product with Serializable

    Type encoding the fact that pixels should be treated as points.

  134. object ProjectedRaster extends Serializable

    The companion object for the ProjectedRaster type.

  135. object ProjectedRasterExtent extends Serializable
  136. object Raster extends Serializable

    The companion object for the Raster type.

  137. object RasterExtent extends Serializable

    The companion object for the RasterExtent type.

  138. object RasterRegion extends Serializable
  139. object RasterSource extends Serializable
  140. object RawArrayTile

    An object housing apply methods which produce RawArrayTiles.

  141. object ReadingSource extends Serializable
  142. object ResampleMethods
  143. object ResampleTarget
  144. object ShortArrayTile extends Serializable

    The companion object associated with the ShortArrayTile type.

  145. object ShortCellType extends DataType with ShortCells with NoNoData with Product with Serializable
  146. object ShortCells extends Serializable
  147. object ShortConstantNoDataCellType extends DataType with ShortCells with ConstantNoData[Short] with Product with Serializable
  148. object ShortConstantTile extends Serializable
  149. object SourceName extends Serializable
  150. object TileFeature extends Serializable
  151. object TileLayout extends Serializable

    The companion object associated with the TileLayout type.

  152. object TileOrMultibandTile
  153. object UByteArrayTile extends Serializable

    The companion object for the UByteArrayTile type.

  154. object UByteCellType extends DataType with UByteCells with NoNoData with Product with Serializable
  155. object UByteCells extends Serializable
  156. object UByteConstantNoDataCellType extends DataType with UByteCells with ConstantNoData[Byte] with Product with Serializable
  157. object UByteConstantTile extends Serializable
  158. object UShortArrayTile extends Serializable

    The companion object associated with the UShortArrayTile type.

  159. object UShortCellType extends DataType with UShortCells with NoNoData with Product with Serializable
  160. object UShortCells extends Serializable
  161. object UShortConstantNoDataCellType extends DataType with UShortCells with ConstantNoData[Short] with Product with Serializable
  162. object UShortConstantTile extends Serializable
  163. object WideIntNoData extends Serializable

Ungrouped