content
stringlengths 10
4.9M
|
---|
Following his acquittal on nine charges of rape and sexual assault, Nigel Evans – the former Deputy Speaker – has claimed that I “had it in for him”. Others have demanded that I apologise, and reflect on my role in the case.
To them, I ask this: what would you do if, in a social setting, someone told you that they had been sexually assaulted by one of your most popular colleagues? Would you have laughed off the allegation, or brushed it aside?
I did not. Instead, I offered to discuss it in a more appropriate setting, once the complainant had taken the time to decide whether he wished to do so. He took me up on my offer, came to my office and set out a very serious allegation: not only that he had been sexually assaulted, but that this had been swept under the carpet by the Whips Office, the only body to which he was able to take his concerns other than the MP about whom he was complaining.
Another young man, a 21-year-old student, then called me to allege that he had been raped. Neither wanted to go to the police, but both asked for my help, as they wanted a disciplinary process to take place – in their words, because they felt other individuals were at risk.
Since the Whips Office is hopelessly conflicted when it comes to investigating serious complaints against MPs – and since one of the complaints was about its original handling of the allegation – I made appointments for both men to see the Speaker, John Bercow. After the first meeting, he took legal advice, then sent a member of his staff to tell me that he could not become involved. The messenger repeatedly told me that his job was to protect the Speaker. So the only avenue open to the complainants was to go to the police.
The specific allegation against me, from some colleagues and commentators, has been that I pressured them to do so. This is a very serious charge. As a former forensic medical examiner, I am completely aware that the decision to report sexual violence to the police must be made solely by the complainants. That is why, when I was approached by the police following the first appointment with the Speaker, I declined to pass over the men’s names or contact details. I did, however, pass the officers’ contact details to the two young people concerned.
In response to the allegations about my role, and since the verdict, I have spoken to them and offered to stand down as an MP if they feel that I pressured them to take the complaint forward. Both are clear that I did not do so, and that I discussed with them the risks of doing so as well as their own concerns about protecting others.
I have set these facts out not to defend my own reputation, but because there are far more important issues at stake. Since the jury delivered its verdict, a backlash has begun.
The police have been criticised for their investigation, and the Crown Prosecution Service for its decision to put the evidence before a jury. Mr Evans has questioned whether such complainants should retain a right to anonymity, given that he feels his reputation has been traduced at no cost to theirs. Others have said that those accused of sexual violence should remain anonymous until conviction, to give them the same protection as their accusers. There have also been demands that prosecutors should not be able to use previous alleged offences when building their case.
I do not question the verdict. But equally, other MPs should not use this case as a pretext to interfere with the independence of the CPS. In particular, it would be completely wrong for politicians to respond to a colleague’s experience by making it even harder for potential victims to come forward.
It is worth revisiting the evidence: according to Rape Crisis, just 15 per cent of women and girls who experience sexual violence ever report it to the police. The barriers for men also include the fear of exposing their sexuality and how that will be handled by those conducting any investigation. Few cases make it to a courtroom and fewer still result in a conviction. Changing the rules on anonymity would slash reporting rates even further.
As for me, was I right to listen to the complainants and pass on their allegations?
As a member of the Health Select Committee, I listened to the evidence from the Francis Inquiry into the Mid Staffs scandal. In response, we told the General Medical Council that doctors ought to be struck off if they looked the other way and failed to report serious allegations about colleagues. It would have been rank hypocrisy to demand that standard from my fellow doctors, while failing to be prepared to do so myself.
This process was never going to be easy. But I have been truly shocked by the rank hostility since Mr Evans’s acquittal, from those who seriously feel I should have done nothing.
How can it be acceptable for a third of the 70 researchers interviewed by Channel 4 News to have experienced sexual harassment at Westminster? The people who truly have questions to answer are those who have for so long turned a blind eye to the reports of such harassment.
I didn’t, and don’t, want to be one of them.
Dr Sarah Wollaston is the Conservative Member of Parliament for Totnes |
def parse_and_analyse_corenlp_coref(input_dir = 'CoreNLP_coref_anno/dev', gold_annotations_folder = '../../../data/baseline/dev'):
mentions = []
with open('coref_analyse_output.txt', 'w') as out_file:
for file_name in os.listdir(input_dir):
if re.match(r'(.+)\.xml', file_name)!= None:
okr_graph = load_graph_from_file(gold_annotations_folder + '/'+ re.match(r'(.+)\.xml', file_name).group(1)[:-4]+'.xml')
tree = ET.parse(input_dir + '/' + file_name)
document = tree.getroot()[0]
sentence_wise_predicted_mentions = defaultdict(list)
sentence_wise_gold_mentions = defaultdict(list)
predicted_coref_dict = defaultdict(list)
gold_coref_dict = defaultdict(list)
coref_node = document.find('coreference')
for coref_id, coref_chain in enumerate(coref_node):
for mention in coref_chain:
sent_num = int(mention[0].text)
start = int(mention[1].text)-1
end = int(mention[2].text)-1
text = mention[4].text
sentence_wise_predicted_mentions[sent_num].append({"indices":range(start, end),"coref":coref_id+1, "text":text})
predicted_coref_dict[coref_id+1].append({"indices":range(start, end), "s_num":sent_num, "text":text })
for entity in okr_graph.entities.values():
for mention in entity.mentions.values():
sentence_wise_gold_mentions[mention.sentence_id].append({"indices":mention.indices,"coref":entity.id, 'text':mention.terms})
print'###'+ file_name + '\n'
for sentence_id, sentence in enumerate(okr_graph.sentences.values()):
print 'Sentence: ', ' '.join(sentence)
print 'Predicted entities: ', [element['text'] for element in sentence_wise_predicted_mentions[sentence_id+1]]
print 'Gold entities: ', [element['text'] for element in sentence_wise_gold_mentions[sentence_id+1]]
print ' '
print "Not printing singletons"
print('\nThe predicted clusters: ')
for cluster_id, cluster in enumerate(predicted_coref_dict.values()):
print('Cluster id: ', cluster_id +1)
print([[okr_graph.sentences[mention['s_num']][index] for index in mention['indices']]for mention in predicted_coref_dict[cluster_id+1]] )
print('\n The Gold clusters:')
for entity in okr_graph.entities.values():
print('cluster_id: ', entity.id )
print([mention.terms for mention in entity.mentions.values()])
print '**********' |
package meta
import (
"fmt"
"github.com/fagongzi/goetty"
"github.com/fagongzi/log"
)
const (
hb byte = 0
hbACK byte = 1
remove byte = 2
)
var (
// ShardingEncoder sharding encode
ShardingEncoder = goetty.NewIntLengthFieldBasedEncoder(&shardingCodec{})
// ShardingDecoder sharding decoder
ShardingDecoder = goetty.NewIntLengthFieldBasedDecoder(&shardingCodec{})
)
type shardingCodec struct {
}
func (c *shardingCodec) Decode(in *goetty.ByteBuf) (bool, interface{}, error) {
t, _ := in.ReadByte()
switch t {
case hb:
msg := &HBMsg{}
msg.Frag.ID = ReadUInt64(in)
msg.Frag.Version = ReadUInt64(in)
msg.Frag.Peers = ReadPeers(in)
msg.Frag.DisableGrow = ReadBool(in)
return true, msg, nil
case hbACK:
return true, &HBACKMsg{
ID: ReadUInt64(in),
Version: ReadUInt64(in),
Peer: ReadPeer(in),
}, nil
case remove:
return true, &RemoveMsg{
ID: ReadUInt64(in),
}, nil
}
return false, nil, fmt.Errorf("%d not support", t)
}
func (c *shardingCodec) Encode(data interface{}, out *goetty.ByteBuf) error {
if msg, ok := data.(*HBMsg); ok {
out.WriteByte(hb)
out.WriteUInt64(msg.Frag.ID)
out.WriteUInt64(msg.Frag.Version)
WritePeers(msg.Frag.Peers, out)
WriteBool(msg.Frag.DisableGrow, out)
} else if msg, ok := data.(*HBACKMsg); ok {
out.WriteByte(hbACK)
out.WriteUInt64(msg.ID)
out.WriteUInt64(msg.Version)
WritePeer(msg.Peer, out)
} else if msg, ok := data.(*RemoveMsg); ok {
out.WriteByte(remove)
out.WriteUInt64(msg.ID)
} else {
log.Fatalf("not support msg %T %+v",
data,
data)
}
return nil
}
|
<reponame>yangtuantuan/servicecomb-service-center
/*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You under the Apache License, Version 2.0
* (the "License"); you may not use this file except in compliance with
* the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package ws_test
import (
_ "github.com/apache/servicecomb-service-center/test"
"context"
"net/http"
"net/http/httptest"
"strings"
"testing"
"time"
wss "github.com/apache/servicecomb-service-center/server/connection/ws"
"github.com/apache/servicecomb-service-center/server/core"
"github.com/apache/servicecomb-service-center/server/event"
"github.com/gorilla/websocket"
"github.com/stretchr/testify/assert"
)
var closeCh = make(chan struct{})
func init() {
testing.Init()
core.Initialize()
}
type watcherConn struct {
MockServer *httptest.Server
ClientConn *websocket.Conn
ServerConn *websocket.Conn
}
func (h *watcherConn) Test() {
h.MockServer = httptest.NewServer(h)
h.ClientConn, _, _ = websocket.DefaultDialer.Dial(
strings.Replace(h.MockServer.URL, "http://", "ws://", 1), nil)
// wait server is ready
<-time.After(time.Second)
}
func (h *watcherConn) ServeHTTP(w http.ResponseWriter, r *http.Request) {
var upgrader = websocket.Upgrader{}
h.ServerConn, _ = upgrader.Upgrade(w, r, nil)
for {
//h.ServerConn.WriteControl(websocket.PingMessage, []byte{}, time.Now().Add(time.Second))
//h.ServerConn.WriteControl(websocket.PongMessage, []byte{}, time.Now().Add(time.Second))
_, _, err := h.ServerConn.ReadMessage()
if err != nil {
return
}
<-closeCh
h.ServerConn.WriteControl(websocket.CloseMessage, []byte{}, time.Now().Add(time.Second))
h.ServerConn.Close()
return
}
h.MockServer.Close()
}
func NewTest() *watcherConn {
ts := &watcherConn{}
ts.Test()
return ts
}
func TestNewWebSocket(t *testing.T) {
mock := NewTest()
t.Run("should return not nil when new", func(t *testing.T) {
assert.NotNil(t, wss.NewWebSocket("", "", mock.ServerConn))
})
}
func TestWebSocket_NeedCheck(t *testing.T) {
mock := NewTest()
conn := mock.ServerConn
options := wss.ToOptions()
webSocket := &wss.WebSocket{
Options: options,
DomainProject: "default",
ConsumerID: "",
Conn: conn,
}
t.Run("should not check when new", func(t *testing.T) {
webSocket.HealthInterval = time.Second
webSocket.Init()
assert.Nil(t, webSocket.NeedCheck())
})
t.Run("should check when check time up", func(t *testing.T) {
webSocket.HealthInterval = time.Microsecond
webSocket.Init()
<-time.After(time.Microsecond)
assert.NotNil(t, webSocket.NeedCheck())
})
t.Run("should not check when busy", func(t *testing.T) {
webSocket.HealthInterval = time.Microsecond
webSocket.Init()
<-time.After(time.Microsecond)
assert.NotNil(t, webSocket.NeedCheck())
assert.Nil(t, webSocket.NeedCheck())
})
}
func TestWebSocket_Idle(t *testing.T) {
mock := NewTest()
webSocket := wss.NewWebSocket("", "", mock.ServerConn)
t.Run("should idle when new", func(t *testing.T) {
select {
case <-webSocket.Idle():
default:
assert.Fail(t, "not idle")
}
})
t.Run("should idle when setIdle", func(t *testing.T) {
select {
case <-webSocket.Idle():
assert.Fail(t, "idle")
default:
webSocket.SetIdle()
select {
case <-webSocket.Idle():
default:
assert.Fail(t, "not idle")
}
}
})
t.Run("should idle when checkHealth", func(t *testing.T) {
_ = webSocket.CheckHealth(context.Background())
select {
case <-webSocket.Idle():
default:
assert.Fail(t, "not idle")
}
})
}
func TestWebSocket_CheckHealth(t *testing.T) {
mock := NewTest()
event.Center().Start()
t.Run("should do nothing when recv PING", func(t *testing.T) {
ws := wss.NewWebSocket("", "", mock.ServerConn)
mock.ClientConn.WriteControl(websocket.PingMessage, []byte{}, time.Now().Add(time.Second))
<-time.After(time.Second)
assert.Nil(t, ws.CheckHealth(context.Background()))
})
t.Run("should return err when consumer not exist", func(t *testing.T) {
ws := wss.NewWebSocket("", "", mock.ServerConn)
assert.Equal(t, "service does not exist", ws.CheckHealth(context.Background()).Error())
})
}
|
WASHINGTON (Reuters) - The number of U.S. workers drawing jobless benefits hit a 25-year high this month and imports suffered a record fall in September, according to reports on Thursday that underscored a rapid drop-off in the U.S. economy.
People search for jobs on computers at the Verdugo Jobs Center, a partnership with the California Employment Development Department, in Glendale, November 7, 2008. REUTERS/Fred Prouser
The number of workers filing new claims for jobless benefits rose by an unexpectedly steep 32,000 last week to 516,000, the highest since the weeks following the September 11, 2001 attacks on the United States, the Labor Department said.
The number of workers still on the benefit rolls after drawing an initial week of aid hit 3.9 million in the week to November 1, the highest since January 1983.
“This is obviously very, very serious deterioration in the labor market, more than a lot of people had expected even a couple of months ago,” said Scott Brown, chief economist with Raymond James & Associates in St. Petersburg, Fla.
“We are looking at the biggest financial crisis since the Great Depression and the biggest economic crisis we have had in the United States since the early 1980s.”
The U.S. economy has been suffering from a housing market crash, a lack of credit and an auto industry that is struggling to survive. One source of growth through the first half of the year has been exports, but that appeared to be stalling.
U.S. exports fell at the fastest pace in seven years as the credit crunch slowed economies around the world.
Worried U.S. consumers also cut back on retail purchases for the second consecutive month in October, according to SpendingPulse data, which excludes auto sales.
Consumer spending fell 1.5 percent last month, after a 2.4 percent drop in September that was the largest since SpendingPulse started the data series in 2003.
At a time when retailers are normally beginning to gear up for the holiday season, the trade data also showed imports of consumer goods fell nearly 7.9 percent in September.
However, a drop in interest rates spurred increased interest in home loans last week as mortgage applications recovered from almost an 8-year low.
“EVERYBODY IS HURTING”
U.S. stocks finished higher in volatile trade on Thursday after three straight days of losses. Investors snapped up beaten-down shares in energy, financial and others sectors, giving stock prices a boost despite the worries about a deepening economic downturn.
The dollar weakened against the euro, but rose against the yen. U.S. government debt prices fell.
A report from the Commerce Department showed a record drop in the price of imported oil and the lowest auto imports since February 2004, factors that helped trim the monthly trade gap to $56.5 billion, slightly below the $57 billion expected on Wall Street.
U.S. imports from China hit a record $33.1 billion in September, but imports from the European Union fell 3.8 percent and imports from the Organization of Petroleum Exporting Countries slumped 27.1 percent as the cost of imported oil fell by a record $12.41 per barrel in September.
“The drop in oil price is a factor, no doubt about it. People are just not driving that much (any) more,” said Joel Naroff, president of Naroff Economic Advisors in Holland, Pennsylvania. “We are seeing a decline in everything — imports and exports ... It tells me everybody is hurting.”
Related Coverage INSTANT VIEW: Jobless claims higher than expected
U.S. goods exports fell by a record $10.4 billion, with all major categories showing a decline. A sharp drop in exports of capital goods was led by civilian aircraft, after posting big numbers in the two prior months.
“We should still have another strong year for exports, but the short-term trend is not as strong as we’d like,” U.S. Commerce Secretary Carlos Gutierrez said. “If anything, what that says is we should help our exporters to offset that.”
Congress could do its part by approving three pending free trade agreements with Colombia, Panama and South Korea, while the White House keeps pushing for an agreement in the long-running Doha round of world trade talks, he said. |
/**
* The cache is divided into four levels:
*
* System Cache: It is the File Cache: the cache shared by a single archive
* file. Once the file is closed, the cached data is release. The user can set
* the max cache used by a single file. Stream Cache: Each opened stream locks
* at most 4 blocks, 1 data block, 3 FAT block.
*
*/
public class SystemCacheManager
{
protected static Logger logger = Logger.getLogger( SystemCacheManager.class
.getName( ) );
protected int maxCacheSize;
protected int usedCacheSize;
protected CacheList caches;
protected boolean enableSystemCache;
public SystemCacheManager( )
{
this( 0 );
}
public SystemCacheManager( int maxCacheSize )
{
this.maxCacheSize = maxCacheSize;
this.usedCacheSize = 0;
this.caches = new CacheList( );
}
public void setMaxCacheSize( int size )
{
maxCacheSize = size;
}
void increaseUsedCacheSize( int size )
{
usedCacheSize += size;
}
public int getUsedCacheSize( )
{
return usedCacheSize;
}
void removeCaches( FileCacheManager manager )
{
Cacheable cache = caches.first( );
while ( cache != null )
{
Cacheable next = cache.getNext( );
if ( cache.manager == manager )
{
caches.remove( cache );
manager.caches.remove( cache.getCacheKey( ) );
usedCacheSize--;
}
cache = next;
}
}
void removeCache( Cacheable cache )
{
caches.remove( cache );
}
void addCaches( Cacheable[] caches )
{
if ( maxCacheSize == 0 )
{
// remove the cache directly
for ( Cacheable cache : caches )
{
cache.getReferenceCount( ).set( -2 );
cache.manager.caches.remove( cache.getCacheKey( ) );
}
}
else
{
for ( Cacheable cache : caches )
{
cache.getReferenceCount( ).set( -1 );
this.caches.add( cache );
}
adjustSystemCaches( );
}
}
void addCache( Cacheable cache )
{
if ( maxCacheSize == 0 )
{
// remove the cache directly
cache.getReferenceCount( ).set( -2 );
cache.manager.caches.remove( cache.getCacheKey( ) );
}
else
{
cache.getReferenceCount( ).set( -1 );
caches.add( cache );
adjustSystemCaches( );
}
}
private void adjustSystemCaches( )
{
int releaseCacheSize = caches.size( ) - maxCacheSize;
if ( releaseCacheSize > 0 )
{
for ( int i = 0; i < releaseCacheSize; i++ )
{
Cacheable removed = caches.remove( );
if ( removed.getReferenceCount( ).compareAndSet( -1, -2 ) )
{
removed.manager.caches.remove( removed.getCacheKey( ) );
usedCacheSize--;
}
}
}
}
} |
<reponame>zanjs/y-mugg-v3<gh_stars>0
package middleware
// QueryPage is
// func QueryPage(q models.QueryParams) models.PageModel {
// }
|
import datetime as dt
import logging
from typing import Any, Dict, Optional
import coloredlogs
import numpy as np
from .kernel import Kernel
from .utils import subdict
logger = logging.getLogger("abides")
def run(
config: Dict[str, Any],
log_dir: str = "",
kernel_seed: int = 0,
kernel_random_state: Optional[np.random.RandomState] = None,
) -> Dict[str, Any]:
"""
Wrapper function that enables to run one simulation.
It does the following steps:
- instantiation of the kernel
- running of the simulation
- return the end_state object
Arguments:
config: configuration file for the specific simulation
log_dir: directory where log files are stored
kernel_seed: simulation seed
kernel_random_state: simulation random state
"""
coloredlogs.install(
level=config["stdout_log_level"],
fmt="[%(process)d] %(levelname)s %(name)s %(message)s",
)
kernel = Kernel(
random_state=kernel_random_state or np.random.RandomState(seed=kernel_seed),
log_dir=log_dir,
**subdict(
config,
[
"start_time",
"stop_time",
"agents",
"agent_latency_model",
"default_computation_delay",
"custom_properties",
],
),
)
sim_start_time = dt.datetime.now()
logger.info(f"Simulation Start Time: {sim_start_time}")
end_state = kernel.run()
sim_end_time = dt.datetime.now()
logger.info(f"Simulation End Time: {sim_end_time}")
logger.info(f"Time taken to run simulation: {sim_end_time - sim_start_time}")
return end_state
|
def save_check(args, model, class_to_idx, possible_inputs):
checkpoint = {'state_dict': model.classifier.state_dict(),
'epochs':args.epochs,
'class_to_idx' : class_to_idx,
'input_size': possible_inputs[args.arch],
'output_size': 102,
'hidden_layers' : args.hidden_units,
'dropout' : args.dropout,
'arch' : args.arch}
torch.save(checkpoint, args.save_dir) |
<filename>src/config.orm.ts<gh_stars>0
import {
DB_HOST,
DB_NAME,
DB_PASSWORD,
DB_PORT,
DB_TYPE,
DB_USERNAME,
NODE_ENV,
} from '@/environments';
const orm = {
local: {
type: DB_TYPE,
host: DB_HOST,
port: DB_PORT,
username: DB_USERNAME,
password: <PASSWORD>,
database: DB_NAME,
},
development: {
type: DB_TYPE,
host: DB_HOST,
port: DB_PORT,
username: DB_USERNAME,
password: <PASSWORD>,
database: DB_NAME,
},
testing: {
type: DB_TYPE,
host: DB_HOST,
port: DB_PORT,
username: DB_USERNAME,
password: <PASSWORD>,
database: DB_NAME,
},
staging: {
type: DB_TYPE,
host: DB_HOST,
port: DB_PORT,
username: DB_USERNAME,
password: <PASSWORD>,
database: DB_NAME,
},
production: {
type: DB_TYPE,
host: DB_HOST,
port: DB_PORT,
username: DB_USERNAME,
password: <PASSWORD>,
database: DB_NAME,
},
};
export default orm[NODE_ENV!];
|
class HTTPSConnection: # R0903: Too few public methods
"""Make Https Request to fetch the result as per requested url"""
def __init__(self, endpoint, headers, timeout, retry_strategy):
if None not in (endpoint, headers):
self.payload = None
self.endpoint = endpoint
self.headers = headers
self.timeout = timeout # default timeout (period=30) seconds
self.retry_strategy = retry_strategy
def get(self, url):
import requests
from requests.adapters import HTTPAdapter
from requests.exceptions import HTTPError, Timeout
"""
Here we create a response object, `response` which will store the request-response.
We use requests.get method since we are sending a GET request.
The four arguments we pass are url, verify(ssl), timeout, headers
"""
try:
self.headers.update(user_agents())
session = requests.Session()
adapter = HTTPAdapter(max_retries=self.retry_strategy)
session.mount('https://', adapter)
# log.info('url: %s', url)
response = session.get(url, verify=True, headers=self.headers, timeout=self.timeout)
if response.encoding is None:
response.encoding = 'utf-8'
if response is not None:
return response.json()
else:
return {"error": "error details not found", "error_code": 422, "error_message": "unknown error"}
except Timeout:
raise TimeoutError('The request timed out')
except ConnectionError:
raise ConnectionError('Connection error occurred')
except JSONDecodeError:
raise TypeError('Invalid JSON in request')
except HTTPError:
raise HTTPError('Http Error Occurred') |
/**
*
* <p>This method silently discards any unread content, if the caller has
* yet not read all content.
*/
public void endDecoding()
throws IOException {
Make sure that we slurp all data yet unread to keep keep-alive
connections alive (I love the English tongue... but maybe this is
just the result of my German tongue and syntax going crazy, so
Mark Twain was right. No, Mark Twain did not invent the scanner API!)
if ( chunkedTransfer ) {
if ( keepAlive && !finalChunkSeen ) {
Only makes sense if the connection can be kept alive, otherwise
we don't want to bother ourselves slurping junk data...
int chunkLength;
long bytesSkipped;
try {
First, get rid of the current chunk, if there is any.
while ( remainingChunkLength > 0 ) {
bytesSkipped = in.skip(remainingChunkLength);
if ( bytesSkipped < 0 ) {
throw(new IOException("Could not skip chunk"));
}
remainingChunkLength -= bytesSkipped;
}
Then dispose any other chunks...
String hexLen;
while ( !finalChunkSeen ) {
Read next chunk header, then flush chunk data, including
the CRLF terminating each chunk.
hexLen = readLine();
chunkLength = Integer.parseInt(hexLen, 16);
if ( chunkLength < 0 ) {
throw(new NumberFormatException("must not be negative"));
}
if ( chunkLength == 0 ) {
break;
}
while ( chunkLength > 0 ) {
bytesSkipped = in.skip(remainingChunkLength);
if ( bytesSkipped < 0 ) {
throw(new IOException("Could not skip chunk"));
}
chunkLength -= bytesSkipped;
}
readLine();
}
} catch ( Exception e ) {
Got in any trouble? Then kill the connection.
close();
}
}
} else if ( keepAlive ) {
Skip remaining unread content, if the content length is known
in advance. Otherwise drop the connection.
if ( remainingContentLength > 0 ) {
long bytesSkipped;
while ( remainingContentLength > 0 ) {
bytesSkipped = in.skip(remainingContentLength);
if ( bytesSkipped < 0 ) {
close();
break;
}
remainingContentLength -= bytesSkipped;
}
} else if ( remainingContentLength < 0 ) {
close();
}
}
Indicate new mode, if the connection is still alive, or close it
if it can not kept alive.
if ( mode != HTTP_DEAD ) {
if ( !keepAlive ) {
close();
} else {
mode = HTTP_IDLE;
}
}
} |
THE president of Russia holds a black belt in judo, once worked for the K.G.B. and has been known, when angered, to make pointed allusions to killing enemies in their outhouses and telling journalists to undergo a bris by a surgeon with lousy aim. Superman wouldn't tug on this guy's cape.
So what was Novaya Gazeta thinking when it compared Vladimir V. Putin to Dobby the House-Elf?
The decidedly liberal Moscow daily reported on Jan. 20 that a major Moscow law firm was preparing to sue Warner Brothers, the factory that churns out the Harry Potter movies, for adapting Mr. Putin's likeness to Dobby, a computer-generated elf in its latest release, ''Harry Potter and the Chamber of Secrets.''
For those who haven't seen the film, Dobby appears near the start to warn young Harry against returning to Hogwarts. He is a kindhearted fellow who gains his freedom from evil masters, a not-unflattering story line that could well fit Mr. Putin, depending on one's view of the K.G.B.
But Dobby is also a wizened midget with bulging green eyeballs and floppy ears who wears a pillowcase. Mr. Putin is perhaps slightly shortish as world leaders go, but wizened he is not. He is a pretty snappy dresser, too.
Advertisement Continue reading the main story
Despite that, the supposed Putin-Dobby resemblance has become something of a news event, and is clogging the chat rooms of Harry Potter Internet fan sites. |
<reponame>bebuch/disposer
//-----------------------------------------------------------------------------
// Copyright (c) 2015-2018 <NAME>
//
// https://github.com/bebuch/disposer
//
// Distributed under the Boost Software License, Version 1.0. (See accompanying
// file LICENSE_1_0.txt or copy at https://www.boost.org/LICENSE_1_0.txt)
//-----------------------------------------------------------------------------
#ifndef _disposer__core__input_base__hpp_INCLUDED_
#define _disposer__core__input_base__hpp_INCLUDED_
namespace disposer{
class output_base;
/// \brief Base for module inputs
///
/// Polymorphe base class for module inputs.
///
/// A module input must have at least one input data type.
/// An input might have more then one data type.
class input_base{
public:
/// \brief Constructor
input_base(output_base* output)noexcept
: output_(output) {}
/// \brief Inputs are not copyable
input_base(input_base const&) = delete;
/// \brief Inputs are movable
input_base(input_base&&) = default;
/// \brief Inputs are not copy-assingable
input_base& operator=(input_base const&) = delete;
/// \brief Inputs are not move-assingble
input_base& operator=(input_base&&) = delete;
/// \brief Get connected output or nullptr
output_base* output_ptr()const noexcept{ return output_; }
private:
/// \brief Pointer to the linked output
output_base* const output_;
};
}
#endif
|
#[doc = r" Register block"]
#[repr(C)]
pub struct RegisterBlock {
#[doc = "0x00 - Peripheral ID register"]
pub perid: PERID,
_reserved0: [u8; 3usize],
#[doc = "0x04 - Peripheral ID Complement register"]
pub idcomp: IDCOMP,
_reserved1: [u8; 3usize],
#[doc = "0x08 - Peripheral Revision register"]
pub rev: REV,
_reserved2: [u8; 3usize],
#[doc = "0x0c - Peripheral Additional Info register"]
pub addinfo: ADDINFO,
_reserved3: [u8; 3usize],
#[doc = "0x10 - OTG Interrupt Status register"]
pub otgistat: OTGISTAT,
_reserved4: [u8; 3usize],
#[doc = "0x14 - OTG Interrupt Control register"]
pub otgicr: OTGICR,
_reserved5: [u8; 3usize],
#[doc = "0x18 - OTG Status register"]
pub otgstat: OTGSTAT,
_reserved6: [u8; 3usize],
#[doc = "0x1c - OTG Control register"]
pub otgctl: OTGCTL,
_reserved7: [u8; 99usize],
#[doc = "0x80 - Interrupt Status register"]
pub istat: ISTAT,
_reserved8: [u8; 3usize],
#[doc = "0x84 - Interrupt Enable register"]
pub inten: INTEN,
_reserved9: [u8; 3usize],
#[doc = "0x88 - Error Interrupt Status register"]
pub errstat: ERRSTAT,
_reserved10: [u8; 3usize],
#[doc = "0x8c - Error Interrupt Enable register"]
pub erren: ERREN,
_reserved11: [u8; 3usize],
#[doc = "0x90 - Status register"]
pub stat: STAT,
_reserved12: [u8; 3usize],
#[doc = "0x94 - Control register"]
pub ctl: CTL,
_reserved13: [u8; 3usize],
#[doc = "0x98 - Address register"]
pub addr: ADDR,
_reserved14: [u8; 3usize],
#[doc = "0x9c - BDT Page register 1"]
pub bdtpage1: BDTPAGE1,
_reserved15: [u8; 3usize],
#[doc = "0xa0 - Frame Number register Low"]
pub frmnuml: FRMNUML,
_reserved16: [u8; 3usize],
#[doc = "0xa4 - Frame Number register High"]
pub frmnumh: FRMNUMH,
_reserved17: [u8; 3usize],
#[doc = "0xa8 - Token register"]
pub token: TOKEN,
_reserved18: [u8; 3usize],
#[doc = "0xac - SOF Threshold register"]
pub softhld: SOFTHLD,
_reserved19: [u8; 3usize],
#[doc = "0xb0 - BDT Page Register 2"]
pub bdtpage2: BDTPAGE2,
_reserved20: [u8; 3usize],
#[doc = "0xb4 - BDT Page Register 3"]
pub bdtpage3: BDTPAGE3,
_reserved21: [u8; 11usize],
#[doc = "0xc0 - Endpoint Control register"]
pub endpt0: ENDPT,
_reserved22: [u8; 3usize],
#[doc = "0xc4 - Endpoint Control register"]
pub endpt1: ENDPT,
_reserved23: [u8; 3usize],
#[doc = "0xc8 - Endpoint Control register"]
pub endpt2: ENDPT,
_reserved24: [u8; 3usize],
#[doc = "0xcc - Endpoint Control register"]
pub endpt3: ENDPT,
_reserved25: [u8; 3usize],
#[doc = "0xd0 - Endpoint Control register"]
pub endpt4: ENDPT,
_reserved26: [u8; 3usize],
#[doc = "0xd4 - Endpoint Control register"]
pub endpt5: ENDPT,
_reserved27: [u8; 3usize],
#[doc = "0xd8 - Endpoint Control register"]
pub endpt6: ENDPT,
_reserved28: [u8; 3usize],
#[doc = "0xdc - Endpoint Control register"]
pub endpt7: ENDPT,
_reserved29: [u8; 3usize],
#[doc = "0xe0 - Endpoint Control register"]
pub endpt8: ENDPT,
_reserved30: [u8; 3usize],
#[doc = "0xe4 - Endpoint Control register"]
pub endpt9: ENDPT,
_reserved31: [u8; 3usize],
#[doc = "0xe8 - Endpoint Control register"]
pub endpt10: ENDPT,
_reserved32: [u8; 3usize],
#[doc = "0xec - Endpoint Control register"]
pub endpt11: ENDPT,
_reserved33: [u8; 3usize],
#[doc = "0xf0 - Endpoint Control register"]
pub endpt12: ENDPT,
_reserved34: [u8; 3usize],
#[doc = "0xf4 - Endpoint Control register"]
pub endpt13: ENDPT,
_reserved35: [u8; 3usize],
#[doc = "0xf8 - Endpoint Control register"]
pub endpt14: ENDPT,
_reserved36: [u8; 3usize],
#[doc = "0xfc - Endpoint Control register"]
pub endpt15: ENDPT,
_reserved37: [u8; 3usize],
#[doc = "0x100 - USB Control register"]
pub usbctrl: USBCTRL,
_reserved38: [u8; 3usize],
#[doc = "0x104 - USB OTG Observe register"]
pub observe: OBSERVE,
_reserved39: [u8; 3usize],
#[doc = "0x108 - USB OTG Control register"]
pub control: CONTROL,
_reserved40: [u8; 3usize],
#[doc = "0x10c - USB Transceiver Control register 0"]
pub usbtrc0: USBTRC0,
_reserved41: [u8; 7usize],
#[doc = "0x114 - Frame Adjust Register"]
pub usbfrmadjust: USBFRMADJUST,
_reserved42: [u8; 43usize],
#[doc = "0x140 - USB Clock recovery control"]
pub clk_recover_ctrl: CLK_RECOVER_CTRL,
_reserved43: [u8; 3usize],
#[doc = "0x144 - IRC48M oscillator enable register"]
pub clk_recover_irc_en: CLK_RECOVER_IRC_EN,
_reserved44: [u8; 15usize],
#[doc = "0x154 - Clock recovery combined interrupt enable"]
pub clk_recover_int_en: CLK_RECOVER_INT_EN,
_reserved45: [u8; 7usize],
#[doc = "0x15c - Clock recovery separated interrupt status"]
pub clk_recover_int_status: CLK_RECOVER_INT_STATUS,
}
#[doc = "Peripheral ID register"]
pub struct PERID {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Peripheral ID register"]
pub mod perid;
#[doc = "Peripheral ID Complement register"]
pub struct IDCOMP {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Peripheral ID Complement register"]
pub mod idcomp;
#[doc = "Peripheral Revision register"]
pub struct REV {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Peripheral Revision register"]
pub mod rev;
#[doc = "Peripheral Additional Info register"]
pub struct ADDINFO {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Peripheral Additional Info register"]
pub mod addinfo;
#[doc = "OTG Interrupt Status register"]
pub struct OTGISTAT {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "OTG Interrupt Status register"]
pub mod otgistat;
#[doc = "OTG Interrupt Control register"]
pub struct OTGICR {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "OTG Interrupt Control register"]
pub mod otgicr;
#[doc = "OTG Status register"]
pub struct OTGSTAT {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "OTG Status register"]
pub mod otgstat;
#[doc = "OTG Control register"]
pub struct OTGCTL {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "OTG Control register"]
pub mod otgctl;
#[doc = "Interrupt Status register"]
pub struct ISTAT {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Interrupt Status register"]
pub mod istat;
#[doc = "Interrupt Enable register"]
pub struct INTEN {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Interrupt Enable register"]
pub mod inten;
#[doc = "Error Interrupt Status register"]
pub struct ERRSTAT {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Error Interrupt Status register"]
pub mod errstat;
#[doc = "Error Interrupt Enable register"]
pub struct ERREN {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Error Interrupt Enable register"]
pub mod erren;
#[doc = "Status register"]
pub struct STAT {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Status register"]
pub mod stat;
#[doc = "Control register"]
pub struct CTL {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Control register"]
pub mod ctl;
#[doc = "Address register"]
pub struct ADDR {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Address register"]
pub mod addr;
#[doc = "BDT Page register 1"]
pub struct BDTPAGE1 {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "BDT Page register 1"]
pub mod bdtpage1;
#[doc = "Frame Number register Low"]
pub struct FRMNUML {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Frame Number register Low"]
pub mod frmnuml;
#[doc = "Frame Number register High"]
pub struct FRMNUMH {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Frame Number register High"]
pub mod frmnumh;
#[doc = "Token register"]
pub struct TOKEN {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Token register"]
pub mod token;
#[doc = "SOF Threshold register"]
pub struct SOFTHLD {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "SOF Threshold register"]
pub mod softhld;
#[doc = "BDT Page Register 2"]
pub struct BDTPAGE2 {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "BDT Page Register 2"]
pub mod bdtpage2;
#[doc = "BDT Page Register 3"]
pub struct BDTPAGE3 {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "BDT Page Register 3"]
pub mod bdtpage3;
#[doc = "Endpoint Control register"]
pub struct ENDPT {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Endpoint Control register"]
pub mod endpt;
#[doc = "USB Control register"]
pub struct USBCTRL {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "USB Control register"]
pub mod usbctrl;
#[doc = "USB OTG Observe register"]
pub struct OBSERVE {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "USB OTG Observe register"]
pub mod observe;
#[doc = "USB OTG Control register"]
pub struct CONTROL {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "USB OTG Control register"]
pub mod control;
#[doc = "USB Transceiver Control register 0"]
pub struct USBTRC0 {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "USB Transceiver Control register 0"]
pub mod usbtrc0;
#[doc = "Frame Adjust Register"]
pub struct USBFRMADJUST {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Frame Adjust Register"]
pub mod usbfrmadjust;
#[doc = "USB Clock recovery control"]
pub struct CLK_RECOVER_CTRL {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "USB Clock recovery control"]
pub mod clk_recover_ctrl;
#[doc = "IRC48M oscillator enable register"]
pub struct CLK_RECOVER_IRC_EN {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "IRC48M oscillator enable register"]
pub mod clk_recover_irc_en;
#[doc = "Clock recovery combined interrupt enable"]
pub struct CLK_RECOVER_INT_EN {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Clock recovery combined interrupt enable"]
pub mod clk_recover_int_en;
#[doc = "Clock recovery separated interrupt status"]
pub struct CLK_RECOVER_INT_STATUS {
register: ::vcell::VolatileCell<u8>,
}
#[doc = "Clock recovery separated interrupt status"]
pub mod clk_recover_int_status;
|
/*
* Copyright 2020 the original author or authors.
* <p>
* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
* <p>
* https://www.apache.org/licenses/LICENSE-2.0
* <p>
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package org.openrewrite.java;
import org.openrewrite.Cursor;
import org.openrewrite.java.tree.J;
public class UnwrapParentheses<P> extends JavaVisitor<P> {
private final J.Parentheses<?> scope;
public UnwrapParentheses(J.Parentheses<?> scope) {
this.scope = scope;
}
@Override
public <T extends J> J visitParentheses(J.Parentheses<T> parens, P p) {
if (scope.isScope(parens) && isUnwrappable(getCursor())) {
J tree = parens.getTree().withPrefix(parens.getPrefix());
if (tree.getPrefix().isEmpty() && getCursor().getParentOrThrow().getValue() instanceof J.Return) {
tree = tree.withPrefix(tree.getPrefix().withWhitespace(" "));
}
return tree;
}
return super.visitParentheses(parens, p);
}
public static boolean isUnwrappable(Cursor parensScope) {
if (!(parensScope.getValue() instanceof J.Parentheses)) {
return false;
}
J parent = parensScope.getParentTreeCursor().getValue();
if (parent instanceof J.If ||
parent instanceof J.Switch ||
parent instanceof J.Synchronized ||
parent instanceof J.Try.Catch ||
parent instanceof J.TypeCast ||
parent instanceof J.WhileLoop) {
return false;
} else if (parent instanceof J.DoWhileLoop) {
return !(parensScope.getValue() == ((J.DoWhileLoop) parent).getWhileCondition());
} else if (parent instanceof J.Unary) {
J innerJ = ((J.Parentheses<?>) parensScope.getValue()).getTree();
return !(innerJ instanceof J.Binary);
}
return true;
}
}
|
def update_acceleration(self, x: float, y: float, z: float) -> None:
self.value = (x, y, z)
if not self.history:
self.history = (x, y, z)
dx = dy = dz = 0.0
else:
dx = x - self.history[0]
dy = y - self.history[1]
dz = z - self.history[2]
alpha = self.config['alpha']
self.history = (self.history[0] * alpha + x * (1 - alpha),
self.history[1] * alpha + y * (1 - alpha),
self.history[2] * alpha + z * (1 - alpha))
self._handle_hits(dx, dy, dz)
if math.fabs(dx) + math.fabs(dy) + math.fabs(dz) < 0.05:
self._handle_level() |
Unveiling: The Electoral Consequences of an Exogenous Mid-Campaign Court Ruling
Strong evidence exists that major campaign-relevant events can have substantial impacts on vote intentions. We know less about how information about such events diffuses and why only some events become salient. We posit that voters often become aware of such exogenous events via a media mechanism. As the salience of the policy issue in the media increases, we argue that, under certain conditions, the media primes the voters to defect from their party and its leader. We investigate these processes by studying an unexpected court ruling during the 2015 Canadian federal election campaign. Based on difference-in-differences and text-as-data approaches, we find that an exogenous court ruling related to immigrant integration led to between a 5 and 11 percentage point decline in the leading party’s support. Beyond modeling how campaign-relevant events become salient through the media, we provide evidence about circumstances where leaders should not expect party loyalty to override crystallized opinions. |
// Copyright (c) Microsoft Corporation. All rights reserved.
// Licensed under the MIT License.
package com.azure.spring.cloud.feature.manager.feature.filters;
import com.azure.spring.cloud.feature.manager.FeatureFilter;
import com.azure.spring.cloud.feature.manager.TargetingException;
import com.azure.spring.cloud.feature.manager.entities.FeatureFilterEvaluationContext;
import com.azure.spring.cloud.feature.manager.targeting.Audience;
import com.azure.spring.cloud.feature.manager.targeting.GroupRollout;
import com.azure.spring.cloud.feature.manager.targeting.ITargetingContextAccessor;
import com.azure.spring.cloud.feature.manager.targeting.TargetingContext;
import com.azure.spring.cloud.feature.manager.targeting.TargetingEvaluationOptions;
import com.azure.spring.cloud.feature.manager.targeting.TargetingFilterSettings;
import com.fasterxml.jackson.databind.MapperFeature;
import com.fasterxml.jackson.databind.ObjectMapper;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import java.nio.ByteBuffer;
import java.nio.charset.Charset;
import java.security.MessageDigest;
import java.security.NoSuchAlgorithmException;
import java.util.ArrayList;
import java.util.LinkedHashMap;
import java.util.List;
import java.util.Map;
import java.util.Optional;
/**
* `Microsoft.TargetingFilter` enables evaluating a user/group/overall rollout of a feature.
*/
public class TargetingFilter implements FeatureFilter {
private static final Logger LOGGER = LoggerFactory.getLogger(TargetingFilter.class);
private static final String USERS = "users";
private static final String GROUPS = "groups";
private static final String AUDIENCE = "Audience";
private static final String OUT_OF_RANGE = "The value is out of the accepted range.";
private static final String REQUIRED_PARAMETER = "Value cannot be null.";
private static final ObjectMapper OBJECT_MAPPER = new ObjectMapper()
.configure(MapperFeature.ACCEPT_CASE_INSENSITIVE_PROPERTIES, true);
private final ITargetingContextAccessor contextAccessor;
private final TargetingEvaluationOptions options;
/**
* `Microsoft.TargetingFilter` evaluates a user/group/overall rollout of a feature.
* @param contextAccessor Context for evaluating the users/groups.
*/
public TargetingFilter(ITargetingContextAccessor contextAccessor) {
this.contextAccessor = contextAccessor;
this.options = new TargetingEvaluationOptions();
}
/**
* `Microsoft.TargetingFilter` evaluates a user/group/overall rollout of a feature.
* @param contextAccessor Context for evaluating the users/groups.
* @param options enables customization of the filter.
*/
public TargetingFilter(ITargetingContextAccessor contextAccessor, TargetingEvaluationOptions options) {
this.contextAccessor = contextAccessor;
this.options = options;
}
@Override
@SuppressWarnings("unchecked")
public boolean evaluate(FeatureFilterEvaluationContext context) {
if (context == null) {
throw new IllegalArgumentException("Targeting Context not configured.");
}
TargetingContext targetingContext = contextAccessor.getContextAsync().block();
if (targetingContext == null) {
LOGGER.warn("No targeting context available for targeting evaluation.");
return false;
}
TargetingFilterSettings settings = new TargetingFilterSettings();
LinkedHashMap<String, Object> parameters = context.getParameters();
if (parameters != null) {
Object audienceObject = parameters.get(AUDIENCE);
if (audienceObject != null) {
parameters = (LinkedHashMap<String, Object>) audienceObject;
}
this.<String>updateValueFromMapToList(parameters, USERS);
updateValueFromMapToList(parameters, GROUPS);
settings.setAudience(OBJECT_MAPPER.convertValue(parameters, Audience.class));
}
tryValidateSettings(settings);
Audience audience = settings.getAudience();
if (targetingContext.getUserId() != null
&& audience.getUsers() != null
&& audience.getUsers().stream()
.anyMatch(user -> compairStrings(targetingContext.getUserId(), user))
) {
return true;
}
if (targetingContext.getGroups() != null && audience.getGroups() != null) {
for (String group : targetingContext.getGroups()) {
Optional<GroupRollout> groupRollout = audience.getGroups().stream()
.filter(g -> compairStrings(g.getName(), group)).findFirst();
if (groupRollout.isPresent()) {
String audienceContextId = targetingContext.getUserId() + "\n" + context.getName() + "\n" + group;
if (isTargeted(audienceContextId, groupRollout.get().getRolloutPercentage())) {
return true;
}
}
}
}
String defaultContextId = targetingContext.getUserId() + "\n" + context.getFeatureName();
return isTargeted(defaultContextId, settings.getAudience().getDefaultRolloutPercentage());
}
private boolean isTargeted(String contextId, double percentage) {
byte[] hash = null;
try {
MessageDigest digest = MessageDigest.getInstance("SHA-256");
hash = digest.digest(contextId.getBytes(Charset.defaultCharset()));
} catch (NoSuchAlgorithmException e) {
throw new TargetingException("Unable to find SHA-256 for targeting.", e);
}
if (hash == null) {
throw new TargetingException("Unable to create Targeting Hash for " + contextId);
}
ByteBuffer wrapped = ByteBuffer.wrap(hash);
int contextMarker = Math.abs(wrapped.getInt());
double contextPercentage = (contextMarker / (double) Integer.MAX_VALUE) * 100;
return contextPercentage < percentage;
}
private void tryValidateSettings(TargetingFilterSettings settings) {
String paramName = "";
String reason = "";
if (settings.getAudience() == null) {
paramName = AUDIENCE;
reason = REQUIRED_PARAMETER;
throw new TargetingException(paramName + " : " + reason);
}
Audience audience = settings.getAudience();
if (audience.getDefaultRolloutPercentage() < 0
|| audience.getDefaultRolloutPercentage() > 100) {
paramName = AUDIENCE + "." + audience.getDefaultRolloutPercentage();
reason = OUT_OF_RANGE;
throw new TargetingException(paramName + " : " + reason);
}
List<GroupRollout> groups = audience.getGroups();
if (groups != null) {
for (int index = 0; index < groups.size(); index++) {
GroupRollout groupRollout = groups.get(index);
if (groupRollout.getRolloutPercentage() < 0 || groupRollout.getRolloutPercentage() > 100) {
paramName = AUDIENCE + "[" + index + "]." + groups.get(index).getRolloutPercentage();
reason = OUT_OF_RANGE;
throw new TargetingException(paramName + " : " + reason);
}
}
}
}
private boolean compairStrings(String s1, String s2) {
if (options.isIgnoreCase()) {
return s1.equalsIgnoreCase(s2);
}
return s1.equals(s2);
}
@SuppressWarnings("unchecked")
private <T> void updateValueFromMapToList(LinkedHashMap<String, Object> parameters, String key) {
Object objectMap = parameters.get(key);
if (objectMap instanceof Map) {
List<T> toType = new ArrayList<>(((Map<String, T>) objectMap).values());
parameters.put(key, toType);
}
}
}
|
/**
* @author Bas Leijdekkers
*/
public class ScriptFilter extends FilterAction {
public ScriptFilter(FilterTable filterTable) {
super("Script", filterTable);
}
@Override
public boolean hasFilter() {
return !StringUtil.isEmpty(myTable.getConstraint().getScriptCodeConstraint());
}
@Override
public void clearFilter() {
myTable.getConstraint().setScriptCodeConstraint("");
}
@Override
public boolean isApplicable(List<PsiElement> nodes, boolean completePattern, boolean target) {
return true;
}
@Override
protected void setLabel(SimpleColoredComponent component) {
component.append("script=").append(StringUtil.unquoteString(myTable.getConstraint().getScriptCodeConstraint()));
}
@Override
public FilterEditor getEditor() {
return new FilterEditor(myTable.getConstraint()) {
private final JLabel myLabel = new JLabel("script=");
private final EditorTextField myTextField = UIUtil.createScriptComponent("", myTable.getProject());
private ContextHelpLabel myHelpLabel;
@Override
protected void layoutComponents() {
new ExpandableEditorSupport(myTextField);
final String[] variableNames = {Configuration.CONTEXT_VAR_NAME, ScriptLog.SCRIPT_LOG_VAR_NAME};
myHelpLabel = ContextHelpLabel.create(
"<p>Use GroovyScript IntelliJ API to filter the search results." +
"<p>Available variables: " + String.join(", ", variableNames));
final GroupLayout layout = new GroupLayout(this);
setLayout(layout);
layout.setAutoCreateContainerGaps(true);
layout.setHorizontalGroup(
layout.createSequentialGroup()
.addComponent(myLabel)
.addComponent(myTextField)
.addPreferredGap(LayoutStyle.ComponentPlacement.RELATED, 1, 1)
.addComponent(myHelpLabel)
);
layout.setVerticalGroup(
layout.createParallelGroup(GroupLayout.Alignment.CENTER)
.addComponent(myLabel)
.addComponent(myTextField)
.addComponent(myHelpLabel)
);
}
@Override
protected void loadValues() {
myTextField.setText(StringUtil.unquoteString(myConstraint.getScriptCodeConstraint()));
}
@Override
protected void saveValues() {
myConstraint.setScriptCodeConstraint('"' + myTextField.getText() + '"');
}
@Override
public JComponent getPreferredFocusedComponent() {
return myTextField;
}
@Override
public JComponent[] getFocusableComponents() {
return new JComponent[]{myTextField};
}
};
}
} |
def fix_predicate(predicate):
if '-' not in predicate:
predicate = lemmatize(predicate, 'v')
if get_pos_in_tree(CFGAnalyzer.PARSER.structure_tree, predicate) in ['IN', 'TO']:
predicate = 'be-' + predicate
elif predicate == '':
predicate = 'be'
if predicate == 'hat':
predicate = 'hate'
elif predicate == 'bear':
predicate = 'born'
return predicate |
Guyliner shares his top 10 gay dating tips to help you bag a great date.
No matter your gender or sexual orientation, dating can seem like a minefield. Sometimes we meet the wrong people, choose a bad venue or fall head over heels with someone who just wants to be friends. While the common dating ‘rules’ – not that I believe in rules – can apply to anybody, there are perhaps a few things we, as gay guys, need to pay a little more attention to.
Cast your net further afield
We can be a very picky bunch. We whinge that we can’t find the right man, or never get a second date, but the usual reason is we’re not looking hard enough in the first place. Whether we’re into bears, jocks or geeks, sometimes our narrow search criteria holds us back. Having fixed ideas of what you want – which usually boil down to looks and little else – could be standing in your way of meeting some great guys. It’s time to think outside the box, look past the beards or muscles, and take chances.
Be positive
Many guys are very clear in their dating profiles – almost rudely so – about what they don’t want or like. Not only is this far too prescriptive, you also run the risk of coming across as overly negative. Say what you like to do, who you want to be with, and why people should date you. A profile full of “not into” is off-putting.
Don’t fetishise
This is becoming a bigger issue in the gay dating world. All this liberation and equality is leading to increased bigotry among us. If you’re white, don’t say you’re “really into black guys”. What does that even mean? You’re objectifying a person with no thought for what else he might have to offer. You’re saying, “You tick a box, you’ll do” like they’re not a person, but a means to satisfy your kink. While you’re checking your racism, think about the way you talk to other guys who aren’t just like you. “Older men are really hot” is nowhere near as serious as racism, and it might seem like a compliment, but this guy doesn’t want to be defined by his age, any more than you’d expect someone to fancy you because of your postcode or shoe size. We’re reducing men to body parts and stats; we need to cut it out.
Avoid regular haunts
When you start dating, don’t go to places you bar-hopped during your bachelor days. You don’t really want to run into one of your old flames – or one of theirs – and it’s good to go somewhere fresh to you both, free of distractions or associations with other dates.
Forget their sexual past
Yes, plenty of us have been around a bit, but don’t let it play on your mind when on a date with a new guy. As far as you’re concerned, this is Day One – only wasteland came before it.
Don’t get hung up on tops and bottoms or everything in between
Yes, you know what you like, but if you’re looking for a relationship, it’s not just about what goes where and who’ll be standing on their head or whatever. If you like someone enough, open your mind to other possibilities. Don’t rule someone out just because you’re both bottoms, for example; nothing is set in stone.
Don’t dismiss guys you meet on an app
Not everyone on a hookup app is looking for sex and even if they are, who gives a toss? We are all grownups and it’s not how you met that’s important but the fact you did at all. Spare us your sanctimony, your grace.
If you just want sex, be upfront
Some guys are going on dates to meet the love of their lives, others aren’t quite sure what they’re looking for, while others are definitely after just one thing. This is fine – nothing wrong with a one-night-stand – as long as he realises that too. There’s nothing worse than a romantic evening followed by a great night in the hay, which leads to unanswered texts because you couldn’t admit you were only ever looking for a one-off. You might not care, but consider your date’s feelings too.
Get rejection right
Rejection can be a useful experience because it teaches you a bit about yourself and the guys you’re dating. Rejecting someone because of their appearance is only natural, but they don’t need to know that’s your reason. “There was no spark” usually suffices if you can’t think of anything more constructive, as people rarely questions it.
If you both feel a connection and want to have sex, go with the flow
We place a lot of importance, misguidedly I feel, on not having sex on the first date. Whether we’re reluctant to perpetuate the stereotype that gay men are promiscuous, or tell ourselves boys who give it up on the first date are less desirable, we certainly think too much about this one. The idea that men who put out aren’t good enough to take home to meet our mother is nonsense. If you feel it between you, then go for it. Sex alone won’t ruin everything, believe me, plenty of other things can go wrong.
The Guyliner has been writing about gay dating since 2010 and is also a columnist at Gay Times Magazine.
For more gay dating insight from The Guyliner visit his website and put his words into practice and meet someone new on our gay dating page. |
<filename>include/krypto/detail/basic_handle_base.hpp
// Copyright (c) 2021-present <NAME>
// All Rights Reserved
//
// Distributed under the "MIT License". See the accompanying LICENSE.rst file.
#pragma once
#include "../common.hpp"
#include "scope_file_descriptor.hpp"
namespace krypto {
namespace detail {
class basic_handle_base
{
public:
basic_handle_base() = default;
explicit basic_handle_base(SSL* ssl) : m_ssl{ssl} {}
protected:
/// prevent deleting object from this type
~basic_handle_base() = default;
bool m_state = false;
SSL *m_ssl = nullptr;
unique_socket m_socket;
};
} // namespace detail
} // namespace krypto |
// QueryUpWithdrawByID get up_income_withdraw by id
func (d *Dao) QueryUpWithdrawByID(c context.Context, id int64) (upWithdraw *model.UpIncomeWithdraw, err error) {
upWithdraw = &model.UpIncomeWithdraw{}
row := d.db.QueryRow(c, _queryUpWithdrawByID, id)
err = row.Scan(&upWithdraw.ID, &upWithdraw.MID, &upWithdraw.WithdrawIncome, &upWithdraw.DateVersion, &upWithdraw.State, &upWithdraw.CTime)
return
} |
/* Translate a faultcode_t as returned by some of the vm routines
* into a suitable errno value.
*/
static int
afs_fc2errno(faultcode_t fc)
{
switch (FC_CODE(fc)) {
case 0:
return 0;
case FC_OBJERR:
return FC_ERRNO(fc);
default:
return EIO;
}
} |
/**
* Specifies the fields by which to order the result set. For use in builder code.
* See {@link #orderBy(AliasedFieldBuilder...)} for the DSL version.
*
* @param orderFields the fields to order by
* @return this, for method chaining.
*/
public T orderBy(Iterable<? extends AliasedFieldBuilder> orderFields) {
if (orderFields == null) {
throw new IllegalArgumentException("Fields were null in order by clause");
}
if(AliasedField.immutableDslEnabled()) {
Iterables.addAll(orderBys, SqlInternalUtils.transformOrderByToAscending(Builder.Helper.buildAll(orderFields)));
} else {
Iterables.addAll(orderBys, Builder.Helper.buildAll(orderFields));
SqlInternalUtils.defaultOrderByToAscending(orderBys);
}
return castToChild(this);
} |
#!/usr/bin/env python
# Copyright 2019 The ANGLE Project Authors. All rights reserved.
# Use of this source code is governed by a BSD-style license that can be
# found in the LICENSE file.
# apply_clang_format_on_all_sources.py:
# Script to apply clang-format recursively on directory,
# example usage:
# ./scripts/apply_clang_format_on_all_sources.py src
from __future__ import print_function
import os
import sys
import platform
import subprocess
# inplace change and use style from .clang-format
CLANG_FORMAT_ARGS = ['-i', '-style=file']
def main(directory):
system = platform.system()
clang_format_exe = 'clang-format'
if system == 'Windows':
clang_format_exe += '.bat'
partial_cmd = [clang_format_exe] + CLANG_FORMAT_ARGS
for subdir, _, files in os.walk(directory):
if 'third_party' in subdir:
continue
for f in files:
if f.endswith(('.c', '.h', '.cpp', '.hpp')):
f_abspath = os.path.join(subdir, f)
print("Applying clang-format on ", f_abspath)
subprocess.check_call(partial_cmd + [f_abspath])
if __name__ == '__main__':
if len(sys.argv) > 2:
print('Too mang args', file=sys.stderr)
elif len(sys.argv) == 2:
main(os.path.join(os.getcwd(), sys.argv[1]))
else:
main(os.getcwd())
|
package txAnalyser
import (
"github.com/KuChainNetwork/kuchain/x/dex"
dexTypes "github.com/KuChainNetwork/kuchain/x/dex/types"
sdk "github.com/cosmos/cosmos-sdk/types"
"github.com/golang/glog"
abci "github.com/tendermint/tendermint/abci/types"
"gorm.io/gorm"
"kds/config"
"kds/util"
"kds/dbmodel"
)
const (
dexMsgTypeCreateDex = "create@dex"
dexMsgTypeUpdateDexDescription = "updatedesc@dex"
dexMsgTypeDestroyDex = "destroy@dex"
dexMsgTypeCreateSymbol = "create@symbol"
dexMsgTypeUpdateSymbol = "update@symbol"
dexMsgTypePauseSymbol = "pause@symbol"
dexMsgTypeRestoreSymbol = "restore@symbol"
dexMsgTypeShutdownSymbol = "shutdown@symbol"
dexMsgTypeSigIn = "sigin"
dexMsgTypeSigOut = "sigout"
dexMsgTypeDeal = "deal"
)
// onDexMessages 处理Dex消息
func (object *Analyser) onDexMessages(db *gorm.DB,
msg sdk.Msg,
txResult *abci.ResponseDeliverTx,
tx *dbmodel.TX) (err error) {
switch msg.Type() {
case dexMsgTypeCreateDex:
message := msg.(*dexTypes.MsgCreateDex)
var messageData dexTypes.MsgCreateDexData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
tx.To = dex.ModuleName
// only main token enable
tx.Amount = util.Coin2Decimal(messageData.Stakings[0], config.Exp).String()
tx.Denom = messageData.Stakings[0].Denom
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeUpdateDexDescription:
message := msg.(*dexTypes.MsgUpdateDexDescription)
var messageData dexTypes.MsgUpdateDexDescriptionData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeDestroyDex:
message := msg.(*dexTypes.MsgDestroyDex)
var messageData dexTypes.MsgDestroyDexData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeCreateSymbol:
message := msg.(*dexTypes.MsgCreateSymbol)
var messageData dexTypes.MsgCreateSymbolData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeUpdateSymbol:
message := msg.(*dexTypes.MsgUpdateSymbol)
var messageData dexTypes.MsgUpdateSymbolData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypePauseSymbol:
message := msg.(*dexTypes.MsgPauseSymbol)
var messageData dexTypes.MsgPauseSymbolData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeRestoreSymbol:
message := msg.(*dexTypes.MsgRestoreSymbol)
var messageData dexTypes.MsgRestoreSymbolData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeShutdownSymbol:
message := msg.(*dexTypes.MsgShutdownSymbol)
var messageData dexTypes.MsgShutdownSymbolData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
}
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeSigIn:
message := msg.(*dexTypes.MsgDexSigIn)
var messageData dexTypes.MsgDexSigInData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.Amount = util.Coin2Decimal(messageData.Amount[0], config.Exp).String()
tx.Denom = messageData.Amount[0].Denom
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeSigOut:
message := msg.(*dexTypes.MsgDexSigOut)
var messageData dexTypes.MsgDexSigOutData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
//TODO process amount
object.fillMessageAndMessageData(tx, message, messageData)
case dexMsgTypeDeal:
message := msg.(*dexTypes.MsgDexDeal)
var messageData dexTypes.MsgDexDealData
if messageData, err = message.GetData(); nil != err {
glog.Fatalln(err)
return
}
tx.From = messageData.Sender().String()
object.fillMessageAndMessageData(tx, message, messageData)
default:
glog.Fatalln("unknown msg type:", msg.Type())
}
return
}
|
/**
* Classify using the given {@link Classifier} and unlabled {@link Instances}.
*
* @param unlabeled unlabeled instanstance containing a {@link Instances#classIndex}
* @param classifier
* @return labeled instances leaving the original instanses unlabeled.
* @throws java.lang.Exception
*/
public Instances runClassifier(Instances unlabeled, Classifier classifier)
throws Exception {
Instances labeled = new Instances(unlabeled);
Integer idx = labeled.classIndex();
if (idx == -1) {
LOG.warn("classIndex not set. Using last attribute for class!");
labeled.setClassIndex(labeled.numAttributes() - 1);
idx = labeled.classIndex();
}
for (int i = 0; i < unlabeled.numInstances(); i++) {
if (i == idx) continue;
double clsLabel = classifier.classifyInstance(unlabeled.instance(i));
labeled.instance(i).setClassValue(clsLabel);
if (LOG.isDebugEnabled()) {
LOG.debug(String.format("%s -> %s", clsLabel, unlabeled.classAttribute().value((int) clsLabel)));
}
}
return labeled;
} |
Comparison of Vitamin D Serum Values between Rheumatoid Arthritis and Lupus Populations: An Observational Study
Background: In recent years, the role of Vitamin D (VitD), as an immunomedulator in autoimmune diseases, has been evaluated in basic science and practice. There is a considerable volume of data on the effect of VitD position in lupus and rheumatoid arthritis exacerbation. Objective: This study aims to compare VitD serum values in lupus (SLE) and Rheumatoid Arthritis (RA) in the geographical region of northeastern Iran. Methods: Lupus and RA Patients were selected with various disease activity levels. All the patients received an equal amount of VitD supplementation and were selected by the same inclusion and exclusion criteria. VitD serum values were measured by a commercial ELISA kit. Data were analyzed in SPSS-15. Results: A total of 148 SLE and 156 RA patients were studied. VitD serum levels were 66.54±41.2 nmol/l in the SLE group and 83.74±46.45 nmol/l in the RA group. Statistical analysis showed that VitD serum levels were lower in lupus patients than RA ones (p=0.006). Conclusion: Since VitD deficiency is very common in Iran, physiologic doses of VitD supplementation in patients lead to higher serum levels of VitD. Lower VitD values in lupus patients compared with RA ones may stem from intestinal malabsorption, higher doses of corticosteroid therapy, renal involvement and proteinuria, different polymorphisms of VitD receptors, and more sun protection strategies in lupus patients.
INTRODUCTION
Systemic Lupus Erythematosus (SLE) and Rheumatoid Arthritis (RA) are two important autoimmune diseases in which the immunomedulatory role of vitamin D (VitD) has been evaluated appropriately. However, there is still some debate about the immunomodulatory role, optimal dose, and type of VitD that should be prescribed.
VitD has been diagnosed in recent years more as a secosteroid than a mere vitamin. It contributes to the modulation of the immune response by inhibiting actions of innate and adaptive immune cells . There is some evidence that B cells are inactivated by binding VitD to VitD receptors (VDRs) on their surface . Furthermore, VitD inhibits autoantibody production Suppression of dendritic cell-related pathways leads to the inhibition of T cell activation . Additional VitD immunomodulatory activities is conducted by 1,25(OH)D . VitD inhibits B cell proliferation prior to acquiring immunoglobulin secreting capabilities. It also blocks differentiation of monocytes into dendritic cells (DC), decreases the production of IL-12, INF-γ, IL-2, and enhances IL-10 production . Other roles of VitD include increased monocyte-macrophage differentiation and control over macrophage responses .
Several studies have supported the fact that VitD deficiency acts not only as a predisposing factor for RA and SLE development but also as an enhancer of disease severity and activity . On the other hand, each disease course leads to VitD deficiency due to treatment strategies, malnutrition, sedentary life style, sun protection especially in SLE, and several other factors . This article compares 25(OH)D serum values in patients with SLE and RA in the same geographical area by an equal amount of VitD supplementation to demonstrate differences. The hypothesis is that VitD in SLE patients may be less than in RA patients. It is important to understand the difference between RA and SLE when there is an equal dose of VitD supplementation.
MATERIALS AND METHODS
This article is a retrospective analysis of two previous cross-sectional studies in which VitD serum values in RA patients, SLE patients, and healthy populations were studied. Both studies were conducted in Mashhad, Iran, located at 360.20° latitude and 59.35° east longitude over a solar year (2013). In the two previous articles, we had a total of 148 SLE and 156 RA patients (case and control, respectively) were studied.
Over six months, from April to September, it tends to be sunny and warm in the region, if not hot. In the following six months, i.e. from October to March, it tends to be usually cold and cloudy .
A total of 99 RA patients diagnosed with ACR criteria and 82 patients who fulfilled the American College of Rheumatology (ACR) criteria for lupus were included for both studies in the Rheumatic Diseases Research Center affiliated with Mashhad University of Medical Sciences (2014). In both studies, the exclusion criteria included systemic co-morbidities such as chronic kidney or liver disease, malnourishment, and malabsorption (serum albumin less than 2.2 mg/dl, cholesterol below 100 mg/dl, and BMI<18.5 kg/m 2 ). Smokers, pregnant women, postpartum and nursing mothers and individuals with BMI>30 kg/m 2 were also excluded (since there is a hypothesis stating that lower VitD in overweight people may simply be representative of a larger volume of distribution of this vitamin because of fat solubility of 25(OH)D ). Moreover, individuals with supra-physiologic doses (>800 U/day) or injectable proportion of VitD from six months prior to sampling or those under chronic anticonvulsive therapy were excluded.
Both groups of patients received 1000 to 1200 mg calcium and 800 U VitD in addition to 400 mg hydroxychloroquine. Other medications were analyzed in detail in each article .
VitD measurement was conducted by ELISA kit (Immundiagnostik AG, Bensheim, Germany) from the sera of participants.
Kolmogorov-Smirnov test was utilized to measure normality of data distribution. ANOVA test was used to calculate differences between VitD serum values in each group. Post-hoc analysis was used for further analysis. Advanced analysis was accomplished by linear regression model. As it was a retrospective research on previous complete data, there was no missing data.
RESULTS
A total of 82 patients (12 males, 70 females) were enrolled in the SLE group and 99 patients (11 males, 89 females) in the RA group. The average age was (29.96±11.47 yrs) in SLE and (43.44±14.31 yrs) in RA groups with a significant difference (p<0.0001). Gender distribution in the two groups was compared using chi-square test, which showed similar distribution (p=0.4). The mean duration of disease in SLE patients was 3(0.5-5.7 IQR) yrs. In RA group, disease duration was 5.9±5.6 yrs, which was significantly higher than in the SLE patients (t=0.03, Man-Whitney test).
VitD serum levels in SLE and RA groups were 66.54±41.2 nmol/l and 83.74±46.45 nmol/l, respectively. Kolmogorov-Smirnov test showed that VitD levels were not normally distributed in SLE group. Statistical analysis showed that VitD serum values were lower in SLE patients than RA ones (p=0.006, Man-Whitney test).
In this study, the values of vitD were fitted with explanatory variables (i.e., age, disease duration, RA and SLE patients) and modeled by multiple linear regression technique. The final analysis is displayed in Table 1. It shows that only lupus as a variable affects VitD serum values negatively, and age and disease duration have no statistically significant impact on VitD serum levels.
DISCUSSION
This study assessed serum values of VitD in SLE and RA patients in the northeast of Iran. We found lower plasma levels of VitD in SLE than RA under similar bio-geographical conditions, sex distribution, VitD and calcium supplementation, and the same inclusion and exclusion criteria. Regression analysis demonstrated that age did not affect VitD serum values in RA and SLE. Furthermore, regression analysis demonstrated that age and disease duration did not affect the difference in VitD serum values between RA and SLE. The mean±SD of VitD serum values in SLE patients was below optimal goal despite supplement therapy .
To describe the difference between RA and SLE patients, several facts are proposed. Given the important role of UVB damage in dermatological and systemic manifestations of lupus, sun protection is a rule in lupus which is considered as a risk factor for 25(OH)D deficiency .
Moreover, renal involvement in lupus may influence protein bindings for VitD and production of 1,25(OH)D. Increasing data has revealed that nephritis is a significant underlying risk factor for VitD deficiency in SLE .
Besides, the medication prescribed for the treatment of SLE may aggregate VitD deficiency . Compared with RA, chronic higher doses of glucocorticoid therapy in SLE decline intestinal absorption and accelerate the catabolism of VitD through increasing 24α-hydroxylase activity . Some research studies propose that the interaction between over-activation of the immune system related to T-regs in SLE can affect the activation of VitD .
Anti-VitD antibodies related to antiDNA have been evaluated in patients with SLE that may reduce VitD functions .
Finally, polymorphism of VDR genes could be a part of VitD imbalance in SLE and RA, as different polymorphisms have been reported in those diseases .
CONCLUSION
This study demonstrated that 25(OH)D serum values in SLE patients are significantly lower than RA patients with the same geographic location, VitD supplementation, and other risk factors. Therefore, VitD deficiency should be considered in SLE patients more profoundly. Further studies can determine whether this is a consequence of SLE or a basic difference in the pathogenesis of two diseases.
DISCLOSER
We certify that there is no actual or potential conflict of interest in relation to this article.
ETHICS APPROVAL AND CONSENT TO PARTICIPATE
Not applicable.
HUMAN AND ANIMAL RIGHTS
No animals/humans were used for studies that are the basis of this research.
CONSENT FOR PUBLICATION
Not applicable. |
<filename>katharsis-jpa/src/main/java/io/katharsis/jpa/JpaRepositoryFilter.java
package io.katharsis.jpa;
import java.io.Serializable;
import java.util.List;
import io.katharsis.jpa.query.JpaQuery;
import io.katharsis.jpa.query.JpaQueryExecutor;
import io.katharsis.jpa.query.Tuple;
import io.katharsis.queryspec.QuerySpec;
/**
* Can be registered with the JpaModule and gets notified about all kinds of repository events.
* The filter then has to possiblity to do all kinds of changes.
*/
public interface JpaRepositoryFilter {
/**
* Called when repository is created. Allows customizations and replacement.
*
* @param <T> repository class
* @param <I> identifier class
* @param repository to filter
* @return filtered repository
*
*/
<T, I extends Serializable> JpaEntityRepository<T, I> filterCreation(JpaEntityRepository<T, I> repository);
/**
* Called when repository is created. Allows customizations and replacement.
*
* @param <S> source repository class
* @param <I> source identifier class
* @param <T> target repository class
* @param <J> target identifier class
* @param repository to filter
* @return filtered repository
*/
<S, I extends Serializable, T, J extends Serializable> JpaRelationshipRepository<S, I, T, J> filterCreation(
JpaRelationshipRepository<S, I, T, J> repository);
/**
* Specifies whether any of the filter methods should be executed for the given resourceType.;
*
* @param resourceType to filter
* @return true if filter should be used for the given resouceType.
*/
boolean accept(Class<?> resourceType);
/**
* Allows to customize the querySpec before creating the query.
*
* @param repository where the query is executed
* @param querySpec to filter
* @return filtered querySpec
*/
QuerySpec filterQuerySpec(Object repository, QuerySpec querySpec);
/**
* Allows to customize the query.
*
* @param <T> repository class
* @param repository where the query is executed
* @param querySpec that is used to query
* @param query to filter
* @return filtered query
*/
<T> JpaQuery<T> filterQuery(Object repository, QuerySpec querySpec, JpaQuery<T> query);
/**
* Allows to customize the query executor.
*
* @param <T> repository class
* @param repository where the query is executed
* @param querySpec that is used to query
* @param executor to filter
* @return filtered executor
*/
<T> JpaQueryExecutor<T> filterExecutor(Object repository, QuerySpec querySpec, JpaQueryExecutor<T> executor);
/**
* Allows to filter tuples and return the filtered slistet.
*
* @param repository where the query is executed
* @param querySpec that is used to query
* @param tuples to filter
* @return filtered list of tuples
*/
List<Tuple> filterTuples(Object repository, QuerySpec querySpec, List<Tuple> tuples);
/**
* Allows to filter resources and return the filtered list.
*
* @param <T> repository class
* @param repository where the query is executed
* @param querySpec that is used to query
* @param resources to filter
* @return filtered list of resources
*/
<T> List<T> filterResults(Object repository, QuerySpec querySpec, List<T> resources);
}
|
def move(self, bots, events):
response = []
for bot in bots:
if not bot.alive:
bots.remove(bot)
response = self.respond(bots,events)
return response |
def parse_c_node(c_node, chars, translation, mapping, key, lines_cut_by_translation, add_three_dots):
if "cdl" not in c_node:
return
if c_node["type"] == "sentence":
if c_node["cdl"][0]["node"] != "d":
if c_node["cdl"][0]["node"] == "c":
lines_cut_by_translation.append(c_node["cdl"][0]["cdl"][0]["ref"])
else:
lines_cut_by_translation.append(c_node["cdl"][0]["ref"])
text = c_node["id"].split(".")[0]
if "label" not in c_node:
start = "all"
end = "all"
elif " - " in c_node["label"]:
labels = c_node["label"].split(" - ")
start = labels[0]
end = labels[1]
else:
start = c_node["label"]
end = start
key = (text, start, end)
for node in c_node["cdl"]:
if node["node"] == "d":
parse_d_node(node, mapping)
elif node["node"] == "c":
parse_c_node(node, chars, translation, mapping, key, lines_cut_by_translation, add_three_dots)
elif node["node"] == "l":
parse_l_node(node, chars, translation, key, add_three_dots)
elif node["node"] == "ll":
parse_l_node(node["choices"][0], chars, translation, key, add_three_dots)
else:
print(node)
raise Exception("We reached a node other than d / c / l / ll. We don't know how to parse it!") |
#ifndef _INITIAL_RAMDISK_HEADER_
#define _INITIAL_RAMDISK_HEADER_
#define RAMMAGIC 0x453ABCDF
/**
* The initial ramdisk header
* Starts with magic, ramdisk checksum and ramdisk size in bytes
*/
struct initial_ramdisk_header {
uint32_t ramdisk_magic;
uint8_t ramdisk_checksum[16];
uint32_t ramdisk_size;
} __attribute__((packed));
#endif
|
/**
* Converts partition info into a JSON object.
*
* @param partitionInfo partition descriptions
*/
private JsonNode json(List<PartitionInfo> partitionInfo) {
ObjectMapper mapper = new ObjectMapper();
ArrayNode partitions = mapper.createArrayNode();
partitionInfo.stream()
.forEach(info -> {
ObjectNode partition = mapper.createObjectNode();
ArrayNode members = partition.putArray("members");
info.members()
.stream()
.forEach(members::add);
partition.put("name", info.name())
.put("term", info.term())
.put("leader", info.leader());
partitions.add(partition);
});
return partitions;
} |
package cortex
import (
"context"
"testing"
"time"
"github.com/prometheus/client_golang/prometheus"
"github.com/stretchr/testify/require"
"github.com/weaveworks/common/server"
"github.com/cortexproject/cortex/pkg/util/services"
)
func TestServerStopViaContext(t *testing.T) {
// server registers some metrics to default registry
savedRegistry := prometheus.DefaultRegisterer
prometheus.DefaultRegisterer = prometheus.NewRegistry()
defer func() {
prometheus.DefaultRegisterer = savedRegistry
}()
serv, err := server.New(server.Config{})
require.NoError(t, err)
ctx, cancel := context.WithTimeout(context.Background(), 500*time.Millisecond)
defer cancel()
s := NewServerService(serv, func() []services.Service { return nil })
require.NoError(t, s.StartAsync(ctx))
// should terminate soon, since context has short timeout
require.NoError(t, s.AwaitTerminated(context.Background()))
}
func TestServerStopViaShutdown(t *testing.T) {
// server registers some metrics to default registry
savedRegistry := prometheus.DefaultRegisterer
prometheus.DefaultRegisterer = prometheus.NewRegistry()
defer func() {
prometheus.DefaultRegisterer = savedRegistry
}()
serv, err := server.New(server.Config{})
require.NoError(t, err)
s := NewServerService(serv, func() []services.Service { return nil })
require.NoError(t, services.StartAndAwaitRunning(context.Background(), s))
// we stop HTTP/gRPC Servers here... that should make server stop.
serv.Shutdown()
require.NoError(t, s.AwaitTerminated(context.Background()))
}
func TestServerStopViaStop(t *testing.T) {
// server registers some metrics to default registry
savedRegistry := prometheus.DefaultRegisterer
prometheus.DefaultRegisterer = prometheus.NewRegistry()
defer func() {
prometheus.DefaultRegisterer = savedRegistry
}()
serv, err := server.New(server.Config{})
require.NoError(t, err)
s := NewServerService(serv, func() []services.Service { return nil })
require.NoError(t, services.StartAndAwaitRunning(context.Background(), s))
serv.Stop()
require.NoError(t, s.AwaitTerminated(context.Background()))
}
|
<gh_stars>0
package dk.statsbiblioteket.doms.licensemodule.service.dto;
import java.util.ArrayList;
import javax.xml.bind.annotation.XmlRootElement;
@XmlRootElement
public class GetUserQueryOutputDTO {
private ArrayList<String> userLicenseGroups = new ArrayList<String>();
private ArrayList<String> userNotInMustGroups = new ArrayList<String>();
private String query;
public GetUserQueryOutputDTO(){
}
public ArrayList<String> getUserLicenseGroups() {
return userLicenseGroups;
}
public void setUserLicenseGroups(ArrayList<String> userLicenseGroups) {
this.userLicenseGroups = userLicenseGroups;
}
public ArrayList<String> getUserNotInMustGroups() {
return userNotInMustGroups;
}
public void setUserNotInMustGroups(ArrayList<String> userNotInMustGroups) {
this.userNotInMustGroups = userNotInMustGroups;
}
public String getQuery() {
return query;
}
public void setQuery(String query) {
this.query = query;
}
}
|
/*
* Method to return the publication back to the library.
*
* Args:
* int publicationID unique id of the publication.
*
* Returns:
* int client ID of the next client the waiting list that borrowed the publication.Return -1 if no client was waiting.
*/
@Override
public int returnItem(int publicationID) {
PublicationQueue pq = null;
pq = checkReturnList(books, publicationID,pq);
pq = checkReturnList(magazines, publicationID,pq);
pq = checkReturnList(bluerays, publicationID,pq);
pq = checkReturnList(cds, publicationID,pq);
if (pq == null) {
return -1;
}
Client nextClient = pq.returnPublication();
return nextClient == null?-1:nextClient.getId();
} |
By Barnett Wright
The Birmingham Times
Federal officials have launched an investigation into Jefferson County in connection with an alleged embezzlement scheme involving several hundred thousands of dollars, according to sources.
At least one Jefferson County employee has been fired after an internal investigation. The FBI has a criminal investigation underway and the amount involved ranges from $200,000 to $375,000, according to people familiar with the matter.
Jefferson County Manager Tony Petelos today declined to comment on the investigation.
“I am not able to comment on any investigation, we will always work with any agency with any investigation and take appropriate action,” Petelos said.
Efforts to reach the FBI for comment were unsuccessful.
Sources say the alleged scheme took place in the county’s information technology department and involved phones and tablets purchased with taxpayer dollars. However, the devices were not used by the county, sources say.
The investigation will likely expand to other individuals and/or entities who may have played a role in the alleged scheme, sources believe.
This post will be updated as additional information becomes available.
Share this: Print
Google
Facebook
Twitter
Pinterest
LinkedIn
Reddit
WhatsApp |
<reponame>Haz-git/Portfolio_v2
import React from 'react';
import styled from 'styled-components';
import { deviceMax, deviceMin } from '../../devices/breakpoints';
//Styles:
const ButtonContainer = styled.button<ButtonProps>`
display: flex;
align-items: center;
justify-content: space-evenly;
border: ${(props) =>
props.disabled
? '1px solid rgba(255,255,255,0.8)'
: '1px solid #fdbc3d'};
padding: 0.7em 1em;
outline: none;
color: ${(props) =>
props.disabled ? 'rgba(255,255,255,0.8)' : props.btnTextColor};
background: ${(props) =>
props.disabled ? '#1b222a' : props.btnBackground};
border-radius: 0.3em;
box-shadow: rgba(13, 56, 72, 0.3) 0px 4px 40px,
rgba(13, 56, 72, 0.22) 0px 4px 12px;
cursor: ${(props) => (props.disabled ? 'not-allowed' : 'pointer')};
transition: all 0.2s ease-in-out;
width: 100%;
&:hover {
transform: ${(props) => (props.disabled ? 'none' : 'scale(1.05)')};
}
@media ${deviceMin.mobileS} {
padding: 0.7em 0.9em;
}
@media ${deviceMin.mobileM} {
padding: 0.7em 1em;
}
@media ${deviceMin.mobileL} {
padding: 0.7em 1em;
}
`;
const ButtonText = styled.p`
font-family: 'Lato', sans-serif;
font-size: 1.5em;
font-weight: 700;
@media ${deviceMin.mobileS} {
font-size: 0.9rem;
}
@media ${deviceMin.mobileM} {
font-size: 1rem;
}
@media ${deviceMin.mobileL} {
font-size: 1.2rem;
}
`;
const IconContainer = styled.div`
margin-right: 0.5rem;
`;
//Interface:
interface ButtonProps {
label?: string;
isLink?: boolean;
onClick?: React.MouseEventHandler;
buttonIcon?: JSX.Element;
btnBackground?: string;
btnTextColor?: string;
isDisabled?: boolean;
onDisabledText?: string;
}
const Button = ({
label,
isLink,
onClick,
buttonIcon,
btnBackground,
btnTextColor,
isDisabled,
onDisabledText,
}: ButtonProps): JSX.Element => {
return (
<ButtonContainer
btnBackground={btnBackground}
btnTextColor={btnTextColor}
onClick={onClick}
disabled={isDisabled}
>
{buttonIcon && <IconContainer>{buttonIcon}</IconContainer>}
{isDisabled === false ? (
<ButtonText>{label}</ButtonText>
) : (
<ButtonText>{onDisabledText}</ButtonText>
)}
</ButtonContainer>
);
};
export default Button;
|
Woman Grows Beard for Movember
This application requires JavaScript.
Siobhain Fletcher is a 36-year-old English woman with polycystic ovary syndrome, a hormonal imbalance that causes her to grow facial hair. She’s also totally fierce. Despite the fact that hair on a woman’s face, with the exception of perfectly sculpted eyebrows, is totally taboo, Siobhain decided to grow her facial hair — for a very good cause.
When Siobhain learned about Movember from a male friend who was participating in the fundraising effort, she decided to use her condition to do some good. So, she set up a Movember fundraising page and grew a freakin’ beard for charity. Think about that next time you bail on an impromptu beach outing because you forgot to shave your legs.
“I pointed out that he had a bit of face fuzz, and asked about it. He told me about ‘Movember,’ and in a spur of the moment decision, I decided to grow mine,” Siobhain told ABC News. “It helps people get checked for prostate and testicular cancer, and hopefully people will, instead of going to a funeral, be going to a remission party.”
In an interview with the Daily Mirror, Siobhain explained that she hoped her willingness to risk embarrassment by sporting a beard would inspire men to risk the potential embarrassment of getting a prostate exam.
“If I can go out on the street with a beard or moustache for a month, then surely men who are experiencing health problems can go and get themselves tested,” she said.
Rock on, Siobhain. |
<reponame>hujunxianligong/snips-nlu
from __future__ import print_function, unicode_literals
import json
from builtins import bytes
from pathlib import Path
import plac
from snips_nlu import SnipsNLUEngine, load_resources
@plac.annotations(
dataset_path=("Path to the dataset file", "positional", None, str),
output_path=("Destination path for the json metrics", "positional", None,
str),
nb_folds=("Number of folds to use for the cross-validation", "option", "n",
int),
train_size_ratio=("Fraction of the data that we want to use for training "
"(between 0 and 1)", "option", "t", float),
exclude_slot_metrics=("Exclude slot metrics and slot errors in the output",
"flag", "s", bool),
include_errors=("Include parsing errors in the output", "flag", "i", bool))
def cross_val_metrics(dataset_path, output_path, nb_folds=5,
train_size_ratio=1.0, exclude_slot_metrics=False,
include_errors=False):
def progression_handler(progress):
print("%d%%" % int(progress * 100))
metrics_args = dict(
dataset=dataset_path,
engine_class=SnipsNLUEngine,
progression_handler=progression_handler,
nb_folds=nb_folds,
train_size_ratio=train_size_ratio,
include_slot_metrics=not exclude_slot_metrics,
)
with Path(dataset_path).open("r", encoding="utf-8") as f:
load_resources(json.load(f)["language"])
from snips_nlu_metrics import compute_cross_val_metrics
metrics = compute_cross_val_metrics(**metrics_args)
if not include_errors:
metrics.pop("parsing_errors")
with Path(output_path).open(mode="w") as f:
json_dump = json.dumps(metrics, sort_keys=True, indent=2)
f.write(bytes(json_dump, encoding="utf8").decode("utf8"))
@plac.annotations(
train_dataset_path=("Path to the dataset used for training", "positional",
None, str),
test_dataset_path=("Path to the dataset used for testing", "positional",
None, str),
output_path=("Destination path for the json metrics", "positional", None,
str),
exclude_slot_metrics=("Exclude slot metrics and slot errors in the output",
"flag", "s", bool),
include_errors=("Include parsing errors in the output", "flag", "i", bool))
def train_test_metrics(train_dataset_path, test_dataset_path, output_path,
exclude_slot_metrics=False, include_errors=False):
metrics_args = dict(
train_dataset=train_dataset_path,
test_dataset=test_dataset_path,
engine_class=SnipsNLUEngine,
include_slot_metrics=not exclude_slot_metrics
)
with Path(train_dataset_path).open("r", encoding="utf-8") as f:
load_resources(json.load(f)["language"])
from snips_nlu_metrics import compute_train_test_metrics
metrics = compute_train_test_metrics(**metrics_args)
if not include_errors:
metrics.pop("parsing_errors")
with Path(output_path).open(mode="w") as f:
json_dump = json.dumps(metrics, sort_keys=True, indent=2)
f.write(bytes(json_dump, encoding="utf8").decode("utf8"))
|
<filename>app/components/web/AboutDialog.tsx
import React from 'react';
import Button from '@material-ui/core/Button';
import Dialog from '@material-ui/core/Dialog';
import Link from '@material-ui/core/Link';
import Typography from '@material-ui/core/Typography';
import DialogActions from '@material-ui/core/DialogActions';
import DialogContent from '@material-ui/core/DialogContent';
import DialogContentText from '@material-ui/core/DialogContentText';
import DialogTitle from '@material-ui/core/DialogTitle';
import Divider from '@material-ui/core/Divider';
import GitHubIcon from '@material-ui/icons/GitHub';
import LinkedInIcon from '@material-ui/icons/LinkedIn';
type Props = {
open: boolean;
setOpen: React.Dispatch<React.SetStateAction<boolean>>
}
export default function AboutDialog(props: Props) {
const handleClose = () => {
props.setOpen(false);
};
return (
<Dialog
open={props.open}
onClose={handleClose}
aria-labelledby="alert-dialog-title"
aria-describedby="alert-dialog-description"
>
<DialogTitle id="alert-dialog-title">{"About"}</DialogTitle>
<DialogContent>
<DialogContentText id="alert-dialog-description">
Lodge-in search for nearby hotels on the map,
provide its details and booking options. The responsive user interface handles both wide and smaller screens
making it usable for both desktop and mobile based browsers.
</DialogContentText>
<DialogContentText>
Lodge-in is a prototype fullstack Javascript web-application build with Node, Express, React, Typescript and MongoDB.
The source code is available on <Link href={"https://github.com/m5khan/lodge-in"} target="_blank" rel="noopener">Github</Link>.
</DialogContentText>
<Divider />
<div style={{paddingTop: '15px'}}>
<Typography variant="caption" color="textPrimary" component="p">
<Link color="inherit" href={"https://github.com/m5khan"} target="_blank" rel="noopener"><GitHubIcon fontSize="large"></GitHubIcon></Link>
<Link color="inherit" style={{marginLeft: '15px'}} href={"https://www.linkedin.com/in/shoaib-khan-65839687/"} target="_blank" rel="noopener"><LinkedInIcon fontSize="large"></LinkedInIcon></Link>
</Typography>
</div>
</DialogContent>
<DialogActions>
<Button onClick={handleClose} color="primary">
Great!
</Button>
</DialogActions>
</Dialog>
);
}
|
/**
* Transforms Cargo request to Domestic Cargo obj.
*
* @param cargo request
* @return Domestic Cargo obj
*/
@Transformer(inputChannel = "cargoRouterDomesticOutputChannel",
outputChannel = "cargoTransformerOutputChannel")
public DomesticCargoMessage transformDomesticCargo(Cargo cargo) {
return new DomesticCargoMessage(cargo, Region.fromValue(cargo.getRegion()));
} |
def load_from_db(datasource, table, local_dir=os.getcwd()):
with tempfile.TemporaryDirectory() as tmp_dir:
tarball = os.path.join(tmp_dir, TARBALL_NAME)
gen = read_with_generator(datasource, table)
with open(tarball, "wb") as f:
for data in gen():
f.write(bytes(data))
return Model._unzip(local_dir, tarball) |
The Daily Beast has a lengthy piece on an incarcerated man who may be innocent. The man, Arizona Batiste, has been locked up for 21 years for the murder of Leonardo Alexander. Batiste says he shot Alexander, who had followed him into his home with a gun, in self-defense. But Batiste was scared, he says, of what he had done and went into flight mode. He dragged Alexander out of the house and into a field behind the home. Batiste says he took Alexander’s gun and his own and passed them on to someone else to get rid of them. Here’s where things begin to go awry.
One gun is discarded (Alexander’s) and one gun ends up being held onto (Batiste’s). Batiste turns himself in the next morning and takes them to the person he gave the guns to. Only Batiste’s is found. The gun belonging to Alexander had been thrown into a lake. The sheriffs actually found Alexander’s gun, but they never told anyone about it, and Batiste’s claim of self-defense doesn't work—sorta. The jury voted 10-2 for conviction. In Louisiana, that doesn’t equal mistrial, it equals guilty.
This story would be fascinating if it wasn’t so tragic, so true, and so commonly replicated in other cities and towns across the country. Charges of conflict of interest (one of the first officers to the scene was related to the victims) and the withholding of evidence by the prosecution are also prominent features of this story. But what is probably the most outrageous part comes once Batiste gets a new lawyer to look into the case and they are made aware of the existence of the deceased’s gun: |
<gh_stars>100-1000
def ifs1(x):
a = 1
if 0 < x < 10:
a = 2
else:
a = 3
return a
def ifs2(x):
a = 1
if 0 == x != 10:
a = 2
else:
a = 3
return a
def ifs3(x):
a = 1
if 0 in x in [[0]]:
a = 2
else:
a = 3
return a
print('ifs1')
print(ifs1(-1))
print(ifs1(1))
print(ifs1(11))
print('ifs2')
print(ifs2(0))
print(ifs2(10))
print('ifs3')
print(ifs3([0]))
print(ifs3([1]))
|
/**
* @author Heiko Braun
* @since 15/09/16
*/
public class Parser {
private final Logger log = Logger.getLogger(Parser.class.getName());
private final AtomicInteger id = new AtomicInteger(0);
public BootstrapData parse(final URL jsonResource) {
try {
final JsonReaderFactory factory = Json.createReaderFactory(null);
final JsonReader reader = factory.createReader(jsonResource.openStream());
final JsonObject root = reader.readObject();
final JsonObject sectionList = (JsonObject) ((JsonArray) root.get("sectionList")).get(0);
final JsonArray items = (JsonArray) sectionList.get("items");
// parse session objects
final List<Session> sessions = new LinkedList<>();
for (final JsonValue item : items) {
final Session session = new Session((JsonObject) item);
session.setId(String.valueOf(this.id.incrementAndGet()));
sessions.add(session);
}
// parse and link speakers and schedules
final List<Speaker> speakers = new LinkedList<>();
final List<Schedule> schedules = new LinkedList<>();
for (final Session session : sessions) {
// speakers
final JsonArray participants = session.getUnderlying().getJsonArray("participants");
final Collection<Speaker> assignedSpeakers = participants.stream()
.map(item -> new Speaker((JsonObject) item))
.collect(Collectors.toCollection(HashSet<Speaker>::new));
assignedSpeakers.forEach(a -> {
boolean exists = false;
for (final Speaker s : speakers) {
if (s.getFullName().toLowerCase().equals(a.getFullName().toLowerCase())) {
a.setId(s.getId());
exists = true;
break;
}
}
if (!exists) {
a.setId(String.valueOf(this.id.incrementAndGet()));
speakers.add(a);
}
});
final HashSet<String> ids = assignedSpeakers.stream()
.map(JsonWrapper::getId)
.collect(Collectors.toCollection(HashSet::new));
session.setSpeakers(ids);
// schedules
final JsonObject times = session.getUnderlying().getJsonArray("times").getJsonObject(0);
final Schedule schedule = new Schedule(times);
schedule.setId(String.valueOf(this.id.incrementAndGet()));
schedules.add(schedule);
schedule.setSessionId(session.getId());
session.setSchedule(schedule.getId());
}
reader.close();
return new BootstrapData(sessions, speakers, schedules);
} catch (final IOException e) {
throw new RuntimeException("Failed to parse 'schedule.json'", e);
}
}
} |
<filename>packages/cubejs-query-orchestrator/src/orchestrator/StreamObjectsCounter.ts
import stream, { TransformCallback } from 'stream';
import { displayCLIWarning } from '@cubejs-backend/shared';
const THREASHOLD_LIMIT = 100_000;
export class LargeStreamWarning extends stream.Transform {
public constructor(preAggregationName: string) {
let count = 0;
super({
objectMode: true,
transform(row: any, encoding: BufferEncoding, callback: TransformCallback) {
count++;
if (count === THREASHOLD_LIMIT) {
displayCLIWarning(
`The pre-aggregation "${preAggregationName}" has more then ${THREASHOLD_LIMIT} rows. Consider exporting this pre-aggregation.`
);
}
this.push(row);
callback();
}
});
}
}
|
/**
* Add a new Referenced Component
* @param component The Component to reference
*/
public void addRef(LD_Component component) {
String elementName = getElementRefName(component);
if(elementName != null) {
addRef(component, getElement(), elementName, LD_Core.REF);
}
} |
/**
* Checks the expiry of the token for the given type of token access or jwt.
* @param type
* @param accessToken
* @return
* @throws ConnectorSDKException
*/
public static boolean isTokenValid(ConnectorSDKUtil.TOKEN_TYPE type, String accessToken) throws ConnectorSDKException{
boolean isValid;
Base64.Decoder base64Decoder = Base64.getDecoder();
try {
String[] parts = accessToken.split("\\.");
String tokenBody = new String(base64Decoder.decode(parts[1].getBytes(Charset.forName(SDKConstants.ENCODING_UTF8))),
Charset.forName(SDKConstants.ENCODING_UTF8));
JSONObject tokenBodyJson = (JSONObject) (new JSONParser().parse(tokenBody));
Date dateOfExpiry = new Date();
if(type.equals(ConnectorSDKUtil.TOKEN_TYPE.ACCESS_TOKEN)) {
String createdAt = (String) tokenBodyJson.get("created_at");
String expiresIn = (String) tokenBodyJson.get("expires_in");
Long createdAtTime = Long.parseLong(createdAt);
Long expiresInTime = Long.parseLong(expiresIn);
Long expiryTime = createdAtTime + expiresInTime;
dateOfExpiry = new Date(expiryTime);
} else {
Long expiresIn = (Long)tokenBodyJson.get("exp");
dateOfExpiry = new Date(expiresIn * 1000);
}
Date currentTimeWithAdditionalHr = new Date(new Date().getTime() + HR_IN_MS);
if(currentTimeWithAdditionalHr.before(dateOfExpiry)){
isValid = true;
} else {
logger.log(Level.WARNING, type.name() + ": is either expired or about to expire.");
isValid = false;
}
}catch (Exception ex){
logger.log(Level.SEVERE, "Error in parsing token :" + ex.getMessage());
throw new ConnectorSDKException(ex.getMessage(), ex.getCause());
}
return isValid;
} |
/**
* Generates an BPEL Invoke Element as String.
*
* @param invokeName the name attribute of the Invoke Element
* @param partnerLinkName the partnerLink attribute of the invoke
* @param operationName the name of the operation used on the given porttype
* @param portType the porttype to call on
* @param inputVarName the input variable name
* @param outputVarName the output variable name
* @return BPEL Invoke Element as String
*/
public String generateInvokeAsString(final String invokeName, final String partnerLinkName,
final String operationName, final QName portType, final String inputVarName,
final String outputVarName) {
final String invokeAsString =
"<bpel:invoke xmlns:bpel=\"http://docs.oasis-open.org/wsbpel/2.0/process/executable\" name=\"" + invokeName
+ "\" partnerLink=\"" + partnerLinkName + "\" operation=\"" + operationName + "\"" + " portType=\""
+ portType.getPrefix() + ":" + portType.getLocalPart() + "\"" + " inputVariable=\"" + inputVarName
+ "\"" + " outputVariable=\"" + outputVarName + "\"></bpel:invoke>";
return invokeAsString;
} |
def train_model(batch_size=128, nb_epoch=100, save_ext='_100epochs_lr005', weights_file=None):
print('loading training data...')
X_train, y_train, w_train = load_training_data('../Data/trainDataNormalized.npz')
print('training data size:')
print(X_train.shape)
p = np.random.permutation(X_train.shape[0])
X_train = X_train[p, :, :]
y_train = y_train[p]
w_train = w_train[p]
X_train = X_train.astype('float32')
X_train = np.expand_dims(X_train, 3)
img_rows = X_train.shape[1]
img_cols = X_train.shape[2]
model = build_model(img_rows, img_cols)
if weights_file is not None:
model.load_weights(weights_file)
sgd = SGD(lr=0.05, decay=1e-4, momentum=0.9, nesterov=True)
model.compile(loss='binary_crossentropy', optimizer=sgd)
print('train model...')
model.fit(X_train, y_train, batch_size=batch_size, epochs=nb_epoch, shuffle=True,
verbose=1, validation_split=0.1, sample_weight=w_train, callbacks=[])
print('load test data...')
X_test, y_test, w_test = load_test_data('../Data/testDataNormalized.npz')
X_test = X_test.astype('float32')
X_test = np.expand_dims(X_test, 3)
print('predict test data...')
preds = model.predict(X_test, batch_size=1, verbose=1)
print('saving results...')
np.save('../Data/predsTestTracks' + save_ext + '.npy', preds)
score = model.evaluate(X_test, y_test, verbose=1)
print('Test score:', score)
model.save_weights('../Data/model_weights' + save_ext + '.h5', overwrite=True) |
<reponame>pvv-boss/ekoset-pvv
import {BaseEntity,Column,Entity,Index,JoinColumn,JoinTable,ManyToMany,ManyToOne,OneToMany,OneToOne,PrimaryColumn,PrimaryGeneratedColumn,RelationId} from "typeorm";
import {AppUser} from "./AppUser";
@Entity("app_user_session",{schema:"brc_ekoset" } )
@Index("relationship_1_fk",["appUser",])
@Index("ind_user_session_token",["userSessionToken",])
export class AppUserSession {
@PrimaryGeneratedColumn({
type:"integer",
name:"user_session_id"
})
userSessionId:number;
@ManyToOne(type=>AppUser, app_user=>app_user.appUserSessions,{ nullable:false,onDelete: 'CASCADE',onUpdate: 'RESTRICT' })
@JoinColumn({ name:'app_user_id'})
appUser:Promise<AppUser | null>;
@RelationId((app_user_session: AppUserSession) => app_user_session.appUser)
appUserId: Promise<number[]>;
@Column("timestamp with time zone",{
nullable:false,
name:"user_session_created_at"
})
userSessionCreatedAt:Date;
@Column("timestamp with time zone",{
nullable:true,
name:"user_session_updated_at"
})
userSessionUpdatedAt:Date | null;
@Column("timestamp with time zone",{
nullable:true,
name:"user_session_expired_at"
})
userSessionExpiredAt:Date | null;
@Column("cidr",{
nullable:true,
name:"user_session_ip"
})
userSessionIp:string | null;
@Column("text",{
nullable:true,
name:"user_session_os"
})
userSessionOs:string | null;
@Column("text",{
nullable:true,
name:"user_session_browser"
})
userSessionBrowser:string | null;
@Column("text",{
nullable:true,
name:"user_session_agent"
})
userSessionAgent:string | null;
@Column("character varying",{
nullable:true,
length:36,
name:"user_session_token"
})
userSessionToken:string | null;
@Column("integer",{
nullable:true,
name:"user_session_block_ind"
})
userSessionBlockInd:number | null;
}
|
<reponame>davenquinn/Attitude<filename>attitude/display/plot/cov_types/__init__.py<gh_stars>1-10
from .regressions import hyperbola, bootstrap_noise
from .misc import augment, ci
|
THE WEALTH OF THE COMMONS:
A World Beyond Market and State
Edited by _David Bollier_ and _Silke Helfrich_
The Commons Strategies Group
© David Bollier, Silke Helfrich and Heinrich Böll Foundation, 2012.
Levellers Press
www.levellerspress.com
71 South Pleasant Street
Amherst, MA 01002
All works in this volume except for those previously published and copyrighted (as noted at the end of such chapters) are available under a Creative Commons Attribution-ShareAlike 3.0 License. (See https://creativecommons.org/licenses/by-sa/3.0/deed.) More information can be found at www.wealthofthecommons.org.
Peter Linebaugh, "Enclosures from the Bottom Up," in _Radical History Review,_ Volume 108, pp. 11–27. Copyright, 2010, MARHO: The Radical Historians Organization, Inc. All rights reserved. Reprinted by permission of the publisher, Duke University Press. www.dukeupress.edu.
A German-language version of this book, with minor differences, is available from transcript publisher of Bielefeld, Germany, under the title, _Commons: Für eine neue Politik jenseits von Markt und Staat_ , Silke Helfrich und Heinrich-Böll-Stiftung (Hg.) http://www.transcript-verlag.de/ts2036/ts2036.php.
Library of Congress Cataloging-in-Publication Data
_The Wealth of the Commons: A World Beyond Market and State_
Edited by David Bollier and Silke Helfrich
isbn 978-1-937146-14-6
Table of Contents
Acknowledgments
Introduction
PART ONE
My Rocky Road to the Commons
The Economy of Wastefulness: The Biology of the Commons
We Are Not Born as Egoists
Resilience Thinking
Institutions and Trust in Commons: Dealing with Social Dilemmas
The Structural Communality of the Commons
The Logic of the Commons & the Market A Shorthand Comparsion of Their Core Beliefs
First Thoughts for a Phenomenology of the Commons
Feminism and the Politics of the Commons
Rethinking the Social Welfare State in Light of the Commons
Common Goods Don't Simply Exist – They Are Created1
The Tragedy of the Anticommons
Why Distinguish Common Goods from Public Goods?
Subsistence: Perspective for a Society Based on Commons
Technology and the Commons
The Commoning of Patterns and the Patterns of Commoning: A Short Sketch
The Abundance of the Commons?
PART TWO
Enclosures from the Bottom Up
The Commons – A Historical Concept of Property Rights
The Global Land Grab: The New Enclosures
Genetically Engineered Promises & Farming Realities
The Intensifying Financial Enclosure of the Commons
Mining as a Threat to the Commons: The Case of South America
Water as a Commons: Only Fundamental Change Can Save Us
Dam Building: Who's "Backward" – Subsistence Cultures or Modern "Development"?
Belo Monte, or the Destruction of the Commons
Subtle But Effective: Modern Forms of Enclosures
Good Bye Night Sky
Crises, Capital and Co-optation: Does Capital Need a Commons Fix?
Hope from the Margins
A New German Raw Materials Strategy: A Modern "Enclosure Of The Commons"?
Using "Protected Natural Areas" to Appropriate the Commons
Intellectual Property Rights and Free Trade Agreements: A Never-Ending Story
Global Enclosures in the Service of Empire
PART THREE
School of Commoning
Practicing Commons in Community Gardens: Urban Gardening as a Corrective for Homo Economicus
Mundraub.org: Sharing Our Common Fruit
Living In "The Garden Of Life"
Reclaiming the Credit Commons:Towards a Butterfly Society
Shared Space: A Space Shared is a Space Doubled
Transition Towns: Initiatives of Transformation
Learning from Minamata: Creating High-Level Well-Being in Local Communities in Japan
Share or Die – A Challenge for Our Times
The Faxinal: A Brazilian Experience with the Commons and Its Relationship with the State
Capable Leadership, Institutional Skills and Resource Abundance Behind Flourishing Coastal Marine Commons in Chile1
Community Based Forest and Livelihood Management in Nepal
Introduction: An Encounter at the Pink Lake
Salt and Trade at the Pink Lake: Community Subsistence in Senegal
El Buen Vivir and the Commons
PART FOUR
The Code is the Seed of the Software
The Boom of Commons-Based Peer Production
Copyright and Fairy Tales
Creative Commons: Governing the Intellectual Commons from Below
Freedom for Users, Not for Software
Public Administration Needs Free Software
From Blue Collar to Open Commons Region: How Linz, Austria, Benefited from Committing to the Commons
Emancipating Innovation Enclosures: The Global Innovation Commons
Move Commons: Labeling, Opening and Connecting Social Initiatives
Peer-to-Peer Economy and New Civilization Centered Around the Sustenance of the Commons
Knowledge is the Water of the Mind: How to Structure Rights in "Immaterial Commons"
PART FIVE
Green Governance: Ecological Survival,
Human Rights and the Law of the Commons
The Common Heritage of Mankind:A Bold Doctrine Kept Within Strict Boundaries
Ideas for Change: Making Meaning Out of Economic and Institutional Diversity
Constructing Commons in the Cultural Environment
The Triune Peer Governance of the Digital Commons
Multilevel Governance and Cross-Scale Coordination for Natural Resource Management: Lessons from Current Research
The Atmosphere as a Global Commons
Transforming Global Resources into Commons
Electricity Commons – Toward a New Industrial Society1
The Failure of Land Privatization: On the Need for New Development Policies
The Yasuní ITT Initiative, or The Complex Construction of Utopia
Equitable Licensing – Ensuring Access to Innovation
P2P-Urbanism: Backed by Evidence
Epilogue
# Acknowledgments
This book has been an extended global exercise in commoning – a collective venture of sharing, collaboration, negotiation and creative production among some of the most diverse commons scholars, activists and projects leaders imaginable. It is as if many, many different streams and rivers from all kinds of landscapes had come together into a mighty new torrent. That, at least, is what the experience of editing this rich, kalaidoscope of a book has been for us. It has been a joy to engage with the 90 contributors to this volume; a privilege to learn about their fascinating projects and absorb their reportage and analyses; and a challenge to assemble this book so that it would be rigorous enough for academic readers yet accessible enough for the layperson.
Our first thanks, then, goes to the contributors who took the time to share their experiences and thinking about the commons. We hope that their essays, as now assembled in one volume, will begin to open up new conversations that might not otherwise occur. Many of them were brought to wider attention at the landmark International Commons Conference in Berlin in November 2010. In many respects, this book is a continuation of the cross-discplinary, transnational, heart-to-heart dialogues that began there.
The Heinrich Böll Foundation has been an indispensable partner in the conception and development of this book over the past two years. We wish to thank Barbara Unmüßig, President of the Foundation, for her unflagging support – indeed, her demand – for a book that would probe more deeply into the world that exists beyond market and state. Heike Löschmann, the head of Department of International Politics at the Böll Foundation, was also a vital force in thinking through the themes of the book, developing its framework and pushing the project forward. Our partner at the Commons Strategies Group, Michel Bauwens, provided important insights and encouragement to us on numerous occasions.
_The Wealth of the Commons_ benefited greatly from the parallel preparation of a German edition of this book, edited by Silke Helfrich and the Böll Foundation. The preparation of that volume helped bring the English edition into focus, and many essays written for the German edition were the basis for English translations for this volume. We are especially grateful to Sandra Lustig and Charles Roberts for their conscientious translations of many essays over the course of months, and their struggle to find just the right words for ideas that are sometimes quite difficult to translate.
A huge thank you to the many people at the Böll Foundation who helped in the preparation of either the German or English edition, or both. These people include Simone Zühr, Joanna Barelkowska and editor Bernd Rheinberg as well as friends and colleagues Brigitte Kratzwald, Katharina Frosch, Thomas Pfeiffer, Martin Siefkes, Andreas Weber, Jacques Paysan, Stefan Meretz and Stefan Tuschen.
Publishing this unusual book required that we find an unusual publisher, one that could understand the significance of the commons and entertain imaginative publishing strategies. We found that publisher in Levellers Press of Amherst, Massachusetts, and are grateful to Levellers' director Steve Strimer for his innovative approach to book publishing.
David Bollier wishes to thank Ellen Bollier for her abiding love and support during the rigors of yet another book project. Silke Helfrich is grateful to her family, especially her kids for the enthusiasm and patience they show toward her endeavors.
We noted earlier that the preparation of this book was an exercise in commoning. Our immodest hope is that _The Wealth of the Commons_ will be but a simple foretaste of an outrageous banquet of commoning that lies ahead.
_David Bollier_
_Amherst_ _, Massachusetts USA_ __
&
_Silke Helfrich_
_Jena_ _, Thüringen Germany_
_Commons Strategies Group_
_May 1, 2012_
# Introduction
**The Commons as a Transformative Vision**
_By David Bollier and Silke Helfrich_
_Commons Strategies Group_
It has become increasingly clear that we are poised between an old world that no longer works and a new one struggling to be born. Surrounded by an archaic order of centralized hierarchies on the one hand and predatory markets on the other, presided over by a state committed to planet-destroying economic growth, people around the world are searching for alternatives. That is the message of various social conflicts all over the world – of the Spanish Indignados and the Occupy movement, and of countless social innovators on the Internet. People want to emancipate themselves not just from poverty and shrinking opportunities, but from governance systems that do not allow them meaningful voice and responsibility. This book is about how we can find the new paths to navigate this transition. It is about our future.
But since there is no path forward, we must make the path. This book therefore is about some of the most promising new paths now being developed. Its seventy-three essays describe the enormous potential of the commons in conceptualizing and building a better future. The pieces, written by authors from thirty countries, fall into three general categories – those that offer a penetrating critique of the existing, increasingly dysfunctional market/state partnership; those that enlarge our theoretical understandings of the commons as a way to change the world; and those that describe innovative working projects that are demonstrating the feasibility and appeal of the commons.
This book begins by offering a number of theoretical analyses of the importance of the commons to the contemporary political economy. Part I includes essays that explore, for example, the "tragedy of the anticommons" dynamic in which excessive, fragmented property rights impede innovation and cooperation; the important differences between "common goods" and "public goods"; and the ways in which the commons challenges some elemental principles of modernity, liberalism and law. New thinking in theoretical biology suggests that the methodology of nature itself favors the commons as a stable, self-sustaining paradigm. The commons, then, is a paradigm that embodies its own logic and patterns of behavior, functioning as a different kind of operating system for society. While many of its dynamics are still hidden to minds steeped in market culture, learning about particular commons can help us recognize the commons as a useful, general paradigm.
The essays of Part II focus on the commodification and privatization of shared resources – the enclosure of the commons – one of the great, untold stories of our time. Enclosures are dispossessing tens of millions of farmers and pastoralists whose lives depend upon customary land commons in Africa, Asia and Latin America. They are disenfranchising urban dwellers whose parks and public spaces are being turned into private, commercial developments; and Internet users who are beset by new copyright laws, digital encryption and international treaties that lock up culture; as well as ordinary citizens whose access to credit is limited by private banks.
Happily, as we see in Parts III and IV, a rich explosion of commons-based experimentation and innovation can be seen around the world. Commons-based models of provisioning represent the building blocks for a new sort of economy, a Commons Sector. Such models can be seen in "collaborative consumption" systems for swaps, barter and sharing; Chilean fishing commons that have stabilized declining Pacific fisheries; fruit-picking commons in Germany that allow people to pick from local fruit trees that have been abandoned; and an ingenious scheme to establish a new type of international trust to save a biodiverse-rich region of Ecuador from oil drilling.
Some of the most recent and exciting commons-based innovations are related to the digital world, as we see in Part IV. Among the examples examined here are the rise of Creative Commons licenses throughout the world; the creation of a regional digital commons in Linz, Austria, designed to reinvigorate its local economy and civic life; and the peer-to-peer economy's powerful role in reinventing societal institutions.
Part V explores how the viability of bottom-up commons often depends upon supportive institutions, policy regimes and law. This is the new frontier for the Commons Sector: developing new bodies of law and policy to facilitate the practices of commoning on the ground. For this, the state must play a more active role in sanctioning and facilitating the functioning of commons, much as it currently sanctions and facilitates the functioning of corporations. And commoners must assert their interests in politics and public policy to make the commons the focus of innovations in law.
There is a simple, practical reason for developing new types of law and policy to support the commons. As the dysfunctionalities of the state become more evident – as seen in its inability to solve the financial crisis or curb ecological destruction – the state has an affirmative interest in helping commons perform tasks that it cannot perform itself. It is important that the state begin to recognize the varieties of collective property regimes (an indigenous landscape, a local agricultural system, an online community) and empower people to be co-proprietarians and co-stewards of their commons as a matter of law.
This book does not attempt to present a "unitary perspective on the commons," which would be oxymoronic in any case, but rather to offer the rich kaleidoscope of perspectives that we have come to expect of the commons. As the reader will soon realize, the commons can be seen as an intellectual framework and political philosophy; it can be seen as a set of social attitudes and commitments; it can be seen as an experiential way of being and even a spiritual disposition; it can be seen as an overarching worldview. But the truth of the matter is that the commons consists of _all_ of the above. It offers a fresh vocabulary and logic for escaping the deadend of market-fundamentalist politics, policy and economics and cultivating more humane alternatives.
It bears noting that this book is neither a how-to manual nor an encyclopedia. It is a selective survey of some of the more prominent vectors of thought and activism around the commons at this point in history. Necessarily, some perspectives and topics are missing. This volume does not address, for example, the role of arts and the commons, enclosures of outer space and broadcast media, organized labor and the commons, or the impact of technologies such as nanotechnology and geo-engineering. That said, the great virtue of the commons framework is its ability to make sense of new phenomena. Once you have learned to see the world through the lens of the commons, you will naturally apply that perspective to your own encounters with topics we could barely address.
**Beyond the market and state**
For generations, the state and market have developed a close, symbiotic relationship, to the extent of forging what might be called the market/state duopoly. Both are deeply committed to a shared vision of technological progress and market competition, enframed in a liberal, nominally democratic polity that revolves around individual freedom and rights. Market and state collaborate intimately and together have constructed an integrated worldview – a political philosophy and cultural epistemology, in fact – with each playing complementary roles to enact their shared utopian ideals of endless growth and consumer satisfaction.
The market uses the price system and its private management of people, capital and resources to generate material wealth. And the state represents the will of the people while facilitating the fair functioning of the "free market." Or so goes the grand narrative. This ideal of "democratic capitalism" is said to maximize the well-being of consumers while enlarging individual political and economic freedoms. This, truly, is the essence of the modern creed of "progress."
Historically, the market/state partnership has been a fruitful one for both. Markets have prospered from the state's provisioning of infrastructure and oversight of investment and market activity. Markets have also benefited from the state's providing of free and discounted access to public forests, minerals, airwaves, research and other public resources. For its part, the state, as designed today, depends upon market growth as a vital source of tax revenue and jobs for people – and as a way to avoid dealing with inequalities of wealth and social opportunity, two politically explosive challenges.
The financial meltdown of 2007–2008 revealed that the textbook idealization of democratic capitalism is largely a sham. The "free market" is not in fact self-regulating and private, but extensively dependent upon public interventions, subsidies, risk-mitigation and legal privileges. The state does not in fact represent the sovereign will of the people, nor does the market enact the autonomous preferences of small investors and consumers. Rather, the system is a more or less closed oligopoly of elite insiders. The political and personal connections between the largest corporations and government are so extensive as to amount to collusion. Transparency is minimal, regulation is corrupted by industry interests, accountability is a politically manipulated show, and the self-determination of the citizenry is mostly confined to choosing between Tweedledum and Tweedledee at election time.
The state in many countries amounts to a partner of clans, mafia-like-structures or dominant ethnicities; in other countries it amounts to a junior partner of the market fundamentalist project. It is charged with advancing privatization, deregulation, budget cutbacks, expansive private property rights and unfettered capital investment. The state provides a useful fig leaf of legitimacy and due process for the market's agenda, but there is little doubt that private capital has overwhelmed democratic, non-market interests except at the margins. State intervention to curb market excesses is generally ineffective and palliative. It doesn't touch the underlying problem, moreover; it acts instead to legitimize the procedures and principles of the market. In consequence, market forces dominate most agendas. In the U.S., corporations have even been recognized as legal "persons" entitled to give unlimited amounts of money to political candidates.
The presumption that the state can and will intervene to represent the interests of citizens is no longer credible. Unable to govern for the long term, captured by commercial interests and hobbled by stodgy bureaucratic structures in an age of nimble electronic networks, the state is arguably incapable of meeting the needs of citizens as a whole. The inescapable conclusion is that the mechanisms and processes of representative democracy are no longer a credible vehicle for the change we need. Conventional political discourse, itself an aging artifact of another era, is incapable of naming our problems, imagining alternatives and reforming itself.
This, truly, is why the commons has such a potentially transformative role to play. It is a discourse that transcends and remakes the categories of the prevailing political and economic order. It provides us with a new socially constructed order of experience, an elemental political worldview and a persuasive grand narrative. The commons identifies the relationships that should matter and sets forth a different operational logic. It validates new schemes of human relations, production and governance – one might call it "commonance," or the governance of the commons.
The commons provides us with the ability to name and then help constitute a new order. We need a new language that does not insidiously replicate the misleading fictions of the old order – for example, that market growth will eventually solve our social ills or that regulation will curb the world's proliferating ecological harms. We need a new discourse and new social practices that assert a new grand narrative, a different constellation of operating principles and a more effective order of governance. Seeking a discourse of this sort is not a fanciful whim. It is an absolute necessity. And, in fact, there is no other way to bring about a new order. Words actually shape the world. By using a new language, the language of the commons, we immediately begin to create a new culture. We can assert a new order of resource stewardship, right livelihood, social priorities and collective enterprise.
**The transformational language of the commons**
This new language situates us as interactive agents of larger collectivities. Our participation in these larger wholes (local communities, online affinity groups, intergenerational traditions) does not eradicate our individuality, but it certainly shapes our preferences, outlooks, values and behaviors: who we are. A key revelation of the commons way of thinking is that we humans are not in fact isolated, atomistic individuals. We are not amoebas with no human agency except hedonistic "utility preferences" expressed in the marketplace.
No: We are commoners – creative, distinctive individuals inscribed within larger wholes. We may have many unattractive human traits fueled by individual fears and ego, but we are also creatures entirely capable of self-organization and cooperation; with a concern for fairness and social justice; and willing to make sacrifices for the larger good and future generations.
As the corruption of the market/state duopoly has intensified, our very language for identifying problems and imagining solutions has been compromised. The snares and deceptions embedded in our prevailing political language go very deep. Such dualisms as "public" and "private," and "state" and "market," and "nature and culture," for example, are taken as self-evident. As heirs of Descartes, we are accustomed to differentiating "subjective" from "objective," and "individual" from "collective" as polar opposites. But such polarities are lexical inheritances that are increasingly inapt as the two poles in reality blur into each other. And yet they continue to profoundly structure how we think about contemporary problems and what spectrum of solutions we regard as plausible.
Those either/or categories and the respective words we use have performative force. They make the world. In the very moment that we stop talking about business models, efficiency and profitability as top priorities, we stop seeing ourselves as _Homo economicus_ and as objects to be manipulated by computer spreadsheets. We start seeing ourselves as commoners in relationship to others, with a shared history and shared future. We start creating a culture of stewardship and co-responsibility for our commons resources while at the same time defending our livelihoods.
The commons helps us recognize, elicit and strengthen these propensities. It challenges us to transcend the obsolete dualisms and mechanistic mindsets. It asks us to think about the world in more organic, holistic and long-term ways. We see that my personal unfolding depends upon the unfolding of others, and theirs upon mine. We see that we mutually affect and help each other as part of a larger, holistic social organism. Complexity theory has identified simple principles that govern the coevolution of species in complex ecosystems. The commons takes such lessons to heart and asserts that we humans co-evolve with and co-produce each other. We do not exist in grand isolation from our fellow human beings and nature. The myth of the "self-made man" that market culture celebrates is absurd – a self-congratulatory delusion that denies the critical role of family, community, networks, institutions and nature in making our world.
Many of the pathologies of the contemporary economy are built upon this deep substrate of erroneous language. Or more precisely, the elite guardians of the market/state find it useful to employ such misleading categories. The corporation in the US and many other nations, for example, likes to cast itself as a "private" entity that hovers above much of the real world and its problems. Its purpose is simply to minimize its costs, maximize its sales, and so earn profits for its investors. This is its institutional DNA. It is designed to ignore countless social and environmental harms (primly described by economists as "externalities") and relentlessly pursue infinite growth.
And so it is that language of capitalism validates a certain set of purposes and power relationships, and projects them into the theaters of our minds. The delusions of endless growth and consumption are encoded into the very epistemology of our language and internalized by people. It is only in recent years that large masses of people have understood the alarming real-world consequences of this cultural model and way of thinking: a globally integrated economy dedicated to the proposition that humans must indefinitely exploit, monetize and financially abstract a finite set of natural resources (oil, minerals, forests, fisheries, water). The rise of Peak Oil and global warming (not to mention other ecosystem declines) suggest that this vision is a time-limited fantasy. Nature has real limits. The drama of the next decade will revolve around whether capitalism can begin to recognize and respect these inherent limits.
The premises of "democratic capitalism" extend to information and culture as well. But here, in order to wring maximum profit from intangibles (words, music, images), the logic is inverted. Instead of treating a finite resource, nature, as infinite and without price, here, the corporation demands that an essentially infinite resource, culture and information, be made finite and scarce. That is the chief purpose of extending the scope and terms of copyright and patent law – to make information and culture artificially scarce so that they can then be treated as private property and sold. This imperative has become all the more acute now that digital technologies have made the reproduction of information and creative works easy and essentially free, and in doing so undermined the customary business models that made books, film and music artificially scarce.
The commons – a vehicle for meeting everyone's basic needs in a roughly equitable way – is being annexed and disassembled to serve a global a market machine which treats nature as a brute commodity. Commoners become isolated individuals. Communities of commoners are splintered and reconstituted as armies of consumers and employees. The "unowned" resources of the commons are converted into the raw fodder for market production and sale – and after every last drop of it has been monetized, the inevitable wastes of the market are dumped back into the commons. Government is dispatched to "mop up" the "externalities," a task that is only irregularly fulfilled because it is so ancillary to neoliberal priorities.
The normal workings of The Economy require constant if not expanding appropriations of resources that morally or legally belong to everyone. The Economy requires that all resources be transmuted into tradeable commodities. Enclosure is a sublimely insidious process. Somehow an act of dispossession and plunder must be reframed as a lawful, common-sense initiative to advance human progress. For example, the World Trade Organization, which purports to advance human development through free trade, is essentially a system for seizing non-market resources from communities, dispossessing people and exploiting fragile ecosystems with the full sanction of international and domestic law. This achievement requires an exceedingly complicated legal and technical apparatus, along with intellectual justifications and political support. Enclosure must be mystified through all sorts of propaganda, public relations and the co-optation of dissent. This process has been critical in the drive to privatize lifeforms, supplant biodiverse lands with crop monocultures, censor and control Internet content, seize groundwater supplies to create proprietary bottled water, appropriate indigenous knowledge and culture, and convert self-reproducing agricultural crops into sterile, proprietary seeds that must be bought again and again.
Through such processes, the very idea of "The Economy" has been constructed, complete with dualisms about what matters (things that bear prices or affect prices) and what doesn't (things that have intrinsic, qualitative, moral or subjective value). Over time, The Economy comes to be seen as a universal, ahistorical, entirely natural phenomenon, a fearsome Moloch that somehow preexists humanity and exists beyond anyone's control. This image begins to express the nightmare of enclosure that afflicts so much of the world – a world where natural ecological processes, communities and vernacular culture have no legal protection or cultural respect.
**The commons as a generative paradigm**
A major point of the commons (discourse), then, is to help us "get outside" of the dominant discourse of the market economy and help us represent different, more wholesome ways of being. It allows us to more clearly identify the value of inalienability – protection against the marketization of everything. Relationships with nature are not required to be economic, extractive and exploitative; they can be constructive and harmonious. For people of the global South, for whom the commons tends to be more of a lived, everyday reality than a metaphor, the language of the commons is the basis for a new vision of "development."
The commons can play this role because it describes a powerful value proposition that market economics ignores. Historically, the commons has often been regarded as a wasteland, a res nullius, a place having no owner and no value. Notwithstanding the long-standing smear of the commons as a "tragedy," the commons, properly understood, is in fact highly generative. It creates enormous stores of value. The "problem" is that this value cannot simply be collapsed into a single scale of commensurable, tradeable value – i.e., price – and it occurs through processes that are too subtle, qualitative and long-term for the market's mandarins to measure. The commons tends to express its bounty through living flows of social and ecological activity, not fixed, countable stocks of capital and inventory.
The generativity of commons stewardship, therefore, is not focused on building things or earning returns on investment, but rather on ensuring our livelihoods, the integrity of the community, the ongoing flows of value-creation, and their equitable distribution and responsible use. Commoners are diverse among themselves, and do not necessarily know in advance how to agree upon or achieve shared goals. The only practical answer, therefore, is to open up a space for robust dialogue and experimentation. There must be room for commoning – the social practices and traditions that enable people to discover, innovate and negotiate new ways of doing things for themselves. In order for the generativity of the commons to manifest itself, it needs the "open spaces" for bottom-up initiatives to occur in interaction with the resources at hand. In this way, citizenship and governance are blended and reconstituted.
**Creating an architecture of law and policy to support the commons**
For too long commons have been marginalized or ignored in public policy, forcing commoners to develop their own private-law "work-arounds" or sui generis legal regimes in order to establish collective legal rights. Examples include the General Public License for free software, which assures its access and use by anyone and land trusts, which establish tracts of land as commons to be enjoyed by all yet owned as private property ("property on the outside, commons on the inside," as Carol M. Rose has put it).1 The future of the commons would be much brighter if the state would begin to provide formal charters and legal doctrines to recognize the collective interests and rights of commoners. There is also a need to reinvent market structures so that the old, centralized corporate structures of capitalism do not dominate, and squeeze out, the more locally responsive, socially mindful business alternatives (a trend that the Solidarity Economy movement has been stoutly resisting).
There is an inherent tension in seeding new sorts of commons initiatives, however, because they must often work within the existing system of law and policy, which risks a co-optation of the commons and the domestication of its innovations. Despite this real danger, commons initiatives need not lose their transformative, catalytic potential simply because they work "within the system." Among commoners, there will invariably be debates about the strategic "purity" of commons-based initiatives, especially those that interact with the marketplace in new ways. Such scrutiny is important. Yet it may also highlight deeper philosophical tensions within the commons movement – namely, that some commoners prefer to have little or no intercourse with markets while others believe that their communities can better thrive if they interact with markets.
This is a creative tension that will never go away, nor should it. But the critical question for commoners to ask is, What is production for? Unlike market capitalism, which requires constant economic growth, the point of the commons is to propagate and extend a commons-based culture. The goal is to meet people's needs – and to reproduce and expand the Commons Sector. Throughout history, civilizations have always had a dominant organizational form. In tribal economies, gift exchange was dominant. In pre-capitalist societies such as feudalism, hierarchies prevailed and rewards were allocated on the basis of one's social status. In our era of capitalism, the market is the primary system for allocating social status, wealth and opportunities for human development. Now that the severe limitations of the market system under capitalism have been made abundantly clear, the question we must confront is whether the commons can become the dominant social form. We believe it is entirely possible to create commons-based innovations that work within existing governance systems while helping bring about a new order.
We hope that the essays of this book encourage new explorations and initiatives in this direction. This is a rare moment in history in which old, fixed categories of thought are giving way to new possibilities. But any transition to a new paradigm will require that enough people "step into history" and make the new categories of the commons their own. Hope for the future lies in people creating their own distinctive forms of commoning throughout the world, and the gradual emergence and confluence of new social/economic practices.
Anthropologists, neurologists, geneticists and other scientists confirm the critical role that cooperation has played in the evolution of the human species. We are hard-wired to cooperate and participate in commons. One might even say that it is our destiny. While the commons may seem odd within the context of 21st Century market culture, it speaks to something buried deep within us. It prods us to deconstruct the oppressive political culture and consciousness that the market/state duopoly demands, and whispers of new possibilities that only we can actualize.
_"The definition of insanity is doing the same thing over and over and expecting it to come out different."_
– Attributed to Albert Einstein
# PART ONE
THE COMMONS AS A NEW PARADIGM
# My Rocky Road to the Commons
by Jacques Paysan
"The Pyrenees, they are not all that high up – their outlines are gently curved, sharp ridges few and far between, and all the peaks are rounded. It seems like music frozen in place in this high country" (Kurt Tucholsky, celebrated German journalist and author, 1927).
We are standing on the Col de Peyreget, where a small sign says we are 2,320 meters above sea level. Not all that high, but I am short of breath nonetheless. Presumably not because of the mountain, but because of gravity. I cannot see the rounded mountaintops, either: they are dozing behind the morning haze. A scent of thyme and damp grass is in the air. Sheep bells are tinkling in the distance.
"There," I say, pointing down into the valley. She gazes into the deep.
"Can you see them?" I ask. "The sheep! Garrett Hardin's sheep."
She rolls her eyes.
"Garrett Hardin?" she replies, "Don't remind me of Garrett Hardin! I'm on vacation" – and begins to hike down the mountain. I watch her go and have to laugh.
When we met, I had never heard of Garrett Hardin or the herdsmen he describes who supposedly attempted to maximize their gain by herding more and more cattle on the pasture until it was ruined by overgrazing: the famous "tragedy of the commons."
"Commons?" I had no idea what that could be.
I glance back at the sheep and take a sip of water from my bottle. Then I follow her.
My perspective on the world has changed dramatically since our first conversations about the commons. Now I have a more nuanced idea of what they are and what they mean.
But getting to this point was a rocky road. In comparison, hiking up to the Col de Peyreget was a piece of cake. The difference between resources and commons was the most difficult part for me to understand. This learning process reminds me of that optical illusion, the image that you see either as two faces or as a vase. The dominating image seems to crowd the complementary contour out of our perception – until the light goes on! But then, it is easy to see both aspects. Isn't that remarkable? The commons concealed in misunderstandings, like the mountain ridges in the mist.
So: what are commons? A pasture where shepherds jointly graze their sheep? No? The social relationship that manages the access of the sheep to the pasture? At that point, I groaned and tore my hair. What was that supposed to be: a social relationship that sheep graze on?
The light went on when I considered an example of the commons that has little to do with politics and sheep: rock climbing!
I stop and listen. Looking up the rough rock face whose base we are hiking along, I can hear the clanging of the carabiners and the calls of the climbers pitting their strength against gravity.
Rock climbing used to be an extreme sport, but today it brings thousands of people to climbing gyms and walls of rock. The mountain and the climbable route are the resource. The active climbers are the commoners who have autonomously agreed on complicated sets of rules: codes of conduct and climbing grades. That was not a simple process, and certainly not without conflict. But today, their differences have been overcome. The climbers take care of the routes, provide for stable anchors that prevent dangerous falls, draw sketches of the routes and give them creative names. They also try to resolve conflicts with conservationists through consensus, which sometimes requires the support of the authorities.
There are no property rights or patents. On the contrary: The most accomplished climbers are constantly inventing new routes and inviting everybody to test their skills on them. An important rule in the process is: "Don't leave footsteps! Allow future climbers to discover the route in the same condition in which you discovered it." Some of these routes are world-famous, for example _The Nose_ on El Capitan in California's Yosemite National Park. Thousands of years from now, when the climbers will have long died out, these rock formations and some iron pitons will remain. But then, they will no longer be a commons, because the commons is the social relationship: the sport of rock climbing! Not the resource itself, the rock. No climbing, no commons. There is no commons without commoning!
My companion is a long way ahead and I would have to hurry to catch up with her. Instead, I stumble across the loose boulders, sunk in philosophical reflections. But the commons have opened my eyes. And how!
Today, I see commons everywhere. In every park where people are playing boules together, enjoying a glass of wine and talking. At the springs in Baktapur, where the Nepalese women form long lines with their water jugs, filling them with drinking water according to rules invisible to us. When I go fishing with my son or talk with doctors about satellite-based telemedicine that could help a physician in Central Africa use his British colleagues' expertise if – if only – we were to organize the use of this expertise in the form of a commons and not as a business model. The kaleidoscope of the commons is colorful, and the list of possibilities I can see grows longer and longer with every one of my thoughts.
Down in the valley, the sheep are bleating. _As a rational being_ , Hardin wrote in 1968 _, each herdsman seeks to maximize his gain_. As if the shepherd were dumber than the sheep. As if he and his colleagues were not able to reach agreement about rules that would ensure a sustainable way of using the pasture in the interest of all. How bizarre this short circuit in the brain seems to me today: it makes us blind to the fact that people do want to cooperate, provided other people do as well. The unfortunate image of the herdsman maximizing his gain blocks our view of the commons, just as the image of faces crowds out the reverse-image of the vase.
I remember a sentence I wrote almost twenty years ago in my doctoral dissertation: _Ever since Charles Darwin postulated in 1871 that man and ape had descended from a common ancestor, man has been trying to define the principal difference between himself and the ape._ At that time, it didn't occur to me that I could do so myself, but today, the solution to this problem seems very simple to me. It is Broca's area, the region of the brain linked to speech production, which exists only in human beings. And language is the most important tool for cooperation. Any worm with its ventral (nerve) cord can compete, and it's just for a hole in the ground. But what sets humans apart from animals is the ability to consciously cooperate at the highest level of perfection.
Trying to catch up with my companion, I trip on a stone and land rudely on a thistle. There's a time for everything, I think, and sit down on the grass. This subject matter is complex, and I cannot solve it while I hike. There must be space for competition, too. Undivided attention, for example, is a fiercely contested good. When recognition and affection come into play, cooperation often ends abruptly. Compared with the problems in a relationship, the question as to how we could regulate our way of handling algorithms and melodies, recipes, literature and scientific insights, intellectual property, authors' rights as well as access to beaches and education is almost child's play. But who ever said it had to be simple?
Speaking of difficult! We had the toughest arguments about patents and copyright.
Not long ago, I would still ask, enraged, "Why should someone benefit from shamelessly copy-and-pasting a text of mine?"
Today I think, "Well, why not? As long as I'm acknowledged properly." As far as Tucholsky is concerned, I enjoy quoting him often – after all, his work is in the public domain by now, and thus saved from the burden of exploitation rights, which have been lifted.
"Saved from the mountains," he wrote in 1927, "saved from climbing and scaling the heights. A little flake is in my heart, born just now, embryonic: yearning for the Pyrenees."
**Jacques Paysan** _(Germany) is a neuroscientist and commons fan. Part of this story is illustrated on the blog http://pyrenaeen.wordpress.com._
# The Economy of Wastefulness: The Biology of the Commons
By Andreas Weber
There is an all-enclosing commons-economy which has been successful for billions of years: the biosphere. Its ecology is the terrestrial household of energy, matter, beings, relationships and meanings which contains any manmade economy and only allows for it to exist. Sunlight, oxygen, drinking water, climate, soil and energy – the products and processes of this household – also nourish the _Homo economicus_ of our time who, despite all his technological and economical progress, still feeds on products of the biosphere.
I wish to argue that nature embodies the commons paradigm _par excellence_. With that definition I do not only mean that man and other beings have been living together according to commons principles for an overwhelming majority of time. My argument is more complex: I am convinced that ecological relations within nature follow the rules of the commons. Therefore, nature can provide us with a powerful methodology of the commons as a natural and social ecology. The goal of this chapter is to give a brief outline of this "existential commons ecology."
**Liberalism as a hidden metaphysics of life**
But which nature are we talking of? To analyze nature's household without the bias added by the liberalist metaphors of nature as capitalist marketplace we will have to reconsider the underlying ecology __ and economy of natural housekeeping step by step. Particularly, we will have to question the mainstream view of ecological interactions as competition and optimization processes between mechanical actors (or "genes") due to the pressure of external laws, e.g., selection. We will rather discover in nature a deep history of evolution towards more freedom, where the players are autonomous subjects bound together in mutual dependence. This idea, however, is in opposition to the current view of matter and information exchange in biological and economic theory.
In the last 200 years few models of reality have been influencing each other so strongly as the theory of natural evolution and the theory of man's household of goods and services. Both disciplines received their current shape in Victorian England, and both reciprocally borrowed and reapplied each other's key metaphors. Consequentially, social findings have been projected on to the natural cosmos and scientific knowledge, and in turn reapplied to socioeconomical theories. Today both paradigms together form a bioeconomic metaphysics which does not so much deliver an objective description of the world as an assessment of civilization itself.
In this context it is important to notice that a political economist, Thomas Robert Malthus, delivered the crucial cornerstone for the modern concept of biology as evolution. Malthus was obsessed by the idea of scarcity as explanation for social change – there would never be enough resources to feed a population which steadily multiplies. Charles Darwin, the biologist, adapted that piece of theory which had clearly derived from the observation of Victorian industrial society and applied it to a comprehensive theory of natural change and development. In its wake such concepts as "struggle for existence," "competition," "growth" and "optimization" tacitly became centerpieces of our self-understanding: biological, technological, and social progress is brought forth by the sum of individual egoisms. In perennial competition, fit species (powerful corporations) exploit niches (markets) and multiply their survival rate (return margins), whereas weaker (less efficient) ones go extinct (bankrupt). The resulting metaphysics of economy and nature, however, are less an objective picture of the world than society's opinion about its own premises.
By this exchange of metaphors, economics came to see itself more and more as a "hard" natural science. It derived its models from biology and physics – leading all the way up to the mathematical concept of _Homo economicus_. This chimera – a machine-like egoist always seeking to maximize his utility – has become the hidden, but all-influencing model of humanity. Its shadow is still cast over newer psychological and game-theoretical approaches. Reciprocally, evolutionary biology also gained inspiration from economical models. The "selfish gene," e.g., is not much more but a _Homo economicus_ mirrored back to biochemistry.2 (1. Concerning the concept of _Homo economicus,_ see Friederike Habermann's essay. 2. See Dawkins, Richard. 1990. _The Selfish Gene_. Oxford University Press)
We can call this alliance between biology and economics an "economic ideology of nature." Today it reigns supreme over our understanding of man and world. It defines our embodied dimension ( _Homo sapiens_ as gene-governed survival machine) as well as our social aspect ( _Homo economicus_ as egoistic maximizer of utility). The idea of universal competition unifying the natural and the social sphere is always rival and exclusive:3 You have to eliminate as many competitors as possible and take the biggest piece of cake for yourself – a license to steal life from others. (3. For an explanation of these terms see Silke Helfrich's essay.)
Historically therefore, the reinvention of nature as an economical process of competition and optimization has been an organizing template for the enclosure of the commons. It has served as a mental fencing-off which preceded the real dispossessions and displacements and invented a context of justification.
The first transformations of common into private property took place in early modern times (1500–1800). This was the same epoch when our self-understanding increasingly was dominated by the dualist view of the French thinker René Descartes. Mind was no longer intimately entangled with body but rather a rational principle that stood above matter. Organisms, the whole diversity of nature, but also man's own body, were conceived of as automata made of subjectless and deterministic matter. This conviction is the refusal of any form of connectedness. The British philosopher Thomas Hobbes expanded on that idea and claimed an absolute separation of society and politics from nature. Nature is seen as the dominion of blind causes and effects and hence is no longer available as a point of reference for human self-understanding – in much the same way as the forest that the nobility had once shared with the peasants became exclusive property and was no longer accessible. The idea that the inhuman forces of opimization and selection dominate the realm of "pure things," and hence also ourselves, closely parallels that historical exclusion. Both follow a basic model of estrangement and fencing off of living abundance. It is most noteworthy that the human sphere, which in this manner has been purified from nature, does not gain more freedom. Rather, society is also understood as a battle of brute and cruel forces – forces which have lost any connection with creative and lawful powers of existing-within-nature and embodied subjectivity. Hobbes' model of society, which remains influential in our time, shuns all connection with natural objects yet nonetheless becomes the embodiment of a world driven by brute force. It is built upon the idea of the "Leviathan," the war of all against all as a "natural" state.
The enclosure of nature that had once been accessible by all reaches deeply into our mind and emotions. The inner wilderness of man increasingly has come under control. It has become difficult to understand oneself as an embodied part of a developing whole. Man-as-a-body did not belong any longer to the realm of beings, nor were his feelings about being alive to be taken seriously anymore. Rather, man's experiences and emotions became isolated from the rest of reality. This view culminates in an idea that today is quite common, that "nature" is not real at all but only exists as a mental concept, leaving no room to care for that which does not exist. The economic ideology of nature excluded any wilderness from our soul; unenclosed nature which accomplishes itself by itself and which is possessed by no being, made no sense to the liberal mind. No understanding of ourselves and of the world which reaches beyond the principles of competition and optimization can now claim any general validity. It is "nothing but" a nice illusion which "in reality" is only proof of the underlying forces in the struggle for existence. Love reduces itself to choice of the fittest mate; cooperation basically is a ruse in the competition for resources; and artistic expression shows the economy of discourses.
The enclosure of nature hence finally touches the _Homo sacer,_ 4 the innermost core of our embodied and feeling self, which contains the vulnerable existence in flesh and blood, the nude, emotional, animate existence. If we prefer to think of ourselves as apart from animate life, we have divorced ourselves from the realm of the living. As a final consequence, the enclosure of the commons manifests itself as biopolitics – the bid to own and monetize life. ( 4. See Agamben, Giorgio. 1998. _Homo sacer: Sovereign Power and Bare Life_. Stanford. Stanford University Press.)
**Natural anticapitalism**
A new economy can become a realistic alternative if we can challenge the mainstream biological view that sees life as an endless process of optimization. A new picture of life indeed is overdue – particularly in biology itself. Here, in fact, the Hobbsean paradigm of "war of all against all" is being overcome. The biological view of the organic world – and the picture of man within it – is changing from the idea of a battlefield between antagonistic survival-machines to that of an interplay of agents with goals and meanings. The organism starts to be seen as a subject who _interprets_ external stimuli and genetic influences rather than being causally governed by them, and who negotiates his existence with others under conditions of limited competition and "weak causality."
This shift in the axioms of "biological liberalism" leads to an emerging picture of the organic world as one in which freedom evolves. This is particularly evident in the following issues:
_1. Efficiency_ : The biosphere is not efficient. Warm-blooded animals consume over 97 percent of their energy only to maintain their metabolism. Photosynthesis achieves a ridiculous efficiency rate of 7 percent. Fish, amphibians and insects have to lay millions of eggs only to allow for the survival of very few offspring. Instead of being efficient, nature is highly redundant. It compensates for possible loss through incredible wastefulness. Natural processes are not parsimonious but rather based on generosity and waste. The biosphere indeed is based on donation, but it is not reciprocal: the foundation of all biological work – solar energy – falls as a gift from heaven.
_2. Growth_ : The biosphere does not grow. The quantity of biomass does not increase. The throughput does not expand – nature is running a steady-state-economy – that is, an economy where all relevant factors remain constant toward one another. Also, the number of species does not necessarily increase. It rises in some epochs and falls in others. The only dimension that really grows is the diversity of experiences: ways of feeling, modes of expression, variations of appearance, novelties of patterns and forms. Therefore, nature does not gain weight, but rather depth.
_3. Competition_ : It has never been possible to prove that a new species arose from competition for a resource alone. Species are rather born by chance: they develop through unexpected mutations and the isolation of a group from the remainder of the population through new symbioses and cooperations (as our body cells have done, for example). Competition alone, e.g., for a limited nutrient, causes biological monotony: the dominance of relatively few species over an ecosystem.
_4. Scarcity: _The basic energetic resource of nature, sunlight, exists in abundance. A second crucial resource – the number of ecological relationships and new niches – has no upper limit. A high number of species and a variety of relations among them do not lead to sharper competition and dominance of a "fitter" species, but rather to a proliferation of relationships among species and thus to an increase in freedom, which is at the same time also an increase of mutual dependencies. The more that is wasted, the bigger the common wealth becomes. In ecosystems where only a few nutrients are freely available, as in the tropical rainforest, this limitation brings forth more niches and thus a higher overall diversity. This is the result of an increase of symbioses and reduced competition. Scarcity on a biological level does not lead to displacement, but to diversification.
_5. Property_ : There is no notion of property in the biosphere. An individual does not even possess his own body. Its matter changes permanently and continuously as it is replaced by oxygen, CO2, and other inputs of energy and matter. But it is not only the physical dimension of self that is made possible through communion with other elements, it is the symbolic as well: language is brought forth by the community of speakers who are using it. Habits in a species are acquired by sharing them. In any of these dimensions the wilderness of the natural world – which has become, and not been made, and which cannot be exclusively possessed by anybody – is necessary for the individual to develop its innermost identity. Individuality – physical and social/symbolic – thus _can only_ emerge through a biological and symbol-based commons.
**Commons features of the biosphere**
In a temperate forest there are different rules for flourishing than in a dry desert. Each ecosystem is the sum of many rules, interactions, and streams of matter, which share common principles but are locally unique. This strict locality follows the fact that living beings do not only _use_ the commons provided by nature, but are physically and relationally _a part of_ them. The individual's existence is inextricably linked to the existence of the overarching system. The quality of this system, its health (and beauty) is based on a precarious balance that has to be negotiated from moment to moment. It is a balance between too much autonomy of the individual and too much pressure for necessity exerted by the system. Flourishing ecosystems historically have developed a host of patterns of balance that lead to extraordinary refinement and high levels of aesthetic beauty. Hence, the forms and beings of nature can be experienced as solutions that maintain a delicate balance in a complex society. The embodied solutions of individual-existence-in-connection are that special beauty of the living which fills most humans with the feeling of sense and belonging.
Nature as such is the paradigm of the commons. Nothing in it is subject to monopoly; everything is open source. The quintessence of the organic realm is not the selfish gene but the source code of genetic information lying open to all. Even the genes being patented today by biocorporations in truth are nonrival and nonexclusive in a biological sense. Only in being so are they able to provide biological and experiential novelty. DNA was only able to branch into so many species because everybody could use its code, tinker with it and derive the most meaningful combinations from it. This is the way _Homo sapiens_ himself came about: by nature playing around with open source code. Some 20 percent of our genome alone is once viral genes that have been creatively recycled. As there is no property in nature – there is no waste. All waste byproducts are food. Every individual at death offers itself as a gift to be feasted upon by others, in the same way it received its existence by the gift of sunlight. There is a still largely unexplored connection between giving and taking in which loss is the precondition for productivity _._
In the ecological commons a multitude of different individuals and diverse species stand in various relationship to one another – competition and cooperation, partnership and predatorship, productivity and destruction. All those relations, however, follow one higher law: over the long run only behavior that allows for productivity of the whole ecosystem and that does not interrupt its self-production is amplified. The individual is able to realize itself only if the whole can realize itself. Ecological freedom obeys this form of necessity. The deeper the connections in the system become, the more creative niches it will afford for its individual members.
**Commons as relations of the living**
A thorough analysis of the _economy of ecology_ can yield a powerful methodology of the commons. Natural processes are able to define a blueprint to transform our treatment of the embodied, material aspect of our existence into a _culture of being alive_. The term "commons" provides the binding element between the natural and the social or cultural worlds. To understand nature in its genuine quality as a commons opens the way to a novel understanding of ourselves – in our biological as well as in our social life.
If nature actually _is_ a commons, it follows that the only possible way to achieve a productive relationship with it will be an _economy of the commons_. The self-realization of _Homo sapiens_ can be best achieved in a system of common goods because such a culture – and thus any household or market system – is the species-specific realization of our own particular embodiment of being alive within a common system of other living subjects.
Although the deliberations that have led us to this point stem from a thorough analysis of biology, their results are not _biologistic_ – but rather the opposite. The thorough analysis here has revealed that the organic realm is the paradigm for the evolution of freedom. Therefore, even if we determine that the commons is the basic law of nature, the necessities resulting from that basic law are non-deterministic – contrary to the prevailing ideas of optimization and growth. The basic idea of the commons is rather grounded on an intricate understanding of _embodied freedom and its relationship to the whole_ : the individual receives her options of self-realization through the prospering of the life/social systems she belongs to. To organize a community between humans and/or nonhuman agents according to the principles of the commons always means to increase individual freedom by enlarging the community's freedom. (See Table 1).
Contrary to what our dualistic culture supposes, reality is not divided into substances of matter (biophysics, deterministic approach) and culture/society (non-matter, indeterministic or mental/semiotic approach). Living reality rather depends on a precarious balance between autonomy and relatedness on all its levels. It is a creative process that produces rules for an increase of the whole through the self-realization of each of its members. These rules are different for each time and each place, but we find them everywhere life is. They are valid not only for autopoiesis – the auto-creation of the organic forms – but also for a well-achieved human relationship, for a prospering ecosystem as well as for an economy in harmony with the biospheric household. These rules are the laws of the commons.
The idea of the commons thus delivers a unifying principle that dissolves the supposed opposition between nature and society/culture. It cancels the separation of the ecological and the social. In any existence that commits itself to the commons, the task we must face is to realize the well-being of the individual while not risking an increase of the surrounding and encompassing whole. Here, too, the idea of the commons conflates the realms of theory and of application. Reflections on theory are not isolated in some separate realm, but inexorably return to practice, to the rituals and idiosyncrasies of mediating, cooperating, sanctioning, negotiating and agreeing, to the burdens and the joy of experienced reality. It is here where the practice of the commons reveals itself as nothing less than the practice of life.
**Andreas Weber** _(Germany) is a biologist, philosopher, magazine writer, and book author. His focus of thinking and writing is the relationship between human self-understanding and nature. He lives in Berlin and Varese Ligure, Italy. His activities can be followed at http://www.autor-andreas-weber.de._
# We Are Not Born as Egoists
__
_By Friederike Habermann_
A woman is writing a letter, and her pen drops to the floor. She leans across the desk and tries to pick it up, but she can't reach it. A small boy realizes that he can help her. He walks over to the pen, picks it up and hands it to the woman.
This is an experiment with twenty-month-old children. In an initial phase, almost all of them are happy to help adults who drop objects and are seemingly unable to pick them up again. Then the children are randomly assigned to three groups. In the first one, the adult does not respond at all to the child's assistance; in the second, the adult praises the child; and in the third, the adult rewards the child with a toy. The result: while the children in the first two groups continue to help as a matter of course, most of the children in the third group do so only if they are rewarded (Warneken/Tomasello 2008).
Philosopher Richard David Precht has a chapter entitled, "What Money Does to Morals," in his book, _The Art of Not Being an Egoist_. He begins: "It is a touching scene," initially referring to a very similar experiment with fourteen-month-old children who help adults open the door of a cupboard (Precht 2010: 314ff). These experiments, conducted by the Max Planck Institute for Evolutionary Anthropology in Leipzig, Germany, can be viewed on the Internet.1 Yet the scenes with the third group of children are not online, and to be honest, I would not want to see them. They would make me sad. (1. Max Planck Institute, http://email.eva.mpg.de/~warneken/video (accessed July 17, 2011).)
An article about the use of monetary incentives for employees, "The Gummy Bear Effect," documents the perverse effects that external incentives can have on people's motivations:
At a children's birthday party, tell an exciting story about pirates, dragons and a sunken treasure. Then have the children draw pictures about the story. The children get to work eagerly and draw pirates' coves, sea monsters and flotillas of pirate ships with many details. Then, the experiment is varied to include an incentive system. A child receives a gummy bear for every picture completed. At first, the children are delighted, but all of a sudden, it becomes apparent that there are two types of children: The "artists" continue to devote themselves to their works of art with as much verve as before and are happy to accept the reward as a positive side effect. The "businesspeople," on the other hand, shift to mass production, churning out simple images with increasing speed and sloppiness, and pile up stacks of gummy bears to show off their success. Engrossed in their pictures, the "artists" take note of the "businesspeople's" piles of gummy bears and slowly but surely lose interest in the details of their works ...] Then comes the last phase of the experiment: The rules of the game are changed yet again, with the explanation that the gummy bears are all gone. Suddenly, not only do the "businesspeople" lose their motivation, but so do the "artists." Introducing and abolishing an incentive system has turned a highly motivated gang of little rascals into a mob in a foul mood.2 (2. [http://www.die-erfinder.com/innovationskultur/der-gummibarchen-effekt-monetare-anreize-sind-fuer-mitarbeiter-nicht-alles.)
Experiments with adults yield similar results. For example, economist Uri Gneezy noticed that when his three-year-old daughter's kindergarten introduced a penalty for parents who were late picking up their children, it did not have the desired effect. So he and his colleague Aldo Rustichini looked into how many parents were late in ten other kindergartens in Haifa, Israel. Then, a penalty of ten shekels (roughly three US dollars) was introduced for parents who were at least ten minutes late. The result: On average, more than twice as many parents were late. And that did not change even when the penalty was abolished. What had previously been a social quality – not making the kindergarten teachers wait – had now been degraded to a quantity that spoke even less to the parents' sense of responsibility. To the parents, the fact that "being late" was available "for free" again may have seemed like an added bargain (Gneezy and Rustichini 2000).
Precht speaks of the "strange power of money," as it destroys our "sense of ... individual qualities, of what is rare and ephemeral, of the moment, of intimacy and so on. Where money rules, everything seems drab and indifferent. Life seems completely objectified – to such an extent that everything besides money becomes irrelevant" (Precht 2010: 319).
Games of cooperation that economists conduct with adults also initially contradict the image of humanity as Homo economicus that is so fundamental to their discipline. Instead of showing that people always pursue their own self-interest, the games bear witness to people's tendency to be fair – but only until the first egoist steps in (Precht 2010: 394f).3 And it is no surprise that when compared with other students, business and economics students are the first to abandon cooperation and adopt uncooperative strategies: after all, they learn about Homo economicus day in and day out. (3. Precht 2010: 394f. Precht refers here to experiments conducted by Ernst Fehr.)
We are all part of the largest experiment of this kind: the modern monetary economy. It, too, is founded on _Homo economicus_ , __ who is defined in the _Duden Dictionary of Foreign Words_ (2005) as "a person guided exclusively by economic considerations of expedience." A second definition describes the term as signifying "current-day man per se" – which implies, as mentioned above, egoism, competitiveness and a habit of reducing life to utility.
In his book _Homo Oeconomicus_ , economist Gebhard Kirchgässner defends him as "not all that dislikable," because he acts just as "disinterested and reasonable" as the priest and the Levite in the parable of the good Samaritan who saw the man who had fallen among robbers and walked past. Provided that he did not have a particular relationship to him, it made no difference to him whether his neighbor was all right or not (Kirchgässner 2000: 47). This is precisely the advantage of modern economic theory: "It assumes a realistic image of humanity and....does not claim that people become 'better' under different circumstances" (2000: 27). Precht comes to a different conclusion: "Strict and tough calculation of utility, ruthlessness and greed are not man's main driving forces, but the result of targeted breeding. One could call this process 'the origin of egoism by capitalist selection,' following Charles Darwin's famous principal work" (Precht 2010: 394).
For more than two decades, feminists have been discussing a poststructuralist approach that attempts to conceive in theoretical terms both of people's deep integration with their social context and their constant construction of themselves, thereby changing that very context. For this reason, our bodies and our emotions and empathy can only be imagined together with everything that leaves its mark on us; we are nonetheless more than a blank page that is an entirely passive object, inscribed by the societal discourse. We are surely not individuals who think and feel autonomously, but rather members of society with all our being (Habermann 2008).
Where, however, should empathy come from, if not from us as people? Insights from epigenetics demonstrate how our biology, including our genes, cannot be conceived of without environmental influences.4 Canadian physician and author Gabor Maté emphasizes that nobody can be separated from the surroundings he or she grew up in. The genetic argument permits one to refrain from calling the social, political or economic conditions into question by instead referring to a fundamental and unchangeable concept of human nature. Accordingly, our society, which is based on competition, falls victim to the myth that people are competitive, individualistic and self-interested by nature. On the contrary: only in a single respect should we speak of human nature, and that is the existence of certain human needs. "As human beings, we have a need for company and close contact; a need to be loved, connected, accepted and seen; to be accepted for what we are. If this need is fulfilled, we develop and become compassionate and cooperative individuals who have empathy for others."5 But in our society, the opposite is frequently to be observed – which results in different traits of character. (4. Concerning the relationship between nature and culture, see Andreas Weber's essay.) (5. Quote from the film, "Zeitgeist – Moving Forward," 2011, at http://www.youtube.com/watch?v=AQNktvqGkkQ.)
Without presupposing such needs as essential and ahistorical, poststructuralist feminism also implies that if these needs are not fulfilled, they will manifest themselves in a subject's psyche in the form of melancholy. Hanna Meissner speaks of a "loss that cannot be mourned because one is not aware of it being a loss, as the life option that is lost or from which one is excluded cannot even be imagined as a potential option in the framework of the symbolic order" (Meißner 2008: 30).
What this means for the quest for a happier society is obvious. Every time someone claims that there cannot be a better society or an economic model less strongly founded on self-interest because "that's how people are, after all," we can counter with Richard David Precht's words, "We are not born as egoists, we are made into them" (Precht 2010: 316).
According to Precht, the insight that material rewards spoil people's character has a deeply disturbing aspect. After all, our entire economic system is based on such exchanges. And if economics is the continuation of ethics by other means, as economist Karl Homann and others claim – what kind of ethics is it that causes tens of thousands of people to starve to death every day? They are the ones who did not have enough to offer in market exchanges.
Accordingly, the question arises how people might withdraw from this peculiar power of money without a "fundamental criticism of our entire economic system," which Precht, too, presents as illusory. Social psychologist Harald Welzer rightly deems so-called _Realpolitik_ as a "politics of illusion," if we consider the extent to which people have closed their eyes on the global societal catastrophes. In this respect, he contends, only utopian politics are realistic.
Fetishizing and sacralizing growth and other such concepts, actually pseudo-concepts, from the past result in illusory realities – just as Realpolitik is in reality only the creation of an illusion of a status quo that no longer exists. That means that Realpolitik is currently politics of illusion, and that utopianism is realism – because utopian action/utopian maxims of action are, after all, realistic inasmuch as they assume that we cannot simply go on as before, and there must be a very fundamental transformation, in fact not a transformation.... in the context of existing practices, but of the framework itself, of the practices themselves.6
(6. Harald Welzer at the Utopia-Konferenz 2009. http://www.youtube.com/watch?v=aS3Eck7c-3Q.)
Welzer responds to Precht's question as to radical social and ecological renewal by democratic means with a plea for changing "cultural practice" – as it is necessary to consider it political.7 (7. Ibid. Part 2: http://www.youtube.com/watch?v=Ov-gnuj3wY8&.)
For decades, feminists have identified local starting points for a different kind of economic system in the "dissident practices" (Carola Moeller) of everyday life. This does not mean that other spaces of political life are meaningless, yet it does mean that a cornerstone of this process is changing our daily practices in a way that is able to alter the specific framework for these practices. If we have understood that we humans exist only if we are interwoven with our environment, then we also understand that new horizons for thinking and acting emerge only in interplay with the changed environment, that is: with an altered material-economic way of life.
"We are amply shaped by society," says Robert Maurice Sapolsky, professor of neurology at Stanford University. "[...D]ifferent large societies could be termed as individualistic or collectivist, and you get very different people in different mind sets [...] coming along with that." And he warns: "[...T]he more stratified a society is the fewer people you have as peers, the fewer people with whom you have symmetrical reciprocal relationships. Instead, all you have [...] is a world with a lot less altruism."8 (8. _Zeitgeist — Moving Forward;_ cf. footnote 5.)
Sapolsky uses the term _peers_. _Commons-based peer production_ is the term that Harvard law professor Yochai Benkler uses to describe the way in which free software is generated – a phenomenon that the theory based on _Homo economicus_ cannot explain.9 (9. On this subject see also the contributions by Christian Siefkes and Michel Bauwens in this volume.)
Only when reflecting later on my book _Halbinseln gegen den Strom. Anders leben und wirtschaften_ (2009), in which I explore alternative ways of conducting economic activities in German-speaking countries, did it become clear to me that these are basically also the principles that can be detected in the more recent initiatives as well. I use the somewhat less cumbersome term _Ecommony_ , yet Sapolsky's idea makes me wonder whether _peer_ might not be too important to be left out. For – and this is the decisive point – "structural communality" (Stefan Meretz) emerges from these principles. It supports cooperation instead of competition and opens up different ways for people to develop.10 (Particularly as an examination of power relationships – be they sexist, racist or otherwise – shows that they always imply and presuppose the construction of "non-peers," or "others" as a foundation; cf. Habermann 2008.)
These "peninsulas" (German: _Halbinseln_ ) are spaces (actual territorial ones or merely social ones) where, to a certain extent, people create a different reality for themselves and try to experiment where such a road could lead them. They are spaces that permit people to develop in a different way because a different set of things are taken for granted there.11 However, in our current state of being, we cannot know what a society inspired by such principles could look like. Exchange, competition and having to assert ourselves have left their mark on us. We need new experiences during which we change and with which we can gain new insights. In this sense the most realistic and feasible truth at the moment seems to be: the world shapes us, and we shape the world. (11. I have elaborated on these principles elsewhere (Habermann 2011).)
**References**
Gneezy, Uri and Aldo Rustichini. 2000. "A Fine is a Price," _Journal of Legal Studies_ (29)1:17.
Habermann, Friederike. 2008. _Der Homo Oeconomicus und das Andere. Hegemonie, Identität und Emanzipation_ , Baden-Baden.
Habermann, Friederike. 2009. Halbinseln gegen den Strom. Anders leben und wirtschaften im Alltag, Königstein.
Habermann, Friederike. 2011. Solidarität wär´ eine prima Alternative. Oder: Brot, Schoki und Freiheit für alle, rls-paper.
Kersting, Wolfgang u.a. 1998. "Grenzen des ökonomischen Imperialismus?" Norbert Brieskorn/Johannes Wallacher (eds.), _Homo Oeconomicus: Der Mensch der Zukunft?_ , Stuttgart/ Berlin/Köln, 33–37.
Kirchgässner, Gebhard (2000): _Homo Oeconomicus. Das ökonomische Modell individuellen Verhaltens und seine Anwendung in den Wirtschafts- und Sozialwissenschaften_ , 2., erg. u. erw. Aufl., Tübingen.
Meißner, Hanna. 2008. "Die gesellschaftliche Form des Subjekts. Judith Butlers Theorie der Subjektivität," _Zeitschrift für Frauenforschung & Geschlechterstudien_, (26)3+4:23-37.
Precht, Richard David. 2010. Die Kunst, kein Egoist zu sein. Warum wir gerne gut sein wollen, und was uns davon abhält, München.
Warneken, Felix/Tomasello, Michael. 2008. "Extrinsic Rewards Undermine Altruistic Tendencies in 20-Month-Olds," _Developmental Psychology_ , (44) 6: 1785–1788.
__
**Friederike Habermann** _(Germany) is an economist, historian and PhD in political science whose work focuses on the interconnectedness of power relations, transnational social movements and alternative subsistence strategies._
# Resilience Thinking
_By Rob Hopkins_
__
_Resilience: the capacity of a system to absorb disturbance and reorganize while undergoing change, so as to retain essentially the same function, structure, identity and feedbacks._
The UK Low Carbon Transition Plan, published by the UK government in 2010, was a bold and powerful statement of intent for a low-carbon economy in the UK (HMG 2009). It stated that by 2020 there would be a five-fold increase in wind generation, feed-in tariffs for domestic energy generation, and an unprecedented scheme to retrofit every house in the country for energy efficiency. I hesitate to criticize creative steps in the right direction taken by government. There is, however, a key flaw in the document, which also appears in much of the wider societal thinking about climate change and the social response it requires. It is the attempt to address the problem without also addressing the key issue of resilience.
"Resilience," I would argue, is a vitally important additional dimension to the concept of sustainability, or to its oxymoronic offspring, "sustainable development." Without resilience, the terms do not adequately address the nature of the challenge we face. Let's take a supermarket as an example. It is possible to increase its sustainability and to reduce its carbon emissions by using less packaging, putting photovoltaics on the roof and installing more energy-efficient fridges. It could stock mostly organic produce and have biodegradable packaging on all its products.
However, resilience thinking would argue that the closure of local food shops and networks that result from the opening of the supermarket – as well as the fact that the store itself only contains two days' worth of food at any moment, the majority of which has been transported great distances – has massively reduced the resilience of community food security while increasing its vulnerability to oil disruptions. Similarly, from a sustainability perspective, installing wind power is highly desirable, but at the moment, most of that infrastructure is installed by large wind energy companies, and the communities that live nearby reap little benefit from them. Were those communities to own that infrastructure and benefit directly from it, even in part, it would greatly increase the resilience of those economies.
The concept of resilience emerged from within the ecological sciences, through the work of pioneers such as C.S. Holling (1973) and more recently, academics such as Neil Adger (2009), Brian Walker and David Salt (2006). It is a way of looking at why some systems collapse when they encounter shock, and some don't. The insights gleaned now offer a very useful overview for determining how systems can adapt and thrive in changing circumstances.
Resilience at the community level depends upon:
• _Diversity:_ a broader base of livelihoods, land use, enterprise and energy systems than at present;
• _Modularity:_ an increased self-reliance (but not necessarily self-sufficiency), with "surge protectors" for the local economy, such as local food production and decentralized energy systems; and
• _Tighter feedback loops: _bringing the results of our actions closer to home, so that we cannot ignore them.
Local food economies model this beautifully. The industrial food system has hugely reduced the number of people working in farming, increased its oil dependency, and reduced diversity, in terms of biodiversity, the diversity of work opportunities, and the diversity of land uses. Also, because our food is grown at greater and greater distances from our communities, we have less and less concern or control over the impacts of its production. Local food – the reconnecting of communities to their local farmers, more seasonal diets, and more community involvement in how farms are run and what they grow – greatly increases community resilience.
In a report called "Resilient Nation" prepared by Charlie Edwards for the UK think tank DEMOS, the author raised the question, "Resilient to what?" (Edwards 2009). Are we building resilience in the face of peak oil and climate change, or of terrorism and pandemics? Edwards listed the things he felt we should be preparing resilience to: climate change, floods, pandemics, energy shortages, nuclear attacks, terrorism and a few others.
The UK government Cabinet Office runs "Regional Resilience Teams," which are charged with creating plans for the emergency preparedness of each region. Yet the main focus of this will most likely be on terrorism and pandemics. This, however, flies in the face of a recent report by the World Economic Forum (2011), which identified the key risks facing the global economy in terms of likelihood of occurrence and potential economic impact. The three leading challenges, it concluded, are economic crisis, energy price volatility and climate change – the very three challenges that Transition Network has been emphasizing for the past five years. While it is clearly not an either/or situation, peak oil and climate change are so destabilizing that we must give them precedence; the solutions they require are markedly different from those needed for terrorism or pandemics.
Therefore, in the Transition movement we have argued that we need to base thinking about resilience primarily on both mitigation and adaptation when it comes to climate change, and more recently to the economic troubles affecting us. Planning for resilience without these concerns at the forefront runs a high risk of missing the point. Indeed, we need a different take on the notion of resilience, one that is less about simple survival when something extremely ghastly occurs than about seeing resilience as a positive, constructive process.
But what would this kind of resilience thinking look like in practice? If breaking our dependency on cheap fossil fuels and creating more economic resilience were to be seen as an opportunity, then our thinking shifts. Making our communities more resilient becomes a historic opportunity to rethink how it feeds, houses and heats itself. The whole idea of "localization as economic development" comes into its own. Localization by itself is not necessarily something that builds resilience. You could imagine a feudal, patriarchal form of localization, for example, that might have a lower carbon footprint but would also stifle diversity, creativity and innovation and not build resilience in many of the ways outlined above.
DuPuis and Goodman (2005) distinguish between "reflexive" and "unreflexive" localization. Unreflexive localization, they argue, "can have two major negative consequences. First it can deny the politics of the local, with potentially problematic social justice consequences. Second, it can lead to proposed solutions, based on alternative standards of purity and perfection, that are vulnerable to corporate cooptation." Localization, in the sense Transition talks about it, is a "reflexive localization," one that would build resilience by focusing on social inclusion, economic innovation, community ownership and a valuing of entrepreneurship and diversity.
These two concepts, resilience and localization, are central and vital ideas in moving forward. The Transition movement has catalyzed a hugely insightful "dry run" of thinking through what all this would look like in practice. It is the practical embodiment of Tom Homer-Dixon's assertion, in _The Upside of Down_ , that "if we want to thrive, we need to move from a growth imperative to a resilience imperative." (Homer-Dixon 2007). But the reality we live in is different: the UK governments Department of Food, Environment and Rural Affairs (DEFRA) in 2006 argued that the just-in-time distribution model on which our food system depends actually _increases_ our resilience, a position which is still largely in place. In 2011, this is still the official government position.
**What does a resilient community look like?**
Creating resilience takes time, resources and proactive and creative design. Often, sustainability thinking doesn't question the notion that higher rates of consumption lead to individual happiness; it simply focuses rather on low-carbon ways of making the same consumer goods. Yet as we enter the world of resource constraints, we will need to link satisfaction and happiness to other less tangible things like community, meaningful work, skills and friendships.
When I give talks on this subject, there are always some who interpret the concept of increasing resilience in the West as something that will necessarily lead to increased impoverishment in the developing world. But the developing world is not likely to be lifted out of poverty by continuing to dismantle its own food resilience and becoming dependent on the fluctuations, insecurities and energy vulnerabilities of the globalized economy.1 Amartya Sen has shown that famine and inequality occur more from the way in which food is produced and distributed than from food shortage. (1. See, for instance, the essays by P.V. Satheesh on GMO seeds and by Liz Alden Wily on land grabs.)
But even that analysis now needs to be revisited from a "resilience" perspective. In fact, tying developing-world food producers into the globalized system leads to their exposure to both food and money shortages, and leads to their becoming increasingly dependent on global trade, which is itself massively dependent on the cheap oil, something we can no longer rely on. Is the way out of poverty really an increasing reliance on the utterly unreliable?
Resilience thinking means that rather than communities meeting each other as unskilled, unproductive, dependent and vulnerable settlements, they would meet as skilled, abundantly productive, self-reliant and resilient communities. It is a very different quality of relationship, and one that could be hugely beneficial to both.
If you were to step outside your front door today and ask the first ten people you met what your town or city might look like in ten years' time if it began today to cut its emissions by 9 percent a year, I imagine most people would say something between how it looked in the 1950s and some science fiction future in which society has collapsed and is living in its wreckage. We have a paucity of stories that articulate what a lower-energy world and what resilient communities might sound like, smell like, feel like and look like. It is hard, but important, to be able to articulate a vision of this world so enticing that people leap out of bed every morning and put their shoulders to the wheel of making it happen.
Resilience thinking can inspire a degree of creative thinking that might actually take us closer to long term solutions. Resilient solutions to climate change might include community-owned energy companies that install renewable energy systems; the building of highly energy-efficient homes that use mainly local materials (clay, straw, hemp); the installation of a range of urban food production models; and the re-linking of farmers with their local markets. By seeing resilience as a key ingredient of the strategies and approaches that will enable communities to thrive beyond today's economic turmoil, huge creativity, reskilling and entrepreneurship are unleashed.
The Scottish government is using its Climate Challenge Fund to fund Transition Scotland Support, seeing Transition initiatives as a key component of the country's push on climate change. (Thanks also to that fund, a number of Transition initiatives have received substantial financial support. For example, Transition Forres received £184,000 and has become a real force for local resilience-building.) In England, Somerset and Leicestershire County Councils have both passed resolutions committing themselves to support local Transition initiatives, and many Transition initiatives are forming very productive working partnerships with their local councils. What underpins these responses is the idea that preparing proactively for the end of the age of cheap oil can either be seen as enormous crises, or as tremendous opportunities.
It is clear, as Jonathon Porritt argues, that attempting to get out of the current recession with the thinking that got us into it in the first place (unregulated banking, high levels of debt, high-carbon lifestyles) will get us into a situation that we simply cannot win (Porritt 2009). A friend of mine who works as a sustainability consultant in the Pacific Northwest talks of a meeting he had with a leading local authority there. Having read their development plan for the next twenty years, he told them, "Your Plan is based on three things: building cars, building airplanes and the financial services sector. Do you have anything else up your sleeves?" As US blogger and commentator John Michael Greer says, we're in danger of turning what could still be a soluble problem into an insoluble predicament. Transition is an exploration of what we need to have "up those sleeves."
**Cultivating inner growth to match external transformations**
Resilience is not just an outer process; it is also an inner one, a personal transformation of becoming more flexible, robust and skilled. If we imagine that Transition on the scale being discussed above will happen purely as an external, material process of solar panels and electric cars – one that doesn't require any growth in our abilities to communicate with each other, support each other through uncertain times and to build our own personal resilience – then we are missing a large part of the picture. Transition initiatives try to promote the "interior" changes that we need by offering skills-sharing, building social networks and creating a shared sense of this being a historic opportunity to build the world anew.
Navigating a successful way through climate change and peak oil will require a journey of such bravery, commitment and vision that future generations will doubtless tell stories and sing great songs about it. But as with any journey, having a clear idea of where you are headed and the resources that you have at your disposal is essential in order to maximize our chances of success. If we leave resilience thinking out, we may well end up an extremely long way from where we initially thought we were headed.
**Recommendations for resilience**
• Grow food everywhere.
• Ask "how would this [development, business, community] function if oil cost $200 a barrel?
• Underpin new developments of energy, building or food, with the principle of community ownership and management.
• Identify key local needs and how they can be met more locally
• Involve everyone.
• Tell a powerful story. This is a cultural process, not an environmental one.
**References**
Adger, W.N. 2009. _Neil Adger: Research Interests, Projects and Publications: Resilience_. http://www.uea.ac.uk/env/people/adgerwn/adger.htm 22 July 2010.
DEFRA [Department for the Environment, Food and Rural Affairs]. 2006. _Food Security and the UK: An Evidence and Analysis Paper_. Food Chain Analysis Group. 2006.
DuPuis, E.M. and D. Goodman. 2005. "Should We Go 'Home' to Eat? Towards a Reflexive Politics of Localism." _Journal of Rural Studies_. 21: 359-371.
Edwards, Charlie. 2009. _Resilient Nation_. London, UK. DEMOS. http://www.demos.co.uk/files/Resilient_Nation_-_web-1.pdf?1242207746.
Homer-Dixon, Thomas. 2006. _The Upside of Down: Catastrophe, Creativity and the Renewal of Civilization_. Island Press.
Her Majesty's Government. 2009. _The UK Low Carbon Transition Plan: National Strategy for Climate Change and Energy_. London, UK. The Stationery Office.
Holling, C.S. 1973. "Resilience and the Stability of Ecological Systems." _Annual Review of Ecologicy and Systematics_ 4: 1-23.
Porritt, Jonathon. 2009. _Living Within Our Means: Avoiding the Ultimate Recession_. Forum for the Future.
Walker, Brian and David Salt. 2006. _Resilience Thinking: Sustaining Ecosystems and People in a Changing World_. Island Press.
World Economic Forum. 2011. _Global Risks 2011, Sixth Edition_. Executive Summary. http://riskreport.weforum.org.
_This essay is based on a longer version published in_ Resurgence, _November/December 2009, p. 12, at http://www.scribd.com/doc/57751128/Resurgence-Issue-257._
**Rob Hopkins** _(Great Britain) is an "engaged optimist" and permaculturist. He was pivotal to the success of the Transition Town Movement and is author of '_ The Transition Companion: Making Your Community More Resilient in Uncertain Times _(2011). He blogs at www.transitionculture.org , and has won the Schumacher Award (2008) and Observer Ethical Award (2009) for Grassroots Campaigning._
# Institutions and Trust in Commons: Dealing with Social Dilemmas
by Martin Beckenkamp
From a game-theoretic point of view, commons represent both a chance and a problem. Game-theory is a mathematical tool that allows us to analyze decision-making in situations with social interdependencies such as sports, where a team has to decide either to play defensively or offensively in a match against another team, or economic situations, where companies have to decide whether to enter into partnerships or do business by themselves. From this perspective, commons provide win-win opportunities. On the other hand, these opportunities may disappear if the players try to maximize their own narrow self-interests. In the latter case, the common welfare is not achieved; the gain of a single actor is allowed to thwart potentially greater gains for the entire community. This tension helps explain why commons are often called a social dilemma.
Trust is an important component of cooperation in the commons because commons are extremely vulnerable. As Elinor Ostrom put it in her 2009 Nobel Prize lecture: "The updated theoretical assumptions of learning and norm-adopting individuals can be used as the foundation for understanding how individuals may gain increased levels of trust in others, leading to more cooperation and higher benefits with feedback mechanisms that reinforce positive or negative learning. It is not only that individuals adopt norms but also that the structure of the situation generates sufficient information about the likely behavior of others to be trustworthy reciprocators who will bear their share of the costs of overcoming a dilemma."
Trust can often be achieved in small groups, where people know each other, because informal norms (and feelings of guilt and shame in cases of defection) are sufficient to stabilize the common welfare. But what about the cases in which groups become sufficiently large and people do not know each other?
In such cases, institutional structures are extremely important for the maintenance of trust. The history of trade gives some examples of institutions that were invented over the centuries in order to enable investors to benefit while preventing trickery and piracy. In many cases, however, institutions are used to establish and consolidate the power of private interests that do not care about the collective interest of all. It can well be argued that many steps of this long history of trade are mirrored in modern commons and online platforms like eBay (which initially was a commons). Many modern commons not only mirror or reinvent traditional commons, they pioneer new institutional arrangements for building trust and cooperation. Open source software projects and Wikipedia are prominent examples.
In modern digital commons, often a small community starts out enthusiastically with great trust among its members. But after some time and considerable growth, instances of criminality or vandalism may occur. When the first defections (or misunderstandings about presumed defections) arise, the whole system is endangered. Solutions about how to handle defections have to be found. On one hand, sanctions have to be strong enough that they can credibly threaten those who intend to defect; on the other hand, they cannot be so strong as to signal general mistrust of the whole community, which has succeeded in cooperating at least some of the time. It is not easy to find benevolent and strong solutions, which is why many commons fail.
However, commons can be successfully stabilized if they adhere to key design principles, according to Elinor Ostrom's landmark research (1990).1 A closer look at seven of her eight design principles shows that they fulfill two requirements mentioned earlier: strength and benevolence. Ostrom identified commons as needing (among other things) clear boundaries that separate members and non-members; the adaptation of rules to local conditions and needs; the involvement of the members in decision-making; and effective monitoring by members and graduated sanctions against rule-breakers. (1. For the full set of design principles, see essay by Ryan T. Conway.)
The design principles for effective self-governance in a commons are somehow dialectic because they recognize the necessity of institutional strength and authority while also recognizing the harm of top-down directives and outside intervention. The same dialectic can be found with respect to benevolence in a commons. The starting point is the conviction that people are willing to cooperate, but this conviction is not blindly applied. Instead, the commons recognizes that people potentially may defect, and appropriate safeguards are thus adopted.
These considerations may seem to be simple at first glance. However, trust is not only a psychological phenomenon between persons; it is equally an _institutional_ phenomenon. Well-designed institutions foster personal trust, and inadequate institutions may stifle or even destroy personal trust. The "interface" between the social psychology of commons and the functionality of institutions is therefore extremely important. It is analogous to the human-computer interface, which may be more or less ergonomic.
Poorly designed institutions may be functional in principle, but the assertion of top-down authority may provoke resistance to perceived threats to freedom ("reactance" _sensu_ Brehm, 1966). Conversely, too little structural authority and too much benevolence may allow conflicts and defections to escalate, ultimately destroying the commons. Ostrom gives examples of village commons that failed because they did not have clear rules for the distribution of crops from the commons to individual offsprings (as opposed to distribution to families).
To put it bluntly as a first key insight: controls and sanctions are necessary components to protect the integrity of the commons.
From my point of view it is important that the members of the commons have a structural or systemic insight into the game-theoretic social dilemmas of commons. They should be aware that there is a potentially tremendous win-win situation, but they should also recognize that any win-win situation is extremely fragile and requires protection against defections.
The history of many failed commons demonstrates that stakeholders often do not see the potential win-win of collective action. They fail to appreciate scientific evidence and political analyses that say, "Take less and you will have more." They perceive that they will be better off if they defect – and indeed, that a failure to defect could jeopardize their survival, as in cases of very poor fishermen who desperately need food.
This leads to a second key insight: Commons can be successfully maintained only if stakeholders have substantial insight into a potential win-win constellation.
This is not only a cognitive problem, but also a problem of emotionally feeling the relevance of commoning as a solution for their circumstances.
Some history of modern commons, like open source projects, started with the fascination about the win-win that the community achieves through collaboration. For instance, Wikipedia started with some enthusiasm that "we," i.e., anybody in the world who wants to participate, "write our encyclopedia." In this case there was no lack of psychological commitment to a potential win-win, but there was a reluctance to accept certain institutional structures or impose sanctions and controls. But this reluctance gradually disappeared following increasing vandalism of the website and cheating in editorial submissions, e.g., self-serving content. At first glance, the idea of rules and sanctions may seem to contradict the idea of an open source project. In fact, such things are what guarantee its survival. Controls and sanctions are a necessary component of successful commons.
The point of rules, sanctions and member participation is to engender trust, a social phenomenon that is both psychological and institutional. Understanding and designing successful commons requires a keen consideration of the interplay between psychology and institutions, or what might be called "institutional ergonomics."
**References**
Brehm, Jack W. 1966. _Theory of Psychological Reactance_. Academic Press, New York.
Ostrom, Elinor. 1990. _Governing the Commons: The Evolution of Institutions for Collective Action_. Cambridge University Press, Cambridge, U.K.
—————. 2009. "Beyond Markets and States: Polycentric Governance of Complex Economic Systems," Nobel Prize lecture, available at http://www.nobelprize.org/nobel_prizes/economics/laureates/2009/ostrom-lecture.html.
**Martin Beckenkamp** _(Germany) is an environmental economics psychologist. He teaches at Cologne University and the BiTS Iserlohn and does his research at the Max Planck Institute for Research on Collective Goods in Bonn, currently on a project about biodiversity under the view of a socal dilemma. He lives in Bonn._
# The Structural Communality of the Commons
By Stefan Meretz
The commons are as varied as life itself, and yet everyone involved with them shares common convictions. If we wish to understand these convictions, we must realize what commons mean in a practical sense, what their function is and always has been. That in turn includes that we concern ourselves with people. After all, commons or common goods are precisely not merely "goods," but a social practice that generates, uses and preserves common resources and products. In other words, it is about the practice of commons, or commoning, and therefore also about us. The debate about the commons is also a debate about images of humanity. So let us take a step back and begin with the general question about living conditions.
Living conditions do not simply exist; instead, human beings actively produce them. In so doing, every generation stands on the shoulders of its forebears. Creating something new and handing down to future generations that which had been created before – and if possible, improved – has been part of human activity since time immemorial. The historical forms in which this occurred, however, have been transformed fundamentally, particularly since the transition to capitalism and a market economy. Although markets have existed for millennia, their function was not as central as they have become in contemporary capitalism, where they set the tone. They determine the rules of global trade. They organize interactions between producers and consumers across the world. Some observers believe they can recognize practices of the commons even in markets. After all, they say, markets are also about using resources jointly, and according to rules that enable markets to function in as unrestricted and unmanipulated ways as possible. However, markets are not commons, and it is worth understanding why.
Although markets are products of human action, their production is also controlled by markets, not by human action. It is no coincidence that markets are spoken of as if they were active subjects. We can read about what the markets are "doing" every day in the business pages. Markets decide, prefer and punish. They are nervous, lose trust or react cautiously. Our actions take place under the direction of the markets, not the other way around. Even a brief look at the rules mentioned above makes that clear. Rules issued by governments first recognize the basic principles of markets, but these rules function only as "add-ons" that are supposed to guide the effects of the markets in one direction or the other.
One direction may mean restricting the effects of the market so as to attain specific social goals. Viewed in this light, the supposedly alternative concept of a centrally planned economy turns out to be nothing more than a radical variant of guiding markets. The other direction can mean designing rules so that market mechanisms can flourish, in the hope that everyone is better off in the end if individuals pursue their own material self-interest. The various schools of economic thought reflect the different directions. They all take for granted the assumption that markets work, and that what matters is optimizing how they work. A common feature is that none of these standard schools of thought question markets themselves. That is why markets are at times described as "second nature" (Fisahn 2010) – a manifestation of nature and its laws that cannot be called into question, but only applied.
The habit of treating markets, and therefore also the economy, as quasi-natural beings prompted economist Karl Polanyi to speak of a reversal of the relationship between the social and the economic: "Instead of economy being embedded in social relations, social relations are embedded in the economic system" (Polanyi 1957). Before the onset of capitalism, only religious ritual acts were seen as having a life of their own in this way. The attitude was: "We cannot regulate god or the market, we can only attempt to secure their goodwill, perhaps plead or at times outwit them, but we can never get them under control." In the case of markets, it is the economic augurs of all kinds who take on the task of fathoming divine will. They are interpreters of the inevitable.
Markets are not commons – and vice versa. The fundamental principle of the commons is that the people who create the commons also create the rules for themselves. But are people able to do so? Isn't it better to trust in a mechanism that may be invisible and impersonal, but that is also generally valid, rather than trying to formulate and negotiate rules oneself? Now we are at the core of the differing concepts of humanity: the market position assumes _Homo economicus_ individuals maximizing their utility.1 These are isolated people who at first think only of themselves and their own utility. Only by trading on the market do they become social creatures. (1. See essay by Friederike Habermann.)
Now, it is not these isolated individuals who determine their social relations. As we saw above, they give themselves up to the workings of the markets, trying to derive benefits from them. To make it abundantly clear: isolated individuals submit to an anonymous power that is not their own by joining it and internalizing its logic. They then have the opportunity to create and confirm their individuality by means of consumption. Consumption is also the medium in which social life takes place. In other words, markets are not only places of distribution; they are places where people connect and develop identities. As consumption does not create true communality, and as many people feel isolated even in a group, the only way out of this dilemma is more consumption. Thus, consumption creates more and more consumption, which matches the producers' interests to sell more and more to consumers. It also perfectly serves the necessity of the capitalist economy to keep growing. However, consumers can never "buy our way out" of their social isolation. Markets are based on and continuously create structural isolation.
Structural isolation does not mean that we do not come together or cooperate. Yet in markets, cooperation always has the bitter flavor of competition as well.2 We cooperate so that we can hold our ground better in competitive situations. With the underlying necessity of competition, any cooperation on one side implies exclusion on the other. One company's success is another company's failure. One country's export surplus is another's trade deficit. One person's success in applying for a job means rejection of all the other candidates. One person's green card means another person's deportation. It is this aspect of markets which I call structural exclusion. Both aspects, structural isolation and exclusion, permeate our actions, thoughts and feelings like a gossamer web. They determine what people consider normal in everyday life. If a fish swims in endless circles in its bowl and has learned not to bump into the glass, seemingly automatically, it might falsely suppose it is enjoying the freedom of the ocean. If we are to withstand structural isolation and exclusion, we need places and forms of compensation. Besides consumption, which we have already mentioned, families and other social relationships play a central role here. Time and again, we can observe that people who lose their social relationships quickly end up in a situation of real isolation and exclusion. (See essay by Michel Bauwens.)
Structural isolation and exclusion entail another type of behavior, one I call structural irresponsibility. Hardly anyone wants to marginalize others, hardly anyone wants their own advantage to be paid for by others – yet this still takes place. Isolation and separateness in markets also mean that we cannot grasp the consequences of a purchase. Perhaps we have heard about people in the Congo working under extreme and inhumane conditions to extract coltan, from which tantalum for producing cellphones is extracted. But do we do without cellphones for this reason? And we have read about t-shirts being produced with child labor, but do we pay attention every time we buy one? Or environmental pollution caused by aluminum production – do we even know which products contain aluminum?
These are only a few of countless examples that show that it is virtually impossible to exercise personal responsibility under market conditions. Short of massive boycotts or public organizing, consumer purchases cannot alter the labor conditions and environmental effects of production; in this respect, money is an extremely poor means of communication. All of our after-the-fact attempts to contain the harmful consequences of market activity amount to a never-ending task, one that often fails, sometimes colossally – for instance, in limiting global CO2 emissions.
But that is not the only option, as the commons demonstrate. Here, people are connected to one another. They use common resources, devise rules to sustain or increase them, and find the social forms that fit best. The starting point is always the needs of the people involved, and those needs are never the same. In a commons, the implicit model of humanity is not about individuals' abstract equality, but rather their concrete uniqueness. People participate actively in the commons process with their rich individuality. Thus, the following is clear: if both the resources and the products are different, and if the people involved remain special individuals, then uniform rules cannot work. But that is not a problem in a commons because, in contrast to the market, the rules of a commons are made by the commoners themselves. It is no simple task to establish workable rules, and they may fail, but there are countless commons that do work, provided that certain conditions for success are taken into account.
Self-organization works if it is in fact self-determined. For this reason, an important aspect during the rule-making process is taking the participants' different needs into account – be it in form of consensus or compromise. It is critical that people feel a sense of fairness. Fairness is not the same thing as formal justice: It describes agreements that nobody feels they need intervene against. That, too, is different in the case of markets. Here, there is a system of equivalent trading that is formally just, because in an ideal market, assets of the same economic value change hands. But first, this holds only on average; individual cases can be unjust or even fraudulent.
Let us recall: People who maximize their own benefit do so at other people's expense, and those other people have to bear the burden. Second, equivalent trading means that different productivities may be expressed in the same prices, but in real terms, in different amounts of effort necessary to achieve the same price. Developing countries have to work much harder than industrialized ones for the same monetary yield. Is that fair? No. The market ignores differences; commons take them into account. What is more, the market pushes differences aside; commons thrive on them. If a few varieties of rice obtain the highest profit, then all other varieties of rice are displaced from the market. Participants in the commons, in contrast, are aware that diversity is not a flaw – an impediment to "maximizing value" – but a positive quality. It means more creativity, more variety, more opportunities for learning, a better quality of life.
Self-organization can fail. It is often unsuccessful if alien logic creeps into practices of the commons, and that can occur in very different ways. For example, if equal portions of a finite resource are made available for the people involved to use (formally just), then it may well be that individuals feel this arrangement to be unfair. This may be the case if the resource is of lesser quality, or if the needs of the people involved differ for reasons made transparent. Formally equal distribution must be augmented by additional criteria that are to be taken into account until everyone feels things are fair.
As soon as fairness is neglected, the danger arises that individual strategies for maximizing utility prevail. Then, market thinking enters into the commons. If one person begins to push through his or her individual goals at other people's expense, fairness is undermined to an ever greater degree. Others respond in kind, a downward spiral sets in, and in the end, self-organization fails. Market ideologues are aware of this effect and occasionally employ it in order to destroy commons. For example, in Peru (and elsewhere) the proposal was made to divide up land that had previously been used jointly and to distribute it to the indigenous population with individual titles of ownership – formally just, of course. Members of communities were to be transformed into isolated, utility-maximizing individuals. The indigenous population rejected this plan because they realized it would endanger their lifestyle.3 (3. See http://womblog.de/2011/05/27/peru-vorschlag-der-individuellen-landtitelvergabe-fr-indigene-stt-auf-kritik/ as well as the contribution by Dirk Löhr on the question of land in this volume.)
Commons work only if everybody is included in the community and nobody is excluded. They are based on cooperation, and they generate cooperation. They enable responsible action, and they require it. In this sense, the social practices of commons represent structural communality. Commons projects represent a practical rebuttal to the _Homo economicus_ paradigm. Nobody has to have certain characteristics in order to participate in commons projects, but many people change when they do. In commons, people can live as what they have actually always been: societal beings who jointly create their living conditions. In contrast to the logic of the market, individuals have nothing to gain from having their way at other people's expense. A central step in learning about practices of the commons is understanding that one's own needs are taken into account only if other people's needs are also part of the common activities. I call this aspect of the commons structural inclusion. The Ubuntu4 philosophy of the Zulu and Xhosa puts it in these words: "I am because you are, and I can be only if you are." (4. The word "ubuntu" roughly means humanity, loving one's neighbor and community spirit.)
Actually, this expresses something obvious. It seems so special to us because we have been trained from an early age to struggle as individuals against others. Selection determines our experiences at school; opportunities in life are allocated along with grades. We experience selection in markets when we need to sell our labor or our products. We experience selection when we are sick or old, when we worry about receiving appropriate care. Selection is the means of structural exclusion employed in the logic of the market. Whatever "doesn't make money" falls between the cracks.
To be sure, the commons have boundaries, and it must be decided who belongs and who does not. We have learned from Elinor Ostrom that drawing such boundaries is important – at least in the case of rival common resources.5 In a commons, there is a very different social logic at play than in market settings; the criteria for access and use may include one's local affiliations, contributions of labor and particular uses of the commons. For example, rules of open-access usage make sense for goods that are non-rival and not consumed or "used up" (such as collaborative websites like Wikipedia or free software programs); such rules help avoid underuse of the resource and the danger that they might be abandoned. In contrast, goods that are rival and consumptive, such as land, water or fisheries, require other sorts of rules because in such cases the problem is overuse, not underuse. (5. The concept of rivalry is explained by Silke.)
What is decisive in the success of a commons is which rules are recognized by the community as reasonable or necessary. Here, the primary question is not whether something pays off, but what sustains the commons and their resources so that everyone involved can benefit in the long term. The social form is valuable in and of itself, as social relationships are the decisive means for settling disputes. And conflicts are to be resolved in such a way that everyone feels that the process and its results are fair, as discussed above.
Thus, commons structurally generate responsibility on the part of their participants for preserving the resource and the collective relationships, while markets generally do not. Commoners are in charge of shaping the social relationships involved; therefore, they can take responsibility for their actions. However, this also entails their responsibility to do so. In the commons, it is possible to deal with conflicting goals and varying needs before taking action. In the market, however, action comes first, and then the consequences are dealt with later. The market is seldom capable of mediating between different needs and identifying responsible solutions because maximum profits is the touchstone for choice.
We are all aware of such paradoxes. We want to drive on a good road network without congestion, but object to having major roads pass by our front doors. We want environmentally friendly energy to replace nuclear power, but we object to windmills marring the landscape. We object to fish stocks being depleted, but want to purchase fresh and cheap fish. Different needs and goals conflict with one another, and the one that can mobilize the most market and political power will prevail. First, we create a fait accompli, then we have to suffer the consequences.
In the commons, people are capable of mediating between different needs and desires from the outset. Farmers can come to an understanding about joint usage of pastures in advance, and can do so time and again to avoid overexploitation of the common resource; fisherfolk can arrange for sustainable fishing quotas, in contrast to nation-states, each of which wants maximum usage for itself; free software projects can agree on programming priorities. Filmmaker Kevin Hansen speaks about commons cultivating a sense of overarching responsibility: "A commons approach innately presumes responsibility and rights for all. No one is left out. It is the responsibility of all commons trustees (effectively, this means everyone) to be responsible – even for those who do not speak.... T]his includes not only the young, elderly or disabled people who cannot speak for themselves. It also means the disenfranchised, the poor, the indigenous and other humans who have traditionally not had a significant voice in politics and economics."6 (6. [http://vimeo.com/25486271)
While including everyone is part of the logic of the commons in terms of principle and structure, such inclusion does not occur automatically, but must be implemented intentionally. The freedom to shape arrangements that exist in principle also entails a necessity to do so. That is different from market relationships, where rules are set externally and uniformly. Whichever option earns money prevails. In a commons, communities must themselves determine the rules appropriate for individual situations and for the people involved in them. In the process, the temptation to achieve gain at the expense of others, after all, is ubiquitous, coming from the logic of the market. Yet to the other, I am the other as well. If I prevail at the expense of others, they will do the same (or exclude me). That would be the beginning of a downward spiral, a development we know well. The company that lowers wages faster than others generates more jobs. The one that cuts benefits most can obtain credit in order to survive. That is the logic of the markets, where most people end up losing, and even the winners cannot be sure whether they themselves might be among the losers tomorrow. We can establish commons and their structural communality, inclusion and generation of responsibility on the part of their participants only in opposition to the logic of exclusion. That is never easy, but it is worth the effort.
**References**
Fisahn, Andreas. 2010. _Die Demokratie entfesseln, nicht die Märkte_ , PapyRossa.
Polanyi, Karl. 1957. _The Great Transformation._ Boston. Beacon.
**Stefan Meretz** _(Germany) is an engineer, computer scientist, and author who lives in Berlin. His publications focus on commons-based peer production and development of a free society beyond market and state. He blogs at www.keimform.de._
# The Logic of the Commons & the Market A Shorthand Comparsion of Their Core Beliefs
By Silke Helfrich
# First Thoughts for a Phenomenology of the Commons
_By Ugo Mattei_
The commons are not concessions. They are resources that belong to the people as a matter of life necessity. Everybody has a right of an equal share of the commons and must be empowered by law to claim equal and direct access to it. Everybody has equal responsibility to the commons and shares a direct responsibility to transfer its wealth to future generations. The commons radically oppose both the State and private property as shaped by market forces, and are powerful sources of emancipation and social justice. However, they have been buried by the dominant academic discourse grounded in scientific positivism. They need to be emancipated by an authentic shift in phenomenological perception in order to produce emancipation.
Social justice is pursued in Western democracies by the (currently declining) institutions of the Welfare State. Access to social justice programs is usually understood as provided by "rights of second generation," which require a specific obligation of the State to respect and guarantee them.
This vision, which places the specific burden of satisfying social rights on the government, has been central to the evolution of Western jurisprudence. Since the Scientific Revolution and the Reformation, social justice has been expelled from the core domain of private law. The Scholastic notion of law in the 16th century – which was based on two concepts of justice, distributive justice and commutative justice – was abandoned at the outset of modern Western jurisprudence. Starting with Grotius in the 17th century, concerns over justice were equated to issues of fairness in contractual exchanges between individuals. Distribution was seen as applying to the whole society and not just to its parts, and was assumed as a social fact. Thus the concerns of distributive justice were expelled from legal science.
Another significant change occurred in the seventeenth century with the so-called scientific revolution, which gave rise to the paradigm of positivism and the dominant wisdom of modernity (Capra 2009). According to this vision, facts must be separated from values, the world of the "is" being clearly different from that of the "ought to be." Economics, developed as an autonomous branch of knowledge in the 18th century, shares such a vision (Blaug 1962). Distribution is considered entirely in the domain of political values (ought to be) rather than measurable facts (is). Consequently, issues related to how resources should be distributed in a just society have been expelled not only from the law but also from the self-proclaimed scientific discourse of economics.
Distributive justice thus became a matter of politics to be dealt with (if at all) by State institutions of public law and by regulation. The birth of the Welfare State in the early 20th Century was considered as an exceptional intervention into the market order by regulation mainly through taxes, with the specific aim to guarantee some social justice to the weaker members of society. In the West, since then, social justice was never able to capture again the core of rights discourse, and consequently has remained at the mercy of fiscal crisis: no money, no social rights! (Mattei & Nicola 2006).
The concept of the commons can provide exactly the necessary tools, both legally and politically, to address the incremental marginalization of social justice. Being outside of the State/Market duopoly, the commons, as an institutional framework, presents an alternative legal paradigm, providing for more equitable distribution of resources. If properly theorized and politically perceived, the Commons can serve the crucial function of reintroducing social justice into the core of the legal and economic discourse by empowering the people to direct action.
**Seeing the commons**
The current vision presents the opposition between "the public" (the domain of the government) and "the private" (the domain of the market and of private property) as exhausting all the range of possibilities in a sort of zero-sum game. This gridlocked opposition is a product of the modernist tradition still dominant today in law and in economics. It hides the commons from the public vision.
The commons provide services that are often taken for granted by their users: many of those who benefit from the commons do not take into account their intrinsic value, only acknowledging it once the commons are destroyed and substitutes need to be found. To some extent, the commons are similar to household work, never noticed when the work is being done. Only when no one is there to do the dishes, you notice its value. In other words you don't miss something until it is gone. An example is the role served by mangroves in coastal regions. When making development decisions, people take their existence for granted and simply do not consider their important role in protecting coastal villages from tsunami waves. Only when a tsunami hits, destroying villages, does the value of such vegetation becomes apparent (Brown 2009). It would be highly expensive to build a similar, artificial barrier.
Seeing the commons and fully appreciating their role in the ecology of life on earth is politically crucial and an absolute necessity for any serious scholarly endeavor. The commons cannot be circumscribed for purposes of analysis; they claim a fully holistic approach. This is why dominant social sciences, having internalized the zero-sum vision of market and government, are ill-equipped to grapple with the issue.
It could be said that the commons disappear as a result of their structural incompatibility with the deepest aspects of the Western "legality," a legality that is founded on the universalizing combination of individualism with the State/private property dichotomy. Centuries before the birth of the modern State, in ancient Rome, the early clans routinely extended their landholdings by usurping the commons. Engels describes the privatization of the commons as the most fundamental economic pattern of European development. Thus Western law has served a very important role in destroying the commons, certainly not in protecting them. This still seems to be the pattern of development in cognitive capitalism (Boyle 2003): think about prosecution of peer–to–peer exchange on the Internet.
But it has always been problematic for commoners to find someone that would represent them in court, to sue those who try to seize the commons. Both historically and today, those who benefit most from the commons are not "owners" in the technical sense, but usually poor farmers (or today young Internet surfers) with no means of accessing the court system. Let's remember how easily farmers in England fell victim to enclosures in the first, crucial phase of early capitalism, which provided the necessary proletarian workforce for the rising manufacturers. Enclosures and violent recruitment of dispossessed peasants to become a capitalist workforce would simply have been impossible without the fundamental alliance between private ownership and the State (Tigar 1977).
The dominant vision of the commons as a poorly theorized exception to _either_ market _or_ government is rooted at the very origins and in the very structure of the dominating Western vision of the law. That is how a social fact becomes real.
**Piercing the veil of the market-state dichotomy**
Private property and the State are the two major legal and political institutions that carry on the dominant view of the world. But the state versus private debate presents a false dichotomy, a distinction without a difference. The state is no longer the democratic representation of the aggregate of individuals, but instead a market actor among many. The collusion or merger of state and private interests, with the same actors (corporations) on both sides of the equation, leaves little room for a "commons" framework, no matter how convincing the evidence about the benefits may be.
Conventional wisdom presents the market and the state as radically conflicting. It assumes, in a cryptic way, that they have a zero-sum relationship: more state is equal to less market and less market is equal to more state. In this reductive scheme, the state and private property become quintessential of public and private poles of opposition. Of course this picture is totally false on both historical and modern levels because the two entities, as social and living institutions, can only be structurally linked in a relationship of mutual symbiosis. The fabricated, clear-cut opposition between the two reflects the ideological choice of the individualistic tradition. This conflict emerged at the very origins of liberal individualism, as seen in Locke and Hobbes, the two champions, respectively, of private property and of State sovereignty.
This reduction hides a shared structure of property (market) and sovereignty (state) based on the concentration of power. Private structures (corporations) concentrate their decisionmaking and power of exclusion in the hands of one subject (the owner) or within a hierarchy (the CEO). Similarly, public structures (bureaucracies) concentrate power at the top of a sovereign hierarchy. Both archetypes are inserted into a fundamental structure: the rule of a subject (an individual, a company, the government) over an object (a private good, an organization, a territory). Such pretended opposition between two domains that share the same structure is the result of modern Cartesian reductionist, quantitative, and individualistic thought.
The individual subject left alone, narcissistic and wanting, finds in products, commodities, and external objects the satisfaction of his desires. This impoverished relational horizon, which has produced our alienation from nature ("we own it therefore we are not part of it") is scientifically constructed as "objective" and measured by a system of prices to be paid for the satisfaction of various increasingly complex "needs." The typical individualistic "fiction" of the liberal tradition, e.g., the myth of Robinson Crusoe, induces market needs by erasing consciousness of the communitarian experience. The more needs the lonely individual has, the more money can be collected to satisfy them. Thus the qualitative paradigm based on meaningful relationships submits to a quantitative one.
Unfortunately, ecology and "systemic" thinking – the paradigms that could reveal the devastating impact of individualistic accumulation on community life – are notably absent in contemporary politics, in part because it looks to the "social sciences" (particularly microeconomics, political science and marketing) as its only repository of ideas. Contrary to microbiologist Garrett Hardin's famed phrase, the "tragedy of the commons" (Hardin 1968) – "a commons is a place of no law and therefore ruin" – state and market mechanisms that rely on the "individual" as its object are in fact the culprits of this ruin today (Feeney et al. 1990).
**Two world views in conflict competition versus cooperation**
Individual selfishness is the central assumption underpinning Hardin's analysis. Only the crude application of the model of _Homo economicus_ explains the results (and academic success) of the so-called "tragedy of the commons." _Homo economicus_ originated in the work of John Stuart Mill and was brought into mainstream political economy in the 18th century by Adam Smith and David Ricardo, both of whom focused on individuals as maximizers of short-term utility. Hardin's "tragedy" parable continued this tradition when it cast the commons as a place of no law. According to Hardin, a common resource, as freely appropriable, stimulates the opportunistic individual behavior of accumulation and ultimately destructive and "inefficient" consumption. This reasoning conjures up the image of a person invited to a buffet where food is freely accessible, and rather than sharing the bounty with others, rushes to try to maximize the amount of calories that can be stored at the expense of others, efficiently consuming the largest possible amount of food in the least possible time.
The "tragedy of the commons" highlights two worldviews in conflict. The dominant worldview is substantially social Darwinism, which makes "competition," "struggle," and "emulation" between physical and legal persons the essence of reality. The recessive worldview, an ecological and holistic understanding of the world, is based on relationships, cooperation and community. This model, still present in the organization of communities in the "periphery," continues to suffer a merciless assault by the structural adjustment and comprehensive "modernization" and "development" plans of the World Bank and International Monetary Fund. As many of the articles in this volume testify, such efforts encourage the "commodification" of land, and of local knowledge, as well as cultural adjustments (imposition of human rights, rule of law, gender equality, etc.) that serve as a justifying rhetoric for continuity in plunder (Mattei & Nader 2008).
Elinor Ostrom and her team of social scientists successfully amassed an overwhelming amount of empirical evidence to show that cooperative property arrangements are in fact successful and that individuals do not necessarily destroy their common-pool resources. Ostrom's work undeniably marks a critical turning point in economic theory. It refuted Hardin's tragedy, but it failed to notice that corporations and States, if not individuals, behave in ways that nonetheless produce tragedy. Without consideration of the fierce historical, political, and legal struggle between commoners on the one hand and the unholy alliance between the State and private property (capital) on the other, Ostrom's findings remain limited in their applicability.
The so-called "original accumulation" described by Marx has been an institutional phenomenon carried on by an alliance between centralized State structures and a concentration of capital by private property and corporate structures. This process has victimized the ordinary ("non-institutional") human being, and has produced and ideologically justified a process of brutal institutional exploitation of the multitudes by the few. Such a phenomenon was by no means limited to the "enclosure" laws of England. The _terra nullius_ doctrines endorsed by John Locke and other scholars during the period of colonial expansion overseas confirm the institutional nature of "tragedy-producing" behavior (Mattei and Nader 2008). Natives were all but denied human condition (were "reduced" to a natural state) because they did not adopt the civilizing institution of private property. In more recent times, the patterns of domination, institutional settings, and narratives of enclosure have taken on more subtle forms, but continue to enclose the commons.
Hardin's parable maintains tremendous predictive power despite Ostrom's critique and all its own intellectual shortcomings, e.g., that the common is a place of no law, precisely because as a rule "mere humans," acting outside of the institutional context of modernity, do respect the commons. Meanwhile, "institutional humans" operating via States and corporations continue to produce tragic outcomes. Thus the panoply of Ostrom's examples of flesh-and-blood individuals who cooperate rather than compete, seems impotent to undermine Hardin's argument. The examples do not take adequate account of the institutional realities and the actual power structures in which decision-making occurs. Indeed, Ostrom's critique of the tragedy of the commons risks shifting attention away from the problem and shielding powerful economic and political actors from responsibility for "tragedies."
Often, scholars accept the specious dichotomy between state and market, as discussed above, and so decline to develop a deeper phenomenological understanding of the commons that could make a radical break from the discourse of commodification. Understanding commons as commodities actually limits our understanding of the many types of commons (natural, social, cultural, knowledge-based, historical) and blunts their revolutionary potential and legitimate claims for a radical, egalitarian redistribution of resources. Much of the literature on the commons should be thoroughly and critically examined so as to avoid reproducing the traditional mechanistic view, the separation between object and subject, and resulting commodification (Rota 1991).
**Rehabilitating the common sense**
A phenomenological understanding of the commons forces us to move beyond the reductionist opposition of "subject-object," which produces the commodification of both. It helps us understand that, unlike private and public goods, commons are not commodities and cannot be reduced to the language of ownership. They express a qualitative relation. It would be reductive to say that we have a common good. We should rather see to what extent we are the commons, in as much as we are part of an environment, an urban or rural ecosystem. Here, the subject is part of the object. For this reason commons are inseparably related and link individuals, communities, and the ecosystem itself.
This holistic revolution has ancient roots, from Aristotle's ontological investigations to later philosophers like Husserl and Heidegger, who employed concepts such as "fundierung" (Heidegger 1962) and "relevance" to signal the end of an "objective" world where subjects are separate from their objects of observation and individuals are separate from their very environment. New holistic attitudes have emerged, also, in the natural sciences through physics and systems biology, which are based on the qualitative mapping of relationships, rather than on quantitative measurements and the positivistic reductionism of Galileo, Descartes, and Newton (Capra 2004). Quantum mechanics in particular, and Einstein's relativity, have caused an epistemological revolution that disciplines such as cognitive science and consciousness studies are attempting to address. Despite the richness of the holistic revolution in these disciplines, this revolution has yet to be embraced in the social sciences.
The commons can be described only from a phenomenological and holistic perspective, which is incompatible with the above-mentioned reductionism and with the idea of individual autonomy as developed in the rights-based capitalistic tradition. In this respect, commons are an _ecological-qualitative_ category based on inclusion, access and community duties, whereas property and State sovereignty are _economical-quantitative _categories based on exclusion (produced scarcity): a rhetoric of individual-centered rights and the violent concentration of power into a few hands.
These insights require the jurists to address the difficult and urgent task of constructing the foundations of a new legal order capable of transcending the dualisms (property/State, subject/object, public/private) inherent in the current order. The new order must overcome the dominance of private property, individualism, and competition, and focus on the collective and the commons. The challenge is to create an institutional setting that can enable long-term sustainability and full inclusion of all global commoners, including the poorest and most vulnerable. To do so we need first an epistemic (and political) emancipation from the predatory appetites of both the State and private property, the two fundamental components of the dominant Western wisdom.
**A political shift**
Today we can see from examples all around us – from global warming to the economic collapse – that the commons offers us a fundamental and necessary shift in the perception of reality. In this context the commons help us reject the illusions of modern liberalism and rationalism. This is why we cannot settle for seeing the "commons" as a mere third way between private property and the state, as most of the current debate seems to suggest. The commons cannot be reduced to managing the leftovers of the Western historical banquet, which is the preoccupation of the contemporary political scene. To the contrary, we believe that the commons must be elevated as an institutional structure that genuinely questions the domains of private property, its ideological apparatuses and the State – not a third way but a challenge to the alliance between private property and the state.
The shift that we need to accomplish not only theoretically but also politically, is to change the dominant wisdom – from the absolute domination of the subject (as owner or State) over the object (territory or environment) – to a focus on the relationship of the two (subject-nature). We need a new common sense that recognizes that each individual's survival depends on his/her relationship with others, with the community, and with the environment. The first necessary shift to a holistic vision requires a reorientation away from quantity (a fundamental idea of the scientific revolution and of capitalist accumulation) to quality.
A legal system based on the commons must use the "ecosystem" as a model, where a community of individuals or social groups is horizontally linked and power is dispersed. It must generally reject the idea of hierarchy in favor of a participatory and collaborative model, one that prevents the concentration of power and puts community interests at the center. Only in such a framework can social rights actually be satisfied. In this logic, a commons is not a mere resource (water, culture, the internet, land, education), but rather a shared conception of reality that radically challenges the seemingly unstoppable trend of enclosure and corporatization.
Even today, despite the dramatic crisis of 2008, State intervention, dubbed Keynesian policy, has served to transfer massive amounts of public money to the private sector. The logic of plunder shared by both the private and the state sector could not be more open. What we need is rather a very large extension of the commons framework: "less government, less market, more commons." This is, I believe, the only way to resurrect an alternative narrative of social inclusion.
**References**
Blaug, Mark. 1962. _Economic Theory in Retrospect_ , 1st ed.
Capra, Fritjof. 2004. _The Web of Life. A New Scientific Understanding of Living Systems._
Heidegger, Martin. 1962. _Being and Time._ John Macquarrie and Edward Robinson, translators.
Mattei, Ugo & Nader, Laura. 2008. _Plunder. When The Rule of Law is Illegal._
Mattei, Ugo & Nicola, Fernanda. 2006. "A Social Dimension in European Private Law? The Call for Setting a Progressive Agenda." 45 _New England_ _L. R._ 1-66
Mattei Ugo. 2011. _Beni comuni. Un manifesto._ Laterza, Bari, Roma.
Boyle, James. 2003. "The Second Enclosure Movement and the Construction of the Public Domain." In 66 _Law and Contemporary Problems_ 33-75.
Brown, Lester R. 2009. _Plan B 4.0. Mobilizing to Save Civilization_. New York, NY: Norton.
Feeney, David and Berkes, Fikret and McCay, Bonnie J. and Acheson, James M. 1990. "The Tragedy of the Commons: Twenty-two years Later." _Human Ecology._ 18(1).
Hardin, Garrett. 1968. "The Tragedy of the Commons." _Science_ (December 13, 1968): 1243-1248.
Rota, Gian Carlo. 1991. _The End of Objectivity. The Legacy of Phenomenology, Lectures at MIT, 1974- 1991._ Second Preliminary Edition, in collaboration with Sean Murphy and Jeff Thompson.
Tigar, Michael. 1977. _Law and the Rise of Capitalism_. New York, NY. Monthly Review Press.
**Ugo Mattei** _(Italy) is a professor of law in Turin and U.C. Hastings. He is the author, with Laura Nader of_ Plunder, When The Rule of Law is Illegal, _and most recently_ Bene Comuni: Un Manifesto _. He has been a lead promoter of the Italian referendum against privatization of water with more than 27 million votes mobilized around the idea "water is a common." He is the Academic Coordinator of the International University College of Turin (www.iuctorino.it), whose main focus is the multidisciplinary study of the commons._
# Feminism and the Politics of the Commons
_By Silvia Federici_
_Reproduction precedes social production. Touch the women, touch the rock_.1
– Peter Linebaugh
(1. Linebaugh, Peter. 2008. _The Magna Carta Manifesto: Liberty and Commons for All._ Berkeley, CA. University of California Press.)
At least since the Zapatistas took over the zócalo in San Cristobal de las Casas on December 31, 1993, to protest legislation dissolving the ejidal lands of Mexico, the concept of "the commons" has been gaining popularity.2 There are important reasons why this apparently archaic idea has come to the center of political discussion in contemporary social movements. Two in particular stand out. On one side is the demise of the statist model of revolution that for decades had sapped the efforts of radical movements to build an alternative to capitalism. On the other hand, the defense against "old and new enclosures" have made visible a world of communal properties and relations that many had believed to be extinct or had not valued until threatened with privatization.3 Ironically, these enclosures have demonstrated that not only has the commons not vanished, but also new forms of social cooperation are constantly being produced, including in areas of life where none previously existed like, for example, the Internet. The idea serves an ideological function as a unifying concept prefiguring the cooperative society that many are striving to create. Nevertheless, ambiguities as well as significant differences remain in the interpretations of this concept, which we need to clarify if we want the principle of the commons to translate into a coherent political project.4 (2. A key source on the politics of the commons and its theoretical foundations is the UK-based electronic journal The Commoner, now entering its fourteenth year of publication (www.commoner.org.uk). See also the essay by Gustavo Esteva in this book. 3. A case in point is the struggle that is taking place in many communities in Maine against Nestlé's appropriation of Maine's waters to bottle Poland Spring. Nestlé's theft has made people aware of the vital importance of these waters and the supporting aquifers and has truly reconstituted them as a common (Food and Water Watch Fact Sheet, July 2009). Food and Water Watch is a self-described "non-profit organization that works to ensure clean water and safe food in the United States and around the world." (4. An excellent site for current debates on the commons is the recently published issue of the UK based movement journal _Turbulence. Ideas For Movement_ (see December 5, 2009 issue), available at http://turbulence.org.uk)
What, for example, constitutes a common? We have land, water, air commons, digital commons; our acquired entitlements, e.g., social security pensions, are often described as commons, and so are languages, libraries, and the collective products of past cultures. But are all these commons equivalent from the viewpoint of their political potential? Are they all compatible? And how can we ensure that they do not project a unity that remains to be constructed? Finally, should we speak of "commons" in the plural, or "the common," as Autonomist Marxists propose we do, this concept designating in their view the social relations characteristic of the dominant form of production in the post-Fordist era?
With these questions in mind, in this essay I look at the politics of the commons from a feminist perspective where "feminist" refers to a standpoint shaped by the struggle against sexual discrimination and over reproductive work, which, to paraphrase Linebaugh's comment above, is the rock upon which society is built and by which every model of social organization must be tested. This intervention is necessary, in my view, to better define this politics and clarify the conditions under which the principle of the common/s can become the foundation of an anti-capitalist program. Two concerns make these tasks especially important.
First, since at least the early 1990s, the language of the commons has been appropriated for instance by the World Bank and put at the service of privatization. Under the guise of protecting biodiversity and conserving the global commons, the Bank has turned rainforests into ecological reserves, has expelled the populations that for centuries had drawn their sustenance from them, while ensuring access to those who can pay, for instance, through eco-tourism.5 The World Bank is not alone in its adaptation of the idea of the commons to market interests. Responding to different motivations, a revalorization of the commons has become trendy among mainstream economists and capitalist planners; witness the growing academic literature on the subject and its cognates: social capital, gift economies, altruism. (5. For more on this subject, see the important article, "Who Pays for the Kyoto Protocol?" by Ana Isla, in which the author describes how the conservation of biodiversity has provided the World Bank and other international agencies with the pretext to enclose rainforests on the ground that they represent "carbon sinks" and "oxygen generators." In Salleh. 2009.)
The extension of the commodity form to every corner of the social factory, which neo-liberalism has promoted, is an ideal limit for capitalist ideologues, but it is a project not only unrealizable but undesirable from the viewpoint of long-term reproduction of the capitalist system. Capitalist accumulation is structurally dependent on the free appropriation of immense quantities of labor and resources that must appear as externalities to the market, like the unpaid domestic work that women have provided, upon which employers have relied for the reproduction of the workforce. It is no accident, then, that long before the Wall Street meltdown, a variety of economists and social theorists warned that the marketization of all spheres of life is detrimental to the market's well-functioning, for markets too, the argument goes, depend on the existence of non-monetary relations like confidence, trust, and gift giving.6 In brief, capital is learning about the virtues of the common good. (6. Bollier, David. 2002. _Silent Theft: The Private Plunder of Our Common Wealth_. New York and London: Routledge. 36–39. )
We must be very careful, then, not to craft the discourse on the commons in such a way as to allow a crisis-ridden capitalist class to revive itself, posturing, for instance, as the environmental guardian of the planet.
A second concern is the unanswered question of how commons can become the foundation of a non-capitalist economy. From Peter Linebaugh's work, especially _The Magna Carta Manifesto_ (2008), we have learned that commons have been the thread that has connected the history of the class struggle into our time, and indeed the fight for the commons is all around us. Mainers are fighting to preserve access to their fisheries, under attack by corporate fleets; residents of Appalachia are organizing to save their mountains threatened by strip mining; open source and free software movements are opposing the commodification of knowledge and opening new spaces for communications and cooperation. We also have the many invisible, commoning activities and communities that people are creating in North America, which Chris Carlsson has described in his _Nowtopia_ (2007). As Carlsson shows, much creativity is invested in the production of "virtual commons" and forms of sociality that thrive under the radar of the money/market economy.
Most important has been the creation of urban gardens, which have spread across the country, thanks mostly to the initiatives of immigrant communities from Africa, the Caribbean or the South of the United States. Their significance cannot be overestimated. Urban gardens have opened the way to a "rurbanization" process that is indispensable if we are to regain control over our food production, regenerate our environment and provide for our subsistence. The gardens are far more than a source of food security. They are centers of sociality, knowledge production, and cultural and intergenerational exchange.7 [....] (7. An early, important work on urban gardens is Bill Weinberg and Peter Lamborn Wilson, eds. 1999. _Avant Gardening: Ecological Struggle in the City & the World_. Brooklyn, NY: Autonomedia. See also the essay by Christa Müller in this book. )
The most significant feature of urban gardens is that they produce for neighborhood consumption, rather than for commercial purposes. This distinguishes them from other reproductive commons that either produce for the market, like the fisheries of Maine's "Lobster Coast,"8 or are bought on the market, like the land trusts that preserve open spaces. The problem, however, is that urban gardens have remained a spontaneous grassroots initiative and there have been few attempts by movements in the US to expand their presence and to make access to land a key terrain of struggle.... (8. The fishing commons of Maine are presently threatened with a new privatization policy justified in the name of preservation and ironically labeled "catch shares." This is a system, already applied in Canada and Alaska, whereby local governments set limits on the amount of fish that can be caught by allocating individual shares on the basis of the amount of fishing that boats have done in the past. This system has proven to be disastrous for small, independent fishermen who are soon forced to sell their share to the highest bidders. Protest against its implementation is now mounting in the fishing communities of Maine. See "Cash Shares or Share-Croppers?" _Fishermen's Voice_ , Vol. 14, No.12, December 2009.)
**Women and the Commons**
More generally, the left has not posed the question of how to bring together the many proliferating commons that are being defended, developed and fought for so that they can form a cohesive whole and provide a foundation for a new mode of production. It is in this context that a feminist perspective on the commons is important because it begins with the realization that, as the primary subjects of reproductive work, historically and in our time, women have depended on access to communal natural resources more than men and have been most penalized by their privatization and most committed to their defense.
As I wrote in _Caliban and the Witch_ (2004), in the first phase of capitalist development, women were at the forefront of the struggle against land enclosures both in England and in the "New World" and they were the staunchest defenders of the communal cultures that European colonization attempted to destroy. In Peru, when the Spanish conquistadores took control of their villages, women fled to the high mountains where they recreated forms of collective life that have survived to this day. Not surprisingly, the sixteenth and seventeenth centuries saw the most violent attack on women in the history of the world: the persecution of women as witches. Today, in the face of a new process of Primitive Accumulation, women are the main social force standing in the way of a complete commercialization of nature, supporting a non-capitalist use of land and a subsistence-oriented agriculture. Women are the subsistence farmers of the world. In Africa, they produce 80 percent of the food people consume, despite the attempts made by the World Bank and other agencies to convince them to divert their activities to cash-cropping. In the 1990s, in many African towns, in the face of rising food prices, they have appropriated plots in public lands and planted corn, beans, cassava along roadsides... in parks, along rail-lines **,** changing the urban landscape of African cities and breaking down the separation between town and country in the process.9 In India, the Philippines, and across Latin America, women have replanted trees in degraded forests, joined hands to chase away loggers, made blockades against mining operations and the construction of dams, and led the revolt against the privatization of water.10 (9. Donald B. Freeman, "Survival Strategy or Business Training Ground? The Significance of Urban Agriculture For the Advancement of Women in African Cities." _African Studies Review_ , 36(3) (December 1993): 1-22. Also, Federici 2008. 10. Shiva 1989, 1991:102–117, 274. )
The other side of women's struggle for direct access to means of reproduction has been the formation across the Third World, from Cambodia to Senegal, of credit associations that function as money commons (Podlashuc 2009). Differently named, the tontines (as they are called in parts of Africa) are autonomous, self-managed, women-made banking systems that provide cash to individuals or groups that have no access to banks, working purely on a basis of trust. In this, they are completely different from the microcredit systems promoted by the World Bank, which function on a basis of mutual policing and shame, reaching the extreme, e.g., in Niger, of posting in public places pictures of the women who fail to repay the loans, so that some women have been driven to suicide.11 (11. I owe this information to Ousseina Alidou, Director of the Center for African Studies at Rutgers University (NJ).)
Women have also led the effort to collectivize reproductive labor both as a means to economize the cost of reproduction and to protect each other from poverty, state violence, and the violence of individual men. An outstanding example is that of the ollas communes (common cooking pots) that women in Chile and Peru set up in the 1980s when, due to stiff inflation, they could no longer afford to shop alone (Fisher 1993; Andreas 1985). Like land reclamations, or the formation of tontines, these practices are the expression of a world where communal bonds are still strong. But it would be a mistake to consider them something pre-political, "natural," or simply a product of "tradition." After repeated phases of colonization, nature and customs no longer exist in any part of the world, except where people have struggled to preserve them and reinvent them. As Leo Podlashuc has noted, grassroots women's communalism today leads to the production of a new reality, it shapes a collective identity, it constitutes a counter-power in the home and the community, and opens a process of self-valorization and self-determination from which there is much that we can learn.
The first lesson we can gain from these struggles is that the "commoning" of the material means of reproduction is the primary mechanism by which a collective interest and mutual bonds are created. It is also the first line of resistance to a life of enslavement and the condition for the construction of autonomous spaces undermining from within the hold that capitalism has on our lives. Undoubtedly the experiences I described are models that cannot be transplanted. For us, in North America, the reclamation and commoning of the means of reproduction must necessarily take different forms. But here too, by pooling our resources and re-appropriating the wealth that we have produced, we can begin to de-link our reproduction from the commodity flows that, through the world market, are responsible for the dispossession of millions across the world. We can begin to disentangle our livelihood not only from the world market but also from the war machine and prison system on which the US economy now depends. Not last we can move beyond the abstract solidarity that so often characterizes relations in the movement, which limits our commitment, our capacity to endure, and the risks we are willing to take.
In a country where private property is defended by the largest arsenal of weaponry in the world, and where three centuries of slavery have produced profound divisions in the social body, the recreation of the common/s appears as a formidable task that could only be accomplished through a long-term process of experimentation, coalition building and reparations. But though this task may now seem more difficult than passing through the eye of a needle, it is also the only possibility we have for widening the space of our autonomy, and refusing to accept that our reproduction occurs at the expense of the world's other commoners and commons.
**Feminist Reconstructions**
What this task entails is powerfully expressed by Maria Mies when she points out that the production of commons requires first a profound transformation in our everyday life, in order to recombine what the social division of labor in capitalism has separated. For the distancing of production from reproduction and consumption leads us to ignore the conditions under which what we eat, wear, or work with have been produced, their social and environmental cost, and the fate of the population on whom the waste we produce is unloaded (Mies 1999). In other words, we need to overcome the state of irresponsibility concerning the consequences of our actions that results from the destructive ways in which the social division of labor is organized in capitalism; short of that, the production of our life inevitably becomes a production of death for others. As Mies points out, globalization has worsened this crisis, widening the distances between what is produced and what is consumed, thereby intensifying, despite the appearance of an increased global interconnectedness, our blindness to the blood in the food we eat, the petroleum we use, the clothes we wear, and the computers we communicate with.
Overcoming this state of oblivion is where a feminist perspective teaches us to start in our reconstruction of the commons. No common is possible unless we refuse to base our life and our reproduction on the suffering of others, unless we refuse to see ourselves as separate from them. Indeed, if commoning has any meaning, it must be the production of ourselves as a common subject. This is how we must understand the slogan "no commons without community." But "community" has to be intended not as a gated reality, a grouping of people joined by exclusive interests separating them from others, as with communities formed on the basis of religion or ethnicity, but rather as a quality of relations, a principle of cooperation and of responsibility to each other and to the earth, the forests, the seas, the animals.
Certainly, the achievement of such community, like the collectivization of our everyday work of reproduction, can only be a beginning. It is no substitute for broader antiprivatization campaigns and the reclamation of our common wealth. But it is an essential part of our education to collective government and our recognition of history as a collective project, which is perhaps the main casualty of the neoliberal era of capitalism.
On this account, we too must include in our political agenda the communalization of housework, reviving that rich feminist tradition that in the US stretches from the utopian socialist experiments of the mid-nineteenth century to the attempts that "materialist feminists" made from the late nineteenth century to the early twentieth century to reorganize and socialize domestic work and thereby the home and the neighborhood, through collective housekeeping – attempts that continued until the 1920s when the Red Scare put an end to them (Hayden 1981 and 1986). These practices and, most importantly, the ability of past feminists to look at reproductive labor as an important sphere of human activity not to be negated but to be revolutionized, must be revisited and revalorized.
One crucial reason for creating collective forms of living is that the reproduction of human beings is the most labor-intensive work on earth and, to a very large extent, it is work that is irreducible to mechanization. We cannot mechanize childcare, care for the ill, or the psychological work necessary to reintegrate our physical and emotional balance. Despite the efforts that futuristic industrialists are making, we cannot robotize care except at a terrible cost for the people involved. No one will accept nursebots as caregivers, especially for children and the ill. Shared responsibility and cooperative work, not given at the cost of the health of the providers, are the only guarantees of proper care. For centuries, the reproduction of human beings has been a collective process. It has been the work of extended families and communities on which people could rely, especially in proletarian neighborhoods, even when they lived alone so that old age was not accompanied by the desolate loneliness and dependence on which so many of our elderly live. It is only with the advent of capitalism that reproduction has been completely privatized, a process that is now carried to a degree that it destroys our lives. This trend must be reversed, and the present time is propitious for such a project.
As the capitalist crisis destroys the basic elements of reproduction for millions of people across the world, including in the United States, the reconstruction of our everyday life is a possibility and a necessity. Like strikes, social/economic crises break the discipline of wage work, forcing new forms of sociality upon us. This is what occurred during the Great Depression, which produced a movement of hobos who turned the freight trains into their commons, seeking freedom in mobility and nomadism (Caffentzis 2006). At the intersections of railroad lines, they organized hobo jungles, pre-figurations, with their self-governance rules and solidarity, of the communist world in which many of the hobos believed (Anderson 1998, Depastino 2003 and Caffentzis 2006). However, but for a few Boxcar Berthas,12 this was predominantly a masculine world, a fraternity of men, and in the long term it could not be sustained. Once the economic crisis and the war came to an end, the hobos were domesticated by the two great engines of labor power fixation: the family and the house. Mindful of the threat of working class recomposition during the Depression, American capital excelled in its application of the principle that has characterized the organization of economic life: cooperation at the point of production, separation and atomization at the point of reproduction. The atomized, serialized family house that Levittown provided, compounded by its umbilical appendix, the car, not only sedentarized the worker but put an end to the type of autonomous workers' commons that hobo jungles had represented (Hayden 1986). Today, as millions of Americans' houses and cars are being repossessed, as foreclosures, evictions, and massive loss of employment are again breaking down the pillars of the capitalist discipline of work, new common grounds are again taking shape, like the tent cities that are sprawling from coast to coast. This time, however, it is women who must build the new commons so that they do not remain transient spaces, temporary autonomous zones, but become the foundation of new forms of social reproduction. (12. _Boxcar Bertha_ (1972) is Martin Scorsese's adaptation of Ben Reitman's Sister of the Road, "the fictionalized autobiography of radical and transient Bertha Thompson." (Wikipedia) See Reitman, Ben. 2002. _Dr. Sister of the Road: The Autobiography of Boxcar Bertha._ Oakland, CA. AK Press.)
If the house is the _oikos_ on which the economy is built, then it is women, historically the house workers and house prisoners, who must take the initiative to reclaim the house as a center of collective life, one traversed by multiple people and forms of cooperation, providing safety without isolation and fixation, allowing for the sharing and circulation of community possessions, and, above all, providing the foundation for collective forms of reproduction. As has already been suggested, we can draw inspiration for this project from the programs of the nineteenth century materialist feminists who, convinced that the home was an important "spatial component of the oppression of women," organized communal kitchens, cooperative households calling for workers' control of reproduction (Hayden 1981).
These objectives are crucial at present. Breaking down the isolation of life in the home is not only a precondition for meeting our most basic needs and increasing our power with regard to employers and the state. As Massimo De Angelis has reminded us, it is also a protection from ecological disaster. For there can be no doubt about the destructive consequences of the "un-economic" multiplication of reproductive assets and self-enclosed dwellings that we now call our homes, dissipating warmth into the atmosphere during the winter, exposing us to unmitigated heat in the summer (De Angelis 2007). Most importantly, we cannot build an alternative society and a strong self-reproducing movement unless we redefine our reproduction in a more cooperative way and put an end to the separation between the personal and the political, and between political activism and the reproduction of everyday life.
It remains to be clarified that assigning women this task of commoning/collectivizing reproduction is not to concede to a naturalistic conception of femininity. Understandably, many feminists view this possibility as a fate worse than death. It is deeply sculpted in our collective consciousness that women have been designated as men's common, a natural source of wealth and services to be as freely appropriated by them as the capitalists have appropriated the wealth of nature. But to paraphrase Dolores Hayden, the reorganization of reproductive work, and therefore the reorganization of housing and public space, is not a question of identity; it is a question of labor and, we can add, a question of power and safety (Hayden 1986). I am reminded here of the experience of the women members of the Landless People's Movement of Brazil [the MST] who, after their communities won the right to maintain the land that they had occupied, insisted that the new houses be built to form one compound so that they could continue to communalize their housework, wash together, cook together, as they had done in the course of the struggle, and be ready to run to give each other support when abused by men. Arguing that women should take the lead in the collectivization of reproductive work and housing is not to naturalize housework as a female vocation. It is refusing to obliterate the collective experiences, the knowledge and the struggles that women have accumulated concerning reproductive work, whose history has been an essential part of our resistance to capitalism. Reconnecting with this history is a crucial step for women and men today both to undo the gendered architecture of our lives and to reconstruct our homes and lives as commons.
**References**
Andreas, Carol. 1985. _When Women Rebel: The Rise of Popular Feminism in Peru_. Westport, CT. Lawrence Hill & Company.
Anderson, Nels. 1998. _On Hobos and Homelessness._ Chicago, IL. University of Chicago Press.
Carlsson, Chris. 2008. _Nowtopia._ Oakland, CA. AK Press.
Caffentzis, George. 2004. "Globalization, The Crisis of Neoliberalism and the Question of the Commons." Paper presented to the First Conference of the Global Justice Center. San Migel d'Allende, Mexico, July 2004.
—————. "Three Temporal Dimensions of Class Struggle." Paper presented at ISA Annual meeting held in San Diego, CA (March 2006).
De Angelis, Massimo. 2007. _The Beginning of History: Value Struggles and Global Capital_. London, UK. Pluto Press.
—————. "The Commons and Social Justice." Unpublished manuscript, 2009.
DePastino, Todd. 2003. _Citizen Hobo._ Chicago, IL. University of Chicago Press.
The Ecologist. 1993. _Whose Commons, Whose Future: Reclaiming the Commons_. Philadelphia, PA. New Society Publishers with Earthscan.
Federici, Silvia. 2011, "Women, Land Struggles, and the Reconstruction of the Commons." _WorkingUSA. The Journal of Labor and Society_ (WUSA), 14(61) (March 2011), Wiley/Blackwell Publications. Published in Spanish as "Mujeres, luchas por la tierra, y la reconstrucción de los bienes comunales," In _Veredas,_ No. 21, 2010. Issue dedicated to Social Movements in the 21st century. Veredas is the Journal of the Department of Social Relations of the Universidad Autonoma Metropolitana of Mexico City in Xochimilco.
—————. 2008. "Witch-Hunting, Globalization and Feminist Solidarity in Africa Today." _Journal of International Women's Studies_ , Special Issue: Women's Gender Activism in Africa. Joint Special Issue with WAGADU. 10(1) (October 2008): 29-35.
—————. 2004. _Caliban and the Witch: Women, The Body, and Primitive Accumulation._ Brooklyn, NY. Autonomedia.
—————. 2004. "Women, Land Struggles and Globalization: An International Perspective." _Journal of Asian and African Studies._ 39(1/2) (January-March 2004).
—————. 2001. "Women, Globalization, and the International Women's Movement." _Canadian Journal of Development Studies._ 22:1025-1036.
Fisher, Jo. 1993. _Out of the Shadows: Women, Resistance and Politics in South America._ London, UK. Latin American Bureau.
Hayden, Dolores. 1981. _The Grand Domestic Revolution_. Cambridge, MA. MIT Press.
—————. 1986. _Redesigning the American Dream: The Future of Housing, Work and Family Life._ New York, NY. Norton.
Isla, Ana. "Enclosure and Microenterprise as Sustainable Development: The Case of the Canada-Costa Rico Debt-for-Nature Investment." _Canadian Journal of Development Studies._ 22 (2001): 935-943.
—————. 2006. "Conservation as Enclosure: Sustainable Development and Biopiracy in Costa Rica: An Ecofeminist Perspective." Unpublished manuscript.
—————. 2009. "Who pays for the Kyoto Protocol?" in _Eco-Sufficiency and Global Justice_ , Ariel Salleh, ed. New York, London. Macmillan Palgrave.
Mies, Maria and Bennholdt-Thomsen, Veronika. 1999. "Defending, Reclaiming, and Reinventing the Commons," In _The Subsistence Perspective: Beyond the Globalized Economy._ London: Zed Books, Reprinted in _Canadian Journal of Development Studies_ , 22 (2001): 997-1024.
Podlashuc, Leo. 2009. "Saving Women: Saving the Commons." In _Eco-Sufficiency and Global Justice_ , ed. Ariel Salleh. New York, London: Macmillan Palgrave.
Shiva, Vandana. 1989. _Staying Alive: Women, Ecology and Development._ London. Zed Books.
—————. 1991. _Ecology and The Politics of Survival: Conflicts Over Natural Resources in India._ New Delhi/London. Sage Publications.
—————. 2005. _Earth Democracy: Justice, Sustainability, and Peace._ Cambridge, MA. South End Press.
_This chapter is adapted from an essay originally published in_ The Commoner _, January 4, 2011, available at http://www.commoner.org.uk/?p=113. It has also been published in _Uses of a Worldwind: Movement, Movements, and Contemporary Radical Currents in the United States _, edited by Craig Hughes, Stevie Peace and Kevin Van Meter for the Team Colors Collective (Oakland: AK Press, 2010)._
**Silvia Federici** _is a long time activist, teacher and writer. She is the author of many essays on political philosophy, feminist theory, cultural studies, and education. Her published works include _Revolution at Point Zero _(2012);_ A Thousand Flowers: Social Struggles Against Structural Adjustment in African Universities _(2000, co-editor_ ); Enduring Western Civilization: The Construction of Western Civilization and its "Others" _(1994 editor_ ); _and_ Caliban and the Witch, _which has been translated and published in Spanish, Korean, Greek and Turkish and is presently being translated into Japanese and Serbian. Federici is Emerita Professor of Political Philosophy and International Studies at Hofstra University in Hempstead, New York._
# Rethinking the Social Welfare State in Light of the Commons
_By Brigitte Kratzwald_
When we talk about commons in Europe, the question usually arises whether public services are also to be considered commons. In order to answer this question, we must examine our understanding of the (social welfare) state on the one hand and the concept of the "public" on the other.
**From the social welfare state to the neoliberal competition state1**
The social welfare state typical of western Europe from the end of World War II to the 1980s had three functions: redistributing wealth by means of taxation; ensuring protection from individual risks through insurance or transfer payments; and providing goods and services that were to be available to all for free or at affordable prices.2 In this way, the state met a number of important economic and social needs while also gaining a high degree of control over people's lives, which often gave rise to the criticism "nanny state." (1. This term was coined by Joachim Hirsch. (Hirsch 2002, pp. 110ff.) 2. However, these elements were represented in varying degrees in the different types of social welfare state as distinguished by Esping-Andersen (1990, pp. 9ff). )
As the neoliberal economic model prevailed around the world, the role and functions of the state were redefined. Now the most important task of the state is to ensure competitiveness in the global economy. By default, the provision of goods and services occurs according to market criteria, or this responsibility is delegated entirely to private companies with the expectation that they will improve efficiency and customer responsiveness. This has been an unfulfilled promise, however. Indispensable goods and services have become more expensive, are often no longer available everywhere, and their quality has diminished. It has become clear that the state is not a neutral actor that truly represents the interests of the general public, but rather it reflects societal power relations.
Worse, social movements that support public services have been forced to defend the continued provision of such state services, as seen in such efforts as the Stop GATS (General Agreement on Trade in Services) campaign, the campaign against the EU Services Directive, and various initiatives against the privatization of water supply, public transportation, hospitals and nursing facilities. The only credible goal is to ensure sufficient funding, not any expansion of services. Because of public austerity programs, however, these campaigns have rarely been successful. If we now consider anew what the idea of the commons could contribute to the question of public service, we must arrive at a new definition of the concept of "public."
**Are the state and the market the only options?**
In the economic definition of goods, public goods are generally characterized as non-rival and non-exclusive – that is, one person's usage does not "use it up" or preclude another from using it. But since the terms of exclusivity are societally negotiable, the definition of what is "public" – i.e., what should be provided by "the state" – is decided at the political level, even more than in the case of commons.3 Even Adam Smith had stated that the state must provide certain things that the market does not provide yet which are in the public interest. He mentioned raising and educating young people, for example (Smith). In the social welfare state, political decisions have assigned many responsibilities to the state, from energy, water supplies, public transportation, housing and public media to health care and education. The state's role was to make sure that these things were available to all. So if nowadays more and more of these areas are assigned to the market, then these, too, are political decisions. Because of this dualism of the market and the state, people have come to perceive that "public" means that something is owned or provided by the state, which is seen as a service institution to meet the needs of its citizens. (3. See the contributions by Silke Helfrich, James Quilligan and Josh Tenenberg in this volume.)
**We are the public!**
Historically speaking, however, the state and the public have been understood in different ways. To Aristotle, for example, man was a _zoon politikon_ , a social being by nature who is destined to organize a society and to act within it. The ideal of the citizen was derived from this concept and citizens were defined by their "participation in judging (krísis) and governing (arché)." Both took place in the public assembly of all citizens who had to fulfill their rights and duties there (Schmidt 2007).4 This active involvement by the citizens constituted the state and did not take place outside of governmental structures (ibid.: 13). (4. However, only free men, who were not obliged to contribute to the labor necessary for societal reproduction, were in a position to participate in this public discussion; such labor was performed by slaves and women.)
In historical England, access to the commons, the communally used land, not only secured the livelihoods but also the independence of those who did not possess land of their own. It gave people the opportunity to take advantage of their political rights. Since the commons was the public place for those who did not own property, enclosures of the commons amounted to a disempowerment of the commoners. Enclosures eliminated the places where commoners convened to defend their rights, and where they planned uprisings and revolutions.5 As late as 1795, a knaves' insurrection in Hüttenberg, Carinthia, began at an assembly on the Tratte, the commons.6 In some Swiss cantons, the Landsgemeinde exists to this day. "The citizens of a canton who have the right to vote meet on a certain day in the open air to settle legislative matters."7 (5. See the essay by Peter Linebaugh in this volume.
6. Cf. http://sabitzer.wordpress.com/tag/bergwesen. _Tratte_ was a common term for the commons in Austria. 7. http://de.wikipedia.org/wiki/Landsgemeinde.)
Issues of public interest were not handled by the institutional state in all these cases, but by all people who participated in shaping a community. Such a concept of the public points to people's ability to appropriate what they need and self-authorize their actions, defining the public sphere as the locus of commoning. Current discussions about public space also point in this direction (Kruse/Steglich 2006). Thus, we can also pose the question about public services from the perspective of the commons, whereby state institutions can also carry out various functions.
**The public sphere – beyond the state and the family**
The concept "private" requires closer inspection too. It has a dual meaning that becomes clearer when we look at privatization in the fields of social services, health and education. On the one hand, privatization refers to the provision of marketable services by profit-oriented "private" enterprises, in other words, by the market. On the other hand, privatization also refers to relegating services that are not marketable to the private sphere, i.e., families and especially women. So there are in fact two dualisms of public and private – the state and the market, and the state/market apparatus and the private sphere, in the sense of family or volunteering. In this sense, the public sphere can be construed as an area "beyond the state and the family," a place of great importance for a society's social reproduction. The public sphere can be seen as the place where the community provides services for its members, or users themselves provide the services, as seen, for example, in many civic associations, volunteer fire departments, and in schools and kindergartens run by dedicated parents. Because so much attention is lavished on the patriarchal social welfare state, this realm of life, analogous to the commons, is often overlooked. Its significance has hardly been perceived at all because we have directed our demands and desires to the state, and looked to it to secure our prosperity. As the safety net provided by the social welfare state deteriorates, however, this area is becoming even more important. Yet at the same time, it is under threat because people have less and less time for it.8 (8. For more on this topic, see Nancy Folbre. 2001. _The Invisible Heart: Economics and Family Values._ New York. New Press.
In other words, rethinking the social welfare state from the perspective of the commons means stepping out of the private sphere and reclaiming the state and the public sphere. In this context, "state" includes all levels of government, including the federal states and the municipalities. This means that commoners need to consider themselves part of the public sphere again, the sphere of politics.9 (9. The three aspects of public goods as developed by Inge Kaul in a different context can provide inspiration for such a definition of publicness (cf. Kaul et al. 2003: 21).)
**Reclaiming the State**
In many cases, governments have proven to be poor trustees of the things entrusted to them. Discontent about how they are doing their job is on the rise. People are standing up and taking responsibility with the words, "This is ours, and we want to make the decisions about it." Only through this process are these things becoming truly public goods and services. In this way, people are reclaiming control over the direct circumstances of their lives. We have been witnessing such processes of reclaiming in great numbers in recent years, going far beyond the demand for sufficient funding of public institutions and services. Some examples include the Berliner Wassertisch, a network of individuals trying to reclaim water management in Berlin,10 the Energiewende Hamburg, a coalition engaged in energy policy,11 and the Austrian railroad passengers' initiative, Pro Bahn.12 (10. The Berliner Wassertisch: http://berliner-wassertisch.net. 11. Energiewende Hamburg: http://unser-netz-hamburg.de. 12. Pro Bahn: http://www.probahn.at.)
Since self-determination is easiest to implement at the local level, it is municipalities above all that can benefit from the idea of the commons.13 One way of doing this is through municipal cooperatives as an alternative to public-private partnerships. Numerous cooperatives of this kind are currently emerging in the field of renewable energy. The funds for financing public institutions come from the citizens themselves, who in return have opportunities to participate and make decisions. While this makes sense in some contexts, it is not a universal solution; after all, the point is also to provide sufficient funding for public services, not simply to replace them with voluntary contributions on the part of the public.
(13. See, e.g., http://kratzwald.wordpress.com/2011/03/23/commons-und-kommunalpolitik/ and http://kommunalwiki.boell.de/index.php/Kategorie:Commons.)
In her book _Reclaim the State_ (Wainwright 2009), Hilary Wainwright describes how people can succeed in taking responsibility for public funds. For example, the people in an affected neighborhood can rally to win authority and direct benefits from state funding rather than delegating such authority and money to, say, real-estate developers commissioned with developing a neighborhood. Wainwright demonstrates that citizens and local politicians can join forces and successfully bring pressure to bear on businesses as well as on politics at the state and federal level.
What such initiatives share with commons is that the users themselves actively take control; rules are devised in a bottom-up procedure, and people demand control over their lives and are prepared to take responsibility for them. In addition, the citizens active in such arrangements can delegate various tasks to the state or the municipality. But in turn, the state and the municipality are held accountable to them, and there must be decision-making procedures that include the users and the people employed. For example, governmental institutions can be assigned to serve as trustees by managing various things according to decisions made by the citizens, but those institutions are denied the right to dispose of resources or sell them at will. In case of conflict, the state can offer mediation and must provide space and funding to carry out such decision-making procedures. The city government of Porto Alegre did so in exemplary fashion for the participatory budget process (Wainwright 2009). Another example is the process for public procurement in Mexico City, one of the world's megametropolises. Government institutions should also be used to support those societal groups for whom it is difficult, for various reasons, to participate in decision-making processes.
How services are provided – by the state, controlled by those affected; by citizens, through various forms of government support and financing; or in self-organized social networks – must be decided anew in every individual case. The prerequisite is that this space for political empowerment is not enclosed by means of privatization.
As in the case of commons, creating and maintaining such public services takes substantial time and cannot be had for free. We must speak out when the idea of the commons is used to justify cutting public expenditures, especially for social services and health, as is the case in England, where Prime Minister David Cameron talks about "Big Society."14 After all, the legal right to certain basic human services must remain untouched. Such an understanding of the role of the public opposes both kinds of privatization, that is, it is also against pushing tasks such as education and care back into the realm of the family and thus into that of women. After all, neither the state nor the family alone can ensure that the needs of children, youths, the elderly and disabled people are met and that they can develop their potential and contribute their skills. Such integration is a task for all of society, as reflected in the famous African proverb: "It takes a village to raise a child."15 (14. See Massimo De Angelis' essay. 15. The declining numbers of children in Germany and their increasing social problems are symptomatic of this. Cf. http://www.freitag.de/politik/1131-kinderarmes-deutschland.)
**References**
Esping-Andersen, Gösta. 1990. _The Three Worlds of Welfare Capitalism._ Cambridge. Polity Press.
Hirsch, Joachim. 2002. _Herrschaft, Hegemonie und politische Alternativen_. VSA Verlag, Hamburg.
Kaul, Inge, Pedro Conceição, Kattel Le Goulve, and Ronald Mendoza. 2003. _Providing Global Public Goods: Managing Globalization_. Oxford and New York, NY. UNDP.
Kruse, Sylvia; Steglich, Anja. 2006. _Temporäre Nutzungen – Stadtgestalt zwischen Selbstorganisation und Steuerung_. In: Möller, Carola; Peters, Ulla; Vellay, Irina: Dissidente Praktiken. Erfahrungen mit herrschafts-und warenkritischer Selbstorganisation. Ulrike Helmer Verlag, Königstein/Taunus.
Schmidt, Jürgen. 2007. _Zivilgesellschaft. Bürgerschaftliches Engagement von der Antike bis zur Gegenwart_. Rowohlt Verlag, Reinbek bei Hamburg.
Smith, Adam (undated edition; original, 1776). _Reichtum der Nationen_. Voltmedia GmbH, Paderborn.
Wainwright, Hilary. 2009. _Reclaim the State. Experiments in Popular Democracy_. London. Seagull Books.
****
**Brigitte Kratzwald** _(Austria) is a social scientist and commons activist. She hosts the website http://www.commons.at and blogs at http://kratzwald.wordpress.com._
# Common Goods Don't Simply Exist – They Are Created1
_By Silke Helfrich_
__
_(1_. I would like to thank Friederike Habermann, Heike Löschmann, Brigitte Kratzwald, Dirk Löhr, Stefan Meretz and Annette Schlemm for their enormously constructive comments.)
Neoclassical economics tends to classify goods in four groups: private and public goods, club goods and common goods. Anyone attempting to apply this classification in order to organize real-world objects will achieve one thing above all: their own confusion.
Drinking water, for example, is usually considered a common good. According to the neoclassical theory, common goods are defined among other things by the fact that we compete for their use. If I drink a glass of water, nobody else can enjoy the same water a second time. Economists call this characteristic "rivalry." Apples, land and water are rival – more or less, of course, as rivalry hardly exists at all in its pure form. The question is rather about differing degrees of competition for consumption. Use by one person limits the opportunities of other people to use the good, but not in terms of "all or nothing," but rather "more or less." In commons research and elsewhere, the more apt term coined by Elinor Ostrom is used: subtractability. It illustrates the gradual nature of the phenomenon. Other individuals' opportunities for use are not necessarily lost due to one's own use, but something is "subtracted" from them. The situation is different when it comes to knowledge or information. Both of them increase as we use them simultaneously and frequently. Economists call this characteristic "non-rivalry." The difference between rival and non-rival resources is a qualitative one, and it must be respected. We all deal with it as a matter of course in our daily lives. When we listen to the same broadcast independently of one another, we are using a non-rival good, as nobody is competing with anybody else for the right to listen to the broadcast by listening to it. Yet we would hardly bite into the same apple at the same time as someone else. If several people each wanted to have part of an apple, they would have to share it. For this reason, rivalry is also called "divisibility."
So, in the classification of goods mentioned above, common goods are considered rival. They are joined by another category: excludability. According to the theory, common goods are characterized by being non-excludable. Much of commons research concurs with this position. For instance, we all indeed have the right to access sufficient quantities of clean drinking water. This right is derived from human rights. From a normative viewpoint, it is therefore difficult to exclude people from using drinking water. But technically speaking, in contrast, it is fairly easy to exclude them. All it takes is refraining from investing in water supply and sewerage, and sealing or privatizing springs or wells, and then bottling the water in containers and selling it at prohibitive prices or making people depend on tank trucks. In fact, roughly three billion people do not have access to clean drinking water!
This example shows that depending on the degree of excludability, drinking water can become any kind of good: common to all of us, private, public or reserved for an exlusive club. We determine the form of use and thereby also the classification of drinking water as a particular type of good – yet we have apparently lost sight of this fact in a gradual process of ontologization.
The term ontology stems from the Greek participle "on" (being) and "logos" (science or study) – in other words, it denotes the study of being and refers to the fundamental constitution of things. According to landscape architect Frank Lorberg, "the human history of things disappears" in a process of ontologization, for it describes the shifting of man-made circumstances into the sphere external to us. Circumstances that invariably emerge in concrete social situations are separated from their historical contexts,2 and in the end seem inscribed in that which we encounter. In short: they become reified. Philosopher Annette Schlemm considers ontologizations to be "reductions of circumstances that are in flux or of things that exist in relationships merely to reified substances" (Schlemm 2011). Everything appears as if it _has always been_ like it is, for over the course of time, people consider things to be natural that in fact evolved historically and were produced by society – jumping to theoretical conclusions, as it were. This process can also be observed in the neoclassical classification of goods. Theoretically determining common goods as rival and not excludable will, at best, make experts of the global drinking water situation utter a disillusioned "if only!" "Rival"? Yes, at least more or less. Canada is different from the Sahel. But "not excludable"? (2. For more on the historical concept of the commons, see Hartmut Zückert's essay.)
**How things were put together that don't belong together**
In 1954, Paul A. Samuelson, the first US Nobel laureate in economics, established his "pure theory of public expenditure" with mathematical brevity. Alongside Richard Musgrave, the sage of public finance, welfare economist Samuelson is considered the father of the theory of public goods.3 In his oft-quoted 2-½ page article, he "explicitly assume[s] two categories of goods: ordinary _private consumption goods_ [...] which can be parcelled out among different individuals [...] and _collective consumption goods_ [...] which all enjoy in common [...]." (Samuelson 1954) Samuelson then categorizes the "public goods" he examines with the non-rival objects. The rival ones, in contrast, are transformed to become "private goods." Samuelson performs this coupling – rival and private on the one hand, non-rival and public on the other – under the heading "assumptions" in his influential article. He assigns each of these dual categories a logic of its own: "(1) _output_ s or goods which everyone always wants to maximize and (2) _inputs_ or factors which everyone always wants to minimize [...]." Here, _Homo economicus_ 4 comes to the fore, even though the author explicitly points out that many areas of life elude this logic of maximizing utility, namely that individuals' social environment influences their preferences, yet "[i]t is not a 'scientific' task of the economist to 'deduce' the form of this function." (3. See James B. Quilligan's essay on the differences between public goods and common goods. 4. See the essay by Friederike Habermann.)
Samuelson then limits his inquiry to the question as to how enough goods for which consumers to do not compete can be supplied. The market as a broker will fail, for the price of non-rival goods can hardly be determined by the interplay of supply and demand. For this reason, music and information, for example, are artificially kept scarce today – in this way, they can be made "priceable." As an alternative, Samuelson believed the community could be responsible for dealing with this issue. Yet decentralized structures within which the people involved negotiate the production and distribution of public goods themselves would never result in the ethically desired result. The only remaining option is the state. And here, Samuelson makes another logical leap, one that can be traced throughout the literature:
rival _and_ private = to be managed by the market
non-rival _and_ public = to be managed by the state
This linkage was successful. To this day, what economists call a "public good" is usually given over to the state. Other institutions are disregarded. The linkage seems imperative and natural, even though the two parts certainly can be separated, and indeed must be separated from one another.
Samuelson was aware of the complexity of his search for the optimal (state) formula for allocation. "The solution 'exists,'" he stated, "the problem is how to 'find' it." (Samuelson 1954) And even then, there could still be free riders who enjoy the common goods without contributing anything in return. This is a problem for sociology, he stated in capitulation, sounding as resigned as an impassioned mathematician reaching the limits of the calculable.
**"Sharing is Possible" 5**
Another sensation followed eleven years later: James McGill Buchanan, also a Nobel laureate, published his article "An Economic Theory of Clubs." (Buchanan 1965) It, too, is short and succinct. "No general theory has been developed which covers the whole spectrum of ownership-consumption possibilities" (ibid., 1). Instead, research remained limited to private or public goods – even though hardly any goods displayed the characteristic of "extreme collectiveness" ascribed to public goods; de facto, practically everything was located somewhere between the two extremes. Therefore, Buchanan proposed "to drop any attempt at an _initial_ classification or differentiation of goods into fully divisible and fully indivisible sets" and tried to develop a theory of goods with "some 'publicness.'" (Buchanan 1965, emphasis added) He called them "club goods." It was not "one user" or "the public" who accessed them, but a group of users. Thus, their utility for an individual depended on the number of people involved. From then on, club goods belonged to the established categories of goods. (5. Ibid., p. 3. The quotation refers to the use of a pair of shoes: "However, for any finite period of time, sharing is possible, even for such evidently private goods.")
Buchanan concluded that the core of the debate about goods was about "the sharing arrangements" – be they organized by the state or cooperatively.6 Accordingly, he did not seek the optimal formula for governmental provision and distribution, but the optimal formula for all those situations in which a limited group of people uses something jointly. He described one of his basic assumptions using the example of a country club. The rule "the more members, the lower each individual's membership fee" is valid only up to a certain size. If the club grows larger, it gets overcrowded, just like a traffic jam on a highway. (6. Ibid, p. 4. Buchanan relates this idea only to things that are used as economic goods. He believes that voluntary sharing does not belong in this category.)
This example shows that Buchanan, too, is aware that his basic assumptions are simplified to a great degree. Memberships and environmental factors change. Different motivations for action can hardly be taken into consideration. Just like Samuelson, he comes to a remarkable and largely overlooked conclusion: actually, "[t]he necessary marginal conditions [...] allow us to classify all goods only _after_ the solution is attained"7 (emphasis added). (7. For example, optimal group size and appropriate rules of use.) Economists following him apparently closed their minds to this insight and its consequences. The textbook version of the classification of goods still looks like this:
**Human history as reflected In things**
Take an example of a "public good": a dike. It is considered indivisible, as the utility of the residents on one side of the river does not diminish the utility of the residents on the other. Therefore, its degree of rivalry is zero. In addition, a dike protects everyone, just as a lighthouse shines the way for everyone, regardless of whether they are taxpayers or not. This technical (or normative) difficulty of excluding someone from using a good, is, as seen above, a characteristic of public goods. Yet a dike could also be built by private companies, part of the costs could be apportioned to the local residents, and anyone in arrears could be excluded from flood insurance. What matters is what happens in practice.
In an analysis of the social function of property, Christoph Engel, director of the Max Planck Institute for Collective Goods in Bonn, Germany, describes how different the reasons given for this alleged non-excludability are. For example, it is said that it is technically difficult to "pack air in sacks and buy one's daily quota of air for breathing at a store." Or: clear allocation of individual property rights may be technically possible, but too expensive, or it is technically possible, but not socially achievable. One need only consider the idea of turning human organs urgently needed for transplants into tradeable goods. And finally, Engel gets to the crux of the matter:
None of these cases must remain unchanged over time. What is technically impossible today may be possible tomorrow, thanks to an invention. What is too expensive today may seem profitable tomorrow. [...] Technical or institutional innovations can make the establishment of usage rights cheaper. Normative convictions can change. (Engel 2002: Section 6)
Buchanan, too, had employed a similar argument: "If the structure of property rights is variable, there would seem to be few goods the services of which are non-excludable, solely due to some physical attributes."
In other words, excludability depends on the concrete circumstances, on what we as acting individuals are capable of doing, and on our decisions. We could also express this idea as follows: a common good does not _have_ the characteristic of non-excludability; rather, it is _given_ this characteristic.
There is hardly a more telling illustration of this notion than that of US cartoonist Matthew Groening, creator of "The Simpsons." The Simpsons live in a curious small town called Springfield. Electricity for the town's population and factories, including one for amphibious vehicles, is supplied by an atomic power plant owned by the ruthless billionaire Charles Montgomery Burns. Burns's heart – this I learn from the (German-language) Simpsonspedia – is "black and shriveled." Small wonder. After all, he has an intense aversion to the sun, which supplies Springfield's population with energy free of charge. In the first part of the famous two-part episode "Who Shot Mister Burns?" the groundskeeper of Springfield's school strikes oil. Everyone is delighted – except for Mr. Burns. He darkens the sun, making sunlight excludable.
**Beyond classifications of goods **
The theory of goods has become considerably more differentiated since the 1960s. Today, we speak of a continuum of goods, a number of subcategories have been added – pure and impure public goods, free goods and many more. Yet this has hardly contributed to a conceptual reorientation. Samuelson's logical leaps have remained, as has the practical invisibility of human history in the things we analyze. The confusion on the part of people who want to place real things in the table shown above continues as well. If we try to allocate the various resources currently labeled as commons according to the criteria of "rivalry" and "non-excludability," we get mired down in differentiations.
In the commons debate, both natural and depletable things such as water, land and forests and renewable, social and cultural things such as seed, algorithms, software, public space or the electromagnetic spectrum are considered as being owned jointly by a group of people – not because of their characteristics in the neoclassical sense, but simply because they are elementary to our lives. The way in which resources are made accessible to society also defines them as common resources. Either we inherited them, or we produced them collectively, often over the course of centuries. That is what makes things common to us, not their alleged characteristics. That is why they are considered common goods and not private goods. Whether we make apples, water and knowledge common goods is up to us.
The degree of rivalry is relevant when it comes to common rules for access and use. It results in different conventions. In the case of rival goods, restrictions to access are necessary – individuals are permitted to pick only the amount from a tree that they can carry in their hands.8 In the case of non-rival goods, only open access guarantees their development to everyone's greatest benefit.9 Unlimited access does not destroy them! Excludability, in contrast, is mostly produced by social processes. It is up to us whether we make apples (or more precisely, apple trees) common goods or whether access to apples always has to take the detour via the market. It is only this decision that determines whether they are to be allocated to the group of common goods, or club goods or private goods. (8. See Katharina Frosch's essay about a Web-enabled commons for fruit-picking. 9. See the essays by Mike Madison et al. and Rainer Kuhlen.)
That is why we can confidently view the proverbial classification of goods from a respectful distance. We can "sublate" it in the Hegelian sense, which means set it aside, retaining what is useful and developing it further at a new level.
Above all, however, we can turn our attention to the question of what we want to do with our common resources. That is what really matters, for common goods _exist_ only if we produce them – and they will remain only if we take care of them.
**References**
Buchanan, James M. "An Economic Theory of Clubs." _Economica_ , New Series, 32/125 (Feb., 1965), 1-14.
Engel, Christoph. 2002.Die soziale Funktion des Eigentums. In von Danwitz, Depenheuer, Engel: Bericht zur Lage des Eigentums. 9–107.
Lorberg, Frank. 2007. _Metaphern und Metamorphosen der Landschaft. Die Funktion von Leitbildern in der Landespflege_. Notizbuch der Kasseler Schule, Bd. 71. Hrsg.: AG Freiraum und Vegetation.
Samuelson, Paul A. 1954. "The Pure Theory of Public Expenditure." _The Review of Economics and Statistics_. (36)4:387–389.
Schlemm, Annette. 2011. Ontologisierungen in der Gesellschaftstheorie. http://philosophenstuebchen.wordpress.com/2011/06/10/ontologisierungen-in-der-gesellschaftstheorie.
**Silke Helfrich** _(Germany) is an author and independent activist of the commons. She is founding member of Commons Strategies Group. She was regional representative of the Heinrich Böell Foundation in Mexico/Central America for several years, and was the editor of_ Wem gehört die Welt _, and translator and editor of_ Elinor Ostrom: Was mehr wird, wenn wir teilen. _She blogs at www.commonsblog.de._
# The Tragedy of the Anticommons
_By Michael Heller_
This essay introduces the tragedy of the anticommons. What's that? Let's start with something familiar: a commons. When too many people share a single resource, we tend to overuse it – we may overfish the oceans and pollute the air. This wasteful overuse is a tragedy of the unmanaged commons. How do we solve such a tragedy?
Often, by creating private property. Private owners tend to avoid overuse because they benefit directly from conserving the resources they control. Unfortunately, privatization can overshoot. Sometimes we create too many separate owners of a single resource. Each one can block the others' use. If cooperation fails, nobody can use the resource. Everybody loses in a hidden tragedy of the anticommons. I say "hidden" because underuse is often hard to spot. For example, who can tell when dozens of patent owners are blocking a promising line of drug research? Innovators don't advertise the lifesaving cures they abandon.
The anticommons is a paradox. While private ownership usually increases wealth, too much ownership has the opposite effect: it wrecks markets, stops innovation, and costs lives. We can reclaim the wealth lost in a tragedy of the anticommons. But it takes tools to end ownership gridlock. The following pages provide the basic analytic tools you need: a brief overview of the anticommons lexicon (Heller 2008; 2010).
**The trilogy of ownership**
Traditionally, ownership has been categorized into three basic types: private, commons, and state property (Heller 2001). Let's unpack those categories:
We all have strong intuitions about private property, but the term is surprisingly hard to pin down. A good starting point comes from William Blackstone, the foundational eighteenth-century British legal theorist. His oft-quoted definition of private property is "that sole and despotic dominion which one man claims and exercises over the external things of the world, in total exclusion of the right of any other individual in the universe." In this view, private property is about an individual decision maker who directs resource use.
Commons property refers to shared resources, resources for which there is no single decision maker. In turn, the commons can be divided into two distinct categories (Eggertsson 2002). The first is open access, a regime in which no one at all can be excluded, like on the high seas. Mistakenly, the legal and economics literatures long conflated the commons with open access, hence reinforcing the link between commons and tragedy. The second type of commons has many names, but for now let's call it group access, a regime in which a limited number of commoners can exclude outsiders but not each other. If the ocean is open access, then a small pond surrounded by a handful of landowners may be group access. Group access is often overlooked even though it is the predominant form of commons ownership, and is often not tragic at all; it is the core concept that this volume celebrates.
State property resembles private property in that there is a single decision maker but differs in that resource use is directed through some process that is, in principle, responsive to the needs of the public as a whole. In recent years, state property has become less central as a theoretical category: intense state regulation of resources has dropped from favor and privatization has accelerated. Today, for many observers, the property trilogy can be reduced to an opposition of private and commons property, what one scholar calls simply "all and none" (Figure 1) (Barzel 1989).
**Figure 1:** _The Standard solution to the commons tragedy_
I believe a substantial cause of our cultural blindness to the costs of fragmented ownership arises from this too simple image of property. We assume, without reflection, that the solution to overuse in an open access commons is ordinary use in private ownership. This logic makes it difficult to imagine underuse dilemmas and impossible to see the uncharted world beyond private property.
Privatizing a commons may cure the tragedy of wasteful overuse, but it may inadvertently spark the opposite. English lacks a term to denote wasteful underuse. To describe this type of fragmentation, I coined the phrase tragedy of the anticommons (Heller 1998). The term covers any setting in which too many people can block each other from creating or using a valuable resource. Rightly understood, the opposite of overuse in a commons is underuse in an anticommons.
This concept makes visible the hidden half of our ownership spectrum, a world of social relations as complex and extensive as any we have previously known (Figure 2). Beyond normal private property lies anticommons ownership. As one commentator has noted, "To simplify a little, the tragedy of the commons tells us why things are likely to fall apart, and the tragedy of the anticommons helps explain why it is often so hard to get them back together" (Fennell 2004).
Often, we think that governments need only to create clear property rights and then get out of the way. So long as rights are clear, owners can trade in markets, move resources to higher valued uses, and generate wealth. But clear rights and ordinary markets are not enough. The anticommons perspective shows that the content of property rights matters as much as the clarity. Wasteful underuse can arise when ownership rights and regulatory controls are too fragmented.
**Figure 2:** _The revealing the hidden half of the ownership spectrum_
Making the tragedy of the anticommons visible upends our intuitions about private property, which can no longer be seen as the end point of ownership. Well-functioning property instead is a fragile balance poised between the extremes of overuse and underuse.
**Lessons from the commons**
Solutions to commons property dilemmas give clues to solving anticommons tragedy. To start, consider the distinction between open access and group access. This distinction can do some work on the anticommons side of the spectrum as well. For open access, like the high seas, states must command resource use directly or create hybrid rights, such as fishing quotas. The anticommons parallel to open access is full exclusion in which an unlimited number of people may block each other. With full exclusion, states must expropriate fragmented rights or create hybrid property regimes so people can bundle their ownership. Otherwise, the resource will be wasted through underuse. There is, however, one important respect in which full exclusion differs from open access: an anticommons is often invisible. You have to spot the underused resource before you can respond to the dilemma.
Group access in a commons also has an anticommons parallel: group exclusion in which a limited number of owners can block each other. For both group access and group exclusion, the full array of market-based, cooperative, and regulatory solutions is available. Although self-regulation may be more complex for anticommons resources, close-knit fragment owners can sometimes organize to overcome anticommons tragedy (Depoorter and Vanneste 2007). For group exclusion resources, the regulatory focus should be support for markets to assemble ownership and removal of roadblocks to cooperation.
Group property on the commons or anticommons side of private ownership is exponentially more important than the rare extremes of open access or full exclusion. Much of the modern economy – corporations, partnerships, trusts, condominiums, even marriages – can be understood as legally structured group property forms for resolving access and exclusion dilemmas (Dagan and Heller 2001). We live or die depending on how we manage group ownership. Now, we can see the full spectrum of property, as shown in Figure 3.
**Figure 3:** _The full spectrum of property, revealed (Heller 1999)_
**The spread of the anticommons idea**
After I proposed the possibility of anticommons tragedy, Nobel laureate James Buchanan and his colleague Yong Yoon undertook to create a formal economic model. They wrote that the anticommons concept helps explain "how and why potential economic value may disappear into the 'black hole' of resource underutilization" (Buchanan and Yoon 2000)." In recent years, economic modeling of the anticommons has become quite sophisticated.
To date, the most debated application of anticommons theory has been in the area of drug patents and innovation (Heller and Eisenberg 1998). Since my 1998 _Science_ article with Rebecca Eisenberg, there has been a flurry of follow-on papers and reports, many concluding that patents should be harder to obtain, in part to avoid potential anticommons tragedy effects. A recent book on the patent crisis concludes that, "the structure of the biotechnology industry seems likely to run high anticommons risks," particularly when companies are attempting to bring products to market (Burk and Lemley 2009).
It's not just biomedical research that's susceptible to anticommons tragedy. The framework has been applied across the high tech frontier, ranging from broadcast spectrum ownership to technology patents. Also, cutting edge art and music are about mashing up and remixing many separately owned bits of culture. Even with land, the most socially important projects require assembling multiple parcels. Innovation has moved on, but we're stuck with old-style ownership that's easy to fragment and hard to put together.
Anticommons theory is now well established, but empirical studies have yet to catch up. How hard is it to negotiate around ownership fragmentation? How much does ownership fragmentation slow down technological innovation? Does the effect vary by industry? It is difficult to measure discoveries that should have been made but weren't, solutions that could exist but don't. We are just starting to examine these conundrums. A recent study reported experimental findings that reject the presumed symmetry of commons and anticommons and find instead that anticommons dilemmas "seem to elicit more individualistic behavior than commons dilemmas" and are "more prone to underuse than commons dilemmas are to overuse." The researchers conclude that "if commons leads to 'tragedy,' anticommons may well lead to 'disaster'" (Vanneste et al 2006).
**Toward a new lexicon**
We have millennia of practice in spotting tragedies of overuse. When too many people fish, fisheries are depleted. When too many people pollute, we choke on dirty air. Then, we spring into action with market-based, cooperative, and legislative solutions. But underuse caused by multiple owners is unfamiliar. The affected resource is hard to spot. Our language is new. Even though a tragedy of the anticommons may be as costly to society as the more familiar forms of resource misuse, we have never noticed, debated, or learned how to fix underuse. As a first step, we need to name the phenomenon: the tragedy of the anticommons should join our lexicon.
_This essay is adapted from Chapter 2 of _The Gridlock Economy _(2010). For further resources, see http://www.gridlockeconomy.com._
**References**
Barzel, Y. 1989. _Economic Analysis of Property Rights_. Cambridge University Press.
Buchanan, J. and Yoon, Y. 2000. "Symmetric Tragedies: Commons and Anticommons." Journal of Law and Economics. 43: 1.
Burk, D. and M. Lemley. 2009. _The Patent Crisis and How the Courts Can Solve It_. University of Chicago Press.
Dagan, H. and M. Heller. 2001. "The Liberal Commons." _Yale Law Journal_ 110: 549.
Depoorter, B. and Vanneste, S. 2007. "Putting Humpty Dumpty Back Together: Pricing in Anticommons Property Arrangements." _Journal of Law_ , _Economics & Policy_. 3:1.
Eggertsson, T. 2002. Open Access versus Common Property. In T. Anderson & F. McChesney, eds., _Property Rights: Cooperation, Conflict, and Law_. 74-85. Princeton University Press.
Fennell, L. 2004. "Common Interest Tragedies." _Northwestern Law Review_ , 98:907.
Heller, M. 1998. "The Tragedy of the Anticommons: Property in the Transition from Marx to Markets." _Harvard Law Review._ 111:621.
—————. 1999. "The Boundaries of Private Property." _Yale Law Journal._ 108:1163.
—————. 2001. "The Dynamic Analytics of Property Law." _Theoretical Inquiries in Law_. 2:79.
—————. 2008. _The Gridlock Economy: How Too Much Ownership Wrecks Markets, Stops Innovation, and Costs Lives_. New York: Basic Books.
—————, editor. 2010. _Commons and Anticommons_. London: Elgar Publishing.
—————, and Eisenberg, R. 1998. "Can Patents Deter Innovation? The Anticommons in Biomedical Research." _Science._ 280:698.
Vanneste, S. et al. 2006. "From 'Tragedy' to 'Disaster': Welfare Effects of Commons and Anticommons Dilemmas." _International Review of Law and Economics._ 26:104.
**Michael Heller** _(USA) is the Lawrence A. Wien Professor of Real Estate Law at Columbia Law School. He is the author of The Gridlock Society (2008) and Commons and Anticommons (2010)._
# Why Distinguish Common Goods from Public Goods?
_By James B. Quilligan_
The devastating recession of 2008–09 and its volatile aftermath have focused everyone's attention on the global economy. There is growing agreement that better policies, laws and institutions are needed, but will the next economy be fair and equal for all inhabitants of Earth? No one really knows. Yet one thing is certain: the political will to create a democratically restructured economic system cannot be generated until a more realistic epistemology is embraced across the planet. When called upon to evaluate and approve new solutions for global economic and socio-ecological coordination, people will need to understand these plans in clear and simple terms. The economics of sharing has to be based, not on political interests or ideology, but on how the world and its subsystems actually work.
Virtually everyone today recognizes the difference between private goods (commercial products and services created by businesses) and public goods (education, parks, roads, public safety, sanitation, utilities, legal systems and national defense provided by sovereign governments). Likewise, the contrast between private and common property has also become very sharp. In our daily lives, we readily perceive the differences between proprietary data and free information, or the berries sold at market and those found in the wild.
Yet the differences between the world's two basic forms of collective property – public goods and common goods – are often blurred. One of the great challenges before us is to create powerful and broadly recognized distinctions between public goods and commons/common goods – the shared resources which people manage by negotiating their own rules through social or customary traditions, norms and practices.1 These distinctions are pivotal. For the commons to be embraced in economic, ecological and social policy, their immediacy should be apparent to everyone. The cognitive apprehension of common goods must quicken our capacity to experience and understand the things we share beyond the enclosed spaces of private and public property. Formal categories may help clarify distinctions among private, public and common goods, but they do not convey the sense of human meaning, being and intersubjectivity that lie at the heart of any commons. Indeed, much of the literature on the commons fails to convey this sense of presence. (1. Although it's not the focus of this article, the differentiation of common goods from common-pool resources (CPRs) is also important. CPRs generally involve an open access regime where there is no system for managing resources; they are freely available for anyone to appropriate because no rights or rules exist for governing them. In a commons, on the other hand, people negotiate their own agreements – both functional and cultural – to manage their shared resources. Common goods thus tend to be managed by informal rules and norms that do not exist in open access regimes like CPRs.)
One sometimes reads that common goods are "rivalrous" (one person's use precludes another's use) and "non-excludable" (it is difficult or impossible to exclude others from using the resource).2 These are ponderous claims, difficult to grasp in the moment (and also conceptually weak, as Helfrich notes in her essay in this volume). Could such non-intuitive definitions be a reason why the commons seem so abstract to many people? How can their ontological reality be recognized when common goods require so much analysis to distinguish them from public goods? (2. For more on the concepts of rivalry and excludability, see Silke Helfrich's essay.)
This article differentiates public from commons/common goods by examining many of the theoretical and practical assumptions that lie behind public property. The sections below address various facets of this distinction and explain why a broadly shared worldview of common goods is vital to the democratic future of the planet. Indeed, acknowledging the role of common goods in our lives can provide epistemological and political leverage points for transforming the global economy and creating globally representative governance.
**To end the confusion between public and commons**
The simplest way of contrasting a public and common good is to ask: Does this particular resource require management as a social mandate or is it an expression of social mutuality and collaboration? In other words, is this property best maintained by government or the public? This is a useful starting place, yet it raises further questions. What exactly do we mean by "public" and public goods? Postwar economists such as Paul Samuelson identified the non-rivalrous qualities of public goods and James M. Buchanan and Vincent Ostrom described their non-excludable aspects.3 These definitions seemed to corroborate John Maynard Keynes' theory, widely adopted by Western governments during the 1930s-50s, that government intervention in the economy is a way to satisfy people's consumption needs through more jobs and higher wages. But Keynesian policies defining "effective demand" conflate individual purchasing power (a market force that spurs wealth-creating behavior) with "personal preference satisfaction" (a broader set of human needs and wants that includes non-market satisfactions). As a result, Keynesian economics virtually ignores the human desire for common goods. Government-stimulated spending and consumption identifies food, water, air, knowledge, community networks and social technologies as market goods, but not as naturally renewable or self-generated social resources. In short, state provision of public goods fails to account for the higher total net benefit that consumers would receive through self-organized and socially negotiated production, use and protection of their own resources. Hence, the commons has no definitional reality in Keynesian thought. (3. Ibid.)
Since the 1980s, the state has concerned itself principally with increasing the rights of private property, free markets and free trade.
This has shifted the meaning of "public" even further away from common property. With the advent of neoliberalism, the public sector now refers, not to citizens self-providing their own resources for their collective benefit, but to the institutions of government provisioning that claim to improve individual well-being through private market goods which are still called public goods. In a mystifying sleight of hand, the resources we use in common are identified as public goods and then deregulated and turned over to the private sphere for production and distribution.
As in the shell game of the magician, common goods disappear through the adept switching of categories: forget where you saw it before, which legal container now holds the good? In this way, goods that were once managed as commons or public goods – water, food, forests, energy, health services, schools, culture, indigenous artifacts, parks, community zoning, knowledge, means of communication, currency, and ecological and genetic resources – have either been privatized outright or remain public or common goods in name only. To call such goods "public" (by declaring them non-rivalrous and non-excludable) is to carry the Keynesian denial of common goods a step further, embracing neoliberal doctrines that ultimately seek to make all goods private goods (and thus rivalrous and excludable).
Not only does the commons vanish through this legal and linguistic shuffle, even the word "public" is stolen from the people. "Public" no longer signifies a community's authority to manage its local resources and express its own social or ecological demands; "public" now means the central governing authority to whom we have surrendered the control of these resources, which then meets our demand through conventional private markets. Everyone sees the growing discontinuity between the masses who are excluded from governmental decision-making (through partisan majorities, rule of law, executive administration and judicial decisions) and the relative few who dominate the process to advance their own private gain. Yet there is little outcry when the word "public" is routinely applied to both the excluded masses and privileged insiders. This facile, misleading use of "public" persists chiefly because citizens have lost their direct understanding and connection with the commons. The strong epistemological frame of reference that once linked the "public sector" to our collective potential for governing and valuing our own resources and asserting a countervailing authority to private markets, has virtually disappeared. In theory, public still means people; in practice, public means government (as captured by elite interests who regularly impede the people's political rights and capacity to control their common goods).
**To integrate producers and consumers**
Understanding the distinction between public and common goods also helps in resolving differences in the roles and identities of producers and consumers. This is a crucial point. In the present system, the market creates value by enclosing a common area, whether material (land, natural/mineral resources) or immaterial (culture, ideas, digital space). A division of labor between producers and consumers is created through top-down, hierarchical structures in the flow of private and public goods. This is said to increase economic efficiency, productivity and quality, while lowering the costs of goods and services.
Yet many alternative communities have developed their own sets of norms and rules to oversee their collective resources sustainably. Whether these commons are traditional (rivers, forests, indigenous cultures) or emerging (solar energy, collaborative consumption, Internet), self-organizing communities take collective action to preserve their local resources, both for themselves and for future generations. It's important to recall that the core principles of production and management in these commons are actually idealized by neoliberalism – i.e., spontaneous, self-regulating freedom (through markets) and rule-based equality (as enforced by the state). When consumers choose to become co-producers of goods and services through their own commons, however, their mutual, integrative work transcends the premises of neoliberalism. It's evident that the freedom and equality expressed through a commons does not result from privatization, centralized institutions or the top tiers of a social hierarchy.
When the users of resources are directly involved in the process of production, their local ideas, learning, imagination, deliberation and self-corrective action are embodied directly in their collaborative activities. Unlike commercial delivery chains or the bureaucratic provision of public goods and services by the state, the autonomy of individual choice is best assured through the cooperative production of value and governance by resource users themselves. The decentralized, self-governing systems of co-production also offer fairer, more direct access to resources (and thus higher efficiency) than can be gained through distributive enterprises operated as private monopolies or state hierarchies. This expands the distribution of the means of production and decision-making far more widely than through the top-down systems of the modern market/state. Hence, common goods that are managed directly and locally constitute a realm of governance and production that moves beyond the modern division of labor.
**To establish social charters and commons trusts**
Discriminating common from public goods is a vital step in the development of covenants and institutions by stakeholders who depend on specific common goods for their livelihood and welfare. When people across a community of practice or region take on the responsibility to sustain their own resources, they may formalize this through a social charter. The charter outlines a group's rights and incentives for a shared resource. It describes patterns of relationships between the resource and its users, managers and producers. Social charters have been developed for forests, pastures, irrigation systems, aquifers, springs, lakes, fisheries, knowledge, genetic resources, public health, energy, landscapes, historic sites, cultural areas and political security regions. Social charters can also be applied to many other domains.
To make them operational, resource users and producers may develop a legal entity or fiduciary association of citizen stakeholders which operates as a trust. Commons trusts are generally created to preserve depletable resources (natural, material), but many replenishable commons (social, cultural, intellectual, digital, solar) can also benefit from trusts that ensure their regeneration. Trustees set a cap on the extraction or the use of a resource according to non-monetized, intergenerational metrics such as sustainability, quality of life and well-being. For example, trusts can be developed for oil fields, aquifers and the atmosphere to ensure their long-term viability. Having protected a commons safely for future generations, the trust may rent a proportion of the resources under the cap to the private sector or to state businesses and utilities for extraction and production. A percentage of this rent could be taxed by the state and redistributed to citizens as dividends or subsistence income, with emphasis on the poor and socially marginalized. Rental or user fees may also be reinvested in the rehabilitation of depleted resources (such as land, rivers, oceans, atmosphere) and the enhancement of replenishable resources (arts, collaborative knowledge, digital codes, solar energy). A full-spectrum, commons-based economy could thus be created through a variety of such trusts: the commons would be protected for the future, the private sector would profit from producing the resources which they rent, and the state would tax these rents to restore degraded commons, fund social dividends and encourage free culture.
**To develop a new identity for civil society**
What segment of society could best sponsor commons/common goods apart from private and public goods? Beginning with the philosophy of Hegel, and differentiated increasingly in recent decades, civil society has identified itself as a "third sector" beyond the market and state. By defining the interests and advocating for the rights of the unrepresented, global networks, nongovernmental organizations, citizens associations and social movements have become a genuine voice of global public opinion. Indeed, many of the interests they are pursuing – healthy food, clean water, clean air, environmental protection, green energy, free flow of information, social technologies, human rights and indigenous peoples' rights – are common pool resources that could be managed as commons.
Yet these self-selected groups do not carry the authority of global representative democracy, since public opinion lacks the legitimacy of people's votes through an electoral process and thus does not increase their political equality in society. Without a credible political mandate, civil society typically challenges specific applications of global authority but rarely its underlying structure. In affirming and upholding the constitutional premises of neoliberalism (including the primacy of individual rights, private property and sovereign borders), most civil society organizations support the embedded division of labor between producers and consumers and thus the enclosure of the commons. This leaves civil society co-dependent on business and government and vulnerable to exploitation. Unable to stand as a true opposition party, civil society faces a huge obstacle in establishing itself as a transformational alternative.
Here is where civil society can learn from commons groups the importance of involving resource users in the process of production. As noted earlier, the commons involve producers who consume their own goods. When resource users are also co-producers, their motivations, knowledge and skills become part of the production praxis, leading to new ways of interacting and coordinating social and economic life. A new production and governance logic of learning-by-doing then becomes possible. Civil society could apply this principle in its own work by embracing these innovative means of co-production and co-governance.4 For example, emerging forms of peer-to-peer creativity and management – such as free software, open hardware groups and the horizontalist decision-making demonstrated by Occupy Wall Street – can teach civil society organizations how to adopt open source (rather than market-driven) values and structures. By operating both as resource users and as producers, enabling local stakeholders to develop their own political power, civil society groups could expand the scope of collective rights, moral legitimacy and civic power that exists beyond the state. Through discovering their necessary role in the global commons movement, the world's civil society organizations would develop a more dynamic basis for collective action, social solidarity and direct democracy than currently exists. (4. While some grassroots activists in international development already follow this principle, the practice of commoning through the mass distribution of production and governance has not yet broken through to the rest of civil society.)
As catalysts for the integration of producers and consumers, many civil society organizations could evolve into local/regional councils and commons trusts, or perhaps form partnerships with them. The increased participation and political choices offered to citizens through these new accountability structures would transform economic, social and political decision-making at all levels of commons (local, state, interstate, regional, and global). This would resolve the present contradiction between the internationalist ideals of civil society groups for redistributing social and natural resources, and their financial and political fears of challenging corporate and state restrictions on the equitable access, protection and use of these commons/common goods. By fostering the collective production and governance of common goods through new forms of participation and trusteeship (instead of private/public ownership), the various movements of civil society, which are after all unelected and self-appointed, would become far more accountable to the people they claim to represent.
**To vest sovereignty in global citizens**
Discriminating common goods from public goods is crucial in recognizing our essential rights to the commons as global citizens. Presently, people's rights to global citizenship are not acknowledged or affirmed because citizen representation is vested in the state and does not go beyond the state level. As national citizens, we empower governments through an implicit social contract, bestowing legitimacy and authority upon the state in return for the public goods of protection, security, infrastructure and other services. In surrendering our deeply personal, subjective power of decision-making to government (which redeploys this power by granting corporations the right to produce and dispense private goods), the idea of an active citizenship with identity and purpose is gravely weakened.
Yet it's human beings as a collective who are sovereign – not their governments. The inalienable rights of people originate, not in authority over a territorial area, but through a customary or emerging identification with an ecology; a form of collective labor; a social technology; a community need or shared conviction; a cultural resource area; an ethnic, religious and linguistic affinity; or a historical identity. When groups of people recognize that the capacity of their commons to support life and development is in decline, this may spur them to claim long-term authority over resources, governance and social value as their planetary birthrights, both at a community and global level. These natural rights to every resource – the atmosphere, oceans, forests and species, food, water, energy and health care, technology, media, trade and finance – arise from a community's dependence on particular commons for survival and security, and from a duty to safeguard the welfare of future generations. The human need for sustenance and livelihood vests these local groups with a new moral and social responsibility: to engage resource users directly in the preservation, access and production of their own commons.
Rather than seek individual or civil rights from the state, commoners declare their sovereign rights as global citizens to protect, access, produce, manage and use this shared resource. People's sovereignty for a commons is legitimated through global citizenship, and this global citizenship is legitimated through the local sovereignty of their commons. This is not circular reasoning; it's the expression of multi-scale decision-making and a planetary identity that transcends the authority of state institutions and recognizes the legitimacy of people's claims as trustees of the world's resources at every level of common property.
**To refute claims of "global public goods"**
Over the past few decades, the intergovernmental system has proclaimed its capacity to meet the needs of the world's population and environment through global public goods. This concept – a hybrid of Keynesian internationalism and corporate/financial neoliberalism – illustrates the lack of understanding and vision in the present management of the global commons. By the Samuelson/Buchanan/Ostrom definition, non-rivalrous and non-excludable public goods are said to be provided by sovereign governments to the citizens within their jurisdictional borders. But this model is virtually meaningless at the multilateral level where there is no representative authority (either through individual states in association or a global institutional framework) to provide public goods to the citizens of the world.
When a state competes across borders for economic resources (commodities, investment, credit) or political resources (strategic surpluses, military advantage, diplomatic sanctions), these goods are certainly rivalrous. Likewise, when a state fails to provide food, developmental assistance or technological transfers to alleviate poverty for its own citizens or those in other nations, millions of people are clearly excluded from access to these goods. In reality, the propaganda bubble behind "global public goods" is fueled by the market forces of rivalry and excludability inherent in private goods, which are profit-driven for the benefit of shareholders, rather than equity-driven for the masses. National governments simply do not have the interdependent power or legitimacy – nor are they designed – to protect, manage and distribute resources for the world's people as a whole.
Yet the liberal myth of global public goods has tentacles everywhere. Under the present system of strong state sovereignty, noninterference across borders and limited multilateral cooperation, governments refuse to establish a representative basis for global resource sovereignty. Both the private and public sectors deny that the world's collective action problems – access to food and water, universal health care, education, distribution of aid and technology, transborder safety and security, world peace, a just legal and political system, a pollution-free environment, clean air and an equitable economic system – can or should be managed as global commons. Meanwhile, the neoliberal commitment by states to private/public growth is destroying the planet and leaving people dispossessed of these collective resources, unable to express or realize the intrinsic value of their local, regional and global commons. It's time for a rational conversation on the norms, rights and duties of every citizen for global common goods: the shared resources that must be negotiated and organized by the world's people themselves.
**To create a new global social contract**
For legitimate forms of commons democracy to be rooted in and distributed across all political communities, a major reconfiguration of socio-economic relations, rules and institutions is needed. To this end, common goods offer the possibility of a legal and constitutional basis for democratic global governance. In bringing this platform forward, the world's people must organize their local commons, declare their sovereignty as global citizens, and call upon governments to acknowledge the natural rights belonging to all human beings and life-forms across the planet. The people's contract for global citizenship will empower resource communities and civil society organizations to create trusteeships, which include but transcend parliamentary forms of governance, giving them a democratic means for voicing local claims to self-determination outside the state system. By this means, national sovereign authority may be renegotiated in terms of commons resource areas and bioregions. Resource users and producers/providers would then make direct decisions on all common properties of significance, holding and managing them for future and existing generations and species. Since every resource domain is unique and so many commons overlap, commons management would be deliberated through local, state, interstate, regional, and global stakeholder discussions. In this way, democratic commons institutions would operate at every level of governance independently while overlapping at the same time.
Obviously, the development of global governance is an enormous challenge. The basis of the sovereign state must be entirely reformulated. By agreeing to a new foundation for common goods in social and economic laws and institutions, the state will have to reduce the dominant role of private goods and recognize the moral and political legitimacy of people's rights to preserve, access, produce, manage and use their own resources. This means developing a new epistemology of resource sovereignty, shared responsibility and legal accountability that recognizes the rights of world citizens to their commons. When the self-organized and participatory systems of common property, social charters and commons trusts are infused into global constitutional governance, the checks and balances that already exist within many nations will find a more perfect expression in the representative decision-making and political equality of democratic commons institutions. The new global economic system and its social contract will be grounded, not in corporate claims or state sovereignty, but in the sovereign rights of citizens to their common goods.
**James Quilligan** _(USA) has been an activist in the Common Heritage and international development fields since the 1970s. He specializes in the epistemology and ontology of the commons and their connection with political and monetary structure._
# Subsistence: Perspective for a Society Based on Commons
_By Veronika Bennholdt-Thomsen_
Subsistence is the sum total of everything that humans need to survive: food and drink, protection from cold and heat, caring and company. If subsistence needs are met, life can continue (Mies/Bennholdt-Thomsen 1999). Many aspects of subsistence – goods and activities – have been transformed into commodities, but by far not all of them. After all, not only children, but adults as well cannot exist without being directly nourished and cared for, without being attended to and given gifts. Certain vital elements of subsistence, the ones that signify humanity, so to speak, cannot practically be commercialized. Accordingly, subsistence is defined as the realm of life beyond payment in a society otherwise permeated by the market.1 Subsistence still belongs to modern human beings' everyday life experience, even if the globalization of markets has driven this fact from people's awareness. That applies to the commons, too, on which our society again still rests. (1. "Subsistence production or production of life includes all work that is expended in the creation, re-creation and maintenance of immediate life and which has no other purpose. Subsistence production therefore stands in contrast to commodity and surplus value production. For subsistence production the aim is 'life', for commodity production it is 'money' which 'produces' ever more money....life is, so to speak, only a coincidental side-effect." (Mies and Bennholdt-Thomsen 1999, p. 20))
Neither subsistence nor commons are vestiges of bygone centuries; on the contrary, they continue to fulfill necessary functions and embody perspectives that point to the future. Yet the opposite view is propagated. The privatization (of land, water and other things) and the commercialization of commons (for example, air or genes), which restricts access or even eliminates them for many people, are actually considered serious solutions for global problems such as hunger and climate change. "To draw farmers from subsistence to commercial agriculture" has been the declared policy of the World Bank since the mid-1970s.
According to the World Trade Organization (WTO), the overall goal of globalized development policy lies in integrating as many areas relevant for daily existence as possible into the monetary and commodity-based economy. One example of this is the internationally promoted expansion of microcredit. The more needs are dealt with via money, the better and more developed a society supposedly is. The profound crisis of the growth-based economy, of which the ecological crises are a part, raises substantial doubts about this view.
**What is taken for granted**
Over the course of modernity, commons as societal institutions (Ostrom/Helfrich 2011) have increasingly been reified to being considered merely material objects. This is nothing less than a fundamentalist reinterpretation of the commons influenced by neoliberal thought. No longer do people perceive the purpose or the meaning of socially binding arrangements when it comes to commons; they mostly see only the object itself to which a societal convention refers. And where the material reality of the phenomena in question is immaterial and volatile – for example, the air or the knowledge about a plant's healing properties – they are reified by privatizing them and assigning them a monetary value – through the establishment of carbon emissions trading rights, for instance, or through the patenting of knowledge according to the WTO's regime for intellectual property rights.
Commons, however, reflect people's understanding of the elemental conditions of nature and human life, not as tradeable commodities. They reflect a set of values and a worldview that is increasingly becoming lost in modernity. In light of the nuclear disaster in Fukushima, it is becoming apparent where our arrogance in relation to the living environment has taken us. We act as if it were possible to technically produce and scientifically control nature in its entirety.
This "modern" mentality originated in the 19th century. But it is now considered obsolete, and not just in physics. Just as particles are not simply isolated bits of matter in quantum physics, commons are far more than the material of which they consist, and far more than the monetary value with which people attempt to capture their nature. They are part of a _web of relationships_ , _both concrete matter and a process in motion, all in one_. But this understanding begins with the fact that they exist, _just as we are given life_ , today just as hundreds of years ago.
In Latin, _subsistere_ means "to endure in and of itself." Subsistence is what is necessary for survival and what belongs to every life, as unquestioned as the air we need for breathing. In addition to food and other necessities of life, the concept also includes the process of reproduction, which takes place anew every day, and this process too is by its very existence self-understood. Even the early working class in England shared the worldview of the "moral economy." That is the term which E.P. Thompson uses to describe the societal convention handed down over millennia by which it is never called into question that all human beings are to be provided with the conditions necessary for their lives to continue. It would be misleading to say that they have a "right" to these conditions, as this would imply the acceptance of a previous limitation.
Conceptualizing economic activity through the lens of subsistence – in other words, perceiving the subsistence perspective of economic activity – means to acknowledge that human life is part of natural processes.
**The individual level and the societal level**
The people in a society founded upon commons orient themselves toward what is necessary for a good life, and not toward using more and more consumer goods. They _individually_ feel responsibility for what is common to all. Consumerism, in contrast, undermines the commons and finally society as well, as it undermines people's feelings of belonging to one another. We are currently experiencing the effects of this problem in our epoch of multiple crises.
Economic, ecological and social crises are merging to form a single one, a crisis of civilization.In light of the catastrophes that they have triggered, the values that characterize our current civilization are proving to be destructive. We need a paradigm shift worldwide: a shift away from egocentric consumerism, away from a society's structural imperative to maximize growth, _and_ away from our arrogance with respect to the living environment. We, the people of our epoch, need new (old) societal institutions that are bound to a new (old) relationship of humans and nature.
We are not facing this situation empty-handed; starting points do exist in terms of the knowledge, cultural values and the natural conditions that are needed. At the individual level, every human being experiences the meaning and significance of subsistence via the unpaid and priceless care that is bestowed upon every child. Such types of experiential knowledge about commons provide us with means for reshaping life at the societal level.
The close connection between the individual level of experience and the sociocultural ability to comprehend commons as a gift of nature is formulated by Miguel D'Escoto and Leonardo Boff in Article 1 of their proposal for a Universal Declaration on the Common Good of the Earth and Humanity. "The supreme and universal Common Good, a condition for all other good, is the Earth itself which, being our Great Mother, must be loved, cared for, regenerated and revered as we do our own mothers."2 It is taken for granted, that "our own mothers" are revered, just as it is taken for granted that every human being experiences the care necessary for subsistence and the corresponding means of subsistence, simply because he or she is born as a human being. The egalitarian condition of all human beings is recognized – as we all are born by "a mother"(Bloch 1961/1997). There is a correspondence between the ideas that food comes from the Earth and life comes from women. This mentality, which is firmly anchored in people's personal sensory experience, supports the culturally binding worldview that all human beings are to be provided with conditions so that their lives can continue. That is why we need commons. They build an important bridge between the individual and the society on the way towards a socialization that teaches us to respect both what is given by nature on the one hand and our existential relationships with other people on the other, rather than destroying both. (2. http://www.rlp.com.ni/noticias/general/71589)
Some, including Western gender feminists, reject the metaphor of "Mother Earth" because it ascribes a special significance to the human mother. They accuse those who recognize the birth-giving capacity of women as a natural given of being essentialists. Hence, gender theorists deny the existence of the human beings forming part of nature as they do not acknowledge mothering as a fact of nature.3 Nevertheless, I would say that whoever shares this accusation should feel free to replace the metaphor Mother Earth with a different image – because the only important things in our epoch are images that help to unlearn the destructive values of the society of maximization and to learn equality anew (because we all exist through the same process of human birth), so that people feel and understand that what is given by nature cannot be appropriated and privatized; they have been given to all of us, _just as life has been given to us_. We need images that support the insight that a commons-based society requires the individual, everyday practice of subsistence. (3. According to gender theory, the sexual existence of the human being is exclusively a social phenomenon.)
**Money is the problem, not the solution**
In keeping with the dominant understanding that the feasibility of any plan is dependent on funding, the question of money is often raised too quickly in discussions about the realization of alternatives to the growth-based economy. Even if some projects to strengthen the commons cannot do without money, this does not alter the fact that the logic of money as we know it is a fundamental built-in error of current-day socialization.
For the civilization based on the economy of maximization, monetary value becomes the touchstone of all value. When value and monetary value are simply equated, the moral error is rarely noticed; that is how normal this reversal is. Time and again, I realize how morally depraved the resulting value system is. When I reread the first UN Millennium Development Goal – "Halve, between 1990 and 2015, the number of people whose income is less than $1 a day. ...Halve, between 1990 and 2015, the proportion of people who suffer from hunger."4 – I think, "And what about the other half?" The morals of the money-based world are light-years away from the humane moral standards that are taken for granted in the subsistence economy, namely that nobody should remain hungry as long as others, have enough to eat.
(4. http://www.un.org/millenniumgoals/poverty.shtml)
One dollar a day! That simulates concreteness, relief that is allegedly material, tangible and reliable (" _In God we trust"_ ). But you can't eat money! The number, as well as the dates and the number of people, is intended to signal authentic commitment and determination. In truth, more people on this planet are hungry today than at the beginning of the millennium.
The logic of money is that of a mathematical equation, an exchange of equivalents. Order is supposedly achieved through the objectivity (or tangible quality of an object) of an invisible hand, which is supposed to be superior to the disorder of diversity given by nature. In the present, this is proving to be completely wrong. The logic of money is not suitable as a moral foundation for civilization.
**The perspective of subsistence and the commons**
"It's your city. Dig it up!" This motto from the urban gardening movement includes all the elements that characterize the cultural transformation shifting away from the paradigm of growth and toward a society founded upon commons.5 (5. On the rediscovery of communal gardening in cities, see the essay by Christa Müller.)
• The public space, that is, the city and its open spaces, are considered to be commons.
• The motto addresses the individual, the person defining him/herself as part of the commons community, by politically empowering him/herself beyond a superordinate, disciplining, possibly state-organized power.
• It includes an understanding of direct communal capacity to act, as is distinctive of grassroots movements.
• It is not about money, but straightforwardly about subsistence. If we desire to create a society based on commons today, we need to take a subsistence-based perspective. And a prerequisite for action oriented toward what is required for a good life is consolidation of the institutions of the commons. Subsistence and commons strengthen each other.
**References**
Bloch, Ernst. 1961. _Naturrecht und menschliche Würde_. Suhrkamp. Frankfurt.
Bloch, Ernst. 1997. _Natural Law and Human Dignity_. Cambridge, MA. MIT Press.
Mies, Maria and Veronika Bennholdt-Thomsen. 1999. _The Subsistence Perspective. Beyond the Globalised Economy_. London, UK. Zed Books.
Ostrom, Elinor and Silke Helfrich, editor and translator. 2011. _Was mehr wird, wenn wir teilen, oekom_. München.
Thompson, E.P. 1980. _The Making of the English Working Class_. Hammondsworth, UK. Penguin.
**Veronika Bennholdt-Thomsen** _(Germany) is an ethnologist and sociologist at the nonprofit Institute for Theory and Practice of Subsistence. Professor Bennholdt-Thomsen has pioneered research on women and subsistence theory in Germany, and focuses on regional and feminist economies in Latin America and Europe. She teaches at the University of Natural Resources and Life Sciences, Vienna._
# Technology and the Commons
_by Josh Tenenberg_
__
"Jens had to cultivate a strong, unified mind to counteract the disparate landscapes, societies, conditions. He jumped from a monthlong spring hunt to a helicopter that would take him to Nuuk to testify in front of Parliament. On behalf of the Hunters' Council, he was working hard to ban the use of snowmobiles and prohibit fishing boats in Inglefield Sound, where the narwhal calve and breed in summer" (Ehrlich 2003). This episode concerning a Greenlandic hunter in the early 21st century encapsulates the main theme of this paper: technologies, the policies that govern them, and their use in particular settings all contribute in dynamic and complex ways to their socio-political effects. Yet intended technological effects are not inevitable, as they are subject to resistance, adaptation, and appropriation by the actors within social settings. Technologies can both exacerbate commons dilemmas as well as contribute to their solutions. A keener awareness of the socio-political implications of technologies will increase the likelihood that people design and use technologies to improve the human condition.
**The politics of technology**
The relationship of technology to politics and social order has interested philosophers, historians, and technologists during the last 50 years. One view, exemplified by Lewis Mumford (1964), asserts that technologies have inherent political qualities: they structure social relations in their very design. "My thesis, to put it bluntly, is that from late neolithic times in the Near East, right down to our own day, two technologies have recurrently existed side by side: one authoritarian, the other democratic, the first system-centered, immensely powerful, but inherently unstable, the other man-centered, relatively weak, but resourceful and durable." Under this view, rather than being used differently in different socio-political settings, technologies exert their own political stamp on society regardless of context of use: technology determines subsequent social development. Society is thus "engineered" through technology.
Winner expresses an alternate view, that most technologies are not immanently political, but that "the design or arrangement of a device or system could provide a convenient means of establishing power and authority in a given setting" (1980). Technologies are the means by which social actors achieve political ends. Winner provides the example of Cyrus McCormick's employment of pneumatic molding machines in his manufacturing plant in the middle 1880s, not because they were more efficient, but because they displaced skilled workers, thereby shifting more power into the hands of managers within the political economy of the plant. Another way that social actors affect technology is in pursuing policies that serve their interests. For example, in a careful legal and historical analysis, Litman (2000) documents how the Hollywood studios, music companies and content industries have been the main actors in crafting copyright policy in the U.S. over much of the 20th century, with the public largely unrepresented.
A third view, promoted by Friedman and Kahn (2002), recognizes that technologies can have political effects, but that these effects are only partly a result of intentional design. As importantly, users of technology in local settings assert their agency to shape, resist, appropriate, and adapt technologies to their intentions. So, for instance, though the planners of Brasília (constructed in the late 1950s) might have had goals to create a thoroughly regularized and rationalized modern city through the very structure of the built environment – its immense (and largely empty) plazas, rectangular apartment blocks, separation of traffic from pedestrians, and segregation of places of work, commerce, and home – the actual residents had other plans. Incrementally constructing an "other" Brasília on the outskirts of the "built" Brasília, originating as squatter settlements of laborers, this non-planned Brasília came to contain 75 percent of the population of the city, winning political recognition and city services only through ongoing political action (Scott 1998).
I take the view that all of these elements – technology, policy, powerful social actors, and technology users in local settings – have complex and reciprocal influences on one another that unfold over time as the different actors plan, take action, and respond to the actions of others. Technologies neither operate autonomously and inevitably to shape social arrangements, nor do individuals and groups simply succumb to the social arrangements enforced by the technologies and policies designed and developed by powerful social actors.
**Focal and non-focal effects of technology**
Technologies are intentionally designed for particular purposes: nets for catching fish, saws for felling trees, telephones for communicating with others at a distance. These proximal, intended effects are what Sclove (1995) calls the "focal" effects of a technology. Yet it is easy to underestimate the complex ways in which people and technologies are intertwined, so that changes to technology sometimes result in far-reaching effects that extend beyond these immediate, focal effects. Technologies also result in what Sclove calls _non-focal_ effects, the "pervasive, latent tendencies" of technologies to "shape patterns of human relationship" (Sclove 1995). These effects are often unintended, outside the focus of many actors in a setting when a new technology is introduced.
Sclove provides the example of Ibieca, Spain, where residents had indoor plumbing installed during the 1970s, replacing their mutual dependence on a village fountain. As a result, "women stopped gathering at the washbasin to intermix scrubbing with the politically empowering gossip about men and village life". And by introducing indoor water pipes, donkeys were no longer needed for hauling water, so that they were more likely to be replaced by tractors for work in the field, which led to a higher dependence of the villagers on outside jobs. Thus, Sclove claims, social bonds were weakened, reducing the possibility for collective political action. Both focal and non-focal effects are important to consider when technological choices (about designs, about policy) are being made.
**Complex interactions between technology and people**
In order to better understand the dynamics of the settings in which social groups interact (including but not limited to commons), Ostrom and colleagues have identified several key elements that can be thought of as the "working parts" of these settings (Ostrom 2005.)1 "These are: (1) the... _participants_ , (2) the _positions_ to be filled by participants, (3) the potential _outcomes_ , (4) the set of allowable _actions_...(5) the _control_ that an individual has...(6) the _information_ available to participants...and (7) the _costs and benefits_ – which serve as incentives and deterrents – assigned to actions and outcomes" [emphasis added] (Ostrom 2005). These elements can be thought of as having political import, i.e., they affect power and authority within a particular setting, because the actors involved craft rules that affect one or more of these elements, for example: who can access a commons, who can sanction, what the actors know about the state of their commons and one another's actions, how preferences are combined (such as "the elected leader decides" or "majority rules"), and the penalties associated with rule noncompliance. (1. See also Ryan T. Conway's essay on Institutional Analysis and Development (IAD).)
Using these same elements, we can inquire as to how technologies affect each of them as an analytic means for examining the impact of technology – both focal and nonfocal – on the social order. For purposes of space, I provide illustrative examples of technologies that affect _participants, control _and _information_.2 (2. See Tenenberg 2008 for a discussion of all seven of the elements indicated above.)
The participants in a commons are the actors who can derive benefit from the commons (such as access to resources), participate in governance (such as rule making and enforcement), and/or be required to contribute to the maintenance of the commons.3 New technologies of transportation, such as the snowmobile in Greenland, mentioned earlier, can have the direct effect of bringing new participants into a setting. Nonfocally, this can strongly affect a commons, since new participants may place increased demand on resources. In addition, they may not share evolved norms that have developed by long-standing commons participants for sustainably managing their commons. (3. Editors' note: In this volume, several articles on concrete practices describe the relationship between common-pool resource management and a careful use of technology. See, for instance, Papa Sow and Elina Marmer, and Gloria Gallardo and Eva Friman.)
Who can participate in a commons is strongly influenced by technologies of exclusion.4 The historical record indicates the importance of these technologies. "Between 1870 and 1880, newspapers in the region [the western prairies of the US] devoted more space to fencing matters than to political, military, or economic issues" (Basella 1988). The growth of the barbed wire industry provides a dramatic illustration. From 10,000 pounds of barbed wire in 1874, the first year of commercial production, production jumped to 600,000 pounds in 1875, to over 12 million pounds in 1877, and 80 million pounds in 1880 (Basella 1988). Technologies of exclusion, such as fences or digital rights management5 are used to enclose physical or virtual spaces. Such enclosures can create new commons, by providing commoners a means to exclude others from despoiling a resource, or they can destroy commons, by allowing powerful elites to capture what had previously been held in common. Technologies of circumvention can likewise be used to nullify technologies of exclusion. Ladders and wire cutters can overcome fences, for example, and software programs for descrambling commercial DVD's can gain access to encrypted content (Touretsky 2001). The latent effects are technological arms races that pit those trying to exclude against those trying to circumvent, a dynamic that we see playing out with digital information on the Internet (Committee on Intellectual Property Rights 2000). (4. See also Silke Helfrich's essay. 5. Editors' note: The term digital rights management (DRM) is used to describe any technology that inhibits uses of digital content that are not desired by the content provider. Sony, Amazon, Apple Inc., Microsoft, AOL, the BBC and others use DRM-technologies. In 1998 the Digital Millennium Copyright Act (DMCA) was passed in the United States to impose criminal penalties on those who circumvent encryption, i.e. DMCA enforces DRM. Because the use of digital rights management inhibits user freedoms, some critics have dubbed it "Digital Restriction Management.")
With exclusion, whether by policy or technology, what might have previously required human monitoring for compliance can be replaced by technologies that dramatically reduce the costs of enclosure. For example, razor wire and electric fences not only "monitor" access, but "sanction" the trespasser, replacing human intervention with automation. Thus, technologies of exclusion embody specific rules of exclusion. The ubiquitous "No trespassing!" sign might signal the rule, but it is the fence that enforces.
Technology also affects the way in which control is distributed among the actors in a particular setting. For instance, cutting guides and mechanical linkages directly constrain the motion of the human body when people use physical tools such as saws and lathes. Through the study of this kind of ergonomic micro-structure of technologically-enabled work in the early part of the 20th century, Frederick Taylor built sociotechnical processes to further structure human labor in the industrial factory. The new technologies and workplace policies were systematically designed so as to deskill labor – so that it could be purchased less expensively – and move control over production from the shop floor to management (Braverman 1974). And yet, nonfocally, as Kusterer (1978) illustrates from his study of "non-skilled" labor in a variety of workplaces, workers are never as compliant as these Taylorist designs suggest: they use ingenuity and learned expertise to increase production and quality, as well as their own autonomy, by working around the managerial and technical constraints of the formal policies that management puts in place. Just as with the case of Brasília, powerful actors may attempt to structure and control sociophysical worlds through idealized, technically shaped visions that fail to take account of on-the-ground realities.
Technologies associated with voting – from paper ballots to punch cards, optical scanners and graphical user interfaces – are increasingly recognized for their role related to political control, particularly following the contested outcome of the 2000 presidential election in the United States. "Election processes are inherently subject to errors and are also historically subject to manipulation and fraud.... Voting is in fact a paradigmatic example of an end-to-end security problem representing a very broad spectrum of technological and social problems that must be systematically addressed – from registration and voter authentication to the casting of ballots and subsequent tallying of results. Each of the current technologies has its own set of vulnerabilities; none is infallible" (Neuman 2004).
Different voting technologies impact the amount of error in vote counting (The Caltech/MIT Voting Technology Project 2001), the security and reliability of the voting process (Felten 2003), and its transparency and auditability (Felten 2003). Focally, a change of technology from paper ballots or punch cards to computer ballots may seem a relatively minor matter of implementation detail. But this overlooks a characteristic of computers: "Most of the time and under most conditions computer operations are invisible" (Moor 1985). Part of the controversy surrounding the use of computerized voting systems concerns the fact that the computational invisibility, when coupled with legally enforced ownership of program source code that excludes all but the owners and their agents from looking at the program internals, makes these systems inherently incapable of audits by disinterested third parties (Massey 2004).
This invisibility of technical operations is one of the ways that technologies affect information, and it is not limited to computer technology. Technologies that do not enable transparency for such things as monitoring other participants' resource use can result in the abandonment or destruction of the technology. Lansing's example (2006) related to rice irrigation in Indonesia during the "Green Revolution" of the 1970s is telling:
This method [the flooding of rice fields on a careful schedule] depends on a smoothly functioning, cooperative system of water management, physically embodied in proportional irrigation dividers, which make it possible to tell at a glance how much water is flowing into each canal and so verify that the division is in accordance with the agreed-on schedule....Modernization plans called for the replacement of these proportional dividers with devices called "Romijn gates"....The use of such devices makes it impossible to determine how much water is being diverted.
Despite the $55 million dollars that the government spent on installing the Romijn gates, "new irrigation machinery installed in the weirs and canals at the behest of the consultants was being torn out by the farmers as soon as they felt that it was safe to do so" (Lansing 2006).
To summarize from these examples, technology is designed for particular purposes, often by social actors with the economic power to direct resources. Focally, the technologies affect who can participate within a setting, the relative control among the different participants, and the information available. The engineering of materials does affect social structure. This is often the explicit intention of its architects: to shape physical activity, to enable patterns of mobility and communication, to divide, to join, to enclose, to circumvent. And yet, individuals within particular settings are not simply acted upon, not powerless in the face of technically enforced regimes of control. Nonfocal effects, sometimes far reaching and unintended by the technology designers, arise from the complexity of the sociophysical world and from the active adaptation and work-arounds to sociotechnical systems by actors on the ground.
**Institutional and technological change**
Social scientists since Max Weber (1895–1994) have underscored the importance of rules and rule-like mechanisms (often called institutions) for ordering social life, many of which change over time to adapt to new circumstances. As Douglas North indicates in his Nobel Prize lecture, "Economic Performance through Time" (1993), "It is the interaction between institutions and organizations that shapes the institutional evolution of an economy. If institutions are the rules of the game, organizations and their entrepreneurs are the players." But what many social scientists (including North) overlook is the importance of technology as it affects institutional and social development. To extend North's sports metaphor, we can consider technologies to be the equipment of the game. People not only change the rules by which they play, they change the equipment. And sometimes, changes to equipment change the very nature of the game.
Technology and the policies related to them interact over time. Stable technologies provide time for the crafting of social policies that are fit to the technology, the people, and the material environment of use. Schlager illustrates in her comparative study of 33 subgroups of fishers worldwide (1995), "Twenty-two groups (67 percent) limit access to their fishing grounds on the basis of type of technology used." She continues, "For example, the cod fishers of Fermeuse, Newfoundland, described by K. Martin (1973, 1979), have 'divided their own fishing grounds, as have many inshore fishing communities, by setting aside certain fishing areas (usually the most productive) for the exclusive use of certain technologies'" (Schaler 1995).
Yet, as technology changes – not as a natural process, but intentionally, often enabled by policy – changes occur throughout the setting in which the technology is used: new participants enter, new information becomes available, different outcomes arise, and costs and benefits are apportioned differently. Because of this, actors in the setting may pursue adaptive responses in policy. These new policies constrain (though do not determine) the development of subsequent technologies, which in turn constrain (though do not determine) further policy responses, continuing in this fashion iteratively and indefinitely.
It would be strange to inquire whether rules and policies are political – how could they not be? And yet it is easy to overlook the political nature of technologies, and their resulting impact on commons, despite the fact that, like rules, they affect the same elements: the participants, the control, the information. But technologies are particularly important to take into account in the construction and maintenance of commons, since they can change quickly and have pervasive effects. And as with rules, they are subject to intentional human design. Technologies are political, but not in a deterministic or inevitable way determined solely by their design. Neither are technologies determined only by powerful social actors through how they direct capital and pursue social policies. As importantly, particularly for the future of commons, individuals and collectives of non-elite actors both comply with and resist technology policy, and as importantly, adapt, appropriate, and alter the technologies to hand to fit the contingencies that they face.
Jens, the Greenlandic hunter mentioned at the start of this paper, does not take a uniform anti-technology stance; he himself depends on technology to survive and to hunt. Nor does he simply accede to the intrusion of snowmobiles into Inglefield Sound, a commons that he shares with several of his countrymen. Rather, he acts in the policy domain (one of the degrees of freedom available to him) to try to prohibit snowmobiles in Inglefield Sound. To ask whether snowmobiles are good or bad, democratic or authoritarian or whether, in general, snowmobiles are political, is beside the point. Rather, the point is how Jens and his fellow Greenlanders will respond to the specifics of a new technology that impacts the commons that they share. Such a response might be technological, e.g., with exhaust mufflers; legal (with a general ban that is enforced); social, e.g., organized vigilante action; or some combination, e.g., a law that requires the use of mufflers at certain times and dates, monitored both by the state and by citizens. What choice they make is political in nature, as are future technological and policy actions that this choice will give rise to.
**References**
Basella, G. 1988. _The Evolution of Technology_. Cambridge University Press.
Braverman, H. 1974. _Labor and Monopoly Capital; The Degradation of Work in the Twentieth Century._ New York. Monthly Review Press.
Committee on Intellectual Property Rights, Computer Science & Telecommunications Board. 2000. _The Digital Dilemma_ : _Intellectual Property in the Information Age_. National Academy Press.
Ehrlich, G. 2003. _This Cold Heaven: Seven Seasons in Greenland_. New York. Vintage.
Eisenstein, E.L. 1983. _The Printing Revolution in Early Modern Europe_. Cambridge. Cambridge University Press.
Felten, E. 2003. "A Skeptical View of DRM and Fair Use." _Communications of the ACM, (_ 46)4:56-61.
Friedman, B. and Kahn Jr., P.H. 2002. "Human Values, ethics, and design." In _Human Factors and Ergonomics,_ 1177-1201.
Kusterer, K. 1978. _Know-how on the Job: The Important Working Knowledge of "Unskilled" Workers_. Boulder, Colorado. Westview Press.
Lansing, S. 2006. _Perfect Order: Recognizing Complexity in Bali._ Princeton. Princeton University Press.
Litman, J. 2000. _Digital Copyright._ **** Amherst, NY. Prometheus Books.
Massey, A. 2004. "But We Have to Protect Our Source: How Electronic Voting Companies' Proprietary Code Ruins Elections." _Hastings_ _Communications and Entertainment Law Journal_ (27): 233.
Moor, J.H. 1985. "What is Computer Ethics." _Metaphilosophy._ 16(4):266- 275.
Mumford, L. 1964. "Authoritarian and Democratic Technics." _Technology and Culture_. (5)1:1-8.
Neumann, P. 2004. "Introduction to the Special Issue on the Problems and Potentials of Voting Systems." _Communications of the ACM._ 47(10):28-30.
North, D. 1993. Nobel Prize Lecture, "Economic Performance through Time," http://nobelprize.org/nobel_prizes/economics/laureates/1993/north-lecture.html.
Ostrom, E. 2005. _Understanding Institutional Diversity._ Princeton. Princeton University Press.
Schlager, E. 1994. "Fishers' institutional responses to common-pool resource dilemmas." In Ostrom, E., Gardner, R. & Walker, J. _Rules, Games, and Common-Pool Resources_, University of Michigan Press. 247-266.
Sclove, R.E. 1995. "Making Technology Democratic," In _Resisting the Virtual Life: The Culture and Politics of Information,_ 85–101.
Scott, J.C. 1998. _Seeing Like a State: How Certain Schemes to Improve the Human Condition Have Failed._ New Haven. Yale University Press.
The Caltech/MIT Voting Technology Project 2001, "Residual Votes Attributable to Technology: An Assessment of the Reliability of Existing Voting Equipment."
Tenenberg, J. 2008. "The Politics of Technology and the Governance of Commons." The 12th Biennial Conference of the International Association for the Study of Commons, Cheltenham, England.
Touretzky, D.S. 2001. "Viewpoint: Free speech rights for programmers." _Communications of the ACM._ 44(8): 23-25.
Weber, M. 1895/1994. _Political Writings_. P. Lassman and R. Speirs, editors and translators. Cambridge. Cambridge University Press.
Winner, L. 1980, "Do Artifacts Have Politics?" _Daedalus._ (109)1: 121-136.
**Josh Tenenberg** _(USA) is a Professor in the Institute of Technology at the University of Washington, Tacoma. He does research in computing education, human-centered design, and the politics of technology. He is co-Editor in Chief of the ACM Transactions on Computing Education._
# The Commoning of Patterns and the Patterns of Commoning: A Short Sketch
_By Franz Nahrada_
What would you have to think of if you want to build a liveable house? Maybe you would start looking at the environmental factors, an identifiable neighborhood, green areas nearby. You would look at the building site and choose to improve what's there. You would create open space towards the south, and give it a distinct positive form. The building should gently absorb daylight and have different levels of intimacy. Common areas should be in the middle, located on the way in, and close to a kitchen and to the garden. And so on.
These concerns may sound trivial, but they are not. There are a thousand ways of doing things wrong – and only a few ways of doing things right. The choices depend on the situation, resources and goals. But what if we had a toolbox that would allow us to understand and combine solutions in a given field, such as architecture? That's the idea of patterns, an idea introduced by Christopher Alexander in the field of architecture (Alexander 1977).
The idea of patterns is to understand reality as a set of patterns that assume an intrinsic design for connectedness between elements of a "living" reality. In a nutshell, Alexander claims that "good" architecture mostly works by the recognition of the right choices to solve problems, and that good solutions can be found on the basis of proven experience of "what works" for human well-being and sustainability. These solutions can be methodologically described as "patterns" which combine theoretical "reconstructions" of well-working solutions with practical guidelines for construction.
A pattern thus can be defined as a proven solution to a common problem that can be identified, analyzed and reproduced. Almost anything can be a pattern, from physical structures to rules of behavior. Patterns ideally complement each other in efficient and creative ways, and tend to reinforce and enable each other's functions. Thus a "pattern language" helps disclose the manifold relations among design elements. By understanding the "grammar" of such a language, even a nonexpert can quickly gain a basic competence in a given field and understand and participate in design and development. Patterns are the best way to condense experience and enable people to go beyond theory and make the right decisions in practical situations.
Alexander developed such a pattern language with 253 patterns. They range from "Organizing the planet as a commonwealth of independent regions" to "using things from your life rather than inauthentic decor for interior design." His patterns span a universe of relevant influences and interdependencies in towns, buildings, and constructions. His innovative method of identifying components by their mutually reinforcing and life-building relations has been successfully transferred to many diverse fields such as object-oriented programming,1 pedagogy, and political activism. More of these conceptual transpositions seem to be in the works. Some claim that this pattern-based process is heralding a scientific revolution that reverses the shortcomings of analytical and isolating methods that have dominated science since René Descartes. Such a science would allow for more coherent views of a field and eliminate the odd structural contradiction between theory and practice. (1. Object Oriented Programming treats chunks of code as entities that can be treated like objects with properties and behavior. It is not only a way to accelerate coding, but also a way to make code reusable and more understandable.)
In his later work, Alexander left the narrow domain of architecture and sought to analyze what lies behind patterns in general. In a very crude way one could say that what lies between patterns are universal laws of life. Or, to be a little bit more precise: patterns are the properties of structures that facilitate the persistence and interplays of different kinds of what we would call energies and potentials. Patterns are like containers for complex, living processes whose energies result in "wholeness," "proportion," "synergy" and "beauty." They are the condensed experience of many successful creations. They talk to us by a "quality without a name," and are recognizeable to intuition. They demand visualization, and not just sequential description.
The schools of thought inspired by Alexander have subsequently developed the concept of "anti-patterns," which are social practices that diminish vitality and sustainability. The cult of the genius in current architecture results in buildings that are often not liveable. The management of societies through punishment breeds the very depravities and criminality that it claims to prevent. This is another hint patterns are by no means to be taken for granted – moreover, they are often ignored and suppressed.
I suggest that patterns are a central topic – and maybe even a methodological requirement – for those interested in the commons. There are three main reasons: Patterns are a common denominator for all kinds of social and cultural practices that allow us to consciously shape our world. They designate knowledge resulting in vital, sustainable, fruitful reality. They allow us to generalize what works. Thus they are the ultimate intellectual commons. Commoning of patterns is an old tradition in many professions, crafts, and disciplines. Wherever patterns are respected, there is a social process that lies behind them.
In a time when everything can be produced easily with machines and automation, capital is shifting its methods of growth from its traditional ways (production) to outright "feudal ways" (taxation). In a time of immense devaluation of products by automation, success lies in asserting the ultimate gains through ownership rights to successful patterns, which confers an ability to tax others to use the pattern. Thus labor and capital are slowly moving apart, a long marriage ending. Patterns of production and products are therefore the strategic nodes that privatizers exploit as they seek to establish their (lucrative) traps to hinder and forbid any successful, competitive activities – or, simply seek to exploit them by trading the licenses. Think of biopiracy and bioprospecting for the sake of commercializing indigenous knowledge. Think also of the gross expansion of patents in all domains of technology. One could think of today's economy as a big preventive endeavor against commoning by enclosing the very essence of free, autonomous labor: the knowledge, experience and procedures required in all professional fields. This enclosure grows as networks and technologies would make it more and more feasible to share knowledge in larger scales and produce in smaller scales – a deadly danger for capital, which needs to do exactly the opposite.
The practice of commoning itself may be understandable as a set of interrelated patterns. Rather than deriving from one single point of departure or axiom, commoning is the product of a multitude of practices that may take many different forms, according to the nature of the collective resource it is built upon as well as many other factors. Thus a pattern language of commoning may be a way to prevent dogmatism and schisms in the commons movement – a way to acknowledge unity in diversity while expanding the applicability and vitality of the core concepts.
**The commoning of patterns**
It is important to see that patterns are more than snippets of cultural heritage; they are even more universal in nature. Their essence lies beyond identity and tradition, even if tradition and culture are the most fertile ground through which to discover patterns. Ideally a pattern community consists of people rooted in cultural traditions yet oriented towards global cooperation. Thus, the essential question is: where is a group of people or a community to effectively take care of a shared resource and shape a whole environment, sets of behaviors, institutions etc.?
We might compare the emerging "pattern communities" to the traditional "scientific community." Although universal in its approach, the latter distances itself from the practical uses and applications of knowledge. There are many ways to reflect on practical use and effects like technology assessment, still science treats its objects in isolation and "neutrally" and often reflects on practice in hindsight.2 Pattern communities on the other hand seek to reflect constantly on the interchange and interplay of their objects with human practice. We find analogies in old guilds of craftsmen or engineers associations. However, such voluntary or mandatory networks were often overshadowed by professional competition and political power plays. Knowledge was often withheld from non-members. Pattern communities in the full sense – as we envision them – constitute a self-organized society of learning, knowledge and self-determination. They might even be managed by nonexperts, based on the essentially democratic idea that the modern individual should not be bound to specific roles in the division of labor. (2. There are new approaches like "transdiciplinary research" that are aware of this dilemma. But they often lack a clear methodology to include a multitude of perspectives. Pattern languages are a way to organize the theoretical field in a way that is open to almost anything that exerts relevant influence and coexists in a given field of reality. It is interesting that Alexander has mixed his architectural and planning patterns with a lot of cultural, political and sociological patterns, expressing the needs and wants of humans in their life cycle – simply by understanding that architecture is meant to meet human needs, and social reality is always in immense interplay with spatial reality. Pattern communities therefore not only allow for inclusion of practical perspectives, they live on them.)
A good example to meet the full requirements of a pattern community seems to me the communities around PloP, the Pattern Languages of Programs, or of object-oriented programming. As Brad Appleton, founding member of the Chicago Patterns Group, puts it: "Forming a common pattern language for conveying the structures and mechanisms of our architectures allows us to intelligibly reason about them. The primary focus is not so much on technology as it is on creating a culture to document and support sound engineering architecture and design."3 (3. Brad Appleton, quoted in http://hillside.net/patterns)
The ambitions of pattern communities are enormous. The maintenance of a common body of knowledge, the distillation and identification of the patterns having the highest potential, the presentation of them in intuitive ways – all of these will only exist if the social interest in providing the necessary resources can successfully organize itself.
So we need to ask the question, What is the social base of a successful commoning of patterns? What type of lifestyle as well as economic logic can beget the constant exchange of knowledge, generous sharing, and the collective refinement and abstraction of good solutions? What is the lifestyle and economic logic that can discourage or prevent patterns of separation, monopolization of knowledge and predatory abuses of ignorance?
The answer might be manifold and ambiguous. Commoning can serve the practical needs of individuals and businesses who are too "weak" financially to compete or trade in the realms of intellectual properties. It can be found in the practices of those who seek autonomy and community-based production. It can be found in traditional institutions that had their original framework in nation states and now see that a global educational commons serves their purposes well. It can be found in international organizations, professional organizations, cooperatives, associations of educators, and so on.
Seeds of pattern communities are emerging in many different domains, also in the heart of scientific communities that have largely weakened their traditional focus on cooperation since they have become more oriented to business applications, obtaining patents, compete for funding, etc. While many universities are busy trying to accumulate patents,4 for example, some are beginning to rediscover the value of generous sharing and form transdisciplinary communities around "pattern repositories." They understand that knowledge will best develop if it is shareable and expandable, and open for review and improvement. (4. See for example the "Ontology Design Catalogue" of the University of Manchester: http://www.gong.manchester.ac.uk/odp/html/index.html or the "Design Pattern Repository" of the Aristotle University of Thessaloniki: http://percerons)
**The patterns of commoning**
We can surely say that patterns – in whichever field – are ideally organized as commons. Can we also say that the commons themselves are a set of patterns? Can we identify successful practices that constitute commons and make them bloom?
The first pattern of commoning we have just met on the way – It is the passive competence pattern5 that reflexively favors sharing of knowledge with "non-experts" and outsiders. One might think that this is a pattern only applicable to intellectual commons. But if we look deeper, we begin to understand that this is a vital necessity for material commons as well. No commons can exist without widespread knowledge about its nature and widespread acceptance and respect for the groups, institutions, and arrangements that care for it. In Austria, we have a very fine public water system, bringing the water that supplies Vienna from mountains almost 200 kilometers away. I like to think of that as a vast commons, not just as a public institution. There are many educational tours that make people aware of the pathways the water takes, of the many maintenance requirements, and the periods of scarcity and abundance that we can partly but never fully mitigate. (5. The term "passive competence" stems from linguistics and means to be able to understand a language without necessarily being able to speak it actively. Passive competence means therefore to understand what an expert is doing without necessarily being an expert oneself. Passive competence is grossly neglected in our education systems.)
So if a central group of experts and maintainers is needed to guide and guard a commons, how do they themselves organize and get accepted and supported by their environment? There are patterns waiting to be found. We have heard that commons may be mostly built around a social charter.6 (6. See James Quilligan's essay) But that might not be the ultimate ground of what holds a commons together. In his contribution to this book, Andreas Weber talks about the natural or "biological" paradigm of an ever-deepening process of exploration, in which individuals discover their roles and niches in a system of mutual dependencies.7 (7. See Andreas Weber's essay) Social activist Rob Hopkins, who co-founded the Transition movement, seeks to abandon strict charters in favor of pattern languages as a "playground" for experimentation and development built on experience. He gives the following rationale:
Transition has a number of qualities, which include the following:
_Viral:_ It spreads rapidly and pops up in the most unexpected places.
_Open Source:_ It is a model that people shape and take ownership of and is made available freely.
_Self organizing:_ It is not centrally controlled, rather it is something people take ownership of and make their own.
_Solutions focused:_ It is inherently positive, not campaigning against things, rather setting out a positive vision of a world that has embraced its limitations.
_Iterative:_ It is continually learning from its successes and its failures and redefining itself, trying to research what is working and what isn't.
_Clarifying:_ It offers a clear explanation of where humanity finds itself based on the best science available.
_Sensitive to place and scale:_ Transition looks different wherever it goes.
_Historic:_ It tries to create a sense of this being a historic opportunity to do something, extraordinary – and perhaps most importantly of all:
_Joyful:_ If its not fun, you're not doing it right.
Any pattern language designed to communicate Transition therefore needs to be able to embody these qualities.8
(8. http://transitionculture.org/2010/06/04/rethinking-transition-as-a-pattern-language-an-introduction/)
Hopkins then describes some very interesting patterns. For example, patterns like "dealing with grief," "constructive criticism," and "civility" are meant to overcome feelings of individual superiority and establish communication between the core group of innovators and the outside world in an effective way. Patterns like "critical thinking" and "measurement" are balanced with "visioning" and "arts and creativity." But there are also patterns like "baking a cake" that serve to capture energies of celebration within the movement.
It might not be too speculative to say that pattern languages themselves might prove as an essential tool or pattern for commoning. The knowledge guiding our action is brought into a form that allows collectives to evolve, seek balance, trace, and value experience and allow them to synthesize the best solution in a given situation.
The narrative that strikes me most in this context – and which makes all the difference in the world when it comes to the distinction of public and common – is the narrative of the Native American Medicine Wheel. Of course this is not one single narrative, but rather a polyphonic one transmitted by several oral traditions. So while my access to it was subjective,9 I will try to extract the essence of what I feel is another fundamental pattern of commoning – The Circle. (9. By the teachers WindEagle and RainbowHawk of the Ehama Institute. http://www.ehama.org)
The circle seeks to encompass all concerns and aspirations within and even outside a group it treats them as equal.
The circle is about review, affirmation, and innovation of social practices.
The circle is organized in a ritual way, forcing people to listen and speak with full attention and from a clear perspective that represents an individual situation and a social concern alike.
The circle seeks to weave together those concerns that include creativity; an awareness/sense of reality; emotions that guide us to the perception of threats and opportunities; a sense of purpose and identity; learning about tools and resources; anticipation of future developments and strategy; the need for clarity in decision making and the sense that all voices have been truly heard and considered; and a conviction that the decision is giving a good perspective to all involved.
The circle will continue to run in an iterative process until optimal consensus has been found.
It is noteworthy that this circle pattern is not limited to small numbers of individuals, but is even applied as a system of governance between groups and nations. The ideal is that at any level of a successful solution, a living and nurturing relationship between very different elements will be found, and that the sequence of perspectives to create this relationship is by no means arbitrary. The eight perspectives included above follow a strict pattern of building upon each other; any other combination will fail to produce the desired result.
Can we apply such patterns in today's emerging common practices? We probably will have to, since commons are not possible without balance-seeking processes whose fruits we cannot fully foresee. We need to introduce complementary patterns that facilitate the dynamics of economic relationships. We need to explore patterns of communication that allow us to establish working cooperation and innovation. We need to identify the optimum sizes and qualities of our habitat. We need to balance privacy and individuality with our mutual dependence.
Pattern languages will help us to avoid schematic thinking and grasp the deeper complexity and the degrees of freedom involved in a world that is evolving into true togetherness – because the ways of command and control, of money and power, and conventional economic thinking, have proven to be way too primitive to solve the problems they have created.
**Reference**
Alexander, Christopher with Sara Ishikawa, Murray Silverstein, Max Jacobson, Ingrid F. King and Shlomo Angel. 1977. _A Pattern Language: Towns, Buildings, Construction._ New York. Center for Environmental Structure Series.
**Franz Nahrada** _(Austria) is a sociologist and networker in Vienna who runs a family hotel and collects information about the building blocks of sustainable communities that fully thrive on global knowledge commons (Global Villages Lab). Its activities can be followed via http://globalvillages.org and http://transitionaustria.ning.com._
# The Abundance of the Commons?
___One of the most spirited panels at the International Commons Conference in Berlin, Germany, in November 2010 dealt with "The Generative Logic of the Commons." Is there indeed "abundance" in the commons, especially ones based on natural resources? Or do such ideas amount to a denial of nature's finite limits? We continue this conversation here._ 1
(1. Additional information can be found at http://p2pfoundation.net/Abundance_of_Food_vs_theAbundance_of_Recipes)
**Silke Helfrich:** Roberto, when you talk about "abundance in the commons," what are you talking about?
**Roberto Verzola:** I am talking of three things: the abundance of free – or low-cost information and knowledge, thanks to new information and communication technologies (ICTs); the abundance that continually asserts itself in biological systems despite human abuse and misuse; and the material abundance possible through the conscious design of closed-loop production processes fueled by renewable energy.
Picture a bottle. You can bottle water, food, air and most other goods for sale. If you use up the bottle's content, it's gone. But learning from a bottle of ideas will never deplete its contents. When we share ideas, we end up with more than we started with. That's _information abundance_. Thanks to new ICTs, we can now share, search, and access much more of the world's storehouse of knowledge than was possible in the past. Then, think of DNA. Nature also bottled them into genes, cells, organisms and species, and put an intrinsic urge in every living organism to reproduce one's own kind. That's _biological abundance_. And finally, consider a factory. Disarranged, it will produce little or nothing at all. But arranged in just the right way, it will start producing goods. That's _organized abundance_.
**Helfrich:** "Biological abundance" reminds me of Andreas Weber, a contributor to this book, who once said: "Nature as a whole is the paradigm of the logic of the commons from the beginning. Nothing in nature is monopolized, everything is open source."
**Verzola:** Yes **,** nature's abundance is hard to miss: bacteria can double in number every half hour; some plants release a million pollen in a day; fish can release one to ten million eggs in one breeding season; a rice grain can produce a thousand grains in a planting season. In seas, reefs, lakes, swamps, grasslands, forests, and other ecosystems, abundant life blooms. Corporate and human acts may damage these ecosystems; but left alone, the abundance reasserts itself. Nature does not grow without limit, but it has no time limit. Species form into self-limiting food webs, creating balanced ecosystems that provide us with perpetual streams of new soil, clean air and water, food, stuff for clothes and houses, medicine, fuel, and other goods and services. By the way, nature is not only about interdependence. It is also about walls and barriers, to protect itself from an "outside." Aquatic species, for example, can release egg and sperm into the same waters, but a sperm can fertilize no other egg but its own type. Genetically, species are virtual autarkies.
**Brian Davey:** As an ecological economist I find these ideas somewhat disturbing. Of course, the knowledge commons have much to offer. Sharing ideas without intellectual property constraints will help us, since much of a chair's production or a car's production is intellectual production. Sharing energy and pooling production arrangement and infrastructures will help too. But "abundance" as a message tends to neglect that there is a difference between an abundance of information and an abundance of material products – it takes energy and materials to produce objects. There can be an abundance of recipes at the same time as a shortage of food. Even the digital commons is based on an energy-guzzling infrastructure consisting of computers, the power supply, etc. Although well-meaning designers can engage in open source design processes trying to reduce the energy usage and material throughput in the maintenance of the internet infrastructure,2 the digital commons is not free. Making a personal computer costs 1800 kilowatt hours in electricity before it is even used.3 In my view the creativity that is freed up by knowledge commons cannot in and of itself lift the limits to growth. So, although the abundance of information will be helpful, it has a limited potential to mitigate the decline in production that is likely to arise through energy descent. In my view, the notion of abundance tends to wish away that the Planet Earth has simply a limited ecological carrying capacity. (2. See also the essay on peer-to-peer production projects by Christian Siefkes. 3. McKay, David J.C.: "Sustainable Energy – Without the Hot Air," UIT Cambridge, 2009, p. 94, at www.withouthotair.com)
**Verzola:** To play down the Internet because it provides recipes but not food is to miss its biggest benefit, which is our new ability to search, access, and share information and knowledge on a global scale in ways that were simply not possible in the past. Remember the saying? "Give someone fish, and he'll eat for a day; teach him how to fish and he'll eat for a lifetime." Don't look for food from the Internet. Look for sustainable ways of growing food, building shelters, and revitalizing our communities.
Sure, the Earth's mineral abundance is nonrenewable, and Peak Oil will soon end the era of cheap fossil fuels. But there is a way out, _if_ we learn how to reorganize production into closed-loop processes. Permaculture, for instance, designs farms that emulate an abundant ecosystem like a forest by putting together what is in effect a self-regenerating forest of useful crops. In industry, recycling is just a first step. The life cycle of every product must be reviewed to move towards true zero-waste production. We have to increase throughput and flow rather than accumulate and then use up stock. This is _organized_ abundance, by design, when, through the right combination of production components, functions and processes, every byproduct is used in another production process and the whole thing is fueled by renewables. That is a long way off, though.
I think that focusing on the three types of abundance above will in general _reduce,_ not raise, energy consumption. Yes, the energy efficiency of the new ICTs can be improved further. But we must look not only at their absolute energy consumption but also at the much higher consumption of the transport, manufacturing and other smoke-stack technologies that the new ICTs replace.
**Wolfgang Hoeschele** : I think we have to add that we also should keep our eyes open to the simple ways of using renewable energy sources that don't require technology. For example, every time we hang our clothes to dry, we are using abundant solar energy.
**Davey:** I can accept this to a certain extent, but we also need to get a grip on the key fact that there are absolute limits. This is also true for the amount of solar and renewable energies available, no matter how ingenious we engineer an infrastructure to capture it, and no matter how good we are at capturing it in biomass. If we want the commons to produce "abundance," we have to be aware of the fact that the power of raw sunshine at midday on a cloudless day is 1000W per square meter – but that is 1000W per square meter of area oriented towards the sun! To get the power per square meter of land area in Britain, where I live, we need to compensate for the tilt between the sun and the land, which reduces the intensity of midday sun to about 60 percent of its value at the equator. And of course it is not midday all the time.
Globally, total incoming solar radiation is 122 Petawatts, which is 10,000 times greater than the total primary energy supply used by humanity. However, given the low density with which it falls across the whole planet, harvesting it for production processes is a costly and energy-intensive process. Many current ideas for harvesting solar energy assume that we can do this through biomass and plant photosynthesis. Permaculture has much to offer – but it cannot resolve the fact that in Britain, there is only 100 watts falling per square meter of flat ground on average for plants to harvest. Nor can human ingenuity do much about the fact that the best plants in Europe can only convert 2 percent of solar energy into carbohydrates. Humans already appropriate 30-40 percent of Net Primary Production of the biomass as food, feed, fiber, and fuel with wood and crop residues supplying 10 percent of total global human energy use. In Europe, 70 percent of all plants are appropriated by humans. Similar things can be said about other renewable energy. The room for maneuver barely exists, if at all.4 No renewables will ever be able to provide an "abundance" if, by abundance we also mean material production abundance. (4. See Vaclav Smil's monumental study, Energy in Nature and Society. General Energetics of Complex Systems (MIT Press, 2008), pp 382-383.)
****
**Hoeschele:** Let us put the argument this way: **** material resources are abundant if they are used in non-depleting or non-degrading ways – for instance, breathing air, or resources that are plentiful enough to meet people's needs, such as fisheries in places where people fish only a small portion of the sustainable yield. ****
**Helfrich** : **** Then we are actually talking about an "abundance with conditions," a concept that may help us to go beyond the traditional eco-argumentation, which, as Franz Nahrada points out, usually "aggregates quantitative aspects of production processes and reproductive capabilities without looking at the interplay between them." Michael Braungart, the father of the Cradle-to-Cradle principle,5 uses a simple image to illustrate this. When you have badly designed material production that produces waste (in an unholy alliance with an economic systems based on consumption, where we need to consume to make "the economy go round"), each additional activity in this badly designed production will increase scarcity. But it's a scarcity _we create_ by the way we produce and consume. The alternative is to design products as "parts of cascades of material re-use and up-cycling," as Braungart suggests. And here is again where the (knowledge) commons come into play. If we want the commons to provide us with food and fuel and stuff, each activity has to be designed in such a way that it increases the base for other activities and thus creates abundance, which in my point of view is: enough to meet everybody's needs. (5. Cradle to Cradle design, or "C2C," is a school of design that seeks to emulate natural processes so that all waste can be treated as inputs to useful processes, much as an ecosystem recirculates all material in circular, regenerative flows. This requires a holistic approach that attempts to make economic, industrial and social systems more organically interdependent and waste-free.)
**Verzola:** Exactly. The problem is that most economists today assume unlimited demand due to infinite wants. Under such assumptions, abundance is indeed impossible. But if people get satiated, then demand is finite and abundance becomes possible. Remember Mahatma Gandhi who said: "There is enough for everyone's needs, but not for everyone's greed."
**Helfrich:** I agree, but let me come back to the issue of production design. During our post-Berlin-Conference conversations, Franz Nahrada suggested that the decisive factor to redesign the way we produce is the interplay between our growing availability of information, code, and knowledge and the material world. What matters is our _ability_ to conceive and design self-feeding and self supporting cycles and arrangements that can permanently harvest systemic gains from other inputs – for example, using the excess heat of a large server farm to warm human settlements. This is a systemic gain that results purely from design.
**Hoeschele:** So far, so good, but there is another problem, which you already referred to. It arises from the very design of the dominant economy. It is certainly the major barrier to triggering those "cascades of abundance by self-feeding and self supporting cycles and arrangements." Oddly enough, mainstream economists and market players often deny real material limits (they suggest unlimited abundance of resources such as petrol), while at the same time telling us that we always face scarcity because our unlimited wants will always exceed the available resources.
For example, they will say that there is no basis to assertions that we will soon face "Peak Oil." But if anybody suggests that we not drill for oil in Alaska, or Ecuador, or anywhere else, then this particular oil is considered essential for our economic development. Meanwhile, any efforts to consume less oil by driving less are considered "bad for the economy" because that will generate less employment. You are supposed to consume more even if you personally have no interest in consuming more, in order to "boost employment." People are said not to be altruistic – but then they are asked to consume more for altruistic reasons!
**Helfrich:** "Consumption for altruistic reasons" – could you explain this more?
**Hoeschele:** Our present economy is designed in such a way that it sees no value in abundant resources because you cannot sell them at a high profit margin. You cannot package air for breathing and then sell it to somebody. Where fish are abundant you can sell them, but only at a modest price. In other words, only exchange value is recognized, use value is not. But use value is what matters in the commons. Today it is advantageous for entrepreneurs to make abundant resources scarce so that they can then be sold at a higher price and generate more exchange value. For example, if demand is increased beyond available supply, the goods become scarce. Think of the hype around iPads, or bottled drinking water sold at a price up to 10,000 times the cost of tap water by suggesting that it is more pure. The argument I make in my book6 is that the work of making abundant resources scarce is not left to individual initiative but is done by scarcity-generating institutions such as inequitable property arrangements, gender and racial hierarchies, car-oriented urban planning, and a money system dominated by central banks. Scarcity can be produced by manipulating either the supply or demand of a commodity such that demand exceeds supply. In this sense, there is scarcity even when there is a huge amount of production or if there are plenty of resources available. (6. Hoeschele, Wolfgang. 2010. The Economics of Abundance: A Political Economy of Freedom, Equity, and Sustainability. Aldershot, UK. Gower Publishing.)
**Helfrich:** In short, our current economy cannot deal with abundance!
**Hoeschele:** One can put it this way: Our current economy maximizes inefficiency of consumption in order to generate the demand needed to justify ever-increasing production and therefore an ever-increasing consumption, or waste, of natural resources. That is the very problem. Remember – our economies depend on an always growing GDP. In such a context, increased efficiency of production does nothing – or not enough – to address issues of "resource limitedness." If it would do so, it would destroy our economic system. But if we remain addicted to oil while supplies diminish, prices will skyrocket! This is why oil companies tend to downplay the imminence of diminishing oil supplies.
**Helfrich:** Does that mean that we can benefit from the potential of abundant resources only if we become more independent from both finite resources such as fossil fuels _and_ from the restraints built into our economic system, which forces market players to make resources scarce in order to convert them into commodities?
**Hoeschele:** I think so. And independence means freedom. We'll all be more free as a result! If we refashion our cities so that everybody can get around, including the old, the young, the poor, the rich, the ones who own cars as well as the ones who don't, then a lot of our dependence on oil evaporates, and at the same time we have more choices about how to move about. If oil prices decline because we don't need that oil anymore – then we've got abundance, and we've brought down those oil corporations as well! Our food systems are also built on scarcity, where growing food only makes sense if it's sold at a sufficient profit margin. Reviving subsistence-oriented production, community gardens and the like can make good, healthy food available at low cost, something that commercial agriculture is too often unable to do.
An economics of abundance seek out these kinds of strategies of providing for our needs; it is not an economics that assumes that abundance exists, but one that analyzes modes of scarcity generation such as the ones I mentioned above, and that points out ways to counteract them. Just as scarcity is socially constructed (and is very real, as real as a humanly constructed building), so also abundance has to be created. Under current circumstances, this is a daunting task, but one that we must face. In short, my contention is that real material limits to resources exist, but that we can also live in abundance – defined as the condition when all people, now and in the future, are enabled to thrive.
**Davey:** I am glad that Wolfgang has defined what he means by abundance. What still is lacking in this discussion is a definition of abundance that we agree on. However, Wolfgang's definition is not the one that I would use. My Oxford Dictionary of English defines "abundance" as "quantity more than sufficient, plenty.... affluence, wealth." This is what I've been taking it to mean.
I totally agree with the notion of striving to organize the economic system to promote well being – and defining well being as "the condition that all people, now and in the future, are enabled to thrive."
And I think that this well being would involve a condition where people do not have to worry about their material needs because they have sufficient resources for these needs and can therefore devote themselves to their free creative interests and the improvement in the quality of their relationships. I agree on the importance of that.
I also agree that the current economic system deliberately seeks to promote dissatisfaction with what people already have in the interests of selling more. This creates a feeling of scarcity and want where really people already have more than is sufficient...They certainly do in developed consumer societies. Further, this promotion of dissatisfaction fosters a motivation system that is not associated with psychological well being. It is based on extrinsic motivations, where people do things because of the money or status but not because of the intrinsic value of doing them. There is also the encouragement of a narrow individualism so people fail to act fully as members of communities and see their place in nature. Therefore, I think "commoning" would be enormously helpful to address these issues and help people to become more fulfilled. It doesn't matter a lot that one cannot, in my view, have material abundance for all because it is not in that direction that a satisfying life lies.
**Verzola:** I'd like to add one more idea. People should become aware of the various sources of abundance for another reason. The same institutions that create artificial scarcity also want to monopolize the sources of abundance, and for exactly the same reason: profitmaking. Because sources of abundance are often part of the commons (knowledge, natural resources, infrastructure, etc.), people have a right to their use, to a voice in the decision-making, and to a stake in their ownership.
**Helfrich:** Brian, you once said: "I think a movement based on abundance is more likely to attract armed men than a movement based on sufficiency." Do you stick to this statement?
**Davey:** Well, words and messages are slippery. I still think the slogan of abundance has the potential to be misleading, and misled people might get angry. Once put into circulation other people may not use it as we would like. I think it is better to have a clear message about the need for collective psychological adjustment to the limits of our world – for sharing fairly and seeking life satisfactions that are different from the activities and goals of a consumer society. In fact I think that we agree on that.
**Verzola:** Brian, "abundance" is not just a slogan; it is a real phenomenon, both on the Internet and in nature. We can make it visible. Even from a purely economic perspective, it is impossible to miss the abundance that keeps reasserting itself within ecosystems. Some scarcities, of course, are just as real. But it seems more important to me to watch out for _articifial_ scarcities, as Wolfgang points out. And we must be wary of _pseudo-_ abundance. Nonetheless, if we want to create _real abundance_ to attain a minimum level of material comfort for all, we must master abundance concepts so that we can, by conscious design, build cascades of abundance, for the good of humanity.
**Davey:** When you, Roberto, argue for emphasizing the abundant side of reality if the other side appears gloomy, I don't accept this at all. We must stay in touch with all sides of reality, no matter how painful. Sometimes things are as bad as they seem, and rather than being cheerily upbeat it's better to stay in touch with things as they are. The psychologist Elisabeth Kubler-Ross developed a model of the stages people typically (if not always) go through on learning that they are dying or about to suffer a great loss. These are denial, bargaining, depression and finally acceptance. I fear that there's an element of denial and wishful thinking in all of this. Yes, nature is abundant – but it also has die-outs and extinction events.
To me, the chief problem of all this abundance stuff is that it might delay emotionally coming to terms with the profound impact of humankind on the fecundity of nature and the exhaustion of energy supplies – without which the information in the seeds and in our software cannot fully evolve. To really take in the threats of climate change and Peak Oil is to be affected emotionally. Many people suffer grief because the future that they saw for themselves and for their children is not there anymore. I think that it is with, or after, the despair that one achieves acceptance and a commitment to constructive action – together with a different kind of hope, one based on realism.
**Hoeschele** : I think in the end we really agree on far more than on what we disagree about. Yet, I'd like to say something more in favor of using words like "abundance," and that is the widespread view that environmentalists are nay-sayers, that they want us to give up the good things in life, and become saintly hermits who renounce wealth for the greater good of the earth and the myriad species that exist here. I know that I've just drawn a caricature, but I find that this image really hurts the cause of trying to develop sustainable ways of living on this planet. When you juxtapose this image with the consumerist barrage of messages, then very few people are going to embrace a new lifestyle of reduced resource consumption.
The message I am trying to convey is that our current conditions are actually a condition of scarcity. Our wants and needs for commodities are always kept in excess of supply (a "feeling of scarcity" if you wish, but the people feeling scarcity can't usually tell the difference between the feeling and some objective reality out there). Instead, if we take another path, we can experience the abundance of having potential access to far more than we need, and the sense of security that comes with this. This opens up far more space for creativity, for generosity, for human relationships of care and mutual support, that foster each individual's personal growth. In my experience, talking about abundance does not lead to fear (an emotion which I feel is intimately tied up with scarcity), but rather to enthusiasm, and to the creativity that we need in order to contribute to an economy built on positive human relationships.
**Verzola** : We should not underestimate the value of a positive message. Reality may be 90 percent bad and only 10 percent good, but to dwell 90 percent of the time on the bad will cause cynicism, despair and a feeling of powerlessness.
**Davey:** But we can take the view that if reality is 90 percent bad, then that is what it is – 90 percent bad with 10 percent good. As the psychiatrist R. D. Laing puts it, "The only pain we can avoid in life is the pain caused by trying to avoid pain."
The literature on the psychology of values and motivations suggests that concentrating on the dark side of something can actually be better for producing more profound shifts in people's attitudes. Clive Hamilton and Tim Kasser once said at a conference at Oxford University that deep reflection on death (usually thought of as "bad"), is better at producing a shift in profound values. They recommend that environmental campaigns avoid appealing to selfish desires such as, "Ten ways you can save money by reducing your carbon emissions." I think it is possible to connect messages with the idea of cooperation and non-material benefits. Instead, at present, most governments and environmental organizations adopt a "don't scare the horses" approach, fearful that exposing people fully to the scientific predictions will immobilize them.
**Hoeschele:** But still, it is important if we choose an imagery of death and dying, or of healing. While acceptance leading to resignation is appropriate in the case of death and dying, in the case of healing it is also important to feel and recognize the pain, but this does not lead to resignation – but to a rallying of one's self-healing capacity. That's the abundance, which can then lead to healing despite odds that doctors (the rational ones) have considered impossible. This isn't just wishful thinking (if it were, I wouldn't support it), but something much more powerful.
**Davey:** Therapist Oliver James argues in his book _Affluenza_ that there is a distinction between positive thinking and positive volition. He considers positive thinking a form of denial that is not helpful. But maybe we can agree on this: one has to recognize and acknowledge that one has a serious health problem, in which death is possible, in order to take that health problem seriously enough that one sets about working on the tasks involved in healing. We may then take steps to work to get better – but still are able to stay in touch with the reality.
**Helfrich:** Marianne Grönemeyer once wrote, "Abundance (the German word is literally "overflowing") has taken on a dissonant overtone. Not the overflowing, but the superfluous, is the meaning that has pushed itself to the foreground." Perhaps our debate can contribute to reversing this tendency and to foreground the things we really have or need in abundance: knowledge, information, healthy relationships, cooperation, and the full potential of self-organization. All of them are essential in the commons.
Many thanks for this conversation!
**Brian Davey** _(Great Britain) is a freelance ecological economist and author. He works in the community and not–for–profit sector. In 1996, he had a post with the Stiftung Bauhaus Dessau, showing how to do community research and development work. He is a member of the Foundation for the Economics of Sustainability (FEASTA), which recently published a book about commons approaches to climate change, _Sharing for Survival.
**Wolfgang Hoeschele** _(Germany/USA) is professor of geography at Truman State University (Missouri, USA), and author of_ The Economics of Abundance: A Political Economy of Freedom, Equity and Sustainability _(Gower, 2010). He researches how to transform our economy so that it can become socially and environmentally sustainable._
**Roberto Verzola** _(Philippines) is a social activist with an engineering and economics background. He has been involved in information technology, energy, environment and agriculture issues. He coordinates a national network that promotes organic farming methods. His current research interest is the political economy of abundance._
**Silke Helfrich** (Germany) is an author and independent activist of the commons. She is founding member of Commons Strategies Group. She was regional representative of the Heinrich Böll Foundation in Mexico/Central America for several years, and was the editor of Wem gehört die Welt, and translator and editor of Elinor Ostrom: Was mehr wird, wenn wir teilen. She blogs at www.commonsblog.de.
# PART TWO
CAPITALISM, ENCLOSURE AND
RESISTANCE
_Catechism_
by Johann Wolfgang von Goethe
_Teacher_.
Bethink, thee, child! Where do those gifts come from?
Something from yourself alone cannot come.
_Child_.
Oh! Everything is from Papa.
_Teacher_.
And he, where does he have them from?
_Child_.
From Grandpapa.
_Teacher_.
Not so! How to your Grandpapa did they befall?
_Child_.
He took them all.
The law locks up the man or woman
Who steals the goose from off the common
But leaves the greater villain loose
Who steals the common from off the goose.
The law demands that we atone
When we take things we do not own
But leaves the lords and ladies fine
Who takes things that are yours and mine.
The poor and wretched don't escape
If they conspire the law to break;
This must be so but they endure
Those who conspire to make the law.
The law locks up the man or woman
Who steals the goose from off the common
And geese will still a common lack
Till they go and steal it back.
Anonymous, 18th Century
# Enclosures from the Bottom Up
_By Peter Linebaugh_
Enclosure is a term that is technically precise (hedge, fence, wall), and expressive of concepts of unfreedom (incarceration, imprisonment, immurement). And it has been an important interpretative idea for understanding the historical suppression of women, the great carceral confinement, or the accumulation by dispossession as well as an important empirical fact. On the one hand, there is the fall of the Berlin Wall; on the other hand, the vain security fence between Mexico and the United States, and the hideous gigantism of the Israeli wall immuring Palestine. Both define the current moment. The "English enclosure movement" has belonged to that series of concrete universals – like the slave trade, the witch burnings, the Irish famine, or the genocide of Native Americans – that has defined the crime of modernism. Yet enclosure's antonym – the commons – carries with it a promising but unspecified sense of an alternative.
Enclosure seems to promise both individual ownership and social productivity, but in fact the concept is inseparable from terror and the destruction of independence and community. Take the cowboy, for instance:
Next to his way with a horse, a cowboy was proudest of his independence. He worked for other men, but they owned nothing of him except his time. He was a free soul. He could ride from the Rio Grande to the Powder River and seldom see a fence. He could start that ride with five dollars in his pocket and have three left when he finished, if that was the way he wanted to travel. Money did not rule him.
The cowboy novelist Elmer Kelton wrote these lines about the 1883 Canadian River cowboy strike in Texas (Kelton 1971, 2008). The cowboy's independence has been perverted into the egotistical individualism of American manhood by Hollywood, which figures him as a gunslinger and the "Indian" as a killer. We lose sight of the cowboy as a worker in the continental meat trade that lies at the base of social and ecological changes in North America since the sixteenth-century conquest. (Cockburn 1996). The "roast beef of old England" also depended on a cattle trade that connected Scotland and the meat markets of Smithfield in London. But the English drovers did not acquire that cultural, ideological subjectivity that the American cowboy did. Why? The symbol of independence was the commoner, the yeoman – a tougher, more enduring breed. But this figure also defined independence in relation to fencelessness. If not the open range, then the open field; if not barbed wire, then the thorn hedge.
The enclosure of the commons has reappeared in the 21st century owing to four developments. First was the uprising in Chiapas led in 1994 by the Zapatistas1 in opposition to the repeal of Article 27 of the Mexican Constitution that provided for _ejido_ , or common lands, attached to each village.2 Another process of "new enclosures" took place in Africa and Indonesia. If the cowboy novelist implied a relation between the fence and money, Pramoedya Toer (2000) implies a relation between fence and crime using the example of Buru Island under the Suharto regime in Indonesia: (1. See Gustavo Esteva's essay. 2. See Ana de Ita's essay.)
But the Buru interior was not empty; there were native people...long before the arrival of political prisoners forced them to leave their land and huts behind. Then, as the prisoners converted the savanna into fields, the native people watched their hunting grounds shrink in size. Even the area's original place names were stolen from them and they, too, were calling the area 'Unit 10.' With ten large barracks planted in their soil and five hundred prisoners settled on their land, what other choice did they have? But the strangest thing of all was when the prisoners began to build fences, erecting borders where no boundaries had ever been. The native people had no word for 'fence' – the concept was completely foreign to their culture. They didn't recognize such manmade limitations on land-use rights.
A second development of the late 20th century bringing about a discussion of enclosure and the commons was the development of the Internet and the World Wide Web as a knowledge commons. A third process was the pollution of the planet's waters and the poisoning of its atmosphere. Finally, a fourth factor was the collapse of the communist countries of eastern Europe, which made it easier to discuss the commons without automatically being suspected of ideological intercourse with the national enemy.
As each of these examples referred either to "enclosures" or to "the commons," interest in the classic case of enclosures, namely England, was renewed. Raymond Williams surveys English literature from the aristocratic pastoral of the fanatical 16th century to the coal miners. He is careful to limn enclosure as but one of several forces in the development of capitalism. Enclosure was a visible social fact, and the sense of collapse and melancholia found in authors like Oliver Goldsmith, George Crabbe or William Cowper, was a response to it. Yet the process of enclosure had been ongoing in England since the thirteenth century before reaching one peak during the fifteenth and sixteenth centuries and then another during the eighteenth and nineteenth centuries. The extension of cultivated land and the concentration of ownership went together. We can call this the "great arc" of English history.
At the end of the 17th century Gregory King estimated that there were 20 million acres of pasture, meadow, forest, heath, moor, mountain, and barren land in a country of 37 million acres (Williams 1973). Even if common rights were exercised in only half of these, it means that in 1688 one quarter of the total area of England and Wales was common land. Between 1725 and 1825 nearly four thousand enclosure acts appropriated more than 6 million acres of land to the politically dominant landowners. The Parliamentary enclosure made the process more documented and more public. It got rid of open-field villages and common rights and contributed to the late 18th century's crisis of poverty. Arthur Young, at first an aggressive advocate of enclosure, changed his mind in the early years of the 19th century, often quoting a poor man who said, "All I know is, I had a cow and Parliament took it away from me." The acts were part of the legalized seizure of land by representatives of the beneficiary class. E.P. Thompson called it a plain enough case of class robbery (Thompson 1964).
On the wastes, cottagers and squatters lost marginal independence. Many villages were lost, and airplane surveys alone detect their traces. Indeed, the first impression that visitors often have when flying into Heathrow is the predominance of green fields and hedges on the ground. This is a post-enclosure feature of the landscape. Hundreds of miles of quickset hedge symbolize barriers between people and land. A visitor who takes a train to the Midlands will perhaps see earthworks in the land resembling the rolling swells of a surf before the waves break. This is the ridge-and-furrow pattern caused by the long practice of strip farming on the open-field system. In the eighteenth century the network of great houses or neoclassical mansions was formed establishing strong points of the rural ruling class. This, along with colonial expansion, constituted the architecture of enclosure.
The General Inclosure Act of 1845 declared that the health and convenience of local inhabitants needed to be taken into consideration during enclosure, and commissioners could set aside an area "for the purpose of exercise and recreation for the inhabitants of the neighbourhood." This act envisioned the great London parks. The Common Lands Census of 1873–74 showed that only 2.5 million acres of common land remained in England. The 1955 Royal Commission on Common Lands introduced a third legal party in addition to the landlord and the commoners, namely, the public. Although this recognized "a universal right of public access on common land," the public significantly does not manage the land, as commoners used to do.3 (3. See also James Quilligan's essay.)
Elinor Ostrom, who was awarded the Nobel Prize for Economics in 2009 for her work on the governance of the commons, has been deeply critical of Garrett Hardin, the biologist who in 1968 published his famous essay, "The Tragedy of the Commons" (Hardin 1968).4 His was a brutal argument with an inhuman conclusion: "Freedom to breed will bring ruin to all." Hardin here alludes to Jeremy Bentham's utilitarianism, Adam Smith's invisible hand, Thomas Malthus's population theory, and Charles Darwin's theory of natural selection, to buttress his arguments with thinkers of the 19th century English establishment. The influence of his article did not arise from such authorities but rather stemmed from its striking tone, which combined the somber and the terrifying with the simple and jejune. The article began with nuclear war and rapidly proceeded to tic-tac-toe as an example of strategic thinking. His class markers were made with remarkable candor: "But what is good? To one person it is wilderness, to another it is ski lodges for thousands. To one it is estuaries to nourish ducks for hunters to shoot; to another it is factory land." These are the activities of the factory owner, not of the factory worker. The crux of his argument is expressed in a few paragraphs: (4. Googling the phrase "tragedy of the commons," in January 2010, I found 197,000 references – a disturbing number.)
The tragedy of the commons develops in this way. Picture a pasture open to all. It is to be expected that each herdsman will try to keep as many cattle as possible in the commons. Such an arrangement may work reasonably satisfactorily for centuries because tribal wars, poaching, and disease keep the numbers of both man and beast well below the carrying capacity of the land. Finally, however, comes the day of reckoning, that is, the day when the long-desired goal of social stability becomes a reality. At this point, the inherent logic of the commons remorselessly generates tragedy. As a rational being, each herdsman seeks to maximize his gain. Explicitly or implicitly, more or less consciously, he asks, 'What is the utility to me of adding one more animal to my herd?' This utility has one negative and one positive component.... Adding together the component partial utilities, the rational herdsman concludes that the only sensible course for him to pursue is to add another animal to his herd. And another.... But this is the conclusion reached by each and every rational herdsman sharing a commons. Therein is the tragedy. Each man is locked into a system that compels him to increase his herd without limit – in a world that is limited. Ruin is the destination toward which all men rush, each pursuing his own best interest in a society that believes in the freedom of the commons. Freedom in a commons brings ruin to all.
Three times Hardin refers to the "rational" herdsman; it is a fantasy. What he most likely means is the selfish herdsman or the lonely herdsman, because, in history, the commons is always governed. The pinder, the hayward, or some other officer elected by the commoners will impound that cow, or will fine that greedy shepherd who puts more than his share onto the commons. This idea forms the basis of Ostrom's intervention. For Hardin, the world is governed by "dog eat dog," not "one and all."
There is an early case of enclosure – that of Otmoor, Oxfordshire. Bernard Reaney, its historian wrote: "The commoners turned out their geese, cattle, horses, pigs and sheep to graze on the moor. Peat was dug for fuel, and old women scraped up the cow-dung to earn a pittance by its sale. The moor provided a plentiful supply of osiers, which enabled the craft of basket-making to thrive in the village...there was also good ducking and fishing, and a profusion of rabbits and wild birds which could furnish an important part of the diet of the poor.... Thus the essential elements of a peasant subsistence economy were provided. The presence of fuel, game, and land for grazing cattle, enabled the Otmoor townspeople to live independently if precariously" (Reaney 1970).
The communal regulations did not permit sheep on the moor from May 1 through October 18 under pain of a three shillings four pence fine. A fine of four pence was given to anyone who put a pig on the moor that was not secured with a ring. Four pence was also the fine for keeping a horse, mare or colt, that was not branded. Each town had its own brand reserved by those known as the "moormen." Digging for peat was forbidden on highways because otherwise the pit had to be filled in. And so on. No rational herdsmen here! Hardin's combination of fake scientism, faux mathematics, and the invocation of a global catastrophe to justify a conclusion of coercive policy was itself a highly ideological response with important precedents.
He admitted that his argument was adopted from that of "a mathematical amateur named William Forster Lloyd." It is true that Lloyd was a mathematician of no particular note, but he was a significant figure in the firmament of the establishment, a professor of political economy at Oxford, a member of Christ Church College, and a vicar in the Church of England. His brother, Charles, died in 1829 as the bishop of Oxford and a member of the House of Lords. Charles was a close friend, and the former tutor, of Robert Peel, the home secretary and founder of the London police, the "bobbies" or "peelers." In September 1832 William Lloyd delivered "Two Lectures on the Checks to Population."5 He was a Malthusian, believing that the increase of food could not keep up with the increase in population. To Malthus (1766 – 1834), population may have preventive or positive checks. The former reduces births, the latter increases deaths. Like Malthus, Lloyd opposed "having all things common." He made pithy observations such as "[a] state of perfect equality by its effect in lowering the standard of desire and almost reducing it to the satisfaction of the natural necessities would bring back society to ignorance and barbarism." (28) (5. William Lloyd. 1833 Two Lectures on the Checks to Population Delivered before the University of Oxford in Michaelmas Term 1832. Oxford: Oxford University Press. Page citations to these lectures will be indicated in the text.)
Furthermore, he believed that the diminution of fecundity and the extinction of life would enhance the means of subsistence. He had a fantasy of the American woodsman living in the wild (8), that harbinger of Hollywood and Marlboro cigarette ads, and regarded marriage as a commons productive of common property: "Marriage is a present good. The difficulties attending the maintenance of a family are future. But in a community of goods, where the children are maintained at public tables, or where each family takes according to its necessities out of the common stock, these difficulties are removed from the individual. They spread themselves, and overflow the whole surface of society, and press equally on every part." (21) The "prudent man determines his conduct by the comparison of the present pleasure with his share of the future ill, and the present sacrifice with his share of the future benefit. This share, in the multitude of a large society, becomes evanescent; and hence, in the absence of any countervailing weight, the conduct of each person is determined by the consideration of the present alone."
Here is the precursor to Hardin's selfish herdsman. Like Hardin, Lloyd is obsessed, if not by nuclear war, then by overpopulation. And like Hardin, the herd is the metaphor for population. "Why are the cattle on a common so puny and stunted? Why is the common itself so bare-worn, and cropped so differently from the adjoining inclosures... ? The common reasons for the establishment of private property in land are deduced from the necessity of offering to individuals sufficient motives for cultivating the ground." (30) Lloyd was fond of Malthus's metaphor – At nature's "mighty feast, to use an expression of Mr. Malthus, there should be no free sittings" (60) – and made one of his own: "To a plank in the sea which cannot support all, all have not an equal right." (75)
As Hardin sent off his essay in 1968, he would not have known that in Oxford at the same time the legendary New Left historian Raphael Samuel went tramping about villages talking to the elderly with two of his students from Ruskin College, the young London-Irish historian Reaney and the glamorous women's libber Sally Alexander. They and their colleagues were to tell a new history. Ruskin was founded in 1899 to provide "educational opportunities for the working-class men." John Ruskin's motto was, "I can promise to be candid but not impartial," and "Oxford, city of dreaming spires / And bleeding liars." With that as its backdrop, the History Workshop responded to and helped create the freedoms of "the Sixties." Little did they know that the conversations they were having would develop into a potent scholarly clue to Hardin's rage expressed in California. Samuel was the founder of the History Workshop movement. "Dig Where You Stand" was its slogan. Accordingly, the first pamphlets concerned Oxfordshire, which enables us to now turn our attention directly to the enclosure of Otmoor.
A few miles from Oxford University are four thousand acres of lowland moor, Otmoor. It was inundated every winter. Otmoor people had a funny walk, "a slouch," which evidently helped them get through the mud puddles, the ditches, and inches of water covering the ground. They were said to have webbed feet. Commoners had their own language and a distinct epistemology, most evident in the poetry of John Clare (1793–1864), himself a laboring commoner. "We have come across... 'balks,' 'fallows,' 'furlongs,' 'furrows,' 'eddings,' 'lands'; and in addition, 'ground'." _Ground_ , a word which Clare almost always uses of an enclosed piece of land, usually meadow-land; _close_ is an enclosed field, usually for pasturing cattle and _plain_ refers almost always to open land, usually under grass. In Clare's autobiography, he describes how as a child he walked across Emmonsailes Heath and got lost. "So I eagerly wanderd on & rambled along the furze the whole day till I got out of my knowledge when the very wild flowers seemd to forget me & I imagind they were the inhabitants of a new countrys the very sun seemd to be a new one & shining in a different quarter of the sky" (Barrel 1972).
This points to an orientation dependent on the unenclosed. Clare puts more into the phrase than just not knowing how to get back. The sun was in a different place in the sky, and the wild flowers forgot him. The loss of the common meant the loss of his whole world. Since we are on the verge of losing ours we might pay those commoners more mind.
Richard Mabey has written of the need for common ground, a system of land tenure, in which one party may own the land but others are entitled to various rights in it such as grazing or cutting firewood. This is a very old system that predates the Norman conquest of 1066 (Mabey 1980). Mabey has identified four major types of common rights: pasture, estovers, pannage, and turbary. But there were many others (piscary, housebote, shack, ploughbote) depending on uses or resources (gorse, bracken, chalk, gravel, clay, rushes, reeds, nuts and herbs). These customary rights might provide fuel, meat, milk, tools, housing, and medicines. Rights were matched to a comprehensive range of rules and controls designed to prevent overconsumption and to reward intricacy, ingenuity, and thrift. It was vital to the community that commons be maintained and harvested to keep resources self-renewing. Epping Forest pollards could not be felled because, while they were the property of the landowner, the commoners had rights to lops and tops. In Selborne Woods, where the commoners had pasture and pannage, the landowner could not replant trees unless they were beech, whose mast was necessary for the pigs. Thirteen cherry balls each with a different name were distributed by lot for harvest rights in Pixey and Yarnton Meads in Oxfordshire. The order in which they were withdrawn from a bag determined the strips in the meadow from which each commoner could take hay that summer.
Mabey admits that if such a system were re-adopted, a "state of impenetrable muddle" could prevail. But how did such a muddle first come about? The tidy reasoner may pull out his or her hair, but this "state of impenetrable muddle" was also a source of power. The power of the commoners! Why did it take seven or eight centuries to enclose England when in Russia it took one generation? Neeson helps us answer the question because she describes the various forms of resistance to enclosure that included petitioning, spreading false rumors, attacking property, foot-dragging, mischief, anonymous threatening poems, grumbling, playing football, breaking the squire's gates, fence breaking, wood stealing, and so forth. She states, "The sense of loss, the sense of robbery could last forever as the bitter inheritance of the rural poor" (Neeson 1996).
The seven towns around Otmoor – Charlton, Fencot and Murcot, Oddington, Beckley, Horton, Studley, and Noke – were small; Noke had fewer than a hundred inhabitants, while Beckley had 370 in 1831. The Moor Court at Beckley in 1687 defined the relation of the towns to the moor as they had been defined in the Domesday Book: "That ye Comon of Otmore shall belong to none but ye Inhabitants of ye seven Townes belonging to Otmore for commoning any manner of Cattle there." Commons were of three kinds: the common or open fields of each village, which rotated year to year; the common rights on them and the town wastes, in this case, Otmoor.
The only gentleman residing in the area was Alexander Croke, a gentleman who bitterly attacked the commoners' theory of the origins of their rights, which they argued stemmed from some queen (perhaps Elizabeth I) who had granted as much land as she could ride around while an oak sheaf was burning. Croke indefatigably fought to enclose the moor for more than fifty years. The struggle began with the proposal in 1801 by the Duke of Marlborough to drain and allot enclosures of over four thousand acres. When notices were affixed on the parish church doors, they were taken down "by a Mob at each place." The next affixing attempt of enclosure notices was in 1815; again it was found impracticable "owing to large Mobs, armed with every description of offensive weapons." The humbler people began to bestir themselves. No records of any manor enjoying rights of common could be found; "the custom of usage without stint, in fact, pointed to some grant before the memory of man."
The enclosure bill was passed despite these discoveries, which "made it unlikely that any lord of the manor had ever had absolute right of soil." The enclosers had Atlantic experience. Croke had been employed by the government in 1801 as a judge in a vice admiralty court in Nova Scotia, attaining a reputation as a narrow-minded Tory. He argued that only proprietors, those who owned their own house, had common right, while "the poor, as such, had no right to the common whatever" (Reaney 1970).
In 1830 the dam that had been part of the drainage effort broke. The farmers took the law into their own hands and cut the embankments. Twenty-two of them were indicted and acquitted. This made a profound impression on the cottagers, and for a week parties of enthusiasts paraded the moor and cut down its fences. Assembling by the light of the full moon, blackening their faces, and dressing in women's clothing, the commoners stepped forth to destroy the fences, the hedges, the bridges, the gates – the infrastructure of enclosure. The high sheriff, the Oxfordshire militia, and Lord Churchill's Yeomanry Cavalry were summoned. Yet the inhabitants were not overawed. They determined to perambulate the bounds of Otmoor in full force, in accordance with old custom. On Monday, September 6, five hundred men, women, and children assembled from the Otmoor towns, joined by five hundred more from elsewhere. They decided to "perambulate the whole circumpherence of Otmoor, in the manner which they state it was customary for them in former times to do, and that abandoning their nocturnal sallies, they would in open daylight go possessioning and demolishing every fence which obstructed their course.... Armed with reap-hooks, hatchets, bill-hooks, and duckets, they marched in order round the seven-mile-long boundary of Otmoor, destroying all the fences on their way."6 Wheelwrights, hatters, and hay dealers, along with shoemakers, bakers, tailors, butchers, basket makers, masons, plumbers, and grooms – the full panoply of village artisans were evident. The commoners were organized. (6. Jackson's Oxford Journal, September 11, 1830. I don't know what a ducket is, and the Oxford English Dictionary is of no help with that particular knowledge.)
There were retaliatory efforts, of course. Sixty or seventy commoners were seized by the cavalry, and forty-four were sent to Oxford jail under the escort of the yeomanry. But the protests happened to take place on the day of Saint Giles's Fair. The streets were crowded with folk. When the cry was raised, "Otmoor forever," the crowds took it up and hurled brickbats, sticks, and stones from every direction. All forty-four prisoners escaped.
The law locks up the man or woman
Who steals the goose from off the common
But leaves the greater villain loose
Who steals the common from the goose.7
(7. For the entire poem, see beginning of Section Two. Editors' note: Boyle adds that the poem probably dates from the 18th century.)
James Boyle has tracked these lines to 1821, tacked as a handbill in Plaistow as a caution to prevent support for the intended enclosure of Hainault or Waltham Forest (Boyle 2003). Its very ease may cause us to overlook two themes of utmost importance, namely, incarceration and reparations. It was Lord Abingdon who openly opposed Croke's first attempt to get a parliamentary act enclosing Otmoor. A leading eighteenth-century Whig, though not a resident, Abingdon argued that hundreds of families would lose their subsistence that depended on "the Right which they now enjoy, of breeding and raising geese upon the Moor" (Reaney 1970).
In the fall of 1832 riots broke out in Oxfordshire. Philip Green was a chimney sweeper and an Oxfordshire leader of anti-enclosure and anti-mechanization. He was "an old man of wars" and was "not afraid." If wages were not raised, Green predicted, commoners would unite to "break all the machines in the Neighbourhood and stop the Labourers from work." As Croke, the encloser, was an Atlantic figure, so Green, a commoner, was conscious of world affairs. Sailors like him would have paid special attention to the Nat Turner revolt of 1831 in Virginia or to the huge Christmas revolt of twenty thousand slaves in Jamaica during the same year. The Enclosure Act was fifteen years old in 1830. For two more years Otmoor would remain in rebellion. A detachment of Coldstream Guards was dispatched to the area. In August 1831 the Home Office sent some London policemen. The church door riots of September 1831 demonstrated the ability of locals to organize an attack during which notices of the financial rates to pay for the work of enclosure were removed. The police officer attempting to put up the notice was stoned as he fled to the clergyman's house. "Damn the body snatchers" was the cry. What did it mean? It was widely believed that the authorities were complicit in "burking," the grim practice of kidnapping and suffocating people and selling their bodies to medical schools. The practice takes its name from an Edinburgh resurrection man, William Burke, who was hanged in 1829. In 1831, five hundred medical students in London would have needed three bodies apiece for their anatomical training, about fifteen hundred cadavers a year. Seven resurrection gangs of body snatchers flourished in London at the time, and one man, John Bishop, sold between five hundred and a thousand over the course of his career. The year 1831 also saw the foundation of the Metropolitan Police in London, where more than a thousand uniformed and armed men patrolled the streets. They were hated and believed by many to be unconstitutional, in violation of the prohibition of a standing army. The taking of land and the taking of bodies were thus closely associated. As the horror of the deed rapidly spread, the police were widely believed to be in league with the surgeons of many of London's distinguished medical colleges.
The commoners turned out on the moor whenever there was a full moon and pulled down the fences. In January 1832 a local magistrate wrote Lord Melbourne that, "The mood in the villages was one of open defiance of the law." The constabulary was helpless and more soldiers were dispatched. "Any force which Government may send down should not remain for a length of time together, but that to avoid the possibility of an undue connexion between the people and the Military" (Reaney 1970). This was the way revolutions were prevented: no fraternization.
Marx wrote in the preface to the first edition of _Das Kapital_ that "the English Established Church will more readily pardon an attack on 38 of its 39 articles than on 1/39th of its income" (Marx 1976). It is not clear whether or not Marx had reviewed the text of the Thirty-Nine Articles established under Elizabeth I during what have been called the "religious" wars of the sixteenth century. The thirty-eighth article in fact reads, "the riches and Goods of Christians are not common, as touching the right, title, and possession of the same, as certain Anabaptists do falsely boast." Anti-communism thus formed an essential part of the doctrine of the English establishment. At the time Marx was writing, the portals of power opened only to the propertied and to the communicants of the Church of England. There is a long association in English history between religion and enclosure going back to the Protestant Reformation. To Marx this separation of people from the land – he called it primary or primitive accumulation – played "the same part as original sin in theology."
The red cloth of the magistrate and the black cassock of the priest combined in Oxford to enclose Otmoor. Four clergymen of the Church of England – the curate of Beckley, the rector of Oddington, and the vicars of Charlton and Noke – were strong supporters of enclosure. Two of them became commissioners, which actually took away land from seventeen hundred people and reassigned it to seventy-eight. Much of the land went to clergymen and to three of the Oxford colleges, Balliol, Oriel, and Magdalen. Lloyd, besides being a professor, was also a clergyman of the Church of England. Without having traced his personal property relations or those of his Oxford college to the struggles over the Otmoor Enclosure Act, it nevertheless seems clear that his arguments responded to the struggles of the common people, those nocturnal and those occurring by daylight, those protracted and those immediate, those urban and those rural. Like Malthus before him and Hardin after him, he was an encloser, not a commoner.
Bottom-up history requires that we must attend not to the completeness of the wall but to its chinks. Lest we forget, the Bristol Radical History Group has renewed the History Workshop tradition in many ways, not least in its pamphlet series, and two of these publications concern enclosures and resistance to them (Wright 2008; Mills 2009). They bring to life again the real history on the ground when the concrete is the enemy of the abstract and when the historian, or people's remembrancer, is a cultural worker serving the people in struggle.
**References**
Barrel, John. 1972. _The Idea of Landscape and the Sense of Place, 1730–1840_. New York, NY. Cambridge University Press.
Boyle, James. 2003. "The Second Enclosure Movement and the Construction of the Public Domain." 66 _Law & Contemporary Problems _(1&2). http://www.law.duke.edu/journals/66LCPBoyle.
Cockburn, Alexander. 1996. "A Short, Meat-Oriented History of the World from Eden to the Mattole." _New Left Review_. 215: 16–42.
Hardin, Garrett. 1968. "The Tragedy of the Commons," _Science_ 162: 1243–48.
Kelton, Elmer. 1971/2008. _The Day the Cowboys Quit_. New York, NY. Forge Books.
Mabey, Richard. 1980. _The Common Ground: A Place for Nature in Britain's Future?_ London. Hutchinson Books.
Marx, Karl. Ben Fowkes, translator. 1976. _Capital_. (vol. 1) London,, UK. Penguin.
Mills, Steve. 2009. _A Barbarous and Ungovernable People! A Short History of the Miners of Kingswood Forest_. Bristol, UK. Bristol Radical History Group.
Neeson, J.M. 1996. _Commoners: Common Right, Enclosure and Social Change, 1700-1820_. Cambridge, UK. Cambridge University Press.
Reaney, Bernard. 1970. _Class Struggle in Nineteenth Century Oxfordshire. The social and communal background to the Otmoor disturbances of 1830 to 1835_ (History Workshop pamphlets, no. 3).
Thompson, E.P. 1964. _The Making of the English Working Class_. New York, NY. Pantheon.
Toer, Pramoedya Ananta. Willem Samuels, translator. 2008. _The Mute's Soliloquy: A Memoir_. New York, NY. Penguin.
Williams, Raymond. 1973. _The Country and the City._ New York, NY. Oxford University Press.
Wright, Ian. 2008. _The Life and Times of Warren James: Free Miner from the Forest of Dean_. Bristol, UK. Bristol Radical History Group.
_The full version of this article was first published in Radical History Review, Issue 108 (Fall 2010) doi 10.1215/01636545-2010-007. © 2010 by MARHO: The Radical Historians' Organization, Inc._
****
**Peter Linebaugh** _(USA) is a historian, or "people's remembrancer," who teaches at the University of Toledo, Ohio. He wrote_ The London Hanged _(2006) and_ The Magna Carta Manifesto _(2008). He is joint author with Cal Winslow, Doug Hay, and E.P. Thompson of _Albion's Fatal Tree _(2011) and, with Marcus Rediker,_ The Many-Headed Hydra _(2012)._
# The Commons – A Historical Concept of Property Rights
_By Hartmut Zückert_
The commons, a historical concept, has become an object of interest for the modern social sciences and the general public like few before it. It is well known that it became famous due to Garrett Hardin and his influential article, "The Tragedy of the Commons" (Hardin 1968). Hardin had extrapolated from the historical phenomenon of the commons to identify principles for managing parking lots, oceans, national parks, air and water.1 The question arises here whether this might be an ahistorical analogy that contributes little to clarifying the problem as it presents itself today. (1. Peter Linebaugh's essay traces the concrete background of Hardin's historical reference.)
The criticism of Hardin's essay made it clear that the historical commons were by no means "open to all" and therefore subject to tragically unavoidable destruction. Instead, there was a clearly defined group of people with rights to the commons who agreed with one another on rules in order to avoid degrading the resource.2 Hardin used a less sharply defined concept than Gordon, who spoke of the oceans as a "common-property resource" (Gordon 1954). However, Gordon's critics argued that it is wrong to speak of common property if nobody has claimed the resources accessible to all as property. (2. An overview of the discussion is to be found in Lerch. 2009.)
Elinor Ostrom dropped the category of property rights as a starting point for analysis and instead founded her studies on the term "common-pool resource," a term used to describe oil or groundwater deposits. She also differentiated between open-access and limited-access natural resources. She agreed with Hardin that open-access resources belonging to no one are vulnerable (Ostrom 1990), but disagreed when it came to limited-access resources. Ostrom and others gave a number of examples of common usage, some of which had existed for centuries and had sustained the resources in question. And this is where the concept of property rights comes into play again.
Ostrom and Schlager differentiated between various bundles of property rights and their holders, namely 1) authorized users, whose rights are limited to access and withdrawal of resources; 2) claimants, who can also exclude others; 3) proprietors, who have additional management rights; and 4) owners, who also have the right of alienation, i.e. to sell the resource. The stronger the bundle of rights, the less danger to the existence of the common pool resources, they postulated (Schlager/Ostrom 1992).
The concept of property as a bundle of rights permits us to create a hierarchy of the rights of authorized users, claimants, proprietors and owners. We can derive a typology by means of a comparative analysis of cases of common property management around the world, or by looking at the historical commons, as to which forms of management and which constitutions relating to property rights enabled them to survive for centuries.
**The commons in historical perspective: the story of enclosures**
Before the Agrarian Revolution, which was linked to the Industrial Revolution, there were two different intensities of land use (the following is based on Zückert 2003): intensive cultivation of arable and meadow land (manuring, plowing, sowing, harrowing, harvesting, irrigation or drainage), which was therefore the peasants' private property; and extensive cultivation of grazing land and woodlands where cattle was herded and wood harvested, and which for this reason remained common property: the commons (see figure). How much livestock an individual could have depended on the amount of hay available as winter fodder, that is, on the size of the meadows. From spring to fall, cattle were herded on the common pasture.
The Agrarian Revolution basically meant that people started to grow forage crops such as clover, turnips and potatoes, making it possible to feed cattle in the barn. Thus, rough pasture was no longer needed. The commons was either turned into fields or cultivated more intensively as pastureland. In other words: it was enclosed. The practice of having animals graze in the forest (wood pasture) was abandoned, and the forests were devoted to intensified timber production and privatized as well for this reason. The only uses to remain communal were those that were possible only on an extensive basis, such as Alpine meadows.
The agrarian innovations required capital investment: changes to crop rotation, seed for the feed crops, fences or hedges, barns and new equipment. For this reason, peasants, leaseholders and manorial lords with substantial holdings were at an advantage in the process of changing the mode of production and promoting it, while smallholders kept to traditional forms of farming. That was the basis of the conflicts around enclosures between manorial lords and leaseholders on the one side and smallholders on the other. Unable to compete, the latter lost out. Without keeping a few head of cattle on the commons, they could not survive, and once the commons was enclosed, they could no longer farm for themselves and thus had to work as laborers on the farms of those who had benefited from the enclosures. That was the true "tragedy of the commons."
The basic distribution of property after the enclosures initially corresponded to the system of property rights that had prevailed before. In the feudal order, property was always shared property, that is, the nobility or the priory loaned the peasant his holding and the land that belonged to it; he had to perform labor services and pay rents in kind or money rents and was subject to the jurisdiction of the feudal lords. As the commons was part of the farmland, it, too, was under the control of the landlord, who was known in England as the _"lord of the soil of the common."_ The lord and the commoners alike herded cattle on the common pasture and harvested timber in the woods. In Europe, the degree to which this occurred depended on whether the feudal lords had agricultural businesses themselves or were sustained mostly by rents.
East of the Elbe River, the peasants had to perform labor services in the fields of the manor even until the 19th century and only had usage rights to the commons. In England and the Rhineland, on the other hand, the manors were leased, and this ensured that the leaseholders had a dominant position vis-à-vis the other commoners in using the commons. In England, the commercial demand for wool resulted in the lord's flocks of sheep flooding the commons. In the Rhineland, the " _Meistbeerbten_ " – the leaseholders – increasingly took on responsibility for managing the forest. In southwestern Germany and Switzerland, the manor fields were let out to the peasants, and the feudal lords limited themselves to the extensive branches of the economy, such as lumbering or grazing sheep, and competed with the peasants for the commons.
Accordingly, property rights developed in different ways. In southwestern Germany, the feudal property was forced back more and more, and around 1800 the peasants were de facto owners of their farms and the common pastures. They also enjoyed defined use rights to the forest, and often also to community woods. East of the Elbe, in contrast, the peasants only had weak property rights to their farms and usage rights to the commons.
With different property regimes, the consequences of the enclosures differed as well. In England, the lords and their leaseholders secured the lion's share of the commons – a scandal criticized publicly as early as 1516 by Thomas More in the critique of society he placed before his "Utopia": "sheep...devour men." The nobility and abbots, he wrote, were "stop[ping] the course of agriculture, destroying houses and towns, reserving only the churches, and enclos[ing] grounds that they may lodge their sheep in them." East of the Elbe, the situation was worse; the nobility was taking possession of the common land and granting the peasants only minimal "compensation." The manors, which had grown large because of the appropriation of the commons, were run with semi-free laborers who obeyed the nobility's lashes. The state acted as midwife of the new system of property rights by passing the _parliamentary enclosures,_ i.e., enclosures enabled by laws of Parliament, in England (c. 1760-1820) or the _Gemeinheitsteilungsordnungen_ in 1821 in Prussia. In southwestern Germany, in contrast, dividing up the commons after a long process resulted in a beneficial situation for the peasants and communities.
**The commons in history: managed by the cooperative**
In terms of property law, the commons were bound to ownership of fields; everyone who owned fields was permitted to herd their cattle on the commons. Arable farming was organized in cooperatives, and the village cooperative had the authority to manage the commons. An important rule concerned the date when the harvest was concluded; on that date, cattle were herded to the stubble, where they manured the soil. In other words, fields and meadows turned into commons after the grain and hay were harvested. Private property was in abeyance and treated as common property until spring returned.
All of a village's cattle were herded on the pasture together, either by peasants taking turns or by a herdsman hired by the cooperative. It was his duty to ensure that the cattle did not go onto the fields. When the increasing number of cattle raised the risk of overgrazing the pasture, the cooperative issued an ordinance for the pasture in the form of a so-called _Weistum,_ or bylaw. It limited the number of cattle ("stinting"), impounding them if necessary and levied fines and enforced their collection. There were similar arrangements for other rules and offenses. If too much wood was cut, allotments were set. Thus, cooperative institutions were required: firstly, an assembly of the cooperative that decided on the rules; secondly, a village mayor who implemented the bylaw of the commons; and thirdly, a village court that adjudicated disputes. In this way, dangers to the commons produced new competencies within the cooperative.
These capacities included oversight of the common land within the village itself, where communal institutions such as the herdsman's house, the smithy, the bakehouse or the bath were situated. The community used wood from the common forest to build and heat such buildings. The community could also sell common land for common purposes. In other words, the cooperative formed communal institutions capable of holding rights and assets.
Cooperative means that the cooperative action of all enables the individual proprietor to conduct economic activity. This is the root of the cooperative motto, later mythologized as, "One for all, all for one!"
Only landowners had property rights to the commons. But besides the peasants, limited use rights were granted to artisans in the village, whose services the peasants depended on, as well as laborers who were employed by the peasants in peak periods, especially the harvest, and who otherwise earned their livelihoods by spinning and weaving. The cooperative permitted these non-peasants to herd one cow on the commons and to collect dead wood in the forest. These usage rights arose from the mutual dependency of villagers on one another. As the number of spinners and weavers in the villages increased during the early stage of industrialization, the numbers of their cattle increased to such an extent in some places that they overburdened the commons. This indeed brought about a crisis of the commons in these industrialized villages, as those who did not own fields were dependent on the marginal use of the commons, even though the commons were actually a complement to the cultivation of fields.
The stronger the peasants' property rights to the fields, and therefore also to the commons, the stronger their self-government. At the village court, it was no longer the interests of the lord that were determinative, but those of the peasants' cooperative. The reeve – an official elected by peasants to supervise the land for a lord – became an institution of the community; the manor court became the village court. People's thinking developed accordingly, and cooperative principles were elevated to the norm. The size of the individual peasants' holdings was irrelevant when the cooperative assembly took a vote. Instead, every peasant had a vote, following the principle of one man, one vote. And the individual's pursuit of profit was always limited so that it would not impair the livelihoods of all; that was the purpose of limiting the number of cattle on the commons. "Common benefit" was the uppermost norm of this cooperatively organized society. And it was by no means limited to the local sphere. As this norm was widely recognized, it was also applied to societal issues in general, such as the demand that rulers use the state to promote the common benefit, and the church to preach these values (Blickle 1998).
Community life was lively and featured an annual procession around the boundaries of the village and the lands belonging to it, a communal drink after auditing the common box (the community funds). Folk customs were combined with the common pasture. To the peasants, the bell that the village bull wore around his neck on the pasture signaled, "the reeve is coming, the reeve is coming!" (The reeve kept the community's breeding bull.) On New Year's Day, the herdsmen blew their horns, went from door to door and sang their song, asking the peasants to give them something – such as their best-smoked sausages. The gifts were considered an expression of the peasants' esteem for the community employees' careful handling of their livestock (Zückert 2001).
The commons were part of an economic system that, given the developmental stage of the agricultural production methods, had no alternative but to be communal. Managing the commons was based on social and cultural interaction (which was all the more vibrant the more the cooperative managed this economic activity itself) and closely connected to the cooperative's property rights to the common resources.
**Global commons?**
The historical concept of the commons covers a broad spectrum of communal property rights, from merely the right to use a resource owned by the feudal lords to self-management, the exclusion of third parties, and even the right to sell the resource. The historical understandings of the commons have the same scope as Ostrom's studies of natural resources.
In contrast, the concept of the commons today often refers to open-access natural resources such as oceans, the atmosphere and space.3 Such aspirational uses of the term do not specify the actual governance regimes that can sustainably manage them, however. (3. Editors' note: What is more, in the modern debate on the commons, all objects and resources that are not produced by an individual or that are given to the general public are called common resources or commons, regardless whether they are natural or cultural resources or whether they require restrictions to access or not. Knowledge commons, for example, flourish best if open access to knowledge and information are guaranteed.)
Are the defining characteristics of the historical commons – or a comparable concept of common property – transferable to open-access commons or even to global resources? Ciriacy-Wantrup and Bishop were convinced that common-property institutions might be helpful in solving current-day problems of natural-resources policy and are doing so already. High-seas fisheries can serve as an example here. Limiting a fishing season to counter overfishing has a parallel in the grazing season on the commons; extending national fishing zones to 200 miles from the coast is analogous to the boundaries of a village's grazing land and the determination of who had rights to graze livestock there. The establishment of national quotas and individual fishermen's quotas resembles the practice of stinting on the commons. Similar institutions regulating use of the atmosphere, they believe, might emerge. Following those who consider the oceans to be the common heritage of all mankind, one could consider these resources to be a "giant commons managed as a trust by some international agency such as the United Nations." (Ciriacy-Wantrup/Bishop 1975)
The historical concept of the commons is a concept of property rights. If we historicize the contemporary debate about the commons and bring the historical concept of the commons into play, we must take that into account. Yet we must consider whether the question of property rights is even the central issue if we seek to solve global problems, and if so, how common-property rights can be fleshed out today.4 (4. I am grateful to Julio Lambing for discussions and food for thought.)
****
**References**
Blickle, Peter. 1998. _From the Communal Reformation to the Revolution of the Common Man. City: Leiden. _
Ciriacy-Wantrup, Siegfried V. and Richard C. Bishop. 1975. "'Common Property' as a Concept in Natural Resource Policy." _Natural Resources Journal._ 15:713–727.
Gordon, H. Scott. 1954. "The Economic Theory of a Common-Property Resource – The Fishery." _Journal of Political Economy._ 62:124-142.
Hardin, Garrett. 1968. "The Tragedy of the Commons." _Science._ 162:1243-1248.
Lerch, Achim. 2009. "The Tragedy of the 'Tragedy of the Commons'." _In Genes, Bytes and Emissions: To Whom Does the World Belong?_ http://www.boell.org//web/148-576.html.
Ostrom, Elinor. 1990. _Governing the Commons. The Evolution of Institutions for Collective Action._ Cambridge, England. Cambridge University Press.
Rösener, Werner. 1985. _Bauern im Mittelalter._ München.
Schlager, Edella and Elinor Ostrom. 1992. "Property-Rights Regimes and Natural Resources: A Conceptual Analysis." _Land Economics._ 68:249-262.
Zückert, Hartmut. 2001. "Gemeindeleben in brandenburgischen Amtsdörfern des 17./18. Jahrhunderts." In Zückert, H., Rudert, T., eds. _Gemeindeleben. Dörfer und kleine Städte im östlichen Deutschland_ (16.-18. Jahrhundert). Köln. 141-179.
—————. 2003. Allmende und Allmendaufhebung. Vergleichende Studien zum Spätmittelalter bis _zu den Agrarreformen des 18./19. Jahrhunderts. Stuttgart._
**Hartmut Zückert** _(Germany) is a historian with a doctorate degree and was a scientific assistant of the Max Planck working group_ Ostelbische Gutsherrschaft, 1995-1999, _at the University of Potsdam. He is the author of_ Allemende und Allmendaufhebung _(2003)._
# The Global Land Grab: The New Enclosures
_By Liz Alden Wily_
**Consider this. It is 1607.** The English have been taking lands in Ireland for several centuries. First written down in the 7th century, Irish customary law is sophisticated and still administered by trained traditional magistrates ( _Brehons_ ). Now rulings in the English courts on Gavelkind (1605) and Tanistry (1607) finally deny that customary law delivers property rights. Family holdings are made tenancies of by now well established Anglo-Irish elites, and the commons, crucial to grazing and hunting, are made more absolutely the property of the elites and new waves of English and Scottish settlers. Irish communities may _use_ the commons at the will of these new owners.
**Now 1823 in America.** Chief Justice Marshall rules that while Indian natives were rightfully _in possession_ ("Aboriginal title") of 43,000 square miles of disputed land – in a case he engineers to be brought before the Supreme Court (and in which he has a private interest) – they illegally sold this tract to developers. He argues that by virtue of conquest, the British Crown became the owner of North America ("the right of discovery"). Therefore only the Crown or its administrations may lawfully sell or grant lands. Possession is no more than lawful occupation and use, and doesn't count. Forty-year-old opinions of the Privy Council in London aid Marshall's argument. These opinions established in 1772 and 1774 that English law supersedes local law, and that for the purposes of property, land is "uninhabited" (unowned) when empty of _civilized_ people (McAuslan 2006).
**1845 in England.** The villagers of Otmoor, Oxfordshire in England, as described by Linebaugh in this volume, have lost the fight to keep their commons, as have hundreds of other communities across the realm. In fact, feudal land law in England (and the rest of Europe) has dictated for some centuries (since 1285) that only those granted land by the king, i.e. the lords, own the land. Local populations hold no more than use rights. These legal realities have come harshly into focus only with industrialization and with private capital hungry for lands and the financial killings which may be made from selling the commons to railways and factories. Parliament, made up of wealthy landlords, is on their side, passing law after law since 1773 to legalize the dispossession of commoners. The Inclosure Act 1845 [ _sic_ ] administers the _coup de grace_ , speeding up the process. Of course private gains under these "parliamentary enclosures" are "in the public interest."
**1895 in Africa.** A decade earlier the Plenipotentiaries of European Powers (as they refer to themselves) agreed to establish respective "spheres of economic influence" throughout the continent and make key entry points like the Niger and Congo Rivers free trade zones. As the newest industrial power and especially anxious to extend trade, Germany hosts the meeting in Berlin in 1884-85. Europe is in economic crisis (the Great Depression 1873-1896). Factory owners desperately need new markets for unsold textiles and other manufactures. Fabulously wealthy entrepreneurs, with "vast accumulations of capital burning holes in their owners' pockets" (Hobsbawn 1987) also seek new enterprises to invest in. The new working classes, having lost their livelihoods and now dependent upon (failing) factory jobs are also in need of new locales to migrate to. The matter is so important that the Powers create an early international trade law, the General Act of the Berlin Conference on West Africa, 1885. In practice, opening markets and enterprise in Africa does not work out so well and free trade goes out the window. By 1895 the economic scramble for Africa has segued into a political scramble with the creation of colonies and protectorates to protect new markets and tap the increasingly apparent wealth of resources and cheap labor in the African hinterlands.
The problem from the 1890s is, How to acquire such massive lands cheaply? For some time traders, profiteers and missionaries have been buying lands from coastal chiefs to create trading posts, ports, missionary enclaves, and more recently, for anti-slavery monitoring posts. Companies backed by European governments have been doing the same. The British Royal Niger Company alone has several hundred land contracts made with West African chiefs guaranteeing access to land for mainly commercial oil palm production, supporting _inter alia_ the burgeoning soap industry in Europe. Chiefs are now selling exploration rights to gold mining companies. Such purchases suggest that European governments are amply aware that Africa is far from _unowned_. There is also the 1844 Bond to consider. This is a bilateral investment treaty signed between "sovereigns of equal power" along the Gold Coast and the British Crown. Nor are such kings and chiefs naive, with a long history of slave and commodity trading behind them and well-established trade missions and embassies in European capitals.
Luckily the old feudal land laws of Europe along with the Marshall Ruling of 1823 mentioned above come to the rescue. These offer a clutch of routes to legalize dispossession at scale. Legality is of concern to colonizers and their parliaments, not least to appease humanist groups at home who count the abolition of slavery as a first success. But the "right of discovery" assures the colonizers undisputed ownership of the soil. This may not work so well along coastal areas but can be amply applied to hinterland areas. Natives themselves unwittingly open the way; many of them claim that only God can _own_ the soil or that their communities, continuing from the past into the present and future, are the owners. While firm in their respective schemes of possession they admit the land itself cannot be sold, at least not without the consent of communities. To Europeans, this conceded lack of fungibility and tendency to communalism "proves" that Africans do not own their lands in the manner European property laws acknowledge. Where bills of sale have queered the pitch, natives may be guaranteed secure occupancy and use – for as long as they actively occupy and farm the land. It would not, in any event, be wise to make it difficult for natives to feed themselves.
Conditionality of occupation and use leaves the attractive prospect that Europeans may claim ownership of several billon hectares of unsettled and unfarmed lands – in short, the communal property within their customary domains. Have not Smith, Locke, Mills and others established long ago that private property only comes into existence by the hand of man's labor? The concept of "wastes" from feudal tenures is neatly applied to the continent by all colonizing powers. Counterpoint constructs of "effectively occupied lands" in the form of settlements and permanent farms, and "unowned and vacant lands" quickly evolve. In the absence of acknowledged owners, the commons fall directly to colonial administrations as their private property. And if there is still any doubt, it is obvious to the white men that the lucrative forests, wetlands and grasslands of Africa cannot amount to property as they are in communal possession; in Europe, private property means individual property. Moreover property obtains legal protection only when an individual person or company has a deed to prove it. Africans do not. In oddly mixed ways, these various proofs of _terra nullius_ are applied.
Legal dispossession of Africans is more or less total. In practice, the ability of colonizers to settle and "develop" more than a million or so hectares in each new polity is constrained (South Africa aside). Natives continue to occupy and use lands which they no longer legally own.
Through the 20th century major colonial incursions are made into these lands. Although cities and towns multiply, they prove more notable for the conflicts they generate than the actual hectares they absorb. Settler schemes, commercial plantations run by parastatals and private enterprise, take a much greater toll, along with evictions caused by the issuance of concessions to foreign enterprises for oil, mining and timber exploitation. Laws are also passed declaring certain resources generically the property of the state; minerals (surface mined for centuries or not), waters, beachfronts, marshlands, mountains, forests and woodlands, fall like ninepins to the state, irrespective of local possession.
**The 1960s in Africa.** Liberation from Europe begins mid-century. Curiously, colonial notions of tenure are sustained in most post-independence land laws. Or perhaps not so curiously, for keeping rural majorities as tenants at will is as useful to new African governments as it had been to colonial masters. Class formation and land commoditization have grown apace since the 1940s. The new African middle class share not only political power and business interests, but the same deep commitments to market-led development so strongly advocated by the new donors (the former colonizers) and international agencies. Positions expressed in the landmark studies of late colonialism in Anglophone (1955) and Francophone officialdom (1959) become embedded national policies in Africa, reinforced by the land policies of the World Bank (1975). These read little differently from those of Malthus and Lloyd, as recorded by Linebaugh: _land privatization is prerequisite to productivity._
Indigenous tenure regimes in general and communal landholding in particular are to be done away with as obstructions to individual-centric economic growth, to allow the polarization needed to produce a landless class for urban industrialization and fewer and larger native land owners assisted to produce food and commodities at scale. As is now so well known, Garrett Hardin, confusing collective group-owned property with open access regimes, adds his penny's worth to destructively good effect (1968).
All over Africa (and Asia) privatization schemes are launched, aiming to individualize, title and register houses and farms (Alden Wily 2011). Where these work, such as in Kenya, commons are subdivided among wealthier farmers. Or they are handed over to governments as forest and wildlife reserves or state-run commercial agriculture developments. Ultimately the reach of privatization schemes is limited, so that by 1990 only around 10 percent of the rural lands of Africa are subject to statutory entitlement, and most of this in the white settler areas of southern Africa. But this is not problematic for African administrations who continue to dispose of untitled, customarily-owned lands at will, often to themselves or other private interests.
**1990 in Africa.** Despite privatization pressures the customary sector remains dominant. As the century nears end half a billion Africans are still regulating their land relations according to community-based norms, shaped by customs but adjusted regularly to meet changing realities. Despite significant failures in the 1970s and 1980s governments hold tenaciously to mechanized large-scale farming as the route to growth. Smallholder agriculture remains starved of investment even though customary smallholders represent the overwhelming majority. Families eke out a living on less and less farmland per capita. Levels of concentration and farm landlessness within the African peasant sector look increasingly like those of South Asia in the 1960s. But where the commons remain these routinely make the difference between pauperization and survival. As in Linebaugh's village of Otmoor over a century past, the unfarmed commons continue to provide a host of services and products, from "pasture to pannage, to fish and fowl" and the waters needed to irrigate farms. Woodlands and forests are especially valuable, doubling the livelihood of the poor in many areas (IUCN 2010). And of course, the rural poor are the majority, some 75 percent of the rural population.
Democratization in the 1990s provokes tenure reforms, often following years of bitter social conflict. A handful of governments, most notably Uganda, Mozambique and Tanzania, acknowledge that Africans cannot remain forever squatters of their own land (Alden Wily 2011). They pass new land laws which for the first time endow customary rights with the legal force of real property, and irrespective of whether or not these interests are formally titled and registered, or owned by individuals, families or communities. The last opens the way for communities to secure thousands of hectares of commonage as acknowledged collective property. However, as well as being flawed in diverse ways, these cases are the exceptions. Most governments continue to avoid real change to their land laws. World Bank structural adjustment programs aid and abet this, coercing governments to accelerate privatization and sell off untitled lands (including the commons) to foreign investors.
**Now consider this. It is 2011.** Hundreds of rural communities in Africa – as well as parts of Asia and Latin America – are physically confronted with eviction or displacement or simply truncation of their livelihoods and lands they customarily presume to be their own. These lands are willfully reallocated by their governments to mainly foreign investors to the tune of an estimated 220 million hectares since mainly 2007, and still rising.1 Two thirds of the lands being sold or mainly leased are in poverty-stricken and investment-hungry Africa. Large-scale deals for hundreds of thousands of hectares dominate, although deals for smaller areas acquired by domestic investors run apace (World Bank 2010). (1. A coalition of agencies and universities published the data on recorded and verified deals in a report, "Land Rights and the Rush for Land," in October 2011 at http:// www.landcoaltion.org/cpl/CPL-synthesis-report)
This is the global land rush, triggered by crises in oil and food markets of the last decade, and compounded by the financial crisis.2 The latter adds backing and raises the speculative stakes enormously. The crisis provides lucrative new investment opportunities to sovereign wealth funds, hedge funds and global agribusiness, the new entrepreneurs with "accumulated capital burning holes in their owners' pockets." Global shifts in economic power are evident; while western actors continue to dominate as land acquirers, the BRICs (Brazil, Russia, India, China) and food-insecure Middle Eastern oil states are active competitors. A regional bias is beginning to show; China and Malaysia dominate land acquisition in Asia while South Africa shows signs of future dominance in Africa. Two South African farmer enclaves already exist in Nigeria, and Congo Brazzaville has granted 88,000 hectares with promises of up to ten million hectares to follow. Negotiations are ongoing in at least 20 other African states (Hall 2011).
(2. For case studies see http://www.landcoalition.org/cplstudies and http://www.future-agricultures.org/index.php?option=com_docman&Itemid=971 and http://media.oaklandinstitute.org/publications)
What foreign governments and other investors primarily seek are lands to feed the lucrative biofuel market by producing sugar cane, jatropha and especially oil palm at scale.3 They also want to produce food crops and livestock for home economies, bypassing unreliable and expensive international food markets. Additionally, investors seek to launch lucrative horticultural, floricultural and carbon credit schemes. For all this cheap deals are needed: cheap land (US$0.50 per hectare in many cases), duty-free import of their equipment, duty-free export of their products, tax-free status for their staff and production, and low-interest loans, often acquired from local banks on the basis of the new land titles they receive. (3. For example, in July 2011 the German Lufthansa became the first airline to use biofuels on regular commercial flights.)
This rush for land, the new landgrab, does not stand alone. Local banks, communications, infrastructural projects, tourism ventures and local industry are also being bought up with a vengeance. These take advantage of the new market liberalization that poor agrarian governments now finally provide after decades of nagging by international financial institutions. For host governments, foreign investment is the new aid and path to economic growth, firmly facilitated by international agencies (Daniel 2011). Local land speculation flourishes in its service. The promise of jobs is more or less the only immediate benefit to national populations, and experience thus far suggests these are not materializing.
Nor is the phenomenon a one-way street. Extending and entrenching competitive "spheres of economic influence" is also on the agenda. Foreign capture of population-rich new markets for home manufactures is actively sought alongside land deals. This is best illustrated in the largely foreign capital buy-in and buy-up of Special Economic Zones (SEZ), most advanced in India but emerging elsewhere, such as in the Chinese "Shenzhen" planned in eight African states (Brautigam 2011). Should these develop they will provide tariff-free entry for Chinese goods at scale and locales for Chinese producers and laborers seeking to escape the saturation of home markets. Bilateral investment treaties, of which nearly five thousand have been signed between North and South states over the last decade, provide the governing framework for these developments.
In short, economic crises and shifts in the balance of political power once again produce seismic shifts in who owns and controls land, resources and production. But where are the poor and the commons in all this?
**The commons and commoners**
The answer is quite simple. Much of the lands being sold or leased to entrepreneurs are commons. This is not surprising because lands defined as commons in the modern agrarian world generally exclude permanent farms and settlements. Governments and investors prefer to avoid settled lands as their dispossession is most likely to provoke resistance. They also want to avoid having to pay compensation for huts and standing crops, or for relocation. Only the unfarmed commons – the forest/woodlands, rangelands and wetlands, can supply the thousands of hectares large-scale investors want. But most of all, the commons are deemed "vacant and available." For the laws of most host lessor states still treat all customarily-owned lands and unfarmed lands in particular as _unowned, unoccupied and idle._ As such they remain the property of the state. This makes their onward sale or lease to private investors perfectly legal. Indeed, without such legality in domestic land law, and investor-friendly international trade law to take their side in international courts if needed, no international or local investor would proceed.
Of course the commons are neither unutilized or idle, nor unowned. On the contrary, under local tenure norms virtually no land is, or ever has been, _unowned,_ and this remains the case despite the century-long subordination of such customary rights as no more than permissive possession (occupancy and use of unowned lands or lands owned by the state).
In practice, customary ownership is nested in spatial domains, the territory of one community extending to the boundaries of the next. While the exact location of intercommunity boundaries are routinely challenged and contested, there is little doubt in the locality as to which community owns and controls which area. Within each of these domains property rights are complex and various. The most usual distinction drawn today is between rights over permanent house and farm plots, and rights over the residual commons. Rights over the former are increasingly absolute in the hands of families, and increasingly alienable. Rights over commons are collective, held in undivided shares, and while they exist in perpetuity are generally inalienable. This is not least because the owner, the community, is a continuing, intergenerational entity. This does not mean that in the right circumstances, parts or even all of a community's commons cannot be leased. Whether the community wishes to do so or not, is, communities believe, a matter for commoners to decide. Clearly, most domestic statutory legislation does not agree, let alone consider these critical estates in land to be community assets in the first instance.
The results of this continuing denial that property ownership exists except as recognized by "imported" European laws are clear for all to see in the current land rush. Not just commons but occupied farms and houses are routinely being lost as investors move in. In Democratic Republic of the Congo, for example, villagers with homesteads scattered in the forest have lost their entire domains to commercial crop farmers and now squat in a neighboring National Park from whence they will in due course also be evicted (Mpoyi 2010). In Ethiopia, communities are already being relocated from 10,000 hectares allocated to a Saudi-Ethiopian company with many more relocations anticipated as its lease is extended to 500,000 hectares (Oakland Institute 2011). Elsewhere communities are merely dramatically squeezed, retaining houses and farms but losing their woodlands and rangelands. Investors are clearing forests, damming rivers and diverting irrigation from smallholders, causing wetlands crucial to fishing, seasonal fodder production and grazing to dry up and enclosing thousands of hectares of grazing lands for mechanized farming for export. All this happens in Ethiopia, where local food security is already an issue and the specter of famine looms. The Ethiopian government is meanwhile expanding areas designated for investors to grow oil and food crops for export by 900,000 hectares in another region.
Sometimes villagers tentatively welcome investors in the belief that jobs, services, education and opportunities will compensate for the loss of traditional lands and livelihoods. The reality can be very different. Villagers in central Sierra Leone, Rwanda, and Kenya are among those not told that canal construction for industrial sugar cane production would dry up their wetlands, critical for seasonal rice production, fishing, reed collection, hunting and grazing.4 Deng (2011) records the case of a community in South Sudan agreeing to hand over 179,000 hectares to a Norwegian company for an annual fee of $15,000 and construction of a few boreholes; the company aims to make millions on both production and carbon credit deals. (4. See footnote 2 for case studies.)
In such cases, traditional leaders and local elites are often facilitators of deals, making money on the side at the expense of their communities. Reports abound of chiefs or local elites in Ghana, Zambia, Nigeria and Mozambique persuading communities of the benefits of releasing their commons to investors, and even reinterpreting their trusteeship as entailing their due right to sell and benefit from those sales. Central government officials, politicians and entrepreneurs are routinely on hand to back them up. Such accounts are repeated throughout Africa, and in some Asian states such as Indonesia and Malaysian Borneo, where 20 million hectares have been scheduled for conversion into oil palm plantations (Colchester 2011). Everywhere the story is more or less the same: communal rights are being grossly interfered with, farming systems upturned, livelihoods decimated, and water use and environments changed in ways which are dubiously sustainable.
Clearly _possession_ is no more sufficient today than it was for the English villagers of the 17th and 18th centuries of enclosure. Only legal recognition of commons as the communal _property_ of communities is sufficient to afford real protection. A handful of states in Africa (and somewhat more in Latin America) have taken this crucial step, setting aside fungibility and formal registration as prerequisites to admission as real property. The land rush instead not only activates the effects of failing to make such changes a thousandfold. It also raises concern that fragile reformist trends will not be sustained. Governments appear to find leasing out their citizens' land too lucrative to themselves and aligned elites, and too advantageous to market-led routes of growth, to let justice or the benefits of the commons stand in their way.
**References**
Alden Wily, L. 2011. "The Law is to Blame: Taking a Hard Look at the Vulnerable Status of Customary Land Rights." In _Africa_ _Development and Change._ (2)3:733-757.
Brautigam, D. 2011. African Shenzhen: China's Special Economic Zones. _Journal of Modern African Studies_. (49)1: 27–54.
Colchester, M. 2011. _Palm Oil and Indigenous Peoples in South East Asia._ Forest Peoples Programme and International Land Coalition, Rome. http://landportal.info/resource/global/new-studies-and-policy-briefs-released-under-international-land-coalition-s-global-r
Daniel, S. 2011. The Role of the International Finance Corporation in Promoting Agricultural Investment and Large-Scale Land Acquisitions http://www.future-agricultures.org/index.php?option+com_docman&Itemid=971.
Deng, D. 2011. "Land Belongs to the Community: Demystifying the 'Global Land Grab' in Southern Sudan." http://www.future-agricultures.org/index.php?option=com_docman&task=cat_view&gid=1552&Itemid=971.
Hall, R. 2011. "The Next Great Trek? South African Commercial Farmers Move North." http://www.futureagricultures.orgindex.php?option=com_docman&task=cat_view&gid=1552&Itemid=971
Hobsbawn, E. 1987. _The Age of Empire 1875-1914._ London. Abacus.
Internations Union for Conservation of Nature. 2010. "The Impacts of Barriers to Pro-poor Forest Management: Livelihoods and Landscapes Strategy." Markets and Incentives Discussion Paper. Gland, IUCN.
McAuslan, P. 2006. "Property and Empire." Paper presented to Sixth Biennial Conference, The Centre for Property Law, School of Law, University of Reading, UK. March 21-23, 2006.
Mpoyi, A. 2010. "Social and Environmental Dimensions of Large Scale Land Acquisitions in the Republic of Congo." Presentation to the World Bank Annual Land Policy & Administration Conference. April 26-27, 2010.
Oakland Institute. 2011. "Understanding Land Investment Deals in Africa. Country Report: Ethiopia." http://media.oaklandinstitute.org/publications.
The World Bank. 2010. "Rising Global Interest in Farmland." Washington, D.C.
**Liz Alden Wily** _(New Zealand) is an independent scholar and international development advisor. She is an affiliated fellow of Leiden Law School and a Fellow of Rights & Resources in Washington, D.C. She is a dual citizen of New Zealand and Britain and lives in Kenya._
# Genetically Engineered Promises & Farming Realities
_by P.V. Satheesh_
The biggest problem with genetic engineering in agriculture is that it runs completely against the grain of sustainable agriculture. It separates the domain of science from the domain of farming community. It externalizes everything that was internal to the communities and formed the basis of sustainability: seeds, manure, pest control and more than anything, community knowledge of agriculture. Biotechnology in agriculture today stands as the manifestation of corporate power that is shaping the food and farming policies in India. That is the reason why we must see biotechnology less as science and more as politics.
Genetic engineering (GE), strangely, rides on the slogans of feeding the world and sustainability. It also claims that transgenics, a major product of biotechnology, can increase yields and reduce pesticide use, two traits that have produced more controversy than success. In order to examine the veracity of these two claims let us look at the home of transgenic crops, the United States, which was the first country to grow GE crops and is still the largest planter of GE crops today. Nearly 55 percent of all genetically engineered crops in the world is cultivated in the US More than 90 percent of all soy planted in US and 85 percent of all corn planted in the US are genetically engineered. In spite of this carpeting of the country by GE crops, has the yield dream been realized?
According to the US Department of Agriculture (USDA), the soy yield in the US did not increase by even 1 percent between 1995 and 2005. These years correspond to the prime GE period in US soy production. Instead of increase, soy yields _fell_ from a peak of 42 bushels/acre in 1994 to 39.5 in 2009. In the interim years, it never touched the peak of 40 bushels/acre. This performance does not look any better when we compare the yields of Round Up Ready Soy, an herbicide-tolerant GE soy, with conventional soy yields. In eight US states where this yield comparison was studied, it was the conventional soy that out-yielded the Round Up Ready Soy in all but one state, according to the USDA. Biotechnologists themselves describe this as "Yield Drag." ****
Let us look at corn production, another favored GE crop. Corn production in the US, which stood at 140 bushels/acre in 1995, nearly reached 150 bushels in 2008, a mere 7 percent increase in 13 years! So where is the promised yield? A Kansas University study in April 2008 showed that the productivity of GM crops (soya, maize, cotton and canola) was actually greater in the era prior to the introduction of GM seeds. Soy showed a drop in yield of up to 10 percent.
In 2007, Nebraska University found that Monsanto's GM soy produced 6% less than the same variety of the company's non-GM version, and up to 11% less than the best available variety of non-GM soy. Other studies, including a USDA study in April 2006, show similar results. Categorically, GM seeds are not the most high-yielding.
The main reason for the lower productivity of GM crops, the studies explain, _is that genetic modification changes the metabolism of the plants, which in some cases inhibits the absorption of nutrients and, in general, demands more energy to express characteristics that are not natural to the plant, denying it the ability to develop fully._
When confronted with these facts, Monsanto's explanation was that "genetically modified seeds are not designed to increase yields" (Lean 2008). While Monsanto has tried to explain itself out of this corner, its claim that its GE crops reduce pesticide use has not been muted. If at all, this is the resounding noise that the company makes.
Let us examine this claim from the US experience. The graph below issued by the US Environmental Protection Agency explains the total pesticide use in the US compared to the rest of the world. Obviously, with more than 55 percent of all GE crops being grown in that country, US pesticide use must be significantly less than the rest of the world. It is not so.
Between 1998 and 2002, world consumption of herbicides and insecticides indicate a clear downturn. But in the US they are as flat as an airstrip, another loud testimony to the fact that GE crops have not been able to decrease pesticide use.
In India it is the same story with Bt cotton, the first and the GE crop grown in the country. The Deccan Development Society, of which I am the Director, and the Andhra Pradesh Coalition in Defence of Diversity, have been studying the impact of Bt cotton, particularly on the small and marginal farmers' fields in the South Indian state of Andhra Pradesh between 2002 – the year when Bt cotton was introduced – and 2009. What are our findings today?
The industry introduced Bt cotton with a bouquet of promises, that:
• Bt cotton is a cutting-edge technology.
• It is the answer to all cotton problems.
• Use Bt cotton, it will lower the cultivation costs.
• It will bring down the pesticide use significantly.
• It will give farmers higher yields.
• It will earn them higher profits.
What was the outcome after five years, in 2007?
• Cultivation costs for Bt Cotton went up significantly.
• Bt yields did not increase more than 5 percent.
• Pesticide use has failed to come down.
Small farmer earnings by cultivating Bt cotton are on the negative. They have lost more than what they have gained.
The graph above on pest management costs incurred by Bt and non–Bt cotton farmers between 2002-3 and 2006-7 tells the complete story (Qayum and Sakkhari 2008). While the first year of Bt cotton gave a marginal pest management edge to Bt growers, the very next year, Bt farmers spent almost the same amount of money as the non-Bt farmers. Bt gave them no special advantage. Between 2005 and 2007 the study concentrated on the comparison between Bt growers and those farmers who had managed their pests under non-pesticidal management (NPM) methods. The NPM farmers scored a clear advantage. Their pest management costs, depending on rain and pest incidence regimes were far lower than the Bt farmers, sometimes just about 50 percent of the Bt farmers.
Over these five years, non-Bt farmers invariably recorded higher net returns than the Bt farmers. In 2004, Bt farmers actually had a negative return while the non-Bt farmers always had a positive return. Another study on Bt cotton in the south Indian state of Karnataka, by three researchers from the University of Hannover in Germany, tells a similar story (Malkarnekar et al. 2006). They found that Bt farmers suffered miserably in the first year and recovered marginally in the second. But even then they had lost nearly 20 percent more money than the non–Bt farmers. Beyond monetary gains and losses, Bt cotton has caused long-term ecological devastation, in the form of serious damage to soil health, the return of forgotten insects, a severe incidence of non-target pests, harm to animal and human health, and death to humans and animals.
Rhizectonia, the root rot disease which was rarely seen in the cotton belts of Andhra Pradesh, increased from zero in 2002 to 40 percent of the soils growing Bt cotton in 2007. The consequent wilt disease spread like wildfire in many fields, particularly of the small farmers. In despair farmers had to pull out the crops planted by their own hands and burn them. For an Indian farmer, this is akin to killing his own child. Nothing can make them feel more devastated.
One clue to this phenomenon was suggested by a study at the Indian Agricultural Research Institute (IARI), New Delhi, which argued that transgenic Bt cotton may constrain the availability of nitrogen, but enhance phosphorus availability in some soil types in India (Kirtiman 2008). Another IARI scientist, Dr. K.R. Kranthi of the Central Institute for Cotton Research, Nagpur, said in one of his studies that Bt cotton may affect soil microbes and nutrients available to the plants. While conclusive reasons for soil degradation have not been found, it is clear that the soils growing Bt cotton were turning toxic in various parts of India.
On the pest front, the sucking pests had a heyday occupying the space left by the helicoverpa while the long forgotten mealy bug, a pest that once flourished in the '60s, came back menacingly to occupy the cotton crop in Andhra Pradesh and Punjab. As a report in the _Business Standard_ (India) explained: "2005, the mealy bugs had destroyed almost the entire cotton crop in several parts of Pakistan, notably in Multan, Sanghar, Mirpurkhas and Tandu Allahyar areas" (Sud 2008). Punjab farmers also paid a very heavy price for this pest, in the 2007 season. Such incidents are warnings that targeting a single pest in a non-holistic fashion, and not the complex causes, is dangerous.
**Human and animal diseases**
In Andhra Pradesh, Bt cotton weeders and pickers suffered skin allergies that they had never experienced before. The same allergy afflicted animals like goat and sheep. In the year 2005, over 2,500 sheep died grazing the leftover Bt cotton stalks (traditionally cotton fields are opened for grazing after the harvest is over). In the beginning the industry papered over this saying that they were, after all, small ruminants. But when buffaloes also started dying (we have counted nearly 12 of them), the answer by the industry was a deafening silence.
This prompted the researchers from Deccan Development Society and Anthra, an organization devoted to animal health, to start an experiment of feeding the sheep under controlled conditions. Three groups of sheep were separated and each group was fed with stalks from Bollgard I, Bollgard II and Non Bt cotton. While two sheep fed with Bollgard I died within 3.5 weeks of the start of the experiment, one sheep fed on Bollgard II died with them. By the end of the fourth week, all the sheep fed with Bollgard had died, while the sheep that did not feed on them stayed alive.
While all this was happening around them, and the farmers started losing their crops, money and hope, a sense of despair enveloped them in the cotton belts of Andhra Pradesh. As a result, several farmers committed suicide. Thus it was ironic that Bt cotton, which was purveyed as a panacea against the farmer suicides, became its cause.
These tragic series of events led to huge protests by Bt cotton farmers. They blocked the main roads through sit-ins, attacked the seed depots, burnt hoardings of Bt seeds and expressed their anger in so many ways. It was quite a dramatic sight to see policemen guarding seed and fertilizer shops from farmers, the very people needed to sustain them.
The Government of Andhra Pradesh instituted its own inquiry into the failure of Bt cotton in 2005 and banned Monsanto seeds. It is another story, but huge pressures from trade and industry as well as the US Government were brought to bear on the Government of Andhra Pradesh, which caved in under such pressures and revoked its ban order.
While all this was happening, the industry continued to paint a rosy picture of Bt cotton. A number of industry-commissioned studies by commercial opinion pollsters claimed that Bt cotton had increased yields, reduced pesticide use, enhanced profits and changed the destiny of cotton farmers. And there were many scientists, prominent among them Dr. Qaim of the University of Bonn, who tried to explain away these problems as arising from "susceptible germplasm." The same set of arguments came from a stable of scientists who are committed advocates of biotechnology. All of them continued to claim that Bt cotton was succeeding in helping the poor. How does one explain this obvious contradiction between the ground reality and scholarly assertions?
Dominic Glover (2009) from the prestigious STEPS Centre of the Institute of Development Studies, University of Sussex, offers some explanation for this contradiction:
This review of studies on the impacts of Bt cotton in China, India and South Africa shows that there is clear evidence of selectivity in the way that partial, ambiguous and equivocal data has been interpreted and represented. In all three cases, the story of success that has been highlighted on the surface has been shown to be, if not untrue, certainly only part of the story.... in a number of different, subtle but identifiable ways, encouraging results have been emphasized, while negative ones have been downplayed.
So the controversy rages on. There is no concerted effort by the scientists outside of the corporate control and the government bodies to come together to make a dispassionate analysis of agrobiotechnology, particularly transgenic crops, especially when it is about to make incursions into our food crops. Starting with Bt eggplant, a host of food crops such as rice, mustard and soy are on the verge of getting approval for commercial cultivation by India's weak regulatory body. While on the threshold of this catastrophe, it will be worth our while to look at some of the warnings issued by Professor Jeffrey Smith (2007) of the Institute for Responsible Science in the US:
The prevailing worldview behind the development of GM foods was that genes were like Lego blocks, independent pieces that snap into place. This is false. The process of creating a GM crop can produce massive changes in the natural functioning of the plant's DNA. Native genes can be mutated, deleted, permanently turned off or on, and hundreds may change their levels of expression. The inserted gene can become truncated, fragmented, mixed with other genes, inverted or multiplied, and the GM protein it produces may have unintended characteristics with harmful side effects.
Thus the promise of biotechnology in agriculture sounds very hollow. As people who have worked at the grassroots with farmers who have planted Bt cotton and have suffered heavily as a consequence, we feel the thick blanket of half-truths that wrap the dark secrets of the "success stories" of genetic engineering.
****
**References**
Glover, Dominc. 2009. "Undying Promise: Agricultural Biotechnology's Pro-Poor Narrative, Ten Years On." STEPS Working Paper 15. Brighton: STEPS Centre.
Kirtiman, Awasthi. 2008. "Bt's Soil Chemistry." _Down to Earth._ (October 31, 2008).
Lean, Geoffrey. 2008. "Exposed: The Great GM Crops Myth," _The Independent_ (U.K.). (April 20, 2008), at http://www.independent.co.uk/environment/green-living/exposed-the-great-gm-crops-myth-812179.html.
Malkarnekar, Ashok, Diemuth Pemsl and Hermann Waibel. 2006. "Technology Adoption Under Heterogeneity and Uncertainty: The Case of Bt-Cotton Production in Karnataka." Hannover, Germany.
Qayum, Abdul, and Kiran Sakkhari. 2008. "Another Year of Doom: Bt Cotton in AP." Andhra Pradesh, India. Deccan Development Society.
Smith, Jeffrey M. 2007. _Genetic Roulette: The Documented Health Risks of Genetically Engineered Food_. Deccan Development Society and Other India Press.
Sud, Surinder. 2008. "From Bollworms to Mealy Bugs." _Business Standard_. (March 11, 2008), at http://www.business-standard.com/india/news/surinder-sudbollworms-to-mealy-bugs/316325.
_This essay is adapted from a presentation made by P.V. Satheesh for the National Seminar on Genetic Engineering, Food and Farming, Institute of Engineers, Mysore, India, on November 7, 2009._
**P.V. Satheesh** _is Founding Member of the Deccan Development Society in India, and currently General Secretary and Director of the Zaheerabad Project. He is an internationally recognized specialist on development, communication and participation. Within Indian civil society, he is a prominent advocate on issues like gender, food sovereignty and organic farming._
# The Intensifying Financial Enclosure of the Commons
_by Antonio Tricarico*_
(*The author wishes to thank Heike Löschmann for co-authoring the German version of this essay, which improved the insights of the initial English draft.)
Financial speculation in food commodities has become one of the main drivers of food price volatility, with devastating impacts on small producers and the poor. Yet the disruptive influence of financial speculation on food markets is only a preview of future crises. International financial markets are now attempting to dominate many conventional markets as a long-term strategy to extract greater profits and accumulate capital. While governments have been discussing the issue in the context of the G20's focus on food security,1 their responses have been insufficient and contradictory so far and do not begin to address speculation in other hard commodities, where prices are even more volatile and the impacts on energy-dependent countries are equally severe. (1. The Group of 20 is the self-proclaimed club of the 20 strongest economic nations, which collectively produce up to 85 percent of the world's global GNP. These nations will decisively determine economic and political developments in the decades to come.)
The systematic financial speculation on commodities (and its systemically influential increase in recent years) has been driven mainly by deregulation of derivative markets. Derivatives markets, which trade in futures contracts and options, among other financial instruments based on other assets, enable the price risks for an asset (wheat, oil, pork bellies) to be transferred from the producer to other parties, often speculators, through the sale of "derivative" financial instruments. Speculation has also soared as investment banks, hedge funds and other institutional investors have jumped into the derivative market, often introducing new financial instruments such as index funds and exchange-traded funds.
All of these trends have been accelerated by financial deregulation, which over the last decade, for the first time in history, has transformed commodities into financial assets. Until the beginning of the 2000's, holding a ton of corn could not produce a revenue stream or rent, other than from sales based on market prices. Today, thanks to financial engineering, such financial schemes are not only possible, they are highly lucrative. The largely unregulated commodity derivatives markets have resulted in greater speculation on food commodities, which can cause high prices and shortages, particularly in poorer countries. Such "financial innovation" is part of a broader trend that is structurally transforming the global economy and natural resources management.
Contrary to common sense and what civil society often assumes, financial markets are penetrating deeper and deeper into the "real economy" of actual production. Speculative finance is increasingly influencing prices and thus productive output in agriculture and energy as well as natural resource commons that have historically functioned outside of markets. The result: speculative capital is becoming structurally intertwined with productive capital, including the commons as productive realms. This expansion of (finance) capital represents a new historic type of enclosure: investor-driven appropriations and control of many forests, fisheries, arable land and water resources historically managed as commons.
The 2007-2008 crash of financial markets and the global economy, coupled with investors' need to diversify investments beyond traditional markets (including equity, bonds and real estate), has intensified the search for new ways to achieve high rates of return, cover heavy losses that some institutional investors experienced during the crisis, and absorb the massive liquidity of capital that exists globally. These needs have propelled the development and even the creation of new types of financial market risks. But in so doing, financial market operators are reformulating the fundamentals of the real economy where everyday production and consumption occur. A massive financial transformation is underway as financial entrepreneurs create new tradable asset classes out of existing commodities, which provide a physical source of value to support new structured financial instruments.
The new financial assets are being created from existing commodities. And where markets do not yet exist, natural resources are being converted into commodities so they can be traded. Indeed, new commodities and markets are being created from scratch to satisfy the demands by financial markets for new, high-return investments
A very good example of this kind of "Rumpelstiltskin capitalism" – the making of something valuable from nothing, like spinning straw into gold – is the carbon market. These markets trade the right to emit carbon, as authorized by state-issued permits of such rights. Carbon-trading rights are also generated by companies through the implementation of projects aimed to reduce emissions in the future and thus to offset real emissions that the same companies are generating today. A carbon credit or certificate is in itself a derivative contract, given that its value is based on the estimated future price of abating carbon emissions. Therefore holding or buying a carbon credit is in itself a bet about the future, something quite different from holding stock in a ton of corn. These rights to emit – or credits and certificates – are then resold on a secondary market, otherwise known as "emission trading." Derivative financial products are built on the rights, credits and certificates, as in the case of other commodities. In this case, as with other commodities, speculative investors are simply trading financial risks associated with the carbon commodity – which itself is highly unstable and virtual.
**How are financialization and natural resources connected?**
We live in a time of finance capitalism, where trading money, risk and associated products is more profitable than production itself, and often accumulates greater capital than trading goods and services. This has huge implications for where capital is invested and the everyday impact that capital markets have on people, as more and more aspects of everyday life – from home ownership to pensions to schooling – are mediated through financial markets (rather than conventional markets alone). This is what people mean when they talk about the "financialization" of the economy.
Financialization should be regarded as more than just a further stage of commodification. Financialization reduces all value that is exchanged (whether tangible, intangible, future or present promises, etc.) into either a financial instrument or a derivative of a financial instrument. Financialization seeks to reduce any work, product or service to an exchangeable financial instrument like currency, and thus make it easier for people to trade (and profit from) these financial instruments. A mortgage loan, for example, is a financial instrument that lets an employee trade a promise of future wages for ownership of a home. Financialization aims to transform labor, goods and services into tradable financial products as we know it from currency trade.
With financialization increasingly penetrating into the real economy, financial markets, financial institutions and financial elites are gaining greater influence over basic economic policies and economic outcomes. Financialization transforms the functioning of economic systems at both the macro and micro levels of the economy in three distinct ways: 1) It changes the structure and operation of financial markets; 2) It changes the behavior of non-financial corporations (whose profits are more and more generated through financial markets than through actual production); and 3) It changes the priorities of economic policy.
Financialization is now reaching into all commodity markets and transforming their basic functioning. Just as the first wave of financialization focused on privatizing public services such as pensions, health care, education and housing systems (in the quest for better returns on investment), so the new wave of financialization seeks to commodify natural resources. In many instances, this leads to enclosures of the commons, which in turn affects both resource _exploitation_ as well as resource _conservation_ projects.
At the same time, growing global competition for the control and management of natural resources worldwide is intensifying pressures on national economies to exploit natural resources, resulting in what Michael T. Klare calls "resource wars" (Klare 2002). This is not simply a matter of rapid industrialization and emerging economies fueling greater global consumption and competition for limited resources. Resource wars are symptoms of new geopolitical and geoeconomic dynamics. The control of natural resources flows is increasingly seen as a key strategic tool for directing futures markets, political relations and economic supremacy.2 (2. See essays by Lili Fuhr and Liz Alden Wily.)
This trend is quite evident in recent large-scale land acquisitions at an international level by governments and the private sector. Their aim often goes beyond just securing future crop production for their own populations; they want to secure long-term, highly profitable positions in foreign markets to enable them to acquire and process natural resources as well as diversify their investments.3 In this context, advanced economies, particularly those reeling from the economic crisis, want to expand capital markets in other countries in order to establish a new private financial infrastructure that can generate enough financial resources to develop these new infrastructure investments. Financial markets awash in liquidity are desperate for such new investment vehicles: At the end of 2010, global capital markets were trading more than $200 trillion, which is almost four times more than the world's GDP, according to the McKinsey Global Institute (McKinsey, 2011). (3. See the essay by Liz Alden Wily)
The emerging "turbo-capitalism" driven by financialization seeks to address two pressing problems now facing investors: how to invest the massive amounts of private wealth and liquidity present today in capital markets, and at the same time how to create new financial instruments that will generate additional revenues for the financial industry.
Developed markets currently account for $30 trillion of the estimated total $43 trillion of global equity market capitalization, according to a recent estimate by Timothy Moe, chief Asia-Pacific strategist at Goldman Sachs. Over the next 20 years, global market capitalization could expand to some $145 trillion, he predicted.4 Looking only at private wealth not channelled through institutional investors, private equity funds managed $2.5 trillion at the end of 2008 (a 15 percent increase compared to 2007, despite the financial turmoil). International Financial Services London forecasts that funds under management will increase to over $3.5 trillion dollars by 2015, starting from less than $1 trillion in 2003.5 More and more private equity funds will focus on emerging economies. Global hedge-fund assets surpassed the $2 trillion mark for the first time ever, Hedge Fund Research Inc. said in April 2011, marking an impressive industry rebound from market losses and customer flight during the financial crisis.6
(4. Udayan Gupta. "The New Urgency of Emerging Markets," Institutional Investor (June 16, 2011), available at http://www.institutionalinvestor.com/Popups/PrintArticle.aspx?ArticleID =2848080. 5. IFSL Research, Private Equity, August 2009. http://www.thecityuk.com/assets/Uploads/Private-Equity-2009.pdf 6. http://online.wsj.com/article/SB10001424052748703922504576272683369646822.html)
This new stage of financialization will provide new economic and legal leverage for the further commodification of nature and the commons in general. More and more natural resources will be extracted and commercialized, unleashing a new massive attack on the global and local environment and the common wealth.
Capital markets regard this approach as a vital long-term strategy to secure and lock in a new structure of control over natural resources that assures attractive profits. But this finance-driven structure will also dramatically reduce the ability of communities to reclaim their shared wealth and assert their collective, locally responsive management. This systemic goal of "financial enclosure" of the commons, when coupled with existing trade and investment agreements,7 could produce a long lasting, legally durable enclosure that would seriously diminish (policy) space for any political player and for social movements – farmers, Transition Towns, Occupy Wall Street, and others. Most importantly, it threatens to extinguish the possibility of people reproducing their livelihoods independent of the overwhelming influence of financial markets. (7. See the essay by Beatriz Busaniche on intellectual property rights and trade policy.)
**Commodity speculation, infrastructure financing**
**and the invention of new markets**
_Food, land and agriculture_
After the first food crisis, financial speculators such as hedge funds managers acquired strong positions in markets for physical food commodities, most importantly rice, corn and wheat. In 2010, hedge funds dominated 24 percent of the maize market, enjoying the commodity's 34 percent price rally. Hedge funds have also increased their control of the soya bean market by 19 percent, up from 13 percent in 2009. These infusions of finance capital have affected the customary functioning of these markets by enabling large players to engage in market abuses and manipulations that make food prices more volatile. Worse, major trading companies in physical markets, such as Cargill, ADM, BUNGE and Glencore, which already play monopoly roles in several cases, are becoming more and more financialized. This means that they generate most of their profits through financial activities instead of through production for physical commodity markets.
Hedge funds, private equity funds and other investors play a central role in large-scale land acquisition, through international speculative investments. This explains why land in most cases is not put immediately into production. Instead, it is used as a vehicle to hedge against inflation or other investments in the same countries; as a way to enter those countries' markets or as simple short-term speculation in land as a financial asset. New investments in agriculture fostered today by international financial institutions must also be seen as investments in the future financialization of the economy. They aim at deepening financial markets in developing countries (or even building them, where they do not currently exist) by making small farmers and consumers more dependent on debt and retail financial markets. For example, financial institutions wish to encourage farmers to cope with food price volatility by financially hedging their risks, or by buying food commodity futures, weather derivatives and the like.
_Oil, electricity and renewable energy_
Ever since oil became a highly financialized commodity in the late Eighties, the price of oil has structurally influenced most economic processes in fossil fuel-addicted societies. The volatility of the price of oil is thereby transferred to other commodities, including food, with severe impacts on other economic sectors and consumers. This process occurs not only through the workings of the "real economy" (as oil prices are incorporated into retail prices), but also through the operations of index funds and other pools of speculative investments.
It is important to remember that major energy companies, such as General Electric and energy trading companies such as Enron, have been highly "financialized" since the Nineties. Their involvement in financial markets and high-risk speculative strategies have led to bankruptcy, as in the case of Enron's infamous speculation (and price manipulations) in the price of electricity. Similarly, today's major energy traders are investment banks and hedge funds – namely JP Morgan, Goldman Sachs and the RAB Energy hedge fund – that control oil productions and stocks directly or indirectly through participation into energy companies, energy service companies and traders (stocks, options and other financial instruments).
Because of this extreme financialization, any policy strategies to inaugurate a "Green New Deal" that focuses on trying to shift patterns in energy consumption and production will not succeed if it does not contain at its core highly financialized features. This risk should not be underestimated. For example, private equity funds in India, both domestic and foreign, have played a key role in listing renewable companies on the stock market through IPOs (initial public offerings, in which stock is first sold to the public). The fact that these offers became significantly over-subscribed increased the value of the companies to the benefit of short-term speculators. Similarly, several exchange-traded funds have stakes in green technology companies, which has helped to raise their profiles among short-term, speculative investors. The financialization of green technologies means that decisions about future energy developments and projects are increasingly directed by short-sighted, profit-maximizing financial speculators biased toward resource extraction.
_Metals and other hard commodities_
As for other hard commodities – coal, metals and non-metals – mining has already seen a strong influx of speculative capital over the last decade. Hedge funds have been playing a major role in financing mining projects and companies, including coal. Today many of the most significant mining multinationals systemically use derivative-based trading. The recent scam of transfer mispricing involving Glencore and its Mopani copper mine in Zambia8 is quite telling: the company used option derivatives to lock in copper sales to a Zug-based subsidiary – Zug is a well known tax haven within Switzerland – at below market prices and then the subsidiary was selling at market prices. (8. A detailed report about the dubious dealings of the Swiss company can be read here: http://www.zambianwatchdog.com/2011/05/04/detailed-report-on-glencore-mopani-mine-dubious-deals-in-zambia)
It is also telling that major investment banks like BNP Paribas are developing "structured commodity finance" as a new field of operation. This novel approach uses the full panoply of financial engineering based on securitization and derivatives to finance large-scale resource-extraction projects and companies. But unlike traditional project financing schemes that simply securitize the expected cash flows, structured commodity finance aims to securitize _the expected future physical output_ of the project or company by issuing securities that are then tradable on financial markets. Such financial instruments would necessarily lead a variety of investors to intensify pressures on resource extraction, disempowering communities who wish to have some say in how their natural resources are managed.
_Water and infrastructure_
In July 2011 the chief economist of Citigroup, Willem Buiter, stated in one of the company's regular thematic research briefings: " _I expect to see a globally integrated market for fresh water within 25 to 30 years. Once the spot markets for water are integrated, futures markets and other derivative water-based financial instruments ... will follow. There will be different grades and types of fresh water, just the way we have light sweet and heavy sour crude oil today. Water as an asset class will, in my view, become eventually the single most important physical-commodity based asset class, dwarfing oil, copper, agricultural commodities and precious metals._"9 This vision goes far beyond the current privatization of water services and utilities; it would require a significant increase in the production of fresh water (desalinization, purification) as well as the storage, shipping and transportation of water through a network of new dams and large-scale canal systems interconnecting different water basins. In short, water itself would become a financial asset, so that holding a physical quantity of water would generate a financial rent. (Ecological considerations of the flows and location of water would be considered secondary or irrelevant.) (9. Tracy Alloway, "Willem Buiter Thinks Water Will Be Bigger Than Oil," Financial Times, July 21, 2001.)
Building new water supply infrastructure would have its own powerful appeal to financial markets because it would require a massive mobilization of capital to build it – once again helping sop up the huge supplies of capital on global markets searching for profitable investments. Here again, a highly financialized approach will be followed in building water infrastructure, as today is happening with private equity infrastructure funds.
Specific attention should be paid to the toll that financialization has taken on water companies. The much-touted public-private partnerships have been significant failures, yet the many privatized water companies – i.e., Obras Sanitarias de la Nacion in Argentina, water supplies in Metro Manila in the Philippines, water utilities in Dar es Salaam in Tanzania – are short of financing and not producing profits. But it is becoming harder and harder to reclaim these companies to serve the public good, and eventually convert their capital base into publicly held or commons-based assets, because financial markets have promoted sophisticated bond issuances that have produced crushing indebtedness.
_Carbon, forest and new markets commodifying nature_
Carbon markets deserve specific attention because they can be seen as a deliberate experiment to try to build a new commodity, from whose trading financial assets and a financial market can then emerge. Today carbon markets are unable to function well primarily because of the virtuality of the asset that is being traded as well as the absence of reliable mechanisms for pricing carbon. These new markets are a clear example of how a new commodity could be created on the basis of market-based environmental and financial regulations: a commodity that itself is a derivative – a bet on avoiding projected carbon emissions against a disputable baseline.
With the inclusion of REDD credits into carbon markets,10 forests too will be financialized in the name of the fight against climate change. 11 This could well hurt people's livelihoods, particularly those of indigenous people living in forest areas. Similarly today there are proposals in the UK and US for establishing markets for trading species, habitats and ecosystems.12 As in the case of carbon and forests, this would require national – and where possible, international – legislation to create new types of commodities, e.g., commitments to establish a new preserved habitat in the future, to plant trees in the future, or to protect some species, which could then be traded within a cap (a defined limit on the resource established by political institutions), and thus become a financial asset. This would lead to what some scholars and activists have called the final financial project, "Nature Inc."13 (10. REDD (Reducing Emissions from Deforestation and Degradation) is a policy model that seeks to financialize the capacity of forests to serve as a carbon sink in the global metabolic cycle. The carbon that forests absorb is being given a monetary value, which can then be used to give different weightings to various economic decisions and to facilitate market trading of carbon credits. In this way REDD will advance the process of finanicalization. 11. Editors' note: These ramifications of REDD are not considered by Shrikrishna Upadhyay's essay. 12. See Joshua Bishop, "The Economics of Ecosystems and Biodiversity in Business and Enterprise" (Earthscan) at http://www.teebweb.org 13. See Andreas Weber's essay.)
**Preventing future enclosure of the commons**
Today we are living a paradox where after the crisis, financial markets are reinventing themselves and are even growing further despite some limited attempts to regulate them. At the same time they are displacing public finance and acquiring a larger share over the management and control of natural resources and strategic physical assets. For financial investors and speculators, controlling natural resources offers significant competitive advantages – information asymmetries, arbitrage possibilities, and hedging by pitting one sector against another e.g., energy users vs. food consumers, regardless of the environmental, social and economic implications.
Financial market managers need to diversify the assets they build upon for security reasons and natural resources offer a very safe option if their management is framed under a market-based approach that from the outset is designed to create new financial assets. However, one thing is clear: the further commodification of the commons would generate new liquidity that would directly be invested in financial markets, thus creating new bubbles and crises. Therefore, the financial restructuring of our economies will only worsen the features of our current over-financialized economy, and make exit strategies out of finance capitalism ever harder.
The financial enclosure of the commons has important implications for civil society struggles and organizing. First, the pressures to extract and commodify natural and social resources will further threaten the livelihoods of local communities that rely on them for their own sustainable and democratic development. However, to date, communities on the ground are largely oblivious of the new financialization scenarios and the new mechanisms aimed at boosting private profits by shifting risks to governments and citizens. Therefore, there is an urgent need to research and explain in plain words what is new in this process of financialization of the commons and how it goes far beyond commodification. Financialization is actually a new paradigm for securing additional leverage for dispossession. We need to expose the key drivers and actors, and open more political space for struggles on the ground so that different constituencies can co-develop a new analytic framework and political narrative that will advance a shared agenda.
Financialization of natural resources will not just affect "developing" countries; it will also be visible in advanced economies and the European Union in particular, where more and more large infrastructure and extractive projects will be pursued, provoking struggles and resistance on the ground. This would allow activists to establish new links of solidarity among affected communities, and in particular between advanced and emerging economies, helping to create renewed forms of international solidarity.
Second, we need to better understand the critical role that international institutions and major decision-making forums, such as the G20 and international financial institutions (IFIs), will play in promoting financialization and infrastructure-building in the name of "development." Key governments, IFIs and influential forums such as the G20 are poised to build on previous work carried out on financial regulation and investment agreements. This would entail "advice" by influential governments and institutions to deregulate subsectors of the financial system, such as public pension systems, so that public and private actors could begin to invest in risky long-term operations and/or heavily structured financial products.
Third, civil society should open up new avenues of policy that go well beyond market-based mechanisms and public finance for existing fiscal and investment mechanisms. By focusing on alternative approaches to public finance, and by reclaiming and defending the commons beyond market and state, civil society could slow the expansion of financial markets.
Finally, financialization of emerging and developing economies will necessarily have inevitable and severe impacts on development processes. It will have serious macroeconomic and macrofinancial implications that are not yet well understood, even by governments. A broader international civil society discussion questioning both micro and macro impacts of this trend through a sustained narrative could open up new political space for democratizing and reclaiming development processes. In particular, discussions should be focused at the local level by asking a number of key questions: What projects and infrastructure are needed by communities? For whom? For what purposes? What forms of financing are needed in order to mobilize domestic resources for development of self-reliant communities and promote existing and new alternative projects and processes?
While the impending new wave of financialization is a serious threat, it also opens new opportunities to bridge civil society struggles at both the micro/community level and macro/national and international levels. One can imagine a new and unifying global campaign framework that would evolve from the "our world is not for sale" approach that has animated previous struggles against the global free trade and investment agenda.
What will happen in the very next years will be crucial. The financial industry will seek to build the consensus and legal and physical infrastructure to achieve a finance-driven enclosure of the commons. To make all of this possible, states will be asked by corporate interests to enact new legislation and authorize new financial infrastructures through ad hoc regulations. In part, this is already happening. It is therefore urgent that civil society movements understand the financial industry's ambitions and act to stop them before it is too late.
**References**
Klare, Michael T. 2001. _Resource Wars: The New Landscape of Global Conflict_. New York, NY. Metropolitan Books.
McKinsey Global Institute. 2011. "Mapping Global Capital Markets, available at: http://www.mckinsey.com/Insights/MGI/Research/Financial_Markets/Mapping_global_capital_markets_2011.
**Antonio Tricarico** _(Italy) is an engineer, campaigner, analyst and editor. He works for Re: Common, formerly the Campaign to Reform the World Bank (CRBM), in Rome, on international financial institutions, financial markets regulation and financial globalization related issues. He has co-authored several publications on IFI-related issues, the most recent being, "La Banca dei Ricchi," and has been correspondent for the Italian newspaper _Il Manifesto _at several international summits._
# Mining as a Threat to the Commons: The Case of South America
_By César Padilla_
The latest cycle of mining expansion in South America dates from the mid-1990s. Since then, levels of investment in exploration and exploitation have generally held steady. Such investment has benefited from reforms in the laws governing mining in almost all countries, and the high demand for basic minerals for industrial use, especially in China and India, which have translated into high prices. The so-called "financial crisis" of the early 21st century further accelerated the rising prices of precious metals, which are now seen as a "safe-haven" value given the vulnerability of currencies. This trend has meant, in turn, an increase in the number of mining projects in the portfolios of transnational corporations and an expansion of the areas given in concession throughout the region.
The concessions granted to mining interests have soared in Peru, from 7.3 percent of the national territory in 2005 to 15.4 percent in 2009. This, in turn, has intensified socio-environmental conflicts on territories and communities. In Colombia, President Santos's aggressive promotion of mining (" _la locomotora minera_") has entailed a substantial increase in mining concessions. According to the Ministry of Mines of Colombia, more than 40 percent of the national territory is being sought for mining concessions. In Argentina, the number of mining projects increased 740 percent from 2003 to 2007 alone, reaching the considerable number of 336 projects (Swampa/Antonelli, 2010). In Ecuador, despite the mining mandate ( _mandato minero_ ) that reverted mining concessions to the State during the Constituent Assembly in 2008 (Acosta 2009), there has been an increase in mining concessions, especially along the southern border with Peru.
The increase in areas given over to mining concessions in South America has involved profound disruptions of ecosystems and the communities that have depended on them for centuries. Communities have lost access to their most valued properties that they customarily shared in a sustained manner. The natural and cultural elements that have supported the communities' development, lifestyles and systems of existence – all the components that contribute to the concept of " _vivir bien_ " (literally, "living well") – are under siege1 (Choquehuanca 2010). (1. See also the conversation between Gustavo Soto Santiesteban and Silke Helfrich.)
Water has been one of the commons goods most affected by mining in the region. Defined as a "thirsty industry" (Cereceda 2007), mining has been dispossessing the agricultural communities of their water sources. It has also diminished access to water for urban populations, especially in critical hydric zones such as northern Chile, southern Peru, and the Bolivian altiplano.2 Accordingly, one of the most important demands of the communities affected by mining is protecting the water sources for their use in agriculture and for human consumption. They also seek to keep water resources intact to conserve the ecosystems and ensure that various rituals associated with water can continue. (2. http://www.larepublica.pe/23-06-2011/minera-sancionada-por-usar-agua-sin-permiso-en-puno)
The most recent conflicts between communities and mining enterprises – in which the governments have not been neutral actors but rather allies of the transnationals – have been over protection of the water. The people of Islay in the Tacna region in southern Peru, worried about their access to water and its conservation, succeeded in getting the government to reject the environmental impact study submitted by Southern Copper Peru for its Tía María mining project. They understood the dangers that mining poses for human existence. For example, the Puno region in Peru was brought to a standstill for 45 days in 2011, and the border with Bolivia was shut down, because of the risks of mining contamination of the rivers that flow into Lake Titicaca.
Mining cannot be productive and sustainably managed if it ends up driving the population from its territory. Mining not only brings an end to the water, but also to the way of life tied to the land, traditions, spirituality and sense of belonging. It has recently been learned that mining by transnational companies in the high Andean glaciers along the border between Chile and Argentina is jeopardizing waters that are critical to these mountainous ecosystems.3 Fortunately, a new Argentinean law protecting the glaciers has been enacted in an attempt to prevent droughts and conserve the ecosystems of these highly productive valleys.4
(3. This is the controversial Pascua-Lama open pit mine of gold, silver and copper that the Canadian company Barrick Gold is developing. For more, see Wikipedia entry, "Pascua Lama," at https://en.wikipedia.org/wiki/Pascua_Lama
4. http://parlamentario.com/noticia-33704.html)
There are similar fights to protect water in northern Colombia's _páramos_ , the ecologically vulnerable high elevations between the upper forest line and permanent snow line. The _páramo_ are a symbol of life in extreme conditions, a place of long cycles of regeneration, reproduction of species and arrested growth. Destroying the _páramo_ destroys not only the ecosystem and the water, but the reproduction of life itself. A Canadian mining company, GreyStar, in the _páramos_ of Santurbán in the department of Santander, near the border with Venezuela, was involved in intense negotiations with the government to build a massive mining operation in the _páramo_. Ultimately, the government succeeded in getting the company to withdraw its environmental impact study.
Mining operations in South America are also having a major impact on the soil, which is especially important to the indigenous and small farmer populations. Mining concessions have taken tens of thousands of hectares from these people and, in the process, impeded free transit through many regions. The mining has also prevented communities from using the soil to raise stock and harvest subsistence resources such as firewood, mushrooms, wild fruits, natural materials for crafts and plants for culinary and medicinal uses. Mining has also wounded the forest, which is the habitat of the spirits, the forces in favor of and against humans, the place where one consults one's destiny and where one gets the answers for future decisions. The mountains have a special meaning in the mythology of the high-Andean cultures; they are the _Apus,_ or sacred mountains, understood as divinities whose supernatural powers care for and protect the inhabitants of the altiplano and govern their destinies.
The ancestral and agricultural peoples depend on their territories for their subsistence and for the development of their culture. This is made clear every time the states make commitments to mining development, such as in the case of Wirikuta in Mexico, spurring opposition by communities that the state wants to resettle elsewhere.5 The Huichol people, who call themselves Wixárika, who inhabit the Sierra de Catorce, consider their surroundings to be a sacred place. They call it Wirikuta and they have paid tribute to it from time immemorial. In their cosmogony, Wirikuta is one of the five cardinal points that gave rise to the world; there were born the gods under the influence of the powerful Tau (the Sun), which they consider the pillar of life. Therefore, they say, its destruction would mean the end of humankind. (5. La Jornada (Mexico City), March 5, 2011.)
What is at stake in all these situations is the replacement of stable, ancient systems of life with systems of consumption and markets. Mining displaces the "permanent" view of life, and imposes conceptions of life as "transitory and disposable." By forcing communities to migrate to cities or other regions, or disrupting their traditional cultures, mining concessions profoundly alter and even destroy communities. In addition, mining interventions destroy archeological vestiges, ceremonial sites, cemeteries, and other material and nonmaterial expressions of culture. Mining exploration roads and large craters resulting from open pit mines inflict harm on large areas of nature, threatening biodiversity as some plant and animal species disappear forever.
Biodiversity is also threatened by climate change, another side effect of mining through the use of fossil fuels in its operations, and in generating thermoelectricity to feed the mineral production processes. It has been noted that nearly 10 percent of global energy consumption can be attributed to mining (Earthworks 2003).
Mining is not just displacing farming from one area to another it is disrupting biodynamic agriculture cycles based on ancestral knowledge that have been effectively used for centuries. Mining threatens the cultural traditions and customs that have sustained soil conservation practices, managed planting time and coordinated agricultural work with subtle bio-indicators. The Quechua and Aymara farmers of Puno were accustomed to predicting the climate and the moments for planting their crops based on biological indicators. The state of development of a species of ants made it possible to determine the rains and frosts in that region of the Peruvian altiplano. If the young ants had lost their wings early, the crops would also come early. A certain cactus that flowered early ratified the message of the insects: the time to plant had come. With the displacement of communities and the consequent abandonment of traditional activities based on ancestral and millenary knowledge of one's surroundings, we are losing priceless cultural knowledge and traditions, which are often impossible to recover.
The mining industry's involvement in South American societies has devalued the idea of sovereignty – the ability of a people to decide the fate of its territories. It has also corrupted governments as mining interests use political manipulation and blackmail to achieve their goals. Mining companies have used a series of financial mechanisms to hide their actual income so that they can avoid paying their due income taxes and royalties (Alcayaga 2005). Such corruption of public servants and white collar crime are further eroding the ethics and morality of South American socieites.
The struggle against mining in the region is often presented as opposition to development. In fact, the communities affected and environmental organizations are struggling to recover and exercise their basic human rights. This struggle will continue so long as mining corporations and governments rely upon the mining model to enclose the commons.
**References**
Acosta, Alberto. 2009. _La maldición de la abundancia_. Quito. Abya Yala.
Alcayaga Julian. 2005. _Manual del defensor del Cobre_.
Cereceda, Enrique. 2007. _Agua y minería, una industria sedienta_. Bnamericas.
Choquehuanca, David. 2010. _Hacia la reconstrucción del vivir bien_. Alai.
Earthworks, at http://www.earthworksaction.org/publications.cfm?pubID=64.
Swampa, M. and A. Antonelli. 2010. _Minería Transnacional, Biblos._ Buenos Aires.
**César Padilla** _(Chile) is an anthropologist with a master's degree and co-founder of the Latin American Observatory of Environmental Conflicts (OCLA), specializing in mining, environment and communities, and coordinator of the Observatory of Latin American Mining Conflicts (OCMAL). He has been involved with conflicts among communities, mining companies and states in several Latin American countries and has published works about social and environmental conflicts provoked by mining._
# Water as a Commons: Only Fundamental Change Can Save Us
__
_By Maude Barlow_
__
Half the tropical forests in the world – the lungs of our ecosystems – are gone; by 2030, at the current rate of harvest, only 10 percent will be left standing. Ninety percent of the big fish in the sea are gone, victim to wanton predatory fishing practices. Says a prominent scientist studying their demise, "There is no blue frontier left." Half the world's wetlands – the kidneys of our ecosystems – were destroyed in the 20th century. According to a Smithsonian scientist, we are headed toward a "biodiversity deficit" in which species and ecosystems will be destroyed at a rate faster than Nature can create new ones.
We are polluting our lakes, rivers and streams to death. Every day, 2 million tons of sewage and industrial and agricultural waste are discharged into the world's water, the equivalent of the weight of the entire human population of more than 7 billion people. The amount of wastewater produced annually is about six times more water than exists in all the rivers of the world. A comprehensive new global study recently reported that 80 percent of the world's rivers are now in peril, affecting 5 billion people on the planet.1 We are also mining our groundwater far faster than nature can replenish it, sucking it up to grow water-guzzling chemical-fed crops in deserts or to water thirsty cities that dump an astounding 200 trillion gallons of land-based water as waste in the oceans every year. The global mining industry sucks up another 200 trillion gallons, which it leaves behind as poison.2 Fully one third of global water withdrawals are now used to produce biofuels, enough water to feed the world. A recent global survey of groundwater found that the rate of depletion more than doubled in the last half century. If water was drained as rapidly from the Great Lakes, they would be bone dry in 80 years. Dirty water is the biggest killer of children; every day more children die of water-borne disease than HIV/AIDS, malaria and war together. In the global South, dirty water kills a child every three and a half seconds. (1. C.J. Vörösmarty et al. 2010. "Global Threats to Human Water Security and River Biodiversity," 467 Nature (September 30, 2010), pp. 555-561, available at http://www.nature.com/nature/journal/v467/n7315/full/nature09440.html 2. César Padilla reports on the mining industry's abuse of the environment in Latin America.)
Knowing there will not be enough food and water for all in the near future, wealthy countries and global investment, pension and hedge funds are buying up land3 and water, fields and forests in the global South, creating a new wave of invasive colonialism that will have huge geopolitical ramifications. Rich investors have already bought up an amount of land double the size of the United Kingdom in Africa alone. (3. See Liz Alden Wily's essay in Part 1.)
The global water crisis is the greatest ecological and human threat humanity has ever faced.
**We simply cannot continue on the present path**
Quite simply we cannot continue on the path that brought us here. Einstein said that problems cannot be solved by the same level of thinking that created them. While mouthing platitudes about caring for the earth, most of our governments are deepening the crisis with new plans for expanded resource exploitation, unregulated free trade deals, more invasive investment, the privatization of absolutely everything and unlimited growth, which assumes unlimited resources. This is the genesis of the crisis. Quite simply, to feed the increasing demands of our consumer-based system, humans have seen nature as a great resource for our personal convenience and profit, not as a living ecosystem from which all life springs. So we have built our economic and development policies based on a human-centric model and assumed either that nature would never fail to provide or that, where it does fail, technology will save the day.
**Two problems that hinder the environmental movement**
From the perspective of the environmental movement, I see two problems that hinder us in our work to stop this carnage. The first is that most environmental groups either have bought into the dominant model of development or feel incapable of changing it. The main form of environmental protection is work to minimize the damages. The second problem with our movement is one of silos. For too long environmentalists have toiled in isolation from those communities and groups working for human and social justice and for fundamental change to the system.
The clearest example I have is in the area I know best, the freshwater crisis. It is finally becoming clear to even the most intransigent silo separatists that the ecological and human water crises are intricately linked, and that to deal effectively with either means dealing with both. The notion that inequitable access can be dealt with by finding more money to pump more groundwater is based on a misunderstanding that assumes unlimited supply, when in fact humans everywhere are overpumping groundwater supplies. Similarly, the hope that communities will cooperate in the restoration of their water systems when they are desperately poor and have no way of conserving or cleaning the limited sources they use is a cruel fantasy. The ecological health of the planet is intricately tied to the need for a just system of water distribution.
The global water justice movement is, I believe, successfully incorporating concerns about the growing ecological water crisis with the promotion of just economic, food and trade policies to ensure water for all.... We developed a set of guiding principles and a vision for an alternative future that are universally accepted in our movement and have served us well in times of stress. We are also deeply critical of the trade and development policies of the World Trade Organization, the World Bank and the World Water Council (whom I call the "Lords of Water"), and we openly challenge their model and authority.
Similarly, a fresh and exciting new movement exploded onto the scene in Copenhagen and set all the traditional players on their heads. The climate justice movement, whose motto is "Change the System, Not the Climate," arrived to challenge not only the stalemate of the government negotiators but the stale state of too-cozy alliances between major environmental groups, international institutions and big business – the traditional "players" on the climate scene....
**How the commons fits in**
I deeply believe it is time for us to extend these powerful new movements, which fuse the analysis and hard work of the environmental community with the vision and commitment of the justice community, into a whole new form of governance...that will allow us and the Earth to survive.... At the center of this new paradigm is the need to protect natural ecosystems and to ensure the equitable and just sharing of their bounty. It also means the recovery of an old concept called the commons.
The commons is based on the notion that just by being members of the human family, we all have rights to certain common heritages, be they the atmosphere and oceans, freshwater and genetic diversity, or culture, language and wisdom. In most traditional societies, it was assumed that what belonged to one belonged to all. Many indigenous societies to this day cannot conceive of denying a person or a family basic access to food, air, land, water and livelihood. Many modern societies extend the same concept of universal access to the notion of a social Commons, creating education, health care and social security for all members of the community. Since adopting the Universal Declaration of Human Rights in 1948, governments are obliged to protect the human rights, cultural diversity and food security of their citizens....
Also to be recovered and expanded is the notion of the public trust doctrine, a longstanding legal principle which holds that certain natural resources, particularly air, water and the oceans, are central to our very existence and therefore must be protected for the common good; they must not be allowed to be appropriated for private gain. Under the public trust doctrine, governments exercise their fiduciary responsibilities to sustain the essence of these resources for the long-term use and enjoyment of the entire populace, not just the privileged who can buy inequitable access.
The public trust doctrine was first codified in 529 A.D. by Emperor Justinian, who declared: "By the laws of nature, these things are common to all mankind: the air, running water, the sea and consequently the shores of the sea." US courts have referred to the public trust doctrine as a "high, solemn and perpetual duty," and held that the states hold title to the lands under navigable waters "in trust for the people of the State." In 2010, the US state of Vermont used the public trust doctrine to protect its groundwater from rampant exploitation, declaring that no one owns this resource but rather, it belongs to the people of Vermont and future generations. The new law also places a priority for this water in times of shortages: water for daily human use, sustainable food production and ecosystem protection takes precedence over water for industrial and commercial use. An exciting new network of Canadian, American and First Nations communities around the Great Lakes is determined to have these lakes name a commons, a public trust and a protected bioregion....
**Inspiring successes around the globe**
Another crucial tenet of the new paradigm is the need to put the natural world back into the center of our existence. If we listen, nature will teach us how to live. Again, using the issue I know best, we know exactly what to do to create a secure water future: protection and restoration of watersheds; conservation; source protection; rainwater and stormwater harvesting; local, sustainable food production; and meaningful laws to halt pollution. Martin Luther King, Jr. said legislation may not change the heart but it will restrain the heartless.
Life and livelihoods have been returned to communities in Rajasthan, India, through a system of rainwater harvesting that has made desertified land bloom and rivers run again thanks to the collective action of villagers. The city of Salisbury, South Australia, has become an international wonder for greening desertified land in the wake of historic low flows of the Murray River. It captures every drop of rain that falls from the sky and collects storm and wastewater and funnels it all through a series of wetlands, which clean it, to underground natural aquifers, which store it, until it is needed.
The natural world also needs its own legal framework,4 what South African environmental lawyer Cullinan calls "wild law." The quest is a body of law that recognizes the inherent rights of the environment, other species and water itself, outside of their usefulness to humans. A wild law requires a change in the human relationship with the natural world from one of exploitation to one of democracy with other beings.... In a world governed by wild law, the destructive, human-centered exploitation of the natural world would be unlawful. Humans would be prohibited from deliberately destroying functioning ecosystems or driving other species to extinction. (4. See also the essay by David Bollier and Burns Weston.)
This kind of legal framework is already being established. The Indian Supreme Court has ruled that protection of natural lakes and ponds is akin to honoring the right to life – the most fundamental right of all according to the Court. Wild law was the inspiration behind an ordinance in Tamaqua Borough, Pennsylvania, which recognized natural ecosystems and natural communities within the borough as "legal persons" for the purposes of stopping the dumping of sewage sludge on wild land....
**What can we do right now?**
Every now and then in history, the human race takes a collective step forward in its evolution. Such a time is upon us now as we begin to understand the urgent need to protect the earth and its ecosystems from which all life comes.
Anything that helps bridge the solitudes and silos is pure gold. Bringing together environmentalists and justice activists to understand one another's work and perspective is crucial. Both sides have to dream into being – together – the world they know is possible and not settle for small improvements to the one we have. This means working for a whole different economic, trade and development model even while fighting the abuses existing in the current one. Given a choice between funding an environmental organization that basically supports the status quo with minor changes and one that promotes a justice agenda as well, I would argue for the latter....
I want to leave you with these words from Lord of the Rings. This is Gandalf speaking the night before he faces a terrible force that threatens all living beings. His words are for you: "The rule of no realm is mine, but all worthy things that are in peril, as the world now stands, those are my care. And for my part, I shall not wholly fail in my task if anything passes through this night that can still grow fair, or bear fruit, and flower again in the days to come. For I too am a steward, did you not know?" – J.R.R. Tolkien
**Maude Barlow** _(Canada) is an activist, author and organizer who has been deeply involved in the global fight for the right to water. She served as Senior Advisor to the 63rd President of the United Nations General Assembly and received the Right Livelihood Award in 2005. This essay is adapted from a plenary speech given by Barlow to the Environmental Grantmakers Association at its annual retreat in Pacific Grove, California, in 2010. _
# Dam Building: Who's "Backward" – Subsistence Cultures or Modern "Development"?
_By Vinod Raina_
Very often, the collective assertions of movements for economic, political or social justice represent just the surface of a complex agenda. If one clicks on their claims, like on a hypertext, one might unravel its layers and discover the less visible spheres of values, traditions and philosophies that animate them – in short, the identities of the people involved. It is worth looking in this fashion at the social movements of India, which have ranged from Maoist type left-wing armed insurrections to campaigns by _adivasi_ (tribal), peasant, worker and _dalit_ (low-caste) movements, all of which are overshadowed by the mostly nonviolent nationalist independence movement inspired by Mahatma Gandhi, which enabled the country to oust the British colonialists in 1947. Many of these social movements continue today, supplemented by the post-independence women's and environmental movements.
The vibrancy of social movements is perhaps the best indicator of the deep roots of the democratic ethos in India, far more so than the rituals of elections. And as Priya Kurian notes, "Rarely have we seen the democratic process at work so palpably and so effectively as in the growing mobilization of people against large dams" (Kurian, 1988). During the past ten years or so, anti-dam movements, particularly the one against the Narmada dams, have received national and international attention, both from supporters as well as critics who see resistance as a revival of anti-developmental Luddism, the 19th Century social movement of textile workers that destroyed mechanized looms.
Dam building has a long history. Nearly 8,000-year-old canals found near the Zagros mountains in the eastern side of Mesopotamia suggest that the farmers there may have been the first dam builders. These primitive dams might have been small weirs of brushwood and earth to divert water into canals. Nearly 3,000 year- old dams were found in Jordan, as part of an elaborate water supply system. Evidence of such dams dating back to the same era exists also in the Mediterranean, the Middle East, China and Central America. Later on, the Romans were excellent dam builders.
A frenzy in dam building since the Second World War has resulted in more than 40,000 large dams on the world's rivers, according to the "World Register of Dams" maintained by the International Commission on Large Dams (ICOLD). An incredible 35,000 of them have been built since 1950! A large dam is usually defined as one measuring 15 meters in height. China had eight of them in 1949; forty years later it had around 19,000! The US is the second-most-dammed country in the world, with around 5,500 large dams, followed by the former USSR (3,000), Japan (2,228) and India (1,137).1 ICOLD defines a mega-dam on the basis of either its height (at least 150 meters), volume (at least 15 million cubic meters), reservoir storage (at least 25 cubic kilometers) or electrical generation capacity (at least 1,000 megawatts – sufficient to power a European city with a million inhabitants). In 1950, ten dams fell in this category. By 1995 the number had risen to 305. "Better river planning" now sites dams so that they cover an entire river basin, emulating the model set by the Tennessee River Valley development project. "Many great rivers are now little more than staircases of reservoirs," as one scholar puts it (McCully 1996).
(1. This data is constantly updated on the ICOLD website at http://icold-cigb.net/GB/World_register/general_synthesis.asp?IDA=206)
**Resistance to dams grows**
Many of the early movements of resistance to dams, like the hard-fought campaign against the 191-meter New Melones Dam in the Sierra Nevada foothills during the 1970s, did not succeed. But the struggle of Cree Indians against Quebec's mammoth James Bay Project led to the abandonment of the last two phases of the project in 1994; the Katun Dam in Russia has been suspended; and the campaign against dams planned for Chile's spectacular Biobio River is still going on. The struggle against the Narmada dams in India since the mid-eighties has become a global "symbol of environmental, political and cultural calamity," according to the _Washington Post_. And Narmada is only one of a long list of examples. In nearly all the cases, citizen opposition to dams is not enough to stop them, even though the people resisting were not remote conservationists, but those directly threatened with displacement.
It is therefore curious that the first successful anti-dam campaign in India, against the Silent Valley dam in Kerala, was motivated by conservation. Unlike most Indian dams, few people would have been displaced by the project, but it would have destroyed a major rainforest of the country. The concern for the forest and its endangered inhabitant, the lion–tailed macaque, persuaded the then Prime Minister, Indira Gandhi, to stop the project. The success of the campaign helped stop other proposed dams on the Godavari and Indravati rivers, at Bhopalpatnam, Inchampalli and Bodhgat, which together would have displaced over 100,000 adivasis and flooded thousands of hectares of forests. __
Dam building in India after independence in 1947 became a major symbol of modernization, scientific progress and a matter of national pride. The first Prime Minister of the country, Jawaharlal Nehru described them as "Temples of modern India." At the time of opening of the 226-meter-high Bhakra dam in 1954, Nehru exulted: "Which place can be greater than this, this Bhakra-Nangal, where thousands of men have worked, have shed their blood and sweat and laid down their lives as well? Where can be a greater holier place than this, which we can regard as higher?"
The impact of dams soared when dam construction was combined with river basin planning in 1948 with the formation of the Damodar Valley Corporation. Modeled on the Tennessee River Corporation, the project envisaged many dams on the Damodar River and other projects on a number of rivers in the eastern Indian state of Bengal. Though there was no visible campaign against this project, a former civil engineer, Kapil Bhattacharya, in a series of brilliant articles in Bengali, analyzed the likely consequences of the projects with astonishing accuracy (Raina, 1998).
Bhattacharya pointed out that the Calcutta port remained functional only because rivers flushed away silt that had flowed into the port during floods; damming these rivers for flood control, he predicted, would make the port non-functional – which is exactly what happened. He also predicted that government engineers would be forced to divert water into the port from an upstream river flowing into the region then known as East Pakistan (Bangladesh), and that this in turn would create international tensions. Again, this is exactly what happened. He foresaw a backflow of city sewage flowing into Calcutta's port and raising its bed. He even predicted that people would blame the local municipal council, not the dams that were far away from the city and beyond the control of the council. Damodar projects today are seen as a curse by hundreds of thousands affected by them; no one realizes that a rigorous social, economic and environmental impact analysis could have saved a lot of misery.
**The Gandhian vision vs. Nehruvian development**
From its inception, the Indian state was confronted by two different visions of reconstruction; the Gandhian project of reviving the village economy as the basis of development, and the Nehruvian plan of prosperity through rapid industrialization. Gandhi put his views together as early as 1921 in his book _Hind Swaraj_ (India's Self Rule). On the threshold of India's independence (October 5, 1945), Gandhi wrote to Nehru:
I believe that, if India is to achieve true freedom,...then sooner or later we will have to live in villages – in huts not in palaces. A few billion people can never live happily and peaceably in cities and palaces.... The villager in this imagined village will...not lead his life like an animal in a squalid dark room. Men and women will live freely and be prepared to face the whole world.... No one will live indolently, nor luxuriously.
"God forbid that India should ever take to industrialization in the manner of the West," Gandhi observed. "If an entire nation of 300 million (nearly _one billion_ today) took to similar economic exploitation, it would strip the world bare like locusts." In 1940, he had already expressed his misgivings regarding centralization, saying, "Nehru wants industrialization because he thinks that if it were socialized, it would be free from the evils of capitalism.... I do visualize electricity, shipbuilding, ironworks, machine-making and the like existing side by side with village crafts. But...I do not share the socialist belief that centralization of production of the necessities of life will conduce to the common welfare." The liberation that Gandhi promised was not merely an economic independence; it was, most profoundly, an assurance that the culture of the Indian peasantry would reign ascendant.
Jawaharlal Nehru brusquely dismissed Gandhi's vision: "A village, normally speaking, is backward intellectually and culturally and no progress can be made from a backward environment." Nehru's own ambivalence was to surface only a few years later when he talked of the evils of gigantic projects.
The Nehruvian developmental agenda has predominated for over fifty years now. There has of course been a great deal of industrialization in these years and a basic technical and service infrastructure laid for self-reliant development. Poverty persists unabated, however.
In their assessment of the Narmada dams, a large number of well-meaning professionals and intellectuals as well as ordinary middle class people ask, "Where then will power come from?" and "How can we do without irrigation – what about food?" and so on. These concerns – which need to be differentiated from similar sounding but more aggressive, self-serving arguments made by politicians, construction agents and other vested interests – need to be taken seriously. They are at the heart of the development debate everywhere. But it is necessary to situate the movement against the Narmada dams within the larger socioeconomic, political and cultural realities of India.
**Dams and the poor**
It is generally believed that any kind of development is finally for the benefit of the "common people." But who are they in India? The general consensus would be the "poor." I believe that an adequate definition of "the poor" is still missing in India.
In developmental terms, the Government defines all those who do not get to eat 2,200 calories or more per day in terms of food as poor. It is highly debatable whether something like poverty should be characterized by an exact line, defined by a single parameter; orders of estimates, based on qualitative criterion, would likely be more helpful.
We do know, however, that indigenous people, or adivasis, are at the poorest rung in the economic ladder of India. They number about 7 percent, or around 72 million people (more than half the population of Japan) out of a total population of nearly 1.2 billion Indians. On a par with them are the landless laborers and marginal and subsistence farmers with up to an acre of land. There is also a large population of people who subsist on their traditional artisanal skills, as potters, iron smelters, bamboo and grass weavers, small-scale handloom workers, leather flayers and tanners. If we add the slum dwellers of the cities, there are about 600 million poor people in India. About two thirds of the population somehow manages to survive and subsist, and another one third, composed of lower, middle and wealthy classes, lives in varying degrees of material comfort.
Except for the urban slum dwellers, the rest of the poor population of India subsists mainly on some form of common natural resource – land for subsistence farming, bamboo, grass, leather, minerals for artisanal occupations, various biomass sources for fuel and housing needs. The best example is that of the _adivasis_ (indigenous people). Living mostly in or close to the forests, their economy, culture and society are organically linked to these forests. The material that goes into making their dwellings, most of the food, firewood for cooking and water is obtained as a free common resource from their immediate physical surroundings. Their encounters with the market are mostly at the weekly travelling _haats,_ which provide essential items like salt, kerosene for domestic lighting, and bare minimum clothing. Items like cooking oil, cereals and pulses, sugar, spices and soap are luxuries to be indulged in once in a while.
Fifty years ago, after more than 150 years of colonialism, the expectations of the people were boundless. The state opted for a mixed economy of private and public, and embarked on a massive industrialization and infrastructure program, hoping that the benefits would trickle down to the common people. Absolutely no concern was given to the forty million people involuntarily displaced through dam building, urbanization, mines, the setting up of industries and the like. The basic premise has been that national development cannot be achieved without a certain sacrifice. Whatever benefits accrued from these projects, in terms of increased electricity, irrigation or industrial products, have generally enriched the richer one-third of the population, and have not trickled down to those who need them most.
There have been other adverse effects on the "common" population too. Since many of them survive only through free access and use of common natural resources, new legislation transferring forests, minor forest produce, land, water and minerals to the state threatens their basic subsistence and cultures. Contrary to government allegations, the _adivasis_ rarely fell entire trees, but rather lope off branches or collect dead wood. The felling of trees is done by contractors who supply fuelwood to big cities, with permission from the same forest department that harasses the poor for using their traditional commons. Even though kerosene and cooking gas is subsidized, it is clear that biomass is going to continue as the main source of energy. Forests have to be conserved so that they can be used sustainably, otherwise most of the Indians will be unable to cook their food.
It may be clear now why people who are likely to be affected by development projects struggle so fiercely against them. Dams, trawler fishing, the siting of power plants and hazardous industries, missile and artillery ranges and a long list of other development projects either take away or pollute the shared natural resources that are critical to the poor's very subsistence. Despite promises to help commoners make a transition to more secure industrial labor, they generally remain dispossessed, and must fend for themselves in the so-called informal sector.
**A question of cultures and beliefs**
Every social movement is almost always a cultural movement too, so if we wish to understand its motivations and persistence, we must understand how the movement derives its sustenance from deeper cultural roots. To understand the motivations of the Narmada movement, we must therefore understand the cultures of human settlements on rivers.
Rivers have played an integral part in the rise of civilizations all over the world. The people who live near rivers have a deep-rooted reverence for rivers, as seen in the riverside temples and holy sites in every nook and corner of India that regard the river as the form of a goddess. Bathing in most rivers is seen as a process of washing away one's sins. The flow of the river is basic to these beliefs, the goddess associated with each river is seen as virginal, and their purity is supposed to be maintained because of the flow. These beliefs are affirmed by the daily rituals followed by millions of people in temples on the river banks, and in numerous songs and stories that honor the river as a provider and giver. In many women's songs the allusion is to that of an empathizer; it is only the river that will understand the sadness of a woman's existence, and its constant flow signifies steadfastness, a constant companion whose life-sustaining qualities act as a balm in her life. This is not surprising since a woman in India spends a large part of her life in and around the river, fetching water, washing clothes, and bathing in groups.
It is common in the _adivasi_ belief system to honor the forest, the fire, thunder and rain, sun, moon and stars, animals and other external elements that influence their lives, for good or for bad. Therefore, most of their ritual is based in keeping peace with these elements. If they feel a militant possessiveness for their land, it is because their ancestors' bones lie there and their ancestors' spirits hover above. A faintly ridiculous simile comes to mind: just as in satellite-based global communications technology, ground stations provide the necessary and critical link to the invisible satellites above. So, it seems, the _adivasi_ see the spirits of their ancestors as the link to the external elements of nature that influence their lives. Their ritual, centered around the totem pole placed at the burial site, suggests a considerable dependence on these spirits to keep the external elements calm, which provides them with a sense of security. Since the proximity of the sites where the ancestors are buried is critical to this belief system, displacement from such sites is such a puzzling, alien and incomprehensible thought that it can arouse immediate militancy.
Imagine what would happen if the land beneath all the world's ground stations for satellite communication were to be acquired for other purposes, say agriculture. The _adivasis_ see their lands as similar "ground stations" for their belief systems, and naturally try to resist any attempts at displacement. And they feel puzzled and angry when offered land-for-land compensation. For a non- _adivasi_ farmer that may be a reasonable choice, provided the land in exchange is adequate and of good quality. But for the _adivasi_ , land is not merely material, so how do you exchange one piece for the other?
These are just two examples of what could be considered as the propelling elements for the local people involved in a movement like that against Narmada dams. These concerns remain mostly invisible, however, since the discourse is mostly about "development," which does not recognize beliefs as part of human development. But in fact, the agenda of modernization is not only about "development" (albeit of a very particular, material sort), but philosophical, too. In such an agenda, traditional and ritual beliefs are indicators of "backwardness" that need to be altered and scientifically tempered. Maybe that is why Nehru saw village-based cultures as backward. In a mechanical Marxist framework, such belief systems constitute the "false consciousness" of people that hinder a "proper" understanding of the material basis of life and existence.
Dam proponents see their scientism as self-evidently superior to traditional cultures: Should the _adivasis_ live as they have for centuries, as museum pieces, with their cultures and beliefs intact? they ask. Do they not have a right to progress? Of course any social group must have the right to change. But that must happen through a process that ensures that the concerned population is socially, economically and politically empowered to make their own decisions. It must be a process that ensures their dignity to make the encounter between tradition and modernity assimilative rather than violative.
A court order to vacate traditional habitations for the national interest can in no way allow the marginalized to modernize. It can and does, however, further alienate them. A much deeper debate seems necessary to explore and understand the notion and importance of "belief security," in the same manner as we recognize it in the material sphere. Lest the allusion to something like belief security be misconstrued as a glorification of misconceived irrationality, we need to remind ourselves that beliefs play an active role even in the domain of the rational, the sciences.
The great physicist Max Planck, reflecting on the fierce opposition to ideas of quantum mechanics (about which he himself was initially skeptical even though he was the first to uncover them), maintained that logical arguments and experimental evidence did not immediately change his previously held beliefs. Opposition to new views wanes, he argued, simply because the older generation of scientists dies and the new ones with different ideas grow up – an idea not much different from the Kuhnian notion of the paradigm shift that occurs over periods of time in the evolution of scientific knowledge. These shifts have to take place in an atmosphere that provides the freedom to explore and exercise choices. When that freedom is taken away, the opposition and resistance of people can be stunningly powerful. After all, cultures, beliefs and local life systems cannot be forcibly changed, no matter how competent the coercion is technologically.
**References**
All India People's Science Network (AIPSN). 1994. "Report on the Consultation for Restructuring the Sardar Sarovar Project" (mimeo). New Delhi, India.
Baviskar. A. 1995. _In the Belly of the River – Tribal Conflicts over Development in the Narmada Valley._ New Delhi, India. Oxford University Press.
Ganguli, B.N. 1973. _Gandhi's Social Philosophy_. New Delhi, India: Indian Social Science Research Council.
International Commission on Large Dams. 1998. _World Register of Dams_ , Paris, France.
Kurian, Priya. 1988. _Land_ _and Water Review._
McCully, Paul. 1996. _Silenced Rivers, The Ecology and Politics of Large Dams_. London. Zed Books.
Raina, Vinod. 1994. "Sardar Sarovar: Case for Lowering Dam Height," _Economic and Political Weekly,_ April 2, 1994. Bombay, India.
—————. 1998. _Waters of Conflict_ – _Alternatives in River Valley Projects; Rediscovering Kapil Bhatacharya and Megnad Saha_ , Nehru Memorial Museum and Library.
**Vinod Raina** _(India) is a physicist and an activist with the People's Science Movement working on science-society issues involving the Bhopal gas disaster, big dams and their impacts. He has been working on the clash between the use of resources for economic growth versus the people's right to reclaim their commons. Raina is Editor of_ The Dispossessed – Victims of Development in Asia.
# Belo Monte, or the Destruction of the Commons
_By Gerhard Dilger_
for Glenn Switkes1
_We, the people of Rio Xingu, want our forests to remain standing, we want our fish and other animals to live. We want to keep our fields and our traditional medicines. We need a clean river for bathing, and we want to drink water without getting sick. We want to live in peace. We want to be happy on our land and celebrate with our children and grandchildren in the future._
Sheyla Juruna, Altamira, Brazil, May 23, 2008
Frenzied growth instead of "the good life"2; authoritarianism and nepotism instead of participation; privatization of nature instead of fair use of the commons – the Brazilian government's decision to build the enormous hydropower plant Belo Monte in the Amazon area is an example of how resource conflicts are still being solved, even in those South American countries with progressive governments. (1. US documentary filmmaker and long-time activist in the international anti-dam movement. He helped coordinate the resistance against Belo Monte until his unexpected death in 2009. 2. The concept of good life is presented in a conversation between Gustavo Soto Santiesteban and Silke Helfrich. Vinod Raina discusses the problem of dams also.)
President Dilma Rousseff, who took office on January 1, 2011, argues that the megaproject is essential for the "development" of Brazil and the region of the Xingu, a tributary of the Amazon, but her argument is threadbare. Simply modernizing the dilapidated Brazilian transmission network would yield several times the amount of energy that Belo Monte is supposed to produce from 2015 and beyond. Her statement must be placed in the context of recent decades: Rousseff and her predecessor Luiz Inácio Lula da Silva have taken up the concepts of development propounded by the Brazilian generals in the 1970s who recruited "people without land" to migrate to Amazonia – allegedly a "land without people." Those were the years when the Transamazônica was built, the dirt road that connects the Xingu region with Belém, the capital of the federal state of Pará, today. Those were also the years of the initial plans for the dam complex on the Rio Xingu.
A broad resistance movement, the first of many, prevented the realization of the project in the late 1980s. The World Bank eventually withdrew a loan worth millions following international protests. None other than Lula, the former trade union activist who also owes his rise to the presidency to the force of the social movements, revived the megaproject in 2003.
In an alliance with domestic and international capital as well as corrupt regional elites, the dominant wing of Lula's and Rousseff's Workers' Party pushed the Belo Monte project through, against the wishes of the population affected by the project. And they did so despite assurances to the contrary, as Erwin Kräutler, the bishop of Altamira and winner of the Right Livelihood Award, emphasizes time and again. Dilma Rousseff systematically avoids talking with the "eco-social wing" of her political base.
Not only is Belo Monte's value to the economy questionable, so are its benefits in entrepreneurial terms. The construction consortium Norte Energia can survive only thanks to state electricity companies and various state pension funds. Low-cost loans from the development bank BNDES, itself funded by Brazilian taxpayers, finance 80 percent of its construction contracts.
Nonetheless, a large part of the electricity subsidized in this way is likely to benefit private steel and aluminum works, thus reinforcing Amazonia's role as a supplier of commodities to Europe, North America and Asia. Brazilian multinational construction corporations as well as European companies such as Andritz, Alstom, Voith/Siemens and Mercedes-Benz benefit from the contracts.
In August 2011, the federal prosecutor's office in Belém filed another suit against the construction of Belo Monte – on the remarkable grounds that it would violate not only the rights of the indigenous peoples, but also those of nature. This is the first time in Brazilian legal history that an argument based on the rights of nature had been made. Such rights were first established in Ecuador's new constitution in 2008.
"Humanity is moving toward recognizing nature as a legal entity," argues prosecutor Felício Pontes, "clean air is no longer considered _res nullius._ It is becoming _res omnium_." Yet there can be no doubt that the Brazilian courts will rule in favor of the powerful, just as the environmental agency Ibama has to yield to the president's directives.
The pace of tropical deforestation is already increasing today. Pontes estimates the area at risk to be 5,300 square kilometers, ten times the area of the planned reservoir. For months at a time, more than 100 kilometers of the Xingu will practically dry up, which will cause the loss of the living environment of the indigenous Arara and Juruna who live there. Belo Monte and the dozens of other planned dams in Amazonia are paving the way for further exploitation of the most diverse resources. Such megaprojects for resource extraction are an expression of outdated ideas of growth to which the Left in Latin America is still committed.3 Pontes states: "This rapacious development model runs counter to the protection of the environment. It does not consider the environment to be the house where all living things are at home." In this context, liberation theologian Kräutler speaks of _Mitwelt_ (German for the environment with which we live and interact) rather than _Umwelt_ (the environment around us). (3. See César Padilla's essay.)
Pontes says he has already seen in his nightmares what the Xingu region is bound to face: children with swollen bellies in the slums of Altamira, and "no more indigenous people living above the dam. All the fantastic diversity that exists today, with the waterfalls and the fish – all that would disappear. Like a desert, a Dantesque vision" (Brum 2011). Still, along with Sheyla Juruna, Erwin Kräutler and other activists in the area – as well as the people supporting them around the world – he has not yet given up resisting the monster dam on the Xingu.4 (4. In October 2011, the protest movement achieved a partial, mainly symbolic legal halt to the construction activities. For one day, 600 demonstrators occupied the construction site.)
In October 2011, the protest movement achieved a partial, mainly symbolic legal halt to the construction activities.
For one day, 600 demonstrators occupied the construction site.
**Reference**
Brum, Eliane. 2011. Um procurador contra Belo Monte, September 5 2011.
http://revistaepoca.globo.com/Sociedade/noticia/2011/09/um-procurador-contra-belo-monte.html.
Pontes, Felício/MPF. 2011. Ação Civil Públic Ambiental com Pedito de Liminar, 91329901001. De Altamira para Belém. July 17, 2011.
**Gerhard Dilger** _(Germany) has been a freelance journalist based in Latin America since 1992. His books include_ The Caribbean – A Crossroads of Cultures _(ed., 1993) and_ Kolumbien _(1996). He is South America correspondent of the independent Berlin daily_ , die tageszeitung, _in Porto Alegre, Brazil. http://gerdilger.sites.uol.com.br_
# Subtle But Effective: Modern Forms of Enclosures
_By Hervé Le Crosnier_
The history of the commons can be read as the expansion of the market sphere and of private decision-making over goods that hitherto were subject to common rules. From this point of view, the late 20th century technologies are double-edged: They have made it possible to expand the commons by offering new modes of regulation, favoring the non-market sphere and creating new opportunities for human activity, particularly in cyberspace.1 Yet they can also empower private control over common resources, especially in the living world and the biosphere. (1. See especially the essays by Christian Siefkes, Josh Tenenberg, Michel Bauwens and Franco Iacomella.)
Some have thought that the expansion of digital commons was inherent in the very nature of the goods in question. Digital information – reproducible _ad infinitum_ at a marginal cost of zero – could be the very symbol of an inalienable public good. The development of new infrastructure for miniaturizing material production to create even more digitally driven devices (3D printers, programmable machines tools, etc.) is expected to drive a similar phenomenon in manufacturing. The self-reproducible capacity of living beings2 made it appear to be the ultimate commons available to be shared by all humankind, to develop new foods, medications and environmental services. (2. See, for instance, Roberto Verzola's argument in the conversation about abundance in nature.)
Yet if one views the commons as the social organization of the maintenance of resources that can be shared by communities of actors acting in concert, one may see many new threats to both the commons and nature. Private control over living beings is now reaching into the deepest levels of people, plants and animals, i.e., their DNA. The same impulse to implant "code for control" is also being implemented deep inside the new digital commons. To understand the nature of these threats in the "knowledge-based society" and the means for combating them, we must define the angles for analyzing these new enclosures, their effects, and their weaknesses.
**The commons are still facing enclosures**
One can distinguish three categories of threats to the commons. First, those that loom over common-pool resources themselves; second, those that threaten the communities that have constructed and now maintain these resources and organize their shared use; and finally, threats to the very activity of commoning.
Common-pool resources may be degraded by pollution, over-exploitation, or even not being used for a collective good (the "anti-commons").3 Free riders may use resources without helping to maintain them. Such threats to the resources themselves exist with respect to the new emerging sectors. A commons such as Wikipedia is easily subject to different forms of "pollution," such as dishonest articles, propaganda and distortions. This demands constant attention and considerable energy from the Wikipedia community to take note of, monitor, and correct such cases of pollution; it is energy drawn away from the capacity to construct an even more complete encyclopedia. Similarly, the commons of world scientific research may also be contaminated by fraud, which erodes collective confidence in the research while boosting the careers of deceitful researchers. Deceptions may at times lead the scientific community to pursue dead-end lines of research and ignore more promising research priorities. (3. See Michael Heller's essay on the "tragedy of the anti-commons.")
The threats to the commons are also threats to communities, their existence and their ways of life. The dispersion of communities, generally due to violence, is the main form of attacks on the commons. One could even apply the term "petro-violence" to designate the ways in which the mad search for fossil fuel hydrocarbons has destroyed the environments of peoples living on oil-rich lands. With the new technologies for prospecting for water tables, or exploitation in difficult conditions such as under the Arctic, or in the great depths of the seas, this petro-violence seeks to capture global common-pool resources for its own profit. The disastrous experience of the explosion of the Blue Horizon oil platform in the Gulf of Mexico in 2010 – which has imperiled the marine ecosystem as well as the coastal economies (very low shrimp production in 2011) – illustrates this point.
Communities may also be victims of internal conflicts provoked by enclosures. Biopiracy is a major example of this phenomenon. It is very difficult to designate an identifiable "community" that can be said to "own" knowledge described as "traditional" – for example, cultural knowledge about the medicinal properties of a plant. Such cultural knowledge is constantly being circulated, and no border has kept people from transmitting their wisdom to one another. Yet rules negotiated at the World Intellectual Property Organization (WIPO) propose a model for distributing benefits that would assign rights to "communities" that possess "traditional knowledge," two terms that are difficult to define in legal terms.
When nations and corporations therefore try to introduce notions of "intellectual property" to indigenous communities that find the concept alien, even when defined as "traditional knowledge," it can provoke internal community conflicts. The same can be said of current so-called land grabbing now occurring internationally, especially in Africa, when communal lands are sold by the village leaders to large foreign companies, speculators and even states, to the detriment of the prior collective uses.
Indigenous communities refer to their existence using the term "peoples," a term that has been recognized by the United Nations. There is a major danger of ignoring the acquired forms of representation in order to leave it up to the appropriators to choose and designate a "restricted" group of actors with whom to negotiate the exploitation of their knowledge. Then, the limited returns to those who possess knowledge induce suspicions and internal wars, ultimately destroying the forms of solidarity that had been part of a community's way of life.4 Sometimes outside actors – corporations and states – seek to buy off certain major actors in the communities to get them to work outside the collective circle. One encounters this phenomenon in both the traditional communities and in networked communities such as developers of free software or university researchers, who often sell their community-derived expertise to large proprietary software companies. (4. Julie Duchatel and Laurent Gaberelle, eds. 2011. "La propriété intellectuelle contre la biodiversité? Géopolitique de la diversité biologique." CETIM. 217.)
The threats to the very activity of creating and maintaining the commons – "commoning" – often occur when laws external to communities are imposed on them. For example, when the patent offices of the United States and Japan allow information and technology companies to take out patents on software or business methods, as they have since the 1980s, they limit the possibilities for the open exchange of code, algorithms and knowledge within the community of free software developers. This means that there will always be a patent to hinder the use of a method or protocol, especially since patents are often formulated in general and very vague terms. Patents can override community rules that developers have adopted, such as the General Public License, which had previously assured the sharing of computer code.5 (5. For more details on the GPL, see Christian Siefkes' essay.)
Commoning is also hindered when that which belongs to everyone, or which was not appropriable by anyone, becomes a marketable good. The growth of mass tourism, for example, has dealt blows to landscape management practices. When researchers or their universities can take out patents, and indeed when they themselves are interested in marketing their research instead of transmitting it in disinterested fashion to students or society in general, knowledge, whether traditional or emerging from public laboratories, can no longer be shared and serve larger global interests.6 (6. A concrete example is examined by Christine Godt, Christian Wagner-Ahlfs and Peter Timmermann in Part 5.)
**The sources of the new enclosures**
Threats to the commons often fall into the following three categories: legal restrictions, technological interventions, and economic decision-making.
The laws favoring enclosures come from outside the communities, and are imposed on them by virtue of the political organization of the world, and through multilateral negotiations. This was quite clearly how "colonial laws" dispossessed the communities of the dominated countries. Today international laws and regulations concerning "intellectual property" often play the leading role, with all the ambiguities with which this term is fraught.7 (7. Beatriz Busaniche discusses intellectual property rules in the framework of the international trade agenda in Part 2.)
Enclosures may also be animated by new technological discoveries and inventions. The appropriators install locks "inside" the shared resource in order to limit its capacity to be shared or to be reproduced at a low cost, so that it must be purchased. Digital Rights Management systems (DRM) are the very symbol of such enclosures by means of technology. The publisher of a digital resource in a DRM decides how a work may be used, often to the detriment of collective uses (libraries), the specific situations of the buyers (requiring that one buy or use certain machines or software), or hitherto legal forms of sharing (private copying). Once encryption is designed into the governance of a resource, one can no longer turn to the courts or social norms to settle the shared use of a resource; rather, its sharing is governed directly by the need to possess a key for de-encryption, which ties the user to the producer. It is this relationship of dependence on producers that recent copyright laws seek to reinforce (the European Union Copyright Directive in Europe, the Digital Millennium Copyright Act in the United States, etc.).
This model of locks built into resources is in the process of taking over the world of living beings: first with genetically modified organisms, or GMOs, which are a "property marker," but especially by Genetic Use Restriction Technologies, or GURTs, which block certain traits in plants that can only be made operational again by adding a chemical product.8 "Terminator" procedures, which block the reproductive capacity of plants, are one application of GURTs. Still other new forms are expected to emerge and further subjugate agriculture to the providers of modified seed and the corresponding chemical product. If successful, GURTs will call into question the centuries-old logic of sharing seeds and cuttings, not to mention possible military applications. (8. See P.V. Satheesh's essay on genetically engineered crops in India in Part 2.)
New business practices are also enclosing the commons in novel ways. Industrial agriculture, for example, is attempting to consolidate landholdings, which often takes lands that commoners have used for generations. It is also producing calibrated fruits and vegetables, which require that one purchase certified seed, which in turn require the purchase of specific chemical inputs. This disrupts the traditional model of seed exchange used by village communities, which has guaranteed biodiversity in the peasants' fields and adaptation of crops to specific localities.
The very success of certain practices in commons can paradoxically be threatening because they attract new types of users who do not share either the goals or the common experience of the first communities of users. One example are newcomers drawn to free software because they need not pay but then behave like consumers rather than user-contributors by failing to exchange knowledge and reinforce the community. Another example are tourists, whose commercial visits modify the structures of village relations and encourage seaside construction to the detriment of the mangroves. The outside wealth brought by tourists can contribute a new ruling class and erode the ways of life and local access to natural resources. Organized mendacity, where children can get tourists' money easily instead of going to school, becomes an economic activity that supplants work in the commons.
The processes described above are just some of the new forms of enclosure that threaten the commons in a world dominated by technology and in which international relations are marked by stark inequalities. These new enclosures affect both commons tied to nature and those directly produced by communities of exchange and sharing, especially in the digital domain. With technology replacing barbed wire, the forms of enclosures have become more subtle and less visible. Yet the logic of destruction of communities and new limits imposed on collective practices and commoning, remain the same as in the long history of enclosures of land.
**Hervé Le Crosnier** _(France) is a researcher who teaches at the University of Caen and the Institut des Sciences de la Communication du CNRS (Paris). He has worked on the impact of the Internet on society and digital cultures, and published, with the Association Vecam_ , Libres Savoirs: Les Biens Communs de la Connaissance _(2011)_ , _ http://cfeditions.com._
# Good Bye Night Sky
__
_By Jonathan Rowe_
_Jonathan Rowe, a long-time activist/thinker, wrote extensively about the deep limitations of conventional economics, the spiritual pathologies of market culture and the appeal of the commons in imagining a better world. He was an editor at the_ Washington Monthly _magazine, staff writer at the_ Christian Science Monitor _, and the first director of the Tomales Bay Institute, later renamed On the Commons. This essay was published on September 4, 2007, on http://www.Onthecommons.org. Rowe died suddenly on March 20, 2011. The online archive for his writings can be found at http://www.jonathanrowe.org. _
There was a time, a few days ago in human history, really, when people spent a lot of time looking at the sky at night. To read Greek mythology, and Shakespeare's plays, one might guess that people were as familiar with the constellations, as they are with corporate brands today. Or close at least. Of course, it was possible back then to see the sky at night. As David Owen pointed out in a recent _New Yorker_ piece (August 20, 2007), in Galileo's day – about 400 years ago –people thought the Milky Way was a continuous ooze, so densely packed were the heavens to the naked eye.
Today we can see only a fraction of what was easily visible back then. We are enclosed in a visual cocoon, and the cause is not just the smog and fumes that fill the sky. Even more it is the light. "Today a person standing on the observation deck of the Empire State Building on a cloudless night," Owen writes, would see "less than 1 percent of what Galileo would have been able to see." We emit so much illumination – if that's the word – down here below, that we have lost the capacity to see above.
It is not just New York City. One common metric rates the darkness of the sky on a scale of one to nine. Galileo's sky was a one. New York City is a nine. The typical US suburb is five, six or seven. There are only a few places on earth – the Australian outback is one – where one can see the sky our ancestors did. "For someone standing on the North Rim of the Grand Canyon on a moonless night, the brightest feature of the sky is not the Milky Way but the glow of Las Vegas, one hundred and seventy five miles away."
If you have in mind to get away from it all in the Lower Forty-Eight, you can pretty much forget it, sight-wise at least. At the utilitarian level of most US debate, there are many implications, none of them good. Excess light, and the resulting interruption of circadian rhythms, has been associated with breast cancer in humans and the decimation of insect species. The waste of electricity is in the billions of dollars. Most outdoor lights – such as streetlights – are unshielded, which means they send more light sideways and upwards than they do down at the intended object.
Calgary, in Canada, cut its electricity bill by more than $2 million a year, simply by switching to shielded street lights that direct their light downwards. Then too, outdoor lighting often is counterproductive to begin with. It puts glaring light on one spot, and so induces night blindness to the darkness that surrounds. The California Department of Transportation has found it safer and more effective to use passive guides such as reflectors, rather than overhead lights.
Security lights often help burglars by lighting up possible entry points. Motion detector lights are much more effective because they attract attention by the very fact of turning on, and they save greatly on electric bills. It is a curious feature of this thing we call "the economy" that it befogs the sky with its version of light; and in the process emits the substances that are causing the climate to warm.
If that is an economy then I wonder what a dis-economy would be. But there is something more about the enclosure of the night, something that is elusive to state but no less important. It goes to the depletion not just of the earth's resources but also of our own. The night sky always has drawn human thought outward and beyond itself. Myth was born here, as was (not coincidentally) the puzzlement of children as to what lay beyond the stars, and what beyond that, and what set it all moving and keeps it all in place.
G.I. Gurdjieff, the teacher who grew up in Asia Minor, wrote in his autobiography ( _Meetings With Remarkable Men_) about his father, an _ashokh_ , a poet and narrator, who sang long narrative poems, memorized or improvised on the spot, to haunting melodies. People would gather to hear him sing these in the evening; and the large night sky was an apt setting for narrations that dealt with archetypal characters who existed out of time – stories that reached deep into the psyche, rather than with the minutia of this person or that.
Today there is a small and ingrown quality to our stories – which is to say something small and ingrown about the way we see ourselves. The enclosure of the night sky with manufactured smog and light has reinforced the enclosure and shrinkage of the psyche that inhabits it. Shut out from the free expansive space that draws us out of ourselves, we get sucked deeper into commoditized entertainments and commercial importunings that spiral endlessly in a tautological loop of self.
I cannot prove this. There is no way to, really. But I have a feeling that what is called "depression" is related to this shrinkage, and the devolution of awareness into a claustrophobic little market "me." My wife, who grew up in the Third World without electricity, and who walked many miles through fields and woods by the light of moon and stars, to this day has night vision that is uncanny. She sees clearly where I stumble.
She also never heard of this thing we call "depression" until she came to the US. A biochemical fact to us, it was a social artifact to her. This is climate change in more ways than one.
# Crises, Capital and Co-optation: Does Capital Need a Commons Fix?
_By Massimo De Angelis_
Today economic crisis is a capitalist crisis of social stability, not a simple recession—that is, a crisis that requires a realignment of class/power relations and new systems of governance in order to re-establish growth and accumulation.1 The last two times in which a real change in capital's governance occurred (in the post-World War II period with the embrace of "Keynesianism" and in the late 1970s with the shift to neoliberalism) followed periods of intense social struggles that helped social movements imagine alternative socio-economic arrangements. Capital, fearing that "ideas gripping the masses" might propel a radical transformation, was suddenly willing to shift its "governance" paradigm to accommodate some social demands while cutting deals with some segments of the movement and displacing the cost of doing the new paradigm onto other communities and environments across the globe. Pitting one sector of the social body against others has always been a strategy of capital development.2 But this time, things are getting a bit more complicated. My first thesis is that in facing _this_ crisis of social stability, capital faces an _impasse_. By "impasse" I mean that vital support for the growth of the social system is no longer forthcoming in sufficient degree, especially from the _environment_ in which the capitalist system operates. (1. For a discussion of crisis of social stability as opposed to other forms of crisis, see De Angelis, 2007a. 2. For a historical and theoretical discussion of how Keynesianism was founded on particular deals with sections of the working class, see De Angelis, 2000. For a theoretical discussion of the relation between capitalist development and social stratification, see the interventions in The Commoner, No. 12, Spring/Summer 2007. For a discussion of the current crisis along the lines proposed here, see Midnight Notes and Friends, 2009.)
Capital, understood as a social force organizing social cooperation for the purpose of accumulation, has a twofold environment. The first is constituted by social systems that reproduce the various facets of life in non-commodified ways. Access to money is, at most, only a means through which needs are satisfied and not an end in itself, as it is for capital. When the purchased commodities exit the market sphere and enter the spheres of social cooperation (households, associations, networks, etc.), they often enter the complex, culturally and politically diverse and variegated sphere of the commons. It is here that the cultural and physical reproduction of labor power, the value-creating commodity so critically important for capital, occurs – outside the control of capital but, of course, strictly coupled to it.
The other system that capital depends upon is the ecological systems upon which all life and social organization depends. The impasse that capital faces consists of the devastation of systems of social reproduction through reductions of wages and welfare over the past 30 years as work has become more atomized, flexible and precarious as well the increasing inability of natural ecosystems to support capital in its endless quest for greater resource extraction and cost-shifting externalities, such as the free use of the atmosphere as a waste dump.
In this sense, capitalism has reached an impasse, the overcoming of which, if done in its own terms, will produce a social and ecological apocalypse at worst, and an intensification of social conflict at best.
How can capital overcome this impasse? The difficulty lies in the fact that if the system has to survive it will have to continue to push for strategies of growth, i.e., accumulation. Capital's systemic necessity for growth derives not only from its elemental need for accumulation through a cost-cutting and cost-externalizing process of competition. Growth is also necessary as a way to reconcile a profit-maximizing mode of _production_ with hierarchical modes of _distribution._ If "all boats are lifted by a rising tide," there will be less pressure to address inequality and redistribution called upon by struggles for social justice.
Yet today, all the strategies and fixes available for capital to pursue growth in the world system will only intensify the crisis of social and ecological reproduction, amplifying and widening the range of resistance even if there is no focal, programmatic point.3 Capital is therefore pressed to shift the mode of governance of social relations, or at least to fine-tune neoliberal governance in such a way to contain the costs associated with the crisis of social reproduction and limit public expenditures necessary to police and control the rebellions generated by the crisis. In either case, capital needs other systems and forms of sociability to fortify its agenda. (3. David Harvey (2007) uses the term "fix" to discuss different capitalist strategies to deal with crises.)
This leads me to my second thesis: to solve or at least to address this impasse, capital needs the commons, or at least specific, domesticated versions of them. It needs a _commons fix_. Since neoliberalism is not about to give up its management of the world, it will likely have to ask the commons to help manage the devastation. And if the commons are not there, capital will have to promote them somehow.
On the other hand, commons are also systems that could do the opposite: they could create a social basis for alternative ways of articulating social production, independent from capital and its prerogatives. Indeed, it is difficult today to conceive emancipation from capital – and achieving new solutions to the demand of _buen vivir_ , social and ecological justice – without at the same time organizing on the terrain of commons, the non-commodified systems of social production. Commons are not just a "third way" beyond state and market failures; they are a vehicle for _claiming ownership_ in the conditions needed for life and its reproduction. The demands for greater democracy since the 1970s, now exploding worldwide in the face of the social and economic crisis, are really grassroots democratic demands to control the means of social reproduction. Democratic freedoms imply personal investments and _responsibilities_ , and commons are vehicles for negotiating these responsibilities and corresponding social relations and _modes_ of production. That is what Peter Linebough calls "commoning."
Hence, there is in fact a double impasse, for both capital and the social movements. Capital needs the commons to deal with the crisis as much as social movements need to confront capital's enclosures of the commons in order to construct serious alternatives and prevent capital's attempts to co-opt the commons. Hence, it is crucial not only to defend existing commons from enclosures, but also to shape new commons as they become a crucial terrain of struggle. This value struggle lies at the heart of the commons' potential as a social system and force that might overcome the hegemony of capital. This struggle between the value-generating logic of the two systems has not been sufficiently addressed in commons literature.
**Commons and capital as social systems**
Commons operate within social spaces that are not occupied by capital, whether these spaces are outside or inside capital's _organizations_. Thus we find commons in community organizations and associations, social centers, neighbor associations, indigenous practices, households, peer-to-peer networks in cyberspace, and in the reproduction of community activities that are organized within faith communities. We also find commons on the shop floor of factories and in the canteens of offices among co-workers supporting one another, sharing their lunch and developing forms of solidarity and mutual aid. We find commons and commoning in the "pores" of social labor that capital cannot control in spite of its always "revolutionary" management strategies.
These commons practices are possible to the degree they fill spaces not occupied by capitalist practices. For this reason, whenever the value-struggle between the two different ways of giving value to human activity reaches a structural limit – and there is no social space left for capital or the commons to develop without contesting the other – a _frontline_ is established. Reaching this frontline is, from the situation of commons, the opportunity to mobilize against the capitalist logic, or to capitulate to it, depending upon a given situation of social powers.
The fact that a frontline is or can be reached between commons and capital is because commons are a special type of social system. Within its realm, there lies the _possibility_ that its labor activity, organization and patterns of social relations will not succumb to external pressures, but instead organize its own reproduction autonomously, following criteria of equity and justice as defined by the commoners themselves. This possibility depends on the _contingent_ power relations within the commons; on the power of networked commons; and on forces _outside_ the commons, such as capital. The commons therefore represents a field of _possibilities_ in the struggle against capital.
Of course, the capitalist organization of production seeks to limit these possibilities as much as possible, both at the level of a particular capitalist enterprise and at the level of their articulation through the market. For example, labor must succumb to the bottom line of capitalist development; it is profit – not the actual contributions of social labor to well-being or _buen vivir_ – that defines whether the social labor mobilized in production and reproduction will be considered _viable._ This implies that struggles _within_ capital for better conditions of work and life can bring about positive emancipatory change for some. However, to the extent these struggles are channeled into profit-seeking capitalist development, these changes _also_ imply higher costs of social reproduction for capital and therefore the need to _shift these costs onto other nodes of social production and on the environment, if capital as a system is to survive_. The last wave of capitalist globalization is a vivid example of this dynamic.
**Commons and capital**
The relation between commons and capital is necessarily ambiguous, since their codependence and co-evolution makes it difficult to point out which of the two systems uses the other. This ambiguity can best be illustrated by looking at the paradigmatic role that the "village commons" has in relation to capital. In a classic study, the anthropologist Claude Meillassoux argued that the work of reproduction and subsistence going on in the village commons in South Africa (mostly carried out by women) allows male laborers to migrate and be available for employment for cash crop or other types of waged work. The work in the village commons reduced the cost of reproduction of these male workers since capitalists who hired them did not have to pay for the cost of their upbringing, or contribute to any social security in case of illness, unemployment or old age retirement (Meillassoux 1981). But Meillassoux also recognized the ambiguous character of the contemporary village commons. If the subsistence-producing commons is too "unproductive," capital loses important aspects of the "free gift" of labor power, while if it is too "productive," fewer workers would migrate out of the village commons, pushing wages up (Caffentzis 2004).
In other words, the relation between the commons and capital is a relation between two autopoietic social systems of production whose mutual interlocking and metabolic flows are regulated by the internal dynamic in each system.
This ambiguity at the heart of the relation between commons and capital means that questions of social power (understood as access to resources and the sense-orientation of the commoners vis-à-vis capital) can be pivotal. The social contingencies of this struggle means that questions of whether a commons can be co-opted cannot be addressed _ideologically_. The question of co-optation is a strategic field of possibilities, one that requires situated judgments based on context and scale. For example, many would argue that access by commons to markets to meet some of their needs is by definition evidence of their co-optation, while in fact it could be a contingent strategy of survival and a precondition for their reproduction.
One key variable in defining the outcome of this ambiguity is the wage rate, in both its "private" and social component. A lower wage rate reduces, among other things, the ability of people to spend time and pool social resources in the commons – to engage in commoning.
**Some current examples of commons co-optation**
The increasing dependence by capital on the commons does not curb its desire to enclose commons, however, as we see in the recent international land grabs now underway.4 Rather, it is likely that, in addition to enclosures, capital will also attempt to use commons to fix many social problems created by the crisis and co-opt the commons as a possible challenge to capital's management. Enclosures and commons co-optation seem to be the two complementary coordinates of a new capitalist strategy. (4. See Liz Alden Wily's essay in Part 2.)
This can be seen in the World Bank's approach to development in the global South. For years it has emphasized the importance of some aspects of commons management, such as pooled resources, community participation, and "trust" as social capital, among others. Whereas communities may create credit associations to pool savings __ and self-govern their distribution through "financial money commons" (Podlashuc 2009), development agencies rely on the same principles to tie communities to banks and microcredit institutions and so promote their dependence on global market circuits. In this fashion, bonds of solidarity and cooperation that are nurtured in commons are turned into mutual control and the threat of shame to serve market interests (Karim 2008).
In Britain, a coalition government of conservatives and liberal/democrats has overseeen massive cuts in public spending since 2010, and now are promoting a vision of "Big Society" that claims to support community empowerment to address social upheavals. The agenda of the neoliberal era is continuing apace, as if no crisis has happened, even as the ruling class clearly recognizes the social and environmental problems caused by this agenda. Unlike Margaret Thatcher in the 1980s, who said that society "does not exist," the conservative prime minister Cameron wants to turn it into a "Big Society" – continuing a strategy of community involvement already pursued by New Labour in the UK, as well as by governments in the US and Canada (De Filippis et al 2010). According to Cameron, governments needs to "open up public services to new providers like charities, social enterprises and private companies so we get more innovation, diversity and responsiveness to public need" and to "create communities with oomph."
But this approach requires recognizing that resources are not simply financial, but _that resources lie dormant in fragmented and atomized communities, and need to be activated_ through some form of commoning. People need to take matters into their own hands by, for example, connecting diabetes patients, the elderly or the marginalized youth into self-help groups.5 There is of course nothing new about the idea of mobilizing communities to clean up their neighborhoods. But what seems to be emerging in discourses such as the "Big Society" is a commitment to a faster speed and scale of change, since, as is widely recognized, social innovation can take a long time to be adopted. (5. In the UK, this type of approach taps into the work of social entrepreneurs such as Hilary Cottam and Charles Leadbeater of www.participle.net.)
Another discourse pioneered by capital to use the commons to serve its interests is the idea of "sustainable communities," a term used in urban planning and design circles when proposing new financial centers, shopping malls or mega-venues like the Olympics. The basic idea of "sustainable communities" is that they "can stand on their own feet and adapt to the changing demands of modern life" (Sustainable Communities 2003). In other words, they do not _decline_ facing the ongoing transformations that the relentless, ever-changing g requirements of the global economy impose. But this idea – with its emphasis on education, training, environment, governance, participation, and, of course, sustainability – amounts to an oxymoronic utopia. It is a vision in which communities never seem to tire of playing competitive games with _other_ communities somewhere else in the world in order to overcome the disruptions and inequalities of wealth and income inflicted by competitive markets. In this way " _commoning" is annexed to a divisive, competitive process_ in order to keep the whole game going. This oxymoronic ontology of our condition seems to be the key to the reproduction of capital (De Angelis 2007b).
In all these cases, commoning is turned into something _for a purpose_ outside the commons themseves _._ The purpose is not to provide alternatives to capital, but to make a particular node of capital – a region or a city – more competitive, while somehow addressing the problems of reproduction at the same time. But we must take heart in the fact that, in spite of capital's strategies to use a commons fix to the problems it creates while never really solving them, commons may well be part of a different historical development.
**Conclusion**
Writing in prison at a time of the consolidation of fascism in Italy, Antonio Gramsci wrote in an often quoted passage: "The old world is dying away, and the new world struggles to come forth: now is the time of monsters" (Gramsci 1971). A monster is an imaginary or legendary creature that combines parts from various animal or human forms. Fascism and Nazism were one type of this monster. Stalinism was another. Today, the articulation between capital, a system that recognizes no limit in its boundless accumulation, and a system that must recognize limits because it is only from within limits that it can reproduce life, love, affects, care and sustainability, may well give way to another monstrous social construction...or not.
Much will depend on us. Whether the avenue ahead is one of commons co-optation or emancipation is not a given. It will depend on political processes that have yet to be developed. Although a critical analysis of capital is necessary, it is not sufficient. The "cell" form of the social force that is responsible for establishing and reproducing life (or alternatively, failing to sustain life, depending upon the power relations), and _by this_ to abolish capital, we call today "the commons." By cell form I mean the general social form upon which this movement _can_ be generated, the _sine qua non_ without which no weaving of cells into a new social fabric without oppression, exploitation and injustice is possible. The commons is the cell form within which social cooperation for life-reproduction generates _powers-to –_ the only __ basis by which people can multiply their powers to the nth degree through networked commons that overcome the boundaries of locality and challenge the _power-over_ the commons established by different forms by capital.
There are at least two things that need to be taken into consideration in order to develop _powers-to_ as an effective force. First, we should not romanticize commons. Actual commons can be distorted, oppressive or emancipatory. When we enter the system-like loops of an established commons, we immediately notice what's at odds with our best-held values, beliefs and cultural mores. Too often, however, we decide to judge the commons on the basis of the values they express in relation to ours. Some activists tend to build communities based on political affinity, other on the basis of religious faith.
In these _identity-based_ commons, a clear boundary is established around the commons that prevent it from expanding _unless_ the outside embraces the values of the inside. "Conversion" here is the main mechanism of commons development – a mechanism, however, inadequate from the perspective of the challenges of building an alternative to capital in the midst of an emergent crisis of social reproduction. I have run across radical social centers that refused to engage with the local community on the terrain of reproduction because the cultural marks of that community did not match with the principles of the activists. Thus, instead of triggering a process in which these cultural marks could be engaged on the terrain of practice, a clear identity boundary is embedded in the commons, thus ensuring its insularity and vulnerability. Identity politics here is a barrier to the development of new emancipatory identities through commoning.
Second, capital can be confronted only to the extent that commons of social reproduction, and of everyday life reproduction in particular (Federici 2011), are developed as key sources of _powers-to_. The social reproduction commons are those commons developed out of the needs of its participants to reproduce some basic aspects of their own lives: health, food, water, education, housing, care, energy. The development of these commons is strategically crucial in developing emancipatory and progressive alternatives. Such commons must address people's basic needs and empower them to refuse the demands of capital by offering access to alternative means of life.
**References**
Caffentzis, G. 2004. "A Tale of Two Conferences. Globalization, the Crisis of Neoliberalism and Question of the Commons." In _The Commoner._ http://www.commoner.org.uk/?p=96.
De Angelis, M. 2000. _Keynesianism, Social Conflict and Political Economy._ London. Macmillan.
—————. 2007a. _The Beginning of History. Value Struggles and Global Capital._ London. Pluto.
—————. 2007b. "Oxymoronic Creatures along the River Thames: Reflections on 'Sustainable Communities,' Neoliberal Governance and Capital's Globalisation." _The Commoner_. Other articles in commons, http://www.commoner.org.uk/?p=38.
De Filippis, J., Fisher, R., & Shragge, E. 2010. _Contesting Communities. The Limits and Potential of Local Organizing._ London. Rutger University Press.
Federici, S. 2011. Feminism and the Politics of the Commons. _The Commoner_. http://www.commoner.org.uk/?p=113.
Gramsci, A. 1971. _Selection from The Prison Notebooks._ New York. International Publishers.
Harvey, D. 2007. _The Limits to Capital_. London. Verso.
Karim, L. 2008. "Demystifying Micro-Credit: The Grameen Bank, NGOs, and Neoliberalism in Bangladesh. _Cultural Dynamics_ , (20)1: 5–29.
Meillassoux, C. 1981. _Maidens, Meal and Money: Capitalism and the Domestic Community_. Cambridge, UK. Cambridge University Press.
Midnight Notes Collective and Friends. 2009. "From Crisis to Commons."
__ http://www.midnightnotes.org/Promissory%20Notes.pdf.
Podlashuc, L. 2009. "Saving Women: Saving the Commons." In _Eco-Sufficiency and Global Justice_ , Ariel Salleh, ed. New York, London. Macmillan Palgrave.
"Sustainable Communities. Building for the Future." 2003. Office of the Deputy Prime Minister, London. Available at http://www.communities.gov.uk/publications/communities/sustainablecommunitiesbuilding.
**Massimo De Angelis** _(Italy) is Professor of Political Economy at the University of East London. He is author, most recently, of_ The Beginning of History: Value Struggles and Global Capital, _and editor of_ The Commoner _web journal, at www.commoner.org.uk._
# Hope from the Margins
_By Gustavo Esteva_
These notes offer a quick glance to ways, in the south of Mexico, in which people are regenerating the society from the bottom up. It is a new kind of revolution without leaders or vanguards, which goes beyond development and globalization. It is about displacing the economy from the center of social life, reclaiming a communal way of being, encouraging radical pluralism, and advancing towards real democracy.
**The Oaxaca Commune**
From June to October 2006, there were no police in the city of Oaxaca (population 600,000), not even to direct traffic. The governor and his functionaries met secretly in hotels or private homes; none of them dared to show up at their offices. The Popular Assembly of the Peoples of Oaxaca (APPO) had posted 24-hour guards in all the public buildings, radio and TV stations. When the governor launched nocturnal attacks against these guards, the people responded by putting up barricades.
Some observers began speaking of the Oaxaca Commune, evoking the Paris Commune of 1871. The analogy is pertinent but exaggerated, except for the reaction these two popular insurrections elicited in the centers of power. Like the European armies that crushed the communards, the Federal Police of Mexico, backed by the army and the navy, conducted a terrible repression on November 25, 2006. They could not use the ways of the 19th century, but they inflicted a massive violation of human rights using an approach that can legitimately be described as state terrorism.
APPO remains a mystery, even for those who were part of it. It challenges conventional interpretations. A popular revolt against a tyrannical governor became a social experiment to apply the governance practices of the indigenous peoples constituting the majority of its population at the level of the state of Oaxaca (3.9 million inhabitants). Ferocious state repression interrupted the experiment but could not cancel it. Instead it took a different shape in communities and barrios as people continued affirming their political autonomy.
A communal way of being still prevails in most of the 13,000 communities of Oaxaca, in which communal obligations have priority over rights. No important decision can be taken without the explicit consent of the communal assembly, where all families are represented and know how to construct consensus. Some inequalities may be easily corrected: a person bringing many dollars after his stay in the US will spend most of them in the next fiesta, as a good majordomo (someone who protects a residence and family), and in exchange earn great prestige in the community. Every family event counts on the contribution of neighbors. Mutual help is used to build many houses and cultivate and harvest crops. Justice means that a crime requires consolation and compensation to the victim, rather than punishment, and it is delivered through community wisdom, not through jails, lawyers or trials. In most communities, every I is still a We.
The notion of _comunalidad_ , coined by two indigenous Oaxaca intellectuals, Floriberto Díaz, Mixe, and Jaime Martínez Luna, Zapotec, may help to explain the vitality and complexity of those practices and attitudes. It can be translated as commonality: the juxtaposition of commons and polity, but it is something else. _Comunalidad_ defines both a collection of practices formed as creative adaptations of old traditions to resist old and new colonialisms, and a mental space, a horizon of intelligibility: how you see and experience the world as a We. The foundation of _comunalidad_ and its core are: 1) the communal territory, in which 2) authority fulfills an organizational function beginning with 3) communal work and 4) fiestas, creating a world through 5) the vernacular language.1 (1. Illich renovated the meaning of vernacular to designate "the activities of people when they are not motivated by thoughts of exchange, a word that denotes autonomous, non-market related actions through which people satisfy everyday needs – the actions that by their own true nature escape bureaucratic control, satisfying needs to which, in the very process, they give specific shape." "The radical change from the vernacular to taught language foreshadows the switch from breast to bottle, from subsistence to welfare, from production for use to production for market, from expectations divided between state and church to a world where the Church is marginal, religion is privatized, and the state assumes the maternal functions heretofore claimed only by the Church." Ivan Illich. 1981. Shadow Work. Boston & London: Marion Boyars. 44 and 58.)
The hierarchical cargos are honorary services to the community that you begin to do very early in life. The _tequio_ – unpaid work done by every family, approved in communal assemblies and organized by communal authorities – is a practice responsible for more than half of all the public works in indigenous communities. _Guelaguetza_ is a complex system of reciprocity involving mutual help and material, symbolic and emotional exchanges, particularly in key moments in life, where a sense of both community ownership and personal freedom is forged as the ethical principle of _comunalidad_. _Guelaguetza_ is also the normative framework weaving the interdependence between the people of the community and the region, creating new links between them and the gods and the dead, and thus recreating the communal territory. Within _guelaguetza_ , giving and taking are sometimes tied, which strengthens a sense of mutual obligation between two persons or families. But reciprocity implies an attitude of open giving to others and the community, and trust and reliance in others and the community, when you are in need.
All this and much more is _comunalidad_ , still alive and thriving in most Indigenous communities in spite of the individualistic veneer imposed on them by the Church, the Spanish Crown, the Mexican State, private corporations or migration to the US. The Oaxaca Commune was an audacious social experiment to bring the same spirit to the whole state.
**A political mutation: territorial defense beyond development**
This way of being, with unique traits in every Oaxacan community, recently experienced a political mutation. As in many other parts in Latin America, the struggle for land assumed the form of territorial defense.2 People are weaving their efforts, knowledge and resistance in the defense of their resources and territory, opposing "development projects" and reclaiming their own notion of the good life. (2. See also the articles in this book by Dick Löhr in Part 5, César Padilla in Part 2 and Liz Alden Wily in Part 2.)
Some people still struggle to get access to the goods and services defining the ideal of life that shaped the contemporary notion of development. They ceded to governments, corporations and the media a traditional function of the people and the civil society: defining what it is to live well. Conventional claims (more roads, schools, health centers, jobs) are still perceived as requisites for social life or as rights that must not be renounced. But practices "bypassing" those institutions are now proliferating as different definitions of the good life – often expressed, in Latin America, as _buen vivir_ , living well – take root.3 These practices are getting increasing visibility in the midst of the crisis because they offer creative survival options in hard times and effectively resist the megaprojects still promoted in the region.4 (3. See also the conversation between Gustavo Soto and Silke Helfrich on the Buen Vivir concept in Part 3. 4. See Gerhard Dilger's essay on the Belo Monte mining operation in Part 2.)
In many ways the people are expressing a sovereign practice of the collective will, which openly challenges faculties of the governments. The political form of this claim is usually presented as autonomy. It has been actualized and reformulated by the indigenous peoples, especially after the Zapatista uprising in 1994, but increasingly includes many other social groups. It has already generated de facto institutional arrangements: an increasing number of people effectively control their territory and govern themselves in their own way (Esteva 2010). Even though indigenous peoples may be less than 10 percent of the population in many areas, they may represent more than 85 percent of the rural territory – as in Oaxaca – and also occupy popular barrios in large cities.
**The struggle for autonomy**
This struggle permeates people's initiatives and movements all over Latin America. Its most solid expression is probably what the Zapatistas created in the 250,000 hectares they have controlled since 1994 in Chiapas, a state bordering Guatemala.
Until 1993 neoliberal globalization appeared as an ineluctable reality. Politicians and scholars offered mere variants of what seemed to be the general destiny. There were no alternatives. The Zapatistas created them. What they are doing in Chiapas is a social experiment without clear precedent. In spite of severe restrictions, after seventeen years of rebelliously rejecting any kind of public funds, under a porous siege of 30,000 troops and exposed to continual paramilitary attacks, their radical innovations clearly anticipate one of the shapes of the post-capitalist world. (Esteva 1998, 2005).
Zapatista families are producing their own life in their own way. They combine traditional practices with contemporary tools to cultivate their basic staples, coffee and other products, which they sell through fair or solidarity trade. Their children attend free "schools" based on community conceptions and common themes, like their own story. They use traditional methods for healing, complemented with their own modern clinics, which give them access to contemporary remedies and practices. They build their own houses and public buildings, with local materials and traditions, enriched with contributions from other parts of the world. Self-government, similar to the Oaxaca tradition in communities and municipalities, operates also at the level of regions through Juntas de Buen Gobierno (Boards of Good Government): ordinary men and women, some of them very young, occupy temporarily the highest rank of authority for a group of municipalities and communities.
In Zapatista territory, land is not an artificial commodity. Territory is a space of responsibility. Occupation is not equivalent to property or tenure. A cosmocentric attitude before nature prevents the possibility of owning it. Within communal territory, land is allocated to the commoners without granting private property, but respecting stable family rights.
People don't delegate their power to representatives. The authorities command by obeying and are not professional politicians or bureaucrats, but ordinary men and women who temporarily perform functions of government, with specific mandates and responsibilities. They can be substituted at any moment. The distance between those governing and those governed vanishes. Justice is not the technical enforcement of formal rules, entrusted to professionals, but the practice of a non-written normative system based on the vitality of changing customs, and direct conversation among people.
The Zapatista struggle for autonomy combines the freedom for self-determination with a serious attempt to conceive ways of political and cultural communion with other peoples, through an intercultural dialogue. This attitude of radical pluralism, looking for the harmonious coexistence of different peoples and cultures, requires a kind of juridical and political pluralism that does not fit well within the design of the nation-state and representative democracy.
Radical democracy, Zapatista style, means "democracy in its essential form, democracy at its root...[It] does not abolish power; it says that the people shall have it, that the power will be their freedom...Radical democracy envisions the people gathered in the public space, with neither the great paternal Leviathan nor the great maternal society standing over them, but only the empty sky – the people making the power of Leviathan their own again, free to speak, to choose, to act" (Lummis 1996).
By their very existence, against all odds, the Zapatistas challenge both the dominant regimes and the conviction that people cannot govern themselves and someone should govern them. While Mexico is literally falling apart,5 dismantled by economic and political mafias, Zapatismo are attempting to reorganize the society from the bottom up, in order to forge new social and political pacts. (5. The US State Department recently classified Mexico with Congo and Pakistan as "failed states." The category is imprecise, but the fact is that the Mexican government can no longer govern in many areas; it is increasingly difficult to distinguish the world of institutions and the world of crime, and what is legal and what is illegal. During the last four years, there have been 50,000 deaths, 10,000 disappeared and 250,000 displaced, directly or indirectly associated with the "war" against organized crime. The very visible Movement for Peace with Justice and Dignity argues that it is basically wrong to approach a public health problem as a military problem, particularly with very weak and corrupt institutions (including the army) and in times of crisis. After several decades of neoliberal policies, eight million young people cannot study or work; more than half of Mexicans live below the poverty line; a fifth of them live in the US...and the richest man on Earth is Mexican. He and many other Mexicans on the Forbes 400 list are increasingly investing abroad, while the country continues to endure a kind of vicious civil war.)
The Zapatistas reclaim dignity and creativity in daily "work," to transform it into a free and joyful activity without the alienations that people face in capitalist societies. It is impossible to fully implement such alternatives in their current conditions, but they are advancing in that direction. Their point of departure is the notion of dignity, the only thing they were left with.
The Zapatistas can be seen as a community of learning. Learning is at the very center of their political project. "Asking, we walk" expresses the principle they continually apply – beyond the straitjacket of any ideology or party structure. It implies a radical opening to the interactions with others and a continual reflection, the decision to continually examine and re-examine their practice. Doing this as a group implies "to walk at the pace of the slowest" and transform their way, ideas and practices into a really collective creation.
As an expression of their learning, the Zapatistas formulated their own political and epistemological reading of reality which begins with reclaiming the word – in a process of liberation from the categories imposed on them during 500 years of colonialism.
They are changing the way to change. Change itself, not only its outcome, should be shaped in the mold of what is being looked for, eliminating the separation between means and ends. If the idea is that the people themselves should take control of their destinies, it is them, not a leader, a vanguard, a party or a structure, who should be the active protagonist of the change.
The struggle for autonomy looks for a new kind of social organization. The Zapatistas did not create a model and it will be absurd to idealize what they created against all odds. But they represent solid proof of the feasibility of a post-capitalist social organization. They are a source of inspiration for all the discontented, rebels and dreamers, who all over the world are looking for concrete proof that it is possible to materialize their dreams of transformation.
**Archipelago of conviviality**
The time has come to leave behind the era of _homo economicus_ 6 – from whom we inherit a planet in ruins. We are thus abandoning the economic society, capitalist or socialist, based on the premise of scarcity;7 never again will the economic sphere be at the center of social life. We are also abandoning the design of the nation-state, whose monopoly of legitimate physical violence became the curse of the modern society. And we are going beyond formal democracy without falling into new forms of authoritarianism. (6. See Friederike Habermann's essay in Part 1. 7. Editors' note: In the commons movement, there is a lively discussion about the concept of abundance versus scarcity. See the conversation between Davey, Helfrich, Höschele and Verzola in Part 1.)
The new society, emerging at the grassroots, has a new political horizon, in what André Gorz called the "archipelago of conviviality:" instead of the individual, the basic cell of this kind of society is the contemporary commons. No word can fully express the diversity of social struggles in Latin America attempting to create, at the grassroots, new ways of life and government. In the same way that commons is a generic term for very different forms of social existence, the immense richness of the social organizations currently existing or being created in Latin America cannot be reduced to formal categories.8 All these forms, actualizations of ancient traditions or contemporary creations, are beyond the private threshold but cannot be defined as public spaces, collective refuges or hunting preserves. They are not forms of property or land tenure. Specific ways of doing things, talking about them and living them express both cultural traditions and recent innovations. Their precise limits (their contours, their perimeters) as well as their internal strings (their straitjackets) are still insufficiently explored territory. They are getting increasing importance in initiatives that move beyond development. (8. Editors' note: The Spanish ejido (the land at the edge of the villages, used in common by the peasants in the 16th century) is not identical to the British commons, to the pre-Hispanic communal regimes, to the modern Mexican ejido, or to the emerging new commons.)
The revolution I am trying to illustrate in this essay was initiated by those defending their way of being from colonialists and developers. They are now regenerating it in contemporary terms. To enclose the enclosers, as they begin to do, they are allied with those searching for alternative ways of life or attempting to protect the water, the air, the forest, the ecology, as Illich anticipated 30 years ago (Illich 1982). All of them are creating a world in which many worlds can be embraced.
**References**
Esteva, Gustavo. 1998. "The Revolution of the New Commons." In Curtis Cook and Juan D. Lindau. _Aboriginal Rights and Self-Government._ Montreal, Canada. McGill-Queen's University Press.
—————. 2003. "The Meaning and Scope of the Struggle for Autonomy." In Jan Rus, Rosalva Hernández and Shannon Matiace, eds. _Mayan Lives, Mayan Utopias._ Lanham. Rowman and Littlefield Publishers.
—————. 2005. _Celebration of Zapatismo._ Oaxaca. Ediciones ¡Basta!
—————. 2007. _Oaxaca_ _Commune and Mexico's Autonomous Movements._ Oaxaca. Ediciones ¡Basta!
—————. 2010. "From the Bottom-up: New Institutional Arrangements in Latin America." _Development_. (53)1:64-69.
Illich, Ivan. 1982. _Gender._ New York. Pantheon.
—————. 1981. _Shadow Work_. Boston and London. Marion Boyars.
Lummis, C. Douglas. 1996. _Radical Democracy._ Ithaca, London. Cornell University Press.
**Gustavo Esteva** _(Mexico) is an activist and public intellectual, the author of numerous books and articles, a columnist for_ La Jornada _(Mexico) and occasionally,_ The Guardian _. He has been actively engaged in the fight for reclaiming the commons, together with indigenous peoples, peasants and urban marginalized. He collaborates with the Universidad de la Tierra (University of the Earth) in Oaxaca, which he helped to found._
# A New German Raw Materials Strategy: A Modern "Enclosure Of The Commons"?
_By Lili Fuhr_
Lithium and cobalt for producing automobile batteries; titanium, chrome and palladium for desalination of sea water; ruthenium and selenium for photovoltaics, rare earths1 for cellphones and laptops – European industry relies on minerals, most of which must be imported, for developing and using numerous technologies of the future. Long-term security of supply of so-called "critical" raw materials was not considered an issue just a few years ago, but the topic has now been thrust to the top of the political agenda. For this reason, the German federal government passed a raw materials strategy in October 2010. The European Commission presented a new version of its 2008 Raw Materials Initiative in February 2011 as well. Both strategies are intended to help ensure a reliable supply of important minerals for European and German industry via trade and investment policy, especially using instruments of foreign trade policy. Like all natural resources, these raw materials are first of all common resources. For this reason, the classical question of the commons arises here, too: How do we handle them so that whatever must be shared can be used in a meaningful and fair way for all without harming others? How are we to understand the new German raw materials strategy against the background of this question? (1. Editors' note: Rare Earths is an abbreviated form of the correct term rare earth metals. The rare earths include cerium, yttrium, neodymium and many others. Although they are fairly abundant in the Earth's crust, they are dispersed widely or mixed with other metals. In other words, larger deposits are indeed rare. That is why a large part of industrial production of rare earth metals occurs by means of chemical processing during extraction of other metals present in higher concentrations – with the corresponding consequences for the environment.)
Only very recently has the debate around the availability of mineral resources come to a head. In the absence of growing interest in communication technologies and renewable energies, many of these raw materials would simply remain in the ground. In addition, their increased exploitation not only raises the question of distribution of these minerals, but also systematically results in additional conflicts around the use of other common resources. Finally, the exploitation of rare minerals interferes considerably with land use and soil structures, water regimes and forestry. As a rule, however, common use of these resources is in the interest of the local population. The increasing exploitation of mineral resources often makes it impossible to use them in a commons-based way. The negative impacts of mining raw materials in developing countries2 with weak institutions, combined with intensive use of common land and forests, an undocumented source of income or food for the poor, have been demonstrated in many cases using the terms "resource curse" and "paradox of plenty." Some raw materials are even used for technologies whose meaning and purpose for the community can be questioned as such, for example, military technologies. (2. See César Padilla's essay on mining in South America in Part 2 and Gerhard Dilger's essay on Belo Monte in Part 2.)
Numerous companies are involved directly or indirectly in human rights violations, environmental destruction and conflicts via their exploration activities or their trade in raw materials. For instance, the German company H. C. Starck has been accused of indirect involvement in financing the civil war in the Democratic Republic of the Congo due to its trade in coltan. In its new raw materials strategy, the German federal government "emphasizes" human rights and "will increase its support" for ensuring that ecological and social standards are observed. Yet it does not engage in any systematic efforts to include those standards in their instruments for promoting foreign trade (guarantees for untied financial loans, investment guarantees, Hermes loan guarantees3) or to establish mandatory requirements for publicly owned German companies. In other words, it will still be possible to grant German businesses guarantees and loan guarantees for investments that have questionable environmental and human rights mpacts. Therefore, there will be no basis for legally binding provisions for prosecuting, let alone punishing, human rights violations, curtailing of indigenous communities' traditional usage rights, displacement of settlers from areas of future resource exploitation or the general destruction of livelihoods. (3. Editors' note: Hermes loan guarantees are state guarantees for high-risk export transactions. If the customer abroad does not pay, the German state steps in. For more than 60 years, the Euler-Hermes Kreditversicherungs-AG (a private credit insurance company) has been a leader in implementing this program, which is why the terms "Hermesdeckungen" or "Hermesbürgschaften" have become established for such guarantees. This kind of export insurance can be granted for export transactions deemed worthy of support, and at defensible economic and political risk. It is not unusual for large dams or atomic power plants to be considered eligible for assistance. Between October 2009 (after the change of government in Germany) and August 2010 alone, state guarantees for shipments to ten atomic plants in China, France, Japan, South Korea, Lithuania, Russia and Slovenia were assumed in principle, according to environmental activists. According to ixpos.de, the foreign trade portal of the German federal government, up to 135 billion euros were included in the federal budget to secure private export transactions. These guarantees result in expenditures only if the customer in question does not pay. The goal of this instrument is to secure jobs in Germany. Comparable export-credit agencies (ECAs) and instruments exist in other European countries as well.)
Developing countries rich in raw materials often use trade-policy measures, such as export tariffs or import preferences, to protect their economies, stabilize government revenues, implement an active policy of industrialization or limit negative environmental effects, depending on the politics of the day. The situation is different in China. The country controls 97 percent of global rare earth production and employs measures to regulate exports in order to exert political pressure on its trading partners. In the final analysis, China is thereby also calling the current international division of labor into question. The German federal government and the EU complain about this – often identically – as a violation of the rules of free trade and warn of adverse economic effects and job losses in Germany. In using this killer argument, they seek to end the discussion and minimize the prospects that the German population might protest. Exceptions are granted only to the poorest developing countries. Now and again, however, the EU threatens them with exclusion from the Generalized System of Preferences4 that grants them preferential access to the European market. (4. Editors' note: In its Common Commercial Policy, the EU limits and controls undesired imports from third countries by tariffs and other means. The EU grants poorer developing countries preferences and exceptions, however, in order to support their economic development.)
The continuation of liberal trade policy advocated in the German and European raw materials strategies therefore systematically stands in the way of the possibility of sustainable and fair raw materials management in the interest of the populations of commodity-rich countries, and ultimately in the interest of us all.
The issues of recycling, substitution and resource efficiency are granted only marginal attention in both strategies: neither our patterns of resource consumption nor the constantly growing demand for resources worldwide are called into question. On the contrary: as the German federal government considers the situation on the international commodity markets to be "very critical," it strives to support German businesses in entering the exploration business themselves. While the strategies do mention that such projects must "also take into consideration the protection of the climate, the soil, the water, the air and biological diversity," binding clauses protecting human rights and the environment as well as social criteria are nowhere to be found.
In other words, from the perspective of resource policy, the opportunities for the commons to develop are coming under pressure from various sides.
For one thing, in many resource-rich developing countries, the state is taking over control of the management of local natural resources, often without taking account of the social and ecological consequences of such action. The contracts between governments and multinational corporations are overwhelmingly designed in such a way that only little money flows to government coffers and therefore, only a small amount is available for the common good. Although many developing countries succeeded in concluding significantly more advantageous contracts in recent years and are therefore in a position to sell their commodities at higher prices on the world market, this, too, guarantees neither sustainability nor social participation. The conflicts mentioned above between the community's claims to land, soil and water on the one hand and the control, managed by nation-states, over the resources on the other, will remain in any case. The losers in these conflicts are often the local communities, as is documented impressively in the present volume.
The raw materials strategies of the German federal government and the EU aim first and foremost to access those resources that others are – literally – sitting on. This sidelines the interests of the local populations.
Despite their own commitments to attaining coherence in development, (foreign) trade and investment policies, these policies thwart the German federal government's and the EU's efforts at poverty eradication or stabilization of the climate – and options for self-determined, commons-based development paths dwindle.
**Lili Fuhr** _(Germany) heads the ecology and sustainable development department of the Heinrich Böll Foundation's head office in Berlin. Her focus is on international resource and climate politics._
# Using "Protected Natural Areas" to Appropriate the Commons
_by Ana de Ita_
Even as worldwide pressures mount to protect sites with high biological diversity, indigenous peoples and local communities are redoubling their struggles of resistance against a "solution" that claims to protect ecosystems, the establishment of protected natural areas (PNAs). The policy of establishing PNAs, which seeks to maintain the best conserved redoubts of the planet, is often at odds with the rights of native peoples, since many of those redoubts exist in the first place only because indigenous communities have conserved, recreated, and maintained them.
In Mexico, half the national territory, some 106 million hectares, is the property of _ejidos_ and _comunidades agrarias_ ,1 home to peasants and indigenous peoples. Although the discourse of protecting nature is familiar to the ways of thinking of such communities, PNAs have become a threat to their territories and to their autonomy or self-determination, which is their main demand. (1. Ejidos denotes a common or collective possession of land or forest that includes private use rights. During colonialism, rights and obligations with respect to land and forests – i.e., the relationships among the Spanish crown, its local represenatives and indigenous peoples – were handled through ejidos. The Mexican constitutions of 1917 underlined and widened the importance of ejidos (Article 27). During the government of President Lazaro Cardenas (1934–1940), about 18 million hectares of land were newly distributed and handed over to ejidatarios for their indefinite, unlimited use. A communidades agraria is another form of collective ownership over land and forests. In has the same essential features of the traditional ejido system but uses another institutional framework.)
PNAs are established by the decree of any level of government and are considered to be of public utility, which according to Article 27(VI) of the Constitution means that lands can be expropriated. In PNAs the rights of persons who possess the territory are legally inferior to the decrees regulating the area, management programs, or environmental land use regimes. In addition, the possessors whose lives depend on these territories, which they use and tend, do not have priority over any other person or social group involved; they are merely considered one more stakeholder. Nor do the possessors have any right to veto management rules, nor to have the guaranteed right to give or withhold their free, prior, and informed consent, even if they are indigenous peoples.
Moreover, PNAs do not even guarantee that conservation objectives will prevail over moneyed interests, for highly contaminating activities such as oil operations and mining are not prohibited. Nor is the appropriation of water or any other resource by any economic actor prohibited; all that is required is that the commercial uses "not cause degradation to the ecological balance."
In the PNAs government administrators, international conservation organizations such as Conservation International, World Wildlife Fund, and The Nature Conservancy, and even private companies such as Coca Cola, breweries, hotels, and many others wrest control over decisions on the territory and resource use from the assembly of _ejidatarios_ and _comuneros_ , making it ever more difficult for the government to establish them.
Up until the year 2010, the National Commission on Protected Natural Areas (Conanp: Comisión Nacional de Áreas Naturales Protegidas) administered 174 PNAs in Mexico covering 25.4 million hectares in all. According to a World Bank study, 95 percent of the PNAs are situated in areas of common use, both _ejidos_ and _comunidades agrarias_ , and at least 71 of them are on the territories of 36 indigenous peoples. Of the more than 152 priority terrestrial areas for conservation, covering some 51 million hectares, at least 60 overlap with indigenous territories.
In the late 1980s, the government, upon announcing plans to establish PNAs, were confronted by the _ejidos_ and _comunidades_ possessing the territories that were proposed as "voluntary" conservation areas. There are now 177 voluntary areas in 15 of Mexico's 31 states, encompassing approximately 208,000 hectares, and at least nine indigenous peoples participate in them. Most are located in Oaxaca, with 79 voluntary certification areas.
Yet in 2008, the General Law on Ecological Balance and Environmental Protection introduced a change, making voluntary conservation areas one more category of protected natural area. The lands were declared to be under federal jurisdiction and of public utility – and then new conditions for their management imposed. This included promoting the entry of newcomers to the lands and giving them decision-making authority over resources used in common – which the communities had specifically sought to prohibit.
The 2008 law has sparked major conflicts in the territories between the communities and the Conanp. Each has its own model of conservation and structure of government. One seeks conservation from within the communities, with the regulations decided by agreement of the assembly, based on consensus-building. The other seeks conservation from outside, with government decisions imposed on the territories. When the communities have sought to terminate their commitment to "voluntary conservation," they have found that it is in fact mandatory, and that they must either wait for the commitment period to run its course or else pay for a technical study to justify their refusal to do so.
In 2010, just before the Conference of Parties in Nagoya, on the Biodiversity Convention, and in Cancún, on climate change, several indigenous peoples – Kuna, Kichwa Kayampi, Q'eqchi de Livingston, Bene Gulash, Ñu Savi – began to circulate what was called the Declaration of Heredia. It demanded that no more protected natural areas be established in indigenous territories; that the ones decreed to date be canceled; and that those lands and territories be returned to the communities and peoples from whom they were taken. The Declaration stated: "No government, no environmental policy or legislation can be imposed above our territorial rights, which are guaranteed in Convention 169 of the International Labor Organization and the United Nations Declaration on the Rights of Indigenous Peoples."
The establishment of PNAs has become a modern instrument of colonization that regards indigenous and peasant territories as empty "no-man's land" that the state can manage as it sees fit.
**References**
World Bank. 2001. _Diagnósticos sociales y planes de desarrollo de pueblos indígenas en las ANP._ Mexico City.
Boege Eckart. 2008. "El patrimonio biocultural de los pueblos indígenas de México." INAH, CDI.
The General Law on Ecological Equilibrium and Environmental Protection, Article 59, amended in May 2008.
Declaration of Heredia, Pronouncement in defense of Mother Earth and against environmental policies, Costa Rica, September 24, 2010, available at http://www.eed.de//fix/files/doc Analysis_15_Protected_Areas_2010_eed_web.pdf.
**Ana de Ita **_(Mexico) is an activist for peasant life and Indigenous autonomy. She is researcher at and founder of the Centro de Estudios para el Cambio en el Campo Mexicano (Ceccam) [Research Center for Change in Rural Mexico]. She is a backer of the Red en Defensa del Maíz [Corn Defense Network], opposing transgenic crops, and a doctoral candidate of the Faculty of Political and Social Sciences at National Autonomous University of Mexico._
# Intellectual Property Rights and Free Trade Agreements: A Never-Ending Story
_By Beatriz Busaniche_
Imagine that a group of highly concentrated transnational corporations in the knowledge industries such as pharmaceuticals, high-tech, and entertainment pack so much lobbying clout that they can convince the governments of the industrialized world to bully developing countries to "harmonize" their copyright, patent and trademarks laws into a global intellectual property regime. That is what happened in the 1990s when the bloc made up of the United States, Europe and Japan was able to incorporate intellectual property matters in the trade agenda. The signing of the Agreement on Trade Related Aspects of Intellectual Property, more commonly known as TRIPS, created a unified global intellectual property regime with minimum standards and established a dispute settlement system to ensure its application and compliance.
At first blush it is surprising that the developing countries would agree to treat intellectual property in the framework of the World Trade Organization (WTO) and not in the customary body for such matters, the World Intellectual Property Organization (WIPO). The larger, industrialized countries had their reasons for wanting this shift – namely, that the WTO has a dispute settlement mechanism that makes it possible to apply punitive measures against those countries that might violate the rules.
In 2001, it appeared that developing countries might make some progress in trade policies that affect their economic development. In the "Doha Round" of negotiations hosted by the World Trade Organization, developing countries won the Doha Declaration on the TRIPS Agreement and Public Health, which urges governments to take advantage of the flexible terms of TRIPS to improve their citizens' access to affordable medicines.
In response to the Doha Round, developed countries began to promote two types of treaties to advance their commercial interests: _investment protection agreements_ and _free trade agreements._ Both seek to expand the scope of coverage and the duration of intellectual property monopolies, a legal approach that obviously benefits large film studios, publishers, record labels and information vendors. The two types of agreements also seek to add new legal provisions that reduce the flexibility of TRIPS provisions, to the detriment of developing countries.
The European Union and the United States are especially active when it comes to promoting the signing of free trade agreements. As of 2011, the United States had signed free trade agreements (FTAs) with 17 countries, while the European Union has FTAs with Chile, Mexico, and South Korea, among others, and is negotiating more with India, Asian bloc nations and the Mercosur (Mercado Común del Sur, or Common Market of the South). The treaties contain chapters expanding intellectual property provisions often known as "TRIPS-plus" clauses.
The free trade agreement signed in 2011 by the European Union and South Korea contains numerous examples of such clauses, among them:
• Extending the duration of medicinal patents1 for as many as five years beyond the 20 years already provided for in the TRIPS. (The rationale: to compensate patent holders for the time needed to produce test data for marketing the drug in a given area.) (1. See also the essay by Christine Godt, Christian Wagner-Ahlfs, and Tinnemann in Part 5.)
• Exclusive protection for the "test data" on drugs and agrotoxics, a new form of protection that directly impedes generic drugs from entering the market.2 This legal provision did not exist in the TRIPS and was deliberately excluded in that negotiation, but was included in a US agreement with Central America and the Dominican Republic. The provision reduces the flexible terms of the TRIPS that otherwise make it possible for the countries to recognize test data to approve a generic drug.3 (2. According to the European Generic Medicines Association, a generic is a medicine that contains the same active principle as a brand name product and acts identically on patients, respecting the regulatory controls of quality, safety, and efficacy. Generics can be produced once the patent on the brand name drug has expired, making possible competition and slashing the market costs of medicinal products. 3. Article 39(3) of TRIPS makes reference to all information that the health authorities of a country require to approve the marketing of a given pharmaceutical or chemical product in the national territory. The text only requires protection against any use in unfair commercial use of the test data the origination of which entails a considerable effort. The article adds that the members will protect those data from any disclosure, except when necessary to protect the public or unless measures are adopted that guarantee protection of the data against unfair use. One example of a good practice in the area is Law 24,766, in force in Argentina, which takes full advantage of the flexibilities of the TRIPS in terms of allowing the sale of generic medicines with an administrative procedure to determine the similarity of the active ingredient of the drug, and without requiring the submission of new test data (which would considerably delay the time it would take for a generic to make it to market).)
• Adding new trade obligations such as protecting Digital Rights Management (DRM) that use technology to regulate the number of times a work in digital format may be used, and the conditions of use. Such restrictive technical measures can, for example, track usage to determine whether a work has been copied, loaned, read one or more times, shared, and even printed, in the case of texts. In some legal systems, such as the Digital Millennium Copyright Act of the United States4, evading these technical measures is a crime, even when done to exercise a right, such as access to works in the public domain, or fair use. (4. Regulations of this sort, known as "anti-circumvention measures," were established in 1996 in the Copyright Agreement and the Performances and Phonograms Treaty. The emblematic regulation of the implementation of such measures is the Digital Millennium Copyright Act of the United States, approved in 1998, http://www.copyright.gov/legislation/dmca.pdf )
• In addition, in the last few years FTAs have included new clauses that impose "secondary liability" on Internet service providers, search engines and other types of services. These FTAs impose joint liability on these services for the actions of Internet users and requires services to look into, monitor, and swiftly act in response to a report of a copyright violation (without specifying what type of report triggers the duty and without guaranteeing the involvement of a judge). Such clauses override domestic judicial systems, constitutional due process guarantees and the presumption of innocence, and constitute a direct threat to freedom of expression on the Internet.5 (5. These issues have been officially noted by the UN Special Rapporteur on the Promotion and Protection of the Right to Freedom of Opinion and Expression, Frank LaRue; the Special Rapporteur for Freedom of Expression of the Inter-American Commission on Human Rights, Catalina Botero Marino; the Representative on Freedom of the Media of the Organization for Security and Cooperation in Europe, Dunja Mijatovi; and the Special Rapporteur on Freedom of Expression and Access to Information of the African Commission on Human and Peoples' Rights, Faith Pansy Tlakula, in their statement of June 1, 2011. See http://cidh.org/relatoria/showarticle.asp?artID=848&lID=2)
• FTAs have been used as vehicles to reduce the flexibility that countries have in their right to regulate plant and seed varieties as they see fit (under sui generis legal regimes)6 and to allow farmers to re-use seeds. The FTAs require that each country ratify a 1991 Act and its amendments that expand the coverage of the varieties to be protected, expand the rights of the breeder and limit the uses of derivative varieties. These provisions threaten native seeds that peasant communities have been exchanging and improving over thousands of years. It means that in the future they're going to have to stop conserving and redistributing their seeds and buy seed from the large corporations in each crop cycle. (6. In the context of the intellectual property negotiations, a sui generis protection is a form of legal coverage implemented autonomously by a country. For example, India has its own law on seeds that is considered a sui generis framework.)
**How FTAs are hostile to commons**
The commons starts from the idea that knowledge (and the right to share and reproduce knowledge) is a basic human right that integrates three specific factors – _common pool resources_ , a _community_ of users organized around them and that community's consensus-based _rules and standards_. It is clear that free trade agreements are hostile to this structure of governance and resource management. By imposing private intellectual property rights on collective knowledge and resources such as seeds and plant varieties, FTAs are in effect modern tools for enclosing the commons.7 (7. See also essays by Peter Linebaugh in Part 2 and Hartmut Zückert in Part 2.)
**Incursion on the public domain and the knowledge commons**
The entire architecture of intellectual property law, which has expanded and become more restrictive since the late 1970s, has been furthering the process of enclosing the commons. This process has consisted of extending the terms of monopolies over knowledge, creative works, seeds, and medicines; ignoring the value of the public domain; and extending intellectual property rights to areas of life never before contemplated in copyright and patent law. If fifty years ago someone had said that a plant, a gene, a mathematical algorithm could be the private property of some person, we would have thought such ideas insane. Nonetheless, in 1980 the first patent was given on a microorganism8 – the same year that a patent was granted to a mathematical algorithm.9 Around this same time, the race to patent genes, plants, and seeds took off. (8. The first precedent is Diamond v. Chakrabarty (1980), available at http://supreme.justia. com/us/447/303/case.html. 9. The first precedent is Diamond v. Diehr (1981), available at http://supreme.justia.com/us/450/175/case.html See also the history of software patents at http://www.bitlaw.com/software-patent/history.html)
Monopolies over such living things have been consolidated by means of the dispute settlement systems used in trade disagreements. Just as in the WTO framework one country may take another before a panel to then impose retaliatory measures if the minimum standards are not applied, so in the case of investment protection agreements, companies themselves may take a country before the World Bank's dispute tribunal, the International Centre for Settlement of Investment Disputes (ICSID), if they feel that their pursuit of profit has been impaired. Thus Phillip Morris once brought an ICSID complaint against Uruguay for its anti-smoking public health policy, claiming that Uruguay was indirectly expropriating without compensation an investment of Swiss origin protected by the agreement.10 (10. For more information see the dossier, "Demanda Philip Morris a Uruguay en el Ciadi," by Redes Amigos de la Tierra Uruguay Friends of the Earth Uruguay], available at [http://www.redes.org.uy/wp-content/uploads/2010/04/Dossier-Philip-MorriS-Uruguay_abril-2010.pdf)
**Who sets the rules?**
The rules and norms that communities adopt to manage their collective resources are essential for preserving, promoting and defending them. The present-day legal architecture and regulation of intellectual property in the FTAs and the IPAs do not reflect a consensus of the interests of communities directly involved. In essence, most negotiations of free trade and investment protection agreements occur behind closed doors, with pre-assembled negotiating documents, and with zero public access to the proceedings or policy documents.
Moreover, because negotiations also involve such issues as customs duties reductions, national procurement operations and investments, developing countries often regard intellectual property as a secondary concern to be used as a bargaining chip to obtain more favorable results on larger trade priorities. It is common for the countries that rely on the export of a specific commodity (such as copper in Chile and soybeans in Argentina) to make concessions in intellectual property policy in order to assure that their key exports have access to international markets.
FTAs have inherited from the GATT trade negotiations and the WTO the logic that nothing in the negotiation is closed until everything is closed. As a result, the negotiators close agreements step by step until they have a final document that the countries sign, with no possibility of new discussions. It is only then that the agreements go before the legislatures of the respective signatory countries, which are no longer able to introduce any change or amendment; they may only cast a "yes" or "no" vote on the texts negotiated as a complete package that cannot be reopened lest the whole negotiation break down. In other words, the regulations are left in the hands of the negotiators operating in secret to advance private commercial interests. Even the legislators of signatory countries have very little ability to influence the treaties.
**The role of communities**
It is clear that this system for establishing policies for intellectual property rights fails to allow communities to protect and preserve their commons. The entire process set up by the TRIPS and strengthened by the FTAs and investment agreements, largely prevents nation-states from defending collective non-market interests without suffering the penalties imposed by trade system's dispute settlement mechanisms. One cannot expect the governments to defend and promote the commons if these same governments are promoting the signing of the trade agreements. Meanwhile, numerous communities and various commons have been dismantled or damaged by FTAs, and the affected commoners have little if any ability to affect trade negotiations.11 This globalized legal framework is equivalent to expropriating the capacity to manage the commons. It destroys community spaces, privatizes the public domain and renders illegal many customary practices of communities, such as exchanging seeds and sharing culture. (11. For example, in 2011, the Fundación Vía Libre of Argentina, the leading advocate for free software, wrote an official letter to the Ministry of Foreign Affairs of Argentina requesting information on the negotiations Mercosur maintains with the European Union for the signing of an FTA. The Argentine government did not respond.)
**A never-ending story**
The outlook for the future of the commons in the context of trade negotiations could not be more discouraging. The dynamics described above can be seen in ongoing inter-regional negotiations between Mercosur and the European Union, and in bilateral treaties such as the one being negotiated between India and the EU, the one signed by South Korea and the EU in 2011 and in numerous bilateral treaties signed around the world. Despite the Doha Round of the WTO, which seemed to open the door to greater flexibility in protecting the commons, it is clear that the strategy of enclosure based on a TRIPS-plus standard, is moving forward step by step. If we are going to defend the commons from new enclosures and recover that which has already been expropriated from communities, we clearly must recover the concept of the commons as a strategic concern and begin the perhaps utopian yet essential task of removing the commons from the global trade agenda.
**Beatriz Busaniche** _(Argentina) is a graduate of social communication and professor at the National University of Buenos Aires. She works for Vía Libre Foundation; is public team leader for Creative Commons Argentina; and currently is Executive Director of Wikimedia Argentina. Her personal blog is http://www.bea.org.ar. _
# Global Enclosures in the Service of Empire
_By David Bollier_
In September 2010, a group of NATO brass, security analysts and other policy elites held a conference called "Protecting the Global Commons." Attendees were described as "senior representatives from the EU institutions and NATO, with national government officials, industry, the international and specialised media, think-tanks, academia and NGOs" – surely one of the oddest group of "commoners" ever assembled.
The event, hosted by a Brussels-based think tank called Security & Defence Agenda, had its own ideas about what the commons is. Let's just say it doesn't regard the commons as a self-organized system designed by commoners themselves to serve their own needs. No. To NATO decision makers, the "global commons" consists of those empty spaces and resources that lie beyond the direct and exclusive control of nation-states. In other words: NATO sees these spaces as no-man's land _without_ governance. To NATO, the key "global commons" are outer space, the oceans and the Internet. The problems posed by these "commons," conference organizers suggest, is that they must somehow be dominated by NATO countries lest hostile countries, rogue states and pirates interfere with US and European commercial and military activities. Hence the need for NATO's military supervision.
A bit of accuracy is in order: Outer space, the oceans and the Internet are _common-pool resources._ They don't belong to anybody individually nor to any state individually. But they are not _commons._ Commons __ require the active participation of the people in formulating and enforcing the rules that govern them. Or "the consent of the governed," as the US Declaration of Independence puts it. That's not really a NATO priority. Instead, as the conference program put it:
What are the political, policy, and operational challenges faced by NATO in the Global Commons? Is the Alliance adequately prepared to execute its responsibilities in a world where the space, maritime, and cyber domains are increasingly vital to the interests of member states and to the day to day peacetime and wartime operations of the Alliance? What capabilities and responsibilities will the Alliance need to develop to sustain its relevance in a world where the global commons are increasingly important?
In a sense, NATO gets it right: space, the oceans and the Internet must be available to all. They are, in its words, the "vital connective tissue in a globalized world." However, the question that didn't seem to get asked at the conference, at least according to its stated agenda and available documentation, is: How shall ordinary citizens and their representatives participate in these deliberations and make sure that governance will serve their interests? That, after all, is what a democratic society is all about.
NATO misconstrues the meaning of the term "commons" by casting it as an ungoverned free-for-all – precisely the error that biologist Garrett Hardin made in his famous 1968 essay on the "tragedy of the commons." Hardin's error poisoned the meaning of the commons for at least a generation, something that NATO may in fact be eager to perpetuate; defining oceans, space and the Internet as "commons" in Hardin's sense of the term, would give it license for dominating these resources. Geopolitical supremacy is the goal. As the program notes put it, "Oceans today are as much a chess board for strategists as a global common. What are the key dynamics of today's maritime domain? What are those of tomorrow? What are the implications for the Alliance?"
NATO's misuse of "commons" is starting to get some traction. In 2011, MIT political scientists Sameer Lalwani and Joshua Shifrinson held a Washington policy briefing at the New America Foundation that proposed that the US "pare back its forward-based naval presence in many regions while retaining 'command of the commons.' It can accomplish this by relying more on regional powers to help in securing the freedom of the seas while maintaining sufficient over-the-horizon naval power to serve as the security guarantor of last resort."
Has no one at the Pentagon, NATO or defense think-tanks read Elinor Ostrom's work? Please, NATO: Simply refrain from using the word "commons." Alternatively, why not begin to imagine new types of global commons institutions that could transcend the parochial, self-serving interests of national governments and their concern for commercial interests over ecological or civic interests? Why not build some creative new transnational governance structures that could truly represent the commoners?
This will not be the last time that commercial or governmental interests attempt to co-opt the term "commons." Which is all the more reason why we need to point out Hardin's error yet again, insist upon the real meaning of the commons, and get institutions like NATO to talk to some real, live commoners every once in a while.
**David Bollier** (USA) is an author, activist and independent scholar of the commons. He is Co-Founder of the Commons Strategies Group and the author of ten books, including Viral Spiral, Brand Name Bullies and Silent Theft. He lives in Amherst, Massachusetts and blogs at www.Bollier.org.
_
_
__
_"Learn three truths: Learn what dwells in man, what is not given to man, and what men live by."_
Leo Tolstoy, _What Men Live By_ (1881)
# PART THREE
****
COMMONING – A SOCIAL INNOVATION
FOR OUR TIMES
# School of Commoning
_By George Pór_
"How would we know when we are commoning?" a young woman asked me at Contact Summit 2011, a major unconference running concurrently with the Occupy Wall Street protests in New York, October 2011. (An "unconference" is a gathering based on participant-generated content.)
When I announced the invitation to my session on commoning, I introduced it by quoting the motto of our School, "Education for Commons Culture & Social Renewal." I explained: "Creating a commons culture is re-inventing all our social institutions for serving the whole, not the few as they do today. Let's find out how commoning can help us achieve that."
Members' driving questions are the key initial resource of any ad hoc learning commons. In such a commons, "we know we are commoning" when we create and maintain an issues list, a collection of burning questions and engage in action-oriented, collaborative inquiries to address them. Therefore, we started by exploring the questions that participants had about three stages that characterize commoning:
1. The ensemble of practices used by people in the course of managing shared resources and reclaiming the commons. In its simplest form, commoning is creating and maintaining something collectively.
2. Moving from the Me to the We, where people become capable of thinking, feeling and acting as co-creative collective entities, without surrendering their individual autonomy.
3. Recognizing the inherent connectedness of humanity as a whole, and keeping our individual and collective "center of gravity" one with it.
The School of Commoning is a commons-based social enterprise established in London under UK law, as a Community Interest Company, in May 2011. Our mission is to enhance individual and collective competences in the creation, protection and governance of commons of all types – natural, cultural and intellectual.
We are running workshops, seminars, retreats, online courses, and creating educational materials in print, video, and a Commoning Game. The School plans to provide training programs for commons facilitators and customized curricula for institutions of higher education.
The School of Commoning maintains a wiki-based Knowledge Garden, one of the largest repositories of commons-related non-academic documents of global relevance. Special sections are dedicated to the commons movement and the issues of a transition to a commons-based society, as well as a questions-driven introductory module for those who are new to the commons. This is a Creative Commons-licensed space1 where users can browse, add to, quote, reuse and remix resources. We also host a regular Commoning Café in London, a networking event that, for many, serves as a first point of entry to the world of commons. (1. See essay by Mike Linksvayer in Part 4.)
Our educational activities have included an online/onsite workshop on "Reclaiming the Commons as a Social Theory of Collective Action" that we facilitated at the Occupy Wall Street Forum on the Commons in New York. Along with the Christian Council for Monetary Justice, we organized an intense "12 days, 12 seminars" program led by James Quilligan, who is also an advisor to our School, on various issues involving the shift towards a commons-based economy. The kick-off seminar was hosted, where else...in the House of Commons.
Our series, the "Commons in Our Life," is aimed at fostering the emergence of new commons, in various areas of social practice. Each event will be dedicated to understanding and supporting the commons in one particular domain of social regeneration that we care about, e.g., health, land use and urbanism, finance, etc. Our Commons Advisory Services work with an international network of leading thinkers and practitioners to provide commons design and consulting services to organizations in civil society, and the public and private sectors.
Commoning is also partnering. Our partners include CommunityIntelligence, Global Commons Trust, Kosmos Journal, Notre Dame University, the P2P Foundation, and the United Nations Institute for Training and Research. If our work inspires your group and you want to explore a collaborative relationship with the School of Commoning, let us know.
**References**
Video presentation, "Voices from the Commons": http://www.youtube.com/watch?v=Pwo5KacwmVE.
Website: http://www.schoolofcommoning.com
**George Pór** _(UK) is an evolutionary thinker, researcher in collective intelligence and strategic learning partner to changemakers and visionary leaders in civil society, business and government. He is Director of School of Commoning ( http://www.schoolofcommoning.com), Fellow of Future Considerations and founder of CommunityIntelligence._
# Practicing Commons in Community Gardens: Urban Gardening as a Corrective for Homo Economicus
_by Christa Müller_
"In these times of ever more blatant marketing of public space, the aspiration to plant potatoes precisely there – and without restricting entry – is nothing less than revolutionary," writes Sabine Rohlf in her book review of _Urban Gardening_.1 Indeed, we can observe the return of gardens to the city everywhere and see it as an expression of a changing relationship between the public and the private. And it is not only this dominant differentiation in modern society that is increasingly becoming blurred; the differences between nature and society as well as that between city and countryside are fading as well, at least from the perspective of urban community gardeners. (1. Berliner Zeitung, April 5, 2011.)
In the 1960s, as the economy boomed, people in West Germany had given up their urban vegetable gardens, not least for reasons of social status; many wished to demonstrate, for example, that they could purchase food and no longer had to grow and preserve it themselves. Today, in contrast, the "Generation Garden" has planted its feet firmly in vegetable patches in the midst of hip urban neighborhoods, the "young farmers of Berlin-Kreuzberg" are creating a furor, the German Federal Cultural Foundation stages the festival "Über Lebenskunst" (a pun meaning both "On the art of living" and – spelled Überlebenskunst – "The art of survival") and people need not be ashamed of showing their fingernails, black from gardening, in public.
What we observe here is a shift in the symbolism and status of post-materialistic values and lifestyles. Do-it-yourself and grow-it-yourself also means finding one's own expression in the products of one's labor. It means setting oneself apart from a life of consuming objects of industrial production. Seeking individual expression is also a quest for new forms and places of community. If the heated general stores and craftsmen's workshops were the places where Germany's social life unfolded in the postwar years, today's urban community gardens and open workshops seem to be developing into hothouses of social solidarity for a post-fossil-fuel urban society.
In recent years, people of the most varied milieus have been joining forces and planting organic gardens in major European cities. They keep bees, reproduce seeds, make natural cosmetics, use plants to dye fabrics, organize open-air meals, and take over and manage public parks. With hands-on neighborhood support, urban gardening activists are planting flowers as they like at the bases of trees and transforming derelict land and garbage-strewn parking decks into places where people can meet and engage in common activities.
The new gardening movement is young, colorful and socially heterogeneous. In Berlin, "indigenous" city dwellers work side-by-side with long-time Turkish residents to grow vegetables in neighborhood gardens and community gardens; pick-your-own gardens and farmers' gardens are forming networks with one another. The intercultural gardening movement is continuing to expand in striking ways, as seen on the online platform Mundraub.org, which uses Web 2.0 technology to tag the locations of fruit trees whose apples and other fruits can be picked for free (Müller 2011). Such novel blending of digital and analog worlds is creating new intermediate worlds that combine open source practices with subsistence-oriented practices of everyday life.2 (2. Mundraub is described in Katharina Frosch's essay in Part 3.)
**Urban gardens as knowledge commons**
Open source is the central guiding principle in all community gardens; the participation and involvement of the neighborhood are essential principles. The gardens are used and managed as commons even if the gardeners do not personally own the land. By encouraging people to participate, urban gardens gather and combine a large amount of knowledge in productive ways. Since there are usually no agricultural professionals among the gardeners, everyone depends on whatever knowledge is available – and everyone is open to learning. They follow the maxim that everybody benefits from sharing knowledge; after all, they can learn from each other, relearn skills they had lost and contribute to bringing about something new. Communal gardening confronts the limited means of urban farmers – whether in soil, materials, tools or access to knowledge – and transforms them into an economic system of plenty through collective ingenuity, giving and reciprocity.3 (3. For more, read the conversation between Brian Davey, Wolfgang Hoeschele, Roberto Verzola and Silke Helfrich in Part 1.)
In urban gardens, both opportunities and the necessity for exchange arise time and again. A vibrant atmosphere emerges where the most varied talents meet. In workshops, for example, people can learn to build their own freight bicycles, window farming4 or greening roofs; they can learn to grow plants on balconies and the walls of buildings, and use plastic water bottles for constant watering of topsoil. There is always a need for ingenuity and productivity, which often come about only when knowledge is passed along, which in turn releases additional knowledge. (4. Window farming is vertical gardening on a windowsill. Plants are grown in hanging plastic bottles, which also provide greenery for the windows.)
Thus, the creative process in a garden never reaches an end. The garden itself is a workshop where things are reinterpreted creatively and placed in new relationships. One thing leads to another. It is not only the inspiring presence of the various plants that provides for a wealth of ideas, but also the ongoing opportunity to engage oneself and be motivated by the objects lying around (Müller 2011).
This is how a real community that uses a garden emerges over time. One of the most important ingredients for success is that the place is not predefined or overly restricted by rules. Instead, the atmosphere of untidiness and openness makes it apparent that cooperation and creative ideas are desired and necessary.
**A new policy for (public) space**
When the neighborhood people of Berlin-Neukölln tend their gardens on the site of the former Berlin-Tempelhof airport in plant containers they crafted themselves, bringing together people of many different backgrounds and generations and supported by the Allmende-Kontor, a common gardening organization, this is first of all an unusual use of public space.5 The garden consists of raised beds in the most varied styles on 5,000 square meters. Plants grow in discarded bed frames, baby buggies, old zinc tubs and wooden containers assembled by the gardeners themselves. (5. http://www.allmende-kontor.de)
But more than an unusual public space, the Allmende-Kontor gardens underscore an important political dimension of urban gardening. The commons-oriented practices enable a different perspective on the city. They both _require_ communities and at the same time _create_ communities. People come together here, but not under the banner of major events, advertising or the obligation to consume. Instead, their self-organized, decentralized practices in the public realm implicitly express a shared aspiration of a green city for all. Yet no grand new societal utopia – "the society of the future" – is being promoted. Instead, simple social interactions slowly transform a concrete space in the here and now, building an alternative to the dominant order based on market fundamentalism (Werner 2011).
In other words, the policy preference for the small-scale as a rediscovery of one's immediate environment is by no means based on a narrowed perspective. On the contrary: the focus is precisely on the overuse, colonization and destruction of the global commons, and for this reason, the local commons is managed as a place where one can raise awareness about a new concept of publicness6 while simultaneously demonstrating that there are indeed alternatives – common usage in place of private property; local quality of life instead of remote-controlled consumption, as it were; and cooperation rather than individual isolation. (6. See also Brigitte Kratzwald's essay on social welfare in light of the commons in Part 1.)
**Managing the "internal commons"**
The new focus on the commons in urban community gardens is not only a political defense of public space for its use toward the common good. At the same time, it is also a reclaiming of people's internal consciousness and a rejection of the ascriptions of _homo economicus_ , an image of humanity that reduces us to competition-oriented individuals whose attention is focused solely on their own advantage.7 This overly simplistic model has been under constructive attack for some time, even in the field of economics. In particular, the social neurosciences have confirmed that people's willingness to cooperate and need for connectedness are central elements of human nature. For scholars of the humanities, this is surely no new insight, yet it is still good to know that there is substantial scientific evidence showing that the existence of a boundary between mind and body, which is often used to justify hegemonic domination, is artificial, and that the interrelationships between body and mind are highly complex. For example, we know today that social or psychological experiences leave physical traces – even in our genes, as shown by epigenetics. Joachim Bauer considers this insight to be the decisive breakthrough regarding our concepts of humankind (Bauer 2008). (7. For more detail on this topic, see Friederike Habermann's essay in Part 1.)
This has two consequences for the subject at hand: for one thing, a practice of the commons such as community gardening enables the gardeners to discover their bodies, the experience of having two hands and being able to create things with them. Such sensory experiences are directly connected to one's grasp of the world. For another, the garden is the ideal place to learn how to cooperate. When designing a system to capture rainwater for the beds, for example, the experience reveals an aspect of being human – namely connectedness – that is just as important as the experience of autonomy (Hüther 2011).
In this sense, commons are a practice of life that enable even the highly individualized subjects of the 21st century to turn their attention to one another, and not least to slow down their lives. After all, time, too, is a resource to be conceptualized in the community. Experiencing time means being able to pursue an activity as one sees fit, enjoying a moment or spending it with others. By accelerating time to an extreme degree, digital capitalism has subjected virtually everyone to a regime of efficiency, with the result that people's sense of time is determined by scarcity and by the stress people subjectively feel to "fill" time with as much utility as possible. Time is "saved," leisure hours are regarded with suspicion, and the boundaries between work and free time are increasingly blurred.
The garden is an antidote that can be used as a refuge by the "exhausted self," as described by French Sociologist Alain Ehrenberg. The garden slows things down and enables experiences with temporal cycles from a different epoch of human history, agrarian society. Small-scale agriculture, which is being rediscovered in many urban gardens, is cyclical in nature. Every year, the cycle begins anew with the preparation of the soil and with sowing. People who farm are exposed to nature, the climatic conditions, the seasons and the cycles of day and night. For city dwellers whose virtual lives have taught them that everything is always possible at the same time, and above all, that everything can be managed at any time, these dimensions of time are highly fascinating. Gardening enables the insight that we are integrated in life cycles ourselves and that it can have a calming effect to simply "give oneself up" to the situation at hand.
In other words, managing the commons creates not only valuable experiences, but also social relationships with far-reaching effects. And, one might add, they are valuable for achieving the transformation of an industrial society based on oil and resource exploitation into a society guided by premises of democratic participation that no longer "lives" on externalizing costs but, to the extent possible, avoids creating them in the first place. Processes of reciprocity and an "economy of symbolic goods," asBourdieu puts it, are just as important for highly differentiated modern societies as for premodern ones (Adloff and Mau 2005). Old and new practices of the commons offer inspiring options for action.
**Urban agriculture: the new trends**
Agropolis is the title of the planning concept of a group of Munich architects who won the Open Scale competition with a "metropolitan food strategy" in 2009.8 The concept for an "urban neighborhood of harvesting" places growing one's own food, the valuation of regional resources and sustainable management of land at the center of urban planning. Harvests are to become a visible part of everyday urban life. If the city implements the model, fruit from the commons and community institutions that exchange, store and process the harvest could create the basis for a productive collaboration on the part of the 20,000 inhabitants of the new neighborhood. (8. http://www.agropolis-muenchen.de)
The Citizens' Garden Laskerwiese is a public park managed by the citizens themselves.9 A group of 35 local residents transformed the previously garbage-strewn, derelict land in Friedrichshain-Kreuzberg, in Berlin, into a park. They concluded a contract with the district authorities, agreeing that the citizens' association is responsible for services such as tending the trees and the lawns on the site. In return, it can use parcels of land and beds for growing vegetables free of charge. Such new models that help cash-strapped municipalities shoulder their financial burden and expand the opportunities for people to shape public spaces require a lot of time and effort for communication on both sides. (9. http://laskerwiese.blogspot.com)
The Allmende-Kontor (roughly: Commons Office) is an initiative of the Berlin urban gardening movement that has been tending community gardens on the site of the former airport Berlin-Tempelhof together with local residents since 2011.10 Raised beds of the most varied styles are being created on 5,000 square meters. The Allmende-Kontor considers itself as a garden for all – and at the same time as a place for storing knowledge, for learning and for consulting and networking Berlin community gardens. The establishment of a pool of gardening tools and a seed bank available for unrestricted use are being planned as well. (10. http://www.allmende-kontor.de)
**References**
Adloff, Frank and Steffen Mau, Eds. 2005. _Vom Geben und Nehmen. Zur Soziologie der Reziprozität._ Frankfurt/New York. Campus.
Bauer, Joachim. 2008. _Das Gedächtnis des Körpers._ Wie Beziehungen und Lebensstile unsere Gene steuern. München. Piper.
Hüther, Gerald. 2011. _Was wir sind und was wir sein könnten. Ein neurobiologischer Mutmacher._ Frankfurt. Fischer.
Müller, Christa, editor. 2011. _Urban Gardening_. Über die Rückkehr der Gärten in die Stadt. München. oekom.
Werner, Karin. 2011. "Eigensinnige Beheimatungen. Gemeinschaftsgärten als Orte des Widerstandes gegen die neoliberale Ordnung." In: Müller, Christa, ed. a.a.O.: 54-75.
**Christa Müller** _(Germany) is a sociologist and author. For many years she has been committed to research on rural and urban subsistence. She is executive partner of the joint foundation "anstiftung & ertomis" in Munich. Her most recent book (in German) is _Urban Gardening: About the Return of Gardens into the City _. She blogs at www.urban-gardening.eu._
# Mundraub.org: Sharing Our Common Fruit
_By Katharina Frosch_
In a rural area in the former East Germany, late summer 2009: Shimmering heat, the intense odor of fermenting fruits is in the air. A tree covered with hundreds of juicy pears, and a foot-high layer of rotting fruit on the ground. A stone's throw away – plums, mirabelles, elder bushes and every now and then an apple tree along the path, maybe of an old, rare variety. An abundance of fresh fruit – in normal seasons, much more than needed to feed birds, insects and other animals – forgotten, abandoned, unused.
Is this our common fruit? Are we invited to harvest it? Today, at least in Germany, unowned fruit trees formally do not exist. Orchards situated outside human settlements are mostly in private hands, even if there is no fence around them. The mile-long fruit tree alleys characteristic of many regions, particularly in the former East Germany, are state- or region-owned. Fruit trees in parks belong to the cities. Harvesting apples without asking the owner amounts to stealing.
The clash between abundant but forgotten fruit in the public space – and the lack of information about property rights – calls for action. Whom to ask if we see an apparently forgotten fruit tree, full to bursting? The website www.mundraub.org1 invites people to tag forgotten fruit trees on an interactive map and to locate existing trees that can be harvested. The website sets forth basic rules to respect private property and prevent damage to the trees and the natural environment, and calls for fair play in general. (1. In German, "Mundraub" – literally, "mouth robbers" – refers to the theft of something edible in a strict legal sense, but the term has friendly, joking connotations, as implied by "filching" or "pilfering" in English.)
In the first two years since the website launch in 2009, more than half a million people have accessed the site, and several hundred are actively contributing to the fruit tree map. The map currently lists about 3,000 "find spots," which roughly correspond to 20,000 – 30,000 trees. So is the rediscovery of common fruit based on the mundraub map another confirmation of Elinor Ostrom's Nobel Prize-winning theories about community self-management of common goods?
Some prophets of doom warned that the mundraub website would incite swarms of reckless, hungry urban dwellers to savage private fruit plantations in the countryside and drive local farmers to ruin. However, there is no evidence that tree damage or stolen fruit have increased since the launch of the website. Users seem to intuitively adopt a responsible attitude. More than once, a "find spot" was taken off the platform at the request of users, lest it get over-used.
While most of the 150 press articles about the mundraub initiative focused on "fruit for free," most users are strongly committed to the idea of sharing and crowdsourcing.2 They are far more concerned about contributing than in getting something for free. They tag trees, discuss botanical issues and recipes connected to local fruit. Perhaps most importantly, fruit-pickers tell splendid anecdotes about the find spot. (2. In this context, crowdsourcing means the collaborative and self-organized collection and management of information about common fruit trees by a large number of self-motivated actors interacting on mundraub.org, most of whom are unknown to the website operators.)
Indeed, the information about the location of free fruit trees, property rights and some how-to rules provided on mundraub.org helps Mundräuber to jointly overtake responsibility for the fruity abundance. It's wholly self-organized, and beyond the market and state in the very ways described by the Ostrom school. Nevertheless, we still have a long way to go: To conserve common fruit trees in the long run, regularly cutting the fruit trees and replanting young ones will be necessary. But the first move towards our common fruit has been made.
**Katharina Frosch** _(Germany) is an innovation economist working on social innovation in urban agriculture, Co-Founder of stadtgarten.org and mundraub.org which won sustainability awards in 2010 and 2011 from the German Council for Sustainable Development._
# Living In "The Garden Of Life"
_By Margrit Kennedy and Declan Kennedy_
Since 1985, an intentional community of about 100 adults and 40 children in the middle of Lower Saxony, Germany, has created the "Lebensgarten Steyerberg" out of a munitions factory housing project built in the late 1930s for World War II.1 The anchor of the community, which is spread out over 65 buildings, is a large community building that serves as a cultural and social center. It has offices, a kitchen and converted hospital space now used for various seminars on health-related topics, including dance, massage and nutrition, together with the so-called _Heilhaus_ (a former hospital now called the Healing Center). (1. http://www.lebensgarten.de)
One of the greatest miracles that we experienced here at Lebensgarten (in English, the Garden of Life), is the greater diversity of skills that people somehow find and develop when the kind of specialists available in major cities are not around. Self-reliance opens up both the opportunity and the necessity to develop new competencies. This has enabled us to discover an entirely new quality of life and new dimensions of personal growth – which is precisely what is needed in the post-growth economy that is nearly upon us. The potential for growth in quality of life is limitless. We would like to present a few examples to illustrate what that means in Lebensgarten, what it requires of us and how it enables us to save resources.
It all began in 1985 with the conversion of the houses and the 2,000-square-meter community center. By focusing on conversion instead of new construction, we needed less building material, less energy for transportation and less labor. Each of us contributed what we could and was allowed to make progress in our own time. Each room in the community center was renovated on the basis of a different financing model, which included partly private, partly communal, and partly a combination of the two. Our respective projects have been financed in many different ways – through membership fees, donations, reduced-interest or interest-free loans from residents and friends, income from the seminar program bank loans as well as sweat equity. We have avoided loans as much as possible because our income varies from year to year.
We would never have believed that something like this would work so well before experiencing it in practice. Part of the reason is that we organize our voluntary work for projects so that participating is fun.
One of the most important systems that we created is the Food Distribution Center, called LeDi, which lets us avoid the need for shopping trips. At the LeDi, we can get practically all the organic food and environmentally friendly products that we need, and at wholesale prices. All the adults and the older teenagers have keys for the LeDi, so they can help themselves to what they need at any time of day or night, deducting the price from the advance deposits they have made. This system makes it easier for them to stock the amounts of foods they need, and has been working for several years.
In addition to comprehensive, practical neighborly assistance in every situation, several people who live in Lebensgarten share a pool of vehicles. People can hang clothes they no longer need in the boutique, where others can take them free of charge. About half the residents of Lebensgarten have created their own jobs on site, mostly providing social or health services and skilled crafts and trades. The Lebensgarten has advanced to become the second-largest provider of accommodation in the region due to the rooms available in private homes and the lodgings at the _Heilhaus_. Lebensgarten is also a nucleus for new business start-ups and offers an innovative milieu for cooperative alliances of freelancers that is usually found only in major cities. Besides dance, yoga and other kinds of exercise programs, Lebensgarten also has a pub – which occasionally runs a disco – and a café that is open Sundays and features our baker's outstanding organic cakes.
Lebensgarten's kitchen offers everybody the splendid opportunity to enjoy tasty and wholesome meals and conversations with a diverse mix of diners instead of having to cook alone. We decided on vegetarian food grown organically because meat and milk consumption could be responsible for half of all greenhouse gas emissions, according to the newest calculations. Of course, everyone is free to prepare their own meals as they please at home.
It seems to me that our experience in handling conflicts is even more important than our use of multiple skills, spaces, cars and equipment. The most astonishing thing is that Lebensgarten is still in existence at all. According to most academic literature about communities, we should have broken up long ago because of internal conflicts. We are, after all, a whole cosmos of many different religious, spiritual and philosophical schools of thought. We are anything but uniform in terms of our ages, educations, incomes, backgrounds and professional experiences. Most of us had our own ideas about what the community was to look like or how it was supposed to work. That caused tensions time and again because nobody had grown up in such a community or knew the rules of the game for this kind of social cooperation. So we have had to devise the rules ourselves, and develop them further day by day with everyone who joined the community. One rule for conflicts is that we ask a neutral person to mediate between those involved in the conflict. If that does not prove successful, we use a more formal process of mediation.
So far, we have used a modified consensus procedure to make all the important decisions. If someone does not agree with a decision that affects her or him, then that person must be asked whether she or he could live with the decision nonetheless if it were made. If not, then the decision is not made in the overwhelming majority of cases. All in all, this procedure is faster and more sustainable than the democratic voting procedures we are familiar with from many other group settings, because there, those who are voted down may later try to undermine the decision in some way – possibly even subconsciously.
In Lebensgarten, nobody is forced to do anything except obey the rules of the community and pay a fee of about 30 euros per month to the community coffers. Every single person is responsible for himself or herself, and everyone knows that this means that they bear responsibility for the community as a whole. This knowledge is passed along to people from outside in numerous enterprises and groups, including vegetarian cooking courses, the School for Understanding and Mediation, the Center for Non-Violent Communication Steyerberg, the Association for Mindfulness and Understanding, the forest kindergarten and the local Artabana group, a supportive community of patients that offers a self-organized alternative to the state health insurance system. Many people involved and engaged in these groups do not live in Lebensgarten, and the various forms of mediation serve as bridges between people who live here or outside the community. The Gaia Action-Learning Academy for Sustainability (GALA) is an educational institution that combines action learning with permaculture2 and other approaches to implement business goals for a healthy and sustainable world in practical ways. (2. The concept of Permaculture has also inspired the Transition Town movement. See the essays by Gerd Wessling in Part 3 and by Rob Hopkins in Part 1.)
The Lebensgarten kitchen has been increasing its use of fruit, vegetables and flowers produced here since the development of a permaculture park (PaLS) directly next to our grounds. In the final analysis, the growing number of decentralized structures means greater autonomy for all of us.
We have come to realize that wealth does not mean accumulating money. Instead, it comes alive in the quality of relationships among people. Wealth is multiplied in the opportunities to communicate with one another at a deep level, to celebrate special occasions, to develop rituals or to explore new patterns of relationships. We do not experience this as "doing without," but rather as a model that makes all of us richer together. Nature has been doing this for millions of years. The economic system is all about diversity, not sameness. It consists of cycles, not competition. Only with mutual understanding and creative connections among ourselves can a human society flourish.
**Margrit Kennedy** _(Germany) is the author of_ Interest and Inflation Free Money _(1987, translated into 23 languages) and numerous books and articles dealing with regional and sectoral complementary currencies, permaculture and urban ecology. http://www.margritkennedy.de, www.monneta.org, www.kennedy-library.info._
**Declan Kennedy** _(Germany) is an Irish architect, urban planner, mediator and permaculture designer who has taught and practiced urban design and landscape, renewable energy and agricultural planning, coupled with holistic strategies, in Germany since 1972. He is a professor at the Architectural Department of the Technical University of Berlin. http://www.declan.de. _
# Reclaiming the Credit Commons: Towards a Butterfly Society
_By Thomas H. Greco, Jr._
By now, local currencies and alternative exchange systems have become familiar themes in the media, even in mainstream newspapers like the _Wall Street Journal_ , _The Guardian_ , and _Der Spiegel_ , as well as on both local and network TV. These reports focus mainly on attempts to keep money circulating locally instead of "leaking out," as a way of enhancing the vitality of local economies and improving the prospects of local businesses in their struggle to compete with large corporate chains.
All of that is well and good, but it misses the main point of what ails our communities – and our world. The problems facing our communities, and civilization as a whole, stem from the very nature of money and the mechanisms by which it is created and allocated by the members of the most powerful cartel the world has ever known. The entire global regime of money and banking has been designed to centralize power and concentrate wealth in the hands of a ruling elite, and it has been doing that ever more effectively for quite a long time.
In every developed economy, labor is highly specialized. Very little of what we need do we make ourselves. This fact makes the exchange of goods and services necessary for subsistence. But primitive barter is inefficient and dependent upon a coincidence of wants or needs – "I have something you want and you have something I want." If one of us has nothing the other wants, no barter is possible. Money was invented to enable exchanges that fall outside the local tight-knit communities in which less formalized modes of give and take are possible. It makes possible trade that is occasional and impersonal.
Money is first and foremost a medium of exchange, a kind of place-holder that enables a seller to deliver real value to a buyer, then use the money received to claim from the market something that s/he needs from someone else.
In earlier times, various commodities that were generally useful served the purpose of exchange media. I might, for example, have no personal use for tobacco, but knowing that many others desire it, I might accept it in payment for my apples. The same goes for gold and silver, which eventually became the preferred commodities for use as exchange media.
But money has evolved over time; money is no longer a "thing." It is credit in a system of accounts, which manifests mainly as "deposits" in banks, and only secondarily, in small amounts, as paper currency notes. Every national currency is supported by the collective credit of everyone who is obliged by law to accept it.
Quite simply, we have allowed the credit commons to be privatized so that it can be accessed only by appealing to some bank to grant a "loan." Someone must go into debt in order for money to come into existence. But nothing is being loaned; banks simply create the money on the basis of the "borrower's" promise to pay. As I put it, we give our collective credit to the banks then beg them to lend some of it back to us – and we pay them interest for the privilege. The result is a chronic scarcity of money within the productive sector of the economy, even while money is lavished upon central governments to enable deficit spending to finance wars, bailouts, and all manner of wasteful spending.
But the worst aspect of the present global money system is its built-in requirement for continual growth – what I call the growth imperative. This stems from the fact that money is created on the basis of interest-bearing debt, so that the amount owed increases simply with the passage of time. But compound interest is an exponential growth function, which means that debt grows, not at a constant steady pace, but at an accelerating rate. The global money system requires the further continual expansion of debt in order to avoid financial collapse. Thus the bubble-and-bust cycles we have seen become ever more extreme, and the competition amongst borrowers for an insufficient supply of money results is ever-increasing environmental despoliation and social degradation.
The credit commons has been the most overlooked aspect of the commons, yet it is the most crucial, because credit is the very foundation and substance of modern money, and money is the essential medium for exchanging goods and services. Whoever controls money controls virtually everything in the material world. The privatization of the credit commons has not only enabled the few to exploit the many, it has also driven economic expansion beyond any reasonable limits and fueled conflict over the control of resources around the world.
In a previous era, the world power structure was based on a collusive arrangement between political authority and religious authority. Kings, emperors and princes relied upon the ecclesiastical hierarchy to legitimize their rule. So long as the people were dependent upon the church and its priests for salvation and admission to "heaven," they docilely accepted that state of affairs, but as beliefs began to change, ecclesiastical authorities lost most of their influence. Today, the global power structure is based upon a collusive arrangement between political authority and financial authority. Even in nominally democratic countries, it is the top level bankers and financiers and their minions in the media, education, medicine and other areas who select political leaders and determine public policy. So long as people depend upon the money that bankers create for their material "salvation" and admission to the "good life," that state of affairs will continue causing the masses – the guarantors of government debt – to sink ever deeper into the quicksand of debt-bondage.
The interest that must be paid to "borrow" our own credit from a bank is not the only parasitic element in this system. Another is the inflation of the money supply that accompanies government's deficit spending. Most national governments consistently spend beyond their incomes, sucking real value out of the economy in return for counterfeit money that the banks create for them under color of law. This debasement of the currency inevitably results in higher prices of basic necessities in the marketplace. To these drains you can add the obscene salaries and bonuses that insiders pay themselves to run the system, and the periodic bailouts that they extract from governments.
The picture becomes crystal clear to anyone willing to take a close look at it: The dominant system of money and banking, based as it is upon usury and the centralization of power and wealth, has visited untold misery and injustice upon the human race and the entire web of life on planet Earth. It is a system that cannot be reformed; it can only be transcended.
**Transcending the money system?**
The good news is that we need not be victims of a system that is so obviously failing us. We have in our hands the power to reclaim the credit commons. We can do it peacefully and without attacking the entrenched regime. It only requires that we each take control of our own credit and give it to those individuals and businesses that merit it and withhold it from those that do not, and for us to apply our talents and energies to those enterprises that enhance community resilience,1 sustainability, self-reliance and the common good. (1. On the concept of resilience see Rob Hopkins' essay in Part 1.)
We have all been conditioned to chase after money as a way of providing ourselves and our families with the material necessities of life, but money has become an instrument of power, a contrivance that enables the few to control the course of human events. So long as we remain enthralled with the pursuit of money, we are all puppets on a string and must do the bidding of the puppet-masters – that small elite who, granting them the best of intentions, act from a place of narrow self-interest, error and gross delusion.
Perhaps they will some day see the light, but we cannot afford to wait. The answer lies in learning to share, cooperate and reorganize to create what I like to call the "Butterfly Society." Community currencies and exchange systems provide an essential tool kit for community- and self-empowerment, but they need to be designed in such a way as to make us less dependent upon political money and banks. Private exchange media should be issued on the basis of the value created and exchanged by local producers, especially the small and medium sized businesses that form the backbone of any economy. This means that a currency must be spent into circulation, not sold for money. It is possible to organize an entirely new structure of money, banking, and finance, one that is interest-free, decentralized, and controlled, not by banks or central governments, but by individuals and businesses that associate and organize themselves into cashless trading networks.
In brief, any group of people can organize to allocate their own collective credit amongst themselves, interest-free. This is merely an extension of the common business practice of selling on open account – "I'll ship you the goods now and you can pay me later," except it is organized, not on a bilateral basis, but within a community of many buyers and sellers. Done on a large enough scale that includes a sufficiently broad range of goods and services, such systems can avoid the dysfunctions inherent in conventional money and banking. They can open the way to more harmonious and mutually beneficial relationships that enable the emergence of true economic democracy.
**Mutual credit clearing – cashless trading**
This approach is no pie-in-the-sky pipe dream. It is proven and well established. Known as mutual credit clearing, it is a process that is used by hundreds of thousands of businesses around the world that are members of scores of commercial "barter" exchanges that provide the necessary accounting and other services for cashless trading. In this process, the things you sell pay for the things you buy without using money as an intermediate exchange medium. Instead of chasing dollars, you use what you have to pay for what you need.
Unlike traditional barter, which depends upon a coincidence of wants and needs between two traders who each have something the other wants, mutual credit clearing provides an accounting for trade credits, a sort of internal currency, that allows traders to sell to some members and buy from others. There are reportedly more than 400,000 companies worldwide who, in this way, trade more than $12 billion dollars worth of goods and services annually without the use of any national currency.
Perhaps the best example of a credit clearing exchange that has operated successfully over a long period of time is the WIR2 Economic Circle Cooperative. Founded in Switzerland in the midst of the Great Depression as a self-help organization, WIR provides a means for its member businesses to continue to buy and sell with one another despite a shortage of Swiss francs in circulation. Over the past three quarters of a century, in good times and bad, WIR (now known as the WIR Bank) has continued to thrive. Its more than 60,000 members throughout Switzerland trade about $2 billion worth of goods and services each year, paying each other, not in official money, but in their own accounting units called WIR credits. (2. Editors' note: WIR, an abbreviation for "Wirtschaftsring-Genossenschaft," is the German word for "we.")
**Credit commons: a peaceful revolution for a happier society **
The challenge for any network, of course, is to achieve sufficient scale to make it useful. The bigger the network, the more opportunities it provides for cashless trades to be made. In the early stages, it may require some help to find those opportunities, but as the members discover each other and become aware of what each has to offer, the benefits of participation become ever more evident and attractive. Like Facebook, Twitter, MySpace and other networks that are purely social, cashless trading networks will eventually grow exponentially—and that will mark a revolutionary shift in political as well as economic empowerment. It will be a quiet and peaceful revolution brought on, not by street demonstrations or by petitioning politicians who serve different masters, but by working together to use the power that is already ours – to apply the resources we have to support each other's productivity and to give credit where credit is due.
Through participation in an exchange network that is open, transparent and democratic, members enjoy the benefits of:
• A reliable and friendly source of credit that is interest-free and community controlled.
• Less need for scarce dollars, euros, pounds, yen, or other political money.
• A stable and sustainable means of payment.
• Increased sales.
• A loyal customer base.
• Reliable suppliers.
• A more prosperous and livable community.
What will it take to make mutual credit clearing networks go viral the way social networks have? That is the key question, the answer to which has heretofore remained elusive. While the WIR has been an obvious success, it seems to have been intentionally constrained and prevented from spreading beyond Swiss borders. And while commercial "barter" has been significant and growing steadily for over forty years, its volume is still tiny in relation to the totality of economic activity.
As they are operated today, commercial trade exchanges are self-limiting and typically impose significant burdens upon their members. These include onerous fees for participation, exclusive memberships, limited scale and range of available goods and services within each exchange, the use of proprietary software, and insufficient standardization of operations, which limits the ability of members of one trade exchange to trade with members of other exchanges.
Virtually all commercial trade exchanges are small, local, and operated as for-profit businesses. Small scale, local control, and independent enterprise are all desirable characteristics. But when it comes to building a new exchange system, something more is required. What the world needs now is a means of payment that is locally controlled but globally useful. That means giving members of a local trade exchange the ability to trade with members of other exchanges easily and inexpensively, with little or no risk.
Here are the things that I believe are needed for cashless trading based on mutual credit clearing to go viral:
1. Members need to offer to the network, not only their slow-moving merchandise and luxury services, but their full range of goods and services at their usual everyday prices. This will assure the value of the internal trade credits and make them truly useful.
2. Like any "common carrier," trade exchanges should make membership open to all with little qualification.
3. Lines of credit (the overdraft privilege), however, must be determined according to each member's ability and willingness to reciprocate, measured, for example, by her record of sales into the network.
4. Trade exchanges must be operated for and by the members in a way that is transparent, open, and responsive.
5. Members must exercise their duties to provide proper oversight and supervision of those assigned to manage the exchange.
6. There must be sufficient standardization in the operation of trade exchanges to assure that their internal credits maintain comparable value.
As trade exchanges master these dimensions of design and operation, they will become models for other exchanges to follow. Then the rapid growth phase will begin, leading eventually to an Internet-like global trading network that will make money obsolete and enable a freer, more harmonious society to emerge.
**References**
Greco, Jr., Thomas H. 2009. _The End of Money and the Future of Civilization_. White River Junction, VT. Chelsea Green.
Greco, Jr., Thomas H., and Megalli, Theo. 2005. "An Annotated Précis, Review, and Critique of Prof. Tobias Studer's WIR and the Swiss National Economy." http://reinventingmoney.com/documents/StuderbookCritique.pdf
Riegel, E. C. 1973. _Flight From Inflation_. Tonopay, NV. The Heather Foundation.
Websites: _Beyond Money_. http://beyondmoney.net, and _Reinventing Money_ ,
http://reinventingmoney.com.
Videos: "The Essence of Money: A Medieval Tale," available at, http://www.digitalcoin.info/The_Essence_of_Money.html, or,
http://www.youtube.com/watch?v=qBX-jaxMneo
Money as Debt: http://www.moneyasdebt.net.
WIR Bank Video Report: http://www.atcoop.com/WIR_Video_3.htm.
**Thomas H. Greco** _(USA) is a writer, networker, consultant and activist. A former engineer, entrepreneur and tenured college professor, he is widely regarded as a leading authority on cashless exchange systems, community currencies, and community economic development. His latest book is _The End of Money and the Future of Civilization _(2009). http://beyondmoney.net._
# Shared Space: A Space Shared is a Space Doubled
_By Sabine Lutz_
Streets and plazas are the spaces of the public, the spaces where people encounter each other. Such encounters can be fleeting or intense, but they always imply the possibility of lingering. Yet lingering is difficult if not impossible if our roads are designed to serve the needs of traffic practically to the exclusion of everything else. The concept of _Shared Space_ was developed to contrast any singular use of a space with a more flexible concept of space open to diverse uses. The design of a street should not predetermine just one particular use, but be open and adaptable for many uses.
**Sharing, not dividing**
Social processes and structures are reflected in public space. However, we have replaced social cooperation with legally regimented separation, where cars, pedestrians and cyclists each have their own lanes and each use (shopping, recreation, living and working) has its own area. Shared Space seeks to reconnect these uses.
Public space is characterized by the fact that it is the place where the most varied interests, outlooks on life and actions can meet. The opportunity for communication and mindfulness, consciously experiencing things and acting, is essential for this to occur. Mindfulness is directed both to one's external surroundings and to internal processes. It assumes that we are both independent individuals and responsible members of a polity. As individuals, we are diverse. As a collective, we need to create connections and cohesion among ourselves. Where could that be expressed better than in the street?
**How does Shared Space work?**
1. The most important prerequisite is decelerating automobile traffic. Contact and communication are possible only when people travel slowly. Deceleration is not brought about by force. It comes about when a street is redesigned to help drivers change their routines: they see various people doing different things to their left and right, and sometimes directly ahead. They recognize that the street is alive, not only lengthwise, but also crosswise. They slow down, thereby making the street safer for everyone.
2. A different design encourages pedestrians and cyclists to use the entire street, not just the sidewalks and bike paths. They can cross the street wherever they like, not only at designated pedestrian crossings. That requires a certain amount of trust (but not blind trust) that generally speaking, drivers are not murderers. Pedestrians and cyclists, too, bear responsibility for safety. They make contact and make sure that they have been seen, while at the same time signaling to drivers: the street is not yours alone.
Imagine a country road linking several villages that has an intersection where dangerous situations often arise because people drive too fast. That intersection, where accidents occur time and again, turns the road into an undesired barrier within the surrounding area, which is used for recreation. On average, 3,000 to 4,000 motor vehicles and 750 to 1,000 cyclists pass the intersection per day. This example is from the Netherlands; the road connects the villages of Ureterp, Siegerswoude and Bakkeveen. It took a lot of time for the residents of these villages to convince the politicians that Shared Space was a feasible option here. But they persevered and transformed the conventional intersection into a plaza where the drivers perceive the proximity of the villages, even if they cannot see them from there. Today, the local residents call it the "village square." Drivers approaching it cannot immediately see where the road continues, since it has been shifted sideways on the far side of the plaza. They have to get their bearings and drive more slowly, which makes the village square safer. Street furniture and greenery were designed with great care. The new village square provides for more mindfulness and more encounters. When the weather is good, there is even a small ice cream stand.
**Backbone and commitment**
If jointly used spaces are to function in practice and take account of transportation needs, urban design and social participation are required. Cities and towns do not need expensive or trendy road designs; they need a cross-sectoral perspective on the function, uses and design of public spaces. And this requires politicians with backbone – leaders who recognize that a different street design can result in different driving behaviors, and this in turn can lead to less gasoline usage and lower CO2 emissions.
But Shared Space __ also requires citizens to develop a different attitude and different behaviors. Citizens must have a say in decision-making, and tough choices have to be made; they must not shift responsibility to politicians, the police or the scientific community. The challenge is to act in a consensus-oriented and communicative manner rather than invoking our rights.
Shared Space __ stands for cooperation in partnership, not only in our behavior in the street, but also in forming opinions on current issues. Here, too, the challenge is to be creative and to share the work, the responsibility and the "space." That results in citizens having more opportunities for self-determination and having their say. The condition is that everyone rethinks their position and takes responsibility, instead of considering themselves simply to be suppliers or consumers of public services.
Shared Space __ is a __ plea and an experimental practice for this type of common and continuous learning process in urban design and civic culture. There is a lot to be done if we are to make public space our space again. We've already made a start!
**Sabine Lutz** _(Netherlands) is developing regional and interregional innovation projects at the crossroads of spatial planning, landscape and social development, amongst which is the EU cooperation project, Shared Space. She is the author of several Shared Space books and articles, all available at www.stichtingommelanden.nl._
# Transition Towns: Initiatives of Transformation
_By Gerd Wessling
_
In 2006, when Rob Hopkins moved from Ireland to the small English town of Totnes with his family and co-founded the first Transition Town Initiative in the world with some friends, he surely never imagined what he was starting. Six years on, there are more than 500 "official" Transition Town initiatives in more than 38 countries, and several thousand more are in the process of formation in many cities, towns and regions across the world.1 The model of Transition transcends cultural barriers and languages, and works very well on all levels in between the regional and the personal. It is open enough to inspire people from Brazilian favelas to small towns in Sweden, and it offers enough common features to forge global connections in how these people think and act in their locality. At the same time, it encourages them to adapt their practical work precisely to their local circumstances, making each Transition initiative unique in its features and projects. (1. See, e.g., www.transition-initiativen.de, www.transitionculture.org, and www.transitionnetwork.org)
What is it that makes the Transition model so attractive for so many extremely different people and cultures? What makes men, women and children get involved in a way that they have often been unaccustomed to, be it in public gardening projects, relearning forgotten cultural practices, re-imagining transportation and energy groups, or sharing their tools and knowledge? The answer might lie in the roots of the movement.
**Less is more**
The transition movement often refers to itself as the "head, heart and hands" of the energy and cultural transition. With that comes the importance of maintaining a balance between these three components, so that none outweighs the others. The "head" refers to scientific and mental conclusions and facts that inspired Hopkins and his collaborators to establish the first Transition Town in Totnes. It includes the insight that the present Western lifestyle is not sustainable, particularly when looking at it with an awareness of Peak Oil (and other resources peaking), climate change and global justice in resource use.
Rather than preaching a doomsday scenario, the Transition movement considers these negative developments to be an opportunity – especially for the West – to significantly increase our quality of life immediately, by transitioning to a gentler way of life based on greater sharing of resource use and better cooperation. That involves recognizing that people can actually improve their quality of life by forsaking many of the goods and habits that they have grown to love, and that resistance to change is often born out of fear of loss and/or laziness. The tangible gains could include, for example:
• better air, water and soil quality as well as biological diversity, instead of further pollution due to fossil fuels;
• silence, instead of noise due to increasing traffic;
• a viable social life within one's own neighborhood, city or region, instead of increasing separation and geographic isolation; and
• respect for diversity, rather than aversion to people and practices perceived as unknown and foreign.
Some of these elements are part of the Transition Movement's "heart," or the so-called "inner Transition." For example, in an "inner Transition" group people might investigate together which of our "inner mechanisms" actually encourage us to create our external industrial growth model, which so often inflicts harm on our environment and our inner well-being. Another aspect of this work might be to examine how one's group can collaborate well and deal constructively with feelings of desperation and powerlessness, posed by overwhelming, "big" challenges. A first, important step might be simply to recognize those emotions and then to find wise and appropriate ways of dealing with them.
The "head," "heart" and the "hands" of the Transition movement draw further upon deep ecology approaches developed by Joanna Macy ("the work that reconnects") as well as the theories and practice of permaculture. "Permanent agriculture" was developed in the 1970s during the first oil crisis and pursues principles basic to every Transition initiative: observing and interaction; capturing and storing energy; generating and harvesting yields; creating self-regulating cycles and accepting feedback; using and valuing renewable resources and services, and not producing waste; integrating instead of separating; prioritizing small and slow solutions; appreciating diversity; paying attention to border zones; and responding creatively to change.
In further developing a Transition initiative, it is equally important to anchor both the "head" and the "heart" as concretely as possible in actions on the ground, be they neighborhood meetings, art or food projects, a reskilling workshop or regional currencies. There is no need to reinvent the wheel though; close exchange and cooperation with already existing initiatives will often do the job and create very rewarding new connections.
**Powerful adoption of the transition model**
Why has the Transition movement had such deep cultural resonances _now_? Haven't community gardens, discussion groups and places to share and exchange things been around for a long time? These questions have not yet been fully answered, and perhaps never will. Presumably the strong embrace of many Transition initiatives adoptions has to do with the fact that compared with some existing movements and political groupings, the Transition model offers some fresh approaches. For example, it often encourages those people who previously just sympathized passively with "green" topics to become actively involved (in many cases, for the first time in their lives!). The Transition movement also offers a vision of a better future – developed in partnership between activists and people in their local community – that speaks to the needs of everyone, whoever and wherever they are. The efforts try to include people as they are, respecting and valuing whatever particular wisdom, creativity and talents they may have. The Transition approach is non-ideological and pragmatic, reflecting the motto: "There's already all the necessary creativity, genius and knowledge in the people in our neighborhood to solve our local problems with ingenious, creative and quality-of-life improving projects, while decreasing resource consumption and increasing our quality of life. How wonderful to finally be able to connect with them!"
Living with less (fossil-fuel-based) energy will probably be unavoidable in the future. Transition initiatives believe that it is better to plan for that, rather than to be shocked and surprised by it. The Transition approach that "the (local) solution will be just as big as the (local) problem" self-empowers us. A lot of positive energy emerges from the Transition model and its projects, which are often "contagious." They inspire people with enthusiasm and common sense, and are easily replicated. And all this while strengthening the resilience2 we so urgently need. (2. See Rob Hopkins' essay on the concept of resilience in Part 1.)
Another key realization of Transition and related movements is, "We ourselves must act, and we must act now." Waiting for governments and institutions to decide and act for us will simply not cut it. Another very positive result of this approach is that when people do get actively involved, they often escape feelings of powerlessness. "I'm just one person and whatever I do doesn't matter" is replaced by "Whatever I do in partnership with others transforms the whole."
Many people perceive their connections within a Transition initiative to be enriching. They also cherish the idea that Transition is still a big experiment whose outcome is uncertain. Nobody knows _the_ answer because _the_ answer simply doesn't exist. Thus the "cheerful disclaimer" on the Transition network websites and books that emphasizes the experimental approach of Transition.
If one were to spell out the Transition model from A to Z, we would have just reached the letter C in terms of its potential. There's still plenty to develop and we all are needed to fill the Transition model with life and our visions. One area of further challenge is certainly to look closer into the many principles and practices the commons and Transition share. They are like natural fellows and very much at ease with each other. Thus it will be most inspiring to see how more and more Transition and commons projects globally overlap and thrive together in a most joyful and life-enriching way.
**Gerd Wessling** _(Germany) is a physicist with long-term connections to places like Auroville (India), Schumacher College (UK) and Totnes (UK). He is Co-Founder of Transition Town Bielefeld and of Transition Netzwerk D/A/CH (Germany/Austria/Switzerland). As a certified Transition Trainer he is leading Europe-wide Transition workshops. He facilitates courses at Schumacher College. http://www.transition-initiativen.de. _
# Learning from Minamata: Creating High-Level Well-Being in Local Communities in Japan
_By Takayoshi Kusago_
The path of Japan's economic and social development after World War II has followed the trajectory of most industrialized countries: the pursuit of high economic growth on the assumption that higher per capita income would ensure people's life satisfaction. But, according to a survey published by the Japanese central government, life satisfaction constantly declined from 1984 to 2005. Two out of three persons are not satisfied with their overall life. This confirms a paradox first identified by Richard Easterlin (1974): There is a gap between the trends of life satisfaction and growth in per capita GDP.
_Figure 1: Happiness Paradox_
__
_ _
Research on subjective well-being shows that important elements of happiness include the possibility to work and be creative, good social relationships, health, life knowledge and life skills. Hence, the key question – at least in industrialized countries at the beginning of the 21st century – is not how to generate more income for people, but how to change the economic and social system in ways that strengthen social relationships and thereby improve well-being.
If we want to leave the economic-welfare-driven development path and move towards one centered around well-being, we need to imagine and experiment with social innovations as well as new measures and indicators for a "happier" society. A deeper look at a real case from a city in Kyushu, Japan, suggests a wider horizon of what is possible.
**The case of Minamata**
About 20 years ago, when people from Minamata were asked where they come from, they avoided mentioning the name of their community.
Minamata is a small city of around 28,525 people (2008) located in the Kumamoto prefecture on the western side of Kyushu Island. Minamata's modernization was based on two key goals of the national development strategy envisioned in the Meiji period (1868-1912) _Fukoku Kyohei_ : a wealthy nation and a strong army. In 1908, Nippon Chisso, a company in the vanguard of the chemical industry, built its factory in Minamata. When the factory was established, people in Minamata had high expectations for the modernization of the local economy and regional prosperity. And in fact, Minamata was the first place in Kyushu to be wired for electricity. Industrial development was the core of Japan's economic strategy and Minamata was surely at its center.
In 1932, the Chisso Company started its operations by combining atmospheric nitrogen with calcium carbide to produce calcium cyanamide, a chemical fertilizer. Nitrogenous fertilizers were key to boosting agricultural production in Japan at the time, due to its lack of arable land and the small-scale nature of its farms. In 1941, it became the first Japanese producer of vinyl chloride. The city's population grew as the company expanded. After World War II, the factory regained its production capacity and led Japan's reconstruction and economic development in the postwar era. However, this economic success had an unexpected cost – a severe neurological disease caused by industrial pollution. "Minamata disease," which consisted of severe brain and nervous system damage, and sometimes death, was officially discovered in 1956. It especially affected people in fishing communities. According to official government measures published in 2001, 2,265 individuals in the area were afflicted, and 1,784 of those victims died as a result of the poisoning and/or the disease.1 (1. http://www.env.go.jp/en/chemi/hs/minamata2002/ch2.html)
At first, the phenomenon was suspected to be some kind of epidemic or mental illness, but it was soon found to be non-infectious. The cause of the Minamata disease was ultimately identified as mercury metal in the effluents from the Chisso factory into Minamata Bay. Before the disease hit human beings through the food chain, fish of Minamata Bay began to float on the surface and cats were acting strangely, ending up by dashing into the ocean to commit suicide.
The number of patients increased; they were forced to go through very difficult lives both physically and mentally. Since it took more than ten years for the government of Japan to officially recognize the role of industrial pollution caused by Chisso, the victims of Minamata disease were virtually ignored by the company, the government and local people, resulting in great mental anguish and social decline. This was partly because the Chisso Company was so economically important to Minamata that many local residents, who heavily relied on Chisso for their livelihoods, were afraid of confronting the problem. For those identified as suffering Minamata disease, their lives became a hell as community people shunned them; others with severe physical symptoms tried to hide their condition lest the community ostracize them. Some patients were both verbally and physically abused even by family members and people who once were good friends. In fact, the social stigma toward people in Minamata became a nationwide phenomenon. Passengers on trains entering Minamata shut their windows. Marriages were broken off if one of the people came from Minamata. It became customary for Minamata residents not to reveal where they came from.
Although Minamata disease was discovered in 1956, the wastewater discharge was not stopped immediately. Rather, the Chisso Company simply changed the location of its mercury effluent outlet. This continued until 1968 when the government officially recognized the effluent of the Chisso plant as the cause of the Minamata disease. The year of this acknowledgment was not accidental. The Chisso Company opened its new factory in Chiba prefecture with a new petroleum-based technology that year. The carbide-based technology was no longer needed, and the official recognition of Minamata disease would not hurt the nation's industrial development. The government's inaction for a decade had incurred enormous costs for people in Minamata, but also for those who lived in Niigata prefecture, which was afflicted by the so-called "second Minamata disease," caused by Showa Denko Company using the same old technology as Chisso.
**People-driven initiative and public-citizen partnership**
In 1969, victims of the Minamata disease filed the first lawsuit against Chisso, followed by a series of lawsuits by others that caused terrible divisions between those who were compensated and those who were not. The physical and mental toll of the disease, and the social trauma experienced by the community, went on for more than forty years. This started to change in 1994 when Masazumi Yoshii, who had been a member of Minamata city council for 19 years, was elected Mayor. He brought about a fundamental change in the public administration, from top-down to bottom-up, by establishing communication with the different patient-groups – who, by then, did not get along well with each other. Yoshii also negotiated with the central and the prefecture government to finalize the compensation accord for all Minamata disease patients, regardless of the seriousness of their conditions.
On May 1, 1994, Yoshii gave a historic speech at the memorial ceremony of the Minamata disease. He offered a formal apology of the Minamata city government towards the Minamata disease patients for its lack of support for the last forty years and declared the vision of together building a _new Minamata_ with a spirit of mutual helpfulness. He called it MOYAINAOSHI, a term which comprises searching for solutions through dialogue and collaboration. He declared these to be the core elements for restoring social relationships among people and between communities, the environment and the people of Minamata. These core elements became what is now called the MOYAINAOSHI movement.
Let's have a look at the key actions taken by the government and local people since 1994 (Kusago 2011).
**1. A new vision**
Two years before Yoshii's 1994 announcement, Minamata city officials declared their ambition to change their development path from one emphasizing high productivity and growth to an environmentally friendly model. The vision was to create a Model Environment City.
**2. An innovative "environment meister" 2 **(2. _Meister_ is derived from the "magister" (Latin for teacher). In Germany and Austria the word Meister is a title in the crafts guilds. In English, a person referred to as Meister is one who has extensive theoretical knowledge and practical skills in his profession, business, or some other kind of work or activity. Wikipedia, at https://en.wikipedia.org/wiki/Meister)
Minamata City has designed the environment meister program, which was implemented in 1998. This program offers certification for safe, healthy and environmentally sensitive products. Certification as a meister has been granted to 28 producers of pesticide-free rice, tea, mandarin oranges, vegetables, and other products like sardines without preservatives. To be qualified as a meister, six criteria must be met:
• Constant production of safe, environmentally friendly and healthy products over five years;
• Experience making such products using natural materials and avoiding chemical substances, etc.;
• Knowledge about and experience with techniques for making products that are safe for environment and health;
• Involvement in activities related to regional environmental problems and environmental conservation;
• Knowledge of environmental problems and environmental conservation; and
• Knowledge of the problems attributed to environmental pollution, including Minamata Disease.
**3. Grassroots action**
The new direction taken by the city government after 1994 motivated local residents to engage in the rebuilding of community through grassroot actions. One example is a women's waste reduction group that improved an ambitious garbage sorting program started by the municipality in 1993. The women studied the root cause of garbage production and found that plastic trays used by stores were a major problem. After carefully surveying usage of trays and vinyl bags at retail shops, they negotiated successfully with the major retail shops to agree to stop using the trays. In addition, the women's groups started distributing shopping bags to all residents to reduce the usage of vinyl shopping bags. They also introduced a certification for "eco-shops," which are stores that promote the conservation of resources and energy, reduce the volume of waste and work on recycling. It was the women who substantially reduced the city's output of garbage.
**4: Neighborhood study, or "Jimotogaku"**
Minamata has both fishing communities and mountain communities. While people in fishing communities have suffered Minamata disease for more than fifty years, people in mountain communities, while suffering less from the disease, faced another problem: urbanization and out-migration. The overwhelming number of jobs in modern Japan was generated in urban or semi-urban areas. Thus, those looking for work, especially among the young, tend to move to big cities like Tokyo, Osaka or Fukuoka. In Minamata's mountain communities the number of residents had declined for years. This situation was seen as the inevitable "fate" of the rural communities in a time of modern development and industrialization.
Tetsuro Yoshimoto, a city officer in Minamata, had himself fretted about the demise of once-beautiful ways of life in the region. He realized that the revitalization of mountain communities might be possible if the city of Minamata looked at them through the lens of MOYAINAOSHI. Yoshimoto saw Minamata city as a whole – an ecosystem centered around the Minamata River flowing from the mountain communities to the fishing area. He proposed that changing local people's mindsets by making them aware of all the resources they possess in their own local communities could be possible by bringing visitors to the mountain communities. Most of the visitors, whose primary purpose in visiting Minamata is to learn about Minamata disease issues, asked local people to guide them in the local village.
Over 3,000 people between 2004 and 2008, many of them from abroad, enjoyed the rural setting and were impressed by the beautiful landscape and the unique livelihoods. In the course of interacting with their guests, local guides were surprised to hear such positive feelings about their communities and such interest in their lifestyles. They had assumed that they were seen as hopelessly "backward" in the modern world. After serving as guides to visitors, they gradually came to understand that they were not "behind," but rather, that they had the potential to develop their communities by themselves. The organized visits proved to be a simple way to enhance local people's autonomy through mutual learning with outsiders.
Based on this experience, one rural community, Kagumeishi, has started a _living museum of Kagumeishi_. Women opened a food catering business adopting a philosophy of local production for local consumption. The primary school of Kagumeishi has developed a school play about the history of the community, with local music and dance. To practice the script, elderly resdidents taught primary school students how to sing and dance. Kagumeishi received an award from the central government as the best practice to revive community in 2005. Currently, there are four communities adopting the neighborhood study method in Minamata.
This method, called "Jimotogaku," was born in the local communities of Minamata. Jimotogaku as a method and a practice focuses on existing local resources, including nature, history, customs, and people, and facilitates the community's interest in managing its resources. "Stop asking for what we do not have, let us start from finding out what we have" is a principle of Jimotogaku. The method also emphasizes collaboration among "Soil and Wind," i.e., community people and outsiders to find out what the local communities have and how to use those local resources to improve their own well-being. One of the Curator's Rules of Thumb in Minamata is: "Never say, 'There is nothing particular in this village.'" Jimotogaku aims at building pride in a community's identity, traditions and lifestyle, and in enhancing autonomy in the design and implementation of local development (Yoshimoto 2008).
**Revitalizing community from below**
A once-broken Japanese community, where people saw only darkness and hopelessness in their local economy, has restored its social bonds and relationships with nature. Minamata had once pursued its well-being through a development model based on growth and foreign technology. Today, the city focuses on the reconstruction and recovery of social inclusion, environmental conservation and the promotion of cultural and spiritual heritage. Minamata has used the neighborhood study method, Jimotogaku, and a people-centered vision to convert a city famous for industrial pollution and an ongoing environmental disaster into a model environmental city. Minamata's new development path was initiated by an excellent leader and followed up with concrete actions taken by his city hall staff – together with local residents. It has shown how government can forge an exemplary public-citizen partnership to reverse a troubled local situation and develop sustainable new models of action. The people of Minamata, in fact, were awarded a national prize for their work in revitalizing their local community.
It is easy to feel despair when witnessing catastrophic harms caused by a development model based on growth and the depletion of resources, and the heinous acts of large corporations and banks. The recent history of Minamata, a one-time beneficiary of the "growth model" as well as its victim, shows that it is possible to rescue and improve even extremely distressed communities hurt by tragic acts. It is possible to redesign our communities, neighborhoods and livelihoods to pursue a more balanced form of well-being.
Today, when people are asked where they come from, they proudly say: From Minamata.
**References**
Easterlin, R. 1974. "Does Economic Growth Improve the Human Lot? Some Empirical Evidence." In P. A. David and M. W. Reder (eds.), _Nations and Households in Economic Growth._ New York. Academic Press. 89–125.
Kusago, T. 2011. "A Sustainable Well-Being Initiative: Social Divisions and the Recovery Process in Minamata, Japan." In Sirgy, J., ed. _Community Quality-of-Life Indicators: Best Cases V._ Springer. 97–111.
Yoshimoto, T. 2008. Jimotogaku wo hajimeyou (Let's Start Neighborhood Study). Iwanami Junior Shinsho, Tokyo.
**Takayoshi Kusago** _(Japan) is Professor in Social System Design, Faculty of Sociology at Kansai University. He engages in research on people-initiated creative community development, theory and practice. http://www2.ipcku.kansai-u.ac.jp/~tkusago/en/en_top.html. _
# Share or Die – A Challenge for Our Times
__
_By Neal Gorenflo_
About a year ago, a weather-beaten, middle-aged man asked me for money on the platform of the Mountain View Caltrain station. I gave him three dollars. He thanked me, and asked what I did for work. I introduced myself, learned his name, Jeff, and we shook hands. I pulled out a card from my computer bag, and handed it to him as I told him that I publish an online magazine about sharing.
Jeff lit up, "Oh I get that – when you're homeless, it's share or die."
That got my attention. I asked him to explain. Jeff said that a year earlier, his girlfriend drank herself to death alone in a motel room. He said she wouldn't have died had someone been with her. For him, isolation equaled death.
Jeff explained his perspective further, that he had no problem giving his last dollar or cigarette to a friend, that it comes back when you need it. But there are those who just take. You stay away from them.
I asked him about the homeless in Mountain View, which is in the middle of prosperous Silicon Valley. Jeff said there are 800 homeless people in the city, and that each has a similar story.
That conversation got under my skin. I shared it with Malcolm Harris the next day on a call about this book. Half-joking, I suggested Jeff's phrase, Share or Die, as a title. At the time, I thought it was over-the-top. I wasn't serious. But, thankfully, Malcolm began using it in correspondence about the book. It stuck.
My conversation with Jeff marked a turning point in my thinking. I had thought of sharing as merely smart because it creates positive social, environmental and economic change through one strategy.
But Jeff's story and the directness of his phrase – share or die – broke through my intellectualization of sharing. Jeff helped me see something that I was blind to, even though I knew all the facts – that sharing is not just a smart strategy, it's necessary for our survival as a species. This has always been so, but today our condition is especially acute.
We're using 50 percent more natural resources per year than the earth can replace, and the global population and per capita consumption are growing. And despite the overconsumption, countries all over the world are being rocked by social unrest because of how unevenly resources are distributed. The social contract is in tatters, and threats to peace and security seem likely to escalate. It's now glaringly obvious to me that we need to learn to share on a global scale fast, or die.
But the threat is not only one of biological death. Those like me – who are in no danger of starving anytime soon – face a spiritual death when we act as if well-being is a private affair, deny the influence we have on each other, and gate ourselves off from the rest of humanity with money and property. We can neither survive nor live well unless we share.
The path to this realization has been slow but steady. I started down it seven years ago when I deliberately shifted my life toward sharing. This shift led to co-founding _Shareable_ magazine two years ago, where I'm publisher. I could never have gotten to the place where I realized how fundamental sharing is to the human experience without my work at _Shareable_. I've been able to see how my own personal narrative connects with an emerging collective narrative about how to thrive as a person within a commons-based society. I hope that our work helps many others see how they can be individual successes within a larger collective success through sharing.
While this consciousness is new to me, we understood the importance of storytelling to movement building when we started _Shareable_. From the beginning, _Shareable_ 's editorial strategy was to affirm those who already share – the sharing community – while at the same time moving sharing into mainstream dialogue through emotionally engaging stories about ordinary people who build rich lives, successful enterprises, and vibrant communities through sharing.
In our minds, the sharing community encompasses all of humanity – though we wanted to speak to influencers in the "developed world" who sensed an impending societal resource crisis or had already experienced a personal crisis and were seeking new ideas about how to provision society or themselves. This bias reflects not only the background of _Shareable'_ s founders, but also the belief that our cohort has an outsized influence on society, whether deserved or not, which it is using to do a lot of damage.
Over time our focus has sharpened. Since we launched, we've increased our focus on topics with one or more of the following characteristics: 1) Contexts where more sharing could have profound impacts; 2) Topics that already generate a lot of dialogue; and 3) Domains where there are a lot of interesting edge cases. This has led to more emphasis on three areas: the young people in their twenties who are called "Generation Y"; cities; and "collaborative consumption," often spurred by technology startups. Together, these focal areas address questions about who, where, and how the developed world might share in the future.
**1. Generation Y**
If the commons are to triumph, it's going to need commoners. This is where the next generation comes in. There's a strong argument that Gen Y is the generation that can bring a shareable world to scale. Roughly 100 million strong in the United States alone, Gen Y grew up on the Internet and brings its values and practices, including sharing, into the real world. In 2009, the marketing firm TrendWatching called them Generation G (for "generous") and said they are accelerating a cultural shift where "giving is already the new taking." The people of Gen Y may not reach their full sharing potential until later in life, but there are promising indicators:
• A recent UCLA poll found that over 75 percent of incoming freshman believe it's "essential or very important" to help others in difficulty, the highest figure in 36 years.
• The same poll found that "working for a cause" was a top career objective, ranking it higher than making money.
• Eighty-three percent will trust a company more if it's socially and environmentally responsible.
• The Arab Spring, the UK movement against public service cuts, 15-M in Spain, and the Occupy Wall Street movement were arguably spearheaded by this generation.
Business strategist Gary Hamel believes that this massive generational force, which outnumbers baby boomers, promises to transform our world in the image of the Internet, a world where sharing and contributing to the common good are as normal as breathing. William Strauss and Neil Howe, authors of _Millennials Rising_ , believes that Gen Y is a hero generation, coming of age in a time of crisis – a crisis they're already helping to resolve, largely by applying the tools and mindset of sharing.
This possibility inspired _Shareable_ to produce _Share or Die_ , an anthology of personal narratives, analyses, cartoons, and how-tos by Gen Y to help Gen Y thrive as they attempt to remake the world. It's fitting that the title was inspired by a homeless man, for we are moving toward a condition of collective homelessness through the destruction of our environment.
**2. Shareable cities**
A revolution is underway in our conception of cities. It couldn't come any sooner, considering that 2007 was the first year in human history that the majority of human beings lived in cities. Perhaps as a result, cities are becoming the focal point for our collective hopes and dreams, as well as for all kinds of innovation needed to avert worsening environmental and economic crises.
In the past, we tended to see cities as dirty, unnatural, and isolating places; today, citizens and urban planners alike are starting to see their potential for generating widespread well-being at low financial and environmental cost. There's increasing appreciation for the benefits of public transit and urban agriculture. People want the streets to make room for pedestrians and bicyclists, and for civic engagement. The very thing that defines a city – its population density – makes sharing easier, from cars to bikes to homes.
Perhaps in response, there seems to be a boomlet in technology that helps First World urbanites understand their environment, share, and use resources more efficiently. IBM has based a massive Smarter Cities campaign around this theme. But it may be that the most successful innovations will spring from the megacities of the developing world. In the absence of vast financial resources, these cities may do as Bogotá, Colombia, did and prioritize human well-being over economic growth through investing in commons such as schools, parks and public transportation. Can a city become a happiness commons? Former Bogotá mayor Enrique Penalosa, who pioneered a number of public-sector civic innovations, including "participatory budgeting," knows from experience that it's possible.
At _Shareable,_ we're convinced that we need to see cities as places to foster commons, and not just markets. To explore that idea further, we started a 20-part series, "Policies for a Shareable City," to outline a policy framework to support urban resource sharing, co-production and mutual aid in the context of a developing-world. The regulatory environment should not just support markets, but also commons-based activity involving food, transportation, housing, governance and more.
**3. Collaborative consumption and sharing as a lifestyle**
The ways to share in everyday life seem to be multiplying like rabbits, but maybe the Great Recession is just forcing all of us to pay more attention these days. There's car sharing, ride sharing, bike sharing, yard sharing, coworking, cohousing, tool libraries, and all kinds of cooperatives – the list goes on. There are also ways to share power, dialogue and knowledge, such as workplace democracy, citizens' deliberative councils, "unconferences" (open, self-organized gatherings) and "world cafés" (focused deliberations).
There are also scores of new Internet startups that are helping people meet real needs. For instance, there's Airbnb (peer accommodations), Thredup (kids clothes), Chegg (textbook rentals), Neighborgoods (general sharing), RelayRides (peer-to-peer car sharing), Hyperlocavore (garden dating), Zimride (ride sharing), and many others.
Taking all of these into account, it's entirely possible to build much of one's life around sharing. You could live in a cohousing community, work in a co-op, grow food in your neighbor's yard, and get to the open space town council meeting via your car share. A shift in emphasis from ownership to access – taking possession of an asset only when we need to use it – can liberate us from the burdens of ownership such as the high costs of maintenance, insurance, taxes, legal liability, storage and disposal.
The positive dynamics of car sharing suggest what's possible if the economy is restructured for access instead of ownership. Carsharing is the decades-old archetype of the sharing economy, but it has arguably only come of age recently with mature technology, a global footprint, and with the first publicly traded car sharing company, Zipcar. With maturity comes statistics: A 2010 UC Berkeley survey of 6,281 North American carsharing members showed that over 50 percent of households who didn't already have access to a car joined to get access to one, and that the total vehicle count in the sample dropped by 50 percent after joining. The same study showed that one carsharing vehicle replaces 9–13 owned cars. A 2011 eGo Carshare study showed that car travel by members dropped an average of 52 percent after joining. The American Public Transportation Association estimates that people save an average of $9,900 a year for each car eliminated from a household. The Intelligent Cities Project estimates that a city can keep $127 million in the local economy annually by reducing the number of cars owned in a city by 15,000.
These findings suggest that collaborative consumption can significantly broaden citizen access to resources, dramatically reduce resource consumption, save citizens big bucks, and strengthen the urban economy all through one strategy – sharing.
While sharing and commons are likely as old as we are as a species, I can't help feeling that these few examples show that something radically new is afoot. Could it be that the confluence of a new generation, new technologies and a rapidly urbanizing global population are setting the stage for the emergence of a commons-based global civilization? There's no way to know for sure, but by understanding our roles in the struggle for the commons and the tectonic shifts about us, we have a better shot at meeting the ultimate challenge – sharing the world's resources. For it becomes clearer every day that our survival depends on increasing our capacity to share. The phrase "share or die" may shock, but it's the shock of the truth.
**Neal Gorenflo** _is the Co-Founder and publisher of_ Shareable _magazine, a nonprofit online magazine about sharing. As a former market researcher, stock analyst, and Fortune 500 strategist, Neal left the corporate world in 2004 to help people share through Internet startups, grassroots organizing and a circle of friends committed to the common good._
# The Faxinal: A Brazilian Experience with the Commons and Its Relationship with the State
_By Mayra Lafoz Bertussi_
In Brazil, innumerable land tenure situations are to be found that express great variety amidst the State's imposition of limited forms of property use. Collective identities, which find expression in social movements, reaffirm their rights to the common use of their territories: communities of indigenous, _quilombolas_ (descendants of members of runaway slave communities), _quebradeiras de coco babaçu_ (or women palm oil coconut breakers), _caiçaras_ , _cipozeiros_ 1, and _faxinalenses_ , or members of the faxinal communities. Examining those forms of appropriation of the territory opens the door to important interpretations of the commons. Here I place emphasis on the common use of territory through the experience of the peoples of the faxinal communities in the state of Paraná, Brazil. (1. Editors' note: Caiçaras and cipozeiros are traditional peoples with a particular relationship with the territory, who live from extraction. Caiçaras live near the sea and engage in both artisanal fishing and crop farming. Cipozeiros are extractivists who make a living by making crafts out of the vines (cipó) that grow where they live (they are "of the cipó").)
Characterizing a faxinal is a delicate matter, as it requires that one define categories. One possible characterization of the faxinal is the designation of a part of the territory for use as a commons. Often known as _criador comum_ ("common stock-raising area") or _terra de criar_ ("land for stock-raising"), such areas are used by the residents of the community to put their animals to pasture and to extract plant resources. Without fences that delimit the area around each property, the animals of a faxinal roam freely in the common area and feed from plant resources beyond what constitutes each community member's private property. The common use of the territory coexists with the legal existence of private property. The experience of the faxinal communities attests precisely to the fact that in the commons private property and common use are interconnected.2 (2. See also the essay by Liz Alden Wily on international land grabs inPart 2.)
_Criações_ , which is to say the animals in the space set aside for stock-raising, are private property, and ensure the food security of the residents. Nonetheless, it is not possible to restrict the categorization of the livestock solely on the basis of their function. Such animals are part of the landscape of a faxinal, and are engaged in the construction of the territories. _Criaçõe_ s may be _soltas_ (open) or _fechadas_ (closed). The quality of "open" or "closed" casts light on an understanding that permeates the use of that territory. "Open" is a way of designating the common use; "closed" designates individual use. And this explains the dynamic of the relationship between common and private use. In this sense, "open" or "closed" may be used for both animals and for natural resources: "open watering place," "closed area for growing yerba mate," "open herd of swine."
In addition to the area for stock-raising is the plot for crops, the _lavoura_ , which is used individually and known as _terra de planta_ , or crop area. The space used as commons has abundant forest cover, whereas the crop area is cleared and all planted. As there are no fences delimiting each property within the common area, the existing fences delimit the common area and keep the animals from invading the crops. The dwellings are within the common area.
The lack of concern with protecting private property in a faxinal does not mean it is an area without owners and without use rules. The arrangements that govern the use of the territory are not apparent because they take on different forms. The most common have to do with work on the fences. A person who works on building or maintaining fences and barriers may let his animals out in the common area. The work is also recognized when it is done collectively; such collective work on fences is referred to as _mutirão de cerca_. As a form of recognizing and valuing partners, the _mutirão de cerca_ attests to one expression of the common use of the territory.
The territory, taken here as a broad category that encompasses expressive social and cultural forms, is permeated by local relationships and agreements between owners and residents. The pasture, the animals themselves, the water, the fences, the barriers, are all active elements in the construction of territories permeated by the relationship between common use and private property.
**Diversity and the State: a complex relationship**
The first regulation aimed principally at the faxinal communities was State Decree No. 3477 of 1997, of the Environmental Institute of Paraná (IAP: Instituto Ambiental do Paraná), which recognized the faxinal communities as sustainable use conservation units. That regulation uses the term _Sistema Faxinal_ ("Faxinal System") to characterize a mode of production. The legal text emphasizes the term _sistema faxinal_ , highlighting the productivist and environmental angles, where the environment is emphasized to the detriment of a traditional way of life of the peoples of the faxinal communities. In that case, the environmental discourse does not take into consideration the role of the local communities themselves in preserving their own environment (Shiraishi 2009).
In August 2005 a political organization emerged to guarantee the defense of collective and territorial rights – the Articulação Puxirão dos Povos Faxinalenses.3 Mobilized around a collective identity, the peoples of the faxinal communities recognize themselves as traditional peoples and make access to the territory their main demand. Their argument in pursuing this aim is recognition of the traditional nature of a unique and distinct territory. (3. Editors' note: Puxirão may be understood as mutirão, that is, collective work.)
The peoples of the faxinal communities put forth understandings of "traditional" that go beyond a linear conception of time. What is called "traditional" is not reduced to history, a remote and static past. As a contemporary form of vindication, traditional peoples and communities incorporate collective identities in the context of specific mobilizations and situations.
Articulação Puxirão dos Povos Faxinalenses generally embraces the positions of what are called new social movements (Almeida 2008). Those groups, by taking on ethnic and collective characteristics in the context of political struggles, make explicit a plurality of ways of being in the world and are able to give visibility to the existence of different groups within the Brazilian nation-state. The organization resists relying on ethnicity as the original or primordial characteristic in empowering one's otherness within the State. In this regard, there is no "original faxinalense" or a "true identity," but rather groups that vindicate such self-identification and belonging.
This updated historical perspective, which has been attained due to the emergence of the collective identity, recently brought about by political and social organizing, does not annul the primary experience, which refers back to a common descendance. The peoples of the faxinal communities access an array of conceptions, all at the same time, when it comes to strengthening a collective identity. In this sense, the identity of _povos de faxinais_ , or peoples of faxinal communities, inherently entails a diversity and variability of situations. Their ancestors came from different places, which is also an argument for their self-identification. The faxinal communities are made up of _caboclos_ , Poles, Ukrainians and Germans; often times they go by the name of the predominant family or the group with the most influence either in constituting or reproducing the territory – e.g. Faxinal dos Küguer, Faxinal dos Coutos. With the emergence of an organization based on self-definition, all that variability is brought together in the designation of peoples of the faxinal communities ( _povos de faxinais_ , or faxinalenses).
The diversity and variability of situations are very important for understanding the faxinal communities, as it reveals aspects and dynamics of identity relationships – both identity of origin and the current formats for representing their identity. Reflecting on this diversity of the faxinal peoples means rejecting an essentialist approach based on the search for a supposed authentic identity. There are various practices in relation to the common use area. Some faxinal communities have open stock-raising areas, that is, without a fence; others allow common pasturing only for large livestock, such as cattle and equines.
In 2006 the social organization was designated a member of the National Commission on Sustainable Development of Traditional Peoples and Communities. A parity (government/civil society) body appointed by the Brazilian State, the Commission brings together representatives of the federal public administration and civil society organizations with ties to traditional peoples and communities. On February 7, 2007, Decree 6,040 was approved; it instituted the National Policy on Sustainable Development of Traditional Peoples and Communities, which includes the peoples of faxinal communities.
In 2007, after constant pressure from the Articulação Puxirão, political organizing efforts resulted in state recognition. According to the law, the state of Paraná recognizes that the faxinal communities have a specific relationship with the territory. While the 1997 state decree does not highlight any particular feature of the faxinal peoples, Article 2 of State Law 15,673/2007 recognizes their identity as such as a criterion for determining the traditional peoples who occupy and use the territory in that specific way. Nonetheless, to date the state has taken few specific initiatives to recognize faxinal territories. Some municipalities already have local legislation to recognize the faxinal communities, yet none has secured formal tenure.
Such legislation represents significant gains in terms of the state recognizing realities of identity and land tenure that link common use and private property. Nonetheless, like several other peoples, the peoples of the faxinal communities still face explicit resistance when it comes to exercising their rights. Several persons have given testimony of violence and persecution against the members of the faxinal communities, and the livestock also suffer hostilities as a symbolic way to deny common use. The authorities ignore most of the legislation recognizing the faxinal territory. Most of the time, the argument in favor of private property is superimposed on rights related to common use.
**References**
Almeida, Alfredo W. B. 2004. _Terras tradicionalmente ocupadas, Processos de Territorialização e Movimentos Sociais._ Estudos Urbanos e Regionais 6(1) (May 2004): 10.
Shiraishi Neto, Joaquim. 2009. "Direito dos Povos dos Faxinais." In _Terra de Faxinais_. Manaus, ed. Universidade do Estado do Amazonas, UEA: 17–28.
**Mayra Lafoz Bertussi** _(Brazil) is an anthropologist associated with the unit of Anthropology and Citizenship (Núcleo de Antropologia e Cidadania, NACi) of the Federal University of Rio Grande do Sul and researcher in the project, New Social Mapping of Brazil. She works on issues like collective identity, territoriality and common use of resources._
# Capable Leadership, Institutional Skills and Resource Abundance Behind Flourishing Coastal Marine Commons in Chile1
_By Gloria L. Gallardo Fernández & Eva Friman_
In the mid-1970s, with the neoliberal economic policy in Chile, exports of the shellfish _loco_ – the most important species economically – increased, rapidly incorporating artisanal fishers into the global market. "Landings" (or the catch) of _loco_ soon reached unprecedented levels only to abruptly fall again – taken as a sign of overexploitation. After a decade of conservation measures (seasonal closures, national quota and bans) that left fishers at odds, a new fishing law was enacted in 1991, instituting a new scheme of "territorial use rights in fisheries," or TURFs. (1. This paper partially builds on Gallardo, G. L., and E. Friman. 2011. "New Marine Commons Along the Chilean Coast. The Management Areas (MAs) of Peñuelas and Chigualoco." International Journal of the Commons (5)2. Data was collected through fieldwork in 2008 and 2011, and email and phone contacts.)
Chilean TURFs, known as management areas (MAs), work within a co-management framework to combine government regulations with fishers' own rules. The TURF system allows fishers to receive exclusive, nontransferable and renewable access and use rights to specific benthic resources (those near the bottom of a body of water) within an allocated seabed. TURFs are only granted to fisher organizations. Between 250 and 600 hectares in size, the MAs are in the prime fishing grounds within the five nautical miles of the coastal zone reserved for artisanal fishers. Since 1997, TURFs have spread along the Chilean coast as the fisheries management regime for more than 30,000 fishers.
Artisanal fisheries land almost all edible fish in Chile, while any high value species generally go to export. Fishers are organized around _caletas_ , about 440 permanent small-scale fishing ports within private or State/municipal land. In some rural areas, _caletas_ are equivalent to fishing villages; in others, fishers live some distance away. A _caleta_ usually involves a pier, a boatyard, huts or sheds in which fisher camp, or houses or a community in which fishers live. Rural _caletas_ often lack electricity, running water, sewage systems and paved roads. Since the new legislation, fishers must fish in a permanent place, no longer allowed to move along the coast, a rule that many fishers do not appreciate.
**From rivalry to collective action**
To apply for an MA is a challenge. Fishers must organize, recruit members and choose leadership. Each organization must decide on its own rules, sanctions for noncompliance, joining fees, exit rules, surveillance mechanisms, income distribution and amounts to set aside for MA costs and social purposes. This demands a certain level of organization and social cohesion. Regulations can be changed by the assembly, i.e., all members, which make key decisions. MAs have a board in charge, and often delegate responsibility for administration, vigilance and commercialization in commissions. Fishers collectively decide when to harvest and at what price to sell, instead of competing for resources in boat crews of three or four as they did earlier. A third of all existing fisher organizations (including non-MA ones) sell their landings in common (INE 2008–2009).
In terms of fishing, the MAs provide better management and planning, greater resources and an improved extraction system. The more than 600 fishery-organizations also empower fishers in their dealings with government authorities, middlemen, restaurants and export companies. Self-employed, artisanal fishers are used to doing without state social welfare, i.e., pensions or insurance for health, disability or death. Within the MAs, they are now able to provide such social welfare benefits for themselves.
**TURFs for making a living? TURFs for long-term sustainability?**
Incomes derived from MAs vary remarkably, as do MA costs that depend in large part on the size and location (urban/rural) of fisheries and the distances to get there. In the early years of the TURF system, performance of MAs in region IV, the system's "cradle," was rather poor, disappointing fishers' high expectations. Measured in 2003, only five of thirty MAs studied did well economically; the rest performed regularly or worse (Zuñiga et al. 2008). Thus MAs, while not a complete economic solution for fishers, are a complement to their livelihoods.
Since 1998, fishers have been allowed to extract _locos_ (the main species for most MAs) only within MAs, and it has become illegal in the open access zones that coexist with MAs. Such open access zones are open to all fishers registered in the region. Both MA and non-MA members try to exceed the existing rules for livelihood reasons. In fact, half of fishers' incomes (including the incomes of MA members) derive from illegal extraction in open access (Orensanz et al. 2005).
And yet scholars and authorities have found that the TURFs are helping to conserve fisheries within MAs – while the contrary holds for open access zones (San Martin et al. 2010) even though the two are ecologically connected. These results show that sustainability may not imply profitability in the short run; low economic results can even indicate a long–run advance towards sustainability (Zuñiga et al. 2008). However, if a MA performs economically poorly, it "further encourages shifts to more desperate and destructive fishing techniques," endangering the ecosystem (Qashu 1999). Fishers' livelihood needs may overshadow conservation concerns if economic returns from the MA are lower than the costs and efforts of engaging in it, and benefits from the territory are less attractive than those outside of it (Gallardo and Friman 2011).
Thus, good economic returns and the value of fishers using their TURFs are two conditions that have to be fulfilled to perform well. Also associated to successful TURFs are two preconditions: one is resource abundance (which might imply multi-species extraction), and the other is sufficient demand from national and/or international markets. However, it appears that human agency in the form of capable leadership and institutional skills – and the capacity to confront new challenges – may be _the_ key condition for economic performance (increasing incomes, income stability and per capita patrimony) and for institutional robustness (well-functioning organization, participation in decision-making, respect for self-imposed rules, few free riders, trust, cohesion, empowerment, self-esteem, social welfare system). Taken together, these pre(conditions) can enable fishers to begin an upward spiral of success in meeting new challenges and diversifying activities that in turn empower them further, while lowering the pressure on the ecosystem and making them less vulnerable to global business cycles.
Fifteen years after the implementation of MAs, many of them still perform poorly, economically and institutionally (Gallardo and Friman 2011). Of the five best-performing MAs in regions III and IV in 2003, Peñuelas was the best, with a global indicator scoring of 0.6982 and annual per capita income of 1,101.236 _pesos_ (US$1,829). Punta de Choros, by contrast, scored only 0.32 in spite of a higher per capita income (3,122.933 _pesos_ (US$5,188) (Zuñiga et al. 2008). The latest statistics on landings show that these two MAs are performing well, and that there is resource abundance in their seabed. If Punta de Choros scored low in 2003, things seem to have dramatically changed for the better. (2. Based on the hierarchical schedule of Lambert and Bloom, (in Zuñiga et al. 2008), the global indicator, scaling from 0 to 1, measures socioeconomic performance of the MAs, including institutional performance, social and economic aspects.)
**Peñuelas**
It is worth exploring the operations of the urban Peñuelas MA in greater depth. The MA has 288 hectares and 197 male members, including 10 retired fishers who are counted when dividing the income. _Machas_ – the main target species – are extracted by divers at eight meters depth. Peñuelas' association is headed by a biannually elected board responsible for all aspects of the association, which has several commissions taking care of the MA operations.
The _caleta_ is situated in the south part of Coquimbo bay in La Serena City, a popular upper- and middle-class summer resort of 200,000 inhabitants. It is located on a beach, but it lacks a pier and crane to lift and lower their forty wooden artisanal boats with outboard motors, so fishers have to push them into the sea and pull them back out again every time, which causes health problems. The impressive _caleta_ building on the beach was constructed with State help, without much cost to the association. The urban and beach setting gives the fishers ready access to markets as well as electricity, piped water and a sewage system, but the urban bay setting also entails greater water contamination. The vast majority of fishers live near the _caleta_ on the other side of the beach road in humble houses, compared to the fancy summer resorts near them. Living in proximity to each other, families can help fishers when necessary. To earn extra incomes, several fishers rent their front houses during the tourist season (2–3 months per year) and some run small home-based restaurants.
Although fishers were advised in 1994 to harvest a maximum of 175 kilos _machas_ per boat, they exceeded that limit, which led to species scarcity that worsened with the 1997 heavy rains. The _macha_ banks collapsed and many fishers, pressured by middlemen and attracted by business opportunities, migrated temporarily to southern Chile to fish with their boats (ESBA 2000) – a common livelihood strategy among fishers before the TURFs were implemented. Peñuelas now extracts _machas_ only three days a week – a self-imposed limit for conservation: "We are the ones responsible for the resource," ex-president Guzman stated (Interview 11-24-2008). The daily _macha_ quota is set in relation to buyer's orders and distributed among fishers according to a system of quotas in relation to labor demand. If all fishers are needed, all go; if demand is low, just some go. Fishers decide with their crew if they go or if another boat takes their quota, or two crews gather in one boat. The next day they change roles, saving both efforts and fuel. While divers put on wet suits, others prepare the boats, dragging them into the water in groups; even dogs help with their bare teeth! Elderly members guard the _caleta_ during the day, and a paid watchman works at night.
The average monthly _macha_ income in Peñuelas from 2002 to 2008 was 300,000 _pesos_ (US$480), complemented by non-MA fishing activities of 250,000 _pesos_ (US$413), yielding an average monthly income of 550,000 _pesos_ (almost US$900). The regional average for fishers is 331,545 _pesos_ (INE 2010). The Peñuelas MA is not only innovative, but also institutionally well functioning. It has a generous attitude towards other fisher organizations – sharing their resources with three of them – and a well-developed internal social welfare system that helps fishers' families as well as the community. Peñuelas' social welfare includes support for elderly, widows and fatherless children, social activities (local school, women's football, sports club for children), medical costs, and in connection to important occasions (children's school equipment, Independence Day, and Christmas).
Peñuelas' special ways of organizing the fishing, marketing and system of shared responsibilities have attracted attention and invitations to speak in southern Chile and Peru.
**Punta de Choros**
Punta de Choros association in La Higuera municipality has two MAs: Punta de Choros and Isla Choros, with a total of 1,000 hectares, 160 male members and 83 privately owned wooden artisanal boats with outboard motors. Although the two _caletas_ that the association administer are rural, they have a good infrastructure with a small dock, electricity and running water (though not a sewage system). The _caletas_ have some restaurants and lodgings resulting from the latest years' tourism development.3 The organization is headed by a board, and like Peñuelas it has a number of commissions taking care of MA operations. Here, too, the internal social welfare system is generous; it includes support for bank and domestic loans, support for funerals, widows/partners of members, occupational diseases, medical recipes, dental costs, sports and recreation. (3. Less positive is that the water quality is on level C (too contaminated for catch to be exported), but the association is in the process of improving it to B (processed products can be exported).
The MA mostly catches the _loco_ , extracted by divers at 25 meters below the surface. Because _loco_ management had positive results, they have also started fishing _lapas_ (keyhole limpet), sea urchins and clams. The extraction of _locos_ here reaches levels hardly ever reached elsewhere. This privilege has allowed Punta de Choros to diversify their activities with local ecotourism and embryonic small oyster aquaculture for local gastronomy. The organization has bought 30 fibre boats for tourism, driven by less-contaminating gas, which attracts 25,000 tourists during the high season (Interview Avilez 2008-11-24). The association's strong economic base has, with State support, also allowed it to acquire their own factory to process their resources. Run within a recently formed cooperative, the factory provisionally employs seventeen fishers from Coquimbo to remove the shells professionally and eight local women, being taught by the Coquimbo fishers how to do this job without damaging the oyster. The long-term plan is to hire fishers' families and create additional jobs in the community.
Avilez links the strong performance of his organisation with an internal discipline to protect the long-term equilibrium of the ecosystem. "We think the levels [of resources] are sustainable," he said (Interview Avilez 2011-08-19). However, he worries that the association lacks enough people who are ready to take on leadership. People are afraid of failing, he adds.
Fishers in Punta de Choros are thriving. Out of the 160 members, 100 have their own cars, and about 70 percent own their own houses – many of them several in various places. "That shows how well we do," Avilez says. Avilez is also the vice president of a regional fisher federation and one of six chosen counsellors under the mayor in La Higuera municipality. That he has become a member of the establishment has facilitated the _caletas_ getting electricity and other modern equipment. The La Higuera municipality has also attracted 183.382 million _pesos_ (US$350,000), based on the yearly average exchange rate) in funds for new infrastructure, equipment, research and development, more than any of the other six municipalities in the region (Sernapesca 2008).
The average monthly income from _locos_ and _lapas_ (the main target species) for an MA fisher in Punta de Choros from 2000 to 2007 was 157.500 _pesos_ (US$252), with a medium catch of 320.000 units. Including also the incomes from sea urchins, clams and tourism, the total monthly income for a Punta de Choros fisher was 777.100 _pesos_ (US$1.243); even higher than in Peñuelas. Looking only at _loco_ extraction in 2008, it was as high as 740.000 units. During 2010-2011, it was even higher – at its highest peak ever – on 1.270.000 units!
**Economic-institutional-conservation as an upward spiral**
For fishers, the shift from open access to use rights, and from individualism and rivalry to organized and participative collectivism achieved through the TURF system, have brought many favourable changes. The TURF system has strengthened and empowered fishers locally, regionally, nationally and internationally. Fishers now have regular interactions with researchers, officials and international actors, something totally new in fishers' lives. In the better off MAs, they also initiate new, diversified commercial ventures, and attract new investments for their villages or municipalities.
Peñuelas and Punta de Choros are MAs that are doing well economically, institutionally and, it would seem, also in term of conservation. International partners admire the leadership of these two MAs and point to them as good models for how to manage threatened coastal resources.
There seems to be a strong relationship between resource abundance, economic performance and institutional performance, which in turn can escalate in a continuous and repetitive process of diversification, self-empowerment, and ecological conservation. Peñuelas and Punta de Choros show the positive aspects that collective action can bring. The analyzed cases first and foremost show that human agency in the form of capable leadership and institutional skills are the key forces behind successful MAs. Therefore, there is hope for those MAs that are (still) performing poorly, granted there are resources and a market demand; much depends on the fishers themselves. However, the State also has an important role in building capacity and trust, and in helping less successful MAs emulate the more successful ones, thus fostering a process where MA organizations start strengthening each other.
**References**
Gallardo, G. L., and E. Friman. 2011. 'New Marine Commons Along the Chilean Coast. The Management Areas (MAs) of Peñuelas and Chigualoco', _International Journal of the Commons_ (5)2:433–485.
INE 2010. Censo Nacional Pesca y Acuacultura. http://www.ine.cl.
La Tercera 2009-01-27. http://latercera.com/contenido/730_96387_9.shtml.
LGPA. 1991. Ley General de Pesca y Acuicultura, No. 18,892.
Orensanz, J. M. (Lobo), A. M. Parma, G. Jerez, N. Barahona, M. Montecinos, and I. Elias. 2005. What are the Key Elements for the Sustainability of S-Fisheries? Insights from South America. _Bulletin of Marine Science_ (76)2:527–556.
Qashu, S. 1999. "Analysis of Marine Resource Conflicts in Two North Central Chilean Fishing Villages". Masters Thesis at Oregon State University.
San Martín, G., A. M. Parma, and J. M. (Lobo) Orensanz. 2010. The Chilean Experience with Territorial Use Rights in Fisheries. In _Handbook of Marine Fisheries Conservation and Management, _eds. R. Q. Grafton, R. Hilborn, D. Squires, M. Tait, and M. Williams. Oxford. Oxford University Press.
Sernapesca 2009. _Anuario estadístico de pesca._ http://www.sernapesca.cl.
Sernapesca 2008. Informe Pesquero Artesanal, Servicio Nacional de Pesca, Región de Coquimbo.
Subpesca and Montoya, M. 2007. Subpesca: Diagnóstico Económico de la Pesquería del Recurso Loco (2003-2006).
Zuñiga, S., P. Ramirez, M. Valdevenito. 2008. Situación socioeconómica de las áreas de manejo en la región de Coquimbo, Chile. _Latin American Journal of Aquatic Research_ 36:1.
UCN 2000-2001. ESBA Peñuelas.
**Interviews**
Avilez, O. 2008-11-24; 2011-08-19.
Guzmán, P. 2008-11-24.
Subpesca/Montoya, M. 2011-08-26.
**Gloria L. Gallardo Fernández** _(Chile/Sweden) is associate professor in sociology working at Uppsala Centre for Sustainable Development, Uppsala University, Sweden. Her research is on common land property and common sea tenure in artisanal fisheries. _
**Eva Friman** _(Sweden) is researcher and program director at Cemus at Uppsala Centre for Sustainable Development at Uppsala University. She is an intellectual historian and ecological economist, with a research interest in history and theories of science, and interdisciplinary sustainability studies. _
# Community Based Forest and Livelihood Management in Nepal
_By Shrikrishna Upadhyay_
The reintroduction of a multiparty system in Nepal in 1990 after the peaceful revolution against the autocratic Monarchial Panchayat regime1 provided political space for communities to get organized and manage common pool resources, including water and forest. The state established new policies and funding mechanisms to support the evolution of new types of grassroots-based, self-governing institutions. The energies released from this self-governance movement resulted in a powerful expansion of community forests in Nepal, which has directly benefited about 1.7 million households, or about 32 percent of the population, organized into 16,000 community forestry user groups (CFUGs) that manage 1.2 million hectares of land, or about one fourth of Nepal's forested areas. (1. Editors' note: Panchayats were the lowest unit of the single-party political system designed to protect the absolute monarchy, which lasted for almost thirty years, until 1990.)
**History of community forestry**
Until their nationalization in 1957, forests belonged to the people. However, it was difficult if not impossible for the government to manage vast tracts of nationalized forests because it lacked any forest administration and it could not easily oversee remote and isolated rural areas. Communities therefore pressured the government to let them take control of forests, particularly in the hills. In 1978, this pressure led to a new forest regulation that transferred the management of some of the forests to local bodies, namely _Panchayats._ Despite this law, however, only 48,541 hectares of forests had been handed over by 1986.
The government recognized the need for active citizen participation in the design process for natural resource management by formally including community organizations in the government's eighth Five Year Plan (1992–1997) for effective delivery of public goods and services. The Forestry Act of 1993 and additional forest regulations in 1995 provided authority to (CFUGs) to manage forests. While the state retained ownership of the forests, it gave community groups the right to manage their forests.
**More sustainable livelihoods through community forestry**
Community management of Nepalese forests has resulted in many ecological and economic benefits, including increased crown cover and higher productivity. A recent study reported that 74 percent of the forest areas managed by the CFUGs was in "good" condition compared to 19 percent in "degraded" condition. Others have reported that CFUGs compare favorably to state forests in terms of changes in forest condition (Nagendra et al. 2008).
The impact of community forestry has fueled the production of wood, timber, fodder and organic matter and non-timber forest products (NTFP) while increasing forest cover and protecting the watershed, resulting in higher discharges of water. In addition, the revenue generated by the CFUGs has been used for financing microenterprises operated by poorer users and for village infrastructure projects. In some cases land-poor segments of the community have cultivated NTFP and other forest products. In other cases CFUGs have started forestry-related communitarian enterprises such as a plant to process medicinal herbs.
According to a study on impact on livelihoods (Ojha and Chchatre 2009) community forestry has had a positive impact on livelihoods and food security. Moreover, a longitudinal five-year study covering 2,700 households from 26 CFUGs in the Koshi Hills showed large-scale improvements on people's livelihoods and food security. It showed that 46 percent of the poor users improved their economic situations and long-term capacities due to their participation in CFUGs. A separate study found that the annual household income of forest users increased by 113 percent over a period of 2003-2008, from Nepalese Ruppias (NRs) 54,995 in 2003 to NRs 117,075 in 2008 (US$710 to $1,512). This represents a 61 percent increase after adjusting for inflation.
The importance of forests as reservoirs to preserve water is often overlooked. Yet that is where the linkage between forests, agriculture and improved quality of life is really noticeable. It is therefore important to foster a holistic, integrated multi-sectoral approach to natural resource management as the best way to improve the quality of livelihoods, especially for the poor. Participatory action research (PAR) involving primary stakeholders is an essential part of this management model because community groups can build their capacities for self-governance only if they can build trust and reciprocity and enhance their ability to resolve inevitable problems and conflicts.
Finally, CFUGs that effectively manage their forests have been able to provide carbon sequestration and environmental services, including the provision of higher-quality water to downstream communities. Under Reducing Emissions from Deforestation and Degradation (REDD), an effort is made to quantify such gains so that a proper compensatory mechanism can be made to reward CFUGs according to their contribution in improving the environment. A community Forestry Fund can help in regenerating forests and creating livelihood opportunities for users. The resources generated from carbon trading and environmental services can be placed into the fund.
As this account suggests, CFUGs could become a vanguard innovator for improved natural resource management in Nepal, building on the energies released by the communitarian movement since 1990. The constitution of CFUGs has provisions for intervening to improve the livelihoods of the poor.
**The challenges of community forestry in Terai**
In Terai, a very dry region in Southern Nepal, the forest cover is being depleted by farming in both the hills and the Indian part of the fertile Gangetic plain. Terai is home to people of Indian origin, an indigenous population called Tharus and people who migrated from hills. This mix of people of different communities makes collective action more difficult. Even though the state owns large blocs of forests, it cannot monitor and enforce usage, and so the forests are essentially open-access areas that anyone can use, especially in the North along the Churia and Shivalik mountain range. Most of the deforestation has occurred in state forests that have considerable quantities of hard wood of high commercial value. Saving Tarai forests is important because it will control river erosion and diminish the chances of flooding in Nepal and Northern India.
Community forestry offers a different, more positive model than conventional approaches. It is concentrated in a few areas where village communities are strong because of traditional bonds of trust and reciprocity due to people's similar ethnic backgrounds. Saving the Terai forest would require new incentive mechanisms for jointly involving people in the management of state forests and helping those people who must be excluded from the forest to find alternative energy sources to substitute for firewood. A coordinated effort among forest agencies, local people, local bodies and other stakeholders will be required to turn the tide of forest destruction in Terai, which currently runs at a rate of 1 percent per year.
**The federated organization of forestry user groups**
As the number of community forest user groups grows, however, it is raising complex problems that need to be addressed. CFUGs need stronger legislative and policy support, for example. This is difficult to achieve, however, because frequent changes in government and other political instability often result in policy changes that interfere with CFUGs' forest management and disrupt the continuity of planning. More generally, the political establishment has not always been supportive of the community model of forest management.
To address some of these concerns, the Federation of Community Forestry User Groups (FECOFON) was set up in 1995 to protect the interests of community forestry groups and to enable a more hospitable policy environment. The Federation organizes exchange programs between various stakeholders and, in the face of anti-CFUG policies or actions, it organizes protest rallies to petition the government for change. In addition, the Federation represents the interests of community forests in international organizations and seeks to advance the global agenda of the community forestry movement. At the same time, it provides operational support to various community forestry user groups in their villages.
**Promotion of renewable energy**
The favorable institutional and policy environment created by the government as well as a new energy program have made alternative energy sources very popular in rural areas. Due to several donor-funded programs, the use of several technologies such as biogas, improved cook stoves, solar and micro-hydro has expanded. Thanks to subsidies and other support systems, several hundred thousand biogas and cook stoves have been installed, which has considerably reduced pressures on forests for wood fuel. Fuel costs for users have also gone down. With carbon trading mechanisms in place, some technologies such as biogas and micro-hydro have now entered into carbon markets and can expect stable and sustainable financial support in the future.
**The need for institutional innovation**
The rise of multiparty democracy in 1990 has increased citizen participation and institutional pluralism in all walks of life. Bottom-up initiatives have spurred several types of self-governing institutions for natural resource management, infrastructure, education, health and microfinance. In many instances the State has been instrumental in providing policy and legislative support to encourage such initiatives at the grassroots level. For example, the state has created autonomous structures to fund and support grassroots-based initiatives, such as the Poverty Alleviation Fund (PAF), which was set up in 2004 with financial assistance from the World Bank. PAF has mobilized 14,000 community groups covering 500,000 poor households in the remote districts of Nepal to undertake activities that increase household income, build infrastructure, develop alternative energy systems and build community capacity. Community forestry has reached such a broad base that it needs to create a community forestry support fund that will focus on integrated natural management at the level of micro-watersheds. Such an autonomous fund could be shared between government and community forestry user groups in proportion to their contributions to carbon sequestration. The funds could come from forest revenues, income from provision for environmental services and carbon trading incomes.
**The way forward**
The record of CFUGs shows clearly that improved management of forests through community participation has the greatest benefits for the poor. We therefore need to move away from a conservation-based model to one that promotes sustainable livelihoods and focuses on food security, good nutrition, and improving quality of life of the poor. This is what we at Support for Poor Producers of Nepal (SAPPROS) are focusing on: participatory action research that can integrate management of land, forest and water at the community level. Farmers, users and beneficiary households all enable us to develop indicators of effectiveness, monitor progress and make improvements over time.
**References**
H. Ojha, L. Persha & A. Chchatre. 2009. "Community Forestry in Nepal," International Food Policy Research Institute (IFPRI) Discussion Paper 00913, A Policy Innovation for Local Livelihood. November 2009.
Bhattarai. S. 2009. "Towards Pro-Poor Institutions: Exclusive Rights to the Poor Groups in Community Management." Discussion paper, Forest Action Nepal and Livelihoods and Forestry program, Kathmandu, Nepal.
H. Nagendra, H. S. Pareeth, B. Sharma, C. H. Schweik and K. R. Adhikari. 2008. "Forest Fragmentation and Regrowth in an Institutional Mosaic of Community Government and Private Ownership in Nepal." _Landscape Ecology_ 23(1).
D.M. Griffin and K.R. Shepherd. 1986. "Human Impact on Some Forests of the Mid Hills of Nepal, Mahat." _The Journal of Forest and Livelihood Nepal_.
B.K. Pokharel, P. Braneey, M. Nurse, Y.B. Malla. 2007. "Community Forestry: Conserving Forests, Sustaining Livelihoods and Strengthening Democracy." _The Journal of Forest and Livelihood _(6)2:8–19.
Sappros. 2002. "Natural Resource Management Manual, Support Activities for Poor Producers of Nepal, Kathmandu." September 2002.
—————. 2002a "A Study of Rural Hill Potentials and Service Delivery Systems, Kathmandu." April 2002.
**Shrikrishna Upadhyay** _(Nepal) is the Executive Chairman of SAPPROS Nepal. His most notable books are_ Pro-Poor Growth and Governance in South Asia –Decentralization and Participatory Development _, and_ Economic Democracy through Pro-Poor Growth _, winner of Right Livelihood Award, 2010. http://www.sappros.org.np._
# Introduction: An Encounter at the Pink Lake
_Silke Helfrich: On February 2011, I visited the Pink Lake, located about one-and-a-half hours' drive from the capital, Dakar, together with another participant of the World Social Forum in Dakar. The scenery there was spectacular. Everywhere around the Lake, women were carrying heavy chests filled with salt on their heads to unload it on the shores. We had no clue how salt digging actually works, but a young Senegalese guide had made us curious to learn more. Algora Ndiaye, a native from Niaga, a small village near the Pink Lake, explained more about it. _
My grandfather was fishing here. But there are no fish anymore. Today, everybody can exploit the salt.
What do you mean "everybody"?
Well, just everybody. The lake is public and everybody is allowed to buy or rent a boat and start working.
Everybody, even strangers?
Yes, and they are not obliged to pay taxes either. This is a public lake and everybody has open access to its resources.
And there is no problem of "overuse"?
No....I guess because there is discipline and sincerity.
Really?
_We became more and more curious, and decided to sit down and talk to understand the situation. We talked for three hours and finally found out why indeed there is no overuse. But it took us several attempts to clarify and cross check our understanding with Algora Ndiaye. We were never really satisfied with his responses to the "overuse-question" and this was because the answer seemed so self-evident to Algora that he did not quite seem to understand why he should try to explain such basic things. He finally did, by accident. And the answer was simplicity itself. _
_Back in Germany, I invited Papa Sow and Elina Marmer to write about the artisanal collection of salt at the Lac Rose and explain why the overuse-answer is perhaps not that simple after all..._
# Salt and Trade at the Pink Lake: Community Subsistence in Senegal
_By Papa Sow and Elina Marmer_
In the last few years, both in academic circles and in the civil society, several authors (Bellah 1984; Putnam 2000; Etzioni 2004; Laimé et al. 2008) have expressed support for the restoration of community as a new form of social integration. In Africa, where some public institutions tend to be weak, this quest and the social and political contestations occur mostly at the community level. Communities are mobilized to become custodians of their environment (Scheffran et al. 2011) and there is a revitalization of initiatives for local development.
In this essay, we look at the case of the "salt collectors" of the Pink Lake, also called Lake Retba or Lac Rose, in the rural area of Dakar, Senegal, and the development of communities' sustenance. It is based on previous publications by Papa Sow (2002), which analyzed the common uses of the lake's resources.
The Pink Lake might be best known for being the former finishing point of the Dakar Rally. The lake is located between white dunes and the seaside in the northeast of Dakar in the rural area. It is fed by groundwater and receives a large supply of Sangalkam village backwater and the dry lakes of Thor and Yandal in the neighboring province of Thiès during the rainy season. Yet it is struck by a fragile ecological balance. With a depth of only three meters, the lake is quite flat and the salt concentration of 380 grams/liter is higher than that of the Dead Sea (340g/l). In 1990, the area of the Pink Lake was estimated to be four square kilometers. In 2005 it had shrunk dramatically to about three square kilometers.
The Lake has been on the UNESCO World Heritage Tentative List since 2005 because of its unique pink color. Some scholars argue that the symbiosis of the dune reflection, high magnesium chloride content and a bacterial carotenoid1 give the kind of red, pink or orange pigmentation (M'Baye 1989). (1. Editors' note: Carotenoids are tetraterpenoid organic pigments that are naturally occurring in the chloroplasts and chromoplats of plants and some other photosynthetic organisms like algae, some bacteria, and some types of fungus. Wikipedia entry, "Carotenoid," at https://en.wikipedia.org/wiki/Carotenoid.)
In the 1970s, in response to persistent droughts and economic hardship, locals began to extract and sell salt from the lake in a self-organized way, initially to supplement their families' income (Sow 2002). An estimated 5,000 people are now working and networking around the lake. Their livelihoods depend on the lake, and their jobs represent niches that local authorities cannot possibly fill through employment policies.
The "salt diggers" have divided the lake into four adjacent sections, Khaar Yaala, Khoss, Virage and Daradji, which is where most economic activity occurs. "Can the salt diggers in the Pink Lake be described as 'commoners'?" the editors of this book asked us.
**Artisanal techniques and self-organization**
Salt collection techniques practiced at the Pink Lake differ from various traditional and modern practices in Senegal (Sow 2002). To collect the product, salt diggers and porters step chest high in the water. The tools they use are simple: basins, sieves, shovels and spades, canoes with paddles called "niosse." The canoes are usually leased from wood traders and transferred to the extractors' ownership, who pay them either in-kind (five to six bowls of salt a day) or in cash. A new factory-made canoe costs 120,000-130,000 CFA (about US$250 in 2012). Salt diggers earn about 10,000 CFA/day (about US$20).
The diggers leave a part of the lake dormant for six months so the salt can regenerate. Areas of digging are then changed twice a year, generally in April and October. Machines and engines are not permitted for harvesting.
Extractors come from different backgrounds and social status, but generally they are peasants and harvesters who have abandoned their seasonal agricultural activities to dedicate themselves to salt digging. Most of the time, this job is a short-term activity used to earn money to migrate to Dakar or other West African countries to set up a business, and even to Europe. Tasks are divided among men, women and girls. Extractors are mainly men who dig the salt with large sticks and fill the boats. Women unload the heavy, wet, black salt from the boats. Young girls sell crafts on the shore and at nearby bungalows and hotels. Some men, called "Kola-kola," bag the dried, now–grey or white salt after it has been iodized. Beside locals, other diggers include migrants from the Diourbel region of Senegal and from Guinea-Bissau and Mali.
The Management Committee (MC), composed of 18 members of the five surrounding villages, was founded in 1994. It organizes the salt-extraction and commercialization, and aims to improve these activities by organizing collective actions. Each member is elected by its village organization (of different backgrounds and types) to represent its interests; a variety of local organizations also take part. Every three months, the Committee holds a general meeting where the activities are evaluated and new decisions are made. All Committee members get compensation for their commitment (the President and the Secretary General seem to be better paid). Although women play an important role at the site, they do not hold any positions in the MC.
The MC is involved in outreach activities, including salt iodization in partnership with the World Food Programme (WFP), UNICEF and NGOs from Senegal and abroad as well as with the state ministries for the environment, commerce, health, industry, etc. The Committee lobbies to help salt diggers to know their rights and can sometimes exert pressure on local authorities.
According to this Committee, salt production was estimated to be 50,000 - 60,000 tons in 2011. The production peak is during the dry season, and drops off during the rainy season ( _hivernage_ ). The quality of salt varies throughout the year, with the best, coarse salt harvested in June-July. Over 70 percent of the salt is exported to Ivory Coast, with the rest sold to Mali, Benin, Burkina Faso, Guinea Bissau, Guinea Conakry, Congo Brazzaville, São Tome, and also to Europe, where it is used to de-ice roads in winter. In 2011, the price of salt was 25-30 CFA per kilo. The MC, which did not wish to disclose the details, receives a kind of tax from the buyers/traders for each ton of salt sold.
Since none of the salt-extraction companies provide paper pay stubs, workers' rights are constantly violated. There are no guaranteed wages, contracts or other legal agreements between employers and workers. In this context of conflict and simmering tensions that neither the State nor local governments can address, the MC was born to oversee and regulate the economic and social activities around the lake. The MC provides a kind of inter-local solidarity among migrants and other vulnerable, economically disadvantaged workers while also socializing the risks linked to the hard work of salt extraction. According to the MC, there is a common fund in which each salt digger contributes an amount of money and can take a portion as needed in case of disaster or accident. Here we see a "forced transfer" of responsibility from the State to the Committee for "risk coverage" related to employment. Although the Committee has managed to downplay the problems, it must be recognized that the responsibilities that it has endorsed generate new social and political uncertainties, some of which are described below.
**Environmental uncertainties and conflict management**
_Land control and regulations_ : There is much confusionabout land tenure at the Lake (Traoré 1997). The Lake is officially recognized and classified as a mine by the State of Senegal, but the State does not collect royalties on its use. Taxes are only collected from hotels, tourism and art and craft vendors. A number of laws since the 1970s has transferred power to local authorities, increasing their responsibilities over natural resources and the countryside. This decentralization of authority has given rural communities autonomous spaces for their own initiatives for both public and private actors. Booming construction and urbanization around the lake have interfered with water runoff, and shells from the lake used in construction and industry have also caused ecological harm. The man-made degradation of the environment and the risks that this represents for salt diggers attract little attention. However, local authorities in cooperation with the state are working on the establishment of a "green curtain" to prevent the silting of the lake by planting trees on the adjacent dunes.
_Health problems and "debauchery"_ : Despite the use of shea butter to protect their skin, salt collectors complain about various skin problems. According to beliefs, rheumatoid arthritis can by treated by bathing in the Lake. Local lobbies and traders have not yet found opportunities to use such healing properties commercially (as some European countries and Israel have) by offering medical bath therapies.
With the salt production boom, much banditry and "debauchery" suddenly appeared. One of the most-wanted fugitive companions of "Ino," a famous Senegalese gangster, was arrested at the site while working secretly as a salt "collector" two years after being accused of a 1994 murder. The MC appealed to remove what they called "unhealthy places," to prevent crime. In 2004, local authorities ordered a "clean up" of Pink Lake. The main reason given for eviction was the construction of new rental homes around the lake. So it was somehow "hunting poverty a step further." Bulldozers came and destroyed the "village of the harvesters" – the temporary settlement of the workers who used to camp on the site – and authorities made them move to surrounding villages and let them come to the Lake only to work.
**Protection of the integrity of the salt diggers**
Senegalese labor regulations are inadequate for protecting property and individuals, so salt diggers at the Pink Lake must provide their own security. Workers themselves have set up checks and penalties for failures to adhere to regulations and local norms, but the legal or juridical scope is quite limited, so sanctions are applied only to existing normative or customary obligations.
The credibility of the system set up by the Committee (and by extension the salt diggers) is based on the regular inspection of conditions of work activities, the strong support by all stakeholders (Rural Council, organizations of the surrounding villages, salt diggers, etc.) and their ability to report breaches. One of the main indicators of the effectiveness of collective action is the ability to lower litigation and conflicts brought in front of what seems to be actually the only "legal" and "recognized" authority: the MC. Some examples of conflict resolutions: If somebody is accused of robbery and the crime is proved, the MC sanctions that person by excluding them from working on the site for six months. If somebody is caught in battle or serious dispute he or she may pay 5,000 CFA and be excluded for three months.
**Conclusion**
The salt diggers are serious about environmental responsibility in their work, and the Management Committee representing them imposes strict measures to prevent overuse of the lake. These measures include ley harvesting (seasonal regeneration) and prohibition of engine use for salt harvesting. However, no studies have been done to evaluate the efficiency of this approach, and there is no information on regulations of the number of the diggers. Also, hydrological and geological data of the lake have not been analyzed. Yet evidence of manmade environmental degradation, climate change and other threats at Pink Lake clearly exist. The precise causes and magnitude, however, have yet to be established.
**References**
Bellah R. N. et al. 1985. _Habits of the Heart. Individualism and Commitment in American Life._ Berkeley, CA. Harper and Row.
Etzioni, A. 2004. _From Empire to Community._ London, Palgrave Macmillan.
Laimé, M. et al. 2008. _Les Batailles de l'eau_. Terre bleue, Nice.
Mbaye, E. M. 1989. "Protection de l'environnement. La Cas du Lac Rose." Mémoire ENEA, Dakar. Unpublished.
Putnam, R. 2000. _Bowling Alone. The Collapse and Revival of American Community._ New York, Simon and Schuster.
Sow, P. 2002. "Les récolteuses de sel du Lac Rose (Sénégal). Histoire d'une innovation sociale feminine." In _Géographie et Cultures_ 41:93-113.
Scheffran, J., Marmer, E. and Sow, P. 2012. "Migration as a Contribution to Resilience and Innovation in Climate Adaptation: Social Networks and Co-development in Northwest Africa." _Journal of Applied Geography_. April 2012 33:119–127.
Traoré, S. 1997. "Les législations et les pratiques locales en matière de foncier et de gestion des ressources au Sénégal." In P. Tersiguel and C. Becker, eds. _Développement durable au Sahel,_ Karthala, coll. Sociétés Espaces, Temps: 89-102.
**Papa Sow** _(Senegal) is a Senior Researcher at the Centre for Development Research (ZEF), University of Bonn, Germany. He received his PhD in Geography from the Autonomous University of Barcelona, Spain. He was granted a Marie Curie Fellowship to research polygamous marriages in Europe in 2009–2011. His research involves socio-economic, environmental, climatic and demographic changes between Africa and Europe. _
**Elina Marmer** _(Germany) has a PhD in climate research and investigates climate adaptation strategies in African countries at micro and macro levels. She is a Marie Curie Fellow at the University of Hamburg and an associate member of the research group, Climate Change and Security, KlimaCampus, Hamburg._
# El Buen Vivir and the Commons
_A Conversation Between Gustavo Soto Santiesteban and Silke Helfrich_
_Gustavo Soto Santiesteban is a writer, semiotician and consultant on indigenous rights at various universities in Bolivia._
**Silke Helfrich:** Gustavo, _Buen Vivir_ (or _Vivir Bien)_ is an expression that has made its way into the constitutions of Ecuador and Bolivia, and has become an expression that would summarize an alternative project for civilization. Portuguese sociologist Boaventura da Souza even took up the slogan, "China or Sumaj Kuasay,"1 which is not self-explanatory. Can you help explain it? (1. Boaventura da Souza Santos. "Diversidades y cambios civilizatorios: ¿la utopía del siglo XXI?" FEDAEPS, FSM Belem. 2009.)
**Gustavo Soto:** _Suma Qamaña,_ _Sumaj Kuasay _and _Sumak Kwasay_ are Aymara and Quechua expressions that translate into Spanish as _Buen Vivir/Vivir Bien._ They __ are reused in the construction of a discourse that speaks of a horizon of purposes alternative to the current state of affairs, one that is neither " _21st century socialism"_ 2 nor "Andean-Amazonian capitalism."3 I think _Buen Vivir_ is a proposal aimed at making _visible and expressible _aspects of reality that are ignored by the dominant paradigm. It is a proposal from a radical and spiritual perspective of ecology, and is logically _incompatible with development and industrialization._ It speaks of the possibility of living in common, for which the very concept "development"4 is not only insufficient but mistaken. (2. Editors' note: "21st century socialism" is a political expression that gained currency ten years ago, particularly in the context of the World Social Forum. It is also frequently used in Venezuela by the administration of President Hugo Chavez. 3. Álvaro García L., Interview with Miguel Lora, www.bolpress.com, May 10, 2009. 4. See Vinod Raina's essay criticizing the concept of "development" in Part 2.)
Javier Medina, a philosopher dedicated to Andean studies, writes: "There is always more in reality than one can experience or express at any given moment. A greater sensitivity to the latent potential of situations, assumed as a sort of broader social paradigm, may encourage us to think about things not only as they are, in the Newtonian paradigm, but also in terms of where they are heading, what they may become" (quoted in Soto 2010). _El Buen Vivir/Vivir Bien _is the name given to something that is like a new principle of hope grounded in ancestral practices of indigenous communities in the Americas.
**Helfrich:** So, it is not surprising that Bolivia and Ecuador are the two countries where the debate on _el Buen Vivir_ is most alive. In Ecuador, 35 percent of the population self-identify as indigenous, and in Bolivia, 62 percent. In a take on the topic, Bolivia's ambassador in Germany, Walter Prudencio Magne Veliz, his country's first indigenous ambassador, said: "An indigenous person thinks more like a 'we' than as an individual 'I'." What does that "we" encompass?
**Soto:** _Suma Qamaña_ implies several meanings manifested in community life: the fact of animals, persons, and crops living together; living with Pachamama ("Mother Earth" – the water, the mountains, the biosphere) and finally living together with the community of ancestors ( _w'aka_ ). It is a community practice that finds organizational expression in the _ayllu_ , which articulates this "economy-life" in the _chacra_ – the rural agricultural space where reciprocity predominates. It is evident that these enunciations are made from the commons, from the community, from the first person plural, and not from "me," from the individual. Strictly speaking, the "individual" without community is bereft, orphaned, incomplete.
**Helfrich:** We find these ideas in many different cultures. It's not just one or the other. Things are not separate, but interrelated. Therefore, Javier Medina, a Bolivian philospher who is one of the most literate interpreters of the idea of _Buen Vivir_ , says it is a display of intelligence that "we Bolivians want to have the State and _also_ want to have the _ayllu_ , though they are two antagonistic magnitudes...." And he continues: "Our problem is that in not picking up on the civilizing nature of both, we confuse them, provoking the inefficiency of both.... At this point..., let's not have any more real State: follow the liberal Third World simulation, nor more real _Ayllus_ : in their place, docile social movements."5 In your opinion, does the _ayllu_ persist in contemporary Bolivia? Do they have like a "physical-social embodiment"? (5. http://lareciprocidad.blogspot.com)
**Soto:** The indigenous _ayllu_ , at the "micro-level," at the local level, persists in the Bolivian altiplano. It is founded on reciprocity more than on the market; on cultural identity more than on homogenization; on decision by assembly more than the electoral mechanism; on its _de facto_ autonomy and its relationship with the "territory," which is not the "land" – factor of production – but rather precisely the totality of the system of relationships.
**Helfrich:** Your description of the _ayllu_ is reminiscent of the concept of _commoning_ , which is discussed so much in this book and which expresses much better than the term _commons_ where the heartbeat of the debate lies. Both _el Buen Vivir_ and _commoning_ can only be thought of in their specific social context and as a social process. Indeed, it seems to me that both are more systems of _production in community and at the same time they produce community._
**Soto:** Yes, the _ayllu_ is much more than a "unit of production"; it is a system of community life which, if you will, "produces" community first. This has been possible precisely because the successive projects of the nation-state have, relatively speaking, failed to assimilate them.
**Helfrich:** In essence, what's the difference between the Andean conception of _el Buen Vivir_ and Western thinking?
**Soto:** Medina situates it in a schema which of course generalizes and is disjunctive, thus it is far from being an adequate case of complex thinking; it's like a map, which should never be confused with what happens in the territory itself. Between the poles there is obviously a long continuum.
**Helfrich:** _Homo mayeuticus_?
**Soto:** It refers to that way of living engaged in dialogue with the complex system of relations that is Nature. Nature is conceived of as a living being and not as a thing of which to make other things, and so it demands great interpretive skills. The interpretations are transmitted through oral expression, everyday experience, the creativity of textiles, ceramics, musical instruments, festive ritual – in sum, through an integral technical/cultural system.
**Helfrich:** What is the sociopolitical reality of the country in which this debate is unfolding?
**Soto:** Even though the new Constitution of the Plurinational State of Bolivia has been printed, that doesn't mean that the practices and meanings described previously will be carried out. To the contrary, the horizon of popular expectations is set forth in the 2010–2015 program of the Movimiento al Socialismo, MAS, which won the 2009 elections with 64 percent of the vote. That program continues being neodevelopmentalist and extraactivist. It articulates the Bolivian economy to the global capitalist interests of the 21st century (USA-EU+BRICS) expressed in megaprojects6 of energy, road-building and extractive industries. This agenda is encapsulated in the IIRSA (Initiative for the Integration of the Regional Infrastructure of South America _)_ , recently relaunched in its second phase by the BNDES, the National Development Bank of Brazil. (6. See Gerhard Dilger's essay on the Belo Monte mining operation in Part 2.)
**Helfrich:** ... an initiative that relies on what Eduardo Gudynas, the director of the Centro Latinoamericano de Ecología Social (CLAES), calls "neo-extractivism."
**Soto:** Exactly. And this strategy fosters the violation of the rights of _Pachamama_ and of the indigenous peoples – and the democratic citizen rights of informed participation in decision-making. _El Buen Vivir_ is not by any means a public policy that takes us towards that alternative horizon. Nonetheless, the complaints and resistances of indigenous communities against mining7 and oil projects, and mega-infrastructure projects geared to global and not local interests, suggest that not everything is lost in the process of change that Bolivia is undergoing. The communitarian logic that also exists in the Bolivian Amazon region is keenly expressed in the current eighth Indigenous March led by the communities of the TIPNIS (Indigenous Territory and National Park Isiboro Sécuro) and supported by the entire Bolivian indigenous movement (Amazonian and Andean).8 The goal is to save a unique ecosystem of the region, a way of life, to shine a light in practice on the post-developmentalist horizon for the 21st century, and which gives content to _el Buen Vivir_. (7. On the consequences of mining in Latin America, see also the essay by César Padilla in Part 2. 8. Editors' note: The eighth Indigenous March was brutally broken up by the Bolivian police. This led to the immediate resignation of the Secretary of Defense and huge social protests and criticism of Evo Morales. Several days later, construction of the road through the TIPNIS region was stopped.)
**Helfrich:** In the debate on the commons, I generally defend the slogan "beyond the state and the market," which does not necessarily mean "without state and market" – for we need a state that expands our spaces for community life.9 How would a state act whose mention of _Suma Qamaña_ were more than symbolic? What do you expect of the state in relation to _el Buen Vivir_? (9. See Gustavo Esteva's essay in Part 2 and Nikos A. Salingaros and Federico Mena-Quintero's essay in Part 5.)
**Soto:** I think that the expectation of a new Constitution of the "plurinational" state was precisely an expectation that the principles of _Vivir Bien_ would be translated into public policies. Nonetheless, the obstinate illusion of modernity10 continues to be the dominant grammar of the exercise of power in Bolivia. Indeed the concept of _Vivir Bien_ has even become trivialized in official propaganda: " _Oil exploration to live well [para vivir bien], hydroelectric plants in the Amazon to live well [para vivir bien],"_ etc _._ (10. See Ugo Mattei's essay on a "phenomenology of the commons" in Part 1.)
It is not a "betrayal" by the Morales administration but the expression of a historic mentality. Let me try to explain: The "revolution of 1952"11 promoted the transformation of the _indígenas_ into c _ampesinos,_ through mixing, the use of Spanish, _individual_ land ownership and the _market_ , and _the state-peasantry pact_ (1952–1974). That process had advocated modernization and national development by diversifying production and the industrialized exploitation of the natural resources in the hands of the state. The failure of that nationalist process led to the modernist neoliberal period, which was defeated by the popular insurgency of 2003. Nonetheless, in the last five years, the increase in international raw materials prices has given new life to the illusion of development based on the old nationalist extractivism. (11. The Wikipedia entry, "The History of Bolivia," notes that the 1952 revolution "introduced universal adult suffrage, carried out a sweeping land reform, promoted rural education, and, in 1952, nationalized the country's largest tin mines.")
**Helfrich:** _Buen Vivir_ seems to me both strange and familiar. Foreign because of the innumerable references born of a different culture and history. And familiar because it makes me think of commoning. Massimo De Angelis writes: "To turn a noun – commons – into a verb [commoning...] simply grounds it in what is, after all, life flow: there are no commons without incessant activities of commoning, of (re)producing in common. But it is through (re)production in common that communities of producers decide for themselves the norms, values, and measures of things."
Louis Wolcher also reminds us that speaking of the commons is not the same as speaking of conflicts over property rights. Rather, it is about "people expressing a form of life to support their autonomy and subsistence needs." In brief, "taking one's life into one's own hands, and not waiting for crumbs to drop from the King's table." Or from the table of the nation-state. At the same time, he fears that in the western world we are in an unlucky position, because "we no longer have cultural memory of another way of being."
**Soto:** This (re)surgence of social theories and horizons that engage in dialogue with the alternative initiatives and quests of the "first" world is very interesting for Latin America. During the 20th century, for example, the discourse, organizational forms, strategies, and vision of progress or "change" – if you want to call it that – drew on the "lessons" of European social and political processes. Now, on this Amerindian side, they drink from the communitarian fountains of the Americas which, we always forget, also inspired the first European utopians. Yet, as you say, it is not just a question of discourses but of practices which, for different reasons, have withstood centuries, and that are the condition that makes it possible to build another truly inclusive social order, one that is for everyone. It is not at all simply a question of Indigenous Areas or Protected Community Areas. What is needed is a change in paradigm.
**References**
Soto, Gustavo S. 2010. "La espuma de estos días," April 21, 2010, available at
http://outrapolitica.wordpress.com/2010/04/21/la-espuma-de-estos-dias.
**Gustavo Soto Santiesteban** _(Bolivia) is a writer, semiotician and consultant on issues of indigenous rights. He is researcher at the Center of Applied Studies of Economic, Social and Cultural Rights (Centro de Estudios Aplicados a los Derechos Económicos, Sociales y Culturales). He is a lecturer of semiotics, philosophy of language and epistemology at different Bolivian universities._
_"Nobody knows so much as we all do together."_
Inscription on a Danish town hall door
# PART FOUR
****
KNOWLEDGE COMMONS
FOR SOCIAL CHANGE
# The Code is the Seed of the Software
_An Interview with Adriana Sánchez by Silke Helfrich_
**Helfrich:** _Adriana, could you briefly introduce yourself?_
**Sánchez** : My name is Adriana Sánchez. I am from southern Costa Rica, a very beautiful territory, which has been gradually ravaged by the intensive agriculture of companies such as the United Fruit Company. I studied language and literature at a self-managing professionals' cooperative specializing in knowledge management, technology and society. We support social and solidarity enterprises. This enterprise is called Sulá Batsú, a name in the Bribrí language that means "creative spirit." I also work voluntarily in the Cultura Libre de Costa Rica community, which brings together artists, developers of free software, farmers, and persons who believe in the importance of sharing knowledge.
**Helfrich** : _In other words, you are farmers and programmers who share the same space?_
**Sánchez:** All of us persons in a social formation, be it a country, a community, or a work team, share interests and a sociocultural heritage. Cultura Libre de Costa Rica hosts a forum in which creators of culture from different sectors who share this heritage can sit down to discuss, reflect, and collectively construct new ways of distributing and protecting their works. Partnerships are created which for many people may be unexpected, but in our case they are the reason for our work: both the software developer and the farmer are bearers of a culture and knowledge that are beneficial to their entire communities, and as such they not only have the right but the duty to reflect on the social change that their activities can generate.
**Helfrich:** _What do software and seeds have in common?_
**Sánchez** : The seed is the germ of life. From it is derived food, clothing, shelter – in short, well-being. It is a small repository that contains centuries of history and knowledge. I've always liked the comparison between free software and seed because it helps us better understand the principle of liberty. If we restrict access to knowledge – independent of whether it is knowledge of how to farm or how to program – we restrict the capacity to create. When a company patents a seed and manipulates it to remove the genetic information it carries within so that it cannot reproduce alone after the harvest, it is restricting the harvest. Shutting off access to software code keeps other creative persons from being able to contribute their knowledge to improve it and adapt it to their needs and those of the persons around them.1 (1. Editors' note: Sanchez refers here to a technology patented by Monsanto that uses genetic manipulation to prevent the germination of the seeds, which is widely known as "terminator technology." Seeds with this altered genetic makeup can no longer produce new seeds that can be shared and used for the next year's harvest. Instead, farmers must always buy new, proprietary seeds each year.)
**Helfrich:** _Why do people want to improve a software program? Why contribute knowledge in that field? Does that change people's quality of life?_
**Sánchez:** Well, there's one omnipresent example: the Internet. During the first years of its development, people needed to have in-depth knowledge of software in order to make use of digital tools (websites, applications, repositories). For almost 10 years now, the digital tools available online can be used by the vast majority of people, including those who do not know how to read and write. Access to new end-user-friendly technologies around the world is improving their quality of life day by day.
Imagine a woman, a single mother, from a rural area in any country of the South: in those countries, services are centralized in the urban areas and this woman will have to travel several hours, even days, to conduct an administrative transaction. Now let's imagine a rural online center that lets her perform that same transaction through the government agency's website, without having to leave her children alone or miss hours or days of work. That is an improvement in quality of life.
Now, let's imagine a rural online center that uses free software and is operated from and by the community. It is not a traditional online center; it's a center where knowledge is not only shared, but is constructed by the people, based on their experience and their needs. This is how free software is designed. If we are able to transmit that way of building collectively to other spaces, there is a value-added that no proprietary tool will ever have: the value of belonging, of community, the value of improving all together to lift everyone up, and independent from "market supply." In other words, autonomy.
Software code should be made freely available to that end. And I think the state should promote free software in public institutions and support the initiatives to universalize information and communications technology services, not just because of the low cost, but also because of their security, versatility, and above all their potential to stimulate learning and develop people's capabilities.
**Helfrich:** _And this value-added, how is it transmitted where you work, in southern Costa Rica? What do the small farmers have to say about it?_
**Sánchez:** In general, promoting free software in these communities is simpler than we might think, for many of the people you work with don't know other operating systems. In addition, developing capacities in the use of Free/Libre Open Source Software (FLOSS) goes beyond mere technical training. It is highly related to social impact. Working on a farm is not just planting the crops. Farmers need to keep track of spending, inventories, calendars, clients and supplier databases. In that sense, agriculture and software go hand and hand, and one who tills the land can easily appreciate that the community and every community member benefits most if the community as a whole – and not third persons – control its own seed and software.
Based on my experience in this area, I can say that a strict process of developing capacities – as enabled by free software – can mean a substantial change in the life of a person and his or her family. And having tools not encumbered by use restrictions, that are free, and that operate swiftly and effectively on old equipment – which is what one generally finds in the countryside – is always a very attractive possibility.
**Helfrich:** _What does the idea of the commons contribute to your work?_
**Sánchez:** At this time, intellectual property laws shut down the flow of knowledge. Knowledge is discussed and generated in "ghettos," where it does not draw on what other persons know. It is so specialized that at the end of the day it doesn't have any day-to-day application. When we work from the perspective of the commons, respecting free access to knowledge and promoting the notion that all people should be able to share in what is known, knowledge is made horizontal. In other words, the farmer's knowledge is as valuable as the software developer's; both benefit the lives of others. When we become empowered through the value we accord to what we know, we can more reflexively access our resources and our rights. This improves our livelihoods.
**Helfrich:** Can you give me a specific example?
**Sánchez:** Oftentimes, especially in the North, local knowledge is understood as limited in scope. It applies in rural areas, for example, or it applies to poor people. Local knowledge is not that: it is what is generated in a locality, and this may be my office, my school, my orchard, or my hackerspace. In these spaces, we constantly build on what has been transmitted to us. We transform that knowledge into any number of tools that enable us to improve our quality of life.
A group of people are working in agriculture and producing organic foods in northern Costa Rica. They have a project for the preservation of creole seeds. Since 2008, they have been selling processed products, such as crackers and flour. They make them in solar ovens that they themselves designed to tap this form of energy, which we usually fail to use. This group is thinking about sharing the instructions for building ovens with persons from other parts of the country, so they can use them for their own benefit. Open licenses such as those used by the free software community2 have seemed to them a good option precisely because they make it possible to put conditions on the release of that knowledge, guaranteeing that it will be protected from the big companies that devour local knowledge and then patent it for their own profit. (2. See also Christian Siefkes's essay on commons-based peer production in Part 4 and Benjamin Mako Hill's essay on free software in Part 4.)
Although licenses like the Creative Commons licenses 3 were designed to protect digital works, they also work for many other processes and creations. They help guarantee that such works are kept within the public sphere, so that that which has always been ours will continus to be ours. (3. See also Mike Linksvayer's essay on Creative Commons licenses in Part 4.)
**Helfrich:** _Thank you very much, Adriana._
**Adriana Sánchez** _(Costa Rica) is a philologist. She is also a practitioner in the field of social uses of ICTs. Working at Sulá Batsú R.L, she is part of the "Cultura Libre CR" group, a meeting point of academics, artists, FLOSS developers, producers, farmers and other cultural managers from the country, promoted by Creative Commons. _
# The Boom of Commons-Based Peer Production
_By Christian Siefkes_
In 1991, an undergraduate Finnish computer science student, Linus Torvalds, had a surprising idea: he began to write a new operating system on his PC. His initial goal was to be able to try some things that weren't possible with the operating systems then available to him. After several months of tinkering, Torvalds noted that he had developed a system that could be useful for others too. He announced his work on the Internet and asked for feedback about features that people would like to see. Some weeks later, he put the software online. Now anybody could download and use his code. It was also possible to adapt it to better fit your needs, if you knew how to program.
The software was met with enormous interest, since the operating systems available at that time offered limited possibilities or were very expensive. And they were developed in companies that normal users couldn't influence. That someone used the Internet to develop an OS, explicitly inviting people to join his efforts and freely sharing the results, was unheard of. Only two years later, more than 100 people were helping develop the software now called _Linux_ (a wordplay on "Linus" and "Unix"). Richard Stallman's GNU Project was another initiative that had already developed a number of useful system components. The combination of the GNU tools with the Linux kernel resulted in an operating system that was both useful and free.
Today, GNU/Linux is one of the three most popular operating systems (next to Windows and Mac OS), used by millions of people. Linux is most popular with companies that need reliable servers. It is frequently used for high-performance applications – more than 90 percent of the world's 500 fastest supercomputers use Linux.1 (1. See http://top500.org/stats/list/37/osfam)
The success of GNU/Linux is based on the fact that – like all _free software_ – it is a commons that everybody can use, improve and share. The freedoms that make free software a commons were first defined by Richard Stallman in the 1980s. He designed the _GNU General Public License_ (GPL) as an exemplary license to legally protect these freedoms. The GPL (also used by Linux) remains the most popular free software license.2 Another crucial factor is the community that coordinates the development of the operating system. The open, decentralized, and seemingly chaotic way of working together pioneered by Torvalds and his collaborators became known as the "bazaar" model of software development (Raymond 2001). It contrasts with the top-down, hierarchical, meticulously planned "cathedral" style of development, once used for erecting the medieval cathedrals but also characteristic for software development in many companies. (2. Regarding alternative licenses and their compatibility with each other, see Mike Linksvayer's essay in Part 4.)
With free software, there is no strict boundary between users and developers. Many participants simply use the software, but some help to improve it, either occasionally or even regularly and intensely. The participants themselves decide whether and how to contribute. Participation is not obligatory, but quite easy if you want to get involved. If you deviate from the customary practices and community guidelines, you risk being "flamed": others may publicly and harshly point out your inappropriate behavior. That's the worst that can happen; more severe sanctions such as formal exclusion are very rare.
**Commons, contributions and cooperation**
The GNU/Linux story reveals the essential characteristics of _peer production._ Peer production is based on commons: resources and goods that are jointly developed and maintained by a community and shared according to community-defined rules.3 The "four freedoms" are the most important rules that the free software community has given itself: everybody may use free programs for any purpose, adapt them to their needs, share them with others, improve them and distribute the improvements.4 (3. For an extensive discussion of peer-to-peer production, see Michel Bauwens' article in this volume in Part 4. 4. See The GNU Project (2010). The Free Software Definition, at http://www.gnu.org/philosophy/free-sw.html)
The General Public License ensures that these four freedoms are preserved in all future versions of a software program. If I modify and distribute a GPL'ed software, I must publish my own version under the GPL. This principle is called "copyleft" since it turns copyright on its head. Instead of granting exclusive rights of control and exploitation to the authors, it ensures that all versions of the software will remain in the commons forever.
Peer production provides the capacity to create new commons and maintain and improve the existing ones. Other resources, such as computers, are typically privately owned, but they can be used to contribute to the shared goals of a project, not for financial gain.5 (5. Commons are often hybrids of private property and public property that co-mingle private and joint use. See for example the essays by Liz Alden Wily in Part 2 and Mayra Lafoz Bertussi in Part 3.)
While production for the market aims to produce something that can be sold, the usual goal of peer production is to produce something useful. Projects have a common goal, and all participants contribute to that goal in one way or another. They do so because they share the objectives of the project, because they enjoy what they are doing, or because they want to "give back" to the community. This differs from market production which is based on exchange.6 (6. For a detailed discussion of the differences between market logic and the logic of the commons, see Stefan Meretz's essay in Part 1 and Silke Helfrich's chart of comparisons in Part 1.)
In contrast to companies and entities in planned economies, peer projects don't have command structures. That does not mean that they are unstructured; on the contrary, most projects have "maintainers" or "admins" who keep the project on course and decide which contributions to integrate and which to reject. However, nobody can order others to do something and nobody is forced to obey others. The participants are "peers": they voluntarily cooperate as equals and no one is subordinate to anybody. Jointly they develop the rules and forms of organization that are most appropriate for their cooperation.
**Free culture and open hardware**
Meanwhile, countless other projects use an open style of cooperation similar to GNU/Linux. The free encyclopedia Wikipedia is the best known example. Ten years after its inception, there are now Wikipedias in more than 200 languages; the English edition alone has more than three million articles. Linux and Wikipedia are important examples of two communities – the _free software movement_ (also called _open source movement_ ) and the _free culture movement_ – that are much larger than their respective flagships. There are hundreds of thousands of free software programs and millions of works (texts, images, music, even movies) published under Creative Commons licenses.7 (7. The degrees of freedom granted by the various Creative Commons licenses vary; not all of the licenses assure all "four freedoms" guaranteed by free software. See Mike Linksvayer's essay in Part 4.)
_Open hardware_ projects design physical products by freely sharing blueprints, design documents, and bills of materials.8 In the field of electronic hardware, the Italian Arduino project is especially well known. Many other projects use or extend its products. Free furniture designs are created by Ronen Kadushin and by the SketchChair project. The Open Architecture Network and the Architecture for Humanity project design buildings whose purpose is to serve the needs of their inhabitants, rather than making building companies rich or architects famous. OpenWear is a collaborative clothing platform that supports people in becoming producers and finding collaborators. Wireless community networks organize freely accessible wireless networks in many parts of the world. The Open Prosthetics Project develops prosthetic limbs. It was started by a former soldier who had lost a hand in war and was unable to find a commercially available prosthesis suiting his needs. A special goal of the project is to improve the medical treatment of people who cannot afford to pay a lot, e.g., in the Global South. (8. See Benjamin Mako Hill's essay on "open" versus "free" in Part 4.)
No production is possible without means of production. The RepRap 3D printer has received a lot of attention because it can "print" many of its own parts. Other free 3D printers are the Fab@Home and the MakerBot, around which a large community has formed. Thingiverse is a platform for sharing 3D designs for such printers. Projects such as FurnLab and CubeSpawn design CNC (computer-controlled) machines for processing wood and metals; their aim is to facilitate "personal fabrication."9 (9. The author thanks Stefan Meretz for his help is compiling this project collection.)
The openness of open hardware generally leads to a high number of adaptations and variants, since everyone can participate and contribute their own improvements. Hence, whatever your taste or needs, it's not unlikely to find that some other person with similar preferences has already created a suitable variant and published it online. This enhances the chance of finding solutions for specialized, niche needs neglected by commercial players because the expected profits are too low.
**The emergence of community-based infrastructures**
You cannot create things from designs and blueprints alone – physical resources and means of production are needed as well. Technological advancements have made various production processes less expensive and more accessible. Today, hobbyists and peer projects can utilize machines they built for themselves or bought inexpensively to produce items whose production would have required capital- and labor-intensive factories just a few decades ago.
Of course, it is neither possible nor reasonable for everyone to have all the equipment necessary for production in his or her own basement. It makes more sense for productive infrastructures to be community-based, i.e., jointly organized by the inhabitants of a village or neighborhood. There are already examples of this. For example, the inhabitants of the South African town Scarborough set up a decentralized "mesh network" that allows them to access the Internet and the telephone network. Necessary equipment such as wireless routers are bought by individual citizens. No single person or entity owns the network or large parts of it, and therefore nobody is in a position to shut it down or censor it. The networks run on free software and a large part of the equipment is developed as open hardware.
Community-organized production places are emerging as well. The global Fab Lab network spans over 50 cities on five continents. Fab Labs are modern open workshops whose goal is to produce "almost anything." That's not yet realistic, but they can already produce furniture, clothing, computer equipment (including circuit boards), and other useful things. So far, Fab Labs mostly employ proprietary machines whose design is not open, making it impossible for people to produce their own versions or to improve them. But parts of the community are trying to overcome this limitation. Their goal is the creation of an entirely commons-based production infrastructure, a network of free and open facilities that utilize only free software and open hardware. This would pave the way to lessening people's dependency on the capitalist market, with commons-based peer production producing more and more of the things that people need.
**Two concepts of plenty**
But can peer production really get that far in the physical world? Won't it be stopped by the fact that natural resources and the Earth's carrying capacity are limited? It would be impossible to produce and use seven billion cars (one for everybody) – the required gasoline would quickly exhaust the Earth's remaining oil reserves, and the resulting CO2 emissions would dramatically accelerate global warming (Exner et al. 2008). However, producing bicycles or e-bikes for everyone should be possible without breaking the limits of the Earth's carrying capacity. And it should be equally feasible to produce other things in sufficient quantity that don't require too many resources.
Digital, Internet-based peer production has produced astonishing amounts of software and contents – a digital plenty that benefits us all. In the physical world, a similar plenty for everyone must seem impossible if one equates plenty with lavishness and wastefulness. But plenty also has another meaning: "getting what I need, when I need it."10 (10. On the subject of plenty, see the conversation between Brian Davey, Wolfgang Hoeschele, Roberto Verzola and Silke Helfrich in Part 1.)
Things that are quickly thrown away won't satisfy more needs than things that you keep longer. Commons-based peer production brings such a needs-driven conception of plenty for everyone into reach. It's not _things_ that matter, but _needs_ : the important point is not whether I have a car, but whether I'm able to freely move to other places and interact with other people.
Physical production is impossible without natural resources. Therefore, peer production won't be able to realize its full potential unless access to resources is managed according to its principles. Digital peer production treats knowledge and software as a commons. Likewise, physical peer production needs to manage resources and means of production as commons, utilizing them in a fair and sustainable way and preserving or improving their current state. For this it is important to find modes that ensure that nobody loses out and that everyone's needs (whether productive or consumptive) are taken seriously.
The challenge is huge, but the unexpected success stories of peer production—such as GNU/Linux and the Wikipedia—show that peer production can achieve a lot. And the long history of the commons contains many examples of the successful long-term usage of natural resources and of the successful management of user-built infrastructures. For the future of commons-based peer production it will be very important to bring together the perspectives and experiences of commoners from all areas – whether "digital," "ecological," or "traditional." They can learn a lot from each other.
**References**
Exner, Andreas, Christian Lauk and Konstantin Kulterer. 2008. _Die Grenzen des Kapitalismus_. Ueberreuter, Wien.
Raymond, Eric. 2001. _The Cathedral and the Bazaar._ O'Reilly, Sebastopol, CA, 2nd edition.
Siefkes, Christian. 2011. "The Emergence of Benefit-driven Production." In Proceedings of OKCon 2011, Berlin. http://www.keimform.de/2011/benefit-driven-production.
**Christian Siefkes** _(Germany) is a software engineer who lives in Berlin. His main research interest is the emancipatory potential of free software and other forms of commons-based peer production. He blogs at www.keimform.de. His publications include _From Exchange to Contributions _(Berlin 2007) and_ The Emergence of Benefit-driven Production _(Proceedings of OKCon 2011)._
# Copyright and Fairy Tales
_By Carolina Botero and Julio César Gaitán_
__
_Once upon a time... there was a fair young princess, full of virtues. A chevalier, charming, brave and handsome blue prince was willing to take on the adventure to be with her. The romance starts and goes on, and leads us to the long-awaited moment in which the two are wedded and the old "...and they lived happily ever after" is finally pronounced._
The fairy tales of any society express a set of values that the society cherishes and seeks to perpetuate. Vladimir Propp found over thirty recurrent leitmotifs in folk tales; they have come to be known as "Propp's functions." One of these is the wedding that seals the happy ending of the adventures (Propp 1928); the " _until death do us part_ " theme conveys the illusion of living happily ever. While this leitmotif may not refer to any model family, it does validate the idea of the traditional union of a man and a woman ignoring other options.
It helps to see how the mythological patterns of fairy tales underlie rational arguments, which can be assembled like Lego pieces in many different yet clearly identifiable positions. The deeper patterns will always be recognizable whatever the particular structure, which suggests that we should look to these deeper patterns and not just the superficial arguments. We now suggest thinking about the mythological patterns that justify and promote the legal concept of copyright, a cultural idea that focuses on the individual creator as the primary agent. This pattern can be compared with the presumption that traditional marriage is the only valid concept of romantic or sexual expression.
**Control as pattern**
Mainstream society constantly asserts that marriage is the way to go, that the family can only be composed of a man and a woman, and that its purpose is procreation. This idea is cast as a self-evident, natural fact. In the same vein we are told that without copyright no one will respect creative works, there will be no creativity and many jobs will be lost. Copyright is thought to be the only plausible scheme for guaranteeing a happy ending in the creative sector. But in fact, the wedding motif and the happy ending it implies are based on a specific family model, much as copyright law is based on an industrial, market-oriented model of cultural creativity.
From this viewpoint, copyright is seen almost exclusively as the only way to protect works of the human intellect. The presumption is that the copyright holder must control the use that others make of his or her works e.g., reproduction, modification, distribution and public communication in order to earn revenues to cover production costs. It is assumed that this is the only way to reward the creator. Here in Colombia, as in many other nations, copyright is regarded as the essential legal element of the value chain of industrial cultural production. The value chain "begins with the creator, goes through production, arrives at distributors and marketing, and finally ends in the public which demands the use of these contents."1 (1. of the Colombian public policy on intellectual property was made by El Consejo Nacional de Política Económica y Social (Conpes) in 2008.)
Because this system of production is so dominant, creators of all kinds dream of signing _that_ contract which, within the model of the creative industry, will give them a chance to win fame and fortune – in other words, the happy ending of their own story. This is a fairy tale, however. Most of us are neither princes nor princesses.
**Diversity as a counterproposal**
Despite the claims by copyright's defenders, there is no direct relationship between creativity and copyright protection. Industries such as fashion (Bollier 2006, Blakley 2010) and cuisine (Fauchart and von Hippel 2006) are notable examples. For example, Bollier cites the exponential growth of the fashion industry, which has no copyright protection for the apparel design that it produces; it relies instead on trademark law for its brand names and logos, which enables the free use and re-use of design elements in a commons. No one can "own" the herringbone suit or mini-dress. Similarly, no one can own food recipes. This "creativity without copyright" contrasts with the music industry's claims that copyright is absolutely essential for any creativity (IFPI 2010).
There is a rich literature documenting how sustainable business schemes can be built around creative communities that are based on the open sharing of content, and not strict control, such as free software and free culture communities.2 These communities have built these models for encouraging creativity around legal licenses based on copyright ownership. But instead of requiring strict control, licenses such as the General Public License for software and Creative Commons licenses authorize copying and sharing without payment or permission. Creativity in these systems _does not revolve around total control of the work,_ and yet they are economically and culturally productive. (2. See essays by Mike Linksvayer on free culture, Christian Siefkes on peer production, and Benjamin Mako Hill on free software all of which are in Part 4.)
Contrary to the mythological pattern of the traditional copyright story, sometimes the law itself allows greater flexibility for certain uses that are important to society, such as education, commentary and parody. Known as "exceptions and limitations" or "fair use" (depending upon the particular legal system), these legal provisions are not only important to culture and democracy, they help generate jobs and taxes (Rogers and Szamosszegi 2007).
For example, libraries and schools can only work _because of_ these exceptions and limitations to copyright protection. Public loans of books at libraries are a treasure that the society cherishes, and should not depend on the author's will, much less on the limits of the market. Copyright laws in most nations acknowledge the importance of fair use and set forth exceptions for libraries, especially for copies associated with custody or preservation. Yet the impulse to control the circulation of works remains very strong. In countries like Colombia, some critics assert that since public lending of books is not expressly mentioned in copyright law, copyright holders are simply tolerating libraries, but that they need not do so. In general, promoters of the traditional narrative of copyright want exceptions and limitations (or fair use) to be as small and limited as possible. But these provisions are in fact more necessary than ever.
**Towards new narratives beyond copyright**
Although we recognize benefits in the traditional family model, the truth is that there are also other ways to conceive a family. Likewise, there are multiple ways to create. Many of them exist beyond copyright as well as within its boundaries.
Today, new technologies make possible highly useful new patterns of creation and use for copyrighted works as well as new venues for creativity, production, dissemination, access and economic success. The new models move beyond historic, industry-based models of creativity, expanding what previously occurred mainly in local and private environments by enabling them to go global on new public platforms.
The Internet has made possible a new production model that relies on volunteers to jointly create and manage their copyright, not as an individual control system to ensure financial reward, but as a community building system and a sharing economy that also generates wealth (Weber 2004). This production model simply cannot be ignored by the market. Rather, it becomes a necessity for governments, businesses and people in general to recognize that the economy of sharing goes hand in hand with "traditional economy" (Benkler 2006). Lawrence Lessig, founder of Creative Commons, notes that the sharing economy does not conform to traditional market dynamics and what copyright law has defined as legitimate (Lessig 2006).
In sum, we must modify the patterns about creativity so that our stories can be constructed in a substantially different way. We must identify these new patterns3 and build new narratives that expand the range of legitimate possibilities. (3. also "The Commoning of Patterns and the Patterns of Commoning," by Franz Nahrada in Part 1.)
We acknowledge the fact that there is a creative environment that benefits from copyright as a control mechanism, but it is also important to acknowledge that it is not the only one, nor can it or should it crush the rest of mechanisms. We must not focus on one form of creativity; we must be willing to accept a social and legal contract where all of them have a place. Just imagine a copyright system that recognizes the legal needs of industry, a free technological culture of traditional communities, and academic communities and urban collectives. That would be a true and worthy challenge our judges and policymakers!
**References**
Benkler, Yochai. 2006. _The Wealth of Networks: How Social Production Transforms Markets and Freedom._ New Haven: Yale University Press.
Blakley, Johanna. 2010. _TED Talk Lessons from Fashion´s Free Culture,_ http://www.ted.com/talks/johanna_blakley_lessons_from_fashion_s_free_culture.html.
Bollier, David and Laurie Racine, editors. 2006. _Ready to Share: Fashion & the Ownership of Creativity. _Los Angeles, CA: Norman Lear Center, USC Annenberg School for Communication and Journalism.
Fauchart, Emmanuelle and Eric von Hippel. 2006. "Norms-based Intellectual Property Systems: The Case of French Chefs." MIT Sloan School of Management, Working Paper 4576-06.
International Federation of the Phonographic Industry. Digital Music Report. 2010. "Music How, When, Where You Want It."
Lessig, Lawrence. 2006. "On the Economies of Culture," available at http://www.lessig.org/blog/2006/09/on_the_economies_of_culture.html
Propp, Vladimir. 2003. _The Morphology of the Folktale,_ University of Texas Press (2nd Edition) Laurence Scott, translator.
Raymond, Eric. 1997. _The Cathedral and the Bazzar_. Sebastopol, CA. O'Reilly Media. 2001.
Rogers, Thomas and Andrew Szamosszegi. 2007. _Fair Use in the U.S. Economy: Economic Contribution of Industries Relying on Fair Use_ (CCIA September 2007). http://www.ccianet.org.
Weber, Steven. 2004. _The Success of Open Networks_. Cambridge, MA. Harvard University Press.
**Carolina** **Botero** _(Colombia) is an activist, consultant and lawyer with master's degrees from universities in Belgium and Spain. She is an author and lecturer on free access, free culture and authors' rights. She leads the Group Rights Internet and Society at Karisma Foundation and serves as Legal Lead for Creative Commons Colombia and Co-Manager for Latin America._
**Julio César Gaitán** _(Colombia) is Director of the Justice Department at Del Rosario University, Bogotá, and has a master's degree in public law and a doctoral degree in evolution of legal systems and new rights. He does research on pluralism and legal cultures, sociology of knowledge and the formation of prejudices._
# Creative Commons: Governing the Intellectual Commons from Below
_By Mike Linksvayer_
The intellectual commons have been poorly governed for a long time. Perhaps always. The particulars of poor governance have varied over the decades, centuries and millenia, depending on the structures of society and technologies over the decades, centuries, and millenia. But the rise of digital networks has opened up a new world of possibilities for creative and cultural freedom. Social interactions in theory restricted by copyright law (a major source of commons malgovernance for centuries) have exploded, unleashing new sorts of social, democratic, and economic value-creation.
The legal and policy response of established content industries – film, music, publishing, information – has generally been to ignore the intellectual commons, and sometimes to attack it. Over the past two decades, it has retroactively extended the terms of copyright law, preventing works from entering the public domain; shrunk "fair use" and other exceptions that allow re-use of copyrighted works without permission or payment; created new copyright-like monopolies; waged mass lawsuits against ordinary people; suppressed technologies that enable mass sharing; and expanded the geographic scope of copyright regimes.
**Commoners develop the tools to build their commons**
The most exciting governance developments for intellectual commons have come not from the legal establishment, public policy or business, but from hackers and activists. Over the past twenty years they have carved out new practices, technological tools and legal affordances to help them build, maintain and protect their intellectual commons. The free software movement led the way in the 1980s, not long after copyright law began to apply to software.1 By the late 1990s, many creators, particularly those using the Internet, wanted to invigorate the commons of culture, education, and science using similar means. From this milieu Creative Commons (CC) was launched in 2002. (1. essay by Christian Siefkes on the relevance of free software in public administration, see also Federico Heinz's essay both of which are in Part 4.)
There were many pre-CC attempts to fashion public licenses that would help govern intellectual commons beyond software. These included the Free Documentation License (FDL), Open Content Principles and Open Publication licenses, Open Audio License, Open Music licenses, Open Directory License, Public Library of Science Open Access License, Electrohippie Collective's Ethical Open Documentation License, Free Art License, and others.
The support and public visibility of CC's initial patrons and founders raised the profile of the nascent movement to build voluntary commons and not coincidentally, contributed to a more centralized stewardship of the tools used to build various commons. Some digital creators started using and recommending CC licenses instead of their own. Others moved their projects to CC licenses equivalent to their existing ones. The stewards and most significant users of remaining licenses often tried to make their licenses more legally compatible with one of the CC licenses, or migrate their works to them, in order to foster a greater interoperability of everyone's content.
**Central stewardship and commons interoperability**
Centralization sounds bad. However, it is one way to address two of the biggest challenges to successful governance of an intellectual commons. The first challenge is how to assure the legal interoperability of content using different public copyright licenses. Lots of licenses and license stewards tend to produce a fractured commons with incompatible pools of content. Indeed, nearly all pre-CC licenses are incompatible with each other. This means that for a work published under one license, an adaptation cannot be published under another license, because the terms of the first license may not be fulfilled when the adaptation is offered under the second license.2 (2. Licenses that require adaptations be licensed under the same license as the original work – known as copyleft or share-alike – are by nature incompatible as donors to other licenses, except via an explicit compatibility clause.)
For software, there are several important license stewards, and many licenses. The problem of interoperability has been partially solved over the decades through the primacy of one steward, the Free Software Foundation (FSF), and its General Public License (GPL). The FSF is the most experienced steward, and its strong commitments to the full freedom of software users (to copy, modify, re-use and share code) has assured transparency and predictability. Some other free software licenses are much more permissive than the GPL, making one-way compatibility (software under a permissive license may be incorporated into a project under the GPL, but not vice versa) a triviality. With other licenses, like the Apache Software License 2.0, great care was taken in crafting their legal provisions to align with the provisions of the GPL. The drafting processes accounted for the goal of compatibility (recipient and donor, respectively) between the GPL and Apache Software License, and provides an example of coordination in intellectual commons governance.
**Freedom, commerce and the commons**
Incompatibilities exist _within_ the CC suite of licenses, by design. These are legal in nature, but also cultural and ideological. For example, may an intellectual commons discriminate against (and prohibit) commercial uses? One line of thought says no: Commerce is such a primary function of society that excluding commercial uses from the commons marginalizes the commons from society – and in any case, the copyleft requirement can force a public benefit from commercial uses (by requiring that the works be shareable and re-useable by others).
Think of commercially produced educational materials that adapt Wikipedia articles. Those commercially produced adaptations of Wikipedia materials must be shared under the CC Attribution-ShareAlike license (BY-SA), which means that others can freely copy and re-use them. Multiple other schools of thought disagree, however: Some creators want to exclude commerce from the commons. Another set of creators profess ignorance about what will be optimal for any given creative domain, e.g., photography, gaming, music, and therefore urge practitioners to figure out the best terms of governance within their respective domains. Yet another set of creators, in stark contrast with the first, may not wish to build non-commercial commons, but want to engage in traditional copyright-based commerce and refrain from granting commercial permissions while permitting non-commercial uses as a marketing strategy.
Debate about the best way to structure intellectual commons within different creative domains long preceded CC. For example, many of the early, non-software public licenses were not fully free/libre/open – that is, they don't permit any use by any user. In the software world, this debate occurred years earlier as hackers questioned whether "free" should mean the freedom to re-use, modify and share for whatever purposes, or available at "no cost." The ultimate consensus was that "free" should mean the former – or as FSF founder Richard Stallman memorably put it, "Free as in freedom, not as in free beer." In 1991 Linux was initially released under non-commercial terms, but it soon switched to the GPL.
The free software world defined itself in terms of freedom quickly and decisively. The same definition might not be appropriate for other parts of the intellectual commons. However, it is also possible that permitting any user to make any use is a "sweet spot" of intellectual commons governance that other domains would have settled on without having free software as an example. Trends toward consensus for a "free as in freedom" standard can be seen in various non-software domains, including scientific communication (0pen access)3, learning (0pen educational resources),4 public sector information, data, and in aggregate statistics concerning the use of CC licenses. In 2003, Attribution-NonCommercial-ShareAlike (BY-NC-SA) was by far the most popular license, surpassed by the fully free Attribution-ShareAlike (BY-SA) in mid-2009. (3. See Benjamin Mako Hill's essay about the different meanings of "open" and "freeing Part 4. 4. See Rainer Kuhlen's essay, "Preserving the Knowledge Ecosystem," in Part 4.)
**Wikipedia and CC**
The trend toward "free as in freedom" has been building for years. Attribution-ShareAlike's (BY-SA) becoming the most popular license in the CC suite coincides with the migration of Wikipedia and other Wikimedia Foundation projects from the Free Documentation License, or FDL, to BY-SA as their primary license. This major shift marked the culmination of a relatively long chapter of modern, non-software intellectual commons governance. Wikipedia started in 2001, before the launch of CC licenses, and used the FDL, designed by the Free Software Foundation specifically for printed free software manuals. Hence FDL was not very appropriate for an online encyclopedia.
Many Wikipedians wished to migrate to BY-SA, but it was not that simple. Wikipedia relies on contributions being made under a public license rather than requiring contributors to grant rights to the site not also granted to the public. Incidentally, this is an intellectual commons governance best practice – a "more-than-equal" participant that does not have to play by the rules of the commons threatens the community's cohesion and retards its self-governance. But the problem was that the FDL is not compatible with other copyleft licenses. Even if legal incompatibility were not an obstacle, it was not clear to many Wikipedians that CC would be the best steward of the project's primary public license. CC's less than fully free/libre/open licenses did not signal a serious enough commitment to non-discriminatory freedom. CC's stewardship was also a concern of the FSF, the FDL's steward, and the entity that would be needed to enable compatibility. As a result, Wikipedia's migration to the BY-SA license has made the intellectual commons more interoperable and thus more robust and unified.
**Public policy adopts CC licenses**
The second challenge that centralized stewards of licenses help address is the visibility and credibility of the resulting commons. Through initial use by bloggers, photographers, musicians, and early institutional connections, CC licenses were able to gain mainstream publicity and validation; later adoption by software platforms and large institutions boosted usage to ever-higher levels. Many governments – Australia and the Netherlands stand out as pioneers – are now using CC tools to release public sector information. Funders are conditioning grants on the release of funded material under a public license, which guarantees at least some public benefit of access and re-use. CC licenses have become a standard means to create and participate in intellectual commons – and that, in turn, has made it easier for more commoners, including the general public, to participate in and benefit from the commons.
Another key to the visibility and credibility of CC licenses has been its worldwide network of affiliates (autonomous and located within existing institutions, e.g., law schools, cultural institutes, and Wikimedia chapters). These affiliates are key sources of expertise – and pressure – needed to optimize CC tools for worldwide use. Without this base, there would be more impetus for governments and others to create their own (incompatible) licensing tools, likely in ways that would fracture the commons.
In the fall of 2011, CC launched the process of gathering requirements for and drafting version 4.0 of its license suite. This will be another crucial (and long!) moment in the governance of the intellectual commons.
**The future of intellectual commons?**
Creative Commons and its colleague movements have re-opened the intellectual commons, which were until recently at best ignored. Now, they cannot be ignored. In many instances they out-cooperate intellectual monopolies in the marketplace as they demonstrate the non-market value of vibrant intellectual commons for culture, learning, science, democracy, and indeed the economy.
There are many open questions related to the governance of the intellectual commons and the appropriate structures for producing them.5 How do we avoid merely recapitulating proprietary methods, and instead utilize the characteristics of the commons to create works, products and commons that are more beneficial economically and politically? (5. See also Rainer Kuhlen's essay on "knowledge ecosystems" in Part 4.)
Despite encouraging bottom-up developments, societal governance of the intellectual commons is still _very poor._ By comparison to the deep well of knowledge and experience concerning how to create and market intellectual monopolies, our knowledge and experience about commons-based peer production6 and governance of intellectual commons is puny. We can hope that history and technology are on our side and that the rise of the next generation will deepen our knowledge. Still, this will require much effort from the commoners to build the future that we need and want. (6. See essays by Christian Siefkes and Michel Bauwens, both of which are in Part 4.).
**Mike Linksvayer** _(USA) is a Senior Fellow at Creative Commons, where he served as Chief Technology Officer and Vice President from 2003 to 2012. One of his main obsessions is forming connections among software freedom and other commons movements. He blogs at http://gondwanaland.com/mlog._
# Freedom for Users, Not for Software
__
_By Benjamin Mako Hill_
In 1985, Richard Stallman founded the free software movement and published a manifesto asking computer users to join him in advocating for, building, and spreading software that would guarantee its users certain liberties (Stallman 2002). Stallman published a "Free Software Definition" (FSD) that enumerated the essential rights of every user in regard to their software:
• The freedom to run the program, for any purpose;
• The freedom to study how the program works, and adapt it to your needs;
• The freedom to redistribute copies so you can help your neighbor; and
• The freedom to improve the program, and release your improvements to the public, so that the whole community benefits.
A computer scientist, Stallman understood how programmers shape software in ways that influence how users of their code are able to act. Programmers might, for example, design software to spy on, work against, or create dependencies in, their users. As users' communication and their lives are increasingly mediated by computers, their experience is increasingly controlled by their technology and, by extension, those who control it. If software is "free," users can turn off exploitative features and work together to improve and control their technology. For Stallman, free software is critical to a free society.
Unfortunately, many people who heard the term "free software" thought the word "free" referred to the fact that the software was distributed at no cost – an understandable source of confusion because free software can be, and usually is, shared without permission or payment. In concerted attempts to address this confusion, the slogan "free as in 'free speech' not as in 'free beer'," and references to the distinction between the French _libre_ and _gratis,_ became clichés in the free software community. A biography of Stallman is titled _Free as in Freedom_ (Williams 2002).
In the late 1990s, a group of free software enthusiasts suggested a new term: _open source_. Like Stallman, this group was frustrated by the ambiguity of the word "free." However, the open source group's primary concern was free software's utility to businesses. Rather than stressing "freedom," which they felt would be off-putting to for-profit firms, open source advocates described the technical benefits that the "openness" of free software development might bring through collaborations among large networks of users. These calls resonated with high-tech firms at the turn of the millennium when the free software GNU/Linux operating system was surging in popularity and the Apache webserver was dominating a market full of proprietary competitors. The "open source" concept gained a further boost in 1998 as Netscape publicly released the source code to its Navigator browser.
But despite rhetorical and philosophical differences, free software and open source referred to the same software, the same communities, the same licenses, and the same development practices. The Open Source Definition was a nearly verbatim copy of the Free Software Guidelines issued by the Debian free software community, which themselves were an attempt to restate Stallman's Free Software Definition. Stallman has described the split between free software and open source as the opposite of a schism. In a schism, two religious groups worship separately due to sometimes-minor disagreements about liturgy or doctrine. In free software and open source, the two groups have articulated fundamentally different philosophies, politics, and motivations. Yet both sides continue to work together closely within the same organizations.
Conversations around _libre_ and _gratis_ in the free software and open source communities overshadowed a second, and much less discussed, level of linguistic ambiguity in the term "free software": the term led to the four freedoms being interpreted as statements about qualities that software itself should have. Of course, Stallman doesn't care about free _software_ ; he cares about free _users_ of software. The slogans "free as in freedom" and "free speech, not free beer" are unhelpful in resolving this second type of ambiguity, and may even increase confusion. "Free as in freedom," is simply silent as to _what_ should be free, while "free speech, not free beer," reproduces a parallel problem: free speech advocates do not actually care about the freedom of _speech_ – they care about the freedom of individuals _to speak_. When the free software movement's core rhetoric focuses attention on the qualities of software, some participants come to view the freedom of users as a second-order concern – it is simply what happens when software is free.
**When software is free, but users are not**
But user freedom does not always stem from software freedom. Indeed, as free software has grown in economic and political importance, it has attracted the attention of some who wish to reap the benefits of free software while keeping users restricted and dependent.
Google, Facebook, and other titans of the Web economy have built their businesses on free software. And they are not merely free riders in their usage of this resource; in many cases, these firms freely share at least some of the code that runs on their services and invest substantial resources in creating or enhancing that code. Each user of a "free software" network service can have a copy of software that allows the FSD's four freedoms. But unless these users run the web service themselves – something that may be technically or economically infeasible – the users remain at the whim of the firm who does run their copy. "Software as a Service" (SaaS) – or software provided via "the cloud" – is entirely compatible with the idea of software that is free. But in that users of the service cannot change the software or use it as they wish without the permission, and oversight, of their service provider, SaaS users are at least as dependent and vulnerable as they would be if the code were closed.
Google's _Chrome OS_ is an attempt to build an operating system that gets users online and connected to services like Google Docs for users to do most of their computing. When Google announced _Chrome OS_ , many in the free software community celebrated; Chrome OS is based on GNU/Linux, is almost entirely free software, and has Google's backing. But the goal of Chrome OS is to change _where_ users' computing happens, by replacing applications a user might run on their own computer with SaaS. Every move from a piece of "desktop" free software to a SaaS service is a move from a situation where a user had control over his or her software to a situation where users have very little control at all. For example, Google's use of free software in its SaaS services enables it to monitor all uses and add or remove features at will. By focusing on the freedom of the software and not the users, many free software supporters failed to appreciate this troubling dynamic.
The TiVo – the pioneering digital video recorder – presented a different challenge. Its software was based on GNU/Linux and, in compliance with the "copyleft" license that most free software is distributed under, the TiVo corporation distributed full access to its source code. But TiVo used encryption to lock down its device so that it would run only approved versions of Linux. TiVo users could study and modify the TiVo software, but they could not use the modified software on their TiVo. The software was free, but the users were not.
SaaS, Chrome OS and "TiVoization" are issues that continue to roil the free software and open source movements and expose philosophical fault-lines. It is unsurprising that open source advocates see no problem with SaaS, Chrome OS, and TiVoization; they are not committed to the freedom of users of software. But each of these examples has been divisive even among people who believe that software should be free. The Free Software Foundation (FSF) has taken explicit stands against each of the issues above. But it has been slow to recognize each threat and has struggled to successfully communicate these messages to its constituency. Today, it seems likely that Google and its service-oriented business model represents a greater threat to future computer users' freedom than does Microsoft's. But because Google scrupulously complies with free software license terms and contributes enormous amounts of code and money to free software projects, free software advocacy has been very slow to recognize, and respond to, the threat that it poses.
Even the FSF continues to struggle with its own software-oriented mission. Stallman and the FSF have worked over the last several years to move nonfree code that runs on what are essentially smaller subcomputers, e.g., a wireless interface or graphics device within a laptop, from the computer's main hard drive into the subprocessors themselves. The point of these efforts is to eliminate nonfree software by turning it into hardware. But are users of software more free if proprietary technology they cannot change exists in one form on their computer rather than another?
The key to answering this question, and others, lies in focusing on the observation that distinguishes "free" from "open." Free software advocates must return to their ultimate goal of freeing people, not software. Stallman and the free software movement's fundamental innovation was to connect questions of personal autonomy and freedom to areas where most did not see its relevance. As the nature of technology changes, so will the way in which users remain free. And as others adapt free software principles to new areas, they will be faced with similar problems of translation. To the extent that our communities are able to distinguish between "openness" of artifacts and to emphasize questions of control, politics, and power, free software philosophy will remain relevant in these broader conversations about new and different commons – in software and beyond.
**References**
Stallman, Richard M. 2002. _Free Software, Free Society: Selected Essays of Richard M. Stallman_. Cambridge, MA. Free Software Foundation.
Williams, Sam. 2002. _Free As in Freedom: Richard Stallman's Crusade for Free Software_. Sebastopol, CA. O'Reilly Media, Inc., 1st ed.
****
****
**Benjamin Mako Hill **_(USA) is a researcher and PhD Candidate at MIT and a fellow at Harvard's Berkman Center for Internet and Society. He studies social structure in free culture and free software communities and is an active participant in many free software and free culture projects._
# Public Administration Needs Free Software
_By Federico Heinz_
Public and private administrations share many common features: they aim at making the best use of finite resources. But they also display important dissimilarities stemming from the fact that the actions of public administrators are public acts, not private ones. Except for a narrowly defined set of information that it gets to keep confidential due to security concerns, while a public body must answer to all of society, and not just to itself.
This has profound consequences when considering the use of information technology by public administrations, where computers have made filing archives obsolete; improved the decision-making ability of clerks; and replaced old communication channels; increasing both the speed and the reliability with which administrations operate. The flipside of these advantages is, of course, dependency: who hasn't witnessed whole government bodies grinding to a halt due to some ominous "computer crash" or other events? Aside from the fortuitous occurrence of crash events, however often they may happen, this dependency on computers raises a much more serious concern: the question of who controls them.
Most computer users believe they control their machines. By extension, they assume that any organization has full control of the machines it owns. They are wrong on both counts: computers have no loyalty towards their owners and will dutifully betray them if so instructed by the only master they blindly obey: the program.
Proprietary software users often experience this betrayal, where the computer actively refuses to carry out the user's orders, or performs actions that the user neither requested nor authorized. Familiar examples range from a computer installing malware (malicious software programs) when users open an email attachment, refusing to copy a song from one media player to another and silently installing unsolicited software on the user's machines, to refusing to work past a certain date or deleting fully paid-for works from the user's e-book reader in order to protect the commercial interests of vendors or third parties.
In administrative bodies that use proprietary software, the problem of programmed control of the public administration's computers is made worse by the combination of restrictive software licensing terms and the prohibitive cost of switching programs for any given task. Not only do proprietary software providers set their programs' licensing terms at their whim, they also often change them, unilaterally and retroactively. They can afford to engage in such customer-unfriendly behavior, because customers know that they can't switch proprietary software providers without also switching programs, which is costly and cumbersome.
Yet a public administration answerable to all of society can't leave the control of critical infrastructure in the hands of individual persons or organizations. It is irresponsible to manage information – whose integrity and availability critically affect citizens' lives – with software for which the administration has obtained only a limited right to use under non-negotiable, restrictive conditions. It is even worse when we consider the risks of entrusting such critical infrastructure to companies based in foreign countries, which may be subject to pressure from intelligence agencies to provide means for remote surveillance or sabotage of specific installations.
These intractable problems can be avoided only through the use of programs that aren't under the control of any individual entity. It requires software that can be obtained from multiple sources, which can be supported and extended by anybody the administration wishes to task with the job; programs that can be thoroughly audited both by the administration and the public, to make sure that they actually fulfill their stated purpose; programs that can be modified to meet the needs of the administration, independently of the goodwill and interests of any particular provider.
It seems like a tall order, but it's not. Such programs are widely available, and actually constitute the foundation of the world's information infrastructure. We call them "free software," a term coined over twenty-five years ago by Richard Stallman, initiator of the movement that made its development possible. It provides technical solutions for the information technology needs of virtually any organization, at a comparable or lower cost than proprietary products, without relinquishing control over the administration's information to outside entities.
Most public administrations, however, still use proprietary software. Why? Government officials will claim that some free software solution lacks a feature deemed essential by technocrats; others will bemoan that the immediate licensing costs of a proprietary system are lower than the deployment and customization effort needed to implement the free equivalent. These and many other variations are just excuses intended to hide a cowardly unwillingness to set responsible policies. Missing features always can be added. Low initial licensing costs are irrelevant when the costs of later switching to another provider are prohibitively high, etc.
We aren't talking about mere convenience here, about which program is "better" than the next, or about price/performance tradeoffs that make once choice preferrable to the other. We are talking about fundamental principles of republican life, to which citizens and certainly governments should have a hard time attaching a price tag. The use of proprietary software in the public administration always entails a fundamental betrayal of the public's trust. No society can afford that.
**Federico Heinz** _(Argentina) is programmer and free software activist and co-founder of Vía Libre foundation, which promotes free knowledge as the driver for social development. He has tendered advice to many parliamentarians in various Latin American countries on the preparation of bills concerning the use of free software in public administration. _
# From Blue Collar to Open Commons Region: How Linz, Austria, Benefited from Committing to the Commons
_By Thomas Gegenhuber, Naumi Haque and Stefan Pawel_
The City of Linz, Austria, launched the first municipal initiative in Europe to build a vibrant public–civil–private digital ecosystem – the Linz Open Commons – to serve the needs of public administration, citizens, enterprises, science, arts communities and educational institutions.
Linz, the provincial capital of Upper Austria, has approximately 190,000 inhabitants and is usually considered an industrial, blue collar town. Nevertheless, the city is open to both cultural and technological change as important drivers for an improved quality of life. In 1979, the City of Linz became known for its pioneering experiments with digital culture by hosting the "Ars Electronica," an initiative that is at once an avant-garde festival, a showcase for excellence in digital art, and a media art lab providing artistic expertise for R&D projects.
**Open Commons Region**
The City of Linz started its digital innovations in 2005 with its Hotspot Initiative, which built 119 freely accessible wi-fi hotspots in public places like parks, libraries and youth centers. The municipality later initiated the Public Space Server to make access to Web publishing more accessible to citizens, and the Creative Commons Subsidy Model, which offers some artists a higher art subsidy from the city if they publish their work under a Creative Commons license.1 The next step was to develop strategies for integrating the Web into local public policy. To accomplish this, the City of Linz has developed a framework for the first Open Commons Region in Europe.2
(1. Mike Linksvayer describes the Creative Commons licenses in Part 4. 2. See http://opencommons.public1.linz.at See also Benjamin Mako Hill's essay about the implications of "openness," in Part 4.)
Christian Forsterleitner, member of the municipal council, explained, "The foundations of an Open Commons Region are the digital, freely accessible public goods of a society. That means free and open source software, open data, open street maps, open educational resources, and freely accessible creative works in the areas of film, music and photography." Gerald Kempinger, as the Chief Information Officer of Linz, notes, "We welcome every initiative – from citizens, community groups and enterprises" (Glechner 2010).
In 2010, the information technology department of the city, in collaboration with Gustav Pomberger, professor of computer science at the Johannes Kepler University Linz, published a study on the "Open Commons Region Linz" (Kempinger and Pomberger 2010). The report summarizes the role of local government in establishing an Open Commons Region. In the past, public funds for economic development had largely focused on capital-intensive infrastructures like roads or civic institutions. In a knowledge economy, it makes sense to also invest in intellectual growth, shared data, and ideas. In this context, the role of the government is to create a framework for making the sharing of information and knowledge easier. This means enacting appropriate legislation, building public awareness, and supporting new Open Commons initiatives proposed by citizens and private enterprises.
The study suggested three major activities to establish an Open Commons Region. The first step was to explain the relevance of Open Commons to the inhabitants of Linz through a public awareness campaign and developing a brand. The second step was to organize, coordinate and encourage Open Commons activities through an office for coordination and assistance, and a system of open data for local government (Kempinger and Pomberger 2010). "The City of Linz needs to open its data sets," noted Leonard Dobusch, researcher in the Department of Management at Free University Berlin and co-editor of the book _Free Networks, Free Knowledge_. "If the city fails to be a positive role model, the Open Commons Region will fail. In circumstances where the government has neither the resources nor the incentives to innovate, the public can take the lead and use the data for productive purposes." The third step called for the city to network with other regions, to establish national and international cooperation to spread the idea of Open Commons, and to learn from other cities in Europe.
By the end of 2010 the office for coordination of the Open Commons activities was launched. Its first project, begun in October 2011, was an Open Government Data platform to provide statistical data about Linz, election results, orthophotos (aerial photographs, geometrically corrected), maps, real-time public transport data and records of the municipal council (Stadt Linz 2010) .
The second initiative was Clickfix, a geodata-based complaint management tool that lets Linz citizens report problems online. Inspired by the internationally well-known SeeClicFix or Fixmystreet, the system makes reports on each problem visible for everybody to see. It's a win-win for both sides: citizens know how the city deals with their problem and the city administration can show how fast and reliable they are in solving a problem.
The Open Commons Region is still a nascent project. But, so far, the response of Linz citizens, academics and the business community is encouraging. Many institutions have problems in understanding and identifying with the philosophy behind the Open Commons Region. However, the City of Linz and the many dedicated stakeholders of the new public–civil–private ecosystem are determined to fulfil the vision of an Open Commons Region.
**References**
Interview with Leonard Dobusch. 2010.
Glechner, Claudia. 2010. "Linz Sees Open Commons Future." _Futurezone,_ August 24, 2010.
Kempinger, Gerald and Gustav Pomberger. 2010. "Open Commons Region Linz.
http://www.linz.at/images/ko-Studie_Open_Commons_Region_Linz.pdf.
Stadt Linz. 2010.
Open Data Linz. http://www.data.linz.gv.at.
**Thomas Gegenhuber** _(Austria) has several years of nonprofit experience. He worked in Toronto for the think-tank nGenera insight that is chaired by Don Tapscott, conducting research on open government. He now contributes to such projects in Linz and blogs at www.thomas-gegenhuber.at._
**Nauman Haque** _(Canada) is currently the Associate Research Director for the Enterprise Council on Small Business at Corporate Executive Board. Nauman has a decade of experience in the research and advisory industry. He has conducted research and provided thought leadership on a variety of topics, including enterprise collaboration, social media, digital identity and customer behavior. _
**Stefan Pawel** _(Austria) is project manager of the Open Commons Region Linz, and has experience in project management of web portals, marketing and sales. He is co-author of _Freie Netze. Freies Wissen. Freiheit vor Ort _and author on the topic of Web Science. He blogs at http://www.blog.opencommons.at and http://www.data.linz.gv.at._
# Emancipating Innovation Enclosures: The Global Innovation Commons
_By David E. Martin_
Patents represent a social contract about innovation – the public, via government, grants limited-term monopolies to entrepreneurs as a way to encourage innovation, and the public reaps new knowledge and market access to new technologies. This social contract to "promote science and the useful arts" has in fact done little to achieve that goal, which has instead been pursued mostly through pubic funding of academic research and contracts with industrial enterprises. At best, patents have been a means to manage market scarcity and thereby profits. As a practical matter, they have been more useful as litigation weapons or tokens of individual achievement.
For decades, policy makers on both sides of the Atlantic have clung to an entirely unfounded axiom that proprietary instruments are necessary to stimulate innovation and financial development. They have purveyed the distorted notion that societies can generate the technological innovations they need only by restricting the creative impulses of humanity and hoarding them in proprietary forms, especially patents. This belief has been aggressively advanced through the World Trade Organization, the World Intellectual Property Organization, competitiveness policies and laws, and egregiously mismanaged representations of "development."
For the past thirty years, economists have unsuccessfully attempted to establish a direct correlation between the deployment of proprietary rights and economic (to say nothing of social) good. This effort has been confounded by two alarming and unaddressed problems. First, modern patent offices have categorically denied any responsibility for the economic consequence of the patents they grant – while relying on business models (fees and personal compensation) that reward patent examiners for issuing more patents. When WIPO, Denmark, and others investigated what happened when patent offices take quality and market consequences into consideration, they found that fewer patents are issued. However, fee income also drops, and so such reforms of the patenting process are quickly shelved.
A second problem has been the sheer proliferation of patents. Since 1980, when the US and Japan launched the modern innovation "cold war," companies have sought new patents as weapons for negotiations over market control. Even a dubious patent can be used as a bargaining chit in litigation and other disputes. The proliferation of patents, many of them illegal, has so thoroughly choked the global corpus of patents that you are more likely to find actual artifacts of innovation and invention through statistically random chance than through actively looking for them. As the system neither does, nor can, work, looking to patents to solve our pressing innovation challenges is misguided in both theory and implementation.
At least since 1980, companies have used patents and other intellectual property regimes to block commercial access to and market use of innovations. It is no accident that some of the largest patent estates were filed by companies who had the most market share to lose. Oil companies filed and held thousands of environmentally desirable patents in fields ranging from solar and wind power to hydrogen and hybrid propulsion. Paint companies filed and held thousands of patents on alternative surface coating techniques only to continue using toxic metals in industrial production. Pharmaceutical companies and their agro-chemical allies filed and held thousands of patents on treatments and cures for disease and on land renewal technologies, ensuring that no one else could use these options.
Defensive patents – representing an estimated 80 percent of all filings by industrialized nations – are not artifacts of innovation but pawns used to minimize risks during litigation. In the meantime, such patents not only preclude others from entering into research and development, and marketing efforts, they freeze much-needed technology out of the market.
Figure 1 illustrates the dismaying impact of patent grants made over the past 25 years. Long before there were any business models or consumer demands for technologies ranging from biochips to fuel cells to hydrogen-powered vehicles, patents were granted for broadly ranging claims that covered explicit and anticipated technologies years before market conditions could conceivably assimilate them. The chart shows the periods of highest patent filings when companies anticipated wide-ranging uses of the technologies (1987-1990), followed by the rapid abandonment of "patent estates" (1989-2006) through failures to maintain the patents or through dissolution of businesses, in each case with more rights released to the Commons than retained by industry. The light gray zone (1997-2001) indicates the period in which large multinational corporations consolidated a significant majority of the entrepreneurial ventures in each industry segment. The black zone (2007-2009) indicates the expiration of the early platform, foundational patents in these market areas. Finally, the hatched zone (various years, 2009 – 2018) indicates the consensus among industry experts and market analysts for when markets for these technologies will mature. Note how a huge number of patents are now expired, abandoned and in the public domain.
_Figure 1._
This chart can be seen as a cause for great depression. However, the realities depicted here also represent an unparalleled opportunity for the future of humanity. What if all of the expired, abandoned and invalid patents were to be consolidated into a single database? Entrepreneurs and national governments could query the database on a country-by-country basis to identify helpful technologies that are in the public domain, and therefore available to use. Once identified, prime technologies for energy, water and agriculture could be developed at lower costs than patented technologies.
This is the basic idea of the Global Innovation Commons, developed by my organization, M-CAM. The project seeks to bring the advantages of the open source software development model – open participation, faster innovation, greater reliability, cheaper costs – to technologies whose patent claims are no longer valid. This means that, as of right now, you can take a step into a world full of possibilities, not roadblocks. You want clean water for China or Sudan – it's in here. You want carbon-free energy – it's in here. You want food production for Asia or South America – it's in here.
In the Global Innovation Commons, all innovation artifacts (patents, research publications, government or industry sponsored research reports, and technology procurement records) have been assembled and reviewed for their legal standing in every country on Earth.1 These innovation artifacts have been compiled so that jurisdictions of enforcement are easily assessed, so infringement can be avoided in any jurisdiction. This enables a business or government to know what can be developed for domestic use only, for limited export, or for general export. Wherever possible, using abandoned patents, global freedom-to-commercialize positions are identified for unrestricted commercial use and deployment. (1. http://www.globalinnovationcommons.org)
By examining each "innovation enclosure artifact" (patents and related filing information) for its jurisdictional scope of enforcement, one can immediately identify those countries where open source freedom-to-operate status prevails. In the database, each innovation artifact, together with its jurisdiction(s) of enforcement is displayed so that the user can identify who is the innovator, the owner of record, and any other pertinent information about the innovation. One can immediately identify both zones for commercial development and use and those zones where active patent enforcement may blockade an open-source-derived product or service.
_Der Spiegel_ has noted that the Global Information Commons database represents a huge advance because it aggregates so many different patent-free technologies from so many different parts of the world: "[The Global Information Commons'] custom-made software and a vast server are programmed to trawl and compare hundreds of thousands of files containing patent information from what would seem an incongruous list of places: Papua New Guinea, Berlin, the Brazilian rainforest, New York. Some of these patents are current; others have expired."
A search of the database reveals that one in three patents registered today as energy-saving technology duplicates inventions that were first developed following the oil crisis of the 1970s, and so can be freely used. A great many patents are not novel at all. They simply duplicate innovations that were made decades ago. But patent applications often disguise this fact by using colorful and complicated language. Overworked government patent examiners struggling with limited resources and seeking to avoid legal hassles often grant new patents that are not truly warranted. The Global Innovation Commons helps reveal and confirm the patent-free status of important technologies.
Here's another reason why so many old patents are now available, at least in certain countries. In the 1970s and 1980s, when many companies were engaged in a "cold war" of innovation abuse, they generally overlooked filing for patents in the "most marginalized states," or MMS – a term we use in place of the conventional term "Least Developed Countries," or "LDCs." Companies didn't file patents there because those markets didn't seem to matter.
This oversight has now created an unprecedented opportunity. Using the Global Innovation Commons, humanity can claim what by international law is ours – namely every innovative thought and every contemplated imagination in the tens of thousands of patents that have now fallen into the commons. As a result of industrialized patentees failing to designate patent protection in MMS, or because patents expired or were abandoned, the scope of potential open-source technology development in many technology sectors is amazing:
_Solar energy power systems: _9,074 patents are available, representing approximately US$9.3 billion in research and development alone and US$133 billion in terminal deployment value.
_Gravitational and magnetism_ - _augmented power systems_ : 16,434 patents are available, representing approximately US$16.8 billion in research and development alone and US$241 billion in terminal deployment value.
_Tidal energy power systems:_ 6,717 patents are available, representing approximately US$6.9 billion in research and development alone and US$98.3 billion in terminal deployment value.
_Hydroelectric and hydromotive power systems:_ 12,869 patents are available, representing approximately US$13.2 billion in research and development alone and US$188 billion in terminal deployment value.
Similar opportunities exist to develop geothermal power systems (11, 449 patents), hybrid electric vehicles (21,412 patents), fuel cells (23,861 patents) and wind turbines (9,028 patents) through technological knowledge that now belongs to the commons. The World Bank has estimated that the technologies in the GIC database could save more than $2 trillion in potential license fees.
When Volkswagen received a patent for a hybrid electric vehicle that includes a rotating flywheel mass variably engaged by a series of clutches in 1979, their allowed patent claims are so broad as to describe virtually every hybrid electric vehicle built since. However, this patent expired in 2002 and is now in the public domain, where anyone, anywhere, can adopt every element of this invention without any fear of patent enforcement. That's right: an automotive company in a marginalized country could use 100 percent of this information to design and build a car to compete with Toyota's Prius. Today.
Every commoner can use this vast database as a tool to develop publicly funded, affordable, open source technologies that can solve urgent challenges in health, energy, transportation, food and water. "Recycling" patent estates that were wrongfully granted can liberate public and private funds for more efficient uses.
This recycling effort can include the use of patents for one of their long-forgotten purposes – to stimulate others to build on them with unanticipated new ideas, open-source style. On a practical level, the government and procurement agencies acting with public funds can adopt a standard procurement and development investment policy that mandates that public funds preferentially flow to those innovators who can deploy or integrate open source technologies.
In this fashion, the Global Innovation Commons promises to spur a new wave of technological innovation through the sharing of new ideas rather than through exclusive, private control of them. This is no academic claim: The majority of science and technology required to deal with emission controls, energy-harnessing storage and distribution, transportation, and water use and reclamation, already exists, and can be found in the Global Innovation Commons database. Prevailing economic thought perpetuates the illusion that we still haven't "innovated" enough. But in reality, more than US$1.6 trillion in latent market innovation has been created over the past three decades alone. It just hasn't been developed and deployed. It hasn't been developed not because it is deficient, but because it could challenge market incumbents and their entrenched technologies and business models.
Given the magnitude of the challenge before humanity, our clarion call is to deploy and honor these innovation impulses, especially to seed environmentally constructive enterprises in the Most Marginalized States. We can begin to imagine a world in which ecosystems, human interaction, and value exchange bring dignity to the Earth, facilitate collaborative engagement between people, and yield prosperity to every engaged person. Ironically, this opportunity arises from a vast storehouse of patent-free innovations from decades ago – a hidden resource created by unequal access to resources, unconsidered consequences, and asymmetric wealth and power distribution.
**David E. Martin** _(USA) is a business founder, public policy advisor, and foresight communicator. He pioneered the field of unstructured data analysis and linguistic genomics and groundbreaking new methods for global finance and ethics. He is the founder and Chairman of M-CAM and shares his life with his wife Colleen and his two children, Katie and Zachary. His blog is Inverted Alchemy, at http://invertedalchemy.blogspot.com._
# Move Commons: Labeling, Opening and Connecting Social Initiatives
_By Javier de la Cueva, Bastien Guerry,_
_Samer Hassan and Vicente J. Ruiz Jurado_
Here and there we see many initiatives promoting the commons in different fields (free culture, open educational resources, seed banks, "reclaim the city"). However, only a few have reached critical mass and are well known by multiple communities; the majority remain in their social silos and political niches, more or less ignored by the mainstream. Yet we all know about people out there who would love to get involved in helping improve the world. They just don't know which initiatives to help, and how to locate them. From the outside, it can be difficult to have a clear view of the ones available. So what happens, typically, is that people end up helping those large non-governmental organizations that have enough resources to pay for ads and marketing. The local, small initiatives, even ones with enormous potential, remain in the shadows because they cannot be easily found.
Move Commons is a Web tool that seeks to change this situation. It aims to boost the visibility of such smaller social initiatives while building a network of related initiatives across the world. As the developers of this Web tool, we strongly believe it can foster mutual discovery, facilitate new projects, and help various movements to reach critical mass.
**How does it work?**
Move Commons helps initiatives, collectives, NGOs, non-profits and social movements to publicly announce their core principles through a mechanism similar to the one used by Creative Commons (CC).1 Creative Commons allows authors to "label" their cultural works using icons representing a specific legal license. Move Commons provides a set of "labels" for social initiatives using a user-friendly, bottom-up system. The labels consist of four icons, together with a complementary set of keywords (such as its field of activism, research topics, geographical location, etc.). Like the CC licenses, Move Commons icons use RDFa tags – a set of metadata protocols – to facilitate Web searches that can locate projects and organizations. (1. Mike Linksvayer's essay on Creative Commons licenses in Part 4.)
Projects can choose Move Commons "badges" that accurately describe the character of their activities, and place the generated logo (a combination of four icons) on their Web pages. Websurfers who reach a homepage with the icons can then see at a glance the general character of the initiative. The icons answer several questions: Is this initiative nonprofit? Is it transparent? Can I use part of their contents for my blog? How are they organized internally? Do they fortify the Commons with their actions?
When you generate the badge for your Web page, Move Commons not only provides you with some easy-to-understand icons, it also gives you some machine-readable "semantic code" containing the information you provided, which you then place on your Website.2 This allows search engines to identify and "understand" the Web pages that have Move Commons badges, enabling searches such as, "Which initiatives exist in Cairo that are grassroots organizations, nonprofit, delivering Creative Commons content, and related to 'environmental education' and 'children'?" (Or substitute your own favorite social concerns, keywords and places.) If your initiative fits that description, the Move Commons semantic code would allow your webpages to be located and appear in the results. This capacity lets projects locate and collaborate with like-minded initiatives anywhere in the world. Potential volunteers can easily find an initiative that interests them even if the initiative is small and unable to market themselves widely. (2. "Semantic code" is metadata that is embedded into webpages to facilitate machine-readable searching and organization of information, enabling Web users to perform information-retrieval tasks in faster and more intelligent ways.)
**Move commons labels**
The four labels we propose for each initiative are: "Non-Profit," "Reproducible," "Grassroots" and "Reinforcing the Commons."
• Non-Profit means that your initiative is a not-for-profit initiative.
• Reproducible means that you make it easy for anyone to clone your initiative. You are documenting your own processes and sharing your contents for others to use. Thus, you are facilitating others to follow your path and avoid problems that have already been solved.
• Grassroots means that your initiative's governance tries to be as horizontal as possible. That is, hierarchical structure is minimal or nonexistent, allowing horizontal grassroots discussions to have a major weight in the decision-making as opposed to relying upon "vertical" instructions from a board.
• Reinforcing the Commons means that your movement aims to reinforce the Commons. Maybe you are working on some environmental project. Maybe you are writing free software. Maybe you are spreading free-licensed learning content. In all cases, you are reinforcing the commons and people should know about it. (We envision the possibility of flexible services in the future that could provide crowd-validation or further details for this self-selected label.)
**Trust and validation**
Move Commons is a self-labeling system where initiatives choose the icons/categories that they believe they comply with. This is certainly different from systems in which centralized institutions issue formal certifications. Such systems rely on the fact that the users must trust blindly the single certification issuer, which theoretically guarantees the accuracy and validity of the certifications, e.g., guaranteeing the nonprofit status of a foundation. However, there are multiple possible problems with the trustworthiness and legitimacy of these institutions.
Within the Move Commons ecosystem, initiatives are the ones that self-assign and self-certify their categories, and thus there is no "centralized certification issuer." This means that there might be initiatives that choose incorrect categories to describe themselves (either by mistake or on purpose), e.g., advertising themselves as "grassroots" when they are not. Optimally, there should be clear criteria for each category, together with a process of crowd-validation by the community.3 Thus, initiatives with controversial or incorrect icons would receive growing pressure to change them. Such processes would be independent services built on top of the open infrastructure. The basic Move Commons layer wouldn't include any validation, allowing flexibility for multiple solutions implemented by third parties. (3. solution can be found in "The Evolution of Reputation," chapter 5 of Rheingold, H. 2002. _Smart Mobs: The Next Social Revolution. _Basic Books.)
**Helping projects reach critical mass**
The Move Commons labels aim to make collectives consider their missions and push them towards the ideals behind the four labels. It hopes to trigger such questions as, "How could we be reproducible?" "What should/can we do to contribute to the Commons?" "Are we horizontal enough to be considered grassroots? Why not?" The labels promote the discovery of small, local groups and encourage volunteers to work for projects that fit their passions, and not just those that are large and well-marketed. Most importantly, volunteers and donors can discover that "they are not alone" – a common problem in small initiatives that do not have the time or resources to learn about other, similar initiatives. Move Commons labels can help groups reach critical mass, reduce the duplication of efforts, share their mistakes and successes, and become part of larger networks of activism, even at the international level.
The driving force behind Move Commons is a few volunteers backed up by the Comunes collective (at http://comunes.org), a nonprofit organization focused on facilitating the work of other collectives and activists through the development of free/libre tools, with the aim of encouraging the commons. By the end of 2011 Move Commons was in the alpha stage of development. We have plans to improve the form for creating the badges,4 e.g., adding new optional fields for the semantic code5 and developing a Move Commons-compatible search engine. Once these are ready, third parties would be able to build additional services on top of the network of MC-labeled initiatives. These might include the aforementioned crowd-validation, recommender systems of initiatives, geographical mapping, network visualization, web widgets and others. In fact, Move Commons is fully decentralized so anyone could generate MC badges, and any search engine can track the semantic code, so we would not become a centralized node. This is essential for commons on open digital platforms.
(4. http://movecommons.org/looking-into-the-future
5. https://github.com/jdelacueva/movecommons-semantics)
****
**Javier de la Cueva** _(Spain) is a practicing lawyer. He has handled the defense for Ladinamo (the first ruling ever to acknowledge Copyleft) and Sharemula (which confirmed that websites offering links to P2P networks do not infringe on intellectual property). He participates actively in Medialab-Prado Commons Lab. He is a Sysadm; writes his scripts in Python; and is an intellectual property lecturer._
**Bastien Guerry** _(France) is a French free software activist. He currently works on exploring new digital experiences for cultural heritage institutions. He spent the last five years working for projects like One Laptop Per Child, Wikimedia and the GNU project._
**Samer Hassan** _(Spain/Lebanon) is an activist, researcher in artificial intelligence and assistant professor at the Universidad Complutense de Madrid. He is Co-Founder of the Comunes.org collective, an umbrella for initiatives such as Ourproject, Kune and Move Commons._
**Vicente J. Ruiz Jurado** _(Spain) is a computer engineer. For more than a decade, he has been happy and busy trying to solve problems in our society through social, environmental, hacking and pro-commons activism. He is Co-Founder of Ourproject, Move Commons and Comunes.org, among others. He keeps trying...._
# Peer-to-Peer Economy and New Civilization Centered Around the Sustenance of the Commons
_By Michel Bauwens and Franco Iacomella_
The "peer to peer" and commons-oriented vision for a new type of civilization and economic system starts from an analysis of what is fundamentally wrong with the current economic system. Rather than put forward a utopian ideal, the P2P vision is based on generalizing the already emerging forms of peer production, peer governance, and peer property.1 It makes three primary critiques of the dysfunctions of the present system: (1. also the essay by Michel Bauwens on peer-to-peer production in Part 5.)
1. _The current political economy is based on a false idea of material abundance._ We call it pseudo-abundance. It is based on a commitment to permanent growth, the infinite accumulation of capital and debt-driven dynamics through compound interest. This is unsustainable, of course, because infinite growth is logically and physically impossible in any physically constrained, finite system.2 (2. See also the conversation between Davey, Helfrich, Hoeschele and Verzola in Part 1.)
2. _The current political economy is based on a false idea of "immaterial scarcity."_ It believes that an exaggerated set of intellectual property monopolies – for copyrights, trademarks and patents – should restrain the sharing of scientific, social and economic innovations.3 Hence the system discourages human cooperation, excludes many people from benefiting from innovation and slows the collective learning of humanity. In an age of grave global challenges, the political economy keeps many practical alternatives sequestered behind private firewalls or unfunded if they cannot generate adequate profits. (3. Beatriz Busaniche, among other authors, describes how this happens in Part 2.)
3. _The pseudo-abundance that destroys the biosphere, and the contrived scarcity that keeps innovation artificially scarce and slow, does not advance social justice._ Although people may have a formal legal equality of civil and political rights, serious and increasing material inequalities make those rights more nominal than real. At the other extreme, the polity explicitly grants human rights to the artificial legal construct of the for-profit corporation, a pathological institution that is solely beholden to its shareholders, and is constitutionally unable to take into account the common good.
The present corporate form is a machine designed to deny and ignore negative environmental and social externalities as much as possible. Because it is driven by profit-maximizing corporations, capitalism is not just a scarcity-allocation mechanism, but a mechanism for engineering artificial scarcities, as epitomized in the sterile Terminator Seeds developed by Monsanto.4 Such seeds are specifically designed so that they can't reproduce themselves, which not only kills cycles of abundance in nature, it also makes farmers permanently dependent on a corporation. (4. See, e.g., Wikipedia entry on genetically modified organisms, at http://en.wikipedia.org/wiki/Genetic_use_restriction_technology)
The above analysis suggests that any solution to contemporary capitalism needs to address these three issues in an integral fashion, i.e., production that allows the continued survival, sustainability and flourishing of the biosphere; protecting and promoting the free sharing of social innovations and knowledge; and the recognition that social and economic justice will not be achieved unless we first recognize the actual scarcity of nature and the actual abundance of knowledge and innovation.
**Vision, values and objectives**
Contemporary society is generally seen as consisting of a public sphere, dominated by the state and public authorities; a private sphere, consisting of profit-maximizing corporations; and a subordinated civil society where the less privileged sectors have great difficulties in ascertaining and asserting their rights and interests.
The peer-to-peer vision relies upon the three major sectors of society – the state, market and civil society – but with different roles and in a revitalized equilibrium. At the core of the new society is civil society, with the commons as its main institution, which uses peer production to generate common value outside of the market logic. These commons consist of both the natural heritage of mankind (oceans, the atmosphere, land, etc.), and commons that are created through collective societal innovation, many of which can be freely shared because of their immaterial nature (shared knowledge, software and design, culture and science). Civil society hosts a wide variety of activities that are naturally and structurally beneficial to the commons – not in an indirect and hypothetical way, as claimed by the "Invisible Hand" metaphor, but in a direct way, by entities that are structurally and constitutionally designed to work for the common good. This sphere includes entities such as trusts, which act as stewards of physical resources of common use (land trusts, natural parks), and for-benefit foundations, which help maintain the infrastructure of cooperation for cultural and digital commons.
The Wikimedia Foundation, which maintains the funding for Wikipedia's technological development is a well-known example in the domain of open knowledge. In like fashion, the Linux Foundation and Apache Foundation support two leading software development communities. It is important to note that these entities do not function as classic NGOs that use "command and control" management and salaried personnel to allocate resources to projects; rather, they use their resources and credibility to help paid and unpaid contributors continue to develop their commons according to their own consensus judgments.
Around this new core is a private sphere, where market entities with private agendas and private governance can still create added-value around the commons by producing relatively scarce goods and services. However, because of the pathological and destructive nature of profit-maximizing corporations, in the P2P economy this private sphere is reformed to serve more ethical ends by using proper taxation, revenue and benefit-sharing modalities to help generate positive externalities, e.g., infrastructure, shareable knowledge, and by using taxation, competition, and rent-for-use to minimize negative externalities, e.g., pollution, overuse of collective resources.5 (5. See also Gerhard Scherhorn's proposal in Part 5 to design a commons-based competition law.)
Cooperative enterprises are the more prominent and developed form of private organization in this new economy. While corporations continue to exist, their operating logic is made to serve the values of the commons. Once the commons and the commoners are at the core of value creation, commoners can be expected to opt for those types of entities that maximize the value system of the commons itself. Today, the open source economy of shared innovation commons and the "ethical economy" of reformed market entities exist as separate spheres. Both need to develop and mature. An early example of this dynamic is IBM's adaptation to the norms and regulations of the Linux community, which showed that even large, old-style corporate entities are capable of transforming themselves.
We believe that new forms of cooperative and distributed property will emerge along these lines, a trend explained by Matt Cropp in his article, "The Coming Micro-Ownership Revolution."6 Cropp's article explains the direct link between P2P-driven declines in transaction costs and the shift to more distributed forms of ownership. The new corporate forms will no longer be based on shareholder-based ownership, but on common capital stock, held by the commoners themselves. These new entities constitute the "third commons" of "created materiality," i.e., humankind's productive machinery (in other words, capital), which joins the first two commons, the inherited material commons of nature and created "immaterial" cultural commons. The new forms of distributed individual property, which can be freely aggregated into collectives, emulate the free aggregation of effort already dominant in peer production rather than the older forms of collectivized and socialized public property. (6. See: http://cuhistory.blogspot.com/2011/05/coming-micro-ownership-revolution.html)
**How commons "out-compete" by "out-cooperating"**
It can be argued that the collaborative economy is hyperproductive in comparison to the traditional industrial-capitalist modality of using a private company, wage labor, and proprietary controls such as patents and copyrights. Commons-based peer production allows rapid sharing of innovation and very low cost mutual coordination on a global scale. It also elicits passionate, voluntary engagement from large networks of contributors as well as rapidly established quick connections between emerging problems and valuable expertise. It is this hyperproductivity of commons-oriented practices and solutions that has led some observers to see commons as "out-competing" or "out-cooperating" conventional capitalism, and peer production as an attractive alternative to investments of shareholder and venture capital in private ventures. IBM is a well-known example of the realignment of a classic for-profit enterprise to the new modality of value creation. The company not only decided to use and contribute to Linux, but also to abide by the open development process of Linux, as well as the norms and rules of that community.
Obviously, when we use the concept of _out-competing_ , we stress the role that emergent peer production plays in the capitalist, for-profit system; we stress that incorporating community dynamics in the overall production process is a better and more efficient way of doing business. This is exactly the argument of the open source movement, which stresses efficiency. The free software movement, by contrast, stresses the ethical imperative of freedom in both its creative and political sense. To talk about "out-competing" allows one to build bridges to the existing mentalities prevalent in the older institutional forms of corporations and government. By contrast, to talk about "out-cooperating" stresses the "transcendent" aspects of peer production, those aspects which are non-capitalist, perhaps even post-capitalist. It stresses the open and free cooperation of producers who are creating a commons together and its transformative potential.
**Civic, market and public spheres**
How do we distinguish civil entities from private entities that choose to engage in some sort of social mission? On the one hand, civil entities are dedicated to the commons as a whole and exercise responsibility for its maintenance as an entity or institution, essentially based on non-market-based cooperation, and are organized as nonprofits; on the other hand, the private entities are voluntary associations of commoners that use market activity to create goods and services using a commons in order to guarantee their own individual and communal social reproduction. What joins both of these "sectors" is a common concern for maintaining the commons.
Over and above the civic and market spheres is a public sphere that is responsible for the overall collective good of the whole of society (as even commoners are primarily concerned with "their" commons). The public sector establishes the general parameters and supports in which the commons operates and by which commoners can thrive. The public sector of the P2P economy is neither a corporate welfare state at the service of a financial elite,7 nor a welfare state that has a paternalistic relation to civil society, but a Partner State, which serves civil society and takes responsibility for the metagovernance of the three spheres. The Partner State is dedicated to supporting "the common value creation of the civic sphere";8 the "market" and the "mission-oriented" activities of the new private sphere; and all the public services that are necessary for the common good of all citizens. (7. See Antonio Tricarico's essay on the financialization of natural resources in Part 2. 8. In peer production and shared innovation commons, the value is created in a common pool by the contributors, and not by individuals and corporations acting in a private capacity to sell commodities in a marketplace.)
It is very important here to distinguish the market from capitalism. Markets predate capitalism, and are a simple technique to allocate resources through the meeting of supply and demand using some medium of exchange. The allocation mechanism is compatible with a wide variety of other, eventually dominant systems. It is compatible with methods of "just pricing," full or "true cost accounting" (internalization of all costs), fair trade, etc. It does not require that labor and money be considered as commodities nor that workers be separated from the means of production. Markets can be subsumed to other logics and modalities such as the state or the commons.
Capitalism, on the other hand, considered by some as an "anti-market" (Braudel 1986), requires amongst other features: 1) the separation of producers and the means of production; and 2) infinite growth (either through competition and capital accumulation, as described by Karl Marx, or through compound interest dynamics, as described by Silvio Gesell).
In the vision of a commons-oriented society, the market is subsumed under the dominant logic of the commons and regulated by the Partner State. It is just one of the hybrid modalities that is compatible with the commons. This vision does not preclude an evolution of society through which the market may become entirely marginal, and be replaced by resource-based economics, for example.9 The important feature is to give commoners and citizens the freedom to choose amongst different mechanisms, and to arrive experimentally at the best solutions for the allocation of scarce resources. (9. In resource-based economics, resources could flow directly to the place of need, or be exchanged through barter or ledger systems, i.e., without recourse to money. It could be argued that a combination of networked cooperation, with open book management and transparency in accounting and production, makes the use of money for the exchange of resources obsolete. Feudal tribute systems are an older example of such money-free exchanges.)
The essential characteristic of the new system is that the commons is the new core, and a variety of hybrid mechanisms can productively coexist around it, including reformed market and state forms.
**Individuality, relationality and collectivity**
A commons-oriented society is not a return to premodern holism, in which the individual is subsumed to the whole, but rather a society that is based on the recognition of the need for relationality and collectivity of the free and equal individual. It is a society based on cooperative individualism rather than collectivism. Already today, in peer production, we can see how individuals can freely aggregate their contributions in a common project. This is possible because peer producers are much more in control of their own means of production, i.e., their personal creativity, computers, and access to networks. We propose to extend this vision and reality to the totality of the means of production. It should extend to citizen-peer producers so that they can aggregate the resources they need, including physical and financial capital stock, as well as coordinate their management practices and goals. This aggregation process will be guided by the need to guarantee good living conditions in a sustainable way. In this context, distributed property is a guarantee against the possible misuse of socialized common property, since the individual can also disaggregate and "fork" both his immaterial and material contributions. Most likely, the future commons society will give citizens an equal share of necessary natural resources to draw from, as well as some form of equitably distributed productive capital, giving them a certain independence from concrete and localized physical resources.
**How to get from here to there**
The animating social force of the commons-based, P2P society is that of citizen-workers seeing themselves as autonomous producers of shared knowledge and value. This is the great contribution of knowledge workers and the hacker class to the history of the modern labor and social movements. The innovations of this new sector can and should merge with the historical traditions of resistance, creation and emancipation of the traditional working class and peasantry, as well as the progressive sectors of the other classes.
One way to envisage alliances is to see merging of new constructive peer production communities in all areas of social life – which are producing the seeds of the new society within the old – with the remobilization of mass movements focused on a positive political program that is often lacking in this time of deep capitalist crisis. In other words, the convergence of the communities dedicated to the "construction of the new" and "resistance to the old" provides the energy and imagination for a new type of policy formulation, one that can recreate a global reform and transformation movement.
Another way to envisage future political and cultural alliances is to see them as a confluence of various global forces: 1) those working against the enclosure and the privatization of knowledge, which are simultaneously constructing new knowledge commons; 2) those working for environmental sustainability, including the protection of existing physical commons; and 3) those working for social justice on a local and global scale. In other words, we need a global alliance between the new "open" movements, the ecological movements, and the traditional social justice and emancipatory movements, in order to create a "grand alliance of the commons."
**References**
Bollier, David. 2009. _Viral Spiral: How the Commoners Built a Digital Republic of Their Own._ New York, NY. New Press.
Botsman, Rachel and Roo Rogers. 2010. _What's Mine is Yours: The Rise of Collaborative Consumption._ New York, NY. HarperCollins.
Brown, Marvin. 2010. _Civilizing the Economy. A New Economics of Provision._ Cambridge, MA. Cambridge University Press.
De Ugarte, David (no date). "Phyles: Economic Democracy in the Network Century." http://deugarte.com/gomi/phyles.pdf.
—————. (no date), "The Power of Networks."
http://deugarte.com/gomi/the-power-of-networks.pdf, Retrieved, October 20, 2011.
—————. (no date), and Pere Quintana, Enrique Gomez, and Arnau Fuentes. "From Nations to Networks." http://deugarte.com/gomi/Nations.pdf.
Gansky, Lisa. 2010. _The Mesh: Why the Future of Business is Sharing_. New York, NY. Penguin Group.
Greco, Thomas. 2009. _The End of Money and the Future of Civilization._ White River Junction, VT. Chelsea Green.
Hecksher, C. and Adler, P. 2006. _The Firm as a Collaborative Community – Reconstructing Trust in the Knowledge Economy._ New York, NY. Oxford University Press.
Helfrich, Silke, ed. 2009. _Genes, Bytes and Emissions: To Whom Does the World Belong?_ Heinrich Böll Foundation.
Hoeschele, Wolfgang. 2010. _The Economics of Abundance: A Political Economy of Freedom, Equity, and Sustainability._ Gower Publishing.
Hyde, Lewis. 2010. _Common as Air. Revolution, Art, and Ownership._ New York, NY. Farrar Straus Giroux.
Kane, Pat. 2003. _The Play Ethic: A Manifesto for a Different Way of Living._ London, UK. Macmillan.
Kleiner, Dmytri. 2010. _The Telekommunist Manifesto._ Institute for Network Cultures.
Krikorian, Gaelle and Kapczynski, Amy, eds. 2010. _Access to Knowledge in the Age of Intellectual Property._ New York, NY. Zone Books.
Lessig, Lawrence. 2004. _Free Culture_. New York, NY. Penguin.
O'Neill, Mathieu. 2009. _Cyberchiefs: Autonomy and Authority in Online Tribes_. London, UK. Macmillan/Pluto Press.
Raymond, Eric. 2001. _The Cathedral and the Bazaar_. Sebastopol, CA. O'Reilly.
Schor, Juliet. 2010. _Plenitude: The New Economics of True Wealth_ New York, NY. Penguin.
Stallman, Richard. 2002. _Free Software, Free Society._ Boston, MA. GNU Press.
von Hippel, Eric. 2004. _Democratizating Innovation._ Cambridge, MA: MIT Press.
Walljasper, Jay. 2010. _All That We Share: A Field Guide to the Commons_ New York, NY: New Press.
Wark, McKenzie. 2004. _A Hacker Manifesto_ Cambridge, MA. Harvard University Press.
Weber, Steve. 2004. _The Success of Open Source_. Cambridge, MA. Harvard University Press.
**Michel Bauwens** _(Belgium/Thailand) is the founder of the P2P Foundation, a global research collaborative network on peer production as well as Co-Founder of the Commons Strategies Group. He lives in Chiang Mai, in northern Thailand. Michel is currently Primavera Research Fellow at the University of Amsterdam and is an external expert at the Pontifical Academy of Social Sciences (2008, 2012)._
**Franco Iacomella** _(Argentina) is an activist and researcher on peer production and commons. He works for the Latin American Faculty of Social Sciences and the Open University of Catalunya. He is member of several organizations in the fields of open education, free software and commons-based peer production. He blogs at www.francoiacomella.org._
# Knowledge is the Water of the Mind: How to Structure Rights in "Immaterial Commons"
_By Rainer Kuhlen_
There is a simple ethical foundation for open access to and free usage of basic resources such as air and water: the mere existence and the development of every human being depend on them. But even fundamental ethical principles and human rights do not always prevail in real life. In history and even now, many knowledge and information resources are claimed as exclusive private property – that is, an owner has the right to exclude others from access to and usage of the property objects.
But aren't there some promising signs that history is not only, as Hegel has claimed, a development of freedom for the few to freedom for all, but also a development of the right of the few to control basic resources to the right of everyone to have such access and use?
Access must be sustainable, of course; the resource cannot be allowed to be overused. So a major challenge is how to make free and open access compatible with sustainability. In the following pages, I suggest applying the concept of sustainability, a basic concept of ecology, to knowledge. In doing this, I will also claim that the idea of a "knowledge economy" and "knowledge ecology" are compatible.
Ecology in general is concerned with the sustainability of natural resources by protecting them from overuse. A knowledge ecology is also concerned with sustainability, but with the sustainability of _immaterial goods_. This cannot be achieved by making knowledge a scarce resource, but only by providing open access to and free use of it on open platforms.
This redefinition of sustainability stems from the differing character of water and knowledge as goods. Knowledge is not consumed or exhausted when used. On the contrary, the more it is used, the more it benefits many people, and the greater the likelihood that new knowledge will be produced from existing knowledge. Such access and reuse makes knowledge sustainable not only for the present but also for future generations.
Knowledge ecology can therefore be defined as the sustainable treatment of knowledge and information (Kuhlen 2004). It is still a new and controversial concept. But there might be a consensus that what I call "immaterial commons" have the same ethical foundation as natural resources: Everyone needs them. Water (let us take it as a symbol of all other basic natural material resources) is essential for the existence of all human beings and for life in general. Yet human life also depends on permanent supplies of immaterial goods such as knowledge, information and culture. In this sense, knowledge is the equivalent of water. This is what I have in mind with the aphorism: _Knowledge is the water of the mind._ Water for physical survival and knowledge for intellectual development.
What is true for water is also true for knowledge. Both can be subject to exclusive private property rights. More accurately, access to knowledge has always, at least in modern Western societies, been subject to private appropriation through private intellectual property rights. As the reality of commercial information markets shows, people can very successfully be excluded from open, unrestricted access to knowledge.
**Knowledge as a common-pool resource and**
**(access to) knowledge as a commons**
Since the groundbreaking volume by Charlotte Hess and Elinor Ostrom (2007), knowledge has been increasingly considered as part of the commons, even though most academic literature still focuses on material, not immaterial commons. To be more precise and use a distinction that Elinor Ostrom takes pains to make, knowledge is part of the common heritage of humankind and thus a common-pool resource (CPR), but it is not necessarily a commons. Knowledge is the result of human development and the ensemble of intellectual activities that has been made publicly available in whatever media form, thus making it a very prominent common-pool resource. But that CPR need not be managed as a commons; it can conceivably be managed by the private rights holders or the state, for example.
"Knowledge," as understood in the literature, generally refers to "all intelligible ideas, information, and data in whatever form in which it is expressed or obtained" (Ostrom and Hess). In our understanding (different only slightly from Ostrom and Hess, but with major consequences) knowledge is primarily a cognitive concept, and cognitive concepts and theories, originally mental structures in the creators' minds, are only accessible, communicable and usable when they are represented in a media form. But the representation itself is not knowledge. Strictly speaking, a book is not a knowledge object; rather it _contains_ knowledge. A piece of music is not a knowledge object; it contains an idea of what the composer had in mind. From an information science point of view, we should avoid the term "knowledge objects" and rather speak of "information objects" when referring to objects that represent knowledge in some kind of media and that are made publicly available and are thus capable of communication and usage. Books, pieces of music and films are information objects that can be traded on commercial information markets or can be freely exchanged in open environments.
It is not our intention to insist on this rather sophisticated distinction between knowledge and information (Kuhlen 1991), and correspondingly knowledge objects and information objects. Therefore, in the following we will for the most part use the abbreviation k&i (knowledge and information), and occasionally use knowledge as a generic term to embrace both knowledge and information – keeping in mind that knowledge refers primarily to a common-pool resource, whereas knowledge as commons (resulting from an application of institutionalizing procedures to the pool resource) is in fact accessible and usable information.
This distinction has some consequences for "excludability" and the right to property. There is general consensus that knowledge itself is not protected by copyright nor by the European "Urheberrecht" (authors' right). Once knowledge is made publicly available in the world, it is in principle open and free to everyone. This is an important and fundamental right, but useless if _access_ to knowledge is withheld or not made possible. In reality access to knowledge, not to mention its free usage, depends on the ways that knowledge is made visible (transformed into information objects in whatever media form), by whom, and with what intentions. It also matters how these information objects are disseminated and made available for use, and under which conditions.
**How to structure rights in immaterial commons**
It is important to remember the distinction between common-pool resources and the commons that Elinor Ostrom has pointed out. Common pools of physical natural resources are provided to us by nature. Immaterial pools are the result of human development and/or the common heritage of humankind.
Each society at any given time in history has developed ways for making common-pool resources accessible and usable, and also for protecting them against overuse and ensuring that they are available and useful for future generations. In the language of institutional economics, common-pool resources only become a commons when they are institutionalized.
The institutionalizing forms are highly dependent on culture and on people's interests, however. They are also driven by the media and technology environments available at any given period of history and thus are subject to change. For instance, the analog world of the Gutenberg print paradigm makes knowledge visible, accessible, communicable and usable in different ways than electronic technologies in the Internet do. Changes in media and the technology environment have also influenced moral behavior – for instance, who can claim authorship and ownership of k&i, and with different implications for access and usage, for who is willing to share k&i, and who will seek to enclose it. The media and technology environment also influences the way political power and economic interests are structured and justified; in modern times, this occurs mainly through laws and the regulations for intellectual property rights.
The ways that commons are built and institutionalized are also affected by technology and the principles and procedures for administer it. Commons are not hieratic with characteristics given by nature or by religion, but rather, to put it in the terms of modern sociology, they are _socially constructed_. They are based on common, normative understandings. From an ethical point of view, the ways in which knowledge as a CPR is institutionalized into a knowledge commons are appropriate if they contribute to just, inclusive and sustainable forms of living for the highest possible number of people.
There is obviously a clear dichotomy between widespread social norms for the production and use of k&i that have been developed in electronic environments, and the dominant organizational and economic principles that govern the production of information goods in international information markets. There is not necessarily a contradiction between the institutionalization of k&i driven by economic self-interests and social norms. But at the moment there is a large chasm between the two and some deep incompatibilities.
For commercial actors, k&i must be made to be scarce objects to which access is controlled and limited, mainly by price, technical barriers and/or legal (copyright) constraints. Whatever objections we may have from a theoretical point of view, commercial publishing procedures serve to institutionalize knowledge. The knowledge production takes the form of a private goods regime, however, not a commons.
Figure 1 visualizes these alternative ways of institutionalizing knowledge, although it is surely too simple (as suggested by the illustration) to believe that modern societies have a free choice between an ethically driven approach and an economically driven one.
We do not have time and space here to elaborate on the hypothesis that institutionalization through copyright regulation is no longer an appropriate means to further economic innovation or to stimulate suitable k&i business models for electronic environments. For a long time, the state of technological development justified the commercial business models for k&i, primarily through copyright and patent law. One consequence was that only those who had the methodical know-how and capital to use the technology could produce and distribute information products. But the technological preconditions for this model are no longer valid in today's world of distributed, networked computing. As the Barcelona Charter issued by digital activists notes:
citizens, artists and consumers are no longer powerless and isolated in the face of the content production and distribution industries: now individuals across many different spheres collaborate, participate and decide in a direct and democratic way! "Free culture" ("free" as in "Freedom", not as "for Free") opens up the possibility of new models for citizen engagement in the provision of public goods and services. These are based on a 'commons' approach. '... Governing of the commons honors participation, inclusion, transparency, equal access, and long-term sustainability. (Barcelona Charter 2010)
In addition, current information market models show different forms of aporia, a puzzling uncertainty about how to move forward. It is therefore necessary to develop new models for the production, distribution, and usage of k&i. Any new model must take into account the following factors:
• Information market failure is becoming more and more evident, particularly with respect to science and education; the traditional intermediaries that guaranteed free access to k&i, e.g., universities, libraries, often can no longer afford to buy or lease commercial information products, or their services are limited and constrained by copyright regulation and/or by digital rights management (DRM).
• The public and people involved in science and education are no longer able or willing to buy or lease information that they themselves may have produced and peer-reviewed; they may want appropriate compensation from publishers or the ability to self-publish their information.
• Producers of k&i feel increasingly uncomfortable with the ways that commercial information markets try to disable people's "information autonomy" – i.e., how works may be used by others and what they expect as fair remuneration.
Finally, and most importantly, there is a shift in normative attitudes towards k&i; k&i objects are increasingly considered open, not proprietary, objects:
• Actors in open environments tend to share the resources they need to produce k&i and, consequently, they appreciate and take advantage of the value-added effects of working collaboratively.
• Producers of k&i believe that k&i are part of the public sphere and thus can be freely used so long as moral rights (chiefly attribution) and, sometimes, the privacy of the producers are respected.
• Users of k&i usually agree to attribute authorship of k&i objects they use to the original producers. They also accept that the k&i they produce by using open k&i will be made available under the same conditions as they enjoyed, i.e., giving the same usage/exploitation rights to other users.
• Producers and users of k&i feel responsible for the sustainability of k&i so that future generations can benefit from it.
• Producers and users of k&i in open environments do not object to the commercial exploitation of k&i as long as free access is guaranteed. The preferred practice is to release k&i immediately, without an embargo time, so that k&i can be commercially and openly available at the same time.
**Open access: a prominent way of institutionalizing**
**knowledge and making it a commons**
Open access is an increasingly popular form of institutionalizing knowledge that has been made publicly available for free access and usage. There is an international consensus on the main objectives of open access and the institutionalizing procedures that must be followed. The Berlin Declaration1 has made two conditions very clear: (1. Berlin Declaration on Open Access to Knowledge in the Science and Humanities, at http://bit.ly/xSbe5t)
1. The author(s) and right holder(s) of such contributions grant(s) to all users a free, irrevocable, worldwide right of access to, and a license to copy, use, distribute, transmit and display the work publicly and to make and distribute derivative works, in any digital medium for any responsible purpose, subject to proper attribution of authorship...
2. A complete version of the work and all supplemental materials...in an appropriate standard electronic format is deposited (and thus published) in at least one online repository using suitable technical standards...to enable open access, unrestricted distribution, interoperability, and long-term archiving.
Publishers on commercial information markets are becoming more and more aware that their business models based on exclusive proprietary of k&i are not only losing their economic appeal, but authors, users, and publicly funded institutions are rebelling. Therefore publishers feel forced to agree to new forms of open publishing. Two distinct forms of OA publishing are dominant. The so-called "Golden Road" to open access, which provides immediate access to works on a publisher's website, comes the closest to our understanding of knowledge as a commons. The "Green Road" approach, by contrast, relies upon authors self-archiving their works in their institutional Web repository, at a university, for example. Such self-archiving might be a secondary publication, after a certain embargo period (usually six months), following publication in a commercial journal.
Figure 2 illustrates some of the possible models for institutionalizing open access k&i in both open and proprietary contexts.
Figure 2 also shows that a knowledge economy and knowledge ecology do not need to be mutually exclusive; they can be entirely compatible. Some publishers, for example, have begun to follow the Golden Road and make their journals available in open access forms – for instance, Springer with its SpringerOpen journals (http://www.springeropen.com). This sounds revolutionary and economically impractical because the OA paradigm requires that all articles be freely available and maintain high peer-review standards, but also because authors retain their copyright completely. But Springer, a commercial company, is still able to earn a profit from its OA publications because it charges users and their institutions for the expense of producing journal articles (which are then made available free online). In the end, it is the public (as taxpayers and students) that pays for commercial OA journals and, in addition, meets the company's expectation of profits.
At this stage, there is increasing public consensus that publishing in science and education should not be subject to commercial exploitation. On the other hand, there is a willingness on the part of many science institutions to finance commercial OA publishing, in order to keep professional publishers with their expertise in the market, as long as they make their publications freely available to everyone.2 In any case, the future of scientific publishing will be OA publishing. (2. For example: The compact for open-access publishing equity supports equity, or COPE, of the business models by committing each university to "the timely establishment of durable mechanisms for underwriting reasonable publication charges for articles written by its faculty and published in fee-based open-access journals and for which other institutions would not be expected to provide funds." (http://www.oacompact.org/). Cf. SCOAP3 – Sponsoring Consortium for Open Access Publishing in Particle Physics (http://scoap3.org/); and the SpringerOpen model of prepay membership (http://www.springeropen.com/libraries/prepaymembership).)
**Open questions**
Even if open access is in principle acknowledged to be the currently most inclusive and sustainable paradigm for access to and use of knowledge, there are still many open questions that need to be answered in order to assure that knowledge is appropriately institutionalized as a commons. Here are some of these questions, mainly concerning how to materialize the copyright regulation towards an understanding and a practice of knowledge as an immaterial commons:
• Given the increasingly open, collaborative and derivative nature of k&i production, does it still make sense to speak of individual intellectual property rights (IPR) rather than common IPR?
• Is there a need for new types of property rights now that knowledge is increasingly produced collaboratively? After all, two pillars of copyright law – the concept of single authorship and that of the final, unchangeable work – have become more and more obsolete.
• Which property rights should the public have to commons objects such as k&i? Is there a need for compensating the public when the knowledge that belongs to a commons is exploited for commercial usage? And if so, what kind of compensation is adequate? Or will the model of the future be that the public, in addition to covering the cost for the production of knowledge, finances commercial OA publishing as it has done by financing libraries?
• Which rights should authors who create new content have? Are the moral rights (primarily attribution of authorship) sufficient, or should an appropriate remuneration system be established?
• Is it still appropriate for the state to regulate processes for knowledge commons, for instance, via patent or copyright laws? Or should it be up to the commoners themselves to organize k&i processes, rules and enforcement systems?
In this essay we have concentrated primarily but not exclusively on knowledge in science and education environments, and also on institutionalizing forms via formal procedures such as copyright law. This is obviously a rather reductionist approach. Knowledge as an immaterial commons has a much broader range, and there are many ways of transforming knowledge as a common-pool resource into an accessible and usable commons. The debate on how best to institutionalize knowledge as an immaterial commons is still open.
**References**
Free Culture Forum. 2010. _Charter for Innovation, Creativity and Access to Knowledge 2.0.1: Citizens' and Artists' Rights in the Digital Age._ Barcelona, Spain. http://fcforum.net/charter_extended.
Hess, Charlotte; Ostrom, Elinor, eds., 2007. _Understanding Knowledge as a Commons: From Theory to Practice._ Cambridge, Massachusetts. MIT Press.
Kuhlen, Rainer. 1991. "Information and Pragmatic Value-adding: Language Games and Information Science." _Computer and the Humanities_ (25):93-101. http://www.jstor.org/pss/30200254.
—————. 2004. "Wissensökologie" In Kuhlen, Rainer; Thomas Seeger and Dietmar Strauch, eds. _Grundlagen der praktischen Information und Dokumentation. Handbuch zur Einführung in die Informationswissenschaft und -praxis.5._ (Auflage 2004): 105-113. http://bit.ly/nus2vn
—————. 2010. "Ethical Foundation of Knowledge as a Commons." In _Proceedings of the International Conference commemorating the 40th Anniversary of the Korean Society for Library and Information Science._ Seoul, Korea. Oct. 8th 2010. http://bit.ly/fEAZyK.
**Rainer Kuhlen** _(Germany) is Professor Information Science, University of Konstanz; Member of the German Committee, UNESCO; and Member of the Green Academy. His most recent book is _Successful Failure: Twilight of Copyright? (2008, in German). His current project is IUWIS, http://www.iuwis.de. Personal website: www.kuhlen.name. Blog: www.netethics-net.
_"The future is not some place we are going to, but one we are creating. The paths to it are not found, but made; and the activity of making them changes both the maker and the destination."_
Peter Ellyard, Australian physicist
# PART FIVE
****
ENVISIONING A COMMONS-BASED POLICY
_AND PRODUCTION FRAMEWORK_
# Green Governance: Ecological Survival, Human Rights and the Law of the Commons
_By David Bollier and Burns H. Weston_
At least since Rachel Carson's _Silent Spring_ , we have known about humankind's squandering of nonrenewable resources, its careless disregard of precious life species and its overall contamination and degradation of delicate ecosystems. In recent decades, these defilements have assumed a systemic dimension. Lately we have come to realize the shocking extent to which our atmospheric emission of carbon dioxide and other greenhouse gases threatens Planet Earth.
If the human species is going to overcome the many interconnected ecological catastrophes now confronting us, this moment in history requires that we entertain some bold modifications of our legal structures and political culture. We must find the means to introduce new ideas for effective and just environmental protection – locally, nationally, regionally, globally, and points in between.
We believe that effective and just environmental protection is best secured via _commons- and rights-based ecological governance_ , operational from local to global and administered according to principles rooted in respect for nature and fellow human beings. We call it "green governance." We also believe that the rigorous application of a reconceptualized human right to a clean and healthy environment (or "right to environment") is the best way actually to promote environmental well-being while meeting everyone's basic needs.
**Making the transition to a new paradigm**
It is our premise that human societies will not succeed in overcoming our myriad eco-crises through better "green technology" or economic reforms alone; we must pioneer new types of governance that allow and encourage people to move from anthropocentrism to biocentrism, and to develop qualitatively different types of relationships with nature itself and, indeed, with each other. An economics and supporting civic polity that valorizes growth and material development as the precondition for virtually everything else are ultimately a dead end – literally.
Achieving a clean, healthy and ecologically balanced environment requires that we cultivate a practical governance paradigm based on, first, a logic of respect for nature, sufficiency, interdependence, shared responsibility and fairness among all human beings; and, second, an ethic of integrated global and local citizenship that insists upon transparency and accountability in all activities affecting the integrity of the environment.
We believe that commons- and rights-based ecological governance – green governance – can fulfill this logic and ethic. Properly done, it can move us beyond the neoliberal State and Market alliance – what we call the "State/Market" – which is chiefly responsible for the current, failed paradigm of ecological governance. (We capitalize "State," "Market" and Commons here when referrring to them as systems of governance and power.)
The basic problem is that the price system, seen as the ultimate governance mechanism of our polity, falls short in its ability to represent notions of value that are subtle, qualitative, long-term and complicated. These are, however, precisely the attributes of natural systems. The price system has trouble taking account of qualitatively different types of value on their own terms, most notably the "carrying capacity" of natural systems and their inherent usage limits. Exchange value is the primary if not the exclusive concern. This, in fact, is the grand narrative of conventional economics. Gross Domestic Product represents the sum total of all market activity, whether that activity is truly beneficial to society or not. Conversely, anything that does not have a price and exists "outside" the market is regarded (for the purposes of policymaking) as having subordinate or no value.
What is more, it is an open secret that various industry lobbies have captured if not corrupted the legislative process in countries around the world; and that the regulatory apparatus, for all its necessary functions, is essentially incapable of fulfilling its statutory mandates, let alone pioneering new standards of environmental stewardship. Further, regulation has become ever more insulated from citizen influence and accountability as scientific expertise and technical proceduralism have come to be more and more the exclusive determinants of who may credibly participate in the process. **** Given the parameters of the administrative State and the neoliberal policy consensus, truly we have reached the limits of leadership and innovation within existing institutions and policy structures.
Still, it will not be an easy task to make the transition from State/Market ecological governance to commons- and rights-based ecological governance. Green governance is, indeed, a daunting proposition. It entails serious reconsideration of some of the most basic premises of our economic, political and legal orders, and of our cultural orders as well. It requires that we enlarge our understanding of "value" in economic thought to account for nature and social well-being; that we expand our sense of human rights and how they can serve strategic as well as moral purposes; that we liberate ourselves from the limitations of State-centric models of legal process; and that we honor the power of non-market participation, local context, and social diversity in structuring economic activity and addressing environmental problems.
Of course, there is also the deeper issue of whether contemporary civilization can be persuaded to disrupt the status quo to save our "lonely planet." Much will depend on our ability to articulate and foster a coherent new paradigm of ecological stewardship. Fortunately, there are some very robust, encouraging developments now beginning to flourish on the periphery of the mainstream political economy. These include insurgent schools of thought in economics, ecological management, and human rights aided by fledgling grassroots movements, e.g., the Occupy movement and Internet communities. Although disparate and irregularly connected, each seeks in its own way to address the many serious deficiencies of centralized governments (corruption, lack of transparency, rigidity, a marginalized citizenry) and concentrated markets (externalized costs, fraud, the bigger-better-faster ethos of material progress). Taken together, these trends suggest the emergent contours of a new paradigm of ecological governance.
For all their power and potential, however, none of these movements or their visions can prevail without some serious grounding in law. And in this regard we believe the legal and moral claims of human rights can be the kind of powerful, mobilizing discourse that is needed for real change. Human rights can provide a broad, flexible platform and a respected legal framework for asserting the right of everyone to a clean and healthy environment.
**The human right to a clean and healthy environment**
Human rights signal a public order of human dignity, for which environmental well-being is essential. They consequently challenge and make demands upon State sovereignty, and upon the parochial agendas of private elites as well. They trump most other legal obligations, being juridically more elevated than commonplace "standards," "laws," or mere policy choices. And they carry with them a sense of entitlement on the part of the rights-holder, and thus facilitate legal and political empowerment.
For these and other reasons, we believe that the human right to a clean and healthy environment can be a powerful tool for imagining and securing a system of ecological, governance in the common interest. But there are skeptics who say that the right does not exist except in moral terms – that it lacks the elements of authority and/or control requisite to making it count as law. Are they right? The answer is both "yes" and "no."
According to the law of the State system, there are at least three ways in which the human right to environment is today officially recognized juridically:
• _As an entitlement derived from other recognized rights_ , centering primarily on the substantive rights to life, to health and to respect for private and family life, but embracing occasionally other perceived surrogate rights as well – e.g., habitat, property, livelihood, culture, dignity, equality or nondiscrimination, and sleep;
• _As an entitlement autonomous unto itself_ , dependent on no more than its own recognition and increasingly favored over the derivative approach insofar as national constitutional and regional treaty prescriptions proclaiming such a right are evidence; and
• _As a cluster of procedural entitlements_ generated from a "reformulation and expansion of existing human rights and duties" (akin to the derivative substantive rights noted first above) and commonly referred to as "procedural environmental rights," i.e., the right to environmental information, to participation in decisionmaking, and to administrative and judicial recourse.
A careful review of each of these official manifestations of the right to environment around the world reveals that, however robust in their particularized applications, they are essentially limited in their legal recognition and jurisdictional reach. It also shows that, as part of our legal as well as moral inheritance, the right to environment needs to be taken extra seriously. For this to happen – indeed, for Earth itself to survive and be hospitable to life upon it– the right must be reimagined and reinvigorated, and as soon as possible.
Juridically, this right is most strongly recognized in its derivative form, i.e., derived from other recognized legal rights, rather than in its autonomous form, i.e., legally recognized in its own right. When framed autonomously, interestingly, the right is found to exist principally – indeed, almost exclusively – in the developing worlds of Africa, Asia, and Latin America. There is also a growing sentiment (primarily at the regional level so far) to recognize procedural environmental rights.
But at bottom, it seems that as long as ecological governance remains in the grip of essentially unregulated (liberal or neoliberal) capitalism, there never will be a human right to environment – certainly not an autonomous one, widely recognized and honored across the globe in any formal or official sense.
In recent years, however, two attractive alternative approaches have emerged. The first approach – intergenerational environmental rights – though firm in legal theory, relies heavily on its ability to appeal to the moral conscience. The second – nature's environmental rights – pioneered by the governments of Ecuador and Bolivia, chooses to alter the procedural playing field altogether. These nations assert that nature has legal rights of its own that must be defended by human surrogates.
Both these approaches go beyond the narrow anthropocentrism of existing law. In their legal character they are autonomous rights rather than derivative rights. They look to claimant surrogates to enforce the rights. And they are asserted primarily at the official national and subnational levels. Politically, both approaches reflect a deep frustration with the environmental community's conventional terms of advocacy and with the formal legal order's deep commitments to neoliberalism.
However, barring some game-changing ecological disaster, huge economic and political forces will continue to resist these innovative legal gambits for reasons that are both historical and philosophical. Green governance that looks to the Commons points toward a different approach for securing a right to a clean and healthy environment. It calls for the establishment of a new procedural environmental right, _the human right to commons- and rights-based ecological governance._
**The commons as a model for ecological governance**
A _commons_ is a regime for managing common-pool resources that eschews individual property rights and State control. It relies instead on common property arrangements that tend to be self-organized and enforced in complex, idiosyncratic social ways. A commons is generally governed by what we call _Vernacular Law –_ the "unofficial" norms, institutions, and procedures that a peer community devises to manage community resources on its own, and typically democratically. State Law and action may set the parameters within which Vernacular Law operates, but it does not directly control how a given commons is organized and managed.
In this way, the Commons operates in a quasi-sovereign manner, similar to the Market but largely escaping the centralized mandates of the State and the logic of Market exchange while mobilizing decentralized participation "on the ground." In its broadest sense, the Commons could become an important vehicle for assuring a right to environment at local, regional, national, and global levels. But this role will require innovative legal and policy norms, institutions and procedures to recognize and support Commons as a matter of law.
The Commons represents an advance over existing governance because it gives us practical ways of naming and protecting value that the market is incapable of doing, and, as already noted, in an essentially democratic manner. For example, the Commons gives us a vocabulary for talking about the proper limits of Market activity—and for enforcing those limits. Commons discourse helps force a conversation about the "market externalities" that often are shunted to the periphery of economic theory, politics and policymaking. It asks questions such as: How can appropriate limits be set on the market exploitation of nature? What legal principles, institutions, and procedures can help manage a shared resource fairly and sustainably over time, sensitive to the ecological rights of future as well as present generations?
The paradigm of green governance is compelling because it comprises at once a basis in _rich legal tradition_ that extends back centuries, an _attractive cultural discourse_ that can organize and personally energize people, and a widespread _participatory social practice_ that, at this very moment, is producing practical results in projects big and small, local and transnational.
The history of legal recognition of the Commons, and thus the commoners' right to the environment, goes back centuries and even millennia. There were forestry conservation laws in effect as early as 1700 B.C. Pharaoh Akhenaten established nature reserves in Egypt in 1370 B.C. Hugo Grotius, often called the father of international law, argued in his famous treatise _Mare Liberum_ (1609) that the seas must be free for navigation and fishing because the law of nature prohibits ownership of things that appear "to have been created by nature for common things"(Baslar 1998).1 Antarctica has been managed as a stable, durable intergovernmental commons since the ratification of the Antarctic Treaty in 1959, enabling international scientists to cooperate in major research projects without the threat of military conflict over territorial claims. The Outer Space Treaty of 1967 declares outer space, the moon and other celestial bodies to be the "province of all mankind" and "not subject to national appropriation...." (1. See also the essay by Prue Taylor in Part 5.)
Commons have been a durable transcultural institution for assuring that people can have direct access to, and use of, natural resources, or that government can act as a formal trustee on behalf of the public interest – what we call "State trustee commons." Commons regimes have acted as a kind of counterpoint to the dominant systems of power because, though the structures of State power have varied over the centuries (tribes, monarchies, feudal estates, republics), managing a forest, fishery, or marshland as a commons addresses certain ontological human wants and needs that endure: the need to meet one's subsistence needs through cooperative uses of shared resources; the expectation of basic fairness and respectful treatment; and the right to a clean, healthy environment.
In this sense, the various historical fragments of what may be called "commons law" (not to be confused with the common law) constitute a legal tradition that can advance human and environmental rights. These regimes speak to the elemental moral consensus that all the creations of nature and society that we inherit from previous generations should be protected and held in trust for future generations.
In our time, the State and Market are seen as the only credible or significant forces for governance. But in fact the Commons is an eminently practical and versatile mode of governance for ecological resources, among many other forms of shared wealth. The viability of the Commons has been overlooked not just because of the persistence of the Hardin "tragedy" parable and the overweening power of the State/Market, but because the Commons exists in so many forms and is managed by so many different types of commoners.
**Imagining a new architecture of law and policy to support the ecological commons**
For a shift to this paradigm to take place, State law and public policy must formally recognize and support the countless commons that now exist and the new ones that must be created. By such means, the State, working with civil society, could facilitate the rise of a Commons Sector, an eclectic array of commons-based institutions, projects, social practices, and values that advance the policy of collective action. Extending to the Commons the legal recognition and generous backing the "free state" and "free market" have enjoyed for generations would unleash tremendous energy and creativity needed to provide better institutional stewardship of our planet. Such recognition of Commons could also help transform the State and Market in many positive ways, not least by checking the cronyism, corruption and secrecy that currently mark each.
If the Commons is going to achieve its promise as a governance template, however, there must be a suitable architecture of law and public policy to support it. We believe that innovations in law and policy are needed in three distinct fields:
1. _General internal governance principles and policies_ that can guide the development and management of commons;
2. _Macro-principles and policies_ – laws, institutions and procedures – that the State/Market can embrace to develop commons and "peer governance"; and
3. _Catalytic legal strategies that commoners_ (civil society and distinct communities), the State, and international intergovernmental bodies can pursue to validate, protect and support ecological commons thus defined.
_General internal governance principles and policies._ Ostrom's eight core design principles, first published in 1990, remain the most solid foundation for understanding the internal governance of commons as a general paradigm. In a book-length study published in 2010, Poteete, Janssen and Ostrom summarize and elaborate on the key factors enabling self-organized groups to develop collective solutions to common-pool resource problems at small to medium scales:
Among the most important are the following: 1) reliable information is available about the immediate and long-term costs and benefits of actions; 2) the individuals involved see the resources as important for their own achievements and have a long-term time horizon; 3) gaining a reputation for being a trustworthy reciprocator is important to those involved; 4) individuals can communicate with at least some of the others involved; 5) informal monitoring and sanctioning is feasible and considered appropriate; and 6) social capital and leadership exist, related to previous successes in solving joint problems (Poteete, Janssen and Ostrom 2010).
Ostrom notes that "extensive empirical research on collective action...has repeatedly identified a necessary central core of trust and reciprocity among those involved that is associated with successful levels of collective action." In addition, "when participants fear they are being 'suckers' for taking costly actions while others enjoy a free ride," it enhances the need for monitoring to root out deception and fraud.
If any commons is to cultivate trust and reciprocity and therefore enhance its chances of stable collective management, its operational and constitutional rules must be seen as fair and respectful. To that end, ecological commons must embody the values of human dignity as expressed in, optimally, the Universal Declaration of Human Rights and nine core international human rights conventions that have evolved from it or those of them as may be applicable. As this suggests, both human rights and nature's rights are implicit in ecological commons governance.
_Macro-principles and policies._ For larger-scale common-pool resources – national, regional, global – the State must play a more active role in establishing and overseeing commons. The State may have an indispensable role to play in instances where a resource cannot be easily divided into parcels (the atmosphere, oceanic fisheries) or where the resource generates large rents relative to the surrounding economy, e.g., petroleum. In such cases, it makes sense for the State to intervene and devise appropriate management systems. _State trustee commons_ typically manage hard and soft minerals, timber, and other natural resources on public lands, national parks and wilderness areas, rivers, lakes and other bodies of water, State-sponsored research, and civil infrastructure, among other things.
In such circumstances, however, there is a structural tension between commoners and the State/Market because the State has strong economic incentives to forge deep political alliances with the Market and thus promote an agenda of privatization, commoditization and globalization despite the adverse consequences for ecosystems and commoners. Any successful regime of commons law must therefore recognize this reality and take aggressive action to ensure that the State/Market does not betray its trust obligations, particularly by colluding with market players in acts of enclosure.
The overall goal must be to reconceptualize the neoliberal State/Market as a "triarchy" with the Commons – the _State/Market/Commons –_ to realign authority and provisioning in new, more beneficial ways.2 The State would maintain its commitments to representative governance and management of public property just as private enterprise would continue to own capital to produce saleable goods and services in the Market sector. But the State must shift its focus to become a "Partner State," as Michel Bauwens puts it, not just of the Market Sector but also of the Commons Sector.3 (2. The term "triarchy" is Michel Bauwens', who expounds on the topic at the P2P Foundation blog, at http://blog.p2pfoundation.net/the-new-triarchy-the-commons-enterprise-the-State/2010/08/25. Peter Barnes has also been an early expositor of the Commons sector, especially in his _Capitalism 3.0: A Guide to Reclaiming the Commons_ (2006). 3. See essay by Michel Bauwens in Part 5.)
_Catalytic legal strategies._ Perhaps the most significant challenge in advancing commons governance is the liberal polity's indifference or hostility to most collectives (corporations excepted). Accordingly, commoners must use ingenious innovations to make their commons legally cognizable and protected. Since legal regimes vary immensely around the world, our proposals should be understood as general approaches that obviously will require modification and refinement for any given jurisdiction. Still, there are a number of legal and activist interventions that could help advance commons governance in select areas.
• Devising ingenious adaptations of private contract and property law is a potentially fruitful way to protect commons. The basic idea is to use conventional bodies of law serving private property interests, but invert their purposes to serve collective rather than individual interests. The most famous example may be the General Public License, or GPL, which copyright owners can attach to software in order to assure that the code and any subsequent modifications of it will be forever accessible to anyone to use.4 The GPL was a seminal legal innovation in helping to establish commons for software code. (4. See Benjamin Mako Hill's essay on free software in Part 4.)
• A number of examples of eco-minded trusts serving the interests of indigenous peoples and poorer countries could emulate private-law work-arounds to property and contract law in order to create new commons. One example is the Global Innovation Commons, a massive international database of lapsed patents that enables anyone to manufacture, modify and share ecologically significant technologies.5 (5. See David Martin's essay on public-domain technologies in Part 4.)
• The "stakeholder trust" could be used to manage and lease ecological resources on behalf of commoners, with revenues being distributed directly to commoners. This model is based on the Alaska Permanent Fund, which collects oil royalties from state lands on behalf of the state's households. Some activists have proposed an Earth Atmospheric Trust to achieve similar results from the auctioning of rights to emit carbon emissions.
• Some of the most innovative work in developing ecological commons (and knowledge commons that work in synergy with them) is emerging in local and regional circumstances. The reason is simple: the scale of such commons makes participation more feasible and the rewards more evident. Salient examples are being pioneered by the "re-localization movement" in the US and UK, and by the Transition Town movement in more than 300 towns worldwide.6 (6. See Gerd Wessling's essay on the Transition movement in Part 3.)
• Federal and provincial governments have a role to play in supporting commons formation and expansion. State and national governments usually have commerce departments that host conferences, assist small businesses, promote exports and so on. Why not analogous support for commons? Governments could also help build translocal structures that could facilitate local and subnational commons, such as Community Supported Agriculture and the Slow Food movement, and thereby amplify their impact.
• The public trust doctrine of environmental law can and should be expanded to apply to a far broader array of natural resources, including protection of the Earth's atmosphere. This would be an important way to ensure that States act as conscientious trustees of our common ecological wealth.
• Various digital networking technologies now make it possible to reinvent the administrative process to be more transparent, participatory and accountable – or indeed, managed as commons. For example, government wikis and "crowd-sourcing" platforms could help enlist citizen-experts to participate in policymaking and enforcement. "Participatory sensing" of water quality and other environmental factors could be decentralized to citizens with a stake in those resources.
**Moving forward**
It might be claimed that green governance is a utopian enterprise. But the reality is that it is the neoliberal project of ever-expanding consumption on a global scale that is the utopian, totalistic dream. It manifestly cannot fulfill its mythological vision of human progress through ubiquitous market activity. It simply demands more than Nature can deliver, and it inflicts too much social inequity and disruption in the process. The first step toward sanity requires that we recognize our myriad ecological crises as symptoms of an unsustainable cultural, socioeconomic and political worldview.
Moving to green governance will entail many novel complexities and imponderable challenges. Yet there is little doubt that we must re-imagine the role of the State and Market, and imagine alternative futures that fortify the Commons Sector. We must gird ourselves for the ambitious task of mobilizing new energies and commitments, deconstructing archaic institutions while building new ones, devising new public policies and legal initiatives, and cultivating new understandings of the environment, economics, human rights, governance, and commons.
**References**
Baslar, Kemal. 1998. _The Concept of the Common Heritage of Mankind and International Law_. Boston, MA. Martinus Nijhoff Publishers. 1997.
Poteete, Amy R., Marco A. Janssen and Elinor Ostrom. 2010. _Working Together: Collective Action, the Commons and Multiple Methods in Practice._ Princeton, NJ. Princeton University Press.
_This essay is derived from a longer treatise available at The Commons Law Project, at http://www.commonslawproject.org. Bollier and Weston will publish a book on this topic, _Green Governance _, in early 2013 (Cambridge University Press)._
**David Bollier** _(USA) is an author, activist and independent scholar of the commons. He is Co-Founder of the Commons Strategies Group, Co-Director of the Commons Law Project (CLP), and the author of ten books, including _Viral Spiral _and_ Silent Theft. _He lives in Amherst, Massachusetts and blogs at www.Bollier.org._
**Burns H. Weston** _(USA) is Distinguished Professor of Law Emeritus & Senior Scholar at the Center for Human Rights at the University of Iowa. He is Director of the Climate Legacy Initiative, Co-Director of the Commons Law Project (CLP) and Fellow of the World Academy of Art and Science. He co-edited _World Order: A Problem-Oriented Coursebook ( _2011)._
# The Common Heritage of Mankind:A Bold Doctrine Kept Within Strict Boundaries
_By Prue Taylor_
The "common heritage of mankind" is an ethical concept and a general concept of international law. It establishes that some localities belong to all humanity and that their resources are available for everyone's use and benefit, taking into account future generations and the needs of developing countries. It is intended to achieve aspects of the sustainable development of common spaces and their resources, but may apply beyond this traditional scope.
When first introduced in the 1960s, the "common heritage of mankind" (CHM) was a controversial concept, and it remains so to this day. This controversy includes issues of scope, content and status, together with CHM's relationship to other legal concepts. Some commentators consider it out of fashion due to its lack of use in practice, e.g., for mining of seabed resources, and its subsequent rejection by modern environmental treaty regimes. In contrast, other commentators consider it a general principle of international law with enduring significance.
Escalating global ecological degradation and ongoing inability to arrest the so-called tragedy of the commons (Hardin 1968) will ensure the continued relevance of the common heritage concept, despite the difficulties surrounding its acceptance by states. Evidence for this can be found in a range of efforts to apply CHM to natural and cultural heritage, marine living resources, Antarctica and global ecological systems such as the atmosphere (Taylor 1998) or climate system.
**Origins of the principle**
Legal discussion of CHM generally begins with the speech of the Maltese ambassador Arvid Pardo (1914–1999) to the United Nations in 1967. In this speech he proposed that the seabed and ocean floor beyond national jurisdiction be considered the CHM. This was an important event that triggered the later negotiation of the 1982 Law of the Sea Convention (UNCLOS III) and other legal developments that subsequently earned Arvid Pardo the title "father of the law of the sea." But CHM has a much longer history, and Pardo drew upon this in developing CHM as a legal concept for the oceans. Other people, including the writer and environmentalist Elisabeth Mann Borgese (1918 – 2002) considered CHM an ethical concept central to a new world order, based on new forms of cooperation, economic theory and philosophy. This history is important to elucidating the ethical core of CHM: the responsibility of humans to care for and protect the environment, of which we are a part, for present and future generations.
A 1948 draft World Constitution provided that the Earth and its resources were to be the common property of mankind, managed for the good of all. Concern about the use of nuclear technology and resources, for military and peaceful purposes, also led to an early proposal that nuclear resources be collectively owned and managed, and not owned by any one state. Traces of CHM are also found in the U.N. Outer Space Treaty (1967), which governs state exploration and use of outer space, the moon, and other celestial bodies. CHM, however, achieved prominence in the context of the evolving law of the sea. The 1967 World Peace through Law Conference referred to the high seas as "the common heritage of mankind" and stated that the seabed should be subject to U.N. jurisdiction and control.
**Revolutionizing the law of the sea**
Concern about the impact of new technologies upon the oceans, militarization and expanding state claims to ownership of parts of the oceans, e.g., continental shelf and exclusive economic zones, together with growing economic disparity and associated harm to long-term human security, prompted Arvid Pardo to develop the idea that all ocean space, i.e., surface of the sea, water column, seabed and its subsoil, and living resources, should be declared the CHM, irrespective of existing claims to national jurisdiction.
The intention was to replace the outdated legal concept of "freedom of the high seas" by proclaiming ocean areas an international commons. (Areas with significant natural resources that are acknowledged to be beyond the limits of the national jurisdiction of sovereign states are known as international commons.) Freedom of the high seas, developed by the Dutch jurist Hugo Grotius (1583–1645), creates an open access regime allowing for its laissez-faire use. The few restrictions that exist serve only to protect the interests of other states and their exercise of free use.
In contrast, as the CHM, ocean space and its resources would be a commons that could not be owned by states beyond a certain limit. As a commons it would be open to the international community of states, but its use would be subject to international administration and management for the common good of all humanity. Where areas of ocean space and resources existed within national jurisdiction, states would regulate and manage use on behalf of all mankind, not solely for the benefit of national interests.
This approach recognized the unity of the oceans as ecological systems and rejected both laissez-faire freedom and unfettered state sovereignty. It included efforts to simplify ocean jurisdiction by establishing one single line of demarcation between national and international ocean space (Draft Ocean Space Treaty of 1971) and prevent gradually expanding claims to national jurisdiction.
The CHM was originally intended as a concept that would revolutionize the law of the sea by applying to all ocean space and resources. But in 1967 Arvid Pardo recognized that this would be rejected by the powerful states who were attempting to extend their sovereign claims to more ocean space and resources. By focusing on the legal status of the much more limited entity of the "seabed" beyond national jurisdiction, it was thought that CHM could gain an important foothold within the U.N. system.
The 1967 Maltese proposal lead to a number of important developments, including the 1970 U.N. General Assembly Declaration of Principles Governing the Sea-Bed and the Ocean Floor and the Subsoil Thereof, Beyond the Limits of National Jurisdiction. This declaration set out the legal principles needed to implement the notion that the seabed and its resources are the CHM, and it helped create consensus for the negotiation of a new law of the sea convention: UNCLOS III (U.N. Convention on the Law of the Sea). The ultimate outcome was a much more limited application of CHM than ever intended by its advocates. As will be explained immediately below, UNCLOS III restricted the application of CHM to a few rocks, e.g., mineral resources such as manganese nodules, sitting on the bottom of the deep seabed.
Part XI of UNCLOS III deals with the seabed and ocean floor and subsoil thereof (the "Area") beyond the limits of national jurisdiction. Article 136 declares the Area and its resources (only) to be the "common heritage of mankind." The Area and its resources cannot be claimed, appropriated, or owned by any state or person (Article 137). All rights to resources belong to mankind as a whole, with the International Seabed Authority (ISA) acting on mankind's behalf (Article 140). The ISA must ensure the equitable sharing of financial and other benefits arising from activities in the Area, taking into particular account the needs and interests of developing states and others. Promotion of research, transfer of technology to developing states and protection of the marine environment's ecological balance are all important functions of the ISA (Articles 143–145).
Part XI provisions create an international administration and management regime for only a small part of the international commons (the Area and its resources). It does not generally replace the freedom of the high seas (Part VII); thus the intended revolution of the law of the sea was not achieved. In the 1970s, the most commercially viable mineral resources of the Area were thought to be manganese nodules, hence Pardo's view that CHM was reduced in its application to "ugly little rocks lying in the darkest depths of all creation." Despite this serious limitation, the use of CHM was revolutionary enough to be one of the reasons why the US refused to adhere to UNCLOS III.
To date, commercial use of the Area and its resources has not occurred. Further, the traditional fragmented approach to jurisdiction over separate elements of ocean space and resources endures despite the irrefutable unity of ecological systems.
**1979 Moon Treaty**
Even though aspects of CHM appeared in the 1967 Outer Space Treaty, it was not until 1979 that a clear statement appeared in the Moon Treaty, a treaty to govern exploration and exploitation of the moon's resources. Article 11(1) declares that the moon and its natural resources are the CHM. Disputes concerning the details of an international system for resource exploitation, including provision for equitable benefit sharing, were resolved by deferring the details of a management regime for the future. The Moon Treaty has been ratified by only a few states; nevertheless it has been used to reject claims to property rights on the basis that it creates a general principle of law, applicable to the whole of the international community and not just states that ratified the treaty.
**Core elements**
There is no concise, fully agreed upon definition of CHM. Its features depend upon the details of the regime applying it or the space/resource to which it is applied. There are a number of core elements, however:
• No state or person can own common heritage spaces or resources (the principle of non-appropriation). They can be used but not owned, as they are a part of the international heritage (patrimony) and therefore belong to all humankind. This protects the international commons from expanding jurisdictional claims. When CHM applies to areas and resources within national jurisdiction, exercise of sovereignty is subject to certain responsibilities to protect the common good.
• The use of common heritage shall be carried out in accordance with a system of cooperative management for the benefit of all humankind, i.e., for the common good. This has been interpreted as creating a type of trustee relationship for explicit protection of the interests of humanity, rather than the interests of particular states or private entities. There shall be active and equitable sharing of benefits (including financial, technological, and scientific) derived from the CHM. This provides a basis for limiting public or private commercial benefits and prioritizing distribution to others, including developing states (intragenerational equity between present generations of humans).
• CHM shall be reserved for peaceful purposes (preventing military uses).
• CHM shall be transmitted to future generations in substantially unimpaired condition (protection of ecological integrity and intergenerational equity between present and future generations of humans).
In recent years, these core elements have ensured that CHM remains central to the efforts of international environmental lawyers. It is recognized as articulating many key components of sustainability.
**Some controversies**
Controversies surround virtually all elements of CHM. This is because, as one commentator describes, it questions the regimes that apply to resources of global significance, irrespective of where they are situated. It therefore challenges traditional international law concepts such as acquisition of territory, sovereignty, sovereign equality, and international personality, as well as the allocation of planetary resources and consent-based sources of international law (Baslar 1997). Further, it has long been recognized that the precedent established for oceans management has the potential to form the basis for the future organization of an increasingly interdependent world.
One overriding issue concerns the extent to which CHM can prevent further fragmentation and privatization of the commons (or enclosure) and replace this trend with more communitarian values and legal protection of the common good. There is a wide divergence of views on whether the core element of non-appropriation prevents CHM from applying to globally significant spaces and resources that exist within the sovereign territory of states, e.g., rainforests and their flora and fauna. The equitable utilization element (or equitable benefit sharing), which requires the sharing of financial, technological, and scientific benefits of use of the CHM, has also proved divisive especially between developed and developing states and corporate actors. Developing states tend to view this element of CHM as pivotal to the achievement of distributive justice.
Developed states and commercial interests see this element as a potential impediment to investment and the use of market incentives, e.g., property rights, to achieve economic and environmental benefits. They favor, for example, exploitation by private enterprise conducted under licensing arrangements. The 1994 Implementation Agreement (amending UNCLOS III, Part XI) was generally viewed as having eroded the distributive elements of the original regime, in favor of protection of commercial interests. The impact of these and other issues saw CHM rejected as a concept to guide U.N. treaty regimes for climate change and for conservation of biological diversity. The 1992 U.N. Framework on Climate Change refers to the problem of climate change as being the "common concern of humankind." The original Maltese proposal was for a treaty declaring the global climate system as a part of the CHM, but this was rejected. Developing states rejected the use of CHM in the 1992 U.N. Convention on Biological Diversity, perceiving it as a potential threat to their sovereign rights to use and benefit from biological resources within their own territories. They were suspicious of interference under the guise of environmental protection or via the acquisition of intellectual property rights.
**Extended applications**
Over the years CHM has been applied to a range of resources and spaces: fisheries, Antarctica, the Arctic landscape, geostationary orbit, genetic resources (the genetic material of plants, animals and life forms, that are of value), and basic food resources. In recent years, the United Nations Educational, Scientific and Cultural Organization (UNESCO) has robustly supported CHM through a wide range of initiatives, e.g., declarations, conventions, and protocols, that recognize natural and cultural heritage as the CHM. Although difficult to define, "natural and cultural heritage" includes tangible and intangible elements, ranging from archaeological sites and historic monuments to cultural phenomena (such as literature, language, and customary practices) and natural systems including islands, biosphere reserves and deserts. One new area of potential application is the human genome. This may prevent the patenting of the human genome by corporate interests.
In an ecological and generational context, it is possible to argue that the Earth itself is a global commons shared by each generation and that CHM should "extend to all natural and cultural resources, wherever located, that are internationally important for the well-being of future generations" (Weiss 1989; Taylor 1998).
**Future outlook**
In the short term and from the perspective of state practice and treaty negotiation, the future use of CHM is likely to be limited. International lawyers tend to treat its use – beyond the UNCLOS III and Moon Treaty – as merely political and aspirational. Issues that will shortly test the commitment of states to CHM include the status of marine living resources (of the "Area" and high seas), claims to the seabed under the melting Arctic ice, and the status of oil reserves under the deep seabed. In the context of the oceans, CHM provides the only current alternative to either freedom of use by all states or the acquisition and exercise of sovereign rights.
It also recognizes the interdependence of ecosystems and acknowledges human use. It therefore has much in common with ecosystem management approaches that aim to move away from piecemeal resource-specific management regimes. CHM is also relevant to the wider debate on transforming the role of the state from exclusive focus on protection of national interests to include responsibility to protect ecological systems, wherever they are located, for the benefit of all.
States might be reticent to embrace the possible applications of CHM, but international law is no longer the sole province of states and international lawyers. Global civil society is playing an increasing role in the development of, and advocacy for, concepts such as CHM.
It is linked to renewed interest in cosmopolitanism, global constitutionalism, global ecological citizenship and justice, and the search for shared ethical principles to guide progress towards a more peaceful and sustainable future for all (Earth Charter Initiative 2000).
**References**
Baslar, Kemal. 1997. _The Concept of the Common Heritage of Mankind in International Law._ The Hague, The Netherlands. Kluwer Law International.
Borgese, Elisabeth Mann. 2000. _Arvid Pardo (1914–1999): In Memoriam._ In Elisabeth Mann Borgese et al., eds., Ocean Yearbook (14th ed.). xix–xxxviii. Chicago. University of Chicago Press.
Committee to Frame a World Constitution. 1948. _Preliminary draft of a world constitution, as proposed and signed by Robert M. Hutchins [and others]._ Chicago. The University of Chicago Press.
Pardo, Arvid. 1967. _Address to the 22nd session of the General Assembly of the United Nations, U.N. GAOR, 22nd sess._ , U.N. Doc. A/6695 (18 August 1967).
Pardo, Arvid. 1975. _The Common Heritage: Selected Papers on Oceans and World )rder 1967–1974._ Malta: Malta University Press.
Sand, Peter H. 2004. "Sovereignty bounded: Public trusteeship for common pool resources?" _Global Environmental Politics_ , (4)1, 47–71.
Taylor, Prue. 1998. _An Ecological Approach to International Law: Responding to Challenges of Climate Change._ London. Routledge.
Tuerk, Helmut. 2010. _The idea of common heritage of mankind._ In Norman A. Martínez Gutiérrez Ed. _Serving the Rule of International Maritime Law: Essays in Honour of Professor David Joseph Attard,_ 157–175. Oxfordshire, U. K. Routledge.
Weiss, Edith Brown. 1989. _In Fairness to Future Generations: International Law, Common Patrimony, and Intergenerational Equity._ Tokyo. United Nations University/Dobbs Ferry, NY. Transnational Publishers.
Wolfrum, Rüdiger. 2008. _Common Heritage of Mankind_. http://www.mpepil.com.
**Treaties and Resolutions**
_Agreement Governing the Activities of States on the Moon and Other Celestial Bodies_ (adopted December 5, 1979, entered into force July 11, 1984) 1363 UNTS 3.
_Convention for the Protection of the World Cultural and Natural Heritage_ (adopted November 16, 1972, entered into force December 17, 1975) 1037 UNTS 151.
_Convention on Biological Diversity_ (adopted on May 22, 1992, entered into force on December 29, 1993).
_The Earth Charter Initiative._ 2000. The Earth Charter. http://www.earthcharterinaction.org/content/pages/Read-the-Charter.html
_United Nations Convention on the Law of the Sea_ (concluded December 10, 1982, entered into force November 16, 1994) 1833 UNTS 397.
_United Nations Framework Convention on Climate Change_ (adopted on May 9, 1992 and entered into force March 21, 1994).
_United Nations General Assembly Resolution 1962 (XVIII) Declaration of Legal Principles Governing the Activities of States in the Exploration and Use of Outer Space_ (13 December 1963) GAOR 18th Session Supp. No. 15, 15.
_United Nations General Assembly Resolution 2749 (XXV) Declaration of Principles Governing the Seabed and the Ocean Floor, and the Subsoil Thereof, beyond the Limits of National Jurisdiction_, U.N. GAOR, 25th Sess., Supp. No. 28, 24. U.N. Doc. A/8028 (1970).
_This essay is an adapted version of Taylor, Prue._ 2011 _._ "Common Heritage of Mankind Principle." In Klaus Bosselmann, Daniel Fogel, and J. B. Ruhl, Eds. _The Encyclopedia of Sustainability, Vol. 3: The Law and Politics of Sustainability_. 64–69. Great Barrington, MA. Berkshire Publishing.
**Prue Taylor** _(New Zealand) is a legal academic at the University of Auckland and Deputy Director of the NZ Centre for Environmental Law. Her research focuses on ecological approaches to law and ethical issues. She recently co-edited_ Property Rights and Sustainability: The Evolution of Property Rights to Meet Ecological Challenges _(Martinus Nijhoff Publishers – BRILL, 2011)._
# Ideas for Change: Making Meaning Out of Economic and Institutional Diversity
__
_By Ryan T. Conway_
The ideas and theories of Elinor Ostrom, one of the world's leading economic scholars studying the way people in communities cooperate (or don't), have inspired their own collective action hub. It includes students and scholars of many disciplines as well as people actively involved in managing community water use, organizing fishing industries, delivering urban services, and operating cooperatives. This "hub" is known as the Workshop in Political Theory and Policy Analysis, and is located at Indiana University in Bloomington.
As a graduate student, I sought out the Workshop in 2010, drawn by the practicality and real-world impact of its "toolkit **"** as well as the diverse group of scholars and practitioners who make use of it. And this is no small team. Over the years the Workshop has hosted almost 260 visiting scholars, with 18 more on the way for the 2011–2012 academic year. Such international and interdisciplinary diversity – which has endured and grown since the Workshop's creation in 1973 – is a true inspiration and a rarity in the academic world.
In this chapter, I sketch out the basics of the Workshop and offer my own perspective on how Workshop tools can be translated in a way that both practitioners and researchers can find useful. My perspective is simple: shared ideas and common understandings are essential for creating institutions and for analyzing them.
**Questioning conventional wisdom: Ostrom's unique insight**
At the Workshop, we're often warned that "there are no panaceas," which is to say that there's no "one size fits all" solution for problematic situations and no one, final model for the social world, since behaviors and circumstances are constantly changing. Our job, as researchers, is to continually update our models of the social world so that we can explain it more accurately and, hopefully, offer helpful insights to anyone faced with tough choices in a complex, social world. This is important, not just as a practice, but as a way of thinking. Specifically, a way of thinking about how everyday people bring some order to their ever-changing activities.
For example, to devise and apply strategies of how "best" to use the resources around us is to practice "economy" with the least ideological baggage in tow. Every kind of "economy"– whether it's an international capitalist market, a centrally planned national system of production and exchange, or a neighborhood bartering community – comes with its own understanding of the world and notion of what's "best." Hence, when a group of people settles on some common assumptions about the world, like how an economy should operate, things become more orderly. Even better, once they have such a common model of the world, they then can try to clarify specific items, attributes and relationships that exist, adding even more layers of order.
But what's a model of the world without the people in it?1 Adding ourselves into the equation requires an act of self-reflection in which we must acknowledge that our rational, intentional and meaning-making abilities all conspire to help us – and our future generations – to survive. Here, though, is where problems can arise: when everyone in a situation seeks to use available resources individually, the benefits don't always add up for the group as a whole and can, instead, hurt everyone. This happens when people can't agree on a story about what's going on, or on ideas of what should be done about it. When we have a problem coordinating our ideas, we often have a problem cooperating. We call this kind of situation a _social dilemma._ (1. Issues of power disparities, race, class, gender have not been formally integrated into the frameworks, but some Workshoppers have pursued such issues, for instance, Clemente 2010.)
One of the nastier social dilemmas is the _tragedy of the commons_ **.** The _commons_ could be any type of shared resources and their respective management regimes, but much of Ostrom's work has revolved around resources such as land, water, etc., that communities use to sustain their livelihood. These kinds of resources – like fisheries or irrigation systems – are often _"common pool resources"_ (CPRs), which means that they are limited resources that are hard to manage with property rights.
For a long time, many researchers and policymakers believed that the only way to avoid tragedy was to privatize the commons or place them under government control. But Ostrom wasn't convinced. She had a fairly radical idea that broke with conventional wisdom: the survival of communities' resources does not depend upon the state to make laws and impose punishments, nor does it depend on assigning a dollar value to every fish, chunk of grass, or drop of water. Rather, people, when they come together, can share understandings and manage their resources by enforcing norms and rules of their own design! The unconventional idea in many quarters was that people could cooperate "beyond markets and states."
**The workshop toolkit**
Through many years and countless studies of commons successes and tragedies, Ostrom and the Workshoppers developed a toolkit for analyzing these situations. Its use has led to discoveries that have aided practitioners and inspired academics. Each tool can be used to help map out the different ways a community organizes its actions through instances of decision making, e.g., agreeing on a type of economy and how to run it. In this section, I'll take you through some of the major analytical tools developed at the Workshop.
The _grammar of institutions_ is something of a master tool: it allows the analyst to break any social norm or rule down into smaller, more easily understood components, or what I would call the building blocks of social relationships. And, though this is adequate for analyzing any single social proscription, most people make decisions in situations where they face multiple and sometimes conflicting social norms and rules. To help analyze such complex situations, another tool has been developed: Workshopper's call it the _IAD,_ which stands for _Institutional Analysis and Development_ framework _._ **** If the grammar of institutions is best suited for analyzing any single social norm or rule, then the IAD is best suited for analyzing any collection of them that occur simultaneously around a single decision. As such, the basic relational building blocks of multiple social proscriptions can be analyzed, simultaneously, using the IAD. Lastly, just as the IAD is adequate for analyzing a collection of social proscriptions that relate to the management of a single, community resource, the _social-ecological systems_ framework _(SES)_ **** allows the researcher to catalogue all of the critical variables related to the management of an entire social-ecological system. Though this framework is somewhat more general than the other two tools, it can still integrate both of them. Just as one can use the IAD to analyze how choices are made about governing a single community resource, the SES can allow the researcher to classify and make comparisons about how multiple resources – within a larger ecosystem – are managed.
**The grammar of institutions**
One strength of the Workshop toolkit is that all of its tools are compatible. This has been possible because they have all evolved from one master tool: the grammar of institutions (Crawford and Ostrom 1995). **** This is the tool that identifies the basic building blocks of social relationships, and the Workshop has special terms for them. As a simplified illustration, consider a housing cooperative where housemates share and rotate roles, one of which is "waste manager." In this role, one of the duties is compost consolidation: on the second Friday of every month, the member must empty all the compost containers into the main bin, without opening the container lids inside and without spilling any of the compost. And there is a rule: if the member fails to complete this duty in the manner specified, that member will have to retain this duty for two additional months.
Using the five relational building blocks – which fit the acronym ADICO – one could analyze the waste-manager example in the following way:
• _Attributes_ (to whom does this norm/rule apply): the house waste manager
• _Deontics_ (may, must not, or must be done): must execute the compost consolidation duty, must not open container lids inside and must not spill any compost)
• _Aims_ (designated actions): empties all compost containers into the main bin
• _Conditions_ (when, where and how does it apply): on the second Friday of every month, in the main house
• _"Or Else"_ (agreed upon, specific punishments to be applied when a person acts in violation of the agreed-upon definitions of the other four parts): or else she will remain the waste manager for the next two months.
Through this example, one can see how we combine these basic relational building blocks to produce a norm or rule that guides people's behavior in a collective action situation. The Workshop refers to these combinations of basic building blocks as _institutional statements,_ **** which can take the form of rules, norms, or shared strategies. When a group organizes its behavior through a statement that includes all five of these parts, this is a _rule._ **** If the group has not specified a punishment – no "Or Else" – this is a _norm._ **** When members of the group only have common knowledge about "attributes," "aims" and "conditions" – who, what, when, where and how one must act – the Workshop approach2 assumes that each person will see the same situation and each, on their own, will come up with the same solution: this is a _shared strategy._ (2. This assumption isn't unique to Workshop thinking, but stems from a large body of research in "game theory," an approach to analysis that assumes people make decisions by calculating the costs and benefits of each option in a choice. This approach has created many powerful, mathematical models, but it assumes that the way each person makes choices is, essentially, the same and, of course, this is a hotly contested assumption.)
The easiest way to picture the relationship between the grammar of institutions and the other Workshop tools – the _Institutional Analysis and Development framework (IAD)_ or _Socio-Ecological Systems framework (SES)_– is to think about the study of DNA (Ostrom 2009). Just as nucleobases and amino acids can combine in various ways to create many different types of proteins, there are basic building blocks of social relationships that can combine in various ways to create many different types of group behaviors. Life scientists needed specific tools to identify genetic building blocks and still other tools for mapping the biological structures these genetic building blocks create. Social scientists are no different: we needed specific tools to identify the building blocks of social relationships and still others to map out the larger social structures they create.
**The Institutional Analysis and Development framework (IAD)**
Let's return to the example of the waste-manager role in the housing coop. If you think about it, the compost consolidation duty might include three levels of decision making: (1) a full house meeting decides to add the role of waste manager to the list of house roles and appoints a subcommittee to determine the specifics of the waste manager role; (2) the subcommittee decides the duties of that role and how they are to be carried out; (3) the member acting in the waste manager role has to choose whether and how to execute it.
Level 1 is a "constitutional-choice situation": members choose how some rules are to be made. Level 2 is a "collective-choice situation": members in the subcommittee make the rules, given the "how" guidelines of Level 1. Level 3 is an "operational-choice situation": the member decides how to execute their waste-manager duties, given the guidelines of Level 2.
The choice made at each of these three levels represents what Workshoppers call an _action situation._ **** To explain this, I'll refer to Figure 1, below. Within the box, notice the seven major elements: Actors, Positions, Actions, Information, Control, Net Costs and Benefits, and Potential Outcomes. Around the outside of the box, notice that a certain rule points toward each of the seven major elements. For example, look at the bottom left corner: a "choice rule" determines what kind of actions a person can take.
Now, recalling that the grammar of institutions is able to analyze each of these rules, one can see that the grammar of institutions and the IAD can be used together, depending on how specific one wants to be in her analysis. And the relationship between the IAD and the SES is quite similar.
The _social-ecological systems framework_ **** (SES) is a framework that presents a comprehensive list of important objects, relationships, and variables that are necessary for understanding how social arrangements – like norms and rules – overlap with the natural relationships in an ecosystem (Ostrom 2007). Just as our last example showed how the IAD can be used for analyzing the management of one community resource – organic compost – the SES allows a researcher to identify several resources within a larger ecosystem and, further, to compare how the different resources are managed, using the IAD to look at each resource, respectively.
If each use of the IAD contains three levels of analysis and each level of analysis contains seven rules, you can see how this can all become very complicated, very quickly. The advantage of the Workshop toolkit is that, when used carefully, it can bring some consistency and order to how one thinks about these incredibly complex situations. What's more, the tools can be used independently: using the SES does not require using the IAD which, in turn, does not require using the grammar of institutions. One chooses which tools to use, depending on how specific they need to be.
If getting through all this "jargon" may not yet seem worth your while, it's worth considering that this is a powerful approach to understanding how people work together, and it has been used by collective action practitioners and scholars around the globe. And, in this case, the payoff is clear: if we can all work from a common understanding – in this case, of Workshop vocabulary analytical tools – we enhance our ability to work together. If you're still not convinced, this next section might change your mind.
**A missing variable: how ideas and our words matter**
"But," you might ask, "do we really need all this new vocabulary to describe common experience?" I would say yes, for a very simple reason: our thinking and talking structures and in part determines how we behave, whether we are practicing collective action or researching it. So learning to share ideas and refer to them with the same words will keep us on the same page. More than this, I am convinced that both the research and practice of collective action are grounded in what Tomasello calls "shared intentionality" (Tomasello et al. 2005), or what some political scientists call collective ideation.
In other words, effective collective action may, in practice, rely on shared vision – both of our world and of the goals we seek within it. In a neighborhood bartering system, this may be an idea of what constitutes the neighborhood, who qualifies as a neighbor, what goods can be exchanged, and a stated or tacit goal for beginning the system in the first place. In the Workshop, this is a collective acceptance of the toolkit itself as a baseline of shared concepts and models that help us to explain social behavior. Without the shared ideas, it would be hard to organize a barter system; without the shared ideas, we wouldn't be a Workshop.
This claim is controversial for some complex reasons.3 But herein lies the beauty of the Workshop: the boundaries of our tools are continually contested, expanded and revised in ways as diverse as the network of Workshoppers itself. So, let's jump into the fray. (3. Few have directly addressed the tension between game-theoretic and ideational approaches. Though it was left relatively undeveloped, Diana Richards broke interesting ground when crafting some elegant formal models that sought to integrate and understand the effects of shared, empirical mental models on performance in coordination dilemmas. See Richards 2001.)
Whether looking at mainstream or alternative economies, one will always run into some kind of social dilemma, like the tragedy of the commons, mentioned above. Many academics say that beating social dilemmas is a matter of solving the collective action problem. This is a generic way of saying that, in order to achieve a benefit that helps the members of a group, some portion of these people must accept a risk of paying extra for a benefit shared by all. Here is where the Workshop applies its ideas. Such groups can, sometimes, solve the collective action problem using the rules, norms and shared strategies, noted above. However, none of those institutional statements, nor their relational building blocks, just spring from thin air. A shared intentionality must be developed – that is, a collective ideation problem must be overcome – before groups can effectively work together.
The collective ideation problem is a problem of finding and agreeing on common definitions, knowledge, and understandings of a situation, all of which are necessary for creating institutions. Indeed, it's hard to make sense of the "institutional grammar" without them. Crawford and Ostrom note: By focusing on mutually understood actor expectations, preferences, and "behavior," one avoids the trap of treating institutions as things that exist apart from the shared understandings and resulting behavior of participants (Crawford and Ostrom 1995). Other economic scholars would agree. Denzau and North wrote a widely received article explaining the importance of sharing understandings, or what they call "mental models" (Denzau and North 1994). And, further, Diana Richards, Whitman Richards, and Brendan McKay have contributed to our understanding of how mental models affect choice, modeling how shared knowledge structures affect how people behave in social dilemmas (Richards 2001 and Richards et al 2002).
Mental models are how we organize and make sense of the world. Mental models are useful, simplified versions of the social and ecological worlds we live in, just like a map is a useful, simplified version of a territory, or a blueprint is a useful, simplified version of a building. Now, if we don't talk through our differing mental models of, say, a fishery, there is a collective ideation problem, because we hold conflicting understandings of our resource.
So how can we move forward from acknowledging that shared ideas and language are important for developing effective institutions? Some research has shown that work within an organization improves through breaking jargon barriers and sharing mental models. Further, we all know how difficult it is to start up, expand, or replicate grassroots collective action projects, such as community supported agriculture programs, neighborhood barter systems, producer and consumer cooperatives, etc. Success in such ventures may very well depend on how much effort is put into resolving the collective ideation problem before working out a scalable solution to the collective action problem. Forging common ground with groups that have different mental models and vocabularies would make it easier for all involved to act collectively. If we then forge common ground with groups that have different mental models and vocabularies, we make it easier for all involved to act collectively.
**References**
Clemente, Floriane. 2010. "Analysing Decentralised Natural Resource Governance: Proposition for a 'Politicised' Institutional Analysis and Development Framework." _Policy Sciences_ 43(2) (June): 129–156.
Cox, Michael, Gwen Arnold and Sergio Villamayoro-Tomás. 2009. "A Review and Reassessment of Design Principles for Community-Based Natural Resource Management, _Ecology and Society_ 15(4): 38.
Crawford, Suees and Elinor Ostrom. 1995. "A Grammar of Institutions." _American Political Science Review_ 89(3): 582–600.
Denzau, Arthur and Douglass North. 1994. "Shared Mental Models: Ideologies and Institutions." _Kyklos_ 47(1): 3–31.
Ostrom, Elinor. 2010. "Beyond Markets and States: Polycentric Governance of Complex Economic Systems." _American Economic Review_. (100)3 (June): 641–672.
—————. 2009. "A General Framework for Analyzing Sustainability of Social-Ecological Systems." _Science_ 325(5939) (24 July): 419–422.
—————. 2007. "A Diagnostic Approach for Going Beyond Panaceas." _PNAS_ 104(39) (September 25): 15181–15187.
—————. 2005. _Understanding Institutional Diversity._ Princeton: Princeton University Press: 189.
Tomasello, Michael, Malinda Carpenter, Josep Call, Tanya Behne, and Henrike Moll. 2005. "Understanding and Sharing Intentions: The Origins of Cultural Cognition." _Behavioral and Brain Sciences_ 28, 675–735.
Richards, Diane. 2001. "Coordination and Shared Mental Models." _American Journal of Political Science_ 45(2): 259–276.
Richards, Whitman, Brendan D. McKay, and Diana Richards. 2002. "The Probability of Collective Choice with Shared Knowledge Structures." _Journal of Mathematical Psychology_. 46: 338–351.
__
_This chapter is adapted from an essay originally published by the Grassroots Economic Organizing (GEO) Newsletter, (2)9, devoted to "Collective Action: Research, Practice and Theory." The full essay is available at _http://geo.coop/node/650 _._
**Ryan T. Conway** _(USA) is a member of the Managing the Health Commons research team at the Workshop in Political Theory and Policy Analysis and is in the Political Science PhD program at Indiana University, Bloomington. His research focuses on how mental models influence the development of cooperative behavior, in otherwise competitive situations._
# Constructing Commons in the Cultural Environment
_by Michael J. Madison, Brett M. Frischmann and Katherine J. Strandburg_
The Maine lobster fishery is a successful example of a managed natural resource commons. To ensure an ongoing supply of lobsters in the face of threats to the fishery from unregulated overfishing, over a period of years Maine lobster fishermen crafted a set of formal and informal rules to determine who can harvest lobsters, at what times and places, and in what volume. By design, the product of their efforts is a commons, a managed-access governance regime that allows both lobsters and the lobster industry to flourish.
How do such commons work? Where do they come from, what contributes to their durability and effectiveness, and what undermines them? These questions are at the heart of an institutionalist research paradigm that has been extremely successful in understanding the successes and failures of natural resource commons arrangements.1 In "Constructing Commons in the Cultural Environment" (hereafter, __ "Constructing Commons"), published in the _Cornell Law Review,_ we confronted the challenge of understanding the governance of what we refer to as constructed commons in the cultural environment. In constructed commons the resources to be produced, conserved, and consumed are not crustaceans but information: copyrighted works of authorship, patented inventions and other forms of information and knowledge that may not be aligned with formal systems of intellectual property law (Madison, et al. 2010). (1. See the essay by Helen Markelova and Esther Mwangi in Part 5.)
The Constructing Commons framework suggests a means to investigate the social role and significance of constructed commons institutions. This investigation is relevant to property law in particular and social ordering more generally. The conventional view of property scholars, particularly those with interests in intellectual property law, is that resource production and consumption are, and ought to be, governed primarily by entitlements to individual resource units, held individually and allocated via market mechanisms. To the extent that those market mechanisms are inadequate to optimize the welfare of society, in the event of market failure, government intervention is the suggested remedy. Intellectual property rights themselves are generally justified as remedies for market failure. Creative works and new inventions are characterized as public goods, whose intangibility prevents their originators from excluding potential users and thus recouping their investments via pricing. Copyright and patent laws create artificial but legally sanctioned forms of exclusion, restoring a measure of market control to creators and innovators.
The conventional view regards communal and collectivist institutions, particularly those that blend informal normative structures with formal government rules, as exceptional and dependent upon pre-existing property entitlements. Systematically performing and analyzing case studies of constructed cultural commons across a wide range of domains according to the proposed framework offers a critical method for assessing the validity of this property-focused narrative.
The phrase "constructed cultural commons," as we use it, refers to socially constructed institutions for developing and sharing cultural and scientific knowledge in a formally or informally managed way, much as a natural resource commons refers to the type of managed-sharing environment for natural resources exemplified by the Maine lobster fishery.
A commons is neither a place nor a thing. Rather, a commons is a resource management or governance regime. Cultural commons are regimes for managing the sharing of information or cultural resources. Commons are "constructed" in the sense that their creation, existence, operation and persistence are matters not of pure accident or random chance, but instead of emergent social process and institutional design. Examples of constructed cultural commons include intellectual property pools, in which owners of patents in a technological domain license their patents to a common "pool" from which producers of complex products can obtain all of the permissions needed to make and sell goods that use the patents; open source computer software projects, which offer users of open source programs the ability to create and share modifications to the programs; Wikipedia, which offers users of this Internet encyclopedia the power to add to and edit its contents; the wire service for journalism operated by the Associated Press, which allows individual member media outlets the opportunity to publish work produced by other members; and "jamband" fan communities, which record, share and comment on musical performances of their favorite groups –with the permission of the artists themselves. The best-known jamband is the community that grew up around and that is still associated with the Grateful Dead.
These examples differ from one another in many significant respects. They share certain basic structural features, as governance regimes for sharing information or cultural resources, that make them well-suited to comparative analysis. Participants design these environments with limitations tailored to the character of the resources, interests, and communities involved. Commons do not operate solely via market transactions grounded in traditional proprietary rights, nor are they structured exclusively by government regulation. Research on intellectual property and related cultural resources has generally failed to focus sufficiently on managed sharing or on the governance of cultural resources via collective mechanisms. The theoretical discussion of intellectual property policy has been focused on extremes of exclusion and open access, ignoring a wide range of constructed commons that persist between these extremes.2 Such discussion is often divorced from empirical studies of creative and inventive communities. In Constructing Commons, we argue that it is high time to devote more attention to the middle ground of constructed cultural commons. (2. See essays by Benjamin Mako Hill, Mike Linksvayer, and Rainer Kuhlen in Part 4.)
Research on the Maine lobster fishery and other natural resource commons is grounded in the case study approach pioneered by Elinor Ostrom and her colleagues. That approach employs a so-called "Institutional Analysis and Development" (IAD) framework of structured inquiries to study a variety of commons arrangements before moving on to create theories and models to explain them (Ostrom, 1990).
A simple illustration of the framework in a cultural context might be a soccer (football) league. The formal rules of soccer are fixed, but the rules-in-use clearly vary somewhat between a professional league and a recreational league, between children's leagues and adult leagues, and so forth. A specific soccer league is also characterized by the relationships among the players (neighbors, professional competitors, friends, etc.), by the attributes of the fields on which games are played, and even by the climate of the places where the games take place. The action arena (soccer games) depends on complex and specific interactions among all of these characteristics. Nonetheless, the outcomes over time in a particular league are the patterns of interaction that are clearly identifiable as "professional soccer," "friendly weekend game," "children's soccer league" and so forth. Moreover, some leagues may be successful, lasting for years even as players come and go, while others will fail.
The goal of applying the IAD framework of analysis in this context would be to use analysis of many different soccer leagues to come to an understanding of success and failure as a function of specific context. In other words, what we want to know is what features of commons lead to it being productive and stable? What features undermine commons? Under what circumstances are commons solutions to be preferred or accepted as matters of public policy, and under what circumstances do commons risk causing social harm?
The method of structured inquiry has the advantages of a systematic approach without prematurely imposing any one theoretical paradigm on the study of commons. It allows the complexity of real-world commons arrangements to inform the search for theoretical understanding rather than papering over such complexity in an attempt to shoehorn existing commons arrangements into a pre-existing model. After engaging in a large number of such studies, Ostrom's approach permits generalization (for example, with regard to design principles for successful commons3) along with more specific theorizing, modeling and even experimental studies of particular aspects observed in the case studies. (3. See the summary of Ostrom's design principles in Conway's article in Part 5.)
Building on Ostrom's work, we propose and argue for the use of a similar framework to systematize case-study-based research exploring the construction of cultural commons. The time is ripe for such an approach, as a number of scholars have begun to do case studies of constructed cultural commons. However, they tend to have studied isolated areas (such as open source software or academic publishing) and to have considered a limited number of descriptive variables. This makes integration and learning from a body of case studies quite difficult, which in turn discourages people from pursuing further case studies.
Constructing Commons adapts, extends and distinguishes Ostrom's IAD framework to account for important differences between constructed cultural commons and natural resource commons. We briefly discuss only a few of the most important issues that distinguish the inquiries necessary for studying them. Most important, unlike commons in the natural resource environment, cultural commons arrangements usually must create a governance structure that produces the relevant resources as well as provides for sharing existing resources.4 This characteristic of cultural commons creates a more intertwined set of exogenous variables, since separating the managed resources from the attributes and rules-in-use of the community that produces them is impossible. (4. Editors' note: Many authors of this volume conceptualize commons as productive social systems where the point is not only about sharing common pool resources but also producing commons.)
Picture a university, which for our purposes should be considered a cultural commons. Faculty and students within a university share existing knowledge and knowledge resources (such as scholarly literature, archival material and research subjects) and collaborate in the production of new knowledge. That activity is rarely limited by proprietary claims made by faculty or students against one another. The university and its many units, departments and disciplines are governed by a detailed scheme of internal regulation. There is also an increasing interest in detailed legal regulation of the process of technology transfer, the point at which the cultural commons of the university intersects with the proprietary marketplace beyond the university's walls (Madison, Frischmann and Strandburg 2009).
In cultural commons, distinguishing outcomes from resources and community attributes is not strictly possible, since the interactions of the participants in such a commons are inextricably linked with the form and content of the knowledge output, which in turn is itself a resource for future production. These differences call for a set of inquiries tailored to cultural commons. Because the resources shared within a cultural commons are culturally constructed and nonrivalrous,5 defining the boundaries of the commonly managed resource is a different task than in the natural resource commons context. (5. On rivalrous goods, see Silke Helfrich's essay in Part 1.)
First, a reference environment must be consciously chosen: either the public domain or a proprietary intellectual property environment may be most appropriate depending upon the particular commons (such as a university research community or patent pool) under investigation. Next, nuanced questions about openness are in order. In natural resource commons, in many cases, the commons is open to members and closed to everyone else, and that is the end of the story. This is sensible because natural resources are rivalrous—preventing overconsumption is usually the goal of the commons arrangement. Intellectual resources, by contrast, are not subject to the same natural constraints and are naturally shareable without a risk of congestion or overconsumption. Thus, a constructed cultural commons arrangement reflects many choices about the degree and type of participation that is available to various persons and entities. Open source software projects, for example, often allow anyone to comment, make suggestions or submit code for potential adoption, but are managed by a small group of core programmers who determine what code to incorporate into official releases. Additionally, individuals having nothing to do with the writing of the code can use it, subject to constraints on commercialization incorporated into the copyright license, which vary from project to project.6 (6. See Mike Linksvayer's essay on Creative Commons licenses and Christian Siefkes' essay on commons-based peer production, both of which are in Part 4.)
We suspect that, over time, the constructed cultural commons framework that we describe will yield a far larger and richer set of commons cases in the cultural context than one might discover by focusing only on patent law or scientific research or software development. The logical and normative priority assigned to proprietary rights and government intervention may turn out to be misplaced; social ordering both depends on and generates a wide variety of formal and informal institutional arrangements. Importantly, understanding commons in the cultural environment is likely to shed light on the ways in which managed sharing or openness with respect to cultural resources generates the "spillovers," or third-party benefits, that are critical to the welfare effects of those resources. (Frischmann and Lemley 2007; Frischmann 2008). The social value of information lies not only in its effect on the producer and the consumer of that information, but also in the ways in which the consumer shares that information with others.
Understanding the origins and operation of constructed cultural commons requires detailed assessments that recognize that commons operate simultaneously at several levels, each nested in a level above, and that each level entails a variety of possible attributes. We suggest buckets or clusters of issues that should guide further inquiry, including the ways in which information resources and resource commons are structured by default rules of exclusion, and the ways in which members of these pools manage participation in the collective production and extraction of information resources. Case studies across disciplines and reviews of existing literature that address cultural commons will help specify relevant attributes within each cluster. We expect the framework to evolve further as researchers apply it to specific case studies.
Beyond our proposal of a framework for studying commons, our consideration of constructed cultural commons also highlights a number of points that are important in the study of intellectual property going forward. Considering constructed commons helps to elevate collective, intermediate solutions to their possible place of significance in accounts of property regimes and should diminish the skepticism of many scholars that collective solutions can work beyond narrowly defined situations. Case studies will also call our attention to the constructed, designed character of both the cultural and the legal environment in regard to knowledge and information policy problems. Finally, as they have done in the study of natural resource management, systematic analyses of constructed commons across a wide range of collected case studies should lead us to doubt panacea prescriptions drawn from overly simplistic models.
**References**
Frischmann, Brett M. 2008. "Speech, Spillovers, and the First Amendment." _University_ _of Chicago_ _Legal Forum_. 301–333.
————— and Mark A. Lemley. 2007. "Spillovers." _Columbia Law Review_ 107(1):257–301.
Madison, Michael J., Brett M. Frischmann and Katherine J. Strandburg. 2010. "Constructing Commons in the Cultural Environment." _Cornell Law Review_ 95(4):657-709.
—————. 2009. "The University as Constructed Cultural Commons." _Washington_ _University_ _Journal of Law & Policy _30: 365-403.
Ostrom, Elinor. 1990. _Governing the Commons: The Evolution of Institutions for Collective Action._ New York. Cambridge University Press.
—————. 2005. _Understanding Institutional Diversity_. Princeton, NJ. Princeton University Press.
**Michael J. Madison** _(USA) is Professor of Law at the University of Pittsburgh. His research focuses on knowledge-based institutions, innovation, and cultural commons. His papers are available at madisonian.net/home, and he blogs at madisonian.net._
**Brett M. Frischmann** _(USA) is a Professor of Law and the Director of the Intellectual Property and Information Law Program at the Cardozo Law School. His research focuses on various different types of commons, including cultural commons and infrastructure commons. He is the author of Infrastructure: The Social Value of Shared Resources (2012)._
**Katherine J. Strandburg** _(USA) is Professor of Law at the New York University. Her publications focus on cultural commons and the implications of user and collaborative innovation for patent law and of networked communication for privacy. Prior to her legal career, she was a PhD research physicist at Argonne National Laboratory._
# The Triune Peer Governance of the Digital Commons
_By Michel Bauwens_
In a foundational essay, "The Political Economy of Peer Production" (Bauwens 2006), I defined commons-based peer production in two different ways. The first perspective draws upon Nick Dyer-Whitford's analysis that peer production consists of:
• _An input phase_ : Without access to open and free "raw material," either preexisting or to be created, there can be no free permissionless self-aggregation around common value;
• _A process phase_ : People who are working together as voluntary contributors outside of the wage-labor dependency system need to develop methods of participatory governance reflecting their equipotential contributions to the commons; and
• _An output phase_ : Commoners won't contribute if there can be a private appropriation of their common work; therefore, they use new forms of open licensing guaranteeing universal availability, and thus create an openly accessible commons.
_Commons-based_ _peer production_ can also be defined as the common creation of value using peer governance to manage this process and peer property to protect common value from private appropriation. "Equipotentiality" refers to the equal freedom, opportunity and capability of everyone to contribute to the commons, by matching the needs for commons development with the freely given contributions of passionate labor provided by commoners. This process relies upon a "stigmergic signalling" system1 that facilitates the voluntary and swift allocation of labor to perform needed tasks. One could say that in peer production, the "division of labor" is transformed in a system that is more akin to a "distribution of tasks." (1. Stigmergy is the signaling language of ants and bees. More generally, they are hint-based environmental mechanisms to coordinate the work of independent actors. For details, see http://p2pfoundation.net/Stigmergy)
Peer governance in the narrow sense should be reserved for those aspects of peer production that are strictly outside a hierarchical allocation of tasks, in the sense of a command and control mechanism that governs the production process directly. However, peer governance may embody different forms of hierarchy, such as quality-selection mechanisms that occur later in the production process. Hierarchies that disempower the mechanisms that enable everyone to freely contribute, however, cannot be considered compatible with peer production and peer governance. To complicate matters further, peer production is a hybrid form of governance because in present circumstances it is interdependent with the capitalist economy in which it emerges.
Indeed, in "real-world" practice, we see the emergence of a triune structure governing such collaborative production. At the core is a community consisting of both voluntary contributors and paid employees, which requires a physical infrastructure to facilitate cooperation and sometimes entails entrepreneurial coalitions of corporations and freelance workers.
Volunteers and paid employees contribute knowledge, code and design to the common pool, using a variety of open licenses to ensure the legal defensibility of their commons.2 Peer production projects are successful as long as they can attract either volunteers or corporate contributors willing to use such open licenses. In general, such communities are governed by rules and norms derived from meritocratic philosophies. While any capable person can generally contribute, they have post-production quality control mechanisms that either individually or collectively apply some standards of meritocratic judgment. (2. See Mike Linksvayer's essay on Creative Commons and other licenses in Part 4.)
This is sometimes called the "maintainer" model of management. The specific rules can be elaborate and in turn create some form of hierarchy, such as the oversight exercised by "admins" and editors in the Wikipedia project. But such governance is not a classic scarcity-based allocation mechanism such as the market, bureaucracy or even a democracy, because contributions (code, text, design, etc.) are generally considered to be nonrival and abundant. Anyone can contribute but some decisions must be made in curating or synthesizing the end product. This can be considered a permissionless process of production, with strong "pluri-archichal" elements. It preserves the possibility of noncooperation or "forking" (in which disaffected participants leave the project to start their own offshoot), while preserving a strong posthoc quality control mechanism, which is needed to guarantee the quality of the end product.
The second aspect of the triune structure of peer production communities, a physical infrastructure of cooperation, is sometimes costly and requires capital investment. Think of the money needed to maintain the servers of the Wikipedia project. In general, such communities create "for-benefit" associations or foundations, which manage and maintain the infrastructure of cooperation, gather donations and perform related functions. These foundations take on the legal form of nonprofits and are generally governed in democratic ways, through elections, sortition (the drawing of lots), rotation and other methods. They are "for-benefit" associations in the sense that they work for the commons and the community of contributors, but do not direct the process of production itself.
Finally, the third player in commons-based peer production are the entrepreneurial coalitions of corporations and freelance workers who either sell their services and labor time, or create added value that can be sold and monetized in the marketplace. Such companies are important for the reproduction of the commoners and the commons, since they may pay many contributors and sustain and finance the for-benefit associations.
Many commons-based peer projects are currently embedded in the mainstream political economy of capitalism. This has resulted in a delicate co-dependency between the communities, which need the capital and monetary income provided by enterprises, and corporations, which need to capture and monetize some of the fruits of the social cooperation.3 This hybrid collaborative economy poses a number of important issues for peer governance. (3. Please note that I'm not discussing the structural conditions of corporate-owned sharing platforms like Facebook or crowdsourcing platforms where freelancers produce for the marketplace.)
• How can the community maintain its independent processes, rules and norms when a substantial number of contributors are paid by companies? In practice, this can lead to open source communities being dominated by single companies, which likely disqualifies them as true commons. But on the other hand, there are also instances of companies adapting to the rules and norms of the community, such as IBM's respectful relationship to the GNU Linux community.
• How can the for-benefit association retain its independence and democratic procedures if it is cofinanced by corporations who may exert a self-serving influence? In practice, many foundations such as the one that oversees GNU Linux limit the representation of single companies to avoid such dominance.
As we can see, peer governance creates many issues around the distribution of power, and creates a new form of (class?) "struggle" between peer producing communities and commoners on the one hand, and entrepreneurial and large corporate entities on the other. Even in the best of cases, there are many "internal" tensions among the new types of meritocratic hierarchies emerging within peer communities themselves. A wide variety of solutions are available but democracy and pluriarchy are never a given and so are always an ongoing social challenge.
What is important, and to some extent historically novel, is the rise of equipotential cooperation mechanisms that function beyond the local level; the generalized possibility for stigmergic, horizontal communication among large numbers of people; the legal protections for maintaining commons that open licenses provide; and the choice that commoners always have to fork a collaborative project. These are promising conditions for democratic governance compared with the almost feudal structures prevalent in private corporations relying upon wage dependency.
_This is why we m_ a _y prefer alternatives that can free peer production from over-dependence on the political economy of capital._ Instead of a situation in which the commons and peer production must depend on the imperatives of capital accumulation for their own social reproduction, we must find better ways to defend not just the autonomy of peer governance, but an autonomous "circulation of the commons" which favor the social practices that animate and give value to this paradigm of production.
Our proposal in this context is that the commoners themselves create a new type of for-benefit entity to operate in the marketplace. Such an entity would have commoners as its members and would give a priority to the sustainability of the commons and its contributing commoners. It would also subsume the profit mechanism to its social goals. By allying and aligning themselves to each other, such peer-based entities could potentially create a counter-economy, and cultivate a new production logic that could overcome dependency on capital. The name of "Phyles" has been proposed for such entities,5 and specific licenses have been developed for their operation.6 Their logic is to limit the free usage of the commons to only such entities that also contribute to the commons, and to let for-profit companies pay for usage. Such a prohibition of "leaking of value" from the commons to capital could be a mechanism to create a productive feedback loop for the autonomy of the commons.
(5. See http://p2pfoundation.net/Phyles.
6. http://p2pfoundation.net/Peer_Production_License.)
**References**
Bauwens, M. 2006. The Political Economy of Peer Production. CTheory, October 2, 2006. http://www.ctheory.net/articles.aspx?id=499.
**Michel Bauwens** _(Belgium/Thailand) is the founder of the P2P Foundation, a global research collaborative network on peer production as well as Co-Founder of the Commons Strategies Group. He lives in Chiang Mai, in northern Thailand. Michel is currently Primavera Research Fellow at the University of Amsterdam and is an external expert at the Pontifical Academy of Social Sciences (2008, 2012)._
# Multilevel Governance and Cross-Scale Coordination for Natural Resource Management: Lessons from Current Research
_By Helen Markelova and Esther Mwangi_
Most authors writing about natural resource management (NRM) agree that their very complexity and the interactions and interdependence between resources and their users require that we focus on the importance of _scale._ Ecological researchers are mostly focused on the geobiophysical scale, while scholars of governance are primarily concerned with governance arrangements at different levels, which may or may not correspond directly to the scale of the resources being managed. Traditionally, there has been a mismatch between human action and ecological systems, as Cash et al. (2006) point out, resulting in poorly designed institutions for NRM. For example, short electoral cycles for government officials may conflict with the long-term planning needed for NRM.
The documented failure to consider the proper scale and cross-scale dynamics in human-environment systems often results in misguided public policy and resource management systems. The challenge, then, is how to recognize and address this mismatch in order to design governance arrangements that can coherently map onto the biogeophysical scale of the resource, either spatially or temporally. This tends to be a very difficult and complex challenge because scale issues are generally linked with political structures and authority.
In this essay, we review current thinking on multilevel governance to explore why coordination across scales and levels is important. We also examine the main policy approaches that have been used to achieve cross-level and cross-scale coordination. Finally we consider some of the factors identified in the literature that contribute to successful cross-scale collaboration.
**Scale issues in NRM and environmental research**
Integrated natural resource management (INRM) is a complex process that occurs at a number of scales with multiple stakeholders, each with their own objectives and perceptions (Campbell et al. 2001). The term "INRM" encompasses a range of activities with numerous components, and therefore risks being over-inclusive, but it seeks to focus on the most appropriate indicators – such as sustainability and distribution of benefits – that vary with the scale at which management takes place and the scale at which prevailing social and economic processes operate. Interventions may work at one scale, but have very different effects at a higher scale. For example, soil and water conservation interventions may improve crop yields at a specific site, but reduce water yields downstream.
The challenge is to ascertain the appropriate scale for evaluating benefits. Campbell et al. (2001) show that the appropriate scale depends on what types of impact are anticipated, the specific objectives, the time scale of the study, the level of accuracy required and the value system that is chosen by the evaluator. It is relatively manageable to make plot- and farm-level analyses, but much more unwieldy to study impacts at the scale of the community and the watershed where numerous complicating factors – ecological, social, cultural, institutional, economic, and political – have to be considered. Researchers may also approach INRM studies with multiple assessment criteria, such as poverty alleviation, ecological resilience, natural resource conservation, economic growth, and human and social development, which reflect the varying interests of different stakeholders.
In most of the studies we reviewed, it becomes clear that environmental interventions (albeit considered at different scale) will not be effective without the appropriate management and governance structures. As Cash and Moser (2000) point out, big problems arise when an environmental phenomenon is managed at an institutional scale whose authoritative reach does not correspond with the geographical scale or particular spatial dynamics of an environmental problem. Ostrom (2009) suggests that although the benefits from interventions seeking to reduce greenhouse gas emissions are distributed across scales, from the household to the globe, small and medium scale governance units are better suited to build trust and commitment than ones working at a global scale alone.
Cross-scale networks of resource management cannot only create more resilient governance but also governance that is more participatory and effective. Adger et al. (2005) note that the marine areas of the Caribbean are managed through integrated and well-linked resource systems (nested within national and international agendas, regimes, networks, and legal systems) and with multiple beneficiaries – and are more robust/resilient than systems with greater or fewer linkages. Resilience and stability of governance systems depends on the distribution of benefits from cross-scale linkages, demonstrated by the ability of the system to command legitimacy and trust among the resource user and governmental stakeholders. Adger et al. believe that multilevel governance should be promoted not just for ecological reasons, but because shared responsibility for management of resources creates positive incentives for sustainable use. It also overcomes problems of legitimacy from traditional NRM and its presumption that the local regime should avoid a larger, scalar interdependence.
Research on forest management also affirms the need for multilevel governance. Ribot et al. (2006) argue that there must be procedures in both policy-making and implementation that encourage public participation, democratic control over forests and community participation – i.e., governance arrangements that span various levels. Poteete and Ostrom (2004) also note that, because forest ecosystems are affected by many biophysical, demographic, economic, and institutional factors, they require complex interactions between ecosystems and social systems. Policies promoting institutional development at the local level require a solid understanding of the determinants of local organization and successful forest management.
_Definition of scale and multilevel governance._ The sections above show that there are multiple definitions of "scale" and "level," depending on the research discipline and/or objective of the study. The natural science literature views scale as an indication of an order of _magnitude_ rather than a specific _value_ (Schulze 2000). Scaling entails changes in processes and actors, upward or downward, from a given scale of observation. It recognizes the interconnectivity of scales and includes the important constraints, interactions, and feedback (lateral flows) that may be associated with such changes in scale.
In governance research, this concept is understood more as linkages between various levels of governing bodies, local, national, and global that are used to further their own interests (Adger et al 2005). Institutional interplay at different levels can be highly asymmetric or relatively balanced. In the Mekong region, for example, central state agencies have authority to create formal rules, while community-based institutions can make adjustments to the operational management of irrigation and flood protection (Lebel et al. 2006).
Cash et al. (2006) distinguish between the terms "scale" and "level." "Scale" refers to the spatial, temporal, quantitative, and analytical dimensions that are used to measure any phenomenon. "Levels" are units of analysis that are located at different positions on a scale. The concept of nested governance also appears as a potential definition of multilevel governance (Ostrom 1990). For example, national rights definitions will establish more specific legal relationships and procedures for the application in national territories. Cross-scale relations imply that processes at any particular scale involve stakeholders from the other scales.
_Participation of various stakeholders. _Across the literature, the state and its various agencies with authority at different levels are mentioned as crucial actors in effective NRM. Swallow et al.'s (2001) watershed management study shows that the state can play a variety of roles at different scales. It can facilitate the development and effectiveness of local organizations (local level), provide assistance through policy and financial support of group activities (municipal level), and promulgate favorable policies that help local organizations to be effective (national level). This study also shows that donor organizations want NGOs as facilitators of watershed management because they are thought to be participatory and willing to listen to farmers' concerns.
Bebbington et al. (2006) point out that it is critical to pay attention to multi-locale bridging arrangements and linkages between villages and nonlocal actors (advocacy NGOs). The bridging relationships with external actors have their own impact on local capacity to respond to changes and pressures. These abilities have often resulted in interesting renegotiations of the relationships between villager, village government, state and business.
_Types of scale. _Different researchers propose various types of scales and levels to be considered in natural resource management; each often corresponds to the type of definition used. For example, Harrington et al. (2001) identify the following types of scale:
a) _the scale of analysis_ : from plant to plot to farm to watershed to region;
b) _the scale of intervention point_ : high-level interventions such as policy changes, adjustments in institutional arrangements or property rights, and the fostering of collective action vs. lower-level interventions such as farmer experimentation or extension for specific practices;
c) _the scale of investment in intervention strategies_ : small versus large investments in extension, farmer experimentation programs, or efforts to provide information to policy makers;
d) _the scale of community empowerment_ : the number of communities able to undertake their own research and adaptation through processes for local learning;
e) _the scale of geographical coverage of an INRM practice_ : whether it is limited to a village or watershed or has attained regional or national relevance; and
f) _the scale of impact_ : for example, the extent to which desirable outcomes, e.g., improved system productivity and resource quality, have been achieved through INRM research.
There are links between these scales: greater impacts are generated from higher levels of investment in suitable intervention strategies, or from more efficient use of these investments through greater reliance on community empowerment, leading to expanded geographical coverage of suitable practices.
On the other hand, Swallow et al. (2001) see scale as hierarchy and as magnitude. Hierarchical scale comprises processes by which higher-level scales impose constraints on lower-level scales. For example, national level laws constrain jurisdiction and autonomy of local-level policy makers, while local bodies have very little impact on the formulation of national laws. Cash et al. (2006) distinguish between the geographical, or spatial scale, and the temporal scale. Temporal scale implies division into time frames related to rates, durations, and frequencies of natural phenomena.
Closely related to these scales is the jurisdictional scale, which is defined as clearly bounded and organized political units, such as towns, counties, states or provinces, and nations, and constitutional and statutory linkages among them. Other scholars see the primary distinction in scales to be along spatial and temporal dimensions. Gottret and White (2001) show that the measurement of impact across spatial scales is a key issue in the impact assessment of INRM research.
_Approaches to integrating cross-scale coordination in natural resource governance._ Most of the literature on multilevel governance in relation to natural resources adopts two contrasting approaches: "Big Government" and "Small is Beautiful." Murphree (2000) argues that while both of these approaches represent attempts at matching scales, both have problems. The "Big Government" approach imposes conventional NRM by government agencies, often failing to recognize existing systems of cross-scale/cross-level interactions in resource use (Mwangi and Ostrom 2009). This locks in patterns of resource use, reduces flexibility and undermines the ability to adjust to sudden shocks, such as climatic variability (Adger et al 2005).
"Small is Beautiful" seeks to place jurisdictions at local or communal levels. Small jurisdictions are more transparent to their constituencies and more politically acceptable. Controls exerted through local peer pressure are tighter and more efficient than prescriptions from afar. "Small is Beautiful" is more capable of linking management inputs and output benefits, which is important for allocating responsibility and motivating environmental investments and controls. Furthermore, the important linkages between responsibility and authority can be coordinated under one local institution or explicitly articulated among the range of actors involved. (Lovell et al. 2002). For "Small is Beautiful" the problem is maintaining links across spatial, functional, and ecological scale (Murphree 2000).
Several solutions have been proposed to address the problems of these two broad policy approaches: decentralization and participation. Both approaches involve the transfer of decisionmaking and political power from central to more local levels such as district, county, parish and communities (Blaikie 2006). Other related reforms include "downward accountability," the granting of a significant degree of decisionmaking autonomy to local bodies, and competent local institutions (Ribot 2001).
_Community participation in resource governance._ Community participation in NRM has been promoted widely for the past few decades as a bottom-up way of creating multiscale governance linkages. By giving people a stake in the process, community participation enhances the prospects of efficient, equitable and sustainable joint action (Blaikie 2006), especially for communities that have an integrated social structure and common interests. However, Lovell et al. (2002) show that bottom-up initiatives require support from external agencies in order for them to function effectively. World Bank-supported watershed development, for example, has been criticized for investing in infrastructure without ensuring on-the-ground support for continued maintenance. On the other hand, NGOs that achieve institutional sustainability in individual villages often cannot replicate their models rapidly. Clearly, a balance is required.
Blaikie (2006) shows that even though this approach was an established policy goal for rural development in Africa, it was often subverted by postcolonial states that favored centralization of power and by foresters, agricultural researchers, and extension officers who regard local participation as professionally disempowering and a distraction from scientific objectives. In Indonesia, Bebbington et al. (2006) demonstrate that projects aimed at increasing local participation in economic development in Indonesia were driven by state and local elites. This limited the opportunities for local communities to link to other actors. The state also facilitated private sector investment excluding local communities, which not only undermined local livelihoods but resulted in an uneven distribution of assets and capacities. Co-management – a sharing of power between governments and local communities – has been proposed as one way of minimizing the risks of community participation/CBNRM approaches (Cash et al. 2006).
_Decentralization and cross-scale coordination._ Co-management in NRM is closely connected with decentralization, a second, top-down approach to creating linkages across scales. Overall, the literature is mixed on the ability of decentralization to promote local participation and deliver lasting and equitable governance arrangements for sustainable resource management.
In their study of decentralization reforms in the Bolivian forestry sector Andersson and Gibson (2006) examine both the positives and negatives of these reforms. Proponents of decentralization believe that it will increase accountability because local governments are more responsive and accountable than central governments. They also have better information on the local conditions and preferences, and will thus make better decisions regarding the provision of public goods. Opponents of decentralization believe that these reforms may reduce local provisioning of public services because local elites are more able to divert public funds for their own interests than a central government. In Central Kalimantan, Indonesia, for example, decentralization resulted in ambiguous rights and rules over forest resources and thus increased deforestation. (McCarthy 2003).
Veron et al. (2006) also find that decentralization is prone to several pitfalls that hinder transparent and equitable linkages across governance levels. Decentralization reforms create new elites at the local level who become the local networks of corruption. Thus, corruption from centralized authorities is decentralized to the local level, to the newly emerging class of political entrepreneurs that did not exist before. They conclude that participatory decentralization and the strengthening of horizontal accountability does not prevent corruption. They suggest that there is need for both upward and downward accountability and that the effectiveness of decentralization also depends on the strength of centralized government institutions.
A study on the decentralization reforms by Wardell and Lund (2006) show that decentralization is beset with contradictions. They may emphasize local resource users yet postcolonial administrations often restrict or suspend customary communal rights. The resulting new legal framework came with stricter rules, but noncompliance with and nonenforcement of the rules created space for rent seeking by local public authorities. In addition, as shown by Bebbington et al. (2006) in Indonesia, state involvement at the local level can become an instrument of social control. The shortfalls of decentralization are summarized effectively by Ribot et al.'s (2006) cross-country studies that show that instead of linking institutional scales, central governments undermined the ability of local governments to make meaningful decisions. They limited the kinds of powers that are transferred, and chose local institutions that serve and answer to central interests.
While decentralization is a promising mechanism for linking NRM institutions across different levels, the politics and policies for pursuing it are complex, situation-specific, and face many obstacles, as Larson (2002) shows. However, there is evidence that decentralization empowers local people to identify their own environmental problems, allocate resources more efficiently, reduce information costs and benefit from a sense of ownership in decision (McCarthy 2003).
_Summary of approaches: preconditions for successful multi-level governance._ Community participation and decentralization approaches have not been completely effective in linking different governance across levels. There is multiple evidence that they lead to elite capture and even negative resource outcomes. Poteete and Ostrom (2004) note that the attributes of a resource, the attributes of users, and the institutional environment are key factors that need to be considered in fostering collaboration across scales for NRM.
Group characteristics such as size and homogeneity become important in dealing with coordination and distributional issues (Poteete and Ostrom 2004). Heterogeneity in groups can exist along several dimensions (such as gender, power, wealth and assets, ethnicity, production system, position on a watershed, etc.) and will tend to increase with group size. But it is important to find out which types of heterogeneity can increase cross-level cooperation (by creating incentives to collaborate, for example) and which may impede it (by undermining trust, for example).
Thus it remains an open question whether radical decentralization is a precondition for effective forest management. Collective action, be it vertical or horizontal, is costly. In addition to obtaining information, actors must overcome coordination problems, distributional issues and the incentive problems associated with common-pool resources and other resources (Poteete and Ostrom, 2004). Local autonomy may be conducive for successful management of common-pool resources such as forests, but it is not sufficient. Acting alone, communities may not be able to defend their forest resources from other communities or takeovers by state agencies or private corporations. Thus, linking between scales is necessary for effective and sustainable NRM.
Murphree (2002) suggests a way to link the efficiency of local jurisdictions with the scale of resource systems, while dodging the top-down pitfalls of decentralization. The managerial requirements of specific resource systems need to be matched to jurisdictions no larger than necessary. Assigning increased authority and responsibility to local users without ascertaining the range of functions of a resource, the diversity of interests among users and the capability of local institutions to take on these roles, will complicate rather than solve problems.
**Conclusion**
Overall, governance arrangements for INRM must be an appropriate mix of local and state institutions, with strong support by central state authorities. State institutions are needed to provide support for the formation or strengthening of these local institutions where they are nonexistent or weak, and to mediate conflicts and enforce resource use agreements worked out by the different local groups (Ostrom 1990 and 1995).
It is impossible to capture and account for the true complexity of human-resource interactions without disaggregating by scale and looking at cross-level linkages. There is wide agreement as well that the type of institution must be matched to the scale of the resource while fostering accountable cross-scale linkages among multiple actors. There is value in both the top-down approach of decentralization and the bottom-up approach of community participation. Yet both approaches are susceptible to some common problems, especially elite capture at different levels, which can ultimately hinder healthy cross-scale linkages.
**References**
Adger, W., Brown, K. and E.L. Tompkins. 2005. "The Political Economy of Cross-scale Networks in Eesource Co-management." _Ecology and Society._ (10)2:9. http://www.ecologyandsociety.org/vol10/iss2/art9.
Andersson, K. and Gibson, C. C. 2006. "Decentralized Governance and Environmental Change: Local Institutional Moderation of Deforestation in Bolivia." _Journal of Policy Analysis and Management._ (26)1:99–123.
Bebbington, A., Dharmawan, L., Fahmi, E. and Guggenheim, S. 2006. "Local Capacity, Village Governance and the Political Economy of Rural Development in Indonesia." _World Development._ (34)11:1958–1976.
Blaikie, P. 2006. "Is Small Really Beautiful? Community-based Natural Resource Management in Malawi and Botswana." _World Development._ (34)11:1942–1957.
Campbell, B., J. A. Sayer, P. Frost, S. Vermeulen, M. Ruiz Pérez, A. Cunningham, and R. Prabhu. 2001. "Assessing the Performance of Natural Resource Systems." _Conservation Ecology._ (5)2:22. http://www.consecol.org/vol5/iss2/art22.
Cash, D. and Moser, S.C. 2000. "Linking Global and Local scales: Designing Dynamic Assessment and Management Processes." _Global Environmental Change._ (10): 109-120.
Gottret, M. and D. White. 2001. "Assessing the Impact of Integrated Natural Resource Management: Challenges and Experiences." _Conservation Ecology._ (5)2: 17. http://www.consecol.org/vol5/iss2/art17.
Harrington, L., J. White, P. Grace, D. Hodson, A. D. Hartkamp, C. Vaughan, and C. Meisner. 2001. "Delivering the Goods: Scaling Out Results of Natural Resource Management Research." _Conservation Ecology._ (5)2:19. http://www.consecol.org/vol5/iss2/art19.
Larson, A. 2002. "Natural Resources and Decentralization in Nicaragua: Are Local Governments Up to the Job." _World Development._ (30)1: 17-31.
Lovell, C., A. Mandondo and Moriarty, P. 2002. "The Question of Scale in Integrated Natural Resource Management." _Conservation Ecology._ (5)2:25. http://www.consecol.org/vol5/iss2/art25.
McCarthy, J. 2003. "Changing to Gray: Decentralization and the Emergence of Volatile Socio-legal Configurations in Central Kalimantan, Indonesia." _World Development._ (32)7:1199-1223.
Murphree, M. 2000. "Boundaries and Borders: The Question of Scale in the Theory and Practice of Common Property Management." Presented at the Eight Biennial Conference of the International Association for the Study of Common Property (IASCP). Bloomington, Indiana, U.S.A. May 31 – June 4.
Mwangi, E. and E. Ostrom. 2008. "A Century of Institutions and Ecology in East Africa's Rangelands: Linking Institutional Robustness with the Ecological Resilience of Kenya's Maasailand." In V.Beckmann and M. Padmanabhan, eds. _Institutions and Sustainability. Political Economy of Agriculture and the Environment. Essays in Honor of Konrad Hagedorn_. Dordrecht: Springer.
Ostrom, E. 1995. "Designing Complexity to Govern Complexity." In S. Hanna and M. Munasinghe, eds. _Property Rights and the Environment: Social and Ecological Issues_. Washington, D.C. The Beijer International Institute of Ecological Economics and the World Bank. 33–45.
—————. 1990. _Governing the Commons. The Evolution of Institutions for Collective Action_. Cambridge: Cambridge University Press.
Poteete, A. and Ostrom, E. 2004. An Institutional Approach to the Study of Forest Resources. Manuscript available at http://www.indiana.edu/~workshop/papers/W01I-8.pdf
—————. 2009. "A Polycentric Approach for Coping with Climate Change." World Bank Policy Research Working Paper Series No. 5095.
Ribot, J., Agrawal, A. and Larson, A. 2006. "Recentralizing While Decentralizing: How National Governments Re-appropriate Forest Resources." _World Development._ (34)11: 1864–1886.
Ribot, J. 2001. "Integral Local Development: 'Accommodating Multiple Interests' through Entrustment and Accountable Representation." _International Journal of Agricultural Resources, Government and Ecology_ (1)3/4:327-350.
Schulze, R. 2000. "Transcending Scales of Space and Time in Impact Studies of Climate and Climate Change on Agrohydrological Responses." _Agriculture_ (82):185-212.
Swallow, BM, Garrity, D., and van Noordwijk, M. 2001. "The Effects of Scales, Flows and Filters on Property Rights and Collective Action in Watershed Management." _Water Policy_ (3):457-474.
Veron, R., Williams, G., Corbridge, S., & Srivastava, M. 2006. "Decentralized Corruption or Corrupt Decentralization? Community Monitoring of Poverty-Alleviation Schemes in Eastern India." _World Development._ (34)11:1922–1941.
Wardell, A. and Lund, C. 2006. "Governing Access to Forests in Northern Gha na: Micro-Politics and the Rents of Non-Enforcement." _World Development_. (34)11:1887–1906.
**Helen Markelova** _(Russia/USA) is pursuing a PhD in Applied Economics at the University of Minnesota, Minneapolis, USA. Previously, she worked for the Collective Action and Property Rights program (CAPRi) of the Consultative Group on International Agricultural Research (CGIAR) doing research on how the institutions of collective action and property rights affect the livelihoods of the poor. _
**Esther Mwangi** _(Kenya) is a senior scientist in the forests and governance program at the Center for International Forestry Research (CIFOR)._
# The Atmosphere as a Global Commons
_By Ottmar Edenhofer, Christian Flachsland and Bernhard Lorentz_
Competition and private property rights unleashed capitalism in the 19th and 20th century by enabling unprecedented economic and population growth. This growth was based on a lottery prize – the discovery of coal, oil and gas supplies (Sombart 1928). Humankind used to eke out a diminished existence in the northern hemispheres until well into the 18th century. People depended on the flow of solar energy. Food, fodder, heating and mechanical energy were drawn from biomass production, water cycles or wind power. Insufficient food production, wars and diseases repeatedly set back the economy to the subsistence level. The discovery of coal and its deployment in industrial steam engines suddenly endowed humankind with huge amounts of stored solar energy. These assets liberated people from the whims of nature and enabled building up a physical capital stock.
The combustion of fossil resources in the global industrial metabolism came with a hidden cost – the conversion of the atmosphere into a free CO2 waste disposal site. Today we know that the storage capacities of this disposal site are limited. Depletion of the atmosphere might cause dangerous and potentially catastrophic climate change. Thus, climate economists play the role of a spoilsport by demonstrating to humankind that its "carbon debt" might outweigh the fortune of resource supplies. What was once considered a lottery prize now turns out to be a burden.
**Is climate protection destabilizing the foundations of modernity? **
Will the abandonment of coal, oil and gas set back humankind to subsistence levels? More than once the Intergovernmental Panel on Climate Change (IPCC) has been accused of destabilizing the very foundations of modernity. Large companies have mobilized strategists to discredit climate change by likening it to an attack on the modern liberal civilization. A simple correlation is ingrained in the historical memory of humankind: all nations that overcame poverty and became rich via industrialization used coal, oil and gas. No prosperity without fossil energy sources!
However, if it is true that overconsumption of fossil energy sources will melt off ice shields, dry out the rainforests, acidify the oceans, result in more frequent floods in Bangladesh and dry up harvests in Zimbabwe, then developing countries are facing an apparently tragic decision: either induce dangerous climate change or engage in dangerous emissions reductions; either pursue climate change mitigation without economic growth or economic growth without climate change mitigation.
As this suggests, a central question of global climate policy is whether decoupling wealth and emissions is feasible. Some observers in the environmental movement are hoping that market mechanisms will inevitably and automatically mitigate climate change. They argue that the limited supplies of coal, oil and gas will lead to increasing resource prices that in turn will induce a rapid switch to renewable energy sources and energy efficiency. This, however, is an illusion. Up to 15,000 billion tons of CO2 are still stored underground, mostly coal that can be used for generating electricity, heating houses, and even for using coal-to-liquid processes to produce transport fuel. Hoping for a rapid, relative cost decrease of renewables is dangerous since this hope might deter further climate policy efforts. Renewables have indeed experienced large cost reductions in recent years, but their share in meeting global primary energy consumption is only about 12 percent, with half of that coming from traditional biomass (IPCC 2011). Without dispute, prices for fossil energy sources will rise at some point and costs of renewables will decrease. The question is: Will this structural change come about in time? The answer from almost all scenario calculations reviewed in the IPCC Special Report on Renewables (IPCC 2011) is: _no_.
Therefore, in order to achieve effective climate change mitigation, dedicated policies are needed to constrain global emissions. Scenario calculations show that with a cost-efficient transformation of the global energy system – and the exploitation of energy efficiency measures, renewable energy, as well as carbon capture and storage technology (CCS)1 – the global GDP loss could be limited to a very few percentage points (IPCC 2011). However, mitigation costs will rise if certain technologies such as renewables, in particular bioenergy or CCS, are not available (Edenhofer et al. 2010a). The next IPCC Assessment Report, due in 2014, will deliver a comprehensive overview of the current research on these questions. (1. Editors' note: CCS is a controversial emerging set of technologies that seek to capture large quantities of carbon emissions and transport them to sites where they can be pumped into underground geological formations and kept out of the atmosphere.)
**The atmosphere as global common**
The prosperity of the 21st century will be determined by the sustainable management of the global commons. This is a new challenge for the future of our economic system. Even if everybody benefits from a sustainable usage of global commons, there are incentives for free-riding. With every nation thinking this way, individual shrewdness turns into collective stupidity. Some form of cooperation will be a survival condition for humanity.
The atmosphere is a global common-pool resource in its function as a sink for CO2 and other greenhouse gases. Currently, it is a "no man's land" that is available to everyone free of charge. Oceans and forests are closely linked to the atmospheric sink through the global carbon cycle and absorb some of the anthropogenic CO2 . Interestingly, oceans and forests are also global common-pool resources that serve as important sources of biodiversity, exhaustible minerals and fish resources. However, the atmosphere and the oceans are threatened by excessive CO2 emissions, and the forests are being depleted by increasing food and bioenergy demand.
The climate conference in Durban in 2011 – yet another attempt to deal with these new scarcities – failed to nail down a binding roadmap for global emission reductions. Solving this issue is a challenge to the international community. This challenge can be outlined as follows (Edenhofer et al. 2011): In order to assure with medium probability that the temperature of the global atmosphere does not rise another 2 degrees – the current target – only about another 750 billion tons of carbon dioxide can be disposed into the atmosphere. A less stringent target allows for another few additional hundreds of billion tons only. With 33 billion tons of global CO2 emissions disgorged by the global energy system in 2010, it can be easily calculated that the atmosphere as a disposal site will be full in only a few decades. Hence, the use of fossil energy sources must be capped globally.
This will precipitate profound distributional conflicts. If climate policy means that a big share of fossil resources is left unexploited, this involves a devaluation of the assets of owners of coal, oil and gas resources. Moreover, the scarce atmospheric exploitation rights need to be equitably distributed between Africa, China, the US, and other world regions. The political process would also need to determine how many atmospheric exploitation rights the next generation would be entitled to. In light of all these difficulties, it is astonishing that there are actually even attempts to reach a global agreement.
Is the efficient and equitable use of commons bound to fail? Elinor Ostrom demonstrated that communities on a _local_ level can in fact enforce effective rules of use (Ostrom et al. 1994). Whether this capability can be replicated at the global level remains unclear. However, it would be dangerous to wait for the establishment of a global government that could regulate the climate according to a fully worked-out scheme before taking stringent climate change mitigation measures. There will not be a world government in the near future. But the management of the atmosphere as a global commons does not require one. In fact, it requires nested, interlinked policies at the international, national, regional and local levels. Elinor Ostrom and others call this multilevel or polycentric governance (Ostrom 2011).2 The question is: Which level is responsible for which issues, and how they can be coordinated? (2. For more, see the essay by Helen Markelova and Esther Mwangi earlier in Part 5.)
In order to set out the legal framework for national commitments the _international level_ is indispensable. The principles of burden-sharing, the support of developing countries, and a deliberative, coordinated plan to prevent free-riding must be tackled at this level.3 At the _national level_ , subsidies for fossil-fuel consumption – worldwide around US$400 billion in 2010 (IEA 2011) – could be phased out and spent on boosting renewable energy technologies. At the _regional level_ , regions like California, Australia, and several large Chinese provinces are planning on introducing emissions trading systems following the European model. Regarding the environmental integrity of these systems, the choice of the absolute emissions cap will be crucial. At the _local level_ , cities could reduce their emissions by enhancing their urban public transport systems and transforming their building infrastructure. An estimated 496 billion tons of CO2 will be emitted over the next fifty years just due to the already existing energy and transport infrastructures (Davis et al. 2011). In other words, there is little scope for further fossil-fuel based infrastructures. (3. Prue Taylor advocates a reevaluation of the principle of the common heritage of humankind earlier in Part 5.)
An intergovernmental agreement remains indispensable. Otherwise emission reductions in one region will always lead to increasing emissions in other regions. However, waiting for a global contract before starting to implement good prototypes would effectively stop the development of climate policy. Such prototypes can prove, especially to emerging economies, that emission reductions do not entail decreasing wealth.
We are only gradually beginning to realize that global common-pool resources are assets to humankind that should be managed as commons. Wasting them would be disastrous. We are trustees of these assets and thus, trustees for future generations. We have the duty to invest so as to increase or at least maintain these assets. However, the distribution of a fixed carbon budget between humans can be a zero-sum game in which the gain of one country is the loss of another one. This is why some observers are very pessimistic regarding the chances of a stringent intergovernmental climate policy. The zero-sum dilemma can only be overcome by beginning a prudent transformational process that can decarbonize the world economy.
**Maps of knowledge**
In order to tackle this task we still lack necessary knowledge. We require a better understanding of economic growth patterns in industrialized and developing countries as well as in emerging economies. The development of "hard" infrastructures like electricity grids, roads and apartments as well as "soft" infrastructures like education and health services need to be better understood. In particular investments in durable hard infrastructure will define emissions patterns for decades (IEA 2011). We are facing the question how to build up urban infrastructures in China, India and Africa without permanently increasing global emissions drastically. The international division of labor between spatial agglomerations determines not only the export and import of goods and capital but also of CO2 and resources (Peters et al. 2011). How can we assure that international trade does not lead to the waste of regional commons? In order to tackle these problems we need to improve our understanding of how effective subsidiary and polycentric governance can work on multiple levels.
We need maps of knowledge, pointing out feasible pathways for a sustainable management of global commons and their dynamics of use while exploring risks and uncertainties in the light of different value systems. This is the intention of the recently founded Mercator Research Institute on Global Commons and Climate Change (MCC). The maps that MCC intends to produce in cooperation with its partners will neither replace travelling nor will they prevent us from the surprises that travelling entails. However, travelling without maps can easily lead into the swamp or, for that matter, to going round in circles.
**References**
Davis S.J., K. Caldeira and H.D. Matthews. 2010. "Future CO2 Emissions and Climate Change from Existing Energy Infrastructure." _Science_ (329)5997: 1330–1333.
Edenhofer, O., Knopf, B., Barker, T., Baumstark, L., Bellevrat, E., Chateau, B., Criqui, P., Isaac, M., Kitous, A., Kypreos, S., Leimbach, M., Lessmann, K., Magné, B., Scrieciu, S., Turton, H., van Vuuren, D.P., eds. 2010a. "The Economics of Low Stabilisation: Model Comparison of Mitigation Strategies and Costs." _The Energy Journal_ (31)1 Special Issue:11–48.
Edenhofer, O., H. Lotze-Campen, J. Wallacher, M. Reder, eds. 2010b. _Global, aber gerecht: Klimawandel bekämpfen, Entwicklung ermöglichen._ Beck 2010.
Edenhofer, O., C. Flachsland, S. Brunner. 2011. "Wer besitzt die Atmosphäre? Zur politischen Ökonomie des Klimwandels." _Leviathan_ (39)2:201–221.
IEA – Internationale Energieagentur. 2011. _World Energy Outlook 2011._ IEA Paris.
IPCC, 2011: O. Edenhofer, R. Pichs-Madruga, Y. Sokona, K. Seyboth, P. Matschoss, S. Kadner, T. Zwickel, P. Eickemeier, G. Hansen, S. Schlömer, C. von Stechow, eds. _IPCC Special Report on Renewable Energy Sources and Climate Change Mitigation._Cambridge, UK and New York, NY. Cambridge University Press.
Ostrom, E., R. Gardner, J. Walker. 1994. _Rules, Games, and Common Pool Resources_. Ann Arbor. University of Michigan Press.
Ostrom, E. 2011. "Handeln statt Warten: Ein mehrstufiger Ansatz zur Bewältigung des Klimaproblems." _Leviathan_ (39)2:267-278.
Peters, Glen P., Minx, Jan C., **** Weber, Christopher L., Edenhofer, Ottmar. 2011. "Growth in emission transfers via international trade from 1990 to 2008." _Proceedings of the National Academy of Sciences_ (108)21:853–8534.
Sombart, Werner. 1928. _Der moderne Kapitalismus. Historisch-systematische Darstellung des gesamteuropäischen Wirtschaftslebens von seinen Anfängen bis zur Gegenwart, Bd. III: Das Wirtschaftsleben im Zeitalter des Hochkapitalismus._ München und Leipzig. Erster Halbband, Duncker and Humblot.
**Ottmar Edenhofer** _(Germany) is professor of the Economics of Climate Change at the Technische Universität Berlin and Co-Chair of the Working Group III of the Intergovernmental Panel on Climate Change (IPCC). He is designated Director of the Mercator Research Institute on Global Commons and Climate Change (MCC), and will continue to act as Deputy Director and Chief Economist at the Potsdam Institute for Climate Impact Research (PIK), where he leads Research Domain III - Sustainable Solutions._
**Christian Flachsland** _(Germany) is researcher and designated leader of the research group "Assessment and Scientific Policy Advice" at the Mercator Research Institute on Global Commons and Climate Change (MCC)._
**Bernhard Lorentz** _(Germany) is President of the Stiftung Mercator, which co-founded the Mercator Research Institute on Global Commons and Climate Change (MCC) jointly with the Potsdam Institute for Climate Impact Research (PIK)._
# Transforming Global Resources into Commons
_By Gerhard Scherhorn_
The greatest problem of our time is that for centuries we have been steadily weaned away from treating our common resources responsibly and carefully so that they can either regenerate or be repaired or replaced after use. Until the Middle Ages local resources such as pastures, woods and fishing waters were really handled that way. But since the 16th century, when agricultural capitalism first began (Wallerstein 1974), these resources were enclosed and privatized by feudal lords. This soon led to the justifying myth that individuals take better care of their own property than communities. It was that myth which wiped out the ancient memories of responsibility for _local_ common resources.
With _global_ resources such as air, water, raw materials and entire ecosystems it has been quite different. These were once seen as inexhaustibly abundant, enabling everybody to use them for free and without any duties to preserve or replace them. In our day we have barely begun to realize that they are finally becoming scarce. But now it is property law that preserves the ancient perception of their unlimited availability. Since the law imposes few if any restrictions on access, the law continues to absolve owners of any obligation to respect global resources.
In seeking the reason we discover that this kind of freedom is the condition for an endless expansion of capitalism. The essence of capitalism is "to accumulate by dispossession" (Harvey 2003), since the progress of capital accumulation depends on the capability to find and exploit new _external_ sources of wealth that can be appropriated.
In this sense property rights fuel the expansion of capitalism. They invite property owners to _externalize_ costs on to those resources that ought to be treated as common property. Externalizing costs means using shared resources to the point where they are exhausted while failing to maintain or reinvest in them. The displaced costs are borne by the resources themselves, which are diminished and depreciated, as a way to boost profits. Thus property law encourages the opposite of sustainability. It promotes the relentless consumption of resources and thereby enhances capitalism. What we need is the contrary: to encourage sustainable ecological stewardship by reinvesting externalized costs, i.e., profits, into the preservation of resources.
**A legal rule to preserve the global resources**
In order to illustrate how this could be accomplished, take German property law as an example. Its central rule is laid down in §903 of the German Civil Law (Bürgerliches Gesetzbuch, BGB), as follows: "The proprietor is entitled, as far as neither the law nor any third-party claims stand in the way, to deal with his property at his discretion, and to exclude others from any influence." Now consider what might occur if the legislature would _alter_ this rule by adding the clause, "...provided he upholds the responsibility to preserve the common resources he uses."
The term "common resources" would refer to Article 20a of the German constitution (Grundgesetz), which requires that "the state protect the natural foundations of life," and to the notable requirement in Article 14.2: "Property obliges. Its use shall as well serve the common welfare." The insertion would restrict individual property rights by imposing a duty to preserve any common resource the proprietor has used or caused to be used. In other words, a proprietor would be required to pay for replacement of what he used or consumed (just as he might pay the costs of preserving his private possessions).
Such a legislative amendment is needed because present laws constitute a barrier to sustainable stewardship of natural resources, and a particular barrier to the task of _commoning,_ Peter Linebaugh's term for the self-determination of commoners in managing their shared resources (Linebaugh 2008). Without amending the law it would not only be difficult to create and manage _local_ commons as exchange trading systems and complementary currencies (Lietaer and Belgin 2011), it would be nearly impossible to establish networks that manage the preservation of _global_ resources as commons. Under current laws each single stockholder of a corporation can sue the management for having ordered investments in protection of the environment that go beyond existing law. Because corporations are so deeply committed – legally and economically – to make profits by externalizing costs, how could managers be persuaded to invest this profit into preserving the consumed global resources? It is impossible so long these resources are not acknowledged as _common_ property.
_Commoning_ the global resources, or some of them, must therefore begin with lobbying to convince legislative bodies to withdraw any legal rules that allow or even induce persons, companies, councils or governmental authorities to exploit global resources. Those rules must be replaced with responsible regulations preserving global resources.
**The core of commoning is agreement and monitoring**
That prerequisite being accomplished (or anticipated), the next step must be to transform a resource into a _commons._ The German term is _allmende_ , a word that once referred to any local community of free people that decided on their common affairs by their own right; common pasture, common wood were historically just the most recent forms of the _allmende_ before it was disbanded (Grimm 1854). Today, in reviving the term _allmende_ we mean a common resource alone, but also the community that manages it as a commons. This is what the term "commoning" means: Managing the resource as a commons, in other words actualizing the _allmende principle_ – the principle that the community members moderate their demands on the resource by mutual agreement and mutual monitoring and enforcement (Scherhorn 2012, following Ostrom 1990).
Thus the core of commoning is that the community members agree on all rules of conduct and procedure, and that they supervise resource use by social control. They determine themselves – often supported by public authorities – how the resource shall be handled and what sanctions for violations shall be imposed. That makes the commons distinct from both the market and the state, which rely upon prices and instructions, respectively, to affect people's behavior. The members of a commons, by contrast, are motivated by their deliberate convictions, inner direction (Riesman 1950), or self-determination (Deci 1995), at least in smaller-scale commons. Commoners are surely not immune from anti-social behavior such as "free riding" deserving of sanctions, but such punishments are more likely to be effective if they have been agreed upon.
An example of a _local_ resource commons, among many others, is the lobster fishery around the island of Monhegan on the coast of Maine in the US In a case study, Princen describes it as:
an evolving system of largely self-regulating fishery management, an evolution,, a series of experiments, that continues to this day.... It has three major developments: a self-imposed half-year closed season formalized in a 1907 state law; a self-imposed limit on the number of traps per lobster-fisher instituted in the 1970s; and, most recently, an unprecedented, state-sanctioned limited-access fishing regime for the island. The context is nearly two centuries of ever-increasing pressure on the lobster fishery along the Eastern seaboard of the US and Canada and the threat, realized in many places, of depletion and loss of livelihood (Princen 2005).
**Global resources need local protection**
Perhaps the only example of an effective _global_ resource commons is the famous Montreal Protocol on Substances that Deplete the Ozone Layer, an international treaty which was signed 1987 by 48 countries and today has nearly 200 signatories. Over the years, the agreement has "been amended to further reduce and completely phase out CFCs, halons and other chemicals...Several subsequent meetings of the signing countries were convened to track overall progress...The full recovery of the ozone layer is not expected until at last 2049" (Encyclopedia Britannica).
The singular success of the Montreal treaty indicates how limited the range of effective agreements between states will be, especially if compared with the series of international conferences on climate protection. For the time being the attempts to build an international climate regime are altogether a trial-and-error process to transform a global open access resource into a global commons, as Wolfgang Sachs has observed (Sachs 2009).
Apart from treaties between states, there are currently two basic strategies for protecting global resources: emissions trading and commons trusts. _Emissions trading_ requires that the emission of CO2-equivalents be restricted to the amount of emission rights the emitter has bought, and that the overall amount of buyable rights will be reduced over time. Hence the price of the emission rights will rise, the quantity of emissions will be reduced, and the climate system as a global resource will be preserved. A _commons trust_ (Barnes 2006) is an independent non-profit enterprise assigned with fiduciary duties to look after the long-term interests of beneficiary commoners, and the power to sell and restrict emission and extraction rights. The trust should be assigned the sole responsibility of preserving a given common resource and be required to distribute any remaining receipts to the people who hold a stake in that resource.
Both concepts depend upon governments to set effective, enforceable rules. But where preserving a common resource results in shortages, governments must withstand the concentrated pressures exerted by buyers, sellers and workers who insist upon economic growth as a source of earnings, sales and jobs. The Monhegan example shows that such pressures can be overcome peacefully, if one group of buyers, sellers, and/or workers who are strongly motivated for sustainable development defend their interest in resource preservation against other groups with somewhat lower legitimation. The state's role is then to mediate the conflict instead of imposing a regulation influencing people's decisions by outer stimuli like prices or instructions.
**A network for sustainability**
The above-suggested legal regime – which stipulates the preservation of natural resources and thereby forbids the externalization of costs – would be a general rule intended primarily to stimulate a general understanding that we are as responsible for our common resources as for our private plants, facilities and investments.
At the same time it would be the basis of specific regulations that may prove to be a necessary condition of legal security. Since externalizing is still common practice, however, it would not be reasonable if we left it wholly to government authorities to find out and prescribe how externalization should be avoided or compensated in each of numerous specific situations. The general rule, if it were in force, would open a second way. It would encourage those who prefer cost internalization to contribute to that search process by joining in communities that work out agreements on what is needed to preserve specific common resources after use. These communities can be characterized by four basic elements: 1) community members 2) who moderate their demands on the resource and reinvest in its preservation by 3) mutual agreement and 4) mutual monitoring.
1) The kind of cooperative social relations that result in taking care of a common resource can arise among suppliers of a specific product as well as among consumers. Suppliers who compete with each other are more aware than others of each other's actions and even costs, and consumers may be in contact with each other through civic associations, Internet communities or advocacy organizations. In either case, the contacts can be local, national or worldwide.
2) Commons of either consumers or suppliers can arise if the need to moderate demand for a specific resource – copper, wheat, fish, oil, electricity, water, soil, etc. – becomes evident, perhaps because the resource is becoming scarce, its price is rising or will rise, or the means can be found to use less of it – through recycling, substitutes or alternatives in production.
3) Mutual agreements between competitors are prohibited by law if they restrain competition, but that should not hold for agreements to internalize costs.
4) Mutual monitoring is a kind of what sociologists call informal social control. It occurs continuously since competitors cannot help but notice and observe each other, and buyers cannot help but compare and assess products and suppliers, and exchange their knowledge among themselves.
These four elements could themselves meld into a network of commons, because a growing number of both suppliers and consumers who long for the opportunity to preserve the resources, will be motivated to preserve the resources they use and to prevent others from continuing to externalize costs, which until now has worked to the disadvantage of those who want to internalize costs. Thus their activity would be helpful and even necessary to enforce the law, whether by recommending a government mandate or by agreeing on customary procedures as substitutes for mandates. In either case, a commons would likely be superior to an external government authority because competitors can better judge whether and what costs are being externalized than any public prosecutor or district attorney, and criticism by civic and consumer associations can be more powerful in persuading a firm to internalize its costs than the risk of litigation (provided there were a legal basis).
In order to make it easier to join in commons of the type indicated, the legal basis for accountability should be even further broadened by amending the competition law, too, which under the current property law forces competitors to externalize costs. Any hidden externalization of costs should from now on be treated as unfair competition, which is principally forbidden by law in several European countries and most states of the US, although with different provisions. Take, for instance, the German law against unfair competition (Gesetz gegen unlauteren Wettbewerb, UWG). It prohibits a supplier from enjoying a competitive market advantage by making deceptive claims about its product(s), as misleading advertisements or taking advantage of consumers' lack of knowledge.
The amendment would consider it unfair competition if a company hides his externalizing practices rather than paying the full costs of protecting or renewing them. Since the UWG permits competing enterprises and civil associations like consumer unions to sue a firm for unfair competition, one can imagine that conscientious firms trying to preserve global resources would use this legal provision to prevent their competitors from achieving an unfair market advantage. And since courts can decide that profits from unfair competition be transferred to the federal budget, management would prefer to reinvest in and protect global resources rather than to be accused of externalizing costs.
**Entrance to new perspectives**
In this way amendments to property and competition laws could help bring into being a network of commons-like communities of enterprises, civil associations and individuals that would monitor the use of global ecological resources. While there is a huge variety of separate problems that have to be solved in this field, encouraging the formation of commons would not only be an effective way to enforce the law but also a way to bring about a general awareness of common resources and everybody's responsibility for them. This, in turn, could open the door for two hidden implications of sustainability that are already knocking at it but aren't allowed to enter.
First, by getting serious about preserving global resources, and acknowledging that markets are not inseparably joined to capitalism (Braudel 1977), sustainable development could become separated from capitalism but aligned with the market economy.
Second, not only natural resources ought to be treated as global commons, but so should the many socially organized institutions that provide employment opportunities, public health systems, educational opportunities, social integration, income and wealth distribution, and communication systems such as the Internet.
To put it in a nutshell: Sustainability is commoning global resources by applying the commons principle of wisely moderating demands on common resources. It is time to ask what perspectives will open up when we proceed this way.
**References**
Barnes, Peter. 2006. _Capitalism 3.0. A Guide to Reclaiming the Commons._ San Francisco. Barrett-Koehler.
Braudel, Fernand. 1977. _Afterthoughts on Material Civilization and Capitalism._ Johns Hopkins University Press.
Deci, Edward. 1995. _Why We Do What We Do. The Dynamics of Personal Autonomy_. New York. Putnam's Sons.
_Encyclopedia Britannica_ , "Montreal Protocol," available at http://www.britannica.com/EBchecked/topic/391101/Montreal-Protocol.
Grimm, Jacob and Wilhelm Grimm. 1854. _Deutsches Wörterbuch_. Reprint München 1999: Deutscher Taschenbuch Verlag.
Harvey, David. 2003. _The New Imperialism._ Oxford. Oxford University Press.
Lietaer, Bernard and Stephen Belgin. 2011. _New Money for a New World. _Qiterra Press.
Linebaugh, Peter. 2008. _The Magna Carta Manifesto: Liberty and Commons for All_. Berkeley. University of California Press.
Ostrom, Elinor. 1990. Governing the Commons. The Evolution of Institutions for Collective Action. Cambridge, MA. Cambridge University Press.
Princen, Thomas. 2005. _The Logic of Sufficiency._ Cambridge, MA. MIT Press.
Riesman, David. 1950. _The Lonely Crowd._ New Haven. Yale University Press. __
Sachs, Wolfgang. 2009. _Proceedings of an International Meeting at Crottorf Castle, Germany,_ by Silke Helfrich. __ http://www.archive.org/details/crottorf-commoners.
Scherhorn, Gerhard. 2012. Die Welt als Allmende. Für ein gemeingüter-sensitives Wettbewerbsrecht. In: Silke Helfrich and Heinrich Böll Foundation, eds. _Commons_ _. Für eine neue Politik jenseits von Markt und Staat. _transcript-Verlag. __
Wallerstein, Immanuel. 1974. The Modern World-System: Capitalist Agriculture and the Origins of the European World-economy in the Sixteenth Century. New York. Academic Press.
_The author wants to thank David Binder for effectively translating his German English into the native language._
__
**Gerhard Scherhorn** _(Germany) was former director of the Academy of Economy and Policy in Hamburg and is professor emeritus of the University of Hohenheim where he gave lectures on consumption theory and consumer policy until his retirement in 1998. He directed the working group "New Models of Wealth" at the Wuppertal Institute for Climate, Environment and Energy from 1996 to 2003 as well as the research group "Sustainable Production and Consumption" until 2005. With Prof. Johannes Hoffmann he heads the Project Group Ethical-Ecological Rating at J.W.Goethe-University, Frankfurt/Main, and runs the website http://www.nehmenundgeben.de. _
# Electricity Commons – Toward a New Industrial Society1
_By Julio Lambing_
From the beginning the modern energy industry was shaped by enterprises. They played a leading role in the development, distribution and commercial use of electrical technology. As a result of complex technological and political developments, a centralized and at the same time networked production model asserted itself. The logic of economies of scale2 and "balanced load management" describes the technological rationality of this process: the larger and more diversified the number of electricity consumers, the more the different user behaviors balance peaks in demand. And the larger the power plants that generate the electricity, the more effectively it can be produced and the lower are the costs per kilowatt hour generated. (1. This article would not have been possible without the efforts of Sebastian Gallehr. I am very grateful to him as well as to Stefan Ulreich, Hans-Joachim Ziesing, Thomas Meister, Helmuth Groscurth, Daniel Dahm and Marian Bichler for the many valuable insights I received from them when preparing this contribution. 2. This concept is based on cost advantages that may arise through the expansion of a company. In this case, the larger the production plant, the greater the decrease in cost per unit of the goods that are produced. This can be a result of different factors: for example as a larger production plant operates more effectively, the purchase price of raw material decreases for larger purchases and interest costs are often reduced when raising capital for large-scale investment projects.)
As a result of this logic, large power plants have supplied large numbers of electricity users via a power grid. For about half a century, in all industrial nations, public policy has decreed that electricity suppliers should be able to act without any competition within their supply areas. In return, pricing policies and investments are controlled or regulated by the authorities and the electricity companies can even be owned by the public sector. The electricity supply system that emerged in the 20th century, therefore, was highly monetized, external to users' homes and businesses, and administered in hierarchical and highly centralized ways.
Beginning in the 1980s, a restructuring of the energy industry began. Public policies that liberalized and privatized energy markets dismantled the geographic monopoly of electricity production. Electricity suppliers were to be exposed to competition, and vertically integrated, interconnected companies were broken up into different levels of the electricity business (electricity generation, transmission and distribution). The aim was to make the grid available for every provider to supply its customers without discrimination, making it necessary to separate electricity producers from the network operators, at least legally, but if possible also in terms of ownership. The electricity consumers themselves were to determine from whom and under what conditions they would receive their electricity. This was coupled with the hope that competition would push the power supply industry to more cost-effective and demand-oriented structures, a higher degree of cost transparency, a reduction of excess capacity, reduced prices and more ecological innovations.
However, the dangers of global climate change, which increasingly entered the public consciousness since the 1990s, illustrate the limitations of a liberalized, private sector-oriented electricity market. Not only has the combustion-based energy production system led to an unprecedented plundering of fossil resources at the expense of future generations, it has also produced an unprecedented human-generated threat to the ecological system. According to a wide consensus of the climate science community, CO2 emissions must be reduced worldwide by at least half, and in the industrial countries by 80 to 95 percent, to avoid dangerous climate change. The electricity sector can only reach this goal in an ecologically and socially sustainable way if, in addition to enormous cuts in consumption in all areas, it also implements a full supply of electricity from renewable energies. Additionally, we must significantly reduce our consumption of other resources, which massively endanger many biological systems, such as oceans, soils, virgin forests, animals and plants. The industrialized nations also use substantially more of the world's available resources, and they pollute a far disproportionate share of the planet's ecological storage reservoirs relative to the worldwide population. The old European systems of electricity supply were ultimately based on the specified goal of supplying even the most remote human settlement with electricity. This meant that networks and production in Europe were usually under public control and were _seen as common goods._ In principle it was thus possible to politically control and directly determine the financial and technological activities of electricity producers. In the liberalized market, however, individual companies do not have an intrinsic motivation to promote anything else but maximum company profit. Based on the purpose of their business, electricity companies _cannot_ therefore have any real interest in reducing the overall consumption of electricity in society. Their obligation to maximize profits will constantly incentivize them to circumvent politically imposed conservation measures, cost reductions and mandates to lower carbon dioxide emissions.
In addition, a fundamental investment problem is emerging in the liberalized electricity markets: an aversion to the construction of new generating plants and electricity networks that are necessary for a full supply of green electricity. The temptation is great to use the existing technical infrastructure for as long as possible, instead of making new, long-term investments.
**Designing a commons-based electricity supply**
As was the case when the nationwide electricity infrastructure was first built, so today we are again at a crossroads: We can and must choose what organizational and technical structures will be used in the future. The liberalization of the electricity market has broken up entrenched structures of production and distribution, and has made them more transparent. At the same time, however, it has created new obstacles when it comes to combating climate change and lowering the consumption of resources.
But if we must obtain our electricity supply from planetary, common resources – the Sun, wind and water – it is worth exploring how the commons perspective might guide a reorganization of the electricity industry. The commons may well play a vital role that both complements and goes beyond the approaches taken by the state and by the private sector.
Based on the fundamental design principles suggested by Elinor Ostrom,3 the elementary structure of an electricity commons can be described as follows: The conventional binary usage structure of buyer/seller (or for governmental organizations, authority/electricity customer) would be replaced by a _user community_ whose members regard themselves as both electricity customers and electricity producers. The scope and boundaries of the electricity infrastructure that is used and the group of beneficial owners must therefore be well delineated. Here, too, the behavioral patterns, the number of electricity consumers and the energy intensity of private as well as commercial activities determine the electricity consumption, the required output and thus the dimensioning of the power plants and electricity grids within this commons. The less electricity consumers use, the less they must produce. (3. See Ostrom's design principles in Conway's article earlier in Part 5.)
A balancing process must thus occur: On the one hand, there are the positive effects that new electrical devices will have for the quality of living and the freedom to act for households and businesses. On the other hand, these changes will influence the consumption of electricity and the necessary production capacity. The designers of any new system of electricity production and consumption must consider both the investment and the maintenance costs for electricity production and grids as well as the stresses caused by local and global consumption of resources.4 (4. This includes both the direct use and harm of landscape that construction of power generating systems and grid infrastructure entails, as well as the global consequences of manufacturing the entire apparatus of electrical equipment.)
If we are to create an optimal balance here, a rich set of procedures, skills and behavioral attitudes must be developed and practiced to ensure the effectiveness of such an electricity commons. For this to occur, rules will be required for the consumption, distribution and provision of the electricity. They must be finely tuned and coordinated with each other; likewise, they have to take consideration of local social, natural and technological conditions. Consumers are not simply at the mercy of these rules and conditions; instead, they participate in their creation. The appropriate handling of electricity consumption and production must be monitored by the consumers themselves or by persons who are legally accountable to them. Violations of rules and standards must be punished by a graduated series of sanctions that the consumer community regards as reasonable and fair. Should conflicts arise, they should be resolved immediately and at the local level if possible. This requires inexpensive and instantaneous communication among the consumers. Conventional public authorities that are accustomed to centralized, bureaucratic command-and-control need to recognize the functional efficiency of small, self-organized and self-regulated entities. (They may have trouble accepting this, but the Internet has already demonstrated the feasibility even of interacting networks of such entities.)
There are three factors that impede the creation of electricity commons based on close producer-consumer collaboration. First, the construction of new production capacity requires substantial financial means. This is especially true for the production of renewable energy, since the cost per produced kilowatt hour for such technologies is still more expensive than for large-scale fossil technologies. Second, a new infrastructure for electricity production (such as utility poles, windmills or agrarian monocultures for biofuels) has an effect on the landscape and will thus affect a larger circle of people whose interests must be integrated into the commons decision-making process.
Third, the technical advantages of electricity grids tend to promote a larger, integrated system of consumers because a larger consumer base requires less power production per access point (household or business), thus reducing costs. This reality stems from the fact that people turn on their vacuum cleaners, toasters or saunas at different times. The larger the grid, the less additional production capacity per access point is needed to meet peaks in demand. The investment costs for each individual customer are reduced. However, the number of members of the electricity commons must therefore be very large, resulting in the need for more complex social and organizational procedures.
On the other hand, it is precisely this grid structure of electricity production that is so helpful in maximizing efficiency and that makes communalization of electricity logical and attractive. Someone who lives "off the grid" and is self-sufficient in energy does not need or want a commons system. But although much praised in green circles, such idealized models of energy inefficiency and social atomization and isolation cannot be a solution for society as a whole. A network of energy users implies interaction between the users. If these interactions occur deliberately and with foresight, the result is collaboration. In addition, if the overall consumption of finite raw materials is going to be reduced – a vital necessity for our times – then we will need to use electricity grids and energy consumer commons to reduce consumption while maximizing efficiencies.
**Hybrid forms of commons in the existing electricity landscape**
Is such a design realistic? In a decentralized scenario oriented toward renewable energies, it seems natural for local groups to set up their own electricity production capacities and influence the collective usage behavior wholly onsite. But in a liberalized electricity market, it is also always possible to establish local producer-consumer electricity commons. The market leaves open the question of who feeds power into the system, who purchases it and how the relationship between the two is shaped. As a practical matter, however, due to the existing economic, political and technical configurations of our energy infrastructure, only hybrid forms are possible, at least as a first step.
One familiar commons-based type of electricity supply is the energy cooperative. In recent years, a number of cooperatives have arisen in Europe (along with other financing models) that have made it their goal to fight climate change and finance "green" power plants. The "purest" form of electricity commons are ones in which the cooperative is both owner and operator of the production plants and power grid as well as the community of electricity customers and decision-makers regarding the infrastructure (members of the cooperative).
In reality, more or less all cooperatives deviate from this ideal. The _Elektrizitätswerke Schönau_ (EWS) is one of the rare examples in which the members of the cooperative own the electricity production plants as well as the power grid. However, there are far more customers of EWS electricity (100,000) than direct coop members (approximately 2,000), so the user community is not coextensive with the community of decision makers. By contrast, the 30,000 customers of the Belgian electricity cooperative _ecopower_ are at the same time members of the cooperative, and thus owners of power plants as well. (A significant number of them were also involved in the planning of production plants. The services of the grid operator, however, are accessed within the framework of the normal electricity market.)
Also noteworthy are the many production cooperatives for photovoltaic plants that directly use their own electricity. Most other electricity-generating cooperatives ("green" production plants, wind turbines and bioenergy power plants) can only establish a mathematical correlation between the amount of electricity they produce and the amount of electricity their members consume – because they sell their electricity to the grid or rely upon feed-in tariffs5 to the public community of electricity customers. (5. Feed-in tariffs are a widely used policy instrument that allows the producer of green electricity to deliver electricity into the nearest public grid. The responsible grid operator then has to purchase this electricity at a guaranteed price, fixed by the authority. Usually, the costs will then be apportioned to all electricity customers in the regulated area.)
As consumers become more closely integrated into local electricity generation, it affects the ways that they consume electricity. This becomes more striking still – and also controllable in differentiated ways – through the use of "smart grids" and "smart metering" technologies. The more accurately the actual energy consumption can be determined at each point in time, and the more information systems make it possible for small consumers to inform themselves of their current usage and the overall capacity situation, the more user communities can control their behavior. The possibility of so-called "Negawatt power stations" – i.e., a coordinated, collective reduction in demand within a defined or even predicted time period – is increasingly realistic. Smart grid technologies also make it possible to harmonize the electricity production of different plants, or to bring together selected production/consumer communities economically into a single network.6 (6. The "smart grid" concept relates to the intelligent control and coordination of power plants, components of the power grid and points of consumption, down to individual electrical appliances in factories and households. Modern Internet and communication technologies are used to quickly balance fluctuating electricity production from wind and sun, or to automatically adjust the electricity usage to the capacity situation at any given moment. "Smart metering" refers to intelligent electricity meters that register precisely timed periodic sampling information about electricity usage at a consumption point and transmit it electronically to the electricity supplier. Energy traffic lights, which inform a user of the current output situation of the grid through light signals, are also part of this technology.)
This makes it possible to create a multistage control system: An overcapacity in one community can be used to compensate for demand peaks in other communities. In terms of energy economics, this corresponds to a "balancing group" – a definable system of energy flows within which supply and demand are balanced. This constitutes a virtual network within a physical network.
The possibility of monitoring and controlling the production and usage behavior of the user communities will increase enormously if they are provided with solutions for using smart metering and smart grids within their area of responsibility. Access to these technologies is crucial for the question of self-determination. Who will be able to and have the right to install the corresponding technical equipment? Who will control its functioning? Who will be able to use it and thus, for example, have access to personal data concerning usage or even the operating characteristics of individual household appliances? For smart metering and smart grids, technological competition and battles for economic and institutional power have already begun between open source solutions and open standards on the one hand and closed, proprietary approaches on the other. The right of citizens to have "data sovereignty" is about to become a major political conflict with implications for energy policy. The results could determine if and how electricity commons are functionally possible.7 (7. Examples of the first kind are the "mySmartGrid" project of the Fraunhofer Institut ITWM in Germany, the OpenADR of the Lawrence Berkeley National Laboratory in California, and the Total Grid Community (www.totalgrid.org).)
The appeal of communal provisioning of electricity may also fuel a new movement in civil society and politics to reappropriate the power industry. In Germany, thousands of concession contracts between municipalities and distribution network operators are due to expire in the year 2016. As this date nears, a wave of remunicipalization efforts is emerging in which municipalities are trying to seize the economic advantages of local provisioning while giving their inhabitants a greater personal stake in achieving the common welfare. About 40 new public utilities have already been established in Germany since 2007.
**Open questions**
In reality we see quite a few viable approximations of an ideal commons-based structure for electricity supply. Policymakers should support these approaches if only because a commons structure can promote the holistic rationality of resource savings and accelerate the transition to renewable energy sources. However, a number of issues must be resolved. The most important one concerns the electricity grid. In the approaches described above, the already existing grid acts as a buffer for usage and production fluctuations that are too large for individual producer-consumer communities to balance. This is especially relevant during times of unstable production from sources such as wind power and photovoltaics. Both the high voltage grid and the regional low voltage grid are then needed as external service providers.
It does not make sense to create competing power grids, for it is neither cost- nor resource-efficient. Power grids constitute a natural monopoly. There will not be any meaningful competition between different actors here. The market will not have a discovery function that could lead to the development of the most efficient solutions, nor will it be possible for customers to discipline a company by switching to the competition. The current German trend toward privatization of the interconnected grid can only occur if there is massive control and regulation to prevent monopoly abuses by owners.
As was the case with previous rural electrification cooperatives, a transmission grid managed as a commons would mean that its users decide on the use, expansion and maintenance of the grid. A particular difficulty is created by the pyramidal, hierarchical structure of the electricity grid: the electricity is transformed down from the higher voltage level. Many million points of consumption, as well as every networked electricity producer, must somehow be incorporated into the design of a commons-based grid in a representative and immediate way. The system services for grid stabilization are thereby undertaken centrally. The wisest choice is probably to have an integrated grid in public ownership controlled by political bodies.
As for technologies that store excess power from wind and sun so that they can be used when needed, it must first be determined if commons concepts make sense. Regarding pipeline-bound processes, such as the artificial generation of methane gas (so-called "wind gas"), large, extensive gas networks are available that are either privately or publicly owned. These are large technical facilities with high capital intensity; correspondingly, the issues of the right of disposal and maintenance will be difficult to clarify. The commons models described above can probably be readily applied to small gas generation plants that are associated with combined heat and power plants situated nearby, so power can be generated from the gas. However, such an approach is probably difficult to apply to new, independent hydrogen networks because of their technical complexity, size and capital intensity.
All the hybrid commons-based projects described above are money-based. However, cooperatives straddle the market economy and social economy. On the one hand, cooperatives make it possible to separate the voting rights of internal governance from the amount of investments, so that the principle of "one user – one vote" prevails. On the other hand, cooperatives regulate their internal financial relationships regarding electricity via conventional cash flows. For small, easily manageable supply models, it could be advantageous to allow undercapitalized members to provide nonmonetary services (in the form of manpower, for example) as a way to obtain electricity or shares in the cooperative. A possible link to other types of economies could be regional (local, complementary) currencies whose values could be backed by obtainable units of electricity. The best-known system of this sort is the Japanese WAT System.8 (8. http://www.watsystems.net/watsystems-translation/english.html.)
More than in any other industrial sector, the electricity industry has for the last 130 years been caught in the conflict between the state and the market, and hamstrung by large, centralized structures. Now, new technologies and new forms of commons-based organization are opening up new possibilities. Michel Foucault developed the image of human life and society as a vibrating, constantly changing network that is permeated by variously competing powers. The relationships between these powers manifest in everyday human actions – in production processes and production plants; in political parties and corporations; in customs, habits and behavior patterns; and in concepts of rationality. Ultimately, they crystallize into government apparatuses, legislation and the social structures of domination. The social consequences of revamping the production, distribution and organization of electricity, a core element of our industrial society, could thus be enormous. The ecological necessity of doing so is clear, and the social benefits could be tremendous. New sorts of commons-based models of electricity generation, distribution and consumption deserve serious consideration by all parts of society.
**References**
Granovetter, Mark and Patrick McGuire. 1998. _The Making of an Industry: Electricity in the United States._ In Michel Callon, ed., _The Laws of The Markets._ Oxford, UK. Blackwell. 147–173.
Hughes, Thomas Parke. 1983. _Networks of Power: Electrification in Western Society, 1880–1930._ Baltimore, MD. Johns Hopkins University Press.
Byrne, John et al. 2009. "Relocating Energy in the Social Commons Ideas for a Sustainable Energy Utility." _Bulletin of Science, Technology & Society_. (29)2: 81–94.
Volz, Richard. 2010. _Stand und Entwicklungsmöglichkeiten von Bürgerenergiegenossenschaften in Deutschland, 2010_.
**Julio Lambing** _(Germany) is executive director of the international business association European Business Council of Sustainable Energy (e5). He is concerned with the theoretical and practical challenges of creation a commons oriented industrial society, a goal that will require modern technologies as well as alternative lifestyles, subcultures and knowledge systems._
# The Failure of Land Privatization: On the Need for New Development Policies
_By Dirk Löhr_
As soon as we start speaking about "globalization," we inevitably associate it with the excessive financial markets that are disconnected from the real economy. There is less public awareness of another type of globalization that also involves the forced unification of institutions all over the world: the institution of private property and privatization strategies. The driving forces behind this development are – besides the usual suspects, the International Monetary Fund, the World Bank, the World Trade Organization – governmental development organizations themselves.
For land use and land rights, development usually entails the formalization, specification and individualization of property rights. It is assumed that informal, collective forms of property rights should be converted into private property (Platteau 1996) because such policies will help ease land conflicts, enhance the efficiency of the land markets, guarantee tenure security and assure access to loans. Anything other than private property is seen as an inferior, immature type of property right.
The privatization strategy of national and international governmental development organizations has often been criticized. Nongovernment organizations (NGO) working on environment and human right issues are particularly vocal in arguing that private property on land means the loss of livelihood and forced evictions, especially among socially and economically vulnerable groups. They strenuously object to private property regimes that exclude all other forms of property rights because such regimes trample underfoot the manifold commons institutions that have ensured broad access to land and sustainable use for a long time. Governmental development organizations are taking greater notice of this criticism, but some promising conceptual alternatives are beyond the scope so far.
**Anatomy of property rights**
So where does this fixation on private property come from? From a legal point of view, private property rights grant the possibility to exclude other persons from an asset. Moreover, owners may do with their property as they like. However, traditionally private property on land has been heavily restricted by public law, e.g. building law. From an economic standpoint, property can be interpreted as a bundle of rights comprising the right to use the asset (usus), to appropriate the yields (usus fructus), to change the asset (abusus) and to sell it (ius abutendi).
The dogma of land privatization was initially pushed by the Property Rights school, which emerged in the US as a branch of New Institutional Economics in the 1960s (Demsetz 1967). Property Rights theorists stress the necessity of coupling a secure right of use with the usus fructus right and the right to sell the asset. They believe that this is the only way to ensure that the persons who bear the investment costs will reap the yields (Feder and Feeny 1991). Investments in improvements (plantings, renovations, houses, etc.) would be stimulated by individual ownership, and an overuse of resources (as described by Garrett Hardin in his "tragedy of the commons" essay) could be avoided. Apart from misleading wording – Hardin was in fact describing a tragedy of open access while commons are always characterized by controlled access1 – this argument seems plausible at first glance. (1. more comprehensive account, see Peter Linebaugh's essay on the history of the commons in Part 2.)
However, it conceals an important fact: The right to take the yields from land ( _usus fructus_ ) and the right to sell the asset ( _ius abutendi_ ) are not limited to the "improvements" (such as plantings or buildings). They also include the most important sources of land value – the location, the intensity of use and the quality of the land compared with marginal lands (where the yields just cover the costs). Economists call these factors "differential rents." Such advantages are often circumstantial and beyond the control of individual owners. In most cases, in fact, the basis for land values is created by the community, e.g., changes in land use plans or investments in infrastructure that affect the value of the site.
A high share of these costs is borne by the community. These costs comprise the costs of planning, the costs of infrastructure construction and the opportunity costs of forgoing alternative public or private land use. In the case of improvements to land, individual owners both pay the costs and receive the benefits. But the same does not hold true for the actual unimproved land because rents and incremental values are privatized, whereas the lion's share of the related costs is borne by the community. The decoupling of benefits and costs is an important driver for a multitude of unfair aberrations such as land grabbing2 and rent-seeking, and not only in developing countries (Löhr 2010). (2. See Liz Alden Wily's essay on international land grabs in Part 2.)
However, the picture presented thus far is not complete. Many developing countries have both private property and state property regimes for land. But there are two reasons why that distinction is often more of a nominal than a real difference. First, while access should be controlled to protected areas – which are often former commons that lost that status during the formalization of property rights in land – the state often does not have the capacity or the will to control access effectively.3 Second, state property is frequently leased out as economic concessions to private sector actors for their private economic exploitation. (3. Ana de Ita illustrates this problem using the example of Mexico in Part 2.)
In Cambodia, for instance, "Economic Land Concessions" on so-called "State Private Land" now account for about 25 percent of the country's agricultural land. In addition, there are extensive concessions regarding forestry, mining and other commercial activity. Although lands used under concessions are regarded as state property, from an economic point of view they have all the characteristics of private property. Even the abusus right is oftentimes de facto in private hands, if, for example, forest protection laws are ignored by the concessionaires and the state ignores violations of the law. Unlike private property, the allocation of benefits from land is not driven by market forces, but by the state – oftentimes in the form of undisclosed payoffs to political cronies. Apart from bribes that are often paid, concessionaires pay no acquisition costs, and the formal fees are often ridiculously low; the concessions are obviously privileges.
**Flattened by the steamroller of privatization: **
**rent-seeking and state capture**
Rent-seeking occurs when institutions allow the privatization of land rents and incremental value at the expense of the community. Oftentimes land speculators and land grabbers hold the state hostage, or succeed in planting its representatives within government agencies. The result: needy people are deprived of their livelihoods, common resources get enclosed and the land concentration process continues. This mechanism of appropriation works in favor of the elite. The privatization agenda can succeed only by overcoming the separation of governmental powers. It generally needs a strong executive power and strong centralized state that can prevail against the lower administrative levels.
Although governmental development organizations may not consciously support land appropriation by the elite, they at least tolerate it while the general population disapproves. Governmental development actors are behaving schizophrenically in this regard: On the one hand they promote and demand "good governance," but on the other hand they are helping to issue a carte blanche for rent seeking (private property on land) that harms use of land as commons.
Increasingly, governmental development organizations see themselves as exporters of a product that might be called "private property titles in land." However, this product does not work well even in the western context, as seen in a long list of failures such as unused and underused sites, urban sprawl, and a systematic bias in the planning process in favor of influential investors (Löhr 2010). In western states, such extreme abuses of privatization are contained by a working separation of governmental powers and a constitutional state. This is not the case in many developing countries that have weak governance. In the end, governmental development organizations in fact are helping to eliminate customary rights in land and thereby destroy numerous land commons.
**One size fits all?**
The elite knows how to play the game. It has access to legal advice and personal connections to key governmental decision makers. In contrast, poorly educated rural people are defenseless when new land titles are suddenly claimed out of the blue. They do not understand what is going on until it is too late. With little understanding of formal legal procedures and no financial and political backing, they have barely any chance of successfully defending their traditional claims. However, law is based on mutual acknowledgement, without which there is no legitimacy.
The problem is a clash of norms. The formalized legal rights invoked by the elite are allowed to override the customary rights of the poor and marginalized to regulate their own commons. The abuse of law to sanction this power play is pushing many states into a state of de facto anarchy. Paradoxically, the resulting, new state of "de facto open access" is sometimes producing a gridlock of fragmented, overlapping property rights claims, a problem known as a "tragedy of anticommons" (Fitzpatrick 2006).4 (4. The tragedy of the anticommons is described by Michael Heller in Part 1.)
**Economic and social consequences**
It is of no surprise, then, that in many cases the results of privatization do not meet the stated expectations. Land is not allocated to the best users, but to speculators. Land often remains unused. "At best," land goes to agribusiness companies, i.e., to powerful and concentrated economic groups.
Ways of life and economic models with a low ability to pay are severely disadvantaged in this context. It means that the diversity of forms essential to a sound social and economic organism, is reduced. The disappearance of traditional ways of life and economic models often goes hand in hand with migration to big cities (and the rise of new slums) or to peripheral regions. Yet the influx of displaced people into peripheral regions, combined with a lack of effective access controls, only causes further degradation of natural resources that had been stable commons in the past. A telling example is the province of Pailin in Cambodia, where about 50 percent of the primary forest has been destroyed, and agricultural land gradually degraded, in recent years.
The central state bears responsibility for much of this harm. It grants most of the economic concessions, usually without consulting regional or local administrations. Oftentimes environment and social impact assessments are conducted inadequately or not carried out at all. The resulting overlapping land claims often lead to disputes, which concessionaires do not even try to solve by negotiating agreements with the people affected. Instead, they simply contact the central government, which has allotted the concession to them, because they expect that the government will "resolve" such conflicts in their favor, using police or armed forces if necessary. The people who lose their livelihoods then join the queue of landless migrants.
**Toward a paradigm shift in development policy 5 **(5. Charlotte Hess also makes observations for a new paradigm for development aid, referring generally to natural resource systems.)
Considering the disastrous impacts of the privatization agenda in many countries, the proponents of the agenda have become more cautious. This has not led to a reconsideration of the privatization paradigm in general, however, but rather to ad hoc modifications of how it is administered on a case-by-case basis.
When challenging the privatization paradigm, several principles are essential:
1. _Neutral planning should provide space for a diversity of lifestyles and economic models._ This refers in particular to social and institutional forms that have a low ability to pay. Such forms are of inestimable importance for social cohesion and ecological functionality, and to enhancing a coexistence of formalized law and customary rights. A diversity of lifestyles and economic models might be supported, for instance, by allocating collective land titles to communities where customary rights are in place. Any legal relationships to outsiders to such communities, however, should be based on formalized law.
2. _The state should be as free from special interests as possible, in order to guarantee neutral planning and to provide scope for forms beyond the capitalist exploitation logic. _The collusion of private special interests with governmental institutions should be criminalized – something that is not always the case even with the western development "blueprints."
3. _Fighting rent seeking also means skimming off land rent and incremental value as far as possible in favor of the community (de-capitalization of land)._ This could be executed by an intelligently designed leasing or land taxation framework. It is clear that this requirement is difficult to enforce in countries where political decision makers are closely connected to owners of large estates and developers.
4. _In addition, state policymaking should be reflect the principles of subsidiarity. Lower administrative levels, e.g., within the land allocation process, should be granted greater powers_.6 Of course, the decentralization of power is the opposite of what influential political decision makers generally want. (6. Markelova and Esther Mwangi discuss subsidiarity and multilevel governance earlier in Part 5.)
If community interests in shared natural resources are to survive, a new development agenda will need to be advanced, and it will need to sail against the wind. It is time to adjust the compass.
**References**
Demsetz, H. 1967. "Toward a Theory of Property Rights." _The American Economic Review_ (57)2: 347–359.
Feder, G. and D. Feeny. 1991. "Land Tenure and Property Rights: Theory and Implications for Development Policy." _The World Bank Economic Review,_ (5)1: 135–153.
Fitzpatrick, D. 2006. "Evolution and Chaos in Property Rights Systems: The Third World Tragedy of Contested Access." _The Yale Law Journal_. __ (115)996–1048.
Löhr, D. 2010. "The Driving Forces of Land Conversion – Towards a Financial Framework for Better Land Use Policy." _Land Tenure Journal_ (FAO). June: 61–89.
Platteau, J.P. 1996. "The Evolutionary Theory of Land Rights as Applied to Sub-Saharan Africa: A Critical assessment." _Development and Change_ (27)29–86.
**Dirk Löhr** _(Germany) is an economist and professor at the Environment Campus Birkenfeld. His research focus is property rights and land. Löhr works as a consultant in development cooperation agencies. For many years he has been Chairman of the Social Science Association (Sozialwissenschaftliche Gesellschaft 1950 e.V.). _
# The Yasuní ITT Initiative, or The Complex Construction of Utopia
_By Alberto Acosta_
__
_"The reasonable man adapts himself to the world; the unreasonable one persists in trying to adapt the world to himself. Therefore, all progress depends on the unreasonable man."_
– George Bernard Shaw
Breaking myths will always be a complex task. So-called realism thwarts change. Whoever enjoys privileges that could be affected by such changes puts up resistance. That is why the idea to leave the oil in the Amazon region in the ground was criticized from the beginning. We knew that it would be difficult to cut a swath through the national and international oil interests and that people would do everything they could to weaken the innovative potential of this revolutionary approach.
Indeed, doubts have been raised ever since the Yasuní-ITT initiative was put on the agenda. (ITT is the abbreviation of the oil fields Ishpingo, Tambococha and Tiputini.) People were baffled by the proposal not to drill for the 850 million barrels of heavy oil in the Yasuní National Park provided there would be an internationally financed compensation payment. Leaving 20 percent of a country's oil reserves untouched seemed completely crazy in an economy addicted to oil. But as crazy as the idea seemed, it attracted support and grew stronger.
The Yasuní ITT initiative has four key goals: 1) To preserve biodiversity unique to the planet – the Yasuní National Park is home to the greatest biodiversity per square kilometer registered by scientists to date, with as many species of trees and shrubs as in all of North America; 2) To protect the land and the lives of the indigenous peoples who live in voluntary isolation (the Tagaeri, the Taromenane and presumably also the Oñamenane); 3) To protect the climate in the interest of all of humanity; and 4) To take a first step toward a post-fossil-fuel era in Ecuador.
And the fifth goal, one might assume, could be the possibility that we – as humanity – may find concrete and institutional solutions to the global problems that are resulting from climate change.
The feasibility studies that assessed the potential of this proposal – in comparison to producing the oil – came to encouraging conclusions. Even if one were to set aside the enormous ecological and social consequences of oil production, the option of leaving the oil in the ground would be more attractive than extracting it. In addition, this option would open up a scenario that would benefit everyone – Ecuador as well as the international community.
**A proposal born of resistance**
The initiative to abandon oil production was not inspired by any particular individual. It has no "owner," but was developed step by step in civil society. People who had suffered from the devastations caused by oil production in the Amazon region developed the proposal even before Rafael Correa became a candidate for President of Ecuador in 2006. Yet the fact that Correa accepted the initiative and the government then supported it was decisive. Correa took on the responsibility for turning the idea not to develop the ITT oil fields into actual policy.
At the turn of the millennium, resistance increased in the communities of the Amazon region and turned into a legal dispute of international significance. The so-called "trial of the century" litigated by the indigenous communities and those communities affected by Chevron-Texaco's oil production became widely known.1 The resistance of the Sarayaku Kichwa community in Pastaza province succeeded in preventing drilling by the Compañía General de Combustibles (CGC) in Block 23, even though the company was backed by the state and its armed forces. This community, which could rely on active international solidarity, obtained a pioneering decision by the Inter-American Commission on Human Rights in July 2004. The Commission argued for numerous measures benefiting the Sarayaku. In 2007, the Ecuadorian government finally accepted the resolution of the Inter-American Commission on Human Rights. (1. Editors' note: Legal proceedings against the oil company began in 1993, first against Texaco, then against Chevron after it had acquired Texaco. US courts said they had "no jurisdiction." Then, proceedings continued in Ecuador. Indigenous women sued the corporation for discharging into the Amazon region's rivers fluids tainted with crude oil and lead from oil production during its operations in Ecuador between 1971 and 1991. According to the plaintiffs, these effluents and numerous pipeline leaks resulted in people developing illnesses. The court handed down its decision in February 2011: The corporation was liable for the consequences of Texaco's oil production and must pay 6 billion euros in damages. Chevron assumed that the verdict would not be enforceable in the US. But an appeals court in New York ruled in September 2011 that the company would have to pay the fine. At the editorial deadline for this book, it was not known whether Chevron would appeal that decision.)
Supported by the categorical opposition of the people affected, a moratorium on extracting oil in the south-central Ecuadorian Amazon region gradually developed. Already formulated in various forums, the demand was taken up in the book _El Ecuador Post-Petrolero_ ( _Post-Petroleum Ecuador_ ) in 2000 (Acosta 2000). The following year, a group concerned with foreign debt discussed whether this proposal might bring with it the opportunity of a historic agreement with international creditors. Ecuador could suspend payments on foreign loans and preserve the Amazon in exchange. All the demands were compiled, and this formed the basis for developing the proposal not to exploit the Yasuní oil as part of a broader oil moratorium. The idea was finally laid out in a position paper by Oil Watch2 in June 2005, and was forcefully brought into the national political debate. The Yasuní ITT initiative was included in the government program 2007-2011 of the Movimiento País (today: Alianza País)3 that was prepared during Rafael Correa's 2006 presidential campaign. (2. note: Oil Watch is an international network that observes and analyzes the effects of oil production, especially on tropical ecosystems. 3. Movimiento PAÍS (also known as Acuerdo PAÍS; PAÍS is the abbreviation of Patria Altiva y Soberana, or "Honest and Sovereign Fatherland") is a political movement and party in Ecuador that encompasses eight political organizations, including the Alianza PAÍS founded by Rafael Correa. It had an absolute majority (approximately 70 percent of the vote) in Ecuador's constitutional assembly in 2007/08 as well as in the new parliament up until the elections in 2009. Rafael Correa, Vice President Lenín Moreno and the author of this contribution are members of its leadership.)
**The character of a revolutionary initiative**
Yasuní ITT would prevent 410 million tons of CO2 emissions. In return, Ecuador expects a financial contribution from the international community. Individual countries, especially the more prosperous societies, can take on their part of the responsibility, depending on their share of the environmental destruction for which they are responsible on this planet.
The initiative proposes that all peoples of the world change their relationship to nature profoundly by contributing to the establishment of a new global legal institution according to the principles of global environmental justice and joint responsibility for the global commons. This institution would not represent the interests of particular nations or private interests; instead, it would be a custodian for what is owned jointly by all of humanity: the atmosphere and biological diversity. This goes far beyond the logic of international cooperation, considered to be "development aid."
**Audacity: a difficult course**
This proposal has taken a convoluted path since becoming a topic of official political discussions. There were steps forward and back, successes and contradictions, approval and controversies. What is interesting, and actually surprising, is that this idea has taken root even though some people considered it extremely far-fetched. Briefly after its official launch, the encouraging voices soon multiplied, more so abroad than in Ecuador. The opportunity that something previously unthinkable would emerge came to the fore in the societal debate, in parliaments and in some governments.
Germany's early support must be mentioned here. Representatives of all parliamentary groups expressed their support for the ITT initiative in June 2008, and asked the German government for support. That is why the rejection of the proposal made by Dirk Niebel, the German Minister for Economic Cooperation and Development, in September 2010,4 was a slap in the face. Niebel's rebuff German reduced the chances for more support, as many potential contributors had taken Germany's solid commitment for granted. The decision apparently reflected a small-minded mentality, not one of a statesman with a broad vision. (4. Editors' note: Dirk Niebel (FDP), the German Federal Minister for Economic Cooperation and Development from 2007 to 2012, fears that the Yasuní ITT initiative might become a "negative precedent" (!). When the Budget Committee convened for its final meeting on this issue in November 2011, he justified his disapproval in the form of a personal letter in the ministry's newsletter. "Good intentions don't necessarily mean that something will work well." Niebel argued that Yasuní ITT would not work well, and that other policy tools are required: "It rewards refraining from producing oil, instead of actively protecting the forest or the indigenous population, for example.")
Things were difficult in Ecuador as well. The proposal formulated by the then-Minister for Energy and Mining5 at the beginning of Correa's presidency collided with the desire of Petroecuador's CEO to produce the oil as quickly as possible. The CEO even signed agreements with foreign companies behind the minister's back – and the minister was a member of Petroecuador's board. The confrontation was settled after President Correa intervened; on March 31, 2007, in an unusual procedure, he heard the various arguments presented by Petroecuador's board. On that day, the option to leave the oil in the ground was mentioned in very concrete terms as the first option, _provided_ that the international community would contribute at least half the monies that would be generated in the event of exploitation. Option B – exploiting the oil – was sketched out in case that initiative were to fail. Since then, the conflict between the two options has been simmering with different degrees of intensity. (5. Editors' note: This refers to the author, Alberto Acosta.)
Later, the initiative's prospects veered back and forth between great hope and growing doubts. President Correa was applauded at the United Nations, OPEC, the World Social Forum and numerous international summits when he presented this way of protecting the Amazon and preventing major negative impacts on the global environment. But it was the same president who made it all too clear that it was a yes-or-no situation – in other words, that the oil would be exploited if there were no international financing. A scent of blackmail was in the air, and it fueled doubts.
In 2010, the Ecuadorian government defined how the revenues raised by the model would be spent. The funds would be controlled by the UN6 and be spent on the transformation of the Ecuadorian energy supply model by developing the potential of alternative energy sources; reforestation and care of protected areas; sustainable social development, especially in the Amazon regions; and finally, investments in technological research. (6. The Yasuní trust fund is managed by the United Nations Environment Programme (UNEP). The goal was for a body independent of national interests to be responsible for managing the fund. Both the government and civil society are represented in the fund's steering committee. The agreement was signed on August 3, 2010.)
A profound discussion in civil society quickly ensued, both domestically and internationally. Thanks to this debate, the original proposal, which used terms such as "compensation" and "international donations," was superseded by a different framing – joint contributions as the fundamental principle of global environmental justice. It became clear that one cannot be compensated for an obligation that one must perform in any case, namely global environmental protection. Debate about the Yasuní ITT initiative also made clear that there could be many financing options, and that emissions trading cannot solve all problems, as even the Ecuadorian delegation had assumed at times.
As the project made distinct progress, it also stimulated hostile responses. Even President Correa dealt it a serious blow. As the only head of government in the world who had an avant-garde proposal to combat global warming, he needlessly risked a confrontation at the United Nations climate summit in Copenhagen in December 2009. After signing the documents establishing the International Trust Fund, he changed his mind at the last minute. His declaration, which was also directed against potential contributors to the fund, shattered the Yasuní ITT negotiating delegation, and the foreign minister handed in his resignation. Again, there were suspicions that oil interests had played a very important role.
Paradoxically, many people in Ecuador found out about the initiative only through these declarations made by the president, and through the ensuing situation.
**The project at a turning point**
We need clear signals for the Yasuní ITT initiative to become a reality. We need coherent and consistent government action. It is up to President Correa to overcome the problems that he himself helped cause and to prove his renewed and strengthened support for the initiative. He should commit himself to the position that ITT will not be touched, at least as long as he is in office.7 The activities linked to oil exploration and exploitation at the edges of ITT should not be permitted, either. And the government could put a stop to other threats to the Yasuní (deforestation, illegal logging, settling, illegal tourism) and prohibit the road from Manta to Manaos as a part of IIRSA.8 It would also be important to explore whether Peru would be able to implement a similar procedure in neighboring oil fields. The areas are in direct proximity to ITT and hold only about one third as much oil as the reserves under Ecuadorian territory. Such an expansion of the initiative could ensure that a much larger area with similar mega-biodiversity would be protected. This area is also home to peoples who have had no contact to the outside world as yet. (7. Editors' note: In other words, at least until 2013; however, Correa can run for another four-term. 8. On The Initiative for the Integration of the Regional Infrastructure of South America, IIRSA, see also the conversation with Gustavo Soto Santiesteban in Part 3.)
Even though it is not yet a reality, Yasuní ITT has produced many satisfactory results. The topic with its many facets has been positioned in the national and international debates. And there are people in Ecuador who are using hard-hitting arguments to advocate for the position that it is appropriate to leave oil in the ground even without international financial involvement. This Option C could be implemented via strict adherence to the constitution. After all, oil production in this area could take place only upon application by the president of the republic, and only on the basis of a "declaration of national interest" by the national assembly, which can call a referendum if it considers it appropriate. Then, the Ecuadorian people would have the last word.
The true guarantor for the success of the Yasuní ITT initiative is dedication on the part of civil society in Ecuador and around the world. Only civil society can take up this project of life. Not extracting an amount of oil that humanity would use up in just nine days would provide a new way of viewing humankind's encounter with nature. It would break open the narrow horizon of selfish, short-term perspectives and encourage similar initiatives around the world. We need two, three, many Yasunís!
**References**
Acosta, Alberto. 2000. _El Ecuador Post-Petrolero_. Acción Ecológica.
**Editors' note:**
_Yasuní-ITT had started out with the goal of establishing a US$350 million fund. Over the next five years, the targets were adjusted downwards, and the cutoff date was postponed time and again. By now, Ecuador's strategy for contributions has taken an important turn. The goal is not only to obtain contributions from the international community, but also from the Ecuadorian people and from private companies as well as public institutions. In 2011, the campaign Yasunízate was initiated (roughly, "Yasunify yourself!"), and it tried out a large variety of fundraising methods – one dollar per person, campaigns in educational institutions and many others. By January 2012, governments had pledged about US$69 million to the fund and Germany promised US$47 million in bitlateral technical assistance. President Correa renewed his commitment to the project and is seeking US$291 million annually in contributions in 2012 and 2013, with an ultimate goal of raising US$3.6 billion over twelve years. For now, no drilling has occurred in the preserve. _
**Alberto Acosta** _(Ecuador) is an Ecuadorian economist, professor and researcher. He was Minister of Energy and Mines from January to June 2007, and President of the Constituent Assembly and Assemblyman, November 2007 to July 2008._
# Equitable Licensing – Ensuring Access to Innovation
_By Christine Godt, Christian Wagner-Ahlfs and Peter Tinnemann_
The results of publicly funded research need to be available for everybody – especially in the case of essential medicines. This basic concept relies on two principles: first, access to medical treatment and a healthy environment are human rights that should be available to everybody; and secondly, research in the field of medicine and environmental science is mainly publicly funded, which means that research should serve public needs and be available to the public. One attractive solution is a licensing model known as "Equitable Licensing," which aims to ensure access to essential medicines resulting from publicly funded research that are protected by patents. This model can help ensure that the social goals of publicly funded research are met under the conditions of modern, patent-based technology transfer.
Equitable Licensing, sometimes known as humanitarian licensing, was first used 2001 to provide AIDS-stricken patients in South Africa access to essential medicines (Stevens and Effort 2008). The concept empowers research institutions to pro-actively influence medical research and drug development, and thus responds to a major challenge of modern medicine in a globalized world: how to provide research and drugs for diseases that mainly concern people in low income countries (the so-called neglected diseases, e.g., malaria, tuberculosis, sleeping sickness). More significant is the fact that many medicines are available but only at the global market price, which is not affordable for most people; drug makers fear that tiered pricing will result in lower-priced drugs being imported back to high-priced markets, a problem known as "parallel imports."
**Equitable licensing and its history**
The term "Equitable Licensing" was first coined in 2001 by Yale Univers ity. The university had given an exclusive license to the pharmaceutical company Bristol-Myers Squibb (BMS) to use the patent on the HIV-medication d4T (Stavudine). d4T was initially discovered in the 1960s at the Detroit Institute of Cancer Research as a cancer therapy. In the 1980s, Tai-Shun Lin and William Prusoff at Yale University found the substance to be effective in treating HIV patients. Their research was funded by the US National Institutes of Health and BMS; Yale University filed for a patent for d4T in 1986, which was issued in 1990. Yale licensed the patent exclusively to Bristol-Myers Squibb, which finally put its proprietary version of d4T, Zerit®, on the market in 1994. As was common practice at that time, the medicine was marketed at a uniform price worldwide. In 2001, the daily dose per patient was available for nearly 12 euro, or about 4,369 euro per year (Schwabe and Paffrath 2002) – an unaffordable price for patients in Africa.
After the drug was put on the Essential Medicines List by the World Health Organization (WHO), Médecins Sans Frontières (MSF) found the price not sustainable for people with AIDS. In February 2001, MSF asked Yale University to waive the South African patent, but Yale rejected that request, citing the exclusive license to BMS. At this point, a group of Yale students intervened with public protests and William Prusoff wrote an opinion piece in the _New York Times._ Responding to public pressure, Yale asked BMS to grant "patent relief" and price cuts. BMS eventually agreed, signing an agreement with Aspen Pharmacare, a leading South African generic manufacturer in June 2001, that enabled local production of the AIDS drug. After the Indian drug manufacturer CIPLA introduced a generic version of the drug, the price of d4T dropped by 96 percent within a year. This allowed MSF to scale up HIV treatment programs across Africa.
A very similar agreement was reached for Tenofovir, the active substance of the AIDS drugs Viread® and Truvada®, which had been licensed to the pharmaceutical company Gilead by the Rega Institute for Medical Research at Catholic University Leuven and the Institute of Organic Chemistry and Biochemistry in Prague (Van Overwalle 2009).
This simple model of lowering the price by Equitable Licensing and competition has matured over the past decade with different types of "humanitarian licensing." One approach creates direct supply obligations for the licensee; another seeks to indirectly lower prices by asking patent holders not to assert patent rights in certain countries, which then enables the local production of cheaper generic drugs. Equitable Licensing has been institutionalized by programs like the "Socially Responsible IP Management Program" at the University of California, Berkeley, and private companies like Boehringer Ingelheim have implemented policies of not asserting patent rights. In 2009, the University of Edinburgh adopted an explicit policy statement that basically follows a "non-assert" approach for Least Developed Countries; the university "expects" its industry partners to "appreciate and cooperate" with this policy.1 (1. http://www.med4all.org/fileadmin/med/pdf/Edinburgh_Essential_Medicines_Position_Statement_2009.pdf )
An offspring of the Yale student initiative is the foundation of UAEM (Universities Allied for Essential Medicines), which now has various chapters worldwide. The group developed the first standard form of an Equitable License, and instigated the so-called Philadelphia Consensus Statement in 2006 in which university leaders acknowledge their institution's social responsibility in making essential medicines accessible.2 (2. http://www.essentialmedicine.org)
The term "Equitable Licenses" is broadly synonymous to "Humanitarian Use Licenses," "Equitable Access," "Global Access," and to some extent to "two-tiered pricing." It differs, however, from other forms of promoting access to medical innovations in five central aspects.
• Equitable Licenses build on contracts such as bilateral and multilateral consortia agreements. Therefore, they are distinct from unilateral governmental intervention such as compulsory licenses.3 (3. Compulsory licenses are rights to use given by the government to a competitor in case of a public emergency (art. 31 TRIPS).)
• The essence of the contract is the transfer of knowledge in one direction, encompassing both time-limited acquisition of rights and long term research collaborations. Thus Equitable Licenses are different from collective licensing models like clearinghouses,4 patent pools5 or information platforms.6 (4. Clearinghouses are institutions offering the service of exchanging and bundling licenses for a specific technology area, without the exclusivity and not bilateral as a patent pool (see Van Overwalle 2009). 5. The most famous AIDS patent pool is the one currently under construction by UNITAID. UNITAID was founded in 2006 by five countries with the mission to improve access to treatment for HIV/AIDS, malaria and tuberculosis. See http://www.medicinespatentpool.org 6. For example, the ChEMBL Neglected Tropical Disease website for compounds inhibiting malaria. Man Tsuey Tse. 2010. _Nature Reviews_ , Vol. 6.)
• The term "Equitable License" is confined to the transfer of knowledge from public research institution towards private industry. Thus, purely private agreements between competitors are not included.
• Purely unilateral private actions like the so-called "non-assert pledges" by industry are equally exempt. They are not "Equitable Licensing" as there is no involvement of a public research institution.
• Equitable Licenses have a clearly envisioned group of beneficiaries and so they are not geared to broadly fostering progress in a given sector. This stands in contrast to the new initiatives fostering "green technologies" (Hall and Helmers 2010).7 (7. Ibid.)
**Equitable Licensing and technology transfer**
Equitable Licensing builds on the modern concept of proprietary technology transfer from universities to industry, universally labeled as "post Bayh-Dole." That term refers to the US Bayh-Dole Act of 1980,8 which was the first of a series of laws enacted by the US Congress to allow university patents on results developed through publicly funded research. Before Bayh-Dole, patents deriving from publicly funded research belonged to the US government. This law laid the foundation for the boom of new startup companies, especially in biotech and information technology fields, by allowing them to exploit cutting-edge academic research. The law helped to reorient the sciences away from basic research and towards applied product development and new organizational forms of research between academia and industry (Cohen et al. 2002). This process has been copied internationally. (8. U.S.C. (United States Code) § 200-212, and implemented by 37 C.F.R. (Code of Federal Regulations) 40.)
The Bayh-Dole philosophy initiated a new understanding of basic research. Earlier, basic research was not seen as having a specific use in mind; since Bayh-Dole, basic research owes a return on investment to the consumer. The law's central mechanism is the patent mechanism, which enables early investment in new technology to reap later returns through a monopoly price. However, this financing mechanism does not function if consumer demand is not sufficient. In the case of neglected diseases, the pool of patients is either too small or not economically significant.
In these cases, public funding aims at remedying market failures. This is done either by funding research or by setting incentives for investments, e.g., a "priority voucher" for humanitarian uses, as set up by the US Patent and Trademark Office in 2010, or a priority voucher for the development of drugs that are relevant for developing countries, as issued by the US Food and Drug Administration in 2008. Another possibility is setting up state-owned research institutions, such as the new National Center for Advancing Translational Sciences (NCATS) set up under the roof of the US National Institutes of Health in December 2010.
Equitable Licensing complements these state interventions (in particular research funding) because it links publicly funded research to institutional and personal social responsibility, and transmits these responsibilities to an industrial partner who develops a product from early research. In other words, the licensing aims at both market failures that stem from insufficient demand, i.e., impoverished patients and at social obligations that are linked to taxpayer-funded research.
Until recently, the success of university technology transfer offices has been evaluated only in terms of numbers of business spin-offs, the amount of financial revenues from contracts, license fees and equity shares in companies. However, successful integration of Equitable Licensing into a technology transfer office´s portfolio seems to require a "just" remuneration of the time invested in projects with a high social value. Also, the widely used standard contracts require adaptation (Godt 2011). After all, negotiating extensive contracts that exert influence on the utilization of medicines is a time-consuming and ambitious process. On the other hand, research institutions need to understand that Equitable Licensing can enormously boost an institution's reputation.
This leads to two conclusions: A patent license must not be awarded to a commercial partner just because it is promising the best license fee. Second, the institution needs to be interested in owning and managing the patent for a long time. This requires that both the research institution and its industrial partner recognize their own benefits from Equitable Licensing and develop appropriate new criteria for rewarding this innovative form of technology management. Carol Mimura, technology manager of University of California, Berkeley, advocates noneconomic metrics that are not linked to any financial returns from a license, but rather reputational gains and medical costs saved (Mimura 2010). These social benefits can be quantified by econometric measures used in health economics like DALYs (Disease Adjusted Life Years) and QUALY (Quality Adjusted Life Years).9 Even if these concepts still need refinement by practice and experience, the important lesson is that universities recognize that financial returns are not the only measure of success. The basic principles need to be reflected in corresponding institutional policies to which the employees of the technology transfer office can refer to. (9. Both concepts are methods for quantification of life extension and life quality improvement that are used in medicine, sociology and economics. The DALY concept was first used 1993 in a world nutrition report by the World Bank. About the method, see Murray 1994.)
An important element of Equitable Licensing is the unique motivation of scientists. The example of the drug Miltefosin shows that it is the insistence of researchers who might also oppose institutional, economic driven decisions that contributes to breakthroughs in the development of essential drugs (Wagner-Ahlfs et al. 2010). The case study also shows that individual dedication to research is more important than either patent or product development policy. In this constellation, Equitable Licensing can transfer the scientist's activism for drug utilization into long-term contract commitments.
**Equitable Licenses – a pragmatic approach to the commons**
Equitable licensing is a pragmatic concept in that it builds on both proprietary research and publicly funded research. It accepts the modern reality that public research results are often patented, and does not demand a public research commons. What matters in Equitable Licensing is that medicines are made available to those in need. Since the patented medications are developed only because of public investments, public policy has an obligation to impose certain public responsibilities on the owners of research results. Equitable Licensing does not rely upon only one standard contract to achieve this goal, however. It can be realized with different standards of performance. Universities can select a "Gold," "Silver" or "Bronze" standard, for example, a modular concept of licensing developed by Christine Godt and Tina Marschall (2010). The publicly available guidelines translate the aimed level into concrete license modules.
Equitable licensing brings three innovations: First, it uses specific contractual commitments to improve the availability of medications developed with public funds. Second, it coordinates the work of many more actors and allows researchers themselves to decide how the fruits of their research will be put on the market, guided by a university's formal policies. Third, the public interest is not exclusively entrusted to governments (via compulsory licensing, for example); patent owners and nongovernmental organizations can play an active role. In this way, Equitable Licensing provides an important practical measure of shared benefit from publicly funded research.
**References**
Cohen, Wesley M., Richard R. Nelson and John P. Walsh. "Links and Impacts: The Influence of Public Research on Industrial R&D." _Management Science._ (48)1–23.
Godt, Christine. 2011. "Equitable Licenses in University-Industry Technology Transfer." GRUR Int. 377-385.
—————— (with support of Tina Marschall). 2010. "Equitable Licensing – Lizenzpolitik & Vertragsbausteine." http://med4all.org.
Hall, Bronwyn H. and Christian Helmers. 2010. "Innovation in Clean/Green Technology: Can Patent Commons Help? Discussion paper for the EPIP annual meeting in Maastricht." Netherlands, September 20-22, 2010.
Murray, Christopher J.L. 1994. "Quantifying the Burden of Disease: The Technical Basis for Disability-Adjusted Life Years." _Bulletin World Health Organization._ 72(3):429-445.
Mimura, Carol. 2010. "Nuanced Management of IP Rights: Shaping Industry-University Relationships to Promote Social Impact," In Dreyfuss, Rochelle C., Harry First and Diane L. Zimmerman, eds., _Working within the Boundaries of Intellectual Property_. Oxford, UK. Oxford University Press. 293.
Stevens, Ashley and April E. Effort. 2008. "Using Academic License Agreements to Promote Global Social Responsibility." _Les Nouvelles – Journal of the Licensing Executives Society Int'l_. 85-101.
Van Overwalle, Geertrui. 2009. _Gene Patents and Collaborative Licensing Models_. University of Leuven, University of Tilburg. http://www.gilead.com.
—————— . 2010. "Designing Models to Clear Patent Thickets in Genetics." In Dreyfuss, Rochelle C., Harry First and Diane L. Zimmerman, eds. _Working within the Boundaries of Intellectual Property_. Oxford, UK. Oxford Unive rsity Press. 305-323.
Wagner-Ahlfs, Christian. 2009. "Gesundheitsforschung für wen? Die gesellschaftliche Verantwortung von Hochschulforschung." In _Forum Wissenschaft,_ 52-54.
—————— and Jennyfer Wolf. 2010. "Miltefosin – Eine Fallstudie, wie öffentliche Erfindungen für arme Länder verfügbar gemacht werden können." _Chemotherapie Journal_ , (19)3: 63-69.
**Christine Godt** _(Germany) is professor of law at Carl-von-Ossietzky University Oldenburg. She works in the area of European and international economic law and intellectual property rights._
**Christian Wagner-Ahlfs** _(Germany) is a chemist, campaigner and editor. His activities for BUKO Pharma-Kampagne focus on making essential and rational medicines available globally. The project www.med4all.org highlights the responsibility of publicly funded research: "Medical Research: Science in the Public Interest."_
**Peter Tinnemann** _(Germany) holds a doctorate in medicine and lectures on and researches global health at the Institut for Social Medicine, Epidemiology and Health Economics of the Charité Universitätsmedizin Berlin. His main research interests are access to medicines, social equality and social medicine. He is a member of MSF and IPPNW._
# P2P-Urbanism: Backed by Evidence
_By Nikos A. Salingaros and Federico Mena-Quintero_
After decades of central planning that ignored local conditions and the complex needs of final users, and then tried to do away with the commons for monetary reasons, people have forgotten the principal geometrical, human-scaled patterns that generated our most successful urban spaces throughout history. There _has_ been an important loss of the shared knowledge that once let people build humane environments without much in the way of formal planning.
The general form of urbanism implemented during the 20th century and the beginning of our own 21st century was large-scale, centrally planned development. Different methods of design came into vogue during this time, each explicitly trying to avoid traditional building forms and techniques that have been used for hundreds, if not thousands of years. This was done just for the sake of "not doing the same that we did in the past." The most prominent "moral leaders" of architecture and urbanism have been the "starchitects": widely known designers whose buildings have notorious visual characteristics, and which are heavily marketed for the sake of novelty alone.
Beyond the architecture of buildings, post-World War II planners implemented formalist ideas regarding the "city as a machine," setting a legal foundation in urban codes that guaranteed the modernist transformation of cities. Mass industrialization during the 20th century led to car-centric development, making it impractical to walk from one place to another. Money-oriented development produced building forms whose disadvantages have been widely discussed: skyscrapers with plenty of sellable floor space but whose form destroys the urban fabric, cookie-cutter housing that does not really fit anyone's needs, office parks that are not close to where the workers actually live.
The New Urbanist movement began as a human-scaled alternative to modernist city planning, which was based upon distances, spaces and speeds that cater to machines and the needs of industry. Among other things, New Urbanism promotes walkable communities where people can live, work and socialize without being totally dependent on cars. It also promotes non-rigid zoning that allows a mixture of work, industry and housing, all done with well-proportioned buildings that borrow heavily from traditional forms and techniques. In Europe a similar movement is known simply as "traditional urbanism." Both groups of urban practitioners share a willingness to involve the community in the planning of their neighborhoods – in contrast to centrally-planned development that creates large complexes of buildings with little to no input from the final dwellers or users.
Nevertheless, New/Traditional Urbanism is still centrally planned and done on a large scale, instead of allowing the initiative for design and construction to be taken by the final users themselves. This is an accident of the times, since existing practices for how construction is financed tend to favor large-scale development. A bias towards top-down implementation is also due to the very pragmatic wish of New Urbanists to "plug into" the existing system rather than to start everything from scratch. New Urbanists have tried to promote decentralized development with the publication of the Duany-Plater-Zyberk (DPZ) planning and zoning document, _Smart Code_ , for free on the Internet in 2003.1 _Smart Code_ is a repository of measurements and detailed design guidelines for generating a human-scale city, very different from the Modernist urban codes now imposed by law. (1. http://www.transect.org/codes.html)
There is evidence that people in numerous places in the world want to end the domination of Modernist thinking in urban planning. Political movements in Europe have finally stepped in to play an active role in urban renewal. Monstrous tower blocks have been demolished, replaced by human-scaled urban fabric designed by local groups. And we have such examples occurring all over the world, each seeking a sharp break from the power base and mindset that still clings to a top-down bureaucratic (and authoritarian) worldview. In many places, however, the law has been used to classify inhuman buildings as "monuments" and thus to indefinitely prolong the symbols so beloved by professional architects and planners.
**The combination of peer-to-peer and urbanism**
That is precisely where the recent P2P-Urbanism comes into play. The P2P-Urbanism movement is drawing in urban designers and planners who have been working independently for years. People who join P2P-Urbanism represent a heterogeneous group consisting of individuals championing collaborative design and user participation in planning: New Urbanists tied to the commercial US movement building neotraditional urban fabric; followers of the father of pattern theory and architect Christopher Alexander, author of _A Pattern Language_ ;2 urban activists; and others. Gradually, practitioners in other fields bring in their knowledge where appropriate. These include permaculturists (who design productive ecosystems that let humans live in harmony with plants and animals) with a deep practical understanding of biophilia; advocates of vernacular and low-energy construction; and various independent or resilient3 communities that wish to sustain themselves "from the ground up." (2. See essay by Franz Nahrada in Part 1. 3. See Rob Hopkins' essay on resilience in Part 1.)
P2P-Urbanism is all about letting people design and build their own environments, using information and techniques that are shared freely. In parallel to the free/open source software movement, designing a city and one's own dwelling and working environment should be based upon freely available design rules rather than some "secret" code decided upon by an appointed authority. Furthermore, open source urban code must be open to modification and adaptation to local conditions and individual needs, which is the whole point of opensource. For example, the DPZ "Smart Code" not only allows but _requires_ calibration to local conditions, and for this reason, in our view, it pertains to P2P-Urbanism despite the corporate parentage of many New Urbanist projects.
One implication of this new way of thinking about the city is to encourage reclaiming common urban space. A significant phenomenon in 20th century urbanism has been the deliberate elimination of shared public space. The open space surrounding standalone Modernist buildings tends to be amorphous and hostile, and therefore useless for common purposes. Attractive public space was recreated in privately controlled spaces within commercial centers. In this way, common space that is essential for citizen interactions (and thus for generating shared societal values) has been privatized, re-packaged and then sold back to the people. P2P-Urbanism reverses this tendency.
**Participation schemes for urbanism and architecture**
Centrally planned environments are often designed strictly "on paper" and subsequently built to that specification, without any room for adaptation or for input from the final users. The worst examples are the results of speculative or megalomaniac building with no adaptive purpose in mind, like Brasília and Pruitt-Igoe (Saint Louis). A top-down way of thinking and urban implementation determines accessibility to public housing and facilities built by government, and has fixed the division of power in the urban arena. However, there has always been a small corps of P2P thinkers and urbanists/planners promoting participatory events outside the official planning system. Those interventions have tended to be temporary rather than permanent, however, because of the difficulty of implementing changes in the built fabric.
Successful urban design has everything to do with real quality of life and sustainability. People's instinctive preferences can be driven either by biophilia (a preference for organic, natural environments) or fashion (with sometimes disastrous consequences). With the Modernist or post-Modernist architectural _status quo_ , the main consideration for construction has been the visual impact of the finished product. P2P-Urbanism, by contrast, is as concerned about the process of planning as with the final, adaptive, human-scale outcome. It represents a set of qualities and goals that go far beyond architecture and urban design. The principles of good urbanism and architecture may be widely shareable and acceptable by "everyday people," but they are not entirely obvious. For example, it takes careful explaining to convince people that a pedestrian network can be woven into car-centric cities, and that rather than making traffic chaotic, this will in fact reduce traffic, which is something that everyone would appreciate. In terms of evolutionary design, a step-by-step design process that takes account of real-time constraints and human needs leads to the desired final result, something impossible to achieve from a pre-conceived design.
An architect familiar with the needs of a certain region may know, for example, that an 80-centimeter eave is enough to protect three-meter tall stories from rainfall in a particular region with a certain average of wind and rain. A builder well-versed in the actual craft of construction, however, knows that to build _this_ kind of eave, with the traditional forms used in this region, requires such and such materials and techniques. The final dweller of a house will be interested in protecting windows and walls from rainfall, and may want to have a say in what kind of window to build: if he wants it to open to the outside, then it must not bump against the wide eave. Thus it is important to _establish communication_ between users, builders, designers and everyone who is involved with a particular environment.
Our hypothetical rainy region will doubtless have other problems that people in similar regions of the world have encountered. P2P-Urbanism lets these geographically separated people connect together to learn from each other's experiences. Trial-and-error can be reduced by being able to ask, "Who knows how to build windows and eaves that will stand this kind of rainfall?" – and to get an answer backed by evidence.
Bigger problems can be attacked in a similar way. Instead of abstract, philosophical-sounding talk like "the shape of the city must reflect the spirit of the age," and "windows must be designed to mimic a curtain wall" (why?), we can look for evidence of cities that are humane and livable. We can then adapt their good ideas to local conditions, drawing upon the knowledge of all the people who participate in the P2P-Urbanism community.
Construction firms that embrace P2P-Urbanism may end up being well-liked in the communities where they work, for they will actually be in constant communication with the users of their "products." They won't just be doing hit-and-run construction that is not loved or cared for by anyone. Up to now, residents have not been able to make any changes on "signature" architecture projects, nor alter the unattractive housing blocks they happen to reside in for economic reasons. P2P-Urbanism instead advocates that people be allowed to modify their environment to suit their needs, and not be forced to rely exclusively on a designer who does not even live there.
P2P-Urbanism is like an informally scientific way of building: take someone's published knowledge, improve it, and publish it again so that other people can do the same. Evidence-based design relies upon a growing stock of scientific experiments that document and interpret the positive or negative effects that the built environment has on human psychology and well-being.
A central feature of New Urbanist projects is a pre-project "charette" that involves user input in a one- or two-day presentation open to public participation. Although sometimes applied in only a superficial manner, a charette process in the best cases is not just an opinion poll; it is also a nondogmatic educational process, a dialogue among stakeholders leading to a final agreement. The result reaches a higher level of understanding compared to where the individual participants started from.
**Consequences for marginalized people **
Some proponents of the movement view P2P-Urbanism as a way to give power to marginalized people to help them create the environment in which they live. This is true, but it is not the whole story. A P2P process will have to somehow channel and amalgamate pure individualist, spontaneous preferences and cravings within a practical common goal. There is a vast distinction between good and bad urban form: only the first type encourages sociocultural relations to flourish; bad urban form leads, among other things, to neighbors who never even interact with each other.
Marginalized people or minorities will find tremendous power in being able to build their own environments inexpensively, and in knowing that they are building something good. There are precedents for this approach in the various ecovillages in Mexico that do their own construction, with local materials, and where everything is hand-built. We can expect consequences similar to what has happened with the use of free/open-source software in Third-World nations: local expertise is formed, a local economy follows and the whole country is enriched by being able to take care of its own problems. We want to facilitate integration of people now separated by differences of social status, using the built environment to help accomplish that.
Thus, P2P-Urbanism provides the key to successfully integrating large-scale planning with informal self-built settlements. Large-scale planning acting with local adaptation is best capable of providing the necessary infrastructure for a healthy city; yet informal, self-built settlements (which are usually illegal) are growing uncontrolled in the developing world.
**Potential detractors of P2P-Urbanism**
P2P-Urbanism is meant to transfer power and knowledge from established architectural practice to common people. This may not be in line with the short-term monetary interests of the current power holders. Developing countries who start doing their own design and construction could save an enormous amount of money by refusing to commission signature architects to design their cities.
We cannot overemphasize that P2P-Urbanism is a radical departure from the generic industrial style known as the "International Style" widely adopted in the 20th century, to one that is essentially a local, shareable knowledge base about adaptive design and building. The former approach to building promotes centralized heavy industry at the expense of local construction groups and community self-help; it ignores local adaptation and traditional techniques, and dismisses P2P-Urbanism as a practical alternative.
Nevertheless, since P2P itself is founded upon sharing and collaboration via the Internet, it can finally bypass the severe existing informational roadblocks (as established by architecture magazines, for instance) through techniques developed for information and software sharing. More than being just a set of ideas, P2P-Urbanism depends critically upon a universal means of free dissemination and transmission, and ties into educational and informational channels that bypass those controlled by the champions of the global consumerist society. The important point, which delimits the private/business focus of the New Urbanists and the commons-oriented alternative approach of the P2P activists, is the commonality of design methods: opensource rules for human-centered architecture and urban design that are freely accessible to all.
Despite a lot of self-serving propaganda, the threat from nonadaptive and energy-wasting urban forms and typologies is just as strong today as it was immediately after World War II. In that period, historic city centers were gutted and people were forced into prison-like high-rises, following a psychotic planning vision of "geometrical fundamentalism" (an ideology that aims to impose simple geometrical solids such as cubes, pyramids, and rectangular slabs on the built environment). This event more than anything else defined urban alienation. Fashionable architectural and urban projects, i.e., those that win commissions and prizes, completely avoid or destroy human-scale urbanism by imposing giant forms built in an extremely expensive, high-tech style. Such outrageously costly projects are routinely celebrated by centralized power without any genuine citizen participation.
Movements like "Landscape Urbanism" have even tried to redress the current practice with the addition of beautiful "green space," which unfortunately only serves to mask the fundamentally anti-nature qualities of those high-tech buildings, as betrayed by their geometry. The surrounding gardens are wonderful and the buildings blend very nicely with the gardens in magazine renderings and pictures, but the actual buildings follow the same anti-urban industrial shapes. Moreover, by inserting huge but inaccessible wild gardens in the middle of cities, the common urban space that people can actually use is in fact severely restricted.
Realigning urbanism to involve the real city dwellers has profound socio-political implications. Not only may fundamental societal changes eventually drive a revision in thinking about world urbanism, the built environment may drive fundamental societal changes. In any case, the physical outcome for the city, which is a picture of the harmonious, partially pedestrian and humanized community, must be the product of a deep sociocultural process. Otherwise it is a fake.
**Nikos A. Salingaros** _(USA) is Professor of Mathematics, University of Texas at San Antonio, and a pioneer of P2P Urbanism. He is the author of 120 scientific papers and seven books, including _Principles of Urban Structure _and_ A Theory of Architecture.
**Federico Mena-Quintero** _(Mexico) is a software developer and Co-Founder of the Gnome project, a widely used free software project to create a graphical environment for computers. He is also part of the Free Workshops for Arts and Technologies, a Mexican project to develop free technology around permaculture and local production of goods._
# Epilogue
_Everything seems stuck in a quagmire, yet a new future is emerging._
BANGKOK, AUGUST 25, 2011. It's hot and humid in the city. The air conditioner's low buzz is the background noise for the academics and activists who have gathered for the "Re-Thinking Property" conference in the auditorium of Chulalongkorn University. The mostly Asian participants are inspired by the idea of analyzing property from the perspective of the commons, which then unexpectedly becomes a focus of the conference.
BERLIN, NOVEMBER 28, 2011. In Germany's capital, some of the country's most important climate researchers have convened even though the UN Climate Conference (COP 17) begins that very day in Durban, South Africa. At a press conference , they introduce the Mercator Research Institute on Global Commons and Climate Change __ to the public (see pp. 392). When asked about the practicability of the commons approach, Ottmar Edenhofer, the institute's director-designate, explains, "One cannot get concrete in a reasonable way if mistakes have already been made in the guiding concepts." This is exactly what has happened over the course of the previous decades, Edenhofer believes, and for that reason the new institute seeks to assess the significance of the commons as a guiding concept in future climate research.
PORTO ALEGRE, JANUARY 24, 2012. Oppressive heat weighs heavily on the city's downtown, whose streets are deserted; not a blade of grass is to be found. It is January, the summer break. About 100 people from various social movements and independent think tanks have been invited to the birthplace of the World Social Forum in southern Brazil to participate in a strategic dialogue as part of a Thematic Social Forum. They divide into 17 working groups to prepare for the Earth Summit in Rio de Janeiro – "Rio+20" – and to consider alternatives to both market-fundamentalist approaches and top-down "green economy" policies. One insight becomes clear – the guiding idea of more multilateral regulation for greater efficiency __ will not solve persistent conflicts over how to use common resources. "Efficiency" simply cannot grapple with actual power relationships and legal structures, let alone overcome the market/state duopoly's deep commitments to relentless growth. A new paradigm is needed, along with new forms of democracy and governance, most Porto Alegre activists agreed after a week of dialogue.
PARIS, JANUARY 26, 2012. The city is about to be hit by a cold snap. In a surprising move, French politician Kader Arif resigns from his position as rapporteur of the European Parliament for the Anti-Counterfeiting Trade Agreement (ACTA) ahead of schedule. He explains: "I would like to harshly denounce the entire process that has led to the signing of this Agreement.... The European Parliament was denied the right to express its opinion and to put the citizens' legitimate demands forward as arguments...." He adds, "I hereby warn the public about this unacceptable situation. I will not take part in this masquerade."1 Negotiations leading up to the Agreement, which aims to control how people can create and share music, video and information on the Internet and other digital technologies, were carefully kept under wraps, deliberately excluding citizens from participating. The public outcry against ACTA is therefore less surprising than the blunt candor of Kader Arif's words. Despite the bitter cold across Europe, there were numerous protests on the continent's streets opposing ACTA and its secretive, corporate dominated policymaking process. (1. the entire text of the declaration, see http://de.wikipedia.org/wiki/Kader_Arif)
CAPE TOWN, JANUARY 27, 2012. People from many places around the Cape walk the four kilometers from Athlon Stadium to Rondebosch Commons together. They want to occupy this place to discuss problems they face every day: housing, land use, evictions, police brutality and increasing segregation.2 A commons does not exist, they say, if it exists in name only. For this reason, their three-day gathering on Rondebosch Commons focuses on how to reclaim control. _Take back the commons_ is the name of the campaign.3 Its principles: "We are _communities._ We are all _leaders._ We include everyone. We are constructive. We must not only change the world, but ourselves. We demand our right to the Commons! We practice a culture of caring and sharing." That vision seems to be too extreme. The police intervene with a massive show of force and arrest 42 people.4 (2. Quoted by Christopher McMichael, http://www.mahala.co.za/reality/take-back-the-common 3. See http://mpbackyarders.org.za/2012/01/28/solidarity-we-invaded-rondebosch-common-but-only-the-police-destroyed-the-fynbos 4. See http://mg.co.za/article/2012-01-30-charges-against-occupy-rondebosch-protesters-withdrawn)
ROME, FEBRUARY 11, 2012. A blizzard has brought the Eternal City to a standstill. Covered with snow, it is as photogenic as ever. The audience is shivering at the Teatro Valle in its prime location between the Pantheon and the Piazza Navona. The theater staff has been occupying the Valle for eight months, seeking to reclaim _their_ Valle as a _bene comune_ (a commons), both in practical and institutional terms. Since its occupation, the Valle has not been a theater "where you simply go, buy a ticket and watch the show," says theater technician and occupier Valerio. He points out: "The real show takes place _before_ the show," when people exchange ideas, work together, and take part in workshops and conversations that permeate the lives of those involved. Irene, a photographer at the Valle, explains: "It could be very important today that we learn to understand that everything is ours. Including the problems!"
On the theater's stage this day, a gathering of international guests is considering an exciting question – how to systematically introduce principles of the commons in the European legal framework? Addressing this question are ACTA activists from Poland and Bulgaria, urban researchers from Spain, Italian professors of law, consultants to the European Commission, members of the German Pirate Party, and many others. They seek to initiate legislative proceedings at the European level, beginning in April 2012, to bring about a European Commons Charter. The Charter Campaign was started by, among others, scholars at the IUC (International University College), an institute of law at Turin University for graduate students from around the world. The IUC had already launched a 2011 water referendum in Italy in which an incredible 27 million people voted for "water as a commons," defeating privatization proposals. The link between current political movements and the idea of the commons debate is not always this obvious. That is why a video featuring voices from the Teatro Valle is entitled _Occupying the Commons,_ referring to both the traditional right of commoners to oppose enclosures and tear down fences, and to the Occupy Movement.
NEW YORK, FEBRUARY 16, 2012. More than 100 people assembled at the Ascension Church in Brooklyn for a three-day _Occupy Wall Street Forum on the Commons_. The event took place simultaneously online and offline, so that people in New York and everywhere else could participate at the same time. The Commons and Occupy movements share more than a basic commitment to understanding democracy itself as a commons; they both struggle to care for it and build it. Democracy ultimately only exists as a social practice, and must be constantly renewed. That was indeed the point of the New York forum as well as this book: we must actively coproduce the commons and find the ways to honor the principles of the commons. Developing appropriate governance systems that embody these principles will naturally advance the interests of the 99 percent.
AND ALL AROUND THE WORLD. In the months before this book went to press, there was a flurry of many other initiatives attempting to push the commons paradigm forward:
In Brussels, a Green Party foundation and two environmental think tanks, Oikos and Etopia, had to turn away people at the door for a major environmental conference on the commons.
In Geneva, the UN Institute for Training and Research (UNITAR) launched a four-module online course on the commons that attracted hundreds of participants from dozens of countries.
In San Francisco, Mayor Ed Wood formally launched The Sharing Economy Working Group to explore the economic and civic benefits of collaborative consumption and other forms of sharing.
In Naples, Italy, Mayor Luigi de Magistris convened municipal officials from throughout Italy to promote the protection of local commons. He also actively pushed an exploratory effort to win a Europe-wide vote for a European Directive on the Commons.
In London, The School of Commoning hosted a twelve-part seminar series, "The Emergence of the Commons-based Economy," and in Barcelona and Buenos Aries, other commoners began plans to start their own commons educational projects.
And so it goes.
To us, the evidence seems clear: people everywhere have a strong desire to escape the helplessness that institutions impose on them, overcome the cynicism that blots out optimism, and transcend the stalemates that stifle practical action. Another world is possible beyond market and state. This book chronicles some new ways forward – and the beginnings of an international commons movement.
_Silke Helfrich_
_David Bollier_
__
_May 1, 2012_
|
/**
* Called when the user press the 'add' button; this method adds a new depot
* to the controller ObservableList of depots
*/
@FXML
private void add() {
try {
if (memberTypeBox.getValue().equals(MemberType.Rider)
&& classBox.getSelectionModel().getSelectedItem() != null) {
contractManager.addContract(Integer.parseInt(yearBox.getSelectionModel().getSelectedItem()),
memberTypeBox.getSelectionModel().getSelectedItem(),
memberBox.getSelectionModel().getSelectedItem().getPersonalCode(),
teamBox.getSelectionModel().getSelectedItem().getName(),
classBox.getSelectionModel().getSelectedItem().getName());
} else if (memberTypeBox.getValue().equals(MemberType.Engineer)
|| memberTypeBox.getValue().equals(MemberType.Mechanic)) {
contractManager.addContract(Integer.parseInt(yearBox.getSelectionModel().getSelectedItem()),
memberTypeBox.getSelectionModel().getSelectedItem(),
memberBox.getSelectionModel().getSelectedItem().getPersonalCode(),
teamBox.getSelectionModel().getSelectedItem().getName());
} else {
System.out.println(memberTypeBox.getValue().equals(MemberType.Rider));
throw new IllegalArgumentException();
}
contractTable.setItems(contractManager.getContracts());
this.clear();
} catch (Exception e) {
e.printStackTrace();
alert.showWarning(e);
}
} |
<filename>include/effect_diffusion.hpp
#ifndef EFFECT_DIFFUSION_HPP_
#define EFFECT_DIFFUSION_HPP_
#include "effect_base.hpp"
#include "field.hpp"
#include "operations.hpp"
#include "OP_partial_derivative.hpp"
class effect_diffusion : public effect
{
public :
effect_diffusion(const double &eta);
void execute(const field_imag &in, field_imag &out) const;
private :
double viscosity;
};
#endif
|
<reponame>halarnold2000/learnhaskell
module Main where
import Lib
import Reverse
import WordNumber
import Cipher
import StdFunctions
main :: IO ()
main = print $ rvrs "Furry is Awesome"
|
<gh_stars>1-10
package dictionary;
import java.util.Set;
public interface ICollectiveDictionary {
public boolean containsEntry(DictionaryEntry entry);
public void build();
public boolean containsSurfaceForm(final String normalizedSurfaceForm);
public Set<Concept> getConceptsForNormalizedSurfaceForm(final String normalizedSurfaceForm);
public boolean normalizedSurfaceFormMatchesConcept(String normalizedSurfaceForm, Concept conceptID);
public boolean containsToken(String token);
public boolean noVowelsNormalizedSurfaceFormMatchesConcept(String noVowelsNormalizedSurfaceForm, Concept conceptID);
public boolean containsNoVowelsSurfaceForm(String noVowelsNormalizedSurfaceForm);
public Set<Concept> getConceptsForNoVowelsNormalizedSurfaceForm(String noVowelsNormalizedSurfaceForm);
public boolean sortedNormalizedSurfaceFormMatchesConcept(String sortedSurfaceForm, Concept conceptID);
public boolean containsSortedSurfaceForm(String sortedSurfaceForm);
public Set<Concept> getConceptsForSortedNormalizedSurfaceForm(String sortedSurfaceForm);
}
|
Socio-economic assessments of Hepatitis C Virus infection: Evidence from Vehari district of Pakistan
The present study corroborates the annual average economic burden of Hepatitis C virus (HCV) and socio-economic factors concerning awareness of HCV in Pakistan. The data of 100 patients collected via conducting interviews/questionnaire from different hospitals to gauge the direct/indirect pecuniary costs of HCV infection. Bottom up approach, Human capital approach and Tobit model were applied to compute the costs and determinants of HCV and its awareness. Results demonstrate that annual average economic burden was 1379.2734 USD. The knowledge/awareness status is vulnerable implying that most of the population has limited knowledge about HCV. Poverty and low levels of schooling years are amidst the main causes of low awareness vis-a-vis HCV and their cures, ceteris paribus. Income, education and test screening have positive impact on knowledge score of HCV. The fi ndings imply for promotion of awareness campaigns and development of diagnostic centers to increase the knowledge score and early diagnostic of HCV. Research Article Socio-economic assessments of Hepatitis C Virus infection: Evidence from Vehari district of Pakistan Dilshad Ahmed1, Muhammad Shakeel2*, Bilal Tariq1 and Tariq Mahmood1 1COMSATS University Islamabad, Vehari Campus, Pakistan 2Visiting Faculty at University of the Punjab and Independent Researcher, Lahore, Pakistan Received: 01 April, 2021 Accepted: 09 April, 2021 Published: 10 April, 2021 *Corresponding author: Muhammad Shakeel, PhD, Visiting Faculty at University of the Punjab and Independent Researcher, Lahore, Pakistan, Email:
Introduction
Hepatitis C is an ailment disturbing the functionality of human Liver developed vis-à-vis the Hepatitis C virus .
The HCV is considered responsible of causing both the kinds of Hepatitis namely acute Hepatitis and chronic Hepatitis.
Globally calculated 71 million people are infected from the chronic Hepatitis C disease. Almost 15-45% of long-sufferings impulsively eliminate the disease in 180 days after infection without getting any kind of care ; the remaining 60 to 80% of infection will lead to the chronic Hepatitis C virus. From these 60 to 80% chronic HCV patients almost 15 to 30% are prone to the dangerous Liver cirrhosis in subsequent 20 years.
Around 399,000 HCV infected patients give up the ghost in every 20 month . The deaths caused by the liver Cancer are 788,000. A big part of these deaths (more than half, 60%) done by long-term results of chronic Hepatitis B and C toxicities (WHO Cancer day, 2018).
The consequences of Hepatitis C are Worldwide including: the highly infected areas from Hepatitis C virus of Eastern Mediterranean and European areas, by the spread of Hepatitis of 2.3 percent and 1.5 percent respectively . Spread of this virus in other areas changes from 0.5 percent to 1.0 percent . The area maximum affected by Hepatitis C virus is Egypt. 22 . HBV and HCV illnesses have general wellbeing dangers to most unindustrialized states where medical facilities backgrounds do not have the suffi cient apparatus to cope with the higher probabilities of detoxifi cation . Furthermore, there is no vaccination to prevent Hepatitis C . Consequently, awareness and knowledge augmentation about HCV is one way and providing the apparatus for the treatment is another way to control this disease.
Various studies corroborated that people have somewhat inadequate/limited knowledge and awareness about Hepatitis B and C disease especially in underdeveloped regions including Pakistan . The numbers of HCV patients are bit higher in rural regions than metropolitan regions of Pakistan (Aziz, et al. 2011). This is somewhat wanting outcome concerning healthy and sustainable environment because 66% of residents live in rural areas in Pakistan (Shaikh, et al. 2005). Punjab is the highly populated province of Pakistan and around 50,000 people are infected from HCV in last six months (dawn paper, 19 December 2017).
Methodology and Data
The study has been conducted on the primary data collected from district Vehari, Punjab Pakistan. List of 500 HCV patients were obtained from DHQ hospital Vehari. Amid these, 100 patients were selected randomly to fi nd the economic burden of Hepatitis. 100 respondents were interviewed to fi nd the awareness status of Hepatitis in general population of the district. Questionnaire-Performa was employed to obtain the information. Bottom up approach is used to calculate the direct pecuniary cost and Human capital approach is employed to compute indirect pecuniary cost. The subsequent sub-sections elaborate the concerns of calculation in a precise manner.
Economic burden
Variables used in the calculation of economic burden are employed on the basis of the study, Sepehrimanesh and Safarpur
Indirect cost
Indirect cost is the combination of costs beard by patients and state other than medical cost. Indirect cost includes income loss due to sickness, income loss for the sake of care attainment and average care service provider wage. Equation 4 explains the indirect cost.
IC absence from work dueto sickness absence from work dueto care cost of care service giver IC is indirect cost. Absence from work is measured in terms of getting leaves from work due to sickness and for care in six months and multiply these leaves from per day income and then multiply it with two to get annual income loss due to sickness. Cost of care service provider is measured in terms of wage rate of service provider.
Awareness
The awareness variables used for this study are taken following the other study of impact of Hepatitis on agriculture productivity and awareness about disease in rural areas (Sardar,
Results and discussion
The present segment elaborates the empirical outputs of the analysis and has three sub-segments of the results demonstrating the economic burden, knowledge score and socio-economic determinants of HCV awareness in Vehari, Pakistan.
Annual average economic burden of Hepatitis C infection
Economic burden is measure in USD.
Descriptive statistics for Knowledge status of Hepatitis C infection
This paper analyzes the knowledge status of Hepatitis C infection in the rural and urban areas of the Vehari. The respondents interviewed were randomly selected. Respondents were: Professionals, Students, Medical staff, skilled workers, labor, farmers and housewives.
Econometric model analysis
Analyze the knowledge status by using software E-views version 9.0 and applying Tobit model as other study employed for awareness of Hepatitis C in Faisalabad . Table 3 shows the determinants of knowledge regarding Hepatitis C infection. The coeffi cient whose Z. Statistics is greater from 2 is taken as signifi cant as other study on awareness of Hepatitis C in Faisalabad follows this way as alluded to earlier. Age was found adversely related with the awareness and this fi nding endorsed the fi ndings of Sardar, et al. , Yaseen, et al. and Brouard, et al. . Specifi cally, coeffi cient value of the age was -1.251 and p value showed that this variable is statistically signifi cant at the 1% selected level of signifi cance. In the same way, years of schooling are positively related with awareness and coeffi cient value of the education is 0.010 and p-value indicates that education is statistically signifi cant impacting the awareness concerning the HCV. This implies that people with less knowledge are more vulnerable to the Hepatitis C infection. Earnings/Income is positively related with the knowledge and coeffi cient value of the income is 1.116 with signifi cant p-value showing impact of earnings is statistically signifi cant in spreading the awareness regarding HCV. Family size was recorded as head counts. It is found that number of family members is positively related with the knowledge score of Hepatitis C infection. The coeffi cient value of the family size is 0.035 and p-value shows that this variable is statistically signifi cant. So, as smaller the family size, family will be more vulnerable to the disease ceteris paribus.
These fi ndings are more similar to the results of the Sardar, et al. and Haq, et al. . The people living with Hepatitis C patients are positively related with the knowledge score of Hepatitis C infection, as the exposure to HCV during experience with them. The coeffi cient value of the respondent living with the Hepatitis C infection is found out to be 0.252 with p-showing that this variable has an impact which statistically signifi cant. It is found out that the screening test is positively related with the knowledge score of Hepatitis C infection. The coeffi cient value of the screening test is the 0.229 with p-value showing that screen testing's impact is statistically signifi cant. This implies that people opting for screening tests could have better knowledge about the Hepatitis C infection and their remedies per se.
Conclusion and suggestion
It has been corroborated that Pakistan is the World second biggest country prone to fatal diseases of Hepatitis C, after Egypt being the fi rst. The annual average economic burden has been gauged with a value of 1379.2734 USD in Pakistan by the study which is comparatively lower as the contemporary empirical evidence indicates that economic burden of Hepatitis C infection is 1625.50 USD in Iran ; among others. This economic burden has been observed and recorded in the Southern Punjab including the district Vehari as a sample of population. This average economic burden may be different from other regions of the country due to people social status such as income, education and distance from hospital among others, ceteris paribus .
Notwithstanding, this is still the huge economic burden for the country where GDP per capita income is 1443.6 USD (World Bank 2016). This also implies that on average it is unequivocal to shoulder the burden of HCV treatment easily by the average individual of the region selected with respect to income/ earnings. This is because means of attaining the entire list of necessities of life has to be fulfi lled with the average amount of income as alluded earlier and any individual infected from HCV may have diffi culties to cure the disease due to estimated high economic burden.
The fi nding of this study also corroborates that only 22% of the sampled population has complete knowledge about the Hepatitis C virus infection, the major part (86%) of these 22% were the medical staff including doctors. The knowledge/ awareness status is quite vulnerable implying that most of the population has limited knowledge about Hepatitis C in the region. Poverty and low levels of schooling/education are amidst the main causes of low awareness vis-a-vis HCV and their cures, ceteris paribus. Income, education and test screening have positive impact on knowledge score of HCV.
It has been corroborated that awareness about the disease and early diagnostic of the disease can inter alia help to reduce the economic burden of the disease. Pakistan has the best way to stop and eliminate the Hepatitis by creating awareness in the general population. Due to knowledge spillover effect, the permeated information on HCV and their remedies could be pervasive and easily available to the population.. Moreover, launching new campaigns about the knowledge of preventive measures for HCV is also imperative for general public especially to rural population's awareness. Building new set ups with proper functioning diagnostic center of Hepatitis C virus at local, district and provincial levels is pivotal for the prompt action against the HCV spread and for the appropriate treatment of infected patients. Last but not least, encouraging general public to go through HCV test on regular basis will help in the early diagnostic of HCV disease and therein will help in reducing the economic burden of Hepatitis C virus, ceteris paribus.
The extant issue of the study has been assessed with respect to the Southern region of Punjab and nonetheless could be further investigated with respect to other regions of the country. These kinds of analyses could be of much use in developing further insights concerning HCV and its control in Pakistan.
Informed consent
All authors are aware of the consequences/outcomes of the present work and agreed the submission to the journal. |
def top_cloud(request, num_tags=100):
top_tags = Tag.objects.not_blacklisted().order_by('-num_addons')[:num_tags]
return render(request, 'tags/top_cloud.html', {'top_tags': top_tags}) |
// Build creates a 'registry' object using the configuration stored in the builder.
func (b *RegistryBuilder) Build() (object *Registry, err error) {
object = new(Registry)
object.id = b.id
object.href = b.href
object.link = b.link
object.url = b.url
object.cloudAlias = b.cloudAlias
object.createdAt = b.createdAt
object.name = b.name
object.orgName = b.orgName
object.teamName = b.teamName
object.type_ = b.type_
object.updatedAt = b.updatedAt
return
} |
package runner
import (
"context"
)
// Runner has both `Run` and `Close` methods.
type Runner interface {
Run() error
Close() error
}
// Runnable contains three operations: BeforeRunning, Running, AfterRunning.
type Runnable interface {
// BeforeRunning, do some initialization.
BeforeRunning(exit <-chan struct{}) error
// Running blocks and starts some tasks.
Running(exit <-chan struct{}) error
// AfterRunning, do some cleaning.
AfterRunning() error
}
// RunnableWithContext is the context version of Runnable.
type RunnableWithContext interface {
// BeforeRunning, do some initialization.
BeforeRunning(ctx context.Context) error
// Running blocks and starts some tasks.
Running(ctx context.Context) error
// AfterRunning, do some cleaning.
AfterRunning() error
}
|
/*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You under the Apache License, Version 2.0
* (the "License"); you may not use this file except in compliance with
* the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
import Card from '@/components/card'
import { SearchOutlined } from '@vicons/antd'
import {
NButton,
NDataTable,
NIcon,
NInput,
NPagination,
NSpace
} from 'naive-ui'
import { defineComponent, onMounted, toRefs } from 'vue'
import { useI18n } from 'vue-i18n'
import { useTable } from './use-table'
import ImportModal from './components/import-modal'
import StartModal from './components/start-modal'
import TimingModal from './components/timing-modal'
import VersionModal from './components/version-modal'
import { useRouter, useRoute } from 'vue-router'
import type { Router } from 'vue-router'
import styles from './index.module.scss'
export default defineComponent({
name: 'WorkflowDefinitionList',
setup() {
const router: Router = useRouter()
const route = useRoute()
const projectCode = Number(route.params.projectCode)
const { variables, getTableData } = useTable()
const requestData = () => {
getTableData({
pageSize: variables.pageSize,
pageNo: variables.page,
searchVal: variables.searchVal
})
}
const handleUpdateList = () => {
requestData()
}
const handleSearch = () => {
variables.page = 1
requestData()
}
const handleChangePageSize = () => {
variables.page = 1
requestData()
}
const createDefinition = () => {
router.push({
path: `/projects/${projectCode}/workflow/definitions/create`
})
}
onMounted(() => {
requestData()
})
return {
requestData,
handleSearch,
handleUpdateList,
createDefinition,
handleChangePageSize,
...toRefs(variables)
}
},
render() {
const { t } = useI18n()
return (
<div class={styles.content}>
<Card class={styles.card}>
<div class={styles.header}>
<NSpace>
<NButton type='primary' onClick={this.createDefinition}>
{t('project.workflow.create_workflow')}
</NButton>
<NButton strong secondary onClick={() => (this.showRef = true)}>
{t('project.workflow.import_workflow')}
</NButton>
</NSpace>
<div class={styles.right}>
<div class={styles.search}>
<div class={styles.list}>
<NButton type='primary' onClick={this.handleSearch}>
<NIcon>
<SearchOutlined />
</NIcon>
</NButton>
</div>
<div class={styles.list}>
<NInput
placeholder={t('resource.function.enter_keyword_tips')}
v-model={[this.searchVal, 'value']}
/>
</div>
</div>
</div>
</div>
</Card>
<Card title={t('project.workflow.workflow_definition')}>
<NDataTable
columns={this.columns}
data={this.tableData}
striped
size={'small'}
class={styles.table}
/>
<div class={styles.pagination}>
<NPagination
v-model:page={this.page}
v-model:page-size={this.pageSize}
page-count={this.totalPage}
show-size-picker
page-sizes={[10, 30, 50]}
show-quick-jumper
onUpdatePage={this.requestData}
onUpdatePageSize={this.handleChangePageSize}
/>
</div>
</Card>
<ImportModal
v-model:show={this.showRef}
onUpdateList={this.handleUpdateList}
/>
<StartModal
v-model:row={this.row}
v-model:show={this.startShowRef}
onUpdateList={this.handleUpdateList}
/>
<TimingModal
v-model:row={this.row}
v-model:show={this.timingShowRef}
onUpdateList={this.handleUpdateList}
/>
<VersionModal
v-model:row={this.row}
v-model:show={this.versionShowRef}
onUpdateList={this.handleUpdateList}
/>
</div>
)
}
})
|
/**
* {@link Region} meta-model.
*
* @author Denis
*/
@StaticMetamodel(Region.class)
public final class Region_ {
public static volatile SingularAttribute<Region, Long> id;
public static volatile SingularAttribute<Region, String> number;
public static volatile SingularAttribute<Region, String> label;
public static volatile SingularAttribute<Region, Date> creationDate;
public static volatile SingularAttribute<Region, String> creationUser;
public static volatile SingularAttribute<Region, Date> updateDate;
public static volatile SingularAttribute<Region, String> updateUser;
private Region_() {
// Only provides static constants.
}
} |
use network::{Node, Connection, Path, Status};
use std::collections::{HashMap, VecDeque};
use uuid::Uuid;
use graphsearch;
pub struct Weight(f32);
#[derive(Debug)]
pub struct Network
{
pub nodes: HashMap<Uuid, Node>,
pub edges: Vec<Edge>,
}
pub struct Entry<'a>
{
uuid: Uuid,
network: &'a mut Network,
}
impl<'a> Entry<'a>
{
pub fn remove(self) -> Node {
self.network.edges = self.network.edges.iter().cloned().filter(|edge| {
!edge.connected_to(&self.uuid)
}).collect();
self.network.nodes.remove(&self.uuid).unwrap()
}
pub fn get(&self) -> &Node {
self.network.nodes.get(&self.uuid).unwrap()
}
pub fn get_mut(&mut self) -> &mut Node {
self.network.nodes.get_mut(&self.uuid).unwrap()
}
}
/// An edge betweeb two nodes.
///
/// Node `a` is always the smaller UUID, and node `b` is
/// always the bigger one.
#[derive(Clone, Debug, PartialEq)]
pub struct Edge
{
pub a: Uuid,
pub b: Uuid,
}
impl Edge
{
pub fn new(node1: Uuid, node2: Uuid) -> Edge {
let mut sorted = [node1, node2];
sorted.sort();
Edge {
a: sorted[0],
b: sorted[1],
}
}
pub fn connected_to(&self, uuid: &Uuid) -> bool {
[&self.a, &self.b].iter().any(|adjacent| &uuid == adjacent)
}
pub fn other_node(&self, uuid: &Uuid) -> Option<&Uuid> {
vec![&self.a, &self.b].into_iter().filter(|a| a != &uuid).next()
}
}
impl Network
{
pub fn empty() -> Self {
Network {
nodes: HashMap::new(),
edges: Vec::new(),
}
}
pub fn new(your_uuid: Uuid) -> Self {
let mut network = Network::empty();
network.insert(Node {
uuid: your_uuid,
connection: None,
status: Status::Local,
});
network
}
pub fn insert(&mut self, node: Node) {
self.nodes.insert(node.uuid.clone(), node);
}
pub fn get(&self, uuid: &Uuid) -> Option<&Node> {
self.nodes.get(uuid)
}
pub fn get_mut(&mut self, uuid: &Uuid) -> Option<&mut Node> {
self.nodes.get_mut(uuid)
}
pub fn node_count(&self) -> usize {
self.nodes.len()
}
pub fn lookup_token_mut(&mut self, token: ::mio::Token) -> Option<&mut Node> {
self.nodes.values_mut().find(|node| node.connection.as_ref().map_or(false, |c| c.token == token))
}
pub fn entry_by_token(&mut self, token: ::mio::Token) -> Option<Entry> {
let uuid = self.nodes.values().find(|node| node.connection.as_ref().map_or(false, |c| c.token == token)).map(|n| n.uuid.clone());
if let Some(uuid) = uuid {
Some(Entry { uuid: uuid, network: self })
} else {
None
}
}
pub fn nodes<'a>(&'a self) -> impl Iterator<Item=&'a Node> {
self.nodes.values()
}
pub fn connect(&mut self, a: &Uuid, b: &Uuid) {
let edge = Edge::new(a.clone(), b.clone());
if self.edges.iter().find(|&e| e == &edge).is_none() {
self.edges.push(edge);
}
}
pub fn siblings(&self, node: &Uuid) -> Vec<&Uuid> {
self.edges.iter().filter_map(|edge| {
if edge.connected_to(node) {
Some(edge.other_node(node).unwrap())
} else {
None
}
}).collect()
}
pub fn set_connection(&mut self, uuid: &Uuid, connection: Connection) {
self.nodes.get_mut(uuid).unwrap().connection = Some(connection);
}
pub fn route(&self, from: &Uuid, to: &Uuid) -> Path {
Path::new(self.shortest_path(from, to))
}
pub fn build_graph(&self) -> graphsearch::Graph<Uuid> {
let raw_graph: Vec<_> = self.nodes.values().map(|node| {
graphsearch::Node {
content: node.uuid.clone(),
adjacent: self.siblings(&node.uuid).into_iter().map(|&sibling| {
let sibling_idx = self.nodes.values().position(|n| n.uuid == sibling).unwrap();
graphsearch::Vertex { cost: 1, node: sibling_idx }
}).collect(),
}
}).collect();
graphsearch::Graph::new(raw_graph)
}
pub fn shortest_path(&self, from: &Uuid, to: &Uuid) -> VecDeque<Uuid> {
println!("route from {} to {}", from, to);
let graph = self.build_graph();
let from_idx = self.nodes.values().position(|node| &node.uuid == from).unwrap();
graph.search(from_idx, to.clone()).expect("no route exists").into_iter().map(|idx| {
self.nodes.values().nth(idx).unwrap().uuid
}).rev().collect()
}
}
|
def loadDatabase(report_selector, remove_cols = {"FIPS", "Country_Region", "Last_Update", "Lat", "Long_", "UID", "ISO3"}):
report_name = None
sel = report_selector.upper()
if sel == "US":
report_name = "daily_reports_us"
elif sel == "WORLD":
report_name = "daily_reports"
else:
print("Report selector must be either \"US\" or \"WORLD\"")
return None
base_dir = "./COVID-19/csse_covid_19_data/csse_covid_19_%s" % report_name
if not (os.path.exists(base_dir) and os.path.isdir(base_dir)):
print("Could not find a database directory. Did you load the CSSE COVID-19 submodule?")
return None
base_fname = base_dir + "/%s.csv"
db_fname = searchForFile(base_fname)
if db_fname == None:
return None
print("Report file %s" % db_fname)
rep = pd.read_csv(db_fname)
orig_cols = set(list(rep))
actual_remove_cols = list(orig_cols.intersection(remove_cols))
return rep.drop(columns = actual_remove_cols) |
import java.io.*;
import java.util.*;
public class EDU_47_D {
static final int TEST_CASES = 2;
public static void main(String[] args) {
//test(TEST_CASES);
Scanner sc = new Scanner(new BufferedReader(new
InputStreamReader(System.in)));
solve(sc);
sc.close();
}
static void test(int T) {
for (int i = 0; i < T; ++i) {
System.out.println(String.format("*****Case #%d*****", i));
try {
Scanner sc = new Scanner(new FileReader(String.format("EDU_43/%d.in", i)));
solve(sc);
sc.close();
} catch (FileNotFoundException e) {
e.printStackTrace();
}
}
}
static void solve(Scanner sc) {
// n > 150 : always true
// n < 150 : brute force test
int n = sc.nextInt();
int m = sc.nextInt();
// Can't be connected
if(n-1 > m) {
System.out.println("Impossible");
}
else if(n > 1000) {
System.out.println("Possible");
outer: for(int i = 1; i <= n; ++i) {
for(int j = i+1; j <= n; ++j) {
if(m == 0)
break outer;
if(gcd(j,i) == 1) {
System.out.println(i + " " + j);
--m;
}
}
}
} else {
long count = 0;
for(int i = 1; i <= n; ++i) {
for(int j = i+1; j <= n; ++j) {
if(gcd(j,i) == 1)
++count;
}
}
if(count >= m) {
System.out.println("Possible");
outer: for(int i = 1; i <= n; ++i) {
for(int j = i+1; j <= n; ++j) {
if(m == 0)
break outer;
if(gcd(j,i) == 1) {
System.out.println(i + " " + j);
--m;
}
}
}
} else {
System.out.println("Impossible");
}
}
}
static int gcd(int a, int b) {
if(b == 0)
return a;
return gcd(b,a%b);
}
}
|
/**
* Update the next job to submit if one is ready.
* @param sendSignal true if signal is to be sent, false otherwise.
*/
private void updateNextJob(final boolean sendSignal) {
final JPPFJob job = nextJobRef.get();
final int size = job.getJobTasks().size();
final long batchTimeout = getBatchTimeout();
final int batchSize = getBatchSize();
if (batchTimeout > 0L) elapsed = (System.nanoTime() - start) / 1_000_000L;
if (size == 0) {
if ((batchTimeout > 0L) && (elapsed >= batchTimeout)) resetTimeout();
return;
}
if (((batchTimeout > 0L) && (elapsed >= batchTimeout)) ||
((batchSize > 0) && (size >= batchSize)) ||
((batchSize <= 0) && (batchTimeout <= 0L))) {
if (debugEnabled) log.debug("preparing job {} for submission, batchTimeout={}, elapsed={}, batchSize={}, size={}", job.getName(), batchTimeout, elapsed, batchSize, size);
currentJobRef.set(job);
nextJobRef.set(createJob());
resetTimeout();
if (sendSignal) {
jobReady.signal();
try {
submittingJob.await();
} catch (final InterruptedException e) {
throw new RejectedExecutionException(e);
}
}
}
} |
def is_url(path):
scheme = urllib.parse.urlparse(path).scheme
return scheme and len(scheme) != 1 |
package ch.uzh.ifi.hase.soprafs21.controller;
import ch.uzh.ifi.hase.soprafs21.entity.Screenshot;
import ch.uzh.ifi.hase.soprafs21.entity.User;
import ch.uzh.ifi.hase.soprafs21.rest.dto.*;
import ch.uzh.ifi.hase.soprafs21.rest.mapper.DTOMapper;
import ch.uzh.ifi.hase.soprafs21.entity.Picture;
import ch.uzh.ifi.hase.soprafs21.service.GameService;
import org.springframework.http.HttpStatus;
import org.springframework.web.bind.annotation.*;
import java.nio.file.Path;
import java.util.*;
/**
* GameController is used to manage incoming REST request coming from the client
* that are related to the gameplay itself
*/
@RestController
public class GameController {
private final GameService gameService;
GameController(GameService gameService) {
this.gameService = gameService;
}
/**
* call the gameService for initailizing the game Round
* @param lobbyId
* @return
*/
@GetMapping("/board/{lobbyId}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public List<UserGetDTO> initGame(@PathVariable String lobbyId) {
List<User> usersList = gameService.initGame(lobbyId);
List<UserGetDTO> initializedUsersDTOs = new ArrayList<>();
// convert each user to the API representation
for (User user : usersList) {
initializedUsersDTOs.add(DTOMapper.INSTANCE.convertEntityToUserGetDTO(user));
}
return initializedUsersDTOs;
}
@GetMapping("/game/checkUsersDoneGuessing/{lobbyId}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public boolean checkUsersDoneGuessing(@PathVariable String lobbyId){
// returns true if all user's are done guessing
return gameService.checkUsersDoneGuessing(lobbyId);
}
/**
* used to reset temporary fields such as pictures for the grid
* @param lobbyId
*/
@PutMapping("/board/{lobbyId}")
@ResponseStatus(HttpStatus.NO_CONTENT)
public void setupNextRound(@PathVariable String lobbyId){
gameService.prepareNewRound(lobbyId);
}
@GetMapping("/screenshots/{lobbyId}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public ArrayList<ArrayList<String>> getScreenshots(@PathVariable String lobbyId) {
ArrayList<ArrayList<String>> response = gameService.getUsersScreenshots(lobbyId);
return response;
}
@PutMapping("/screenshot/{username}")
@ResponseStatus(HttpStatus.NO_CONTENT)
public void saveScreenshots(@RequestBody String screenshotURL, @PathVariable String username) {
gameService.saveScreenshotURL(screenshotURL, username);
}
/**
* @return Return a List of Screenshots for the guessing screen
*/
@GetMapping("/screenshot/{lobbyID}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public List<ScreenshotGetDTO> showScreenshots(@PathVariable String lobbyID) {
List<Screenshot> screenshots = gameService.getScreenshots(lobbyID);
List<ScreenshotGetDTO> screenshotGetDTOs = new ArrayList<>();
for (Screenshot shot : screenshots) {
screenshotGetDTOs.add(DTOMapper.INSTANCE.convertEntityToScreenshotGetDTO(shot));
}
return screenshotGetDTOs;
}
@PostMapping("/guesses/{lobbyid}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public String submitGuesses(@RequestBody UserPostDTO userPostDTO, @PathVariable String lobbyid) {
User user = DTOMapper.INSTANCE.convertUserPostDTOtoEntity(userPostDTO);
return gameService.handleGuesses(lobbyid, user);
}
@GetMapping("/score/{lobbyId}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public ArrayList<ArrayList<String>> returnScore(@PathVariable String lobbyId) {
return gameService.returnScore(lobbyId);
}
/**
* Used to send a List of picture Elements to frontend
* Pictures are already mapped to a coordinate.
*/
@GetMapping("/pictures/{lobbyId}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public List<PicturesGetDTO> getPictures(@PathVariable String lobbyId) {
Picture[] pictures = gameService.getListOfPictures(lobbyId); // is changed to take from gameplay Entity
List<PicturesGetDTO> picturesGetDTOs = new ArrayList();
for (Picture picture : pictures) {
picturesGetDTOs.add(DTOMapper.INSTANCE.convertEntityToPicturesGetDTO(picture));
}
return picturesGetDTOs;
}
/**
* gets the picture corresponding to the correct user id
*/
@GetMapping("/picture/{id}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public PicturesGetDTO getCorrespondingPicture(@PathVariable String id) {
Picture correspondingPicture = gameService.getCorrespondingToUser(Long.valueOf(id));
PicturesGetDTO pictureResult = DTOMapper.INSTANCE.convertEntityToPicturesGetDTO(correspondingPicture);
return pictureResult;
}
/**
* used to return the current Round of a game
* @param lobbyId
* @return gamePlayGetDTO containing the current round
*/
@GetMapping("/rounds/{lobbyId}")
@ResponseStatus(HttpStatus.OK)
@ResponseBody
public GamePlayGetDTO getCurrentRound(@PathVariable String lobbyId){
GamePlayGetDTO gamePlayGetDTO = DTOMapper.INSTANCE.convertEntityToGamePlayGetDTO(gameService.getGamePlay(lobbyId));
return gamePlayGetDTO;
}
/**
* will be used in the client to reset the counters for round handling
* (use a later Component, rather than MainBoard in Fe)
*/
@PutMapping("/rounds/{lobbyId}")
@ResponseStatus(HttpStatus.NO_CONTENT)
public void resetCounterForNextRound(@PathVariable String lobbyId){
gameService.resetCounterForRoundHandling(lobbyId);
}
/**
* is used to have the user exit form a lobby if he leaves the game.
* @param lobbyId
* @param userId
*/
@DeleteMapping("/players/{lobbyId}/{userId}")
@ResponseStatus(HttpStatus.NO_CONTENT)
@ResponseBody
public void exitGame(@PathVariable String lobbyId,@PathVariable String userId){
gameService.removeUserFromLobby(lobbyId, Long.parseLong(userId));
}
/**
* is used to remove game and lobby for all after a user left the game
* @param lobbyId
*/
@DeleteMapping("/games/{lobbyId}")
@ResponseStatus(HttpStatus.NO_CONTENT)
public void deleteGameAndLobby(@PathVariable String lobbyId){
gameService.removeGameAndLobby(lobbyId);
}
}
|
import React from 'react';
import ReactDOM from 'react-dom';
import './index.scss';
import App from '@app/App';
import reportWebVitals from '@app/reportWebVitals';
import {Provider} from 'react-redux';
import {toast} from 'react-toastify';
import store from '@store';
import {library} from '@fortawesome/fontawesome-svg-core';
import {fas} from '@fortawesome/free-solid-svg-icons';
import {fab} from '@fortawesome/free-brands-svg-icons';
import {far} from '@fortawesome/free-regular-svg-icons';
library.add(fab, fas, far);
toast.configure({
autoClose: 3000,
draggable: false,
position: 'top-right',
hideProgressBar: false,
newestOnTop: true,
closeOnClick: true,
rtl: false,
pauseOnHover: true
});
ReactDOM.render(
<React.StrictMode>
<Provider store={store}>
<App />
</Provider>
</React.StrictMode>,
document.getElementById('root')
);
// If you want to start measuring performance in your app, pass a function
// to log results (for example: reportWebVitals(console.log))
// or send to an analytics endpoint. Learn more: https://bit.ly/CRA-vitals
reportWebVitals();
|
from pathlib import Path
class NAME:
ARTICLES = "articles"
CONTENTS = "contents.lr"
DRAFT = "__draft__"
class PATH:
HERE: Path = Path(__file__).parent
PROJECT: Path = HERE.parent
OUTPUT: Path = PROJECT.parent / "build"
DRAFTS: Path = PROJECT / "drafts"
CONTENT: Path = PROJECT / "content"
ARTICLES: Path = CONTENT / "articles"
class URL:
WEBSITE = "https://oliver.bestwalter.de"
WEBSITE_ARTICLES = f"{WEBSITE}/{NAME.ARTICLES}"
class _GH_REPO:
URL = "https://github.com/obestwalter/obestwalter.github.io"
CONTENT = f"{URL}/tree/lektor-sources/content"
ISSUES = f"{URL}/issues?q=is%3Aissue+is%3Aopen+sort%3Aupdated-desc"
LICENSE = f"{CONTENT}/LICENSE"
class _GL_REPO:
URL = "https://gitlab.com/obestwalter/tmp_website_private"
SOURCE = f"{URL}/tree/lektor-sources"
CONTENT = f"{SOURCE}/content"
ISSUES = f"{URL}/issues"
LICENSE = f"{CONTENT}/LICENSE"
REPO = _GH_REPO
class LEBUT:
REPO = REPO
URL = URL
|
/*
* Copyright (c) Baidu Inc. All rights reserved.
*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You under the Apache License, Version 2.0
* (the "License"); you may not use this file except in compliance with
* the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package com.baidu.brcc.service.impl;
import static org.mockito.Mockito.any;
import static org.mockito.Mockito.anyVararg;
import static org.mockito.Mockito.when;
import java.util.Arrays;
import java.util.Calendar;
import java.util.GregorianCalendar;
import java.util.HashMap;
import org.junit.Before;
import org.junit.Test;
import org.mockito.InjectMocks;
import org.mockito.Mock;
import org.mockito.MockitoAnnotations;
import org.slf4j.Logger;
import org.springframework.scheduling.concurrent.ThreadPoolTaskExecutor;
import com.baidu.brcc.dao.ConfigChangeLogMapper;
import com.baidu.brcc.dao.base.BaseMapper;
import com.baidu.brcc.dao.base.CommonMapper;
import com.baidu.brcc.domain.ConfigChangeLogExample;
import com.baidu.brcc.domain.ConfigChangeLogWithBLOBs;
import com.baidu.brcc.domain.ConfigGroup;
import com.baidu.brcc.service.ConfigGroupService;
public class ConfigChangeLogServiceImplTest {
@Mock
Logger LOGGER;
@Mock
ThreadPoolTaskExecutor executor;
@Mock
ConfigChangeLogMapper configChangeLogMapper;
@Mock
ConfigGroupService configGroupService;
@Mock
CommonMapper commonMapper;
@InjectMocks
ConfigChangeLogServiceImpl configChangeLogServiceImpl;
@Before
public void setUp() {
MockitoAnnotations.initMocks(this);
}
@Test
public void testGetMapper() throws Exception {
BaseMapper<ConfigChangeLogWithBLOBs, Long, ConfigChangeLogExample> result =
configChangeLogServiceImpl.getMapper();
}
@Test
public void testNewExample() throws Exception {
ConfigChangeLogExample result = configChangeLogServiceImpl.newExample();
}
@Test
public void testNewIdInExample() throws Exception {
ConfigChangeLogExample result = configChangeLogServiceImpl.newIdInExample(Arrays.<Long>asList(Long.valueOf(1)));
}
@Test
public void testSaveLogWithBackground() throws Exception {
when(configGroupService.selectByPrimaryKey(any(), anyVararg())).thenReturn(new ConfigGroup());
configChangeLogServiceImpl
.saveLogWithBackground(Long.valueOf(1), "operator", Long.valueOf(1), new HashMap<String, String>() {{
put("String", "String");
}}, new HashMap<String, String>() {{
put("String", "String");
}}, new GregorianCalendar(2021, Calendar.MARCH, 10, 14, 45).getTime());
}
@Test
public void testStop() throws Exception {
configChangeLogServiceImpl.stop();
}
@Test
public void testCountByExample() throws Exception {
when(configChangeLogMapper.countByExample(any())).thenReturn(0L);
long result = configChangeLogServiceImpl.countByExample(null);
}
@Test
public void testDeleteByPrimaryKey() throws Exception {
when(configChangeLogMapper.deleteByPrimaryKey(any())).thenReturn(0);
int result = configChangeLogServiceImpl.deleteByPrimaryKey(Long.valueOf(1));
}
@Test
public void testDeleteByExample() throws Exception {
when(configChangeLogMapper.deleteByExample(any())).thenReturn(0);
int result = configChangeLogServiceImpl.deleteByExample(null);
}
@Test
public void testInsert() throws Exception {
when(configChangeLogMapper.insert(any())).thenReturn(0);
int result = configChangeLogServiceImpl.insert(new ConfigChangeLogWithBLOBs());
}
@Test
public void testInsertSelective() throws Exception {
when(configChangeLogMapper.insertSelective(any())).thenReturn(0);
int result = configChangeLogServiceImpl.insertSelective(new ConfigChangeLogWithBLOBs());
}
@Test
public void testUpdateByPrimaryKeySelective() throws Exception {
when(configChangeLogMapper.updateByPrimaryKeySelective(any())).thenReturn(0);
int result = configChangeLogServiceImpl.updateByPrimaryKeySelective(new ConfigChangeLogWithBLOBs());
}
@Test
public void testUpdateByPrimaryKey() throws Exception {
when(configChangeLogMapper.updateByPrimaryKey(any())).thenReturn(0);
int result = configChangeLogServiceImpl.updateByPrimaryKey(new ConfigChangeLogWithBLOBs());
}
@Test
public void testUpdateByExampleSelective() throws Exception {
when(configChangeLogMapper.updateByExampleSelective(any(), any())).thenReturn(0);
int result = configChangeLogServiceImpl.updateByExampleSelective(new ConfigChangeLogWithBLOBs(), null);
}
}
|
module BoardSpec where
import Board (advanceBoard, readBoard, writeBoard)
import Data.Either (fromLeft, fromRight)
import Data.Text (pack)
import Test.Hspec
import Types (Color (..))
{- HLINT ignore "Redundant do" -}
spec :: Spec
spec = do
describe "writeBoard and readBoard" $ do
it "serialize properly" $ do
let boardStr =
"rnbqkbnr\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\RNBQKBNR"
let deserializedBoard = fromRight [] $ readBoard $ pack boardStr
writeBoard deserializedBoard `shouldBe` boardStr
describe "advanceBoard" $ do
it "accepts valid castling (black short)" $ do
let board =
fromRight [] $
readBoard $
pack
"rnbqkbnr\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\RNBQK..R"
let advancedBoard = fromRight [] $ advanceBoard board Black ((5, 8), (7, 8))
writeBoard advancedBoard
`shouldBe` "rnbqkbnr\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\RNBQ.SL."
it "accepts valid castling (black long)" $ do
let board =
fromRight [] $
readBoard $
pack
"rnbqkbnr\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\R...KBNR"
let advancedBoard = fromRight [] $ advanceBoard board Black ((5, 8), (3, 8))
writeBoard advancedBoard
`shouldBe` "rnbqkbnr\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\..LS.BNR"
it "accepts valid castling (white short)" $ do
let board =
fromRight [] $
readBoard $
pack
"rnbqk..r\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\RNBQKBNR"
let advancedBoard = fromRight [] $ advanceBoard board White ((5, 1), (7, 1))
writeBoard advancedBoard
`shouldBe` "rnbq.sl.\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\RNBQKBNR"
it "accepts valid castling (white long)" $ do
let board =
fromRight [] $
readBoard $
pack
"r...kbnr\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\RNBQKBNR"
let advancedBoard = fromRight [] $ advanceBoard board White ((5, 1), (3, 1))
writeBoard advancedBoard
`shouldBe` "..ls.bnr\
\pppppppp\
\........\
\........\
\........\
\........\
\PPPPPPPP\
\RNBQKBNR"
it "accepts en passant" $ do
let board =
fromRight [] $
readBoard $
pack
"rnbqkbnr\
\ppppppp.\
\........\
\........\
\......Op\
\........\
\PPPPPP.P\
\RNBQKBNR"
let advancedBoard = fromRight [] $ advanceBoard board White ((8, 5), (7, 6))
writeBoard advancedBoard
`shouldBe` "rnbqkbnr\
\ppppppp.\
\........\
\........\
\........\
\......p.\
\PPPPPP.P\
\RNBQKBNR"
it "rejects invalid en passant" $ do
let board =
fromRight [] $
readBoard $
pack
"rnbqkbnr\
\ppppppp.\
\........\
\........\
\......Pp\
\........\
\PPPPPP.P\
\RNBQKBNR"
let errorMessage = fromLeft [] $ advanceBoard board White ((8, 5), (7, 6))
errorMessage `shouldBe` "ERROR: Invalid move: Normal ((8,5),(7,6))"
|
Lamborghini, known for its super luxury sports cars is bringing something to India that it started manufacturing before its famous sports cars.
Lamborghini-known to be associated with the rich and famous is now targeting affluent farmers, golf courses, cricket grounds, vine yards & luxury resorts as it unveils its tractors in India. The launch is scheduled for December 12 at the largest agricultural exhibition 'KISAN' to be held in Pune.
Lamborghini tractors have a history older than its cars. It was launched way back in the mid 1950s and in 1973 got acquired by the SDF Group. The group has been manufacturing Lamborghini tractors at its facility in Ranipet, Tamil Nadu, but has so far only exported them.
SDF Group had gained ownership of the Lamborghini brand of tractors after acquiring Trattori Lamborghini, founded by Ferruccio Lamborghini -- creator of the Lamborghini cars.
"We are thrilled to launch this beautiful Lamborghini tractor in India. Highly popular abroad, Lamborghini has won the hearts of many across the globe and I am confident the same story will be repeated here," Bhanu Sharma, managing director and CEO, SDF India said.
The prices are yet to be disclosed by the company.
The sports car business of Lamborghini is under Automobili Lamborghini SpA, which is owned by the Volkswagen Group. |
<filename>flame_test.go
// Copyright 2021 Flamego. All rights reserved.
// Use of this source code is governed by a MIT-style
// license that can be found in the LICENSE file.
package flamego
import (
"bytes"
"net/http"
"net/http/httptest"
"os"
"testing"
"time"
"github.com/stretchr/testify/assert"
)
func TestClassic(t *testing.T) {
_ = Classic() // For the sake of code coverage
}
// Make sure Run doesn't blow up
func TestFlame_Run(t *testing.T) {
_ = os.Setenv("FLAMEGO_ADDR", "0.0.0.0:4001")
f := NewWithLogger(&bytes.Buffer{})
go f.Run(4002)
time.Sleep(1 * time.Second)
f.Stop()
}
func TestFlame_Before(t *testing.T) {
f := New()
var buf bytes.Buffer
f.Before(func(http.ResponseWriter, *http.Request) bool {
buf.WriteString("foo")
return false
})
f.Before(func(http.ResponseWriter, *http.Request) bool {
buf.WriteString("bar")
return true
})
f.Get("/", func() {
buf.WriteString("boom")
})
resp := httptest.NewRecorder()
req, err := http.NewRequest(http.MethodGet, "/", nil)
assert.Nil(t, err)
f.ServeHTTP(resp, req)
assert.Equal(t, "foobar", buf.String())
}
func TestFlame_ServeHTTP(t *testing.T) {
var buf bytes.Buffer
f := New()
f.Use(func(c Context) {
buf.WriteString("foo")
c.Next()
buf.WriteString("ban")
})
f.Use(func(c Context) {
buf.WriteString("bar")
c.Next()
buf.WriteString("baz")
})
f.Get("/", func() {})
f.Action(func(w http.ResponseWriter, r *http.Request) {
buf.WriteString("bat")
w.WriteHeader(http.StatusBadRequest)
})
resp := httptest.NewRecorder()
req, err := http.NewRequest(http.MethodGet, "/", nil)
assert.Nil(t, err)
f.ServeHTTP(resp, req)
assert.Equal(t, "foobarbatbazban", buf.String())
assert.Equal(t, http.StatusBadRequest, resp.Code)
}
func TestFlame_Handlers(t *testing.T) {
var buf bytes.Buffer
batman := func() {
buf.WriteString("batman!")
}
f := New()
f.Use(func(c Context) {
buf.WriteString("foo")
c.Next()
buf.WriteString("ban")
})
f.Handlers(
batman,
batman,
batman,
)
f.Get("/", func() {})
f.Action(func(w http.ResponseWriter, r *http.Request) {
buf.WriteString("bat")
w.WriteHeader(http.StatusBadRequest)
})
resp := httptest.NewRecorder()
req, err := http.NewRequest(http.MethodGet, "/", nil)
assert.Nil(t, err)
f.ServeHTTP(resp, req)
assert.Equal(t, "batman!batman!batman!bat", buf.String())
assert.Equal(t, http.StatusBadRequest, resp.Code)
}
func TestFlame_EarlyWrite(t *testing.T) {
var buf bytes.Buffer
f := New()
f.Use(func(w http.ResponseWriter) {
buf.WriteString("foobar")
_, _ = w.Write([]byte("Hello world"))
})
f.Use(func() {
buf.WriteString("bat")
})
f.Get("/", func() {})
f.Action(func(w http.ResponseWriter) {
buf.WriteString("baz")
w.WriteHeader(http.StatusBadRequest)
})
resp := httptest.NewRecorder()
req, err := http.NewRequest(http.MethodGet, "/", nil)
assert.Nil(t, err)
f.ServeHTTP(resp, req)
assert.Equal(t, "foobar", buf.String())
assert.Equal(t, http.StatusOK, resp.Code)
}
func TestFlame_NoRace(t *testing.T) {
f := New()
handlers := []Handler{func() {}, func() {}}
// Ensure append will not reallocate alice that triggers the race condition
f.handlers = handlers[:1]
f.Get("/", func() {})
for i := 0; i < 2; i++ {
go func() {
req, err := http.NewRequest(http.MethodGet, "/", nil)
resp := httptest.NewRecorder()
assert.Nil(t, err)
f.ServeHTTP(resp, req)
}()
}
}
func TestEnv(t *testing.T) {
defer SetEnv(EnvTypeDev)
envs := []EnvType{
EnvTypeDev,
EnvTypeProd,
EnvTypeTest,
}
for _, env := range envs {
SetEnv(env)
assert.Equal(t, env, Env())
}
}
|
def shuffle(self, data, labels):
rows = np.shape(data)[0]
permutation = np.random.permutation(rows)
data = data[permutation, :]
labels = labels[permutation]
return |
/** Item that outputs with a uniform range */
@RequiredArgsConstructor
private static class Range extends RandomItem {
/** Item result, max count will be up to the the result stack size */
private final ItemOutput result;
/** Minimum count of the item */
private final int minCount;
@Override
public ItemStack get(Random random) {
ItemStack result = this.result.get();
// safety in case min count is too high
int newCount = result.getCount();
if (result.getCount() > minCount) {
newCount = minCount + random.nextInt(result.getCount() - minCount);
if (newCount <= 0) {
return ItemStack.EMPTY;
}
}
return ItemHandlerHelper.copyStackWithSize(result, newCount);
}
@Override
public JsonElement serialize() {
JsonElement resultElement = this.result.serialize();
JsonObject object;
// if a primitive, that means its just an item name, so build an object around it
if (resultElement.isJsonPrimitive()) {
object = new JsonObject();
object.add("item", resultElement);
} else {
object = resultElement.getAsJsonObject();
}
object.addProperty("min", minCount);
object.addProperty("max", GsonHelper.getAsInt(object, "count", 1));
object.remove("count");
return object;
}
@Override
public void write(FriendlyByteBuf buffer) {
result.write(buffer);
buffer.writeEnum(RandomType.RANGE);
buffer.writeVarInt(minCount);
}
} |
/**
* This class contains custom scoping description.
*
* See https://www.eclipse.org/Xtext/documentation/303_runtime_concepts.html#scoping
* on how and when to use it.
*/
@SuppressWarnings("all")
public class PapljScopeProvider extends AbstractPapljScopeProvider {
@Inject
@Extension
private PapljTypeProvider _papljTypeProvider;
@Inject
@Extension
private PapljLib _papljLib;
@Override
public IScope getScope(final EObject context, final EReference reference) {
IScope _switchResult = null;
boolean _matched = false;
if (context instanceof MemberRef) {
boolean _equals = Objects.equal(reference, PapljPackage.Literals.MEMBER_REF__MEMBER);
if (_equals) {
_matched=true;
_switchResult = this.scope_MemberRef_member(((MemberRef)context), reference);
}
}
if (!_matched) {
_switchResult = super.getScope(context, reference);
}
return _switchResult;
}
public IScope scope_MemberRef_member(final MemberRef ref, final EReference r) {
IScope _xblockexpression = null;
{
final Type type = this._papljTypeProvider.typeOf(ref.getLeft());
final IScope scope = this.getScopesForClasses(IScope.NULLSCOPE, type, ref.isMethodInvocation());
_xblockexpression = scope;
}
return _xblockexpression;
}
public IScope scope_Var_member(final Var ref, final EReference r) {
IScope _xblockexpression = null;
{
final Type type = EcoreUtil2.<Type>getContainerOfType(ref, Type.class);
final IScope scope = this.getScopesForClasses(IScope.NULLSCOPE, type, ref.isMethodInvocation());
final IScope newScope = this.getScopesForBindings(scope, ref);
_xblockexpression = newScope;
}
return _xblockexpression;
}
public IScope getScopesForClasses(final IScope baseScope, final Type type, final boolean isMethodInvocation) {
IScope _xblockexpression = null;
{
IScope scope = baseScope;
if (((type == null) || this._papljTypeProvider.isPrimitive(type))) {
return scope;
}
List<Type> _reverseView = ListExtensions.<Type>reverseView(this._papljLib.ancestorsWithAny(type));
for (final Type c : _reverseView) {
scope = Scopes.scopeFor(this.selectMembers(c, isMethodInvocation), scope);
}
_xblockexpression = Scopes.scopeFor(this.selectMembers(type, isMethodInvocation), scope);
}
return _xblockexpression;
}
public Iterable<Member> selectMembers(final Type type, final boolean isMethodInvocation) {
Iterable<Member> _xifexpression = null;
if (isMethodInvocation) {
Iterable<Method> _methods = PapljModelUtil.methods(type);
Iterable<Field> _fields = PapljModelUtil.fields(type);
_xifexpression = Iterables.<Member>concat(_methods, _fields);
} else {
Iterable<Field> _fields_1 = PapljModelUtil.fields(type);
Iterable<Method> _methods_1 = PapljModelUtil.methods(type);
_xifexpression = Iterables.<Member>concat(_fields_1, _methods_1);
}
return _xifexpression;
}
protected IScope _symbolsDefinedBefore(final EObject container, final EObject o) {
return this.symbolsDefinedBefore(container.eContainer(), o.eContainer());
}
protected IScope _symbolsDefinedBefore(final Method m, final EObject o) {
return Scopes.scopeFor(m.getParams());
}
protected IScope _symbolsDefinedBefore(final Block2 b, final EObject o) {
return Scopes.scopeFor(this.variablesDeclaredBefore(b.getExprs(), o), this.symbolsDefinedBefore(b.eContainer(), o.eContainer()));
}
private ArrayList<EObject> variablesDeclaredBefore(final List<Expr> list, final EObject o) {
return CollectionLiterals.<EObject>newArrayList();
}
public IScope getScopesForBindings(final IScope baseScope, final Expr e) {
IScope _xblockexpression = null;
{
IScope scope = baseScope;
if ((e == null)) {
return scope;
}
List<Let> _reverseView = ListExtensions.<Let>reverseView(PapljModelUtil.lets(e));
for (final Let l : _reverseView) {
scope = Scopes.scopeFor(this.selectBindings(l), scope);
}
_xblockexpression = scope;
}
return _xblockexpression;
}
public EList<Binding> selectBindings(final Let let) {
return let.getBindings();
}
public IScope symbolsDefinedBefore(final EObject m, final EObject o) {
if (m instanceof Method) {
return _symbolsDefinedBefore((Method)m, o);
} else if (m instanceof Block2) {
return _symbolsDefinedBefore((Block2)m, o);
} else if (m != null) {
return _symbolsDefinedBefore(m, o);
} else {
throw new IllegalArgumentException("Unhandled parameter types: " +
Arrays.<Object>asList(m, o).toString());
}
}
} |
import { Service } from "@sap/cds/apis/services";
import { Lecture, Room, AlldayEvent } from "./entities";
export = (srv: Service) => {
const { Rooms, Lectures } = srv.entities;
srv.before('CREATE', 'Lectures', async (req) => {
const data = req.data as Lecture,
{ starttime, endtime, room_ID } = data;
const start = new Date(starttime).toISOString(),
end = new Date(endtime).toISOString();
let lectures = [];
lectures = await srv.read(Lectures).where({
room_ID: room_ID, and: {
starttime: { '>': start }, and: { starttime: { '<': end } },
or: {
endtime: { '>': start }, and: { endtime: { '<': end } },
or: { starttime: { '<': start }, and: { endtime: { '>': end } } }
}
}
}) as Lecture[];
if (lectures.length > 0)
return req.error(400, "The selected Room is not available for this timeframe.")
})
srv.before('UPDATE', 'Lectures', async (req) => {
const data = req.data as Lecture,
{ ID, starttime, endtime, room_ID } = data;
const lecture = await srv.read(Lectures).where({ ID: ID }).limit(1) as Lecture[];
const start = starttime ? new Date(starttime).toISOString() : lecture[0].starttime,
end = endtime ? new Date(endtime).toISOString() : lecture[0].endtime,
roomID = room_ID ? room_ID : lecture[0].room_ID;
let lectures = [];
lectures = await srv.read(Lectures).where({
room_ID: roomID, and: {
ID: { '<>': ID }, and: {
starttime: { '>': start }, and: { starttime: { '<': end } },
or: {
endtime: { '>': start }, and: { endtime: { '<': end } },
or: { starttime: { '<': start }, and: { endtime: { '>': end } } }
}
}
},
}) as Lecture[];
if (lectures.length > 0)
return req.error(400, "The selected Room is not available for this timeframe.")
})
srv.on('createEvent', async (req) => {
const data = req.data as AlldayEvent,
{ reqSeats, date } = data;
const startDate = new Date(date),
endDate = new Date(date);
endDate.setDate(startDate.getDate() + 1);
endDate.setTime(endDate.getTime() - 1000);
const overlappingLectures = await srv.read(Lectures)
.where({
starttime: { between: startDate.toISOString(), and: endDate.toISOString() },
or: { endtime: { between: startDate.toISOString(), and: endDate.toISOString() } }
}).columns('room_ID') as Lecture[];
const bookedRoomIDs = overlappingLectures.map(r => r.room_ID);
let rooms;
if (bookedRoomIDs.length >= 1) {
rooms = await srv.read(Rooms).where({
seats: { '>=': reqSeats },
and: { ID: { 'NOT IN': bookedRoomIDs } }
}).orderBy('seats asc').limit(1) as Room[];
} else {
rooms = await srv.read(Rooms).where({
seats: { '>=': reqSeats }
}).orderBy('seats asc').limit(1) as Room[];
}
if (rooms.length > 0) {
const lecture = await srv.create(Lectures).entries({
"starttime": startDate,
"endtime": endDate,
"course_ID": null,
"prof_ID": null,
"room_ID": rooms[0].ID
}) as Lecture;
return lecture;
} else {
return req.error(400, "No matching rooms available that day.")
}
})
srv.after('READ', 'Lectures', (each) => {
const lecture = each as Lecture;
if (lecture.starttime && lecture.endtime) {
const start = new Date(lecture.starttime),
end = new Date(lecture.endtime);
start.setDate(start.getDate() + 1);
start.setTime(start.getTime() - 1000);
lecture.allday = (start.toISOString() == end.toISOString() || new Date(lecture.starttime).toISOString() == end.toISOString());
}
})
srv.after('READ', 'Rooms', (each) => {
const room = each as Room;
if (room.lectures) {
for (const lecture of room.lectures) {
const start = new Date(lecture.starttime),
end = new Date(lecture.endtime);
start.setDate(start.getDate() + 1);
start.setTime(start.getTime() - 1000);
lecture.allday = (start.toISOString() == end.toISOString() || new Date(lecture.starttime).toISOString() == end.toISOString());
}
}
})
} |
<gh_stars>1-10
#include <JCDT_Lib/internal/lookup/BindingSymbolTable.h>
#include <JCDT_Lib/internal/util/tuple.h>
#include <JCDT_Lib/internal/lookup/TypeSymbol.h>
#include <JCDT_Lib/internal/lookup/MethodSymbol.h>
#include <JCDT_Lib/internal/lookup/PackageSymbol.h>
#include <JCDT_Lib/internal/lookup/VariableSymbol.h>
#include <JCDT_Lib/internal/lookup/BlockSymbol.h>
#include <JCDT_Lib/internal/impl/NameSymbol.h>
#include <JCDT_Lib/internal/lookup/FileSymbol.h>
#include <JCDT_Lib/internal/lookup/LabelSymbol.h>
#include <JCDT_Lib/internal/lookup/DirectorySymbol.h>
#include <JCDT_Lib/internal/lookup/PathSymbol.h>
namespace Jikes { // Open namespace Jikes block
void BindingSymbolTable::AddTypeSymbol(TypeSymbol* symbol)
{
symbol->pool_index = NumTypeSymbols();
if (!type_symbol_pool)
type_symbol_pool = new Tuple<TypeSymbol*>(256);
type_symbol_pool->Next() = symbol;
Hash(symbol);
}
void BindingSymbolTable::AddMethodSymbol(MethodSymbol* symbol)
{
symbol->pool_index = NumMethodSymbols();
if (!method_symbol_pool)
method_symbol_pool = new ConvertibleArray<MethodSymbol*>(256);
method_symbol_pool->Next() = symbol;
// not hashed, because of method overloading
}
void BindingSymbolTable::AddVariableSymbol(VariableSymbol* symbol)
{
symbol->pool_index = NumVariableSymbols();
if (!variable_symbol_pool)
variable_symbol_pool = new ConvertibleArray<VariableSymbol*>(256);
variable_symbol_pool->Next() = symbol;
Hash(symbol);
}
PackageSymbol* BindingSymbolTable::FindPackageSymbol(const NameSymbol* name_symbol)
{
assert(base);
for (Symbol* symbol = base[name_symbol->index % hash_size];
symbol; symbol = symbol->next)
{
if (name_symbol == symbol->Identity() && PackageSymbol::PackageCast(symbol))
return (PackageSymbol*)symbol;
}
return NULL;
}
TypeSymbol* BindingSymbolTable::InsertAnonymousTypeSymbol(NameSymbol* name_symbol)
{
TypeSymbol* symbol = new TypeSymbol(name_symbol);
AddAnonymousSymbol(symbol);
return symbol;
}
TypeSymbol* BindingSymbolTable::InsertTypeSymbol(NameSymbol* name_symbol)
{
assert(base);
TypeSymbol* symbol = new TypeSymbol(name_symbol);
AddTypeSymbol(symbol);
return symbol;
}
void BindingSymbolTable::DeleteTypeSymbol(TypeSymbol* type)
{
assert(base);
unsigned k = type->name_symbol->index % hash_size;
if (type == base[k])
base[k] = type->next;
else
{
Symbol* previous = base[k];
for (Symbol* symbol = previous->next;
symbol != type; previous = symbol, symbol = symbol->next)
;
previous->next = type->next;
}
unsigned last_index = NumTypeSymbols() - 1;
if (type->pool_index != last_index)
{
// Move last element to position previously occupied by element being
// deleted
TypeSym(last_index)->pool_index = type->pool_index;
TypeSym(type->pool_index) = TypeSym(last_index);
}
type_symbol_pool->Reset(last_index); // remove last slot in symbol_pool
delete type;
}
void BindingSymbolTable::DeleteAnonymousTypes()
{
for (unsigned i = 0; i < NumAnonymousSymbols(); i++)
{
TypeSymbol* symbol = AnonymousSym(i);
symbol->UnlinkFromParents();
delete symbol;
}
delete anonymous_symbol_pool;
anonymous_symbol_pool = NULL;
}
TypeSymbol* BindingSymbolTable::FindTypeSymbol(const NameSymbol* name_symbol)
{
assert(base);
for (Symbol* symbol = base[name_symbol->index % hash_size];
symbol; symbol = symbol->next)
{
if (name_symbol == symbol->Identity() && TypeSymbol::TypeCast(symbol))
return (TypeSymbol*)symbol;
}
return NULL;
}
MethodSymbol* BindingSymbolTable::InsertMethodSymbol(MethodSymbol* symbol)
{
assert(base);
AddMethodSymbol(symbol);
const NameSymbol* name_symbol = symbol->Identity();
MethodSymbol* base_method = NULL;
Symbol* candidate;
for (candidate = base[name_symbol->index % hash_size];
candidate; candidate = candidate->next)
{
if (name_symbol == candidate->Identity() &&
MethodSymbol::MethodCast(candidate))
{
base_method = (MethodSymbol*)candidate;
break;
}
}
if (base_method)
{
symbol->next = symbol; // mark method as overloaded
symbol->next_method = base_method->next_method;
base_method->next_method = symbol;
}
else Hash(symbol);
return symbol;
}
MethodSymbol* BindingSymbolTable::FindMethodSymbol(const NameSymbol* name_symbol)
{
if (!name_symbol)
return NULL;
assert(base);
for (Symbol* symbol = base[name_symbol->index % hash_size];
symbol; symbol = symbol->next)
{
if (name_symbol == symbol->Identity() && MethodSymbol::MethodCast(symbol))
return (MethodSymbol*)symbol;
}
return NULL;
}
VariableSymbol* BindingSymbolTable::InsertVariableSymbol(const NameSymbol* name_symbol)
{
assert(base);
VariableSymbol* symbol = new VariableSymbol(name_symbol);
AddVariableSymbol(symbol);
return symbol;
}
VariableSymbol* BindingSymbolTable::InsertVariableSymbol(VariableSymbol* symbol)
{
assert(base);
AddVariableSymbol(symbol);
return symbol;
}
VariableSymbol* BindingSymbolTable::FindVariableSymbol(const NameSymbol* name_symbol)
{
if(!name_symbol)
return NULL;
assert(base);
for (Symbol* symbol = base[name_symbol->index % hash_size];
symbol; symbol = symbol->next)
{
if (name_symbol == symbol->Identity() && VariableSymbol::VariableCast(symbol))
return (VariableSymbol*)symbol;
}
return NULL;
}
FileSymbol* BindingSymbolTable::InsertFileSymbol(const NameSymbol* name_symbol)
{
assert(base);
FileSymbol* symbol = new FileSymbol(name_symbol);
AddOtherSymbol(symbol);
Hash(symbol);
return symbol;
}
void BindingSymbolTable::InsertFileSymbol(FileSymbol* symbol)
{
assert(base);
AddOtherSymbol(symbol);
Hash(symbol);
}
FileSymbol* BindingSymbolTable::FindFileSymbol(const NameSymbol* name_symbol)
{
if (!name_symbol)
return NULL;
assert(base);
for (Symbol* symbol = base[name_symbol->index % hash_size];
symbol; symbol = symbol->next)
{
if (name_symbol == symbol->Identity() && FileSymbol::FileCast(symbol))
return (FileSymbol*)symbol;
}
return NULL;
}
LabelSymbol* BindingSymbolTable::InsertLabelSymbol(NameSymbol* name_symbol)
{
assert(base);
LabelSymbol* symbol = new LabelSymbol(name_symbol);
AddOtherSymbol(symbol);
Hash(symbol);
return symbol;
}
LabelSymbol* BindingSymbolTable::FindLabelSymbol(const NameSymbol* name_symbol)
{
if (!name_symbol)
return NULL;
assert(base);
for (Symbol* symbol = base[name_symbol->index % hash_size];
symbol; symbol = symbol->next)
{
if (name_symbol == symbol->Identity() && LabelSymbol::LabelCast(symbol))
return (LabelSymbol*)symbol;
}
return NULL;
}
BlockSymbol* BindingSymbolTable::InsertBlockSymbol(unsigned hash_size)
{
BlockSymbol* symbol = new BlockSymbol(hash_size);
AddOtherSymbol(symbol);
return symbol;
}
PackageSymbol* BindingSymbolTable::InsertPackageSymbol(NameSymbol* name_symbol,
PackageSymbol* owner)
{
assert(base);
PackageSymbol* symbol = new PackageSymbol(name_symbol, owner);
AddOtherSymbol(symbol);
Hash(symbol);
return symbol;
}
DirectorySymbol* BindingSymbolTable::FindDirectorySymbol(const NameSymbol* name_symbol)
{
if (!name_symbol)
return NULL;
assert(base);
for (Symbol* symbol = base[name_symbol->index % hash_size];
symbol; symbol = symbol->next)
{
if (name_symbol == symbol->Identity() && DirectorySymbol::DirectoryCast(symbol))
return (DirectorySymbol*)symbol;
}
return NULL;
}
PathSymbol* BindingSymbolTable::InsertPathSymbol(NameSymbol* name_symbol,
DirectorySymbol* directory_symbol)
{
assert(base);
PathSymbol* symbol = new PathSymbol(name_symbol);
directory_symbol->owner = symbol;
symbol->root_directory = directory_symbol;
AddOtherSymbol(symbol);
Hash(symbol);
return symbol;
}
PathSymbol* BindingSymbolTable::FindPathSymbol(const NameSymbol* name_symbol)
{
if (!name_symbol)
return NULL;
assert(base);
for (Symbol* symbol = base[name_symbol->index % hash_size];
symbol; symbol = symbol->next)
{
/* if (name_symbol == symbol -> Identity() && symbol -> PathCast())
return (PathSymbol*) symbol;*/
if (name_symbol == symbol->Identity() && PathSymbol::PathCast(symbol))
return (PathSymbol*)symbol;
}
return NULL;
}
DirectorySymbol* BindingSymbolTable::InsertDirectorySymbol(const NameSymbol* name_symbol,
Symbol* owner,
bool source_path)
{
assert(base);
DirectorySymbol* symbol = new DirectorySymbol(name_symbol, owner,
source_path);
AddOtherSymbol(symbol);
Hash(symbol);
return symbol;
}
MethodSymbol* BindingSymbolTable::FindOverloadMethod(MethodSymbol* base_method,
AstMethodDeclarator* method_declarator)
{
for (MethodSymbol* method = base_method; method;
method = method->next_method)
{
assert(method->IsTyped());
if (method->NumFormalParameters() ==
method_declarator->NumFormalParameters())
{
int i;
for (i = method->NumFormalParameters() - 1; i >= 0; i--)
{
AstFormalParameter* parameter =
method_declarator->FormalParameter(i);
if (method->FormalParameter(i)->Type() !=
parameter->formal_declarator->symbol->Type())
{
break;
}
}
if (i < 0)
return method;
}
}
return NULL;
}
unsigned SymbolTable::primes[] = { DEFAULT_HASH_SIZE, 101, 401, MAX_HASH_SIZE };
void BindingSymbolTable::Rehash()
{
hash_size = primes[++prime_index];
delete[] base;
base = (Symbol**)memset(new Symbol*[hash_size], 0,
hash_size * sizeof(Symbol*));
unsigned k;
for (k = 0; k < NumTypeSymbols(); k++)
{
TypeSymbol* symbol = TypeSym(k);
int i = symbol->name_symbol->index % hash_size;
symbol->next = base[i];
base[i] = symbol;
}
for (k = 0; k < NumMethodSymbols(); k++)
{
MethodSymbol* symbol = MethodSym(k);
if (symbol->next != symbol) // not an overload
{
int i = symbol->name_symbol->index % hash_size;
symbol->next = base[i];
base[i] = symbol;
}
}
for (k = 0; k < NumVariableSymbols(); k++)
{
VariableSymbol* symbol = VariableSym(k);
int i = symbol->name_symbol->index % hash_size;
symbol->next = base[i];
base[i] = symbol;
}
for (k = 0; k < NumOtherSymbols(); k++)
{
Symbol* symbol = OtherSym(k);
if (!BlockSymbol::BlockCast( symbol ))
{
int i = symbol->Identity()->index % hash_size;
symbol->next = base[i];
base[i] = symbol;
}
}
}
BindingSymbolTable::BindingSymbolTable(unsigned hash_size_)
: SymbolTable(hash_size_),
type_symbol_pool(NULL)
, anonymous_symbol_pool(NULL)
, method_symbol_pool(NULL)
, variable_symbol_pool(NULL)
, other_symbol_pool(NULL)
{
}
BindingSymbolTable::~BindingSymbolTable()
{
unsigned i;
for (i = 0; i < NumAnonymousSymbols(); i++)
delete AnonymousSym(i);
delete anonymous_symbol_pool;
for (i = 0; i < NumTypeSymbols(); i++)
delete TypeSym(i);
delete type_symbol_pool;
for (i = 0; i < NumMethodSymbols(); i++)
delete MethodSym(i);
delete method_symbol_pool;
for (i = 0; i < NumVariableSymbols(); i++)
delete VariableSym(i);
delete variable_symbol_pool;
for (i = 0; i < NumOtherSymbols(); i++)
delete OtherSym(i);
delete other_symbol_pool;
}
} // Close namespace Jikes block
|
April 3, 2015 5 min read
This story originally appeared on Business Insider
Who doesn't desire power?
There's a little Frank Underwood in all of us.
At the beginning of "House of Cards,"Kevin Spacey's character explains why power beats money
Money is the McMansion in Sarasota that starts falling apart after 10 years. Power is the old stone building that stands for centuries. I cannot respect someone who doesn't see the difference.
But should you find and hold power — as Underwood so deliciously does — it's going to do some really weird things to your perception of yourself and others.
Here's what the research says:
1. If you feel powerful, you're more inspired by yourself than anybody else.
According to a 2015 study led by Gerben A. Van Kleef at the University of Amsterdam, powerful people find themselves more inspiring than anybody else. In a study of 140 undergraduates, he found that people who agreed highly to statements like "I can get others to do what I want" were more inspired by talking about their own life-changing experiences than hearing other people discuss theirs.
To Research Digest blogger Alex Fradera, it's indicative of self-sufficiency.
"As a matter of course, powerful people don't expect others to fulfill their needs, and may therefore find it difficult to consider anyone else a worthy source of inspiration," he writes. "It's a little like a child for whom no one in the playground is up to scratch, so they become their own best friend."
2. If you feel powerful, you're the first to act.
In a 2003 study led by Columbia University psychologist Adam Galinsky, people who felt more powerful than their peers were more likely to take a card in a game of blackjack, fix an annoying fan in a room, and take action in social dilemmas. A 2007 study coauthored by Galinsky added to that theme, finding that powerful people are more likely to act first in a negotiation.
In 2012, the University of Texas' Jennifer A. Whitson found an explanation as to why: Powerful people are less likely to perceive — and remember — constraints to their goals.
It's like how eagles and alligators evolved to have their eyes close together.
"The vision of predators is fixated on their object of pursuit — their prey — leaving little visual room for unexpected danger or potential threats in their surroundings," she and her authors write. "This directed focus allows them to pounce into action to secure their meal."
Same for CEOs.
3. If you feel powerful, you're more likely to cheat.
It's not that men are more disposed to having sex outside of their marriages than women.
According to a 2011 study led by Joris Lammers at Tilburg University in the Netherlands, it's that powerful people are more likely to cheat.
His team surveyed 1,561 professionals, asking how high up in their organizations they were and their history or interest in cheating.
"Results showed that elevated power is positively associated with infidelity because power increases confidence in the ability to attract partners," they wrote. "This association was found for both actual infidelity and intentions to engage in infidelity in the future."
Gender didn't matter.
Powerful women were just as likely to have or pursue affairs as powerful men. This goes against a commonly held assumption about cheating. It's not that men are inherently more likely to cheat than women, it's just that men are more likely to hold powerful positions.
"As a social psychologist, I believe that the situation is everything and that the situation or instance is often stronger than the individual," Lammers said in a statement. "As more and more women are in greater positions of power and are considered equal to men, then familiar assumptions about their behavior may also change."
4. If you feel powerful, you feel distant from other people.
According to Joe Magee at New York University and Pamela Smith at the University of California at San Diego, powerful people feel more socially distant than non-powerful people.
It happens for a few reasons:
• People become close to one another when they are "symmetrically dependent" on one another and have repeated interactions, Magee and Smith say. You and your boss aren't symmetrically dependent; you depend on her approval more than she does yours. But you and the other people on her team are symmetrical, so you're likely to become close over time.
• Research indicates that powerful people don't need to associate with others in the same way.
• Powerful people have to think more abstractly than everybody else. They're concerned with meeting goals more than developing relationships.
So the isolation is a result of the social situation that power puts you in — and the need to get things done.
It works for Mr. Underwood. |
def hide_cursor(stream=sys.stdout):
handle = get_stream_handle(stream=stream)
if os.name == "nt":
from ._winconsole import hide_cursor
hide_cursor()
else:
handle.write("\033[?25l")
handle.flush() |
#include<cstdio>
#include<iostream>
#include<cmath>
#include<algorithm>
#include<string>
#include<cstring>
#include<cctype>
#include<queue>
#include<stack>
#include<map>
#include<set>
#include<iomanip>
#include<sstream>
#include<vector>
#include<cstdlib>
#include<ctime>
#include<list>
#include<deque>
#include<bitset>
#include<fstream>
#define ld double
#define ull unsigned long long
#define ll long long
#define pii pair<int,int >
#define iiii pair<int,pii >
#define mp make_pair
#define INF 2000000000
#define MOD 1000000007
#define rep(i,x) for(int (i)=0;(i)<(x);(i)++)
inline int getint(){
int x=0,p=1;char c=getchar();
while (c<=32)c=getchar();
if(c==45)p=-p,c=getchar();
while (c>32)x=x*10+c-48,c=getchar();
return x*p;
}
using namespace std;
//ruogu
const int N=2e5+10;
const int M=1e7+10;
int a[N],n,h0[N],h1[N];
int T,cnt;
int to[2][M];
//
void ins(int &rt,int x,int d){
if(!rt){
rt=++cnt;
to[0][rt]=to[1][rt]=0;
}
if(d<0)return;
ins(to[x>>d&1][rt],x,d-1);
}
int qry(int rt,int x,int d){
if(d<0)return 0;
if(to[x>>d&1][rt])return qry(to[x>>d&1][rt],x,d-1);
return (1<<d)|qry(to[!(x>>d&1)][rt],x,d-1);
}
ll solve(int l,int r,int d){
if(r-l<=1)return 0ll;
if(d<0)return 0ll;
int c0=0,c1=0;
for(int i=l;i<r;i++){
if(a[i]>>d&1)h0[c0++]=a[i];
else h1[c1++]=a[i];
}
if(!c0||!c1)return solve(l,r,d-1);
int p=l;
rep(i,c0)a[p++]=h0[i];
rep(i,c1)a[p++]=h1[i];
ll res=solve(l,l+c0,d-1)+solve(l+c0,r,d-1);
T=cnt=0;
p=l+c0;
int ans=INF;
for(int i=p;i<r;i++)ins(T,a[i],29);
for(int i=l;i<p;i++)ans=min(ans,qry(T,a[i],29));
return res+1ll*ans;
}
int main(){
n=getint();
rep(i,n)a[i]=getint();
printf("%lld\n",solve(0,n,29));
return 0;
} |
// Copyright 2016 Google Inc. All Rights Reserved.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// https://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
// A library for translating between absolute times (represented by
// std::chrono::time_points of the std::chrono::system_clock) and civil
// times (represented by cctz::civil_second) using the rules defined by
// a time zone (cctz::time_zone).
#ifndef ABSL_TIME_INTERNAL_CCTZ_TIME_ZONE_H_
#define ABSL_TIME_INTERNAL_CCTZ_TIME_ZONE_H_
#include <chrono>
#include <cstdint>
#include <string>
#include <utility>
#include "absl/base/config.h"
#include "absl/time/internal/cctz/include/cctz/civil_time.h"
namespace absl {
ABSL_NAMESPACE_BEGIN
namespace time_internal {
namespace cctz {
// Convenience aliases. Not intended as public API points.
template <typename D>
using time_point = std::chrono::time_point<std::chrono::system_clock, D>;
using seconds = std::chrono::duration<std::int_fast64_t>;
using sys_seconds = seconds; // Deprecated. Use cctz::seconds instead.
namespace detail {
template <typename D>
inline std::pair<time_point<seconds>, D> split_seconds(
const time_point<D>& tp) {
auto sec = std::chrono::time_point_cast<seconds>(tp);
auto sub = tp - sec;
if (sub.count() < 0) {
sec -= seconds(1);
sub += seconds(1);
}
return {sec, std::chrono::duration_cast<D>(sub)};
}
inline std::pair<time_point<seconds>, seconds> split_seconds(
const time_point<seconds>& tp) {
return {tp, seconds::zero()};
}
} // namespace detail
// cctz::time_zone is an opaque, small, value-type class representing a
// geo-political region within which particular rules are used for mapping
// between absolute and civil times. Time zones are named using the TZ
// identifiers from the IANA Time Zone Database, such as "America/Los_Angeles"
// or "Australia/Sydney". Time zones are created from factory functions such
// as load_time_zone(). Note: strings like "PST" and "EDT" are not valid TZ
// identifiers.
//
// Example:
// cctz::time_zone utc = cctz::utc_time_zone();
// cctz::time_zone pst = cctz::fixed_time_zone(std::chrono::hours(-8));
// cctz::time_zone loc = cctz::local_time_zone();
// cctz::time_zone lax;
// if (!cctz::load_time_zone("America/Los_Angeles", &lax)) { ... }
//
// See also:
// - http://www.iana.org/time-zones
// - https://en.wikipedia.org/wiki/Zoneinfo
class time_zone {
public:
time_zone() : time_zone(nullptr) {} // Equivalent to UTC
time_zone(const time_zone&) = default;
time_zone& operator=(const time_zone&) = default;
std::string name() const;
// An absolute_lookup represents the civil time (cctz::civil_second) within
// this time_zone at the given absolute time (time_point). There are
// additionally a few other fields that may be useful when working with
// older APIs, such as std::tm.
//
// Example:
// const cctz::time_zone tz = ...
// const auto tp = std::chrono::system_clock::now();
// const cctz::time_zone::absolute_lookup al = tz.lookup(tp);
struct absolute_lookup {
civil_second cs;
// Note: The following fields exist for backward compatibility with older
// APIs. Accessing these fields directly is a sign of imprudent logic in
// the calling code. Modern time-related code should only access this data
// indirectly by way of cctz::format().
int offset; // civil seconds east of UTC
bool is_dst; // is offset non-standard?
const char* abbr; // time-zone abbreviation (e.g., "PST")
};
absolute_lookup lookup(const time_point<seconds>& tp) const;
template <typename D>
absolute_lookup lookup(const time_point<D>& tp) const {
return lookup(detail::split_seconds(tp).first);
}
// A civil_lookup represents the absolute time(s) (time_point) that
// correspond to the given civil time (cctz::civil_second) within this
// time_zone. Usually the given civil time represents a unique instant
// in time, in which case the conversion is unambiguous. However,
// within this time zone, the given civil time may be skipped (e.g.,
// during a positive UTC offset shift), or repeated (e.g., during a
// negative UTC offset shift). To account for these possibilities,
// civil_lookup is richer than just a single time_point.
//
// In all cases the civil_lookup::kind enum will indicate the nature
// of the given civil-time argument, and the pre, trans, and post
// members will give the absolute time answers using the pre-transition
// offset, the transition point itself, and the post-transition offset,
// respectively (all three times are equal if kind == UNIQUE). If any
// of these three absolute times is outside the representable range of a
// time_point<seconds> the field is set to its maximum/minimum value.
//
// Example:
// cctz::time_zone lax;
// if (!cctz::load_time_zone("America/Los_Angeles", &lax)) { ... }
//
// // A unique civil time.
// auto jan01 = lax.lookup(cctz::civil_second(2011, 1, 1, 0, 0, 0));
// // jan01.kind == cctz::time_zone::civil_lookup::UNIQUE
// // jan01.pre is 2011/01/01 00:00:00 -0800
// // jan01.trans is 2011/01/01 00:00:00 -0800
// // jan01.post is 2011/01/01 00:00:00 -0800
//
// // A Spring DST transition, when there is a gap in civil time.
// auto mar13 = lax.lookup(cctz::civil_second(2011, 3, 13, 2, 15, 0));
// // mar13.kind == cctz::time_zone::civil_lookup::SKIPPED
// // mar13.pre is 2011/03/13 03:15:00 -0700
// // mar13.trans is 2011/03/13 03:00:00 -0700
// // mar13.post is 2011/03/13 01:15:00 -0800
//
// // A Fall DST transition, when civil times are repeated.
// auto nov06 = lax.lookup(cctz::civil_second(2011, 11, 6, 1, 15, 0));
// // nov06.kind == cctz::time_zone::civil_lookup::REPEATED
// // nov06.pre is 2011/11/06 01:15:00 -0700
// // nov06.trans is 2011/11/06 01:00:00 -0800
// // nov06.post is 2011/11/06 01:15:00 -0800
struct civil_lookup {
enum civil_kind {
UNIQUE, // the civil time was singular (pre == trans == post)
SKIPPED, // the civil time did not exist (pre >= trans > post)
REPEATED, // the civil time was ambiguous (pre < trans <= post)
} kind;
time_point<seconds> pre; // uses the pre-transition offset
time_point<seconds> trans; // instant of civil-offset change
time_point<seconds> post; // uses the post-transition offset
};
civil_lookup lookup(const civil_second& cs) const;
// Finds the time of the next/previous offset change in this time zone.
//
// By definition, next_transition(tp, &trans) returns false when tp has
// its maximum value, and prev_transition(tp, &trans) returns false
// when tp has its minimum value. If the zone has no transitions, the
// result will also be false no matter what the argument.
//
// Otherwise, when tp has its minimum value, next_transition(tp, &trans)
// returns true and sets trans to the first recorded transition. Chains
// of calls to next_transition()/prev_transition() will eventually return
// false, but it is unspecified exactly when next_transition(tp, &trans)
// jumps to false, or what time is set by prev_transition(tp, &trans) for
// a very distant tp.
//
// Note: Enumeration of time-zone transitions is for informational purposes
// only. Modern time-related code should not care about when offset changes
// occur.
//
// Example:
// cctz::time_zone nyc;
// if (!cctz::load_time_zone("America/New_York", &nyc)) { ... }
// const auto now = std::chrono::system_clock::now();
// auto tp = cctz::time_point<cctz::seconds>::min();
// cctz::time_zone::civil_transition trans;
// while (tp <= now && nyc.next_transition(tp, &trans)) {
// // transition: trans.from -> trans.to
// tp = nyc.lookup(trans.to).trans;
// }
struct civil_transition {
civil_second from; // the civil time we jump from
civil_second to; // the civil time we jump to
};
bool next_transition(const time_point<seconds>& tp,
civil_transition* trans) const;
template <typename D>
bool next_transition(const time_point<D>& tp, civil_transition* trans) const {
return next_transition(detail::split_seconds(tp).first, trans);
}
bool prev_transition(const time_point<seconds>& tp,
civil_transition* trans) const;
template <typename D>
bool prev_transition(const time_point<D>& tp, civil_transition* trans) const {
return prev_transition(detail::split_seconds(tp).first, trans);
}
// version() and description() provide additional information about the
// time zone. The content of each of the returned strings is unspecified,
// however, when the IANA Time Zone Database is the underlying data source
// the version() std::string will be in the familar form (e.g, "2018e") or
// empty when unavailable.
//
// Note: These functions are for informational or testing purposes only.
std::string version() const; // empty when unknown
std::string description() const;
// Relational operators.
friend bool operator==(time_zone lhs, time_zone rhs) {
return &lhs.effective_impl() == &rhs.effective_impl();
}
friend bool operator!=(time_zone lhs, time_zone rhs) { return !(lhs == rhs); }
template <typename H>
friend H AbslHashValue(H h, time_zone tz) {
return H::combine(std::move(h), &tz.effective_impl());
}
class Impl;
private:
explicit time_zone(const Impl* impl) : impl_(impl) {}
const Impl& effective_impl() const; // handles implicit UTC
const Impl* impl_;
};
// Loads the named time zone. May perform I/O on the initial load.
// If the name is invalid, or some other kind of error occurs, returns
// false and "*tz" is set to the UTC time zone.
bool load_time_zone(const std::string& name, time_zone* tz);
// Returns a time_zone representing UTC. Cannot fail.
time_zone utc_time_zone();
// Returns a time zone that is a fixed offset (seconds east) from UTC.
// Note: If the absolute value of the offset is greater than 24 hours
// you'll get UTC (i.e., zero offset) instead.
time_zone fixed_time_zone(const seconds& offset);
// Returns a time zone representing the local time zone. Falls back to UTC.
// Note: local_time_zone.name() may only be something like "localtime".
time_zone local_time_zone();
// Returns the civil time (cctz::civil_second) within the given time zone at
// the given absolute time (time_point). Since the additional fields provided
// by the time_zone::absolute_lookup struct should rarely be needed in modern
// code, this convert() function is simpler and should be preferred.
template <typename D>
inline civil_second convert(const time_point<D>& tp, const time_zone& tz) {
return tz.lookup(tp).cs;
}
// Returns the absolute time (time_point) that corresponds to the given civil
// time within the given time zone. If the civil time is not unique (i.e., if
// it was either repeated or non-existent), then the returned time_point is
// the best estimate that preserves relative order. That is, this function
// guarantees that if cs1 < cs2, then convert(cs1, tz) <= convert(cs2, tz).
inline time_point<seconds> convert(const civil_second& cs,
const time_zone& tz) {
const time_zone::civil_lookup cl = tz.lookup(cs);
if (cl.kind == time_zone::civil_lookup::SKIPPED) return cl.trans;
return cl.pre;
}
namespace detail {
using femtoseconds = std::chrono::duration<std::int_fast64_t, std::femto>;
std::string format(const std::string&, const time_point<seconds>&,
const femtoseconds&, const time_zone&);
bool parse(const std::string&, const std::string&, const time_zone&,
time_point<seconds>*, femtoseconds*, std::string* err = nullptr);
} // namespace detail
// Formats the given time_point in the given cctz::time_zone according to
// the provided format string. Uses strftime()-like formatting options,
// with the following extensions:
//
// - %Ez - RFC3339-compatible numeric UTC offset (+hh:mm or -hh:mm)
// - %E*z - Full-resolution numeric UTC offset (+hh:mm:ss or -hh:mm:ss)
// - %E#S - Seconds with # digits of fractional precision
// - %E*S - Seconds with full fractional precision (a literal '*')
// - %E#f - Fractional seconds with # digits of precision
// - %E*f - Fractional seconds with full precision (a literal '*')
// - %E4Y - Four-character years (-999 ... -001, 0000, 0001 ... 9999)
//
// Note that %E0S behaves like %S, and %E0f produces no characters. In
// contrast %E*f always produces at least one digit, which may be '0'.
//
// Note that %Y produces as many characters as it takes to fully render the
// year. A year outside of [-999:9999] when formatted with %E4Y will produce
// more than four characters, just like %Y.
//
// Tip: Format strings should include the UTC offset (e.g., %z, %Ez, or %E*z)
// so that the resulting string uniquely identifies an absolute time.
//
// Example:
// cctz::time_zone lax;
// if (!cctz::load_time_zone("America/Los_Angeles", &lax)) { ... }
// auto tp = cctz::convert(cctz::civil_second(2013, 1, 2, 3, 4, 5), lax);
// std::string f = cctz::format("%H:%M:%S", tp, lax); // "03:04:05"
// f = cctz::format("%H:%M:%E3S", tp, lax); // "03:04:05.000"
template <typename D>
inline std::string format(const std::string& fmt, const time_point<D>& tp,
const time_zone& tz) {
const auto p = detail::split_seconds(tp);
const auto n = std::chrono::duration_cast<detail::femtoseconds>(p.second);
return detail::format(fmt, p.first, n, tz);
}
// Parses an input string according to the provided format string and
// returns the corresponding time_point. Uses strftime()-like formatting
// options, with the same extensions as cctz::format(), but with the
// exceptions that %E#S is interpreted as %E*S, and %E#f as %E*f. %Ez
// and %E*z also accept the same inputs.
//
// %Y consumes as many numeric characters as it can, so the matching data
// should always be terminated with a non-numeric. %E4Y always consumes
// exactly four characters, including any sign.
//
// Unspecified fields are taken from the default date and time of ...
//
// "1970-01-01 00:00:00.0 +0000"
//
// For example, parsing a string of "15:45" (%H:%M) will return a time_point
// that represents "1970-01-01 15:45:00.0 +0000".
//
// Note that parse() returns time instants, so it makes most sense to parse
// fully-specified date/time strings that include a UTC offset (%z, %Ez, or
// %E*z).
//
// Note also that parse() only heeds the fields year, month, day, hour,
// minute, (fractional) second, and UTC offset. Other fields, like weekday (%a
// or %A), while parsed for syntactic validity, are ignored in the conversion.
//
// Date and time fields that are out-of-range will be treated as errors rather
// than normalizing them like cctz::civil_second() would do. For example, it
// is an error to parse the date "Oct 32, 2013" because 32 is out of range.
//
// A second of ":60" is normalized to ":00" of the following minute with
// fractional seconds discarded. The following table shows how the given
// seconds and subseconds will be parsed:
//
// "59.x" -> 59.x // exact
// "60.x" -> 00.0 // normalized
// "00.x" -> 00.x // exact
//
// Errors are indicated by returning false.
//
// Example:
// const cctz::time_zone tz = ...
// std::chrono::system_clock::time_point tp;
// if (cctz::parse("%Y-%m-%d", "2015-10-09", tz, &tp)) {
// ...
// }
template <typename D>
inline bool parse(const std::string& fmt, const std::string& input,
const time_zone& tz, time_point<D>* tpp) {
time_point<seconds> sec;
detail::femtoseconds fs;
const bool b = detail::parse(fmt, input, tz, &sec, &fs);
if (b) {
// TODO: Return false if unrepresentable as a time_point<D>.
*tpp = std::chrono::time_point_cast<D>(sec);
*tpp += std::chrono::duration_cast<D>(fs);
}
return b;
}
} // namespace cctz
} // namespace time_internal
ABSL_NAMESPACE_END
} // namespace absl
#endif // ABSL_TIME_INTERNAL_CCTZ_TIME_ZONE_H_
|
/**
* Sets the name of the database table that stores the entities.
*/
public Builder<T> table(String tableName)
{
this.table = tableName;
return this;
} |
/* Licensed under the Apache License, Version 2.0 (the "License");
* you may not use this file except in compliance with the License.
* You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package org.camunda.bpm.engine.cassandra.provider.operation;
import static com.datastax.driver.core.querybuilder.QueryBuilder.eq;
import static com.datastax.driver.core.querybuilder.QueryBuilder.in;
import java.util.ArrayList;
import java.util.List;
import org.camunda.bpm.engine.cassandra.provider.CassandraPersistenceSession;
import org.camunda.bpm.engine.cassandra.provider.table.ProcessDefinitionTableHandler;
import com.datastax.driver.core.BatchStatement;
import com.datastax.driver.core.Row;
import com.datastax.driver.core.Session;
import com.datastax.driver.core.querybuilder.QueryBuilder;
public class BulkDeleteProcessDefinitionByDeploymentId implements BulkOperationHandler {
public void perform(CassandraPersistenceSession session, Object parameter, BatchStatement flush) {
String deploymentId = (String) parameter;
Session s = session.getSession();
List<Row> processDefinitionsToDelete = s.execute(QueryBuilder.select("id", "key", "version").from(ProcessDefinitionTableHandler.TABLE_NAME).where(eq("deployment_id", deploymentId))).all();
List<String> ids = new ArrayList<String>();
for (Row processDefinitionToDelete : processDefinitionsToDelete) {
ids.add(processDefinitionToDelete.getString("id"));
flush.add(QueryBuilder.delete().all().from(ProcessDefinitionTableHandler.TABLE_NAME_IDX_VERSION)
.where(eq("key", processDefinitionToDelete.getString("key")))
.and(eq("version", processDefinitionToDelete.getInt("version"))));
}
flush.add(QueryBuilder.delete().all().from(ProcessDefinitionTableHandler.TABLE_NAME).where(in("id", ids)));
}
}
|
<reponame>petr-muller/abductor<gh_stars>100-1000
__inline static void *allocate (unsigned int __10884_34___n);
__inline static void * allocate (unsigned int __10884_34___n)
{
return 0;
}
__inline static void *allocate___0 (unsigned int __11367_34___n);
__inline static void * allocate___0 (unsigned int __11367_34___n)
{
return 0;
}
int main () {
allocate___0(0);
return 0;
}
|
Differential projective modules over algebras with radical square zero
Let $Q$ be a finite quiver and $\Lambda$ be the radical square zero algebra of $Q$ over a field. We give a full and dense functor from the category of reduced differential projective modules over $\Lambda$ to the category of representations of the opposite of $Q$. If moreover $Q$ has oriented cycles and $Q$ is not a basic cycle, we prove that the algebra of dual numbers over $\Lambda$ is not virtually Gorenstein.
The Gorenstein projective modules over algebras with radical square zero have been well studied. X.-W. Chen shows that a connected Artin algebra with radical square zero is either selfinjective or CM-free. Recall that an Artin algebra is called CM-free if every totally reflexive module is projective. C. M. Ringel and B.-L. Xiong extend this result to arbitrary Gorenstein projective modules.
However, the Gorenstein projective modules over algebras with radical cubic zero are quite complicated. Y. Yoshino studies a class of commutative local Artin algebras with radical cubic zero, over these algebras the simple module has no right approximations by the totally reflexive modules. They are not virtually Gorenstein algebras in the sense of .
The totally reflexive modules over S n = k /(X 2 , Y i Y j ) are studied by D. A. Rangel Tracy , where k is a field, n ≥ 2 and 1 ≤ i, j ≤ n. The main result gives a bijection from the reduced totally reflexive modules over S n to the finite-dimensional modules over the free algebra of n variables.
Inspired their works, we investigate the differential projective modules over Artin algebras with radical square zero.
Let k be a field and Q be a finite quiver. Denote by kQ the path algebra of Q. Let J be the arrow ideal of kQ, then the quotient algebra kQ/J 2 is an Artin algebra with radical square zero. Let Q op be the opposite quiver of Q.
We construct a "Koszul dual functor" F from the category of reduced differential projective kQ/J 2 -modules to the category of kQ op -modules.
Denote by Diff 0 (kQ/J 2 -Proj) the full subcategory of Diff(kQ/J 2 -Proj) formed by reduced differential projective kQ/J 2 -modules. We recall the abelian category kQ op -Mod of all kQ op -modules.
The following is the main result of this paper; see also , compare .
Theorem 1.1. Let k be a field and Q be a finite quiver. Then taking the top makes a functor F : Diff 0 (kQ/J 2 -Proj) → kQ op -Mod from the category of reduced differential projective kQ/J 2 -modules to the category of kQ op -modules. Moreover, (1) F is full, dense, and detects the isomorphisms; (2) F is exact and commutes with all small coproducts; (3) F vanishes on all null-homotopic maps; (4) For any M, N in Diff 0 (kQ/J 2 -Proj), there is an isomorphism The "Koszul dual functor" F has a good restriction on some full subcategories. More precisely, we have the following. (3) M is exact if and only if Ext n kQ op (kQ 0 , F (M )) = 0 for n = 0, 1. We give a compact generator for the homotopy category Diff(kQ/J 2 -Proj) as follows. Let C be the kQ/J 2 -module kQ/J 2 ⊗ kQ0 kQ op with a differential d given by d(y ⊗ z) = α∈Q1 yα ⊗ α * z for y ∈ kQ/J 2 , z ∈ kQ op . Here, α * ∈ Q op is the reversed arrow of α.
We have the following.
Theorem 1.3. The above C is a compact generator for Diff(kQ/J 2 -Proj).
Recall that a finite connected quiver Q is a basic cycle if the number of vertices is equal to the number of arrows in Q and all arrows form an oriented cycle.
The following gives a class of noncommutative algebras with radical cubic zero which are not virtually Gorenstein algebras; compare . Theorem 1.4. If Q is a finite connected quiver with oriented cycles and Q is not a basic cycle. Then the algebra kQ/J 2 of dual number over kQ/J 2 is not virtually Gorenstein.
The present paper is organized as follows. In Section 2 and Section 3, we recall some required facts about quivers and radical square zero algebras, respectively. In Section 4, we construct the functor F and prove Theorem 1.1. In Section 5, we study the restriction of F and give the proofs of Proposition 1.2 and Theorem 1.3. In Section 6, we study virtual Gorensteinness of algebras and prove Theorem 1.4.
Quivers and representations
In this section, we recall some facts about quivers and their representations. We refer to for more details.
A finite quiver Q is a quadruple (Q 0 , Q 1 ; s, t), where Q 0 is the finite set of vertices, Q 1 is the finite set of arrows, and s, t : Q 1 → Q 0 are the source map and the target map, respectively. Denote by e i the trivial path at i for i ∈ Q 0 , where s(e i ) = t(e i ) = i. A nontrivial path p is a sequence α l · · · α 2 α 1 of arrows, where l ≥ 1 and t(α i ) = s(α i+1 ) for 1 ≤ i ≤ l − 1. Here, s(p) = s(α 1 ) and t(p) = t(α l ). A nontrivial path p is called an oriented cycle if s(p) = t(p). A finite quiver Q is said to be acyclic if it has no oriented cycles.
Let kQ be the path algebra of Q over a field k. Recall that kQ is a hereditary algebra and kQ is finite dimensional if and only if Q is acyclic.
A representation of Q is a collection (M i , M α ) i∈Q0,α∈Q1 , where M i is a k-vector space and M α is a k-linear map from M s(α) to M t(α) . If M, N are representations of Q, a morphism from M to N is a collection Recall that the category of representations of Q is equivalent to the category of kQ-modules. We identify a kQ-module with the associated representation of Q.
Let J be the arrow ideal of kQ; it is the ideal generated by all arrows in Q. For an admissible ideal I of kQ satisfying J n ⊆ I ⊆ J 2 for some n ≥ 2, the quotient algebra kQ/I is finite dimensional over k. Recall that a kQ/I-module is a kQ-module M such that wM = 0 for every w ∈ I.
Projective modules for radical square zero algebras
Let k be a field and Q be a finite quiver. Recall that the unit element of the path algebra kQ is i∈Q0 e i , where e i the trivial path at vertex i.
Let J be arrow ideal of kQ, then kQ/J 2 is the radical square zero algebra of Q. In this section, we study some facts about the projective kQ/J 2 -modules.
Proof. Observe that (1)-(4) hold for the regular module over kQ/J 2 . Since M is projective over kQ/J 2 , it is a direct summand of direct sums of copies of kQ/J 2 . Since taking the radicals, kernels and images commute with all small coproducts, we infer that (1)-(4) also hold for M .
Then the map F is surjective. Since Ker F = Rad(M, N ), this gives rise to the desired short exact sequence.
Proof. We identify Rad(M, N ) with Hom kQ/J 2 (M, rad N ). Then the map F is well defined since rad 2 (N ) is zero. By Lemma 3.2 the map F is surjective and Ker F = 0. Then F is an isomorphism.
We recall Lemma 3.1(1)-(4). Denote by p α : (rad N ) t(α) → Im N α the natural projection and by i α : Im N α → (rad N ) t(α) the natural inclusion. Let us denote by N α : where α runs through all arrows terminating at i. One checks that G and G −1 are mutually inverse isomorphisms.
Therefore, the composite γ = G • F is an isomorphism.
Recall the opposite quiver Q op of Q. The underlying graph of Q op is the same as Q, but the orientations are all reversed. We denote by α * the reversed arrow in We need the following lemmas.
Proof. This follows from . Proof. Since the path algebra kQ op is hereditary, the projective dimension of X is no more than one. Then the statement follows from .
Construction of the "Koszul dual functor"
In this section, for a finite quiver Q we show that taking the top makes a full and dense functor from the category of reduced differential projective kQ/J 2 -modules to the category of kQ op -modules. Here, Q op is the opposite of Q.
Let M and N be differential projective kQ/J 2 -modules. A kQ/J 2 -module map f : M → N is said to be null homotopic if there is a kQ/J 2 -module map r : M → N such that f = rd + δr. Here, d and δ are the differentials of M and N , respectively. Denote by Hpt(M, N ) the subspace of Hom kQ/J 2 (M, N ) formed by null-homotopic maps.
Let M be a differential projective kQ/J 2 -module. Recall that M is said to be contractible if the identity map of M is null homotopic, and M is said to be reduced if M has no nonzero contractible direct summands.
We need the following.
(1) M is reduced if and only if the differential of M is a radical map.
(2) There exists a decomposition M = M ′ M ′′ such that M ′ is contractible and M ′′ is reduced. Moreover, this decomposition is unique up to isomorphism.
where d is the differential. Then (1) and (2) Let us recall some notations. We denote by Diff(kQ/J 2 -Proj) the category of all differential projective kQ/J 2 -modules. It is a Frobenius category and it admits all small products. Denote by Diff 0 (kQ/J 2 -Proj) the full subcategory consisting of reduced differential projective kQ/J 2 -modules.
Recall the homopopy category Diff(kQ/J 2 -Proj) of all differential projective kQ/J 2 -modules. The objects are all differential projective kQ/J 2 -modules. The morphisms are obtained from differential kQ/J 2 -module maps by factoring out the null homotopic maps.
Note that Diff 0 (kQ/J 2 -Proj) is not extension closed in Diff(kQ/J 2 -Proj). However, the homotopy categories of these two categories are equivalent.
Let (M, d) and (N, δ) be reduced differential projective kQ/J 2 -modules. Then we have inclusions In fact, since M and N are reduced, by Lemma 4.1(1) d and δ are radical maps. If f : M → N is radical, then f d = 0 = δf and thus f is a differential map. Then we obtain the inclusion on the right hand side. Similarly, the inclusion on the left hand side also holds.
We now prove the following key lemma. Here, we recall the maps F and γ from Lemma 3.3. " ⇐= " Since M is projective, there is a kQ/J 2 -module map r : M → N such that θ = F (r). Note that f is radical and γ(f ) = γ(rd + δr). Then f = rd + δr by Lemma 3.3. We infer that f is null homotopic.
We now construct the "Koszul dual functor" F from the category of reduced differential projective kQ/J 2 -modules to the category of kQ op -modules.
For any object (M, d) For a morphism f in Diff 0 (kQ/J 2 -Proj), recall that F (f ) is a kQ 0 -module map. It follows from Lemma 4.2(1) that F (f ) is a kQ op -module map.
Let σ be the algebra isomorphism of kQ op induced by σ(q) = (−1) l q for every path q in Q op , where l is the length of q. Note that σ 2 is the identity map.
For a kQ op -module X, let σ X be the twisted module of X. Here, σ X is equal to X as k-vector spaces, and the action • is given by w We see that σ ( σ X) is the same as X. However, the twisted module σ X and the original module X need not be isomorphic. The following is an example. Example 4.3. Let k be field and Q be the following quiver.
If the characteristic of k is not equal to 2, then the two kQ-modules X and σ X are not isomorphic.
Let M be a reduced differential projective kQ/J 2 -module. The shift Σ(M ) of M is the equal to M as kQ/J 2 -modules, while the differential of Σ(M ) is the negative of the differential of M . Observe that the kQ op -modules σ F (M ) and F Σ(M ) are isomorphic.
We have the following. Proof. (1) Let M and N be in Diff 0 (kQ/J 2 -Proj) and let g : F (M ) → F (N ) be a kQ op -module map. By Lemma 3.2 there is a kQ/J 2 -module map f : M → N such that g = F (f ). Since g is a kQ op -module map, it follows from Lemma 4.2(1) that f is a differential map . This shows that the functor F is full. For a kQ op -module X, set G(X) be the kQ/J 2 -module kQ/J 2 ⊗ kQ0 X with a differential d given by for y i ∈ (kQ/J 2 )e i and x i ∈ X i . Here, we recall the target t(α) of the arrow α.
Note that G(X) is a reduced differential projective kQ/J 2 -module and F (G(X)) is isomorphic to X. It follows that the functor F is dense.
It remains to show that F detects the isomorphisms. Suppose that f : M → N is a morphism in Diff 0 (kQ/J 2 -Proj) with F (f ) being an isomorphism.
Let g be the inverse of F (f ). Since N is projective, there exists a morphism h : Then hf and f h are isomorphisms. It follows that f is an isomorphism.
(2) For every reduced differential projective kQ/J 2 -module M , recall that F (M ) is isomorphic to kQ 0 ⊗ kQ/J 2 M as k-vector spaces. It follows that F is exact and commutes with all small coproducts.
(3) Since every null-homotopic map is radical and F vanishes on all radical maps, it follows that F vanishes on all null-homotopic maps.
(4) Let M and N be in Diff 0 (kQ/J 2 -Proj). Since the functor F is full by (1) Corollary 4.6. The functor F gives a bijection from the isoclasses of objects in the homotopy category of differential projective kQ/J 2 -modules to the isoclasses of objects in the category of kQ op -modules, which carries indecomposable objects to indecomposable objects.
Compact generator
Let k be a field and Q be a finite quiver. Recall the opposite quiver Q op and the radical square algebra kQ/J 2 of Q.
Let C be the kQ/J 2 -module kQ/J 2 ⊗ kQ0 kQ op with a differential d given by for y ∈ kQ/J 2 and z ∈ kQ op . Here, we recall that α * is the reversed arrow of α.
Observe that C is a reduced differential projective kQ/J 2 -module. Recall the functor F from the previous section. It is routine to show that F (C) is isomorphic to the regular module over kQ op .
Recall the homotopy category Diff(kQ/J 2 -Proj) of differential projective kQ/J 2module. We will later show C is a compact generator for this triangulated category.
Let M be a differential projective kQ/J 2 -module. By Lemma 4.1(2) there exists a decomposition M = M ′ M ′′ such that M ′ is contractible and M ′′ is reduced. Recall that the cohomology group H(M ) of M is Ker d/ Im d, where d is differential of M . We also recall that M is said to be exact if its cohomology group is zero. Proof. Note that H(M ) is isomorphic to Diff(kQ/J 2 -Proj)(kQ/J 2 , M ). Here we denote by kQ/J 2 the differential module kQ/J 2 with vanishing differential. Then (1) and (2) follow from Theorem 4.5(4).
The "Koszul dual functor" F has a good restriction on some full subcategories. More precisely, we have the following result. (2) " =⇒ " Assume that M is compact. Let {Y λ } λ∈L be a set of kQ op -modules. Since the functor F is dense by Theorem 4.5(1), every Y λ is isomorphic to F (T λ ) for some reduced differential projective kQ/J 2 -module T λ . By Theorem 4.5(2) and (4) there are isomorphisms and It follows from Lemma 3.5 that F (M ) is finitely presented. " ⇐= " Assume that X = F (M ) is a finitely presented kQ op -module. Let us take a set {T λ } λ∈L of differential projective kQ/J 2 -modules. By Lemma 4.1(2) we have T λ = T ′ λ T ′′ λ such that T ′ λ is contractible and T ′′ λ is reduced. By Lemma 3.5 and Theorem 4.5(4) we have isomorphisms Then M is compact in Diff(kQ/J 2 -Proj).
We have two full subcategories of T = Diff(kQ/J 2 -Proj). Denote by T c is the full subcategory formed by compact objects and by T f d is the full subcategory formed by objects M such that its reduced part M ′′ is finite dimensional. Corollary 5.4. The bijection in Corollary 4.6 carries finite-dimensional objects to finite-dimensional objects and carries compact objects to finitely presented objects.
In particular, if we take Q to be the n-loop quiver with n ≥ 2, then the bijection between finite-dimensional objects has already studied in .
Let T be a triangulated category admitting all small coproducts. An object S in T is said to be compact if for any set {T λ } λ∈L of objects in T , the natural monomorphism is an epimorphism (and thus isomorphism).
Recall that a triangulated category T is said to be compactly generated if T admits all small coproducts, and there exists a set S of objects in T such that (1) Given T ∈ T , if T (Σ n S, T ) = 0 for every S ∈ S and n ∈ Z, then T ≃ 0; (2) Every object S ∈ S is compact. Here, Σ denotes the translation functor of T . The set S is called a compact generating set for T . In particular, if S = {S 0 } is a singleton, then S 0 is called a compact generator for T .
We now prove that C is a compact generator for Diff(kQ/J 2 -Proj).
Theorem 5.5. The homotopy category Diff(kQ/J 2 -Proj) is compactly generated, where C is a compact generator for it.
Take a set {T λ } λ∈L of objects in Diff(kQ/J 2 -Proj). Then Lemma 4.1(2) yields that T λ = T ′ λ T ′′ λ , where T ′ λ is contractible and T ′′ λ is reduced. By Lemma 5.1(1) there are isomorphisms Recall from Theorem 4.5(2) that F commutes with all small coproducts. It follows that C is a compact object in Diff(kQ/J 2 -Proj). Therefore C is a compact generator for Diff(kQ/J 2 -Proj).
Virtually Gorenstein algebras
In this section, we study the virtue Gorensteiness of algebras. Here, we recall the notion of Gorenstein projective modules and Gorenstein injective modules; see for more details.
Given a ring Λ, a complex P • of projective Λ-modules is said to be totally acyclic if P • is acyclic and Hom Λ (P • , T ) is acyclic for every projective Λ-module T . A Λmodule M is said to be Gorenstein projective if there exists a totally acyclic complex P • of projective Λ-modules such that M is isomorphic to Coker(d −1 : P −1 → P 0 ). The complex P • is called a complete projective resolution of M .
Dually, a complex I • of injective Λ-modules is said to be totally acyclic if I • is acyclic and Hom Λ (T, I • ) is acyclic for every injective Λ-module T . A Λ-module M is said to be Gorenstein injective if there exists a totally acyclic complex I • of injective Λ-modules such that M is isomorphic to Ker(d 0 : I 0 → I 1 ). The complex I • is called a complete injective resolution of M .
Denote by Λ-Mod the category of all Λ-modules. Let us denote by Λ-Proj the full subcategory of projective Λ-modules and denote by Λ-GProj the full subcategory of Gorenstein projective Λ-modules.
We need the following facts; see for more details.
(2) The stable category Λ-GProj is a triangulated category. Let Λ = Λ / T 2 be the ring of dual numbers over Λ. Note that differential modules over Λ are just modules over Λ . In particular, if Λ is an algebra over a field k, then the algebra Λ is isomorphic to the tensor product Λ ⊗ k k of algebras. Here, we recall that k = k / T 2 is the algebra of dual numbers over k; it is a selfinjective algebra.
By a differential Λ-module (M, d) is Gorenstein projective if and only if the underlying Λ-module M is Gorenstein projective. Then we know that every differential projective Λ-module is Gorenstein projective since every projective module is Gorenstein projective.
Let Λ be an Artin algebra. Recall that Λ is said to Gorenstein if the injective dimension of Λ and the injective dimension of Λ op are both finite. Algebras of finite global dimension and selfinjective algebras are Gorenstein algebras.
We also recall that Λ is said to be virtually Gorenstein if for every Λ-module M , the functor Ext 1 Λ (−, M ) vanishes on all Gorenstein projective Λ-modules if and only if the functor Ext 1 Λ (M, −) vanishes on all Gorenstein injective Λ-modules. Algebras of finite representation type and Gorenstein algebras are virtually Gorenstein algebras. Examples of non-virtually Gorenstein algebras can be founded in .
We need the following.
Lemma 6.1. Let Λ and Γ be finite-dimensional algebras over a field k.
(1) Λ is virtually Gorenstein if and only if every reduced compact object in the stable category Λ-GProj is finite dimensional. Let k be a field and Q be a finite quiver. We investigate the Gorenstein projective differential modules over the radical square zero algebra kQ/J 2 of Q. Recall that a finite connected quiver Q is a basic cycle if the number of vertices is equal to the number of arrows in Q and all arrows form an oriented cycle. Proposition 6.2. Let k be a field and Q be a finite connected quiver. |
package zemberek.embedding;
import com.google.common.collect.Lists;
import java.io.IOException;
import java.nio.file.Path;
import java.nio.file.Paths;
import java.util.ArrayList;
import java.util.Collections;
import java.util.HashMap;
import java.util.HashSet;
import java.util.LinkedHashSet;
import java.util.List;
import java.util.Locale;
import java.util.Map;
import java.util.Scanner;
import java.util.Set;
import java.util.stream.Collectors;
import zemberek.core.ScoredItem;
import zemberek.core.logging.Log;
import zemberek.core.turkish.TurkishAlphabet;
import zemberek.morphology.TurkishMorphology;
import zemberek.morphology.analysis.SentenceAnalysis;
import zemberek.morphology.analysis.SentenceWordAnalysis;
import zemberek.morphology.analysis.SingleAnalysis;
import zemberek.morphology.analysis.WordAnalysis;
public class DistanceBasedStemmer {
static Locale TR = new Locale("tr");
static TurkishAlphabet alphabet = TurkishAlphabet.INSTANCE;
Map<String, WordVector> vectorMap;
TurkishMorphology morphology;
DistanceList distances;
public DistanceBasedStemmer(
Map<String, WordVector> vectorMap,
DistanceList distances,
TurkishMorphology morphology) throws IOException {
this.vectorMap = vectorMap;
this.morphology = morphology;
this.distances = distances;
}
public static DistanceBasedStemmer load(Path vector, Path distances, Path vocabFile)
throws IOException {
Log.info("Loading vector file.");
List<WordVector> wordVectors = WordVector.loadFromBinary(vector);
Map<String, WordVector> map = new HashMap<>(wordVectors.size());
for (WordVector wordVector : wordVectors) {
map.put(wordVector.word, wordVector);
}
Log.info("Loading distances.");
DistanceList experiment = DistanceList.readFromBinary(distances, vocabFile);
TurkishMorphology morphology = TurkishMorphology.createWithDefaults();
return new DistanceBasedStemmer(map, experiment, morphology);
}
static String normalize(String input) {
String s = alphabet.normalize(input.toLowerCase(TR).replaceAll("'", ""));
return alphabet.normalizeCircumflex(s);
}
public static void main(String[] args) throws IOException {
Path root = Paths.get("/home/ahmetaa/data/vector");
Path binVectorFile = root.resolve("model-large-min10.vec.bin");
Path vocabFile = root.resolve("vocab-large-min10.bin");
Path distanceFile = root.resolve("distance-large-min10.bin");
DistanceBasedStemmer experiment = DistanceBasedStemmer
.load(binVectorFile, distanceFile, vocabFile);
String input;
System.out.println("Enter sentence:");
Scanner sc = new Scanner(System.in);
input = sc.nextLine();
while (!input.equals("exit") && !input.equals("quit")) {
if (input.trim().length() == 0) {
Log.info(input + " cannot be found.");
input = sc.nextLine();
continue;
}
experiment.findStems(input);
input = sc.nextLine();
}
}
public float distance(String a, String b) {
if (!vectorMap.containsKey(a) || !vectorMap.containsKey(b)) {
return 0;
}
return vectorMap.get(a).cosDistance(vectorMap.get(b));
}
public float totalDistance(String a, List<String> b) {
float score = 0;
for (String s : b) {
score += distance(a, s);
}
return score;
}
public void findStems(String str) {
str = "<s> <s> " + str + " </s> </s>";
SentenceAnalysis analysis = morphology.analyzeAndDisambiguate(str);
List<SentenceWordAnalysis> swaList = analysis.getWordAnalyses();
for (int i = 2; i < analysis.size() - 2; i++) {
SentenceWordAnalysis swa = swaList.get(i);
String s = swaList.get(i).getWordAnalysis().getInput();
List<String> bigramContext = Lists.newArrayList(
normalize(swaList.get(i - 1).getWordAnalysis().getInput()),
normalize(swaList.get(i - 2).getWordAnalysis().getInput()),
normalize(swaList.get(i + 1).getWordAnalysis().getInput()),
normalize(swaList.get(i + 2).getWordAnalysis().getInput()));
List<String> unigramContext = Lists.newArrayList(
normalize(swaList.get(i - 1).getWordAnalysis().getInput()),
normalize(swaList.get(i + 1).getWordAnalysis().getInput()));
Set<String> stems = new HashSet<>();
WordAnalysis wordResults = swa.getWordAnalysis();
stems.addAll(
wordResults.stream().map(a -> normalize(a.getDictionaryItem().lemma)).collect(Collectors.toList()));
List<ScoredItem<String>> scores = new ArrayList<>();
for (String stem : stems) {
if (!distances.containsWord(stem)) {
Log.info("Cannot find %s in vocab.", stem);
continue;
}
List<WordDistances.Distance> distances = this.distances.getDistance(stem);
float score = totalDistance(stem, bigramContext);
int k = 0;
for (WordDistances.Distance distance : distances) {
/* if (s.equals(distance.word)) {
continue;
}*/
score += distance(s, distance.word);
if (k++ == 10) {
break;
}
}
scores.add(new ScoredItem<>(stem, score));
}
Collections.sort(scores);
Log.info("%n%s : ", s);
for (ScoredItem<String> score : scores) {
Log.info("Lemma = %s Score = %.7f", score.item, score.score);
}
}
Log.info("==== Z disambiguation result ===== ");
for (SentenceWordAnalysis a : analysis) {
Log.info("%n%s : ", a.getWordAnalysis().getInput());
LinkedHashSet<String> items = new LinkedHashSet<>();
for (SingleAnalysis wa : a.getWordAnalysis()) {
items.add(wa.getDictionaryItem().toString());
}
for (String item : items) {
Log.info("%s", item);
}
}
}
}
|
<gh_stars>10-100
package io.opensphere.mantle.data.util;
import java.io.File;
import java.net.URI;
import io.opensphere.core.util.lang.StringUtilities;
/**
* Layer utilities.
*/
public final class LayerUtils
{
/** This probably isn't comprehensive, but it's a start. */
private static final char[] DISALLOWED_LAYER_NAME_CHARS = new char[] { '(', ')' };
/**
* Gets a layer name from the given URI.
*
* @param uri the URI
* @return the layer name
*/
public static String getLayerName(URI uri)
{
String layerName;
try
{
File file = new File(uri);
layerName = file.getName();
}
catch (IllegalArgumentException e)
{
String path = uri.getPath();
int lastSep = path.lastIndexOf('/');
lastSep = lastSep < 0 ? 0 : lastSep;
int dotIndex = path.lastIndexOf('.');
int dot = dotIndex > lastSep ? dotIndex : path.length();
layerName = path.substring(lastSep + 1, dot);
}
// Remove file extension
if (layerName.indexOf('.') != -1)
{
layerName = layerName.split("\\.")[0];
}
// Replace disallowed characters
char replacementChar = '_';
for (char ch : DISALLOWED_LAYER_NAME_CHARS)
{
layerName = layerName.replace(ch, replacementChar);
}
layerName = StringUtilities.trim(layerName, replacementChar);
return layerName;
}
/**
* Gets the disallowedLayerNameChars.
*
* @return the disallowedLayerNameChars
*/
public static char[] getDisallowedLayerNameChars()
{
return DISALLOWED_LAYER_NAME_CHARS.clone();
}
/** Disallow instantiation. */
private LayerUtils()
{
}
}
|
March Madness 2017 is a month-long competition on PopCrush to determine the best of the best of South Korean boy bands and girl groups.
This round is now over! Vote for TVXQ in the semi-finals here !
The battle begins today between TVXQ and BIGBANG, two long established acts on the K-pop scene now going head-to-head in the first round of PopCrush's 2017 March Madness series.
With Yunho and Changmin's mandatory military service ending in 2017, TVXQ is plotting what is expected to be a massive comeback to the K-pop scene this year. Their last studio album, Rise as God , was released in 2015.
BIGBANG, on the other hand, are going harder than ever over one decade since their 2006 debut, having just released their third full-length studio album Made in December of 2016, featuring smash-hit singles "Fxxk It" and "Last Dance." They're also planning a special fan meeting event throughout Japan later in 2017.
The battle starts now: place your vote between TVXQ and BIGBANG. This round ends on March 10.
Join the conversation on social media! Use #PCMarchMadness to discuss this year's competition.
TVXQ and BIGBANG Over the Years: |
/**
* Registers all defined command in the given {@link Commands} object.
*/
public void register(Commands commands) {
Method preExecute = getPreExecuteMethod(commands);
String cmdPrefix = "";
if (commands.getClass().isAnnotationPresent(NestedCommands.class)) {
cmdPrefix = registerNestedCommand(commands, preExecute);
}
for (Method method : commands.getClass().getDeclaredMethods()) {
if (!method.isAnnotationPresent(Command.class)) {
continue;
}
Command cmdAnnotation = method.getAnnotation(Command.class);
validateCommand(method, false);
Validate.notEmpty(cmdAnnotation.name());
String cmdName = cmdPrefix + cmdAnnotation.name();
PluginCommand command = plugin.getCommand(cmdName);
Validate.notNull(command, String.format("Command '%s' does not exist", cmdName));
CommandExecutor executor = new MethodCommandExecutor(messages, commands, preExecute, method, cmdAnnotation);
setCommand(command, executor);
}
} |
/**
* Append a slice of a CharSequence to this adapter.
*
* @param value A CharSequence instance to append to this adapter.
* @param offset The index of the first char in value to include in the proto-string.
* @param length The length of the proto-String in chars.
* @return This adapter.
*/
public final CharSequenceAdapterBuilder append(final CharSequence value, final int offset, final int length) {
if (length > 0) {
ensureSpace(length);
cachedHashCode = 0;
for (int ci = 0; ci < length; ++ci) {
storage[used++] = value.charAt(offset + ci);
}
}
return this;
} |
package sweetiebot
// RateLimit checks the rate limit, returns false if it was violated, and updates the rate limit
func RateLimit(prevtime *int64, interval int64, curtime int64) bool {
d := (*prevtime) // perform a read so it doesn't change on us
if curtime-d > interval {
*prevtime = curtime // CompareAndSwapInt64 doesn't work on x86 so we just assume this worked
return true
}
return false
}
|
Multi-objective Optimization of Hydrogen Production in Hybrid Renewable Energy Systems
The proposed multi-objective optimized hybrid renewable energy system consists of solar panels, wind turbines, a proton exchange membrane (PEM) electrolyzer for hydrogen production, and an absorption cooling system for the summer season. This study is conducted in two locations in Egypt and Saudi Arabia as the case studies. The study presents a thermodynamic analysis to investigate the system performance. In addition, an optimization-based analysis is conducted using NSGA-II algorithm to determine optimal values of the decision variables. The hybrid renewable system can operate in a significant performance with water mass flow rate of 1.8 kg/s to produce hydrogen with a mass flow rate of 0.2 kg/s, and ammonia mass flow rate of about 0.2 kg/s to produce cooling load between 40 and 120 kW with energy and exergy efficiency of more than 65%. |
<gh_stars>0
import {Injectable} from '@angular/core';
import {HttpClient} from '@angular/common/http';
import {map} from 'rxjs/operators';
@Injectable ()
export class ConfigService {
private config: Object;
private confPromise: Promise<Object>;
constructor (private readonly http: HttpClient) { }
getConfPromise (): Promise<Object> {
if (!this.confPromise) {
this.confPromise = new Promise ((resolve) => {
const url = 'config.json?' + new Date().getTime();
this.http.get (url).pipe(map (res => res))
.subscribe (config => {
this.config = config;
resolve ();
});
});
}
return this.confPromise;
}
/** method for getting config by key inside component*/
getConfigByKey (key: string): any | undefined {
if(!this.config) {
this.getConfPromise().then((config) => {
this.config = config;
return this.getValueFromObj(this.config, key);
});
} else {
return this.getValueFromObj(this.config, key);
}
}
private getValueFromObj(obj, key): any|undefined {
const arr = key.split('.');
const k = arr[0];
arr.shift();
const next = arr.join('.');
if (next !== '') {
return this.getValueFromObj (obj[k], next);
} else {
return obj[k];
}
}
/** method for getting config by key inside service*/
public getCongfigByKeyPromise (key: string): Promise<string> {
return new Promise<string>((resolve) => {
this.getConfPromise().then( () => {
resolve(this.getConfigByKey(key));
});
});
}
}
|
module StackSet () where
import Data.Set (Set(..))
data LL a = Nil | Cons { head :: a, tail :: LL a }
{-@ data LL a = Nil | Cons { head :: a
, tail :: {v: LL a | not (Set_mem head (elts v)) } }
@-}
{-@ measure elts :: LL a -> (Set a)
elts (Nil) = {v | (Set_emp v)}
elts (Cons x xs) = {v | v = (Set_cup (Set_sng x) (elts xs)) }
@-}
{-@ predicate Disjoint X Y = (Set_emp (Set_cap (elts X) (elts Y))) @-}
{-@ predicate NotIn X Y = not (Set_mem X (elts Y)) @-}
ll2 = Cons x0 (Cons x1 (Cons x2 Nil))
where x0 :: Int
x0 = 0
x1 = 1
x2 = 2
{-@ data Stack a = St { focus :: a
, up :: {vu: LL a | (NotIn focus vu) }
, down :: {vd: LL a | ((NotIn focus vd) && (Disjoint up vd)) }
}
@-}
data Stack a = St { focus :: !a
, up :: !(LL a)
, down :: !(LL a)
}
{-@ fresh :: a -> Stack a @-}
fresh x = St x Nil Nil
{-@ moveUp :: Stack a -> Stack a @-}
moveUp (St x (Cons y ys) zs) = St y ys (Cons x zs)
moveUp s = s
{-@ moveDn :: Stack a -> Stack a @-}
moveDn (St x ys (Cons z zs)) = St z (Cons x ys) zs
moveDn s = s
|
Subsets and Splits
No saved queries yet
Save your SQL queries to embed, download, and access them later. Queries will appear here once saved.