Changeset - f066d6e874db
[Not reviewed]
default
! ! !
drewp@bigasterisk.com - 6 years ago 2019-05-22 00:08:22
drewp@bigasterisk.com
2to3 with these fixers: all idioms set_literal
Ignore-this: cbd28518218c2f0ddce8c4f92d3b8b33
76 files changed with 300 insertions and 302 deletions:
0 comments (0 inline, 0 general)
bin/ascoltami2
Show inline comments
 
#!bin/python
 
from run_local import log
 
from twisted.internet import reactor
 
import web, thread, sys, optparse, logging
 
import web, _thread, sys, optparse, logging
 
from rdflib import URIRef
 
sys.path.append(".")
 
sys.path.append('/usr/lib/python2.7/dist-packages')  # For gi
 

	
 
import gi
 
gi.require_version('Gst', '1.0')
 
gi.require_version('Gtk', '3.0')
 

	
 
from light9.ascoltami.player import Player
 
from light9.ascoltami.playlist import Playlist, NoSuchSong
 
from light9.ascoltami.webapp import makeWebApp, songUri, songLocation
 
from light9 import networking, showconfig
bin/bumppad
Show inline comments
 
#!bin/python
 
from __future__ import division, nested_scopes
 

	
 
import sys, time, math
 
import Tkinter as tk
 
import tkinter as tk
 

	
 
import run_local
 
import light9.dmxclient as dmxclient
 
from light9.TLUtility import make_attributes_from_args
 

	
 
from light9.Submaster import Submaster, sub_maxes
 

	
 

	
 
class pad(tk.Frame):
 
    levs = None  # Submaster : level
 

	
 
    def __init__(self, master, root, mag):
 
@@ -46,25 +46,25 @@ class pad(tk.Frame):
 

	
 
            root.bind(
 
                "<KeyPress-%s>" % key, lambda ev, sub=sub: self.bumpto(sub, 1))
 
            root.bind("<KeyRelease-%s>" % key,
 
                      lambda ev, sub=sub: self.bumpto(sub, 0))
 

	
 
    def bumpto(self, sub, lev):
 
        now = time.time()
 
        self.levs[sub] = lev * self.mag.get()
 
        self.master.after_idle(self.output)
 

	
 
    def output(self):
 
        dmx = sub_maxes(*[s * l for s, l in self.levs.items()]).get_dmx_list()
 
        dmx = sub_maxes(*[s * l for s, l in list(self.levs.items())]).get_dmx_list()
 
        dmxclient.outputlevels(dmx, clientid="bumppad")
 

	
 

	
 
root = tk.Tk()
 
root.tk_setPalette("maroon4")
 
root.wm_title("bumppad")
 
mag = tk.DoubleVar()
 

	
 
tk.Label(root,
 
         text="Keypad press/release activate sub; 1..5 set mag",
 
         font="Helvetica -12 italic",
 
         anchor='w').pack(side='bottom', fill='x')
bin/captureDevice
Show inline comments
 
#!bin/python
 
from __future__ import division
 

	
 
from rdflib import URIRef
 
from twisted.internet import reactor
 
from twisted.internet.defer import inlineCallbacks, Deferred
 

	
 
import logging
 
import optparse
 
import os
 
import time
 
import treq
 
import cyclone.web, cyclone.websocket, cyclone.httpclient
 
from greplin import scales
 

	
bin/clientdemo
Show inline comments
 
@@ -16,24 +16,24 @@ if __name__ == "__main__":
 
    g = SyncedGraph(networking.rdfdb.url, "clientdemo")
 

	
 
    from light9.Submaster import PersistentSubmaster
 
    sub = PersistentSubmaster(
 
        graph=g, uri=URIRef("http://light9.bigasterisk.com/sub/bcools"))
 

	
 
    #get sub to show its updating name, then push that all the way into KC gui so we can see just names refresh in there
 

	
 
    L9 = Namespace("http://light9.bigasterisk.com/")
 

	
 
    def updateDemoValue():
 
        v = list(g.objects(L9['demo'], L9['is']))
 
        print "demo value is %r" % v
 
        print("demo value is %r" % v)
 

	
 
    g.addHandler(updateDemoValue)
 

	
 
    def adj():
 
        g.patch(
 
            Patch(addQuads=[(L9['demo'], L9['is'], Literal(os.getpid()),
 
                             L9['clientdemo'])],
 
                  delQuads=[]))
 

	
 
    reactor.callLater(2, adj)
 
    reactor.run()
bin/collector
Show inline comments
 
#!bin/python
 
"""
 
Collector receives device attrs from multiple senders, combines
 
them, and sends output attrs to hardware. The combining part has
 
custom code for some attributes.
 

	
 
Input can be over http or zmq.
 
"""
 

	
 
from __future__ import division
 

	
 
from run_local import log
 

	
 
from rdflib import URIRef, Literal
 
from twisted.internet import reactor, utils
 
from txzmq import ZmqEndpoint, ZmqFactory, ZmqPullConnection
 
import json
 
import logging
 
import optparse
 
import time
 
import traceback
 
import cyclone.web, cyclone.websocket
 
from greplin import scales
 
@@ -25,25 +25,25 @@ from lib.cycloneerr import PrettyErrorHa
 
from light9.collector.output import EnttecDmx, Udmx, DummyOutput
 
from light9.collector.collector import Collector
 
from light9.namespaces import L9
 
from light9 import networking
 
from rdfdb.syncedgraph import SyncedGraph
 
from light9.greplin_cyclone import StatsForCyclone
 

	
 

	
 
def parseJsonMessage(msg):
 
    body = json.loads(msg)
 
    settings = []
 
    for device, attr, value in body['settings']:
 
        if isinstance(value, basestring) and value.startswith('http'):
 
        if isinstance(value, str) and value.startswith('http'):
 
            value = URIRef(value)
 
        else:
 
            value = Literal(value)
 
        settings.append((URIRef(device), URIRef(attr), value))
 
    return body['client'], body['clientSession'], settings, body['sendTime']
 

	
 

	
 
def startZmq(port, collector):
 
    stats = scales.collection('/zmqServer', scales.PmfStat('setAttr'))
 

	
 
    zf = ZmqFactory()
 
    addr = 'tcp://*:%s' % port
 
@@ -105,25 +105,25 @@ class WebListeners(object):
 
            # could lead to slowdowns in the real dmx output.
 
            for client, seen in self.clients:
 
                if seen.get(dev) == attrs:
 
                    continue
 
                if msg is None:
 
                    msg = self.makeMsg(dev, attrs, outputMap)
 

	
 
                seen[dev] = attrs
 
                client.sendMessage(msg)
 

	
 
    def makeMsg(self, dev, attrs, outputMap):
 
        attrRows = []
 
        for attr, val in attrs.items():
 
        for attr, val in list(attrs.items()):
 
            output, index = outputMap[(dev, attr)]
 
            attrRows.append({
 
                'attr': attr.rsplit('/')[-1],
 
                'val': val,
 
                'chan': (output.shortId(), index + 1)
 
            })
 
        attrRows.sort(key=lambda r: r['chan'])
 
        for row in attrRows:
 
            row['chan'] = '%s %s' % (row['chan'][0], row['chan'][1])
 

	
 
        msg = json.dumps({'outputAttrsSet': {
 
            'dev': dev,
bin/collector_loadtest.py
Show inline comments
 
import sys
 
sys.path.append('bin')
 
from run_local import log
 
from light9.collector.collector_client import sendToCollector, sendToCollectorZmq
 
from light9.namespaces import L9, DEV
 
from twisted.internet import reactor
 
import time
 
import logging
 
log.setLevel(logging.DEBUG)
 

	
 

	
 
def loadTest():
 
    print "scheduling loadtest"
 
    print("scheduling loadtest")
 
    n = 2500
 
    times = [None] * n
 
    session = "loadtest%s" % time.time()
 
    offset = 0
 
    for i in range(n):
 

	
 
        def send(i):
 
            if i % 100 == 0:
 
                log.info('sendToCollector %s', i)
 
            d = sendToCollector("http://localhost:999999/", session,
 
                                [[DEV["backlight1"], L9["color"], "#ffffff"],
 
                                 [DEV["backlight2"], L9["color"], "#ffffff"],
 
@@ -32,23 +32,23 @@ def loadTest():
 
                                 [DEV["houseSide"], L9["level"], .8],
 
                                 [DEV["backlight5"], L9["uv"], 0.011]])
 

	
 
            def ontime(dt, i=i):
 
                times[i] = dt
 

	
 
            d.addCallback(ontime)
 

	
 
        reactor.callLater(offset, send, i)
 
        offset += .002
 

	
 
    def done():
 
        print "loadtest done"
 
        print("loadtest done")
 
        with open('/tmp/times', 'w') as f:
 
            f.write(''.join('%s\n' % t for t in times))
 
        reactor.stop()
 

	
 
    reactor.callLater(offset + .5, done)
 
    reactor.run()
 

	
 

	
 
if __name__ == '__main__':
 
    loadTest()
bin/curvecalc
Show inline comments
 
#!bin/python
 
"""
 
now launches like this:
 
% bin/curvecalc http://light9.bigasterisk.com/show/dance2007/song1
 

	
 

	
 

	
 
todo: curveview should preserve more objects, for speed maybe
 

	
 
"""
 
from __future__ import division
 

	
 

	
 
import sys
 
import imp
 
sys.path.append('/usr/lib/python2.7/dist-packages')  # For gtk
 
from twisted.internet import gtk3reactor
 
gtk3reactor.install()
 
from twisted.internet import reactor
 

	
 
import time, textwrap, os, optparse, linecache, signal, traceback, json
 
import gi
 
from gi.repository import Gtk
 
from gi.repository import GObject
 
from gi.repository import Gdk
 

	
 
from urlparse import parse_qsl
 
from urllib.parse import parse_qsl
 
import louie as dispatcher
 
from rdflib import URIRef, Literal, RDF, RDFS
 
import logging
 

	
 
from run_local import log
 
from light9 import showconfig, networking
 
from light9.curvecalc import curveview
 
from light9.curvecalc.curve import Curveset
 
from light9.curvecalc.curveedit import serveCurveEdit
 
from light9.curvecalc.musicaccess import Music
 
from light9.curvecalc.output import Output
 
from light9.curvecalc.subterm import Subterm
 
@@ -162,44 +163,44 @@ class Main(object):
 
            flags=Gtk.DestDefaults.ALL,
 
            targets=[Gtk.TargetEntry('text/uri-list', 0, 0)],
 
            actions=Gdk.DragAction.COPY)
 

	
 
    def acceptDragsOnCurveViews(self):
 
        w = self.wtree.get_object("curves")
 
        w.drag_dest_set(flags=Gtk.DestDefaults.ALL,
 
                        targets=[Gtk.TargetEntry('text/uri-list', 0, 0)],
 
                        actions=Gdk.DragAction.COPY)
 

	
 
        def recv(widget, context, x, y, selection, targetType, time):
 
            subUri = URIRef(selection.data.strip())
 
            print "into curves", subUri
 
            print("into curves", subUri)
 
            with self.graph.currentState(tripleFilter=(subUri, RDFS.label,
 
                                                       None)) as current:
 
                subName = current.label(subUri)
 

	
 
            if '?' in subUri:
 
                subName = self.handleSubtermDrop(subUri)
 
            else:
 
                try:
 
                    self.makeSubterm(subName,
 
                                     withCurve=True,
 
                                     sub=subUri,
 
                                     expr="%s(t)" % subName)
 
                except SubtermExists:
 
                    # we're not making sure the expression/etc are
 
                    # correct-- user mihgt need to fix things
 
                    pass
 
            curveView = self.curvesetView.row(subName).curveView
 
            t = self.lastSeenInputTime  # curveView.current_time() # new curve hasn't heard the time yet. this has gotten too messy- everyone just needs to be able to reach the time source
 
            print "time", t
 
            print("time", t)
 
            curveView.add_points([(t - .5, 0), (t, 1)])
 

	
 
        w.connect("drag-data-received", recv)
 

	
 
    def onDragDataInNewSubZone(self, widget, context, x, y, selection,
 
                               targetType, time):
 
        data = URIRef(selection.data.strip())
 
        if '?' in data:
 
            self.handleSubtermDrop(data)
 
            return
 
        with self.graph.currentState(tripleFilter=(data, None,
 
                                                   None)) as current:
 
@@ -403,25 +404,25 @@ class Main(object):
 
    def onSave(self, *args):
 
        # only doing curves still. I hope to eliminate all this.
 
        log.info("saving curves")
 
        self.curveset.save()
 
        log.info("saved")
 

	
 
    def makeStatusLines(self, master):
 
        """various labels that listen for dispatcher signals"""
 
        for row, (signame, textfilter) in enumerate([
 
            ('input time', lambda t: "%.2fs" % t),
 
            ('output levels', lambda levels: textwrap.fill(
 
                "; ".join([
 
                    "%s:%.2f" % (n, v) for n, v in levels.items()[:2] if v > 0
 
                    "%s:%.2f" % (n, v) for n, v in list(levels.items())[:2] if v > 0
 
                ]), 70)),
 
            ('update period', lambda t: "%.1fms" % (t * 1000)),
 
            ('update status', lambda x: str(x)),
 
        ]):
 
            key = Gtk.Label("%s:" % signame)
 
            value = Gtk.Label("")
 
            master.resize(row + 1, 2)
 
            master.attach(key, 0, 1, row, row + 1)
 
            master.attach(value, 1, 2, row, row + 1)
 
            key.set_alignment(1, 0)
 
            value.set_alignment(0, 0)
 

	
 
@@ -436,49 +437,49 @@ class Main(object):
 

	
 
    def refreshCurveView(self):
 
        wtree = self.wtree
 
        mtimes = [
 
            os.path.getmtime(f) for f in [
 
                'light9/curvecalc/curveview.py',
 
                'light9/curvecalc/zoomcontrol.py',
 
            ]
 
        ]
 

	
 
        if (not hasattr(self, 'curvesetView') or
 
                self.curvesetView._mtimes != mtimes):
 
            print "reload curveview.py"
 
            print("reload curveview.py")
 
            curvesVBox = wtree.get_object("curves")
 
            zoomControlBox = wtree.get_object("zoomControlBox")
 
            [curvesVBox.remove(c) for c in curvesVBox.get_children()]
 
            [zoomControlBox.remove(c) for c in zoomControlBox.get_children()]
 
            try:
 
                linecache.clearcache()
 
                reload(curveview)
 
                imp.reload(curveview)
 

	
 
                # old ones are not getting deleted right
 
                if hasattr(self, 'curvesetView'):
 
                    self.curvesetView.live = False
 

	
 
                # mem problem somewhere; need to hold a ref to this
 
                self.curvesetView = curveview.Curvesetview(
 
                    self.graph, curvesVBox, zoomControlBox, self.curveset)
 
                self.curvesetView._mtimes = mtimes
 

	
 
                # this is scheduled after some tk shuffling, to
 
                # try to minimize the number of times we redraw
 
                # the curve at startup. If tk is very slow, it's
 
                # ok. You'll just get some wasted redraws.
 
                self.curvesetView.goLive()
 
            except Exception:
 
                print "reload failed:"
 
                print("reload failed:")
 
                traceback.print_exc()
 
        if self.opts.reload:
 
            reactor.callLater(1, self.refreshCurveView)
 

	
 

	
 
class MaxTime(object):
 
    """
 
    looks up the time in seconds for the session's current song
 
    """
 

	
 
    def __init__(self, graph, session):
 
        self.graph, self.session = graph, session
bin/dmxserver
Show inline comments
 
@@ -15,25 +15,25 @@ clients shall connect to the xmlrpc serv
 
  their PID (or some other cookie)
 

	
 
  a length-n list of 0..1 levels which will represent the channel
 
    values for the n first dmx channels.
 

	
 
server is port 8030; xmlrpc method is called outputlevels(pid,levellist).
 

	
 
todo:
 
  save dmx on quit and restore on restart
 
  if parport fails, run in dummy mode (and make an option for that too)
 
"""
 

	
 
from __future__ import division
 

	
 
from twisted.internet import reactor
 
from twisted.web import xmlrpc, server
 
import sys, time, os
 
from optparse import OptionParser
 
import run_local
 
import txosc.dispatch, txosc. async
 
from light9.io import ParportDMX, UsbDMX
 

	
 
from light9.updatefreq import Updatefreq
 
from light9 import networking
 

	
 
from txzmq import ZmqEndpoint, ZmqFactory, ZmqPullConnection, ZmqRequestTimeoutError
 
@@ -59,25 +59,25 @@ class ReceiverApplication(object):
 
    following channels.
 
    """
 

	
 
    def __init__(self, port, lightServer):
 
        self.port = port
 
        self.lightServer = lightServer
 
        self.receiver = txosc.dispatch.Receiver()
 
        self.receiver.addCallback("/dmx/*", self.pixel_handler)
 
        self._server_port = reactor.listenUDP(
 
            self.port,
 
            txosc. async .DatagramServerProtocol(self.receiver),
 
            interface='0.0.0.0')
 
        print "Listening OSC on udp port %s" % (self.port)
 
        print("Listening OSC on udp port %s" % (self.port))
 

	
 
    def pixel_handler(self, message, address):
 
        # this is already 1-based though I don't know why
 
        startChannel = int(message.address.split('/')[2])
 
        levels = [a.value for a in message.arguments]
 
        allLevels = [0] * (startChannel - 1) + levels
 
        self.lightServer.xmlrpc_outputlevels("osc@%s" % startChannel, allLevels)
 

	
 

	
 
class XMLRPCServe(xmlrpc.XMLRPC):
 

	
 
    def __init__(self, options):
 
@@ -88,55 +88,55 @@ class XMLRPCServe(xmlrpc.XMLRPC):
 
        self.lastseen = {}  # clientID : time last seen
 
        self.clientfreq = {}  # clientID : updatefreq
 

	
 
        self.combinedlevels = []  # list of levels, after max'ing the clients
 
        self.clientschanged = 1  # have clients sent anything since the last send?
 
        self.options = options
 
        self.lastupdate = 0  # time of last dmx send
 
        self.laststatsprint = 0  # time
 

	
 
        # desired seconds between sendlevels() calls
 
        self.calldelay = 1 / options.updates_per_sec
 

	
 
        print "starting parport connection"
 
        print("starting parport connection")
 
        self.parportdmx = UsbDMX(dimmers=90, port=options.dmx_device)
 
        if os.environ.get('DMXDUMMY', 0):
 
            self.parportdmx.godummy()
 
        else:
 
            self.parportdmx.golive()
 

	
 
        self.updatefreq = Updatefreq()  # freq of actual dmx sends
 
        self.num_unshown_updates = None
 
        self.lastshownlevels = None
 
        # start the loop
 
        self.sendlevels()
 

	
 
        # the other loop
 
        self.purgeclients()
 

	
 
    def purgeclients(self):
 
        """forget about any clients who haven't sent levels in a while.
 
        this runs in a loop"""
 

	
 
        purge_age = 10  # seconds
 

	
 
        reactor.callLater(1, self.purgeclients)
 

	
 
        now = time.time()
 
        cids = self.lastseen.keys()
 
        cids = list(self.lastseen.keys())
 
        for cid in cids:
 
            lastseen = self.lastseen[cid]
 
            if lastseen < now - purge_age:
 
                print("forgetting client %s (no activity for %s sec)" %
 
                      (cid, purge_age))
 
                print(("forgetting client %s (no activity for %s sec)" %
 
                      (cid, purge_age)))
 
                try:
 
                    del self.clientlevels[cid]
 
                except KeyError:
 
                    pass
 
                del self.clientfreq[cid]
 
                del self.lastseen[cid]
 

	
 
    def sendlevels(self):
 
        """sends to dmx if levels have changed, or if we havent sent
 
        in a while"""
 

	
 
        reactor.callLater(self.calldelay, self.sendlevels)
 
@@ -166,44 +166,44 @@ class XMLRPCServe(xmlrpc.XMLRPC):
 
        if self.clientschanged or time.time(
 
        ) > self.lastupdate + self.calldelay:
 
            self.lastupdate = time.time()
 
            self.sendlevels_dmx()
 

	
 
        self.clientschanged = 0  # clear the flag
 

	
 
    def calclevels(self):
 
        """combine all the known client levels into self.combinedlevels"""
 
        self.combinedlevels = []
 
        for chan in range(0, self.parportdmx.dimmers):
 
            x = 0
 
            for clientlist in self.clientlevels.values():
 
            for clientlist in list(self.clientlevels.values()):
 
                if len(clientlist) > chan:
 
                    # clamp client levels to 0..1
 
                    cl = max(0, min(1, clientlist[chan]))
 
                    x = max(x, cl)
 
            self.combinedlevels.append(x)
 

	
 
    def printlevels(self):
 
        """write all the levels to stdout"""
 
        print "Levels:", "".join(
 
            ["% 2d " % (x * 100) for x in self.combinedlevels])
 
        print("Levels:", "".join(
 
            ["% 2d " % (x * 100) for x in self.combinedlevels]))
 

	
 
    def printstats(self):
 
        """print the clock, freq, etc, with a \r at the end"""
 

	
 
        sys.stdout.write("dmxserver up at %s, [polls %s] " % (
 
            time.strftime("%H:%M:%S"),
 
            str(self.updatefreq),
 
        ))
 
        for cid, freq in self.clientfreq.items():
 
        for cid, freq in list(self.clientfreq.items()):
 
            sys.stdout.write("[%s %s] " % (cid, str(freq)))
 
        sys.stdout.write("\r")
 
        sys.stdout.flush()
 

	
 
    def sendlevels_dmx(self):
 
        """output self.combinedlevels to dmx, and keep the updates/sec stats"""
 
        # they'll get divided by 100
 
        if self.parportdmx:
 
            self.parportdmx.sendlevels([l * 100 for l in self.combinedlevels])
 
        self.updatefreq.update()
 

	
 
    def xmlrpc_echo(self, x):
 
@@ -228,25 +228,25 @@ class XMLRPCServe(xmlrpc.XMLRPC):
 
        i = len(trunc) - 1
 
        if i < 0:
 
            return []
 
        while trunc[i] == 0 and i >= 0:
 
            i -= 1
 
        if i < 0:
 
            return []
 
        trunc = trunc[:i + 1]
 
        return trunc
 

	
 
    def trackClientFreq(self, cid):
 
        if cid not in self.lastseen:
 
            print "hello new client %s" % cid
 
            print("hello new client %s" % cid)
 
            self.clientfreq[cid] = Updatefreq()
 
        self.lastseen[cid] = time.time()
 
        self.clientfreq[cid].update()
 

	
 

	
 
parser = OptionParser()
 
parser.add_option("-f",
 
                  "--fast-updates",
 
                  action='store_true',
 
                  help=('display all dmx output to stdout instead '
 
                        'of the usual reduced output'))
 
parser.add_option("-r",
 
@@ -255,27 +255,27 @@ parser.add_option("-r",
 
                  default=20,
 
                  help=('dmx output frequency'))
 
parser.add_option("-d",
 
                  "--dmx-device",
 
                  default='/dev/dmx0',
 
                  help='dmx device name')
 
parser.add_option("-n",
 
                  "--dummy",
 
                  action="store_true",
 
                  help="dummy mode, same as DMXDUMMY=1 env variable")
 
(options, songfiles) = parser.parse_args()
 

	
 
print options
 
print(options)
 

	
 
if options.dummy:
 
    os.environ['DMXDUMMY'] = "1"
 

	
 
port = networking.dmxServer.port
 
print "starting xmlrpc server on port %s" % port
 
print("starting xmlrpc server on port %s" % port)
 
xmlrpcServe = XMLRPCServe(options)
 
reactor.listenTCP(port, server.Site(xmlrpcServe))
 

	
 
startZmq(networking.dmxServerZmq.port, xmlrpcServe.xmlrpc_outputlevels)
 

	
 
oscApp = ReceiverApplication(9051, xmlrpcServe)
 

	
 
reactor.run()
bin/effecteval
Show inline comments
 
#!bin/python
 

	
 
from __future__ import division
 

	
 
from run_local import log
 
from twisted.internet import reactor
 
from twisted.internet.defer import inlineCallbacks, returnValue
 
import cyclone.web, cyclone.websocket, cyclone.httpclient
 
import sys, optparse, logging, subprocess, json, itertools
 
from rdflib import URIRef, Literal
 

	
 
sys.path.append('/usr/lib/pymodules/python2.7/')  # for numpy, on rpi
 
sys.path.append('/usr/lib/python2.7/dist-packages')  # For numpy
 
from light9 import networking, showconfig
 
from light9.effecteval.effect import EffectNode
 
from light9.effect.edit import getMusicStatus, songNotePatch
 
@@ -164,25 +164,25 @@ class Code(PrettyErrorHandler, cyclone.w
 
        for i in itertools.count(0):
 
            k = 'codeLines[%s][text]' % i
 
            v = self.get_argument(k, None)
 
            if v is not None:
 
                codeLines.append(Literal(v))
 
            else:
 
                break
 
        if not codeLines:
 
            log.info("no codelines received on PUT /code")
 
            return
 
        with self.settings.graph.currentState(tripleFilter=(None, L9['effect'],
 
                                                            effect)) as g:
 
            song = g.subjects(L9['effect'], effect).next()
 
            song = next(g.subjects(L9['effect'], effect))
 

	
 
        replaceObjects(self.settings.graph, song, effect, L9['code'], codeLines)
 

	
 
        # right here we could tell if the code has a python error and return it
 
        self.send_error(202)
 

	
 

	
 
class EffectEval(PrettyErrorHandler, cyclone.web.RequestHandler):
 

	
 
    @inlineCallbacks
 
    def get(self):
 
        # return dmx list for that effect
bin/effectsequencer
Show inline comments
 
#!bin/python
 
"""
 
plays back effect notes from the timeline
 
"""
 
from __future__ import division
 

	
 
from run_local import log
 
from twisted.internet import reactor
 
from light9.greplin_cyclone import StatsForCyclone
 
from rdfdb.syncedgraph import SyncedGraph
 
from light9 import networking, showconfig
 
from greplin import scales
 
import optparse, sys, logging
 
import cyclone.web
 
from rdflib import URIRef
 
from light9.effect.sequencer import Sequencer, Updates
 
from light9.collector.collector_client import sendToCollector
 

	
bin/homepageConfig
Show inline comments
 
#!bin/python
 
from run_local import log
 
from rdflib import RDF, URIRef
 
from light9 import networking, showconfig
 
from light9.namespaces import L9
 
from urlparse import urlparse
 
from urllib import splitport
 
from urllib.parse import urlparse
 
from urllib.parse import splitport
 

	
 
from rdfdb.syncedgraph import SyncedGraph
 
from twisted.internet import reactor
 

	
 
graph = showconfig.getGraph()
 

	
 
netHome = graph.value(showconfig.showUri(), L9['networking'])
 
webServer = graph.value(netHome, L9['webServer'])
 
if not webServer:
 
    raise ValueError('no %r :webServer' % netHome)
 
print "listen %s;" % splitport(urlparse(webServer).netloc)[1]
 
print("listen %s;" % splitport(urlparse(webServer).netloc)[1])
 

	
 

	
 
def location(path, server):
 
    print """
 
    print("""
 
    location /%(path)s/ {
 

	
 
      # for websocket
 
      proxy_http_version 1.1;
 
      proxy_set_header Upgrade $http_upgrade;
 
      proxy_set_header Connection "upgrade";
 
      proxy_set_header Host $host;
 

	
 
      proxy_pass %(server)s;
 
      proxy_buffering off;
 
      rewrite /[^/]+/(.*) /$1 break;
 
    }""" % vars()
 
    }""" % vars())
 

	
 

	
 
for role, server in sorted(graph.predicate_objects(netHome)):
 
    if not server.startswith('http') or role == L9['webServer']:
 
        continue
 
    path = graph.value(role, L9['urlPath'])
 
    if not path:
 
        continue
 
    server = server.rstrip('/')
 
    location(path, server)
 

	
 
showPath = showconfig.showUri().split('/', 3)[-1]
 
print """
 
print("""
 
    location /%(path)s {
 
      root %(root)s;
 
    }""" % {
 
    'path': showPath,
 
    'root': showconfig.root()[:-len(showPath)]
 
}
 
})
bin/inputdemo
Show inline comments
 
#!bin/python
 
import sys
 
sys.path.append('/usr/lib/python2.7/dist-packages')  # For gtk
 
from twisted.internet import gtk3reactor
 
gtk3reactor.install()
 
from twisted.internet import reactor
 
from rdflib import URIRef
 
import optparse, logging, urllib, time
 
import optparse, logging, urllib.request, urllib.parse, urllib.error, time
 
from gi.repository import Gtk
 
from run_local import log
 
from light9 import showconfig, networking
 
from light9 import clientsession
 
from rdfdb.syncedgraph import SyncedGraph
 
import cyclone.httpclient
 
from light9.curvecalc.client import sendLiveInputPoint
 

	
 

	
 
class App(object):
 

	
 
    def __init__(self):
 
@@ -25,25 +25,25 @@ class App(object):
 
        opts, args = parser.parse_args()
 

	
 
        log.setLevel(logging.DEBUG if opts.debug else logging.INFO)
 

	
 
        self.session = clientsession.getUri('inputdemo', opts)
 
        self.graph = SyncedGraph(networking.rdfdb.url, "inputdemo")
 

	
 
        self.graph.initiallySynced.addCallback(lambda _: self.launch())
 

	
 
        self.curve = args[0] if args else URIRef(
 
            'http://light9.bigasterisk.com/show/dance2014/song1/curve/c-1401259747.675542'
 
        )
 
        print "sending points on curve %s" % self.curve
 
        print("sending points on curve %s" % self.curve)
 

	
 
        reactor.run()
 

	
 
    def launch(self):
 
        win = Gtk.Window()
 

	
 
        slider = Gtk.Scale.new_with_range(orientation=Gtk.Orientation.VERTICAL,
 
                                          min=0,
 
                                          max=1,
 
                                          step=.001)
 
        slider.props.inverted = True
 
        slider.connect('value-changed', self.onChanged)
 
@@ -51,16 +51,16 @@ class App(object):
 
        win.add(slider)
 
        win.parse_geometry('50x250')
 
        win.connect("delete-event", lambda *a: reactor.crash())
 
        win.connect("destroy", lambda *a: reactor.crash())
 
        win.show_all()
 

	
 
    def onChanged(self, scale):
 
        t1 = time.time()
 
        d = sendLiveInputPoint(self.curve, scale.get_value())
 

	
 
        @d.addCallback
 
        def done(result):
 
            print "posted in %.1f ms" % (1000 * (time.time() - t1))
 
            print("posted in %.1f ms" % (1000 * (time.time() - t1)))
 

	
 

	
 
App()
bin/inputquneo
Show inline comments
 
#!bin/python
 
"""
 
read Quneo midi events, write to curvecalc and maybe to effects
 
"""
 
from __future__ import division
 

	
 
from run_local import log
 
import logging, urllib
 
import logging, urllib.request, urllib.parse, urllib.error
 
import cyclone.web, cyclone.httpclient
 
from rdflib import URIRef
 
from twisted.internet import reactor, task
 
from light9.curvecalc.client import sendLiveInputPoint
 
from light9.namespaces import L9, RDF, RDFS
 
from rdfdb.syncedgraph import SyncedGraph
 
from light9 import networking
 

	
 
import sys
 
sys.path.append('/usr/lib/python2.7/dist-packages')  # For pygame
 
import pygame.midi
 

	
 
@@ -54,52 +54,52 @@ class WatchMidi(object):
 
                dev)
 
            if 'QUNEO' in name and isInput:
 
                return dev
 
        raise ValueError("didn't find quneo input device")
 

	
 
    def step(self):
 
        if not self.inp.poll():
 
            return
 
        NOTEON, NOTEOFF = 144, 128
 
        for ev in self.inp.read(999):
 
            (status, d1, d2, _), _ = ev
 
            if status in [NOTEON, NOTEOFF]:
 
                print status, d1, d2
 
                print(status, d1, d2)
 

	
 
            if status == NOTEON:
 
                if not self.noteIsOn.get(d1):
 
                    self.noteIsOn[d1] = True
 
                    try:
 
                        e = self.effectMap[d1]
 
                        cyclone.httpclient.fetch(
 
                            url=networking.effectEval.path('songEffects'),
 
                            method='POST',
 
                            headers={
 
                                'Content-Type':
 
                                ['application/x-www-form-urlencoded']
 
                            },
 
                            postdata=urllib.urlencode([('drop', e)]),
 
                            postdata=urllib.parse.urlencode([('drop', e)]),
 
                        )
 
                    except KeyError:
 
                        pass
 

	
 
            if status == NOTEOFF:
 
                self.noteIsOn[d1] = False
 

	
 
            if 0:
 
                # curve editing mode, not done yet
 
                for group in [(23, 24, 25), (6, 18)]:
 
                    if d1 in group:
 
                        if not self.noteIsOn.get(group):
 
                            print "start zero"
 
                            print("start zero")
 

	
 
                            for d in group:
 
                                sendLiveInputPoint(curves[d], 0)
 
                            self.noteIsOn[group] = True
 
                        else:  # miss first update
 
                            sendLiveInputPoint(curves[d1], d2 / 127)
 

	
 
                    if status == 128:  #noteoff
 
                        for d in group:
 
                            sendLiveInputPoint(curves[d], 0)
 
                        self.noteIsOn[group] = False
 

	
bin/keyboardcomposer
Show inline comments
 
#!bin/python
 

	
 
from __future__ import division, nested_scopes
 

	
 
from run_local import log
 
import cgi, time, logging
 
from optparse import OptionParser
 
import webcolors, colorsys
 
from louie import dispatcher
 
from twisted.internet import reactor, tksupport
 
from twisted.web import resource
 
from rdflib import URIRef, Literal
 
import Tix as tk
 
import tkinter.tix as tk
 

	
 
from light9.Fadable import Fadable
 
from light9.subclient import SubClient
 
from light9 import showconfig, networking, prof
 
from light9.uihelpers import toplevelat
 
from light9.namespaces import L9, RDF, RDFS
 
from light9.tkdnd import initTkdnd, dragSourceRegister, dropTargetRegister
 
from light9 import clientsession
 
from rdfdb.syncedgraph import SyncedGraph
 
from light9.effect.sequencer import CodeWatcher
 
import light9.effect.effecteval
 
from light9.effect.settings import DeviceSettings
 
from rdfdb.patch import Patch
 
from light9.effect.simple_outputs import SimpleOutputs
 

	
 
from bcf2000 import BCF2000
 
import imp
 

	
 
nudge_keys = {'up': list('qwertyui'), 'down': list('asdfghjk')}
 

	
 

	
 
class DummySliders:
 

	
 
    def valueOut(self, name, value):
 
        pass
 

	
 
    def close(self):
 
        pass
 

	
 
@@ -241,46 +242,46 @@ class KeyboardComposer(tk.Frame, SubClie
 
    def redraw_sliders(self):
 
        self.draw_sliders()
 
        if len(self.rows):
 
            self.change_row(self.current_row)
 
            self.rows[self.current_row].focus()
 

	
 
        self.stop_frequent_update_time = 0
 

	
 
    def draw_sliders(self):
 
        for r in self.rows:
 
            r.destroy()
 
        self.rows = []
 
        for b in self.subbox.values():
 
        for b in list(self.subbox.values()):
 
            b.cleanup()
 
        self.subbox.clear()
 
        self.slider_table.clear()
 

	
 
        self.tk_focusFollowsMouse()
 

	
 
        rowcount = -1
 
        col = 0
 
        last_group = None
 

	
 
        withgroups = []
 
        for effect in self.graph.subjects(RDF.type, L9['Effect']):
 
            withgroups.append((self.graph.value(effect, L9['group']),
 
                               self.graph.value(effect, L9['order']),
 
                               self.graph.label(effect), effect))
 
        withgroups.sort()
 

	
 
        log.info("withgroups %s", withgroups)
 

	
 
        self.effectEval = {}
 
        reload(light9.effect.effecteval)
 
        imp.reload(light9.effect.effecteval)
 
        simpleOutputs = SimpleOutputs(self.graph)
 
        for group, order, sortLabel, effect in withgroups:
 
            if col == 0 or group != last_group:
 
                row = self.make_row(group)
 
                rowcount += 1
 
                col = 0
 

	
 
            subbox = SubmasterBox(row, self.graph, effect, self.session, col,
 
                                  rowcount)
 
            subbox.place(relx=col / 8, rely=0, relwidth=1 / 8, relheight=1)
 
            self.subbox[effect] = self.slider_table[(rowcount, col)] = subbox
 

	
 
@@ -329,25 +330,25 @@ class KeyboardComposer(tk.Frame, SubClie
 
                                width=1,
 
                                font=('Arial', 10),
 
                                bg='red',
 
                                fg='white',
 
                                anchor='c')
 
            keylabel.pack(side=tk.LEFT, expand=1, fill=tk.X)
 
            col += 1
 

	
 
        keyhintrow.pack(fill=tk.X, expand=0)
 
        self.keyhints = keyhintrow
 

	
 
    def setup_key_nudgers(self, tkobject):
 
        for d, keys in nudge_keys.items():
 
        for d, keys in list(nudge_keys.items()):
 
            for key in keys:
 
                # lowercase makes full=0
 
                keysym = "<KeyPress-%s>" % key
 
                tkobject.bind(keysym, \
 
                    lambda evt, num=keys.index(key), d=d: \
 
                        self.got_nudger(num, d))
 

	
 
                # uppercase makes full=1
 
                keysym = "<KeyPress-%s>" % key.upper()
 
                keysym = keysym.replace('SEMICOLON', 'colon')
 
                tkobject.bind(keysym, \
 
                    lambda evt, num=keys.index(key), d=d: \
 
@@ -492,25 +493,25 @@ class KeyboardComposer(tk.Frame, SubClie
 
                               newObject=group)
 

	
 
    def highlight_row(self, row):
 
        row = self.rows[row]
 
        row['bg'] = 'red'
 

	
 
    def unhighlight_row(self, row):
 
        row = self.rows[row]
 
        row['bg'] = 'black'
 

	
 
    def get_levels(self):
 
        return dict([
 
            (uri, box.slider_var.get()) for uri, box in self.subbox.items()
 
            (uri, box.slider_var.get()) for uri, box in list(self.subbox.items())
 
        ])
 

	
 
    def get_output_settings(self, _graph=None):
 
        _graph = _graph or self.graph
 
        outputSettings = []
 
        for setting in _graph.objects(self.session, L9['subSetting']):
 
            effect = _graph.value(setting, L9['sub'])
 
            strength = _graph.value(setting, L9['level'])
 
            if strength:
 
                now = time.time()
 
                out, report = self.effectEval[effect].outputFromEffect(
 
                    [(L9['strength'], strength)],
 
@@ -531,25 +532,25 @@ class KeyboardComposer(tk.Frame, SubClie
 
        stmts.extend([
 
            (effect, RDF.type, L9['Effect'], ctx),
 
            (effect, RDFS.label, Literal(subname), ctx),
 
            (effect, L9['publishAttr'], L9['strength'], ctx),
 
        ])
 

	
 
        self.graph.suggestPrefixes(ctx, {'eff': effect + '/'})
 
        self.graph.patch(Patch(addQuads=stmts, delQuads=[]))
 

	
 
        self.sub_name.delete(0, tk.END)
 

	
 
    def alltozero(self):
 
        for uri, subbox in self.subbox.items():
 
        for uri, subbox in list(self.subbox.items()):
 
            if subbox.scale.scale_var.get() != 0:
 
                subbox.scale.fade(value=0.0, length=0)
 

	
 

	
 
# move to web lib
 
def postArgGetter(request):
 
    """return a function that takes arg names and returns string
 
    values. Supports args encoded in the url or in postdata. No
 
    support for repeated args."""
 
    # this is something nevow normally does for me
 
    request.content.seek(0)
 
    fields = cgi.FieldStorage(request.content,
bin/lightsim
Show inline comments
 
#!bin/python
 

	
 
from __future__ import division
 

	
 
import run_local
 
import sys, logging
 

	
 
sys.path.append("lib")
 
import qt4reactor
 
qt4reactor.install()
 

	
 
from twisted.internet import reactor
 
from twisted.internet.task import LoopingCall
 
from twisted.web.xmlrpc import Proxy
 
from louie import dispatcher
 
from PyQt4.QtGui import QWidget, QLabel, QVBoxLayout, QHBoxLayout, QMainWindow
bin/listsongs
Show inline comments
 
@@ -12,17 +12,17 @@ from twisted.internet import reactor
 
from rdflib import RDF
 
from light9 import networking
 
from light9.namespaces import L9
 
from rdfdb.syncedgraph import SyncedGraph
 

	
 
graph = SyncedGraph(networking.rdfdb.url, "listsongs")
 

	
 

	
 
@graph.initiallySynced.addCallback
 
def printSongs(result):
 
    with graph.currentState() as current:
 
        for song in current.subjects(RDF.type, L9['Song']):
 
            print song
 
            print(song)
 
    reactor.stop()
 

	
 

	
 
reactor.run()
bin/mpd_timing_test
Show inline comments
 
@@ -2,19 +2,19 @@
 
"""
 
records times coming out of ascoltami
 

	
 
for example:
 

	
 
 % mpd_timing_test > timing
 
 # play some music in ascoltami, then ctrl-c
 
 % gnuplot
 
 > plot "timing" with lines
 

	
 
"""
 

	
 
import xmlrpclib, time
 
import xmlrpc.client, time
 

	
 
s = xmlrpclib.ServerProxy("http://localhost:8040")
 
s = xmlrpc.client.ServerProxy("http://localhost:8040")
 
start = time.time()
 
while 1:
 
    print time.time() - start, s.gettime()
 
while True:
 
    print(time.time() - start, s.gettime())
 
    time.sleep(.01)
bin/musictime
Show inline comments
 
#!/usr/bin/env python
 
import run_local
 
import light9.networking
 

	
 
import Tkinter as tk
 
import tkinter as tk
 
import time
 
import restkit, jsonlib
 

	
 

	
 
class MusicTime:
 

	
 
    def __init__(self, url):
 
        self.player = restkit.Resource(url)
 

	
 
    def get_music_time(self):
 
        playtime = None
 
        while not playtime:
 
            try:
 
                playtime = jsonlib.read(self.player.get("time").body_string(),
 
                                        use_float=True)['t']
 
            except restkit.RequestError, e:
 
                print "Server error %s, waiting" % e
 
            except restkit.RequestError as e:
 
                print("Server error %s, waiting" % e)
 
                time.sleep(2)
 
        return playtime
 

	
 

	
 
class MusicTimeTk(tk.Frame, MusicTime):
 

	
 
    def __init__(self, master, url):
 
        tk.Frame.__init__(self)
 
        MusicTime.__init__(self, url)
 
        self.timevar = tk.DoubleVar()
 
        self.timelabel = tk.Label(self,
 
                                  textvariable=self.timevar,
 
                                  bd=2,
 
                                  relief='raised',
 
                                  width=10,
 
                                  padx=2,
 
                                  pady=2,
 
                                  anchor='w')
 
        self.timelabel.pack(expand=1, fill='both')
 

	
 
        def print_time(evt, *args):
 
            self.timevar.set(self.get_music_time())
 
            print self.timevar.get(), evt.keysym
 
            print(self.timevar.get(), evt.keysym)
 

	
 
        self.timelabel.bind('<KeyPress>', print_time)
 
        self.timelabel.bind('<1>', print_time)
 
        self.timelabel.focus()
 
        self.update_time()
 

	
 
    def update_time(self):
 
        self.timevar.set(self.get_music_time())
 
        self.after(100, self.update_time)
 

	
 

	
 
if __name__ == "__main__":
bin/paintserver
Show inline comments
 
#!bin/python
 

	
 
from __future__ import division
 

	
 
from run_local import log
 
import json
 
from twisted.internet import reactor
 
from light9.greplin_cyclone import StatsForCyclone
 
from rdfdb.syncedgraph import SyncedGraph
 
from light9 import networking, showconfig
 
from greplin import scales
 
import optparse, sys, logging
 
import cyclone.web
 
from rdflib import URIRef
 
from light9 import clientsession
 
import light9.paint.solve
 
from lib.cycloneerr import PrettyErrorHandler
 
from light9.namespaces import RDF, L9, DEV
 
import imp
 

	
 

	
 
class Solve(PrettyErrorHandler, cyclone.web.RequestHandler):
 

	
 
    def post(self):
 
        painting = json.loads(self.request.body)
 
        with self.settings.stats.solve.time():
 
            img = self.settings.solver.draw(painting)
 
            sample, sampleDist = self.settings.solver.bestMatch(
 
                img, device=DEV['aura2'])
 
            with self.settings.graph.currentState() as g:
 
                bestPath = g.value(sample, L9['imagePath']).replace(L9[''], '')
 
@@ -33,25 +34,25 @@ class Solve(PrettyErrorHandler, cyclone.
 
        self.write(
 
            json.dumps({
 
                'bestMatch': {
 
                    'uri': sample,
 
                    'path': bestPath,
 
                    'dist': sampleDist
 
                },
 
                #    'layers': layers,
 
                #    'out': out,
 
            }))
 

	
 
    def reloadSolver(self):
 
        reload(light9.paint.solve)
 
        imp.reload(light9.paint.solve)
 
        self.settings.solver = light9.paint.solve.Solver(self.settings.graph)
 
        self.settings.solver.loadSamples()
 

	
 

	
 
class BestMatches(PrettyErrorHandler, cyclone.web.RequestHandler):
 

	
 
    def post(self):
 
        body = json.loads(self.request.body)
 
        painting = body['painting']
 
        devs = [URIRef(d) for d in body['devices']]
 
        with self.settings.stats.solve.time():
 
            img = self.settings.solver.draw(painting)
bin/picamserve
Show inline comments
 
#!env_pi/bin/python
 
from __future__ import division
 

	
 
from run_local import log
 
import sys
 
sys.path.append('/usr/lib/python2.7/dist-packages/')
 
import io, logging, traceback, time
 
import cyclone.web
 
from twisted.internet import reactor, threads
 
from twisted.internet.defer import inlineCallbacks
 
from light9 import prof
 

	
 
try:
 
    import picamera
 
    cameraCls = picamera.PiCamera
bin/run_local.py
Show inline comments
 
@@ -50,37 +50,37 @@ def fixSysPath():
 
        root + 'env/local/lib/python2.7/site-packages',
 
        root + 'env/local/lib/python2.7/site-packages/gtk-2.0',
 
        root + 'env/lib/python2.7/site-packages',
 
        root + 'env/lib/python2.7/site-packages/gtk-2.0',
 
    ]
 

	
 

	
 
fixSysPath()
 

	
 
from twisted.python.failure import Failure
 

	
 
try:
 
    import Tkinter
 
    import tkinter
 
except ImportError:
 
    pass
 
else:
 

	
 
    def rce(self, exc, val, tb):
 
        sys.stderr.write("Exception in Tkinter callback\n")
 
        if True:
 
            sys.excepthook(exc, val, tb)
 
        else:
 
            Failure(val, exc, tb).printDetailedTraceback()
 

	
 
    Tkinter.Tk.report_callback_exception = rce
 
    tkinter.Tk.report_callback_exception = rce
 

	
 
import coloredlogs, logging, time
 
try:
 
    import faulthandler
 
    faulthandler.enable()
 
except ImportError:
 
    pass
 

	
 
progName = sys.argv[0].split('/')[-1]
 
log = logging.getLogger()  # this has to get the root logger
 
log.name = progName  # but we can rename it for clarity
 

	
 
@@ -94,22 +94,22 @@ class FractionTimeFilter(logging.Filter)
 
        # Don't filter the record.
 
        return 1
 

	
 

	
 
coloredlogs.install(
 
    level='DEBUG',
 
    fmt='%(fractionTime)s %(name)s[%(process)d] %(levelname)s %(message)s')
 
logging.getLogger().handlers[0].addFilter(FractionTimeFilter())
 

	
 

	
 
def setTerminalTitle(s):
 
    if os.environ.get('TERM', '') in ['xterm', 'rxvt', 'rxvt-unicode-256color']:
 
        print "\033]0;%s\007" % s  # not escaped/protected correctly
 
        print("\033]0;%s\007" % s)  # not escaped/protected correctly
 

	
 

	
 
if 'listsongs' not in sys.argv[0] and 'homepageConfig' not in sys.argv[0]:
 
    setTerminalTitle(
 
        '[%s] %s' %
 
        (socket.gethostname(), ' '.join(sys.argv).replace('bin/', '')))
 

	
 
# see http://www.youtube.com/watch?v=3cIOT9kM--g for commands that make
 
# profiles and set background images
bin/staticclient
Show inline comments
 
#!bin/python
 
"""
 
push a dmx level forever
 
"""
 
from __future__ import division, nested_scopes
 

	
 
import time, logging
 
from optparse import OptionParser
 
import logging, urllib
 
import logging, urllib.request, urllib.parse, urllib.error
 
from twisted.internet import reactor, tksupport, task
 
from rdflib import URIRef, RDF, RDFS, Literal
 

	
 
from run_local import log
 
log.setLevel(logging.DEBUG)
 

	
 
from light9 import dmxclient, showconfig, networking
 

	
 
if __name__ == "__main__":
 
    parser = OptionParser(usage="%prog")
 
    parser.add_option('--chan', help='channel number, starts at 1',
 
                      type=int)  #todo: or name or uri
bin/subcomposer
Show inline comments
 
@@ -6,34 +6,34 @@ subcomposer
 

	
 
    EditChoice widget
 
      can change currentSub to another sub
 

	
 
    Levelbox widget
 
      watch observable(currentSub) for a new sub, and also watch currentSub for edits to push to the OneLevel widgets
 

	
 
        OneLevel widget
 
          UI edits are caught here and go all the way back to currentSub
 

	
 

	
 
"""
 
from __future__ import division, nested_scopes
 

	
 

	
 
from run_local import log
 
import time, logging
 

	
 
log.setLevel(logging.DEBUG)
 

	
 
from optparse import OptionParser
 
import logging, urllib
 
import Tkinter as tk
 
import logging, urllib.request, urllib.parse, urllib.error
 
import tkinter as tk
 
import louie as dispatcher
 
from twisted.internet import reactor, tksupport, task
 
from rdflib import URIRef, RDF, RDFS, Literal
 

	
 
from light9.dmxchanedit import Levelbox
 
from light9 import dmxclient, Submaster, prof, showconfig, networking
 
from light9.Patch import get_channel_name
 
from light9.uihelpers import toplevelat
 
from rdfdb.syncedgraph import SyncedGraph
 
from light9 import clientsession
 
from light9.tkdnd import initTkdnd
 
from light9.namespaces import L9
 
@@ -110,25 +110,25 @@ class Subcomposer(tk.Frame):
 

	
 
        def clicked(*args):
 
            self.makeGlobal(newName=e.get())
 
            box.destroy()
 

	
 
        b.bind("<Button-1>", clicked)
 
        e.focus()
 

	
 
    def makeGlobal(self, newName):
 
        """promote our local submaster into a non-local, named one"""
 
        uri = self.currentSub().uri
 
        newUri = showconfig.showUri() + ("/sub/%s" %
 
                                         urllib.quote(newName, safe=''))
 
                                         urllib.parse.quote(newName, safe=''))
 
        with self.graph.currentState(tripleFilter=(uri, None, None)) as current:
 
            if (uri, RDF.type, L9['LocalSubmaster']) not in current:
 
                raise ValueError("%s is not a local submaster" % uri)
 
            if (newUri, None, None) in current:
 
                raise ValueError("new uri %s is in use" % newUri)
 

	
 
        # the local submaster was storing in ctx=self.session, but now
 
        # we want it to be in ctx=uri
 

	
 
        self.relocateSub(newUri, newName)
 

	
 
        # these are in separate patches for clarity as i'm debugging this
 
@@ -152,26 +152,26 @@ class Subcomposer(tk.Frame):
 
            return u
 

	
 
        delQuads = self.currentSub().allQuads()
 
        addQuads = [(repl(s), p, repl(o), newUri) for s, p, o, c in delQuads]
 
        # patch can't span contexts yet
 
        self.graph.patch(Patch(addQuads=addQuads, delQuads=[]))
 
        self.graph.patch(Patch(addQuads=[], delQuads=delQuads))
 

	
 
    def setupSubChoiceLinks(self):
 
        graph = self.graph
 

	
 
        def ann():
 
            print "currently: session=%s currentSub=%r _currentChoice=%r" % (
 
                self.session, self.currentSub(), self._currentChoice())
 
            print("currently: session=%s currentSub=%r _currentChoice=%r" % (
 
                self.session, self.currentSub(), self._currentChoice()))
 

	
 
        @graph.addHandler
 
        def graphChanged():
 
            # some bug where SC is making tons of graph edits and many
 
            # are failing. this calms things down.
 
            log.warn('skip graphChanged')
 
            return
 

	
 
            s = graph.value(self.session, L9['currentSub'])
 
            log.debug('HANDLER getting session currentSub from graph: %s', s)
 
            if s is None:
 
                s = self.switchToLocal()
 
@@ -236,25 +236,25 @@ class Subcomposer(tk.Frame):
 

	
 
    def setupLevelboxUi(self):
 
        self.levelbox = Levelbox(self, self.graph, self.currentSub)
 
        self.levelbox.pack(side='top')
 

	
 
        tk.Button(
 
            self,
 
            text="All to zero",
 
            command=lambda *args: self.currentSub().clear()).pack(side='top')
 

	
 
    def savenewsub(self, subname):
 
        leveldict = {}
 
        for i, lev in zip(range(len(self.levels)), self.levels):
 
        for i, lev in zip(list(range(len(self.levels))), self.levels):
 
            if lev != 0:
 
                leveldict[get_channel_name(i + 1)] = lev
 

	
 
        s = Submaster.Submaster(subname, levels=leveldict)
 
        s.save()
 

	
 
    def sendupdate(self):
 
        d = self.currentSub().get_dmx_list()
 
        dmxclient.outputlevels(d, twisted=True)
 

	
 

	
 
def launch(opts, args, root, graph, session):
bin/tkdnd_minimal_drop.py
Show inline comments
 
#!bin/python
 
from run_local import log
 
import Tkinter as tk
 
import tkinter as tk
 
from light9.tkdnd import initTkdnd, dropTargetRegister
 
from twisted.internet import reactor, tksupport
 

	
 
root = tk.Tk()
 
initTkdnd(root.tk, "tkdnd/trunk/")
 
label = tk.Label(root, borderwidth=2, relief='groove', padx=10, pady=10)
 
label.pack()
 
label.config(text="drop target %s" % label._w)
 

	
 
frame1 = tk.Frame()
 
frame1.pack()
 

	
 
labelInner = tk.Label(frame1, borderwidth=2, relief='groove', padx=10, pady=10)
 
labelInner.pack(side='left')
 
labelInner.config(text="drop target inner %s" % labelInner._w)
 
tk.Label(frame1, text="not a target").pack(side='left')
 

	
 

	
 
def onDrop(ev):
 
    print "onDrop", ev
 
    print("onDrop", ev)
 

	
 

	
 
def enter(ev):
 
    print 'enter', ev
 
    print('enter', ev)
 

	
 

	
 
def leave(ev):
 
    print 'leave', ev
 
    print('leave', ev)
 

	
 

	
 
dropTargetRegister(label,
 
                   onDrop=onDrop,
 
                   onDropEnter=enter,
 
                   onDropLeave=leave,
 
                   hoverStyle=dict(background="yellow", relief='groove'))
 

	
 
dropTargetRegister(labelInner,
 
                   onDrop=onDrop,
 
                   onDropEnter=enter,
 
                   onDropLeave=leave,
 
                   hoverStyle=dict(background="yellow", relief='groove'))
 

	
 

	
 
def prn():
 
    print "cont", root.winfo_containing(201, 151)
 
    print("cont", root.winfo_containing(201, 151))
 

	
 

	
 
b = tk.Button(root, text="coord", command=prn)
 
b.pack()
 

	
 
#tk.mainloop()
 
tksupport.install(root, ms=10)
 
reactor.run()
bin/tracker
Show inline comments
 
#!/usr/bin/python
 
from __future__ import division, nested_scopes
 

	
 

	
 
import sys
 
sys.path.append("../../editor/pour")
 
sys.path.append("../light8")
 

	
 
from Submaster import Submaster
 
from skim.zooming import Zooming, Pair
 
from math import sqrt, sin, cos
 
from pygame.rect import Rect
 
from xmlnodebase import xmlnodeclass, collectiveelement, xmldocfile
 
from dispatch import dispatcher
 

	
 
import dmxclient
 

	
 
import Tkinter as tk
 
import tkinter as tk
 

	
 
defaultfont = "arial 8"
 

	
 

	
 
def pairdist(pair1, pair2):
 
    return pair1.dist(pair2)
 

	
 

	
 
def canvashighlighter(canvas, obj, attribute, normalval, highlightval):
 
    """creates bindings on a canvas obj that make attribute go
 
    from normal to highlight when the mouse is over the obj"""
 
    canvas.tag_bind(
 
@@ -71,28 +71,28 @@ class Fieldset(collectiveelement):
 

	
 
    def version(self):
 
        """read-only version attribute on fieldset tag"""
 
        return self._getorsetattr("version", None)
 

	
 
    def report(self, x, y):
 
        """reports active fields and their intensities"""
 
        active = 0
 
        for f in self.getall():
 
            name = f.name()
 
            intens = f.calc(x, y)
 
            if intens > 0:
 
                print name, intens,
 
                print(name, intens, end=' ')
 
                active += 1
 
        if active > 0:
 
            print
 
            print()
 
        self.dmxsend(x, y)
 

	
 
    def dmxsend(self, x, y):
 
        """output lights to dmx"""
 
        levels = dict([(f.name(), f.calc(x, y)) for f in self.getall()])
 
        dmxlist = Submaster(None, levels).get_dmx_list()
 
        dmxclient.outputlevels(dmxlist)
 

	
 
    def getbounds(self):
 
        """returns xmin,xmax,ymin,ymax for the non-zero areas of this field"""
 
        r = None
 
        for f in self.getall():
 
@@ -126,25 +126,25 @@ class FieldDisplay:
 
        self.canvas = canvas
 
        self.field = field
 
        self.tags = [str(id(self))]  # canvas tag to id our objects
 

	
 
    def setcoords(self):
 
        """adjust canvas obj coords to match the field"""
 
        # this uses the canvas object ids saved by makeobjs
 
        f = self.field
 
        c = self.canvas
 
        w2c = self.canvas.world2canvas
 

	
 
        # rings
 
        for intens, ring in self.rings.items():
 
        for intens, ring in list(self.rings.items()):
 
            rad = f.getdistforintensity(intens)
 
            p1 = w2c(*(f.center() - Pair(rad, rad)))
 
            p2 = w2c(*(f.center() + Pair(rad, rad)))
 
            c.coords(ring, p1[0], p1[1], p2[0], p2[1])
 

	
 
        # text
 
        p1 = w2c(*f.center())
 
        c.coords(self.txt, *p1)
 

	
 
    def makeobjs(self):
 
        """(re)create the canvas objs (null coords) and make their bindings"""
 
        c = self.canvas
 
@@ -242,25 +242,25 @@ class Tracker(tk.Frame):
 
        self.displays = {}
 

	
 
        c = self.canvas = Zooming(self, bg='black', closeenough=5)
 
        c.pack(fill='both', exp=1)
 

	
 
        # preserve edge coords over window resize
 
        c.bind("<Configure>", self.configcoords)
 

	
 
        c.bind("<Motion>", lambda ev: self._fieldset().report(*c.canvas2world(
 
            ev.x, ev.y)))
 

	
 
        def save(ev):
 
            print "saving"
 
            print("saving")
 
            self.fieldsetfile.save()
 

	
 
        master.bind("<Key-s>", save)
 
        dispatcher.connect(self.autobounds, "field coord changed")
 

	
 
    def _fieldset(self):
 
        return self.fieldsetfile.fieldset()
 

	
 
    def load(self, filename):
 
        self.fieldsetfile = Fieldsetfile(filename)
 
        self.displays.clear()
 
        for f in self.fieldsetfile.fieldset().getall():
 
@@ -287,25 +287,25 @@ class Tracker(tk.Frame):
 

	
 
        c = self.canvas
 
        c.delete('cornercoords')
 
        for x, anc2 in ((self.xmin, 'w'), (self.xmax, 'e')):
 
            for y, anc1 in ((self.ymin, 'n'), (self.ymax, 's')):
 
                pos = c.world2canvas(x, y)
 
                c.create_text(pos[0],
 
                              pos[1],
 
                              text="%s,%s" % (x, y),
 
                              fill='white',
 
                              anchor=anc1 + anc2,
 
                              tags='cornercoords')
 
        [d.setcoords() for d in self.displays.values()]
 
        [d.setcoords() for d in list(self.displays.values())]
 

	
 

	
 
########################################################################
 
########################################################################
 

	
 
root = tk.Tk()
 
root.wm_geometry('700x350')
 
tra = Tracker(root)
 
tra.pack(fill='both', exp=1)
 

	
 
tra.load("fieldsets/demo")
 

	
bin/wavecurve
Show inline comments
 
#!bin/python
 
import optparse
 
import run_local
 
from light9.wavepoints import simp
 

	
 

	
 
def createCurve(inpath, outpath, t):
 
    print "reading %s, writing %s" % (inpath, outpath)
 
    print("reading %s, writing %s" % (inpath, outpath))
 
    points = simp(inpath.replace('.ogg', '.wav'), seconds_per_average=t)
 

	
 
    f = file(outpath, 'w')
 
    for time_val in points:
 
        print >> f, "%s %s" % time_val
 
        print("%s %s" % time_val, file=f)
 

	
 

	
 
parser = optparse.OptionParser(usage="""%prog inputSong.wav outputCurve
 

	
 
You probably just want -a
 

	
 
""")
 
parser.add_option("-t",
 
                  type="float",
 
                  default=.01,
 
                  help="seconds per sample (default .01, .07 is smooth)")
 
parser.add_option("-a",
bin/webcontrol
Show inline comments
 
#!bin/python
 
"""
 
web UI for various commands that we might want to run from remote
 
computers and phones
 

	
 
todo:
 
disable buttons that don't make sense
 
"""
 
import sys, xmlrpclib, traceback
 
import sys, xmlrpc.client, traceback
 
from twisted.internet import reactor
 
from twisted.python import log
 
from twisted.python.util import sibpath
 
from twisted.internet.defer import inlineCallbacks, returnValue
 
from twisted.web.client import getPage
 
from nevow.appserver import NevowSite
 
from nevow import rend, static, loaders, inevow, url, tags as T
 
from rdflib import URIRef
 
from louie.robustapply import robust_apply
 
sys.path.append(".")
 
from light9 import showconfig, networking
 
from light9.namespaces import L9
 
from urllib import urlencode
 
from urllib.parse import urlencode
 

	
 

	
 
# move to web lib
 
def post(url, **args):
 
    return getPage(url, method='POST', postdata=urlencode(args))
 

	
 

	
 
class Commands(object):
 

	
 
    @staticmethod
 
    def playSong(graph, songUri):
 
        s = xmlrpclib.ServerProxy(networking.musicPlayer.url)
 
        s = xmlrpc.client.ServerProxy(networking.musicPlayer.url)
 
        songPath = graph.value(URIRef(songUri), L9.showPath)
 
        if songPath is None:
 
            raise ValueError("unknown song %s" % songUri)
 
        return s.playfile(songPath.encode('ascii'))
 

	
 
    @staticmethod
 
    def stopMusic(graph):
 
        s = xmlrpclib.ServerProxy(networking.musicPlayer.url)
 
        s = xmlrpc.client.ServerProxy(networking.musicPlayer.url)
 
        return s.stop()
 

	
 
    @staticmethod
 
    def worklightsOn(graph):
 
        return post(networking.keyboardComposer.path('fadesub'),
 
                    subname='scoop',
 
                    level=.5,
 
                    secs=.5)
 

	
 
    @staticmethod
 
    def worklightsOff(graph):
 
        return post(networking.keyboardComposer.path('fadesub'),
 
@@ -81,32 +81,32 @@ class Main(rend.Page):
 
        for song in songs:
 
            out.append(
 
                T.form(method="post", action="playSong")
 
                [T.input(type='hidden', name='songUri', value=song),
 
                 T.button(type='submit')[graph.label(song)]])
 
        return out
 

	
 
    @inlineCallbacks
 
    def locateChild(self, ctx, segments):
 
        try:
 
            func = getattr(Commands, segments[0])
 
            req = inevow.IRequest(ctx)
 
            simpleArgDict = dict((k, v[0]) for k, v in req.args.items())
 
            simpleArgDict = dict((k, v[0]) for k, v in list(req.args.items()))
 
            try:
 
                ret = yield robust_apply(func, func, self.graph,
 
                                         **simpleArgDict)
 
            except KeyboardInterrupt:
 
                raise
 
            except Exception, e:
 
                print "Error on command %s" % segments[0]
 
            except Exception as e:
 
                print("Error on command %s" % segments[0])
 
                traceback.print_exc()
 
                returnValue((url.here.up().add('status',
 
                                               str(e)).add('error',
 
                                                           1), segments[1:]))
 

	
 
            returnValue((url.here.up().add('status', ret), segments[1:]))
 
            #actually return the orig page, with a status message from the func
 
        except AttributeError:
 
            pass
 
        returnValue(rend.Page.locateChild(self, ctx, segments))
 

	
 
    def child_icon(self, ctx):
light9/Effects.py
Show inline comments
 
from __future__ import division
 

	
 
import random as random_mod
 
import math
 
import logging, colorsys
 
import light9.Submaster as Submaster
 
from chase import chase as chase_logic
 
import showconfig
 
from .chase import chase as chase_logic
 
from . import showconfig
 
from rdflib import RDF
 
from light9 import Patch
 
from light9.namespaces import L9
 
log = logging.getLogger()
 

	
 
registered = []
 

	
 

	
 
def register(f):
 
    registered.append(f)
 
    return f
 

	
 
@@ -68,25 +68,25 @@ def chase(t,
 
          names=None,
 
          combiner=max,
 
          random=False):
 
    """names is list of URIs. returns a submaster that chases through
 
    the inputs"""
 
    if random:
 
        r = random_mod.Random(random)
 
        names = names[:]
 
        r.shuffle(names)
 

	
 
    chase_vals = chase_logic(t, ontime, offset, onval, offval, names, combiner)
 
    lev = {}
 
    for uri, value in chase_vals.items():
 
    for uri, value in list(chase_vals.items()):
 
        try:
 
            dmx = Patch.dmx_from_uri(uri)
 
        except KeyError:
 
            log.info(("chase includes %r, which doesn't resolve to a dmx chan" %
 
                      uri))
 
            continue
 
        lev[dmx] = value
 

	
 
    return Submaster.Submaster(name="chase", levels=lev)
 

	
 

	
 
@register
 
@@ -133,25 +133,25 @@ def stack(t, names=None, fade=0):
 
def smoove(x):
 
    return -2 * (x**3) + 3 * (x**2)
 

	
 

	
 
def configExprGlobals():
 
    graph = showconfig.getGraph()
 
    ret = {}
 

	
 
    for chaseUri in graph.subjects(RDF.type, L9['Chase']):
 
        shortName = chaseUri.rsplit('/')[-1]
 
        chans = graph.value(chaseUri, L9['channels'])
 
        ret[shortName] = list(graph.items(chans))
 
        print "%r is a chase" % shortName
 
        print("%r is a chase" % shortName)
 

	
 
    for f in registered:
 
        ret[f.__name__] = f
 

	
 
    ret['nsin'] = lambda x: (math.sin(x * (2 * math.pi)) + 1) / 2
 
    ret['ncos'] = lambda x: (math.cos(x * (2 * math.pi)) + 1) / 2
 

	
 
    def nsquare(t, on=.5):
 
        return (t % 1.0) < on
 

	
 
    ret['nsquare'] = nsquare
 

	
light9/Fadable.py
Show inline comments
 
# taken from SnackMix -- now that's reusable code
 
from Tix import *
 
from tkinter.tix import *
 
import time
 

	
 

	
 
class Fadable:
 
    """Fading mixin: must mix in with a Tk widget (or something that has
 
    'after' at least) This is currently used by VolumeBox and MixerTk.
 
    It's probably too specialized to be used elsewhere, but could possibly
 
    work with an Entry or a Meter, I guess.  (Actually, this is used by
 
    KeyboardComposer and KeyboardRecorder now too.)
 

	
 
    var is a Tk variable that should be used to set and get the levels.
 
    If use_fades is true, it will use fades to move between levels.
light9/FlyingFader.py
Show inline comments
 
from Tix import *
 
from tkinter.tix import *
 
from time import time, sleep
 
from __future__ import division
 

	
 

	
 

	
 
class Mass:
 

	
 
    def __init__(self):
 
        self.x = 0  # position
 
        self.xgoal = 0  # position goal
 

	
 
        self.v = 0  # velocity
 
        self.maxspeed = .8  # maximum speed, in position/second
 
        self.maxaccel = 3  # maximum acceleration, in position/second^2
 
        self.eps = .03  # epsilon - numbers within this much are considered the same
light9/Patch.py
Show inline comments
 
@@ -2,26 +2,25 @@ import os
 
from rdflib import RDF
 
from light9.namespaces import L9
 
from light9 import showconfig
 

	
 

	
 
def resolve_name(channelname):
 
    "Ensure that we're talking about the primary name of the light."
 
    return get_channel_name(get_dmx_channel(channelname))
 

	
 

	
 
def get_all_channels():
 
    """returns primary names for all channels (sorted)"""
 
    prinames = reverse_patch.values()[:]
 
    prinames.sort()
 
    prinames = sorted(list(reverse_patch.values())[:])
 
    return prinames
 

	
 

	
 
def get_dmx_channel(name):
 
    if str(name) in patch:
 
        return patch[str(name)]
 

	
 
    try:
 
        i = int(name)
 
        return i
 
    except ValueError:
 
        raise ValueError("Invalid channel name: %r" % name)
light9/Submaster.py
Show inline comments
 
from __future__ import division
 

	
 
import os, logging, time
 
from rdflib import Graph, RDF
 
from rdflib import RDFS, Literal, BNode
 
from light9.namespaces import L9, XSD
 
from light9.TLUtility import dict_scale, dict_max
 
from light9 import showconfig
 
from light9.Patch import resolve_name, get_dmx_channel, get_channel_uri, reload_data
 
from louie import dispatcher
 
from rdfdb.patch import Patch
 
from .rdfdb.patch import Patch
 
log = logging.getLogger('submaster')
 

	
 
class Submaster(object):
 
    """mapping of channels to levels"""
 
    def __init__(self, name, levels):
 
        """this sub has a name just for debugging. It doesn't get persisted.
 
        See PersistentSubmaster.
 

	
 
        levels is a dict
 
        """
 
        self.name = name
 
        self.levels = levels
 
@@ -29,67 +29,66 @@ class Submaster(object):
 

	
 
        #log.debug("%s initial levels %s", self.name, self.levels)
 

	
 
    def _editedLevels(self):
 
        pass
 

	
 
    def set_level(self, channelname, level, save=True):
 
        self.levels[resolve_name(channelname)] = level
 
        self._editedLevels()
 

	
 
    def set_all_levels(self, leveldict):
 
        self.levels.clear()
 
        for k, v in leveldict.items():
 
        for k, v in list(leveldict.items()):
 
            # this may call _editedLevels too many times
 
            self.set_level(k, v, save=0)
 

	
 
    def get_levels(self):
 
        return self.levels
 

	
 
    def no_nonzero(self):
 
        return all(v == 0 for v in self.levels.itervalues())
 
        return all(v == 0 for v in self.levels.values())
 

	
 
    def __mul__(self, scalar):
 
        return Submaster("%s*%s" % (self.name, scalar),
 
                         levels=dict_scale(self.levels, scalar))
 
    __rmul__ = __mul__
 
    def max(self, *othersubs):
 
        return sub_maxes(self, *othersubs)
 

	
 
    def __add__(self, other):
 
        return self.max(other)
 

	
 
    def ident(self):
 
        return (self.name, tuple(sorted(self.levels.items())))
 

	
 
    def __repr__(self):
 
        items = getattr(self, 'levels', {}).items()
 
        items.sort()
 
        items = sorted(list(getattr(self, 'levels', {}).items()))
 
        levels = ' '.join(["%s:%.2f" % item for item in items])
 
        return "<'%s': [%s]>" % (getattr(self, 'name', 'no name yet'), levels)
 

	
 
    def __cmp__(self, other):
 
        # not sure how useful this is
 
        if not isinstance(other, Submaster):
 
            return -1
 
        return cmp(self.ident(), other.ident())
 

	
 
    def __hash__(self):
 
        return hash(self.ident())
 

	
 
    def get_dmx_list(self):
 
        leveldict = self.get_levels() # gets levels of sub contents
 

	
 
        levels = []
 
        for k, v in leveldict.items():
 
        for k, v in list(leveldict.items()):
 
            if v == 0:
 
                continue
 
            try:
 
                dmxchan = get_dmx_channel(k) - 1
 
            except ValueError:
 
                log.error("error trying to compute dmx levels for submaster %s"
 
                          % self.name)
 
                raise
 
            if dmxchan >= len(levels):
 
                levels.extend([0] * (dmxchan - len(levels) + 1))
 
            levels[dmxchan] = max(v, levels[dmxchan])
 

	
 
@@ -105,27 +104,27 @@ class Submaster(object):
 
        names.  The levels will be the same."""
 
        newsub = Submaster("%s (normalized)" % self.name, {})
 
        newsub.set_all_levels(self.levels)
 
        return newsub
 

	
 
    def crossfade(self, othersub, amount):
 
        """Returns a new sub that is a crossfade between this sub and
 
        another submaster.
 

	
 
        NOTE: You should only crossfade between normalized submasters."""
 
        otherlevels = othersub.get_levels()
 
        keys_set = {}
 
        for k in self.levels.keys() + otherlevels.keys():
 
        for k in list(self.levels.keys()) + list(otherlevels.keys()):
 
            keys_set[k] = 1
 
        all_keys = keys_set.keys()
 
        all_keys = list(keys_set.keys())
 

	
 
        xfaded_sub = Submaster("xfade", {})
 
        for k in all_keys:
 
            xfaded_sub.set_level(k,
 
                                 linear_fade(self.levels.get(k, 0),
 
                                             otherlevels.get(k, 0),
 
                                             amount))
 

	
 
        return xfaded_sub
 

	
 
class PersistentSubmaster(Submaster):
 
    def __init__(self, graph, uri):
 
@@ -232,25 +231,25 @@ class PersistentSubmaster(Submaster):
 
        return quads
 

	
 

	
 
    def save(self):
 
        raise NotImplementedError("obsolete?")
 
        if self.temporary:
 
            log.info("not saving temporary sub named %s",self.name)
 
            return
 

	
 
        graph = Graph()
 
        subUri = L9['sub/%s' % self.name]
 
        graph.add((subUri, RDFS.label, Literal(self.name)))
 
        for chan in self.levels.keys():
 
        for chan in list(self.levels.keys()):
 
            try:
 
                chanUri = get_channel_uri(chan)
 
            except KeyError:
 
                log.error("saving dmx channels with no :Channel node "
 
                          "is not supported yet. Give channel %s a URI "
 
                          "for it to be saved. Omitting this channel "
 
                          "from the sub." % chan)
 
                continue
 
            lev = BNode()
 
            graph.add((subUri, L9['lightLevel'], lev))
 
            graph.add((lev, L9['channel'], chanUri))
 
            graph.add((lev, L9['level'],
 
@@ -270,25 +269,25 @@ def sub_maxes(*subs):
 
    nonzero_subs = [s for s in subs if not s.no_nonzero()]
 
    name = "max(%s)" % ", ".join([repr(s) for s in nonzero_subs])
 
    return Submaster(name,
 
                     levels=dict_max(*[sub.levels for sub in nonzero_subs]))
 

	
 
def combine_subdict(subdict, name=None, permanent=False):
 
    """A subdict is { Submaster objects : levels }.  We combine all
 
    submasters first by multiplying the submasters by their corresponding
 
    levels and then max()ing them together.  Returns a new Submaster
 
    object.  You can give it a better name than the computed one that it
 
    will get or make it permanent if you'd like it to be saved to disk.
 
    Serves 8."""
 
    scaledsubs = [sub * level for sub, level in subdict.items()]
 
    scaledsubs = [sub * level for sub, level in list(subdict.items())]
 
    maxes = sub_maxes(*scaledsubs)
 
    if name:
 
        maxes.name = name
 
    if permanent:
 
        maxes.temporary = False
 

	
 
    return maxes
 

	
 
class Submasters(object):
 
    "Collection o' Submaster objects"
 
    def __init__(self, graph):
 
        self.submasters = {} # uri : Submaster
 
@@ -305,26 +304,25 @@ class Submasters(object):
 
            log.debug("found sub %s", s)
 
            if s not in self.submasters:
 
                sub = self.submasters[s] = PersistentSubmaster(self.graph, s)
 
                dispatcher.send("new submaster", sub=sub)
 
            current.add(s)
 
        for s in set(self.submasters.keys()) - current:
 
            del self.submasters[s]
 
            dispatcher.send("lost submaster", subUri=s)
 
        log.info("findSubs finished, %s subs", len(self.submasters))
 

	
 
    def get_all_subs(self):
 
        "All Submaster objects"
 
        l = self.submasters.items()
 
        l.sort()
 
        l = sorted(list(self.submasters.items()))
 
        l = [x[1] for x in l]
 
        songs = []
 
        notsongs = []
 
        for s in l:
 
            if s.name and s.name.startswith('song'):
 
                songs.append(s)
 
            else:
 
                notsongs.append(s)
 
        combined = notsongs + songs
 

	
 
        return combined
 

	
light9/TLUtility.py
Show inline comments
 
"""Collected utility functions, many are taken from Drew's utils.py in
 
Cuisine CVS and Hiss's Utility.py."""
 

	
 
from __future__ import generators
 

	
 
import sys
 

	
 
__author__ = "David McClosky <dmcc@bigasterisk.com>, " + \
 
             "Drew Perttula <drewp@bigasterisk.com>"
 
__cvsid__ = "$Id: TLUtility.py,v 1.1 2003/05/25 08:25:35 dmcc Exp $"
 
__version__ = "$Revision: 1.1 $"[11:-2]
 

	
 
def make_attributes_from_args(*argnames):
 
    """
 
    This function simulates the effect of running
 
      self.foo=foo
 
    for each of the given argument names ('foo' in the example just
 
@@ -23,58 +23,58 @@ def make_attributes_from_args(*argnames)
 
            self.foo=foo
 
            self.bar=bar
 
            self.baz=baz
 
            ... 
 
    """
 
    
 
    callerlocals=sys._getframe(1).f_locals
 
    callerself=callerlocals['self']
 
    for a in argnames:
 
        try:
 
            setattr(callerself,a,callerlocals[a])
 
        except KeyError:
 
            raise KeyError, "Function has no argument '%s'" % a
 
            raise KeyError("Function has no argument '%s'" % a)
 

	
 
def enumerate(*collections):
 
    """Generates an indexed series:  (0,coll[0]), (1,coll[1]) ...
 
    
 
    this is a multi-list version of the code from the PEP:
 
    enumerate(a,b) gives (0,a[0],b[0]), (1,a[1],b[1]) ...
 
    """
 
    i = 0
 
    iters = [iter(collection) for collection in collections]
 
    while 1:
 
        yield [i,] + [iterator.next() for iterator in iters]
 
    while True:
 
        yield [i,] + [next(iterator) for iterator in iters]
 
        i += 1
 

	
 
def dumpobj(o):
 
    """Prints all the object's non-callable attributes"""
 
    print repr(o)
 
    print(repr(o))
 
    for a in [x for x in dir(o) if not callable(getattr(o, x))]:
 
        try:
 
            print "  %20s: %s " % (a, getattr(o, a))
 
            print("  %20s: %s " % (a, getattr(o, a)))
 
        except:
 
            pass
 
    print ""
 
    print("")
 

	
 
def dict_filter_update(d, **newitems):
 
    """Adds a set of new keys and values to dictionary 'd' if the values are
 
    true:
 

	
 
    >>> some_dict = {}
 
    >>> dict_filter_update(some_dict, a=None, b=0, c=1, e={}, s='hello')
 
    >>> some_dict
 
    {'c': 1, 's': 'hello'}
 
    """
 
    for k, v in newitems.items():
 
    for k, v in list(newitems.items()):
 
        if v: d[k] = v
 

	
 
def try_get_logger(channel):
 
    """Tries to get a logger with the channel 'channel'.  Will return a
 
    silent DummyClass if logging is not available."""
 
    try:
 
        import logging
 
        log = logging.getLogger(channel)
 
    except ImportError:
 
        log = DummyClass()
 
    return log
 

	
 
@@ -100,25 +100,25 @@ class DummyClass:
 
        """Constructs a DummyClass"""
 
        make_attributes_from_args('use_warnings', 'raise_exceptions')
 
    def __getattr__(self, key):
 
        """Raises an exception to warn the user that a Dummy is not being
 
        replaced in time."""
 
        if key == "__del__":
 
            return
 
        msg = "Attempted usage of '%s' on a DummyClass" % key
 
        if self.use_warnings:
 
            import warnings
 
            warnings.warn(msg)
 
        if self.raise_exceptions:
 
            raise AttributeError, msg
 
            raise AttributeError(msg)
 
        return lambda *args, **kw: self.bogus_function()
 
    def bogus_function(self):
 
        pass
 

	
 
class ClassyDict(dict):
 
    """A dict that accepts attribute-style access as well (for keys
 
    that are legal names, obviously). I used to call this Struct, but
 
    chose the more colorful name to avoid confusion with the struct
 
    module."""
 
    def __getattr__(self, a):
 
        return self[a]
 
    def __setattr__(self, a, v):
 
@@ -135,52 +135,52 @@ def trace(func):
 
    >>>
 
    >>>
 
    >>> f = trace(f)
 
    >>> f(1, 2)
 
    |>> f called args: [1, 2]
 
    1 2 3
 
    <<| f returned 3
 
    3
 

	
 
    TODO: print out default keywords (maybe)
 
          indent for recursive call like the lisp version (possible use of 
 
              generators?)"""
 
    name = func.func_name
 
    name = func.__name__
 
    def tracer(*args, **kw):
 
        s = '|>> %s called' % name
 
        if args:
 
            s += ' args: %r' % list(args)
 
        if kw:
 
            s += ' kw: %r' % kw
 
        print s
 
        print(s)
 
        ret = func(*args, **kw)
 
        print '<<| %s returned %s' % (name, ret)
 
        print('<<| %s returned %s' % (name, ret))
 
        return ret
 
    return tracer
 

	
 
# these functions taken from old light8 code
 
def dict_max(*dicts):
 
    """
 
    ({'a' : 5, 'b' : 9}, {'a' : 10, 'b' : 4})
 
      returns ==> {'a' : 10, 'b' : 9}
 
    """
 
    newdict = {}
 
    for d in dicts:
 
        for k,v in d.items():
 
        for k,v in list(d.items()):
 
            newdict[k] = max(v, newdict.get(k, 0))
 
    return newdict
 

	
 
def dict_scale(d,scl):
 
    """scales all values in dict and returns a new dict"""
 
    return dict([(k,v*scl) for k,v in d.items()])
 
    return dict([(k,v*scl) for k,v in list(d.items())])
 
    
 
def dict_subset(d, dkeys, default=0):
 
    """Subset of dictionary d: only the keys in dkeys.  If you plan on omitting
 
    keys, make sure you like the default."""
 
    newd = {} # dirty variables!
 
    for k in dkeys:
 
        newd[k] = d.get(k, default)
 
    return newd
 

	
 
# functions specific to Timeline
 
# TBD
 
def last_less_than(array, x):
light9/ascoltami/player.py
Show inline comments
 
#!/usr/bin/python
 
"""
 
alternate to the mpd music player, for ascoltami
 
"""
 
from __future__ import division
 

	
 
import time, logging, traceback
 
from gi.repository import GObject, Gst
 
from twisted.internet import reactor, task
 

	
 
log = logging.getLogger()
 

	
 

	
 
class Player(object):
 

	
 
    def __init__(self, autoStopOffset=4, onEOS=None):
 
        """autoStopOffset is the number of seconds before the end of
 
        song before automatically stopping (which is really pausing).
 
@@ -46,32 +46,32 @@ class Player(object):
 
                self.pause()
 

	
 
            self.lastWatchTime = t
 
        except:
 
            traceback.print_exc()
 

	
 
    def watchForMessages(self, bus):
 
        """this would be nicer than pollForMessages but it's not working for
 
        me. It's like add_signal_watch isn't running."""
 
        bus.add_signal_watch()
 

	
 
        def onEos(*args):
 
            print "onEos", args
 
            print("onEos", args)
 
            if self.onEOS is not None:
 
                self.onEOS(self.getSong())
 

	
 
        bus.connect('message::eos', onEos)
 

	
 
        def onStreamStatus(bus, message):
 
            print "streamstatus", bus, message
 
            print("streamstatus", bus, message)
 
            (statusType, _elem) = message.parse_stream_status()
 
            if statusType == Gst.StreamStatusType.ENTER:
 
                self.setupAutostop()
 

	
 
        bus.connect('message::stream-status', onStreamStatus)
 

	
 
    def pollForMessages(self):
 
        """bus.add_signal_watch seems to be having no effect, but this works"""
 
        bus = self.pipeline.get_bus()
 
        mt = Gst.MessageType
 
        msg = bus.poll(
 
            mt.EOS | mt.STREAM_STATUS | mt.ERROR,  # | mt.ANY,
light9/chase.py
Show inline comments
 
from __future__ import division
 

	
 

	
 

	
 
def chase(t,
 
          ontime=0.5,
 
          offset=0.2,
 
          onval=1.0,
 
          offval=0.0,
 
          names=None,
 
          combiner=max):
 
    names = names or []
 
    # maybe this is better:
 
    # period = ontime + ((offset + ontime) * (len(names) - 1))
 
@@ -34,15 +34,14 @@ def chase(t,
 

	
 

	
 
if __name__ == "__main__":
 
    # a little testing
 
    for x in range(80):
 
        x /= 20.0
 
        output = chase(x,
 
                       onval='x',
 
                       offval=' ',
 
                       ontime=0.1,
 
                       offset=0.2,
 
                       names=('a', 'b', 'c', 'd'))
 
        output = output.items()
 
        output.sort()
 
        print "%.2f\t%s" % (x, ' '.join([str(x) for x in output]))
 
        output = sorted(list(output.items()))
 
        print("%.2f\t%s" % (x, ' '.join([str(x) for x in output])))
light9/clientsession.py
Show inline comments
 
"""
 
some clients will support the concept of a named session that keeps
 
multiple instances of that client separate
 
"""
 
from rdflib import URIRef
 
from urllib import quote
 
from urllib.parse import quote
 
from light9 import showconfig
 

	
 

	
 
def add_option(parser):
 
    parser.add_option(
 
        '-s',
 
        '--session',
 
        help="name of session used for levels and window position",
 
        default='default')
 

	
 

	
 
def getUri(appName, opts):
light9/collector/collector.py
Show inline comments
 
from __future__ import division
 

	
 
import time
 
import logging
 
from rdflib import Literal
 
from light9.namespaces import L9, RDF
 
from light9.collector.output import setListElem
 
from light9.collector.device import toOutputAttrs, resolve
 

	
 
# types only
 
from rdflib import Graph, URIRef
 
from typing import List, Dict, Tuple, Any, TypeVar, Generic
 
from light9.collector.output import Output
 

	
 
@@ -79,25 +79,25 @@ class Collector(Generic[ClientType, Clie
 
                self.allDevices.add(dev)
 
                self.deviceType[dev] = dc
 

	
 
                for remap in self.graph.objects(dev, L9['outputAttrRange']):
 
                    attr = self.graph.value(remap, L9['outputAttr'])
 
                    start = float(self.graph.value(remap, L9['start']))
 
                    end = float(self.graph.value(remap, L9['end']))
 
                    self.remapOut[(dev, attr)] = start, end
 

	
 
    def _forgetStaleClients(self, now):
 
        # type: (float) -> None
 
        staleClientSessions = []
 
        for c, (t, _) in self.lastRequest.iteritems():
 
        for c, (t, _) in self.lastRequest.items():
 
            if t < now - self.clientTimeoutSec:
 
                staleClientSessions.append(c)
 
        for c in staleClientSessions:
 
            log.info('forgetting stale client %r', c)
 
            del self.lastRequest[c]
 

	
 
    # todo: move to settings.py
 
    def resolvedSettingsDict(self, settingsList):
 
        # type: (List[Tuple[URIRef, URIRef, float]]) -> Dict[Tuple[URIRef, URIRef], float]
 
        out = {}  # type: Dict[Tuple[URIRef, URIRef], float]
 
        for d, da, v in settingsList:
 
            if (d, da) in out:
 
@@ -109,42 +109,42 @@ class Collector(Generic[ClientType, Clie
 
    def _warnOnLateRequests(self, client, now, sendTime):
 
        requestLag = now - sendTime
 
        if requestLag > .1 and now > self.initTime + 10 and getattr(
 
                self, '_lastWarnTime', 0) < now - 3:
 
            self._lastWarnTime = now
 
            log.warn(
 
                'collector.setAttrs from %s is running %.1fms after the request was made',
 
                client, requestLag * 1000)
 

	
 
    def _merge(self, lastRequests):
 
        deviceAttrs = {}  # device: {deviceAttr: value}
 
        for _, lastSettings in lastRequests:
 
            for (device, deviceAttr), value in lastSettings.iteritems():
 
            for (device, deviceAttr), value in lastSettings.items():
 
                if (device, deviceAttr) in self.remapOut:
 
                    start, end = self.remapOut[(device, deviceAttr)]
 
                    value = Literal(start + float(value) * (end - start))
 

	
 
                attrs = deviceAttrs.setdefault(device, {})
 
                if deviceAttr in attrs:
 
                    value = resolve(device, deviceAttr,
 
                                    [attrs[deviceAttr], value])
 
                attrs[deviceAttr] = value
 
                # list should come from the graph. these are attrs
 
                # that should default to holding the last position,
 
                # not going to 0.
 
                if deviceAttr in [L9['rx'], L9['ry'], L9['zoom'], L9['focus']]:
 
                    self.stickyAttrs[(device, deviceAttr)] = value
 

	
 
        # e.g. don't let an unspecified rotation go to 0
 
        for (d, da), v in self.stickyAttrs.iteritems():
 
        for (d, da), v in self.stickyAttrs.items():
 
            daDict = deviceAttrs.setdefault(d, {})
 
            if da not in daDict:
 
                daDict[da] = v
 

	
 
        return deviceAttrs
 

	
 
    def setAttrs(self, client, clientSession, settings, sendTime):
 
        """
 
        settings is a list of (device, attr, value). These attrs are
 
        device attrs. We resolve conflicting values, process them into
 
        output attrs, and call Output.update/Output.flush to send the
 
        new outputs.
 
@@ -154,56 +154,56 @@ class Collector(Generic[ClientType, Clie
 

	
 
        Each client session's last settings will be forgotten after
 
        clientTimeoutSec.
 
        """
 
        now = time.time()
 
        self._warnOnLateRequests(client, now, sendTime)
 

	
 
        self._forgetStaleClients(now)
 

	
 
        uniqueSettings = self.resolvedSettingsDict(settings)
 
        self.lastRequest[(client, clientSession)] = (now, uniqueSettings)
 

	
 
        deviceAttrs = self._merge(self.lastRequest.itervalues())
 
        deviceAttrs = self._merge(iter(self.lastRequest.values()))
 

	
 
        outputAttrs = {}  # device: {outputAttr: value}
 
        for d in self.allDevices:
 
            try:
 
                devType = self.deviceType[d]
 
            except KeyError:
 
                log.warn("request for output to unconfigured device %s" % d)
 
                continue
 
            try:
 
                outputAttrs[d] = toOutputAttrs(devType, deviceAttrs.get(d, {}))
 
                if self.listeners:
 
                    self.listeners.outputAttrsSet(d, outputAttrs[d],
 
                                                  self.outputMap)
 
            except Exception as e:
 
                log.error('failing toOutputAttrs on %s: %r', d, e)
 

	
 
        pendingOut = {}  # output : values
 
        for out in self.outputs:
 
            pendingOut[out] = [0] * out.numChannels
 

	
 
        for device, attrs in outputAttrs.iteritems():
 
            for outputAttr, value in attrs.iteritems():
 
        for device, attrs in outputAttrs.items():
 
            for outputAttr, value in attrs.items():
 
                self.setAttr(device, outputAttr, value, pendingOut)
 

	
 
        dt1 = 1000 * (time.time() - now)
 
        self.flush(pendingOut)
 
        dt2 = 1000 * (time.time() - now)
 
        if dt1 > 30:
 
            log.warn(
 
                "slow setAttrs: %.1fms -> flush -> %.1fms. lr %s da %s oa %s" %
 
                (dt1, dt2, len(
 
                    self.lastRequest), len(deviceAttrs), len(outputAttrs)))
 

	
 
    def setAttr(self, device, outputAttr, value, pendingOut):
 
        output, index = self.outputMap[(device, outputAttr)]
 
        outList = pendingOut[output]
 
        setListElem(outList, index, value, combine=max)
 

	
 
    def flush(self, pendingOut):
 
        """write any changed outputs"""
 
        for out, vals in pendingOut.iteritems():
 
        for out, vals in pendingOut.items():
 
            out.update(vals)
 
            out.flush()
light9/collector/collector_client.py
Show inline comments
 
from __future__ import division
 

	
 
from light9 import networking
 
from light9.effect.settings import DeviceSettings
 
from twisted.internet import defer
 
from txzmq import ZmqEndpoint, ZmqFactory, ZmqPushConnection
 
import json, time, logging
 
import treq
 

	
 
log = logging.getLogger('coll_client')
 

	
 
_zmqClient = None
 

	
 

	
light9/collector/device.py
Show inline comments
 
from __future__ import division
 

	
 
import logging
 
import math
 
from light9.namespaces import L9, RDF, DEV
 
from rdflib import Literal
 
from webcolors import hex_to_rgb, rgb_to_hex
 
from colormath.color_objects import sRGBColor, CMYColor
 
import colormath.color_conversions
 

	
 
log = logging.getLogger('device')
 

	
 

	
 
class Device(object):
light9/collector/output.py
Show inline comments
 
from __future__ import division
 

	
 
from rdflib import URIRef
 
import sys
 
import time
 
import usb.core
 
import logging
 
from twisted.internet import task, threads, reactor
 
from greplin import scales
 
log = logging.getLogger('output')
 

	
 

	
 
# eliminate this: lists are always padded now
 
def setListElem(outList, index, value, fill=0, combine=lambda old, new: new):
 
@@ -160,30 +160,30 @@ class Udmx(DmxOutput):
 
    def update(self, values):
 
        now = time.time()
 
        if now > self.lastLog + 1:
 
            log.debug('%s %s', self.shortId(), ' '.join(map(str, values)))
 
            self.lastLog = now
 

	
 
        self.currentBuffer = ''.join(map(chr, values))
 

	
 
    def sendDmx(self, buf):
 
        with Udmx.stats.write.time():
 
            try:
 
                if not buf:
 
                    print "skip empty msg"
 
                    print("skip empty msg")
 
                    return True
 
                self.dev.SendDMX(buf)
 
                return True
 
            except usb.core.USBError as e:
 
                # not in main thread
 
                if e.errno != 75:
 
                    msg = 'usb: sending %s bytes to %r; error %r' % (
 
                        len(buf), self.uri, e)
 
                    print msg
 
                    print(msg)
 
                return False
 

	
 
    def countError(self):
 
        # in main thread
 
        Udmx.stats.usbErrors += 1
 

	
 
    def shortId(self):
 
        return self._shortId
light9/curvecalc/client.py
Show inline comments
 
"""
 
client code for talking to curvecalc
 
"""
 
import cyclone.httpclient
 
from light9 import networking
 
import urllib
 
import urllib.request, urllib.parse, urllib.error
 
from run_local import log
 

	
 

	
 
def sendLiveInputPoint(curve, value):
 
    f = cyclone.httpclient.fetch(networking.curveCalc.path('liveInputPoint'),
 
                                 method='POST',
 
                                 timeout=1,
 
                                 postdata=urllib.urlencode({
 
                                 postdata=urllib.parse.urlencode({
 
                                     'curve': curve,
 
                                     'value': str(value),
 
                                 }))
 

	
 
    @f.addCallback
 
    def cb(result):
 
        if result.code // 100 != 2:
 
            raise ValueError("curveCalc said %s: %s", result.code, result.body)
 

	
 
    return f
light9/curvecalc/curve.py
Show inline comments
 
from __future__ import division
 

	
 
import glob, time, logging, ast, os
 
from bisect import bisect_left, bisect
 
import louie as dispatcher
 
from twisted.internet import reactor
 
from rdflib import Literal
 
from light9 import showconfig
 
from light9.namespaces import L9, RDF, RDFS
 
from rdfdb.patch import Patch
 

	
 
log = logging.getLogger()
 
# todo: move to config, consolidate with ascoltami, musicPad, etc
 
introPad = 4
 
@@ -46,44 +46,44 @@ class Curve(object):
 

	
 
    def load(self, filename):
 
        self.points[:] = []
 
        for line in file(filename):
 
            x, y = line.split()
 
            self.points.append((float(x), ast.literal_eval(y)))
 
        self.points.sort()
 
        dispatcher.send("points changed", sender=self)
 

	
 
    def set_from_string(self, pts):
 
        self.points[:] = []
 
        vals = pts.split()
 
        pairs = zip(vals[0::2], vals[1::2])
 
        pairs = list(zip(vals[0::2], vals[1::2]))
 
        for x, y in pairs:
 
            self.points.append((float(x), ast.literal_eval(y)))
 
        self.points.sort()
 
        dispatcher.send("points changed", sender=self)
 

	
 
    def points_as_string(self):
 

	
 
        def outVal(x):
 
            if isinstance(x, basestring):  # markers
 
            if isinstance(x, str):  # markers
 
                return x
 
            return "%.4g" % x
 

	
 
        return ' '.join(
 
            "%s %s" % (outVal(p[0]), outVal(p[1])) for p in self.points)
 

	
 
    def save(self, filename):
 
        # this is just around for markers, now
 
        if filename.endswith('-music') or filename.endswith('_music'):
 
            print "not saving music track"
 
            print("not saving music track")
 
            return
 
        f = file(filename, 'w')
 
        for p in self.points:
 
            f.write("%s %r\n" % p)
 
        f.close()
 

	
 
    def eval(self, t, allow_muting=True):
 
        if self.muted and allow_muting:
 
            return 0
 
        if not self.points:
 
            raise ValueError("curve has no points")
 
        i = bisect_left(self.points, (t, None)) - 1
 
@@ -139,25 +139,25 @@ class Curve(object):
 
        p = self.points.pop(i)
 
        dispatcher.send("points changed", sender=self)
 
        return p
 

	
 
    def remove_point(self, pt):
 
        self.points.remove(pt)
 
        dispatcher.send("points changed", sender=self)
 

	
 
    def indices_between(self, x1, x2, beyond=0):
 
        leftidx = max(0, bisect(self.points, (x1, None)) - beyond)
 
        rightidx = min(len(self.points),
 
                       bisect(self.points, (x2, None)) + beyond)
 
        return range(leftidx, rightidx)
 
        return list(range(leftidx, rightidx))
 

	
 
    def points_between(self, x1, x2):
 
        """returns (x,y) points"""
 
        return [self.points[i] for i in self.indices_between(x1, x2)]
 

	
 
    def point_before(self, x):
 
        """(x,y) of the point left of x, or None"""
 
        leftidx = self.index_before(x)
 
        if leftidx is None:
 
            return None
 
        return self.points[leftidx]
 

	
 
@@ -320,35 +320,35 @@ class Curveset(object):
 
                                uri=uri,
 
                                label=curvename,
 
                                curve=cr.curve)
 
            except Exception as e:
 
                log.error("loading %s failed: %s", uri, e)
 

	
 
        basename = os.path.join(
 
            showconfig.curvesDir(),
 
            showconfig.songFilenameFromURI(self.currentSong))
 
        try:
 
            self.markers.load("%s.markers" % basename)
 
        except IOError:
 
            print "no marker file found"
 
            print("no marker file found")
 

	
 
    def save(self):
 
        """writes a file for each curve with a name
 
        like basename-curvename, or saves them to the rdf graph"""
 
        basename = os.path.join(
 
            showconfig.curvesDir(),
 
            showconfig.songFilenameFromURI(self.currentSong))
 

	
 
        patches = []
 
        for cr in self.curveResources.values():
 
        for cr in list(self.curveResources.values()):
 
            patches.extend(cr.getSavePatches())
 

	
 
        self.markers.save("%s.markers" % basename)
 
        # this will cause reloads that will rebuild our curve list
 
        for p in patches:
 
            self.graph.patch(p)
 

	
 
    def sorter(self, name):
 
        return self.curves[name].uri
 

	
 
    def curveUrisInOrder(self):
 
        return sorted(self.curveResources.keys())
light9/curvecalc/curveview.py
Show inline comments
 
from __future__ import division
 

	
 
import math, logging, traceback
 
from gi.repository import Gtk
 
from gi.repository import Gdk
 
from gi.repository import GooCanvas
 
import louie as dispatcher
 
from rdflib import Literal
 
from twisted.internet import reactor
 
from light9.curvecalc.zoomcontrol import RegionZoom
 
from light9.curvecalc import cursors
 
from light9.curvecalc.curve import introPad, postPad
 
from lib.goocanvas_compat import Points, polyline_new_line
 
import imp
 

	
 
log = logging.getLogger()
 
print "curveview.py toplevel"
 
print("curveview.py toplevel")
 

	
 

	
 
def vlen(v):
 
    return math.sqrt(v[0] * v[0] + v[1] * v[1])
 

	
 

	
 
def angle_between(base, p0, p1):
 
    p0 = p0[0] - base[0], p0[1] - base[1]
 
    p1 = p1[0] - base[0], p1[1] - base[1]
 
    p0 = [x / vlen(p0) for x in p0]
 
    p1 = [x / vlen(p1) for x in p1]
 
    dot = p0[0] * p1[0] + p0[1] * p1[1]
 
@@ -39,26 +40,25 @@ class Sketch:
 
        self.last_x = None
 

	
 
    def motion(self, ev):
 
        p = self.curveview.world_from_screen(ev.x, ev.y)
 
        p = p[0], max(0, min(1, p[1]))
 
        if self.last_x is not None and abs(ev.x - self.last_x) < 4:
 
            return
 
        self.last_x = ev.x
 
        self.pts.append(p)
 
        self.curveview.add_point(p)
 

	
 
    def release(self, ev):
 
        pts = self.pts
 
        pts.sort()
 
        pts = sorted(self.pts)
 
        finalPoints = pts[:]
 

	
 
        dx = .01
 
        to_remove = []
 
        for i in range(1, len(pts) - 1):
 
            x = pts[i][0]
 

	
 
            p_left = (x - dx, self.curveview.curve(x - dx))
 
            p_right = (x + dx, self.curveview.curve(x + dx))
 

	
 
            if angle_between(pts[i], p_left, p_right) > 160:
 
                to_remove.append(i)
 
@@ -159,25 +159,25 @@ class SelectManip(object):
 
        self.origMaxValue = max(p[1] for p in self.origPoints)
 
        moveLeft, moveRight = self.getDragRange(idxs)
 

	
 
        if param == 'centerScale':
 
            self.maxPointMove = min(moveLeft, moveRight)
 

	
 
        self.dragRange = (self.dragStartTime - moveLeft,
 
                          self.dragStartTime + moveRight)
 
        return True
 

	
 
    def onMotion(self, item, target_item, event, param):
 
        if hasattr(self, 'dragStartTime'):
 
            origPts = zip(self.getSelectedIndices(), self.origPoints)
 
            origPts = list(zip(self.getSelectedIndices(), self.origPoints))
 
            left = origPts[0][1][0]
 
            right = origPts[-1][1][0]
 
            width = right - left
 
            dontCross = .001
 

	
 
            clampLo = left if param == 'right' else self.dragRange[0]
 
            clampHi = right if param == 'left' else self.dragRange[1]
 

	
 
            def clamp(x, lo, hi):
 
                return max(lo, min(hi, x))
 

	
 
            mouseT = self.getWorldTime(event.x)
 
@@ -452,25 +452,25 @@ class Curveview(object):
 
        canvas.connect("scroll-event", self.onScroll)
 
        canvas.connect("button-release-event", self.onRelease)
 
        root.connect("button-press-event", self.onCanvasPress)
 

	
 
        self.widget.connect("key-press-event", self.onKeyPress)
 

	
 
        self.widget.connect("focus-in-event", self.onFocusIn)
 
        self.widget.connect("focus-out-event", self.onFocusOut)
 
        #self.widget.connect("event", self.onAny)
 
        return canvas
 

	
 
    def onAny(self, w, event):
 
        print "   %s on %s" % (event, w)
 
        print("   %s on %s" % (event, w))
 

	
 
    def onFocusIn(self, *args):
 
        dispatcher.send('curve row focus change')
 
        dispatcher.send("all curves lose selection", butNot=self)
 

	
 
        self.widget.modify_bg(Gtk.StateFlags.NORMAL, Gdk.color_parse("red"))
 

	
 
    def onFocusOut(self, widget=None, event=None):
 
        dispatcher.send('curve row focus change')
 
        self.widget.modify_bg(Gtk.StateFlags.NORMAL, Gdk.color_parse("gray30"))
 

	
 
        # you'd think i'm unselecting when we lose focus, but we also
 
@@ -546,26 +546,26 @@ class Curveview(object):
 
        """user pushed on a slider. make a new key.  if value is None,
 
        the value will be the same as the last."""
 
        if curve != self.curve:
 
            return
 

	
 
        if value is None:
 
            value = self.curve.eval(self.current_time())
 

	
 
        self.curve.insert_pt((self.current_time(), value))
 

	
 
    def print_state(self, msg=""):
 
        if 0:
 
            print "%s: dragging_dots=%s selecting=%s" % (
 
                msg, self.dragging_dots, self.selecting)
 
            print("%s: dragging_dots=%s selecting=%s" % (
 
                msg, self.dragging_dots, self.selecting))
 

	
 
    def select_points(self, pts):
 
        """set selection to the given point values (tuples, not indices)"""
 
        idxs = []
 
        for p in pts:
 
            idxs.append(self.curve.points.index(p))
 
        self.select_indices(idxs)
 

	
 
    def select_indices(self, idxs):
 
        """set selection to these point indices. This is the only
 
        writer to self.selected_points"""
 
        self.selected_points = idxs
 
@@ -740,25 +740,25 @@ class Curveview(object):
 
            self._update_curve2()
 
        except Exception:
 
            log.error("in update_curve on %s", self.curve.uri)
 
            raise
 

	
 
    def _update_curve2(self):
 
        if not getattr(self, '_pending_update', False):
 
            return
 
        self._pending_update = False
 
        if not self.alive():
 
            return
 
        if not self.redrawsEnabled:
 
            print "no redrawsEnabled, skipping", self
 
            print("no redrawsEnabled, skipping", self)
 
            return
 

	
 
        visible_x = (self.world_from_screen(0, 0)[0],
 
                     self.world_from_screen(self.canvas.props.x2, 0)[0])
 

	
 
        visible_idxs = self.curve.indices_between(visible_x[0],
 
                                                  visible_x[1],
 
                                                  beyond=1)
 
        visible_points = [self.curve.points[i] for i in visible_idxs]
 

	
 
        if getattr(self, 'curveGroup', None):
 
            self.curveGroup.remove()
 
@@ -984,25 +984,25 @@ class Curveview(object):
 
            for ii in range(len(idxs)):
 
                if ii > i:
 
                    ii -= 1
 
                newidxs.append(idxs[ii])
 

	
 
            self.select_indices(newsel)
 
            idxs[:] = newidxs
 

	
 
    def highlight_selected_dots(self):
 
        if not self.redrawsEnabled:
 
            return
 

	
 
        for i, d in self.dots.items():
 
        for i, d in list(self.dots.items()):
 
            if i in self.selected_points:
 
                d.set_property('fill_color', 'red')
 
            else:
 
                d.set_property('fill_color', 'blue')
 

	
 
    def dotpress(self, r1, r2, ev, dotidx):
 
        self.print_state("dotpress")
 
        if dotidx not in self.selected_points:
 
            self.select_indices([dotidx])
 

	
 
        self.last_mouse_world = self.world_from_screen(ev.x, ev.y)
 
        self.dragging_dots = True
 
@@ -1152,25 +1152,25 @@ class CurveRow(object):
 
    def setHeight(self, h):
 
        self.curveView.widget.set_size_request(-1, h)
 

	
 
        # this should have been automatic when the size changed, but
 
        # the signals for that are wrong somehow.
 
        reactor.callLater(0, self.curveView.setCanvasToWidgetSize)
 

	
 
    def setupControls(self, controls, name, curve):
 
        box = Gtk.Box.new(Gtk.Orientation.HORIZONTAL, 0)
 
        controls.add(box)
 

	
 
        curve_name_label = Gtk.LinkButton()
 
        print "need to truncate this name length somehow"
 
        print("need to truncate this name length somehow")
 

	
 
        def update_label():
 
            # todo: abort if we don't still exist...
 
            p = curve_name_label.props
 
            p.uri = curve.uri
 
            p.label = self.graph.label(curve.uri)
 

	
 
        self.graph.addHandler(update_label)
 

	
 
        self.muted = Gtk.CheckButton("M")
 
        self.muted.connect("toggled", self.sync_mute_to_curve)
 
        dispatcher.connect(self.mute_changed, 'mute changed', sender=curve)
 
@@ -1228,29 +1228,29 @@ class Curvesetview(object):
 
        dispatcher.connect(self.set_featured_curves, "set_featured_curves")
 
        dispatcher.connect(self.song_has_changed, "song_has_changed")
 

	
 
        self.newcurvename = Gtk.EntryBuffer.new("", 0)
 

	
 
        eventBox = self.curvesVBox.get_parent()
 
        eventBox.connect("key-press-event", self.onKeyPress)
 
        eventBox.connect("button-press-event", self.takeFocus)
 

	
 
        self.watchCurveAreaHeight()
 

	
 
    def __del__(self):
 
        print "del curvesetview", id(self)
 
        print("del curvesetview", id(self))
 

	
 
    def initZoomControl(self, zoomControlBox):
 
        import light9.curvecalc.zoomcontrol
 
        reload(light9.curvecalc.zoomcontrol)
 
        imp.reload(light9.curvecalc.zoomcontrol)
 
        zoomControl = light9.curvecalc.zoomcontrol.ZoomControl()
 
        zoomControlBox.add(zoomControl.widget)
 
        zoomControl.widget.show_all()
 
        return zoomControl
 

	
 
    def clear_curves(self):
 
        """curveset is about to re-add all new curves"""
 
        while self.allCurveRows:
 
            self.allCurveRows.pop().destroy()
 

	
 
    def song_has_changed(self):
 
        self.zoomControl.redrawzoom()
light9/curvecalc/output.py
Show inline comments
 
@@ -20,25 +20,25 @@ class Output(object):
 
        self.recent_t = []
 
        self.later = None
 

	
 
        self.update()
 

	
 
    def update(self):
 
        d = self.music.current_time()
 
        d.addCallback(self.update2)
 
        d.addErrback(self.updateerr)
 

	
 
    def updateerr(self, e):
 

	
 
        print e.getTraceback()
 
        print(e.getTraceback())
 
        dispatcher.send("update status", val=e.getErrorMessage())
 
        if self.later and not self.later.cancelled and not self.later.called:
 
            self.later.cancel()
 
        self.later = reactor.callLater(1, self.update)
 

	
 
    def update2(self, t):
 
        # spot alsa soundcard offset is always 0, we get times about a
 
        # second ahead of what's really getting played
 
        #t = t - .7
 
        dispatcher.send("update status",
 
                        val="ok: receiving time from music player")
 
        if self.later and not self.later.cancelled and not self.later.called:
light9/curvecalc/subterm.py
Show inline comments
 
@@ -82,25 +82,25 @@ class Subterm(object):
 
            try:
 
                if isinstance(subexpr_eval, Submaster.Submaster):
 
                    # if the expression returns a submaster, just return it
 
                    return subexpr_eval
 
                else:
 
                    # otherwise, return our submaster multiplied by the value
 
                    # returned
 
                    if subexpr_eval == 0:
 
                        return Submaster.Submaster("zero", {})
 
                    subUri = current.value(self.uri, L9['sub'])
 
                    sub = self.submasters.get_sub_by_uri(subUri)
 
                    return sub * subexpr_eval
 
            except Exception, e:
 
            except Exception as e:
 
                dispatcher.send("expr_error", sender=self.uri, exc=repr(e))
 
                return Submaster.Submaster(name='Error: %s' % str(e), levels={})
 

	
 
    def curves_used_by_expr(self):
 
        """names of curves that are (maybe) used in this expression"""
 

	
 
        with self.graph.currentState(tripleFilter=(self.uri, None,
 
                                                   None)) as current:
 
            expr = current.value(self.uri, L9['expression'])
 

	
 
        used = []
 
        for name in self.curveset.curveNamesInOrder():
 
@@ -124,21 +124,21 @@ class Subterm(object):
 
                            exc="no expr, using 0")
 
            return 0
 
        glo = self.curveset.globalsdict()
 
        glo['t'] = t
 

	
 
        glo = exprglo.exprGlobals(glo, t)
 
        glo['getsub'] = lambda name: self.submasters.get_sub_by_name(name)
 
        glo['chan'] = lambda name: Submaster.Submaster(
 
            "chan", {get_dmx_channel(name): 1})
 

	
 
        try:
 
            self.lasteval = eval(expr, glo)
 
        except Exception, e:
 
        except Exception as e:
 
            dispatcher.send("expr_error", sender=self.uri, exc=e)
 
            return Submaster.Submaster("zero", {})
 
        else:
 
            dispatcher.send("expr_error", sender=self.uri, exc="ok")
 
        return self.lasteval
 

	
 
    def __repr__(self):
 
        return "<Subterm %s>" % self.uri
light9/curvecalc/subtermview.py
Show inline comments
 
@@ -33,35 +33,34 @@ class Subexprview(object):
 

	
 
        self.entry.connect("focus-in-event", self.onFocus)
 

	
 
        dispatcher.connect(self.exprError,
 
                           "expr_error",
 
                           sender=self.ownerSubterm)
 
        keep.append(self.__dict__)
 

	
 
    def onFocus(self, *args):
 
        curveNames = self.curveset.curveNamesInOrder()
 
        currentExpr = self.entryBuffer.get_text()
 

	
 
        usedCurves = [n for n in curveNames if n in currentExpr]
 
        usedCurves.sort()
 
        usedCurves = sorted([n for n in curveNames if n in currentExpr])
 

	
 
        dispatcher.send("set_featured_curves", curveNames=usedCurves)
 

	
 
    def exprError(self, exc):
 
        self.error.set_text(str(exc))
 

	
 
    def set_expression_from_graph(self):
 
        e = str(self.graph.value(self.ownerSubterm, L9['expression']))
 
        print "from graph, set to %r" % e
 
        print("from graph, set to %r" % e)
 

	
 
        if e != self.entryBuffer.get_text():
 
            self.entryBuffer.set_text(e, len(e))
 

	
 
    def entry_changed(self, *args):
 
        log.info("want to patch to %r", self.entryBuffer.get_text())
 
        self.graph.patchObject(self.saveContext, self.ownerSubterm,
 
                               L9['expression'],
 
                               Literal(self.entryBuffer.get_text()))
 

	
 

	
 
class Subtermview(object):
light9/curvecalc/zoomcontrol.py
Show inline comments
 
from __future__ import division
 

	
 
from gi.repository import Gtk
 
from gi.repository import GObject
 
from gi.repository import GooCanvas
 
import louie as dispatcher
 
from light9.curvecalc import cursors
 
from lib.goocanvas_compat import Points, polyline_new_line
 
from twisted.internet import reactor
 

	
 

	
 
class ZoomControl(object):
 
    """
 
    please pack .widget
light9/dmxchanedit.py
Show inline comments
 
@@ -7,26 +7,26 @@ proposal for new focus and edit system:
 
- rows can be selected
 
- the chan number or label can be used to select rows. dragging over rows brings all of them into or out of the current selection
 
- numbers drag up and down (like today)
 
- if you drag a number in a selected row, all the selected numbers change
 
- if you start dragging a number in an unselected row, your row becomes the new selection and then the edit works
 

	
 

	
 
proposal for new attribute system:
 
- we always want to plan some attributes for each light: where to center; what stage to cover; what color gel to apply; whether the light is burned out
 
- we have to stop packing these into the names. Names should be like 'b33' or 'blue3' or just '44'. maybe 'blacklight'.
 

	
 
"""
 
from __future__ import nested_scopes, division
 
import Tkinter as tk
 

	
 
import tkinter as tk
 
from rdflib import RDF, Literal
 
import math, logging
 
from decimal import Decimal
 
from light9.namespaces import L9
 
log = logging.getLogger('dmxchanedit')
 
stdfont = ('Arial', 7)
 

	
 

	
 
def gradient(lev, low=(80, 80, 180), high=(255, 55, 50)):
 
    out = [int(l + lev * (h - l)) for h, l in zip(high, low)]
 
    col = "#%02X%02X%02X" % tuple(out)
 
    return col
 
@@ -218,25 +218,25 @@ class Levelbox(tk.Frame):
 

	
 
        remaining = set(self.levelFromUri.keys())
 
        for ll in self.graph.objects(sub, L9['lightLevel']):
 
            chan = self.graph.value(ll, L9['channel'])
 
            try:
 
                lev = self.graph.value(ll, L9['level']).toPython()
 
            except AttributeError as e:
 
                log.error('on lightlevel %r:', ll)
 
                log.exception(e)
 
                continue
 
            if isinstance(lev, Decimal):
 
                lev = float(lev)
 
            assert isinstance(lev, (int, long, float)), repr(lev)
 
            assert isinstance(lev, (int, float)), repr(lev)
 
            try:
 
                self.levelFromUri[chan].setTo(lev)
 
                remaining.remove(chan)
 
            except KeyError as e:
 
                log.exception(e)
 
        for channel in remaining:
 
            self.levelFromUri[channel].setTo(0)
 

	
 
    def onLevelChange(self, chan, newLevel):
 
        """UI received a change which we put in the graph"""
 
        if self.currentSub() is None:
 
            raise ValueError("no currentSub in Levelbox")
light9/dmxclient.py
Show inline comments
 
""" module for clients to use for easy talking to the dmx
 
server. sending levels is now a simple call to
 
dmxclient.outputlevels(..)
 

	
 
client id is formed from sys.argv[0] and the PID.  """
 

	
 
import xmlrpclib, os, sys, socket, time, logging
 
import xmlrpc.client, os, sys, socket, time, logging
 
from twisted.internet import defer
 
from txzmq import ZmqEndpoint, ZmqFactory, ZmqPushConnection
 
import json
 

	
 
from light9 import networking
 
_dmx = None
 
log = logging.getLogger('dmxclient')
 

	
 
procname = os.path.basename(sys.argv[0])
 
procname = procname.replace('.py', '')
 
_id = "%s-%s-%s" % (procname, socket.gethostname(), os.getpid())
 

	
 
@@ -41,36 +41,36 @@ def outputlevels(levellist, twisted=0, c
 
    """present a list of dmx channel levels, each scaled from
 
    0..1. list can be any length- it will apply to the first len() dmx
 
    channels.
 

	
 
    if the server is not found, outputlevels will block for a
 
    second."""
 

	
 
    global _dmx, _id
 

	
 
    if _dmx is None:
 
        url = networking.dmxServer.url
 
        if not twisted:
 
            _dmx = xmlrpclib.Server(url)
 
            _dmx = xmlrpc.client.Server(url)
 
        else:
 
            _dmx = TwistedZmqClient(networking.dmxServerZmq)
 

	
 
    if not twisted:
 
        try:
 
            _dmx.outputlevels(clientid, levellist)
 
        except socket.error, e:
 
        except socket.error as e:
 
            log.error("dmx server error %s, waiting" % e)
 
            time.sleep(1)
 
        except xmlrpclib.Fault, e:
 
        except xmlrpc.client.Fault as e:
 
            log.error("outputlevels had xml fault: %s" % e)
 
            time.sleep(1)
 
    else:
 
        _dmx.send(clientid, levellist)
 
        return defer.succeed(None)
 

	
 

	
 
dummy = os.getenv('DMXDUMMY')
 
if dummy:
 
    print "dmxclient: DMX is in dummy mode."
 
    print("dmxclient: DMX is in dummy mode.")
 

	
 
    def outputlevels(*args, **kw):
 
        pass
light9/editchoice.py
Show inline comments
 
import Tkinter as tk
 
import tkinter as tk
 
from rdflib import URIRef
 
from light9.tkdnd import dragSourceRegister, dropTargetRegister
 

	
 

	
 
class Local(object):
 
    """placeholder for the local uri that EditChoice does not
 
    manage. Set resourceObservable to Local to indicate that you're
 
    unlinked"""
 

	
 

	
 
class EditChoice(object):
 
    """
 
@@ -101,18 +101,18 @@ class EditChoice(object):
 
                               hoverStyle=dict(background="#555500"))
 

	
 
    def uriChanged(self, newUri):
 
        # if this resource had a type icon or a thumbnail, those would be
 
        # cool to show in here too
 
        if newUri is Local:
 
            self.subIcon.config(text="(local)")
 
        else:
 
            self.graph.addHandler(self.updateLabel)
 

	
 
    def updateLabel(self):
 
        uri = self.resourceObservable()
 
        print "get label", repr(uri)
 
        print("get label", repr(uri))
 
        label = self.graph.label(uri)
 
        self.subIcon.config(text=label or uri)
 

	
 
    def switchToLocalSub(self):
 
        self.resourceObservable(Local)
light9/effect/edit.py
Show inline comments
 
@@ -56,27 +56,27 @@ def songEffectPatch(graph, dropped, song
 
        elif L9['Submaster'] in droppedTypes:
 
            quads.extend([
 
                (effect, L9['code'], Literal('out = %s * env' % dropped.n3()),
 
                 ctx),
 
            ])
 
        else:
 
            raise NotImplementedError(
 
                "don't know how to add an effect from %r (types=%r)" %
 
                (dropped, droppedTypes))
 

	
 
        _maybeAddMusicLine(quads, effect, song, ctx)
 

	
 
    print "adding"
 
    print("adding")
 
    for qq in quads:
 
        print qq
 
        print(qq)
 
    returnValue(Patch(addQuads=quads))
 

	
 

	
 
@inlineCallbacks
 
def songNotePatch(graph, dropped, song, event, ctx, note=None):
 
    """
 
    drop into effectsequencer timeline
 

	
 
    ported from timeline.coffee makeNewNote
 
    """
 
    with graph.currentState(tripleFilter=(dropped, None, None)) as g:
 
        droppedTypes = list(g.objects(dropped, RDF.type))
 
@@ -154,25 +154,25 @@ def _songHasEffect(graph, song, uri):
 

	
 

	
 
def musicCurveForSong(uri):
 
    return URIRef(uri + 'music')
 

	
 

	
 
def _newEffect(graph, song, ctx):
 
    effect = graph.sequentialUri(song + "/effect-")
 
    quads = [
 
        (song, L9['effect'], effect, ctx),
 
        (effect, RDF.type, L9['Effect'], ctx),
 
    ]
 
    print "_newEffect", effect, quads
 
    print("_newEffect", effect, quads)
 
    return effect, quads
 

	
 

	
 
@inlineCallbacks
 
def _newEnvelopeCurve(graph, ctx, uri, label, fade=2):
 
    """this does its own patch to the graph"""
 

	
 
    cr = CurveResource(graph, uri)
 
    cr.newCurve(ctx, label=Literal(label))
 
    yield _insertEnvelopePoints(cr.curve, fade)
 
    cr.saveCurve()
 

	
light9/effect/effecteval.py
Show inline comments
 
from __future__ import division
 

	
 
from rdflib import URIRef, Literal
 
from light9.namespaces import L9, RDF, DEV
 
from webcolors import rgb_to_hex, hex_to_rgb
 
from colorsys import hsv_to_rgb
 
from decimal import Decimal
 
import math
 
import traceback
 
from noise import pnoise1
 
import logging
 
import time
 
from light9.effect.settings import DeviceSettings
 
from light9.effect.scale import scale
 
import random
 
random.seed(0)
 
print "reload effecteval"
 
print("reload effecteval")
 

	
 
log = logging.getLogger('effecteval')
 

	
 

	
 
def literalColor(rnorm, gnorm, bnorm):
 
    return Literal(
 
        rgb_to_hex([int(rnorm * 255),
 
                    int(gnorm * 255),
 
                    int(bnorm * 255)]))
 

	
 

	
 
def literalColorHsv(h, s, v):
 
@@ -87,25 +87,25 @@ class EffectEval(object):
 
                self.effect, strength,
 
                effectSettings.get(L9['colorScale'], None)))
 

	
 
        if self.effect.startswith(L9['effect/']):
 
            tail = 'effect_' + self.effect[len(L9['effect/']):]
 
            try:
 
                func = globals()[tail]
 
            except KeyError:
 
                report['error'] = 'effect code not found for %s' % self.effect
 
            else:
 
                out.update(func(effectSettings, strength, songTime, noteTime))
 

	
 
        outList = [(d, a, v) for (d, a), v in out.iteritems()]
 
        outList = [(d, a, v) for (d, a), v in out.items()]
 
        return DeviceSettings(self.graph, outList), report
 

	
 

	
 
def effect_Curtain(effectSettings, strength, songTime, noteTime):
 
    return {(L9['device/lowPattern%s' % n], L9['color']):
 
            literalColor(strength, strength, strength)
 
            for n in range(301, 308 + 1)}
 

	
 

	
 
def effect_animRainbow(effectSettings, strength, songTime, noteTime):
 
    out = {}
 
    tint = effectSettings.get(L9['tint'], '#ffffff')
 
@@ -128,25 +128,25 @@ def effect_animRainbow(effectSettings, s
 
            (dev, L9['rx']):
 
            lerp(.27, .7, (n - 1) / 4) + .2 * math.sin(ang + n),
 
            (dev, L9['ry']):
 
            lerp(.46, .52, (n - 1) / 4) + .5 * math.cos(ang + n),
 
        })
 
    return out
 

	
 

	
 
def effect_auraSparkles(effectSettings, strength, songTime, noteTime):
 
    out = {}
 
    tint = effectSettings.get(L9['tint'], '#ffffff')
 
    tintStrength = float(effectSettings.get(L9['tintStrength'], 0))
 
    print effectSettings
 
    print(effectSettings)
 
    tr, tg, tb = hex_to_rgb(tint)
 
    for n in range(1, 5 + 1):
 
        scl = strength * ((int(songTime * 10) % n) < 1)
 
        col = literalColorHsv((songTime + (n / 5)) % 1, 1, scl)
 

	
 
        dev = L9['device/aura%s' % n]
 
        out.update({
 
            (dev, L9['color']): col,
 
            (dev, L9['zoom']): .95,
 
        })
 
        ang = songTime * 4
 
        out.update({
 
@@ -200,25 +200,25 @@ def effect_aurawash(effectSettings, stre
 
    out = {}
 
    scl = strength
 
    period = float(effectSettings.get(L9['period'], 125 / 60 / 4))
 
    if period < .05:
 
        quantTime = songTime
 
    else:
 
        quantTime = int(songTime / period) * period
 
    noisePos = quantTime * 6.3456
 

	
 
    col = literalColorHsv(noise(noisePos), 1, scl)
 
    col = scale(col, effectSettings.get(L9['colorScale']) or '#ffffff')
 

	
 
    print songTime, quantTime, col
 
    print(songTime, quantTime, col)
 

	
 
    for n in range(1, 5 + 1):
 
        dev = L9['device/aura%s' % n]
 
        out.update({
 
            (dev, L9['color']): col,
 
            (dev, L9['zoom']): .5,
 
        })
 
        out.update({
 
            (dev, L9['rx']): lerp(.27, .7, (n - 1) / 4),
 
            (dev, L9['ry']): lerp(.46, .52, (n - 1) / 4),
 
        })
 
    return out
light9/effect/scale.py
Show inline comments
 
from __future__ import division
 

	
 
from rdflib import Literal
 
from decimal import Decimal
 
from webcolors import rgb_to_hex, hex_to_rgb
 

	
 

	
 
def scale(value, strength):
 
    if isinstance(value, Literal):
 
        value = value.toPython()
 

	
 
    if isinstance(value, Decimal):
 
        value = float(value)
 

	
 
    if isinstance(value, basestring):
 
    if isinstance(value, str):
 
        if value[0] == '#':
 
            if strength == '#ffffff':
 
                return value
 
            r, g, b = hex_to_rgb(value)
 
            if isinstance(strength, Literal):
 
                strength = strength.toPython()
 
            if isinstance(strength, basestring):
 
            if isinstance(strength, str):
 
                sr, sg, sb = [v / 255 for v in hex_to_rgb(strength)]
 
            else:
 
                sr = sg = sb = strength
 
            return rgb_to_hex([int(r * sr), int(g * sg), int(b * sb)])
 
    elif isinstance(value, (int, float)):
 
        return value * strength
 

	
 
    raise NotImplementedError("%r,%r" % (value, strength))
light9/effect/sequencer.py
Show inline comments
 
'''
 
copies from effectloop.py, which this should replace
 
'''
 

	
 
from __future__ import division
 

	
 
from louie import dispatcher
 
from rdflib import URIRef
 
from twisted.internet import reactor
 
from twisted.internet import defer
 
from twisted.internet.inotify import INotify
 
from twisted.python.filepath import FilePath
 
import cyclone.sse
 
import logging, bisect, time
 
import traceback
 

	
 
from light9.namespaces import L9, RDF
 
from light9.vidref.musictime import MusicTime
 
from light9.effect import effecteval
 
from light9.effect.settings import DeviceSettings
 
from light9.effect.simple_outputs import SimpleOutputs
 

	
 
from greplin import scales
 
import imp
 

	
 
log = logging.getLogger('sequencer')
 
stats = scales.collection(
 
    '/sequencer/',
 
    scales.PmfStat('update'),
 
    scales.PmfStat('compileGraph'),
 
    scales.PmfStat('compileSong'),
 
    scales.DoubleStat('recentFps'),
 
)
 

	
 

	
 
class Note(object):
 
@@ -86,48 +87,48 @@ class Note(object):
 
        list of (device, attr, value), and a report for web
 
        """
 
        report = {
 
            'note': str(self.uri),
 
            'effectClass': self.effectEval.effect,
 
        }
 
        effectSettings = self.baseEffectSettings.copy()
 
        effectSettings[L9['strength']] = self.evalCurve(t)
 
        report['effectSettings'] = dict(
 
            (str(k), str(v)) for k, v in sorted(effectSettings.items()))
 
        report['nonZero'] = effectSettings[L9['strength']] > 0
 
        out, evalReport = self.effectEval.outputFromEffect(
 
            effectSettings.items(),
 
            list(effectSettings.items()),
 
            songTime=t,
 
            # note: not using origin here since it's going away
 
            noteTime=t - self.points[0][0])
 
        report['devicesAffected'] = len(out.devices())
 
        return out, report
 

	
 

	
 
class CodeWatcher(object):
 

	
 
    def __init__(self, onChange):
 
        self.onChange = onChange
 

	
 
        self.notifier = INotify()
 
        self.notifier.startReading()
 
        self.notifier.watch(FilePath(effecteval.__file__.replace('.pyc',
 
                                                                 '.py')),
 
                            callbacks=[self.codeChange])
 

	
 
    def codeChange(self, watch, path, mask):
 

	
 
        def go():
 
            log.info("reload effecteval")
 
            reload(effecteval)
 
            imp.reload(effecteval)
 
            self.onChange()
 

	
 
        # in case we got an event at the start of the write
 
        reactor.callLater(.1, go)
 

	
 

	
 
class Sequencer(object):
 

	
 
    def __init__(self, graph, sendToCollector, fps=40):
 
        self.graph = graph
 
        self.fps = fps
 
        self.sendToCollector = sendToCollector
light9/effect/settings.py
Show inline comments
 
from __future__ import division
 

	
 
"""
 
Data structure and convertors for a table of (device,attr,value)
 
rows. These might be effect attrs ('strength'), device attrs ('rx'),
 
or output attrs (dmx channel).
 
"""
 
import decimal
 
import numpy
 
from rdflib import URIRef, Literal
 
from light9.namespaces import RDF, L9, DEV
 
from rdfdb.patch import Patch
 
import logging
 
log = logging.getLogger('settings')
 
from light9.collector.device import resolve
 

	
 

	
 
def parseHex(h):
 
    if h[0] != '#': raise ValueError(h)
 
    return [int(h[i:i + 2], 16) for i in 1, 3, 5]
 
    return [int(h[i:i + 2], 16) for i in (1, 3, 5)]
 

	
 

	
 
def parseHexNorm(h):
 
    return [x / 255 for x in parseHex(h)]
 

	
 

	
 
def toHex(rgbFloat):
 
    return '#%02x%02x%02x' % tuple(
 
        max(0, min(255, int(v * 255))) for v in rgbFloat)
 

	
 

	
 
def getVal(graph, subj):
 
@@ -103,111 +103,111 @@ class _Settings(object):
 
    @classmethod
 
    def fromBlend(cls, graph, others):
 
        """others is a list of (weight, Settings) pairs"""
 
        out = cls(graph, [])
 
        for weight, s in others:
 
            if not isinstance(s, cls):
 
                raise TypeError(s)
 
            for row in s.asList():  # could work straight from s._compiled
 
                if row[0] is None:
 
                    raise TypeError('bad row %r' % (row,))
 
                dd = out._compiled.setdefault(row[0], {})
 

	
 
                if isinstance(row[2], basestring):
 
                if isinstance(row[2], str):
 
                    prev = parseHexNorm(dd.get(row[1], '#000000'))
 
                    newVal = toHex(prev +
 
                                   weight * numpy.array(parseHexNorm(row[2])))
 
                else:
 
                    newVal = dd.get(row[1], 0) + weight * row[2]
 
                dd[row[1]] = newVal
 
        out._delZeros()
 
        return out
 

	
 
    def _zeroForAttr(self, attr):
 
        if attr == L9['color']:
 
            return '#000000'
 
        return 0.0
 

	
 
    def _delZeros(self):
 
        for dev, av in self._compiled.items():
 
            for attr, val in av.items():
 
        for dev, av in list(self._compiled.items()):
 
            for attr, val in list(av.items()):
 
                if val == self._zeroForAttr(attr):
 
                    del av[attr]
 
            if not av:
 
                del self._compiled[dev]
 

	
 
    def __hash__(self):
 
        itemed = tuple([(d, tuple([(a, v)
 
                                   for a, v in sorted(av.items())]))
 
                        for d, av in sorted(self._compiled.items())])
 
        return hash(itemed)
 

	
 
    def __eq__(self, other):
 
        if not issubclass(other.__class__, self.__class__):
 
            raise TypeError("can't compare %r to %r" %
 
                            (self.__class__, other.__class__))
 
        return self._compiled == other._compiled
 

	
 
    def __ne__(self, other):
 
        return not self == other
 

	
 
    def __nonzero__(self):
 
    def __bool__(self):
 
        return bool(self._compiled)
 

	
 
    def __repr__(self):
 
        words = []
 

	
 
        def accum():
 
            for dev, av in self._compiled.iteritems():
 
                for attr, val in sorted(av.iteritems()):
 
            for dev, av in self._compiled.items():
 
                for attr, val in sorted(av.items()):
 
                    words.append(
 
                        '%s.%s=%s' %
 
                        (dev.rsplit('/')[-1], attr.rsplit('/')[-1], val))
 
                    if len(words) > 5:
 
                        words.append('...')
 
                        return
 

	
 
        accum()
 
        return '<%s %s>' % (self.__class__.__name__, ' '.join(words))
 

	
 
    def getValue(self, dev, attr):
 
        return self._compiled.get(dev, {}).get(attr, self._zeroForAttr(attr))
 

	
 
    def _vectorKeys(self, deviceAttrFilter=None):
 
        """stable order of all the dev,attr pairs for this type of settings"""
 
        raise NotImplementedError
 

	
 
    def asList(self):
 
        """old style list of (dev, attr, val) tuples"""
 
        out = []
 
        for dev, av in self._compiled.iteritems():
 
            for attr, val in av.iteritems():
 
        for dev, av in self._compiled.items():
 
            for attr, val in av.items():
 
                out.append((dev, attr, val))
 
        return out
 

	
 
    def devices(self):
 
        return self._compiled.keys()
 
        return list(self._compiled.keys())
 

	
 
    def toVector(self, deviceAttrFilter=None):
 
        out = []
 
        for dev, attr in self._vectorKeys(deviceAttrFilter):
 
            v = self.getValue(dev, attr)
 
            if attr == L9['color']:
 
                out.extend(parseHexNorm(v))
 
            else:
 
                out.append(v)
 
        return out
 

	
 
    def byDevice(self):
 
        for dev, av in self._compiled.iteritems():
 
        for dev, av in self._compiled.items():
 
            yield dev, self.__class__._fromCompiled(self.graph, {dev: av})
 

	
 
    def ofDevice(self, dev):
 
        return self.__class__._fromCompiled(self.graph,
 
                                            {dev: self._compiled.get(dev, {})})
 

	
 
    def distanceTo(self, other):
 
        diff = numpy.array(self.toVector()) - other.toVector()
 
        d = numpy.linalg.norm(diff, ord=None)
 
        log.info('distanceTo %r - %r = %g', self, other, d)
 
        return d
 

	
light9/effect/simple_outputs.py
Show inline comments
 
from __future__ import division
 

	
 
import traceback
 
from light9.namespaces import L9, RDF
 
from light9.effect.scale import scale
 

	
 

	
 
class SimpleOutputs(object):
 

	
 
    def __init__(self, graph):
 
        self.graph = graph
 

	
 
        # effect : [(dev, attr, value, isScaled)]
 
        self.effectOutputs = {}
light9/effecteval/effect.py
Show inline comments
 
@@ -72,25 +72,25 @@ class CodeLine(object):
 

	
 
    def _uriIsSub(self, uri):
 
        return self.graph.contains((uri, RDF.type, L9['Submaster']))
 

	
 
    @prof.logTime
 
    def _resourcesAsPython(self, resources):
 
        """
 
        mapping of the local names for uris in the code to high-level
 
        objects (Submaster, Curve)
 
        """
 
        out = {}
 
        subs = prof.logTime(Submaster.get_global_submasters)(self.graph)
 
        for localVar, uri in resources.items():
 
        for localVar, uri in list(resources.items()):
 

	
 
            for rdfClass in self.graph.objects(uri, RDF.type):
 
                if rdfClass == L9['Curve']:
 
                    cr = CurveResource(self.graph, uri)
 
                    # this is slow- pool these curves somewhere, maybe just with curveset
 
                    prof.logTime(cr.loadCurve)()
 
                    out[localVar] = cr.curve
 
                    break
 
                elif rdfClass == L9['Submaster']:
 
                    out[localVar] = subs.get_sub_by_uri(uri)
 
                    break
 
                else:
 
@@ -122,25 +122,25 @@ class EffectNode(object):
 

	
 
        self.sortCodes()
 

	
 
        #reload(Effects)
 
        self.otherFuncs = prof.logTime(Effects.configExprGlobals)()
 

	
 
    def sortCodes(self):
 
        """put self.codes in a working evaluation order"""
 
        codeFromOutput = dict((c.outName, c) for c in self.codes)
 
        deps = {}
 
        for c in self.codes:
 
            outName = c.outName
 
            inNames = c.possibleVars.intersection(codeFromOutput.keys())
 
            inNames = c.possibleVars.intersection(list(codeFromOutput.keys()))
 
            inNames.discard(outName)
 
            deps[outName] = inNames
 
        self.codes = [
 
            codeFromOutput[n] for n in toposort.toposort_flatten(deps)
 
        ]
 

	
 
    def _currentSubSettingValues(self, sub):
 
        """what KC subSettings are setting levels right now?"""
 
        cs = self.graph.currentState
 
        with cs(tripleFilter=(None, L9['sub'], sub)) as g1:
 
            for subj in g1.subjects(L9['sub'], sub):
 
                with cs(tripleFilter=(subj, None, None)) as g2:
light9/effecteval/effectloop.py
Show inline comments
 
from __future__ import division
 

	
 
import time, json, logging, traceback
 
import numpy
 
import serial
 
from twisted.internet import reactor, threads
 
from twisted.internet.defer import inlineCallbacks, returnValue, succeed
 
from twisted.internet.error import TimeoutError
 
from rdflib import URIRef, Literal
 
import cyclone.httpclient
 
from light9.namespaces import L9, RDF, RDFS
 
from light9.effecteval.effect import EffectNode
 
from light9 import Effects
 
from light9 import networking
 
@@ -174,25 +174,25 @@ class EffectLoop(object):
 
        if log.isEnabledFor(logging.DEBUG):
 
            log.debug(self.logMessage(out))
 
        else:
 
            if now > self.lastLogTime + 5:
 
                msg = self.logMessage(out)
 
                if msg != self.lastLogMsg:
 
                    log.info(msg)
 
                    self.lastLogMsg = msg
 
                self.lastLogTime = now
 

	
 
    def logMessage(self, out):
 
        return ("send dmx: {%s}" % ", ".join(
 
            "%r: %.3g" % (str(k), v) for k, v in out.get_levels().items()))
 
            "%r: %.3g" % (str(k), v) for k, v in list(out.get_levels().items())))
 

	
 

	
 
Z = numpy.zeros((50, 3), dtype=numpy.float16)
 

	
 

	
 
class ControlBoard(object):
 

	
 
    def __init__(
 
            self,
 
            dev='/dev/serial/by-id/usb-FTDI_FT232R_USB_UART_A7027NYX-if00-port0'
 
    ):
 
        log.info('opening %s', dev)
 
@@ -297,22 +297,22 @@ class LedLoop(EffectLoop):
 
            if self.lastSent.get(key) == compValue:
 
                continue
 

	
 
            log.debug('value changed: %s(%s %s)', meth, selectArgs, value)
 

	
 
            getattr(self.board, meth)(*(selectArgs + (value,)))
 
            self.lastSent[key] = compValue
 

	
 
        yield succeed(None)  # there was an attempt at an async send
 

	
 
    def logMessage(self, out):
 
        return str([(w, p.tolist() if isinstance(p, numpy.ndarray) else p)
 
                    for w, p in out.items()])
 
                    for w, p in list(out.items())])
 

	
 

	
 
def makeEffectLoop(graph, stats, outputWhere):
 
    if outputWhere == 'dmx':
 
        return EffectLoop(graph, stats)
 
    elif outputWhere == 'leds':
 
        return LedLoop(graph, stats)
 
    else:
 
        raise NotImplementedError("unknown output system %r" % outputWhere)
light9/effecteval/test_effect.py
Show inline comments
 
import unittest
 
import mock
 
import sys
 
sys.path.insert(0, 'bin')  # for run_local
 

	
 
from effect import CodeLine
 
from .effect import CodeLine
 
from rdflib import URIRef
 

	
 

	
 
def isCurve(self, uri):
 
    return 'curve' in uri
 

	
 

	
 
def isSub(self, uri):
 
    return 'sub' in uri
 

	
 

	
 
@mock.patch('light9.effecteval.effect.CodeLine._uriIsCurve', new=isCurve)
 
@@ -67,17 +67,17 @@ class TestAsPython(unittest.TestCase):
 
        self.assertEqual({'_res0': URIRef('http://example/curve1')}, uris)
 

	
 

	
 
@mock.patch('light9.effecteval.effect.CodeLine._uriIsCurve', new=isCurve)
 
@mock.patch('light9.effecteval.effect.CodeLine._resourcesAsPython',
 
            new=lambda self, r: self.expr)
 
class TestPossibleVars(unittest.TestCase):
 

	
 
    def test1(self):
 
        self.assertEqual(set([]), CodeLine(None, 'a1 = 1').possibleVars)
 

	
 
    def test2(self):
 
        self.assertEqual(set(['a2']), CodeLine(None, 'a1 = a2').possibleVars)
 
        self.assertEqual({'a2'}, CodeLine(None, 'a1 = a2').possibleVars)
 

	
 
    def test3(self):
 
        self.assertEqual(set(['a2', 'a3']),
 
        self.assertEqual({'a2', 'a3'},
 
                         CodeLine(None, 'a1 = a2 + a3').possibleVars)
light9/io/__init__.py
Show inline comments
 
from __future__ import division
 

	
 
import sys
 

	
 

	
 
class BaseIO(object):
 

	
 
    def __init__(self):
 
        self.dummy = 1
 
        self.__name__ = 'BaseIO'
 
        # please override and set __name__ to your class name
 

	
 
    def golive(self):
 
        """call this if you want to promote the dummy object becomes a live object"""
 
        print "IO: %s is going live" % self.__name__
 
        print("IO: %s is going live" % self.__name__)
 
        self.dummy = 0
 
        # you'd override with additional startup stuff here,
 
        # perhaps even loading a module and saving it to a class
 
        # attr so the subclass-specific functions can use it
 

	
 
    def godummy(self):
 
        print "IO: %s is going dummy" % self.__name__
 
        print("IO: %s is going dummy" % self.__name__)
 
        self.dummy = 1
 
        # you might override this to close ports, etc
 

	
 
    def isdummy(self):
 
        return self.dummy
 

	
 
    def __repr__(self):
 
        if self.dummy:
 
            return "<dummy %s instance>" % self.__name__
 
        else:
 
            return "<live %s instance>" % self.__name__
 

	
 
@@ -35,25 +35,25 @@ class BaseIO(object):
 
    # and they should return dummy values if self.dummy==1.
 

	
 

	
 
class ParportDMX(BaseIO):
 

	
 
    def __init__(self, dimmers=68):
 
        BaseIO.__init__(self)
 
        self.__name__ = 'ParportDMX'
 
        self.dimmers = dimmers
 

	
 
    def golive(self):
 
        BaseIO.golive(self)
 
        import parport
 
        from . import parport
 
        self.parport = parport
 
        self.parport.getparport()
 

	
 
    def sendlevels(self, levels):
 
        if self.dummy:
 
            return
 

	
 
        levels = list(levels) + [0]
 
        # if levels[14] > 0: levels[14] = 100 # non-dim
 
        self.parport.outstart()
 
        for p in range(1, self.dimmers + 2):
 
            self.parport.outbyte(levels[p - 1] * 255 / 100)
 
@@ -62,25 +62,25 @@ class ParportDMX(BaseIO):
 
class UsbDMX(BaseIO):
 

	
 
    def __init__(self, dimmers=72, port='/dev/dmx0'):
 
        BaseIO.__init__(self)
 
        self.__name__ = "UsbDMX"
 
        self.port = port
 
        self.out = None
 
        self.dimmers = dimmers
 

	
 
    def _dmx(self):
 
        if self.out is None:
 
            if self.port == 'udmx':
 
                from udmx import Udmx
 
                from .udmx import Udmx
 
                self.out = Udmx()
 
                self.out.write = self.out.SendDMX
 
            else:
 
                sys.path.append("dmx_usb_module")
 
                from dmx import Dmx
 
                self.out = Dmx(self.port)
 
        return self.out
 

	
 
    def sendlevels(self, levels):
 
        if self.dummy:
 
            return
 
        # I was outputting on 76 and it was turning on the light at
light9/io/udmx.py
Show inline comments
 
from __future__ import division
 

	
 
import logging
 
import usb.core
 
from usb.util import CTRL_TYPE_VENDOR, CTRL_RECIPIENT_DEVICE, CTRL_OUT
 

	
 
log = logging.getLogger('udmx')
 
"""
 
Send dmx to one of these:
 
http://www.amazon.com/Interface-Adapter-Controller-Lighting-Freestyler/dp/B00W52VIOS
 

	
 
[4520784.059479] usb 1-2.3: new low-speed USB device number 6 using xhci_hcd
 
[4520784.157410] usb 1-2.3: New USB device found, idVendor=16c0, idProduct=05dc
 
[4520784.157416] usb 1-2.3: New USB device strings: Mfr=1, Product=2, SerialNumber=3
 
@@ -21,25 +21,25 @@ or https://github.com/markusb/uDMX-linux
 
"""
 

	
 
cmd_SetChannelRange = 0x0002
 

	
 

	
 
class Udmx(object):
 

	
 
    def __init__(self, bus):
 
        self.dev = None
 
        for dev in usb.core.find(idVendor=0x16c0,
 
                                 idProduct=0x05dc,
 
                                 find_all=True):
 
            print "udmx device at %r" % dev.bus
 
            print("udmx device at %r" % dev.bus)
 
            if bus is None or bus == dev.bus:
 
                self.dev = dev
 
        if not self.dev:
 
            raise IOError('no matching udmx device found for requested bus %r' %
 
                          bus)
 
        log.info('found udmx at %r', self.dev)
 

	
 
    def SendDMX(self, buf):
 
        ret = self.dev.ctrl_transfer(bmRequestType=CTRL_TYPE_VENDOR |
 
                                     CTRL_RECIPIENT_DEVICE | CTRL_OUT,
 
                                     bRequest=cmd_SetChannelRange,
 
                                     wValue=len(buf),
 
@@ -50,14 +50,14 @@ class Udmx(object):
 

	
 

	
 
def demo(chan, fps=44):
 
    import time, math
 
    u = Udmx()
 
    while True:
 
        nsin = math.sin(time.time() * 6.28) / 2.0 + 0.5
 
        nsin8 = int(255 * nsin)
 
        try:
 
            u.SendDMX('\x00' * (chan - 1) + chr(210) + chr(nsin8) + chr(nsin8) +
 
                      chr(nsin8))
 
        except usb.core.USBError as e:
 
            print "err", time.time(), repr(e)
 
            print("err", time.time(), repr(e))
 
        time.sleep(1 / fps)
light9/networking.py
Show inline comments
 
from urlparse import urlparse
 
from urllib import splitport
 
from showconfig import getGraph, showUri
 
from namespaces import L9
 
from urllib.parse import urlparse
 
from urllib.parse import splitport
 
from .showconfig import getGraph, showUri
 
from .namespaces import L9
 

	
 

	
 
class ServiceAddress(object):
 

	
 
    def __init__(self, service):
 
        self.service = service
 

	
 
    def _url(self):
 
        graph = getGraph()
 
        net = graph.value(showUri(), L9['networking'])
 
        ret = graph.value(net, self.service)
 
        if ret is None:
light9/paint/solve.py
Show inline comments
 
from __future__ import division
 

	
 
from light9.namespaces import RDF, L9, DEV
 
from PIL import Image
 
import numpy
 
import scipy.misc, scipy.ndimage, scipy.optimize
 
import cairo
 
import logging
 

	
 
from light9.effect.settings import DeviceSettings, parseHex, toHex
 

	
 
log = logging.getLogger('solve')
 

	
 
# numpy images in this file are (x, y, c) layout.
 
@@ -143,37 +143,37 @@ class Solver(object):
 
            ctx.set_source_rgb(r / 255, g / 255, b / 255)
 
            ctx.stroke()
 

	
 
        #surface.write_to_png('/tmp/surf.png')
 
        return numpyFromCairo(surface)
 

	
 
    def bestMatch(self, img, device=None):
 
        """the one sample that best matches this image"""
 
        #img = self._blur(img)
 
        results = []
 
        dist = ImageDist(img)
 
        if device is None:
 
            items = self.samples.items()
 
            items = list(self.samples.items())
 
        else:
 
            items = self.samplesForDevice[device]
 
        for uri, img2 in sorted(items):
 
            if img.shape != img2.shape:
 
                log.warn("mismatch %s %s", img.shape, img2.shape)
 
                continue
 
            results.append((dist.distanceTo(img2), uri, img2))
 
        results.sort()
 
        topDist, topUri, topImg = results[0]
 
        print 'tops2'
 
        print('tops2')
 
        for row in results[:4]:
 
            print '%.5f' % row[0], row[1][-20:], self.sampleSettings[row[1]]
 
            print('%.5f' % row[0], row[1][-20:], self.sampleSettings[row[1]])
 

	
 
        #saveNumpy('/tmp/best_in.png', img)
 
        #saveNumpy('/tmp/best_out.png', topImg)
 
        #saveNumpy('/tmp/mult.png', topImg / 255 * img)
 
        return topUri, topDist
 

	
 
    def bestMatches(self, img, devices=None):
 
        """settings for the given devices that point them each
 
        at the input image"""
 
        dist = ImageDist(img)
 
        devSettings = []
 
        for dev in devices:
 
@@ -212,26 +212,25 @@ class Solver(object):
 
        best light DeviceSettings to match the image
 
        """
 
        pic0 = self.draw(painting).astype(numpy.float)
 
        pic0Blur = self._blur(pic0)
 
        saveNumpy('/tmp/sample_paint_%s.png' % len(painting['strokes']),
 
                  pic0Blur)
 
        sampleDist = {}
 
        dist = ImageDist(pic0Blur)
 
        for sample, picSample in sorted(self.blurredSamples.items()):
 
            #saveNumpy('/tmp/sample_%s.png' % sample.split('/')[-1],
 
            #          f(picSample))
 
            sampleDist[sample] = dist.distanceTo(picSample)
 
        results = [(d, uri) for uri, d in sampleDist.items()]
 
        results.sort()
 
        results = sorted([(d, uri) for uri, d in list(sampleDist.items())])
 

	
 
        sample = results[0][1]
 

	
 
        # this is wrong; some wrong-alignments ought to be dimmer than full
 
        brightest0 = brightest(pic0)
 
        brightestSample = brightest(self.samples[sample])
 

	
 
        if max(brightest0) < 1 / 255:
 
            return DeviceSettings(self.graph, [])
 

	
 
        scale = brightest0 / brightestSample
 

	
 
@@ -275,43 +274,43 @@ class Solver(object):
 
            ranges=sum([s for dev, da, s in dims], []),
 
            finish=None,
 
            disp=True,
 
            full_output=True)
 
        if fval > 30000:
 
            raise ValueError('solution has error of %s' % fval)
 
        return DeviceSettings.fromVector(self.graph,
 
                                         x0,
 
                                         deviceAttrFilter=deviceAttrFilter)
 

	
 
    def combineImages(self, layers):
 
        """make a result image from our self.samples images"""
 
        out = (self.fromPath.itervalues().next() * 0).astype(numpy.uint16)
 
        out = (next(iter(self.fromPath.values())) * 0).astype(numpy.uint16)
 
        for layer in layers:
 
            colorScaled = self.fromPath[layer['path']] * layer['color']
 
            out += colorScaled.astype(numpy.uint16)
 
        numpy.clip(out, 0, 255, out)
 
        return out.astype(numpy.uint8)
 

	
 
    def simulationLayers(self, settings):
 
        """
 
        how should a simulation preview approximate the light settings
 
        (device attribute values) by combining photos we have?
 
        """
 
        assert isinstance(settings, DeviceSettings)
 
        layers = []
 

	
 
        for dev, devSettings in settings.byDevice():
 
            requestedColor = devSettings.getValue(dev, L9['color'])
 
            candidatePics = []  # (distance, path, picColor)
 
            for sample, s in self.sampleSettings.items():
 
            for sample, s in list(self.sampleSettings.items()):
 
                path = self.path[sample]
 
                otherDevSettings = s.ofDevice(dev)
 
                if not otherDevSettings:
 
                    continue
 
                dist = devSettings.distanceTo(otherDevSettings)
 
                log.info('  candidate pic %s %s dist=%s', sample, path, dist)
 
                candidatePics.append((dist, path, s.getValue(dev, L9['color'])))
 
            candidatePics.sort()
 
            # we could even blend multiple top candidates, or omit all
 
            # of them if they're too far
 
            bestDist, bestPath, bestPicColor = candidatePics[0]
 
            log.info('  device best d=%g path=%s color=%s', bestDist, bestPath,
light9/paint/solve_test.py
Show inline comments
 
import unittest
 
import numpy.testing
 
import solve
 
from . import solve
 
from rdflib import Namespace
 
from light9.namespaces import RDF, L9, DEV
 
from rdfdb.localsyncedgraph import LocalSyncedGraph
 
from light9.effect.settings import DeviceSettings
 

	
 

	
 
class TestSolve(unittest.TestCase):
 

	
 
    def setUp(self):
 
        self.graph = LocalSyncedGraph(
 
            files=['test/cam/lightConfig.n3', 'test/cam/bg.n3'])
 
        self.solver = solve.Solver(self.graph,
 
@@ -24,25 +24,25 @@ class TestSolve(unittest.TestCase):
 
        self.assertEqual(DeviceSettings(self.graph, []), devAttrs)
 

	
 
    @unittest.skip("unfinished")
 
    def testSingleLightCloseMatch(self):
 
        devAttrs = self.solveMethod({
 
            'strokes': [{
 
                'pts': [[224, 141], [223, 159]],
 
                'color': '#ffffff'
 
            }]
 
        })
 
        self.assertEqual(
 
            DeviceSettings(self.graph, [
 
                (DEV['aura1'], L9['color'], u"#ffffff"),
 
                (DEV['aura1'], L9['color'], "#ffffff"),
 
                (DEV['aura1'], L9['rx'], 0.5),
 
                (DEV['aura1'], L9['ry'], 0.573),
 
            ]), devAttrs)
 

	
 

	
 
class TestSolveBrute(TestSolve):
 

	
 
    def setUp(self):
 
        super(TestSolveBrute, self).setUp()
 
        self.solveMethod = self.solver.solveBrute
 

	
 

	
 
@@ -59,49 +59,49 @@ class TestSimulationLayers(unittest.Test
 
                                   sessions=[L9['session0']])
 
        self.solver.loadSamples()
 

	
 
    def testBlack(self):
 
        self.assertEqual([],
 
                         self.solver.simulationLayers(
 
                             settings=DeviceSettings(self.graph, [])))
 

	
 
    def testPerfect1Match(self):
 
        layers = self.solver.simulationLayers(
 
            settings=DeviceSettings(self.graph, [(
 
                DEV['aura1'], L9['color'],
 
                u"#ffffff"), (DEV['aura1'], L9['rx'],
 
                "#ffffff"), (DEV['aura1'], L9['rx'],
 
                              0.5), (DEV['aura1'], L9['ry'], 0.573)]))
 
        self.assertEqual([{
 
            'path': CAM_TEST['bg2-d.jpg'],
 
            'color': (1., 1., 1.)
 
        }], layers)
 

	
 
    def testPerfect1MatchTinted(self):
 
        layers = self.solver.simulationLayers(
 
            settings=DeviceSettings(self.graph, [(
 
                DEV['aura1'], L9['color'],
 
                u"#304050"), (DEV['aura1'], L9['rx'],
 
                "#304050"), (DEV['aura1'], L9['rx'],
 
                              0.5), (DEV['aura1'], L9['ry'], 0.573)]))
 
        self.assertEqual([{
 
            'path': CAM_TEST['bg2-d.jpg'],
 
            'color': (.188, .251, .314)
 
        }], layers)
 

	
 
    def testPerfect2Matches(self):
 
        layers = self.solver.simulationLayers(
 
            settings=DeviceSettings(self.graph, [
 
                (DEV['aura1'], L9['color'], u"#ffffff"),
 
                (DEV['aura1'], L9['color'], "#ffffff"),
 
                (DEV['aura1'], L9['rx'], 0.5),
 
                (DEV['aura1'], L9['ry'], 0.573),
 
                (DEV['aura2'], L9['color'], u"#ffffff"),
 
                (DEV['aura2'], L9['color'], "#ffffff"),
 
                (DEV['aura2'], L9['rx'], 0.7),
 
                (DEV['aura2'], L9['ry'], 0.573),
 
            ]))
 
        self.assertItemsEqual([
 
            {
 
                'path': CAM_TEST['bg2-d.jpg'],
 
                'color': (1, 1, 1)
 
            },
 
            {
 
                'path': CAM_TEST['bg2-f.jpg'],
 
                'color': (1, 1, 1)
 
            },
light9/prof.py
Show inline comments
 
@@ -28,26 +28,26 @@ def watchPoint(filename, lineno, event="
 
    for lines that are function definitions, like what a profiler
 
    gives you.
 

	
 
    Switch to 'line' to match lines inside functions. Execution speed
 
    will be much slower."""
 
    seenTraces = {}  # trace contents : count
 

	
 
    def trace(frame, ev, arg):
 
        if ev == event:
 
            if (frame.f_code.co_filename, frame.f_lineno) == (filename, lineno):
 
                stack = ''.join(traceback.format_stack(frame))
 
                if stack not in seenTraces:
 
                    print "watchPoint hit"
 
                    print stack
 
                    print("watchPoint hit")
 
                    print(stack)
 
                    seenTraces[stack] = 1
 
                else:
 
                    seenTraces[stack] += 1
 

	
 
        return trace
 

	
 
    sys.settrace(trace)
 

	
 
    # atexit, print the frequencies?
 

	
 

	
 
def logTime(func):
light9/showconfig.py
Show inline comments
 
import logging, warnings
 
from twisted.python.filepath import FilePath
 
from os import path, getenv
 
from rdflib import Graph
 
from rdflib import URIRef
 
from namespaces import MUS, L9
 
from .namespaces import MUS, L9
 
log = logging.getLogger('showconfig')
 

	
 
_config = None # graph
 
def getGraph():
 
    warnings.warn("code that's using showconfig.getGraph should be "
 
                  "converted to use the sync graph", stacklevel=2)
 
    global _config
 
    if _config is None:
 
        graph = Graph()
 
        # note that logging is probably not configured the first time
 
        # we're in here
 
        warnings.warn("reading n3 files around %r" % root())
light9/tkdnd.py
Show inline comments
 
@@ -36,25 +36,25 @@ class TkdndEvent(object):
 

	
 
    tclSubstitutions = ' '.join(sorted(substitutions.keys()))
 

	
 
    def __repr__(self):
 
        return "<TkdndEvent %r>" % self.__dict__
 

	
 
class Hover(object):
 
    def __init__(self, widget, style):
 
        self.widget, self.style = widget, style
 
        self.oldStyle = {}
 

	
 
    def set(self, ev):
 
        for k, v in self.style.items():
 
        for k, v in list(self.style.items()):
 
            self.oldStyle[k] = self.widget.cget(k)
 
        self.widget.configure(**self.style)
 
        return ev.action
 

	
 
    def restore(self, ev):
 
        self.widget.configure(**self.oldStyle)
 

	
 
def initTkdnd(tk, tkdndBuildDir):
 
    """
 
    pass the 'tk' attribute of any Tkinter object, and the top dir of
 
    your built tkdnd package
 
    """
light9/uihelpers.py
Show inline comments
 
"""all the tiny tk helper functions"""
 

	
 
from __future__ import nested_scopes
 

	
 
#from Tkinter import Button
 
import logging, time
 
from rdflib import Literal
 
from Tix import Button, Toplevel, Tk, IntVar, Entry, DoubleVar
 
import Tkinter
 
from tkinter.tix import Button, Toplevel, Tk, IntVar, Entry, DoubleVar
 
import tkinter
 
from light9.namespaces import L9
 

	
 
log = logging.getLogger("toplevel")
 

	
 
windowlocations = {
 
    'sub' : '425x738+00+00',
 
    'console' : '168x24+848+000',
 
    'leveldisplay' : '144x340+870+400',
 
    'cuefader' : '314x212+546+741',
 
    'effect' : '24x24+0963+338',
 
    'stage' : '823x683+37+030',
 
    'scenes' : '504x198+462+12',
 
@@ -24,25 +24,25 @@ def bindkeys(root,key, func):
 
    root.bind(key, func)
 
    for w in root.winfo_children():
 
        w.bind(key, func)
 

	
 

	
 
def toplevel_savegeometry(tl,name):
 
    try:
 
        geo = tl.geometry()
 
        if not geo.startswith("1x1"):
 
            f=open(".light9-window-geometry-%s" % name.replace(' ','_'),'w')
 
            f.write(tl.geometry())
 
        # else the window never got mapped
 
    except Exception, e:
 
    except Exception as e:
 
        # it's ok if there's no saved geometry
 
        pass
 

	
 
def toplevelat(name, existingtoplevel=None, graph=None, session=None):
 
    tl = existingtoplevel or Toplevel()
 
    tl.title(name)
 

	
 
    lastSaved = [None]
 
    setOnce = [False]
 
    graphSetTime = [0]
 
    def setPosFromGraphOnce():
 
        """
 
@@ -53,25 +53,25 @@ def toplevelat(name, existingtoplevel=No
 
            return
 
        geo = graph.value(session, L9.windowGeometry)
 
        log.debug("setPosFromGraphOnce %s", geo)
 

	
 
        setOnce[0] = True
 
        graphSetTime[0] = time.time()
 
        if geo is not None and geo != lastSaved[0]:
 
            tl.geometry(geo)
 
            lastSaved[0] = geo
 

	
 
    def savePos(ev):
 
        geo = tl.geometry()
 
        if not isinstance(ev.widget, (Tk, Tkinter.Tk)):
 
        if not isinstance(ev.widget, (Tk, tkinter.Tk)):
 
            # I think these are due to internal widget size changes,
 
            # not the toplevel changing
 
            return
 
        # this is trying to not save all the startup automatic window
 
        # sizes. I don't have a better plan for this yet.
 
        if graphSetTime[0] == 0 or time.time() < graphSetTime[0] + 3:
 
            return
 
        if not setOnce[0]:
 
            return
 
        lastSaved[0] = geo
 
        log.debug("saving position %s", geo)
 
        graph.patchObject(session, session, L9.windowGeometry, Literal(geo))
 
@@ -94,53 +94,53 @@ def positionOnCurrentDesktop(xform, scre
 
    y = int(y) % screenHeight
 
    return "%s+%s+%s" % (size, x, y)
 

	
 

	
 
def toggle_slider(s):
 
    if s.get() == 0:
 
        s.set(100)
 
    else:
 
        s.set(0)
 

	
 
# for lambda callbacks
 
def printout(t):
 
    print 'printout', t
 
    print('printout', t)
 

	
 
def printevent(ev):
 
    for k in dir(ev):
 
        if not k.startswith('__'):
 
            print 'ev', k, getattr(ev,k)
 
            print('ev', k, getattr(ev,k))
 

	
 
def eventtoparent(ev,sequence):
 
    "passes an event to the parent, screws up TixComboBoxes"
 

	
 
    wid_class = str(ev.widget.__class__)
 
    if wid_class == 'Tix.ComboBox' or wid_class == 'Tix.TixSubWidget':
 
        return
 

	
 
    evdict={}
 
    for x in ['state', 'time', 'y', 'x', 'serial']:
 
        evdict[x]=getattr(ev,x)
 
#    evdict['button']=ev.num
 
    par=ev.widget.winfo_parent()
 
    if par!=".":
 
        ev.widget.nametowidget(par).event_generate(sequence,**evdict)
 
    #else the event made it all the way to the top, unhandled
 

	
 
def colorlabel(label):
 
    """color a label based on its own text"""
 
    txt=label['text'] or "0"
 
    lev=float(txt)/100
 
    low=(80,80,180)
 
    high=(255,55,050)
 
    high=(255,55,0o50)
 
    out = [int(l+lev*(h-l)) for h,l in zip(high,low)]
 
    col="#%02X%02X%02X" % tuple(out)
 
    label.config(bg=col)
 

	
 
# TODO: get everyone to use this
 
def colorfade(low, high, percent):
 
    '''not foolproof.  make sure 0 < percent < 1'''
 
    out = [int(l+percent*(h-l)) for h,l in zip(high,low)]
 
    col="#%02X%02X%02X" % tuple(out)
 
    return col
 

	
 
def colortotuple(anytkobj, colorname):
 
@@ -209,58 +209,58 @@ class FancyDoubleVar(DoubleVar):
 
        Return the name of the callback.
 
        """
 
        cbname = self._master._register(callback)
 
        self._tk.call("trace", "variable", self._name, mode, cbname)
 

	
 
        # we build a list of the trace callbacks (the py functrions and the tcl functionnames)
 
        self.callbacklist[cbname] = mode
 
#        print "added trace:",callback,cbname
 

	
 
        return cbname
 
    trace=trace_variable
 
    def disable_traces(self):
 
        for cb,mode in self.callbacklist.items():
 
        for cb,mode in list(self.callbacklist.items()):
 
#            DoubleVar.trace_vdelete(self,v[0],k)
 
            self._tk.call("trace", "vdelete", self._name, mode,cb)
 
            # but no master delete!
 

	
 
    def recreate_traces(self):
 
        for cb,mode in self.callbacklist.items():
 
        for cb,mode in list(self.callbacklist.items()):
 
#            self.trace_variable(v[0],v[1])
 
            self._tk.call("trace", "variable", self._name, mode,cb)
 

	
 
    def trace_named(self, name, callback):
 
        if name in self.namedtraces:
 
            print "FancyDoubleVar: already had a trace named %s - replacing it" % name
 
            print("FancyDoubleVar: already had a trace named %s - replacing it" % name)
 
            self.delete_named(name)
 

	
 
        cbname = self.trace_variable('w',callback) # this will register in self.callbacklist too
 

	
 
        self.namedtraces[name] = cbname
 
        return cbname
 

	
 
    def delete_named(self, name):
 
        if name in self.namedtraces:
 

	
 
            cbname = self.namedtraces[name]
 

	
 
            self.trace_vdelete('w',cbname)
 
	    #self._tk.call("trace","vdelete",self._name,'w',cbname)
 
            print "FancyDoubleVar: successfully deleted trace named %s" % name
 
            print("FancyDoubleVar: successfully deleted trace named %s" % name)
 
        else:
 
            print "FancyDoubleVar: attempted to delete named %s which wasn't set to any function" % name
 
            print("FancyDoubleVar: attempted to delete named %s which wasn't set to any function" % name)
 

	
 
def get_selection(listbox):
 
    'Given a listbox, returns first selection as integer'
 
    selection = int(listbox.curselection()[0]) # blech
 
    return selection
 

	
 
if __name__=='__main__':
 
    root=Tk()
 
    root.tk_focusFollowsMouse()
 
    iv=IntVar()
 
    def cb():
 
        print "cb!"
 
        print("cb!")
 
    t = Togglebutton(root,text="testbutton",command=cb,variable=iv)
 
    t.pack()
 
    Entry(root,textvariable=iv).pack()
 
    root.mainloop()
light9/updatefreq.py
Show inline comments
 
"""calculates your updates-per-second"""
 

	
 
from __future__ import division
 

	
 
import time
 

	
 
class Updatefreq:
 
    """make one of these, call update() on it as much as you want,
 
    and then float() or str() the object to learn the updates per second.
 

	
 
    the samples param to __init__ specifies how many past updates will
 
    be stored.  """
 
    
 
    def __init__(self,samples=20):
 
        self.times=[0]
 
        self.samples=samples
light9/vidref/main.py
Show inline comments
 
@@ -81,25 +81,25 @@ class Gui(object):
 
                self.replayViews.update(position)
 
        except:
 
            traceback.print_exc()
 
        return True
 

	
 
    def getInputs(self):
 
        return ['auto', 'dv', 'video0']
 

	
 
    def on_liveVideoEnabled_toggled(self, widget):
 
        self.pipeline.setLiveVideo(widget.get_active())
 

	
 
    def on_liveFrameRate_value_changed(self, widget):
 
        print widget.get_value()
 
        print(widget.get_value())
 

	
 
    def onMusicTimeChange(self, position):
 
        self.ignoreScaleChanges = True
 
        try:
 
            self.musicScale.set_range(0, position['duration'])
 
            self.musicScale.set_value(position['t'])
 
        finally:
 
            self.ignoreScaleChanges = False
 

	
 
    def onMusicScaleValue(self, scaleRange):
 
        """the scale position has changed. if it was by the user, send
 
        it back to music player"""
light9/vidref/qt_test.py
Show inline comments
 
@@ -28,53 +28,53 @@ class Vid(object):
 

	
 
        self.s = MySink()
 
        self.player.add(self.s)
 
        #        self.scaler.link(self.s)
 

	
 
        bus = self.player.get_bus()
 
        bus.add_signal_watch()
 
        #        bus.enable_sync_message_emission() # with this we segv
 
        #        bus.connect("message", self.on_message) # with this we segv
 
        bus.connect("sync-message::element", self.on_sync_message)
 

	
 
    def on_message(self, bus, message):
 
        print "msg", bus, message
 
        print("msg", bus, message)
 
        t = message.type
 
        if t == gst.MESSAGE_EOS:
 
            self.player.set_state(gst.STATE_NULL)
 
        elif t == gst.MESSAGE_ERROR:
 
            err, debug = message.parse_error()
 
            print "Error: %s" % err, debug
 
            print("Error: %s" % err, debug)
 
            self.player.set_state(gst.STATE_NULL)
 

	
 
    def on_sync_message(self, bus, message):
 
        print "syncmsg", bus, message
 
        print("syncmsg", bus, message)
 
        if message.structure is None:
 
            return
 
        message_name = message.structure.get_name()
 
        if message_name == "prepare-xwindow-id":
 
            print "pxi"
 
            print("pxi")
 
            win_id = self.windowId
 
            assert win_id
 
            imagesink = message.src
 
            imagesink.set_property("force-aspect-ratio", True)
 
            print "set_xwindow_id"
 
            print("set_xwindow_id")
 
            imagesink.set_xwindow_id(win_id)
 
            print "dnoe msg"
 
            print("dnoe msg")
 

	
 
    def startPrev(self):
 
        self.player.set_state(gst.STATE_PLAYING)
 
        print "should be playing"
 
        print("should be playing")
 

	
 

	
 
class MainWin(QtGui.QMainWindow):
 

	
 
    def __init__(self, *args):
 
        super(MainWin, self).__init__(*args)
 

	
 
        uic.loadUi('light9/vidref/vidref.ui', self)
 
        v = Vid(self.liveView.winId())
 
        v.startPrev()
 

	
 
    @QtCore.pyqtSlot()
 
    def startLiveView(self):
 
        print "slv"
 
        print("slv")
light9/vidref/remotepivideo.py
Show inline comments
 
"""
 
like videorecorder.py, but talks to a bin/picamserve instance
 
"""
 
import os, time, logging
 
import gtk
 
import numpy
 
import treq
 
from twisted.internet import defer
 
from light9.vidref.replay import framerate, songDir, takeDir, snapshotDir
 
from light9 import prof, showconfig
 
from light9.namespaces import L9
 
from PIL import Image
 
from StringIO import StringIO
 
from io import StringIO
 
log = logging.getLogger('remotepi')
 

	
 

	
 
class Pipeline(object):
 

	
 
    def __init__(self, liveVideo, musicTime, recordingTo, graph):
 
        self.musicTime = musicTime
 
        self.recordingTo = recordingTo
 

	
 
        self.liveVideo = self._replaceLiveVideoWidget(liveVideo)
 

	
 
        self._snapshotRequests = []
 
@@ -71,25 +71,25 @@ class Pipeline(object):
 
        returns deferred to the path (which is under snapshotDir()) where
 
        we saved the image.
 
        """
 
        filename = "%s/%s.jpg" % (snapshotDir(), time.time())
 
        d = defer.Deferred()
 
        self._snapshotRequests.append((d, filename))
 
        return d
 

	
 
    def setInput(self, name):
 
        pass
 

	
 
    def setLiveVideo(self, on):
 
        print "setLiveVideo", on
 
        print("setLiveVideo", on)
 

	
 
    def onFrame(self, jpg, frameTime):
 
        # We could pass frameTime here to try to compensate for lag,
 
        # but it ended up looking worse in a test. One suspect is the
 
        # rpi clock drift might be worse than the lag. The value of
 
        # (now - frameTime) stutters regularly between 40ms, 140ms,
 
        # and 200ms.
 
        position = self.musicTime.getLatest()
 

	
 
        for d, filename in self._snapshotRequests:
 
            with open(filename, 'w') as out:
 
                out.write(jpg)
light9/vidref/replay.py
Show inline comments
 
from __future__ import division
 

	
 
import os, gtk, shutil, logging, time
 
from bisect import bisect_left
 
from decimal import Decimal
 
log = logging.getLogger()
 

	
 
framerate = 15
 

	
 

	
 
def songDir(song):
 
    safeUri = song.split('://')[-1].replace('/', '_')
 
    return os.path.expanduser("~/light9-vidref/play-%s" % safeUri)
 

	
light9/vidref/videorecorder.py
Show inline comments
 
import pygst
 
pygst.require("0.10")
 
import gst, gobject, time, logging, os, traceback
 
import gtk
 
from PIL import Image
 
from threading import Thread
 
from twisted.internet import defer
 
from Queue import Queue, Empty
 
from queue import Queue, Empty
 
from light9.vidref.replay import framerate, songDir, takeDir, snapshotDir
 
log = logging.getLogger()
 

	
 

	
 
class Pipeline(object):
 

	
 
    def __init__(self, liveVideoXid, musicTime, recordingTo):
 
        self.musicTime = musicTime
 
        self.liveVideoXid = liveVideoXid
 
        self.recordingTo = recordingTo
 
        self.snapshotRequests = Queue()
 

	
 
@@ -47,25 +47,25 @@ class Pipeline(object):
 
            "testpattern": "videotestsrc name=src1",
 
            "dv": "dv1394src name=src1 ! dvdemux ! dvdec",
 
            "v4l": "v4l2src device=/dev/video0 name=src1",
 
        }[name]
 

	
 
        cam = (
 
            sourcePipe + " ! "
 
            "videorate ! video/x-raw-yuv,framerate=%s/1 ! "
 
            "videoscale ! video/x-raw-yuv,width=640,height=480;video/x-raw-rgb,width=320,height=240 ! "
 
            "videocrop left=160 top=180 right=120 bottom=80 ! "
 
            "queue name=vid" % framerate)
 

	
 
        print cam
 
        print(cam)
 
        self.pipeline = gst.parse_launch(cam)
 

	
 
        def makeElem(t, n=None):
 
            e = gst.element_factory_make(t, n)
 
            self.pipeline.add(e)
 
            return e
 

	
 
        sink = makeElem("xvimagesink")
 

	
 
        def setRec(t):
 
            # if you're selecting the text while gtk is updating it,
 
            # you can get a crash in xcb_io
light9/wavelength.py
Show inline comments
 
#!/usr/bin/python
 

	
 
from __future__ import division, nested_scopes
 

	
 
import sys, wave
 

	
 
def wavelength(filename):
 
    filename = filename.replace('.ogg', '.wav')
 
    wavefile = wave.open(filename, 'rb')
 

	
 
    framerate = wavefile.getframerate() # frames / second
 
    nframes = wavefile.getnframes() # number of frames
 
    song_length = nframes / framerate
 

	
 
    return song_length
 

	
 
if __name__ == "__main__":
 
    for songfile in sys.argv[1:]:
 
        print songfile, wavelength(songfile)
 
        print(songfile, wavelength(songfile))
light9/wavepoints.py
Show inline comments
 
from __future__ import division
 

	
 
import wave, audioop
 

	
 
def simp(filename, seconds_per_average=0.001):
 
    """smaller seconds_per_average means fewer data points"""
 
    wavefile = wave.open(filename, 'rb')
 
    print "# gnuplot data for %s, seconds_per_average=%s" % \
 
        (filename, seconds_per_average)
 
    print "# %d channels, samplewidth: %d, framerate: %s, frames: %d\n# Compression type: %s (%s)" % wavefile.getparams()
 
    print("# gnuplot data for %s, seconds_per_average=%s" % \
 
        (filename, seconds_per_average))
 
    print("# %d channels, samplewidth: %d, framerate: %s, frames: %d\n# Compression type: %s (%s)" % wavefile.getparams())
 

	
 
    framerate = wavefile.getframerate() # frames / second
 
    frames_to_read = int(framerate * seconds_per_average)
 
    print "# frames_to_read=%s" % frames_to_read
 
    print("# frames_to_read=%s" % frames_to_read)
 

	
 
    time_and_max = []
 
    values = []
 
    count = 0
 
    while 1:
 
    while True:
 
        fragment = wavefile.readframes(frames_to_read)
 
        if not fragment:
 
            break
 

	
 
        # other possibilities:
 
        # m = audioop.avg(fragment, 2)
 
        # print count, "%s %s" % audioop.minmax(fragment, 2)
 

	
 
        m = audioop.rms(fragment, wavefile._framesize)
 
        time_and_max.append((count, m))
 
        values.append(m)
 
        count += frames_to_read
0 comments (0 inline, 0 general)