# copyright 2003-2014 LOGILAB S.A. (Paris, FRANCE), all rights reserved.# contact http://www.logilab.fr/ -- mailto:contact@logilab.fr## This file is part of CubicWeb.## CubicWeb is free software: you can redistribute it and/or modify it under the# terms of the GNU Lesser General Public License as published by the Free# Software Foundation, either version 2.1 of the License, or (at your option)# any later version.## CubicWeb is distributed in the hope that it will be useful, but WITHOUT# ANY WARRANTY; without even the implied warranty of MERCHANTABILITY or FITNESS# FOR A PARTICULAR PURPOSE. See the GNU Lesser General Public License for more# details.## You should have received a copy of the GNU Lesser General Public License along# with CubicWeb. If not, see <http://www.gnu.org/licenses/>."""Defines the central class for the CubicWeb RQL server: the repository.The repository is an abstraction allowing execution of rql queries againstdata sources. Most of the work is actually done in helper classes. Therepository mainly:* brings these classes all together to provide a single access point to a cubicweb instance.* handles session management"""from__future__importprint_function__docformat__="restructuredtext en"importthreadingimportQueuefromwarningsimportwarnfromitertoolsimportchainfromtimeimporttime,localtime,strftimefromcontextlibimportcontextmanagerfromlogilab.common.decoratorsimportcached,clear_cachefromlogilab.common.deprecationimportdeprecatedfromyamsimportBadSchemaDefinitionfromrql.utilsimportrqlvar_makerfromcubicwebimport(CW_MIGRATION_MAP,QueryError,UnknownEid,AuthenticationError,ExecutionError,BadConnectionId,ValidationError,Unauthorized,UniqueTogetherError,onevent,ViolatedConstraint)fromcubicwebimportcwvreg,schema,serverfromcubicweb.serverimportShuttingDown,utils,hook,querier,sourcesfromcubicweb.server.sessionimportSession,InternalManagerNO_CACHE_RELATIONS=set([('owned_by','object'),('created_by','object'),('cw_source','object'),])defprefill_entity_caches(entity):cnx=entity._cw# prefill entity relation cachesforrschemainentity.e_schema.subject_relations():rtype=str(rschema)ifrtypeinschema.VIRTUAL_RTYPESor(rtype,'subject')inNO_CACHE_RELATIONS:continueifrschema.final:entity.cw_attr_cache.setdefault(rtype,None)else:entity.cw_set_relation_cache(rtype,'subject',cnx.empty_rset())forrschemainentity.e_schema.object_relations():rtype=str(rschema)ifrtypeinschema.VIRTUAL_RTYPESor(rtype,'object')inNO_CACHE_RELATIONS:continueentity.cw_set_relation_cache(rtype,'object',cnx.empty_rset())defdel_existing_rel_if_needed(cnx,eidfrom,rtype,eidto):"""delete existing relation when adding a new one if card is 1 or ? have to be done once the new relation has been inserted to avoid having an entity without a relation for some time this kind of behaviour has to be done in the repository so we don't have hooks order hazardness """# skip that if integrity explicitly disabledifnotcnx.is_hook_category_activated('activeintegrity'):returnrdef=cnx.rtype_eids_rdef(rtype,eidfrom,eidto)card=rdef.cardinality# one may be tented to check for neweids but this may cause more than one# relation even with '1?' cardinality if thoses relations are added in the# same transaction where the entity is being created. This never occurs from# the web interface but may occurs during test or dbapi connection (though# not expected for this). So: don't do it, we pretend to ensure repository# consistency.## notes:# * inlined relations will be implicitly deleted for the subject entity# * we don't want read permissions to be applied but we want delete# permission to be checkedifcard[0]in'1?':withcnx.security_enabled(read=False):cnx.execute('DELETE X %s Y WHERE X eid %%(x)s, ''NOT Y eid %%(y)s'%rtype,{'x':eidfrom,'y':eidto})ifcard[1]in'1?':withcnx.security_enabled(read=False):cnx.execute('DELETE X %s Y WHERE Y eid %%(y)s, ''NOT X eid %%(x)s'%rtype,{'x':eidfrom,'y':eidto})defpreprocess_inlined_relations(cnx,entity):"""when an entity is added, check if it has some inlined relation which requires to be extrated for proper call hooks """relations=[]activeintegrity=cnx.is_hook_category_activated('activeintegrity')eschema=entity.e_schemaforattrinentity.cw_edited:rschema=eschema.subjrels[attr]ifnotrschema.final:# inlined relationvalue=entity.cw_edited[attr]relations.append((attr,value))cnx.update_rel_cache_add(entity.eid,attr,value)rdef=cnx.rtype_eids_rdef(attr,entity.eid,value)ifrdef.cardinality[1]in'1?'andactiveintegrity:withcnx.security_enabled(read=False):cnx.execute('DELETE X %s Y WHERE Y eid %%(y)s'%attr,{'x':entity.eid,'y':value})returnrelationsclassNullEventBus(object):defpublish(self,msg):passdefadd_subscription(self,topic,callback):passdefstart(self):passdefstop(self):passclassRepository(object):"""a repository provides access to a set of persistent storages for entities and relations """def__init__(self,config,tasks_manager=None,vreg=None):self.config=configifvregisNone:vreg=cwvreg.CWRegistryStore(config)self.vreg=vregself._tasks_manager=tasks_managerself.app_instances_bus=NullEventBus()self.info('starting repository from %s',self.config.apphome)# dictionary of opened sessionsself._sessions={}# list of functions to be called at regular interval# list of running threadsself._running_threads=[]# initial schema, should be build or replaced latterself.schema=schema.CubicWebSchema(config.appid)self.vreg.schema=self.schema# until actual schema is loaded...# shutdown flagself.shutting_down=False# sources (additional sources info in the system database)self.system_source=self.get_source('native','system',config.system_source_config.copy())self.sources_by_uri={'system':self.system_source}# querier helper, need to be created after sources initializationself.querier=querier.QuerierHelper(self,self.schema)# cache eid -> (type, extid, actual source)self._type_source_cache={}# cache extid -> eidself._extid_cache={}# open some connection setsifconfig.init_cnxset_pool:self.init_cnxset_pool()# the hooks managerself.hm=hook.HooksManager(self.vreg)# registry hook to fix user class on registry reload@onevent('after-registry-reload',self)deffix_user_classes(self):# After registry reload the 'CWUser' class used for CWEtype# changed. So any existing user object have a different class than# the new loaded one. We are hot fixing this.usercls=self.vreg['etypes'].etype_class('CWUser')forsessioninself._sessions.itervalues():ifnotisinstance(session.user,InternalManager):session.user.__class__=userclsdefinit_cnxset_pool(self):"""should be called bootstrap_repository, as this is what it does"""config=self.configself._cnxsets_pool=Queue.Queue()# 0. init a cnxset that will be used to fetch bootstrap information from# the databaseself._cnxsets_pool.put_nowait(self.system_source.wrapped_connection())# 1. set used cubesifconfig.creatingornotconfig.read_instance_schema:config.bootstrap_cubes()else:self.set_schema(self.config.load_bootstrap_schema(),resetvreg=False)config.init_cubes(self.get_cubes())# 2. load schemaifconfig.quick_start:# quick start: only to get a minimal repository to get cubes# information (eg dump/restore/...)## restrict appobject_path to only load hooks and entity classes in# the registryconfig.cube_appobject_path=set(('hooks','entities'))config.cubicweb_appobject_path=set(('hooks','entities'))# limit connections pool to 1config['connections-pool-size']=1ifconfig.quick_startorconfig.creatingornotconfig.read_instance_schema:# load schema from the file systemifnotconfig.creating:self.info("set fs instance'schema")self.set_schema(config.load_schema(expand_cubes=True))else:# normal start: load the instance schema from the databaseself.info('loading schema from the repository')self.set_schema(self.deserialize_schema())# 3. initialize data sourcesifconfig.creating:# call init_creating so that for instance native source can# configurate tsearch according to postgres versionself.system_source.init_creating()else:self.init_sources_from_database()if'CWProperty'inself.schema:self.vreg.init_properties(self.properties())# 4. close initialization connection set and reopen fresh ones for# proper initializationself._get_cnxset().close(True)self.cnxsets=[]# list of available cnxsets (can't iterate on a Queue)foriinxrange(config['connections-pool-size']):self.cnxsets.append(self.system_source.wrapped_connection())self._cnxsets_pool.put_nowait(self.cnxsets[-1])# internals ###############################################################definit_sources_from_database(self):self.sources_by_eid={}ifself.config.quick_start \ornot'CWSource'inself.schema:# # 3.10 migrationself.system_source.init_creating()returnwithself.internal_cnx()ascnx:# FIXME: sources should be ordered (add_entity priority)forsourceentincnx.execute('Any S, SN, SA, SC WHERE S is_instance_of CWSource, ''S name SN, S type SA, S config SC').entities():ifsourceent.name=='system':self.system_source.eid=sourceent.eidself.sources_by_eid[sourceent.eid]=self.system_sourceself.system_source.init(True,sourceent)continueself.add_source(sourceent)def_clear_planning_caches(self):clear_cache(self,'source_defs')defadd_source(self,sourceent):try:source=self.get_source(sourceent.type,sourceent.name,sourceent.host_config,sourceent.eid)exceptRuntimeError:ifself.config.repairing:self.exception('cant setup source %s, skipped',sourceent.name)returnraiseself.sources_by_eid[sourceent.eid]=sourceself.sources_by_uri[sourceent.name]=sourceifself.config.source_enabled(source):# call source's init method to complete their initialisation if# needed (for instance looking for persistent configuration using an# internal session, which is not possible until connections sets have been# initialized)source.init(True,sourceent)else:source.init(False,sourceent)self._clear_planning_caches()defremove_source(self,uri):source=self.sources_by_uri.pop(uri)delself.sources_by_eid[source.eid]self._clear_planning_caches()defget_source(self,type,uri,source_config,eid=None):# set uri and type in source config so it's available through# source_defs()source_config['uri']=urisource_config['type']=typereturnsources.get_source(type,source_config,self,eid)defset_schema(self,schema,resetvreg=True):self.info('set schema %s%#x',schema.name,id(schema))ifresetvreg:# trigger full reload of all appobjectsself.vreg.set_schema(schema)else:self.vreg._set_schema(schema)self.querier.set_schema(schema)forsourceinself.sources_by_uri.itervalues():source.set_schema(schema)self.schema=schemadefdeserialize_schema(self):"""load schema from the database"""fromcubicweb.server.schemaserialimportdeserialize_schemaappschema=schema.CubicWebSchema(self.config.appid)self.debug('deserializing db schema into %s%#x',appschema.name,id(appschema))withself.internal_cnx()ascnx:try:deserialize_schema(appschema,cnx)exceptBadSchemaDefinition:raiseexceptExceptionasex:importtracebacktraceback.print_exc()raiseException('Is the database initialised ? (cause: %s)'%ex)returnappschemadef_prepare_startup(self):"""Prepare "Repository as a server" for startup. * trigger server startup hook, * register session clean up task. """ifnot(self.config.creatingorself.config.repairingorself.config.quick_start):# call instance level initialisation hooksself.hm.call_hooks('server_startup',repo=self)# register a task to cleanup expired sessionself.cleanup_session_time=self.config['cleanup-session-time']or60*60*24assertself.cleanup_session_time>0cleanup_session_interval=min(60*60,self.cleanup_session_time/3)assertself._tasks_managerisnotNone,"This Repository is not intended to be used as a server"self._tasks_manager.add_looping_task(cleanup_session_interval,self.clean_sessions)defstart_looping_tasks(self):"""Actual "Repository as a server" startup. * trigger server startup hook, * register session clean up task, * start all tasks. XXX Other startup related stuffs are done elsewhere. In Repository XXX __init__ or in external codes (various server managers). """self._prepare_startup()assertself._tasks_managerisnotNone,"This Repository is not intended to be used as a server"self._tasks_manager.start()deflooping_task(self,interval,func,*args):"""register a function to be called every `interval` seconds. looping tasks can only be registered during repository initialization, once done this method will fail. """assertself._tasks_managerisnotNone,"This Repository is not intended to be used as a server"self._tasks_manager.add_looping_task(interval,func,*args)defthreaded_task(self,func):"""start function in a separated thread"""utils.RepoThread(func,self._running_threads).start()#@lockeddef_get_cnxset(self):try:returnself._cnxsets_pool.get(True,timeout=5)exceptQueue.Empty:raiseException('no connections set available after 5 secs, probably either a ''bug in code (too many uncommited/rolled back ''connections) or too much load on the server (in ''which case you can try to set a bigger ''connections pool size)')def_free_cnxset(self,cnxset):self._cnxsets_pool.put_nowait(cnxset)defshutdown(self):"""called on server stop event to properly close opened sessions and connections """assertnotself.shutting_down,'already shutting down'ifnot(self.config.creatingorself.config.repairingorself.config.quick_start):# then, the system source is still availableself.hm.call_hooks('before_server_shutdown',repo=self)self.shutting_down=Trueself.system_source.shutdown()ifself._tasks_managerisnotNone:self._tasks_manager.stop()ifnot(self.config.creatingorself.config.repairingorself.config.quick_start):self.hm.call_hooks('server_shutdown',repo=self)forthreadinself._running_threads:self.info('waiting thread %s...',thread.getName())thread.join()self.info('thread %s finished',thread.getName())self.close_sessions()whilenotself._cnxsets_pool.empty():cnxset=self._cnxsets_pool.get_nowait()try:cnxset.close(True)exceptException:self.exception('error while closing %s'%cnxset)continuehits,misses=self.querier.cache_hit,self.querier.cache_misstry:self.info('rql st cache hit/miss: %s/%s (%s%% hits)',hits,misses,(hits*100)/(hits+misses))hits,misses=self.system_source.cache_hit,self.system_source.cache_missself.info('sql cache hit/miss: %s/%s (%s%% hits)',hits,misses,(hits*100)/(hits+misses))nocache=self.system_source.no_cacheself.info('sql cache usage: %s/%s (%s%%)',hits+misses,nocache,((hits+misses)*100)/(hits+misses+nocache))exceptZeroDivisionError:passdefcheck_auth_info(self,cnx,login,authinfo):"""validate authentication, raise AuthenticationError on failure, return associated CWUser's eid on success. """# iter on sources_by_uri then check enabled source since sources doesn't# contain copy based sourcesforsourceinself.sources_by_uri.itervalues():ifself.config.source_enabled(source)andsource.support_entity('CWUser'):try:returnsource.authenticate(cnx,login,**authinfo)exceptAuthenticationError:continueelse:raiseAuthenticationError('authentication failed with all sources')defauthenticate_user(self,cnx,login,**authinfo):"""validate login / password, raise AuthenticationError on failure return associated CWUser instance on success """eid=self.check_auth_info(cnx,login,authinfo)cwuser=self._build_user(cnx,eid)ifself.config.consider_user_stateand \notcwuser.cw_adapt_to('IWorkflowable').stateincwuser.AUTHENTICABLE_STATES:raiseAuthenticationError('user is not in authenticable state')returncwuserdef_build_user(self,cnx,eid):"""return a CWUser entity for user with the given eid"""cls=self.vreg['etypes'].etype_class('CWUser')st=cls.fetch_rqlst(cnx.user,ordermethod=None)st.add_eid_restriction(st.get_variable('X'),'x','Substitute')rset=cnx.execute(st.as_string(),{'x':eid})assertlen(rset)==1,rsetcwuser=rset.get_entity(0,0)# pylint: disable=W0104# prefetch / cache cwuser's groups and properties. This is especially# useful for internal sessions to avoid security insertionscwuser.groupscwuser.propertiesreturncwuser# public (dbapi) interface ################################################@deprecated("[3.19] use _cw.call_service('repo_stats')")defstats(self):# XXX restrict to managers session?"""Return a dictionary containing some statistics about the repository resources usage. This is a public method, not requiring a session id. This method is deprecated in favor of using _cw.call_service('repo_stats') """withself.internal_cnx()ascnx:returncnx.call_service('repo_stats')@deprecated("[3.19] use _cw.call_service('repo_gc_stats')")defgc_stats(self,nmax=20):"""Return a dictionary containing some statistics about the repository memory usage. This is a public method, not requiring a session id. nmax is the max number of (most) referenced object returned as the 'referenced' result """withself.internal_cnx()ascnx:returncnx.call_service('repo_gc_stats',nmax=nmax)defget_schema(self):"""Return the instance schema. This is a public method, not requiring a session id. """returnself.schemadefget_cubes(self):"""Return the list of cubes used by this instance. This is a public method, not requiring a session id. """versions=self.get_versions(not(self.config.creatingorself.config.repairingorself.config.quick_startorself.config.mode=='test'))cubes=list(versions)cubes.remove('cubicweb')returncubesdefget_option_value(self,option,foreid=None):"""Return the value for `option` in the configuration. This is a public method, not requiring a session id. `foreid` argument is deprecated and now useless (as of 3.19). """ifforeidisnotNone:warn('[3.19] foreid argument is deprecated',DeprecationWarning,stacklevel=2)# XXX we may want to check we don't give sensible informationreturnself.config[option]@cacheddefget_versions(self,checkversions=False):"""Return the a dictionary containing cubes used by this instance as key with their version as value, including cubicweb version. This is a public method, not requiring a session id. """fromlogilab.common.changelogimportVersionvcconf={}withself.internal_cnx()ascnx:forpk,versionincnx.execute('Any K,V WHERE P is CWProperty, P value V, P pkey K, ''P pkey ~="system.version.%"',build_descr=False):cube=pk.split('.')[-1]# XXX cubicweb migrationifcubeinCW_MIGRATION_MAP:cube=CW_MIGRATION_MAP[cube]version=Version(version)vcconf[cube]=versionifcheckversions:ifcube!='cubicweb':fsversion=self.config.cube_version(cube)else:fsversion=self.config.cubicweb_version()ifversion<fsversion:msg=('instance has %s version %s but %s ''is installed. Run "cubicweb-ctl upgrade".')raiseExecutionError(msg%(cube,version,fsversion))returnvcconf@cacheddefsource_defs(self):"""Return the a dictionary containing source uris as value and a dictionary describing each source as value. This is a public method, not requiring a session id. """sources={}# remove sensitive informationforuri,sourceinself.sources_by_uri.iteritems():sources[uri]=source.public_configreturnsourcesdefproperties(self):"""Return a result set containing system wide properties. This is a public method, not requiring a session id. """withself.internal_cnx()ascnx:# don't use cnx.execute, we don't want rset.req setreturnself.querier.execute(cnx,'Any K,V WHERE P is CWProperty,''P pkey K, P value V, NOT P for_user U',build_descr=False)@deprecated("[3.19] Use session.call_service('register_user') instead'")defregister_user(self,login,password,email=None,**kwargs):"""check a user with the given login exists, if not create it with the given password. This method is designed to be used for anonymous registration on public web site. """withself.internal_cnx()ascnx:cnx.call_service('register_user',login=login,password=password,email=email,**kwargs)cnx.commit()deffind_users(self,fetch_attrs,**query_attrs):"""yield user attributes for cwusers matching the given query_attrs (the result set cannot survive this method call) This can be used by low-privileges account (anonymous comes to mind). `fetch_attrs`: tuple of attributes to be fetched `query_attrs`: dict of attr/values to restrict the query """assertquery_attrsifnothasattr(self,'_cwuser_attrs'):cwuser=self.schema['CWUser']self._cwuser_attrs=set(str(rschema)forrschema,_eschemaincwuser.attribute_definitions()ifnotrschema.meta)cwuserattrs=self._cwuser_attrsforkinchain(fetch_attrs,query_attrs):ifknotincwuserattrs:raiseException('bad input for find_user')withself.internal_cnx()ascnx:varmaker=rqlvar_maker()vars=[(attr,varmaker.next())forattrinfetch_attrs]rql='Any %s WHERE X is CWUser, '%','.join(var[1]forvarinvars)rql+=','.join('X %s%s'%(var[0],var[1])forvarinvars)+','rset=cnx.execute(rql+','.join('X %s%%(%s)s'%(attr,attr)forattrinquery_attrs),query_attrs)returnrset.rowsdefnew_session(self,login,**kwargs):"""open a new session for a given user raise `AuthenticationError` if the authentication failed raise `ConnectionError` if we can't open a connection """cnxprops=kwargs.pop('cnxprops',None)# use an internal connectionwithself.internal_cnx()ascnx:# try to get a user objectuser=self.authenticate_user(cnx,login,**kwargs)session=Session(user,self,cnxprops)user._cw=user.cw_rset.req=sessionuser.cw_clear_relation_cache()self._sessions[session.sessionid]=sessionself.info('opened session %s for user %s',session.sessionid,login)withsession.new_cnx()ascnx:self.hm.call_hooks('session_open',cnx)# commit connection at this point in case write operation has been# done during `session_open` hookscnx.commit()returnsessiondefconnect(self,login,**kwargs):"""open a new session for a given user and return its sessionid """returnself.new_session(login,**kwargs).sessioniddefcheck_session(self,sessionid):"""raise `BadConnectionId` if the connection is no more valid, else return its latest activity timestamp. """returnself._get_session(sessionid).timestampdefclose(self,sessionid,txid=None,checkshuttingdown=True):"""close the session with the given id"""session=self._get_session(sessionid,txid=txid,checkshuttingdown=checkshuttingdown)# operation uncommited before close are rolled back before hook is calledwithsession.new_cnx()ascnx:self.hm.call_hooks('session_close',cnx)# commit connection at this point in case write operation has been# done during `session_close` hookscnx.commit()session.close()delself._sessions[sessionid]self.info('closed session %s for user %s',sessionid,session.user.login)# session handling ########################################################defclose_sessions(self):"""close every opened sessions"""forsessionidinlist(self._sessions):try:self.close(sessionid,checkshuttingdown=False)exceptException:# XXX BaseException?self.exception('error while closing session %s'%sessionid)defclean_sessions(self):"""close sessions not used since an amount of time specified in the configuration """mintime=time()-self.cleanup_session_timeself.debug('cleaning session unused since %s',strftime('%H:%M:%S',localtime(mintime)))nbclosed=0forsessioninself._sessions.values():ifsession.timestamp<mintime:self.close(session.sessionid)nbclosed+=1returnnbclosed@contextmanagerdefinternal_cnx(self):"""Context manager returning a Connection using internal user which have every access rights on the repository. Beware that unlike the older :meth:`internal_session`, internal connections have all hooks beside security enabled. """withSession(InternalManager(),self)assession:withsession.new_cnx()ascnx:cnx.user._cw=cnx# XXX remove when "vreg = user._cw.vreg"# hack in entity.py is gonewithcnx.security_enabled(read=False,write=False):yieldcnxdef_get_session(self,sessionid,txid=None,checkshuttingdown=True):"""return the session associated with the given session identifier"""ifcheckshuttingdownandself.shutting_down:raiseShuttingDown('Repository is shutting down')try:session=self._sessions[sessionid]exceptKeyError:raiseBadConnectionId('No such session %s'%sessionid)returnsession# data sources handling #################################################### * correspondance between eid and (type, source)# * correspondance between eid and local id (i.e. specific to a given source)deftype_and_source_from_eid(self,eid,cnx):"""return a tuple `(type, extid, actual source uri)` for the entity of the given `eid` """try:eid=int(eid)exceptValueError:raiseUnknownEid(eid)try:returnself._type_source_cache[eid]exceptKeyError:etype,extid,auri=self.system_source.eid_type_source(cnx,eid)self._type_source_cache[eid]=(etype,extid,auri)returnetype,extid,auridefclear_caches(self,eids):etcache=self._type_source_cacheextidcache=self._extid_cacherqlcache=self.querier._rql_cacheforeidineids:try:etype,extid,auri=etcache.pop(int(eid))# may be a string in some casesrqlcache.pop(('%s X WHERE X eid %s'%(etype,eid),),None)extidcache.pop(extid,None)exceptKeyError:etype=Nonerqlcache.pop(('Any X WHERE X eid %s'%eid,),None)self.system_source.clear_eid_cache(eid,etype)deftype_from_eid(self,eid,cnx):"""return the type of the entity with id <eid>"""returnself.type_and_source_from_eid(eid,cnx)[0]defquerier_cache_key(self,cnx,rql,args,eidkeys):cachekey=[rql]forkeyinsorted(eidkeys):try:etype=self.type_from_eid(args[key],cnx)exceptKeyError:raiseQueryError('bad cache key %s (no value)'%key)exceptTypeError:raiseQueryError('bad cache key %s (value: %r)'%(key,args[key]))cachekey.append(etype)# ensure eid is correctly typed in argsargs[key]=int(args[key])returntuple(cachekey)defextid2eid(self,source,extid,etype,cnx,insert=True,sourceparams=None):"""Return eid from a local id. If the eid is a negative integer, that means the entity is known but has been copied back to the system source hence should be ignored. If no record is found, ie the entity is not known yet: 1. an eid is attributed 2. the source's :meth:`before_entity_insertion` method is called to build the entity instance 3. unless source's :attr:`should_call_hooks` tell otherwise, 'before_add_entity' hooks are called 4. record is added into the system source 5. the source's :meth:`after_entity_insertion` method is called to complete building of the entity instance 6. unless source's :attr:`should_call_hooks` tell otherwise, 'before_add_entity' hooks are called """try:returnself._extid_cache[extid]exceptKeyError:passeid=self.system_source.extid2eid(cnx,extid)ifeidisnotNone:self._extid_cache[extid]=eidself._type_source_cache[eid]=(etype,extid,source.uri)returneidifnotinsert:return# no link between extid and eid, create one# write query, ensure connection's mode is 'write' so connections# won't be released until commit/rollbacktry:eid=self.system_source.create_eid(cnx)self._extid_cache[extid]=eidself._type_source_cache[eid]=(etype,extid,source.uri)entity=source.before_entity_insertion(cnx,extid,etype,eid,sourceparams)ifsource.should_call_hooks:# get back a copy of operation for later restore if# necessary, see belowpending_operations=cnx.pending_operations[:]self.hm.call_hooks('before_add_entity',cnx,entity=entity)self.add_info(cnx,entity,source,extid)source.after_entity_insertion(cnx,extid,entity,sourceparams)ifsource.should_call_hooks:self.hm.call_hooks('after_add_entity',cnx,entity=entity)returneidexceptException:# XXX do some cleanup manually so that the transaction has a# chance to be commited, with simply this entity discardedself._extid_cache.pop(extid,None)self._type_source_cache.pop(eid,None)if'entity'inlocals():hook.CleanupDeletedEidsCacheOp.get_instance(cnx).add_data(entity.eid)self.system_source.delete_info_multi(cnx,[entity])ifsource.should_call_hooks:cnx.pending_operations=pending_operationsraisedefadd_info(self,cnx,entity,source,extid=None):"""add type and source info for an eid into the system table, and index the entity with the full text index """# begin by inserting eid/type/source/extid into the entities tablehook.CleanupNewEidsCacheOp.get_instance(cnx).add_data(entity.eid)self.system_source.add_info(cnx,entity,source,extid)def_delete_cascade_multi(self,cnx,entities):"""same as _delete_cascade but accepts a list of entities with the same etype and belonging to the same source. """pendingrtypes=cnx.transaction_data.get('pendingrtypes',())# delete remaining relations: if user can delete the entity, he can# delete all its relations without security checkingwithcnx.security_enabled(read=False,write=False):in_eids=','.join([str(_e.eid)for_einentities])withcnx.running_hooks_ops():forrschema,_,roleinentities[0].e_schema.relation_definitions():ifrschema.rule:continue# computed relationrtype=rschema.typeifrtypeinschema.VIRTUAL_RTYPESorrtypeinpendingrtypes:continueifrole=='subject':# don't skip inlined relation so they are regularly# deleted and so hooks are correctly calledrql='DELETE X %s Y WHERE X eid IN (%s)'%(rtype,in_eids)else:rql='DELETE Y %s X WHERE X eid IN (%s)'%(rtype,in_eids)try:cnx.execute(rql,build_descr=False)exceptValidationError:raiseexceptUnauthorized:self.exception('Unauthorized exception while cascading delete for entity %s. ''RQL: %s.\nThis should not happen since security is disabled here.',entities,rql)raiseexceptException:ifself.config.mode=='test':raiseself.exception('error while cascading delete for entity %s. RQL: %s',entities,rql)definit_entity_caches(self,cnx,entity,source):"""add entity to connection entities cache and repo's extid cache. Return entity's ext id if the source isn't the system source. """cnx.set_entity_cache(entity)ifsource.uri=='system':extid=Noneelse:extid=source.get_extid(entity)self._extid_cache[str(extid)]=entity.eidself._type_source_cache[entity.eid]=(entity.cw_etype,extid,source.uri)returnextiddefglob_add_entity(self,cnx,edited):"""add an entity to the repository the entity eid should originally be None and a unique eid is assigned to the entity instance """entity=edited.entityentity._cw_is_saved=False# entity has an eid but is not yet saved# init edited_attributes before calling before_add_entity hooksentity.cw_edited=editedsource=self.system_source# allocate an eid to the entity before calling hooksentity.eid=self.system_source.create_eid(cnx)# set caches asapextid=self.init_entity_caches(cnx,entity,source)ifserver.DEBUG&server.DBG_REPO:print('ADD entity',self,entity.cw_etype,entity.eid,edited)prefill_entity_caches(entity)self.hm.call_hooks('before_add_entity',cnx,entity=entity)relations=preprocess_inlined_relations(cnx,entity)edited.set_defaults()ifcnx.is_hook_category_activated('integrity'):edited.check(creation=True)self.add_info(cnx,entity,source,extid)try:source.add_entity(cnx,entity)except(UniqueTogetherError,ViolatedConstraint)asexc:userhdlr=cnx.vreg['adapters'].select('IUserFriendlyError',cnx,entity=entity,exc=exc)userhdlr.raise_user_exception()edited.saved=entity._cw_is_saved=True# trigger after_add_entity after after_add_relationself.hm.call_hooks('after_add_entity',cnx,entity=entity)# call hooks for inlined relationsforattr,valueinrelations:self.hm.call_hooks('before_add_relation',cnx,eidfrom=entity.eid,rtype=attr,eidto=value)self.hm.call_hooks('after_add_relation',cnx,eidfrom=entity.eid,rtype=attr,eidto=value)returnentity.eiddefglob_update_entity(self,cnx,edited):"""replace an entity in the repository the type and the eid of an entity must not be changed """entity=edited.entityifserver.DEBUG&server.DBG_REPO:print('UPDATE entity',entity.cw_etype,entity.eid,entity.cw_attr_cache,edited)hm=self.hmeschema=entity.e_schemacnx.set_entity_cache(entity)orig_edited=getattr(entity,'cw_edited',None)entity.cw_edited=editedsource=self.system_sourcetry:only_inline_rels,need_fti_update=True,Falserelations=[]forattrinlist(edited):ifattr=='eid':continuerschema=eschema.subjrels[attr]ifrschema.final:ifgetattr(eschema.rdef(attr),'fulltextindexed',False):need_fti_update=Trueonly_inline_rels=Falseelse:# inlined relationprevious_value=entity.related(attr)orNoneifprevious_valueisnotNone:previous_value=previous_value[0][0]# got a result setifprevious_value==entity.cw_attr_cache[attr]:previous_value=Noneelse:hm.call_hooks('before_delete_relation',cnx,eidfrom=entity.eid,rtype=attr,eidto=previous_value)relations.append((attr,edited[attr],previous_value))# call hooks for inlined relationsforattr,value,_tinrelations:hm.call_hooks('before_add_relation',cnx,eidfrom=entity.eid,rtype=attr,eidto=value)ifnotonly_inline_rels:hm.call_hooks('before_update_entity',cnx,entity=entity)ifcnx.is_hook_category_activated('integrity'):edited.check()try:source.update_entity(cnx,entity)edited.saved=Trueexcept(UniqueTogetherError,ViolatedConstraint)asexc:userhdlr=cnx.vreg['adapters'].select('IUserFriendlyError',cnx,entity=entity,exc=exc)userhdlr.raise_user_exception()self.system_source.update_info(cnx,entity,need_fti_update)ifnotonly_inline_rels:hm.call_hooks('after_update_entity',cnx,entity=entity)forattr,value,prevvalueinrelations:# if the relation is already cached, update existant cacherelcache=entity.cw_relation_cached(attr,'subject')ifprevvalueisnotNone:hm.call_hooks('after_delete_relation',cnx,eidfrom=entity.eid,rtype=attr,eidto=prevvalue)ifrelcacheisnotNone:cnx.update_rel_cache_del(entity.eid,attr,prevvalue)del_existing_rel_if_needed(cnx,entity.eid,attr,value)cnx.update_rel_cache_add(entity.eid,attr,value)hm.call_hooks('after_add_relation',cnx,eidfrom=entity.eid,rtype=attr,eidto=value)finally:iforig_editedisnotNone:entity.cw_edited=orig_editeddefglob_delete_entities(self,cnx,eids):"""delete a list of entities and all related entities from the repository"""# mark eids as being deleted in cnx info and setup cache update# operation (register pending eids before actual deletion to avoid# multiple call to glob_delete_entities)op=hook.CleanupDeletedEidsCacheOp.get_instance(cnx)ifnotisinstance(eids,(set,frozenset)):warn('[3.13] eids should be given as a set',DeprecationWarning,stacklevel=2)eids=frozenset(eids)eids=eids-op._containerop._container|=eidsdata_by_etype={}# values are [list of entities]## WARNING: the way this dictionary is populated is heavily optimized# and does not use setdefault on purpose. Unless a new release# of the Python interpreter advertises large perf improvements# in setdefault, this should not be changed without profiling.foreidineids:etype=self.type_from_eid(eid,cnx)# XXX should cache entity's cw_metainformationentity=cnx.entity_from_eid(eid,etype)try:data_by_etype[etype].append(entity)exceptKeyError:data_by_etype[etype]=[entity]source=self.system_sourceforetype,entitiesindata_by_etype.iteritems():ifserver.DEBUG&server.DBG_REPO:print('DELETE entities',etype,[entity.eidforentityinentities])self.hm.call_hooks('before_delete_entity',cnx,entities=entities)self._delete_cascade_multi(cnx,entities)source.delete_entities(cnx,entities)source.delete_info_multi(cnx,entities)self.hm.call_hooks('after_delete_entity',cnx,entities=entities)# don't clear cache here, it is done in a hook on commitdefglob_add_relation(self,cnx,subject,rtype,object):"""add a relation to the repository"""self.glob_add_relations(cnx,{rtype:[(subject,object)]})defglob_add_relations(self,cnx,relations):"""add several relations to the repository relations is a dictionary rtype: [(subj_eid, obj_eid), ...] """source=self.system_sourcerelations_by_rtype={}subjects_by_types={}objects_by_types={}activintegrity=cnx.is_hook_category_activated('activeintegrity')forrtype,eids_subj_objinrelations.iteritems():ifserver.DEBUG&server.DBG_REPO:forsubjeid,objeidineids_subj_obj:print('ADD relation',subjeid,rtype,objeid)forsubjeid,objeidineids_subj_obj:ifrtypeinrelations_by_rtype:relations_by_rtype[rtype].append((subjeid,objeid))else:relations_by_rtype[rtype]=[(subjeid,objeid)]ifnotactivintegrity:continue# take care to relation of cardinality '?1', as all eids will# be inserted later, we've remove duplicated eids since they# won't be caught by `del_existing_rel_if_needed`rdef=cnx.rtype_eids_rdef(rtype,subjeid,objeid)card=rdef.cardinalityifcard[0]in'?1':withcnx.security_enabled(read=False):cnx.execute('DELETE X %s Y WHERE X eid %%(x)s, ''NOT Y eid %%(y)s'%rtype,{'x':subjeid,'y':objeid})subjects=subjects_by_types.setdefault(rdef,{})ifsubjeidinsubjects:delrelations_by_rtype[rtype][subjects[subjeid]]subjects[subjeid]=len(relations_by_rtype[rtype])-1continuesubjects[subjeid]=len(relations_by_rtype[rtype])-1ifcard[1]in'?1':withcnx.security_enabled(read=False):cnx.execute('DELETE X %s Y WHERE Y eid %%(y)s, ''NOT X eid %%(x)s'%rtype,{'x':subjeid,'y':objeid})objects=objects_by_types.setdefault(rdef,{})ifobjeidinobjects:delrelations_by_rtype[rtype][objects[objeid]]objects[objeid]=len(relations_by_rtype[rtype])continueobjects[objeid]=len(relations_by_rtype[rtype])forrtype,source_relationsinrelations_by_rtype.iteritems():self.hm.call_hooks('before_add_relation',cnx,rtype=rtype,eids_from_to=source_relations)forrtype,source_relationsinrelations_by_rtype.iteritems():source.add_relations(cnx,rtype,source_relations)rschema=self.schema.rschema(rtype)forsubjeid,objeidinsource_relations:cnx.update_rel_cache_add(subjeid,rtype,objeid,rschema.symmetric)forrtype,source_relationsinrelations_by_rtype.iteritems():self.hm.call_hooks('after_add_relation',cnx,rtype=rtype,eids_from_to=source_relations)defglob_delete_relation(self,cnx,subject,rtype,object):"""delete a relation from the repository"""ifserver.DEBUG&server.DBG_REPO:print('DELETE relation',subject,rtype,object)source=self.system_sourceself.hm.call_hooks('before_delete_relation',cnx,eidfrom=subject,rtype=rtype,eidto=object)source.delete_relation(cnx,subject,rtype,object)rschema=self.schema.rschema(rtype)cnx.update_rel_cache_del(subject,rtype,object,rschema.symmetric)self.hm.call_hooks('after_delete_relation',cnx,eidfrom=subject,rtype=rtype,eidto=object)# these are overridden by set_log_methods below# only defining here to prevent pylint from complaininginfo=warning=error=critical=exception=debug=lambdamsg,*a,**kw:NonefromloggingimportgetLoggerfromcubicwebimportset_log_methodsset_log_methods(Repository,getLogger('cubicweb.repository'))