153 references to ReadOnlySpan
GenerateDocumentationAndConfigFiles (2)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
http2cat (2)
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
IIS.FunctionalTests (2)
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
IIS.LongTests (2)
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
IIS.NewHandler.FunctionalTests (2)
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
IIS.NewShim.FunctionalTests (2)
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
IIS.ShadowCopy.Tests (1)
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
IISExpress.FunctionalTests (2)
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
Metrics (2)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
Metrics.Legacy (2)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
Microsoft.AspNetCore.Http.Connections (1)
src\SignalR\common\Shared\PipeWriterStream.cs (1)
52_pipeWriter.Write(new ReadOnlySpan<byte>(buffer, offset, count));
Microsoft.AspNetCore.Http.Connections.Client (1)
src\SignalR\common\Shared\PipeWriterStream.cs (1)
52_pipeWriter.Write(new ReadOnlySpan<byte>(buffer, offset, count));
Microsoft.AspNetCore.OutputCaching.Microbenchmarks (1)
EndToEndBenchmarks.cs (1)
209if (!Payload.Span.SequenceEqual(new(oversized, 0, PayloadLength)))
Microsoft.AspNetCore.Server.HttpSys.FunctionalTests (2)
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
Microsoft.AspNetCore.Server.IIS (1)
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
Microsoft.AspNetCore.Server.Kestrel.Core (8)
Internal\Http3\QPack\EncoderStreamReader.cs (1)
268return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
Middleware\Internal\LoggingStream.cs (4)
81Log("Read", new ReadOnlySpan<byte>(buffer, offset, read)); 101Log("ReadAsync", new ReadOnlySpan<byte>(buffer, offset, read)); 128Log("Write", new ReadOnlySpan<byte>(buffer, offset, count)); 140Log("WriteAsync", new ReadOnlySpan<byte>(buffer, offset, count));
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\runtime\Http3\QPack\QPackDecoder.cs (1)
637return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
Microsoft.AspNetCore.Server.Kestrel.Core.Tests (2)
src\Shared\test\Shared.Tests\runtime\Http2\HuffmanDecodingTests.cs (2)
74int decodedByteCount = Huffman.Decode(new ReadOnlySpan<byte>(encoded, 0, encodedByteCount), ref decoded); 344int decodedLength = Huffman.Decode(new ReadOnlySpan<byte>(encoded, 0, encoded.Length), ref decodedBytes);
Microsoft.AspNetCore.Shared.Tests (5)
runtime\Http2\HuffmanDecodingTests.cs (2)
74int decodedByteCount = Huffman.Decode(new ReadOnlySpan<byte>(encoded, 0, encodedByteCount), ref decoded); 344int decodedLength = Huffman.Decode(new ReadOnlySpan<byte>(encoded, 0, encoded.Length), ref decodedBytes);
src\Shared\runtime\Http2\Hpack\HPackDecoder.cs (1)
599return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\runtime\Http3\QPack\QPackDecoder.cs (1)
637return Huffman.Decode(new ReadOnlySpan<byte>(_stringOctets, 0, _stringLength), ref dst);
src\Shared\ServerInfrastructure\BufferExtensions.cs (1)
188buffer.Write(new ReadOnlySpan<byte>(byteBuffer, position, length));
Microsoft.AspNetCore.SignalR.Client.Core (1)
src\SignalR\common\Shared\PipeWriterStream.cs (1)
52_pipeWriter.Write(new ReadOnlySpan<byte>(buffer, offset, count));
Microsoft.AspNetCore.WebUtilities (1)
HttpRequestStreamReader.cs (1)
192var source = new ReadOnlySpan<char>(_charBuffer, _charBufferIndex, charsRemaining);
Microsoft.CodeAnalysis (3)
CodeGen\TokenMap.cs (1)
116return new ReadOnlySpan<object>(items, 0, count);
Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
Microsoft.CodeAnalysis.Analyzers (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.AnalyzerUtilities (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.BannedApiAnalyzers (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.CodeStyle (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.Collections.Package (1)
Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.Extensions.Package (1)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.InteractiveHost (1)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.PerformanceSensitiveAnalyzers (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.PublicApiAnalyzers (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.ResxSourceGenerator (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.Threading.Package (1)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Microsoft.CodeAnalysis.Workspaces (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
Storage\SQLite\v2\SQLitePersistentStorage.Accessor.cs (1)
250new ReadOnlySpan<byte>(dataBytes, 0, dataLength));
Microsoft.Extensions.AI (1)
ChatCompletion\ChatResponse{T}.cs (1)
104var utf8Span = new ReadOnlySpan<byte>(buffer, 0, utf8SpanLength);
Microsoft.Extensions.AI.OpenAI (1)
src\Shared\ServerSentEvents\ArrayBuffer.cs (1)
91public readonly ReadOnlySpan<byte> ActiveReadOnlySpan => new ReadOnlySpan<byte>(_bytes, _activeStart, _availableStart - _activeStart);
Microsoft.Extensions.Caching.Hybrid (4)
Internal\BufferChunk.cs (1)
89internal ReadOnlySpan<byte> AsSpan() => Length == 0 ? default : new(OversizedArray!, Offset, Length);
Internal\HybridCachePayload.cs (2)
192ReadOnlySpan<byte> bytes = new(source.Array!, source.Offset, source.Count); 373value = new(scratch, 0, charCount);
Internal\InbuiltTypeSerializer.cs (1)
60target.Write(new(oversized, 0, length));
Microsoft.Extensions.Caching.SqlServer (2)
DatabaseOperations.cs (2)
341if (new ReadOnlySpan<byte>(lease, 0, read).TryCopyTo(memory.Span)) 348destination.Write(new(lease, 0, read));
Microsoft.Extensions.Logging.Console (1)
src\libraries\Common\src\System\Net\ArrayBuffer.cs (1)
90public ReadOnlySpan<byte> ActiveReadOnlySpan => new ReadOnlySpan<byte>(_bytes, _activeStart, _availableStart - _activeStart);
Roslyn.Diagnostics.Analyzers (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
Shared (1)
ServerSentEvents\ArrayBuffer.cs (1)
91public readonly ReadOnlySpan<byte> ActiveReadOnlySpan => new ReadOnlySpan<byte>(_bytes, _activeStart, _availableStart - _activeStart);
System.Collections.Immutable (3)
System\Collections\Immutable\ImmutableArray_1.Builder.cs (1)
1019new ReadOnlySpan<T>(_elements, 0, this.Count).CopyTo(destination);
System\Collections\Immutable\ImmutableArray_1.cs (1)
906public ReadOnlySpan<T> AsSpan(int start, int length) => new ReadOnlySpan<T>(array, start, length);
System\Collections\Immutable\ImmutableArray_1.netcoreapp.cs (1)
21return new ReadOnlySpan<T>(self.array, start, length);
System.Data.Common (1)
System\Data\SQLTypes\SQLBytes.cs (1)
328ReadOnlySpan<byte> span = new ReadOnlySpan<byte>(_rgbBuf, (int)offset, count);
System.Formats.Asn1 (5)
System\Formats\Asn1\AsnCharacterStringEncodings.cs (4)
89return GetByteCount(new ReadOnlySpan<char>(chars, index, count)); 114new ReadOnlySpan<char>(chars, charIndex, charCount), 129return GetCharCount(new ReadOnlySpan<byte>(bytes, index, count)); 149new ReadOnlySpan<byte>(bytes, byteIndex, byteCount),
System\Formats\Asn1\AsnWriter.cs (1)
344return new ReadOnlySpan<byte>(_buffer, 0, _offset);
System.Formats.Cbor (2)
System\Formats\Cbor\Writer\CborWriter.cs (2)
228return new ReadOnlySpan<byte>(_buffer, 0, _offset); 253new ReadOnlySpan<byte>(_buffer, 0, _offset).CopyTo(newBuffer);
System.IO.Hashing (2)
System\IO\Hashing\XxHash32.cs (1)
148remaining = new ReadOnlySpan<byte>(_holdback, 0, remainingLength);
System\IO\Hashing\XxHash64.cs (1)
148remaining = new ReadOnlySpan<byte>(_holdback, 0, remainingLength);
System.IO.Packaging (1)
System\IO\Packaging\InterleavedZipPackagePartStream.cs (1)
284=> WriteCore(new ReadOnlySpan<byte>(buffer, offset, count));
System.Linq (1)
System\Linq\Chunk.cs (1)
66TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();
System.Memory (1)
System\Buffers\ReadOnlySequence.Helpers.cs (1)
665first = new ReadOnlySpan<T>((T[])startObject, startIndex, (endIndex & ReadOnlySequence.IndexBitMask) - startIndex);
System.Net.ServerSentEvents (1)
src\libraries\Common\src\System\Net\ArrayBuffer.cs (1)
90public ReadOnlySpan<byte> ActiveReadOnlySpan => new ReadOnlySpan<byte>(_bytes, _activeStart, _availableStart - _activeStart);
System.Net.WebClient (1)
src\libraries\Common\src\System\IO\ChunkedMemoryStream.cs (1)
38Write(new ReadOnlySpan<byte>(buffer, offset, count));
System.Private.CoreLib (36)
src\libraries\System.Private.CoreLib\src\System\BitConverter.cs (1)
817var src = new ReadOnlySpan<byte>(value, startIndex, length);
src\libraries\System.Private.CoreLib\src\System\Collections\Generic\CollectionExtensions.cs (1)
171new ReadOnlySpan<T>(list._items, 0, list._size).CopyTo(destination);
src\libraries\System.Private.CoreLib\src\System\Convert.cs (4)
2340return ToBase64String(new ReadOnlySpan<byte>(inArray, offset, length), options); 2414ToBase64CharsLargeNoLineBreaks(new ReadOnlySpan<byte>(inArray, offsetIn, length), outArray.AsSpan(offsetOut), charLengthRequired); 3070return ToHexString(new ReadOnlySpan<byte>(inArray, offset, length)); 3147return ToHexStringLower(new ReadOnlySpan<byte>(inArray, offset, length));
src\libraries\System.Private.CoreLib\src\System\Guid.cs (1)
918return Unsafe.BitCast<ReadOnlySpan<char>, ReadOnlySpan<TChar>>(new ReadOnlySpan<char>(chArr, 0, newLength));
src\libraries\System.Private.CoreLib\src\System\IO\BinaryReader.cs (1)
364byteBuffer = new ReadOnlySpan<byte>(mStream.InternalGetBuffer(), position, numBytes);
src\libraries\System.Private.CoreLib\src\System\IO\BufferedStream.cs (1)
452new ReadOnlySpan<byte>(_buffer, _readPos, readbytes).CopyTo(destination);
src\libraries\System.Private.CoreLib\src\System\IO\MemoryStream.cs (1)
227var span = new ReadOnlySpan<byte>(_buffer, origPos, count);
src\libraries\System.Private.CoreLib\src\System\IO\Strategies\BufferedFileStreamStrategy.cs (2)
211new ReadOnlySpan<byte>(_buffer, _readPos, n).CopyTo(destination); 468WriteSpan(new ReadOnlySpan<byte>(buffer, offset, count), new ArraySegment<byte>(buffer, offset, count));
src\libraries\System.Private.CoreLib\src\System\IO\Strategies\OSFileStreamStrategy.cs (1)
231Write(new ReadOnlySpan<byte>(buffer, offset, count));
src\libraries\System.Private.CoreLib\src\System\IO\Stream.cs (2)
323new ReadOnlySpan<byte>(localBuffer, 0, result).CopyTo(localDestination.Span); 791new ReadOnlySpan<byte>(sharedBuffer, 0, numRead).CopyTo(buffer);
src\libraries\System.Private.CoreLib\src\System\IO\StreamReader.cs (5)
464new ReadOnlySpan<byte>(byteBuffer, n, _byteLen - n).CopyTo(byteBuffer); 751charsRead = _decoder.GetChars(new ReadOnlySpan<byte>(_byteBuffer, 0, _byteLen), userBuffer, flush: false); 770charsRead = _decoder.GetChars(new ReadOnlySpan<byte>(_byteBuffer, 0, _byteLen), userBuffer, flush: true); 1151n = _decoder.GetChars(new ReadOnlySpan<byte>(tmpByteBuffer, 0, _byteLen), buffer.Span.Slice(charsRead), flush: false); 1215n = _decoder.GetChars(new ReadOnlySpan<byte>(tmpByteBuffer, 0, _byteLen), buffer.Span.Slice(charsRead), flush: false);
src\libraries\System.Private.CoreLib\src\System\IO\StreamWriter.cs (2)
313int count = _encoder.GetBytes(new ReadOnlySpan<char>(_charBuffer, 0, _charPos), byteBuffer, flushEncoder); 992int count = _encoder.GetBytes(new ReadOnlySpan<char>(_charBuffer, 0, _charPos), byteBuffer, flushEncoder);
src\libraries\System.Private.CoreLib\src\System\IO\UnmanagedMemoryStream.cs (1)
607WriteCore(new ReadOnlySpan<byte>(buffer, offset, count));
src\libraries\System.Private.CoreLib\src\System\ReadOnlySpan.cs (1)
211=> new ReadOnlySpan<T>(segment.Array, segment.Offset, segment.Count);
src\libraries\System.Private.CoreLib\src\System\Runtime\InteropServices\SafeBuffer.cs (1)
310WriteSpan(byteOffset, new ReadOnlySpan<T>(array, index, count));
src\libraries\System.Private.CoreLib\src\System\Runtime\InteropServices\TypeMapLazyDictionary.cs (1)
95Buffer = new ReadOnlySpan<char>(backingBuffer, 0, validLength);
src\libraries\System.Private.CoreLib\src\System\String.Manipulation.cs (1)
782return JoinCore(separator, new ReadOnlySpan<string?>(value, startIndex, count));
src\libraries\System.Private.CoreLib\src\System\Text\Encoding.cs (2)
722new ReadOnlySpan<byte>(arrByte, 0, byteCount).CopyTo(new Span<byte>(bytes, byteCount)); 871new ReadOnlySpan<char>(arrChar, 0, charCount).CopyTo(new Span<char>(chars, charCount));
src\libraries\System.Private.CoreLib\src\System\Text\StringBuilder.cs (5)
921new ReadOnlySpan<char>(chunk.m_ChunkChars, chunkStartIndex, chunkCount).CopyTo(destination.Slice(curDestIndex)); 2038ReadOnlySpan<char> chunk = new ReadOnlySpan<char>(sbChunk.m_ChunkChars, 0, chunk_length); 2677new ReadOnlySpan<char>(chunk.m_ChunkChars, 0, copyCount1).CopyTo(newChunk.m_ChunkChars); 2683new ReadOnlySpan<char>(chunk.m_ChunkChars, copyCount1, copyCount2).CopyTo(chunk.m_ChunkChars); 2794new ReadOnlySpan<char>(endChunk.m_ChunkChars, endIndexInChunk, copyCount).CopyTo(endChunk.m_ChunkChars.AsSpan(copyTargetIndexInChunk));
src\libraries\System.Private.CoreLib\src\System\Text\TranscodingStream.cs (1)
472Write(new ReadOnlySpan<byte>(buffer, offset, count));
src\libraries\System.Private.CoreLib\src\System\Threading\PortableThreadPool.WaitThread.cs (1)
244int signaledHandleIndex = WaitHandle.WaitAny(new ReadOnlySpan<SafeWaitHandle>(_waitHandles, 0, numUserWaits + 1), timeoutDurationMs);
System.Private.DataContractSerialization (1)
System\Runtime\Serialization\Json\JsonEncodingStreamWrapper.cs (1)
250Write(new ReadOnlySpan<byte>(buffer, offset, count));
System.Security.Cryptography.Cose (1)
System\Security\Cryptography\Cose\PureDataToBeSignedBuilder.cs (1)
38operation(arg, new ReadOnlySpan<byte>(_stream.GetBuffer(), 0, checked((int)_stream.Length)));
System.Security.Cryptography.Pkcs (2)
System\Security\Cryptography\Pkcs\CmsSignature.DSA.cs (1)
158var signature = new ReadOnlySpan<byte>(rented, 0, bytesWritten);
System\Security\Cryptography\Pkcs\CmsSignature.ECDsa.cs (1)
173var signedHash = new ReadOnlySpan<byte>(rented, 0, bytesWritten);
System.ServiceModel.NetFramingBase (1)
System\ServiceModel\Channels\SingletonConnectionReader.cs (1)
546new ReadOnlySpan<byte>(localBuffer, 0, result).CopyTo(localDestination.Span);
System.Text.Json (1)
src\libraries\Common\src\System\Net\ArrayBuffer.cs (1)
90public ReadOnlySpan<byte> ActiveReadOnlySpan => new ReadOnlySpan<byte>(_bytes, _activeStart, _availableStart - _activeStart);
System.Windows.Forms (2)
System\Windows\Forms\ActiveX\Control.ActiveXImpl.cs (1)
1543new ReadOnlySpan<byte>(stream.GetBuffer(), 0, (int)stream.Length)));
System\Windows\Forms\ActiveX\DataStreamFromComStream.cs (1)
119ReadOnlySpan<byte> span = new(buffer, index, count);
Test.Utilities (2)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
Text.Analyzers (3)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (2)
126Append(new ReadOnlySpan<byte>(buffer, 0, read)); 175Append(new ReadOnlySpan<byte>(buffer, 0, read));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (1)
972TSource[] chunk = new ReadOnlySpan<TSource>(source, index, Math.Min(size, source.Length - index)).ToArray();