driver-spondoolies-sp30.c 14 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489
  1. /*
  2. * Copyright 2014 Con Kolivas <kernel@kolivas.org>
  3. * Copyright 2014 Zvi (Zvisha) Shteingart - Spondoolies-tech.com
  4. *
  5. * This program is free software; you can redistribute it and/or modify it
  6. * under the terms of the GNU General Public License as published by the Free
  7. * Software Foundation; either version 3 of the License, or (at your option)
  8. * any later version. See COPYING for more details.
  9. */
  10. /*
  11. This driver communicates the job requests via Unix socket to the minergate
  12. process, that is responsible for controlling the Spondoolies Dawson SP10 miner.
  13. The jobs sent each with unique ID and returned asynchronously in one of the next
  14. transactions. REQUEST_PERIOD and REQUEST_SIZE define the communication rate with minergate.
  15. */
  16. #include <float.h>
  17. #include <limits.h>
  18. #include <pthread.h>
  19. #include <stdint.h>
  20. #include <stdio.h>
  21. #include <strings.h>
  22. #include <sys/time.h>
  23. #include <unistd.h>
  24. #include <assert.h>
  25. #include <time.h>
  26. #include <sys/socket.h>
  27. #include <sys/un.h>
  28. #include <unistd.h>
  29. #include <string.h>
  30. #include <math.h>
  31. #include "config.h"
  32. #ifdef WIN32
  33. #include <windows.h>
  34. #endif
  35. #include "compat.h"
  36. #include "miner.h"
  37. #include "driver-spondoolies-sp30-p.h"
  38. #include "driver-spondoolies-sp30.h"
  39. #ifdef WORDS_BIGENDIAN
  40. # define swap32tobe(out, in, sz) ((out == in) ? (void)0 : memmove(out, in, sz))
  41. # define LOCAL_swap32be(type, var, sz) ;
  42. # define swap32tole(out, in, sz) swap32yes(out, in, sz)
  43. # define LOCAL_swap32le(type, var, sz) LOCAL_swap32(type, var, sz)
  44. #else
  45. # define swap32tobe(out, in, sz) swap32yes(out, in, sz)
  46. # define LOCAL_swap32be(type, var, sz) LOCAL_swap32(type, var, sz)
  47. # define swap32tole(out, in, sz) ((out == in) ? (void)0 : memmove(out, in, sz))
  48. # define LOCAL_swap32le(type, var, sz) ;
  49. #endif
  50. static inline void swap32yes(void *out, const void *in, size_t sz)
  51. {
  52. size_t swapcounter;
  53. for (swapcounter = 0; swapcounter < sz; ++swapcounter)
  54. (((uint32_t*)out)[swapcounter]) = swab32(((uint32_t*)in)[swapcounter]);
  55. }
  56. static void send_minergate_pkt(const minergate_req_packet_sp30* mp_req, minergate_rsp_packet_sp30* mp_rsp,
  57. int socket_fd)
  58. {
  59. int nbytes, nwrote, nread;
  60. nbytes = sizeof(minergate_req_packet_sp30);
  61. nwrote = write(socket_fd, (const void *)mp_req, nbytes);
  62. if (unlikely(nwrote != nbytes))
  63. _quit(-1);
  64. nbytes = sizeof(minergate_rsp_packet_sp30);
  65. nread = read(socket_fd, (void *)mp_rsp, nbytes);
  66. if (unlikely(nread != nbytes))
  67. _quit(-1);
  68. assert(mp_rsp->magic == 0xcaf4);
  69. }
  70. static bool spondoolies_prepare_sp30(struct thr_info *thr)
  71. {
  72. struct cgpu_info *spondoolies_sp30 = thr->cgpu;
  73. struct timeval now;
  74. assert(spondoolies_sp30);
  75. cgtime(&now);
  76. /* FIXME: Vladik */
  77. #if NEED_FIX
  78. get_datestamp(spondoolies_sp30->init, &now);
  79. #endif
  80. return true;
  81. }
  82. static int init_socket(void)
  83. {
  84. int socket_fd;
  85. struct sockaddr_un address;
  86. printf("Init\n");
  87. socket_fd = socket(PF_UNIX, SOCK_STREAM, 0);
  88. if (socket_fd < 0) {
  89. printf("socket() failed\n");
  90. perror("Err:");
  91. return 0;
  92. }
  93. /* start with a clean address structure */
  94. memset(&address, 0, sizeof(struct sockaddr_un));
  95. address.sun_family = AF_UNIX;
  96. sprintf(address.sun_path, MINERGATE_SOCKET_FILE_SP30);
  97. if (connect(socket_fd, (struct sockaddr *) &address, sizeof(struct sockaddr_un))) {
  98. printf("connect() failed\n");
  99. perror("Err:");
  100. return 0;
  101. }
  102. return socket_fd;
  103. }
  104. static bool spondoolies_flush_queue(struct spond_adapter* a, bool flush_queue)
  105. {
  106. if (!a->parse_resp) {
  107. static int i = 0;
  108. if (i++ % 10 == 0 && a->works_in_minergate_and_pending_tx + a->works_pending_tx != a->works_in_driver)
  109. printf("%d + %d != %d\n", a->works_in_minergate_and_pending_tx, a->works_pending_tx,a->works_in_driver);
  110. assert(a->works_in_minergate_and_pending_tx + a->works_pending_tx == a->works_in_driver);
  111. send_minergate_pkt(a->mp_next_req, a->mp_last_rsp, a->socket_fd);
  112. if (flush_queue) {
  113. printf("FLUSH!\n");
  114. a->mp_next_req->mask |= 0x02;
  115. } else {
  116. a->mp_next_req->mask &= ~0x02;
  117. }
  118. a->mp_next_req->req_count = 0;
  119. a->parse_resp = 1;
  120. a->works_in_minergate_and_pending_tx += a->works_pending_tx;
  121. a->works_pending_tx = 0;
  122. }
  123. return true;
  124. }
  125. static void spondoolies_detect_sp30(__maybe_unused bool hotplug)
  126. {
  127. struct cgpu_info *cgpu = calloc(1, sizeof(*cgpu));
  128. struct device_drv *drv = &sp30_drv;
  129. struct spond_adapter *a;
  130. #if NEED_FIX
  131. nDevs = 1;
  132. #endif
  133. assert(cgpu);
  134. cgpu->drv = drv;
  135. cgpu->deven = DEV_ENABLED;
  136. cgpu->threads = 1;
  137. cgpu->device_data = calloc(sizeof(struct spond_adapter), 1);
  138. if (unlikely(!(cgpu->device_data)))
  139. quit(1, "Failed to calloc cgpu_info data");
  140. a = cgpu->device_data;
  141. a->cgpu = (void *)cgpu;
  142. a->adapter_state = ADAPTER_STATE_OPERATIONAL;
  143. a->mp_next_req = allocate_minergate_packet_req_sp30(0xca, 0xfe);
  144. a->mp_last_rsp = allocate_minergate_packet_rsp_sp30(0xca, 0xfe);
  145. pthread_mutex_init(&a->lock, NULL);
  146. a->socket_fd = init_socket();
  147. if (a->socket_fd < 1) {
  148. printf("Error connecting to minergate server!");
  149. _quit(-1);
  150. }
  151. assert(add_cgpu(cgpu));
  152. // Clean MG socket
  153. spondoolies_flush_queue(a, true);
  154. spondoolies_flush_queue(a, true);
  155. spondoolies_flush_queue(a, true);
  156. applog(LOG_DEBUG, "SPOND spondoolies_detect_sp30 done");
  157. }
  158. static struct api_data *spondoolies_api_stats_sp30(struct cgpu_info *cgpu)
  159. {
  160. struct spond_adapter *a = cgpu->device_data;
  161. struct api_data *root = NULL;
  162. root = api_add_int(root, "ASICs total rate", &a->temp_rate, false);
  163. root = api_add_int(root, "Temparature front", &a->front_temp, false);
  164. root = api_add_int(root, "Temparature rear top", &a->rear_temp_top, false);
  165. root = api_add_int(root, "Temparature rear bot", &a->rear_temp_bot, false);
  166. return root;
  167. }
  168. #if 0
  169. static unsigned char get_leading_zeroes(const unsigned char *target)
  170. {
  171. unsigned char leading = 0;
  172. int first_non_zero_chr;
  173. uint8_t m;
  174. for (first_non_zero_chr = 31; first_non_zero_chr >= 0; first_non_zero_chr--) {
  175. if (target[first_non_zero_chr] == 0)
  176. leading += 8;
  177. else
  178. break;
  179. }
  180. // j = first non-zero
  181. m = target[first_non_zero_chr];
  182. while ((m & 0x80) == 0) {
  183. leading++;
  184. m = m << 1;
  185. }
  186. return leading;
  187. }
  188. #endif
  189. static void spondoolies_shutdown_sp30(__maybe_unused struct thr_info *thr)
  190. {
  191. }
  192. static void fill_minergate_request(minergate_do_job_req_sp30* work, struct work *cg_work, int max_offset)
  193. {
  194. uint32_t x[64 / 4];
  195. uint64_t wd;
  196. memset(work, 0, sizeof(minergate_do_job_req_sp30));
  197. //work->
  198. LOCAL_swap32le(unsigned char, cg_work->midstate, 32 / 4)
  199. LOCAL_swap32le(unsigned char, cg_work->data + 64, 64 / 4)
  200. swap32yes(x, cg_work->data + 64, 64 / 4);
  201. memcpy(work->midstate, cg_work->midstate, 32);
  202. work->mrkle_root = ntohl(x[0]);
  203. work->timestamp = ntohl(x[1]);
  204. work->difficulty = ntohl(x[2]);
  205. //work->leading_zeroes = get_leading_zeroes(cg_work->target);
  206. // Is there no better way to get leading zeroes?
  207. work->leading_zeroes = 31;
  208. wd = round(cg_work->device_diff);
  209. while (wd) {
  210. work->leading_zeroes++;
  211. wd = wd >> 1;
  212. }
  213. //printf("%d %d\n",work->leading_zeroes, (int)round(cg_work->work_difficulty));
  214. work->work_id_in_sw = cg_work->subid;
  215. work->ntime_limit = max_offset;
  216. //printf("ID:%d, TS:%x\n",work->work_id_in_sw,work->timestamp);
  217. //work->ntime_offset = ntime_offset;
  218. }
  219. // returns true if queue full.
  220. static struct timeval last_force_queue;
  221. unsigned long usec_stamp(void)
  222. {
  223. static unsigned long long int first_usec = 0;
  224. struct timeval tv;
  225. unsigned long long int curr_usec;
  226. cgtime(&tv);
  227. curr_usec = tv.tv_sec * 1000000 + tv.tv_usec;
  228. if (first_usec == 0) {
  229. first_usec = curr_usec;
  230. curr_usec = 0;
  231. } else
  232. curr_usec -= first_usec;
  233. return curr_usec;
  234. }
  235. static bool spondoolies_queue_full_sp30(struct cgpu_info *cgpu)
  236. {
  237. struct spond_adapter* a = cgpu->device_data;
  238. #if 0
  239. static int bla = 0;
  240. if (!((bla++)%500)) {
  241. printf("FAKE TEST FLUSH T:%d!\n",usec_stamp());
  242. a->reset_mg_queue = 3;
  243. }
  244. #endif
  245. // Only once every 1/10 second do work.
  246. bool ret = false, do_sleep = false;
  247. int next_job_id;
  248. struct timeval tv;
  249. struct work *work;
  250. unsigned int usec;
  251. mutex_lock(&a->lock);
  252. assert(a->works_pending_tx <= REQUEST_SIZE);
  253. gettimeofday(&tv, NULL);
  254. usec = (tv.tv_sec-last_force_queue.tv_sec) * 1000000;
  255. usec += (tv.tv_usec-last_force_queue.tv_usec);
  256. if ((usec >= REQUEST_PERIOD) ||
  257. (a->reset_mg_queue == 3) || // push flush
  258. ((a->reset_mg_queue == 2)) || // Fast pull
  259. ((a->reset_mg_queue == 1) && (a->works_pending_tx == REQUEST_SIZE))) { // Fast push after flush
  260. spondoolies_flush_queue(a, (a->reset_mg_queue == 3));
  261. if (a->reset_mg_queue) {
  262. //printf("FLUSH(%d) %d T:%d\n",a->reset_mg_queue , a->works_pending_tx, usec_stamp());
  263. if (a->works_pending_tx || (a->reset_mg_queue == 3)) {
  264. a->reset_mg_queue--;
  265. }
  266. }
  267. last_force_queue = tv;
  268. }
  269. // see if we have enough jobs
  270. if (a->works_pending_tx == REQUEST_SIZE) {
  271. ret = true;
  272. goto return_unlock;
  273. }
  274. // see if can take 1 more job.
  275. // Must be smaller to prevent overflow.
  276. assert(MAX_JOBS_PENDING_IN_MINERGATE_SP30 < MINERGATE_ADAPTER_QUEUE_SP30);
  277. next_job_id = (a->current_job_id + 1) % MAX_JOBS_PENDING_IN_MINERGATE_SP30;
  278. if (a->my_jobs[next_job_id].cgminer_work) {
  279. ret = true;
  280. goto return_unlock;
  281. }
  282. work = get_queued(cgpu);
  283. if (unlikely(!work)) {
  284. do_sleep = true;
  285. goto return_unlock;
  286. }
  287. work->thr = cgpu->thr[0];
  288. work->thr_id = cgpu->thr[0]->id;
  289. assert(work->thr);
  290. a->current_job_id = next_job_id;
  291. work->subid = a->current_job_id;
  292. // Get pointer for the request
  293. a->my_jobs[a->current_job_id].cgminer_work = work;
  294. a->my_jobs[a->current_job_id].state = SPONDWORK_STATE_IN_BUSY;
  295. //printf("Push: %d\n", a->current_job_id);
  296. int max_ntime_roll = (work->drv_rolllimit < MAX_NROLES) ? work->drv_rolllimit : MAX_NROLES;
  297. minergate_do_job_req_sp30* pkt_job = &a->mp_next_req->req[a->works_pending_tx];
  298. fill_minergate_request(pkt_job, work, max_ntime_roll);
  299. a->works_in_driver++;
  300. a->works_pending_tx++;
  301. a->mp_next_req->req_count++;
  302. a->my_jobs[a->current_job_id].merkle_root = pkt_job->mrkle_root;
  303. return_unlock:
  304. //printf("D:P.TX:%d inD:%d\n", a->works_pending_tx, a->works_in_driver);
  305. mutex_unlock(&a->lock);
  306. if (do_sleep)
  307. cgsleep_ms(10);
  308. return ret;
  309. }
  310. static void spond_poll_stats(struct cgpu_info *spond, struct spond_adapter *a)
  311. {
  312. FILE *fp = fopen("/var/run/mg_rate_temp", "r");
  313. if (!fp) {
  314. applog(LOG_DEBUG, "SPOND unable to open mg_rate_temp");
  315. a->temp_rate = a->front_temp = a->rear_temp_top = a->rear_temp_bot = 0;
  316. } else {
  317. int ret = fscanf(fp, "%d %d %d %d", &a->temp_rate, &a->front_temp , &a->rear_temp_top , &a->rear_temp_bot);
  318. if (ret != 4)
  319. a->temp_rate = a->front_temp = a->rear_temp_top = a->rear_temp_bot = 0;
  320. fclose(fp);
  321. }
  322. applog(LOG_DEBUG, "SPOND poll_stats rate: %d front: %d rear(T/B): %d/%d",
  323. a->temp_rate, a->front_temp , a->rear_temp_top, a->rear_temp_bot);
  324. /* Use the rear temperature as the dev temperature for now */
  325. spond->temp = (a->rear_temp_top + a->rear_temp_bot)/2;
  326. }
  327. // Return completed work to submit_nonce() and work_completed()
  328. // struct timeval last_force_queue = {0};
  329. static int64_t spond_scanhash_sp30(struct thr_info *thr)
  330. {
  331. struct cgpu_info *cgpu = thr->cgpu;
  332. struct spond_adapter *a = cgpu->device_data;
  333. int64_t ghashes = 0;
  334. cgtimer_t cgt;
  335. time_t now_t;
  336. cgsleep_prepare_r(&cgt);
  337. now_t = time(NULL);
  338. /* Poll stats only once per second */
  339. if (now_t != a->last_stats) {
  340. a->last_stats = now_t;
  341. spond_poll_stats(cgpu, a);
  342. }
  343. if (a->parse_resp) {
  344. int array_size, i;
  345. mutex_lock(&a->lock);
  346. //ghashes = (a->mp_last_rsp->gh_div_50_rate);
  347. //ghashes = ghashes * 50000 * REQUEST_PERIOD;
  348. array_size = a->mp_last_rsp->rsp_count;
  349. for (i = 0; i < array_size; i++) { // walk the jobs
  350. int job_id;
  351. minergate_do_job_rsp_sp30* work = a->mp_last_rsp->rsp + i;
  352. job_id = work->work_id_in_sw;
  353. if ((a->my_jobs[job_id].cgminer_work)) {
  354. if (a->my_jobs[job_id].merkle_root == work->mrkle_root) {
  355. assert(a->my_jobs[job_id].state == SPONDWORK_STATE_IN_BUSY);
  356. if (work->winner_nonce) {
  357. struct work *cg_work = a->my_jobs[job_id].cgminer_work;
  358. bool ok;
  359. ok = submit_noffset_nonce(cg_work->thr, cg_work, work->winner_nonce, work->ntime_offset);
  360. if (ok)
  361. ghashes += 0xffffffffull * cg_work->device_diff;
  362. /*printf("WIn on %d (+%d), none=%x = %d\n",
  363. * work->work_id_in_sw, work->ntime_offset, htole32(work->winner_nonce), ok);*/
  364. a->wins++;
  365. }
  366. //printf("%d ntime_clones = %d\n",job_id,a->my_jobs[job_id].ntime_clones);
  367. //printf("Done with %d\n", job_id);
  368. if (work->job_complete) {
  369. //printf("Complete %d\n", job_id);
  370. work_completed(a->cgpu, a->my_jobs[job_id].cgminer_work);
  371. a->good++;
  372. a->my_jobs[job_id].cgminer_work = NULL;
  373. a->my_jobs[job_id].state = SPONDWORK_STATE_EMPTY;
  374. a->works_in_minergate_and_pending_tx--;
  375. a->works_in_driver--;
  376. }
  377. } else {
  378. a->bad++;
  379. printf("Dropping minergate old job id=%d mrkl=%x my-mrkl=%x\n",
  380. job_id, a->my_jobs[job_id].merkle_root, work->mrkle_root);
  381. }
  382. } else {
  383. a->empty++;
  384. printf("No cgminer job (id:%d res:%d)!\n",job_id, work->res);
  385. }
  386. }
  387. mutex_unlock(&a->lock);
  388. a->parse_resp = 0;
  389. }
  390. cgsleep_ms_r(&cgt, 40);
  391. return ghashes;
  392. }
  393. // Remove all work from queue
  394. static void spond_flush_work_sp30(struct cgpu_info *cgpu)
  395. {
  396. struct spond_adapter *a = cgpu->device_data;
  397. //printf("GOT FLUSH!%d\n");
  398. mutex_lock(&a->lock);
  399. a->reset_mg_queue = 3;
  400. mutex_unlock(&a->lock);
  401. }
  402. struct device_drv sp30_drv = {
  403. .drv_id = DRIVER_sp30,
  404. .dname = "Sp30",
  405. .name = "S30",
  406. .min_diff = 16,
  407. .max_diff = 1024.0, // Limit max diff to get some nonces back regardless
  408. .drv_detect = spondoolies_detect_sp30,
  409. .get_api_stats = spondoolies_api_stats_sp30,
  410. .thread_prepare = spondoolies_prepare_sp30,
  411. .thread_shutdown = spondoolies_shutdown_sp30,
  412. .hash_work = hash_queued_work,
  413. .queue_full = spondoolies_queue_full_sp30,
  414. .scanwork = spond_scanhash_sp30,
  415. .flush_work = spond_flush_work_sp30,
  416. };