Searched defs:buffer (Results 351 - 375 of 765) sorted by relevance

<<11121314151617181920>>

/frameworks/av/services/audiopolicy/common/managerdefinitions/src/
H A DHwModule.cpp224 char buffer[SIZE]; local
227 snprintf(buffer, SIZE, " - name: %s\n", getName());
228 result.append(buffer);
229 snprintf(buffer, SIZE, " - handle: %d\n", mHandle);
230 result.append(buffer);
231 snprintf(buffer, SIZE, " - version: %u.%u\n", getHalVersionMajor(), getHalVersionMinor());
232 result.append(buffer);
237 snprintf(buffer, SIZE, " output %zu:\n", i);
238 write(fd, buffer, strlen(buffer));
312 char buffer[SIZE]; local
[all...]
/frameworks/av/services/camera/libcameraservice/device3/
H A DCamera3BufferManager.cpp51 ALOGE("%s: Stream id (%d) with stream set id (%d) total buffer count %zu is invalid",
60 // For Gralloc v1, try to allocate a buffer and see if it is successful, otherwise, stream
61 // buffer sharing for this newly added stream is not supported. For Gralloc v0, we don't
107 // The max allowed buffer count should be the max of buffer count of each stream inside a stream
124 ALOGE("%s: stream %d with set id %d wasn't properly registered to this buffer manager!",
137 // Remove the stream info from info map and recalculate the buffer count water mark.
193 ALOGV("StreamSet %d has no buffer available to free", streamSetId);
198 // This will drop the reference to one free buffer, which will effectively free one
199 // buffer (fro
222 sp<GraphicBuffer> buffer; local
274 GraphicBufferEntry buffer; local
[all...]
H A DCamera3IOStreamBase.cpp62 " buffer signal time is %" PRId64,
150 void Camera3IOStreamBase::handoutBufferLocked(camera3_stream_buffer &buffer, argument
162 buffer.stream = this;
163 buffer.buffer = handle;
164 buffer.acquire_fence = acquireFence;
165 buffer.release_fence = releaseFence;
166 buffer.status = status;
220 const camera3_stream_buffer &buffer,
238 res = returnBufferCheckedLocked(buffer, timestam
219 returnAnyBufferLocked( const camera3_stream_buffer &buffer, nsecs_t timestamp, bool output) argument
[all...]
H A DCamera3InputStream.cpp49 camera3_stream_buffer *buffer) {
74 ALOGE("%s: Stream %d: Can't acquire next output buffer: %s (%d)",
87 handoutBufferLocked(*buffer, &(anb->handle), /*acquireFence*/fenceFd,
98 const camera3_stream_buffer &buffer,
113 // Find the buffer we are returning
121 if (anb != NULL && &(anb->handle) == buffer.buffer) {
130 ALOGE("%s: Stream %d: Can't return buffer that wasn't sent to HAL",
135 if (buffer.status == CAMERA3_BUFFER_STATUS_ERROR) {
136 if (buffer
48 getInputBufferLocked( camera3_stream_buffer *buffer) argument
97 returnBufferCheckedLocked( const camera3_stream_buffer &buffer, nsecs_t timestamp, bool output, sp<Fence> *releaseFenceOut) argument
165 returnInputBufferLocked( const camera3_stream_buffer &buffer) argument
297 const sp<GraphicBuffer> buffer = gb.promote(); local
[all...]
H A DCamera3SharedOutputStream.cpp78 const sp<GraphicBuffer> buffer(static_cast<GraphicBuffer*>(anwBuffer));
81 res = mStreamSplitter->notifyBufferReleased(buffer);
131 status_t Camera3SharedOutputStream::getBufferLocked(camera3_stream_buffer *buffer, argument
142 // Attach the buffer to the splitter output queues. This could block if
150 ALOGE("%s: Stream %d: Cannot attach stream splitter buffer to outputs: %s (%d)",
165 handoutBufferLocked(*buffer, &(anb->handle), /*acquireFence*/fenceFd,
172 ANativeWindowBuffer* buffer, int anwReleaseFence) {
173 status_t res = consumer->queueBuffer(consumer.get(), buffer, anwReleaseFence);
175 // After queuing buffer to the internal consumer queue, check whether the buffer i
171 queueBufferToConsumer(sp<ANativeWindow>& consumer, ANativeWindowBuffer* buffer, int anwReleaseFence) argument
[all...]
/frameworks/base/cmds/incidentd/tests/
H A DPrivacyBuffer_test.cpp62 ASSERT_EQ(NO_ERROR, buffer.read(tf.fd, 10000));
63 ASSERT_EQ(str.size(), buffer.size());
75 EncodedBuffer::iterator bufData = buffer.data();
115 FdBuffer buffer; member in class:PrivacyBufferTest
241 EncodedBuffer::iterator bufData = buffer.data();
255 EncodedBuffer::iterator bufData = buffer.data();
265 EncodedBuffer::iterator bufData = buffer.data();
/frameworks/base/cmds/statsd/src/config/
H A DConfigManager.cpp78 vector<uint8_t> buffer(numBytes);
79 config.SerializeToArray(&buffer[0], numBytes);
94 StorageManager::hasIdenticalConfig(key, buffer)) {
99 update_saved_configs_locked(key, buffer, numBytes);
104 update_saved_configs_locked(key, buffer, numBytes);
270 const vector<uint8_t>& buffer,
279 StorageManager::writeFile(file_name.c_str(), &buffer[0], numBytes);
269 update_saved_configs_locked(const ConfigKey& key, const vector<uint8_t>& buffer, const int numBytes) argument
/frameworks/base/cmds/statsd/src/metrics/
H A DEventMetricProducer.cpp89 std::unique_ptr<std::vector<uint8_t>> buffer(new std::vector<uint8_t>(bufferSize));
95 std::memcpy(&((*buffer)[pos]), it.readBuffer(), toRead);
100 return buffer;
119 std::unique_ptr<std::vector<uint8_t>> buffer = serializeProtoLocked(*mProto); local
122 reinterpret_cast<char*>(buffer.get()->data()), buffer.get()->size());
/frameworks/base/cmds/statsd/src/storage/
H A DStorageManager.cpp71 void StorageManager::writeFile(const char* file, const void* buffer, int numBytes) { argument
80 int result = write(fd, buffer, numBytes);
/frameworks/base/cmds/statsd/tests/e2e/
H A DMetricConditionLink_e2e_test.cpp202 vector<uint8_t> buffer; local
204 &buffer);
205 EXPECT_TRUE(buffer.size() > 0);
206 EXPECT_TRUE(reports.ParseFromArray(&buffer[0], buffer.size()));
320 vector<uint8_t> buffer; local
323 &buffer);
324 EXPECT_TRUE(buffer.size() > 0);
325 EXPECT_TRUE(reports.ParseFromArray(&buffer[0], buffer
[all...]
/frameworks/base/core/java/android/content/res/
H A DAssetFileDescriptor.java219 byte[] buffer = new byte[1];
220 int result = read(buffer, 0, 1);
221 return result == -1 ? -1 : buffer[0] & 0xff;
225 public int read(byte[] buffer, int offset, int count) throws IOException { argument
229 int res = super.read(buffer, offset, count);
234 return super.read(buffer, offset, count);
238 public int read(byte[] buffer) throws IOException { argument
239 return read(buffer, 0, buffer.length);
300 public void write(byte[] buffer, in argument
313 write(byte[] buffer) argument
[all...]
H A DStringBlock.java170 SpannableString buffer = new SpannableString(str);
179 buffer.setSpan(new StyleSpan(Typeface.BOLD),
183 buffer.setSpan(new StyleSpan(Typeface.ITALIC),
187 buffer.setSpan(new UnderlineSpan(),
191 buffer.setSpan(new TypefaceSpan("monospace"),
195 buffer.setSpan(new RelativeSizeSpan(1.25f),
199 buffer.setSpan(new RelativeSizeSpan(0.8f),
203 buffer.setSpan(new SubscriptSpan(),
207 buffer.setSpan(new SuperscriptSpan(),
211 buffer
359 addParagraphSpan(Spannable buffer, Object what, int start, int end) argument
[all...]
/frameworks/base/core/java/android/database/
H A DCursor.java242 * Retrieves the requested column text and stores it in the buffer provided.
243 * If the buffer size is not sufficient, a new char buffer will be allocated
246 * if the target column is null, return buffer
247 * @param buffer the buffer to copy the text into.
249 void copyStringToBuffer(int columnIndex, CharArrayBuffer buffer); argument
H A DCursorWrapper.java141 public void copyStringToBuffer(int columnIndex, CharArrayBuffer buffer) { argument
142 mCursor.copyStringToBuffer(columnIndex, buffer);
/frameworks/base/core/java/android/hardware/usb/
H A DUsbDeviceConnection.java165 * This method transfers data starting from index 0 in the buffer.
174 * @param buffer buffer for data portion of transaction,
182 int index, byte[] buffer, int length, int timeout) {
183 return controlTransfer(requestType, request, value, index, buffer, 0, length, timeout);
198 * @param buffer buffer for data portion of transaction,
200 * @param offset the index of the first byte in the buffer to send or receive
207 byte[] buffer, int offset, int length, int timeout) {
208 checkBounds(buffer, offse
181 controlTransfer(int requestType, int request, int value, int index, byte[] buffer, int length, int timeout) argument
206 controlTransfer(int requestType, int request, int value, int index, byte[] buffer, int offset, int length, int timeout) argument
233 bulkTransfer(UsbEndpoint endpoint, byte[] buffer, int length, int timeout) argument
253 bulkTransfer(UsbEndpoint endpoint, byte[] buffer, int offset, int length, int timeout) argument
354 checkBounds(byte[] buffer, int start, int length) argument
380 native_control_request(int requestType, int request, int value, int index, byte[] buffer, int offset, int length, int timeout) argument
382 native_bulk_request(int endpoint, byte[] buffer, int offset, int length, int timeout) argument
[all...]
H A DUsbRequest.java54 /** The buffer that is currently being read / written */
67 * Whether this buffer was {@link #queue(ByteBuffer) queued using the new behavior} or
72 /** Temporary buffer than might be used while buffer is enqueued */
169 * <p>For OUT endpoints, the given buffer data will be sent on the endpoint. For IN endpoints,
170 * the endpoint will attempt to read the given number of bytes into the specified buffer. If the
174 * @param buffer the buffer containing the bytes to write, or location to store the results of a
188 public boolean queue(ByteBuffer buffer, int length) { argument
198 // save our buffer fo
240 queue(@ullable ByteBuffer buffer) argument
367 native_queue(ByteBuffer buffer, int offset, int length) argument
368 native_queue_array(byte[] buffer, int length, boolean out) argument
369 native_dequeue_array(byte[] buffer, int length, boolean out) argument
370 native_queue_direct(ByteBuffer buffer, int length, boolean out) argument
[all...]
/frameworks/base/core/java/android/net/
H A DSntpClient.java109 byte[] buffer = new byte[NTP_PACKET_SIZE];
110 DatagramPacket request = new DatagramPacket(buffer, buffer.length, address, port);
115 buffer[0] = NTP_MODE_CLIENT | (NTP_VERSION << 3);
120 writeTimeStamp(buffer, TRANSMIT_TIME_OFFSET, requestTime);
125 DatagramPacket response = new DatagramPacket(buffer, buffer.length);
131 final byte leap = (byte) ((buffer[0] >> 6) & 0x3);
132 final byte mode = (byte) (buffer[0] & 0x7);
133 final int stratum = (int) (buffer[
231 read32(byte[] buffer, int offset) argument
250 readTimeStamp(byte[] buffer, int offset) argument
264 writeTimeStamp(byte[] buffer, int offset, long time) argument
[all...]
/frameworks/base/core/java/android/os/
H A DMemoryFile.java176 * @param buffer byte array to read bytes into.
178 * @param destOffset offset into the byte array buffer to read into.
183 public int readBytes(byte[] buffer, int srcOffset, int destOffset, int count) argument
188 mMapping.get(buffer, destOffset, count);
199 * @param buffer byte array to write bytes from.
200 * @param srcOffset offset into the byte array buffer to write from.
205 public void writeBytes(byte[] buffer, int srcOffset, int destOffset, int count) argument
210 mMapping.put(buffer, srcOffset, count);
283 public int read(byte buffer[], int offset, int count) throws IOException { argument
284 if (offset < 0 || count < 0 || offset + count > buffer
316 write(byte buffer[], int offset, int count) argument
[all...]
H A DSharedMemory.java232 * Unmaps a buffer previously returned by {@link #map(int, int, int)}. This will immediately
237 * @param buffer The buffer to unmap
239 public static void unmap(@NonNull ByteBuffer buffer) { argument
240 if (buffer instanceof DirectByteBuffer) {
241 NioUtils.freeDirectBuffer(buffer);
/frameworks/base/core/java/android/speech/
H A DRecognitionService.java253 * @param buffer a buffer containing a sequence of big-endian 16-bit integers representing a
256 public void bufferReceived(byte[] buffer) throws RemoteException { argument
257 mListener.onBufferReceived(buffer);
/frameworks/base/core/java/android/speech/tts/
H A DFileSynthesisCallback.java153 public int audioAvailable(byte[] buffer, int offset, int length) { argument
155 Log.d(TAG, "FileSynthesisRequest.audioAvailable(" + buffer + "," + offset
181 System.arraycopy(buffer, offset, bufferCopy, 0, length);
185 fileChannel.write(ByteBuffer.wrap(buffer, offset, length));
H A DSynthesisPlaybackQueueItem.java115 byte[] buffer = null;
119 // (a) there is a buffer available to tread. In which case
123 while ((buffer = take()) != null) {
124 mAudioTrack.write(buffer);
260 void put(byte[] buffer) throws InterruptedException { argument
270 // Don't bother queueing the buffer if we've stopped. The playback thread
278 mDataBufferList.add(new ListEntry(buffer));
279 mUnconsumedBytes += buffer.length;
/frameworks/base/core/java/android/text/method/
H A DBaseMovementMethod.java127 * buffer as well as those present in the key event.
132 * @param buffer The text buffer.
136 protected int getMovementMetaState(Spannable buffer, KeyEvent event) { argument
138 int metaState = MetaKeyKeyListener.getMetaState(buffer, event)
153 * @param buffer The text buffer.
160 protected boolean handleMovementKey(TextView widget, Spannable buffer, argument
165 return left(widget, buffer);
168 return leftWord(widget, buffer);
252 left(TextView widget, Spannable buffer) argument
264 right(TextView widget, Spannable buffer) argument
276 up(TextView widget, Spannable buffer) argument
288 down(TextView widget, Spannable buffer) argument
300 pageUp(TextView widget, Spannable buffer) argument
312 pageDown(TextView widget, Spannable buffer) argument
324 top(TextView widget, Spannable buffer) argument
336 bottom(TextView widget, Spannable buffer) argument
348 lineStart(TextView widget, Spannable buffer) argument
360 lineEnd(TextView widget, Spannable buffer) argument
365 leftWord(TextView widget, Spannable buffer) argument
370 rightWord(TextView widget, Spannable buffer) argument
384 home(TextView widget, Spannable buffer) argument
398 end(TextView widget, Spannable buffer) argument
466 scrollLeft(TextView widget, Spannable buffer, int amount) argument
487 scrollRight(TextView widget, Spannable buffer, int amount) argument
508 scrollUp(TextView widget, Spannable buffer, int amount) argument
535 scrollDown(TextView widget, Spannable buffer, int amount) argument
565 scrollPageUp(TextView widget, Spannable buffer) argument
585 scrollPageDown(TextView widget, Spannable buffer) argument
607 scrollTop(TextView widget, Spannable buffer) argument
625 scrollBottom(TextView widget, Spannable buffer) argument
645 scrollLineStart(TextView widget, Spannable buffer) argument
664 scrollLineEnd(TextView widget, Spannable buffer) argument
[all...]
/frameworks/base/core/java/android/util/apk/
H A DApkVerityBuilder.java61 * {@link ByteBufferFactory}. The bytes layout in the buffer will be used by the kernel and is
127 * extensions, Merkle tree, and the tree's root hash. The output buffer is flipped to the
163 * A helper class to consume and digest data by block continuously, and write into a buffer.
193 * then writes the final digest to the output buffer. Repeat until all data are consumed.
198 public void consume(ByteBuffer buffer) throws DigestException { argument
199 int offset = buffer.position();
200 int remaining = buffer.remaining();
203 // Optimization: set the buffer limit to avoid allocating a new ByteBuffer object.
204 buffer.limit(buffer
327 generateFsverityHeader(ByteBuffer buffer, long fileSize, int depth, byte[] salt) argument
358 generateFsverityExtensions(ByteBuffer buffer, long signingBlockOffset, long signingBlockSize, long eocdOffset) argument
461 slice(ByteBuffer buffer, int begin, int end) argument
470 skip(ByteBuffer buffer, int bytes) argument
[all...]
/frameworks/base/core/java/android/util/jar/
H A DStrictJarFile.java347 public int read(byte[] buffer, int byteOffset, int byteCount) throws IOException { argument
352 int r = super.read(buffer, byteOffset, byteCount);
358 entry.write(buffer, byteOffset, size);
399 @Override public int read(byte[] buffer, int byteOffset, int byteCount) throws IOException { argument
402 i = super.read(buffer, byteOffset, byteCount);
458 @Override public int read(byte[] buffer, int byteOffset, int byteCount) throws IOException { argument
469 int count = IoBridge.read(fd, buffer, byteOffset, byteCount);

Completed in 315 milliseconds

<<11121314151617181920>>