OSDN Git Service

946a835e3920626c4364ccb0adc847d38bc9ae28
[android-x86/external-bluetooth-bluez.git] / android / hal-audio.c
1 /*
2  * Copyright (C) 2013 Intel Corporation
3  *
4  * Licensed under the Apache License, Version 2.0 (the "License");
5  * you may not use this file except in compliance with the License.
6  * You may obtain a copy of the License at
7  *
8  *      http://www.apache.org/licenses/LICENSE-2.0
9  *
10  * Unless required by applicable law or agreed to in writing, software
11  * distributed under the License is distributed on an "AS IS" BASIS,
12  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
13  * See the License for the specific language governing permissions and
14  * limitations under the License.
15  *
16  */
17
18 #include <errno.h>
19 #include <pthread.h>
20 #include <poll.h>
21 #include <stdio.h>
22 #include <stdlib.h>
23 #include <string.h>
24 #include <sys/socket.h>
25 #include <sys/un.h>
26 #include <unistd.h>
27 #include <arpa/inet.h>
28 #include <fcntl.h>
29
30 #include <hardware/audio.h>
31 #include <hardware/hardware.h>
32
33 #include "audio-msg.h"
34 #include "ipc-common.h"
35 #include "hal-log.h"
36 #include "hal-msg.h"
37 #include "hal-audio.h"
38 #include "../src/shared/util.h"
39
40 #define FIXED_A2DP_PLAYBACK_LATENCY_MS 25
41
42 #define FIXED_BUFFER_SIZE (20 * 512)
43
44 #define MAX_DELAY       100000 /* 100ms */
45
46 static const uint8_t a2dp_src_uuid[] = {
47                 0x00, 0x00, 0x11, 0x0a, 0x00, 0x00, 0x10, 0x00,
48                 0x80, 0x00, 0x00, 0x80, 0x5f, 0x9b, 0x34, 0xfb };
49
50 static int listen_sk = -1;
51 static int audio_sk = -1;
52
53 static pthread_t ipc_th = 0;
54 static pthread_mutex_t sk_mutex = PTHREAD_MUTEX_INITIALIZER;
55
56 static void timespec_add(struct timespec *base, uint64_t time_us,
57                                                         struct timespec *res)
58 {
59         res->tv_sec = base->tv_sec + time_us / 1000000;
60         res->tv_nsec = base->tv_nsec + (time_us % 1000000) * 1000;
61
62         if (res->tv_nsec >= 1000000000) {
63                 res->tv_sec++;
64                 res->tv_nsec -= 1000000000;
65         }
66 }
67
68 static void timespec_diff(struct timespec *a, struct timespec *b,
69                                                         struct timespec *res)
70 {
71         res->tv_sec = a->tv_sec - b->tv_sec;
72         res->tv_nsec = a->tv_nsec - b->tv_nsec;
73
74         if (res->tv_nsec < 0) {
75                 res->tv_sec--;
76                 res->tv_nsec += 1000000000; /* 1sec */
77         }
78 }
79
80 static uint64_t timespec_diff_us(struct timespec *a, struct timespec *b)
81 {
82         struct timespec res;
83
84         timespec_diff(a, b, &res);
85
86         return res.tv_sec * 1000000ll + res.tv_nsec / 1000ll;
87 }
88
89 #if defined(ANDROID)
90 /*
91  * Bionic does not have clock_nanosleep() prototype in time.h even though
92  * it provides its implementation.
93  */
94 extern int clock_nanosleep(clockid_t clock_id, int flags,
95                                         const struct timespec *request,
96                                         struct timespec *remain);
97 #endif
98
99 static const audio_codec_get_t audio_codecs[] = {
100                 codec_sbc,
101 };
102
103 #define NUM_CODECS (sizeof(audio_codecs) / sizeof(audio_codecs[0]))
104
105 #define MAX_AUDIO_ENDPOINTS NUM_CODECS
106
107 struct audio_endpoint {
108         uint8_t id;
109         const struct audio_codec *codec;
110         void *codec_data;
111         int fd;
112
113         struct media_packet *mp;
114         size_t mp_data_len;
115
116         uint16_t seq;
117         uint32_t samples;
118         struct timespec start;
119
120         bool resync;
121 };
122
123 static struct audio_endpoint audio_endpoints[MAX_AUDIO_ENDPOINTS];
124
125 enum a2dp_state_t {
126         AUDIO_A2DP_STATE_NONE,
127         AUDIO_A2DP_STATE_STANDBY,
128         AUDIO_A2DP_STATE_SUSPENDED,
129         AUDIO_A2DP_STATE_STARTED
130 };
131
132 struct a2dp_stream_out {
133         struct audio_stream_out stream;
134
135         struct audio_endpoint *ep;
136         enum a2dp_state_t audio_state;
137         struct audio_input_config cfg;
138
139         uint8_t *downmix_buf;
140 };
141
142 struct a2dp_audio_dev {
143         struct audio_hw_device dev;
144         struct a2dp_stream_out *out;
145 };
146
147 static int audio_ipc_cmd(uint8_t service_id, uint8_t opcode, uint16_t len,
148                         void *param, size_t *rsp_len, void *rsp, int *fd)
149 {
150         ssize_t ret;
151         struct msghdr msg;
152         struct iovec iv[2];
153         struct ipc_hdr cmd;
154         char cmsgbuf[CMSG_SPACE(sizeof(int))];
155         struct ipc_status s;
156         size_t s_len = sizeof(s);
157
158         pthread_mutex_lock(&sk_mutex);
159
160         if (audio_sk < 0) {
161                 error("audio: Invalid cmd socket passed to audio_ipc_cmd");
162                 goto failed;
163         }
164
165         if (!rsp || !rsp_len) {
166                 memset(&s, 0, s_len);
167                 rsp_len = &s_len;
168                 rsp = &s;
169         }
170
171         memset(&msg, 0, sizeof(msg));
172         memset(&cmd, 0, sizeof(cmd));
173
174         cmd.service_id = service_id;
175         cmd.opcode = opcode;
176         cmd.len = len;
177
178         iv[0].iov_base = &cmd;
179         iv[0].iov_len = sizeof(cmd);
180
181         iv[1].iov_base = param;
182         iv[1].iov_len = len;
183
184         msg.msg_iov = iv;
185         msg.msg_iovlen = 2;
186
187         ret = sendmsg(audio_sk, &msg, 0);
188         if (ret < 0) {
189                 error("audio: Sending command failed:%s", strerror(errno));
190                 goto failed;
191         }
192
193         /* socket was shutdown */
194         if (ret == 0) {
195                 error("audio: Command socket closed");
196                 goto failed;
197         }
198
199         memset(&msg, 0, sizeof(msg));
200         memset(&cmd, 0, sizeof(cmd));
201
202         iv[0].iov_base = &cmd;
203         iv[0].iov_len = sizeof(cmd);
204
205         iv[1].iov_base = rsp;
206         iv[1].iov_len = *rsp_len;
207
208         msg.msg_iov = iv;
209         msg.msg_iovlen = 2;
210
211         if (fd) {
212                 memset(cmsgbuf, 0, sizeof(cmsgbuf));
213                 msg.msg_control = cmsgbuf;
214                 msg.msg_controllen = sizeof(cmsgbuf);
215         }
216
217         ret = recvmsg(audio_sk, &msg, 0);
218         if (ret < 0) {
219                 error("audio: Receiving command response failed:%s",
220                                                         strerror(errno));
221                 goto failed;
222         }
223
224         if (ret < (ssize_t) sizeof(cmd)) {
225                 error("audio: Too small response received(%zd bytes)", ret);
226                 goto failed;
227         }
228
229         if (cmd.service_id != service_id) {
230                 error("audio: Invalid service id (%u vs %u)", cmd.service_id,
231                                                                 service_id);
232                 goto failed;
233         }
234
235         if (ret != (ssize_t) (sizeof(cmd) + cmd.len)) {
236                 error("audio: Malformed response received(%zd bytes)", ret);
237                 goto failed;
238         }
239
240         if (cmd.opcode != opcode && cmd.opcode != AUDIO_OP_STATUS) {
241                 error("audio: Invalid opcode received (%u vs %u)",
242                                                 cmd.opcode, opcode);
243                 goto failed;
244         }
245
246         if (cmd.opcode == AUDIO_OP_STATUS) {
247                 struct ipc_status *s = rsp;
248
249                 if (sizeof(*s) != cmd.len) {
250                         error("audio: Invalid status length");
251                         goto failed;
252                 }
253
254                 if (s->code == AUDIO_STATUS_SUCCESS) {
255                         error("audio: Invalid success status response");
256                         goto failed;
257                 }
258
259                 pthread_mutex_unlock(&sk_mutex);
260
261                 return s->code;
262         }
263
264         pthread_mutex_unlock(&sk_mutex);
265
266         /* Receive auxiliary data in msg */
267         if (fd) {
268                 struct cmsghdr *cmsg;
269
270                 *fd = -1;
271
272                 for (cmsg = CMSG_FIRSTHDR(&msg); cmsg;
273                                         cmsg = CMSG_NXTHDR(&msg, cmsg)) {
274                         if (cmsg->cmsg_level == SOL_SOCKET
275                                         && cmsg->cmsg_type == SCM_RIGHTS) {
276                                 memcpy(fd, CMSG_DATA(cmsg), sizeof(int));
277                                 break;
278                         }
279                 }
280
281                 if (*fd < 0)
282                         goto failed;
283         }
284
285         if (rsp_len)
286                 *rsp_len = cmd.len;
287
288         return AUDIO_STATUS_SUCCESS;
289
290 failed:
291         /* Some serious issue happen on IPC - recover */
292         shutdown(audio_sk, SHUT_RDWR);
293         pthread_mutex_unlock(&sk_mutex);
294
295         return AUDIO_STATUS_FAILED;
296 }
297
298 static int ipc_open_cmd(const struct audio_codec *codec)
299 {
300         uint8_t buf[BLUEZ_AUDIO_MTU];
301         struct audio_cmd_open *cmd = (struct audio_cmd_open *) buf;
302         struct audio_rsp_open rsp;
303         size_t cmd_len = sizeof(buf) - sizeof(*cmd);
304         size_t rsp_len = sizeof(rsp);
305         int result;
306
307         DBG("");
308
309         memcpy(cmd->uuid, a2dp_src_uuid, sizeof(a2dp_src_uuid));
310
311         cmd->codec = codec->type;
312         cmd->presets = codec->get_presets(cmd->preset, &cmd_len);
313
314         cmd_len += sizeof(*cmd);
315
316         result = audio_ipc_cmd(AUDIO_SERVICE_ID, AUDIO_OP_OPEN, cmd_len, cmd,
317                                 &rsp_len, &rsp, NULL);
318
319         if (result != AUDIO_STATUS_SUCCESS)
320                 return 0;
321
322         return rsp.id;
323 }
324
325 static int ipc_close_cmd(uint8_t endpoint_id)
326 {
327         struct audio_cmd_close cmd;
328         int result;
329
330         DBG("");
331
332         cmd.id = endpoint_id;
333
334         result = audio_ipc_cmd(AUDIO_SERVICE_ID, AUDIO_OP_CLOSE,
335                                 sizeof(cmd), &cmd, NULL, NULL, NULL);
336
337         return result;
338 }
339
340 static int ipc_open_stream_cmd(uint8_t endpoint_id, uint16_t *mtu, int *fd,
341                                                 struct audio_preset **caps)
342 {
343         char buf[BLUEZ_AUDIO_MTU];
344         struct audio_cmd_open_stream cmd;
345         struct audio_rsp_open_stream *rsp =
346                                         (struct audio_rsp_open_stream *) &buf;
347         size_t rsp_len = sizeof(buf);
348         int result;
349
350         DBG("");
351
352         if (!caps)
353                 return AUDIO_STATUS_FAILED;
354
355         cmd.id = endpoint_id;
356
357         result = audio_ipc_cmd(AUDIO_SERVICE_ID, AUDIO_OP_OPEN_STREAM,
358                                 sizeof(cmd), &cmd, &rsp_len, rsp, fd);
359         if (result == AUDIO_STATUS_SUCCESS) {
360                 size_t buf_len = sizeof(struct audio_preset) +
361                                         rsp->preset[0].len;
362                 *mtu = rsp->mtu;
363                 *caps = malloc(buf_len);
364                 memcpy(*caps, &rsp->preset, buf_len);
365         } else {
366                 *caps = NULL;
367         }
368
369         return result;
370 }
371
372 static int ipc_close_stream_cmd(uint8_t endpoint_id)
373 {
374         struct audio_cmd_close_stream cmd;
375         int result;
376
377         DBG("");
378
379         cmd.id = endpoint_id;
380
381         result = audio_ipc_cmd(AUDIO_SERVICE_ID, AUDIO_OP_CLOSE_STREAM,
382                                         sizeof(cmd), &cmd, NULL, NULL, NULL);
383
384         return result;
385 }
386
387 static int ipc_resume_stream_cmd(uint8_t endpoint_id)
388 {
389         struct audio_cmd_resume_stream cmd;
390         int result;
391
392         DBG("");
393
394         cmd.id = endpoint_id;
395
396         result = audio_ipc_cmd(AUDIO_SERVICE_ID, AUDIO_OP_RESUME_STREAM,
397                                         sizeof(cmd), &cmd, NULL, NULL, NULL);
398
399         return result;
400 }
401
402 static int ipc_suspend_stream_cmd(uint8_t endpoint_id)
403 {
404         struct audio_cmd_suspend_stream cmd;
405         int result;
406
407         DBG("");
408
409         cmd.id = endpoint_id;
410
411         result = audio_ipc_cmd(AUDIO_SERVICE_ID, AUDIO_OP_SUSPEND_STREAM,
412                                         sizeof(cmd), &cmd, NULL, NULL, NULL);
413
414         return result;
415 }
416
417 static int register_endpoints(void)
418 {
419         struct audio_endpoint *ep = &audio_endpoints[0];
420         size_t i;
421
422         for (i = 0; i < NUM_CODECS; i++, ep++) {
423                 const struct audio_codec *codec = audio_codecs[i]();
424
425                 if (!codec)
426                         return AUDIO_STATUS_FAILED;
427
428                 ep->id = ipc_open_cmd(codec);
429
430                 if (!ep->id)
431                         return AUDIO_STATUS_FAILED;
432
433                 ep->codec = codec;
434                 ep->codec_data = NULL;
435                 ep->fd = -1;
436         }
437
438         return AUDIO_STATUS_SUCCESS;
439 }
440
441 static void unregister_endpoints(void)
442 {
443         size_t i;
444
445         for (i = 0; i < MAX_AUDIO_ENDPOINTS; i++) {
446                 struct audio_endpoint *ep = &audio_endpoints[i];
447
448                 if (ep->id) {
449                         ipc_close_cmd(ep->id);
450                         memset(ep, 0, sizeof(*ep));
451                 }
452         }
453 }
454
455 static bool open_endpoint(struct audio_endpoint *ep,
456                                                 struct audio_input_config *cfg)
457 {
458         struct audio_preset *preset;
459         const struct audio_codec *codec;
460         uint16_t mtu;
461         uint16_t payload_len;
462         int fd;
463
464         if (ipc_open_stream_cmd(ep->id, &mtu, &fd, &preset) !=
465                                                         AUDIO_STATUS_SUCCESS)
466                 return false;
467
468         DBG("mtu=%u", mtu);
469
470         payload_len = mtu;
471         if (ep->codec->use_rtp)
472                 payload_len -= sizeof(struct rtp_header);
473
474         ep->fd = fd;
475
476         codec = ep->codec;
477         codec->init(preset, payload_len, &ep->codec_data);
478         codec->get_config(ep->codec_data, cfg);
479
480         ep->mp = calloc(mtu, 1);
481         if (!ep->mp)
482                 goto failed;
483
484         if (ep->codec->use_rtp) {
485                 struct media_packet_rtp *mp_rtp =
486                                         (struct media_packet_rtp *) ep->mp;
487                 mp_rtp->hdr.v = 2;
488                 mp_rtp->hdr.pt = 0x60;
489                 mp_rtp->hdr.ssrc = htonl(1);
490         }
491
492         ep->mp_data_len = payload_len;
493
494         free(preset);
495
496         return true;
497
498 failed:
499         close(fd);
500         free(preset);
501
502         return false;
503 }
504
505 static void close_endpoint(struct audio_endpoint *ep)
506 {
507         ipc_close_stream_cmd(ep->id);
508         if (ep->fd >= 0) {
509                 close(ep->fd);
510                 ep->fd = -1;
511         }
512
513         free(ep->mp);
514
515         ep->codec->cleanup(ep->codec_data);
516         ep->codec_data = NULL;
517 }
518
519 static bool resume_endpoint(struct audio_endpoint *ep)
520 {
521         if (ipc_resume_stream_cmd(ep->id) != AUDIO_STATUS_SUCCESS)
522                 return false;
523
524         ep->samples = 0;
525         ep->resync = false;
526
527         ep->codec->update_qos(ep->codec_data, QOS_POLICY_DEFAULT);
528
529         return true;
530 }
531
532 static void downmix_to_mono(struct a2dp_stream_out *out, const uint8_t *buffer,
533                                                                 size_t bytes)
534 {
535         const int16_t *input = (const void *) buffer;
536         int16_t *output = (void *) out->downmix_buf;
537         size_t i, frames;
538
539         /* PCM 16bit stereo */
540         frames = bytes / (2 * sizeof(int16_t));
541
542         for (i = 0; i < frames; i++) {
543                 int16_t l = le16_to_cpu(get_unaligned(&input[i * 2]));
544                 int16_t r = le16_to_cpu(get_unaligned(&input[i * 2 + 1]));
545
546                 put_unaligned(cpu_to_le16((l + r) / 2), &output[i]);
547         }
548 }
549
550 static bool wait_for_endpoint(struct audio_endpoint *ep, bool *writable)
551 {
552         int ret;
553
554         while (true) {
555                 struct pollfd pollfd;
556
557                 pollfd.fd = ep->fd;
558                 pollfd.events = POLLOUT;
559                 pollfd.revents = 0;
560
561                 ret = poll(&pollfd, 1, 500);
562
563                 if (ret >= 0) {
564                         *writable = !!(pollfd.revents & POLLOUT);
565                         break;
566                 }
567
568                 if (errno != EINTR) {
569                         ret = errno;
570                         error("poll failed (%d)", ret);
571                         return false;
572                 }
573         }
574
575         return true;
576 }
577
578 static bool write_to_endpoint(struct audio_endpoint *ep, size_t bytes)
579 {
580         struct media_packet *mp = (struct media_packet *) ep->mp;
581         int ret;
582
583         while (true) {
584                 ret = write(ep->fd, mp, bytes);
585
586                 if (ret >= 0)
587                         break;
588
589                 /*
590                  * this should not happen so let's issue warning, but do not
591                  * fail, we can try to write next packet
592                  */
593                 if (errno == EAGAIN) {
594                         ret = errno;
595                         warn("write failed (%d)", ret);
596                         break;
597                 }
598
599                 if (errno != EINTR) {
600                         ret = errno;
601                         error("write failed (%d)", ret);
602                         return false;
603                 }
604         }
605
606         return true;
607 }
608
609 static bool write_data(struct a2dp_stream_out *out, const void *buffer,
610                                                                 size_t bytes)
611 {
612         struct audio_endpoint *ep = out->ep;
613         struct media_packet *mp = (struct media_packet *) ep->mp;
614         struct media_packet_rtp *mp_rtp = (struct media_packet_rtp *) ep->mp;
615         size_t free_space = ep->mp_data_len;
616         size_t consumed = 0;
617
618         while (consumed < bytes) {
619                 size_t written = 0;
620                 ssize_t read;
621                 uint32_t samples;
622                 int ret;
623                 struct timespec current;
624                 uint64_t audio_sent, audio_passed;
625                 bool do_write = false;
626
627                 /*
628                  * prepare media packet in advance so we don't waste time after
629                  * wakeup
630                  */
631                 if (ep->codec->use_rtp) {
632                         mp_rtp->hdr.sequence_number = htons(ep->seq++);
633                         mp_rtp->hdr.timestamp = htonl(ep->samples);
634                 }
635                 read = ep->codec->encode_mediapacket(ep->codec_data,
636                                                 buffer + consumed,
637                                                 bytes - consumed, mp,
638                                                 free_space, &written);
639
640                 /*
641                  * not much we can do here, let's just ignore remaining
642                  * data and continue
643                  */
644                 if (read <= 0)
645                         return true;
646
647                 /* calculate where are we and where we should be */
648                 clock_gettime(CLOCK_MONOTONIC, &current);
649                 if (!ep->samples)
650                         memcpy(&ep->start, &current, sizeof(ep->start));
651                 audio_sent = ep->samples * 1000000ll / out->cfg.rate;
652                 audio_passed = timespec_diff_us(&current, &ep->start);
653
654                 /*
655                  * if we're ahead of stream then wait for next write point,
656                  * if we're lagging more than 100ms then stop writing and just
657                  * skip data until we're back in sync
658                  */
659                 if (audio_sent > audio_passed) {
660                         struct timespec anchor;
661
662                         ep->resync = false;
663
664                         timespec_add(&ep->start, audio_sent, &anchor);
665
666                         while (true) {
667                                 ret = clock_nanosleep(CLOCK_MONOTONIC,
668                                                         TIMER_ABSTIME, &anchor,
669                                                         NULL);
670
671                                 if (!ret)
672                                         break;
673
674                                 if (ret != EINTR) {
675                                         error("clock_nanosleep failed (%d)",
676                                                                         ret);
677                                         return false;
678                                 }
679                         }
680                 } else if (!ep->resync) {
681                         uint64_t diff = audio_passed - audio_sent;
682
683                         if (diff > MAX_DELAY) {
684                                 warn("lag is %jums, resyncing", diff / 1000);
685
686                                 ep->codec->update_qos(ep->codec_data,
687                                                         QOS_POLICY_DECREASE);
688                                 ep->resync = true;
689                         }
690                 }
691
692                 /* in resync mode we'll just drop mediapackets */
693                 if (!ep->resync) {
694                         /* wait some time for socket to be ready for write,
695                          * but we'll just skip writing data if timeout occurs
696                          */
697                         if (!wait_for_endpoint(ep, &do_write))
698                                 return false;
699
700                         if (do_write) {
701                                 if (ep->codec->use_rtp)
702                                         written += sizeof(struct rtp_header);
703
704                                 if (!write_to_endpoint(ep, written))
705                                         return false;
706                         }
707                 }
708
709                 /*
710                  * AudioFlinger provides 16bit PCM, so sample size is 2 bytes
711                  * multiplied by number of channels. Number of channels is
712                  * simply number of bits set in channels mask.
713                  */
714                 samples = read / (2 * popcount(out->cfg.channels));
715                 ep->samples += samples;
716                 consumed += read;
717         }
718
719         return true;
720 }
721
722 static ssize_t out_write(struct audio_stream_out *stream, const void *buffer,
723                                                                 size_t bytes)
724 {
725         struct a2dp_stream_out *out = (struct a2dp_stream_out *) stream;
726         const void *in_buf = buffer;
727         size_t in_len = bytes;
728
729         /* just return in case we're closing */
730         if (out->audio_state == AUDIO_A2DP_STATE_NONE)
731                 return -1;
732
733         /* We can auto-start only from standby */
734         if (out->audio_state == AUDIO_A2DP_STATE_STANDBY) {
735                 DBG("stream in standby, auto-start");
736
737                 if (!resume_endpoint(out->ep))
738                         return -1;
739
740                 out->audio_state = AUDIO_A2DP_STATE_STARTED;
741         }
742
743         if (out->audio_state != AUDIO_A2DP_STATE_STARTED) {
744                 error("audio: stream not started");
745                 return -1;
746         }
747
748         if (out->ep->fd < 0) {
749                 error("audio: no transport socket");
750                 return -1;
751         }
752
753         /*
754          * currently Android audioflinger is not able to provide mono stream on
755          * A2DP output so down mixing needs to be done in hal-audio plugin.
756          *
757          * for reference see
758          * AudioFlinger::PlaybackThread::readOutputParameters()
759          * frameworks/av/services/audioflinger/Threads.cpp:1631
760          */
761         if (out->cfg.channels == AUDIO_CHANNEL_OUT_MONO) {
762                 if (!out->downmix_buf) {
763                         error("audio: downmix buffer not initialized");
764                         return -1;
765                 }
766
767                 downmix_to_mono(out, buffer, bytes);
768
769                 in_buf = out->downmix_buf;
770                 in_len = bytes / 2;
771         }
772
773         if (!write_data(out, in_buf, in_len))
774                 return -1;
775
776         return bytes;
777 }
778
779 static uint32_t out_get_sample_rate(const struct audio_stream *stream)
780 {
781         struct a2dp_stream_out *out = (struct a2dp_stream_out *) stream;
782
783         DBG("");
784
785         return out->cfg.rate;
786 }
787
788 static int out_set_sample_rate(struct audio_stream *stream, uint32_t rate)
789 {
790         struct a2dp_stream_out *out = (struct a2dp_stream_out *) stream;
791
792         DBG("");
793
794         if (rate != out->cfg.rate) {
795                 warn("audio: cannot set sample rate to %d", rate);
796                 return -1;
797         }
798
799         return 0;
800 }
801
802 static size_t out_get_buffer_size(const struct audio_stream *stream)
803 {
804         DBG("");
805
806         /*
807          * We should return proper buffer size calculated by codec (so each
808          * input buffer is encoded into single media packed) but this does not
809          * work well with AudioFlinger and causes problems. For this reason we
810          * use magic value here and out_write code takes care of splitting
811          * input buffer into multiple media packets.
812          */
813         return FIXED_BUFFER_SIZE;
814 }
815
816 static uint32_t out_get_channels(const struct audio_stream *stream)
817 {
818         DBG("");
819
820         /*
821          * AudioFlinger can only provide stereo stream, so we return it here and
822          * later we'll downmix this to mono in case codec requires it
823          */
824
825         return AUDIO_CHANNEL_OUT_STEREO;
826 }
827
828 static audio_format_t out_get_format(const struct audio_stream *stream)
829 {
830         struct a2dp_stream_out *out = (struct a2dp_stream_out *) stream;
831
832         DBG("");
833
834         return out->cfg.format;
835 }
836
837 static int out_set_format(struct audio_stream *stream, audio_format_t format)
838 {
839         DBG("");
840         return -ENOSYS;
841 }
842
843 static int out_standby(struct audio_stream *stream)
844 {
845         struct a2dp_stream_out *out = (struct a2dp_stream_out *) stream;
846
847         DBG("");
848
849         if (out->audio_state == AUDIO_A2DP_STATE_STARTED) {
850                 if (ipc_suspend_stream_cmd(out->ep->id) != AUDIO_STATUS_SUCCESS)
851                         return -1;
852                 out->audio_state = AUDIO_A2DP_STATE_STANDBY;
853         }
854
855         return 0;
856 }
857
858 static int out_dump(const struct audio_stream *stream, int fd)
859 {
860         DBG("");
861         return -ENOSYS;
862 }
863
864 static int out_set_parameters(struct audio_stream *stream, const char *kvpairs)
865 {
866         struct a2dp_stream_out *out = (struct a2dp_stream_out *) stream;
867         char *kvpair;
868         char *str;
869         char *saveptr;
870         bool enter_suspend = false;
871         bool exit_suspend = false;
872
873         DBG("%s", kvpairs);
874
875         str = strdup(kvpairs);
876         if (!str)
877                 return -ENOMEM;
878
879         kvpair = strtok_r(str, ";", &saveptr);
880
881         for (; kvpair && *kvpair; kvpair = strtok_r(NULL, ";", &saveptr)) {
882                 char *keyval;
883
884                 keyval = strchr(kvpair, '=');
885                 if (!keyval)
886                         continue;
887
888                 *keyval = '\0';
889                 keyval++;
890
891                 if (!strcmp(kvpair, "closing")) {
892                         if (!strcmp(keyval, "true"))
893                                 out->audio_state = AUDIO_A2DP_STATE_NONE;
894                 } else if (!strcmp(kvpair, "A2dpSuspended")) {
895                         if (!strcmp(keyval, "true"))
896                                 enter_suspend = true;
897                         else
898                                 exit_suspend = true;
899                 }
900         }
901
902         free(str);
903
904         if (enter_suspend && out->audio_state == AUDIO_A2DP_STATE_STARTED) {
905                 if (ipc_suspend_stream_cmd(out->ep->id) != AUDIO_STATUS_SUCCESS)
906                         return -1;
907                 out->audio_state = AUDIO_A2DP_STATE_SUSPENDED;
908         }
909
910         if (exit_suspend && out->audio_state == AUDIO_A2DP_STATE_SUSPENDED)
911                 out->audio_state = AUDIO_A2DP_STATE_STANDBY;
912
913         return 0;
914 }
915
916 static char *out_get_parameters(const struct audio_stream *stream,
917                                                         const char *keys)
918 {
919         DBG("");
920         return strdup("");
921 }
922
923 static uint32_t out_get_latency(const struct audio_stream_out *stream)
924 {
925         struct a2dp_stream_out *out = (struct a2dp_stream_out *) stream;
926         struct audio_endpoint *ep = out->ep;
927         size_t pkt_duration;
928
929         DBG("");
930
931         pkt_duration = ep->codec->get_mediapacket_duration(ep->codec_data);
932
933         return FIXED_A2DP_PLAYBACK_LATENCY_MS + pkt_duration / 1000;
934 }
935
936 static int out_set_volume(struct audio_stream_out *stream, float left,
937                                                                 float right)
938 {
939         DBG("");
940         /* volume controlled in audioflinger mixer (digital) */
941         return -ENOSYS;
942 }
943
944 static int out_get_render_position(const struct audio_stream_out *stream,
945                                                         uint32_t *dsp_frames)
946 {
947         DBG("");
948         return -ENOSYS;
949 }
950
951 static int out_add_audio_effect(const struct audio_stream *stream,
952                                                         effect_handle_t effect)
953 {
954         DBG("");
955         return -ENOSYS;
956 }
957
958 static int out_remove_audio_effect(const struct audio_stream *stream,
959                                                         effect_handle_t effect)
960 {
961         DBG("");
962         return -ENOSYS;
963 }
964
965 static uint32_t in_get_sample_rate(const struct audio_stream *stream)
966 {
967         DBG("");
968         return -ENOSYS;
969 }
970
971 static int in_set_sample_rate(struct audio_stream *stream, uint32_t rate)
972 {
973         DBG("");
974         return -ENOSYS;
975 }
976
977 static size_t in_get_buffer_size(const struct audio_stream *stream)
978 {
979         DBG("");
980         return -ENOSYS;
981 }
982
983 static uint32_t in_get_channels(const struct audio_stream *stream)
984 {
985         DBG("");
986         return -ENOSYS;
987 }
988
989 static audio_format_t in_get_format(const struct audio_stream *stream)
990 {
991         DBG("");
992         return -ENOSYS;
993 }
994
995 static int in_set_format(struct audio_stream *stream, audio_format_t format)
996 {
997         DBG("");
998         return -ENOSYS;
999 }
1000
1001 static int in_standby(struct audio_stream *stream)
1002 {
1003         DBG("");
1004         return -ENOSYS;
1005 }
1006
1007 static int in_dump(const struct audio_stream *stream, int fd)
1008 {
1009         DBG("");
1010         return -ENOSYS;
1011 }
1012
1013 static int in_set_parameters(struct audio_stream *stream, const char *kvpairs)
1014 {
1015         DBG("");
1016         return -ENOSYS;
1017 }
1018
1019 static char *in_get_parameters(const struct audio_stream *stream,
1020                                                         const char *keys)
1021 {
1022         DBG("");
1023         return strdup("");
1024 }
1025
1026 static int in_set_gain(struct audio_stream_in *stream, float gain)
1027 {
1028         DBG("");
1029         return -ENOSYS;
1030 }
1031
1032 static ssize_t in_read(struct audio_stream_in *stream, void *buffer,
1033                                                                 size_t bytes)
1034 {
1035         DBG("");
1036         return -ENOSYS;
1037 }
1038
1039 static uint32_t in_get_input_frames_lost(struct audio_stream_in *stream)
1040 {
1041         DBG("");
1042         return -ENOSYS;
1043 }
1044
1045 static int in_add_audio_effect(const struct audio_stream *stream,
1046                                                         effect_handle_t effect)
1047 {
1048         DBG("");
1049         return -ENOSYS;
1050 }
1051
1052 static int in_remove_audio_effect(const struct audio_stream *stream,
1053                                                         effect_handle_t effect)
1054 {
1055         DBG("");
1056         return -ENOSYS;
1057 }
1058
1059 static int audio_open_output_stream(struct audio_hw_device *dev,
1060                                         audio_io_handle_t handle,
1061                                         audio_devices_t devices,
1062                                         audio_output_flags_t flags,
1063                                         struct audio_config *config,
1064                                         struct audio_stream_out **stream_out)
1065
1066 {
1067         struct a2dp_audio_dev *a2dp_dev = (struct a2dp_audio_dev *) dev;
1068         struct a2dp_stream_out *out;
1069
1070         out = calloc(1, sizeof(struct a2dp_stream_out));
1071         if (!out)
1072                 return -ENOMEM;
1073
1074         DBG("");
1075
1076         out->stream.common.get_sample_rate = out_get_sample_rate;
1077         out->stream.common.set_sample_rate = out_set_sample_rate;
1078         out->stream.common.get_buffer_size = out_get_buffer_size;
1079         out->stream.common.get_channels = out_get_channels;
1080         out->stream.common.get_format = out_get_format;
1081         out->stream.common.set_format = out_set_format;
1082         out->stream.common.standby = out_standby;
1083         out->stream.common.dump = out_dump;
1084         out->stream.common.set_parameters = out_set_parameters;
1085         out->stream.common.get_parameters = out_get_parameters;
1086         out->stream.common.add_audio_effect = out_add_audio_effect;
1087         out->stream.common.remove_audio_effect = out_remove_audio_effect;
1088         out->stream.get_latency = out_get_latency;
1089         out->stream.set_volume = out_set_volume;
1090         out->stream.write = out_write;
1091         out->stream.get_render_position = out_get_render_position;
1092
1093         /* TODO: for now we always use endpoint 0 */
1094         out->ep = &audio_endpoints[0];
1095
1096         if (!open_endpoint(out->ep, &out->cfg))
1097                 goto fail;
1098
1099         DBG("rate=%d channels=%d format=%d", out->cfg.rate,
1100                                         out->cfg.channels, out->cfg.format);
1101
1102         if (out->cfg.channels == AUDIO_CHANNEL_OUT_MONO) {
1103                 out->downmix_buf = malloc(FIXED_BUFFER_SIZE / 2);
1104                 if (!out->downmix_buf)
1105                         goto fail;
1106         }
1107
1108         *stream_out = &out->stream;
1109         a2dp_dev->out = out;
1110
1111         out->audio_state = AUDIO_A2DP_STATE_STANDBY;
1112
1113         return 0;
1114
1115 fail:
1116         error("audio: cannot open output stream");
1117         free(out);
1118         *stream_out = NULL;
1119         return -EIO;
1120 }
1121
1122 static void audio_close_output_stream(struct audio_hw_device *dev,
1123                                         struct audio_stream_out *stream)
1124 {
1125         struct a2dp_audio_dev *a2dp_dev = (struct a2dp_audio_dev *) dev;
1126         struct a2dp_stream_out *out = (struct a2dp_stream_out *) stream;
1127
1128         DBG("");
1129
1130         close_endpoint(a2dp_dev->out->ep);
1131
1132         free(out->downmix_buf);
1133
1134         free(stream);
1135         a2dp_dev->out = NULL;
1136 }
1137
1138 static int audio_set_parameters(struct audio_hw_device *dev,
1139                                                         const char *kvpairs)
1140 {
1141         struct a2dp_audio_dev *a2dp_dev = (struct a2dp_audio_dev *) dev;
1142         struct a2dp_stream_out *out = a2dp_dev->out;
1143
1144         DBG("");
1145
1146         if (!out)
1147                 return 0;
1148
1149         return out->stream.common.set_parameters((struct audio_stream *) out,
1150                                                                 kvpairs);
1151 }
1152
1153 static char *audio_get_parameters(const struct audio_hw_device *dev,
1154                                                         const char *keys)
1155 {
1156         DBG("");
1157         return strdup("");
1158 }
1159
1160 static int audio_init_check(const struct audio_hw_device *dev)
1161 {
1162         DBG("");
1163         return 0;
1164 }
1165
1166 static int audio_set_voice_volume(struct audio_hw_device *dev, float volume)
1167 {
1168         DBG("");
1169         return -ENOSYS;
1170 }
1171
1172 static int audio_set_master_volume(struct audio_hw_device *dev, float volume)
1173 {
1174         DBG("");
1175         return -ENOSYS;
1176 }
1177
1178 static int audio_set_mode(struct audio_hw_device *dev, int mode)
1179 {
1180         DBG("");
1181         return -ENOSYS;
1182 }
1183
1184 static int audio_set_mic_mute(struct audio_hw_device *dev, bool state)
1185 {
1186         DBG("");
1187         return -ENOSYS;
1188 }
1189
1190 static int audio_get_mic_mute(const struct audio_hw_device *dev, bool *state)
1191 {
1192         DBG("");
1193         return -ENOSYS;
1194 }
1195
1196 static size_t audio_get_input_buffer_size(const struct audio_hw_device *dev,
1197                                         const struct audio_config *config)
1198 {
1199         DBG("");
1200         return -ENOSYS;
1201 }
1202
1203 static int audio_open_input_stream(struct audio_hw_device *dev,
1204                                         audio_io_handle_t handle,
1205                                         audio_devices_t devices,
1206                                         struct audio_config *config,
1207                                         struct audio_stream_in **stream_in)
1208 {
1209         struct audio_stream_in *in;
1210
1211         DBG("");
1212
1213         in = calloc(1, sizeof(struct audio_stream_in));
1214         if (!in)
1215                 return -ENOMEM;
1216
1217         in->common.get_sample_rate = in_get_sample_rate;
1218         in->common.set_sample_rate = in_set_sample_rate;
1219         in->common.get_buffer_size = in_get_buffer_size;
1220         in->common.get_channels = in_get_channels;
1221         in->common.get_format = in_get_format;
1222         in->common.set_format = in_set_format;
1223         in->common.standby = in_standby;
1224         in->common.dump = in_dump;
1225         in->common.set_parameters = in_set_parameters;
1226         in->common.get_parameters = in_get_parameters;
1227         in->common.add_audio_effect = in_add_audio_effect;
1228         in->common.remove_audio_effect = in_remove_audio_effect;
1229         in->set_gain = in_set_gain;
1230         in->read = in_read;
1231         in->get_input_frames_lost = in_get_input_frames_lost;
1232
1233         *stream_in = in;
1234
1235         return 0;
1236 }
1237
1238 static void audio_close_input_stream(struct audio_hw_device *dev,
1239                                         struct audio_stream_in *stream_in)
1240 {
1241         DBG("");
1242         free(stream_in);
1243 }
1244
1245 static int audio_dump(const audio_hw_device_t *device, int fd)
1246 {
1247         DBG("");
1248         return -ENOSYS;
1249 }
1250
1251 static int audio_close(hw_device_t *device)
1252 {
1253         struct a2dp_audio_dev *a2dp_dev = (struct a2dp_audio_dev *)device;
1254
1255         DBG("");
1256
1257         unregister_endpoints();
1258
1259         shutdown(listen_sk, SHUT_RDWR);
1260         shutdown(audio_sk, SHUT_RDWR);
1261
1262         pthread_join(ipc_th, NULL);
1263
1264         close(listen_sk);
1265         listen_sk = -1;
1266
1267         free(a2dp_dev);
1268         return 0;
1269 }
1270
1271 static void *ipc_handler(void *data)
1272 {
1273         bool done = false;
1274         struct pollfd pfd;
1275         int sk;
1276
1277         DBG("");
1278
1279         while (!done) {
1280                 DBG("Waiting for connection ...");
1281
1282                 sk = accept(listen_sk, NULL, NULL);
1283                 if (sk < 0) {
1284                         int err = errno;
1285
1286                         if (err == EINTR)
1287                                 continue;
1288
1289                         if (err != ECONNABORTED && err != EINVAL)
1290                                 error("audio: Failed to accept socket: %d (%s)",
1291                                                         err, strerror(err));
1292
1293                         break;
1294                 }
1295
1296                 pthread_mutex_lock(&sk_mutex);
1297                 audio_sk = sk;
1298                 pthread_mutex_unlock(&sk_mutex);
1299
1300                 DBG("Audio IPC: Connected");
1301
1302                 if (register_endpoints() != AUDIO_STATUS_SUCCESS) {
1303                         error("audio: Failed to register endpoints");
1304
1305                         unregister_endpoints();
1306
1307                         pthread_mutex_lock(&sk_mutex);
1308                         shutdown(audio_sk, SHUT_RDWR);
1309                         close(audio_sk);
1310                         audio_sk = -1;
1311                         pthread_mutex_unlock(&sk_mutex);
1312
1313                         continue;
1314                 }
1315
1316                 memset(&pfd, 0, sizeof(pfd));
1317                 pfd.fd = audio_sk;
1318                 pfd.events = POLLHUP | POLLERR | POLLNVAL;
1319
1320                 /* Check if socket is still alive. Empty while loop.*/
1321                 while (poll(&pfd, 1, -1) < 0 && errno == EINTR);
1322
1323                 if (pfd.revents & (POLLHUP | POLLERR | POLLNVAL)) {
1324                         info("Audio HAL: Socket closed");
1325
1326                         pthread_mutex_lock(&sk_mutex);
1327                         close(audio_sk);
1328                         audio_sk = -1;
1329                         pthread_mutex_unlock(&sk_mutex);
1330                 }
1331         }
1332
1333         /* audio_sk is closed at this point, just cleanup endpoints states */
1334         memset(audio_endpoints, 0, sizeof(audio_endpoints));
1335
1336         info("Closing Audio IPC thread");
1337         return NULL;
1338 }
1339
1340 static int audio_ipc_init(void)
1341 {
1342         struct sockaddr_un addr;
1343         int err;
1344         int sk;
1345
1346         DBG("");
1347
1348         sk = socket(PF_LOCAL, SOCK_SEQPACKET, 0);
1349         if (sk < 0) {
1350                 err = -errno;
1351                 error("audio: Failed to create socket: %d (%s)", -err,
1352                                                                 strerror(-err));
1353                 return err;
1354         }
1355
1356         memset(&addr, 0, sizeof(addr));
1357         addr.sun_family = AF_UNIX;
1358
1359         memcpy(addr.sun_path, BLUEZ_AUDIO_SK_PATH,
1360                                         sizeof(BLUEZ_AUDIO_SK_PATH));
1361
1362         if (bind(sk, (struct sockaddr *) &addr, sizeof(addr)) < 0) {
1363                 err = -errno;
1364                 error("audio: Failed to bind socket: %d (%s)", -err,
1365                                                                 strerror(-err));
1366                 goto failed;
1367         }
1368
1369         if (listen(sk, 1) < 0) {
1370                 err = -errno;
1371                 error("audio: Failed to listen on the socket: %d (%s)", -err,
1372                                                                 strerror(-err));
1373                 goto failed;
1374         }
1375
1376         listen_sk = sk;
1377
1378         err = pthread_create(&ipc_th, NULL, ipc_handler, NULL);
1379         if (err) {
1380                 err = -err;
1381                 ipc_th = 0;
1382                 error("audio: Failed to start Audio IPC thread: %d (%s)",
1383                                                         -err, strerror(-err));
1384                 goto failed;
1385         }
1386
1387         return 0;
1388
1389 failed:
1390         close(sk);
1391         return err;
1392 }
1393
1394 static int audio_open(const hw_module_t *module, const char *name,
1395                                                         hw_device_t **device)
1396 {
1397         struct a2dp_audio_dev *a2dp_dev;
1398         int err;
1399
1400         DBG("");
1401
1402         if (strcmp(name, AUDIO_HARDWARE_INTERFACE)) {
1403                 error("audio: interface %s not matching [%s]", name,
1404                                                 AUDIO_HARDWARE_INTERFACE);
1405                 return -EINVAL;
1406         }
1407
1408         err = audio_ipc_init();
1409         if (err < 0)
1410                 return err;
1411
1412         a2dp_dev = calloc(1, sizeof(struct a2dp_audio_dev));
1413         if (!a2dp_dev)
1414                 return -ENOMEM;
1415
1416         a2dp_dev->dev.common.tag = HARDWARE_DEVICE_TAG;
1417         a2dp_dev->dev.common.version = AUDIO_DEVICE_API_VERSION_CURRENT;
1418         a2dp_dev->dev.common.module = (struct hw_module_t *) module;
1419         a2dp_dev->dev.common.close = audio_close;
1420
1421         a2dp_dev->dev.init_check = audio_init_check;
1422         a2dp_dev->dev.set_voice_volume = audio_set_voice_volume;
1423         a2dp_dev->dev.set_master_volume = audio_set_master_volume;
1424         a2dp_dev->dev.set_mode = audio_set_mode;
1425         a2dp_dev->dev.set_mic_mute = audio_set_mic_mute;
1426         a2dp_dev->dev.get_mic_mute = audio_get_mic_mute;
1427         a2dp_dev->dev.set_parameters = audio_set_parameters;
1428         a2dp_dev->dev.get_parameters = audio_get_parameters;
1429         a2dp_dev->dev.get_input_buffer_size = audio_get_input_buffer_size;
1430         a2dp_dev->dev.open_output_stream = audio_open_output_stream;
1431         a2dp_dev->dev.close_output_stream = audio_close_output_stream;
1432         a2dp_dev->dev.open_input_stream = audio_open_input_stream;
1433         a2dp_dev->dev.close_input_stream = audio_close_input_stream;
1434         a2dp_dev->dev.dump = audio_dump;
1435
1436         /*
1437          * Note that &a2dp_dev->dev.common is the same pointer as a2dp_dev.
1438          * This results from the structure of following structs:a2dp_audio_dev,
1439          * audio_hw_device. We will rely on this later in the code.
1440          */
1441         *device = &a2dp_dev->dev.common;
1442
1443         return 0;
1444 }
1445
1446 static struct hw_module_methods_t hal_module_methods = {
1447         .open = audio_open,
1448 };
1449
1450 struct audio_module HAL_MODULE_INFO_SYM = {
1451         .common = {
1452                 .tag = HARDWARE_MODULE_TAG,
1453                 .version_major = 1,
1454                 .version_minor = 0,
1455                 .id = AUDIO_HARDWARE_MODULE_ID,
1456                 .name = "A2DP Bluez HW HAL",
1457                 .author = "Intel Corporation",
1458                 .methods = &hal_module_methods,
1459         },
1460 };