s3db.js 19.1.1-next.4c11df9b → 19.1.1-next.93ad4925

This diff represents the content of publicly available package versions that have been released to one of the supported registries. The information contained in this diff is provided for informational purposes only and reflects changes between package versions as they appear in their respective public registries.
package/dist/s3db.es.js CHANGED
@@ -2,12 +2,11 @@ import path$2, { join, dirname, resolve as resolve$1 } from 'path';
2
2
  import EventEmitter$1, { EventEmitter } from 'events';
3
3
  import { chunk, isEmpty, isFunction as isFunction$1, merge, isString, invert, uniq, cloneDeep as cloneDeep$1, get as get$1, set, isObject as isObject$2 } from 'lodash-es';
4
4
  import { expandHTTP2Options, createHttp2MetricsHooks, createClient, getGlobalHttp2Metrics, parseHttp2Error, Http2Error, TemplateEngine } from 'recker';
5
- import { Readable } from 'node:stream';
6
5
  import { S3Client as S3Client$1, PutObjectCommand, GetObjectCommand, HeadObjectCommand, CopyObjectCommand, DeleteObjectCommand, DeleteObjectsCommand, ListObjectsV2Command } from '@aws-sdk/client-s3';
7
6
  import crypto$2, { createHash, createPublicKey, createVerify, generateKeyPairSync, createSign, randomBytes, randomUUID } from 'crypto';
8
7
  import { nanoid } from 'nanoid';
9
8
  import fs$3, { writeFile, readFile, mkdir, rename, unlink, appendFile, copyFile, readdir, stat, rm, watch, access } from 'fs/promises';
10
- import { Readable as Readable$1, Transform, Writable } from 'stream';
9
+ import { Readable, Transform, Writable } from 'stream';
11
10
  import * as fs$2 from 'fs';
12
11
  import fs__default, { existsSync, writeFileSync, createReadStream, createWriteStream, readFileSync } from 'fs';
13
12
  import os$2, { cpus, platform } from 'os';
@@ -286,7 +285,6 @@ function parseRetryAfter$1(headerValue) {
286
285
  return undefined;
287
286
  }
288
287
  class ReckerHttpHandler {
289
- metadata = { handlerProtocol: 'h2' };
290
288
  options;
291
289
  client;
292
290
  deduplicator;
@@ -363,23 +361,16 @@ class ReckerHttpHandler {
363
361
  circuitBreakerTrips: 0,
364
362
  };
365
363
  }
364
+ get metadata() {
365
+ return this.client?.metadata ?? { handlerProtocol: 'http/1.1' };
366
+ }
366
367
  async handle(request, { abortSignal, requestTimeout } = {}) {
367
- const protocol = request.protocol || 'https:';
368
- const defaultPort = protocol === 'https:' ? 443 : 80;
369
- const port = request.port || defaultPort;
370
368
  const hostname = request.hostname;
371
- const url = `${protocol}//${hostname}:${port}${request.path}`;
372
369
  const method = request.method;
373
370
  if (this.circuitBreaker && !this.circuitBreaker.canRequest(hostname)) {
374
371
  this.metrics.circuitBreakerTrips++;
375
372
  throw new Error(`Circuit breaker OPEN for ${hostname}`);
376
373
  }
377
- const headers = {};
378
- for (const [key, value] of Object.entries(request.headers)) {
379
- if (value !== undefined) {
380
- headers[key] = value;
381
- }
382
- }
383
374
  const doRequest = async () => {
384
375
  this.metrics.requests++;
385
376
  let lastError;
@@ -388,20 +379,32 @@ class ReckerHttpHandler {
388
379
  while (attempt < maxAttempts) {
389
380
  attempt++;
390
381
  try {
391
- const reckerResponse = await this.client.request(url, {
392
- method,
382
+ const headers = {};
383
+ for (const [key, value] of Object.entries(request.headers)) {
384
+ if (value !== undefined) {
385
+ headers[key] = value;
386
+ }
387
+ }
388
+ const result = await this.client.handle({
389
+ protocol: request.protocol,
390
+ hostname: request.hostname,
391
+ port: request.port,
392
+ path: request.path,
393
+ query: request.query,
394
+ method: request.method,
393
395
  headers,
394
396
  body: request.body,
395
- signal: abortSignal,
396
- timeout: requestTimeout || this.options.bodyTimeout,
397
- http2: this.options.http2,
397
+ }, {
398
+ abortSignal,
399
+ requestTimeout: requestTimeout || this.options.bodyTimeout,
398
400
  });
401
+ const statusCode = result.response.statusCode;
399
402
  if (this.options.enableRetry && attempt < maxAttempts &&
400
- isRetryableError(null, reckerResponse.status)) {
403
+ isRetryableError(null, statusCode)) {
401
404
  this.metrics.retries++;
402
405
  let delay;
403
406
  if (this.options.respectRetryAfter) {
404
- const retryAfter = parseRetryAfter$1(reckerResponse.headers.get('Retry-After'));
407
+ const retryAfter = parseRetryAfter$1(result.response.headers['retry-after'] ?? null);
405
408
  delay = retryAfter !== undefined
406
409
  ? Math.min(retryAfter, this.options.maxRetryDelay)
407
410
  : calculateRetryDelay(attempt, this.options.retryDelay, this.options.maxRetryDelay, this.options.retryJitter);
@@ -415,22 +418,7 @@ class ReckerHttpHandler {
415
418
  if (this.circuitBreaker) {
416
419
  this.circuitBreaker.recordSuccess(hostname);
417
420
  }
418
- let body;
419
- if (reckerResponse.body) {
420
- body = Readable.fromWeb(reckerResponse.body);
421
- }
422
- const responseHeaders = {};
423
- for (const [key, value] of reckerResponse.headers.entries()) {
424
- responseHeaders[key] = value;
425
- }
426
- return {
427
- response: {
428
- statusCode: reckerResponse.status,
429
- reason: reckerResponse.statusText,
430
- headers: responseHeaders,
431
- body
432
- }
433
- };
421
+ return result;
434
422
  }
435
423
  catch (error) {
436
424
  lastError = error;
@@ -439,7 +427,6 @@ class ReckerHttpHandler {
439
427
  }
440
428
  if (this.options.enableRetry && attempt < maxAttempts && isRetryableError(error)) {
441
429
  this.metrics.retries++;
442
- // Check for HTTP/2 specific retry delay (e.g., ENHANCE_YOUR_CALM)
443
430
  const h2Delay = getHttp2RetryDelay(error);
444
431
  const delay = h2Delay !== undefined
445
432
  ? Math.min(h2Delay, this.options.maxRetryDelay)
@@ -453,6 +440,8 @@ class ReckerHttpHandler {
453
440
  throw lastError;
454
441
  };
455
442
  if (this.deduplicator) {
443
+ const protocol = request.protocol || 'https:';
444
+ const url = `${protocol}//${hostname}${request.path}`;
456
445
  const originalRequests = this.metrics.requests;
457
446
  const result = await this.deduplicator.dedupe(method, url, doRequest);
458
447
  if (this.metrics.requests === originalRequests) {
@@ -1612,7 +1601,6 @@ const BUILT_IN_SENSITIVE_FIELDS = [
1612
1601
  'certificatekey',
1613
1602
  'certificate_key',
1614
1603
  'certificate-key',
1615
- 'key',
1616
1604
  'credential',
1617
1605
  'credentials',
1618
1606
  'hash',
@@ -6034,7 +6022,7 @@ class MemoryStorage {
6034
6022
  }
6035
6023
  this._touchKey(key);
6036
6024
  this.logger.debug({ key, size: obj.size }, `GET ${key} (${obj.size} bytes)`);
6037
- const bodyStream = Readable$1.from(obj.body);
6025
+ const bodyStream = Readable.from(obj.body);
6038
6026
  bodyStream.transformToString = async (encoding = 'utf-8') => {
6039
6027
  const chunks = [];
6040
6028
  for await (const chunk of bodyStream) {
@@ -6050,7 +6038,7 @@ class MemoryStorage {
6050
6038
  return new Uint8Array(Buffer.concat(chunks));
6051
6039
  };
6052
6040
  bodyStream.transformToWebStream = () => {
6053
- return Readable$1.toWeb(bodyStream);
6041
+ return Readable.toWeb(bodyStream);
6054
6042
  };
6055
6043
  return {
6056
6044
  Body: bodyStream,
@@ -7959,7 +7947,7 @@ class FileSystemStorage {
7959
7947
  info.push(`decompressed: ${metadata.size}→${finalBuffer.length}`);
7960
7948
  }
7961
7949
  this.logger.debug({ key, size: metadata.size, compressed: metadata.compressed }, `GET ${key} (${info.join(', ')})`);
7962
- const bodyStream = Readable$1.from(finalBuffer);
7950
+ const bodyStream = Readable.from(finalBuffer);
7963
7951
  bodyStream.transformToString = async (encoding = 'utf-8') => {
7964
7952
  const chunks = [];
7965
7953
  for await (const chunk of bodyStream) {
@@ -7975,7 +7963,7 @@ class FileSystemStorage {
7975
7963
  return new Uint8Array(Buffer.concat(chunks));
7976
7964
  };
7977
7965
  bodyStream.transformToWebStream = () => {
7978
- return Readable$1.toWeb(bodyStream);
7966
+ return Readable.toWeb(bodyStream);
7979
7967
  };
7980
7968
  return {
7981
7969
  Body: bodyStream,
@@ -18248,8 +18236,8 @@ class Database extends SafeEventEmitter {
18248
18236
  })();
18249
18237
  this.version = '1';
18250
18238
  this.s3dbVersion = (() => {
18251
- const [ok, , version] = tryFnSync(() => (typeof globalThis['19.1.1-next.4c11df9b'] !== 'undefined' && globalThis['19.1.1-next.4c11df9b'] !== '19.1.1-next.4c11df9b'
18252
- ? globalThis['19.1.1-next.4c11df9b']
18239
+ const [ok, , version] = tryFnSync(() => (typeof globalThis['19.1.1-next.93ad4925'] !== 'undefined' && globalThis['19.1.1-next.93ad4925'] !== '19.1.1-next.93ad4925'
18240
+ ? globalThis['19.1.1-next.93ad4925']
18253
18241
  : 'latest'));
18254
18242
  return ok ? version : 'latest';
18255
18243
  })();
@@ -51041,6 +51029,9 @@ function deleteChunkedCookie(context, name, options = {}, cookieJar = null) {
51041
51029
  });
51042
51030
  });
51043
51031
  }
51032
+ function isChunkedCookie(context, name) {
51033
+ return !!getCookie(context, `${name}.__chunks`);
51034
+ }
51044
51035
 
51045
51036
  const logger$i = createLogger({
51046
51037
  name: 'OidcValidator',
@@ -64035,14 +64026,19 @@ class ApiPlugin extends Plugin {
64035
64026
  var index$5 = /*#__PURE__*/Object.freeze({
64036
64027
  __proto__: null,
64037
64028
  ApiPlugin: ApiPlugin,
64029
+ CookieChunkOverflowError: CookieChunkOverflowError,
64038
64030
  OIDCClient: OIDCClient,
64039
64031
  OpenGraphHelper: OpenGraphHelper,
64040
64032
  RouteContext: RouteContext$1,
64041
64033
  createContextInjectionMiddleware: createContextInjectionMiddleware,
64034
+ deleteChunkedCookie: deleteChunkedCookie,
64042
64035
  ejsEngine: ejsEngine,
64043
64036
  errorResponse: errorResponse,
64037
+ getChunkedCookie: getChunkedCookie,
64038
+ isChunkedCookie: isChunkedCookie,
64044
64039
  jsxEngine: jsxEngine,
64045
64040
  pugEngine: pugEngine,
64041
+ setChunkedCookie: setChunkedCookie,
64046
64042
  setupTemplateEngine: setupTemplateEngine,
64047
64043
  successResponse: successResponse,
64048
64044
  withContext: withContext
@@ -160276,5 +160272,5 @@ var terraformExporter = /*#__PURE__*/Object.freeze({
160276
160272
  exportToTerraformState: exportToTerraformState
160277
160273
  });
160278
160274
 
160279
- export { AVAILABLE_BEHAVIORS, AdaptiveTuning, AdjacencyListDriver, AnalyticsNotEnabledError, ApiPlugin, AsyncEventEmitter, AuditPlugin, AuthenticationError$1 as AuthenticationError, BACKUP_DRIVERS, BUILT_IN_SENSITIVE_FIELDS, BackupPlugin, BaseBackupDriver, BaseCloudDriver, BaseError, BaseReplicator, BehaviorError, Benchmark, CONTENT_TYPE_DICT, CRON_PRESETS, CURRENCY_DECIMALS, CachePlugin, S3Client as Client, ConnectionString, ConnectionStringError, CookieFarmPlugin, CookieFarmSuitePlugin, CoordinatorPlugin, CostsPlugin, CrawlContext, CronManager, CryptoError, DEFAULT_BEHAVIOR, Database, DatabaseError, DistributedLock, DistributedSequence, EncryptionError, ErrorClassifier, ErrorMap, EventualConsistencyPlugin, Factory, FailbanManager, FetchFallback, FileSystemClient, FileSystemStorage, FilesystemBackupDriver, FilesystemCache, FullTextPlugin, GeoPlugin, GraphConfigurationError, GraphError, GraphPlugin, HighPerformanceInserter, HybridFetcher, IdentityPlugin, ImporterPlugin, InMemoryPersistence, IncrementalConfigError, IncrementalSequence, InvalidEdgeError, InvalidParentError, InvalidResourceItem, KubernetesInventoryPlugin, LatencyBuffer, MLPlugin, MemoryCache, MemoryClient, MemorySampler, MemoryStorage, MetadataLimitError, MetricsPlugin, MissingMetadata, MultiBackupDriver, NON_RETRIABLE, NestedSetDriver, NoSuchBucket, NoSuchKey, NodeNotFoundError, NotFound, OIDCClient, OpenGraphHelper, PartitionAwareFilesystemCache, PartitionDriverError, PartitionError, PartitionQueue, PathNotFoundError, PerformanceMonitor, PermissionError, Plugin, PluginError, PluginObject, PluginStorage, PluginStorageError, ProcessManager$1 as ProcessManager, PuppeteerPlugin, QueueConsumerPlugin, RETRIABLE, RabbitMqConsumer, ReckerHttpHandler, ReckerWrapper, ReconPlugin, ReplicationError, ReplicatorPlugin, Resource, ResourceError, ResourceIdsPageReader, ResourceIdsReader, ResourceNotFound, ResourceReader, ResourceWriter, RingBuffer, RootNodeError, RouteContext$1 as RouteContext, S3BackupDriver, S3Cache, S3Client, S3QueuePlugin, Database as S3db, S3dbError, S3dbReplicator, SMTPPlugin, STATUS_MESSAGE_DICT, SafeEventEmitter, SchedulerPlugin, Schema, SchemaError, Seeder, SpiderPlugin, SqsConsumer, SqsReplicator, StateMachinePlugin, StreamError, StreamInserter, TTLPlugin, TaskExecutor, TasksPool, TasksRunner, TfStatePlugin, TournamentPlugin, Transformers, TreeConfigurationError, TreeIntegrityError, TreePlugin, URL_PREFIX_DICT, UnknownError, ValidationError, Validator, VectorPlugin, VertexNotFoundError, WebSocketPlugin, WebSocketServer, WebhookReplicator, analyzeString, behaviors, benchmark, bytesToMB, cacheValidator, calculateAttributeNamesSize, calculateAttributeSizes, calculateBufferSavings, calculateDictionaryCompression, calculateEffectiveLimit, calculateEncodedSize, calculateIPSavings, calculateSystemOverhead, calculateTotalSize, calculateUTF8Bytes, captureHeapSnapshot, clearBit, clearBitFast, clearUTF8Memory, clearValidatorCache, compactHash, compareEncodings, compareMemorySnapshots, compressIPv6, computeBackoff, countBits, countBitsFast, createBackupDriver, createBitmap, createBitmapFast, createConsumer, createContextInjectionMiddleware, createCronManager, createCustomGenerator, createHttpClient, createHttpClientSync, createIncrementalIdGenerator, createLockedFunction, createLogger, createPayloadRedactionSerializer, createRedactRules, createReplicator, createSafeEventEmitter, createSensitiveDataSerializer, createSequence, decode, decodeBits, decodeBitsFast, decodeBuffer, decodeDecimal, decodeFixedPoint, decodeFixedPointBatch, decodeGeoLat, decodeGeoLon, decodeGeoPoint, decodeIPv4, decodeIPv6, decodeMoney, decrypt, S3db as default, detectIPVersion, dictionaryDecode, dictionaryEncode, ejsEngine, encode, encodeBits, encodeBitsFast, encodeBuffer, encodeDecimal, encodeFixedPoint, encodeFixedPointBatch, encodeGeoLat, encodeGeoLon, encodeGeoPoint, encodeIPv4, encodeIPv6, encodeMoney, encrypt, errorResponse, evictUnusedValidators, exampleUsage, expandHash, expandIPv6, flatten, forEachWithConcurrency, forceGC, formatIncrementalValue, formatMemoryUsage, formatMoney, generateSchemaFingerprint, generateTypes, getAccuracyForPrecision, getBehavior, getBit, getBitFast, getCacheMemoryUsage, getCacheStats, getCachedValidator, getCronManager, getCurrencyDecimals, getDictionaryStats, getGlobalLogger, getLoggerOptionsFromEnv, getMemoryUsage, getNanoidInitializationError, getPrecisionForAccuracy, getProcessManager, getSizeBreakdown, getSupportedCurrencies, getUrlAlphabet, hashPassword, hashPasswordSync, httpGet, httpPost, idGenerator, initializeNanoid, intervalToCron, isBcryptHash, isPreconditionFailure, isReckerAvailable, isSensitiveField, isSupportedCurrency, isValidCoordinate, isValidIPv4, isValidIPv6, jsxEngine, lazyLoadPlugin, loadApiPlugin, loadBackupPlugin, loadBigqueryReplicator, loadCloudInventoryPlugin, loadCookieFarmPlugin, loadCookieFarmSuitePlugin, loadDynamoDBReplicator, loadGeoPlugin, loadIdentityPlugin, loadKubernetesInventoryPlugin, loadMLPlugin, loadMongoDBReplicator, loadMySQLReplicator, loadPlanetScaleReplicator, loadPostgresReplicator, loadPuppeteerPlugin, loadQueueConsumerPlugin, loadRabbitMqConsumer, loadReconPlugin, loadReplicatorPlugin, loadSMTPPlugin, loadSpiderPlugin, loadSqsConsumer, loadSqsReplicator, loadTursoReplicator, loadWebSocketPlugin, mapAwsError, mapWithConcurrency, md5, measureMemory, metadataDecode, metadataEncode, optimizedDecode, optimizedEncode, parseIncrementalConfig, passwordGenerator, preloadRecker, printTypes, pugEngine, releaseValidator, resetCronManager, resetGlobalLogger, resetProcessManager, setBit, setBitFast, setupTemplateEngine, sha256, sleep$1 as sleep, streamToString, successResponse, toggleBit, toggleBitFast, transformValue, tryFn, tryFnSync, unflatten, validateBackupConfig, validateIncrementalConfig, validateReplicatorConfig, verifyPassword$1 as verifyPassword, withContext };
160275
+ export { AVAILABLE_BEHAVIORS, AdaptiveTuning, AdjacencyListDriver, AnalyticsNotEnabledError, ApiPlugin, AsyncEventEmitter, AuditPlugin, AuthenticationError$1 as AuthenticationError, BACKUP_DRIVERS, BUILT_IN_SENSITIVE_FIELDS, BackupPlugin, BaseBackupDriver, BaseCloudDriver, BaseError, BaseReplicator, BehaviorError, Benchmark, CONTENT_TYPE_DICT, CRON_PRESETS, CURRENCY_DECIMALS, CachePlugin, S3Client as Client, ConnectionString, ConnectionStringError, CookieFarmPlugin, CookieFarmSuitePlugin, CoordinatorPlugin, CostsPlugin, CrawlContext, CronManager, CryptoError, DEFAULT_BEHAVIOR, Database, DatabaseError, DistributedLock, DistributedSequence, EncryptionError, ErrorClassifier, ErrorMap, EventualConsistencyPlugin, Factory, FailbanManager, FetchFallback, FileSystemClient, FileSystemStorage, FilesystemBackupDriver, FilesystemCache, FullTextPlugin, GeoPlugin, GraphConfigurationError, GraphError, GraphPlugin, HighPerformanceInserter, HybridFetcher, IdentityPlugin, ImporterPlugin, InMemoryPersistence, IncrementalConfigError, IncrementalSequence, InvalidEdgeError, InvalidParentError, InvalidResourceItem, KubernetesInventoryPlugin, LatencyBuffer, MLPlugin, MemoryCache, MemoryClient, MemorySampler, MemoryStorage, MetadataLimitError, MetricsPlugin, MissingMetadata, MultiBackupDriver, NON_RETRIABLE, NestedSetDriver, NoSuchBucket, NoSuchKey, NodeNotFoundError, NotFound, OIDCClient, OpenGraphHelper, PartitionAwareFilesystemCache, PartitionDriverError, PartitionError, PartitionQueue, PathNotFoundError, PerformanceMonitor, PermissionError, Plugin, PluginError, PluginObject, PluginStorage, PluginStorageError, ProcessManager$1 as ProcessManager, PuppeteerPlugin, QueueConsumerPlugin, RETRIABLE, RabbitMqConsumer, ReckerHttpHandler, ReckerWrapper, ReconPlugin, ReplicationError, ReplicatorPlugin, Resource, ResourceError, ResourceIdsPageReader, ResourceIdsReader, ResourceNotFound, ResourceReader, ResourceWriter, RingBuffer, RootNodeError, RouteContext$1 as RouteContext, S3BackupDriver, S3Cache, S3Client, S3QueuePlugin, Database as S3db, S3dbError, S3dbReplicator, SMTPPlugin, STATUS_MESSAGE_DICT, SafeEventEmitter, SchedulerPlugin, Schema, SchemaError, Seeder, SpiderPlugin, SqsConsumer, SqsReplicator, StateMachinePlugin, StreamError, StreamInserter, TTLPlugin, TaskExecutor, TasksPool, TasksRunner, TfStatePlugin, TournamentPlugin, Transformers, TreeConfigurationError, TreeIntegrityError, TreePlugin, URL_PREFIX_DICT, UnknownError, ValidationError, Validator, VectorPlugin, VertexNotFoundError, WebSocketPlugin, WebSocketServer, WebhookReplicator, analyzeString, behaviors, benchmark, bytesToMB, cacheValidator, calculateAttributeNamesSize, calculateAttributeSizes, calculateBufferSavings, calculateDictionaryCompression, calculateEffectiveLimit, calculateEncodedSize, calculateIPSavings, calculateSystemOverhead, calculateTotalSize, calculateUTF8Bytes, captureHeapSnapshot, clearBit, clearBitFast, clearUTF8Memory, clearValidatorCache, compactHash, compareEncodings, compareMemorySnapshots, compressIPv6, computeBackoff, countBits, countBitsFast, createBackupDriver, createBitmap, createBitmapFast, createConsumer, createContextInjectionMiddleware, createCronManager, createCustomGenerator, createHttpClient, createHttpClientSync, createIncrementalIdGenerator, createLockedFunction, createLogger, createPayloadRedactionSerializer, createRedactRules, createReplicator, createSafeEventEmitter, createSensitiveDataSerializer, createSequence, decode, decodeBits, decodeBitsFast, decodeBuffer, decodeDecimal, decodeFixedPoint, decodeFixedPointBatch, decodeGeoLat, decodeGeoLon, decodeGeoPoint, decodeIPv4, decodeIPv6, decodeMoney, decrypt, S3db as default, deleteChunkedCookie, detectIPVersion, dictionaryDecode, dictionaryEncode, ejsEngine, encode, encodeBits, encodeBitsFast, encodeBuffer, encodeDecimal, encodeFixedPoint, encodeFixedPointBatch, encodeGeoLat, encodeGeoLon, encodeGeoPoint, encodeIPv4, encodeIPv6, encodeMoney, encrypt, errorResponse, evictUnusedValidators, exampleUsage, expandHash, expandIPv6, flatten, forEachWithConcurrency, forceGC, formatIncrementalValue, formatMemoryUsage, formatMoney, generateSchemaFingerprint, generateTypes, getAccuracyForPrecision, getBehavior, getBit, getBitFast, getCacheMemoryUsage, getCacheStats, getCachedValidator, getChunkedCookie, getCronManager, getCurrencyDecimals, getDictionaryStats, getGlobalLogger, getLoggerOptionsFromEnv, getMemoryUsage, getNanoidInitializationError, getPrecisionForAccuracy, getProcessManager, getSizeBreakdown, getSupportedCurrencies, getUrlAlphabet, hashPassword, hashPasswordSync, httpGet, httpPost, idGenerator, initializeNanoid, intervalToCron, isBcryptHash, isChunkedCookie, isPreconditionFailure, isReckerAvailable, isSensitiveField, isSupportedCurrency, isValidCoordinate, isValidIPv4, isValidIPv6, jsxEngine, lazyLoadPlugin, loadApiPlugin, loadBackupPlugin, loadBigqueryReplicator, loadCloudInventoryPlugin, loadCookieFarmPlugin, loadCookieFarmSuitePlugin, loadDynamoDBReplicator, loadGeoPlugin, loadIdentityPlugin, loadKubernetesInventoryPlugin, loadMLPlugin, loadMongoDBReplicator, loadMySQLReplicator, loadPlanetScaleReplicator, loadPostgresReplicator, loadPuppeteerPlugin, loadQueueConsumerPlugin, loadRabbitMqConsumer, loadReconPlugin, loadReplicatorPlugin, loadSMTPPlugin, loadSpiderPlugin, loadSqsConsumer, loadSqsReplicator, loadTursoReplicator, loadWebSocketPlugin, mapAwsError, mapWithConcurrency, md5, measureMemory, metadataDecode, metadataEncode, optimizedDecode, optimizedEncode, parseIncrementalConfig, passwordGenerator, preloadRecker, printTypes, pugEngine, releaseValidator, resetCronManager, resetGlobalLogger, resetProcessManager, resolveCacheMemoryLimit, setBit, setBitFast, setChunkedCookie, setupTemplateEngine, sha256, sleep$1 as sleep, streamToString, successResponse, toggleBit, toggleBitFast, transformValue, tryFn, tryFnSync, unflatten, validateBackupConfig, validateIncrementalConfig, validateReplicatorConfig, verifyPassword$1 as verifyPassword, withContext };
160280
160276
  //# sourceMappingURL=s3db.es.js.map