dask.array.Array
- class dask.array.Array(dask, name, chunks, dtype=None, meta=None, shape=None)[source]
Parallel Dask Array
A parallel nd-array comprised of many numpy arrays arranged in a grid.
This constructor is for advanced uses only. For normal use see the
dask.array.from_array()
function.- Parameters
- daskdict
Task dependency graph
- namestring
Name of array in dask
- shapetuple of ints
Shape of the entire array
- chunks: iterable of tuples
block sizes along each dimension
- dtypestr or dtype
Typecode or data-type for the new Dask Array
- metaempty ndarray
empty ndarray created with same NumPy backend, ndim and dtype as the Dask Array being created (overrides dtype)
See also
- __init__(*args, **kwargs)
Methods
__init__
(*args, **kwargs)all
([axis, out, keepdims, where])This docstring was copied from numpy.ndarray.all.
any
([axis, out, keepdims, where])This docstring was copied from numpy.ndarray.any.
argmax
([axis, out])This docstring was copied from numpy.ndarray.argmax.
argmin
([axis, out])This docstring was copied from numpy.ndarray.argmin.
argtopk
(k[, axis, split_every])The indices of the top k elements of an array.
astype
(dtype, **kwargs)Copy of the array, cast to a specified type.
choose
(choices[, out, mode])This docstring was copied from numpy.ndarray.choose.
clip
([min, max, out])This docstring was copied from numpy.ndarray.clip.
compute
(**kwargs)Compute this dask collection
Compute the chunk sizes for a Dask array.
conj
()copy
()Copy array.
cumprod
([axis, dtype, out])This docstring was copied from numpy.ndarray.cumprod.
cumsum
([axis, dtype, out])This docstring was copied from numpy.ndarray.cumsum.
dot
(b[, out])This docstring was copied from numpy.ndarray.dot.
flatten
([order])This docstring was copied from numpy.ndarray.ravel.
map_blocks
(*args[, name, token, dtype, ...])Map a function across all blocks of a dask array.
map_overlap
(func, depth[, boundary, trim])Map a function over blocks of the array with some overlap
max
([axis, out, keepdims, initial, where])This docstring was copied from numpy.ndarray.max.
mean
([axis, dtype, out, keepdims, where])This docstring was copied from numpy.ndarray.mean.
min
([axis, out, keepdims, initial, where])This docstring was copied from numpy.ndarray.min.
moment
(order[, axis, dtype, keepdims, ddof, ...])Calculate the nth centralized moment.
nonzero
()This docstring was copied from numpy.ndarray.nonzero.
persist
(**kwargs)Persist this dask collection into memory
prod
([axis, dtype, out, keepdims, initial, ...])This docstring was copied from numpy.ndarray.prod.
ravel
([order])This docstring was copied from numpy.ndarray.ravel.
rechunk
([chunks, threshold, ...])See da.rechunk for docstring
repeat
(repeats[, axis])This docstring was copied from numpy.ndarray.repeat.
reshape
(shape[, order])This docstring was copied from numpy.ndarray.reshape.
round
([decimals, out])This docstring was copied from numpy.ndarray.round.
squeeze
([axis])This docstring was copied from numpy.ndarray.squeeze.
std
([axis, dtype, out, ddof, keepdims, where])This docstring was copied from numpy.ndarray.std.
store
(targets[, lock, regions, compute, ...])Store dask arrays in array-like objects, overwrite data in target
sum
([axis, dtype, out, keepdims, initial, where])This docstring was copied from numpy.ndarray.sum.
swapaxes
(axis1, axis2)This docstring was copied from numpy.ndarray.swapaxes.
to_dask_dataframe
([columns, index, meta])Convert dask Array to dask Dataframe
to_delayed
([optimize_graph])Convert into an array of
dask.delayed.Delayed
objects, one per chunk.to_hdf5
(filename, datapath, **kwargs)Store array in HDF5 file
to_svg
([size])Convert chunks from Dask Array into an SVG Image
to_tiledb
(uri, *args, **kwargs)Save array to the TileDB storage manager
to_zarr
(*args, **kwargs)Save array to the zarr storage format
topk
(k[, axis, split_every])The top k elements of an array.
trace
([offset, axis1, axis2, dtype, out])This docstring was copied from numpy.ndarray.trace.
transpose
(*axes)This docstring was copied from numpy.ndarray.transpose.
var
([axis, dtype, out, ddof, keepdims, where])This docstring was copied from numpy.ndarray.var.
view
([dtype, order])Get a view of the array as a new data type
visualize
([filename, format, optimize_graph])Render the computation of this object's task graph using graphviz.
Attributes
A
T
An array-like interface to the blocks of an array.
Chunks property.
Length of one array element in bytes
Number of bytes in array
Slice an array by partitions.
Number of elements in array
Vectorized indexing with broadcasting.