blob: ed5d57bc0f753f3941813b3671c33ff3dc0ed31c [file] [log] [blame]
package mounttable
import (
"encoding/json"
"fmt"
"os"
"path"
"strings"
"sync"
"time"
"veyron.io/veyron/veyron/lib/glob"
"veyron.io/veyron/veyron2"
"veyron.io/veyron/veyron2/ipc"
"veyron.io/veyron/veyron2/naming"
"veyron.io/veyron/veyron2/security"
"veyron.io/veyron/veyron2/services/mounttable"
"veyron.io/veyron/veyron2/services/security/access"
verror "veyron.io/veyron/veyron2/verror2"
"veyron.io/veyron/veyron2/vlog"
)
var (
errNamingLoop = verror.Register("veyron.io/veyron/veyron/services/mountable/lib", verror.NoRetry, "Loop in namespace")
)
// mountTable represents a namespace. One exists per server instance.
type mountTable struct {
sync.RWMutex
root *node
acls map[string]security.Authorizer
}
var _ ipc.Dispatcher = (*mountTable)(nil)
// mountContext represents a client bind. The name is the name that was bound to.
type mountContext struct {
name string
elems []string // parsed elements of name
cleanedElems []string // parsed elements of cleaned name (with leading /
// and double / removed).
mt *mountTable
}
// mount represents a single mount point. It contains OAs of all servers mounted
// here. The servers are considered equivalent, i.e., RPCs to a name below this
// point can be sent to any of these servers.
type mount struct {
servers *serverList
mt bool
}
// node is a single point in the tree representing the mount table.
type node struct {
parent *node
mount *mount
children map[string]*node
}
// NewMountTable creates a new server that uses the ACLs specified in
// aclfile for authorization.
//
// aclfile is a JSON-encoded mapping from paths in the mounttable to the
// access.TaggedACLMap for that path. The tags used in the map are the typical
// access tags (the Tag type defined in veyron2/services/security/access).
func NewMountTable(aclfile string) (*mountTable, error) {
acls, err := parseACLs(aclfile)
if err != nil {
return nil, err
}
return &mountTable{
root: new(node),
acls: acls,
}, nil
}
func parseACLs(path string) (map[string]security.Authorizer, error) {
if path == "" {
return nil, nil
}
var acls map[string]access.TaggedACLMap
f, err := os.Open(path)
if err != nil {
return nil, err
}
defer f.Close()
if err = json.NewDecoder(f).Decode(&acls); err != nil {
return nil, err
}
result := make(map[string]security.Authorizer)
for name, acl := range acls {
result[name], err = access.TaggedACLAuthorizer(acl, access.TypicalTagType())
if err != nil {
return nil, fmt.Errorf("Unable to create ACL for %q: %v", name, err)
}
}
if result["/"] == nil {
return nil, fmt.Errorf("No acl for / in %s", path)
}
return result, nil
}
// Lookup implements ipc.Dispatcher.Lookup.
func (mt *mountTable) Lookup(name string) (interface{}, security.Authorizer, error) {
vlog.VI(2).Infof("*********************Lookup %s", name)
mt.RLock()
defer mt.RUnlock()
ms := &mountContext{
name: name,
mt: mt,
}
if len(name) > 0 {
ms.elems = strings.Split(name, "/")
ms.cleanedElems = strings.Split(strings.TrimLeft(path.Clean(name), "/"), "/")
}
return mounttable.MountTableServer(ms), ms, nil
}
// findNode returns the node for the name path represented by elems. If none exists and create is false, return nil.
// Otherwise create the path and return a pointer to the terminal node.
func (mt *mountTable) findNode(elems []string, create bool) *node {
cur := mt.root
// Iterate down the tree.
for _, e := range elems {
// if we hit another mount table, we're done
if cur.mount != nil {
return nil
}
// then walk the children
c, ok := cur.children[e]
if ok {
cur = c
continue
}
if !create {
return nil
}
next := new(node)
if cur.children == nil {
cur.children = make(map[string]*node)
}
cur.children[e] = next
next.parent = cur
cur = next
}
return cur
}
// isActive returns true if a mount has unexpired servers attached.
func (m *mount) isActive() bool {
if m == nil {
return false
}
return m.servers.removeExpired() > 0
}
// walk returns the first mount point node on the elems path and the suffix of elems below that mount point.
// If no mount point is found, it returns nil,nil.
func (mt *mountTable) walk(n *node, elems []string) (*node, []string) {
if n.mount.isActive() {
return n, elems
} else if n.mount != nil {
n.removeUseless()
}
if len(elems) > 0 {
if c, ok := n.children[elems[0]]; ok {
if nn, nelems := mt.walk(c, elems[1:]); nn != nil {
return nn, nelems
}
}
}
return nil, nil
}
func (mt *mountTable) authorizeStep(name string, c security.Context) error {
if mt.acls == nil {
return nil
}
mt.Lock()
acl := mt.acls[name]
mt.Unlock()
vlog.VI(2).Infof("authorizeStep(%v) %v %v %v", name, c.RemoteBlessings(), c.MethodTags(), acl)
if acl != nil {
return acl.Authorize(c)
}
return nil
}
// Authorize verifies that the client has access to the requested node.
// Checks the acls on all nodes in the path starting at the root.
func (ms *mountContext) Authorize(context security.Context) error {
if err := ms.mt.authorizeStep("/", context); err != nil {
return err
}
key := ""
for _, step := range ms.cleanedElems {
key := key + "/" + step
if err := ms.mt.authorizeStep(key, context); err != nil {
return err
}
}
return nil
}
// ResolveStep returns the next server in a resolution, the name remaining below that server,
// and whether or not that server is another mount table.
func (ms *mountContext) ResolveStep(context ipc.ServerContext) (servers []naming.VDLMountedServer, suffix string, err error) {
vlog.VI(2).Infof("ResolveStep %q", ms.name)
mt := ms.mt
// TODO(caprita): we need to grab a write lock because walk may
// garbage-collect expired servers. Rework this to avoid this potential
// bottleneck.
mt.Lock()
defer mt.Unlock()
// Find the next mount point for the name.
n, elems := mt.walk(mt.root, ms.elems)
if n == nil {
if len(ms.elems) == 0 {
return nil, ms.name, verror.Make(naming.ErrNoSuchNameRoot, context, ms.name)
}
return nil, ms.name, verror.Make(naming.ErrNoSuchName, context, ms.name)
}
return n.mount.servers.copyToSlice(), strings.Join(elems, "/"), nil
}
// ResolveStepX returns the next server in a resolution in the form of a MountEntry. The name
// in the mount entry is the name relative to the server's root.
func (ms *mountContext) ResolveStepX(context ipc.ServerContext) (entry naming.VDLMountEntry, err error) {
vlog.VI(2).Infof("ResolveStep %q", ms.name)
mt := ms.mt
// TODO(caprita): we need to grab a write lock because walk may
// garbage-collect expired servers. Rework this to avoid this potential
// bottleneck.
mt.Lock()
defer mt.Unlock()
// Find the next mount point for the name.
n, elems := mt.walk(mt.root, ms.elems)
if n == nil {
entry.Name = ms.name
if len(ms.elems) == 0 {
err = verror.Make(naming.ErrNoSuchNameRoot, context, ms.name)
} else {
err = verror.Make(naming.ErrNoSuchName, context, ms.name)
}
return
}
entry.Servers = n.mount.servers.copyToSlice()
entry.Name = strings.Join(elems, "/")
entry.MT = n.mount.mt
return
}
func hasMTFlag(flags naming.MountFlag) bool {
return (flags & naming.MT) == naming.MT
}
func hasReplaceFlag(flags naming.MountFlag) bool {
return (flags & naming.Replace) == naming.Replace
}
// Mount a server onto the name in the receiver.
func (ms *mountContext) Mount(context ipc.ServerContext, server string, ttlsecs uint32, flags naming.MountFlag) error {
mt := ms.mt
if ttlsecs == 0 {
ttlsecs = 10 * 365 * 24 * 60 * 60 // a really long time
}
vlog.VI(2).Infof("*********************Mount %q -> %s", ms.name, server)
// Make sure the server name is reasonable.
epString, _ := naming.SplitAddressName(server)
runtime := veyron2.RuntimeFromContext(context)
_, err := runtime.NewEndpoint(epString)
if err != nil {
return fmt.Errorf("malformed address %q for mounted server %q", epString, server)
}
// Find/create node in namespace and add the mount.
mt.Lock()
defer mt.Unlock()
n := mt.findNode(ms.cleanedElems, true)
if n == nil {
return verror.Make(naming.ErrNoSuchNameRoot, context, ms.name)
}
if hasReplaceFlag(flags) {
n.mount = nil
}
// TODO(p): When the endpoint actually has the ServesMountTable bit,
// or this with ep.ServesMountTable().
wantMT := hasMTFlag(flags)
if n.mount == nil {
n.mount = &mount{servers: NewServerList(), mt: wantMT}
} else {
if wantMT != n.mount.mt {
return fmt.Errorf("MT doesn't match")
}
}
n.mount.servers.add(server, time.Duration(ttlsecs)*time.Second)
return nil
}
// A useful node has children or an active mount.
func (n *node) isUseful() bool {
return len(n.children) > 0 || n.mount.isActive()
}
// removeUseless removes a node and all of its ascendants that are not useful.
func (n *node) removeUseless() {
if n.isUseful() {
return
}
if n.parent == nil {
return
}
for k, c := range n.parent.children {
if c == n {
delete(n.parent.children, k)
break
}
}
n.parent.removeUseless()
}
// removeUselessSubtree removes all descendant nodes of this node that are not
// useful (after calling removeUselessSubtree recursively). Returns if this
// node is useful anymore.
func (n *node) removeUselessSubtree() bool {
for k, c := range n.children {
if !c.removeUselessSubtree() {
delete(n.children, k)
}
}
return n.isUseful()
}
// Unmount removes servers from the name in the receiver. If server is specified, only that
// server is removed.
func (ms *mountContext) Unmount(context ipc.ServerContext, server string) error {
mt := ms.mt
mt.Lock()
defer mt.Unlock()
n := mt.findNode(ms.cleanedElems, false)
if n == nil {
return nil
}
defer n.removeUseless()
if server == "" {
n.mount = nil
return nil
}
if n.mount != nil && n.mount.servers.remove(server) == 0 {
n.mount = nil
}
return nil
}
// A struct holding a partial result of Glob.
type globEntry struct {
n *node
name string
}
func (mt *mountTable) globStep(n *node, name string, pattern *glob.Glob, context ipc.GlobContext) {
vlog.VI(2).Infof("globStep(%s, %s)", name, pattern)
if mt.acls != nil {
acl_name := "/" + strings.TrimLeft(naming.Join(context.Suffix(), name), "/")
// Skip this node if the user isn't authorized.
if acl := mt.acls[acl_name]; acl != nil {
if err := acl.Authorize(context); err != nil {
return
}
}
}
sender := context.SendStream()
// If this is a mount point, we're done.
if m := n.mount; m != nil {
// Garbage-collect if expired.
if !m.isActive() {
n.removeUseless()
return
}
sender.Send(
naming.VDLMountEntry{
Name: name, Servers: m.servers.copyToSlice(),
MT: n.mount.mt,
})
return
}
if pattern.Len() == 0 {
// Garbage-collect if no useful descendants.
if !n.removeUselessSubtree() {
n.removeUseless()
return
}
sender.Send(naming.VDLMountEntry{Name: name})
}
if pattern.Finished() {
return
}
// Recurse through the children.
for k, c := range n.children {
if ok, _, suffix := pattern.MatchInitialSegment(k); ok {
mt.globStep(c, naming.Join(name, k), suffix, context)
}
}
}
// Glob finds matches in the namespace. If we reach a mount point before matching the
// whole pattern, return that mount point.
// pattern is a glob pattern as defined by the veyron/lib/glob package.
func (ms *mountContext) Glob(context ipc.GlobContext, pattern string) error {
vlog.VI(2).Infof("mt.Glob %v", ms.elems)
g, err := glob.Parse(pattern)
if err != nil {
return err
}
mt := ms.mt
// TODO(caprita): we need to grab a write lock because globStep may
// garbage-collect expired servers. Rework this to avoid this potential
// bottleneck.
mt.Lock()
defer mt.Unlock()
// If the current name is not fully resolvable on this nameserver we
// don't need to evaluate the glob expression. Send a partially resolved
// name back to the client.
n := mt.findNode(ms.cleanedElems, false)
if n == nil {
ms.linkToLeaf(context)
return nil
}
mt.globStep(n, "", g, context)
return nil
}
func (ms *mountContext) linkToLeaf(stream ipc.GlobServerStream) {
n, elems := ms.mt.walk(ms.mt.root, ms.cleanedElems)
if n == nil {
return
}
servers := n.mount.servers.copyToSlice()
for i, s := range servers {
servers[i].Server = naming.Join(s.Server, strings.Join(elems, "/"))
}
stream.SendStream().Send(naming.VDLMountEntry{Name: "", Servers: servers})
}