package raster
- Alphabetic
- By Inheritance
- raster
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- HistogramJsonFormats
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- Implicits
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Type Members
-
class
ArrayMultibandTile extends MultibandTile with MacroMultibandCombiners
The ArrayMultibandTile type.
-
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.
-
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.
- sealed trait BitCells extends DataType
-
case class
BitConstantTile(v: Boolean, cols: Int, rows: Int) extends ConstantTile with Product with Serializable
The BitConstantTile type.
-
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.
- implicit final class ByteArrayFiller extends AnyVal
-
abstract
class
ByteArrayTile extends MutableArrayTile
ArrayTile based on Array[Byte] (each cell as a Byte).
- sealed trait ByteCells extends DataType
-
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
-
case class
ByteConstantTile(v: Byte, cols: Int, rows: Int, cellType: ByteCells with NoDataHandling = ByteConstantNoDataCellType) extends ConstantTile with Product with Serializable
The ByteConstantTile type.
-
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
-
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
- case class ByteUserDefinedNoDataCellType(noDataValue: Byte) extends DataType with ByteCells with UserDefinedNoData[Byte] with Product with Serializable
-
trait
CellFeatures[R, D] extends AnyRef
Type class to convert a raster into features of cell geometries
-
abstract
class
CellGrid[N] extends GridIntegral[N]
A grid composed of cells with specific value types
-
trait
CellSet extends AnyRef
A lighweight wrapper around performing foreach calculations on a set of cell coordinates
-
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
- type CellType = DataType with NoDataHandling
-
class
CellTypeEncodingBench extends AnyRef
- Annotations
- @BenchmarkMode() @State() @OutputTimeUnit()
- type ColorMap = raster.render.ColorMap
-
case class
CompositeTile(tiles: Seq[Tile], tileLayout: TileLayout) extends Tile with Product with Serializable
The CompositeTile type.
-
sealed
trait
Connectivity extends AnyRef
An encoding of the connectivity of vector tiles.
-
sealed
trait
ConstantNoData[T] extends HasNoData[T]
The ConstantNoData type, derived from NoDataHandling.
-
abstract
class
ConstantTile extends Tile
The trait underlying constant tile types.
- case class ConvertTargetCellType(cellType: CellType) extends TargetCellType with Product with Serializable
-
case class
CroppedTile(sourceTile: Tile, gridBounds: GridBounds[Int]) extends Tile with Product with Serializable
The CroppedTile type.
- type DI = DummyImplicit
-
sealed abstract
class
DataType extends Serializable
The DataType type.
-
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.
- trait DelayedConversionMultibandTileMethods extends MethodExtensions[MultibandTile]
-
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.
- trait DelayedConversionTileMethods extends MethodExtensions[Tile]
-
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
- case class Dimensions[N](cols: N, rows: N)(implicit evidence$1: Integral[N]) extends Product2[N, N] with Serializable with Product
- implicit final class DoubleArrayFiller extends AnyVal
-
abstract
class
DoubleArrayTile extends MutableArrayTile
ArrayTile based on Array[Double] (each cell as a Double).
-
sealed
trait
DoubleCells extends DataType
The DoubleCells type, derived from DataType
-
final
case class
DoubleConstantNoDataArrayTile(arr: Array[Double], cols: Int, rows: Int) extends DoubleArrayTile with Product with Serializable
The DoubleConstantNoDataArrayTile, derived from DoubleArrayTile.
-
case class
DoubleConstantTile(v: Double, cols: Int, rows: Int, cellType: DoubleCells with NoDataHandling = DoubleConstantNoDataCellType) extends ConstantTile with Product with Serializable
The DoubleConstantTile type.
-
final
case class
DoubleRawArrayTile(arr: Array[Double], cols: Int, rows: Int) extends DoubleArrayTile with Product with Serializable
The DoubleRawArrayTile, derived from DoubleArrayTile.
- type DoubleTileMapper = macros.DoubleTileMapper
- type DoubleTileVisitor = macros.DoubleTileVisitor
-
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.
- case class DoubleUserDefinedNoDataCellType(noDataValue: Double) extends DataType with DoubleCells with UserDefinedNoData[Double] with Product with Serializable
- type FastMapHistogram = raster.histogram.FastMapHistogram
-
sealed
trait
FixedNoDataEncoding extends raster.CellTypeEncoding.CellTypeEncoding
Base trait for encoding CellTypes with fixed or no NoData values.
- implicit final class FloatArrayFiller extends AnyVal
-
abstract
class
FloatArrayTile extends MutableArrayTile
ArrayTile based on Array[Float] (each cell as a Float).
- sealed trait FloatCells extends DataType
-
final
case class
FloatConstantNoDataArrayTile(arr: Array[Float], cols: Int, rows: Int) extends FloatArrayTile with Product with Serializable
The FloatConstantNoDataArrayTile derived from FloatArrayTile.
-
case class
FloatConstantTile(v: Float, cols: Int, rows: Int, cellType: FloatCells with NoDataHandling = FloatConstantNoDataCellType) extends ConstantTile with Product with Serializable
The FloatConstantTile type.
-
final
case class
FloatRawArrayTile(arr: Array[Float], cols: Int, rows: Int) extends FloatArrayTile with Product with Serializable
The FloatRawArrayTile derived from FloatArrayTile.
-
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.
- case class FloatUserDefinedNoDataCellType(noDataValue: Float) extends DataType with FloatCells with UserDefinedNoData[Float] with Product with Serializable
-
class
GenericRasterBench extends AnyRef
- Annotations
- @BenchmarkMode() @State()
-
case class
GeoAttrsError(msg: String) extends Exception with Product with Serializable
GeoAttrsError exception.
- trait Grid[N] extends Serializable
-
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.
-
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()
-
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).
- abstract class GridIntegral[N] extends Grid[N]
-
sealed
trait
HasNoData[T] extends NoDataHandling
Base trait for all cell type having a
NoData
value - type Histogram[T <: AnyVal] = raster.histogram.Histogram[T]
- 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
-
implicit
class
SinglebandRasterAnyRefMethods extends AnyRef
- Definition Classes
- Implicits
-
implicit
class
TilePercentileExtensions extends AnyRef
- Definition Classes
- Implicits
-
implicit
class
TileTupleExtensions extends AnyRef
- Definition Classes
- Implicits
-
implicit
class
TraversableTileExtensions extends AnyRef
- Definition Classes
- Implicits
-
implicit
class
withCellFeaturesMethods[R] extends Methods[R]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileMethods extends MethodExtensions[MultibandTile] with DelayedConversionMultibandTileMethods
- Definition Classes
- Implicits
-
implicit
class
withTileMethods extends MethodExtensions[Tile] with DelayedConversionTileMethods
- Definition Classes
- Implicits
- implicit final class IntArrayFiller extends AnyVal
-
abstract
class
IntArrayTile extends MutableArrayTile
ArrayTile based on Array[Int] (each cell as an Int).
- sealed trait IntCells extends DataType
-
final
case class
IntConstantNoDataArrayTile(arr: Array[Int], cols: Int, rows: Int) extends IntArrayTile with Product with Serializable
The IntConstantNoDataArrayTile derived from IntArrayTile.
-
case class
IntConstantTile(v: Int, cols: Int, rows: Int, cellType: IntCells with NoDataHandling = IntConstantNoDataCellType) extends ConstantTile with Product with Serializable
The IntConstantTile type.
-
final
case class
IntRawArrayTile(arr: Array[Int], cols: Int, rows: Int) extends IntArrayTile with Product with Serializable
The IntRawArrayTile derived from IntArrayTile.
- type IntTileMapper = macros.IntTileMapper
- type IntTileVisitor = macros.IntTileVisitor
-
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.
- case class IntUserDefinedNoDataCellType(noDataValue: Int) extends DataType with IntCells with UserDefinedNoData[Int] with Product with Serializable
- case class InterpretAsTargetCellType(cellType: CellType) extends TargetCellType with Product with Serializable
-
trait
IterableTile extends MacroIterableTile
Trait to supply foreach(|Double) methods.
- trait MacroGeotiffMultibandCombiners extends AnyRef
- trait MacroMultibandCombiners extends AnyRef
-
trait
MappableTile[T <: MappableTile[T]] extends MacroMappableTile[T]
The MappableTile trait.
- 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
-
abstract
class
MosaicRasterSource extends RasterSource
Single threaded instance of a reader for reading windows out of collections of rasters
- type MultibandRaster = Raster[MultibandTile]
- abstract class MultibandTile extends CellGrid[Int] with MacroCombinableMultibandTile[Tile] with MacroCombineFunctions[Tile, MultibandTile]
-
abstract
class
MutableArrayTile extends ArrayTile
MutableArrayTile is an ArrayTile whose cells can be written to (mutated).
- type MutableHistogram[T <: AnyVal] = raster.histogram.MutableHistogram[T]
- type Neighborhood = raster.mapalgebra.focal.Neighborhood
-
sealed
trait
NoDataHandling extends AnyRef
Base trait for all cell types associated with handling
NoData
values or not. -
sealed
trait
NoNoData extends NoDataHandling
Base trait for all "raw" cell types, not having a
NoData
value. - case class PaddedTile(chunk: Tile, colOffset: Int, rowOffset: Int, cols: Int, rows: Int) extends Tile with Product with Serializable
-
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.
-
sealed abstract
class
PixelSampleType extends AnyRef
The base class for the two concrete PixelSampleTypes.
-
case class
ProjectedRaster[T <: CellGrid[Int]](raster: Raster[T], crs: CRS) extends Product with Serializable
The ProjectedRaster type.
- class ProjectedRasterExtent extends RasterExtent
-
trait
ProjectedRasterLike extends AnyRef
Conformance interface for entities that are tile-like with a projected extent.
-
case class
Raster[+T <: CellGrid[Int]](tile: T, extent: Extent) extends CellGrid[Int] with Product2[T, Extent] with Product with Serializable
The Raster type.
-
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.
- trait RasterMetadata extends Serializable
-
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.
-
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
- trait RasterSourceProvider extends AnyRef
- case class ReadingSource(source: RasterSource, sourceToTargetBand: Map[Int, Int]) extends Serializable with Product
- type ResampleMethod = raster.resample.ResampleMethod
-
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.
-
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
- implicit final class ShortArrayFiller extends AnyVal
-
abstract
class
ShortArrayTile extends MutableArrayTile
ArrayTile based on Array[Short] (each cell as a Short).
-
sealed
trait
ShortCells extends DataType
The ShortCells type, derived from DataType
-
final
case class
ShortConstantNoDataArrayTile(arr: Array[Short], cols: Int, rows: Int) extends ShortArrayTile with Product with Serializable
ShortConstantNoDataArrayTile derived from ShortArrayTile.
-
case class
ShortConstantTile(v: Short, cols: Int, rows: Int, cellType: ShortCells with NoDataHandling = ShortConstantNoDataCellType) extends ConstantTile with Product with Serializable
The ShortConstantTile type.
-
final
case class
ShortRawArrayTile(arr: Array[Short], cols: Int, rows: Int) extends ShortArrayTile with Product with Serializable
ShortRawArrayTile derived from ShortArrayTile.
-
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.
- case class ShortUserDefinedNoDataCellType(noDataValue: Short) extends DataType with ShortCells with UserDefinedNoData[Short] with Product with Serializable
- type SinglebandRaster = Raster[Tile]
-
trait
SourceName extends Serializable
Represents the path to data or name of the data that is to be read.
-
trait
SourcePath extends SourceName
Represents the path to data that is to be read.
-
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.
- type StreamingHistogram = raster.histogram.StreamingHistogram
- case class StringName(value: String) extends SourceName with Product with Serializable
-
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
- type TargetCell = raster.mapalgebra.focal.TargetCell
-
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.
- sealed trait TargetCellType extends AnyRef
-
case class
TargetDimensions(cols: Long, rows: Long) extends ResampleTarget with Product with Serializable
Resample, aiming for a specific number of cell columns/rows
-
case class
TargetRegion(region: GridExtent[_]) extends ResampleTarget with Product with Serializable
Resample, sampling values into a user-supplied GridExtent
-
abstract
class
Tile extends CellGrid[Int] with IterableTile with MappableTile[Tile]
Base trait for a Tile.
-
case class
TileExtents(extent: Extent, tileLayout: TileLayout) extends Product with Serializable
The TileExtents type.
-
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
-
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
- sealed class TileOrMultibandTile[T] extends AnyRef
-
abstract
class
UByteArrayTile extends MutableArrayTile
ArrayTile based on Array[Byte] (each cell as a Byte).
-
sealed
trait
UByteCells extends DataType
The UByteCells type, derived from DataType
-
final
case class
UByteConstantNoDataArrayTile(arr: Array[Byte], cols: Int, rows: Int) extends UByteArrayTile with Product with Serializable
UByteConstantNoDataArrayTile derived from UByteArrayTile.
-
case class
UByteConstantTile(v: Byte, cols: Int, rows: Int, cellType: UByteCells with NoDataHandling = UByteConstantNoDataCellType) extends ConstantTile with Product with Serializable
The UByteConstantTile type.
-
final
case class
UByteRawArrayTile(arr: Array[Byte], cols: Int, rows: Int) extends UByteArrayTile with Product with Serializable
UByteRawArrayTile derived from UByteArrayTile.
-
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.
- case class UByteUserDefinedNoDataCellType(noDataValue: Byte) extends DataType with UByteCells with UserDefinedNoData[Byte] with Product with Serializable
-
abstract
class
UShortArrayTile extends MutableArrayTile
ArrayTile based on Array[Short] (each cell as a Short).
-
sealed
trait
UShortCells extends DataType
The UShortCells type, derived from DataType
-
class
UShortConstantNoDataArrayTile extends UShortArrayTile
UShortConstantNoDataArrayTile derived from UShortArrayTile.
-
case class
UShortConstantTile(v: Short, cols: Int, rows: Int, cellType: UShortCells with NoDataHandling = UShortConstantNoDataCellType) extends ConstantTile with Product with Serializable
The UShortConstantTile type.
-
class
UShortRawArrayTile extends UShortArrayTile
UShortRawArrayTile derived from UShortArrayTile.
-
class
UShortUserDefinedNoDataArrayTile extends UShortArrayTile with UserDefinedShortNoDataConversions
UShortUserDefinedNoDataArrayTile derived from UShortArrayTile.
- case class UShortUserDefinedNoDataCellType(noDataValue: Short) extends DataType with UShortCells with UserDefinedNoData[Short] with Product with Serializable
- trait UserDefinedByteNoDataConversions extends AnyRef
- trait UserDefinedDoubleNoDataConversions extends AnyRef
- trait UserDefinedFloatNoDataConversions extends AnyRef
- trait UserDefinedIntNoDataConversions extends AnyRef
-
sealed
trait
UserDefinedNoData[T] extends HasNoData[T]
The UserDefinedNoData type, derived from NoDataHandling.
-
sealed
trait
UserDefinedNoDataEncoding extends raster.CellTypeEncoding.CellTypeEncoding
Base trait for encoding CellTypes with user defined NoData values.
- trait UserDefinedShortNoDataConversions extends AnyRef
-
case class
WideDoubleNoData(asDouble: Double) extends WidenedNoData with Product with Serializable
NoData stored as a Double
-
case class
WideIntNoData(asInt: Int) extends WidenedNoData with Product with Serializable
NoData value stored as an Int.
-
sealed
trait
WidenedNoData extends AnyRef
Container for NoData value using wider word size than declared to handled unsigned number rollover.
-
implicit
class
withTileCostDistanceMethods extends CostDistanceMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterTileFeatureCropMethods[D] extends RasterTileFeatureCropMethods[MultibandTile, D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileCropMethods extends MultibandTileCropMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileFeatureCropMethods[D] extends TileFeatureCropMethods[MultibandTile, D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileRasterCropMethods extends RasterCropMethods[MultibandTile]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterTileFeatureCropMethods[D] extends RasterTileFeatureCropMethods[Tile, D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileCropMethods extends SinglebandTileCropMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileFeatureCropMethods[D] extends TileFeatureCropMethods[Tile, D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileRasterCropMethods extends RasterCropMethods[Tile]
- Definition Classes
- Implicits
-
implicit
class
withDoubleKernelDensityMethods extends DoubleKernelDensityMethods
- Definition Classes
- Implicits
-
implicit
class
withIntKernelDensityMethods extends IntKernelDensityMethods
- Definition Classes
- Implicits
-
implicit
class
withEuclideanDistanceTileArrayCoordinateMethods extends EuclideanDistanceTileCoordinateArrayMethods
- Definition Classes
- Implicits
-
implicit
class
withEuclideanDistanceTileArrayMethods extends EuclideanDistanceTileArrayMethods
- Definition Classes
- Implicits
-
implicit
class
withEuclideanDistanceTileCoordinateMethods extends EuclideanDistanceTileCoordinateMethods
- Definition Classes
- Implicits
-
implicit
class
withEuclideanDistanceTileMethods extends EuclideanDistanceTileMethods
- Definition Classes
- Implicits
-
implicit
class
withEuclideanDistanceTileMultiPointMethods extends EuclideanDistanceTileMultiPointMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileEqualizationMethods extends MultibandEqualizationMethods
- Definition Classes
- Implicits
-
implicit
class
withTileEqualizationMethods extends SinglebandEqualizationMethods
- Definition Classes
- Implicits
-
implicit
class
withTileHydrologyMethods extends HydrologyMethods
- Definition Classes
- Implicits
-
implicit
class
withInverseDistanceWeightedMethods[D] extends InverseDistanceWeightedMethods[D]
- Definition Classes
- Implicits
-
implicit
class
withKrigingInterpolationMethods extends MethodExtensions[Traversable[PointFeature[Double]]] with SimpleKrigingMethods with OrdinaryKrigingMethods with UniversalKrigingMethods with GeoKrigingMethods
- Definition Classes
- Implicits
-
implicit
class
withTileFocalMethods extends FocalMethods
- Definition Classes
- Implicits
-
implicit
class
HillshadeTuple extends AnyRef
- Definition Classes
- Implicits
-
implicit
class
withTileHillshadeMethods extends HillshadeMethods
- Definition Classes
- Implicits
-
implicit
class
withTileLocalMethods extends LocalMethods
- Definition Classes
- Implicits
-
implicit
class
withTileSeqLocalMethods extends LocalSeqMethods
- Definition Classes
- Implicits
-
implicit
class
withTileZonalMethods extends ZonalMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterMaskMethods extends RasterMaskMethods[MultibandTile]
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterTileFeatureMaskMethods[D] extends RasterTileFeatureMaskMethods[MultibandTile, D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileFeatureMaskMethods[D] extends TileFeatureMaskMethods[MultibandTile, D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileMaskMethods extends MultibandTileMaskMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterMaskMethods extends RasterMaskMethods[Tile]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterTileFeatureMaskMethods[D] extends RasterTileFeatureMaskMethods[Tile, D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileFeatureMaskMethods[D] extends TileFeatureMaskMethods[Tile, D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileMaskMethods extends SinglebandTileMaskMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileMatchingMethods extends MultibandMatchingMethods
- Definition Classes
- Implicits
-
implicit
class
withTileMatchingMethods extends SinglebandMatchingMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandMergeMethods extends MultibandTileMergeMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterMergeMethod extends RasterMergeMethods[MultibandTile]
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterTileFeatureMergeMethods[D] extends RasterTileFeatureMergeMethods[MultibandTile, D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileFeatureMergeMethods[D] extends TileFeatureMergeMethods[MultibandTile, D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandMergeMethods extends SinglebandTileMergeMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterMergeMethod extends RasterMergeMethods[Tile]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterTileFeatureMergeMethods[D] extends RasterTileFeatureMergeMethods[Tile, D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileFeatureMergeMethods[D] extends TileFeatureMergeMethods[Tile, D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileFeaturePrototypeMethods[D] extends MultibandTileFeaturePrototypeMethods[D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTilePrototypeMethods extends MultibandTilePrototypeMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileFeaturePrototypeMethods[D] extends SinglebandTileFeaturePrototypeMethods[D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTilePrototypeMethods extends SinglebandTilePrototypeMethods
- Definition Classes
- Implicits
-
implicit
class
withFeatureDoubleRasterizeMethods extends FeatureDoubleRasterizeMethods[Geometry]
- Definition Classes
- Implicits
-
implicit
class
withFeatureIntRasterizeMethods extends FeatureIntRasterizeMethods[Geometry]
- Definition Classes
- Implicits
-
implicit
class
withGeometryRasterizeMethods extends GeometryRasterizeMethods
- Definition Classes
- Implicits
-
implicit
class
withRasterExtentRasterizeMethods extends RasterExtentRasterizeMethods[RasterExtent]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRegionGroupMethdos extends RegionGroupMethods
- Definition Classes
- Implicits
-
implicit
class
RGBA extends AnyRef
- Definition Classes
- Implicits
-
implicit
class
withMultibandRenderMethods extends MultibandColorMethods with MultibandJpgRenderMethods with MultibandPngRenderMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRenderMethods extends ColorMethods with JpgRenderMethods with PngRenderMethods with AsciiRenderMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandProjectedRasterReprojectMethods extends ProjectedRasterReprojectMethods[MultibandTile]
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterReprojectMethods extends MultibandRasterReprojectMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterTileFeatureReprojectMethods[D] extends RasterTileFeatureReprojectMethods[MultibandTile, D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandReprojectMethods extends MultibandTileReprojectMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileFeatureReprojectMethods[D] extends TileFeatureReprojectMethods[MultibandTile, D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandProjectedRasterReprojectMethods extends ProjectedRasterReprojectMethods[Tile]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterReprojectMethods extends SinglebandRasterReprojectMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterTileFeatureReprojectMethods[D] extends RasterTileFeatureReprojectMethods[Tile, D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandReprojectMethods extends SinglebandTileReprojectMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileFeatureReprojectMethods[D] extends TileFeatureReprojectMethods[Tile, D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterResampleMethods extends MultibandRasterResampleMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandResampleMethods extends MultibandTileResampleMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterResampleMethods extends SinglebandRasterResampleMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandResampleMethods extends SinglebandTileResampleMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileSigmoidalMethods extends MultibandSigmoidalMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileSigmoidalMethods extends SinglebandSigmoidalMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterSplitMethods extends RasterSplitMethods[MultibandTile] with MultibandRasterSplitMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileFeatureSplitMethods[D] extends TileFeatureSplitMethods[MultibandTile, D] with MultibandTileFeatureSplitMethods[D]
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileSplitMethods[D] extends MultibandTileSplitMethods
- Definition Classes
- Implicits
-
implicit
class
withRasterExtentSplitMethods extends RasterExtentSplitMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterSplitMethods extends RasterSplitMethods[Tile] with SinglebandRasterSplitMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileFeatureSplitMethods[D] extends TileFeatureSplitMethods[Tile, D] with SinglebandTileFeatureSplitMethods[D]
- Definition Classes
- Implicits
-
implicit
class
withSinglebandTileSplitMethods[D] extends SinglebandTileSplitMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandSummaryMethods extends MultibandTileSummaryMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandSummaryMethods extends SinglebandTileSummaryMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandRasterTransformMethods extends RasterTransformMethods[MultibandTile] with MultibandRasterTransformMethods
- Definition Classes
- Implicits
-
implicit
class
withMultibandTileTransformTileMethods extends MultibandTileTransformMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterTransformMethods extends RasterTransformMethods[Tile] with SinglebandRasterTransformMethods
- Definition Classes
- Implicits
-
implicit
class
withTileTransformMethods extends TransformTileMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandRasterVectorizeMethods extends SinglebandRasterVectorizeMethods
- Definition Classes
- Implicits
-
implicit
class
withSinglebandVectorizeMethods extends TileVectorizeMethods
- Definition Classes
- Implicits
-
implicit
class
withTileViewshedMethods extends ViewshedMethods
- Definition Classes
- Implicits
Value Members
- val CellValue: raster.rasterize.CellValue.type
- val ColorMap: raster.render.ColorMap.type
- val ColorMapOptions: Options.type
- val ColorMaps: raster.render.ColorMaps.type
- val ColorRamp: raster.render.ColorRamp.type
- val ColorRamps: raster.render.ColorRamps.type
- val CropOptions: Options.type
- val DoubleHistogram: raster.histogram.DoubleHistogram.type
- val FastMapHistogram: raster.histogram.FastMapHistogram.type
- val IntHistogram: raster.histogram.IntHistogram.type
- val JpgSettings: Settings.type
- final val NODATA: Int(-2147483648)
- val PngColorEncoding: raster.render.png.PngColorEncoding.type
- val PngSettings: Settings.type
- val RGB: raster.render.RGB.type
- val RasterizerOptions: Options.type
- val SplitOptions: Options.type
- val Stitcher: raster.stitch.Stitcher.type
- val StreamingHistogram: raster.histogram.StreamingHistogram.type
- val TargetCell: raster.mapalgebra.focal.TargetCell.type
- val ZFactor: raster.mapalgebra.focal.ZFactor.type
- macro def b2d(n: Byte): Double
- macro def b2f(n: Byte): Float
- macro def b2i(n: Byte): Int
- macro def b2s(n: Byte): Short
- macro def b2ub(n: Byte): Byte
- macro def b2us(n: Byte): Short
- final val byteNODATA: Byte(-128)
-
implicit
val
cellTypeDecoder: Decoder[CellType]
- Definition Classes
- Implicits
-
implicit
val
cellTypeEncoder: Encoder[CellType]
- Definition Classes
- Implicits
- macro def d2b(n: Double): Byte
- macro def d2f(n: Double): Float
- macro def d2i(n: Double): Int
- macro def d2s(n: Double): Short
- macro def d2ub(n: Double): Byte
- macro def d2us(n: Double): Short
- final val doubleNODATA: Double(NaN)
- macro def f2b(n: Float): Byte
- macro def f2d(n: Float): Double
- macro def f2i(n: Float): Int
- macro def f2s(n: Float): Short
- macro def f2ub(n: Float): Byte
- macro def f2us(n: Float): Short
- final val floatNODATA: Float(NaN)
-
implicit
val
histogramDoubleDecoder: Decoder[raster.histogram.Histogram[Double]]
- Definition Classes
- HistogramJsonFormats
-
implicit
val
histogramDoubleEncoder: Encoder[raster.histogram.Histogram[Double]]
- Definition Classes
- HistogramJsonFormats
-
implicit
val
histogramIntDecoder: Decoder[raster.histogram.Histogram[Int]]
- Definition Classes
- HistogramJsonFormats
-
implicit
val
histogramIntEncoder: Encoder[raster.histogram.Histogram[Int]]
- Definition Classes
- HistogramJsonFormats
- macro def i2b(n: Int): Byte
- macro def i2d(n: Int): Double
- macro def i2f(n: Int): Float
- macro def i2s(n: Int): Short
- macro def i2ub(n: Int): Byte
- macro def i2us(n: Int): Short
- macro def isData(d: Double): Boolean
- macro def isData(f: Float): Boolean
- macro def isData(i: Int): Boolean
- macro def isNoData(d: Double): Boolean
- macro def isNoData(f: Float): Boolean
- macro def isNoData(i: Int): Boolean
-
implicit
def
rasterHasRasterExtent[T <: CellGrid[Int]]: GetComponent[Raster[T], RasterExtent]
- Definition Classes
- Implicits
- macro def s2b(n: Short): Byte
- macro def s2d(n: Short): Double
- macro def s2f(n: Short): Float
- macro def s2i(n: Short): Int
- macro def s2ub(n: Short): Byte
- macro def s2us(n: Short): Short
- final val shortNODATA: Short(-32768)
-
implicit
val
streamingHistogramDecoder: Decoder[raster.histogram.StreamingHistogram]
- Definition Classes
- HistogramJsonFormats
-
implicit
val
streamingHistogramEncoder: Encoder[raster.histogram.StreamingHistogram]
- Definition Classes
- HistogramJsonFormats
- macro def ub2b(n: Byte): Byte
- macro def ub2d(n: Byte): Double
- macro def ub2f(n: Byte): Float
- macro def ub2i(n: Byte): Int
- macro def ub2s(n: Byte): Short
- macro def ub2us(n: Byte): Short
- final val ubyteNODATA: Byte
- macro def us2b(n: Short): Byte
- macro def us2d(n: Short): Double
- macro def us2f(n: Short): Float
- macro def us2i(n: Short): Int
- macro def us2s(n: Short): Short
- macro def us2ub(n: Short): Byte
- final val ushortNODATA: Short
-
object
ArrayMultibandTile extends Serializable
The companion object for the ArrayMultibandTile type.
-
object
ArrayTile extends Serializable
An object housing apply methods which produce ArrayTiles.
-
object
BitArrayTile extends Serializable
The companion object for the BitArrayTile type.
-
object
BitCellType extends DataType with BitCells with NoNoData with Product with Serializable
The BitCellType type, derived from BitCells and NoNoData.
-
object
BitConstantTile extends Serializable
The companion object for the BitConstantTile type.
- object BufferTile extends Serializable
-
object
ByteArrayTile extends Serializable
The companion object for the ByteArrayTile type.
- object ByteCellType extends DataType with ByteCells with NoNoData with Product with Serializable
- object ByteCells extends Serializable
- object ByteConstantNoDataCellType extends DataType with ByteCells with ConstantNoData[Byte] with Product with Serializable
- object ByteConstantTile extends Serializable
- object CellFeatures
-
object
CellSize extends Serializable
The companion object for the CellSize type.
- object CellType
-
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.
-
object
CompositeTile extends Serializable
The companion object for the CompositeTile type.
- object ConstantTile extends Serializable
-
object
CroppedTile extends Serializable
The companion object for the CroppedTile type.
-
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.
- object Dimensions extends Serializable
-
object
DoubleArrayTile extends Serializable
The companion object for the DoubleArrayTile type.
- object DoubleCellType extends DataType with DoubleCells with NoNoData with Product with Serializable
- object DoubleCells extends Serializable
- object DoubleConstantNoDataCellType extends DataType with DoubleCells with ConstantNoData[Double] with Product with Serializable
- object DoubleConstantTile extends Serializable
-
object
EightNeighbors extends Connectivity with Product with Serializable
Eight-way connectivity.
- object EmptyName extends SourceName with Product with Serializable
-
object
FloatArrayTile extends Serializable
The companion object for the FloatArrayTile type.
- object FloatCellType extends DataType with FloatCells with NoNoData with Product with Serializable
- object FloatCells extends Serializable
- object FloatConstantNoDataCellType extends DataType with FloatCells with ConstantNoData[Float] with Product with Serializable
- object FloatConstantTile extends Serializable
-
object
FourNeighbors extends Connectivity with Product with Serializable
Four-way connectivity.
- object GenericRasterBench
- object GeoAttrsError extends Serializable
-
object
GridBounds extends Serializable
The companion object for the GridBounds type.
- object GridExtent extends Serializable
- object Implicits extends Implicits
-
object
IntArrayTile extends Serializable
The companion object for the IntArray type.
- object IntCellType extends DataType with IntCells with NoNoData with Product with Serializable
- object IntCells extends Serializable
- object IntConstantNoDataCellType extends DataType with IntCells with ConstantNoData[Int] with Product with Serializable
- object IntConstantTile extends Serializable
- object MosaicRasterSource extends Serializable
- object MultibandTile extends Serializable
- object Neighborhoods
- object PixelInterleaveBandArrayTile extends Serializable
-
object
PixelIsArea extends PixelSampleType with Product with Serializable
Type encoding the fact that pixels should be treated as suitably-tiny extents.
-
object
PixelIsPoint extends PixelSampleType with Product with Serializable
Type encoding the fact that pixels should be treated as points.
-
object
ProjectedRaster extends Serializable
The companion object for the ProjectedRaster type.
- object ProjectedRasterExtent extends Serializable
-
object
Raster extends Serializable
The companion object for the Raster type.
-
object
RasterExtent extends Serializable
The companion object for the RasterExtent type.
- object RasterRegion extends Serializable
- object RasterSource extends Serializable
-
object
RawArrayTile
An object housing apply methods which produce RawArrayTiles.
- object ReadingSource extends Serializable
- object ResampleMethods
- object ResampleTarget
-
object
ShortArrayTile extends Serializable
The companion object associated with the ShortArrayTile type.
- object ShortCellType extends DataType with ShortCells with NoNoData with Product with Serializable
- object ShortCells extends Serializable
- object ShortConstantNoDataCellType extends DataType with ShortCells with ConstantNoData[Short] with Product with Serializable
- object ShortConstantTile extends Serializable
- object SourceName extends Serializable
- object TileFeature extends Serializable
-
object
TileLayout extends Serializable
The companion object associated with the TileLayout type.
- object TileOrMultibandTile
-
object
UByteArrayTile extends Serializable
The companion object for the UByteArrayTile type.
- object UByteCellType extends DataType with UByteCells with NoNoData with Product with Serializable
- object UByteCells extends Serializable
- object UByteConstantNoDataCellType extends DataType with UByteCells with ConstantNoData[Byte] with Product with Serializable
- object UByteConstantTile extends Serializable
-
object
UShortArrayTile extends Serializable
The companion object associated with the UShortArrayTile type.
- object UShortCellType extends DataType with UShortCells with NoNoData with Product with Serializable
- object UShortCells extends Serializable
- object UShortConstantNoDataCellType extends DataType with UShortCells with ConstantNoData[Short] with Product with Serializable
- object UShortConstantTile extends Serializable
- object WideIntNoData extends Serializable