diff --git a/.env b/.env index e00b705a83968..4ac91d4e0bf81 100644 --- a/.env +++ b/.env @@ -17,3 +17,4 @@ PULSAR_ADDRESS=pulsar://pulsar:6650 ETCD_ENDPOINTS=etcd:2379 AZURITE_CONNECTION_STRING="DefaultEndpointsProtocol=http;AccountName=devstoreaccount1;AccountKey=Eby8vdM02xNOcqFlqUwJPLlmEtlCDXJ1OUzFT50uSRZ6IFsuFq2UVErCz4I6tq/K1SZFPTOtr/KBHBeksoGMGw==;BlobEndpoint=http://azurite:10000/devstoreaccount1;" +DOCKER_VOLUME_DIRECTORY=/disk2/duk/data/milvus-docker-volumes diff --git a/configs/milvus.yaml.back b/configs/milvus.yaml.back new file mode 100644 index 0000000000000..21f2710ab7bcf --- /dev/null +++ b/configs/milvus.yaml.back @@ -0,0 +1,805 @@ +# Licensed to the LF AI & Data foundation under one +# or more contributor license agreements. See the NOTICE file +# distributed with this work for additional information +# regarding copyright ownership. The ASF licenses this file +# to you under the Apache License, Version 2.0 (the +# "License"); you may not use this file except in compliance +# with the License. You may obtain a copy of the License at +# +# http://www.apache.org/licenses/LICENSE-2.0 +# +# Unless required by applicable law or agreed to in writing, software +# distributed under the License is distributed on an "AS IS" BASIS, +# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. +# See the License for the specific language governing permissions and +# limitations under the License. + +# Related configuration of etcd, used to store Milvus metadata & service discovery. +etcd: + endpoints: localhost:2379 + rootPath: by-dev # The root path where data is stored in etcd + metaSubPath: meta # metaRootPath = rootPath + '/' + metaSubPath + kvSubPath: kv # kvRootPath = rootPath + '/' + kvSubPath + log: + level: info # Only supports debug, info, warn, error, panic, or fatal. Default 'info'. + # path is one of: + # - "default" as os.Stderr, + # - "stderr" as os.Stderr, + # - "stdout" as os.Stdout, + # - file path to append server logs to. + # please adjust in embedded Milvus: /tmp/milvus/logs/etcd.log + path: stdout + ssl: + enabled: false # Whether to support ETCD secure connection mode + tlsCert: /path/to/etcd-client.pem # path to your cert file + tlsKey: /path/to/etcd-client-key.pem # path to your key file + tlsCACert: /path/to/ca.pem # path to your CACert file + # TLS min version + # Optional values: 1.0, 1.1, 1.2, 1.3。 + # We recommend using version 1.2 and above. + tlsMinVersion: 1.3 + requestTimeout: 10000 # Etcd operation timeout in milliseconds + use: + embed: false # Whether to enable embedded Etcd (an in-process EtcdServer). + data: + dir: default.etcd # Embedded Etcd only. please adjust in embedded Milvus: /tmp/milvus/etcdData/ + auth: + enabled: false # Whether to enable authentication + userName: # username for etcd authentication + password: # password for etcd authentication + +metastore: + type: etcd # Default value: etcd, Valid values: [etcd, tikv] + +# Related configuration of tikv, used to store Milvus metadata. +# Notice that when TiKV is enabled for metastore, you still need to have etcd for service discovery. +# TiKV is a good option when the metadata size requires better horizontal scalability. +tikv: + endpoints: 127.0.0.1:2389 # Note that the default pd port of tikv is 2379, which conflicts with etcd. + rootPath: by-dev # The root path where data is stored in tikv + metaSubPath: meta # metaRootPath = rootPath + '/' + metaSubPath + kvSubPath: kv # kvRootPath = rootPath + '/' + kvSubPath + requestTimeout: 10000 # ms, tikv request timeout + snapshotScanSize: 256 # batch size of tikv snapshot scan + ssl: + enabled: false # Whether to support TiKV secure connection mode + tlsCert: # path to your cert file + tlsKey: # path to your key file + tlsCACert: # path to your CACert file + +localStorage: + path: /home/duk/code/milvus-data/milvus-data/ # please adjust in embedded Milvus: /tmp/milvus/data/ + +# Related configuration of MinIO/S3/GCS or any other service supports S3 API, which is responsible for data persistence for Milvus. +# We refer to the storage service as MinIO/S3 in the following description for simplicity. +minio: + address: localhost # Address of MinIO/S3 + port: 9000 # Port of MinIO/S3 + accessKeyID: minioadmin # accessKeyID of MinIO/S3 + secretAccessKey: minioadmin # MinIO/S3 encryption string + useSSL: false # Access to MinIO/S3 with SSL + ssl: + tlsCACert: /path/to/public.crt # path to your CACert file + bucketName: a-bucket # Bucket name in MinIO/S3 + rootPath: files # The root path where the message is stored in MinIO/S3 + # Whether to useIAM role to access S3/GCS instead of access/secret keys + # For more information, refer to + # aws: https://docs.aws.amazon.com/IAM/latest/UserGuide/id_roles_use.html + # gcp: https://cloud.google.com/storage/docs/access-control/iam + # aliyun (ack): https://www.alibabacloud.com/help/en/container-service-for-kubernetes/latest/use-rrsa-to-enforce-access-control + # aliyun (ecs): https://www.alibabacloud.com/help/en/elastic-compute-service/latest/attach-an-instance-ram-role + useIAM: false + # Cloud Provider of S3. Supports: "aws", "gcp", "aliyun". + # You can use "aws" for other cloud provider supports S3 API with signature v4, e.g.: minio + # You can use "gcp" for other cloud provider supports S3 API with signature v2 + # You can use "aliyun" for other cloud provider uses virtual host style bucket + # When useIAM enabled, only "aws", "gcp", "aliyun" is supported for now + cloudProvider: aws + # Custom endpoint for fetch IAM role credentials. when useIAM is true & cloudProvider is "aws". + # Leave it empty if you want to use AWS default endpoint + iamEndpoint: + logLevel: fatal # Log level for aws sdk log. Supported level: off, fatal, error, warn, info, debug, trace + region: # Specify minio storage system location region + useVirtualHost: false # Whether use virtual host mode for bucket + requestTimeoutMs: 10000 # minio timeout for request time in milliseconds + # The maximum number of objects requested per batch in minio ListObjects rpc, + # 0 means using oss client by default, decrease these configration if ListObjects timeout + listObjectsMaxKeys: 0 + +# Milvus supports four MQ: rocksmq(based on RockDB), natsmq(embedded nats-server), Pulsar and Kafka. +# You can change your mq by setting mq.type field. +# If you don't set mq.type field as default, there is a note about enabling priority if we config multiple mq in this file. +# 1. standalone(local) mode: rocksmq(default) > natsmq > Pulsar > Kafka +# 2. cluster mode: Pulsar(default) > Kafka (rocksmq and natsmq is unsupported in cluster mode) +mq: + # Default value: "default" + # Valid values: [default, pulsar, kafka, rocksmq, natsmq] + type: default + enablePursuitMode: true # Default value: "true" + pursuitLag: 10 # time tick lag threshold to enter pursuit mode, in seconds + pursuitBufferSize: 8388608 # pursuit mode buffer size in bytes + mqBufSize: 16 # MQ client consumer buffer length + +# Related configuration of pulsar, used to manage Milvus logs of recent mutation operations, output streaming log, and provide log publish-subscribe services. +pulsar: + address: localhost # Address of pulsar + port: 6650 # Port of Pulsar + webport: 80 # Web port of pulsar, if you connect directly without proxy, should use 8080 + maxMessageSize: 5242880 # 5 * 1024 * 1024 Bytes, Maximum size of each message in pulsar. + tenant: public + namespace: default + requestTimeout: 60 # pulsar client global request timeout in seconds + enableClientMetrics: false # Whether to register pulsar client metrics into milvus metrics path. + +# If you want to enable kafka, needs to comment the pulsar configs +# kafka: +# brokerList: +# saslUsername: +# saslPassword: +# saslMechanisms: +# securityProtocol: +# ssl: +# enabled: false # whether to enable ssl mode +# tlsCert: # path to client's public key (PEM) used for authentication +# tlsKey: # path to client's private key (PEM) used for authentication +# tlsCaCert: # file or directory path to CA certificate(s) for verifying the broker's key +# tlsKeyPassword: # private key passphrase for use with ssl.key.location and set_ssl_cert(), if any +# readTimeout: 10 + +rocksmq: + # The path where the message is stored in rocksmq + # please adjust in embedded Milvus: /tmp/milvus/rdb_data + path: /home/duk/code/milvus-data/rocksmq-data + lrucacheratio: 0.06 # rocksdb cache memory ratio + rocksmqPageSize: 67108864 # 64 MB, 64 * 1024 * 1024 bytes, The size of each page of messages in rocksmq + retentionTimeInMinutes: 4320 # 3 days, 3 * 24 * 60 minutes, The retention time of the message in rocksmq. + retentionSizeInMB: 8192 # 8 GB, 8 * 1024 MB, The retention size of the message in rocksmq. + compactionInterval: 86400 # 1 day, trigger rocksdb compaction every day to remove deleted data + compressionTypes: 0,0,7,7,7 # compaction compression type, only support use 0,7. 0 means not compress, 7 will use zstd. Length of types means num of rocksdb level. + +# natsmq configuration. +# more detail: https://docs.nats.io/running-a-nats-service/configuration +natsmq: + server: # server side configuration for natsmq. + port: 4222 # 4222 by default, Port for nats server listening. + storeDir: /home/duk/code/milvus-data/nats-data # /var/lib/milvus/nats by default, directory to use for JetStream storage of nats. + maxFileStore: 17179869184 # (B) 16GB by default, Maximum size of the 'file' storage. + maxPayload: 8388608 # (B) 8MB by default, Maximum number of bytes in a message payload. + maxPending: 67108864 # (B) 64MB by default, Maximum number of bytes buffered for a connection Applies to client connections. + initializeTimeout: 4000 # (ms) 4s by default, waiting for initialization of natsmq finished. + monitor: + trace: false # false by default, If true enable protocol trace log messages. + debug: false # false by default, If true enable debug log messages. + logTime: true # true by default, If set to false, log without timestamps. + logFile: /home/duk/code/milvus-data/logs/nats.log # /tmp/milvus/logs/nats.log by default, Log file path relative to .. of milvus binary if use relative path. + logSizeLimit: 536870912 # (B) 512MB by default, Size in bytes after the log file rolls over to a new one. + retention: + maxAge: 4320 # Maximum age of any message in the P-channel + maxBytes: # How many bytes the single P-channel may contain. Removing oldest messages if the P-channel exceeds this size + maxMsgs: # How many message the single P-channel may contain. Removing oldest messages if the P-channel exceeds this limit + +# Related configuration of rootCoord, used to handle data definition language (DDL) and data control language (DCL) requests +rootCoord: + dmlChannelNum: 16 # The number of dml channels created at system startup + maxPartitionNum: 4096 # Maximum number of partitions in a collection + minSegmentSizeToEnableIndex: 1024 # It's a threshold. When the segment size is less than this value, the segment will not be indexed + enableActiveStandby: false + maxDatabaseNum: 64 # Maximum number of database + maxGeneralCapacity: 65536 # upper limit for the sum of of product of partitionNumber and shardNumber + gracefulStopTimeout: 5 # seconds. force stop node without graceful stop + ip: # if not specified, use the first unicastable address + port: 53100 + grpc: + serverMaxSendSize: 536870912 + serverMaxRecvSize: 268435456 + clientMaxSendSize: 268435456 + clientMaxRecvSize: 536870912 + +# Related configuration of proxy, used to validate client requests and reduce the returned results. +proxy: + timeTickInterval: 200 # ms, the interval that proxy synchronize the time tick + healthCheckTimeout: 3000 # ms, the interval that to do component healthy check + msgStream: + timeTick: + bufSize: 512 + maxNameLength: 255 # Maximum length of name for a collection or alias + # Maximum number of fields in a collection. + # As of today (2.2.0 and after) it is strongly DISCOURAGED to set maxFieldNum >= 64. + # So adjust at your risk! + maxFieldNum: 64 + maxVectorFieldNum: 4 # Maximum number of vector fields in a collection. + maxShardNum: 16 # Maximum number of shards in a collection + maxDimension: 32768 # Maximum dimension of a vector + # Whether to produce gin logs.\n + # please adjust in embedded Milvus: false + ginLogging: true + ginLogSkipPaths: / # skip url path for gin log + maxTaskNum: 1024 # max task number of proxy task queue + mustUsePartitionKey: false # switch for whether proxy must use partition key for the collection + accessLog: + enable: false # if use access log + minioEnable: false # if upload sealed access log file to minio + localPath: /tmp/milvus_access + filename: # Log filename, leave empty to use stdout. + maxSize: 64 # Max size for a single file, in MB. + cacheSize: 10240 # Size of log of memory cache, in B + rotatedTime: 0 # Max time for single access log file in seconds + remotePath: access_log/ # File path in minIO + remoteMaxTime: 0 # Max time for log file in minIO, in hours + formatters: + base: + format: "[$time_now] [ACCESS] <$user_name: $user_addr> $method_name [status: $method_status] [code: $error_code] [sdk: $sdk_version] [msg: $error_msg] [traceID: $trace_id] [timeCost: $time_cost]" + query: + format: "[$time_now] [ACCESS] <$user_name: $user_addr> $method_name [status: $method_status] [code: $error_code] [sdk: $sdk_version] [msg: $error_msg] [traceID: $trace_id] [timeCost: $time_cost] [database: $database_name] [collection: $collection_name] [partitions: $partition_name] [expr: $method_expr]" + methods: "Query,Search,Delete" + connectionCheckIntervalSeconds: 120 # the interval time(in seconds) for connection manager to scan inactive client info + connectionClientInfoTTLSeconds: 86400 # inactive client info TTL duration, in seconds + maxConnectionNum: 10000 # the max client info numbers that proxy should manage, avoid too many client infos + gracefulStopTimeout: 30 # seconds. force stop node without graceful stop + slowQuerySpanInSeconds: 5 # query whose executed time exceeds the `slowQuerySpanInSeconds` can be considered slow, in seconds. + http: + enabled: true # Whether to enable the http server + debug_mode: false # Whether to enable http server debug mode + port: # high-level restful api + acceptTypeAllowInt64: true # high-level restful api, whether http client can deal with int64 + enablePprof: true # Whether to enable pprof middleware on the metrics port + ip: # if not specified, use the first unicastable address + port: 19530 + internalPort: 19529 + grpc: + serverMaxSendSize: 268435456 + serverMaxRecvSize: 67108864 + clientMaxSendSize: 268435456 + clientMaxRecvSize: 67108864 + +# Related configuration of queryCoord, used to manage topology and load balancing for the query nodes, and handoff from growing segments to sealed segments. +queryCoord: + taskMergeCap: 1 + taskExecutionCap: 256 + autoHandoff: true # Enable auto handoff + autoBalance: true # Enable auto balance + autoBalanceChannel: true # Enable auto balance channel + balancer: ScoreBasedBalancer # auto balancer used for segments on queryNodes + globalRowCountFactor: 0.1 # the weight used when balancing segments among queryNodes + scoreUnbalanceTolerationFactor: 0.05 # the least value for unbalanced extent between from and to nodes when doing balance + reverseUnBalanceTolerationFactor: 1.3 # the largest value for unbalanced extent between from and to nodes after doing balance + overloadedMemoryThresholdPercentage: 90 # The threshold percentage that memory overload + balanceIntervalSeconds: 60 + memoryUsageMaxDifferencePercentage: 30 + rowCountFactor: 0.4 # the row count weight used when balancing segments among queryNodes + segmentCountFactor: 0.4 # the segment count weight used when balancing segments among queryNodes + globalSegmentCountFactor: 0.1 # the segment count weight used when balancing segments among queryNodes + segmentCountMaxSteps: 50 # segment count based plan generator max steps + rowCountMaxSteps: 50 # segment count based plan generator max steps + randomMaxSteps: 10 # segment count based plan generator max steps + growingRowCountWeight: 4 # the memory weight of growing segment row count + balanceCostThreshold: 0.001 # the threshold of balance cost, if the difference of cluster's cost after executing the balance plan is less than this value, the plan will not be executed + checkSegmentInterval: 1000 + checkChannelInterval: 1000 + checkBalanceInterval: 10000 + checkIndexInterval: 10000 + channelTaskTimeout: 60000 # 1 minute + segmentTaskTimeout: 120000 # 2 minute + distPullInterval: 500 + heartbeatAvailableInterval: 10000 # 10s, Only QueryNodes which fetched heartbeats within the duration are available + loadTimeoutSeconds: 600 + distRequestTimeout: 5000 # the request timeout for querycoord fetching data distribution from querynodes, in milliseconds + heatbeatWarningLag: 5000 # the lag value for querycoord report warning when last heatbeat is too old, in milliseconds + checkHandoffInterval: 5000 + enableActiveStandby: false + checkInterval: 1000 + checkHealthInterval: 3000 # 3s, the interval when query coord try to check health of query node + checkHealthRPCTimeout: 2000 # 100ms, the timeout of check health rpc to query node + brokerTimeout: 5000 # 5000ms, querycoord broker rpc timeout + collectionRecoverTimes: 3 # if collection recover times reach the limit during loading state, release it + observerTaskParallel: 16 # the parallel observer dispatcher task number + checkAutoBalanceConfigInterval: 10 # the interval of check auto balance config + checkNodeSessionInterval: 60 # the interval(in seconds) of check querynode cluster session + gracefulStopTimeout: 5 # seconds. force stop node without graceful stop + enableStoppingBalance: true # whether enable stopping balance + channelExclusiveNodeFactor: 4 # the least node number for enable channel's exclusive mode + cleanExcludeSegmentInterval: 60 # the time duration of clean pipeline exclude segment which used for filter invalid data, in seconds + ip: # if not specified, use the first unicastable address + port: 19531 + grpc: + serverMaxSendSize: 536870912 + serverMaxRecvSize: 268435456 + clientMaxSendSize: 268435456 + clientMaxRecvSize: 536870912 + +# Related configuration of queryNode, used to run hybrid search between vector and scalar data. +queryNode: + stats: + publishInterval: 1000 # Interval for querynode to report node information (milliseconds) + segcore: + knowhereThreadPoolNumRatio: 4 # The number of threads in knowhere's thread pool. If disk is enabled, the pool size will multiply with knowhereThreadPoolNumRatio([1, 32]). + # used for zilliz-cloud ; please ignore it for open source. + knowhereScoreConsistency: false + chunkRows: 128 # The number of vectors in a chunk. + interimIndex: + enableIndex: true # Enable segment build with index to accelerate vector search when segment is in growing or binlog. + nlist: 128 # temp index nlist, recommend to set sqrt(chunkRows), must smaller than chunkRows/8 + nprobe: 16 # nprobe to search small index, based on your accuracy requirement, must smaller than nlist + memExpansionRate: 1.15 # extra memory needed by building interim index + buildParallelRate: 0.5 # the ratio of building interim index parallel matched with cpu num + loadMemoryUsageFactor: 1 # The multiply factor of calculating the memory usage while loading segments + enableDisk: false # enable querynode load disk index, and search on disk index + maxDiskUsagePercentage: 95 + cache: + enabled: true + memoryLimit: 2147483648 # 2 GB, 2 * 1024 *1024 *1024 + readAheadPolicy: willneed # The read ahead policy of chunk cache, options: `normal, random, sequential, willneed, dontneed` + # options: async, sync, off. + # Specifies the necessity for warming up the chunk cache. + # 1. If set to "sync" or "async," the original vector data will be synchronously/asynchronously loaded into the + # chunk cache during the load process. This approach has the potential to substantially reduce query/search latency + # for a specific duration post-load, albeit accompanied by a concurrent increase in disk usage; + # 2. If set to "off," original vector data will only be loaded into the chunk cache during search/query. + warmup: async + mmap: + mmapEnabled: false # Enable mmap for loading data + lazyload: + enabled: false # Enable lazyload for loading data + waitTimeout: 30000 # max wait timeout duration in milliseconds before start to do lazyload search and retrieve + requestResourceTimeout: 5000 # max timeout in milliseconds for waiting request resource for lazy load, 5s by default + requestResourceRetryInterval: 2000 # retry interval in milliseconds for waiting request resource for lazy load, 2s by default + maxRetryTimes: 1 # max retry times for lazy load, 1 by default + maxEvictPerRetry: 1 # max evict count for lazy load, 1 by default + grouping: + enabled: true + maxNQ: 1000 + topKMergeRatio: 20 + scheduler: + receiveChanSize: 10240 + unsolvedQueueSize: 10240 + # maxReadConcurrentRatio is the concurrency ratio of read task (search task and query task). + # Max read concurrency would be the value of hardware.GetCPUNum * maxReadConcurrentRatio. + # It defaults to 2.0, which means max read concurrency would be the value of hardware.GetCPUNum * 2. + # Max read concurrency must greater than or equal to 1, and less than or equal to hardware.GetCPUNum * 100. + # (0, 100] + maxReadConcurrentRatio: 1 + cpuRatio: 10 # ratio used to estimate read task cpu usage. + maxTimestampLag: 86400 + scheduleReadPolicy: + # fifo: A FIFO queue support the schedule. + # user-task-polling: + # The user's tasks will be polled one by one and scheduled. + # Scheduling is fair on task granularity. + # The policy is based on the username for authentication. + # And an empty username is considered the same user. + # When there are no multi-users, the policy decay into FIFO" + name: fifo + taskQueueExpire: 60 # Control how long (many seconds) that queue retains since queue is empty + enableCrossUserGrouping: false # Enable Cross user grouping when using user-task-polling policy. (Disable it if user's task can not merge each other) + maxPendingTaskPerUser: 1024 # Max pending task per user in scheduler + dataSync: + flowGraph: + maxQueueLength: 16 # Maximum length of task queue in flowgraph + maxParallelism: 1024 # Maximum number of tasks executed in parallel in the flowgraph + enableSegmentPrune: false # use partition prune function on shard delegator + ip: # if not specified, use the first unicastable address + port: 21123 + grpc: + serverMaxSendSize: 536870912 + serverMaxRecvSize: 268435456 + clientMaxSendSize: 268435456 + clientMaxRecvSize: 536870912 + +indexCoord: + bindIndexNodeMode: + enable: false + address: localhost:22930 + withCred: false + nodeID: 0 + segment: + minSegmentNumRowsToEnableIndex: 1024 # It's a threshold. When the segment num rows is less than this value, the segment will not be indexed + +indexNode: + scheduler: + buildParallel: 1 + enableDisk: true # enable index node build disk vector index + maxDiskUsagePercentage: 95 + ip: # if not specified, use the first unicastable address + port: 21121 + grpc: + serverMaxSendSize: 536870912 + serverMaxRecvSize: 268435456 + clientMaxSendSize: 268435456 + clientMaxRecvSize: 536870912 + +dataCoord: + channel: + watchTimeoutInterval: 300 # Timeout on watching channels (in seconds). Datanode tickler update watch progress will reset timeout timer. + balanceWithRpc: true # Whether to enable balance with RPC, default to use etcd watch + legacyVersionWithoutRPCWatch: 2.4.0 # Datanodes <= this version are considered as legacy nodes, which doesn't have rpc based watch(). This is only used during rolling upgrade where legacy nodes won't get new channels + balanceSilentDuration: 300 # The duration after which the channel manager start background channel balancing + balanceInterval: 360 # The interval with which the channel manager check dml channel balance status + checkInterval: 1 # The interval in seconds with which the channel manager advances channel states + notifyChannelOperationTimeout: 5 # Timeout notifing channel operations (in seconds). + segment: + maxSize: 1024 # Maximum size of a segment in MB + diskSegmentMaxSize: 2048 # Maximun size of a segment in MB for collection which has Disk index + sealProportion: 0.12 + assignmentExpiration: 2000 # The time of the assignment expiration in ms + allocLatestExpireAttempt: 200 # The time attempting to alloc latest lastExpire from rootCoord after restart + maxLife: 86400 # The max lifetime of segment in seconds, 24*60*60 + # If a segment didn't accept dml records in maxIdleTime and the size of segment is greater than + # minSizeFromIdleToSealed, Milvus will automatically seal it. + # The max idle time of segment in seconds, 10*60. + maxIdleTime: 600 + minSizeFromIdleToSealed: 16 # The min size in MB of segment which can be idle from sealed. + # The max number of binlog file for one segment, the segment will be sealed if + # the number of binlog file reaches to max value. + maxBinlogFileNumber: 32 + smallProportion: 0.5 # The segment is considered as "small segment" when its # of rows is smaller than + # (smallProportion * segment max # of rows). + # A compaction will happen on small segments if the segment after compaction will have + compactableProportion: 0.85 + # over (compactableProportion * segment max # of rows) rows. + # MUST BE GREATER THAN OR EQUAL TO !!! + # During compaction, the size of segment # of rows is able to exceed segment max # of rows by (expansionRate-1) * 100%. + expansionRate: 1.25 + autoUpgradeSegmentIndex: false # whether auto upgrade segment index to index engine's version + enableCompaction: true # Enable data segment compaction + compaction: + enableAutoCompaction: true + indexBasedCompaction: true + rpcTimeout: 10 + maxParallelTaskNum: 10 + workerMaxParallelTaskNum: 2 + levelzero: + forceTrigger: + minSize: 8388608 # The minmum size in bytes to force trigger a LevelZero Compaction, default as 8MB + maxSize: 67108864 # The maxmum size in bytes to force trigger a LevelZero Compaction, default as 64MB + deltalogMinNum: 10 # The minimum number of deltalog files to force trigger a LevelZero Compaction + deltalogMaxNum: 30 # The maxmum number of deltalog files to force trigger a LevelZero Compaction, default as 30 + enableGarbageCollection: true + gc: + interval: 3600 # gc interval in seconds + missingTolerance: 86400 # file meta missing tolerance duration in seconds, default to 24hr(1d) + dropTolerance: 10800 # file belongs to dropped entity tolerance duration in seconds. 3600 + removeConcurrent: 32 # number of concurrent goroutines to remove dropped s3 objects + scanInterval: 168 # garbage collection scan residue interval in hours + enableActiveStandby: false + brokerTimeout: 5000 # 5000ms, dataCoord broker rpc timeout + autoBalance: true # Enable auto balance + checkAutoBalanceConfigInterval: 10 # the interval of check auto balance config + import: + filesPerPreImportTask: 2 # The maximum number of files allowed per pre-import task. + taskRetention: 10800 # The retention period in seconds for tasks in the Completed or Failed state. + maxSizeInMBPerImportTask: 6144 # To prevent generating of small segments, we will re-group imported files. This parameter represents the sum of file sizes in each group (each ImportTask). + scheduleInterval: 2 # The interval for scheduling import, measured in seconds. + checkIntervalHigh: 2 # The interval for checking import, measured in seconds, is set to a high frequency for the import checker. + checkIntervalLow: 120 # The interval for checking import, measured in seconds, is set to a low frequency for the import checker. + maxImportFileNumPerReq: 1024 # The maximum number of files allowed per single import request. + waitForIndex: true # Indicates whether the import operation waits for the completion of index building. + gracefulStopTimeout: 5 # seconds. force stop node without graceful stop + ip: # if not specified, use the first unicastable address + port: 13333 + grpc: + serverMaxSendSize: 536870912 + serverMaxRecvSize: 268435456 + clientMaxSendSize: 268435456 + clientMaxRecvSize: 536870912 + +dataNode: + dataSync: + flowGraph: + maxQueueLength: 16 # Maximum length of task queue in flowgraph + maxParallelism: 1024 # Maximum number of tasks executed in parallel in the flowgraph + maxParallelSyncMgrTasks: 256 # The max concurrent sync task number of datanode sync mgr globally + skipMode: + enable: true # Support skip some timetick message to reduce CPU usage + skipNum: 4 # Consume one for every n records skipped + coldTime: 60 # Turn on skip mode after there are only timetick msg for x seconds + segment: + insertBufSize: 16777216 # Max buffer size to flush for a single segment. + deleteBufBytes: 67108864 # Max buffer size in bytes to flush del for a single channel, default as 16MB + syncPeriod: 600 # The period to sync segments if buffer is not empty. + memory: + forceSyncEnable: true # Set true to force sync if memory usage is too high + forceSyncSegmentNum: 1 # number of segments to sync, segments with top largest buffer will be synced. + checkInterval: 3000 # the interal to check datanode memory usage, in milliseconds + forceSyncWatermark: 0.5 # memory watermark for standalone, upon reaching this watermark, segments will be synced. + timetick: + byRPC: true + interval: 500 + channel: + # specify the size of global work pool of all channels + # if this parameter <= 0, will set it as the maximum number of CPUs that can be executing + # suggest to set it bigger on large collection numbers to avoid blocking + workPoolSize: -1 + # specify the size of global work pool for channel checkpoint updating + # if this parameter <= 0, will set it as 10 + updateChannelCheckpointMaxParallel: 10 + updateChannelCheckpointInterval: 60 # the interval duration(in seconds) for datanode to update channel checkpoint of each channel + updateChannelCheckpointRPCTimeout: 20 # timeout in seconds for UpdateChannelCheckpoint RPC call + maxChannelCheckpointsPerPRC: 128 # The maximum number of channel checkpoints per UpdateChannelCheckpoint RPC. + channelCheckpointUpdateTickInSeconds: 10 # The frequency, in seconds, at which the channel checkpoint updater executes updates. + import: + maxConcurrentTaskNum: 16 # The maximum number of import/pre-import tasks allowed to run concurrently on a datanode. + maxImportFileSizeInGB: 16 # The maximum file size (in GB) for an import file, where an import file refers to either a Row-Based file or a set of Column-Based files. + readBufferSizeInMB: 16 # The data block size (in MB) read from chunk manager by the datanode during import. + compaction: + levelZeroBatchMemoryRatio: 0.05 # The minimal memory ratio of free memory for level zero compaction executing in batch mode + gracefulStopTimeout: 1800 # seconds. force stop node without graceful stop + ip: # if not specified, use the first unicastable address + port: 21124 + grpc: + serverMaxSendSize: 536870912 + serverMaxRecvSize: 268435456 + clientMaxSendSize: 268435456 + clientMaxRecvSize: 536870912 + slot: + slotCap: 2 # The maximum number of tasks(e.g. compaction, importing) allowed to run concurrently on a datanode. + +# Configures the system log output. +log: + level: info # Only supports debug, info, warn, error, panic, or fatal. Default 'info'. + file: + rootPath: # root dir path to put logs, default "" means no log file will print. please adjust in embedded Milvus: /tmp/milvus/logs + maxSize: 300 # MB + maxAge: 10 # Maximum time for log retention in day. + maxBackups: 20 + format: text # text or json + stdout: true # Stdout enable or not + +grpc: + log: + level: WARNING + gracefulStopTimeout: 10 # second, time to wait graceful stop finish + client: + compressionEnabled: false + dialTimeout: 200 + keepAliveTime: 10000 + keepAliveTimeout: 20000 + maxMaxAttempts: 10 + initialBackoff: 0.2 + maxBackoff: 10 + minResetInterval: 1000 + maxCancelError: 32 + minSessionCheckInterval: 200 + +# Configure the proxy tls enable. +tls: + serverPemPath: configs/cert/server.pem + serverKeyPath: configs/cert/server.key + caPemPath: configs/cert/ca.pem + +common: + defaultPartitionName: _default # default partition name for a collection + defaultIndexName: _default_idx # default index name + entityExpiration: -1 # Entity expiration in seconds, CAUTION -1 means never expire + indexSliceSize: 16 # MB + threadCoreCoefficient: + highPriority: 10 # This parameter specify how many times the number of threads is the number of cores in high priority pool + middlePriority: 5 # This parameter specify how many times the number of threads is the number of cores in middle priority pool + lowPriority: 1 # This parameter specify how many times the number of threads is the number of cores in low priority pool + buildIndexThreadPoolRatio: 0.75 + DiskIndex: + MaxDegree: 56 + SearchListSize: 100 + PQCodeBudgetGBRatio: 0.125 + BuildNumThreadsRatio: 1 + SearchCacheBudgetGBRatio: 0.1 + LoadNumThreadRatio: 8 + BeamWidthRatio: 4 + gracefulTime: 5000 # milliseconds. it represents the interval (in ms) by which the request arrival time needs to be subtracted in the case of Bounded Consistency. + gracefulStopTimeout: 1800 # seconds. it will force quit the server if the graceful stop process is not completed during this time. + storageType: remote # please adjust in embedded Milvus: local, available values are [local, remote, opendal], value minio is deprecated, use remote instead + # Default value: auto + # Valid values: [auto, avx512, avx2, avx, sse4_2] + # This configuration is only used by querynode and indexnode, it selects CPU instruction set for Searching and Index-building. + simdType: auto + security: + authorizationEnabled: false + # The superusers will ignore some system check processes, + # like the old password verification when updating the credential + superUsers: + tlsMode: 0 + session: + ttl: 30 # ttl value when session granting a lease to register service + retryTimes: 30 # retry times when session sending etcd requests + locks: + metrics: + enable: false # whether gather statistics for metrics locks + threshold: + info: 500 # minimum milliseconds for printing durations in info level + warn: 1000 # minimum milliseconds for printing durations in warn level + storage: + scheme: s3 + enablev2: false + ttMsgEnabled: true # Whether the instance disable sending ts messages + traceLogMode: 0 # trace request info + bloomFilterSize: 100000 # bloom filter initial size + maxBloomFalsePositive: 0.05 # max false positive rate for bloom filter + +# QuotaConfig, configurations of Milvus quota and limits. +# By default, we enable: +# 1. TT protection; +# 2. Memory protection. +# 3. Disk quota protection. +# You can enable: +# 1. DML throughput limitation; +# 2. DDL, DQL qps/rps limitation; +# 3. DQL Queue length/latency protection; +# 4. DQL result rate protection; +# If necessary, you can also manually force to deny RW requests. +quotaAndLimits: + enabled: true # `true` to enable quota and limits, `false` to disable. + # quotaCenterCollectInterval is the time interval that quotaCenter + # collects metrics from Proxies, Query cluster and Data cluster. + # seconds, (0 ~ 65536) + quotaCenterCollectInterval: 3 + ddl: + enabled: false + collectionRate: -1 # qps, default no limit, rate for CreateCollection, DropCollection, LoadCollection, ReleaseCollection + partitionRate: -1 # qps, default no limit, rate for CreatePartition, DropPartition, LoadPartition, ReleasePartition + db: + collectionRate: -1 # qps of db level , default no limit, rate for CreateCollection, DropCollection, LoadCollection, ReleaseCollection + partitionRate: -1 # qps of db level, default no limit, rate for CreatePartition, DropPartition, LoadPartition, ReleasePartition + indexRate: + enabled: false + max: -1 # qps, default no limit, rate for CreateIndex, DropIndex + db: + max: -1 # qps of db level, default no limit, rate for CreateIndex, DropIndex + flushRate: + enabled: false + max: -1 # qps, default no limit, rate for flush + collection: + max: -1 # qps, default no limit, rate for flush at collection level. + db: + max: -1 # qps of db level, default no limit, rate for flush + compactionRate: + enabled: false + max: -1 # qps, default no limit, rate for manualCompaction + db: + max: -1 # qps of db level, default no limit, rate for manualCompaction + dml: + # dml limit rates, default no limit. + # The maximum rate will not be greater than max. + enabled: false + insertRate: + max: -1 # MB/s, default no limit + db: + max: -1 # MB/s, default no limit + collection: + max: -1 # MB/s, default no limit + partition: + max: -1 # MB/s, default no limit + upsertRate: + max: -1 # MB/s, default no limit + db: + max: -1 # MB/s, default no limit + collection: + max: -1 # MB/s, default no limit + partition: + max: -1 # MB/s, default no limit + deleteRate: + max: -1 # MB/s, default no limit + db: + max: -1 # MB/s, default no limit + collection: + max: -1 # MB/s, default no limit + partition: + max: -1 # MB/s, default no limit + bulkLoadRate: + max: -1 # MB/s, default no limit, not support yet. TODO: limit bulkLoad rate + db: + max: -1 # MB/s, default no limit, not support yet. TODO: limit db bulkLoad rate + collection: + max: -1 # MB/s, default no limit, not support yet. TODO: limit collection bulkLoad rate + partition: + max: -1 # MB/s, default no limit, not support yet. TODO: limit partition bulkLoad rate + dql: + # dql limit rates, default no limit. + # The maximum rate will not be greater than max. + enabled: false + searchRate: + max: -1 # vps (vectors per second), default no limit + db: + max: -1 # vps (vectors per second), default no limit + collection: + max: -1 # vps (vectors per second), default no limit + partition: + max: -1 # vps (vectors per second), default no limit + queryRate: + max: -1 # qps, default no limit + db: + max: -1 # qps, default no limit + collection: + max: -1 # qps, default no limit + partition: + max: -1 # qps, default no limit + limits: + maxCollectionNum: 65536 + maxCollectionNumPerDB: 65536 + maxInsertSize: -1 # maximum size of a single insert request, in bytes, -1 means no limit + maxResourceGroupNumOfQueryNode: 1024 # maximum number of resource groups of query nodes + limitWriting: + # forceDeny false means dml requests are allowed (except for some + # specific conditions, such as memory of nodes to water marker), true means always reject all dml requests. + forceDeny: false + ttProtection: + enabled: false + # maxTimeTickDelay indicates the backpressure for DML Operations. + # DML rates would be reduced according to the ratio of time tick delay to maxTimeTickDelay, + # if time tick delay is greater than maxTimeTickDelay, all DML requests would be rejected. + # seconds + maxTimeTickDelay: 300 + memProtection: + # When memory usage > memoryHighWaterLevel, all dml requests would be rejected; + # When memoryLowWaterLevel < memory usage < memoryHighWaterLevel, reduce the dml rate; + # When memory usage < memoryLowWaterLevel, no action. + enabled: true + dataNodeMemoryLowWaterLevel: 0.85 # (0, 1], memoryLowWaterLevel in DataNodes + dataNodeMemoryHighWaterLevel: 0.95 # (0, 1], memoryHighWaterLevel in DataNodes + queryNodeMemoryLowWaterLevel: 0.85 # (0, 1], memoryLowWaterLevel in QueryNodes + queryNodeMemoryHighWaterLevel: 0.95 # (0, 1], memoryHighWaterLevel in QueryNodes + growingSegmentsSizeProtection: + # No action will be taken if the growing segments size is less than the low watermark. + # When the growing segments size exceeds the low watermark, the dml rate will be reduced, + # but the rate will not be lower than minRateRatio * dmlRate. + enabled: false + minRateRatio: 0.5 + lowWaterLevel: 0.2 + highWaterLevel: 0.4 + diskProtection: + enabled: true # When the total file size of object storage is greater than `diskQuota`, all dml requests would be rejected; + diskQuota: -1 # MB, (0, +inf), default no limit + diskQuotaPerDB: -1 # MB, (0, +inf), default no limit + diskQuotaPerCollection: -1 # MB, (0, +inf), default no limit + diskQuotaPerPartition: -1 # MB, (0, +inf), default no limit + limitReading: + # forceDeny false means dql requests are allowed (except for some + # specific conditions, such as collection has been dropped), true means always reject all dql requests. + forceDeny: false + queueProtection: + enabled: false + # nqInQueueThreshold indicated that the system was under backpressure for Search/Query path. + # If NQ in any QueryNode's queue is greater than nqInQueueThreshold, search&query rates would gradually cool off + # until the NQ in queue no longer exceeds nqInQueueThreshold. We think of the NQ of query request as 1. + # int, default no limit + nqInQueueThreshold: -1 + # queueLatencyThreshold indicated that the system was under backpressure for Search/Query path. + # If dql latency of queuing is greater than queueLatencyThreshold, search&query rates would gradually cool off + # until the latency of queuing no longer exceeds queueLatencyThreshold. + # The latency here refers to the averaged latency over a period of time. + # milliseconds, default no limit + queueLatencyThreshold: -1 + resultProtection: + enabled: false + # maxReadResultRate indicated that the system was under backpressure for Search/Query path. + # If dql result rate is greater than maxReadResultRate, search&query rates would gradually cool off + # until the read result rate no longer exceeds maxReadResultRate. + # MB/s, default no limit + maxReadResultRate: -1 + maxReadResultRatePerDB: -1 + maxReadResultRatePerCollection: -1 + # colOffSpeed is the speed of search&query rates cool off. + # (0, 1] + coolOffSpeed: 0.9 + +trace: + # trace exporter type, default is stdout, + # optional values: ['noop','stdout', 'jaeger', 'otlp'] + exporter: noop + # fraction of traceID based sampler, + # optional values: [0, 1] + # Fractions >= 1 will always sample. Fractions < 0 are treated as zero. + sampleFraction: 0 + jaeger: + url: # when exporter is jaeger should set the jaeger's URL + otlp: + endpoint: # example: "127.0.0.1:4318" + secure: true + +#when using GPU indexing, Milvus will utilize a memory pool to avoid frequent memory allocation and deallocation. +#here, you can set the size of the memory occupied by the memory pool, with the unit being MB. +#note that there is a possibility of Milvus crashing when the actual memory demand exceeds the value set by maxMemSize. +#if initMemSize and MaxMemSize both set zero, +#milvus will automatically initialize half of the available GPU memory, +#maxMemSize will the whole available GPU memory. +gpu: + initMemSize: # Gpu Memory Pool init size + maxMemSize: # Gpu Memory Pool Max size diff --git a/demo/start.txt b/demo/start.txt new file mode 100644 index 0000000000000..036089d3d70ba --- /dev/null +++ b/demo/start.txt @@ -0,0 +1,8 @@ +milvus/bin/milvus run standalone > milvus-data/debug/log-1.txt 2> milvus-data/debug/err-1.txt + +etcd --data-dir milvus-data/etcd-data +etcd -advertise-client-urls=http://127.0.0.1:2379 -listen-client-urls http://0.0.0.0:2379 --data-dir milvus-data/etcd-data + +minio server milvus-data/minio-data + +apache-pulsar-2.8.2/bin/pulsar standalone \ No newline at end of file diff --git a/demo/test_json_and_csv_467187962003049091.csv b/demo/test_json_and_csv_467187962003049091.csv new file mode 100644 index 0000000000000..1bc34baf3342b --- /dev/null +++ b/demo/test_json_and_csv_467187962003049091.csv @@ -0,0 +1,101 @@ +floatVecField,bfloat16VecField +"[0.97348994,0.18364559,0.6716139,0.20463996,0.57509786,0.45693088,0.13706304,0.517287,0.0713821,0.21587422,0.81239706,0.20871876,0.7321938,0.23226695,0.92166007,0.6227395,0.77176344,0.46152914,0.66455275,0.10684287,0.08330721,0.26829684,0.7108264,0.7678311,0.8942481,0.6457155,0.7339568,0.33626968,0.28574064,0.070123635,0.35644034,0.46906093,0.75922084,0.19228822,0.4871467,0.13720034,0.656826,0.7359651,0.4970803,0.9326413,0.86367774,0.028827066,0.011074921,0.6227414,0.7434625,0.65636104,0.25148666,0.5988423,0.4599008,0.5767946,0.35443264,0.21729577,0.73187155,0.7531751,0.9545665,0.6407624,0.083856426,0.9700598,0.11429237,0.09858969,0.27599254,0.34086728,0.7753307,0.5287368]","[-30.875,-16.5,43.25,-14.5,-23.5,-35.5,-40.75,-48.75,-28.375,-6.8125,31,24.125,-40.75,-33,-10.9375,41.5,-19.875,-22.25,-23.75,-24.75,-49.25,45.75,17.625,25.75,5.5625,-41.5,4.875,-45.75,13.375,-8.1875,-49,-14.75]" +"[0.34637263,0.23768362,0.60299087,0.65930265,0.9100921,0.14951335,0.63095003,0.15575668,0.27580455,0.56351537,0.8229619,0.220444,0.47312713,0.7899019,0.32410443,0.56647563,0.30353814,0.51607203,0.63875335,0.10060371,0.13512675,0.88269055,0.5497201,0.903678,0.10761932,0.11039449,0.31188822,0.054963984,0.6287179,0.041096147,0.5543064,0.85241395,0.24707921,0.9641096,0.16803393,0.22942996,0.44259867,0.28599912,0.66586655,0.47897705,0.5640338,0.3783989,0.39029378,0.18201236,0.7640742,0.18579623,0.37209928,0.09477112,0.9795771,0.7245206,0.17083699,0.10943091,0.19379431,0.45949128,0.41637745,0.6238885,0.6281464,0.0005543964,0.124373205,0.97009754,0.77245295,0.16028471,0.5306067,0.5362056]","[-40.75,-2.5625,2.71875,-41.75,-34.5,-14.8125,-9,-26.125,11.9375,-23,-22.5,-47.75,38.25,49.5,-24.125,47.25,-38.5,-0.6171875,-22.875,-8.5625,-39.25,19,39.75,28.875,23.125,-44,39.75,-43,39.75,44.75,12.125,33.25]" +"[0.25307462,0.9872258,0.44600967,0.075478755,0.9486995,0.9009919,0.29920828,0.9820183,0.272393,0.5256052,0.044662315,0.77258766,0.8626149,0.15176587,0.5436234,0.13494818,0.3362146,0.578164,0.0008220642,0.27371693,0.9080775,0.1881627,0.11150463,0.027746601,0.84949434,0.64284796,0.47510538,0.28471535,0.49133438,0.7133074,0.28427622,0.42002177,0.6750507,0.37031648,0.861757,0.90506136,0.024661234,0.042512417,0.058254257,0.033570822,0.31268135,0.29207322,0.38480276,0.6721591,0.6292683,0.29018563,0.11475523,0.2667002,0.11117055,0.9129727,0.35568568,0.62278587,0.81989634,0.59021765,0.09781845,0.16867769,0.4618155,0.5392846,0.512941,0.2509213,0.9334666,0.79376036,0.47073153,0.8402677]","[-0.265625,-40.25,30.75,-15.875,-0.83984375,27.625,-35.5,-35.5,46.75,16.25,25.375,19,29.125,-15.375,-37.5,-38.5,-36.75,-31.25,-48.75,16.375,46.25,-32.5,-32,-46.5,42.25,-24.75,48,-1.09375,19.875,-25.375,47.75,-49.5]" +"[0.16709034,0.1681943,0.45612663,0.4607479,0.0058467207,0.82111937,0.6279681,0.8022256,0.31040236,0.9327161,0.91985595,0.54809463,0.90015477,0.4569153,0.88664174,0.7005615,0.65880346,0.5913372,0.0381357,0.42188135,0.7213677,0.15147918,0.89300984,0.32582557,0.6030773,0.23668718,0.2075812,0.085374676,0.93043417,0.25299233,0.99416053,0.12828036,0.4665877,0.54140556,0.23728584,0.115998626,0.16913502,0.47984004,0.6259136,0.10520846,0.37114084,0.33562395,0.8212617,0.63926864,0.45487127,0.8827456,0.1339406,0.7283109,0.9123077,0.061809905,0.2730222,0.4671232,0.47050637,0.5351327,0.49810633,0.82329,0.90303195,0.4736466,0.51660144,0.0021384705,0.40913504,0.35294822,0.61203915,0.87553334]","[24.875,28,-11.375,2.265625,15.375,-13.375,-8.9375,-24.875,0.16308594,-39,0.33203125,32.5,31.875,37.25,32.25,33.75,-27.75,-30,44.75,-49.5,-49,-30.375,-41,32,-49,-25.25,13.5625,-46,-38.25,49.5,-5.90625,2.28125]" +"[0.28421116,0.95462996,0.5257625,0.22289458,0.8954739,0.7602569,0.32490402,0.08582327,0.64089316,0.7335192,0.07622238,0.8058913,0.64390326,0.2049538,0.42150012,0.9924657,0.8694121,0.69368064,0.5194918,0.98419785,0.2955615,0.39170384,0.25644708,0.6266737,0.80696994,0.23746409,0.9872296,0.15483773,0.6710551,0.1287496,0.9081415,0.30871594,0.11731259,0.13496596,0.10583648,0.97652227,0.10043594,0.5053965,0.19585621,0.605663,0.38115332,0.76087725,0.36209726,0.53249115,0.6645863,0.009721886,0.75737005,0.35597673,0.007704003,0.0955044,0.44569203,0.77102375,0.885146,0.20357542,0.73024887,0.21706647,0.7450936,0.27002552,0.3777483,0.6410288,0.5266314,0.6563401,0.9073752,0.6234989]","[-46.25,7.03125,-42.25,39,14.8125,25.5,-42.75,-32.25,-6.3125,36,-22.375,-1.15625,-9.4375,44.5,-20.75,4.53125,29.625,18.125,28.5,-34.75,-22.875,-21.125,21.875,17.125,49.75,-33.25,-27.375,-8.6875,-7.28125,7.78125,-35.75,26.75]" +"[0.32428828,0.11752425,0.7936253,0.41004953,0.086844586,0.09386198,0.88079345,0.1756856,0.6393012,0.65844625,0.6087387,0.45477378,0.96902394,0.06185263,0.14100014,0.7657615,0.75533766,0.85989106,0.0578442,0.39673364,0.6411922,0.5912149,0.991238,0.6496897,0.021369701,0.3051289,0.17906973,0.77825415,0.70463765,0.22987871,0.12203348,0.71205413,0.2893173,0.28266943,0.57392114,0.5011839,0.4423967,0.26680863,0.2910336,0.68488884,0.15791838,0.30688635,0.29408342,0.59892714,0.30814147,0.7606118,0.6250631,0.14361727,0.87935966,0.56918967,0.2438965,0.63934314,0.48773474,0.48326603,0.747472,0.3824442,0.44222033,0.2729365,0.9472284,0.6822347,0.050450075,0.2954289,0.60584176,0.5517175]","[-34.75,23.25,-19,-3.15625,-40.25,-38,-7.59375,-18.375,10.5625,-46.5,-37.5,47.75,-10.6875,38,-29.625,-34,36,-36.75,39,5.0625,-46.5,-13.125,-21.125,23.25,48,-42.5,-48.25,-42.5,0.76171875,43.75,-10.8125,-17.5]" +"[0.27866107,0.6864951,0.23104423,0.39041388,0.37719896,0.539066,0.41324666,0.7919707,0.557868,0.9792702,0.52724445,0.64236146,0.93117225,0.49009228,0.93809795,0.1937529,0.9086407,0.9396348,0.6325006,0.14250496,0.38069046,0.6586242,0.0548663,0.65777266,0.514667,0.37149078,0.13315156,0.67234915,0.7647139,0.61816084,0.17207468,0.5460472,0.4997434,0.27914816,0.9301988,0.53649944,0.74805915,0.40706193,0.24986221,0.28296795,0.5877666,0.07091055,0.6173606,0.5639981,0.424668,0.93183744,0.5112666,0.31357867,0.595813,0.37388575,0.1340366,0.52229744,0.8537664,0.58238083,0.42522362,0.7306344,0.0012664407,0.2615153,0.88215077,0.20272318,0.71320987,0.79268295,0.43021673,0.54955065]","[-12.125,10.6875,-46.75,-17.875,6.90625,35.5,-2.4375,35,-24,-13.1875,-39.25,-20.625,30.125,34.25,25.875,24.875,31.125,31,23.375,32,-32.25,16.25,35.25,-31.125,21,1.0859375,35.75,12.1875,-32,-49.25,18.75,14.375]" +"[0.64058924,0.8298036,0.4536559,0.17740773,0.67104125,0.6451938,0.6198434,0.7098781,0.35507995,0.353629,0.697126,0.5519053,0.035643008,0.13128151,0.63671774,0.5478598,0.39694837,0.0602932,0.15996018,0.7967724,0.37292814,0.7142458,0.26010218,0.050459173,0.5354363,0.6115435,0.15098055,0.06383955,0.8461937,0.8446063,0.0057615805,0.062214784,0.35059336,0.1606821,0.78082603,0.3072225,0.20688187,0.9580441,0.23781,0.2761387,0.49129286,0.29025522,0.8437771,0.633666,0.7678628,0.36644572,0.22288273,0.36710352,0.46253535,0.38232905,0.21968806,0.28805298,0.4204068,0.35537252,0.4236161,0.55579925,0.9537397,0.96877277,0.4934053,0.5132506,0.9400866,0.56809676,0.9120378,0.69056636]","[22.5,39,44.75,9.5625,-31,8.9375,-23.75,37.25,15.5625,29.5,-38.5,23.375,14.25,-35.75,17.5,-47.25,-33.25,-19.625,-27,20.875,45.75,40,-31,3.109375,22.625,19.125,-28.375,39.25,35.5,19.625,-25.5,-35]" +"[0.21394418,0.8803786,0.59326696,0.2635005,0.44496864,0.20757379,0.12691504,0.5892394,0.12053906,0.400156,0.55695367,0.6392792,0.26185372,0.5766776,0.43359068,0.21611054,0.5238496,0.9812925,0.35401326,0.8484357,0.8138693,0.68685234,0.3745619,0.91365606,0.98967564,0.10656149,0.0057758964,0.5822305,0.53485286,0.15947546,0.7499074,0.026259229,0.5488891,0.10990549,0.24323967,0.0061950055,0.40513182,0.94337785,0.97228694,0.18448594,0.15242322,0.61076635,0.00687709,0.6926294,0.8256909,0.5592444,0.6362975,0.58143026,0.33927092,0.35508218,0.632174,0.2215143,0.93502444,0.29045048,0.7371254,0.8706796,0.06881384,0.8374951,0.33070758,0.21209273,0.2935425,0.68212086,0.57471335,0.4870502]","[-4.9375,-20.25,26.375,43.75,45.25,16.375,34.25,-29.5,-18.5,26.25,-39,-42.75,-34,-2.109375,20.625,45,38.5,6.625,-14.4375,23.75,-8.0625,16,-2.0625,39.75,8.5,20.125,-37.75,26.875,-14.375,-9.375,-27.625,30.125]" +"[0.46401337,0.73596215,0.6008019,0.6318032,0.9632428,0.36101922,0.19033118,0.079244934,0.93602884,0.8569375,0.037441276,0.51484203,0.9083118,0.9290836,0.5300944,0.9358413,0.32614344,0.7019017,0.7870495,0.89885134,0.11905689,0.5489642,0.0028603014,0.5743859,0.352324,0.32319653,0.3009047,0.08020948,0.60448235,0.08125438,0.11250525,0.114490055,0.9494071,0.4269515,0.06453104,0.6329421,0.8536645,0.7782552,0.10850187,0.06262007,0.86556387,0.83376676,0.51384765,0.9112636,0.010521116,0.6262977,0.8526182,0.8937969,0.17358328,0.95387006,0.3895123,0.65722835,0.7694807,0.15322313,0.034639686,0.18528174,0.33060426,0.89187515,0.64315605,0.5798241,0.66905075,0.6645818,0.22967267,0.38428402]","[19.5,-46.75,-12.3125,-49.5,44,-7.84375,32.25,-23,-48.75,-20.25,32.75,19.875,-17.875,33,-23,-43,27.75,-2.25,-41.25,16.625,-27,35.25,-3.515625,-13.6875,-8.8125,24,-6.5625,-10.75,28.5,18.375,-20,-34]" +"[0.3359055,0.36650634,0.70638996,0.9007225,0.37530822,0.98481506,0.41590732,0.6111497,0.41127127,0.45329526,0.89567786,0.69069093,0.3385958,0.30193675,0.8942712,0.06574256,0.12851214,0.6330937,0.9037909,0.9629158,0.14358895,0.33176547,0.17982839,0.4971031,0.7620305,0.6721604,0.077859916,0.80323696,0.98322874,0.706503,0.018829135,0.2844706,0.4314365,0.5116316,0.59893745,0.54259276,0.29201832,0.011640509,0.8143809,0.33067083,0.22128804,0.33762887,0.59193474,0.60627866,0.46225107,0.08881829,0.18463649,0.47561282,0.062119238,0.13849676,0.3797519,0.06532551,0.41919,0.29777926,0.31073993,0.35748154,0.39336246,0.8996548,0.12587453,0.24607852,0.60509425,0.9789744,0.7842514,0.7583458]","[-1.78125,43,-44.5,42.5,-31.625,31.5,-8.0625,26.75,7.1875,13.4375,15.125,35.5,28.75,-46.75,11.0625,-5.0625,-24.375,-37.5,32,48.25,-26.875,6.90625,17.875,-43,-36.25,16.875,44,-5,21.875,39.75,13.5625,-26.75]" +"[0.2776883,0.76384693,0.6033157,0.57663524,0.80829656,0.51963294,0.061357893,0.9892574,0.10903329,0.39156023,0.44352767,0.646225,0.3885194,0.085309155,0.8874541,0.40979385,0.2740713,0.8114262,0.93923444,0.6474502,0.636899,0.087418675,0.26908234,0.24798983,0.71043247,0.47945315,0.32372656,0.46957898,0.71219,0.5662497,0.6674871,0.8897923,0.53508556,0.84295803,0.13577196,0.10865966,0.69776434,0.6721364,0.6962641,0.5324952,0.5760644,0.58009857,0.38413116,0.013595484,0.21560541,0.38981703,0.9795545,0.3419762,0.6403787,0.35141543,0.43439904,0.6889035,0.49538517,0.3183865,0.9857907,0.08730436,0.9189867,0.96639824,0.5749706,0.3351115,0.3469733,0.052139003,0.7864675,0.8979334]","[26,39.75,-9.375,-29.875,28.875,37.5,-46.5,-24.75,-34.75,14.875,-1.0625,43.5,-6.34375,-16.875,-31.125,-20,-44,2.015625,49.75,-34.75,-43.25,45,-40.25,9.375,41.5,14.0625,-47.75,-25.75,28.75,17.125,-19.375,-33.5]" +"[0.73742,0.32429233,0.28739044,0.24434929,0.3305654,0.47866106,0.38894334,0.7362975,0.84787244,0.33854246,0.64093184,0.12267356,0.8034362,0.054841828,0.834797,0.023208361,0.60353905,0.5696299,0.50316447,0.4131633,0.85371816,0.5427871,0.3762515,0.5887305,0.12852405,0.6334801,0.6510773,0.4904203,0.43303955,0.73258525,0.41694534,0.600681,0.38430482,0.97997624,0.4420404,0.35985997,0.669555,0.44183737,0.48907793,0.6849643,0.8463721,0.90953165,0.6546561,0.90593064,0.039145768,0.42149463,0.86003697,0.40871084,0.6175964,0.5870248,0.53178686,0.9646074,0.1576742,0.29814163,0.26920342,0.57536423,0.42117313,0.36000443,0.696141,0.93731123,0.9456217,0.81985146,0.68752474,0.10288522]","[-34,0.87109375,-28,31.25,35.25,-6.78125,17.375,-34.25,20.25,47,49.75,-22.125,-19.375,-23.125,-5.4375,-11.25,19.125,22.75,-21.125,13.0625,-31.375,-1.2421875,29,-47.25,46.5,-2.140625,46.5,33.5,18.875,14.9375,34.75,-41]" +"[0.12283583,0.5765568,0.4710808,0.80130905,0.7013543,0.5609381,0.39565894,0.108266205,0.20630361,0.8900755,0.47676376,0.78557885,0.09483836,0.4274831,0.41043174,0.487021,0.54886013,0.7370356,0.20308536,0.07130826,0.16693589,0.4613492,0.1843092,0.093363136,0.55289155,0.45263028,0.85907596,0.44657633,0.8677902,0.52035093,0.8046169,0.8143056,0.8904713,0.85190594,0.9247962,0.6825233,0.6591082,0.4439609,0.63478744,0.64375347,0.3079051,0.4285464,0.12908779,0.94480795,0.28516328,0.025982482,0.07372007,0.9819173,0.8081707,0.4688989,0.41114932,0.36009252,0.024645925,0.1101116,0.4049289,0.9154718,0.30008417,0.85279346,0.9886045,0.18490273,0.04001315,0.9186626,0.93501365,0.9699308]","[-42.75,43.5,1.8203125,37,-40.25,27.875,-19,-25.875,19.625,-31.25,15.0625,47.75,35.25,-36,-22.75,32.75,48,19,-29.875,20.25,35.5,4.0625,39,-42.75,16.5,-5.0625,-9.875,40.5,-32.5,-42.25,-17.75,-9.6875]" +"[0.028762847,0.27941975,0.9303923,0.48994824,0.16262482,0.965337,0.75888616,0.41579303,0.946159,0.6927015,0.42436635,0.30774236,0.58954597,0.4264208,0.020558547,0.23737668,0.4797884,0.7815975,0.1375301,0.59153605,0.10429795,0.10555707,0.20188151,0.16100089,0.8811752,0.7890196,0.094324075,0.42230934,0.34703103,0.24597102,0.92543566,0.2185595,0.1832668,0.92213744,0.043143243,0.99063545,0.05677775,0.024382412,0.50745106,0.8191295,0.15554933,0.3707692,0.12693414,0.046883866,0.8650896,0.12422891,0.47226447,0.77416676,0.14436167,0.48928073,0.90836525,0.24012963,0.13380761,0.2832563,0.66133016,0.8357506,0.63579977,0.40035775,0.11588304,0.2965724,0.8361574,0.58428454,0.80087245,0.47395378]","[-23.5,44.75,43.5,47.75,-33,-21.25,2.03125,-25.5,21,11.625,-6.53125,-24,43.75,31.625,-13.75,-38.25,20.125,-35.25,9.0625,15.375,-46.75,6.90625,17.125,-4.96875,19.5,-13.6875,15.25,9.625,5.21875,-7.03125,-16.75,-10.0625]" +"[0.75828224,0.6360404,0.6396807,0.8221486,0.33213413,0.71022356,0.9826681,0.46865833,0.66436785,0.6874459,0.49858198,0.434016,0.0066902665,0.2301574,0.12259166,0.663611,0.32753542,0.5215848,0.40319008,0.091050446,0.059901286,0.55576855,0.9020771,0.50357825,0.26219392,0.056261666,0.073794946,0.49397773,0.9416539,0.99436116,0.63702667,0.16611513,0.09628895,0.50511557,0.20184012,0.31643343,0.18651623,0.05014567,0.87938935,0.8269504,0.22726005,0.23767692,0.12181462,0.2548988,0.95967126,0.6502879,0.7600026,0.5761278,0.8294272,0.16758616,0.985463,0.5164624,0.76728386,0.7526306,0.32990912,0.21093106,0.903986,0.70921594,0.25244772,0.14884502,0.6317563,0.38768008,0.9358642,0.47929788]","[18,8.375,5.09375,-44.25,22.875,-21.625,-3.953125,37.25,23.875,38.25,31.375,19.375,10.1875,-26,9.1875,47.25,4.65625,11.875,17.875,-34,45.75,-2.671875,-40.5,-26.25,34.75,-41,42.75,-25.625,-36.5,-44.5,19.375,-1.8671875]" +"[0.6211244,0.5705775,0.88791484,0.18245818,0.09596547,0.74524736,0.6013545,0.5735573,0.15821491,0.53634727,0.53039634,0.99963856,0.2669489,0.8582399,0.36571768,0.3822805,0.27181917,0.8714566,0.84658974,0.14115678,0.82673013,0.75578904,0.20929545,0.39020976,0.99781275,0.7300232,0.54126567,0.3541417,0.9153565,0.23365292,0.6043925,0.47538623,0.8530119,0.05719497,0.7470376,0.17420568,0.058357146,0.47356153,0.25266516,0.7313314,0.9423595,0.82565004,0.18538533,0.6867203,0.62170184,0.06975726,0.28044504,0.81389374,0.6609742,0.544265,0.77674866,0.8149686,0.07410577,0.9296572,0.49229655,0.024514182,0.29650778,0.99735266,0.97337115,0.5008498,0.7505369,0.04490735,0.48370942,0.21063031]","[-44.75,29.75,-25.75,-4.625,-10.6875,2.5625,-33.75,20.875,3.9375,-36,-10.125,49,19.25,-31.375,-47.75,27.625,-19.75,-40.75,12.125,-14.875,-12.125,-24.25,-47.75,46.25,-40.25,8.3125,-18.75,-40.5,-42,-22.875,-8.125,21.25]" +"[0.569393,0.39842245,0.8942473,0.73866874,0.9226515,0.39548418,0.5742803,0.7604963,0.8656194,0.26495025,0.99367034,0.4640038,0.30375698,0.16850446,0.18695499,0.15006012,0.48521426,0.34252387,0.8646098,0.8914876,0.15668154,0.124970466,0.11673733,0.34939864,0.07703897,0.6997089,0.40332606,0.41685033,0.35367563,0.0068761674,0.11804945,0.62437594,0.36739963,0.14212708,0.00053609576,0.648054,0.27888206,0.29385093,0.05058863,0.30484825,0.49351913,0.10984526,0.091909476,0.12092972,0.023253923,0.3013809,0.73646146,0.32846656,0.7955981,0.24448453,0.70034164,0.7386655,0.36937568,0.03367012,0.35761696,0.62446314,0.75031495,0.313681,0.010776882,0.66394067,0.10428341,0.03507068,0.05224171,0.6226092]","[27.375,45.75,45,-2.75,28,-0.22167969,41.75,42.25,-3.625,49.5,-45.5,43.5,25.875,20,6,12,-35.25,28.375,-34.75,-41.25,11.6875,28.5,-33,-12.25,-5.03125,1.3203125,-29.875,44.75,38.5,-5.40625,23.625,-28.625]" +"[0.09182283,0.051410355,0.4750939,0.81628114,0.30347037,0.99693286,0.29459754,0.5573521,0.52623814,0.30696124,0.54542285,0.8142954,0.7441471,0.67631066,0.50009286,0.27428457,0.32501298,0.66093683,0.50093406,0.86541677,0.7803987,0.89975023,0.8360166,0.82769996,0.25328812,0.27686656,0.9047943,0.71790886,0.9898632,0.1642593,0.91347104,0.48457193,0.97333884,0.0805903,0.41340074,0.10077296,0.95255524,0.29462913,0.18480201,0.13791032,0.017938409,0.91861653,0.3038616,0.0026358513,0.35139292,0.87712544,0.18181235,0.2515791,0.9204611,0.97031623,0.8209888,0.16220012,0.53959966,0.05963805,0.5987683,0.85977507,0.14232607,0.456454,0.45097867,0.7314165,0.12813824,0.97759485,0.23871897,0.42167157]","[-1.9375,11.5625,13.75,-3,44.75,11.375,2.0625,-49.25,0.859375,-9.125,-22.125,13.5625,-1.1015625,26.375,12.0625,-44.25,48.25,-8.875,1.7109375,-28.625,26.5,-8.6875,-3.5,-27.375,22.5,-1.7265625,-39.25,-11.75,5.53125,20,-38,30.125]" +"[0.20111826,0.20889272,0.12222279,0.76202977,0.018384872,0.24230948,0.34587637,0.52689403,0.66951734,0.1496474,0.3116213,0.12640415,0.9228701,0.6887756,0.47808143,0.9744557,0.42782384,0.14779454,0.29326874,0.4091614,0.9753717,0.3667738,0.8955053,0.31327233,0.36053348,0.3075239,0.26726994,0.16763276,0.09859781,0.23636293,0.6144414,0.45849714,0.030117346,0.033925407,0.4223073,0.7784983,0.07586549,0.47580862,0.16691828,0.31334838,0.9568735,0.15787178,0.7469526,0.41239074,0.7959145,0.8359251,0.060103722,0.7655388,0.7992088,0.000079807316,0.46803132,0.34542906,0.6481989,0.36634463,0.5472488,0.6414198,0.49911073,0.30512,0.0409139,0.1050434,0.96140176,0.97850037,0.93475854,0.19143914]","[28.25,-31,-2.265625,-41.25,-37,-17.75,7.9375,39.5,0.068359375,44.5,-8.75,-46.5,11.875,-38.75,31.375,43.5,0.859375,-47.5,-34.75,-8.875,-34,-3.390625,13.375,8.875,-16.375,20,19,-37.5,-14.625,-5.34375,18.125,-21.875]" +"[0.08775939,0.4283646,0.7101789,0.27748132,0.52810293,0.5816647,0.083301455,0.5511972,0.54855996,0.49592072,0.31549463,0.7146988,0.23766331,0.8163928,0.86329293,0.99798346,0.61779463,0.0008762518,0.635903,0.30710483,0.48023742,0.4067054,0.1027289,0.9947169,0.47321212,0.28408945,0.78242576,0.13549061,0.97861296,0.051200286,0.6165857,0.643406,0.14612742,0.8751349,0.44809186,0.6548863,0.66078967,0.88808805,0.74504644,0.31832874,0.78177,0.44134045,0.3762482,0.9297851,0.43945086,0.8028106,0.64344674,0.8784638,0.28681245,0.7922464,0.70464516,0.3839366,0.26162437,0.3274395,0.72155136,0.96309763,0.21078455,0.26608607,0.29522902,0.8975753,0.25297,0.28918892,0.9595496,0.8155306]","[27.375,8.4375,10.125,-34.75,0.40039062,-2.453125,-31,21.625,36.25,-30.75,16.25,40.25,-26,-45.25,14.4375,-8.125,15.8125,-7,42.25,-17.5,0.4140625,25.125,-27.75,-9.375,-28.625,10.25,-45.75,39.75,-27.125,42.5,-39.75,44.25]" +"[0.65685177,0.7967462,0.65292466,0.47451296,0.487105,0.7703699,0.46215242,0.068360925,0.60461277,0.6806389,0.010948174,0.18897659,0.8906668,0.7300914,0.38688356,0.12408817,0.56204575,0.0037919874,0.08732596,0.38963246,0.057055213,0.90844226,0.48278856,0.493267,0.72689456,0.44059002,0.6000618,0.34064367,0.5161428,0.09022448,0.066437885,0.924375,0.47435242,0.7726047,0.5868732,0.19517516,0.37014866,0.54562485,0.8612679,0.9646098,0.6879411,0.7179708,0.82238245,0.20676227,0.47169217,0.18847263,0.030084528,0.7215885,0.1940058,0.8705641,0.5552904,0.85425425,0.19084111,0.65513355,0.8825815,0.17911267,0.9383283,0.1445964,0.60026556,0.524949,0.85351497,0.44019926,0.9020619,0.12076631]","[-1.734375,0.041015625,-43,28,-9.1875,-16.875,13.0625,25.875,18.875,22,-33,25.75,-31.75,31.25,26.25,48,-22.25,-41.5,10,-1.7890625,-45.25,-22.375,31.25,-26.75,-0.6875,17.625,17.5,-14.9375,-27.625,33,-35.75,-47.75]" +"[0.30844283,0.2376385,0.6043445,0.36989665,0.1805029,0.8584536,0.7186344,0.2039891,0.53399473,0.40497106,0.21961164,0.049922653,0.08543531,0.96432036,0.44378152,0.66983813,0.20963399,0.62360966,0.016017769,0.6327681,0.114422776,0.5726738,0.57229704,0.71577066,0.91735655,0.22237916,0.2442725,0.49104455,0.63414687,0.43167186,0.7791959,0.62292874,0.85084134,0.7960938,0.46224585,0.2022884,0.4263549,0.17605765,0.00801641,0.042320196,0.71777546,0.7300519,0.0624454,0.9996326,0.14539194,0.40029496,0.65128034,0.46233115,0.2216075,0.17642419,0.15189856,0.58033663,0.56212217,0.13686444,0.38799226,0.73769355,0.5905406,0.8770144,0.36519283,0.17165183,0.5229868,0.15600987,0.691431,0.07228361]","[10.9375,-13.3125,-28.625,35.25,-43,-23.25,29,-10.6875,-32,-33,-22.25,-28,28,49.5,41.5,4.40625,10.1875,-28.5,45,44.25,-32.5,-24.125,-39,2.984375,-0.91796875,-15.3125,15.4375,5.03125,-24.25,-12.0625,-16,-10.25]" +"[0.10348506,0.84525734,0.6528396,0.480097,0.60616106,0.17438708,0.7033915,0.9066734,0.28832147,0.27141386,0.40126196,0.7361419,0.75739896,0.20185831,0.9595122,0.046889644,0.89057046,0.6122676,0.5689852,0.14686872,0.87214136,0.42331377,0.15778129,0.6459605,0.37968746,0.65812176,0.33455014,0.35163447,0.04506678,0.85788375,0.6587064,0.5068443,0.25387546,0.35821617,0.63774276,0.45589358,0.37449834,0.7342579,0.78256685,0.8416643,0.0059738536,0.78489983,0.61526626,0.8568159,0.59405357,0.11915635,0.47373962,0.09422982,0.24009466,0.16764745,0.62546146,0.52660525,0.8840554,0.277747,0.6368095,0.048093513,0.102367945,0.05119757,0.5801811,0.09398359,0.6583618,0.72135013,0.05448462,0.24337053]","[18.625,27.75,-46,-26,-9.0625,-39.75,24.5,-39,-18.875,47,35,-44,4.3125,34.25,47.25,-37,-41.75,-3.390625,23.5,32,-15.5625,-5.21875,45.5,-4.0625,-46,46.5,-20.25,-25.75,-22.625,24.375,-49,24.25]" +"[0.68767625,0.8423521,0.99071527,0.52480906,0.36981148,0.15564997,0.18547417,0.7027981,0.012189027,0.62604487,0.35200384,0.9060035,0.2292723,0.43366623,0.7526672,0.07912019,0.68071985,0.9961246,0.6684942,0.8439865,0.5607376,0.18943308,0.41741526,0.7191012,0.9515549,0.66444296,0.7924931,0.15165201,0.2989833,0.038535733,0.2903466,0.6215752,0.63402385,0.25747532,0.82302487,0.9680371,0.01732841,0.4629055,0.8753637,0.76709676,0.68216276,0.9717941,0.71810544,0.789116,0.36564803,0.101204626,0.71481127,0.94412106,0.16499074,0.5493175,0.96618533,0.50799316,0.21065487,0.5628668,0.39166626,0.00724035,0.3745904,0.85556495,0.9353182,0.31790212,0.92414623,0.07647752,0.9689257,0.7397357]","[20.5,35.5,-41,27.5,-22.125,-11.5625,28.875,20,-22.875,47.25,-43,-17.625,-37.25,-16.375,-28.75,5.5,11.125,44.25,-15.0625,-22.5,32,18,-24,-35.5,28.25,5.6875,-28.875,40.5,42.75,-41.5,0.99609375,-9.875]" +"[0.38357934,0.4886526,0.10867981,0.89116144,0.4340823,0.1410137,0.15438984,0.9488114,0.20077457,0.3325992,0.5209849,0.25490028,0.54786325,0.012972608,0.86531675,0.7889768,0.98311675,0.64231473,0.31320858,0.42020848,0.22714357,0.81701416,0.98130095,0.36613837,0.77757686,0.8570605,0.8294839,0.6427045,0.5766567,0.826531,0.20938928,0.008007914,0.6946657,0.4499606,0.18625017,0.18329144,0.13487984,0.65840966,0.48199955,0.6410035,0.029614242,0.25729093,0.4402286,0.86701065,0.19888356,0.8818605,0.47250497,0.33825704,0.7958316,0.3209422,0.91376144,0.4136033,0.9509642,0.5794441,0.93583465,0.85908073,0.694633,0.22920674,0.0721125,0.73773897,0.44041517,0.07608467,0.6638589,0.88309646]","[-11.625,-16.5,-8.6875,-30.875,-29.125,35.25,-39,-21.75,-16.75,-29.75,37.5,-38.5,43.5,33.75,-48,-26.875,2.375,0.87109375,28,-37,-36.25,13.375,18.5,12.75,-6.59375,-17.625,11.9375,-27.875,44.25,-5.21875,-15.5,-21.375]" +"[0.7787835,0.94104344,0.044769764,0.6136475,0.32781577,0.4435063,0.38646492,0.824941,0.004762718,0.123713665,0.8313167,0.22196738,0.5947063,0.13396005,0.25409296,0.56303614,0.6650313,0.08519147,0.05260708,0.6784503,0.29955387,0.67279947,0.88296777,0.015142175,0.2013418,0.50736594,0.90582085,0.97014856,0.09483,0.5691447,0.17495069,0.01317448,0.06826056,0.103881285,0.3622784,0.9386693,0.028252285,0.6887031,0.3331701,0.43791652,0.9807209,0.9110269,0.68638295,0.5480295,0.659549,0.82110184,0.581732,0.26441014,0.9654526,0.7154511,0.6875814,0.6189274,0.32725886,0.5430922,0.5254563,0.08505539,0.7420291,0.121101566,0.1469022,0.416121,0.006508772,0.26344138,0.024670865,0.018679949]","[1.21875,-40.25,-11.875,-15.75,17.625,37.75,15.9375,32.25,-32.5,6.25,-25.25,34.25,-40.75,6.0625,-2.8125,40.25,1.5859375,21,-17.375,9.5,-12.875,-36,-35.5,-25.125,19.875,22.375,-19.75,-36.5,-16.625,23.25,41.25,-42.75]" +"[0.6044582,0.2221436,0.8244782,0.43078062,0.8741876,0.6127108,0.4417127,0.8815114,0.8475388,0.68245006,0.9979441,0.38844675,0.4730327,0.2594483,0.48447645,0.4870291,0.31676814,0.8038267,0.5839229,0.022215264,0.5137671,0.963778,0.7988502,0.45370644,0.22035438,0.29909837,0.93535453,0.5055454,0.77121264,0.8096407,0.8244675,0.051335037,0.0983,0.36566436,0.42854875,0.8724556,0.14380156,0.1667389,0.9806659,0.68401945,0.95292175,0.9251103,0.47241718,0.07869726,0.027945135,0.5451597,0.13216831,0.9837194,0.16778111,0.7548095,0.22363296,0.41814148,0.35564378,0.21051493,0.56195784,0.03585494,0.11853085,0.9107681,0.5028087,0.6051295,0.021075204,0.5075246,0.6037283,0.44707844]","[-14.5,24.75,-15.0625,-2.9375,37.75,11.0625,11.6875,27.875,48.75,33.25,5.4375,-23.625,36,-23.625,15.25,-49.5,-13.1875,-36,42.75,39.5,24.5,10.6875,-28,-33.25,9.75,12.1875,21.5,26.75,-6.03125,34,41,1.0234375]" +"[0.17482011,0.65349543,0.2684204,0.5780167,0.8212344,0.06885737,0.41565734,0.6547479,0.96671003,0.40622953,0.05383342,0.93157405,0.97110903,0.84017414,0.9729293,0.9749458,0.2136868,0.508665,0.0045522065,0.53031486,0.5844471,0.96857977,0.0154250525,0.32780024,0.15925212,0.4631677,0.35746136,0.4801421,0.8835984,0.46799126,0.8553378,0.9537854,0.2880129,0.80294263,0.7581544,0.6868791,0.08629599,0.90661395,0.71632713,0.08693256,0.8687486,0.26317623,0.7908471,0.7153632,0.84042764,0.77706474,0.012991439,0.71817046,0.7693697,0.9272926,0.6666367,0.7983966,0.33481094,0.9128337,0.7761778,0.23589721,0.0746207,0.94943273,0.13942686,0.81670326,0.025478976,0.9800894,0.5597018,0.74492866]","[46.75,38.25,-47.25,-40.75,33,48,23.5,14.5,38.5,-33.5,-9.875,-48.75,45.25,12.25,1.59375,-3.953125,25.75,36,-24.75,33,-49.5,46.75,33.75,10.0625,-4.25,-20.25,8.3125,-5.03125,8.875,3.828125,-29.375,-37.25]" +"[0.9780465,0.58729804,0.3278158,0.042050805,0.9838018,0.37757313,0.87621516,0.34853974,0.16511214,0.12154298,0.2679557,0.73123264,0.15382725,0.98424995,0.84201634,0.76813453,0.73981553,0.85161066,0.83408165,0.7568787,0.25750604,0.98133105,0.7824335,0.65350056,0.2539314,0.24168846,0.43764257,0.48238662,0.23340066,0.48262176,0.20441175,0.9530761,0.21734138,0.69329566,0.91979605,0.8413115,0.0018731888,0.31044504,0.3682113,0.52986085,0.8620591,0.09307148,0.5717592,0.067147255,0.4590973,0.4399496,0.82451445,0.82718396,0.008884165,0.33056867,0.7570654,0.66648763,0.5899968,0.23760875,0.6531266,0.9552117,0.92509294,0.81204003,0.39278153,0.41884157,0.9182109,0.8154692,0.52526647,0.6186324]","[-15.0625,21.125,-14.375,-39.25,-36,42.25,2.03125,29.25,-45.75,36.5,-3.984375,32.75,43,33.75,-12.4375,-14.25,-43.25,-19.625,-1.6171875,-20,-15.0625,-41.25,-10.0625,26.75,-7.0625,13.0625,-32.75,38.75,15.75,31.75,-45.5,2.484375]" +"[0.21339191,0.24392346,0.9758285,0.57455117,0.30169132,0.69601065,0.89777285,0.71760464,0.30042115,0.070881225,0.15899178,0.51156336,0.5405496,0.08386194,0.9545485,0.9506713,0.6753428,0.48342866,0.32498002,0.30639413,0.941087,0.04936715,0.40660393,0.5972495,0.09102706,0.29999173,0.021288969,0.08428669,0.5111563,0.5542559,0.94949067,0.9109447,0.35978228,0.31795597,0.5597044,0.53971213,0.44882017,0.7617063,0.7411604,0.48758054,0.6957811,0.21228997,0.6963425,0.7964876,0.70024,0.48171353,0.6932329,0.7369964,0.016966468,0.15558653,0.49351373,0.4193336,0.8471115,0.51104087,0.18197007,0.060064647,0.87850654,0.58078265,0.25167057,0.20252575,0.638254,0.7259869,0.74547684,0.056084413]","[37.75,18.125,-21.5,-11.0625,-14.0625,-42,2.703125,46.25,38,48,11.25,-38.75,18,-8.75,-36.75,-30,4.1875,10.6875,1.890625,-22.125,30.5,-33.25,36,20.75,-46.5,-29.875,-8.875,-43.5,39,-41.25,-33.75,-42.5]" +"[0.037014827,0.5523258,0.91062623,0.057730082,0.16455226,0.18852681,0.507702,0.2133974,0.8030262,0.5644116,0.32786384,0.61859435,0.60459363,0.0365933,0.9850299,0.21867667,0.889244,0.15974861,0.076397836,0.015319321,0.085914135,0.75676906,0.79182345,0.38004103,0.026107788,0.4478044,0.2073991,0.8514591,0.828646,0.37509462,0.3802146,0.7929193,0.7246676,0.92111266,0.17372335,0.7644258,0.8806689,0.23240152,0.16776711,0.33284494,0.8586775,0.43996602,0.34902102,0.020789832,0.46986574,0.21499416,0.47947884,0.034101482,0.6749447,0.11431777,0.99843246,0.5429715,0.4451294,0.7160986,0.8825096,0.8980224,0.9063986,0.19719426,0.41615483,0.10656404,0.5103691,0.807141,0.16808839,0.98300964]","[-44.5,32,-47,30.375,-12.3125,34.75,-8.6875,31.125,0.19726562,-1,12.4375,46,31.75,20.25,26.5,-46.75,-37.25,47.5,-9.0625,-27.625,22.625,-30,-37.25,21.125,8.6875,-22.25,30.75,3.984375,20.75,-10.75,43.25,-45.25]" +"[0.77981323,0.630027,0.95709795,0.6499879,0.5941991,0.3636602,0.25283512,0.27973333,0.7659068,0.18097624,0.9104007,0.64820063,0.005424442,0.67235553,0.9698558,0.8253358,0.6235026,0.3267187,0.23383205,0.83054256,0.7148811,0.20922664,0.8065509,0.0061979443,0.5317623,0.33190286,0.57788134,0.5768202,0.0875839,0.66254,0.9124577,0.07641434,0.8202031,0.86652637,0.988762,0.61071324,0.70470196,0.2878386,0.87525314,0.30374652,0.59921414,0.5605141,0.19930963,0.11486036,0.6820004,0.84311056,0.5148809,0.74590826,0.56605303,0.85699815,0.94981134,0.63029575,0.110192895,0.24407728,0.55257446,0.09601457,0.74505436,0.20329873,0.6148107,0.8359139,0.57324696,0.49913403,0.283909,0.2668669]","[-43.5,9.875,-16.25,33,10.0625,15.25,18.875,15.1875,14.5,18.875,44.25,-34.75,-12.0625,4.5,7.25,48.75,-6.6875,40.5,5.90625,44.25,-18.25,-33,-4.53125,-4.53125,-34.75,17.125,37.75,-25.75,-10,-5.25,23.75,-2.328125]" +"[0.07638663,0.4071125,0.38318616,0.041135047,0.5326544,0.11737779,0.754498,0.7821517,0.020797037,0.689887,0.8062486,0.73348045,0.9358596,0.49921858,0.07431924,0.79979646,0.9125761,0.60350794,0.113903314,0.21187115,0.3197978,0.6206113,0.42566666,0.9785831,0.39973733,0.74529326,0.21552657,0.92631745,0.4525828,0.20831187,0.22762047,0.5296926,0.6104866,0.73053074,0.37641972,0.20389311,0.9125287,0.44298023,0.6841292,0.79462254,0.27954543,0.6059353,0.14769197,0.6669149,0.9160528,0.98606783,0.56174195,0.8851316,0.94920075,0.88583565,0.53728217,0.48053363,0.030744579,0.41928843,0.029546218,0.3197662,0.19430386,0.6545522,0.2447235,0.8707425,0.10568299,0.7494439,0.061524794,0.4585383]","[0.27539062,4.8125,42.25,1.828125,6.15625,-15.75,42.5,46.75,25.875,-28.125,31.625,-35,22.125,-20.75,-29.875,-28.75,4.625,47.25,48.75,-5.625,25.875,37.75,-19.5,30.375,14.375,48.25,29.75,-7.09375,4.28125,-23.125,-26.25,20]" +"[0.08465924,0.831909,0.29860583,0.77439386,0.12939312,0.46536055,0.004705534,0.33528936,0.92700577,0.6431984,0.60115606,0.7584295,0.52004623,0.63302225,0.7595903,0.6902572,0.1679499,0.17957723,0.7519166,0.18648338,0.13741796,0.6933576,0.703251,0.27236328,0.5731696,0.2357393,0.38878337,0.083138004,0.5880409,0.5094753,0.82359767,0.33812782,0.43932393,0.7840226,0.37459007,0.75906235,0.4474078,0.095476866,0.9981786,0.6073785,0.9298487,0.6120119,0.554892,0.5691522,0.0972593,0.37647304,0.34323266,0.9326074,0.55325943,0.67299086,0.7381645,0.786848,0.35672626,0.4301211,0.12784468,0.51873726,0.344641,0.52526504,0.8549945,0.2729992,0.6230186,0.9096293,0.48972145,0.38789856]","[31.375,-42.25,6.4375,0.89453125,-8.8125,9.5,0.6796875,-7.4375,1.2109375,-25.125,-48,-27.75,-3.90625,3.484375,-7.875,39,40.5,-30.875,-24.375,-15.875,31.5,27,-38.25,0.9609375,41.25,-39.5,30.625,-11.9375,39.5,28.375,-45.75,2.34375]" +"[0.18695702,0.20321664,0.33887795,0.6283936,0.07774327,0.32911107,0.15204431,0.21158431,0.31735557,0.31873515,0.4477933,0.45055413,0.08438623,0.110758945,0.06424395,0.5413084,0.37702662,0.9507763,0.9659291,0.86159045,0.6371742,0.10038689,0.047607508,0.20233499,0.44260412,0.8751387,0.30215055,0.768279,0.694679,0.26845253,0.9196897,0.7638134,0.15972008,0.9340138,0.77339613,0.4042136,0.45882562,0.4723791,0.58171004,0.79658616,0.50375473,0.8574245,0.66977173,0.80210537,0.98541915,0.082738966,0.93813074,0.045245904,0.8781107,0.77727467,0.59956294,0.47327724,0.43722525,0.76363665,0.24754371,0.36910892,0.84021086,0.76449835,0.4101146,0.44385102,0.5899346,0.64481646,0.22816864,0.5477394]","[20.125,25.75,-33.5,21.75,-37.75,3.265625,34.5,18.375,-11.375,-40.25,21.5,49.25,-18,-14.4375,1.0078125,-28.375,-33.5,47.5,-40,22.75,22.75,39.75,7.40625,21.25,-13.625,-19.75,42.5,13.3125,3.359375,-22,47.5,-7.3125]" +"[0.13798277,0.0372231,0.05298706,0.026684755,0.23167461,0.77829945,0.15401512,0.86323047,0.80904937,0.59278154,0.74522376,0.075703844,0.9276659,0.092101105,0.07155116,0.13354099,0.69846076,0.46739465,0.24895437,0.2843568,0.19308007,0.11965543,0.44871557,0.9948642,0.4008349,0.912809,0.5970973,0.91690946,0.911642,0.030095307,0.69103545,0.574314,0.047479384,0.44798082,0.7574993,0.10801962,0.44325334,0.15659383,0.09073802,0.65408975,0.68864805,0.5297064,0.7203496,0.050914075,0.8362685,0.57206035,0.14956911,0.22922587,0.88024104,0.40412602,0.8887417,0.50252914,0.57449126,0.50355214,0.7415451,0.09560751,0.6028449,0.53456867,0.066059455,0.9705223,0.92450106,0.5064679,0.8944456,0.61318094]","[46,-18,11.0625,20.875,-10.5625,16.25,3.015625,18.25,-33.5,14.125,5.9375,-2.5,-3.171875,49.75,-3.78125,-44,-20.375,-38,47,14.375,37.5,-49.75,-14,-31.5,-34,-41.25,-38.5,-21.25,-4.1875,19.125,33.5,49.5]" +"[0.11157264,0.9946018,0.72945374,0.09361291,0.7970346,0.090858795,0.9280967,0.5054962,0.021124847,0.21747154,0.28199598,0.6427558,0.3810736,0.70541525,0.48285344,0.4516901,0.021676429,0.3000196,0.825254,0.7388299,0.25164998,0.09461225,0.15323272,0.8730289,0.6929198,0.5236057,0.29501647,0.82732385,0.24100505,0.5395879,0.94629705,0.24913935,0.45329186,0.18099648,0.1815246,0.9351377,0.28072852,0.73545516,0.2753592,0.3923767,0.38481265,0.45357075,0.6768673,0.18663558,0.7664916,0.42551208,0.18325764,0.44130725,0.038357615,0.6150388,0.26084563,0.9608668,0.17247286,0.9279537,0.77078044,0.8433813,0.25779024,0.6370068,0.08607735,0.03129033,0.13490616,0.7713906,0.93985325,0.84975487]","[-42.25,-10.375,-16.875,-29.875,-5.59375,2.5,47.5,-15.3125,-49,23.5,43.25,-42.5,-28.625,-28.875,9.5,-31,3.765625,36.5,42.25,-37.75,1.8515625,10.4375,-35,-25.375,-22.375,-35.25,-25.125,-48.25,3.0625,-45,14,-34]" +"[0.68807423,0.70735514,0.57271475,0.6235782,0.38714758,0.7470717,0.506221,0.8982948,0.5829424,0.985151,0.36991543,0.08515112,0.64780724,0.11867443,0.46761435,0.83089453,0.3858309,0.7512959,0.6303056,0.6334168,0.68722755,0.905571,0.70125777,0.079326235,0.2847221,0.06643265,0.45990163,0.626635,0.73851895,0.07974799,0.37795088,0.7376368,0.27755523,0.4957657,0.22162803,0.73571837,0.5640565,0.013633132,0.04189734,0.86836314,0.39390627,0.84112525,0.96697193,0.5426106,0.06738794,0.4300572,0.27760983,0.56341314,0.1897385,0.27340555,0.54090136,0.6320961,0.7403934,0.22984135,0.7489774,0.25211,0.849067,0.36749125,0.094398536,0.78829265,0.051773958,0.30167103,0.3295492,0.560574]","[4.65625,4.25,-11.125,11.125,12.0625,42.75,48.25,39.75,21.375,34,16.375,28.875,49.75,-2.734375,25.375,5.3125,4.78125,-47,-40.5,-5.5625,35.25,49.25,16.75,36.25,16.5,7.25,-39.25,46.5,5.78125,-13.75,19.25,40.5]" +"[0.62590307,0.4730555,0.5143024,0.7400377,0.09729304,0.72493756,0.959982,0.98990375,0.6118087,0.9164002,0.5924123,0.31409177,0.7129488,0.44753307,0.7368132,0.49860564,0.71846724,0.9440224,0.86970425,0.9288748,0.8660023,0.7308698,0.28432277,0.07713722,0.023624336,0.71013707,0.7375767,0.36600426,0.26602337,0.6096527,0.72939134,0.27763587,0.7852319,0.35285512,0.52532744,0.2676204,0.5576011,0.53494704,0.8179915,0.34802863,0.27321622,0.60159594,0.38670206,0.8427001,0.85214096,0.6492275,0.21912386,0.5950326,0.24724205,0.4847001,0.24040791,0.71448314,0.45358077,0.8654295,0.06962857,0.67273706,0.096577905,0.52504367,0.9417112,0.18092807,0.35636124,0.9349098,0.9936837,0.29791304]","[28.375,-35.5,25.75,-47.5,25.375,49.5,38.25,22.375,39.75,19.625,-39.5,14.9375,-38.75,3.59375,0.4453125,31.875,0.43554688,47.5,-35.25,3.1875,5.625,9.75,-24.5,12.5625,-8.5,4.34375,-11.0625,35,38.5,42,14.5,-25.125]" +"[0.3632019,0.4378152,0.3169868,0.0483831,0.23498353,0.17838562,0.25121716,0.9433248,0.5813989,0.5365534,0.5609859,0.11035459,0.9255645,0.28316745,0.38181284,0.2451351,0.7033259,0.6314965,0.4565567,0.9000986,0.53772557,0.4136447,0.8383641,0.03252166,0.44401312,0.06071992,0.79530734,0.38347772,0.80169076,0.6731427,0.14818552,0.108565986,0.6858668,0.609087,0.5251247,0.41350663,0.4728836,0.70078206,0.3330528,0.25174177,0.5592758,0.72869873,0.53140336,0.20169091,0.9535028,0.89667195,0.24877198,0.5802795,0.7340626,0.12387722,0.46330017,0.8434134,0.86478865,0.2350768,0.53663486,0.11684581,0.101894125,0.8960471,0.38116553,0.5489956,0.4260087,0.2164831,0.3649796,0.8742367]","[3.140625,-30.375,25.5,31.625,5.34375,-14.1875,45.75,31.5,-6.75,25.625,-46.5,49,-14.6875,-2.828125,-12.6875,-28.875,-36.75,16.375,-41.75,-11.6875,-39.25,-8.5625,38.25,-31.75,-17,-17.875,-46,-33,48,2.125,6.65625,-31.75]" +"[0.15033853,0.05396438,0.16855182,0.7694105,0.7349307,0.74225837,0.8363971,0.6002226,0.53557354,0.9518659,0.55535847,0.5359252,0.18551642,0.4039799,0.54056937,0.5693903,0.7274987,0.11000511,0.5375733,0.1745831,0.8097115,0.6795442,0.98888123,0.8344953,0.7026905,0.43727967,0.32403558,0.79236513,0.44989684,0.549162,0.6884249,0.26266664,0.08171709,0.97877437,0.95000744,0.41945317,0.10249012,0.50448513,0.37434557,0.9191395,0.054005098,0.60332054,0.17180634,0.3004409,0.49967936,0.2108608,0.3649237,0.56979966,0.57585806,0.6871239,0.011539041,0.89640576,0.14436433,0.087279454,0.7416531,0.8071215,0.7242795,0.962694,0.03039096,0.7644512,0.8491756,0.6789493,0.5019264,0.0034607633]","[-14.5,14.5625,26,12.8125,-28.875,-39,6.1875,13.3125,12.25,-7.3125,39,16,-26.125,-18.5,49,-15.875,19.125,-4.5,-0.7265625,-40.25,27.5,17,37,-8.375,-18.375,-8.5,26.75,-42.5,2.78125,-43.75,18.875,38.75]" +"[0.30783364,0.027119659,0.22575209,0.9655476,0.24870545,0.047725998,0.23170026,0.36999458,0.40389535,0.45709988,0.7518672,0.76807773,0.8744009,0.64978707,0.5172989,0.5059063,0.70675296,0.6378856,0.33765087,0.68290764,0.86765546,0.93972206,0.84308624,0.25127536,0.10159354,0.19775309,0.8210649,0.9431624,0.58428514,0.9317162,0.38554132,0.544001,0.23800705,0.76901704,0.792431,0.16296,0.75079453,0.44172555,0.6877227,0.7220548,0.7692132,0.09097071,0.7999131,0.39576125,0.12585361,0.8128382,0.87954444,0.29052696,0.34114474,0.39145854,0.70763683,0.5414258,0.35632965,0.9897232,0.9922162,0.44163465,0.6136564,0.6094328,0.7674427,0.41955474,0.7509225,0.2950084,0.95974976,0.88809645]","[48.75,8.375,-28.625,-10.1875,4.46875,0.5625,48.75,11.5,27.625,-0.48632812,-45.5,-15.8125,-22.625,1.75,-10.25,-18.125,-33.25,4.90625,39.5,40.75,45.5,-13.25,-44.5,4.46875,-10.8125,30.875,-1,-20.875,46.5,-3.140625,-22.125,-37.25]" +"[0.2939439,0.56615824,0.47729868,0.45343,0.07507634,0.42452255,0.024463905,0.028522853,0.8580452,0.99675894,0.034406126,0.010451373,0.7743605,0.6135159,0.18680263,0.27874994,0.44640964,0.16318525,0.95358914,0.5450469,0.15932609,0.12683927,0.044703726,0.15428582,0.64445597,0.8565322,0.78714275,0.6980953,0.06353565,0.7744736,0.90607136,0.82147247,0.33051464,0.01707307,0.7184163,0.99909735,0.39423534,0.87070787,0.0661592,0.21132855,0.7203356,0.6247804,0.46856666,0.25762296,0.9990265,0.025613688,0.29990986,0.89734125,0.45721307,0.5371485,0.5393385,0.6627454,0.96097803,0.26085204,0.80731034,0.39116108,0.58376795,0.6619996,0.6847339,0.97474295,0.3521754,0.6757386,0.98735535,0.65844774]","[24.625,49.25,46.5,3.296875,22.375,10.4375,-2.828125,-11.25,-1.640625,48,-7.40625,43,21.5,-39,-16,15.3125,-3.265625,-44.75,-46.5,48.5,-10.0625,-11.9375,17.5,13.0625,-25.75,9.6875,-49.5,14.5625,-42,32.75,25.5,39.25]" +"[0.3790552,0.62183213,0.24376243,0.6878157,0.80996,0.45175934,0.47280803,0.9994772,0.284749,0.6514699,0.09419588,0.038970467,0.5574011,0.6995939,0.86751723,0.5469431,0.9709039,0.10136634,0.2246632,0.673713,0.4785042,0.3628282,0.6971229,0.59585816,0.46858987,0.43639335,0.8095526,0.18400455,0.019983867,0.415286,0.67106605,0.5687699,0.44835174,0.042203866,0.2598901,0.53429997,0.22920968,0.6897699,0.625229,0.15571968,0.35125682,0.8918064,0.51127404,0.87969357,0.49423668,0.86593467,0.21445112,0.5252121,0.05934228,0.65179586,0.47067744,0.16229892,0.51389354,0.5204911,0.90311706,0.77565694,0.12688044,0.86142635,0.49697775,0.2260824,0.47014344,0.87319255,0.6604853,0.40849206]","[4.9375,7.625,-33.25,-19.125,8.125,33.5,-31.75,40.5,41.25,-25.875,-8.5,36.25,-2.8125,5.3125,0.99609375,-0.029785156,43.5,24.125,-5.25,24.625,-15.625,-42,-20.875,46.25,-49.25,28.125,36.25,0.19335938,42.25,31.25,-21.375,47.25]" +"[0.5142933,0.50745875,0.52809083,0.92212576,0.3157925,0.44649866,0.031662975,0.04038959,0.9742703,0.7716659,0.6981525,0.3665847,0.63173455,0.36413944,0.261729,0.24309033,0.6515114,0.7499015,0.5272416,0.6057771,0.53304714,0.9824744,0.111367255,0.676608,0.3647209,0.9456881,0.3957169,0.14529304,0.18074162,0.41368505,0.9517193,0.67855215,0.6066134,0.78048575,0.13668987,0.7692479,0.9528826,0.96372664,0.5427747,0.79793054,0.42727688,0.4479142,0.5129835,0.25170144,0.88446623,0.521448,0.68270296,0.38688564,0.7300613,0.33067146,0.26313114,0.1430875,0.5391086,0.5512057,0.49934936,0.77518046,0.8319485,0.65110236,0.52023,0.08344835,0.33053622,0.19071482,0.7851748,0.41240305]","[-34.5,17.625,-3.78125,14.75,2.359375,3.625,32.25,3.25,24.75,-9.375,43,-29.5,34.5,42.75,9.4375,-14.8125,20.625,-9.8125,49,20,-16,8.875,27.25,17.5,-42.75,-18.875,36.75,-23.25,30.5,-37.25,-21.75,45]" +"[0.017780483,0.33335733,0.79514354,0.45479238,0.052999567,0.23510236,0.7413692,0.43030113,0.33682796,0.44462916,0.013608088,0.86665946,0.33651152,0.9987447,0.9081752,0.38216743,0.40758678,0.1965753,0.52964884,0.8002433,0.46909976,0.9902505,0.14333351,0.83454514,0.90456325,0.46995482,0.42762217,0.67636824,0.27454564,0.7688465,0.26296797,0.62887156,0.500508,0.4362067,0.7314985,0.1346855,0.77376646,0.79575217,0.44521824,0.8642111,0.4687469,0.38358954,0.84050894,0.20213847,0.64857763,0.06713859,0.38340634,0.40721777,0.84402055,0.06326107,0.507847,0.04408097,0.25757223,0.9040273,0.3147544,0.38064247,0.2456605,0.06422969,0.91829455,0.04091814,0.9353491,0.07215063,0.06197758,0.3328363]","[43.75,38.5,-16.25,30.25,23.25,-36.25,-11.5625,-36,-42,33,-9.0625,-39,-22.125,-31.625,-44.5,-49,-20.125,-2.546875,-6.0625,-36.5,-28,34,-40.5,8,2.21875,-6.9375,10.8125,-39.5,13.0625,41,48.25,22.125]" +"[0.47152343,0.5226694,0.32659626,0.98836535,0.27688098,0.63168883,0.38209987,0.3770289,0.8952054,0.29052368,0.79606843,0.5339343,0.84506685,0.93418014,0.73631567,0.9981074,0.5031353,0.55478954,0.52702504,0.6497715,0.38138372,0.8458568,0.2679038,0.28225416,0.66552967,0.9441226,0.028049257,0.16931228,0.781842,0.7142137,0.46327075,0.87487686,0.9861051,0.019124387,0.7867634,0.34073675,0.29211864,0.6655471,0.025134075,0.62764615,0.1394368,0.014371416,0.94168335,0.43495,0.8167697,0.53115,0.60536814,0.29190227,0.5727684,0.9608202,0.65048987,0.40564382,0.90466833,0.0954931,0.9500341,0.35088128,0.2777612,0.1802372,0.2514154,0.20708562,0.33737093,0.37697738,0.7632505,0.5774651]","[-6.1875,7.46875,-37.75,42.5,-7.3125,9,13.8125,5.375,-47.25,-43.25,8.4375,-44,8.875,-42.5,32.25,-4.84375,26.625,-46.25,47.25,26.25,49,9.1875,9.625,-15.875,-47.75,-1.640625,-35.25,19.25,-31.125,-18.25,16.25,35.25]" +"[0.39310694,0.6788411,0.27286685,0.103395045,0.67637855,0.0028753465,0.12921517,0.2012166,0.23228636,0.5507399,0.20461018,0.75212187,0.40480015,0.62978524,0.23915176,0.17709385,0.93185335,0.91995656,0.25392824,0.98415583,0.9176571,0.5589375,0.70386934,0.321875,0.36696848,0.37914753,0.43976256,0.14596984,0.3406415,0.8869503,0.26016793,0.4934203,0.019998634,0.48520628,0.841404,0.32195625,0.39865056,0.43848616,0.35273197,0.3089316,0.51225835,0.061002173,0.7504851,0.5225014,0.6315376,0.7567971,0.9138916,0.38953328,0.5127923,0.318056,0.97107863,0.12589245,0.26516983,0.5135324,0.7669071,0.64885336,0.86585677,0.08883355,0.2578107,0.77729744,0.4893462,0.22362801,0.14357054,0.99968296]","[3.078125,36,-41.75,-21.375,-4.4375,-42.25,-10.8125,-20.375,-0.84765625,37.25,-12.625,-17.875,19,-23.75,-22.125,21,5.15625,-48.25,-0.51171875,-39.5,40.25,45.25,-37.25,-11.0625,-5.25,10.25,14.5625,19.25,30.75,-10.25,49.5,-24.75]" +"[0.87806726,0.5846697,0.91941625,0.028278511,0.697246,0.33188504,0.8685197,0.17633326,0.37725288,0.51358247,0.7041265,0.3491187,0.87530994,0.6892673,0.4682251,0.90772736,0.8931922,0.7547012,0.22194192,0.9816716,0.78755534,0.38542107,0.11923575,0.12824088,0.56543326,0.9159815,0.952594,0.05451375,0.3014945,0.62541825,0.66205245,0.62493086,0.6809055,0.9684982,0.7982846,0.76222515,0.7841627,0.78426427,0.9257992,0.69276613,0.21316141,0.9257068,0.056042712,0.32128146,0.4284605,0.5625545,0.65882015,0.65504515,0.31004867,0.06317011,0.6805843,0.67441547,0.18289259,0.7912467,0.9962483,0.9867878,0.8586505,0.22258417,0.83139193,0.31467426,0.92484415,0.03265173,0.630014,0.3685697]","[39,-8.3125,-44.5,-6,-3.859375,13.3125,-12.125,26.625,-33.5,44,-6.71875,21.875,8,-38.5,22,-39,28.875,37.25,42.25,6.625,29.5,-42.75,31.5,9.5625,33.25,-46.5,-0.84375,28.25,24.625,-10,-11.0625,-45.5]" +"[0.99597263,0.255186,0.74417806,0.7360147,0.84386957,0.8721614,0.80294746,0.058625165,0.5038792,0.36335188,0.8527933,0.47373277,0.9801203,0.5793082,0.7709943,0.5192374,0.5362803,0.48108062,0.17677076,0.6599322,0.68986917,0.5896344,0.35194817,0.8432633,0.32634825,0.7179935,0.99362475,0.4396168,0.08314257,0.7014911,0.8729814,0.05851371,0.43613183,0.5761386,0.96598583,0.2645795,0.5425017,0.3054969,0.59047306,0.67890704,0.78641105,0.45992172,0.005880006,0.61313856,0.08034811,0.81511503,0.3382368,0.99046665,0.73887664,0.038081296,0.61078984,0.54121,0.8142297,0.7626476,0.6302475,0.14790872,0.30149078,0.7927825,0.17595464,0.29040575,0.75130045,0.33700252,0.32980523,0.46512341]","[-33.75,21.875,-24,36.75,44.5,-31.125,-1.7578125,-12.5625,40.5,44,-12.5,8.6875,27.625,-20.625,-40.5,31.375,36.25,-10.125,30.75,43.75,9.75,17.125,-28.25,7.53125,39,8.375,-46.25,25,23.375,-29.25,6.46875,-3.828125]" +"[0.3859921,0.794028,0.48271424,0.61033714,0.5485661,0.63191783,0.8231668,0.3687595,0.983963,0.41746685,0.3646706,0.41797388,0.25177896,0.3002728,0.6419503,0.6378356,0.019960193,0.48306248,0.4190751,0.4709606,0.07564482,0.018534068,0.43881038,0.10637942,0.3397229,0.92559636,0.054974854,0.645244,0.21288362,0.34699324,0.9376409,0.0441493,0.025227053,0.7288874,0.52033716,0.7757305,0.69749755,0.61308396,0.21585141,0.6717992,0.7393541,0.4173968,0.71220034,0.90245014,0.81909937,0.2991409,0.22011997,0.17002372,0.5127624,0.32375592,0.702032,0.6544188,0.28045878,0.1352049,0.91682243,0.12672761,0.8253992,0.9605017,0.9575338,0.5259685,0.36666623,0.20231107,0.07515097,0.8433752]","[41.5,0.36914062,-11.9375,-0.19921875,6.125,14.5625,-48,20,-26.5,-16.375,45.75,36.75,33.5,3.8125,-4.3125,21,-46.5,-19.25,43.5,-21.625,20.125,-32,-44,12.125,-44,-13.625,-27.75,32.5,-12.0625,-4.5,8.5625,34]" +"[0.060919344,0.3651994,0.12378019,0.4012844,0.8473694,0.592391,0.8175479,0.71924734,0.441852,0.077674285,0.5759984,0.37726903,0.019923843,0.21691537,0.6675043,0.10439526,0.9689236,0.10074378,0.22026695,0.62919647,0.09311823,0.6685948,0.44451,0.7428715,0.81064945,0.9997291,0.97029465,0.95553267,0.047130257,0.36454993,0.5178817,0.53309566,0.74325204,0.409152,0.37338656,0.3290046,0.40867835,0.94212097,0.58746034,0.56191456,0.31863394,0.4013746,0.3895989,0.21412301,0.7594857,0.5274441,0.16570024,0.7065776,0.65660554,0.9735878,0.030253215,0.00073008885,0.4487955,0.44335428,0.592772,0.997188,0.1654638,0.2994011,0.75909746,0.81402075,0.29697502,0.537609,0.57826954,0.24440627]","[-29.75,-11,6.90625,9.4375,-17.125,-17.5,-15,-6.46875,34.75,-44,24.5,22.5,43.75,-22,-45.75,-19.625,36.75,3.796875,-48,42.5,-31.25,38.5,14.1875,32.5,38.75,21.25,16.875,45.75,-36.75,20.875,-24.5,-17.5]" +"[0.40660635,0.23120856,0.31715333,0.365314,0.99660033,0.33132902,0.72486097,0.4872427,0.27363375,0.33442342,0.3464565,0.25683722,0.8029111,0.78925604,0.12096926,0.60078365,0.53683144,0.41740575,0.24741514,0.8803943,0.28913057,0.5045563,0.7230461,0.4522877,0.83833283,0.061986797,0.48832545,0.056301896,0.024857307,0.8626653,0.34771505,0.8472803,0.5295595,0.1369546,0.44251695,0.03190196,0.43343094,0.26036337,0.3848983,0.40398476,0.77971077,0.65962917,0.95495194,0.5099951,0.75410765,0.16901171,0.17236137,0.6329564,0.7262972,0.9055687,0.6422112,0.27678877,0.12505335,0.48128554,0.38012242,0.39438906,0.12915947,0.022714011,0.10971138,0.07602658,0.7365675,0.09952653,0.13132434,0.10717191]","[7.46875,0.01953125,-24.875,35.75,-15.8125,34.75,0.54296875,30.25,-28.625,-47.5,-49.5,-17.625,-46.25,-15.5625,20.375,-30.875,-33.25,-9.0625,-48.25,-22.25,-8.0625,13.9375,-45.25,23.625,13.5,5.40625,28.5,32.75,48.75,38.75,-4.625,-20.25]" +"[0.69724905,0.5699388,0.5974701,0.90979403,0.36418536,0.8081216,0.9469664,0.34750512,0.8785942,0.36992455,0.10227771,0.3256286,0.18060894,0.13929527,0.55786383,0.68935627,0.020365542,0.4666501,0.41748494,0.2580716,0.25650585,0.7469866,0.6478184,0.92982787,0.9200515,0.0008569525,0.58943427,0.3229367,0.3469253,0.64060557,0.98780024,0.28528762,0.02669616,0.06437112,0.4032064,0.49256328,0.10643085,0.72153217,0.630024,0.32621846,0.6149292,0.024500737,0.0845782,0.62535936,0.80375624,0.34487158,0.94458145,0.5244928,0.8084152,0.9633734,0.18191569,0.49903294,0.2470539,0.6538689,0.9821049,0.95519394,0.62459517,0.18212797,0.6052148,0.18662164,0.026823642,0.032067377,0.4936672,0.9448502]","[-39,37,-38,-38.5,-26.625,-31.375,-22.625,-34,27.125,28.625,-19.375,-31,12.1875,-18.25,-15.8125,-5.4375,42.5,-46,11.375,-43.5,20.125,-19.25,34.75,24.75,-6.03125,-49.5,-3.5625,44.25,-11.125,-24.5,11,-48.5]" +"[0.7709524,0.87556654,0.8073292,0.56367236,0.50493664,0.35700437,0.5605782,0.057524327,0.59582293,0.8144743,0.04448393,0.060420845,0.81185377,0.43400338,0.72388816,0.05986652,0.7957949,0.64912325,0.9371155,0.021822827,0.1615428,0.047915448,0.4070983,0.6551153,0.019861868,0.50419295,0.50091517,0.6952068,0.6086887,0.03695375,0.71267587,0.6597308,0.97119296,0.8151037,0.9378548,0.47207466,0.7060629,0.81701404,0.4488352,0.77563834,0.5510086,0.353331,0.7922558,0.39148638,0.6439887,0.1210588,0.72916067,0.34522766,0.2407246,0.55487585,0.5291307,0.9894369,0.76598096,0.84083104,0.44762912,0.120414644,0.14175399,0.1669762,0.093765035,0.986746,0.67129666,0.08206733,0.92801243,0.72062796]","[-17.125,40.75,-31.625,33.25,29.625,24.875,2.34375,-24.25,-27.75,-41.75,40.5,-42.25,-39.5,-40.5,46.75,-22.125,34,-9,-28.125,49.5,42.5,28.625,27.5,29.625,14.0625,-35.75,-14.6875,-45.5,25,-7.5,-42.75,39.75]" +"[0.60623044,0.24426095,0.45844144,0.47579846,0.450171,0.725677,0.999416,0.38556936,0.51031715,0.66590816,0.16264017,0.6061114,0.5931071,0.75007254,0.60952884,0.9191715,0.90663624,0.56876636,0.40928036,0.38135242,0.30531168,0.16212377,0.9730335,0.0632084,0.783477,0.36014655,0.118592426,0.5113476,0.44941965,0.08190142,0.54975164,0.13902774,0.62706465,0.2955199,0.089109145,0.49714795,0.26088533,0.47521812,0.04562369,0.33971542,0.03339521,0.6067178,0.5336634,0.81536144,0.8897128,0.7834459,0.36265734,0.02101703,0.08788524,0.27027708,0.058923528,0.7547703,0.1748614,0.67658216,0.22437513,0.25298998,0.5060372,0.3466832,0.5706869,0.17144091,0.92833674,0.22275649,0.402321,0.1518053]","[34.5,-40.25,-26.25,-8.25,-21.125,46.75,43.75,10.5625,-42.25,45.5,5.59375,-13.9375,40.25,28.25,0.640625,-29.875,21.875,-4.40625,48.25,9.9375,38.75,10.375,-17.625,16.75,-5.84375,23.875,39,40.25,-13,-16.875,-7.84375,32.25]" +"[0.725702,0.44336894,0.31432453,0.32237184,0.66627717,0.47392958,0.07100043,0.7322088,0.011559387,0.10714715,0.7343511,0.5758672,0.34517077,0.90234315,0.8295113,0.15103793,0.20522648,0.057096194,0.6368524,0.22182167,0.46080709,0.9466344,0.6822103,0.0026221685,0.66747993,0.52504915,0.54150903,0.68382746,0.6338146,0.56616163,0.36672115,0.5140762,0.27962476,0.8096983,0.52080077,0.9237937,0.8832696,0.41834572,0.70577294,0.9553325,0.0030275888,0.042943027,0.81410867,0.8931256,0.68608713,0.26400906,0.03975911,0.27956837,0.7672368,0.78348774,0.121110424,0.360174,0.59083945,0.13730028,0.5822384,0.75186676,0.78313226,0.21947333,0.805599,0.2955934,0.3969454,0.014275578,0.662432,0.19236001]","[-24.625,44,12.6875,-38.25,-46.5,38.5,35.25,34,-26.875,-38.75,-10.75,14.5625,-33.25,6.25,45,4.46875,-21.875,48.5,36,40.75,-6.65625,-37,-0.39453125,-45.5,-16,-22.875,40.75,49,-41.75,-22.625,-47.75,0.58984375]" +"[0.11816265,0.5677012,0.22752494,0.04086177,0.71527493,0.47778532,0.7902171,0.8923808,0.45539123,0.8796446,0.5452154,0.74124897,0.83282363,0.6504591,0.4890598,0.64411664,0.42522788,0.6683277,0.6958312,0.8626399,0.42332643,0.13109247,0.45697495,0.8128232,0.43633866,0.13640493,0.14722197,0.5916239,0.5492566,0.32417947,0.13897824,0.4359311,0.274026,0.9397818,0.4949286,0.11473092,0.58995664,0.1250256,0.9233199,0.025071247,0.44341037,0.624178,0.34997565,0.46474418,0.012203981,0.8151504,0.5483329,0.8809924,0.039988834,0.24863808,0.046042718,0.19076172,0.87798434,0.2256666,0.84977305,0.19545731,0.2421999,0.5675232,0.07901449,0.3860727,0.2507776,0.46580872,0.96980244,0.62548697]","[-24.75,4.78125,39.5,17.75,6.15625,17.75,29.625,21.5,-20.625,43.75,18.25,10.25,-18,-24.875,-28,39.25,-47.75,-19.125,-24.875,31.625,-3.296875,-29.875,31.375,39.5,41.75,-20.375,29.125,-23.875,0.75,-7.75,4.1875,12.4375]" +"[0.49299097,0.60669976,0.7255986,0.9660784,0.2832972,0.1728531,0.34663504,0.1952663,0.8809008,0.6806379,0.50340945,0.033675253,0.7491761,0.6856438,0.68711257,0.8037158,0.00802033,0.45153674,0.54998195,0.9902218,0.35491908,0.50118494,0.34379217,0.4192287,0.2801085,0.4272149,0.12914854,0.9693281,0.09307258,0.44186774,0.8025731,0.71986085,0.31505254,0.53997296,0.385138,0.78098506,0.89398426,0.96449023,0.10654061,0.9109775,0.018467193,0.87265515,0.9779257,0.48103547,0.27451503,0.37968302,0.55619115,0.24895614,0.1408114,0.14796372,0.4750359,0.62772405,0.06170911,0.05801109,0.66027737,0.77518344,0.49363184,0.5446333,0.79294777,0.8753984,0.09297751,0.51697016,0.17957251,0.1652925]","[-48.75,11.8125,-28.375,-13.8125,-20.25,5.71875,-1.1796875,14.9375,-16.75,42.5,7.40625,-11.1875,-27.75,-39.25,-8.3125,19.625,-37.25,49.75,38.5,-1.2890625,41,-5.375,32.75,-15.125,-47.75,-22.625,0.41210938,44,-10.9375,-9.6875,22,31.125]" +"[0.9213663,0.2067104,0.8194554,0.07163238,0.29493383,0.35645404,0.5197381,0.23404017,0.58033633,0.147634,0.78011477,0.17411314,0.80186105,0.009533442,0.072534,0.6668891,0.75870925,0.21702024,0.78547096,0.27267113,0.2384461,0.08041846,0.87358576,0.30090678,0.17835183,0.6862718,0.9563139,0.9139406,0.9431139,0.9229123,0.21519598,0.99552095,0.71319956,0.3893505,0.17910346,0.95784646,0.013270243,0.1284785,0.53088325,0.95699644,0.48067525,0.14814761,0.77812046,0.37037137,0.81162035,0.09136994,0.71973705,0.56971186,0.6220902,0.04613972,0.76648045,0.16475396,0.515682,0.6996957,0.5815975,0.3853466,0.26531178,0.08837006,0.25196186,0.746547,0.16235468,0.82735366,0.82759523,0.38788438]","[-14.3125,29.375,43.5,-35.25,-10.875,-23.5,31.25,18.125,-45,45,-47.5,-3.9375,-35.75,-12.875,29.5,-22.25,-20.25,19.375,-1.3125,-15.4375,-23.375,-29.875,24,16.5,34.75,11.625,-36.75,-22.5,28.75,12.6875,-33,-46.75]" +"[0.7499044,0.6082224,0.04600758,0.756421,0.36785427,0.3907128,0.34838134,0.9637292,0.6703868,0.21823753,0.24913333,0.3897862,0.47058183,0.14845668,0.3927802,0.91508347,0.47556123,0.427734,0.0977878,0.5947833,0.45757675,0.58309966,0.60065717,0.8963997,0.69271046,0.96909314,0.63311565,0.10101731,0.7781783,0.4203217,0.74571836,0.8904306,0.5162373,0.32900667,0.4583806,0.48422176,0.8142127,0.278355,0.66588175,0.12406232,0.08029646,0.24347836,0.9023182,0.5614329,0.9007428,0.3013189,0.6705569,0.3356448,0.61481994,0.4998917,0.43889478,0.613919,0.5923885,0.3277796,0.16121727,0.51642233,0.95506155,0.9733222,0.9984757,0.8612389,0.25767553,0.20396885,0.7971047,0.78301114]","[38.5,-41.75,43.5,6.46875,-6.75,-32.25,0.13476562,-8.125,-17.875,43,-44.5,44,-2.484375,2.78125,-47.25,-7.9375,37.25,-2.828125,-9.125,-29.25,-27.375,-10.3125,-10.5,39.5,11.25,20.25,-18.375,46.75,29.125,-18.5,-2.890625,-4.8125]" +"[0.6887204,0.14062339,0.11249231,0.5297888,0.302295,0.17829974,0.6992149,0.9008723,0.15324138,0.17273119,0.43359634,0.56508476,0.82303756,0.5626456,0.72085315,0.31903756,0.1659478,0.14841586,0.5684313,0.67632043,0.48421606,0.30804694,0.4749733,0.9556809,0.19178192,0.2144887,0.6936653,0.84219044,0.27885798,0.4110932,0.8948654,0.8956662,0.8753252,0.7423812,0.033641696,0.6924315,0.19396894,0.14818741,0.6183352,0.7306087,0.14724658,0.7827952,0.39324215,0.9501331,0.38088,0.67022586,0.9249631,0.6758097,0.8533369,0.52144116,0.82017606,0.78405917,0.61928725,0.31300277,0.5773133,0.7616527,0.087058045,0.9317358,0.6804799,0.37483296,0.32740945,0.35991904,0.6624307,0.07789241]","[-31.625,-36.75,44,24.125,38,39,-47.25,2.9375,21.625,-43.75,-1.40625,0.19726562,43.75,-17.125,4.28125,42,-15.1875,-35.5,35.5,1.8515625,-0.68359375,40.75,31.625,1.4765625,25.5,27.5,-6.6875,-11.5,-48,-12.125,-29,39]" +"[0.017947042,0.48250577,0.28054005,0.47947365,0.45112506,0.26288265,0.62965137,0.6294838,0.85508645,0.19715182,0.07751826,0.83312213,0.5550844,0.42313898,0.09876509,0.6960997,0.5310557,0.13520217,0.88348854,0.8506519,0.44736394,0.66341966,0.56724215,0.47579452,0.21798031,0.99061215,0.75666445,0.23997693,0.1332018,0.88050044,0.7928157,0.3843616,0.3736546,0.60549045,0.36133078,0.91416734,0.79834336,0.3018855,0.84869003,0.22238638,0.7891533,0.3823862,0.7528435,0.3097575,0.10862334,0.6509364,0.131224,0.8229386,0.18651092,0.73253745,0.79804456,0.6416439,0.5279717,0.54180264,0.8943181,0.026592141,0.9118344,0.60790145,0.19559185,0.32485104,0.12164103,0.26231527,0.66497064,0.5828873]","[-47.75,-40.5,-15.375,-30.375,40,38.25,-28.625,26.25,48.75,35.25,36.5,43.5,-0.38085938,39.75,25.25,4.5625,25.625,27.375,15.5,2.640625,41.25,-41,21.25,2.953125,-46,-41.5,8.3125,32.75,38.75,-11.0625,-43.25,-37.5]" +"[0.31332725,0.5440178,0.640527,0.58146673,0.3492562,0.6917331,0.38422954,0.2752066,0.79968417,0.57821006,0.16999269,0.596704,0.22026998,0.037558965,0.04146293,0.9879877,0.12866592,0.10328197,0.7057433,0.06650929,0.7255013,0.27703872,0.311648,0.14433324,0.41616812,0.1855511,0.33425564,0.8069384,0.20618053,0.2955282,0.9543837,0.8434864,0.5424556,0.5660385,0.78069264,0.29040763,0.6296755,0.79902434,0.13794279,0.4694087,0.11538106,0.22283576,0.7466926,0.7681676,0.347944,0.6670021,0.98277885,0.010990875,0.6446442,0.65031505,0.4111733,0.34064627,0.005761886,0.42036852,0.78359383,0.5507451,0.46118942,0.98159045,0.84335446,0.38680914,0.40732512,0.5242962,0.7511007,0.69093]","[45.25,-19.5,-44,24.125,3.265625,24.875,-18,2.296875,-29.625,7.21875,-15.4375,-30,47.25,-15.375,27.625,27.75,-19.875,33.75,29.75,7.5625,-49.25,-43.75,14.25,-49,41.5,44.5,-27.75,-13.75,-1.328125,-31.5,23.25,-5.5]" +"[0.38481557,0.55994505,0.5182144,0.47254342,0.981768,0.9645172,0.47533408,0.1326061,0.7386776,0.0575676,0.47985643,0.8959506,0.8676058,0.8915154,0.17258133,0.068319805,0.9427602,0.27903512,0.59765935,0.8119886,0.5972521,0.8154834,0.5111275,0.4901353,0.13070539,0.7641518,0.20498353,0.92043,0.47185355,0.39859426,0.86908466,0.9990107,0.1593444,0.93400264,0.90353245,0.5479588,0.32046032,0.45699275,0.968669,0.110974334,0.5623078,0.8553507,0.57520455,0.22622274,0.8510899,0.38770708,0.33949324,0.6523546,0.45919695,0.9255177,0.7103591,0.76369226,0.64634556,0.7872461,0.3415634,0.44935876,0.48420885,0.19888888,0.75482595,0.35173783,0.6433343,0.45049447,0.44034663,0.29762152]","[-41.25,-44.25,-24.125,21.5,23.5,-22.5,24.125,-9.875,-0.18359375,35,34.75,-33,-41,-7.6875,-16,21.875,-20,19.25,-42.5,34.5,45.5,-37.25,-3.234375,-12.5,-22.875,33.75,-28.375,-47.5,5.71875,-35,-21.5,-11.125]" +"[0.6311647,0.7039291,0.9970396,0.6997801,0.08913714,0.6380122,0.667495,0.19461247,0.1231402,0.48872498,0.7886837,0.8881885,0.64468485,0.62033284,0.22498588,0.88499,0.05328826,0.7476439,0.89539367,0.2873537,0.20637093,0.5266701,0.4312897,0.20525205,0.2475555,0.7239283,0.34417212,0.36193305,0.7878412,0.22535855,0.71445096,0.4465551,0.7624065,0.48027232,0.4707877,0.23470849,0.15025002,0.5552165,0.040255725,0.4865327,0.06282807,0.92613304,0.7903559,0.03883608,0.7445336,0.10836924,0.5621311,0.10009188,0.95276237,0.5121776,0.9642029,0.4944488,0.639066,0.8761793,0.15080959,0.2858151,0.25565785,0.68875563,0.46662262,0.027056733,0.5162947,0.74760115,0.18430208,0.20458786]","[-38,-9.9375,41,-21.125,-0.076660156,-42.75,18.25,2.296875,-38.75,42.25,-16.875,-0.30273438,-43.5,40.5,22.375,28.75,4.1875,-27.375,-18.875,38.75,-22.875,-34,-48,31.75,-30,-5.9375,13.0625,37,41.75,48,-39.5,24.875]" +"[0.485508,0.37413764,0.44523484,0.7034456,0.20240489,0.32506016,0.26833525,0.58034086,0.80459577,0.9011667,0.8248614,0.36656705,0.63884205,0.36716858,0.6394874,0.42966753,0.8613801,0.13905747,0.8426798,0.8713795,0.61677396,0.033363428,0.01474943,0.41278362,0.8489571,0.6606854,0.49274525,0.47446364,0.8473977,0.21751642,0.61549896,0.21692774,0.26380092,0.7585806,0.17606394,0.59876347,0.32843724,0.23758106,0.55580044,0.022633398,0.3554391,0.76319575,0.7318612,0.5894881,0.89043605,0.6222616,0.5246171,0.2180436,0.05268929,0.0694858,0.46813032,0.78465724,0.04525981,0.25531834,0.11470863,0.28502873,0.35879132,0.93637526,0.9740101,0.30210015,0.633937,0.24760158,0.086867526,0.40525]","[25.375,-39.75,9.25,20.625,39.25,35.75,-0.42578125,-19.375,27.125,-20.75,11.5,-1.7109375,2.296875,28.5,-36.5,-40.5,13.9375,0.49414062,22.25,-38,-18.5,-7.71875,44.5,43.5,-24.625,47.75,11.9375,-11.6875,28.5,-28,-14.125,-19]" +"[0.7627204,0.6814395,0.84726834,0.38800123,0.76666945,0.45129156,0.56687385,0.3377285,0.6507701,0.2618101,0.07264566,0.20779583,0.1400014,0.66997397,0.14330772,0.7049595,0.8315254,0.35937,0.73477954,0.51851135,0.8071333,0.19902924,0.88719046,0.62642944,0.84272975,0.87869865,0.96428275,0.42077026,0.062512726,0.19007245,0.66304594,0.5344539,0.5946874,0.8542645,0.069360346,0.98904055,0.23936239,0.07213634,0.47230503,0.19254881,0.82497114,0.9195776,0.21922636,0.083431736,0.49258223,0.8932931,0.099244036,0.962404,0.29502317,0.09243759,0.5562602,0.13561171,0.79159254,0.97346765,0.21825305,0.4180513,0.8966236,0.24452962,0.19216384,0.8397652,0.21003537,0.15051709,0.3868629,0.2978314]","[-38.5,-31.875,-6.25,-15.25,-37.75,-20.875,-28.75,49,-20.875,-4.59375,49.25,-41.5,-44.25,-38.75,1.1875,1.0234375,18.375,-21.875,-13.9375,23,-28,-29.25,36,14.625,21.5,3.984375,23.25,26.875,36,2.96875,-8.4375,45.75]" +"[0.5509639,0.029782217,0.4313001,0.30515757,0.3051365,0.1123025,0.33134604,0.802061,0.42340028,0.43911517,0.4626259,0.11786947,0.7664922,0.9635163,0.77325237,0.8919121,0.8388937,0.8598515,0.18766908,0.5799235,0.5305545,0.6420454,0.7397006,0.96896595,0.6772394,0.5316254,0.932966,0.57283396,0.41292074,0.04717832,0.056807846,0.09394761,0.2750302,0.7622157,0.3506675,0.8925932,0.1684426,0.11699017,0.04952356,0.0914638,0.63776934,0.9108202,0.93826497,0.006844556,0.9299634,0.5443876,0.06548336,0.6277939,0.2160309,0.9448154,0.20667377,0.14197855,0.62837726,0.19404605,0.7578995,0.14702083,0.7972461,0.5186217,0.7692913,0.51831853,0.14913507,0.06628585,0.38322803,0.05269277]","[49.5,5.6875,6.34375,-6.75,3.34375,24.75,7.46875,14.5625,10.5625,-27.5,-29.625,40.75,6.71875,38,-5.78125,-46.75,-7.03125,19.375,-47.75,3.375,-26.25,14.9375,25,-10.625,-49.5,-14.375,18.25,28.875,-35,-46,48.75,44.25]" +"[0.041705105,0.6383004,0.8833641,0.72362936,0.8921708,0.17722881,0.7442426,0.8222386,0.5975064,0.26232928,0.56926024,0.5664463,0.44310778,0.36307135,0.020206328,0.062436845,0.34376124,0.39764518,0.8686831,0.51272166,0.39947584,0.67073464,0.023358777,0.9328068,0.28298253,0.37510207,0.23527198,0.95103836,0.71554214,0.47228003,0.008217248,0.9748903,0.4932124,0.09929584,0.504065,0.26324794,0.6780665,0.5547523,0.4903993,0.10167649,0.4234896,0.4966888,0.113714494,0.81475395,0.51038975,0.18062145,0.140442,0.19001216,0.8742891,0.8601943,0.0750556,0.92836446,0.81780815,0.7509072,0.45161614,0.7329662,0.45562586,0.6959437,0.027150322,0.56853414,0.4591578,0.49025196,0.99879986,0.07836844]","[42.25,-24.5,46.75,47,35.25,-25.375,-40.25,12.8125,-26.625,7.21875,7.15625,-34.75,0.76953125,-25.125,-47.5,0.44140625,25.75,-38,-8.4375,14.375,42,44,1.234375,-41.25,39.25,43.75,38.5,36.5,45.5,2.3125,-32.75,24.375]" +"[0.42909855,0.41114295,0.99639934,0.77841556,0.7728038,0.3049477,0.00024157738,0.23110604,0.5292935,0.15797603,0.2501885,0.36736542,0.32837564,0.18685159,0.083245955,0.79912204,0.7044796,0.9244028,0.98805666,0.037623316,0.031225242,0.36362216,0.8414825,0.22339684,0.55366313,0.80307144,0.76240563,0.08253695,0.5705359,0.43594676,0.15017973,0.3282078,0.5702909,0.9738724,0.66884625,0.14497477,0.049679205,0.3159888,0.93423575,0.16799082,0.58551484,0.2825535,0.22577018,0.31578282,0.03710928,0.5682509,0.536554,0.78144675,0.3653436,0.83223224,0.43490106,0.66028,0.9068104,0.80341053,0.19326198,0.7475824,0.2371221,0.04910441,0.6053862,0.010719138,0.000581316,0.78530145,0.51792777,0.39994228]","[-18.875,41.5,23.625,-31.375,34.25,34.25,-15.5,16.5,7.28125,0.19628906,0.15136719,-12.875,16.375,-43.75,18,-42,-7.0625,-45.75,-48,3.328125,-41.75,4.40625,20.875,-39.5,-2.3125,15.625,31.125,49.75,14.4375,25,-27.625,-17.125]" +"[0.96042484,0.08633099,0.7619173,0.6620993,0.93284464,0.663595,0.98592705,0.2619552,0.067823894,0.7520335,0.88650835,0.35489014,0.97232604,0.5589001,0.9234113,0.9402044,0.9266912,0.5828965,0.4654987,0.46655563,0.70100397,0.34398276,0.21294428,0.6539319,0.2694643,0.33125007,0.63664305,0.4000551,0.56771487,0.80243206,0.7478664,0.16125475,0.18746527,0.11206545,0.83884364,0.18590458,0.78139395,0.43678468,0.8285131,0.7422769,0.8235813,0.92024803,0.7118208,0.51936716,0.84390926,0.16127782,0.8861721,0.1941016,0.6696561,0.47817594,0.7049164,0.5167243,0.6524602,0.80660456,0.54793084,0.6902853,0.18316098,0.5816356,0.1595545,0.35242814,0.96393216,0.28539795,0.27765468,0.47289863]","[-45.25,-49.25,13.3125,49.5,-12.3125,-8.0625,39,42.5,5.375,-45.75,-9.1875,12,-32.75,9.375,7.90625,-26.75,3.140625,47,8.125,-2.328125,-11.75,7.84375,-1.3671875,45.25,-42.25,48.75,-9.875,-16.5,-41,-7.34375,14.25,38.5]" +"[0.5678944,0.65635395,0.006604923,0.35460362,0.4374972,0.64028263,0.19585402,0.007406307,0.8004375,0.6494671,0.5542871,0.30078718,0.49070162,0.34125936,0.9734557,0.57337385,0.030368831,0.34900844,0.67142606,0.9592718,0.8469602,0.19945462,0.13889463,0.24318047,0.40996248,0.61899215,0.7639662,0.5842669,0.38018474,0.43146282,0.5464036,0.08657966,0.43592992,0.4794207,0.4413182,0.5369253,0.27165663,0.914784,0.91725194,0.5393848,0.54717594,0.8472321,0.12832941,0.15323599,0.6103929,0.45438367,0.035166003,0.18547377,0.19722958,0.98077357,0.8287249,0.076168805,0.16963191,0.48009062,0.26132342,0.4656917,0.2770149,0.9720249,0.7177586,0.14444548,0.30237275,0.8843471,0.38787398,0.607939]","[14.8125,-7.90625,45,-46.75,26.125,-22,-28,-8.4375,29.5,-27.75,-36.25,34.25,17.75,32.75,13,15.9375,-1.6953125,20.125,-37.75,46,-47.5,8.375,-47.75,-31.75,-9.375,46,29.25,-26.25,-7.78125,19.75,-6.1875,16.625]" +"[0.1938324,0.99672353,0.235223,0.83634925,0.9410029,0.76632005,0.6634547,0.8732806,0.3698566,0.5439387,0.28678933,0.11723526,0.1853206,0.13191392,0.07727673,0.027872235,0.7030078,0.45287842,0.9789467,0.889126,0.14399788,0.67576456,0.72797394,0.20543203,0.8038291,0.4408608,0.64913845,0.9765854,0.09074257,0.1942085,0.054001357,0.4050219,0.6223819,0.8619756,0.8701886,0.85045105,0.47723883,0.8748099,0.8033408,0.7620364,0.9903744,0.76283896,0.27105266,0.10287778,0.84255373,0.88812345,0.5405998,0.9509775,0.25392544,0.090871744,0.9112844,0.101317056,0.07873133,0.18919395,0.044887595,0.62110466,0.86582834,0.6284731,0.41711882,0.5855681,0.2133482,0.3794744,0.17963211,0.29978642]","[12.8125,-1.75,2.59375,37,9.4375,-1.9921875,-11.5625,18.875,-4.3125,-32.25,41.5,-18,-38.25,2.625,-7.375,-37.25,29.75,-16.125,-10.25,33.75,-42.5,-22.5,36.75,-17.5,16.375,-3.6875,46.5,-41.75,42,-36.25,30.375,7.21875]" +"[0.1240148,0.77782154,0.4081531,0.39551592,0.38535717,0.78647715,0.86188155,0.013923938,0.58831686,0.030830426,0.92216647,0.87824017,0.95624125,0.79865104,0.14260657,0.45799682,0.0038860955,0.13945766,0.17483523,0.6427449,0.56566167,0.11436719,0.7543065,0.48445043,0.4299949,0.2841194,0.5097139,0.8935228,0.8178599,0.7687223,0.48447308,0.71441066,0.50305116,0.7015192,0.6241829,0.07719381,0.6756355,0.6987203,0.55823463,0.96462274,0.7121218,0.3423468,0.6912599,0.40709043,0.70286983,0.7955218,0.32093677,0.203468,0.075851694,0.4656846,0.26122615,0.8752172,0.67164487,0.48096892,0.5212409,0.18179122,0.8919191,0.9296869,0.64448655,0.013611398,0.54114133,0.7515602,0.014805977,0.29896048]","[38.5,27.875,14.3125,9.75,35.5,-29.125,26.25,-40.25,27.25,25.5,30,3.421875,15.4375,-7.4375,-31.75,32.25,-29.375,23.625,20.125,-1.765625,-18.875,-28.375,2.578125,43.5,-45.25,16.125,-30.375,48.5,31.25,44.25,11,-11.3125]" +"[0.26171908,0.83613133,0.06694071,0.5851511,0.2154965,0.9470661,0.2899432,0.25609004,0.6737154,0.027478006,0.08794049,0.3499198,0.11908838,0.56271243,0.8853933,0.4706901,0.91211987,0.9246277,0.5807798,0.40098327,0.5382785,0.08365422,0.9494101,0.24158487,0.95071083,0.5344465,0.77909017,0.40280303,0.102491274,0.15662812,0.76348794,0.40891927,0.31434202,0.37192598,0.2863421,0.6679036,0.7916158,0.96933925,0.9243236,0.017540028,0.5550986,0.09432573,0.6978171,0.2754851,0.7672237,0.20720227,0.23209961,0.6092465,0.30031222,0.030145053,0.9834449,0.4556176,0.21926801,0.7961434,0.8495683,0.6774702,0.40296236,0.3163265,0.39471167,0.55921847,0.7368836,0.45940822,0.37820554,0.14997303]","[-46.5,-23.25,12.0625,25.5,-49.25,-33.25,-23.625,-32.25,-45,14.4375,12.3125,28.375,44.5,23.5,26.25,13.875,-20.5,47.25,-41,37,-2.328125,11.625,-16.5,5.125,-23.625,-30.125,-5.53125,-42.25,-14.1875,-42,11.6875,26.375]" +"[0.9526822,0.84572,0.07693938,0.033353645,0.75430536,0.20826069,0.82923794,0.90336996,0.45348108,0.91502213,0.1711237,0.049990546,0.9746897,0.48854926,0.5034416,0.33034396,0.54238445,0.036024738,0.44101116,0.051864736,0.60992193,0.5522058,0.9253114,0.55464536,0.94378155,0.7744476,0.95156723,0.18822408,0.5483888,0.5775691,0.7465094,0.7361762,0.25481337,0.8776372,0.73700964,0.43809554,0.41056338,0.41383404,0.5371831,0.7896648,0.5049906,0.48260814,0.82678795,0.9039676,0.25424087,0.52349246,0.13642232,0.377929,0.44594964,0.17070943,0.997932,0.24845155,0.7359545,0.1588471,0.54121345,0.7599817,0.4180834,0.5114587,0.2680024,0.19084214,0.34330842,0.27343884,0.98883754,0.6298534]","[-44,8.125,45.75,42,-9.0625,-48.25,42.25,-34.5,8.4375,-10,-35.75,-44.75,-47.75,-42,-7.65625,-6.4375,-23.375,-25.25,-12.625,-46.75,13.25,-15.1875,14.4375,-0.7109375,44,-10.125,-1.4921875,21.125,-16.875,-39,0.484375,-4.75]" +"[0.03973828,0.26658994,0.9698141,0.068087325,0.14830515,0.64193696,0.6726394,0.08629454,0.38526925,0.49624127,0.055456672,0.21034083,0.037738558,0.40161678,0.8467511,0.68289715,0.7003766,0.7500926,0.13233525,0.026815558,0.8098169,0.15925592,0.18437134,0.5600783,0.11781018,0.5620204,0.38370392,0.49682468,0.26775235,0.5721835,0.4297453,0.6282406,0.05765445,0.13430794,0.758036,0.2840832,0.0014284799,0.47534388,0.47782558,0.15137424,0.64454716,0.26645494,0.5587303,0.4156306,0.9401017,0.86399496,0.086120605,0.8928951,0.26487336,0.81005096,0.4418991,0.40074307,0.49249643,0.21693943,0.84377587,0.4805802,0.29366177,0.9233404,0.33567294,0.6839734,0.1500561,0.89936155,0.9820711,0.81563]","[14.875,14.4375,-44.25,-18.125,-40.75,22.5,-20,-41.5,-17.875,7.65625,24.25,40.25,39.5,6.53125,23.625,-38.25,44,31,24.125,38,-8.375,18,9.3125,-38,40,23.625,1.4296875,46,5.46875,-27.125,-44,-11.8125]" +"[0.7131932,0.6045929,0.98346496,0.07972702,0.21830723,0.12825489,0.28065774,0.6826569,0.53192484,0.80409324,0.6353177,0.34708223,0.1299556,0.27883154,0.0072683324,0.395663,0.24460179,0.33068857,0.9198001,0.036530364,0.58956194,0.14325668,0.93349797,0.65912765,0.5325456,0.3576081,0.5491489,0.07130153,0.944526,0.33946928,0.8513438,0.18431167,0.09629722,0.8872502,0.863087,0.067006014,0.8199737,0.30990428,0.9366058,0.35181284,0.74677974,0.9992552,0.85056573,0.9528217,0.25659418,0.8380662,0.8311591,0.8282343,0.11205584,0.37173423,0.21424085,0.023658725,0.7479285,0.6989943,0.63152707,0.84121716,0.33972478,0.9473938,0.29338515,0.40680206,0.87937045,0.71108705,0.7704121,0.81414914]","[-20.125,19.375,-23.25,30.625,40.75,23.375,12.3125,6.0625,-46.25,41.5,-10.0625,-47.25,-26.375,25.125,30,-3.15625,-6.03125,29.625,-23.75,-49.5,-11.375,8.25,0.84765625,-30.5,-21.75,20.5,27.5,-21,49.75,33,-40.75,6.78125]" +"[0.30276382,0.57991666,0.72893256,0.93929267,0.42996946,0.1620442,0.5826454,0.94473046,0.67848,0.0056335744,0.74444085,0.15487629,0.19423285,0.68158334,0.94157237,0.88909507,0.15915476,0.33677468,0.76449573,0.8847488,0.3360583,0.66711265,0.6800323,0.74556905,0.95203376,0.7008657,0.5960122,0.5470983,0.84017175,0.11788823,0.64108086,0.3144919,0.8818331,0.9085192,0.7030433,0.35358357,0.705931,0.5385201,0.31476027,0.47870356,0.3995609,0.20089935,0.9018119,0.107465826,0.5896546,0.18573724,0.95575017,0.4679675,0.33332205,0.30239868,0.4095493,0.31756735,0.031525735,0.6330983,0.1927361,0.47798672,0.8206115,0.31750423,0.17686269,0.26835302,0.71143186,0.9174034,0.53541005,0.8023905]","[-34,-13.4375,10.625,-4.78125,20.875,8.3125,46.25,-47,-46.25,3.15625,9.8125,-21.25,2.625,17.125,-32.75,-40.25,29.875,-4.5,-28.5,35.75,-10.625,27,-18.375,0.46875,12.8125,36.75,-48.75,-30,43.5,14.25,-45.25,26.125]" +"[0.5831189,0.9691585,0.17511983,0.033124123,0.77160645,0.15350373,0.9641342,0.43508315,0.9600237,0.6287325,0.6321093,0.43182096,0.12746936,0.27343753,0.240855,0.74354917,0.9822053,0.3875833,0.50600004,0.98374975,0.83676416,0.94756734,0.95584303,0.06636006,0.95247436,0.058867272,0.92574126,0.17170501,0.835292,0.4926175,0.8884916,0.46386638,0.41667494,0.30430174,0.698124,0.3738558,0.7154597,0.595849,0.814161,0.9931353,0.3066788,0.83028984,0.12933777,0.9238933,0.7471242,0.47180006,0.5177735,0.67320055,0.31907263,0.72031206,0.3441928,0.43801364,0.78207827,0.6235076,0.06776595,0.8066474,0.12091486,0.14163363,0.88266325,0.39450282,0.7063997,0.0021072507,0.6847472,0.3238876]","[-13.5,-2.65625,21.25,-3.625,-13.25,-9.0625,-39,-29.625,-48.25,6.28125,-0.9453125,-16.125,16.25,13.1875,-15.25,49,-47,0.546875,43.75,-5.46875,44,7.875,29.375,47.5,-30.875,-27.125,10.6875,-34.5,-27.75,38.75,21.875,15.1875]" +"[0.48999447,0.2847933,0.35661402,0.779326,0.6852362,0.5644676,0.901124,0.36479473,0.6802297,0.1299042,0.030825872,0.11191163,0.35211995,0.22948056,0.46754047,0.65849364,0.108029366,0.7446547,0.7833142,0.62227434,0.8746919,0.696236,0.33222228,0.8558004,0.6679301,0.54482377,0.8486694,0.019388855,0.49573877,0.31539324,0.8745154,0.41464546,0.3392511,0.7069815,0.10469626,0.56983244,0.66709816,0.0056709405,0.16666223,0.98480886,0.20954543,0.67209727,0.86280763,0.87440556,0.83808404,0.24120809,0.14555736,0.46011412,0.977249,0.72908056,0.09357973,0.60499614,0.48353782,0.14032312,0.71852434,0.88778806,0.7703664,0.40851337,0.85072184,0.938915,0.84709346,0.48650527,0.95057464,0.5220505]","[25.25,32.75,39.5,-47.75,34.25,-26.25,-15.1875,-49,-46.25,-22.625,39.75,-21,-36.25,-32.25,-25.5,-30.5,-5.84375,-21.625,-49,-6.03125,46,-19.125,-49,-7.6875,27.375,-45.75,-49.5,30.5,20.875,-31.625,14.875,-11.9375]" +"[0.3723158,0.7061916,0.34697628,0.71355575,0.3155271,0.40974835,0.75632423,0.3909518,0.32781234,0.42199117,0.076576374,0.94606584,0.13835704,0.1852221,0.08483534,0.17930067,0.7964036,0.5419181,0.68076175,0.15309684,0.5598176,0.47963065,0.5939466,0.5576726,0.65468186,0.24968345,0.9485388,0.93769044,0.23142931,0.5178296,0.88677055,0.20110072,0.39238653,0.47982478,0.16703783,0.86080295,0.8028504,0.25301668,0.016537247,0.30335456,0.20306638,0.8193349,0.47484338,0.73446953,0.20321544,0.021802766,0.36734152,0.5543516,0.6371901,0.0752439,0.7763762,0.0070848702,0.7427706,0.54794765,0.5153363,0.7404349,0.79267365,0.39591816,0.97584057,0.9413083,0.14703014,0.31059554,0.24308813,0.453541]","[-6.875,35.5,-41.75,42.75,8.6875,-10.6875,29.75,-42.75,39.5,-49,16.25,43.75,-7.28125,19.75,41.25,-39.25,-8.8125,18.25,-14.5,14.9375,15.8125,-0.07861328,-28.125,18,-45.5,49.5,-38,-21.25,21.875,-11.1875,37,-23]" +"[0.6902099,0.98224443,0.22218531,0.6914797,0.8984686,0.55126923,0.46103066,0.62190145,0.6040562,0.61077744,0.050271552,0.13593888,0.29492554,0.4199703,0.66206455,0.024337538,0.9050209,0.21404824,0.6812337,0.80766386,0.1284866,0.47485706,0.7831489,0.44847372,0.57320356,0.09559885,0.5912016,0.95778906,0.5343507,0.37386495,0.9813698,0.06558716,0.6669166,0.5673079,0.73229057,0.14985293,0.67122597,0.19793984,0.6810366,0.26834917,0.7763995,0.8742002,0.5791059,0.5522534,0.34574932,0.9827783,0.57588506,0.64496696,0.45394954,0.0566683,0.5512641,0.26870498,0.46795076,0.46023747,0.022970546,0.74475515,0.7628229,0.90927476,0.09442218,0.7196718,0.8761881,0.07412771,0.9001479,0.45880133]","[37.75,-3.609375,-4.71875,-6.3125,25.5,-44.5,11.625,-47.5,28.75,39.25,33,-21.625,-9.125,-34.5,16.25,40.75,-42,-39,-38.5,7.75,38.25,-2.53125,4.15625,3.34375,-48.5,-23.5,16.625,-31.875,43.25,-27,-37.5,38.25]" +"[0.16948672,0.9575049,0.3795925,0.08518478,0.016287608,0.58976036,0.59772104,0.9048579,0.82033354,0.5118714,0.72459465,0.8797325,0.06387481,0.032368623,0.120871425,0.6112618,0.2680751,0.8443451,0.84437567,0.84676474,0.51409304,0.2928473,0.33529493,0.8560533,0.36477008,0.60451025,0.64234394,0.17325066,0.18338117,0.14227533,0.572398,0.5025741,0.57968044,0.049145967,0.9727344,0.7214965,0.9308159,0.12670736,0.20365737,0.62955844,0.093838066,0.040414844,0.40878707,0.044829655,0.73441744,0.72068536,0.9633076,0.80061144,0.3884941,0.99745476,0.705285,0.23640254,0.45751,0.66486984,0.8374338,0.7648719,0.52758175,0.085769,0.23309289,0.23182905,0.08052138,0.51061213,0.88071936,0.83211553]","[-46,-29.25,-23.875,8.8125,44,-34,-36,-5.5,-2.484375,9.25,19.5,0.921875,48,-41.5,36.5,-34,49,-13.125,-3.03125,-27,-42,-7.125,33.25,-37.75,9.375,-28.375,-22.875,-43.75,-46.5,-37.5,32.75,-32]" +"[0.0451265,0.60541475,0.38821563,0.1358086,0.40735292,0.7064019,0.64104766,0.62286454,0.90097314,0.81873196,0.41711873,0.64988697,0.6017051,0.9384993,0.61135375,0.98505944,0.35403264,0.47343937,0.74041086,0.575882,0.57546943,0.5348046,0.2419378,0.30408633,0.68112123,0.074941404,0.6891227,0.76770943,0.5713198,0.7303255,0.3794536,0.4202227,0.50421363,0.18496875,0.77800834,0.53761953,0.830535,0.70392984,0.5996059,0.78570336,0.7708225,0.8390538,0.5948143,0.82335913,0.50793815,0.9991803,0.6457372,0.41689986,0.4506702,0.7802623,0.7588462,0.7146182,0.122038245,0.59240955,0.56031626,0.11044377,0.7592565,0.16111268,0.86032134,0.41119638,0.4519747,0.5845934,0.97738427,0.40037072]","[3.703125,35.75,45.25,-23.25,38.75,-37,15.375,-8.3125,28.375,5.625,38,-49,-0.30859375,-3.5625,-29.625,-35.5,45.5,-12.75,26.375,-12.9375,24,-46.25,16,5.21875,-43.75,43.75,45.75,2.875,-37.5,-24.5,37.25,34.75]" +"[0.33775133,0.7142587,0.16717607,0.5041431,0.018830217,0.020720925,0.9299879,0.22351491,0.3703962,0.5971543,0.312481,0.10496273,0.46240747,0.98351574,0.8644343,0.39652428,0.69275993,0.3702478,0.95464313,0.0829308,0.87240285,0.8567406,0.16973004,0.17440762,0.9024105,0.5958147,0.6128333,0.4198848,0.2195047,0.12719461,0.8150755,0.124573626,0.4458906,0.7662177,0.61000544,0.8290669,0.79503375,0.23245706,0.5659252,0.97921586,0.053913906,0.7101385,0.4600243,0.9862773,0.33930722,0.07818037,0.20072675,0.5871471,0.9511934,0.52472174,0.5066403,0.97685474,0.020058872,0.9872218,0.81309503,0.13434742,0.865375,0.5867703,0.3161596,0.74259573,0.30665305,0.63296074,0.65004337,0.42499596]","[-20.375,-12.125,-34,36,-32.75,12.8125,17.25,38.25,7.15625,39.5,32,7.09375,-42.5,-43.25,23.75,24.375,16.125,15.8125,-7.5625,-1.3515625,-48.5,26.75,-11.9375,-16,-39.75,27,18.625,-24,5.6875,15.0625,21,29.625]" +"[0.68865955,0.3952261,0.35932708,0.7778047,0.48242876,0.2205962,0.69932187,0.15988348,0.0068898103,0.35140395,0.81154877,0.9159422,0.8053033,0.23315075,0.20349061,0.5079615,0.263592,0.13210902,0.3829875,0.71468174,0.90841913,0.7422445,0.03184946,0.75469244,0.54524183,0.9397291,0.29475084,0.20032765,0.035300445,0.27699664,0.23560034,0.37525773,0.6289305,0.88848585,0.29377526,0.89954096,0.93591875,0.40914434,0.15751396,0.31507373,0.252567,0.20852126,0.44268107,0.72115725,0.23662059,0.541619,0.769528,0.22597155,0.39627573,0.58671665,0.6038382,0.32185254,0.29310963,0.60472393,0.85706747,0.21358219,0.6259573,0.3255484,0.94550174,0.52363193,0.8917227,0.19709313,0.16709,0.67218226]","[-47.25,-49.5,-27,29.5,25,46,-27,-38.5,-8.125,-1.390625,11.4375,-15.625,-33,-5.96875,36.25,2.0625,-23.75,-32,39.75,34.25,-39.75,-3.96875,47.5,46.5,-11.4375,21.75,-17.875,24.625,-17.25,1.5859375,11.4375,-40.5]" +"[0.53221714,0.31703654,0.12367431,0.37123778,0.5786093,0.40455657,0.81205034,0.7697503,0.7440103,0.61338866,0.8620964,0.35101637,0.55773807,0.7073472,0.90236205,0.012203732,0.8305356,0.38372755,0.9811637,0.12752098,0.78417903,0.64781463,0.43097755,0.9374458,0.85225165,0.11371868,0.91867346,0.60396516,0.5908196,0.8342869,0.8465178,0.42363524,0.19117841,0.99700767,0.7836377,0.2743451,0.008808918,0.09673844,0.23757777,0.013774986,0.8616869,0.10921093,0.75938654,0.83657676,0.854834,0.12495352,0.03137041,0.7315528,0.83934873,0.3441762,0.9338948,0.30879265,0.38860914,0.6108482,0.8722764,0.15569116,0.33042416,0.6898502,0.58751315,0.24895883,0.16271788,0.37549835,0.03517723,0.8451407]","[-14.875,26.875,-7.5,-43.25,-39.5,-0.95703125,-10,4.875,-42.25,-29.875,-47.75,1.9609375,-5.125,46,-35.25,30.375,38,28,-38.25,13.4375,-9.5,37.75,-0.44140625,-49.75,-35.75,40.25,-7.15625,-5.25,36,33.25,-12.25,15.6875]" +"[0.70913064,0.09153739,0.3510383,0.41121602,0.77492267,0.77227026,0.14357337,0.23699473,0.9657712,0.42939368,0.19323483,0.8227475,0.41756627,0.036271546,0.97857964,0.2140414,0.13451423,0.4546758,0.9229821,0.41974136,0.7689069,0.600089,0.18438864,0.46165913,0.9403688,0.07783584,0.08708499,0.12855059,0.56729037,0.13711517,0.7408898,0.19447267,0.9542179,0.52915245,0.5065635,0.5120173,0.72938573,0.53960365,0.96988773,0.2019615,0.93281883,0.31323054,0.5067624,0.81659204,0.041146982,0.81217486,0.47387466,0.36165887,0.80780596,0.010213656,0.16871852,0.6147725,0.48518685,0.7863781,0.7702899,0.5520803,0.84457064,0.69656384,0.01075882,0.4301063,0.31597665,0.3964297,0.4630467,0.062412146]","[40.5,26.5,19,28.125,-21.125,-21.375,-25.5,-13.1875,-2.265625,19.25,9.9375,-22.75,-28.5,40.25,46.5,-35,19.25,27.125,-13.75,47.75,6.625,5.28125,-16,32.25,16.5,34.75,-22.75,4.3125,-46,-14.1875,0.41601562,-21]" +"[0.7212016,0.14879422,0.15411805,0.47430596,0.31046718,0.93619925,0.5855448,0.8669951,0.9407336,0.88859427,0.085005954,0.60744554,0.88299644,0.9697482,0.25779396,0.2964569,0.120682776,0.68194413,0.15227231,0.94925433,0.12765075,0.08659617,0.8273684,0.050902776,0.36514854,0.25305945,0.9916572,0.018880643,0.107069984,0.14715469,0.30740333,0.35442874,0.68131757,0.049373966,0.14957382,0.63987935,0.6473984,0.77352685,0.22153533,0.8499598,0.3043118,0.9332364,0.70772636,0.96495324,0.64936537,0.68704516,0.7856882,0.9231049,0.8692283,0.2292048,0.38849202,0.4846973,0.5253029,0.12725607,0.08825746,0.23385529,0.5240396,0.9025833,0.72952735,0.95576304,0.30167055,0.21382265,0.49282584,0.53997785]","[-29.875,-42.25,-21.875,-11.4375,35.75,35,-26.5,6.34375,-3.46875,-31.75,16,-32.25,-10,-21.125,-8.4375,-31.875,-14.8125,-48.5,-16.75,-3.71875,0.83984375,-42.5,-15.25,37.25,-44,-20.25,-15.625,25.125,-13.375,-43,8.375,6.15625]" +"[0.2941286,0.05588962,0.0945542,0.17373852,0.9825257,0.1867211,0.9720306,0.02264046,0.8064447,0.7281826,0.46117583,0.15424368,0.9838038,0.4522104,0.09307483,0.62729234,0.15407649,0.7822393,0.00022227065,0.8428649,0.9181278,0.20095313,0.10838426,0.46968827,0.56839687,0.85761166,0.290319,0.65864223,0.4024475,0.7558779,0.7552013,0.5758064,0.21415307,0.6105683,0.84566474,0.69851464,0.12443008,0.6647433,0.1331963,0.3596618,0.1766836,0.6218182,0.88579494,0.43310788,0.38554975,0.12013579,0.4562973,0.032003928,0.9171758,0.30969223,0.041582666,0.8535929,0.37917158,0.5298653,0.966817,0.81219584,0.56475717,0.20110573,0.14621168,0.67411035,0.23898682,0.12339112,0.74271977,0.16191448]","[2.640625,-13.625,21.5,-38.25,42.75,37.75,41.25,-48.5,40.25,-32,33.75,29.625,-38.25,-15,-45.25,-14.625,47,49.75,-7.5625,-2.375,-47.75,27.75,-26.375,-47.5,48.5,8.0625,-36.75,-24.625,48,34.5,31.875,-20.75]" +"[0.7057963,0.56331354,0.44751963,0.40668863,0.5748692,0.30964687,0.9080785,0.06013386,0.032917127,0.10080068,0.060017936,0.1487172,0.5454347,0.2590642,0.75144476,0.8042801,0.74742615,0.30859333,0.32412142,0.8664449,0.91918546,0.09394556,0.14499146,0.604724,0.16566844,0.7198509,0.554697,0.0091265505,0.6616119,0.80082613,0.16088824,0.592572,0.9944482,0.052720886,0.075207226,0.8796323,0.6787902,0.2452097,0.26971608,0.035033707,0.54822326,0.9025232,0.24965756,0.213599,0.023935439,0.25288415,0.85862446,0.7515387,0.6376835,0.87241215,0.8046715,0.91212434,0.7492022,0.7919578,0.54521215,0.81078136,0.10937383,0.4528885,0.06699998,0.29373726,0.21044171,0.8362038,0.19054069,0.698287]","[-10.75,10.5,48,20.625,-44,-23.125,-33.5,49.75,20.875,43,8.3125,28.25,20.625,-14.0625,-14.3125,42,-27.875,-6.375,-45.5,-16.375,36.25,31,-1.6171875,30.25,40.75,-5.8125,17.375,11.625,14.4375,28.5,15.4375,25.125]" +"[0.29886064,0.57163936,0.49402913,0.6051208,0.5067325,0.06964572,0.87919736,0.64867586,0.029891403,0.90953004,0.24210365,0.93326247,0.23173715,0.73860294,0.02046532,0.48912677,0.901809,0.26039478,0.36024237,0.8189891,0.87145346,0.7978932,0.5170254,0.9063963,0.14626947,0.060193393,0.14906548,0.06942293,0.8968752,0.31771415,0.49507287,0.14806636,0.17154633,0.51410675,0.5398606,0.9392697,0.0095017385,0.3666279,0.5049469,0.0047221687,0.97353053,0.6649634,0.95756835,0.1509598,0.1609192,0.6881618,0.7483769,0.008964914,0.038817745,0.7985935,0.3759172,0.02065654,0.8048646,0.0646807,0.3956569,0.3346578,0.80647177,0.57516277,0.48648122,0.6901435,0.9588674,0.613545,0.3147489,0.053555097]","[43.75,13.3125,46.5,-17.375,-6.1875,34.25,2.484375,10.75,37.75,-10.5625,25,42.25,-1.3046875,-28.25,44.75,-46.5,41.25,-26.125,-15.9375,-23.5,-1.7734375,-8.5,-43.25,19.875,-42,47.75,4.125,19.375,45,-39.25,35,-26.25]" +"[0.41080484,0.78054035,0.73171014,0.09953439,0.7414799,0.68884426,0.41593653,0.864128,0.59249514,0.2533577,0.7413935,0.74517626,0.15079165,0.27928424,0.19704111,0.8515408,0.059866887,0.4264866,0.38519678,0.61162806,0.13917577,0.14790101,0.70107114,0.113126546,0.9527641,0.17382653,0.12042329,0.16552733,0.118057646,0.7637158,0.80186373,0.30292046,0.9018716,0.5088984,0.8177527,0.5596252,0.6556563,0.7686984,0.70946074,0.7283415,0.86963475,0.7822673,0.9029464,0.5933623,0.95737994,0.7184237,0.13221411,0.66143596,0.8278681,0.42172846,0.625256,0.72504324,0.17468394,0.88933617,0.07761316,0.90265656,0.9249012,0.9934345,0.70094585,0.2790462,0.69527876,0.028818967,0.10726786,0.28990188]","[-8.875,7.8125,-37,27.125,3.671875,-49.5,-28.625,20.75,-30.25,18.375,22.375,40.25,-23.5,38.5,39.25,-33,32.25,-11.5,-25.125,13.4375,-2.15625,0.6328125,-32,43.5,-41.75,-48.25,47,-32,14.9375,19,33,29.625]" +"[0.10807366,0.64723665,0.76682436,0.21902704,0.18862714,0.12490884,0.91295946,0.85908,0.0729091,0.11885392,0.72594243,0.2374655,0.95494336,0.9474077,0.6307225,0.94349605,0.3202401,0.052974805,0.7705078,0.21659245,0.7661481,0.542842,0.2971649,0.73128706,0.18375313,0.66676605,0.13937898,0.91315055,0.7388371,0.9611881,0.85258114,0.43082616,0.341551,0.32125255,0.2863824,0.019052489,0.8635858,0.8481157,0.42446804,0.47878045,0.06684261,0.88087785,0.9625744,0.75272644,0.642158,0.2668818,0.15240216,0.44796124,0.9460542,0.1687962,0.6934991,0.7180676,0.5552552,0.29416013,0.8391509,0.035606824,0.9554765,0.7895169,0.041703008,0.10529966,0.5603025,0.2006253,0.24470942,0.9021879]","[-17.375,12.0625,8.0625,33.25,0.24609375,43.5,42,46.5,23.875,-25.625,32.25,20.625,-16,48,-41.25,47.5,-45.5,-10.0625,-46.5,36.25,-35.5,-10.5,-4.625,-32.75,1.2578125,40.25,-30.25,44.5,-4.6875,17.375,39.25,1.203125]" +"[0.79822165,0.5271812,0.13875912,0.83661646,0.086049944,0.94509673,0.5090812,0.020730898,0.52233434,0.02478148,0.18738304,0.4855189,0.7522907,0.43971357,0.7105382,0.6939131,0.68663627,0.21243666,0.5401683,0.4675785,0.3939104,0.38796425,0.44399428,0.7734535,0.6469042,0.34907675,0.8433964,0.366671,0.7816779,0.19547805,0.68406016,0.4401043,0.19950621,0.10675324,0.08639799,0.80655015,0.08704111,0.6185073,0.25382906,0.15188126,0.95612794,0.9772172,0.6357931,0.36000025,0.24227731,0.8651025,0.30878764,0.42448026,0.72468096,0.37743565,0.76740265,0.98362637,0.6218768,0.71063966,0.9999021,0.8149579,0.9747628,0.84297407,0.10285088,0.284958,0.49059564,0.2595358,0.6281419,0.48755494]","[-33.25,-18.125,-0.33398438,49,6.8125,-9.8125,4.3125,-20.25,4.25,-37,12.25,-28.375,-18.625,-43.5,13.125,5.53125,40.5,-40.75,15.0625,34,24.75,19.75,10.8125,-19.75,-21.375,9.125,-33.75,7.59375,24.75,0.86328125,-15.8125,-5.40625]" +"[0.6400245,0.9314587,0.77195305,0.7405903,0.32126865,0.9067161,0.10703154,0.79777914,0.019302603,0.5520549,0.17404573,0.30362058,0.8353563,0.9799697,0.062175352,0.58681643,0.2850037,0.9026989,0.89349186,0.78713876,0.20984472,0.3638,0.28322792,0.50515467,0.97422427,0.9753932,0.433162,0.13382635,0.1303556,0.39882714,0.41078517,0.5526825,0.8061633,0.025483284,0.63163257,0.93885165,0.22354567,0.6835038,0.56764346,0.26103577,0.519785,0.008365882,0.41120976,0.7068035,0.7767702,0.79923725,0.3299179,0.32560846,0.5317939,0.15270999,0.6416277,0.32403964,0.58708435,0.44047928,0.30407372,0.3571986,0.11844085,0.892204,0.2689286,0.54838794,0.9852467,0.007436984,0.11179705,0.93955535]","[-0.18945312,-35,8.625,-47.25,-13.125,-47,-5.9375,3.234375,41.5,4.09375,43,16.375,-30,16.125,-19.75,31.625,-4.5,-33,26.75,-42.25,-13.5,29.625,-2.015625,2.65625,-42.5,-24.625,48,9.75,-39.5,-19.25,-2.9375,-37.5]" +"[0.005972577,0.82245547,0.07293866,0.3847261,0.117394984,0.042442378,0.07845569,0.2573438,0.44386873,0.5658583,0.41173953,0.34131524,0.81509703,0.9902378,0.34509775,0.15409766,0.3977313,0.34469965,0.08933301,0.1203193,0.7103826,0.61375624,0.8445354,0.74636066,0.5539782,0.18000828,0.50231653,0.9041114,0.12067462,0.18596888,0.12442492,0.9061718,0.9430782,0.4109052,0.83770263,0.16011941,0.38389832,0.28274915,0.38489574,0.66684234,0.5425202,0.14599892,0.99657404,0.53798956,0.20179889,0.096637286,0.9777572,0.936378,0.75759625,0.8248537,0.92863977,0.5866596,0.15971424,0.8400449,0.23035757,0.6498295,0.8061774,0.95671976,0.91081786,0.47023678,0.73047745,0.6982697,0.9128964,0.086431995]","[1.3984375,-20,-27.5,-42.75,6.25,2.921875,8.1875,-12.5625,-14.375,-23.5,-36.25,29.75,-28.5,-28.875,-4.53125,-19.5,24.375,-8.4375,43.25,17.375,-34.25,-32.5,-14.25,36.25,-6.6875,-2.265625,-11.75,9.5625,31.875,-5.40625,-44.75,27.875]" diff --git a/demo/test_json_and_csv_467187962003049091.json b/demo/test_json_and_csv_467187962003049091.json new file mode 100644 index 0000000000000..a80523a9a7b32 --- /dev/null +++ b/demo/test_json_and_csv_467187962003049091.json @@ -0,0 +1,10202 @@ +[ + { + "bfloat16VecField": [ + -30.875, + -16.5, + 43.25, + -14.5, + -23.5, + -35.5, + -40.75, + -48.75, + -28.375, + -6.8125, + 31, + 24.125, + -40.75, + -33, + -10.9375, + 41.5, + -19.875, + -22.25, + -23.75, + -24.75, + -49.25, + 45.75, + 17.625, + 25.75, + 5.5625, + -41.5, + 4.875, + -45.75, + 13.375, + -8.1875, + -49, + -14.75 + ], + "floatVecField": [ + 0.97348994, + 0.18364559, + 0.6716139, + 0.20463996, + 0.57509786, + 0.45693088, + 0.13706304, + 0.517287, + 0.0713821, + 0.21587422, + 0.81239706, + 0.20871876, + 0.7321938, + 0.23226695, + 0.92166007, + 0.6227395, + 0.77176344, + 0.46152914, + 0.66455275, + 0.10684287, + 0.08330721, + 0.26829684, + 0.7108264, + 0.7678311, + 0.8942481, + 0.6457155, + 0.7339568, + 0.33626968, + 0.28574064, + 0.070123635, + 0.35644034, + 0.46906093, + 0.75922084, + 0.19228822, + 0.4871467, + 0.13720034, + 0.656826, + 0.7359651, + 0.4970803, + 0.9326413, + 0.86367774, + 0.028827066, + 0.011074921, + 0.6227414, + 0.7434625, + 0.65636104, + 0.25148666, + 0.5988423, + 0.4599008, + 0.5767946, + 0.35443264, + 0.21729577, + 0.73187155, + 0.7531751, + 0.9545665, + 0.6407624, + 0.083856426, + 0.9700598, + 0.11429237, + 0.09858969, + 0.27599254, + 0.34086728, + 0.7753307, + 0.5287368 + ] + }, + { + "bfloat16VecField": [ + -40.75, + -2.5625, + 2.71875, + -41.75, + -34.5, + -14.8125, + -9, + -26.125, + 11.9375, + -23, + -22.5, + -47.75, + 38.25, + 49.5, + -24.125, + 47.25, + -38.5, + -0.6171875, + -22.875, + -8.5625, + -39.25, + 19, + 39.75, + 28.875, + 23.125, + -44, + 39.75, + -43, + 39.75, + 44.75, + 12.125, + 33.25 + ], + "floatVecField": [ + 0.34637263, + 0.23768362, + 0.60299087, + 0.65930265, + 0.9100921, + 0.14951335, + 0.63095003, + 0.15575668, + 0.27580455, + 0.56351537, + 0.8229619, + 0.220444, + 0.47312713, + 0.7899019, + 0.32410443, + 0.56647563, + 0.30353814, + 0.51607203, + 0.63875335, + 0.10060371, + 0.13512675, + 0.88269055, + 0.5497201, + 0.903678, + 0.10761932, + 0.11039449, + 0.31188822, + 0.054963984, + 0.6287179, + 0.041096147, + 0.5543064, + 0.85241395, + 0.24707921, + 0.9641096, + 0.16803393, + 0.22942996, + 0.44259867, + 0.28599912, + 0.66586655, + 0.47897705, + 0.5640338, + 0.3783989, + 0.39029378, + 0.18201236, + 0.7640742, + 0.18579623, + 0.37209928, + 0.09477112, + 0.9795771, + 0.7245206, + 0.17083699, + 0.10943091, + 0.19379431, + 0.45949128, + 0.41637745, + 0.6238885, + 0.6281464, + 0.0005543964, + 0.124373205, + 0.97009754, + 0.77245295, + 0.16028471, + 0.5306067, + 0.5362056 + ] + }, + { + "bfloat16VecField": [ + -0.265625, + -40.25, + 30.75, + -15.875, + -0.83984375, + 27.625, + -35.5, + -35.5, + 46.75, + 16.25, + 25.375, + 19, + 29.125, + -15.375, + -37.5, + -38.5, + -36.75, + -31.25, + -48.75, + 16.375, + 46.25, + -32.5, + -32, + -46.5, + 42.25, + -24.75, + 48, + -1.09375, + 19.875, + -25.375, + 47.75, + -49.5 + ], + "floatVecField": [ + 0.25307462, + 0.9872258, + 0.44600967, + 0.075478755, + 0.9486995, + 0.9009919, + 0.29920828, + 0.9820183, + 0.272393, + 0.5256052, + 0.044662315, + 0.77258766, + 0.8626149, + 0.15176587, + 0.5436234, + 0.13494818, + 0.3362146, + 0.578164, + 0.0008220642, + 0.27371693, + 0.9080775, + 0.1881627, + 0.11150463, + 0.027746601, + 0.84949434, + 0.64284796, + 0.47510538, + 0.28471535, + 0.49133438, + 0.7133074, + 0.28427622, + 0.42002177, + 0.6750507, + 0.37031648, + 0.861757, + 0.90506136, + 0.024661234, + 0.042512417, + 0.058254257, + 0.033570822, + 0.31268135, + 0.29207322, + 0.38480276, + 0.6721591, + 0.6292683, + 0.29018563, + 0.11475523, + 0.2667002, + 0.11117055, + 0.9129727, + 0.35568568, + 0.62278587, + 0.81989634, + 0.59021765, + 0.09781845, + 0.16867769, + 0.4618155, + 0.5392846, + 0.512941, + 0.2509213, + 0.9334666, + 0.79376036, + 0.47073153, + 0.8402677 + ] + }, + { + "bfloat16VecField": [ + 24.875, + 28, + -11.375, + 2.265625, + 15.375, + -13.375, + -8.9375, + -24.875, + 0.16308594, + -39, + 0.33203125, + 32.5, + 31.875, + 37.25, + 32.25, + 33.75, + -27.75, + -30, + 44.75, + -49.5, + -49, + -30.375, + -41, + 32, + -49, + -25.25, + 13.5625, + -46, + -38.25, + 49.5, + -5.90625, + 2.28125 + ], + "floatVecField": [ + 0.16709034, + 0.1681943, + 0.45612663, + 0.4607479, + 0.0058467207, + 0.82111937, + 0.6279681, + 0.8022256, + 0.31040236, + 0.9327161, + 0.91985595, + 0.54809463, + 0.90015477, + 0.4569153, + 0.88664174, + 0.7005615, + 0.65880346, + 0.5913372, + 0.0381357, + 0.42188135, + 0.7213677, + 0.15147918, + 0.89300984, + 0.32582557, + 0.6030773, + 0.23668718, + 0.2075812, + 0.085374676, + 0.93043417, + 0.25299233, + 0.99416053, + 0.12828036, + 0.4665877, + 0.54140556, + 0.23728584, + 0.115998626, + 0.16913502, + 0.47984004, + 0.6259136, + 0.10520846, + 0.37114084, + 0.33562395, + 0.8212617, + 0.63926864, + 0.45487127, + 0.8827456, + 0.1339406, + 0.7283109, + 0.9123077, + 0.061809905, + 0.2730222, + 0.4671232, + 0.47050637, + 0.5351327, + 0.49810633, + 0.82329, + 0.90303195, + 0.4736466, + 0.51660144, + 0.0021384705, + 0.40913504, + 0.35294822, + 0.61203915, + 0.87553334 + ] + }, + { + "bfloat16VecField": [ + -46.25, + 7.03125, + -42.25, + 39, + 14.8125, + 25.5, + -42.75, + -32.25, + -6.3125, + 36, + -22.375, + -1.15625, + -9.4375, + 44.5, + -20.75, + 4.53125, + 29.625, + 18.125, + 28.5, + -34.75, + -22.875, + -21.125, + 21.875, + 17.125, + 49.75, + -33.25, + -27.375, + -8.6875, + -7.28125, + 7.78125, + -35.75, + 26.75 + ], + "floatVecField": [ + 0.28421116, + 0.95462996, + 0.5257625, + 0.22289458, + 0.8954739, + 0.7602569, + 0.32490402, + 0.08582327, + 0.64089316, + 0.7335192, + 0.07622238, + 0.8058913, + 0.64390326, + 0.2049538, + 0.42150012, + 0.9924657, + 0.8694121, + 0.69368064, + 0.5194918, + 0.98419785, + 0.2955615, + 0.39170384, + 0.25644708, + 0.6266737, + 0.80696994, + 0.23746409, + 0.9872296, + 0.15483773, + 0.6710551, + 0.1287496, + 0.9081415, + 0.30871594, + 0.11731259, + 0.13496596, + 0.10583648, + 0.97652227, + 0.10043594, + 0.5053965, + 0.19585621, + 0.605663, + 0.38115332, + 0.76087725, + 0.36209726, + 0.53249115, + 0.6645863, + 0.009721886, + 0.75737005, + 0.35597673, + 0.007704003, + 0.0955044, + 0.44569203, + 0.77102375, + 0.885146, + 0.20357542, + 0.73024887, + 0.21706647, + 0.7450936, + 0.27002552, + 0.3777483, + 0.6410288, + 0.5266314, + 0.6563401, + 0.9073752, + 0.6234989 + ] + }, + { + "bfloat16VecField": [ + -34.75, + 23.25, + -19, + -3.15625, + -40.25, + -38, + -7.59375, + -18.375, + 10.5625, + -46.5, + -37.5, + 47.75, + -10.6875, + 38, + -29.625, + -34, + 36, + -36.75, + 39, + 5.0625, + -46.5, + -13.125, + -21.125, + 23.25, + 48, + -42.5, + -48.25, + -42.5, + 0.76171875, + 43.75, + -10.8125, + -17.5 + ], + "floatVecField": [ + 0.32428828, + 0.11752425, + 0.7936253, + 0.41004953, + 0.086844586, + 0.09386198, + 0.88079345, + 0.1756856, + 0.6393012, + 0.65844625, + 0.6087387, + 0.45477378, + 0.96902394, + 0.06185263, + 0.14100014, + 0.7657615, + 0.75533766, + 0.85989106, + 0.0578442, + 0.39673364, + 0.6411922, + 0.5912149, + 0.991238, + 0.6496897, + 0.021369701, + 0.3051289, + 0.17906973, + 0.77825415, + 0.70463765, + 0.22987871, + 0.12203348, + 0.71205413, + 0.2893173, + 0.28266943, + 0.57392114, + 0.5011839, + 0.4423967, + 0.26680863, + 0.2910336, + 0.68488884, + 0.15791838, + 0.30688635, + 0.29408342, + 0.59892714, + 0.30814147, + 0.7606118, + 0.6250631, + 0.14361727, + 0.87935966, + 0.56918967, + 0.2438965, + 0.63934314, + 0.48773474, + 0.48326603, + 0.747472, + 0.3824442, + 0.44222033, + 0.2729365, + 0.9472284, + 0.6822347, + 0.050450075, + 0.2954289, + 0.60584176, + 0.5517175 + ] + }, + { + "bfloat16VecField": [ + -12.125, + 10.6875, + -46.75, + -17.875, + 6.90625, + 35.5, + -2.4375, + 35, + -24, + -13.1875, + -39.25, + -20.625, + 30.125, + 34.25, + 25.875, + 24.875, + 31.125, + 31, + 23.375, + 32, + -32.25, + 16.25, + 35.25, + -31.125, + 21, + 1.0859375, + 35.75, + 12.1875, + -32, + -49.25, + 18.75, + 14.375 + ], + "floatVecField": [ + 0.27866107, + 0.6864951, + 0.23104423, + 0.39041388, + 0.37719896, + 0.539066, + 0.41324666, + 0.7919707, + 0.557868, + 0.9792702, + 0.52724445, + 0.64236146, + 0.93117225, + 0.49009228, + 0.93809795, + 0.1937529, + 0.9086407, + 0.9396348, + 0.6325006, + 0.14250496, + 0.38069046, + 0.6586242, + 0.0548663, + 0.65777266, + 0.514667, + 0.37149078, + 0.13315156, + 0.67234915, + 0.7647139, + 0.61816084, + 0.17207468, + 0.5460472, + 0.4997434, + 0.27914816, + 0.9301988, + 0.53649944, + 0.74805915, + 0.40706193, + 0.24986221, + 0.28296795, + 0.5877666, + 0.07091055, + 0.6173606, + 0.5639981, + 0.424668, + 0.93183744, + 0.5112666, + 0.31357867, + 0.595813, + 0.37388575, + 0.1340366, + 0.52229744, + 0.8537664, + 0.58238083, + 0.42522362, + 0.7306344, + 0.0012664407, + 0.2615153, + 0.88215077, + 0.20272318, + 0.71320987, + 0.79268295, + 0.43021673, + 0.54955065 + ] + }, + { + "bfloat16VecField": [ + 22.5, + 39, + 44.75, + 9.5625, + -31, + 8.9375, + -23.75, + 37.25, + 15.5625, + 29.5, + -38.5, + 23.375, + 14.25, + -35.75, + 17.5, + -47.25, + -33.25, + -19.625, + -27, + 20.875, + 45.75, + 40, + -31, + 3.109375, + 22.625, + 19.125, + -28.375, + 39.25, + 35.5, + 19.625, + -25.5, + -35 + ], + "floatVecField": [ + 0.64058924, + 0.8298036, + 0.4536559, + 0.17740773, + 0.67104125, + 0.6451938, + 0.6198434, + 0.7098781, + 0.35507995, + 0.353629, + 0.697126, + 0.5519053, + 0.035643008, + 0.13128151, + 0.63671774, + 0.5478598, + 0.39694837, + 0.0602932, + 0.15996018, + 0.7967724, + 0.37292814, + 0.7142458, + 0.26010218, + 0.050459173, + 0.5354363, + 0.6115435, + 0.15098055, + 0.06383955, + 0.8461937, + 0.8446063, + 0.0057615805, + 0.062214784, + 0.35059336, + 0.1606821, + 0.78082603, + 0.3072225, + 0.20688187, + 0.9580441, + 0.23781, + 0.2761387, + 0.49129286, + 0.29025522, + 0.8437771, + 0.633666, + 0.7678628, + 0.36644572, + 0.22288273, + 0.36710352, + 0.46253535, + 0.38232905, + 0.21968806, + 0.28805298, + 0.4204068, + 0.35537252, + 0.4236161, + 0.55579925, + 0.9537397, + 0.96877277, + 0.4934053, + 0.5132506, + 0.9400866, + 0.56809676, + 0.9120378, + 0.69056636 + ] + }, + { + "bfloat16VecField": [ + -4.9375, + -20.25, + 26.375, + 43.75, + 45.25, + 16.375, + 34.25, + -29.5, + -18.5, + 26.25, + -39, + -42.75, + -34, + -2.109375, + 20.625, + 45, + 38.5, + 6.625, + -14.4375, + 23.75, + -8.0625, + 16, + -2.0625, + 39.75, + 8.5, + 20.125, + -37.75, + 26.875, + -14.375, + -9.375, + -27.625, + 30.125 + ], + "floatVecField": [ + 0.21394418, + 0.8803786, + 0.59326696, + 0.2635005, + 0.44496864, + 0.20757379, + 0.12691504, + 0.5892394, + 0.12053906, + 0.400156, + 0.55695367, + 0.6392792, + 0.26185372, + 0.5766776, + 0.43359068, + 0.21611054, + 0.5238496, + 0.9812925, + 0.35401326, + 0.8484357, + 0.8138693, + 0.68685234, + 0.3745619, + 0.91365606, + 0.98967564, + 0.10656149, + 0.0057758964, + 0.5822305, + 0.53485286, + 0.15947546, + 0.7499074, + 0.026259229, + 0.5488891, + 0.10990549, + 0.24323967, + 0.0061950055, + 0.40513182, + 0.94337785, + 0.97228694, + 0.18448594, + 0.15242322, + 0.61076635, + 0.00687709, + 0.6926294, + 0.8256909, + 0.5592444, + 0.6362975, + 0.58143026, + 0.33927092, + 0.35508218, + 0.632174, + 0.2215143, + 0.93502444, + 0.29045048, + 0.7371254, + 0.8706796, + 0.06881384, + 0.8374951, + 0.33070758, + 0.21209273, + 0.2935425, + 0.68212086, + 0.57471335, + 0.4870502 + ] + }, + { + "bfloat16VecField": [ + 19.5, + -46.75, + -12.3125, + -49.5, + 44, + -7.84375, + 32.25, + -23, + -48.75, + -20.25, + 32.75, + 19.875, + -17.875, + 33, + -23, + -43, + 27.75, + -2.25, + -41.25, + 16.625, + -27, + 35.25, + -3.515625, + -13.6875, + -8.8125, + 24, + -6.5625, + -10.75, + 28.5, + 18.375, + -20, + -34 + ], + "floatVecField": [ + 0.46401337, + 0.73596215, + 0.6008019, + 0.6318032, + 0.9632428, + 0.36101922, + 0.19033118, + 0.079244934, + 0.93602884, + 0.8569375, + 0.037441276, + 0.51484203, + 0.9083118, + 0.9290836, + 0.5300944, + 0.9358413, + 0.32614344, + 0.7019017, + 0.7870495, + 0.89885134, + 0.11905689, + 0.5489642, + 0.0028603014, + 0.5743859, + 0.352324, + 0.32319653, + 0.3009047, + 0.08020948, + 0.60448235, + 0.08125438, + 0.11250525, + 0.114490055, + 0.9494071, + 0.4269515, + 0.06453104, + 0.6329421, + 0.8536645, + 0.7782552, + 0.10850187, + 0.06262007, + 0.86556387, + 0.83376676, + 0.51384765, + 0.9112636, + 0.010521116, + 0.6262977, + 0.8526182, + 0.8937969, + 0.17358328, + 0.95387006, + 0.3895123, + 0.65722835, + 0.7694807, + 0.15322313, + 0.034639686, + 0.18528174, + 0.33060426, + 0.89187515, + 0.64315605, + 0.5798241, + 0.66905075, + 0.6645818, + 0.22967267, + 0.38428402 + ] + }, + { + "bfloat16VecField": [ + -1.78125, + 43, + -44.5, + 42.5, + -31.625, + 31.5, + -8.0625, + 26.75, + 7.1875, + 13.4375, + 15.125, + 35.5, + 28.75, + -46.75, + 11.0625, + -5.0625, + -24.375, + -37.5, + 32, + 48.25, + -26.875, + 6.90625, + 17.875, + -43, + -36.25, + 16.875, + 44, + -5, + 21.875, + 39.75, + 13.5625, + -26.75 + ], + "floatVecField": [ + 0.3359055, + 0.36650634, + 0.70638996, + 0.9007225, + 0.37530822, + 0.98481506, + 0.41590732, + 0.6111497, + 0.41127127, + 0.45329526, + 0.89567786, + 0.69069093, + 0.3385958, + 0.30193675, + 0.8942712, + 0.06574256, + 0.12851214, + 0.6330937, + 0.9037909, + 0.9629158, + 0.14358895, + 0.33176547, + 0.17982839, + 0.4971031, + 0.7620305, + 0.6721604, + 0.077859916, + 0.80323696, + 0.98322874, + 0.706503, + 0.018829135, + 0.2844706, + 0.4314365, + 0.5116316, + 0.59893745, + 0.54259276, + 0.29201832, + 0.011640509, + 0.8143809, + 0.33067083, + 0.22128804, + 0.33762887, + 0.59193474, + 0.60627866, + 0.46225107, + 0.08881829, + 0.18463649, + 0.47561282, + 0.062119238, + 0.13849676, + 0.3797519, + 0.06532551, + 0.41919, + 0.29777926, + 0.31073993, + 0.35748154, + 0.39336246, + 0.8996548, + 0.12587453, + 0.24607852, + 0.60509425, + 0.9789744, + 0.7842514, + 0.7583458 + ] + }, + { + "bfloat16VecField": [ + 26, + 39.75, + -9.375, + -29.875, + 28.875, + 37.5, + -46.5, + -24.75, + -34.75, + 14.875, + -1.0625, + 43.5, + -6.34375, + -16.875, + -31.125, + -20, + -44, + 2.015625, + 49.75, + -34.75, + -43.25, + 45, + -40.25, + 9.375, + 41.5, + 14.0625, + -47.75, + -25.75, + 28.75, + 17.125, + -19.375, + -33.5 + ], + "floatVecField": [ + 0.2776883, + 0.76384693, + 0.6033157, + 0.57663524, + 0.80829656, + 0.51963294, + 0.061357893, + 0.9892574, + 0.10903329, + 0.39156023, + 0.44352767, + 0.646225, + 0.3885194, + 0.085309155, + 0.8874541, + 0.40979385, + 0.2740713, + 0.8114262, + 0.93923444, + 0.6474502, + 0.636899, + 0.087418675, + 0.26908234, + 0.24798983, + 0.71043247, + 0.47945315, + 0.32372656, + 0.46957898, + 0.71219, + 0.5662497, + 0.6674871, + 0.8897923, + 0.53508556, + 0.84295803, + 0.13577196, + 0.10865966, + 0.69776434, + 0.6721364, + 0.6962641, + 0.5324952, + 0.5760644, + 0.58009857, + 0.38413116, + 0.013595484, + 0.21560541, + 0.38981703, + 0.9795545, + 0.3419762, + 0.6403787, + 0.35141543, + 0.43439904, + 0.6889035, + 0.49538517, + 0.3183865, + 0.9857907, + 0.08730436, + 0.9189867, + 0.96639824, + 0.5749706, + 0.3351115, + 0.3469733, + 0.052139003, + 0.7864675, + 0.8979334 + ] + }, + { + "bfloat16VecField": [ + -34, + 0.87109375, + -28, + 31.25, + 35.25, + -6.78125, + 17.375, + -34.25, + 20.25, + 47, + 49.75, + -22.125, + -19.375, + -23.125, + -5.4375, + -11.25, + 19.125, + 22.75, + -21.125, + 13.0625, + -31.375, + -1.2421875, + 29, + -47.25, + 46.5, + -2.140625, + 46.5, + 33.5, + 18.875, + 14.9375, + 34.75, + -41 + ], + "floatVecField": [ + 0.73742, + 0.32429233, + 0.28739044, + 0.24434929, + 0.3305654, + 0.47866106, + 0.38894334, + 0.7362975, + 0.84787244, + 0.33854246, + 0.64093184, + 0.12267356, + 0.8034362, + 0.054841828, + 0.834797, + 0.023208361, + 0.60353905, + 0.5696299, + 0.50316447, + 0.4131633, + 0.85371816, + 0.5427871, + 0.3762515, + 0.5887305, + 0.12852405, + 0.6334801, + 0.6510773, + 0.4904203, + 0.43303955, + 0.73258525, + 0.41694534, + 0.600681, + 0.38430482, + 0.97997624, + 0.4420404, + 0.35985997, + 0.669555, + 0.44183737, + 0.48907793, + 0.6849643, + 0.8463721, + 0.90953165, + 0.6546561, + 0.90593064, + 0.039145768, + 0.42149463, + 0.86003697, + 0.40871084, + 0.6175964, + 0.5870248, + 0.53178686, + 0.9646074, + 0.1576742, + 0.29814163, + 0.26920342, + 0.57536423, + 0.42117313, + 0.36000443, + 0.696141, + 0.93731123, + 0.9456217, + 0.81985146, + 0.68752474, + 0.10288522 + ] + }, + { + "bfloat16VecField": [ + -42.75, + 43.5, + 1.8203125, + 37, + -40.25, + 27.875, + -19, + -25.875, + 19.625, + -31.25, + 15.0625, + 47.75, + 35.25, + -36, + -22.75, + 32.75, + 48, + 19, + -29.875, + 20.25, + 35.5, + 4.0625, + 39, + -42.75, + 16.5, + -5.0625, + -9.875, + 40.5, + -32.5, + -42.25, + -17.75, + -9.6875 + ], + "floatVecField": [ + 0.12283583, + 0.5765568, + 0.4710808, + 0.80130905, + 0.7013543, + 0.5609381, + 0.39565894, + 0.108266205, + 0.20630361, + 0.8900755, + 0.47676376, + 0.78557885, + 0.09483836, + 0.4274831, + 0.41043174, + 0.487021, + 0.54886013, + 0.7370356, + 0.20308536, + 0.07130826, + 0.16693589, + 0.4613492, + 0.1843092, + 0.093363136, + 0.55289155, + 0.45263028, + 0.85907596, + 0.44657633, + 0.8677902, + 0.52035093, + 0.8046169, + 0.8143056, + 0.8904713, + 0.85190594, + 0.9247962, + 0.6825233, + 0.6591082, + 0.4439609, + 0.63478744, + 0.64375347, + 0.3079051, + 0.4285464, + 0.12908779, + 0.94480795, + 0.28516328, + 0.025982482, + 0.07372007, + 0.9819173, + 0.8081707, + 0.4688989, + 0.41114932, + 0.36009252, + 0.024645925, + 0.1101116, + 0.4049289, + 0.9154718, + 0.30008417, + 0.85279346, + 0.9886045, + 0.18490273, + 0.04001315, + 0.9186626, + 0.93501365, + 0.9699308 + ] + }, + { + "bfloat16VecField": [ + -23.5, + 44.75, + 43.5, + 47.75, + -33, + -21.25, + 2.03125, + -25.5, + 21, + 11.625, + -6.53125, + -24, + 43.75, + 31.625, + -13.75, + -38.25, + 20.125, + -35.25, + 9.0625, + 15.375, + -46.75, + 6.90625, + 17.125, + -4.96875, + 19.5, + -13.6875, + 15.25, + 9.625, + 5.21875, + -7.03125, + -16.75, + -10.0625 + ], + "floatVecField": [ + 0.028762847, + 0.27941975, + 0.9303923, + 0.48994824, + 0.16262482, + 0.965337, + 0.75888616, + 0.41579303, + 0.946159, + 0.6927015, + 0.42436635, + 0.30774236, + 0.58954597, + 0.4264208, + 0.020558547, + 0.23737668, + 0.4797884, + 0.7815975, + 0.1375301, + 0.59153605, + 0.10429795, + 0.10555707, + 0.20188151, + 0.16100089, + 0.8811752, + 0.7890196, + 0.094324075, + 0.42230934, + 0.34703103, + 0.24597102, + 0.92543566, + 0.2185595, + 0.1832668, + 0.92213744, + 0.043143243, + 0.99063545, + 0.05677775, + 0.024382412, + 0.50745106, + 0.8191295, + 0.15554933, + 0.3707692, + 0.12693414, + 0.046883866, + 0.8650896, + 0.12422891, + 0.47226447, + 0.77416676, + 0.14436167, + 0.48928073, + 0.90836525, + 0.24012963, + 0.13380761, + 0.2832563, + 0.66133016, + 0.8357506, + 0.63579977, + 0.40035775, + 0.11588304, + 0.2965724, + 0.8361574, + 0.58428454, + 0.80087245, + 0.47395378 + ] + }, + { + "bfloat16VecField": [ + 18, + 8.375, + 5.09375, + -44.25, + 22.875, + -21.625, + -3.953125, + 37.25, + 23.875, + 38.25, + 31.375, + 19.375, + 10.1875, + -26, + 9.1875, + 47.25, + 4.65625, + 11.875, + 17.875, + -34, + 45.75, + -2.671875, + -40.5, + -26.25, + 34.75, + -41, + 42.75, + -25.625, + -36.5, + -44.5, + 19.375, + -1.8671875 + ], + "floatVecField": [ + 0.75828224, + 0.6360404, + 0.6396807, + 0.8221486, + 0.33213413, + 0.71022356, + 0.9826681, + 0.46865833, + 0.66436785, + 0.6874459, + 0.49858198, + 0.434016, + 0.0066902665, + 0.2301574, + 0.12259166, + 0.663611, + 0.32753542, + 0.5215848, + 0.40319008, + 0.091050446, + 0.059901286, + 0.55576855, + 0.9020771, + 0.50357825, + 0.26219392, + 0.056261666, + 0.073794946, + 0.49397773, + 0.9416539, + 0.99436116, + 0.63702667, + 0.16611513, + 0.09628895, + 0.50511557, + 0.20184012, + 0.31643343, + 0.18651623, + 0.05014567, + 0.87938935, + 0.8269504, + 0.22726005, + 0.23767692, + 0.12181462, + 0.2548988, + 0.95967126, + 0.6502879, + 0.7600026, + 0.5761278, + 0.8294272, + 0.16758616, + 0.985463, + 0.5164624, + 0.76728386, + 0.7526306, + 0.32990912, + 0.21093106, + 0.903986, + 0.70921594, + 0.25244772, + 0.14884502, + 0.6317563, + 0.38768008, + 0.9358642, + 0.47929788 + ] + }, + { + "bfloat16VecField": [ + -44.75, + 29.75, + -25.75, + -4.625, + -10.6875, + 2.5625, + -33.75, + 20.875, + 3.9375, + -36, + -10.125, + 49, + 19.25, + -31.375, + -47.75, + 27.625, + -19.75, + -40.75, + 12.125, + -14.875, + -12.125, + -24.25, + -47.75, + 46.25, + -40.25, + 8.3125, + -18.75, + -40.5, + -42, + -22.875, + -8.125, + 21.25 + ], + "floatVecField": [ + 0.6211244, + 0.5705775, + 0.88791484, + 0.18245818, + 0.09596547, + 0.74524736, + 0.6013545, + 0.5735573, + 0.15821491, + 0.53634727, + 0.53039634, + 0.99963856, + 0.2669489, + 0.8582399, + 0.36571768, + 0.3822805, + 0.27181917, + 0.8714566, + 0.84658974, + 0.14115678, + 0.82673013, + 0.75578904, + 0.20929545, + 0.39020976, + 0.99781275, + 0.7300232, + 0.54126567, + 0.3541417, + 0.9153565, + 0.23365292, + 0.6043925, + 0.47538623, + 0.8530119, + 0.05719497, + 0.7470376, + 0.17420568, + 0.058357146, + 0.47356153, + 0.25266516, + 0.7313314, + 0.9423595, + 0.82565004, + 0.18538533, + 0.6867203, + 0.62170184, + 0.06975726, + 0.28044504, + 0.81389374, + 0.6609742, + 0.544265, + 0.77674866, + 0.8149686, + 0.07410577, + 0.9296572, + 0.49229655, + 0.024514182, + 0.29650778, + 0.99735266, + 0.97337115, + 0.5008498, + 0.7505369, + 0.04490735, + 0.48370942, + 0.21063031 + ] + }, + { + "bfloat16VecField": [ + 27.375, + 45.75, + 45, + -2.75, + 28, + -0.22167969, + 41.75, + 42.25, + -3.625, + 49.5, + -45.5, + 43.5, + 25.875, + 20, + 6, + 12, + -35.25, + 28.375, + -34.75, + -41.25, + 11.6875, + 28.5, + -33, + -12.25, + -5.03125, + 1.3203125, + -29.875, + 44.75, + 38.5, + -5.40625, + 23.625, + -28.625 + ], + "floatVecField": [ + 0.569393, + 0.39842245, + 0.8942473, + 0.73866874, + 0.9226515, + 0.39548418, + 0.5742803, + 0.7604963, + 0.8656194, + 0.26495025, + 0.99367034, + 0.4640038, + 0.30375698, + 0.16850446, + 0.18695499, + 0.15006012, + 0.48521426, + 0.34252387, + 0.8646098, + 0.8914876, + 0.15668154, + 0.124970466, + 0.11673733, + 0.34939864, + 0.07703897, + 0.6997089, + 0.40332606, + 0.41685033, + 0.35367563, + 0.0068761674, + 0.11804945, + 0.62437594, + 0.36739963, + 0.14212708, + 0.00053609576, + 0.648054, + 0.27888206, + 0.29385093, + 0.05058863, + 0.30484825, + 0.49351913, + 0.10984526, + 0.091909476, + 0.12092972, + 0.023253923, + 0.3013809, + 0.73646146, + 0.32846656, + 0.7955981, + 0.24448453, + 0.70034164, + 0.7386655, + 0.36937568, + 0.03367012, + 0.35761696, + 0.62446314, + 0.75031495, + 0.313681, + 0.010776882, + 0.66394067, + 0.10428341, + 0.03507068, + 0.05224171, + 0.6226092 + ] + }, + { + "bfloat16VecField": [ + -1.9375, + 11.5625, + 13.75, + -3, + 44.75, + 11.375, + 2.0625, + -49.25, + 0.859375, + -9.125, + -22.125, + 13.5625, + -1.1015625, + 26.375, + 12.0625, + -44.25, + 48.25, + -8.875, + 1.7109375, + -28.625, + 26.5, + -8.6875, + -3.5, + -27.375, + 22.5, + -1.7265625, + -39.25, + -11.75, + 5.53125, + 20, + -38, + 30.125 + ], + "floatVecField": [ + 0.09182283, + 0.051410355, + 0.4750939, + 0.81628114, + 0.30347037, + 0.99693286, + 0.29459754, + 0.5573521, + 0.52623814, + 0.30696124, + 0.54542285, + 0.8142954, + 0.7441471, + 0.67631066, + 0.50009286, + 0.27428457, + 0.32501298, + 0.66093683, + 0.50093406, + 0.86541677, + 0.7803987, + 0.89975023, + 0.8360166, + 0.82769996, + 0.25328812, + 0.27686656, + 0.9047943, + 0.71790886, + 0.9898632, + 0.1642593, + 0.91347104, + 0.48457193, + 0.97333884, + 0.0805903, + 0.41340074, + 0.10077296, + 0.95255524, + 0.29462913, + 0.18480201, + 0.13791032, + 0.017938409, + 0.91861653, + 0.3038616, + 0.0026358513, + 0.35139292, + 0.87712544, + 0.18181235, + 0.2515791, + 0.9204611, + 0.97031623, + 0.8209888, + 0.16220012, + 0.53959966, + 0.05963805, + 0.5987683, + 0.85977507, + 0.14232607, + 0.456454, + 0.45097867, + 0.7314165, + 0.12813824, + 0.97759485, + 0.23871897, + 0.42167157 + ] + }, + { + "bfloat16VecField": [ + 28.25, + -31, + -2.265625, + -41.25, + -37, + -17.75, + 7.9375, + 39.5, + 0.068359375, + 44.5, + -8.75, + -46.5, + 11.875, + -38.75, + 31.375, + 43.5, + 0.859375, + -47.5, + -34.75, + -8.875, + -34, + -3.390625, + 13.375, + 8.875, + -16.375, + 20, + 19, + -37.5, + -14.625, + -5.34375, + 18.125, + -21.875 + ], + "floatVecField": [ + 0.20111826, + 0.20889272, + 0.12222279, + 0.76202977, + 0.018384872, + 0.24230948, + 0.34587637, + 0.52689403, + 0.66951734, + 0.1496474, + 0.3116213, + 0.12640415, + 0.9228701, + 0.6887756, + 0.47808143, + 0.9744557, + 0.42782384, + 0.14779454, + 0.29326874, + 0.4091614, + 0.9753717, + 0.3667738, + 0.8955053, + 0.31327233, + 0.36053348, + 0.3075239, + 0.26726994, + 0.16763276, + 0.09859781, + 0.23636293, + 0.6144414, + 0.45849714, + 0.030117346, + 0.033925407, + 0.4223073, + 0.7784983, + 0.07586549, + 0.47580862, + 0.16691828, + 0.31334838, + 0.9568735, + 0.15787178, + 0.7469526, + 0.41239074, + 0.7959145, + 0.8359251, + 0.060103722, + 0.7655388, + 0.7992088, + 0.000079807316, + 0.46803132, + 0.34542906, + 0.6481989, + 0.36634463, + 0.5472488, + 0.6414198, + 0.49911073, + 0.30512, + 0.0409139, + 0.1050434, + 0.96140176, + 0.97850037, + 0.93475854, + 0.19143914 + ] + }, + { + "bfloat16VecField": [ + 27.375, + 8.4375, + 10.125, + -34.75, + 0.40039062, + -2.453125, + -31, + 21.625, + 36.25, + -30.75, + 16.25, + 40.25, + -26, + -45.25, + 14.4375, + -8.125, + 15.8125, + -7, + 42.25, + -17.5, + 0.4140625, + 25.125, + -27.75, + -9.375, + -28.625, + 10.25, + -45.75, + 39.75, + -27.125, + 42.5, + -39.75, + 44.25 + ], + "floatVecField": [ + 0.08775939, + 0.4283646, + 0.7101789, + 0.27748132, + 0.52810293, + 0.5816647, + 0.083301455, + 0.5511972, + 0.54855996, + 0.49592072, + 0.31549463, + 0.7146988, + 0.23766331, + 0.8163928, + 0.86329293, + 0.99798346, + 0.61779463, + 0.0008762518, + 0.635903, + 0.30710483, + 0.48023742, + 0.4067054, + 0.1027289, + 0.9947169, + 0.47321212, + 0.28408945, + 0.78242576, + 0.13549061, + 0.97861296, + 0.051200286, + 0.6165857, + 0.643406, + 0.14612742, + 0.8751349, + 0.44809186, + 0.6548863, + 0.66078967, + 0.88808805, + 0.74504644, + 0.31832874, + 0.78177, + 0.44134045, + 0.3762482, + 0.9297851, + 0.43945086, + 0.8028106, + 0.64344674, + 0.8784638, + 0.28681245, + 0.7922464, + 0.70464516, + 0.3839366, + 0.26162437, + 0.3274395, + 0.72155136, + 0.96309763, + 0.21078455, + 0.26608607, + 0.29522902, + 0.8975753, + 0.25297, + 0.28918892, + 0.9595496, + 0.8155306 + ] + }, + { + "bfloat16VecField": [ + -1.734375, + 0.041015625, + -43, + 28, + -9.1875, + -16.875, + 13.0625, + 25.875, + 18.875, + 22, + -33, + 25.75, + -31.75, + 31.25, + 26.25, + 48, + -22.25, + -41.5, + 10, + -1.7890625, + -45.25, + -22.375, + 31.25, + -26.75, + -0.6875, + 17.625, + 17.5, + -14.9375, + -27.625, + 33, + -35.75, + -47.75 + ], + "floatVecField": [ + 0.65685177, + 0.7967462, + 0.65292466, + 0.47451296, + 0.487105, + 0.7703699, + 0.46215242, + 0.068360925, + 0.60461277, + 0.6806389, + 0.010948174, + 0.18897659, + 0.8906668, + 0.7300914, + 0.38688356, + 0.12408817, + 0.56204575, + 0.0037919874, + 0.08732596, + 0.38963246, + 0.057055213, + 0.90844226, + 0.48278856, + 0.493267, + 0.72689456, + 0.44059002, + 0.6000618, + 0.34064367, + 0.5161428, + 0.09022448, + 0.066437885, + 0.924375, + 0.47435242, + 0.7726047, + 0.5868732, + 0.19517516, + 0.37014866, + 0.54562485, + 0.8612679, + 0.9646098, + 0.6879411, + 0.7179708, + 0.82238245, + 0.20676227, + 0.47169217, + 0.18847263, + 0.030084528, + 0.7215885, + 0.1940058, + 0.8705641, + 0.5552904, + 0.85425425, + 0.19084111, + 0.65513355, + 0.8825815, + 0.17911267, + 0.9383283, + 0.1445964, + 0.60026556, + 0.524949, + 0.85351497, + 0.44019926, + 0.9020619, + 0.12076631 + ] + }, + { + "bfloat16VecField": [ + 10.9375, + -13.3125, + -28.625, + 35.25, + -43, + -23.25, + 29, + -10.6875, + -32, + -33, + -22.25, + -28, + 28, + 49.5, + 41.5, + 4.40625, + 10.1875, + -28.5, + 45, + 44.25, + -32.5, + -24.125, + -39, + 2.984375, + -0.91796875, + -15.3125, + 15.4375, + 5.03125, + -24.25, + -12.0625, + -16, + -10.25 + ], + "floatVecField": [ + 0.30844283, + 0.2376385, + 0.6043445, + 0.36989665, + 0.1805029, + 0.8584536, + 0.7186344, + 0.2039891, + 0.53399473, + 0.40497106, + 0.21961164, + 0.049922653, + 0.08543531, + 0.96432036, + 0.44378152, + 0.66983813, + 0.20963399, + 0.62360966, + 0.016017769, + 0.6327681, + 0.114422776, + 0.5726738, + 0.57229704, + 0.71577066, + 0.91735655, + 0.22237916, + 0.2442725, + 0.49104455, + 0.63414687, + 0.43167186, + 0.7791959, + 0.62292874, + 0.85084134, + 0.7960938, + 0.46224585, + 0.2022884, + 0.4263549, + 0.17605765, + 0.00801641, + 0.042320196, + 0.71777546, + 0.7300519, + 0.0624454, + 0.9996326, + 0.14539194, + 0.40029496, + 0.65128034, + 0.46233115, + 0.2216075, + 0.17642419, + 0.15189856, + 0.58033663, + 0.56212217, + 0.13686444, + 0.38799226, + 0.73769355, + 0.5905406, + 0.8770144, + 0.36519283, + 0.17165183, + 0.5229868, + 0.15600987, + 0.691431, + 0.07228361 + ] + }, + { + "bfloat16VecField": [ + 18.625, + 27.75, + -46, + -26, + -9.0625, + -39.75, + 24.5, + -39, + -18.875, + 47, + 35, + -44, + 4.3125, + 34.25, + 47.25, + -37, + -41.75, + -3.390625, + 23.5, + 32, + -15.5625, + -5.21875, + 45.5, + -4.0625, + -46, + 46.5, + -20.25, + -25.75, + -22.625, + 24.375, + -49, + 24.25 + ], + "floatVecField": [ + 0.10348506, + 0.84525734, + 0.6528396, + 0.480097, + 0.60616106, + 0.17438708, + 0.7033915, + 0.9066734, + 0.28832147, + 0.27141386, + 0.40126196, + 0.7361419, + 0.75739896, + 0.20185831, + 0.9595122, + 0.046889644, + 0.89057046, + 0.6122676, + 0.5689852, + 0.14686872, + 0.87214136, + 0.42331377, + 0.15778129, + 0.6459605, + 0.37968746, + 0.65812176, + 0.33455014, + 0.35163447, + 0.04506678, + 0.85788375, + 0.6587064, + 0.5068443, + 0.25387546, + 0.35821617, + 0.63774276, + 0.45589358, + 0.37449834, + 0.7342579, + 0.78256685, + 0.8416643, + 0.0059738536, + 0.78489983, + 0.61526626, + 0.8568159, + 0.59405357, + 0.11915635, + 0.47373962, + 0.09422982, + 0.24009466, + 0.16764745, + 0.62546146, + 0.52660525, + 0.8840554, + 0.277747, + 0.6368095, + 0.048093513, + 0.102367945, + 0.05119757, + 0.5801811, + 0.09398359, + 0.6583618, + 0.72135013, + 0.05448462, + 0.24337053 + ] + }, + { + "bfloat16VecField": [ + 20.5, + 35.5, + -41, + 27.5, + -22.125, + -11.5625, + 28.875, + 20, + -22.875, + 47.25, + -43, + -17.625, + -37.25, + -16.375, + -28.75, + 5.5, + 11.125, + 44.25, + -15.0625, + -22.5, + 32, + 18, + -24, + -35.5, + 28.25, + 5.6875, + -28.875, + 40.5, + 42.75, + -41.5, + 0.99609375, + -9.875 + ], + "floatVecField": [ + 0.68767625, + 0.8423521, + 0.99071527, + 0.52480906, + 0.36981148, + 0.15564997, + 0.18547417, + 0.7027981, + 0.012189027, + 0.62604487, + 0.35200384, + 0.9060035, + 0.2292723, + 0.43366623, + 0.7526672, + 0.07912019, + 0.68071985, + 0.9961246, + 0.6684942, + 0.8439865, + 0.5607376, + 0.18943308, + 0.41741526, + 0.7191012, + 0.9515549, + 0.66444296, + 0.7924931, + 0.15165201, + 0.2989833, + 0.038535733, + 0.2903466, + 0.6215752, + 0.63402385, + 0.25747532, + 0.82302487, + 0.9680371, + 0.01732841, + 0.4629055, + 0.8753637, + 0.76709676, + 0.68216276, + 0.9717941, + 0.71810544, + 0.789116, + 0.36564803, + 0.101204626, + 0.71481127, + 0.94412106, + 0.16499074, + 0.5493175, + 0.96618533, + 0.50799316, + 0.21065487, + 0.5628668, + 0.39166626, + 0.00724035, + 0.3745904, + 0.85556495, + 0.9353182, + 0.31790212, + 0.92414623, + 0.07647752, + 0.9689257, + 0.7397357 + ] + }, + { + "bfloat16VecField": [ + -11.625, + -16.5, + -8.6875, + -30.875, + -29.125, + 35.25, + -39, + -21.75, + -16.75, + -29.75, + 37.5, + -38.5, + 43.5, + 33.75, + -48, + -26.875, + 2.375, + 0.87109375, + 28, + -37, + -36.25, + 13.375, + 18.5, + 12.75, + -6.59375, + -17.625, + 11.9375, + -27.875, + 44.25, + -5.21875, + -15.5, + -21.375 + ], + "floatVecField": [ + 0.38357934, + 0.4886526, + 0.10867981, + 0.89116144, + 0.4340823, + 0.1410137, + 0.15438984, + 0.9488114, + 0.20077457, + 0.3325992, + 0.5209849, + 0.25490028, + 0.54786325, + 0.012972608, + 0.86531675, + 0.7889768, + 0.98311675, + 0.64231473, + 0.31320858, + 0.42020848, + 0.22714357, + 0.81701416, + 0.98130095, + 0.36613837, + 0.77757686, + 0.8570605, + 0.8294839, + 0.6427045, + 0.5766567, + 0.826531, + 0.20938928, + 0.008007914, + 0.6946657, + 0.4499606, + 0.18625017, + 0.18329144, + 0.13487984, + 0.65840966, + 0.48199955, + 0.6410035, + 0.029614242, + 0.25729093, + 0.4402286, + 0.86701065, + 0.19888356, + 0.8818605, + 0.47250497, + 0.33825704, + 0.7958316, + 0.3209422, + 0.91376144, + 0.4136033, + 0.9509642, + 0.5794441, + 0.93583465, + 0.85908073, + 0.694633, + 0.22920674, + 0.0721125, + 0.73773897, + 0.44041517, + 0.07608467, + 0.6638589, + 0.88309646 + ] + }, + { + "bfloat16VecField": [ + 1.21875, + -40.25, + -11.875, + -15.75, + 17.625, + 37.75, + 15.9375, + 32.25, + -32.5, + 6.25, + -25.25, + 34.25, + -40.75, + 6.0625, + -2.8125, + 40.25, + 1.5859375, + 21, + -17.375, + 9.5, + -12.875, + -36, + -35.5, + -25.125, + 19.875, + 22.375, + -19.75, + -36.5, + -16.625, + 23.25, + 41.25, + -42.75 + ], + "floatVecField": [ + 0.7787835, + 0.94104344, + 0.044769764, + 0.6136475, + 0.32781577, + 0.4435063, + 0.38646492, + 0.824941, + 0.004762718, + 0.123713665, + 0.8313167, + 0.22196738, + 0.5947063, + 0.13396005, + 0.25409296, + 0.56303614, + 0.6650313, + 0.08519147, + 0.05260708, + 0.6784503, + 0.29955387, + 0.67279947, + 0.88296777, + 0.015142175, + 0.2013418, + 0.50736594, + 0.90582085, + 0.97014856, + 0.09483, + 0.5691447, + 0.17495069, + 0.01317448, + 0.06826056, + 0.103881285, + 0.3622784, + 0.9386693, + 0.028252285, + 0.6887031, + 0.3331701, + 0.43791652, + 0.9807209, + 0.9110269, + 0.68638295, + 0.5480295, + 0.659549, + 0.82110184, + 0.581732, + 0.26441014, + 0.9654526, + 0.7154511, + 0.6875814, + 0.6189274, + 0.32725886, + 0.5430922, + 0.5254563, + 0.08505539, + 0.7420291, + 0.121101566, + 0.1469022, + 0.416121, + 0.006508772, + 0.26344138, + 0.024670865, + 0.018679949 + ] + }, + { + "bfloat16VecField": [ + -14.5, + 24.75, + -15.0625, + -2.9375, + 37.75, + 11.0625, + 11.6875, + 27.875, + 48.75, + 33.25, + 5.4375, + -23.625, + 36, + -23.625, + 15.25, + -49.5, + -13.1875, + -36, + 42.75, + 39.5, + 24.5, + 10.6875, + -28, + -33.25, + 9.75, + 12.1875, + 21.5, + 26.75, + -6.03125, + 34, + 41, + 1.0234375 + ], + "floatVecField": [ + 0.6044582, + 0.2221436, + 0.8244782, + 0.43078062, + 0.8741876, + 0.6127108, + 0.4417127, + 0.8815114, + 0.8475388, + 0.68245006, + 0.9979441, + 0.38844675, + 0.4730327, + 0.2594483, + 0.48447645, + 0.4870291, + 0.31676814, + 0.8038267, + 0.5839229, + 0.022215264, + 0.5137671, + 0.963778, + 0.7988502, + 0.45370644, + 0.22035438, + 0.29909837, + 0.93535453, + 0.5055454, + 0.77121264, + 0.8096407, + 0.8244675, + 0.051335037, + 0.0983, + 0.36566436, + 0.42854875, + 0.8724556, + 0.14380156, + 0.1667389, + 0.9806659, + 0.68401945, + 0.95292175, + 0.9251103, + 0.47241718, + 0.07869726, + 0.027945135, + 0.5451597, + 0.13216831, + 0.9837194, + 0.16778111, + 0.7548095, + 0.22363296, + 0.41814148, + 0.35564378, + 0.21051493, + 0.56195784, + 0.03585494, + 0.11853085, + 0.9107681, + 0.5028087, + 0.6051295, + 0.021075204, + 0.5075246, + 0.6037283, + 0.44707844 + ] + }, + { + "bfloat16VecField": [ + 46.75, + 38.25, + -47.25, + -40.75, + 33, + 48, + 23.5, + 14.5, + 38.5, + -33.5, + -9.875, + -48.75, + 45.25, + 12.25, + 1.59375, + -3.953125, + 25.75, + 36, + -24.75, + 33, + -49.5, + 46.75, + 33.75, + 10.0625, + -4.25, + -20.25, + 8.3125, + -5.03125, + 8.875, + 3.828125, + -29.375, + -37.25 + ], + "floatVecField": [ + 0.17482011, + 0.65349543, + 0.2684204, + 0.5780167, + 0.8212344, + 0.06885737, + 0.41565734, + 0.6547479, + 0.96671003, + 0.40622953, + 0.05383342, + 0.93157405, + 0.97110903, + 0.84017414, + 0.9729293, + 0.9749458, + 0.2136868, + 0.508665, + 0.0045522065, + 0.53031486, + 0.5844471, + 0.96857977, + 0.0154250525, + 0.32780024, + 0.15925212, + 0.4631677, + 0.35746136, + 0.4801421, + 0.8835984, + 0.46799126, + 0.8553378, + 0.9537854, + 0.2880129, + 0.80294263, + 0.7581544, + 0.6868791, + 0.08629599, + 0.90661395, + 0.71632713, + 0.08693256, + 0.8687486, + 0.26317623, + 0.7908471, + 0.7153632, + 0.84042764, + 0.77706474, + 0.012991439, + 0.71817046, + 0.7693697, + 0.9272926, + 0.6666367, + 0.7983966, + 0.33481094, + 0.9128337, + 0.7761778, + 0.23589721, + 0.0746207, + 0.94943273, + 0.13942686, + 0.81670326, + 0.025478976, + 0.9800894, + 0.5597018, + 0.74492866 + ] + }, + { + "bfloat16VecField": [ + -15.0625, + 21.125, + -14.375, + -39.25, + -36, + 42.25, + 2.03125, + 29.25, + -45.75, + 36.5, + -3.984375, + 32.75, + 43, + 33.75, + -12.4375, + -14.25, + -43.25, + -19.625, + -1.6171875, + -20, + -15.0625, + -41.25, + -10.0625, + 26.75, + -7.0625, + 13.0625, + -32.75, + 38.75, + 15.75, + 31.75, + -45.5, + 2.484375 + ], + "floatVecField": [ + 0.9780465, + 0.58729804, + 0.3278158, + 0.042050805, + 0.9838018, + 0.37757313, + 0.87621516, + 0.34853974, + 0.16511214, + 0.12154298, + 0.2679557, + 0.73123264, + 0.15382725, + 0.98424995, + 0.84201634, + 0.76813453, + 0.73981553, + 0.85161066, + 0.83408165, + 0.7568787, + 0.25750604, + 0.98133105, + 0.7824335, + 0.65350056, + 0.2539314, + 0.24168846, + 0.43764257, + 0.48238662, + 0.23340066, + 0.48262176, + 0.20441175, + 0.9530761, + 0.21734138, + 0.69329566, + 0.91979605, + 0.8413115, + 0.0018731888, + 0.31044504, + 0.3682113, + 0.52986085, + 0.8620591, + 0.09307148, + 0.5717592, + 0.067147255, + 0.4590973, + 0.4399496, + 0.82451445, + 0.82718396, + 0.008884165, + 0.33056867, + 0.7570654, + 0.66648763, + 0.5899968, + 0.23760875, + 0.6531266, + 0.9552117, + 0.92509294, + 0.81204003, + 0.39278153, + 0.41884157, + 0.9182109, + 0.8154692, + 0.52526647, + 0.6186324 + ] + }, + { + "bfloat16VecField": [ + 37.75, + 18.125, + -21.5, + -11.0625, + -14.0625, + -42, + 2.703125, + 46.25, + 38, + 48, + 11.25, + -38.75, + 18, + -8.75, + -36.75, + -30, + 4.1875, + 10.6875, + 1.890625, + -22.125, + 30.5, + -33.25, + 36, + 20.75, + -46.5, + -29.875, + -8.875, + -43.5, + 39, + -41.25, + -33.75, + -42.5 + ], + "floatVecField": [ + 0.21339191, + 0.24392346, + 0.9758285, + 0.57455117, + 0.30169132, + 0.69601065, + 0.89777285, + 0.71760464, + 0.30042115, + 0.070881225, + 0.15899178, + 0.51156336, + 0.5405496, + 0.08386194, + 0.9545485, + 0.9506713, + 0.6753428, + 0.48342866, + 0.32498002, + 0.30639413, + 0.941087, + 0.04936715, + 0.40660393, + 0.5972495, + 0.09102706, + 0.29999173, + 0.021288969, + 0.08428669, + 0.5111563, + 0.5542559, + 0.94949067, + 0.9109447, + 0.35978228, + 0.31795597, + 0.5597044, + 0.53971213, + 0.44882017, + 0.7617063, + 0.7411604, + 0.48758054, + 0.6957811, + 0.21228997, + 0.6963425, + 0.7964876, + 0.70024, + 0.48171353, + 0.6932329, + 0.7369964, + 0.016966468, + 0.15558653, + 0.49351373, + 0.4193336, + 0.8471115, + 0.51104087, + 0.18197007, + 0.060064647, + 0.87850654, + 0.58078265, + 0.25167057, + 0.20252575, + 0.638254, + 0.7259869, + 0.74547684, + 0.056084413 + ] + }, + { + "bfloat16VecField": [ + -44.5, + 32, + -47, + 30.375, + -12.3125, + 34.75, + -8.6875, + 31.125, + 0.19726562, + -1, + 12.4375, + 46, + 31.75, + 20.25, + 26.5, + -46.75, + -37.25, + 47.5, + -9.0625, + -27.625, + 22.625, + -30, + -37.25, + 21.125, + 8.6875, + -22.25, + 30.75, + 3.984375, + 20.75, + -10.75, + 43.25, + -45.25 + ], + "floatVecField": [ + 0.037014827, + 0.5523258, + 0.91062623, + 0.057730082, + 0.16455226, + 0.18852681, + 0.507702, + 0.2133974, + 0.8030262, + 0.5644116, + 0.32786384, + 0.61859435, + 0.60459363, + 0.0365933, + 0.9850299, + 0.21867667, + 0.889244, + 0.15974861, + 0.076397836, + 0.015319321, + 0.085914135, + 0.75676906, + 0.79182345, + 0.38004103, + 0.026107788, + 0.4478044, + 0.2073991, + 0.8514591, + 0.828646, + 0.37509462, + 0.3802146, + 0.7929193, + 0.7246676, + 0.92111266, + 0.17372335, + 0.7644258, + 0.8806689, + 0.23240152, + 0.16776711, + 0.33284494, + 0.8586775, + 0.43996602, + 0.34902102, + 0.020789832, + 0.46986574, + 0.21499416, + 0.47947884, + 0.034101482, + 0.6749447, + 0.11431777, + 0.99843246, + 0.5429715, + 0.4451294, + 0.7160986, + 0.8825096, + 0.8980224, + 0.9063986, + 0.19719426, + 0.41615483, + 0.10656404, + 0.5103691, + 0.807141, + 0.16808839, + 0.98300964 + ] + }, + { + "bfloat16VecField": [ + -43.5, + 9.875, + -16.25, + 33, + 10.0625, + 15.25, + 18.875, + 15.1875, + 14.5, + 18.875, + 44.25, + -34.75, + -12.0625, + 4.5, + 7.25, + 48.75, + -6.6875, + 40.5, + 5.90625, + 44.25, + -18.25, + -33, + -4.53125, + -4.53125, + -34.75, + 17.125, + 37.75, + -25.75, + -10, + -5.25, + 23.75, + -2.328125 + ], + "floatVecField": [ + 0.77981323, + 0.630027, + 0.95709795, + 0.6499879, + 0.5941991, + 0.3636602, + 0.25283512, + 0.27973333, + 0.7659068, + 0.18097624, + 0.9104007, + 0.64820063, + 0.005424442, + 0.67235553, + 0.9698558, + 0.8253358, + 0.6235026, + 0.3267187, + 0.23383205, + 0.83054256, + 0.7148811, + 0.20922664, + 0.8065509, + 0.0061979443, + 0.5317623, + 0.33190286, + 0.57788134, + 0.5768202, + 0.0875839, + 0.66254, + 0.9124577, + 0.07641434, + 0.8202031, + 0.86652637, + 0.988762, + 0.61071324, + 0.70470196, + 0.2878386, + 0.87525314, + 0.30374652, + 0.59921414, + 0.5605141, + 0.19930963, + 0.11486036, + 0.6820004, + 0.84311056, + 0.5148809, + 0.74590826, + 0.56605303, + 0.85699815, + 0.94981134, + 0.63029575, + 0.110192895, + 0.24407728, + 0.55257446, + 0.09601457, + 0.74505436, + 0.20329873, + 0.6148107, + 0.8359139, + 0.57324696, + 0.49913403, + 0.283909, + 0.2668669 + ] + }, + { + "bfloat16VecField": [ + 0.27539062, + 4.8125, + 42.25, + 1.828125, + 6.15625, + -15.75, + 42.5, + 46.75, + 25.875, + -28.125, + 31.625, + -35, + 22.125, + -20.75, + -29.875, + -28.75, + 4.625, + 47.25, + 48.75, + -5.625, + 25.875, + 37.75, + -19.5, + 30.375, + 14.375, + 48.25, + 29.75, + -7.09375, + 4.28125, + -23.125, + -26.25, + 20 + ], + "floatVecField": [ + 0.07638663, + 0.4071125, + 0.38318616, + 0.041135047, + 0.5326544, + 0.11737779, + 0.754498, + 0.7821517, + 0.020797037, + 0.689887, + 0.8062486, + 0.73348045, + 0.9358596, + 0.49921858, + 0.07431924, + 0.79979646, + 0.9125761, + 0.60350794, + 0.113903314, + 0.21187115, + 0.3197978, + 0.6206113, + 0.42566666, + 0.9785831, + 0.39973733, + 0.74529326, + 0.21552657, + 0.92631745, + 0.4525828, + 0.20831187, + 0.22762047, + 0.5296926, + 0.6104866, + 0.73053074, + 0.37641972, + 0.20389311, + 0.9125287, + 0.44298023, + 0.6841292, + 0.79462254, + 0.27954543, + 0.6059353, + 0.14769197, + 0.6669149, + 0.9160528, + 0.98606783, + 0.56174195, + 0.8851316, + 0.94920075, + 0.88583565, + 0.53728217, + 0.48053363, + 0.030744579, + 0.41928843, + 0.029546218, + 0.3197662, + 0.19430386, + 0.6545522, + 0.2447235, + 0.8707425, + 0.10568299, + 0.7494439, + 0.061524794, + 0.4585383 + ] + }, + { + "bfloat16VecField": [ + 31.375, + -42.25, + 6.4375, + 0.89453125, + -8.8125, + 9.5, + 0.6796875, + -7.4375, + 1.2109375, + -25.125, + -48, + -27.75, + -3.90625, + 3.484375, + -7.875, + 39, + 40.5, + -30.875, + -24.375, + -15.875, + 31.5, + 27, + -38.25, + 0.9609375, + 41.25, + -39.5, + 30.625, + -11.9375, + 39.5, + 28.375, + -45.75, + 2.34375 + ], + "floatVecField": [ + 0.08465924, + 0.831909, + 0.29860583, + 0.77439386, + 0.12939312, + 0.46536055, + 0.004705534, + 0.33528936, + 0.92700577, + 0.6431984, + 0.60115606, + 0.7584295, + 0.52004623, + 0.63302225, + 0.7595903, + 0.6902572, + 0.1679499, + 0.17957723, + 0.7519166, + 0.18648338, + 0.13741796, + 0.6933576, + 0.703251, + 0.27236328, + 0.5731696, + 0.2357393, + 0.38878337, + 0.083138004, + 0.5880409, + 0.5094753, + 0.82359767, + 0.33812782, + 0.43932393, + 0.7840226, + 0.37459007, + 0.75906235, + 0.4474078, + 0.095476866, + 0.9981786, + 0.6073785, + 0.9298487, + 0.6120119, + 0.554892, + 0.5691522, + 0.0972593, + 0.37647304, + 0.34323266, + 0.9326074, + 0.55325943, + 0.67299086, + 0.7381645, + 0.786848, + 0.35672626, + 0.4301211, + 0.12784468, + 0.51873726, + 0.344641, + 0.52526504, + 0.8549945, + 0.2729992, + 0.6230186, + 0.9096293, + 0.48972145, + 0.38789856 + ] + }, + { + "bfloat16VecField": [ + 20.125, + 25.75, + -33.5, + 21.75, + -37.75, + 3.265625, + 34.5, + 18.375, + -11.375, + -40.25, + 21.5, + 49.25, + -18, + -14.4375, + 1.0078125, + -28.375, + -33.5, + 47.5, + -40, + 22.75, + 22.75, + 39.75, + 7.40625, + 21.25, + -13.625, + -19.75, + 42.5, + 13.3125, + 3.359375, + -22, + 47.5, + -7.3125 + ], + "floatVecField": [ + 0.18695702, + 0.20321664, + 0.33887795, + 0.6283936, + 0.07774327, + 0.32911107, + 0.15204431, + 0.21158431, + 0.31735557, + 0.31873515, + 0.4477933, + 0.45055413, + 0.08438623, + 0.110758945, + 0.06424395, + 0.5413084, + 0.37702662, + 0.9507763, + 0.9659291, + 0.86159045, + 0.6371742, + 0.10038689, + 0.047607508, + 0.20233499, + 0.44260412, + 0.8751387, + 0.30215055, + 0.768279, + 0.694679, + 0.26845253, + 0.9196897, + 0.7638134, + 0.15972008, + 0.9340138, + 0.77339613, + 0.4042136, + 0.45882562, + 0.4723791, + 0.58171004, + 0.79658616, + 0.50375473, + 0.8574245, + 0.66977173, + 0.80210537, + 0.98541915, + 0.082738966, + 0.93813074, + 0.045245904, + 0.8781107, + 0.77727467, + 0.59956294, + 0.47327724, + 0.43722525, + 0.76363665, + 0.24754371, + 0.36910892, + 0.84021086, + 0.76449835, + 0.4101146, + 0.44385102, + 0.5899346, + 0.64481646, + 0.22816864, + 0.5477394 + ] + }, + { + "bfloat16VecField": [ + 46, + -18, + 11.0625, + 20.875, + -10.5625, + 16.25, + 3.015625, + 18.25, + -33.5, + 14.125, + 5.9375, + -2.5, + -3.171875, + 49.75, + -3.78125, + -44, + -20.375, + -38, + 47, + 14.375, + 37.5, + -49.75, + -14, + -31.5, + -34, + -41.25, + -38.5, + -21.25, + -4.1875, + 19.125, + 33.5, + 49.5 + ], + "floatVecField": [ + 0.13798277, + 0.0372231, + 0.05298706, + 0.026684755, + 0.23167461, + 0.77829945, + 0.15401512, + 0.86323047, + 0.80904937, + 0.59278154, + 0.74522376, + 0.075703844, + 0.9276659, + 0.092101105, + 0.07155116, + 0.13354099, + 0.69846076, + 0.46739465, + 0.24895437, + 0.2843568, + 0.19308007, + 0.11965543, + 0.44871557, + 0.9948642, + 0.4008349, + 0.912809, + 0.5970973, + 0.91690946, + 0.911642, + 0.030095307, + 0.69103545, + 0.574314, + 0.047479384, + 0.44798082, + 0.7574993, + 0.10801962, + 0.44325334, + 0.15659383, + 0.09073802, + 0.65408975, + 0.68864805, + 0.5297064, + 0.7203496, + 0.050914075, + 0.8362685, + 0.57206035, + 0.14956911, + 0.22922587, + 0.88024104, + 0.40412602, + 0.8887417, + 0.50252914, + 0.57449126, + 0.50355214, + 0.7415451, + 0.09560751, + 0.6028449, + 0.53456867, + 0.066059455, + 0.9705223, + 0.92450106, + 0.5064679, + 0.8944456, + 0.61318094 + ] + }, + { + "bfloat16VecField": [ + -42.25, + -10.375, + -16.875, + -29.875, + -5.59375, + 2.5, + 47.5, + -15.3125, + -49, + 23.5, + 43.25, + -42.5, + -28.625, + -28.875, + 9.5, + -31, + 3.765625, + 36.5, + 42.25, + -37.75, + 1.8515625, + 10.4375, + -35, + -25.375, + -22.375, + -35.25, + -25.125, + -48.25, + 3.0625, + -45, + 14, + -34 + ], + "floatVecField": [ + 0.11157264, + 0.9946018, + 0.72945374, + 0.09361291, + 0.7970346, + 0.090858795, + 0.9280967, + 0.5054962, + 0.021124847, + 0.21747154, + 0.28199598, + 0.6427558, + 0.3810736, + 0.70541525, + 0.48285344, + 0.4516901, + 0.021676429, + 0.3000196, + 0.825254, + 0.7388299, + 0.25164998, + 0.09461225, + 0.15323272, + 0.8730289, + 0.6929198, + 0.5236057, + 0.29501647, + 0.82732385, + 0.24100505, + 0.5395879, + 0.94629705, + 0.24913935, + 0.45329186, + 0.18099648, + 0.1815246, + 0.9351377, + 0.28072852, + 0.73545516, + 0.2753592, + 0.3923767, + 0.38481265, + 0.45357075, + 0.6768673, + 0.18663558, + 0.7664916, + 0.42551208, + 0.18325764, + 0.44130725, + 0.038357615, + 0.6150388, + 0.26084563, + 0.9608668, + 0.17247286, + 0.9279537, + 0.77078044, + 0.8433813, + 0.25779024, + 0.6370068, + 0.08607735, + 0.03129033, + 0.13490616, + 0.7713906, + 0.93985325, + 0.84975487 + ] + }, + { + "bfloat16VecField": [ + 4.65625, + 4.25, + -11.125, + 11.125, + 12.0625, + 42.75, + 48.25, + 39.75, + 21.375, + 34, + 16.375, + 28.875, + 49.75, + -2.734375, + 25.375, + 5.3125, + 4.78125, + -47, + -40.5, + -5.5625, + 35.25, + 49.25, + 16.75, + 36.25, + 16.5, + 7.25, + -39.25, + 46.5, + 5.78125, + -13.75, + 19.25, + 40.5 + ], + "floatVecField": [ + 0.68807423, + 0.70735514, + 0.57271475, + 0.6235782, + 0.38714758, + 0.7470717, + 0.506221, + 0.8982948, + 0.5829424, + 0.985151, + 0.36991543, + 0.08515112, + 0.64780724, + 0.11867443, + 0.46761435, + 0.83089453, + 0.3858309, + 0.7512959, + 0.6303056, + 0.6334168, + 0.68722755, + 0.905571, + 0.70125777, + 0.079326235, + 0.2847221, + 0.06643265, + 0.45990163, + 0.626635, + 0.73851895, + 0.07974799, + 0.37795088, + 0.7376368, + 0.27755523, + 0.4957657, + 0.22162803, + 0.73571837, + 0.5640565, + 0.013633132, + 0.04189734, + 0.86836314, + 0.39390627, + 0.84112525, + 0.96697193, + 0.5426106, + 0.06738794, + 0.4300572, + 0.27760983, + 0.56341314, + 0.1897385, + 0.27340555, + 0.54090136, + 0.6320961, + 0.7403934, + 0.22984135, + 0.7489774, + 0.25211, + 0.849067, + 0.36749125, + 0.094398536, + 0.78829265, + 0.051773958, + 0.30167103, + 0.3295492, + 0.560574 + ] + }, + { + "bfloat16VecField": [ + 28.375, + -35.5, + 25.75, + -47.5, + 25.375, + 49.5, + 38.25, + 22.375, + 39.75, + 19.625, + -39.5, + 14.9375, + -38.75, + 3.59375, + 0.4453125, + 31.875, + 0.43554688, + 47.5, + -35.25, + 3.1875, + 5.625, + 9.75, + -24.5, + 12.5625, + -8.5, + 4.34375, + -11.0625, + 35, + 38.5, + 42, + 14.5, + -25.125 + ], + "floatVecField": [ + 0.62590307, + 0.4730555, + 0.5143024, + 0.7400377, + 0.09729304, + 0.72493756, + 0.959982, + 0.98990375, + 0.6118087, + 0.9164002, + 0.5924123, + 0.31409177, + 0.7129488, + 0.44753307, + 0.7368132, + 0.49860564, + 0.71846724, + 0.9440224, + 0.86970425, + 0.9288748, + 0.8660023, + 0.7308698, + 0.28432277, + 0.07713722, + 0.023624336, + 0.71013707, + 0.7375767, + 0.36600426, + 0.26602337, + 0.6096527, + 0.72939134, + 0.27763587, + 0.7852319, + 0.35285512, + 0.52532744, + 0.2676204, + 0.5576011, + 0.53494704, + 0.8179915, + 0.34802863, + 0.27321622, + 0.60159594, + 0.38670206, + 0.8427001, + 0.85214096, + 0.6492275, + 0.21912386, + 0.5950326, + 0.24724205, + 0.4847001, + 0.24040791, + 0.71448314, + 0.45358077, + 0.8654295, + 0.06962857, + 0.67273706, + 0.096577905, + 0.52504367, + 0.9417112, + 0.18092807, + 0.35636124, + 0.9349098, + 0.9936837, + 0.29791304 + ] + }, + { + "bfloat16VecField": [ + 3.140625, + -30.375, + 25.5, + 31.625, + 5.34375, + -14.1875, + 45.75, + 31.5, + -6.75, + 25.625, + -46.5, + 49, + -14.6875, + -2.828125, + -12.6875, + -28.875, + -36.75, + 16.375, + -41.75, + -11.6875, + -39.25, + -8.5625, + 38.25, + -31.75, + -17, + -17.875, + -46, + -33, + 48, + 2.125, + 6.65625, + -31.75 + ], + "floatVecField": [ + 0.3632019, + 0.4378152, + 0.3169868, + 0.0483831, + 0.23498353, + 0.17838562, + 0.25121716, + 0.9433248, + 0.5813989, + 0.5365534, + 0.5609859, + 0.11035459, + 0.9255645, + 0.28316745, + 0.38181284, + 0.2451351, + 0.7033259, + 0.6314965, + 0.4565567, + 0.9000986, + 0.53772557, + 0.4136447, + 0.8383641, + 0.03252166, + 0.44401312, + 0.06071992, + 0.79530734, + 0.38347772, + 0.80169076, + 0.6731427, + 0.14818552, + 0.108565986, + 0.6858668, + 0.609087, + 0.5251247, + 0.41350663, + 0.4728836, + 0.70078206, + 0.3330528, + 0.25174177, + 0.5592758, + 0.72869873, + 0.53140336, + 0.20169091, + 0.9535028, + 0.89667195, + 0.24877198, + 0.5802795, + 0.7340626, + 0.12387722, + 0.46330017, + 0.8434134, + 0.86478865, + 0.2350768, + 0.53663486, + 0.11684581, + 0.101894125, + 0.8960471, + 0.38116553, + 0.5489956, + 0.4260087, + 0.2164831, + 0.3649796, + 0.8742367 + ] + }, + { + "bfloat16VecField": [ + -14.5, + 14.5625, + 26, + 12.8125, + -28.875, + -39, + 6.1875, + 13.3125, + 12.25, + -7.3125, + 39, + 16, + -26.125, + -18.5, + 49, + -15.875, + 19.125, + -4.5, + -0.7265625, + -40.25, + 27.5, + 17, + 37, + -8.375, + -18.375, + -8.5, + 26.75, + -42.5, + 2.78125, + -43.75, + 18.875, + 38.75 + ], + "floatVecField": [ + 0.15033853, + 0.05396438, + 0.16855182, + 0.7694105, + 0.7349307, + 0.74225837, + 0.8363971, + 0.6002226, + 0.53557354, + 0.9518659, + 0.55535847, + 0.5359252, + 0.18551642, + 0.4039799, + 0.54056937, + 0.5693903, + 0.7274987, + 0.11000511, + 0.5375733, + 0.1745831, + 0.8097115, + 0.6795442, + 0.98888123, + 0.8344953, + 0.7026905, + 0.43727967, + 0.32403558, + 0.79236513, + 0.44989684, + 0.549162, + 0.6884249, + 0.26266664, + 0.08171709, + 0.97877437, + 0.95000744, + 0.41945317, + 0.10249012, + 0.50448513, + 0.37434557, + 0.9191395, + 0.054005098, + 0.60332054, + 0.17180634, + 0.3004409, + 0.49967936, + 0.2108608, + 0.3649237, + 0.56979966, + 0.57585806, + 0.6871239, + 0.011539041, + 0.89640576, + 0.14436433, + 0.087279454, + 0.7416531, + 0.8071215, + 0.7242795, + 0.962694, + 0.03039096, + 0.7644512, + 0.8491756, + 0.6789493, + 0.5019264, + 0.0034607633 + ] + }, + { + "bfloat16VecField": [ + 48.75, + 8.375, + -28.625, + -10.1875, + 4.46875, + 0.5625, + 48.75, + 11.5, + 27.625, + -0.48632812, + -45.5, + -15.8125, + -22.625, + 1.75, + -10.25, + -18.125, + -33.25, + 4.90625, + 39.5, + 40.75, + 45.5, + -13.25, + -44.5, + 4.46875, + -10.8125, + 30.875, + -1, + -20.875, + 46.5, + -3.140625, + -22.125, + -37.25 + ], + "floatVecField": [ + 0.30783364, + 0.027119659, + 0.22575209, + 0.9655476, + 0.24870545, + 0.047725998, + 0.23170026, + 0.36999458, + 0.40389535, + 0.45709988, + 0.7518672, + 0.76807773, + 0.8744009, + 0.64978707, + 0.5172989, + 0.5059063, + 0.70675296, + 0.6378856, + 0.33765087, + 0.68290764, + 0.86765546, + 0.93972206, + 0.84308624, + 0.25127536, + 0.10159354, + 0.19775309, + 0.8210649, + 0.9431624, + 0.58428514, + 0.9317162, + 0.38554132, + 0.544001, + 0.23800705, + 0.76901704, + 0.792431, + 0.16296, + 0.75079453, + 0.44172555, + 0.6877227, + 0.7220548, + 0.7692132, + 0.09097071, + 0.7999131, + 0.39576125, + 0.12585361, + 0.8128382, + 0.87954444, + 0.29052696, + 0.34114474, + 0.39145854, + 0.70763683, + 0.5414258, + 0.35632965, + 0.9897232, + 0.9922162, + 0.44163465, + 0.6136564, + 0.6094328, + 0.7674427, + 0.41955474, + 0.7509225, + 0.2950084, + 0.95974976, + 0.88809645 + ] + }, + { + "bfloat16VecField": [ + 24.625, + 49.25, + 46.5, + 3.296875, + 22.375, + 10.4375, + -2.828125, + -11.25, + -1.640625, + 48, + -7.40625, + 43, + 21.5, + -39, + -16, + 15.3125, + -3.265625, + -44.75, + -46.5, + 48.5, + -10.0625, + -11.9375, + 17.5, + 13.0625, + -25.75, + 9.6875, + -49.5, + 14.5625, + -42, + 32.75, + 25.5, + 39.25 + ], + "floatVecField": [ + 0.2939439, + 0.56615824, + 0.47729868, + 0.45343, + 0.07507634, + 0.42452255, + 0.024463905, + 0.028522853, + 0.8580452, + 0.99675894, + 0.034406126, + 0.010451373, + 0.7743605, + 0.6135159, + 0.18680263, + 0.27874994, + 0.44640964, + 0.16318525, + 0.95358914, + 0.5450469, + 0.15932609, + 0.12683927, + 0.044703726, + 0.15428582, + 0.64445597, + 0.8565322, + 0.78714275, + 0.6980953, + 0.06353565, + 0.7744736, + 0.90607136, + 0.82147247, + 0.33051464, + 0.01707307, + 0.7184163, + 0.99909735, + 0.39423534, + 0.87070787, + 0.0661592, + 0.21132855, + 0.7203356, + 0.6247804, + 0.46856666, + 0.25762296, + 0.9990265, + 0.025613688, + 0.29990986, + 0.89734125, + 0.45721307, + 0.5371485, + 0.5393385, + 0.6627454, + 0.96097803, + 0.26085204, + 0.80731034, + 0.39116108, + 0.58376795, + 0.6619996, + 0.6847339, + 0.97474295, + 0.3521754, + 0.6757386, + 0.98735535, + 0.65844774 + ] + }, + { + "bfloat16VecField": [ + 4.9375, + 7.625, + -33.25, + -19.125, + 8.125, + 33.5, + -31.75, + 40.5, + 41.25, + -25.875, + -8.5, + 36.25, + -2.8125, + 5.3125, + 0.99609375, + -0.029785156, + 43.5, + 24.125, + -5.25, + 24.625, + -15.625, + -42, + -20.875, + 46.25, + -49.25, + 28.125, + 36.25, + 0.19335938, + 42.25, + 31.25, + -21.375, + 47.25 + ], + "floatVecField": [ + 0.3790552, + 0.62183213, + 0.24376243, + 0.6878157, + 0.80996, + 0.45175934, + 0.47280803, + 0.9994772, + 0.284749, + 0.6514699, + 0.09419588, + 0.038970467, + 0.5574011, + 0.6995939, + 0.86751723, + 0.5469431, + 0.9709039, + 0.10136634, + 0.2246632, + 0.673713, + 0.4785042, + 0.3628282, + 0.6971229, + 0.59585816, + 0.46858987, + 0.43639335, + 0.8095526, + 0.18400455, + 0.019983867, + 0.415286, + 0.67106605, + 0.5687699, + 0.44835174, + 0.042203866, + 0.2598901, + 0.53429997, + 0.22920968, + 0.6897699, + 0.625229, + 0.15571968, + 0.35125682, + 0.8918064, + 0.51127404, + 0.87969357, + 0.49423668, + 0.86593467, + 0.21445112, + 0.5252121, + 0.05934228, + 0.65179586, + 0.47067744, + 0.16229892, + 0.51389354, + 0.5204911, + 0.90311706, + 0.77565694, + 0.12688044, + 0.86142635, + 0.49697775, + 0.2260824, + 0.47014344, + 0.87319255, + 0.6604853, + 0.40849206 + ] + }, + { + "bfloat16VecField": [ + -34.5, + 17.625, + -3.78125, + 14.75, + 2.359375, + 3.625, + 32.25, + 3.25, + 24.75, + -9.375, + 43, + -29.5, + 34.5, + 42.75, + 9.4375, + -14.8125, + 20.625, + -9.8125, + 49, + 20, + -16, + 8.875, + 27.25, + 17.5, + -42.75, + -18.875, + 36.75, + -23.25, + 30.5, + -37.25, + -21.75, + 45 + ], + "floatVecField": [ + 0.5142933, + 0.50745875, + 0.52809083, + 0.92212576, + 0.3157925, + 0.44649866, + 0.031662975, + 0.04038959, + 0.9742703, + 0.7716659, + 0.6981525, + 0.3665847, + 0.63173455, + 0.36413944, + 0.261729, + 0.24309033, + 0.6515114, + 0.7499015, + 0.5272416, + 0.6057771, + 0.53304714, + 0.9824744, + 0.111367255, + 0.676608, + 0.3647209, + 0.9456881, + 0.3957169, + 0.14529304, + 0.18074162, + 0.41368505, + 0.9517193, + 0.67855215, + 0.6066134, + 0.78048575, + 0.13668987, + 0.7692479, + 0.9528826, + 0.96372664, + 0.5427747, + 0.79793054, + 0.42727688, + 0.4479142, + 0.5129835, + 0.25170144, + 0.88446623, + 0.521448, + 0.68270296, + 0.38688564, + 0.7300613, + 0.33067146, + 0.26313114, + 0.1430875, + 0.5391086, + 0.5512057, + 0.49934936, + 0.77518046, + 0.8319485, + 0.65110236, + 0.52023, + 0.08344835, + 0.33053622, + 0.19071482, + 0.7851748, + 0.41240305 + ] + }, + { + "bfloat16VecField": [ + 43.75, + 38.5, + -16.25, + 30.25, + 23.25, + -36.25, + -11.5625, + -36, + -42, + 33, + -9.0625, + -39, + -22.125, + -31.625, + -44.5, + -49, + -20.125, + -2.546875, + -6.0625, + -36.5, + -28, + 34, + -40.5, + 8, + 2.21875, + -6.9375, + 10.8125, + -39.5, + 13.0625, + 41, + 48.25, + 22.125 + ], + "floatVecField": [ + 0.017780483, + 0.33335733, + 0.79514354, + 0.45479238, + 0.052999567, + 0.23510236, + 0.7413692, + 0.43030113, + 0.33682796, + 0.44462916, + 0.013608088, + 0.86665946, + 0.33651152, + 0.9987447, + 0.9081752, + 0.38216743, + 0.40758678, + 0.1965753, + 0.52964884, + 0.8002433, + 0.46909976, + 0.9902505, + 0.14333351, + 0.83454514, + 0.90456325, + 0.46995482, + 0.42762217, + 0.67636824, + 0.27454564, + 0.7688465, + 0.26296797, + 0.62887156, + 0.500508, + 0.4362067, + 0.7314985, + 0.1346855, + 0.77376646, + 0.79575217, + 0.44521824, + 0.8642111, + 0.4687469, + 0.38358954, + 0.84050894, + 0.20213847, + 0.64857763, + 0.06713859, + 0.38340634, + 0.40721777, + 0.84402055, + 0.06326107, + 0.507847, + 0.04408097, + 0.25757223, + 0.9040273, + 0.3147544, + 0.38064247, + 0.2456605, + 0.06422969, + 0.91829455, + 0.04091814, + 0.9353491, + 0.07215063, + 0.06197758, + 0.3328363 + ] + }, + { + "bfloat16VecField": [ + -6.1875, + 7.46875, + -37.75, + 42.5, + -7.3125, + 9, + 13.8125, + 5.375, + -47.25, + -43.25, + 8.4375, + -44, + 8.875, + -42.5, + 32.25, + -4.84375, + 26.625, + -46.25, + 47.25, + 26.25, + 49, + 9.1875, + 9.625, + -15.875, + -47.75, + -1.640625, + -35.25, + 19.25, + -31.125, + -18.25, + 16.25, + 35.25 + ], + "floatVecField": [ + 0.47152343, + 0.5226694, + 0.32659626, + 0.98836535, + 0.27688098, + 0.63168883, + 0.38209987, + 0.3770289, + 0.8952054, + 0.29052368, + 0.79606843, + 0.5339343, + 0.84506685, + 0.93418014, + 0.73631567, + 0.9981074, + 0.5031353, + 0.55478954, + 0.52702504, + 0.6497715, + 0.38138372, + 0.8458568, + 0.2679038, + 0.28225416, + 0.66552967, + 0.9441226, + 0.028049257, + 0.16931228, + 0.781842, + 0.7142137, + 0.46327075, + 0.87487686, + 0.9861051, + 0.019124387, + 0.7867634, + 0.34073675, + 0.29211864, + 0.6655471, + 0.025134075, + 0.62764615, + 0.1394368, + 0.014371416, + 0.94168335, + 0.43495, + 0.8167697, + 0.53115, + 0.60536814, + 0.29190227, + 0.5727684, + 0.9608202, + 0.65048987, + 0.40564382, + 0.90466833, + 0.0954931, + 0.9500341, + 0.35088128, + 0.2777612, + 0.1802372, + 0.2514154, + 0.20708562, + 0.33737093, + 0.37697738, + 0.7632505, + 0.5774651 + ] + }, + { + "bfloat16VecField": [ + 3.078125, + 36, + -41.75, + -21.375, + -4.4375, + -42.25, + -10.8125, + -20.375, + -0.84765625, + 37.25, + -12.625, + -17.875, + 19, + -23.75, + -22.125, + 21, + 5.15625, + -48.25, + -0.51171875, + -39.5, + 40.25, + 45.25, + -37.25, + -11.0625, + -5.25, + 10.25, + 14.5625, + 19.25, + 30.75, + -10.25, + 49.5, + -24.75 + ], + "floatVecField": [ + 0.39310694, + 0.6788411, + 0.27286685, + 0.103395045, + 0.67637855, + 0.0028753465, + 0.12921517, + 0.2012166, + 0.23228636, + 0.5507399, + 0.20461018, + 0.75212187, + 0.40480015, + 0.62978524, + 0.23915176, + 0.17709385, + 0.93185335, + 0.91995656, + 0.25392824, + 0.98415583, + 0.9176571, + 0.5589375, + 0.70386934, + 0.321875, + 0.36696848, + 0.37914753, + 0.43976256, + 0.14596984, + 0.3406415, + 0.8869503, + 0.26016793, + 0.4934203, + 0.019998634, + 0.48520628, + 0.841404, + 0.32195625, + 0.39865056, + 0.43848616, + 0.35273197, + 0.3089316, + 0.51225835, + 0.061002173, + 0.7504851, + 0.5225014, + 0.6315376, + 0.7567971, + 0.9138916, + 0.38953328, + 0.5127923, + 0.318056, + 0.97107863, + 0.12589245, + 0.26516983, + 0.5135324, + 0.7669071, + 0.64885336, + 0.86585677, + 0.08883355, + 0.2578107, + 0.77729744, + 0.4893462, + 0.22362801, + 0.14357054, + 0.99968296 + ] + }, + { + "bfloat16VecField": [ + 39, + -8.3125, + -44.5, + -6, + -3.859375, + 13.3125, + -12.125, + 26.625, + -33.5, + 44, + -6.71875, + 21.875, + 8, + -38.5, + 22, + -39, + 28.875, + 37.25, + 42.25, + 6.625, + 29.5, + -42.75, + 31.5, + 9.5625, + 33.25, + -46.5, + -0.84375, + 28.25, + 24.625, + -10, + -11.0625, + -45.5 + ], + "floatVecField": [ + 0.87806726, + 0.5846697, + 0.91941625, + 0.028278511, + 0.697246, + 0.33188504, + 0.8685197, + 0.17633326, + 0.37725288, + 0.51358247, + 0.7041265, + 0.3491187, + 0.87530994, + 0.6892673, + 0.4682251, + 0.90772736, + 0.8931922, + 0.7547012, + 0.22194192, + 0.9816716, + 0.78755534, + 0.38542107, + 0.11923575, + 0.12824088, + 0.56543326, + 0.9159815, + 0.952594, + 0.05451375, + 0.3014945, + 0.62541825, + 0.66205245, + 0.62493086, + 0.6809055, + 0.9684982, + 0.7982846, + 0.76222515, + 0.7841627, + 0.78426427, + 0.9257992, + 0.69276613, + 0.21316141, + 0.9257068, + 0.056042712, + 0.32128146, + 0.4284605, + 0.5625545, + 0.65882015, + 0.65504515, + 0.31004867, + 0.06317011, + 0.6805843, + 0.67441547, + 0.18289259, + 0.7912467, + 0.9962483, + 0.9867878, + 0.8586505, + 0.22258417, + 0.83139193, + 0.31467426, + 0.92484415, + 0.03265173, + 0.630014, + 0.3685697 + ] + }, + { + "bfloat16VecField": [ + -33.75, + 21.875, + -24, + 36.75, + 44.5, + -31.125, + -1.7578125, + -12.5625, + 40.5, + 44, + -12.5, + 8.6875, + 27.625, + -20.625, + -40.5, + 31.375, + 36.25, + -10.125, + 30.75, + 43.75, + 9.75, + 17.125, + -28.25, + 7.53125, + 39, + 8.375, + -46.25, + 25, + 23.375, + -29.25, + 6.46875, + -3.828125 + ], + "floatVecField": [ + 0.99597263, + 0.255186, + 0.74417806, + 0.7360147, + 0.84386957, + 0.8721614, + 0.80294746, + 0.058625165, + 0.5038792, + 0.36335188, + 0.8527933, + 0.47373277, + 0.9801203, + 0.5793082, + 0.7709943, + 0.5192374, + 0.5362803, + 0.48108062, + 0.17677076, + 0.6599322, + 0.68986917, + 0.5896344, + 0.35194817, + 0.8432633, + 0.32634825, + 0.7179935, + 0.99362475, + 0.4396168, + 0.08314257, + 0.7014911, + 0.8729814, + 0.05851371, + 0.43613183, + 0.5761386, + 0.96598583, + 0.2645795, + 0.5425017, + 0.3054969, + 0.59047306, + 0.67890704, + 0.78641105, + 0.45992172, + 0.005880006, + 0.61313856, + 0.08034811, + 0.81511503, + 0.3382368, + 0.99046665, + 0.73887664, + 0.038081296, + 0.61078984, + 0.54121, + 0.8142297, + 0.7626476, + 0.6302475, + 0.14790872, + 0.30149078, + 0.7927825, + 0.17595464, + 0.29040575, + 0.75130045, + 0.33700252, + 0.32980523, + 0.46512341 + ] + }, + { + "bfloat16VecField": [ + 41.5, + 0.36914062, + -11.9375, + -0.19921875, + 6.125, + 14.5625, + -48, + 20, + -26.5, + -16.375, + 45.75, + 36.75, + 33.5, + 3.8125, + -4.3125, + 21, + -46.5, + -19.25, + 43.5, + -21.625, + 20.125, + -32, + -44, + 12.125, + -44, + -13.625, + -27.75, + 32.5, + -12.0625, + -4.5, + 8.5625, + 34 + ], + "floatVecField": [ + 0.3859921, + 0.794028, + 0.48271424, + 0.61033714, + 0.5485661, + 0.63191783, + 0.8231668, + 0.3687595, + 0.983963, + 0.41746685, + 0.3646706, + 0.41797388, + 0.25177896, + 0.3002728, + 0.6419503, + 0.6378356, + 0.019960193, + 0.48306248, + 0.4190751, + 0.4709606, + 0.07564482, + 0.018534068, + 0.43881038, + 0.10637942, + 0.3397229, + 0.92559636, + 0.054974854, + 0.645244, + 0.21288362, + 0.34699324, + 0.9376409, + 0.0441493, + 0.025227053, + 0.7288874, + 0.52033716, + 0.7757305, + 0.69749755, + 0.61308396, + 0.21585141, + 0.6717992, + 0.7393541, + 0.4173968, + 0.71220034, + 0.90245014, + 0.81909937, + 0.2991409, + 0.22011997, + 0.17002372, + 0.5127624, + 0.32375592, + 0.702032, + 0.6544188, + 0.28045878, + 0.1352049, + 0.91682243, + 0.12672761, + 0.8253992, + 0.9605017, + 0.9575338, + 0.5259685, + 0.36666623, + 0.20231107, + 0.07515097, + 0.8433752 + ] + }, + { + "bfloat16VecField": [ + -29.75, + -11, + 6.90625, + 9.4375, + -17.125, + -17.5, + -15, + -6.46875, + 34.75, + -44, + 24.5, + 22.5, + 43.75, + -22, + -45.75, + -19.625, + 36.75, + 3.796875, + -48, + 42.5, + -31.25, + 38.5, + 14.1875, + 32.5, + 38.75, + 21.25, + 16.875, + 45.75, + -36.75, + 20.875, + -24.5, + -17.5 + ], + "floatVecField": [ + 0.060919344, + 0.3651994, + 0.12378019, + 0.4012844, + 0.8473694, + 0.592391, + 0.8175479, + 0.71924734, + 0.441852, + 0.077674285, + 0.5759984, + 0.37726903, + 0.019923843, + 0.21691537, + 0.6675043, + 0.10439526, + 0.9689236, + 0.10074378, + 0.22026695, + 0.62919647, + 0.09311823, + 0.6685948, + 0.44451, + 0.7428715, + 0.81064945, + 0.9997291, + 0.97029465, + 0.95553267, + 0.047130257, + 0.36454993, + 0.5178817, + 0.53309566, + 0.74325204, + 0.409152, + 0.37338656, + 0.3290046, + 0.40867835, + 0.94212097, + 0.58746034, + 0.56191456, + 0.31863394, + 0.4013746, + 0.3895989, + 0.21412301, + 0.7594857, + 0.5274441, + 0.16570024, + 0.7065776, + 0.65660554, + 0.9735878, + 0.030253215, + 0.00073008885, + 0.4487955, + 0.44335428, + 0.592772, + 0.997188, + 0.1654638, + 0.2994011, + 0.75909746, + 0.81402075, + 0.29697502, + 0.537609, + 0.57826954, + 0.24440627 + ] + }, + { + "bfloat16VecField": [ + 7.46875, + 0.01953125, + -24.875, + 35.75, + -15.8125, + 34.75, + 0.54296875, + 30.25, + -28.625, + -47.5, + -49.5, + -17.625, + -46.25, + -15.5625, + 20.375, + -30.875, + -33.25, + -9.0625, + -48.25, + -22.25, + -8.0625, + 13.9375, + -45.25, + 23.625, + 13.5, + 5.40625, + 28.5, + 32.75, + 48.75, + 38.75, + -4.625, + -20.25 + ], + "floatVecField": [ + 0.40660635, + 0.23120856, + 0.31715333, + 0.365314, + 0.99660033, + 0.33132902, + 0.72486097, + 0.4872427, + 0.27363375, + 0.33442342, + 0.3464565, + 0.25683722, + 0.8029111, + 0.78925604, + 0.12096926, + 0.60078365, + 0.53683144, + 0.41740575, + 0.24741514, + 0.8803943, + 0.28913057, + 0.5045563, + 0.7230461, + 0.4522877, + 0.83833283, + 0.061986797, + 0.48832545, + 0.056301896, + 0.024857307, + 0.8626653, + 0.34771505, + 0.8472803, + 0.5295595, + 0.1369546, + 0.44251695, + 0.03190196, + 0.43343094, + 0.26036337, + 0.3848983, + 0.40398476, + 0.77971077, + 0.65962917, + 0.95495194, + 0.5099951, + 0.75410765, + 0.16901171, + 0.17236137, + 0.6329564, + 0.7262972, + 0.9055687, + 0.6422112, + 0.27678877, + 0.12505335, + 0.48128554, + 0.38012242, + 0.39438906, + 0.12915947, + 0.022714011, + 0.10971138, + 0.07602658, + 0.7365675, + 0.09952653, + 0.13132434, + 0.10717191 + ] + }, + { + "bfloat16VecField": [ + -39, + 37, + -38, + -38.5, + -26.625, + -31.375, + -22.625, + -34, + 27.125, + 28.625, + -19.375, + -31, + 12.1875, + -18.25, + -15.8125, + -5.4375, + 42.5, + -46, + 11.375, + -43.5, + 20.125, + -19.25, + 34.75, + 24.75, + -6.03125, + -49.5, + -3.5625, + 44.25, + -11.125, + -24.5, + 11, + -48.5 + ], + "floatVecField": [ + 0.69724905, + 0.5699388, + 0.5974701, + 0.90979403, + 0.36418536, + 0.8081216, + 0.9469664, + 0.34750512, + 0.8785942, + 0.36992455, + 0.10227771, + 0.3256286, + 0.18060894, + 0.13929527, + 0.55786383, + 0.68935627, + 0.020365542, + 0.4666501, + 0.41748494, + 0.2580716, + 0.25650585, + 0.7469866, + 0.6478184, + 0.92982787, + 0.9200515, + 0.0008569525, + 0.58943427, + 0.3229367, + 0.3469253, + 0.64060557, + 0.98780024, + 0.28528762, + 0.02669616, + 0.06437112, + 0.4032064, + 0.49256328, + 0.10643085, + 0.72153217, + 0.630024, + 0.32621846, + 0.6149292, + 0.024500737, + 0.0845782, + 0.62535936, + 0.80375624, + 0.34487158, + 0.94458145, + 0.5244928, + 0.8084152, + 0.9633734, + 0.18191569, + 0.49903294, + 0.2470539, + 0.6538689, + 0.9821049, + 0.95519394, + 0.62459517, + 0.18212797, + 0.6052148, + 0.18662164, + 0.026823642, + 0.032067377, + 0.4936672, + 0.9448502 + ] + }, + { + "bfloat16VecField": [ + -17.125, + 40.75, + -31.625, + 33.25, + 29.625, + 24.875, + 2.34375, + -24.25, + -27.75, + -41.75, + 40.5, + -42.25, + -39.5, + -40.5, + 46.75, + -22.125, + 34, + -9, + -28.125, + 49.5, + 42.5, + 28.625, + 27.5, + 29.625, + 14.0625, + -35.75, + -14.6875, + -45.5, + 25, + -7.5, + -42.75, + 39.75 + ], + "floatVecField": [ + 0.7709524, + 0.87556654, + 0.8073292, + 0.56367236, + 0.50493664, + 0.35700437, + 0.5605782, + 0.057524327, + 0.59582293, + 0.8144743, + 0.04448393, + 0.060420845, + 0.81185377, + 0.43400338, + 0.72388816, + 0.05986652, + 0.7957949, + 0.64912325, + 0.9371155, + 0.021822827, + 0.1615428, + 0.047915448, + 0.4070983, + 0.6551153, + 0.019861868, + 0.50419295, + 0.50091517, + 0.6952068, + 0.6086887, + 0.03695375, + 0.71267587, + 0.6597308, + 0.97119296, + 0.8151037, + 0.9378548, + 0.47207466, + 0.7060629, + 0.81701404, + 0.4488352, + 0.77563834, + 0.5510086, + 0.353331, + 0.7922558, + 0.39148638, + 0.6439887, + 0.1210588, + 0.72916067, + 0.34522766, + 0.2407246, + 0.55487585, + 0.5291307, + 0.9894369, + 0.76598096, + 0.84083104, + 0.44762912, + 0.120414644, + 0.14175399, + 0.1669762, + 0.093765035, + 0.986746, + 0.67129666, + 0.08206733, + 0.92801243, + 0.72062796 + ] + }, + { + "bfloat16VecField": [ + 34.5, + -40.25, + -26.25, + -8.25, + -21.125, + 46.75, + 43.75, + 10.5625, + -42.25, + 45.5, + 5.59375, + -13.9375, + 40.25, + 28.25, + 0.640625, + -29.875, + 21.875, + -4.40625, + 48.25, + 9.9375, + 38.75, + 10.375, + -17.625, + 16.75, + -5.84375, + 23.875, + 39, + 40.25, + -13, + -16.875, + -7.84375, + 32.25 + ], + "floatVecField": [ + 0.60623044, + 0.24426095, + 0.45844144, + 0.47579846, + 0.450171, + 0.725677, + 0.999416, + 0.38556936, + 0.51031715, + 0.66590816, + 0.16264017, + 0.6061114, + 0.5931071, + 0.75007254, + 0.60952884, + 0.9191715, + 0.90663624, + 0.56876636, + 0.40928036, + 0.38135242, + 0.30531168, + 0.16212377, + 0.9730335, + 0.0632084, + 0.783477, + 0.36014655, + 0.118592426, + 0.5113476, + 0.44941965, + 0.08190142, + 0.54975164, + 0.13902774, + 0.62706465, + 0.2955199, + 0.089109145, + 0.49714795, + 0.26088533, + 0.47521812, + 0.04562369, + 0.33971542, + 0.03339521, + 0.6067178, + 0.5336634, + 0.81536144, + 0.8897128, + 0.7834459, + 0.36265734, + 0.02101703, + 0.08788524, + 0.27027708, + 0.058923528, + 0.7547703, + 0.1748614, + 0.67658216, + 0.22437513, + 0.25298998, + 0.5060372, + 0.3466832, + 0.5706869, + 0.17144091, + 0.92833674, + 0.22275649, + 0.402321, + 0.1518053 + ] + }, + { + "bfloat16VecField": [ + -24.625, + 44, + 12.6875, + -38.25, + -46.5, + 38.5, + 35.25, + 34, + -26.875, + -38.75, + -10.75, + 14.5625, + -33.25, + 6.25, + 45, + 4.46875, + -21.875, + 48.5, + 36, + 40.75, + -6.65625, + -37, + -0.39453125, + -45.5, + -16, + -22.875, + 40.75, + 49, + -41.75, + -22.625, + -47.75, + 0.58984375 + ], + "floatVecField": [ + 0.725702, + 0.44336894, + 0.31432453, + 0.32237184, + 0.66627717, + 0.47392958, + 0.07100043, + 0.7322088, + 0.011559387, + 0.10714715, + 0.7343511, + 0.5758672, + 0.34517077, + 0.90234315, + 0.8295113, + 0.15103793, + 0.20522648, + 0.057096194, + 0.6368524, + 0.22182167, + 0.46080709, + 0.9466344, + 0.6822103, + 0.0026221685, + 0.66747993, + 0.52504915, + 0.54150903, + 0.68382746, + 0.6338146, + 0.56616163, + 0.36672115, + 0.5140762, + 0.27962476, + 0.8096983, + 0.52080077, + 0.9237937, + 0.8832696, + 0.41834572, + 0.70577294, + 0.9553325, + 0.0030275888, + 0.042943027, + 0.81410867, + 0.8931256, + 0.68608713, + 0.26400906, + 0.03975911, + 0.27956837, + 0.7672368, + 0.78348774, + 0.121110424, + 0.360174, + 0.59083945, + 0.13730028, + 0.5822384, + 0.75186676, + 0.78313226, + 0.21947333, + 0.805599, + 0.2955934, + 0.3969454, + 0.014275578, + 0.662432, + 0.19236001 + ] + }, + { + "bfloat16VecField": [ + -24.75, + 4.78125, + 39.5, + 17.75, + 6.15625, + 17.75, + 29.625, + 21.5, + -20.625, + 43.75, + 18.25, + 10.25, + -18, + -24.875, + -28, + 39.25, + -47.75, + -19.125, + -24.875, + 31.625, + -3.296875, + -29.875, + 31.375, + 39.5, + 41.75, + -20.375, + 29.125, + -23.875, + 0.75, + -7.75, + 4.1875, + 12.4375 + ], + "floatVecField": [ + 0.11816265, + 0.5677012, + 0.22752494, + 0.04086177, + 0.71527493, + 0.47778532, + 0.7902171, + 0.8923808, + 0.45539123, + 0.8796446, + 0.5452154, + 0.74124897, + 0.83282363, + 0.6504591, + 0.4890598, + 0.64411664, + 0.42522788, + 0.6683277, + 0.6958312, + 0.8626399, + 0.42332643, + 0.13109247, + 0.45697495, + 0.8128232, + 0.43633866, + 0.13640493, + 0.14722197, + 0.5916239, + 0.5492566, + 0.32417947, + 0.13897824, + 0.4359311, + 0.274026, + 0.9397818, + 0.4949286, + 0.11473092, + 0.58995664, + 0.1250256, + 0.9233199, + 0.025071247, + 0.44341037, + 0.624178, + 0.34997565, + 0.46474418, + 0.012203981, + 0.8151504, + 0.5483329, + 0.8809924, + 0.039988834, + 0.24863808, + 0.046042718, + 0.19076172, + 0.87798434, + 0.2256666, + 0.84977305, + 0.19545731, + 0.2421999, + 0.5675232, + 0.07901449, + 0.3860727, + 0.2507776, + 0.46580872, + 0.96980244, + 0.62548697 + ] + }, + { + "bfloat16VecField": [ + -48.75, + 11.8125, + -28.375, + -13.8125, + -20.25, + 5.71875, + -1.1796875, + 14.9375, + -16.75, + 42.5, + 7.40625, + -11.1875, + -27.75, + -39.25, + -8.3125, + 19.625, + -37.25, + 49.75, + 38.5, + -1.2890625, + 41, + -5.375, + 32.75, + -15.125, + -47.75, + -22.625, + 0.41210938, + 44, + -10.9375, + -9.6875, + 22, + 31.125 + ], + "floatVecField": [ + 0.49299097, + 0.60669976, + 0.7255986, + 0.9660784, + 0.2832972, + 0.1728531, + 0.34663504, + 0.1952663, + 0.8809008, + 0.6806379, + 0.50340945, + 0.033675253, + 0.7491761, + 0.6856438, + 0.68711257, + 0.8037158, + 0.00802033, + 0.45153674, + 0.54998195, + 0.9902218, + 0.35491908, + 0.50118494, + 0.34379217, + 0.4192287, + 0.2801085, + 0.4272149, + 0.12914854, + 0.9693281, + 0.09307258, + 0.44186774, + 0.8025731, + 0.71986085, + 0.31505254, + 0.53997296, + 0.385138, + 0.78098506, + 0.89398426, + 0.96449023, + 0.10654061, + 0.9109775, + 0.018467193, + 0.87265515, + 0.9779257, + 0.48103547, + 0.27451503, + 0.37968302, + 0.55619115, + 0.24895614, + 0.1408114, + 0.14796372, + 0.4750359, + 0.62772405, + 0.06170911, + 0.05801109, + 0.66027737, + 0.77518344, + 0.49363184, + 0.5446333, + 0.79294777, + 0.8753984, + 0.09297751, + 0.51697016, + 0.17957251, + 0.1652925 + ] + }, + { + "bfloat16VecField": [ + -14.3125, + 29.375, + 43.5, + -35.25, + -10.875, + -23.5, + 31.25, + 18.125, + -45, + 45, + -47.5, + -3.9375, + -35.75, + -12.875, + 29.5, + -22.25, + -20.25, + 19.375, + -1.3125, + -15.4375, + -23.375, + -29.875, + 24, + 16.5, + 34.75, + 11.625, + -36.75, + -22.5, + 28.75, + 12.6875, + -33, + -46.75 + ], + "floatVecField": [ + 0.9213663, + 0.2067104, + 0.8194554, + 0.07163238, + 0.29493383, + 0.35645404, + 0.5197381, + 0.23404017, + 0.58033633, + 0.147634, + 0.78011477, + 0.17411314, + 0.80186105, + 0.009533442, + 0.072534, + 0.6668891, + 0.75870925, + 0.21702024, + 0.78547096, + 0.27267113, + 0.2384461, + 0.08041846, + 0.87358576, + 0.30090678, + 0.17835183, + 0.6862718, + 0.9563139, + 0.9139406, + 0.9431139, + 0.9229123, + 0.21519598, + 0.99552095, + 0.71319956, + 0.3893505, + 0.17910346, + 0.95784646, + 0.013270243, + 0.1284785, + 0.53088325, + 0.95699644, + 0.48067525, + 0.14814761, + 0.77812046, + 0.37037137, + 0.81162035, + 0.09136994, + 0.71973705, + 0.56971186, + 0.6220902, + 0.04613972, + 0.76648045, + 0.16475396, + 0.515682, + 0.6996957, + 0.5815975, + 0.3853466, + 0.26531178, + 0.08837006, + 0.25196186, + 0.746547, + 0.16235468, + 0.82735366, + 0.82759523, + 0.38788438 + ] + }, + { + "bfloat16VecField": [ + 38.5, + -41.75, + 43.5, + 6.46875, + -6.75, + -32.25, + 0.13476562, + -8.125, + -17.875, + 43, + -44.5, + 44, + -2.484375, + 2.78125, + -47.25, + -7.9375, + 37.25, + -2.828125, + -9.125, + -29.25, + -27.375, + -10.3125, + -10.5, + 39.5, + 11.25, + 20.25, + -18.375, + 46.75, + 29.125, + -18.5, + -2.890625, + -4.8125 + ], + "floatVecField": [ + 0.7499044, + 0.6082224, + 0.04600758, + 0.756421, + 0.36785427, + 0.3907128, + 0.34838134, + 0.9637292, + 0.6703868, + 0.21823753, + 0.24913333, + 0.3897862, + 0.47058183, + 0.14845668, + 0.3927802, + 0.91508347, + 0.47556123, + 0.427734, + 0.0977878, + 0.5947833, + 0.45757675, + 0.58309966, + 0.60065717, + 0.8963997, + 0.69271046, + 0.96909314, + 0.63311565, + 0.10101731, + 0.7781783, + 0.4203217, + 0.74571836, + 0.8904306, + 0.5162373, + 0.32900667, + 0.4583806, + 0.48422176, + 0.8142127, + 0.278355, + 0.66588175, + 0.12406232, + 0.08029646, + 0.24347836, + 0.9023182, + 0.5614329, + 0.9007428, + 0.3013189, + 0.6705569, + 0.3356448, + 0.61481994, + 0.4998917, + 0.43889478, + 0.613919, + 0.5923885, + 0.3277796, + 0.16121727, + 0.51642233, + 0.95506155, + 0.9733222, + 0.9984757, + 0.8612389, + 0.25767553, + 0.20396885, + 0.7971047, + 0.78301114 + ] + }, + { + "bfloat16VecField": [ + -31.625, + -36.75, + 44, + 24.125, + 38, + 39, + -47.25, + 2.9375, + 21.625, + -43.75, + -1.40625, + 0.19726562, + 43.75, + -17.125, + 4.28125, + 42, + -15.1875, + -35.5, + 35.5, + 1.8515625, + -0.68359375, + 40.75, + 31.625, + 1.4765625, + 25.5, + 27.5, + -6.6875, + -11.5, + -48, + -12.125, + -29, + 39 + ], + "floatVecField": [ + 0.6887204, + 0.14062339, + 0.11249231, + 0.5297888, + 0.302295, + 0.17829974, + 0.6992149, + 0.9008723, + 0.15324138, + 0.17273119, + 0.43359634, + 0.56508476, + 0.82303756, + 0.5626456, + 0.72085315, + 0.31903756, + 0.1659478, + 0.14841586, + 0.5684313, + 0.67632043, + 0.48421606, + 0.30804694, + 0.4749733, + 0.9556809, + 0.19178192, + 0.2144887, + 0.6936653, + 0.84219044, + 0.27885798, + 0.4110932, + 0.8948654, + 0.8956662, + 0.8753252, + 0.7423812, + 0.033641696, + 0.6924315, + 0.19396894, + 0.14818741, + 0.6183352, + 0.7306087, + 0.14724658, + 0.7827952, + 0.39324215, + 0.9501331, + 0.38088, + 0.67022586, + 0.9249631, + 0.6758097, + 0.8533369, + 0.52144116, + 0.82017606, + 0.78405917, + 0.61928725, + 0.31300277, + 0.5773133, + 0.7616527, + 0.087058045, + 0.9317358, + 0.6804799, + 0.37483296, + 0.32740945, + 0.35991904, + 0.6624307, + 0.07789241 + ] + }, + { + "bfloat16VecField": [ + -47.75, + -40.5, + -15.375, + -30.375, + 40, + 38.25, + -28.625, + 26.25, + 48.75, + 35.25, + 36.5, + 43.5, + -0.38085938, + 39.75, + 25.25, + 4.5625, + 25.625, + 27.375, + 15.5, + 2.640625, + 41.25, + -41, + 21.25, + 2.953125, + -46, + -41.5, + 8.3125, + 32.75, + 38.75, + -11.0625, + -43.25, + -37.5 + ], + "floatVecField": [ + 0.017947042, + 0.48250577, + 0.28054005, + 0.47947365, + 0.45112506, + 0.26288265, + 0.62965137, + 0.6294838, + 0.85508645, + 0.19715182, + 0.07751826, + 0.83312213, + 0.5550844, + 0.42313898, + 0.09876509, + 0.6960997, + 0.5310557, + 0.13520217, + 0.88348854, + 0.8506519, + 0.44736394, + 0.66341966, + 0.56724215, + 0.47579452, + 0.21798031, + 0.99061215, + 0.75666445, + 0.23997693, + 0.1332018, + 0.88050044, + 0.7928157, + 0.3843616, + 0.3736546, + 0.60549045, + 0.36133078, + 0.91416734, + 0.79834336, + 0.3018855, + 0.84869003, + 0.22238638, + 0.7891533, + 0.3823862, + 0.7528435, + 0.3097575, + 0.10862334, + 0.6509364, + 0.131224, + 0.8229386, + 0.18651092, + 0.73253745, + 0.79804456, + 0.6416439, + 0.5279717, + 0.54180264, + 0.8943181, + 0.026592141, + 0.9118344, + 0.60790145, + 0.19559185, + 0.32485104, + 0.12164103, + 0.26231527, + 0.66497064, + 0.5828873 + ] + }, + { + "bfloat16VecField": [ + 45.25, + -19.5, + -44, + 24.125, + 3.265625, + 24.875, + -18, + 2.296875, + -29.625, + 7.21875, + -15.4375, + -30, + 47.25, + -15.375, + 27.625, + 27.75, + -19.875, + 33.75, + 29.75, + 7.5625, + -49.25, + -43.75, + 14.25, + -49, + 41.5, + 44.5, + -27.75, + -13.75, + -1.328125, + -31.5, + 23.25, + -5.5 + ], + "floatVecField": [ + 0.31332725, + 0.5440178, + 0.640527, + 0.58146673, + 0.3492562, + 0.6917331, + 0.38422954, + 0.2752066, + 0.79968417, + 0.57821006, + 0.16999269, + 0.596704, + 0.22026998, + 0.037558965, + 0.04146293, + 0.9879877, + 0.12866592, + 0.10328197, + 0.7057433, + 0.06650929, + 0.7255013, + 0.27703872, + 0.311648, + 0.14433324, + 0.41616812, + 0.1855511, + 0.33425564, + 0.8069384, + 0.20618053, + 0.2955282, + 0.9543837, + 0.8434864, + 0.5424556, + 0.5660385, + 0.78069264, + 0.29040763, + 0.6296755, + 0.79902434, + 0.13794279, + 0.4694087, + 0.11538106, + 0.22283576, + 0.7466926, + 0.7681676, + 0.347944, + 0.6670021, + 0.98277885, + 0.010990875, + 0.6446442, + 0.65031505, + 0.4111733, + 0.34064627, + 0.005761886, + 0.42036852, + 0.78359383, + 0.5507451, + 0.46118942, + 0.98159045, + 0.84335446, + 0.38680914, + 0.40732512, + 0.5242962, + 0.7511007, + 0.69093 + ] + }, + { + "bfloat16VecField": [ + -41.25, + -44.25, + -24.125, + 21.5, + 23.5, + -22.5, + 24.125, + -9.875, + -0.18359375, + 35, + 34.75, + -33, + -41, + -7.6875, + -16, + 21.875, + -20, + 19.25, + -42.5, + 34.5, + 45.5, + -37.25, + -3.234375, + -12.5, + -22.875, + 33.75, + -28.375, + -47.5, + 5.71875, + -35, + -21.5, + -11.125 + ], + "floatVecField": [ + 0.38481557, + 0.55994505, + 0.5182144, + 0.47254342, + 0.981768, + 0.9645172, + 0.47533408, + 0.1326061, + 0.7386776, + 0.0575676, + 0.47985643, + 0.8959506, + 0.8676058, + 0.8915154, + 0.17258133, + 0.068319805, + 0.9427602, + 0.27903512, + 0.59765935, + 0.8119886, + 0.5972521, + 0.8154834, + 0.5111275, + 0.4901353, + 0.13070539, + 0.7641518, + 0.20498353, + 0.92043, + 0.47185355, + 0.39859426, + 0.86908466, + 0.9990107, + 0.1593444, + 0.93400264, + 0.90353245, + 0.5479588, + 0.32046032, + 0.45699275, + 0.968669, + 0.110974334, + 0.5623078, + 0.8553507, + 0.57520455, + 0.22622274, + 0.8510899, + 0.38770708, + 0.33949324, + 0.6523546, + 0.45919695, + 0.9255177, + 0.7103591, + 0.76369226, + 0.64634556, + 0.7872461, + 0.3415634, + 0.44935876, + 0.48420885, + 0.19888888, + 0.75482595, + 0.35173783, + 0.6433343, + 0.45049447, + 0.44034663, + 0.29762152 + ] + }, + { + "bfloat16VecField": [ + -38, + -9.9375, + 41, + -21.125, + -0.076660156, + -42.75, + 18.25, + 2.296875, + -38.75, + 42.25, + -16.875, + -0.30273438, + -43.5, + 40.5, + 22.375, + 28.75, + 4.1875, + -27.375, + -18.875, + 38.75, + -22.875, + -34, + -48, + 31.75, + -30, + -5.9375, + 13.0625, + 37, + 41.75, + 48, + -39.5, + 24.875 + ], + "floatVecField": [ + 0.6311647, + 0.7039291, + 0.9970396, + 0.6997801, + 0.08913714, + 0.6380122, + 0.667495, + 0.19461247, + 0.1231402, + 0.48872498, + 0.7886837, + 0.8881885, + 0.64468485, + 0.62033284, + 0.22498588, + 0.88499, + 0.05328826, + 0.7476439, + 0.89539367, + 0.2873537, + 0.20637093, + 0.5266701, + 0.4312897, + 0.20525205, + 0.2475555, + 0.7239283, + 0.34417212, + 0.36193305, + 0.7878412, + 0.22535855, + 0.71445096, + 0.4465551, + 0.7624065, + 0.48027232, + 0.4707877, + 0.23470849, + 0.15025002, + 0.5552165, + 0.040255725, + 0.4865327, + 0.06282807, + 0.92613304, + 0.7903559, + 0.03883608, + 0.7445336, + 0.10836924, + 0.5621311, + 0.10009188, + 0.95276237, + 0.5121776, + 0.9642029, + 0.4944488, + 0.639066, + 0.8761793, + 0.15080959, + 0.2858151, + 0.25565785, + 0.68875563, + 0.46662262, + 0.027056733, + 0.5162947, + 0.74760115, + 0.18430208, + 0.20458786 + ] + }, + { + "bfloat16VecField": [ + 25.375, + -39.75, + 9.25, + 20.625, + 39.25, + 35.75, + -0.42578125, + -19.375, + 27.125, + -20.75, + 11.5, + -1.7109375, + 2.296875, + 28.5, + -36.5, + -40.5, + 13.9375, + 0.49414062, + 22.25, + -38, + -18.5, + -7.71875, + 44.5, + 43.5, + -24.625, + 47.75, + 11.9375, + -11.6875, + 28.5, + -28, + -14.125, + -19 + ], + "floatVecField": [ + 0.485508, + 0.37413764, + 0.44523484, + 0.7034456, + 0.20240489, + 0.32506016, + 0.26833525, + 0.58034086, + 0.80459577, + 0.9011667, + 0.8248614, + 0.36656705, + 0.63884205, + 0.36716858, + 0.6394874, + 0.42966753, + 0.8613801, + 0.13905747, + 0.8426798, + 0.8713795, + 0.61677396, + 0.033363428, + 0.01474943, + 0.41278362, + 0.8489571, + 0.6606854, + 0.49274525, + 0.47446364, + 0.8473977, + 0.21751642, + 0.61549896, + 0.21692774, + 0.26380092, + 0.7585806, + 0.17606394, + 0.59876347, + 0.32843724, + 0.23758106, + 0.55580044, + 0.022633398, + 0.3554391, + 0.76319575, + 0.7318612, + 0.5894881, + 0.89043605, + 0.6222616, + 0.5246171, + 0.2180436, + 0.05268929, + 0.0694858, + 0.46813032, + 0.78465724, + 0.04525981, + 0.25531834, + 0.11470863, + 0.28502873, + 0.35879132, + 0.93637526, + 0.9740101, + 0.30210015, + 0.633937, + 0.24760158, + 0.086867526, + 0.40525 + ] + }, + { + "bfloat16VecField": [ + -38.5, + -31.875, + -6.25, + -15.25, + -37.75, + -20.875, + -28.75, + 49, + -20.875, + -4.59375, + 49.25, + -41.5, + -44.25, + -38.75, + 1.1875, + 1.0234375, + 18.375, + -21.875, + -13.9375, + 23, + -28, + -29.25, + 36, + 14.625, + 21.5, + 3.984375, + 23.25, + 26.875, + 36, + 2.96875, + -8.4375, + 45.75 + ], + "floatVecField": [ + 0.7627204, + 0.6814395, + 0.84726834, + 0.38800123, + 0.76666945, + 0.45129156, + 0.56687385, + 0.3377285, + 0.6507701, + 0.2618101, + 0.07264566, + 0.20779583, + 0.1400014, + 0.66997397, + 0.14330772, + 0.7049595, + 0.8315254, + 0.35937, + 0.73477954, + 0.51851135, + 0.8071333, + 0.19902924, + 0.88719046, + 0.62642944, + 0.84272975, + 0.87869865, + 0.96428275, + 0.42077026, + 0.062512726, + 0.19007245, + 0.66304594, + 0.5344539, + 0.5946874, + 0.8542645, + 0.069360346, + 0.98904055, + 0.23936239, + 0.07213634, + 0.47230503, + 0.19254881, + 0.82497114, + 0.9195776, + 0.21922636, + 0.083431736, + 0.49258223, + 0.8932931, + 0.099244036, + 0.962404, + 0.29502317, + 0.09243759, + 0.5562602, + 0.13561171, + 0.79159254, + 0.97346765, + 0.21825305, + 0.4180513, + 0.8966236, + 0.24452962, + 0.19216384, + 0.8397652, + 0.21003537, + 0.15051709, + 0.3868629, + 0.2978314 + ] + }, + { + "bfloat16VecField": [ + 49.5, + 5.6875, + 6.34375, + -6.75, + 3.34375, + 24.75, + 7.46875, + 14.5625, + 10.5625, + -27.5, + -29.625, + 40.75, + 6.71875, + 38, + -5.78125, + -46.75, + -7.03125, + 19.375, + -47.75, + 3.375, + -26.25, + 14.9375, + 25, + -10.625, + -49.5, + -14.375, + 18.25, + 28.875, + -35, + -46, + 48.75, + 44.25 + ], + "floatVecField": [ + 0.5509639, + 0.029782217, + 0.4313001, + 0.30515757, + 0.3051365, + 0.1123025, + 0.33134604, + 0.802061, + 0.42340028, + 0.43911517, + 0.4626259, + 0.11786947, + 0.7664922, + 0.9635163, + 0.77325237, + 0.8919121, + 0.8388937, + 0.8598515, + 0.18766908, + 0.5799235, + 0.5305545, + 0.6420454, + 0.7397006, + 0.96896595, + 0.6772394, + 0.5316254, + 0.932966, + 0.57283396, + 0.41292074, + 0.04717832, + 0.056807846, + 0.09394761, + 0.2750302, + 0.7622157, + 0.3506675, + 0.8925932, + 0.1684426, + 0.11699017, + 0.04952356, + 0.0914638, + 0.63776934, + 0.9108202, + 0.93826497, + 0.006844556, + 0.9299634, + 0.5443876, + 0.06548336, + 0.6277939, + 0.2160309, + 0.9448154, + 0.20667377, + 0.14197855, + 0.62837726, + 0.19404605, + 0.7578995, + 0.14702083, + 0.7972461, + 0.5186217, + 0.7692913, + 0.51831853, + 0.14913507, + 0.06628585, + 0.38322803, + 0.05269277 + ] + }, + { + "bfloat16VecField": [ + 42.25, + -24.5, + 46.75, + 47, + 35.25, + -25.375, + -40.25, + 12.8125, + -26.625, + 7.21875, + 7.15625, + -34.75, + 0.76953125, + -25.125, + -47.5, + 0.44140625, + 25.75, + -38, + -8.4375, + 14.375, + 42, + 44, + 1.234375, + -41.25, + 39.25, + 43.75, + 38.5, + 36.5, + 45.5, + 2.3125, + -32.75, + 24.375 + ], + "floatVecField": [ + 0.041705105, + 0.6383004, + 0.8833641, + 0.72362936, + 0.8921708, + 0.17722881, + 0.7442426, + 0.8222386, + 0.5975064, + 0.26232928, + 0.56926024, + 0.5664463, + 0.44310778, + 0.36307135, + 0.020206328, + 0.062436845, + 0.34376124, + 0.39764518, + 0.8686831, + 0.51272166, + 0.39947584, + 0.67073464, + 0.023358777, + 0.9328068, + 0.28298253, + 0.37510207, + 0.23527198, + 0.95103836, + 0.71554214, + 0.47228003, + 0.008217248, + 0.9748903, + 0.4932124, + 0.09929584, + 0.504065, + 0.26324794, + 0.6780665, + 0.5547523, + 0.4903993, + 0.10167649, + 0.4234896, + 0.4966888, + 0.113714494, + 0.81475395, + 0.51038975, + 0.18062145, + 0.140442, + 0.19001216, + 0.8742891, + 0.8601943, + 0.0750556, + 0.92836446, + 0.81780815, + 0.7509072, + 0.45161614, + 0.7329662, + 0.45562586, + 0.6959437, + 0.027150322, + 0.56853414, + 0.4591578, + 0.49025196, + 0.99879986, + 0.07836844 + ] + }, + { + "bfloat16VecField": [ + -18.875, + 41.5, + 23.625, + -31.375, + 34.25, + 34.25, + -15.5, + 16.5, + 7.28125, + 0.19628906, + 0.15136719, + -12.875, + 16.375, + -43.75, + 18, + -42, + -7.0625, + -45.75, + -48, + 3.328125, + -41.75, + 4.40625, + 20.875, + -39.5, + -2.3125, + 15.625, + 31.125, + 49.75, + 14.4375, + 25, + -27.625, + -17.125 + ], + "floatVecField": [ + 0.42909855, + 0.41114295, + 0.99639934, + 0.77841556, + 0.7728038, + 0.3049477, + 0.00024157738, + 0.23110604, + 0.5292935, + 0.15797603, + 0.2501885, + 0.36736542, + 0.32837564, + 0.18685159, + 0.083245955, + 0.79912204, + 0.7044796, + 0.9244028, + 0.98805666, + 0.037623316, + 0.031225242, + 0.36362216, + 0.8414825, + 0.22339684, + 0.55366313, + 0.80307144, + 0.76240563, + 0.08253695, + 0.5705359, + 0.43594676, + 0.15017973, + 0.3282078, + 0.5702909, + 0.9738724, + 0.66884625, + 0.14497477, + 0.049679205, + 0.3159888, + 0.93423575, + 0.16799082, + 0.58551484, + 0.2825535, + 0.22577018, + 0.31578282, + 0.03710928, + 0.5682509, + 0.536554, + 0.78144675, + 0.3653436, + 0.83223224, + 0.43490106, + 0.66028, + 0.9068104, + 0.80341053, + 0.19326198, + 0.7475824, + 0.2371221, + 0.04910441, + 0.6053862, + 0.010719138, + 0.000581316, + 0.78530145, + 0.51792777, + 0.39994228 + ] + }, + { + "bfloat16VecField": [ + -45.25, + -49.25, + 13.3125, + 49.5, + -12.3125, + -8.0625, + 39, + 42.5, + 5.375, + -45.75, + -9.1875, + 12, + -32.75, + 9.375, + 7.90625, + -26.75, + 3.140625, + 47, + 8.125, + -2.328125, + -11.75, + 7.84375, + -1.3671875, + 45.25, + -42.25, + 48.75, + -9.875, + -16.5, + -41, + -7.34375, + 14.25, + 38.5 + ], + "floatVecField": [ + 0.96042484, + 0.08633099, + 0.7619173, + 0.6620993, + 0.93284464, + 0.663595, + 0.98592705, + 0.2619552, + 0.067823894, + 0.7520335, + 0.88650835, + 0.35489014, + 0.97232604, + 0.5589001, + 0.9234113, + 0.9402044, + 0.9266912, + 0.5828965, + 0.4654987, + 0.46655563, + 0.70100397, + 0.34398276, + 0.21294428, + 0.6539319, + 0.2694643, + 0.33125007, + 0.63664305, + 0.4000551, + 0.56771487, + 0.80243206, + 0.7478664, + 0.16125475, + 0.18746527, + 0.11206545, + 0.83884364, + 0.18590458, + 0.78139395, + 0.43678468, + 0.8285131, + 0.7422769, + 0.8235813, + 0.92024803, + 0.7118208, + 0.51936716, + 0.84390926, + 0.16127782, + 0.8861721, + 0.1941016, + 0.6696561, + 0.47817594, + 0.7049164, + 0.5167243, + 0.6524602, + 0.80660456, + 0.54793084, + 0.6902853, + 0.18316098, + 0.5816356, + 0.1595545, + 0.35242814, + 0.96393216, + 0.28539795, + 0.27765468, + 0.47289863 + ] + }, + { + "bfloat16VecField": [ + 14.8125, + -7.90625, + 45, + -46.75, + 26.125, + -22, + -28, + -8.4375, + 29.5, + -27.75, + -36.25, + 34.25, + 17.75, + 32.75, + 13, + 15.9375, + -1.6953125, + 20.125, + -37.75, + 46, + -47.5, + 8.375, + -47.75, + -31.75, + -9.375, + 46, + 29.25, + -26.25, + -7.78125, + 19.75, + -6.1875, + 16.625 + ], + "floatVecField": [ + 0.5678944, + 0.65635395, + 0.006604923, + 0.35460362, + 0.4374972, + 0.64028263, + 0.19585402, + 0.007406307, + 0.8004375, + 0.6494671, + 0.5542871, + 0.30078718, + 0.49070162, + 0.34125936, + 0.9734557, + 0.57337385, + 0.030368831, + 0.34900844, + 0.67142606, + 0.9592718, + 0.8469602, + 0.19945462, + 0.13889463, + 0.24318047, + 0.40996248, + 0.61899215, + 0.7639662, + 0.5842669, + 0.38018474, + 0.43146282, + 0.5464036, + 0.08657966, + 0.43592992, + 0.4794207, + 0.4413182, + 0.5369253, + 0.27165663, + 0.914784, + 0.91725194, + 0.5393848, + 0.54717594, + 0.8472321, + 0.12832941, + 0.15323599, + 0.6103929, + 0.45438367, + 0.035166003, + 0.18547377, + 0.19722958, + 0.98077357, + 0.8287249, + 0.076168805, + 0.16963191, + 0.48009062, + 0.26132342, + 0.4656917, + 0.2770149, + 0.9720249, + 0.7177586, + 0.14444548, + 0.30237275, + 0.8843471, + 0.38787398, + 0.607939 + ] + }, + { + "bfloat16VecField": [ + 12.8125, + -1.75, + 2.59375, + 37, + 9.4375, + -1.9921875, + -11.5625, + 18.875, + -4.3125, + -32.25, + 41.5, + -18, + -38.25, + 2.625, + -7.375, + -37.25, + 29.75, + -16.125, + -10.25, + 33.75, + -42.5, + -22.5, + 36.75, + -17.5, + 16.375, + -3.6875, + 46.5, + -41.75, + 42, + -36.25, + 30.375, + 7.21875 + ], + "floatVecField": [ + 0.1938324, + 0.99672353, + 0.235223, + 0.83634925, + 0.9410029, + 0.76632005, + 0.6634547, + 0.8732806, + 0.3698566, + 0.5439387, + 0.28678933, + 0.11723526, + 0.1853206, + 0.13191392, + 0.07727673, + 0.027872235, + 0.7030078, + 0.45287842, + 0.9789467, + 0.889126, + 0.14399788, + 0.67576456, + 0.72797394, + 0.20543203, + 0.8038291, + 0.4408608, + 0.64913845, + 0.9765854, + 0.09074257, + 0.1942085, + 0.054001357, + 0.4050219, + 0.6223819, + 0.8619756, + 0.8701886, + 0.85045105, + 0.47723883, + 0.8748099, + 0.8033408, + 0.7620364, + 0.9903744, + 0.76283896, + 0.27105266, + 0.10287778, + 0.84255373, + 0.88812345, + 0.5405998, + 0.9509775, + 0.25392544, + 0.090871744, + 0.9112844, + 0.101317056, + 0.07873133, + 0.18919395, + 0.044887595, + 0.62110466, + 0.86582834, + 0.6284731, + 0.41711882, + 0.5855681, + 0.2133482, + 0.3794744, + 0.17963211, + 0.29978642 + ] + }, + { + "bfloat16VecField": [ + 38.5, + 27.875, + 14.3125, + 9.75, + 35.5, + -29.125, + 26.25, + -40.25, + 27.25, + 25.5, + 30, + 3.421875, + 15.4375, + -7.4375, + -31.75, + 32.25, + -29.375, + 23.625, + 20.125, + -1.765625, + -18.875, + -28.375, + 2.578125, + 43.5, + -45.25, + 16.125, + -30.375, + 48.5, + 31.25, + 44.25, + 11, + -11.3125 + ], + "floatVecField": [ + 0.1240148, + 0.77782154, + 0.4081531, + 0.39551592, + 0.38535717, + 0.78647715, + 0.86188155, + 0.013923938, + 0.58831686, + 0.030830426, + 0.92216647, + 0.87824017, + 0.95624125, + 0.79865104, + 0.14260657, + 0.45799682, + 0.0038860955, + 0.13945766, + 0.17483523, + 0.6427449, + 0.56566167, + 0.11436719, + 0.7543065, + 0.48445043, + 0.4299949, + 0.2841194, + 0.5097139, + 0.8935228, + 0.8178599, + 0.7687223, + 0.48447308, + 0.71441066, + 0.50305116, + 0.7015192, + 0.6241829, + 0.07719381, + 0.6756355, + 0.6987203, + 0.55823463, + 0.96462274, + 0.7121218, + 0.3423468, + 0.6912599, + 0.40709043, + 0.70286983, + 0.7955218, + 0.32093677, + 0.203468, + 0.075851694, + 0.4656846, + 0.26122615, + 0.8752172, + 0.67164487, + 0.48096892, + 0.5212409, + 0.18179122, + 0.8919191, + 0.9296869, + 0.64448655, + 0.013611398, + 0.54114133, + 0.7515602, + 0.014805977, + 0.29896048 + ] + }, + { + "bfloat16VecField": [ + -46.5, + -23.25, + 12.0625, + 25.5, + -49.25, + -33.25, + -23.625, + -32.25, + -45, + 14.4375, + 12.3125, + 28.375, + 44.5, + 23.5, + 26.25, + 13.875, + -20.5, + 47.25, + -41, + 37, + -2.328125, + 11.625, + -16.5, + 5.125, + -23.625, + -30.125, + -5.53125, + -42.25, + -14.1875, + -42, + 11.6875, + 26.375 + ], + "floatVecField": [ + 0.26171908, + 0.83613133, + 0.06694071, + 0.5851511, + 0.2154965, + 0.9470661, + 0.2899432, + 0.25609004, + 0.6737154, + 0.027478006, + 0.08794049, + 0.3499198, + 0.11908838, + 0.56271243, + 0.8853933, + 0.4706901, + 0.91211987, + 0.9246277, + 0.5807798, + 0.40098327, + 0.5382785, + 0.08365422, + 0.9494101, + 0.24158487, + 0.95071083, + 0.5344465, + 0.77909017, + 0.40280303, + 0.102491274, + 0.15662812, + 0.76348794, + 0.40891927, + 0.31434202, + 0.37192598, + 0.2863421, + 0.6679036, + 0.7916158, + 0.96933925, + 0.9243236, + 0.017540028, + 0.5550986, + 0.09432573, + 0.6978171, + 0.2754851, + 0.7672237, + 0.20720227, + 0.23209961, + 0.6092465, + 0.30031222, + 0.030145053, + 0.9834449, + 0.4556176, + 0.21926801, + 0.7961434, + 0.8495683, + 0.6774702, + 0.40296236, + 0.3163265, + 0.39471167, + 0.55921847, + 0.7368836, + 0.45940822, + 0.37820554, + 0.14997303 + ] + }, + { + "bfloat16VecField": [ + -44, + 8.125, + 45.75, + 42, + -9.0625, + -48.25, + 42.25, + -34.5, + 8.4375, + -10, + -35.75, + -44.75, + -47.75, + -42, + -7.65625, + -6.4375, + -23.375, + -25.25, + -12.625, + -46.75, + 13.25, + -15.1875, + 14.4375, + -0.7109375, + 44, + -10.125, + -1.4921875, + 21.125, + -16.875, + -39, + 0.484375, + -4.75 + ], + "floatVecField": [ + 0.9526822, + 0.84572, + 0.07693938, + 0.033353645, + 0.75430536, + 0.20826069, + 0.82923794, + 0.90336996, + 0.45348108, + 0.91502213, + 0.1711237, + 0.049990546, + 0.9746897, + 0.48854926, + 0.5034416, + 0.33034396, + 0.54238445, + 0.036024738, + 0.44101116, + 0.051864736, + 0.60992193, + 0.5522058, + 0.9253114, + 0.55464536, + 0.94378155, + 0.7744476, + 0.95156723, + 0.18822408, + 0.5483888, + 0.5775691, + 0.7465094, + 0.7361762, + 0.25481337, + 0.8776372, + 0.73700964, + 0.43809554, + 0.41056338, + 0.41383404, + 0.5371831, + 0.7896648, + 0.5049906, + 0.48260814, + 0.82678795, + 0.9039676, + 0.25424087, + 0.52349246, + 0.13642232, + 0.377929, + 0.44594964, + 0.17070943, + 0.997932, + 0.24845155, + 0.7359545, + 0.1588471, + 0.54121345, + 0.7599817, + 0.4180834, + 0.5114587, + 0.2680024, + 0.19084214, + 0.34330842, + 0.27343884, + 0.98883754, + 0.6298534 + ] + }, + { + "bfloat16VecField": [ + 14.875, + 14.4375, + -44.25, + -18.125, + -40.75, + 22.5, + -20, + -41.5, + -17.875, + 7.65625, + 24.25, + 40.25, + 39.5, + 6.53125, + 23.625, + -38.25, + 44, + 31, + 24.125, + 38, + -8.375, + 18, + 9.3125, + -38, + 40, + 23.625, + 1.4296875, + 46, + 5.46875, + -27.125, + -44, + -11.8125 + ], + "floatVecField": [ + 0.03973828, + 0.26658994, + 0.9698141, + 0.068087325, + 0.14830515, + 0.64193696, + 0.6726394, + 0.08629454, + 0.38526925, + 0.49624127, + 0.055456672, + 0.21034083, + 0.037738558, + 0.40161678, + 0.8467511, + 0.68289715, + 0.7003766, + 0.7500926, + 0.13233525, + 0.026815558, + 0.8098169, + 0.15925592, + 0.18437134, + 0.5600783, + 0.11781018, + 0.5620204, + 0.38370392, + 0.49682468, + 0.26775235, + 0.5721835, + 0.4297453, + 0.6282406, + 0.05765445, + 0.13430794, + 0.758036, + 0.2840832, + 0.0014284799, + 0.47534388, + 0.47782558, + 0.15137424, + 0.64454716, + 0.26645494, + 0.5587303, + 0.4156306, + 0.9401017, + 0.86399496, + 0.086120605, + 0.8928951, + 0.26487336, + 0.81005096, + 0.4418991, + 0.40074307, + 0.49249643, + 0.21693943, + 0.84377587, + 0.4805802, + 0.29366177, + 0.9233404, + 0.33567294, + 0.6839734, + 0.1500561, + 0.89936155, + 0.9820711, + 0.81563 + ] + }, + { + "bfloat16VecField": [ + -20.125, + 19.375, + -23.25, + 30.625, + 40.75, + 23.375, + 12.3125, + 6.0625, + -46.25, + 41.5, + -10.0625, + -47.25, + -26.375, + 25.125, + 30, + -3.15625, + -6.03125, + 29.625, + -23.75, + -49.5, + -11.375, + 8.25, + 0.84765625, + -30.5, + -21.75, + 20.5, + 27.5, + -21, + 49.75, + 33, + -40.75, + 6.78125 + ], + "floatVecField": [ + 0.7131932, + 0.6045929, + 0.98346496, + 0.07972702, + 0.21830723, + 0.12825489, + 0.28065774, + 0.6826569, + 0.53192484, + 0.80409324, + 0.6353177, + 0.34708223, + 0.1299556, + 0.27883154, + 0.0072683324, + 0.395663, + 0.24460179, + 0.33068857, + 0.9198001, + 0.036530364, + 0.58956194, + 0.14325668, + 0.93349797, + 0.65912765, + 0.5325456, + 0.3576081, + 0.5491489, + 0.07130153, + 0.944526, + 0.33946928, + 0.8513438, + 0.18431167, + 0.09629722, + 0.8872502, + 0.863087, + 0.067006014, + 0.8199737, + 0.30990428, + 0.9366058, + 0.35181284, + 0.74677974, + 0.9992552, + 0.85056573, + 0.9528217, + 0.25659418, + 0.8380662, + 0.8311591, + 0.8282343, + 0.11205584, + 0.37173423, + 0.21424085, + 0.023658725, + 0.7479285, + 0.6989943, + 0.63152707, + 0.84121716, + 0.33972478, + 0.9473938, + 0.29338515, + 0.40680206, + 0.87937045, + 0.71108705, + 0.7704121, + 0.81414914 + ] + }, + { + "bfloat16VecField": [ + -34, + -13.4375, + 10.625, + -4.78125, + 20.875, + 8.3125, + 46.25, + -47, + -46.25, + 3.15625, + 9.8125, + -21.25, + 2.625, + 17.125, + -32.75, + -40.25, + 29.875, + -4.5, + -28.5, + 35.75, + -10.625, + 27, + -18.375, + 0.46875, + 12.8125, + 36.75, + -48.75, + -30, + 43.5, + 14.25, + -45.25, + 26.125 + ], + "floatVecField": [ + 0.30276382, + 0.57991666, + 0.72893256, + 0.93929267, + 0.42996946, + 0.1620442, + 0.5826454, + 0.94473046, + 0.67848, + 0.0056335744, + 0.74444085, + 0.15487629, + 0.19423285, + 0.68158334, + 0.94157237, + 0.88909507, + 0.15915476, + 0.33677468, + 0.76449573, + 0.8847488, + 0.3360583, + 0.66711265, + 0.6800323, + 0.74556905, + 0.95203376, + 0.7008657, + 0.5960122, + 0.5470983, + 0.84017175, + 0.11788823, + 0.64108086, + 0.3144919, + 0.8818331, + 0.9085192, + 0.7030433, + 0.35358357, + 0.705931, + 0.5385201, + 0.31476027, + 0.47870356, + 0.3995609, + 0.20089935, + 0.9018119, + 0.107465826, + 0.5896546, + 0.18573724, + 0.95575017, + 0.4679675, + 0.33332205, + 0.30239868, + 0.4095493, + 0.31756735, + 0.031525735, + 0.6330983, + 0.1927361, + 0.47798672, + 0.8206115, + 0.31750423, + 0.17686269, + 0.26835302, + 0.71143186, + 0.9174034, + 0.53541005, + 0.8023905 + ] + }, + { + "bfloat16VecField": [ + -13.5, + -2.65625, + 21.25, + -3.625, + -13.25, + -9.0625, + -39, + -29.625, + -48.25, + 6.28125, + -0.9453125, + -16.125, + 16.25, + 13.1875, + -15.25, + 49, + -47, + 0.546875, + 43.75, + -5.46875, + 44, + 7.875, + 29.375, + 47.5, + -30.875, + -27.125, + 10.6875, + -34.5, + -27.75, + 38.75, + 21.875, + 15.1875 + ], + "floatVecField": [ + 0.5831189, + 0.9691585, + 0.17511983, + 0.033124123, + 0.77160645, + 0.15350373, + 0.9641342, + 0.43508315, + 0.9600237, + 0.6287325, + 0.6321093, + 0.43182096, + 0.12746936, + 0.27343753, + 0.240855, + 0.74354917, + 0.9822053, + 0.3875833, + 0.50600004, + 0.98374975, + 0.83676416, + 0.94756734, + 0.95584303, + 0.06636006, + 0.95247436, + 0.058867272, + 0.92574126, + 0.17170501, + 0.835292, + 0.4926175, + 0.8884916, + 0.46386638, + 0.41667494, + 0.30430174, + 0.698124, + 0.3738558, + 0.7154597, + 0.595849, + 0.814161, + 0.9931353, + 0.3066788, + 0.83028984, + 0.12933777, + 0.9238933, + 0.7471242, + 0.47180006, + 0.5177735, + 0.67320055, + 0.31907263, + 0.72031206, + 0.3441928, + 0.43801364, + 0.78207827, + 0.6235076, + 0.06776595, + 0.8066474, + 0.12091486, + 0.14163363, + 0.88266325, + 0.39450282, + 0.7063997, + 0.0021072507, + 0.6847472, + 0.3238876 + ] + }, + { + "bfloat16VecField": [ + 25.25, + 32.75, + 39.5, + -47.75, + 34.25, + -26.25, + -15.1875, + -49, + -46.25, + -22.625, + 39.75, + -21, + -36.25, + -32.25, + -25.5, + -30.5, + -5.84375, + -21.625, + -49, + -6.03125, + 46, + -19.125, + -49, + -7.6875, + 27.375, + -45.75, + -49.5, + 30.5, + 20.875, + -31.625, + 14.875, + -11.9375 + ], + "floatVecField": [ + 0.48999447, + 0.2847933, + 0.35661402, + 0.779326, + 0.6852362, + 0.5644676, + 0.901124, + 0.36479473, + 0.6802297, + 0.1299042, + 0.030825872, + 0.11191163, + 0.35211995, + 0.22948056, + 0.46754047, + 0.65849364, + 0.108029366, + 0.7446547, + 0.7833142, + 0.62227434, + 0.8746919, + 0.696236, + 0.33222228, + 0.8558004, + 0.6679301, + 0.54482377, + 0.8486694, + 0.019388855, + 0.49573877, + 0.31539324, + 0.8745154, + 0.41464546, + 0.3392511, + 0.7069815, + 0.10469626, + 0.56983244, + 0.66709816, + 0.0056709405, + 0.16666223, + 0.98480886, + 0.20954543, + 0.67209727, + 0.86280763, + 0.87440556, + 0.83808404, + 0.24120809, + 0.14555736, + 0.46011412, + 0.977249, + 0.72908056, + 0.09357973, + 0.60499614, + 0.48353782, + 0.14032312, + 0.71852434, + 0.88778806, + 0.7703664, + 0.40851337, + 0.85072184, + 0.938915, + 0.84709346, + 0.48650527, + 0.95057464, + 0.5220505 + ] + }, + { + "bfloat16VecField": [ + -6.875, + 35.5, + -41.75, + 42.75, + 8.6875, + -10.6875, + 29.75, + -42.75, + 39.5, + -49, + 16.25, + 43.75, + -7.28125, + 19.75, + 41.25, + -39.25, + -8.8125, + 18.25, + -14.5, + 14.9375, + 15.8125, + -0.07861328, + -28.125, + 18, + -45.5, + 49.5, + -38, + -21.25, + 21.875, + -11.1875, + 37, + -23 + ], + "floatVecField": [ + 0.3723158, + 0.7061916, + 0.34697628, + 0.71355575, + 0.3155271, + 0.40974835, + 0.75632423, + 0.3909518, + 0.32781234, + 0.42199117, + 0.076576374, + 0.94606584, + 0.13835704, + 0.1852221, + 0.08483534, + 0.17930067, + 0.7964036, + 0.5419181, + 0.68076175, + 0.15309684, + 0.5598176, + 0.47963065, + 0.5939466, + 0.5576726, + 0.65468186, + 0.24968345, + 0.9485388, + 0.93769044, + 0.23142931, + 0.5178296, + 0.88677055, + 0.20110072, + 0.39238653, + 0.47982478, + 0.16703783, + 0.86080295, + 0.8028504, + 0.25301668, + 0.016537247, + 0.30335456, + 0.20306638, + 0.8193349, + 0.47484338, + 0.73446953, + 0.20321544, + 0.021802766, + 0.36734152, + 0.5543516, + 0.6371901, + 0.0752439, + 0.7763762, + 0.0070848702, + 0.7427706, + 0.54794765, + 0.5153363, + 0.7404349, + 0.79267365, + 0.39591816, + 0.97584057, + 0.9413083, + 0.14703014, + 0.31059554, + 0.24308813, + 0.453541 + ] + }, + { + "bfloat16VecField": [ + 37.75, + -3.609375, + -4.71875, + -6.3125, + 25.5, + -44.5, + 11.625, + -47.5, + 28.75, + 39.25, + 33, + -21.625, + -9.125, + -34.5, + 16.25, + 40.75, + -42, + -39, + -38.5, + 7.75, + 38.25, + -2.53125, + 4.15625, + 3.34375, + -48.5, + -23.5, + 16.625, + -31.875, + 43.25, + -27, + -37.5, + 38.25 + ], + "floatVecField": [ + 0.6902099, + 0.98224443, + 0.22218531, + 0.6914797, + 0.8984686, + 0.55126923, + 0.46103066, + 0.62190145, + 0.6040562, + 0.61077744, + 0.050271552, + 0.13593888, + 0.29492554, + 0.4199703, + 0.66206455, + 0.024337538, + 0.9050209, + 0.21404824, + 0.6812337, + 0.80766386, + 0.1284866, + 0.47485706, + 0.7831489, + 0.44847372, + 0.57320356, + 0.09559885, + 0.5912016, + 0.95778906, + 0.5343507, + 0.37386495, + 0.9813698, + 0.06558716, + 0.6669166, + 0.5673079, + 0.73229057, + 0.14985293, + 0.67122597, + 0.19793984, + 0.6810366, + 0.26834917, + 0.7763995, + 0.8742002, + 0.5791059, + 0.5522534, + 0.34574932, + 0.9827783, + 0.57588506, + 0.64496696, + 0.45394954, + 0.0566683, + 0.5512641, + 0.26870498, + 0.46795076, + 0.46023747, + 0.022970546, + 0.74475515, + 0.7628229, + 0.90927476, + 0.09442218, + 0.7196718, + 0.8761881, + 0.07412771, + 0.9001479, + 0.45880133 + ] + }, + { + "bfloat16VecField": [ + -46, + -29.25, + -23.875, + 8.8125, + 44, + -34, + -36, + -5.5, + -2.484375, + 9.25, + 19.5, + 0.921875, + 48, + -41.5, + 36.5, + -34, + 49, + -13.125, + -3.03125, + -27, + -42, + -7.125, + 33.25, + -37.75, + 9.375, + -28.375, + -22.875, + -43.75, + -46.5, + -37.5, + 32.75, + -32 + ], + "floatVecField": [ + 0.16948672, + 0.9575049, + 0.3795925, + 0.08518478, + 0.016287608, + 0.58976036, + 0.59772104, + 0.9048579, + 0.82033354, + 0.5118714, + 0.72459465, + 0.8797325, + 0.06387481, + 0.032368623, + 0.120871425, + 0.6112618, + 0.2680751, + 0.8443451, + 0.84437567, + 0.84676474, + 0.51409304, + 0.2928473, + 0.33529493, + 0.8560533, + 0.36477008, + 0.60451025, + 0.64234394, + 0.17325066, + 0.18338117, + 0.14227533, + 0.572398, + 0.5025741, + 0.57968044, + 0.049145967, + 0.9727344, + 0.7214965, + 0.9308159, + 0.12670736, + 0.20365737, + 0.62955844, + 0.093838066, + 0.040414844, + 0.40878707, + 0.044829655, + 0.73441744, + 0.72068536, + 0.9633076, + 0.80061144, + 0.3884941, + 0.99745476, + 0.705285, + 0.23640254, + 0.45751, + 0.66486984, + 0.8374338, + 0.7648719, + 0.52758175, + 0.085769, + 0.23309289, + 0.23182905, + 0.08052138, + 0.51061213, + 0.88071936, + 0.83211553 + ] + }, + { + "bfloat16VecField": [ + 3.703125, + 35.75, + 45.25, + -23.25, + 38.75, + -37, + 15.375, + -8.3125, + 28.375, + 5.625, + 38, + -49, + -0.30859375, + -3.5625, + -29.625, + -35.5, + 45.5, + -12.75, + 26.375, + -12.9375, + 24, + -46.25, + 16, + 5.21875, + -43.75, + 43.75, + 45.75, + 2.875, + -37.5, + -24.5, + 37.25, + 34.75 + ], + "floatVecField": [ + 0.0451265, + 0.60541475, + 0.38821563, + 0.1358086, + 0.40735292, + 0.7064019, + 0.64104766, + 0.62286454, + 0.90097314, + 0.81873196, + 0.41711873, + 0.64988697, + 0.6017051, + 0.9384993, + 0.61135375, + 0.98505944, + 0.35403264, + 0.47343937, + 0.74041086, + 0.575882, + 0.57546943, + 0.5348046, + 0.2419378, + 0.30408633, + 0.68112123, + 0.074941404, + 0.6891227, + 0.76770943, + 0.5713198, + 0.7303255, + 0.3794536, + 0.4202227, + 0.50421363, + 0.18496875, + 0.77800834, + 0.53761953, + 0.830535, + 0.70392984, + 0.5996059, + 0.78570336, + 0.7708225, + 0.8390538, + 0.5948143, + 0.82335913, + 0.50793815, + 0.9991803, + 0.6457372, + 0.41689986, + 0.4506702, + 0.7802623, + 0.7588462, + 0.7146182, + 0.122038245, + 0.59240955, + 0.56031626, + 0.11044377, + 0.7592565, + 0.16111268, + 0.86032134, + 0.41119638, + 0.4519747, + 0.5845934, + 0.97738427, + 0.40037072 + ] + }, + { + "bfloat16VecField": [ + -20.375, + -12.125, + -34, + 36, + -32.75, + 12.8125, + 17.25, + 38.25, + 7.15625, + 39.5, + 32, + 7.09375, + -42.5, + -43.25, + 23.75, + 24.375, + 16.125, + 15.8125, + -7.5625, + -1.3515625, + -48.5, + 26.75, + -11.9375, + -16, + -39.75, + 27, + 18.625, + -24, + 5.6875, + 15.0625, + 21, + 29.625 + ], + "floatVecField": [ + 0.33775133, + 0.7142587, + 0.16717607, + 0.5041431, + 0.018830217, + 0.020720925, + 0.9299879, + 0.22351491, + 0.3703962, + 0.5971543, + 0.312481, + 0.10496273, + 0.46240747, + 0.98351574, + 0.8644343, + 0.39652428, + 0.69275993, + 0.3702478, + 0.95464313, + 0.0829308, + 0.87240285, + 0.8567406, + 0.16973004, + 0.17440762, + 0.9024105, + 0.5958147, + 0.6128333, + 0.4198848, + 0.2195047, + 0.12719461, + 0.8150755, + 0.124573626, + 0.4458906, + 0.7662177, + 0.61000544, + 0.8290669, + 0.79503375, + 0.23245706, + 0.5659252, + 0.97921586, + 0.053913906, + 0.7101385, + 0.4600243, + 0.9862773, + 0.33930722, + 0.07818037, + 0.20072675, + 0.5871471, + 0.9511934, + 0.52472174, + 0.5066403, + 0.97685474, + 0.020058872, + 0.9872218, + 0.81309503, + 0.13434742, + 0.865375, + 0.5867703, + 0.3161596, + 0.74259573, + 0.30665305, + 0.63296074, + 0.65004337, + 0.42499596 + ] + }, + { + "bfloat16VecField": [ + -47.25, + -49.5, + -27, + 29.5, + 25, + 46, + -27, + -38.5, + -8.125, + -1.390625, + 11.4375, + -15.625, + -33, + -5.96875, + 36.25, + 2.0625, + -23.75, + -32, + 39.75, + 34.25, + -39.75, + -3.96875, + 47.5, + 46.5, + -11.4375, + 21.75, + -17.875, + 24.625, + -17.25, + 1.5859375, + 11.4375, + -40.5 + ], + "floatVecField": [ + 0.68865955, + 0.3952261, + 0.35932708, + 0.7778047, + 0.48242876, + 0.2205962, + 0.69932187, + 0.15988348, + 0.0068898103, + 0.35140395, + 0.81154877, + 0.9159422, + 0.8053033, + 0.23315075, + 0.20349061, + 0.5079615, + 0.263592, + 0.13210902, + 0.3829875, + 0.71468174, + 0.90841913, + 0.7422445, + 0.03184946, + 0.75469244, + 0.54524183, + 0.9397291, + 0.29475084, + 0.20032765, + 0.035300445, + 0.27699664, + 0.23560034, + 0.37525773, + 0.6289305, + 0.88848585, + 0.29377526, + 0.89954096, + 0.93591875, + 0.40914434, + 0.15751396, + 0.31507373, + 0.252567, + 0.20852126, + 0.44268107, + 0.72115725, + 0.23662059, + 0.541619, + 0.769528, + 0.22597155, + 0.39627573, + 0.58671665, + 0.6038382, + 0.32185254, + 0.29310963, + 0.60472393, + 0.85706747, + 0.21358219, + 0.6259573, + 0.3255484, + 0.94550174, + 0.52363193, + 0.8917227, + 0.19709313, + 0.16709, + 0.67218226 + ] + }, + { + "bfloat16VecField": [ + -14.875, + 26.875, + -7.5, + -43.25, + -39.5, + -0.95703125, + -10, + 4.875, + -42.25, + -29.875, + -47.75, + 1.9609375, + -5.125, + 46, + -35.25, + 30.375, + 38, + 28, + -38.25, + 13.4375, + -9.5, + 37.75, + -0.44140625, + -49.75, + -35.75, + 40.25, + -7.15625, + -5.25, + 36, + 33.25, + -12.25, + 15.6875 + ], + "floatVecField": [ + 0.53221714, + 0.31703654, + 0.12367431, + 0.37123778, + 0.5786093, + 0.40455657, + 0.81205034, + 0.7697503, + 0.7440103, + 0.61338866, + 0.8620964, + 0.35101637, + 0.55773807, + 0.7073472, + 0.90236205, + 0.012203732, + 0.8305356, + 0.38372755, + 0.9811637, + 0.12752098, + 0.78417903, + 0.64781463, + 0.43097755, + 0.9374458, + 0.85225165, + 0.11371868, + 0.91867346, + 0.60396516, + 0.5908196, + 0.8342869, + 0.8465178, + 0.42363524, + 0.19117841, + 0.99700767, + 0.7836377, + 0.2743451, + 0.008808918, + 0.09673844, + 0.23757777, + 0.013774986, + 0.8616869, + 0.10921093, + 0.75938654, + 0.83657676, + 0.854834, + 0.12495352, + 0.03137041, + 0.7315528, + 0.83934873, + 0.3441762, + 0.9338948, + 0.30879265, + 0.38860914, + 0.6108482, + 0.8722764, + 0.15569116, + 0.33042416, + 0.6898502, + 0.58751315, + 0.24895883, + 0.16271788, + 0.37549835, + 0.03517723, + 0.8451407 + ] + }, + { + "bfloat16VecField": [ + 40.5, + 26.5, + 19, + 28.125, + -21.125, + -21.375, + -25.5, + -13.1875, + -2.265625, + 19.25, + 9.9375, + -22.75, + -28.5, + 40.25, + 46.5, + -35, + 19.25, + 27.125, + -13.75, + 47.75, + 6.625, + 5.28125, + -16, + 32.25, + 16.5, + 34.75, + -22.75, + 4.3125, + -46, + -14.1875, + 0.41601562, + -21 + ], + "floatVecField": [ + 0.70913064, + 0.09153739, + 0.3510383, + 0.41121602, + 0.77492267, + 0.77227026, + 0.14357337, + 0.23699473, + 0.9657712, + 0.42939368, + 0.19323483, + 0.8227475, + 0.41756627, + 0.036271546, + 0.97857964, + 0.2140414, + 0.13451423, + 0.4546758, + 0.9229821, + 0.41974136, + 0.7689069, + 0.600089, + 0.18438864, + 0.46165913, + 0.9403688, + 0.07783584, + 0.08708499, + 0.12855059, + 0.56729037, + 0.13711517, + 0.7408898, + 0.19447267, + 0.9542179, + 0.52915245, + 0.5065635, + 0.5120173, + 0.72938573, + 0.53960365, + 0.96988773, + 0.2019615, + 0.93281883, + 0.31323054, + 0.5067624, + 0.81659204, + 0.041146982, + 0.81217486, + 0.47387466, + 0.36165887, + 0.80780596, + 0.010213656, + 0.16871852, + 0.6147725, + 0.48518685, + 0.7863781, + 0.7702899, + 0.5520803, + 0.84457064, + 0.69656384, + 0.01075882, + 0.4301063, + 0.31597665, + 0.3964297, + 0.4630467, + 0.062412146 + ] + }, + { + "bfloat16VecField": [ + -29.875, + -42.25, + -21.875, + -11.4375, + 35.75, + 35, + -26.5, + 6.34375, + -3.46875, + -31.75, + 16, + -32.25, + -10, + -21.125, + -8.4375, + -31.875, + -14.8125, + -48.5, + -16.75, + -3.71875, + 0.83984375, + -42.5, + -15.25, + 37.25, + -44, + -20.25, + -15.625, + 25.125, + -13.375, + -43, + 8.375, + 6.15625 + ], + "floatVecField": [ + 0.7212016, + 0.14879422, + 0.15411805, + 0.47430596, + 0.31046718, + 0.93619925, + 0.5855448, + 0.8669951, + 0.9407336, + 0.88859427, + 0.085005954, + 0.60744554, + 0.88299644, + 0.9697482, + 0.25779396, + 0.2964569, + 0.120682776, + 0.68194413, + 0.15227231, + 0.94925433, + 0.12765075, + 0.08659617, + 0.8273684, + 0.050902776, + 0.36514854, + 0.25305945, + 0.9916572, + 0.018880643, + 0.107069984, + 0.14715469, + 0.30740333, + 0.35442874, + 0.68131757, + 0.049373966, + 0.14957382, + 0.63987935, + 0.6473984, + 0.77352685, + 0.22153533, + 0.8499598, + 0.3043118, + 0.9332364, + 0.70772636, + 0.96495324, + 0.64936537, + 0.68704516, + 0.7856882, + 0.9231049, + 0.8692283, + 0.2292048, + 0.38849202, + 0.4846973, + 0.5253029, + 0.12725607, + 0.08825746, + 0.23385529, + 0.5240396, + 0.9025833, + 0.72952735, + 0.95576304, + 0.30167055, + 0.21382265, + 0.49282584, + 0.53997785 + ] + }, + { + "bfloat16VecField": [ + 2.640625, + -13.625, + 21.5, + -38.25, + 42.75, + 37.75, + 41.25, + -48.5, + 40.25, + -32, + 33.75, + 29.625, + -38.25, + -15, + -45.25, + -14.625, + 47, + 49.75, + -7.5625, + -2.375, + -47.75, + 27.75, + -26.375, + -47.5, + 48.5, + 8.0625, + -36.75, + -24.625, + 48, + 34.5, + 31.875, + -20.75 + ], + "floatVecField": [ + 0.2941286, + 0.05588962, + 0.0945542, + 0.17373852, + 0.9825257, + 0.1867211, + 0.9720306, + 0.02264046, + 0.8064447, + 0.7281826, + 0.46117583, + 0.15424368, + 0.9838038, + 0.4522104, + 0.09307483, + 0.62729234, + 0.15407649, + 0.7822393, + 0.00022227065, + 0.8428649, + 0.9181278, + 0.20095313, + 0.10838426, + 0.46968827, + 0.56839687, + 0.85761166, + 0.290319, + 0.65864223, + 0.4024475, + 0.7558779, + 0.7552013, + 0.5758064, + 0.21415307, + 0.6105683, + 0.84566474, + 0.69851464, + 0.12443008, + 0.6647433, + 0.1331963, + 0.3596618, + 0.1766836, + 0.6218182, + 0.88579494, + 0.43310788, + 0.38554975, + 0.12013579, + 0.4562973, + 0.032003928, + 0.9171758, + 0.30969223, + 0.041582666, + 0.8535929, + 0.37917158, + 0.5298653, + 0.966817, + 0.81219584, + 0.56475717, + 0.20110573, + 0.14621168, + 0.67411035, + 0.23898682, + 0.12339112, + 0.74271977, + 0.16191448 + ] + }, + { + "bfloat16VecField": [ + -10.75, + 10.5, + 48, + 20.625, + -44, + -23.125, + -33.5, + 49.75, + 20.875, + 43, + 8.3125, + 28.25, + 20.625, + -14.0625, + -14.3125, + 42, + -27.875, + -6.375, + -45.5, + -16.375, + 36.25, + 31, + -1.6171875, + 30.25, + 40.75, + -5.8125, + 17.375, + 11.625, + 14.4375, + 28.5, + 15.4375, + 25.125 + ], + "floatVecField": [ + 0.7057963, + 0.56331354, + 0.44751963, + 0.40668863, + 0.5748692, + 0.30964687, + 0.9080785, + 0.06013386, + 0.032917127, + 0.10080068, + 0.060017936, + 0.1487172, + 0.5454347, + 0.2590642, + 0.75144476, + 0.8042801, + 0.74742615, + 0.30859333, + 0.32412142, + 0.8664449, + 0.91918546, + 0.09394556, + 0.14499146, + 0.604724, + 0.16566844, + 0.7198509, + 0.554697, + 0.0091265505, + 0.6616119, + 0.80082613, + 0.16088824, + 0.592572, + 0.9944482, + 0.052720886, + 0.075207226, + 0.8796323, + 0.6787902, + 0.2452097, + 0.26971608, + 0.035033707, + 0.54822326, + 0.9025232, + 0.24965756, + 0.213599, + 0.023935439, + 0.25288415, + 0.85862446, + 0.7515387, + 0.6376835, + 0.87241215, + 0.8046715, + 0.91212434, + 0.7492022, + 0.7919578, + 0.54521215, + 0.81078136, + 0.10937383, + 0.4528885, + 0.06699998, + 0.29373726, + 0.21044171, + 0.8362038, + 0.19054069, + 0.698287 + ] + }, + { + "bfloat16VecField": [ + 43.75, + 13.3125, + 46.5, + -17.375, + -6.1875, + 34.25, + 2.484375, + 10.75, + 37.75, + -10.5625, + 25, + 42.25, + -1.3046875, + -28.25, + 44.75, + -46.5, + 41.25, + -26.125, + -15.9375, + -23.5, + -1.7734375, + -8.5, + -43.25, + 19.875, + -42, + 47.75, + 4.125, + 19.375, + 45, + -39.25, + 35, + -26.25 + ], + "floatVecField": [ + 0.29886064, + 0.57163936, + 0.49402913, + 0.6051208, + 0.5067325, + 0.06964572, + 0.87919736, + 0.64867586, + 0.029891403, + 0.90953004, + 0.24210365, + 0.93326247, + 0.23173715, + 0.73860294, + 0.02046532, + 0.48912677, + 0.901809, + 0.26039478, + 0.36024237, + 0.8189891, + 0.87145346, + 0.7978932, + 0.5170254, + 0.9063963, + 0.14626947, + 0.060193393, + 0.14906548, + 0.06942293, + 0.8968752, + 0.31771415, + 0.49507287, + 0.14806636, + 0.17154633, + 0.51410675, + 0.5398606, + 0.9392697, + 0.0095017385, + 0.3666279, + 0.5049469, + 0.0047221687, + 0.97353053, + 0.6649634, + 0.95756835, + 0.1509598, + 0.1609192, + 0.6881618, + 0.7483769, + 0.008964914, + 0.038817745, + 0.7985935, + 0.3759172, + 0.02065654, + 0.8048646, + 0.0646807, + 0.3956569, + 0.3346578, + 0.80647177, + 0.57516277, + 0.48648122, + 0.6901435, + 0.9588674, + 0.613545, + 0.3147489, + 0.053555097 + ] + }, + { + "bfloat16VecField": [ + -8.875, + 7.8125, + -37, + 27.125, + 3.671875, + -49.5, + -28.625, + 20.75, + -30.25, + 18.375, + 22.375, + 40.25, + -23.5, + 38.5, + 39.25, + -33, + 32.25, + -11.5, + -25.125, + 13.4375, + -2.15625, + 0.6328125, + -32, + 43.5, + -41.75, + -48.25, + 47, + -32, + 14.9375, + 19, + 33, + 29.625 + ], + "floatVecField": [ + 0.41080484, + 0.78054035, + 0.73171014, + 0.09953439, + 0.7414799, + 0.68884426, + 0.41593653, + 0.864128, + 0.59249514, + 0.2533577, + 0.7413935, + 0.74517626, + 0.15079165, + 0.27928424, + 0.19704111, + 0.8515408, + 0.059866887, + 0.4264866, + 0.38519678, + 0.61162806, + 0.13917577, + 0.14790101, + 0.70107114, + 0.113126546, + 0.9527641, + 0.17382653, + 0.12042329, + 0.16552733, + 0.118057646, + 0.7637158, + 0.80186373, + 0.30292046, + 0.9018716, + 0.5088984, + 0.8177527, + 0.5596252, + 0.6556563, + 0.7686984, + 0.70946074, + 0.7283415, + 0.86963475, + 0.7822673, + 0.9029464, + 0.5933623, + 0.95737994, + 0.7184237, + 0.13221411, + 0.66143596, + 0.8278681, + 0.42172846, + 0.625256, + 0.72504324, + 0.17468394, + 0.88933617, + 0.07761316, + 0.90265656, + 0.9249012, + 0.9934345, + 0.70094585, + 0.2790462, + 0.69527876, + 0.028818967, + 0.10726786, + 0.28990188 + ] + }, + { + "bfloat16VecField": [ + -17.375, + 12.0625, + 8.0625, + 33.25, + 0.24609375, + 43.5, + 42, + 46.5, + 23.875, + -25.625, + 32.25, + 20.625, + -16, + 48, + -41.25, + 47.5, + -45.5, + -10.0625, + -46.5, + 36.25, + -35.5, + -10.5, + -4.625, + -32.75, + 1.2578125, + 40.25, + -30.25, + 44.5, + -4.6875, + 17.375, + 39.25, + 1.203125 + ], + "floatVecField": [ + 0.10807366, + 0.64723665, + 0.76682436, + 0.21902704, + 0.18862714, + 0.12490884, + 0.91295946, + 0.85908, + 0.0729091, + 0.11885392, + 0.72594243, + 0.2374655, + 0.95494336, + 0.9474077, + 0.6307225, + 0.94349605, + 0.3202401, + 0.052974805, + 0.7705078, + 0.21659245, + 0.7661481, + 0.542842, + 0.2971649, + 0.73128706, + 0.18375313, + 0.66676605, + 0.13937898, + 0.91315055, + 0.7388371, + 0.9611881, + 0.85258114, + 0.43082616, + 0.341551, + 0.32125255, + 0.2863824, + 0.019052489, + 0.8635858, + 0.8481157, + 0.42446804, + 0.47878045, + 0.06684261, + 0.88087785, + 0.9625744, + 0.75272644, + 0.642158, + 0.2668818, + 0.15240216, + 0.44796124, + 0.9460542, + 0.1687962, + 0.6934991, + 0.7180676, + 0.5552552, + 0.29416013, + 0.8391509, + 0.035606824, + 0.9554765, + 0.7895169, + 0.041703008, + 0.10529966, + 0.5603025, + 0.2006253, + 0.24470942, + 0.9021879 + ] + }, + { + "bfloat16VecField": [ + -33.25, + -18.125, + -0.33398438, + 49, + 6.8125, + -9.8125, + 4.3125, + -20.25, + 4.25, + -37, + 12.25, + -28.375, + -18.625, + -43.5, + 13.125, + 5.53125, + 40.5, + -40.75, + 15.0625, + 34, + 24.75, + 19.75, + 10.8125, + -19.75, + -21.375, + 9.125, + -33.75, + 7.59375, + 24.75, + 0.86328125, + -15.8125, + -5.40625 + ], + "floatVecField": [ + 0.79822165, + 0.5271812, + 0.13875912, + 0.83661646, + 0.086049944, + 0.94509673, + 0.5090812, + 0.020730898, + 0.52233434, + 0.02478148, + 0.18738304, + 0.4855189, + 0.7522907, + 0.43971357, + 0.7105382, + 0.6939131, + 0.68663627, + 0.21243666, + 0.5401683, + 0.4675785, + 0.3939104, + 0.38796425, + 0.44399428, + 0.7734535, + 0.6469042, + 0.34907675, + 0.8433964, + 0.366671, + 0.7816779, + 0.19547805, + 0.68406016, + 0.4401043, + 0.19950621, + 0.10675324, + 0.08639799, + 0.80655015, + 0.08704111, + 0.6185073, + 0.25382906, + 0.15188126, + 0.95612794, + 0.9772172, + 0.6357931, + 0.36000025, + 0.24227731, + 0.8651025, + 0.30878764, + 0.42448026, + 0.72468096, + 0.37743565, + 0.76740265, + 0.98362637, + 0.6218768, + 0.71063966, + 0.9999021, + 0.8149579, + 0.9747628, + 0.84297407, + 0.10285088, + 0.284958, + 0.49059564, + 0.2595358, + 0.6281419, + 0.48755494 + ] + }, + { + "bfloat16VecField": [ + -0.18945312, + -35, + 8.625, + -47.25, + -13.125, + -47, + -5.9375, + 3.234375, + 41.5, + 4.09375, + 43, + 16.375, + -30, + 16.125, + -19.75, + 31.625, + -4.5, + -33, + 26.75, + -42.25, + -13.5, + 29.625, + -2.015625, + 2.65625, + -42.5, + -24.625, + 48, + 9.75, + -39.5, + -19.25, + -2.9375, + -37.5 + ], + "floatVecField": [ + 0.6400245, + 0.9314587, + 0.77195305, + 0.7405903, + 0.32126865, + 0.9067161, + 0.10703154, + 0.79777914, + 0.019302603, + 0.5520549, + 0.17404573, + 0.30362058, + 0.8353563, + 0.9799697, + 0.062175352, + 0.58681643, + 0.2850037, + 0.9026989, + 0.89349186, + 0.78713876, + 0.20984472, + 0.3638, + 0.28322792, + 0.50515467, + 0.97422427, + 0.9753932, + 0.433162, + 0.13382635, + 0.1303556, + 0.39882714, + 0.41078517, + 0.5526825, + 0.8061633, + 0.025483284, + 0.63163257, + 0.93885165, + 0.22354567, + 0.6835038, + 0.56764346, + 0.26103577, + 0.519785, + 0.008365882, + 0.41120976, + 0.7068035, + 0.7767702, + 0.79923725, + 0.3299179, + 0.32560846, + 0.5317939, + 0.15270999, + 0.6416277, + 0.32403964, + 0.58708435, + 0.44047928, + 0.30407372, + 0.3571986, + 0.11844085, + 0.892204, + 0.2689286, + 0.54838794, + 0.9852467, + 0.007436984, + 0.11179705, + 0.93955535 + ] + }, + { + "bfloat16VecField": [ + 1.3984375, + -20, + -27.5, + -42.75, + 6.25, + 2.921875, + 8.1875, + -12.5625, + -14.375, + -23.5, + -36.25, + 29.75, + -28.5, + -28.875, + -4.53125, + -19.5, + 24.375, + -8.4375, + 43.25, + 17.375, + -34.25, + -32.5, + -14.25, + 36.25, + -6.6875, + -2.265625, + -11.75, + 9.5625, + 31.875, + -5.40625, + -44.75, + 27.875 + ], + "floatVecField": [ + 0.005972577, + 0.82245547, + 0.07293866, + 0.3847261, + 0.117394984, + 0.042442378, + 0.07845569, + 0.2573438, + 0.44386873, + 0.5658583, + 0.41173953, + 0.34131524, + 0.81509703, + 0.9902378, + 0.34509775, + 0.15409766, + 0.3977313, + 0.34469965, + 0.08933301, + 0.1203193, + 0.7103826, + 0.61375624, + 0.8445354, + 0.74636066, + 0.5539782, + 0.18000828, + 0.50231653, + 0.9041114, + 0.12067462, + 0.18596888, + 0.12442492, + 0.9061718, + 0.9430782, + 0.4109052, + 0.83770263, + 0.16011941, + 0.38389832, + 0.28274915, + 0.38489574, + 0.66684234, + 0.5425202, + 0.14599892, + 0.99657404, + 0.53798956, + 0.20179889, + 0.096637286, + 0.9777572, + 0.936378, + 0.75759625, + 0.8248537, + 0.92863977, + 0.5866596, + 0.15971424, + 0.8400449, + 0.23035757, + 0.6498295, + 0.8061774, + 0.95671976, + 0.91081786, + 0.47023678, + 0.73047745, + 0.6982697, + 0.9128964, + 0.086431995 + ] + } +] \ No newline at end of file diff --git a/deployments/docker/dev/docker-compose.yml b/deployments/docker/dev/docker-compose.yml index cb8da102c4a50..a273b461d0a93 100644 --- a/deployments/docker/dev/docker-compose.yml +++ b/deployments/docker/dev/docker-compose.yml @@ -78,7 +78,7 @@ services: - "14268:14268" # jaeger.thirft zookeeper: - image: wurstmeister/zookeeper:latest + image: zookeeper:latest ports: - "2181:2181" diff --git a/docker-compose.yml b/docker-compose.yml index bb99f4c0cee65..2c41535781054 100644 --- a/docker-compose.yml +++ b/docker-compose.yml @@ -9,7 +9,13 @@ x-ccache: &ccache services: builder: +<<<<<<< HEAD image: ${IMAGE_REPO}/milvus-env:${OS_NAME}-${DATE_VERSION} +======= + # image: ${IMAGE_REPO}/milvus-env:${OS_NAME}-${DATE_VERSION} + # image: milvusdb/milvus-env:ubuntu20.04-20240429-6289f3a + image: milvusdb/milvus-env:ubuntu20.04-20240520-d27db99 +>>>>>>> demo # Build devcontainer build: context: . @@ -31,6 +37,9 @@ services: MINIO_ADDRESS: ${MINIO_ADDRESS} CONAN_USER_HOME: /home/milvus AZURE_STORAGE_CONNECTION_STRING: ${AZURITE_CONNECTION_STRING} + LIBJEMALLOC: /go/src/github.com/milvus-io/milvus/internal/core/output/lib/libjemalloc.so + PKG_CONFIG_PATH: /go/src/github.com/milvus-io/milvus/internal/core/output/lib/pkgconfig:/go/src/github.com/milvus-io/milvus/internal/core/output/lib64/pkgconfig + LD_LIBRARY_PATH: /go/src/github.com/milvus-io/milvus/internal/core/output/lib:/go/src/github.com/milvus-io/milvus/internal/core/output/lib64 volumes: &builder-volumes - .:/go/src/github.com/milvus-io/milvus:delegated - ${DOCKER_VOLUME_DIRECTORY:-.docker}/${IMAGE_ARCH}-${OS_NAME}-ccache:/ccache:delegated @@ -47,6 +56,12 @@ services: command: &builder-command > /bin/bash -c " make check-proto-product && make verifiers && make unittest" +<<<<<<< HEAD +======= + networks: + milvus_dev: + ipv4_address: 172.27.0.2 +>>>>>>> demo gpubuilder: image: ${IMAGE_REPO}/milvus-env:gpu-${OS_NAME}-${GPU_DATE_VERSION} @@ -87,6 +102,12 @@ services: command: &builder-command-gpu > /bin/bash -c " make check-proto-product && make verifiers && make unittest" +<<<<<<< HEAD +======= + networks: + milvus_dev: + ipv4_address: 172.27.0.3 +>>>>>>> demo etcd: image: milvusdb/etcd:3.5.5-r2 @@ -99,12 +120,26 @@ services: healthcheck: test: ['CMD', '/opt/bitnami/scripts/etcd/healthcheck.sh'] interval: 30s +<<<<<<< HEAD timeout: 20s retries: 3 +======= + timeout: 3600s + retries: 3 + networks: + milvus_dev: + ipv4_address: 172.27.0.4 +>>>>>>> demo pulsar: image: apachepulsar/pulsar:2.8.2 command: bin/pulsar standalone --no-functions-worker --no-stream-storage +<<<<<<< HEAD +======= + networks: + milvus_dev: + ipv4_address: 172.27.0.5 +>>>>>>> demo minio: image: minio/minio:RELEASE.2023-03-20T20-16-18Z @@ -112,15 +147,27 @@ services: MINIO_ACCESS_KEY: minioadmin MINIO_SECRET_KEY: minioadmin command: minio server /minio_data +<<<<<<< HEAD +======= + volumes: + - ${DOCKER_VOLUME_DIRECTORY:-.docker}/${OS_NAME}-minio:/minio_data +>>>>>>> demo healthcheck: test: ['CMD', 'curl', '-f', 'http://localhost:9000/minio/health/live'] interval: 30s timeout: 20s retries: 3 +<<<<<<< HEAD +======= + networks: + milvus_dev: + ipv4_address: 172.27.0.6 +>>>>>>> demo azurite: image: mcr.microsoft.com/azure-storage/azurite command: azurite-blob --blobHost 0.0.0.0 +<<<<<<< HEAD jaeger: image: jaegertracing/all-in-one:latest @@ -128,3 +175,21 @@ services: networks: default: name: milvus_dev +======= + networks: + milvus_dev: + ipv4_address: 172.27.0.7 + + jaeger: + image: jaegertracing/all-in-one:latest + networks: + milvus_dev: + ipv4_address: 172.27.0.8 + +networks: + milvus_dev: + ipam: + driver: default + config: + - subnet: 172.27.0.0/16 +>>>>>>> demo diff --git a/docker-compose.yml.back b/docker-compose.yml.back new file mode 100644 index 0000000000000..9898408c4caba --- /dev/null +++ b/docker-compose.yml.back @@ -0,0 +1,130 @@ +version: '3.5' + +x-ccache: &ccache + CCACHE_COMPILERCHECK: content + CCACHE_COMPRESS: 1 + CCACHE_COMPRESSLEVEL: 5 + CCACHE_MAXSIZE: 2G + CCACHE_DIR: /ccache + +services: + builder: + image: ${IMAGE_REPO}/milvus-env:${OS_NAME}-${DATE_VERSION} + # Build devcontainer + build: + context: . + dockerfile: build/docker/builder/cpu/${OS_NAME}/Dockerfile + args: + TARGETARCH: ${IMAGE_ARCH} + cache_from: + - ${IMAGE_REPO}/milvus-env:${OS_NAME}-${LATEST_DATE_VERSION} + platform: linux/${IMAGE_ARCH} + shm_size: 2G + # expose 19530 port so we can directly access milvus inside build container + # ports: + # - "19530:19530" + environment: + <<: *ccache + OS_NAME: ${OS_NAME} + PULSAR_ADDRESS: ${PULSAR_ADDRESS} + ETCD_ENDPOINTS: ${ETCD_ENDPOINTS} + MINIO_ADDRESS: ${MINIO_ADDRESS} + CONAN_USER_HOME: /home/milvus + AZURE_STORAGE_CONNECTION_STRING: ${AZURITE_CONNECTION_STRING} + volumes: &builder-volumes + - .:/go/src/github.com/milvus-io/milvus:delegated + - ${DOCKER_VOLUME_DIRECTORY:-.docker}/${IMAGE_ARCH}-${OS_NAME}-ccache:/ccache:delegated + - ${DOCKER_VOLUME_DIRECTORY:-.docker}/${IMAGE_ARCH}-${OS_NAME}-go-mod:/go/pkg/mod:delegated + - ${DOCKER_VOLUME_DIRECTORY:-.docker}/${IMAGE_ARCH}-${OS_NAME}-vscode-extensions:/home/milvus/.vscode-server/extensions:delegated + - ${DOCKER_VOLUME_DIRECTORY:-.docker}/${IMAGE_ARCH}-${OS_NAME}-conan:/home/milvus/.conan:delegated + working_dir: '/go/src/github.com/milvus-io/milvus' + depends_on: + - etcd + - minio + - pulsar + - azurite + # Command + command: &builder-command > + /bin/bash -c " + make check-proto-product && make verifiers && make unittest" + + gpubuilder: + image: ${IMAGE_REPO}/milvus-env:gpu-${OS_NAME}-${GPU_DATE_VERSION} + # Build devcontainer + build: + context: . + dockerfile: build/docker/builder/gpu/${OS_NAME}/Dockerfile + args: + TARGETARCH: ${IMAGE_ARCH} + cache_from: + - ${IMAGE_REPO}/milvus-env:gpu-${OS_NAME}-${LATEST_GPU_DATE_VERSION} + # user: {{ CURRENT_ID }} + shm_size: 2G + # expose 19530 port so we can directly access milvus inside build container + # ports: + # - "19530:19530" + environment: + <<: *ccache + OS_NAME: ${OS_NAME} + PULSAR_ADDRESS: ${PULSAR_ADDRESS} + ETCD_ENDPOINTS: ${ETCD_ENDPOINTS} + MINIO_ADDRESS: ${MINIO_ADDRESS} + CONAN_USER_HOME: /home/milvus + AZURE_STORAGE_CONNECTION_STRING: ${AZURITE_CONNECTION_STRING} + volumes: &builder-volumes-gpu + - .:/go/src/github.com/milvus-io/milvus:delegated + - ${DOCKER_VOLUME_DIRECTORY:-.docker-gpu}/${OS_NAME}-ccache:/ccache:delegated + - ${DOCKER_VOLUME_DIRECTORY:-.docker-gpu}/${OS_NAME}-go-mod:/go/pkg/mod:delegated + - ${DOCKER_VOLUME_DIRECTORY:-.docker-gpu}/${OS_NAME}-vscode-extensions:/home/milvus/.vscode-server/extensions:delegated + - ${DOCKER_VOLUME_DIRECTORY:-.docker-gpu}/${OS_NAME}-conan:/home/milvus/.conan:delegated + working_dir: '/go/src/github.com/milvus-io/milvus' + depends_on: + - etcd + - minio + - pulsar + - azurite + # Command + command: &builder-command-gpu > + /bin/bash -c " + make check-proto-product && make verifiers && make unittest" + + etcd: + image: milvusdb/etcd:3.5.5-r2 + environment: + - ALLOW_NONE_AUTHENTICATION=yes + - ETCD_AUTO_COMPACTION_MODE=revision + - ETCD_AUTO_COMPACTION_RETENTION=1000 + - ETCD_QUOTA_BACKEND_BYTES=4294967296 + - ETCD_SNAPSHOT_COUNT=50000 + healthcheck: + test: ['CMD', '/opt/bitnami/scripts/etcd/healthcheck.sh'] + interval: 30s + timeout: 3600s + retries: 3 + + pulsar: + image: apachepulsar/pulsar:2.8.2 + command: bin/pulsar standalone --no-functions-worker --no-stream-storage + + minio: + image: minio/minio:RELEASE.2023-03-20T20-16-18Z + environment: + MINIO_ACCESS_KEY: minioadmin + MINIO_SECRET_KEY: minioadmin + command: minio server /minio_data + healthcheck: + test: ['CMD', 'curl', '-f', 'http://localhost:9000/minio/health/live'] + interval: 30s + timeout: 20s + retries: 3 + + azurite: + image: mcr.microsoft.com/azure-storage/azurite + command: azurite-blob --blobHost 0.0.0.0 + + jaeger: + image: jaegertracing/all-in-one:latest + +networks: + default: + name: milvus_dev diff --git a/scripts/devcontainer.sh b/scripts/devcontainer.sh index ba87d1a28df57..84312e8b606cb 100755 --- a/scripts/devcontainer.sh +++ b/scripts/devcontainer.sh @@ -68,6 +68,8 @@ fi pushd "$ROOT_DIR" +DOCKER_VOLUME_DIRECTORY="/disk2/duk/data/milvus-docker-volumes" +echo $DOCKER_VOLUME_DIRECTORY mkdir -p "${DOCKER_VOLUME_DIRECTORY:-.docker}/amd64-${OS_NAME}-ccache" mkdir -p "${DOCKER_VOLUME_DIRECTORY:-.docker}/amd64-${OS_NAME}-go-mod" mkdir -p "${DOCKER_VOLUME_DIRECTORY:-.docker}/amd64-${OS_NAME}-vscode-extensions" diff --git a/setenv.sh b/setenv.sh new file mode 100644 index 0000000000000..b89643f0210ca --- /dev/null +++ b/setenv.sh @@ -0,0 +1,9 @@ +go env -w GOPROXY=https://goproxy.cn,direct && +go env -w GOBIN=/go/bin && +go install golang.org/x/tools/gopls@latest && +go install github.com/go-delve/delve/cmd/dlv@latest && +# export LIBJEMALLOC=/go/src/github.com/milvus-io/milvus/internal/core/output/lib/libjemalloc.so && +# export PKG_CONFIG_PATH=/go/src/github.com/milvus-io/milvus/internal/core/output/lib/pkgconfig:/go/src/github.com/milvus-io/milvus/internal/core/output/lib64/pkgconfig && +# export LD_LIBRARY_PATH=/go/src/github.com/milvus-io/milvus/internal/core/output/lib:/go/src/github.com/milvus-io/milvus/internal/core/output/lib64 && +# export RPATH=$LD_LIBRARY_PATH && +echo "success" \ No newline at end of file diff --git a/tests/integration/import/multi_vector_test.go b/tests/integration/import/multi_vector_test.go index 7738853a56bd3..48e19c8e76d88 100644 --- a/tests/integration/import/multi_vector_test.go +++ b/tests/integration/import/multi_vector_test.go @@ -123,6 +123,8 @@ func (s *BulkInsertSuite) testMultipleVectorFields() { err = os.MkdirAll(c.ChunkManager.RootPath(), os.ModePerm) s.NoError(err) + options := []*commonpb.KeyValuePair{} + switch s.fileType { case importutilv2.Numpy: importFile, err := GenerateNumpyFiles(c.ChunkManager, schema, rowCount) @@ -154,11 +156,25 @@ func (s *BulkInsertSuite) testMultipleVectorFields() { }, }, } + case importutilv2.CSV: + filePath := fmt.Sprintf("/tmp/test_%d.csv", rand.Int()) + _ = GenerateCSVFile(s.T(), filePath, schema, rowCount) + defer os.Remove(filePath) + options = []*commonpb.KeyValuePair{{Key: "sep", Value: string(sep)}} + s.NoError(err) + files = []*internalpb.ImportFile{ + { + Paths: []string{ + filePath, + }, + }, + } } importResp, err := c.Proxy.ImportV2(ctx, &internalpb.ImportRequest{ CollectionName: collectionName, Files: files, + Options: options, }) s.NoError(err) s.Equal(int32(0), importResp.GetStatus().GetCode()) @@ -226,3 +242,8 @@ func (s *BulkInsertSuite) TestMultipleVectorFields_Parquet() { s.fileType = importutilv2.Parquet s.testMultipleVectorFields() } + +func (s *BulkInsertSuite) TestMultipleVectorFields_CSV() { + s.fileType = importutilv2.CSV + s.testMultipleVectorFields() +} diff --git a/tests/integration/import/util_test.go b/tests/integration/import/util_test.go index 74d4a89cb4e08..6073434f4c59f 100644 --- a/tests/integration/import/util_test.go +++ b/tests/integration/import/util_test.go @@ -18,6 +18,7 @@ package importv2 import ( "context" + "encoding/csv" "encoding/json" "fmt" "os" @@ -202,6 +203,26 @@ func GenerateJSONFile(t *testing.T, filePath string, schema *schemapb.Collection assert.NoError(t, err) } +func GenerateCSVFile(t *testing.T, filePath string, schema *schemapb.CollectionSchema, count int) rune { + insertData, err := testutil.CreateInsertData(schema, count) + assert.NoError(t, err) + + csvData, err := testutil.CreateInsertDataForCSV(schema, insertData) + assert.NoError(t, err) + + sep := ',' + wf, err := os.OpenFile(filePath, os.O_RDWR|os.O_CREATE, 0o666) + assert.NoError(t, err) + + writer := csv.NewWriter(wf) + writer.Comma = sep + writer.WriteAll(csvData) + writer.Flush() + assert.NoError(t, err) + + return sep +} + func WaitForImportDone(ctx context.Context, c *integration.MiniClusterV2, jobID string) error { for { resp, err := c.Proxy.GetImportProgress(ctx, &internalpb.GetImportProgressRequest{