Skip to content

Commit

Permalink
doc fixes
Browse files Browse the repository at this point in the history
  • Loading branch information
amitmurthy committed Nov 22, 2017
1 parent f94345e commit 6603295
Show file tree
Hide file tree
Showing 9 changed files with 117 additions and 116 deletions.
4 changes: 2 additions & 2 deletions doc/make.jl
Original file line number Diff line number Diff line change
Expand Up @@ -149,11 +149,11 @@ const PAGES = [
],
]

using DelimitedFiles, Test, Mmap, SharedArrays, Profile, Base64, FileWatching, CRC32c
using DelimitedFiles, Test, Mmap, SharedArrays, Profile, Base64, FileWatching, CRC32c, Distributed

makedocs(
build = joinpath(pwd(), "_build/html/en"),
modules = [Base, Core, BuildSysImg, DelimitedFiles, Test, Mmap, SharedArrays, Profile, Base64, FileWatching],
modules = [Base, Core, BuildSysImg, DelimitedFiles, Test, Mmap, SharedArrays, Profile, Base64, FileWatching, Distributed],
clean = false,
doctest = "doctest" in ARGS,
linkcheck = "linkcheck" in ARGS,
Expand Down
6 changes: 4 additions & 2 deletions doc/src/index.md
Original file line number Diff line number Diff line change
Expand Up @@ -49,7 +49,10 @@
* [Numbers](@ref lib-numbers)
* [Strings](@ref lib-strings)
* [Arrays](@ref lib-arrays)
* [Tasks and Parallel Computing](@ref)
* [Tasks](@ref)
* [Distributed Computing](@ref)
* [Multi-Threading](@ref)
* [Shared Arrays](@ref)
* [Linear Algebra](@ref)
* [Constants](@ref lib-constants)
* [Filesystem](@ref)
Expand All @@ -68,7 +71,6 @@
* [SIMD Support](@ref)
* [Profiling](@ref lib-profiling)
* [Memory-mapped I/O](@ref)
* [Shared Arrays](@ref)
* [Base64](@ref)
* [File Events](@ref lib-filewatching)

Expand Down
4 changes: 2 additions & 2 deletions doc/src/manual/parallel-computing.md
Original file line number Diff line number Diff line change
Expand Up @@ -1312,14 +1312,14 @@ requirements for the inbuilt `LocalManager` and `SSHManager`:
All processes in a cluster share the same cookie which, by default, is a randomly generated string
on the master process:

* [`Base.cluster_cookie()`](@ref) returns the cookie, while `Base.cluster_cookie(cookie)()` sets
* [`cluster_cookie()`](@ref) returns the cookie, while `cluster_cookie(cookie)()` sets
it and returns the new cookie.
* All connections are authenticated on both sides to ensure that only workers started by the master
are allowed to connect to each other.
* The cookie may be passed to the workers at startup via argument `--worker=<cookie>`. If argument
`--worker` is specified without the cookie, the worker tries to read the cookie from its
standard input (STDIN). The STDIN is closed immediately after the cookie is retrieved.
* ClusterManagers can retrieve the cookie on the master by calling [`Base.cluster_cookie()`](@ref).
* ClusterManagers can retrieve the cookie on the master by calling [`cluster_cookie()`](@ref).
Cluster managers not using the default TCP/IP transport (and hence not specifying `--worker`)
must call `init_worker(cookie, manager)` with the same cookie as on the master.

Expand Down
1 change: 0 additions & 1 deletion doc/src/stdlib/base.md
Original file line number Diff line number Diff line change
Expand Up @@ -90,7 +90,6 @@ primitive type
```@docs
Base.BLAS
Base.Dates
Base.Distributed
Base.Docs
Base.Iterators
Base.LAPACK
Expand Down
1 change: 1 addition & 0 deletions doc/src/stdlib/distributed.md
6 changes: 4 additions & 2 deletions doc/src/stdlib/index.md
Original file line number Diff line number Diff line change
Expand Up @@ -6,7 +6,10 @@
* [Numbers](@ref lib-numbers)
* [Strings](@ref lib-strings)
* [Arrays](@ref lib-arrays)
* [Tasks and Parallel Computing](@ref)
* [Tasks](@ref)
* [Distributed Computing](@ref)
* [Shared Arrays](@ref)
* [Multi-Threading](@ref)
* [Linear Algebra](@ref)
* [Constants](@ref lib-constants)
* [Filesystem](@ref)
Expand All @@ -26,6 +29,5 @@
* [SIMD Support](@ref)
* [Profiling](@ref lib-profiling)
* [Memory-mapped I/O](@ref)
* [Shared Arrays](@ref)
* [Base64](@ref)
* [File Events](@ref lib-filewatching)
47 changes: 47 additions & 0 deletions doc/src/stdlib/multi-threading.md
Original file line number Diff line number Diff line change
@@ -0,0 +1,47 @@

# Multi-Threading

This experimental interface supports Julia's multi-threading capabilities. Types and functions
described here might (and likely will) change in the future.

```@docs
Base.Threads.threadid
Base.Threads.nthreads
Base.Threads.@threads
Base.Threads.Atomic
Base.Threads.atomic_cas!
Base.Threads.atomic_xchg!
Base.Threads.atomic_add!
Base.Threads.atomic_sub!
Base.Threads.atomic_and!
Base.Threads.atomic_nand!
Base.Threads.atomic_or!
Base.Threads.atomic_xor!
Base.Threads.atomic_max!
Base.Threads.atomic_min!
Base.Threads.atomic_fence
```

## ccall using a threadpool (Experimental)

```@docs
Base.@threadcall
```

## Synchronization Primitives

```@docs
Base.Threads.AbstractLock
Base.lock
Base.unlock
Base.trylock
Base.islocked
Base.ReentrantLock
Base.Threads.Mutex
Base.Threads.SpinLock
Base.Threads.RecursiveSpinLock
Base.Semaphore
Base.acquire
Base.release
```

52 changes: 1 addition & 51 deletions doc/src/stdlib/parallel.md
Original file line number Diff line number Diff line change
@@ -1,6 +1,4 @@
# Tasks and multi-threading

## Tasks
# Tasks

```@docs
Core.Task
Expand Down Expand Up @@ -28,51 +26,3 @@ Base.bind(c::Channel, task::Task)
Base.asyncmap
Base.asyncmap!
```


## Multi-Threading

This experimental interface supports Julia's multi-threading capabilities. Types and functions
described here might (and likely will) change in the future.

```@docs
Base.Threads.threadid
Base.Threads.nthreads
Base.Threads.@threads
Base.Threads.Atomic
Base.Threads.atomic_cas!
Base.Threads.atomic_xchg!
Base.Threads.atomic_add!
Base.Threads.atomic_sub!
Base.Threads.atomic_and!
Base.Threads.atomic_nand!
Base.Threads.atomic_or!
Base.Threads.atomic_xor!
Base.Threads.atomic_max!
Base.Threads.atomic_min!
Base.Threads.atomic_fence
```

## ccall using a threadpool (Experimental)

```@docs
Base.@threadcall
```

## Synchronization Primitives

```@docs
Base.Threads.AbstractLock
Base.lock
Base.unlock
Base.trylock
Base.islocked
Base.ReentrantLock
Base.Threads.Mutex
Base.Threads.SpinLock
Base.Threads.RecursiveSpinLock
Base.Semaphore
Base.acquire
Base.release
```

112 changes: 56 additions & 56 deletions stdlib/Distributed/docs/src/index.md
Original file line number Diff line number Diff line change
@@ -1,55 +1,55 @@
# Distributed Computing

```@docs
Base.addprocs
Base.nprocs
Base.nworkers
Base.procs()
Base.procs(::Integer)
Base.workers
Base.rmprocs
Base.interrupt
Base.myid
Base.pmap
Base.RemoteException
Base.Future
Base.RemoteChannel(::Integer)
Base.RemoteChannel(::Function, ::Integer)
Base.wait
Base.fetch(::Any)
Base.remotecall(::Any, ::Integer, ::Any...)
Base.remotecall_wait(::Any, ::Integer, ::Any...)
Base.remotecall_fetch(::Any, ::Integer, ::Any...)
Base.remote_do(::Any, ::Integer, ::Any...)
Base.put!(::RemoteChannel, ::Any...)
Base.put!(::Future, ::Any)
Base.take!(::RemoteChannel, ::Any...)
Base.isready(::RemoteChannel, ::Any...)
Base.isready(::Future)
Base.WorkerPool
Base.CachingPool
Base.default_worker_pool
Base.clear!(::CachingPool)
Base.remote
Base.remotecall(::Any, ::Base.Distributed.AbstractWorkerPool, ::Any...)
Base.remotecall_wait(::Any, ::Base.Distributed.AbstractWorkerPool, ::Any...)
Base.remotecall_fetch(::Any, ::Base.Distributed.AbstractWorkerPool, ::Any...)
Base.remote_do(::Any, ::Base.Distributed.AbstractWorkerPool, ::Any...)
Base.timedwait
Base.@spawn
Base.@spawnat
Base.@fetch
Base.@fetchfrom
Base.@async
Base.@sync
Base.@parallel
Base.@everywhere
Base.clear!(::Any, ::Any; ::Any)
Base.remoteref_id
Base.channel_from_id
Base.worker_id_from_socket
Base.cluster_cookie()
Base.cluster_cookie(::Any)
Distributed.addprocs
Distributed.nprocs
Distributed.nworkers
Distributed.procs()
Distributed.procs(::Integer)
Distributed.workers
Distributed.rmprocs
Distributed.interrupt
Distributed.myid
Distributed.pmap
Distributed.RemoteException
Distributed.Future
Distributed.RemoteChannel(::Integer)
Distributed.RemoteChannel(::Function, ::Integer)
Distributed.wait
Distributed.fetch(::Any)
Distributed.remotecall(::Any, ::Integer, ::Any...)
Distributed.remotecall_wait(::Any, ::Integer, ::Any...)
Distributed.remotecall_fetch(::Any, ::Integer, ::Any...)
Distributed.remote_do(::Any, ::Integer, ::Any...)
Distributed.put!(::RemoteChannel, ::Any...)
Distributed.put!(::Future, ::Any)
Distributed.take!(::RemoteChannel, ::Any...)
Distributed.isready(::RemoteChannel, ::Any...)
Distributed.isready(::Future)
Distributed.WorkerPool
Distributed.CachingPool
Distributed.default_worker_pool
Distributed.clear!(::CachingPool)
Distributed.remote
Distributed.remotecall(::Any, ::Distributed.Distributed.AbstractWorkerPool, ::Any...)
Distributed.remotecall_wait(::Any, ::Distributed.Distributed.AbstractWorkerPool, ::Any...)
Distributed.remotecall_fetch(::Any, ::Distributed.Distributed.AbstractWorkerPool, ::Any...)
Distributed.remote_do(::Any, ::Distributed.Distributed.AbstractWorkerPool, ::Any...)
Distributed.timedwait
Distributed.@spawn
Distributed.@spawnat
Distributed.@fetch
Distributed.@fetchfrom
Distributed.@async
Distributed.@sync
Distributed.@parallel
Distributed.@everywhere
Distributed.clear!(::Any, ::Any; ::Any)
Distributed.remoteref_id
Distributed.channel_from_id
Distributed.worker_id_from_socket
Distributed.cluster_cookie()
Distributed.cluster_cookie(::Any)
```

## Cluster Manager Interface
Expand All @@ -60,11 +60,11 @@ same host, and `SSHManager`, for launching on remote hosts via `ssh`. TCP/IP soc
and transport messages between processes. It is possible for Cluster Managers to provide a different transport.

```@docs
Base.launch
Base.manage
Base.kill(::ClusterManager, ::Int, ::WorkerConfig)
Base.connect(::ClusterManager, ::Int, ::WorkerConfig)
Base.init_worker
Base.start_worker
Base.process_messages
Distributed.launch
Distributed.manage
Distributed.kill(::ClusterManager, ::Int, ::WorkerConfig)
Distributed.connect(::ClusterManager, ::Int, ::WorkerConfig)
Distributed.init_worker
Distributed.start_worker
Distributed.process_messages
```

0 comments on commit 6603295

Please sign in to comment.