Beispiel #1
0
def query_assocmeta_gene_cpg(gene,
                             dbConnection,
                             window=250000,
                             columns="*",
                             maxpval=0.05):
    # get IDs
    SQL = """SELECT name,chr,start_pos,stop_pos from gene WHERE name = '{0}'""".format(
        gene)
    query = PySQLPool.getNewQuery(dbConnection)
    query.Query(SQL)
    geneinfo = query.record[0]
    if len(geneinfo) is 0:
        return ()
    cols = ",".join(["a." + x for x in columns.split(",")])
    SQL = """SELECT {0}, b.name, b.rsid, c.chr, c.pos, b.allele1 AS a1, b.allele2 AS a2 FROM assoc_meta a, snp b, cpg c
		WHERE a.snp=b.name
		AND a.cpg=c.name
		AND c.chr = {1}
		AND c.pos >= {2}
		AND c.pos <= {3}
		AND a.pval < {4}
		ORDER BY a.pval""".format(cols, geneinfo['chr'],
                            geneinfo['start_pos'] - window,
                            geneinfo['stop_pos'] + window, maxpval)

    query = PySQLPool.getNewQuery(dbConnection)
    query.Query(SQL)
    return query.record
Beispiel #2
0
	def run(self):

		with Connection.Connection(self.socket, self.name, self.debug) as conn:
			while conn.get_message():

				answer = self.default_answer

				if conn["sender"] != "" and conn["recipient"] != "":
					if self.debug:
						logging.debug("Mail from {0} to {1} with SASL: {2}".format(conn["sender"], conn["recipient"], conn["sasl_username"]))
					for flt in self.flts:
						with self._mutex:
							try:
								flt_answer = flt.check(conn)
							except:
								logging.error("Error in checking policy {0}. Traceback: \n{1}\n".format(flt, traceback.format_exc()))
						if flt_answer:
							break

					if flt_answer:
						answer = flt_answer

					if self.debug:
						logging.debug("Answer for mail {0} to {1} was: {2}".format(conn["sender"], conn["recipient"], answer))

				if conn["request"] == "smtpd_access_policy":
					conn.answer(answer)
				try:
					PySQLPool.cleanupPool()
				except:
					logging.warn('Error in cleaning SQL pool. Traceback: \n{0}\n'.format(traceback.format_exc()))
		if self.debug:
			stop_time = time.time()
			logging.debug("Process named {0} started {1}, stopped {2}. Working {3} seconds.".format(self.name, time.strftime("%d.%m.%y - %H:%M:%S", time.localtime(self.start_time)), time.strftime("%d.%m.%y - %H:%M:%S", time.localtime(stop_time)), (stop_time - self.start_time)))
Beispiel #3
0
def set_conninfo(conn_info, max_pool_count=3):
    conn = PySQLPool.getNewConnection(host=conn_info["hostname"],
                                      username=conn_info["username"],
                                      password=conn_info["password"],
                                      schema=conn_info["schema"])
    PySQLPool.getNewPool().maxActiveConnections = max_pool_count

    return conn
def set_conninfo(conn_info, max_pool_count = 3):
  conn = PySQLPool.getNewConnection(
           host     = conn_info["hostname"],
           username = conn_info["username"],
           password = conn_info["password"],
           schema   = conn_info["schema"]
         )
  PySQLPool.getNewPool().maxActiveConnections = max_pool_count

  return conn
Beispiel #5
0
def TestConnect(sAddr, nPort, sUser, sPasswd):
    try:
        testConn = PySQLPool.getNewConnection(username=sUser, password=sPasswd, host=sAddr, port=nPort, db='mysql', charset='utf8')
        query = PySQLPool.getNewQuery(testConn)
        query.query(r'select * from user')

        return True, '成功'
    except Exception,e:
        print e
        return False,e
Beispiel #6
0
	def testDBConnection(self):
		"""
		Test actual connection to Database
		"""
		connDict = {
					"host":self.host,
					"user":self.username,
					"passwd":self.password,
					"db":self.db}
		connection = PySQLPool.getNewConnection(**connDict)
		query = PySQLPool.getNewQuery(connection)
		query.Query("select current_user")
		result = str(query.record[0]['current_user']).split('@')[0]
		self.assertEqual(result, 'unittest', "DB Connection Failed")
Beispiel #7
0
	def testQuickQueryCreation(self):
		"""
		Quick Query Creation
		"""
		try:
			connDict = {
						"host":self.host,
						"user":self.username,
						"passwd":self.password,
						"db":self.db}
			connection = PySQLPool.getNewConnection(**connDict)
			query = PySQLPool.getNewQuery(connection)
		except Exception, e:
			self.fail('Failed to create PySQLQuery Object')
Beispiel #8
0
def TestConnect(sAddr, nPort, sUser, sPasswd):
    try:
        testConn = PySQLPool.getNewConnection(username=sUser,
                                              password=sPasswd,
                                              host=sAddr,
                                              port=nPort,
                                              db='mysql',
                                              charset='utf8')
        query = PySQLPool.getNewQuery(testConn)
        query.query(r'select * from user')

        return True, '成功'
    except Exception, e:
        print e
        return False, e
Beispiel #9
0
    def testDBConnection(self):
        """
		Test actual connection to Database
		"""
        connDict = {
            "host": self.host,
            "user": self.username,
            "passwd": self.password,
            "db": self.db
        }
        connection = PySQLPool.getNewConnection(**connDict)
        query = PySQLPool.getNewQuery(connection)
        query.Query("select current_user")
        result = str(query.record[0]['current_user']).split('@')[0]
        self.assertEqual(result, 'unittest', "DB Connection Failed")
Beispiel #10
0
    def testQuickQueryCreation(self):
        """
		Quick Query Creation
		"""
        try:
            connDict = {
                "host": self.host,
                "user": self.username,
                "passwd": self.password,
                "db": self.db
            }
            connection = PySQLPool.getNewConnection(**connDict)
            query = PySQLPool.getNewQuery(connection)
        except Exception as e:
            self.fail('Failed to create PySQLQuery Object')
Beispiel #11
0
    def _loadsql(self):
        try:
            sql_1 = "SELECT `white_list_users`.`id`, `users`.`username`, `white_list_users`.`token`, `white_list_users`.`action` FROM `users` RIGHT JOIN `white_list_users` ON `users`.`id` = `white_list_users`.`user_id`"
            sql_2 = "DELETE FROM `white_list_users` WHERE `id` = {0}"

            res = {}
            users = {}
            rules = {}
            clean_rulse = list()

            query = PySQLPool.getNewQuery(self._sql_pool, True)

            query.Query(sql_1)
            for row in query.record:
                if not self._keep_rules and row["username"] == None:
                    clean_rulse.append(int(row["id"]))
                if row["username"] == None:
                    continue
                if row["username"].lower() in self._exclude_mails:
                    continue
                if not res.has_key(row["username"].lower()):
                    res[row["username"].lower()] = dict()
                res[row["username"].lower()][row["token"].lower()] = row["action"]

            for iter in clean_rulse:
                query.Query(sql_2.format(iter))

            return res
        except:
            if self._debug:
                logging.debug(
                    "Error in getting SQL data for User policy. Traceback: \n{0}\n".format(traceback.format_exc())
                )

            return None
Beispiel #12
0
def get_history_volumn_detail_accord_property(ip_address, property_name, start_time, end_time):
    '''

    '''
    property_name = string.lower(property_name)
    table_name = ''
    sql = ''
    result = []
    if property_name.find('service') != -1:
        table_name = model_redis.get_service_table_accord_ip(ip_address)
        sql = config_mysql.GET_HIS_VOLUMN_ACCORD_SERVICE.format(table_name, ip_address, start_time, end_time)
    else:
        property_type = get_property_type(property_name)
        if property_type != '':
            table_name = config_mysql.PRO_TO_TABLE[property_type]
            sql = config_mysql.HIS_SQL_TEMPLATE.format(property_name, table_name,
                                                       ip_address, start_time, end_time)
        else:
            table_name = model_redis.get_service_table_accord_ip(ip_address)
            sql = config_mysql.GET_HIS_VOLUMN_ACCORD_THE_SERVICE.format(table_name, ip_address, property_name,
                                                                        start_time, end_time)
    if sql != '':
        print sql
        query = PySQLPool.getNewQuery(his_conn)
        query.Query(sql)
        for item in query.record:
            item['time'] = utils.date_to_timestamp_general(item['time'], '%Y%m%d-%H')
            result.append(item)
        print result
        return {
            'ip_address': ip_address,
            'property_name': property_name,
            'property_value': result
        }
Beispiel #13
0
 def connect(self):
     return PySQLPool.getNewConnection(username=self._db_user,
                                       password=self._db_pass,
                                       host=self._db_host,
                                       db=self._db_name,
                                       charset='utf8',
                                       commitOnEnd=self.commitOnEnd)
Beispiel #14
0
def manytasks(sas):
  connection = PySQLPool.getNewConnection(username='******', password='******', host='localhost', db='sandyfiles')
  

  for i in range(2):
    t = Thread(target=checksamples, args=(i,connection,))
    t.start() 
Beispiel #15
0
def prices():
    query = PySQLPool.getNewQuery(connection, commitOnEnd=True)
    query.Query("""select * from price_list where price_time = %s""", (ist_today(),))
    if int(query.rowcount) > 0:
        logging.error("found in db")
        price_dict = {}

        for record in query.record:
            if (record['city']) in price_dict:
                fuel_dict = price_dict[record['city']]
                fuel_dict[record['type']] = str(record['price'])
            else:
                fuel_dict = {}
                fuel_dict[record['type']] = str(record['price'])
                price_dict[record['city']] = fuel_dict

        prices_json = {"status": {"message": "Successful", "code": 0},
                       "data": {"fuelprice": price_dict, "cities": price_dict.keys()}}
    else:
        prices_json = get_prices_from_iocl_website()
        petrol_time = datetime.datetime.fromtimestamp(float(prices_json.get("data", {}).get("timestamp", ist_today())))
        for city, price_dict in prices_json.get("data", {}).get("fuelprice", {}).iteritems():
            for fuel_type, price in price_dict.iteritems():
                query.Query("""insert into price_list (city,price, type, price_time) values (%s,%s, %s, %s) on duplicate key update price=%s """,(city,price,fuel_type,petrol_time,price))

    return json.dumps(prices_json)
Beispiel #16
0
 def load_database_entry(self):
     """Create the Database Querys"""
     query = PySQLPool.getNewQuery(self._db)
     query.execute("SELECT * FROM `mc_versioning` WHERE `mc_caching_id`=%s and `flag_delete`='0' and `aktiv`='1'", (self._entry))
     #data = query.record
     for data in query.record:
         return data
Beispiel #17
0
def repoThread():
    global repoList
    global repoVal
    while len(repoList) > 0:
        row = repoList.pop()
        regions = regionList()
        prices = getMineralBasket()
        refValue = ((row['Tritanium'] * prices['Tritanium']['sellavg']) +
        (row['Pyerite'] * prices['Pyerite']['sellavg']) +
        (row['Mexallon'] * prices['Mexallon']['sellavg']) +
        (row['Isogen'] * prices['Isogen']['sellavg']) +
        (row['Nocxium'] * prices['Nocxium']['sellavg']) +
        (row['Zydrine'] * prices['Zydrine']['sellavg']) +
        (row['Megacyte'] * prices['Megacyte']['sellavg']) +
        (row['Morphite'] * prices['Morphite']['sellavg'])) / row['portion']
        queryValue = PySQLPool.getNewQuery(db)
        stuff = refValue * 1.02
        queryValue.Query("""SELECT region, sellavg, sell, buy, buyavg from prices where itemid = %s""" % (row['typeID'],))
        for rowValue in queryValue.record:
            if rowValue['sellavg'] > stuff:
                continue
            if rowValue['sellavg'] != 0 and refValue/rowValue['sellavg'] * 100 > 100:
                repoVal[regions[rowValue['region']]][itemName(row['typeID'])] = {'sellavg': rowValue['sellavg'], 'sell': rowValue['sell'], 'buy': rowValue['buy'], 'buyavg': rowValue['buyavg'], 'refprice': refValue, 'percentage': refValue/rowValue['sellavg']* 100}
            elif rowValue['sellavg'] == 0 and rowValue['sell'] != 0 and refValue/rowValue['sell'] * 100 > 100:
                repoVal[regions[rowValue['region']]][itemName(row['typeID'])] = {'sellavg': rowValue['sellavg'], 'sell': rowValue['sell'], 'buy': rowValue['buy'], 'buyavg': rowValue['buyavg'], 'refprice': refValue, 'percentage': refValue/rowValue['sell'] * 100}
            else:
                continue
Beispiel #18
0
def get_snpid_from_rsid(rsid, dbConnection):
    rsids = ",".join(["'" + x + "'" for x in rsid])
    SQL = """SELECT name,rsid from snp
		WHERE rsid IN ({0})""".format(rsids)
    query = PySQLPool.getNewQuery(dbConnection)
    query.Query(SQL)
    return query.record
Beispiel #19
0
	def _loadsql(self, users):
		try:
			sql_1 = "SELECT `user_id`, `token`, `action` FROM `white_list_users`"
			sql_2 = "DELETE FROM `white_list_users` WHERE `user_id` = '{0}'"

			res={}
			rules={}
			clean_rules=list()

			for uid in users:
				if users[uid] in self._exclude_mails:
					continue
				res[users[uid]] = {}

			query = PySQLPool.getNewQuery(self._sql_pool, True)

			query.Query(sql_1)
			for row in query.record:
				tmp = {}
				tmp[row["token"].lower()] = row["action"]
				if users.has_key(str(int(row["user_id"]))):
					res[users[str(int(row["user_id"]))]].update(tmp)
				else:
					if not self._keep_rules:
						clean_rules.append(row["user_id"])
						
			if not self._keep_rules:
				clean_rules = list(set(clean_rulse))
				for id in clean_rulse:
					query.Query(sql_2.format(id))
			return res
		except:
			if self._debug:
				logging.debug("Error in getting SQL data for UserLdap policy. Traceback: \n{0}\n".format(traceback.format_exc()))
			return None
Beispiel #20
0
def regionID(id):
    query = PySQLPool.getNewQuery(db)
    query.Query("""SELECT regionID from eve.mapRegions where regionName = %s""", (id,))
    if len(query.record) != 1:
        return None
    for row in query.record:
        return row['regionID']
Beispiel #21
0
    def get_uuid(self):
        """Create the Database Querys"""
        query = PySQLPool.getNewQuery(self._db)
        query.execute("SELECT * FROM `mc_caching` WHERE `id`=%s and `flag_delete`='0' and `aktiv`='1'", (self._entry))

        for row in query.record:
            return row["mc_uuid"]
Beispiel #22
0
 def fillQueue(self):
     query = PySQLPool.getNewQuery(self._db)
     query.execute("SELECT id FROM `mc_caching` WHERE last_crawl <= DATE_SUB(NOW(),INTERVAL 1 MINUTE) and `aktiv`='1' and `flag_delete`='0' ORDER BY `last_crawl` ASC")
     for row in query.record:
         if not row['id'] in self._queue.queue:
             self._queue.put(row["id"])
     return
Beispiel #23
0
def insert_new_important_service(request_data):
    service_name = request_data['Services_name']
    instance = request_data['oop_name']
    business_name = request_data['business_name']
    ip = request_data['ip_address']
    editor = request_data['editor'] if request_data['editor'] else ''
    description = request_data['description'] if request_data['description'] else ''
    import datetime

    date_time = datetime.datetime.strptime(request_data['input_date'], '%Y%m%d')
    sql = config_mysql.ADD_NEW_IMPORTANT_SERVICE.format(service_name, ip, description, editor,
                                                        date_time, business_name, instance)
    print sql
    try:
        query = PySQLPool.getNewQuery(connection)
        query.Query(sql)
        query.Query("commit;")
        row_id = query.lastInsertID
        if query.affectedRows == 1:
            return True
        else:
            return False
    except:
        traceback.print_exc()
        return False
Beispiel #24
0
  def query(self, sqlQuery):
#    cursor = self.db.cursor()
#    cursor.execute(sqlQuery)
#    rows =  cursor.fetchall()
#    return rows
    query = PySQLPool.getNewQuery(connection = self.db)
    query.Query(sqlQuery)
    return query.record
Beispiel #25
0
def regionStatus(id):
    query = PySQLPool.getNewQuery(db)
    query.Query(
        """SELECT factionID from eve.mapRegions where regionID = %s and factionID is not null""",
        (id, ))
    if len(query.record) == 1:
        return True
    return None
Beispiel #26
0
def cleanupPool():
    """
	Cleanup connection pool. Closing all inactive connections.
	
	@author: Nick Verbeck
	@since: 9/12/2008
	"""
    PySQLPool.PySQLPool().Cleanup()
Beispiel #27
0
def terminatePool():
    """
	Terminate all Connection
	
	@author: Nick Verbeck
	@since: 5/12/2008
	"""
    PySQLPool.PySQLPool().Terminate()
Beispiel #28
0
def commitPool():
    """
	Commits All changes in pool
	
	@author: Nick Verbeck
	@since: 9/12/2008
	"""
    PySQLPool.PySQLPool().Commit()
Beispiel #29
0
def save_data (table, url, node, dns, https, http, http_code, download_size, fst_byte, ping):
    global conn, db, hostname, username, password, database

    tmp="insert into " + table + " (host, node, dns_time, https_time, http_time, code, size, 1st_byte, ping) values ('%s', '%s', %.3f, %.3f, %.3f, %d, %d, %.3f, %.3f)" %(url[1], node, dns, https, http, http_code, download_size, fst_byte, ping)
    print tmp

    conn = PySQLPool.getNewQuery(db,commitOnEnd=True)
    conn.Query(tmp)
Beispiel #30
0
def getNewPool():
    """
	Create a new PySQLPool
	
	@author: Nick Verbeck
	@since: 5/12/2008
	"""
    return PySQLPool.PySQLPool()
Beispiel #31
0
	def testQuickConnectionCreation(self):
		"""
		Quick Connection Creation
		"""
		try:
			connection = PySQLPool.getNewConnection(host=self.host, user=self.username, passwd=self.password, db=self.db)
		except Exception, e:
			self.fail("Failed to create connection with error: "+str(e))
Beispiel #32
0
 def _dbConnect(self):
     try:
         self.connection = PySQLPool.getNewConnection( username = self.username, \
             password = self.password, \
             host = self.host, \
             db = self.db )
     except:
         #	    self.logger.error( 'database connection failed' )
         die('database connection failed')
Beispiel #33
0
 def testQuickQueryCreation(self):
     """
     Quick Query Creation
     """
     try:
         query = PySQLPool.getNewQuery(self.connection)
         self.assertTrue(isinstance(query, PySQLPool.query.PySQLQuery))
     except Exception, e:
         self.fail('Failed to create PySQLQuery Object with error: '+str(e))
def get_secret(conn, api_key):
  res = None

  query = PySQLPool.getNewQuery(connection=conn)
  r = query.Query("SELECT SVC_SECRETKEY FROM TBMB_ISSVC WHERE SVC_APIKEY = %s", (api_key))
  if r == 1:
    res = query.record[0]['SVC_SECRETKEY']

  return res
def get_id(conn, api_key):
  res = None

  query = PySQLPool.getNewQuery(connection=conn)
  r = query.Query("SELECT MEM_SQ FROM TBMB_ISSVC WHERE  SVC_APIKEY = %s", (api_key))
  if r == 1:
    res = query.record[0]['MEM_SQ']

  return res
def process(market_data):
  query = pysqlpool.getNewQuery(connection)

  insertData = []
  for history in market_data.get_all_entries_ungrouped():
    insertData.append((history.type_id, history.region_id, history.historical_date, history.low_price, history.high_price, history.average_price, history.total_quantity, history.num_orders, history.generated_at))

  sql  = 'INSERT INTO `items_history` (`type_id`, `region_id`, `date`, `price_low`, `price_high`, `price_average`, '
  sql += '`quantity`, `num_orders`, `created`) VALUES (%s, %s, %s, %s, %s, %s, %s, %s, %s) '
  sql += 'ON DUPLICATE KEY UPDATE '
  sql += '`price_low`=VALUES(`price_low`), `price_high`=VALUES(`price_high`), `price_average`=VALUES(`price_average`), '
  sql += '`quantity`=VALUES(`quantity`), `num_orders`=VALUES(`num_orders`)'
  query.executeMany(sql, insertData)

  gevent.sleep()
  pysqlpool.getNewPool().Commit()
  sys.stdout.write(".")
  sys.stdout.flush()
Beispiel #37
0
def regionID(id):
    query = PySQLPool.getNewQuery(db)
    query.Query(
        """SELECT regionID from eve.mapRegions where regionName = %s""",
        (id, ))
    if len(query.record) != 1:
        return None
    for row in query.record:
        return row['regionID']
Beispiel #38
0
 def execute(self, sql, args=None):
     '''
     Excutes arbitrary sql string in current database connection.    
     Returns results as PySQLPool query object.
     '''
     log.debug('SQL.execute ' + sql)
     queryobj = PySQLPool.getNewQuery(self.connect())
     queryobj.Query(sql, args)
     return queryobj
Beispiel #39
0
def get_important_service_accord_ip(ip_address):
    result = []
    sql = config_mysql.GET_IMPORTANT_SERVICE_ACCORD_IP.format(ip_address)
    query = PySQLPool.getNewQuery(connection)
    try:
        query.Query(sql)
        result = list(set([item['service_name'] for item in list(query.record)]))
    except Exception, e:
        print e.message
Beispiel #40
0
def get_id(conn, api_key):
    res = None

    query = PySQLPool.getNewQuery(connection=conn)
    r = query.Query("SELECT MEM_SQ FROM TBMB_ISSVC WHERE  SVC_APIKEY = %s",
                    (api_key))
    if r == 1:
        res = query.record[0]['MEM_SQ']

    return res
Beispiel #41
0
 def getResult(self, sql_query):
     """
     Get result form database when SQL query statement
     :param sql_query: SQL Query
     :return data: Object Array of the results
     """
     query = PySQLPool.getNewQuery(connection)
     query.Query(sql_query)
     data = query.record
     return data
Beispiel #42
0
 def getResult(self,sql_query):
     """
     Get result form database when SQL query statement
     :param sql_query: SQL Query
     :return data: Object Array of the results
     """
     query = PySQLPool.getNewQuery(connection)
     query.Query(sql_query)
     data = query.record
     return data
Beispiel #43
0
    def testQuickDictConnectionCreation(self):
        """
		Quick Connection Creation using Kargs/Dict
		"""
        try:
            connection = PySQLPool.getNewConnection(**self.connDict)
            self.assertTrue(
                isinstance(connection, PySQLPool.connection.Connection))
        except Exception, e:
            self.fail("Failed to create connection with error: " + str(e))
Beispiel #44
0
 def _getSids(self):
     try:
         query = PySQLPool.getNewQuery(self.connection)
         query.Query('select sid, url from cam where dump is true')
         self.sids = {}
         for row in query.record:
             #	     	print( '%s - %s' % ( row[ 'sid' ], row[ 'url' ] ) )
             self.sids[row['sid']] = row['url']
         self.logger.info("sid list updated")
     except:
         self.logger.warning("getSids failed")
Beispiel #45
0
def getMineralBasket(region = 10000002):
    try:
        with pool.reserve() as mc:
            basket = mc.get("basket" + str(region))
        if basket != None:
            return basket
    except:
        pass
    query = PySQLPool.getNewQuery(db)
    query.Query("""SELECT * from prices where (itemid BETWEEN 34 and 40 or itemid = 11399) and region = '%i'""" % (region))
    retVal = {}
    for row in query.record:
        intQuery = PySQLPool.getNewQuery(db)
        intQuery.Query("""SELECT typeName from eve.invTypes where typeID = %i""" % (row['itemid']))
        for name in intQuery.record:
            typeName = name['typeName']
        retVal[typeName] = row
    with pool.reserve() as mc:
        mc.set("basket" + str(region), retVal, time=600)
    return retVal
Beispiel #46
0
def get_secret(conn, api_key):
    res = None

    query = PySQLPool.getNewQuery(connection=conn)
    r = query.Query(
        "SELECT SVC_SECRETKEY FROM TBMB_ISSVC WHERE SVC_APIKEY = %s",
        (api_key))
    if r == 1:
        res = query.record[0]['SVC_SECRETKEY']

    return res
Beispiel #47
0
    def testHashKeyGen(self):
        """
		Test Hash Key Generation
		"""
        try:
            connection = PySQLPool.getNewConnection(**self.connDict)
            hashStr = ''.join([str(x) for x in connection.info.values()])
            key = md5(hashStr).hexdigest()
            self.assertEqual(connection.key, key, msg="Hash Keys don't match")
        except Exception, e:
            self.fail("Failed to create connection with error: " + str(e))
Beispiel #48
0
    def testQuickConnectionCreation(self):
        """
		Quick Connection Creation
		"""
        try:
            connection = PySQLPool.getNewConnection(host=self.host,
                                                    user=self.username,
                                                    passwd=self.password,
                                                    db=self.db)
        except Exception as e:
            self.fail("Failed to create connection with error: " + str(e))
Beispiel #49
0
    def getQueryObject(**kwargs):
        """
        Get a new connection from the PySQLPool
        @return a new connection, of None if an error has occured
        """
        try:

            conn = PySQLPool.getNewConnection(host='localhost',
                                              username='******',
                                              password='',
                                              schema='test',
                                              port=3306,
                                              commitOnEnd=True)
            query = PySQLPool.getNewQuery(connection=conn)

            return query
        #something went wrong
        except Exception, e:
            logging.error("Could not get query object: %s", e)
            return None
Beispiel #50
0
    def getResultParamaters(self,sql_query,values):
        """
        Get result form database when SQL query and values statement
        :param sql_query: SQL Query
        :param values: Vales to be inserted into the query before being run
        :return data: Object Array of the results
        """

        query = PySQLPool.getNewQuery(connection)
        query.Query(sql_query,values)
        data = query.record
        return data
Beispiel #51
0
 def _connect_to_db(cls, db_name, db_user, db_passwd):
     try:
         connection = PySQLPool.getNewConnection(
                                                 host=cls.__config.db_host,
                                                 username=db_user,
                                                 password=cls.__aescoder.decrypt(db_passwd),
                                                 db=db_name,
                                                 commitOnEnd=True,
                                                 use_unicode=True,
                                                 charset = 'utf8')
     except MySQLdb.Error, e:
         raise Exception("connection %d: %s" % (e.args[0], e.args[1]))
Beispiel #52
0
    def getResultParamaters(self, sql_query, values):
        """
        Get result form database when SQL query and values statement
        :param sql_query: SQL Query
        :param values: Vales to be inserted into the query before being run
        :return data: Object Array of the results
        """

        query = PySQLPool.getNewQuery(connection)
        query.Query(sql_query, values)
        data = query.record
        return data
    def getQueryObject(**kwargs):
        """
        Get a new connection from the PySQLPool
        @return a new connection, of None if an error has occured
        """
        try:


            conn = PySQLPool.getNewConnection(host = 'localhost',
                username=  '******',
                password=  '',
                schema=  'test',
                port= 3306,
                commitOnEnd = True)
            query = PySQLPool.getNewQuery(connection = conn)

            return query
        #something went wrong
        except Exception, e:
            logging.error("Could not get query object: %s", e)
            return None
Beispiel #54
0
def SIGINT_handler(pid_file, socket_fd, sql_pool, signum, frame):
	logging.info("Caught SIGNAL 2. Exiting...")

	if os.path.exists(pid_file):
		try:
			os.remove(pid_file)
		except:
			logging.error("Error in first forking. Traceback: \n{0}\n".format(traceback.format_exc()))


	try:
		socket_fd.shutdown(socket.SHUT_RDWR)
		socket_fd.close()
	except:
		logging.error("Error in closing master socket. Traceback: \n{0}\n".format(traceback.format_exc()))

	try:
		PySQLPool.terminatePool()
	except:
		logging.error("Error in terminating SQL pool. Traceback: \n{0}\n".format(traceback.format_exc()))
	sys.exit(0)
Beispiel #55
0
    def testQuickConnectionCreation(self):
        """
		Quick Connection Creation
		"""
        try:
            connection = PySQLPool.getNewConnection(host=self.host,
                                                    user=self.username,
                                                    passwd=self.password,
                                                    db=self.db)
            self.assertTrue(
                isinstance(connection, PySQLPool.connection.Connection))
        except Exception, e:
            self.fail("Failed to create connection with error: " + str(e))
Beispiel #56
0
	def testQuickDictConnectionCreation(self):
		"""
		Quick Connection Creation using Kargs/Dict
		"""
		try:
			connDict = {
					"host":self.host,
					"user":self.username,
					"passwd":self.password,
					"db":self.db}
			connection = PySQLPool.getNewConnection(**connDict)
		except Exception, e:
			self.fail("Failed to create connection with error: "+str(e))
Beispiel #57
0
def repoSearch():
    global repoList
    global repoVal
    query = PySQLPool.getNewQuery(db)
    prices = getMineralBasket(10000030)
    regions = regionList()
    for data in regions:
        repoVal[regions[data]] = {}
    query.Query("SELECT * FROM repromin where rate > 5")
    for row in query.record:
        repoList.append(row)
        
    threads = []
    for i in range(maxThreads):
        """Worker scanning system"""
        t = threading.Thread(target=repoThread, args=())
        threads.append(t)
        time.sleep(.1)
        t.start()

    while threading.activeCount()>1:
        """Verification of the number of active theads for monitoring purposes."""
        time.sleep(1)
        print "Active threads: %i/%i" % (threading.activeCount() - 1, maxThreads)
        sys.stdout.flush()

    output = """<html><head><script type="text/javascript" src="https://ajax.googleapis.com/ajax/libs/jquery/1.7.2/jquery.min.js"></script>
    <script type="text/javascript" src="http://snipanet.com/inc/jquery.tablesorter.min.js"></script>
    <link rel="stylesheet" href="http://snipanet.com/inc/themes/blue/style.css" type="text/css">
    <script type="text/javascript">
    $(document).ready(function() 
    { 
    """
    for num in range(len(repoVal)):
        output += """$("#myTable%i").tablesorter();""" % (num,)
    output += """}
    ); 
    </script>
    </head><body>
    """
    incNum = 0;
    for region in repoVal:
        data = repoVal[region]
        if len(data) == 0 or regionStatus(regionID(region)) == None or data[prices]['percentage'] < 100:
            continue
        output += """Region: %s<br><table id="myTable%i" class="tablesorter"><thead><tr><th>Item Name</th><th>Sell Avg</th><th>Sell Price</th><th>Buy Avg</th><th>Buy Price</th><th>Refine Price</th><th>Refine Percentage</tr></thead><tbody>""" % (region, incNum)
        for prices in data:
            output += "<tr><td>%s</td><td>%s</td><td>%s</td><td>%s</td><td>%s</td><td>%s</td><td>%.2f%%</td></tr>" % (prices, locale.format("%.2f", data[prices]['sellavg'], grouping=True), locale.format("%.2f", data[prices]['sell'], grouping=True), locale.format("%.2f", data[prices]['buyavg'], grouping=True), locale.format("%.2f", data[prices]['buy'], grouping=True), locale.format("%.2f", data[prices]['refprice'], grouping=True), data[prices]['percentage'])
        output += "</tbody></table><br><br>"
        incNum += 1
    return output
Beispiel #58
0
    def testQuickDictConnectionCreation(self):
        """
		Quick Connection Creation using Kargs/Dict
		"""
        try:
            connDict = {
                "host": self.host,
                "user": self.username,
                "passwd": self.password,
                "db": self.db
            }
            connection = PySQLPool.getNewConnection(**connDict)
        except Exception as e:
            self.fail("Failed to create connection with error: " + str(e))