You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by gi...@apache.org on 2022/05/07 03:57:41 UTC

[beam] branch nightly-refs/heads/master updated (8d3b4bbaa94 -> f432136d32d)

This is an automated email from the ASF dual-hosted git repository.

github-bot pushed a change to branch nightly-refs/heads/master
in repository https://gitbox.apache.org/repos/asf/beam.git


    from 8d3b4bbaa94 [BEAM-5878] Add (failing) kwonly-argument test (#17509)
     add c7541ddb6fa Add parameter for service account impersonation in GCP credentials
     add 2af0dc79912 Merge pull request #17394: [BEAM-14014] Add parameter for service account impersonation in GCP credentials
     add 96309815e34 Merge pull request #17490 from [BEAM-14370] [Website] Add new page about appache beam
     add c8b857c191d Setting up a basic directory
     add f55bc27b9bd Mirroring Python SDK's directory structure
     add ee53b0ba29d Merge remote-tracking branch 'javascript/master' into javascript
     add 4f86a957ab2 add .gitignore for node/ts project
     add 6c651191cd6 Adds initial tests
     add b66d6250e69 'runners' is the correct directory name
     add b984a0c0848 Merge branch 'master' of https://github.com/robertwb/beam-javascript into add-initial-test
     add 7a82478b7a8 Merge pull request #1 from kerrydc/add-initial-test
     add 1c9aeff1ce3 sketching the core API for JS SDK
     add 4d16093445f Merge pull request #2 from pabloem/core-api
     add 393c7947c59 Merge remote-tracking branch 'javascript/master' into javascript
     add 90989139113 Worker directory.
     add 5afeb9bcc98 Fix complile errors with explicit any for callables.
     add 2ddd5b01c77 Add worker entry point.
     add fa94f13d555 Add proto generation code.
     add 8d9de5f7543 Add generated proto files.
     add d94e2f85acd Attempts to get ts protos to compile.
     add bf7a45d151b Exclude ts protos for now.
     add fddcd2d7bad More changes to get ts protos working.
     add 8d796835150 Update scripts and config to get protos compiling.
     add 231ba22ce3d Update geenrated files.
     add a765a82de95 Generate server for loopback worker.
     add 3ce8b3ffb57 Generated grpc servers for loopback.
     add 7c1c4538edc Add typescript formatter.
     add 8becb2eed7d Loopback server (that does nothing).
     add 13c96917398 add build and clean script to compile ts
     add 72f700fd501 Merge pull request #3 from robertwb/build-scripts
     add fa90fef55e2 Merge remote-tracking branch 'javascript/javascript' into javascript
     add ceacadf0b54 Working server.
     add 3faba353e45 Also generate grpc clients.
     add 91cbe756b1e Basic implementation of worker harness.
     add e827d344578 Starting expansion of primitive transforms
     add e9acdd84be0 Starting to implement and support standard coders
     add 3ba60a2df20 fix the build
     add 6753374244d Merge pull request #5 from pabloem/standard-coders
     add 9e7e7b1dc74 Add some missing files for worker harness.
     add 93b206de889 Refactor operators to use registration.
     add e40c2863864 Encapsulate worker service in a class.
     add 0da24b987e2 enable ts in mocha
     add 1c707903a19 update readme
     add 02988731274 Merge pull request #6 from robertwb/test-ts
     add 4bea06b628d --save-dev @types/mocha
     add a698dafee27 translate core_test.js to typescript
     add 4cfab74b704 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add ce88f36948a Add some tests for the worker code.
     add a6e4827d8ce Port standard_coders_test to typescript (superficially)
     add 195ab4a8b11 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add faeeee592be Starting the proto translation of Impulse, ParDo, GBK
     add 7368c010ba2 Merge pull request #7 from pabloem/primitive-expansion-1
     add 74b0f6ede94 Fixing old lock file error.
     add 4928bcb07ea Adding transform names and fixing GBK coder issue
     add dbf5dd634a2 Merge pull request #8 from pabloem/primitive-expansion-2
     add 02361a8779d npx tsfmt -r src/apache_beam/base.ts src/apache_beam/transforms/core.ts
     add 3df8719ad91 Refactor API to allow for composites.
     add 58839b54b3a switch to import style require() statements
     add c11a651aaea Add Coder interface using protobufjs classes
     add 290d66115da BytesCoder with some failures
     add 31d5ebbbe1d Added GeneralObjectCoder and using it as coder for most transforms (#9)
     add 39db53bb466 Fix order of arguments to deepEqual
     add 2172e9dc825 Encode expected encoding as binary
     add 7c2e4906912 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add 63c4e3d31fc Simplify GBK coder computation.
     add deacc00a46b Remove top-level PValue.
     add 138dfab18d7 Initial setup for automated Java expansion startup
     add c438782f068 Update exp_service.ts
     add 59b7020a224 Merge branch 'expansionStartup' into javascript
     add 4f7b8980731 Fix up coder deserialization
     add f2826b9dd26 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add f3ebcca78c2 Make tests green
     add 936d3f77e38 Rename PValueish to PValue.
     add 96111d71e5d Make Runner.run async.
     add 7328b101776 Direct runner.
     add 1200a221d92 bson and fast-deep-equal should not be listed as devdependency
     add 5fcfe5770c9 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add 8072fb29853 Add basic Dockerfile that starts ExternalWorkerPool
     add dfd172ccb5a Merge branch 'container' into javascript
     add e11446b70f0 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add dcfa7efdb6c Added flatten, assertion checkers.
     add 07724fa7353 Testing expansion service communication
     add 92c6012b8c9 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add d49cc3e7927 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add 0a465486d48 node runner
     add b27b2bc8567 whitespaces
     add 3e23533de05 Merge pull request #10 from robertwb/node-runner
     add b226bdc53a6 progress on basic coders
     add 884ad82d190 Merge pull request #11 from pabloem/basic-coders-progress-1
     add 8d0982eeb55 Fixing the build.
     add 0e2df4700b4 Cleanup, simplify access.
     add 339fb89e94b Adding limited support for KVCoder and IterableCoder
     add c371434f0de Introduce PipelineContext.
     add e6a5a69cd13 Add toProto to all coders.
     add 6f169011403 Some work with coders.
     add 6bd0a9280c1 Remove debug logging.
     add ba535c5116d Use coders over data channel.
     add b82959a8ea4 explicitly sequence sub-coder serializations
     add 84d68a40207 no more need to extend FakeCoder
     add d095d440950 actually advance reader
     add 7620c7ba35c autoformat
     add f273cf75de0 protobufjs already can write and read signed varints
     add 6eb6eda2263 with improved test harness, kv has many more failures
     add b3a3aa6828a Implementing RowCoder encoding.
     add 05fcb976cc4 read bytescoder from correct position
     add 738208ad089 no more fake coders
     add df99a218ab3 varint examples all work
     add 6f256dffb95 simplify coder value parsing
     add 655c230ee10 global window coder
     add 242497109b8 Add P(...) operator.
     add 7d616b7809e fix swapEndian32
     add b128b5da099 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add 68aa5fd141f Merge branch 'javascript' into row-coder
     add 56358c29e0c Corrected sorting of encoded positions to reflect an argsort instead.
     add 2ccad661c3e Implementing RowCoder decoding.
     add 26ce7a0f2fe remove unused container dir
     add 7d5174f19bd Populate environments.
     add 28fe59c30ee Merge branch 'javascript' into row-coder
     add fa36afb96b7 Completed implementation of basic row coder
     add a31a07e1e49 preliminary unbounded iterable coder
     add 3892f6f7484 friendlier description of standard coder test case
     add e01654c754b fix test harness; iterable works
     add 45bea456363 first pass at boot.go
     add 99b71b0c3de Merge branch 'gradle' into javascript
     add 9952870356e update package-lock.json
     add 886026d2768 make NodeRunner a subclass of Runner
     add 5dc8682adaf add waitUntilFinish interface member
     add fddb51d916d Adding double coder
     add f6cf05038c3 scaffolding for windowed values
     add c715a2cc240 fix direct runner
     add 593c86cdafe Adding type information to PColleciton and PTransform
     add cc06f4d03d8 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add 12bbd788ed4 add runAsync method to base.Runner
     add 7fc06237b33 Adding typing information for DoFns
     add 4c3e69ae60d add interval window
     add 510ba9301f5 Export PValue.
     add cd3f4c61b91 Add CombineFn interface.
     add 9497b77079b Typed flatten.
     add 82a1b92da4d Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add 3b8170f8274 add Long package
     add 00dbccfd89e Adding more types. Making PValue typed
     add 0a3f01580b1 instant coder draft
     add 4869775cfd0 Return job state from direct runner.
     add b3277ac01de implement NodeRunner.runPipeline
     add fcee2c7c284 type instant = long
     add 27d78f51974 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add ed28e20203e autoformat
     add c89d8c14f0d Merge branch 'javascript' of github.com:robertwb/beam-javascript into row-coder
     add 9fd42f7b763 loopback runner works
     add d068e7b9ba3 GBK working on ULR.
     add bb2eca98563 Async transforms.
     add f9a9a8c8c28 External transform grpah splicing.
     add e6fac08b7c4 Fix IntervalWindowCoder, almost
     add 2568f538ee6 fix interval window coder
     add d6f18350b82 autoformat
     add 178cce1033d move core element types into values.ts
     add 238113b278d just build object directly to be cool
     add d9b0647af8b Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add 14fbe613ae8 Fix merge.
     add 10478ddf159 progress on windowed value: paneinfo encoding
     add c6ecf57b550 Merge branch 'javascript' of github.com:robertwb/beam-javascript into javascript
     add c58008e92c9 autoformat
     add 1dc811dbc31 full windowed value coder
     add 76dcc501766 Updates tests to use correct types, adds generics where needed to DoFns
     add d35ed5e1d2e Add serialization librarires.'
     add 1a7ee9dbca8 Add Split() PTransform, for producing multiple outputs from a single PCollection.
     add ba549bd8496 Merge branch 'javascript' into row-coder
     add 7c52bb1b378 Adding Schema inference from JSON
     add 3e0f9ab19a0 Merge pull request #12 from pskevin/row-coder
     add 485d8294235 Schema-encoded external payloads.
     add be92a446d4b Merge branch 'javascript' into row-coder
     add c5555f30f56 Removing unused directories
     add 68559486c5e Support for finishBundle and improving typing annotations.
     add f42cebea165 A base implementation of combiners with GBK/ParDo
     add bf957d719f7 Fully propagate windowing information in both remote and direct runner.
     add b6ed255edbe Make args and kwargs optional for python external transform.
     add e5f52f12508 Infer schema for external transforms.
     add dff596af888 Implementing a custom combine fn as an example. Small fixes
     add e1e9230f4bf Fix missing windowing information in combiners.
     add 6720fb3ef23 PostShuffle needn't group by key as that's already done.
     add 58784d58b5a Guard pre-combine for global window only.
     add fb711984051 WindowInto
     add 4b511fbe70c Fix optional kwargs.
     add ed609f4e4c3 A couple of tweaks for js + py
     add 6d6853334a9 Add windowing file.
     add 7a7db3c4294 CombineBy transform, stand-alone WordCount.
     add 39ee4806cb7 cleanup
     add 79bbe803905 Actually fix optional external kwargs.
     add 84c103f0752 Demo2, textio read.
     add 9e60df16710 Add command lines for starting up the servers.
     add 5a8c076dc45 Run prettier on the full codebase.
     add 7bce3e7d011 Merge branch 'fqn' into javascript
     add cf8c59780ac Update deps.
     add f47d2f35766 Adding docstrings for core.ts. Prettier dependency
     add 1d7f13bb91a Documenting coder interfaces
     add 433089ab0e1 Added documentation for a few standard coders
     add 4d9551421b2 Unified grouping and combining.
     add 36726c7738b Allow PCollection ids to be lazy.
     add 9edc8276f67 Reorganize module structure.
     add 443463528f2 A couple more renames.
     add b4804379b30 Simplify.
     add 94c8f481974 Consolidation.
     add 206ed482c29 Fix build.
     add de4390dd767 Add optional context to ParDo.
     add 2c52f348be5 fixup: iterable coder endian sign issue
     add 79cf6c02a71 omit context for map(console.log)
     add 837301a2d24 Fix ReadFromText coders.
     add 4284b1b7972 Flesh out README with overview and current state.
     add 09e8e29b6f5 Readme typo
     add b1369461b4a Two more TODOs.
     add 9293e2b3ca9 Add a pointer to the example wordcount to the readme.
     add d6fa775a730 Documenting coders and implementing unknown-length method
     add c5383b74321 UIID dependency.
     add a9f1d2b47b8 Artifact handling.
     add 6a713db4522 Properly wait on data channel for bundle completion.
     add 6dea150ed2c Automatic java expansion service startup.
     add 48fdb5a04f1 Process promises.
     add c294d0a93bd Implement side inputs.
     add b6c6fc21d7c Cleanup.
     add 9008ac7db0a Put complex constext stuff in its own file.
     add 785b09c6f1c Rename BoundedWindow to just Window.
     add 9116f40670c Alternative splitter class.
     add f0ee6d09809 Documenting internal functions
     add 8e8e6adcdd1 Take a pass clarifying the TODOs.
     add 5a11be885d6 Sql transform wrapper.
     add acc67556f94 Incorporate some feedback into the TODOs.
     add 968529e1847 More TODOs.
     add b2a03d5134c Remove app placeholder.
     add ef95f1def84 Apache license headers.
     add ba36fccacb9 More TODOs
     add dada2bc6552 Add actions for typescript sdk
     add a38cc2287d6 Fix test command
     add 949eddcdc36 Add missing version
     add 05bd33d369d Fix codecovTest command
     add f6570cacfeb Only do prettier check on linux
     add 8de08ed6544 Only get codecov on linux
     add 76d50597412 Merge pull request #16 from damccorm/javascript - Rename node-ts to typescript and add GitHub Action
     add 682e1daa7d5 Suggestions for TypeScript todos
     add c84260bccda Merge remote-tracking branch 'frigus02/ts-suggestions' into javascript
     add 19cf60751ab Resolve some comments.
     add 81445cb91ee Fix compile errors.
     add d2d14723fc5 Prettier.
     add b6fd5bf2bc6 Re-order expandInternal arguments pending unification.
     add c059f707156 More consistent and stricter PTransform naming.
     add 2de2ab7aedd Notes on explicit, if less idiomatic, use of classes.
     add f6875b1903b Let DoFn be an interface rather than a class.
     add edd596b3975 Provide DoFn context to start and finish bundle.
     add 2e2757e9a23 Optional promise code simplification.
     add a56c7813467 Cleanup todos.
     add cf952b5cf59 Avoid any type where not needed.
     add 85f73a4fe7d Apache RAT excludes for typescript.
     add de762033f90 Remove empty READMEs.
     add 7d9bf1694ae Add licences statement to readme files.
     add 52d7a782029 Merge branch 'master' into javascript
     add d7375a7096c More RAT fixes.
     add 4c3072f2cec Another unsupported coder.
     add 53aff1be4cc Remove debugging code.
     add 64ee4fb68b4 Fix automatic naming with code coverage.
     add 624da63b8c2 Coders cleanup.
     add f68b991aae4 Add tests for RowCoder.
     add 1d455a821ed Normalize capitalization, comments.
     add d9be62af832 Install typescript closure packages.
     add a32a4fba061 npm audit fix
     add a6ecc7a3720 Move more imports out of base.
     add c64e5e38f87 Changes needed to compile with ts closure plugin.
     add 1ea4f85e7d2 Use ttsc and ts-closure-transform plugin.
     add b600f709ec0 Serialization registration to actually get serialization working.
     add 864575f98d5 Container images working on local runner.
     add a09f5de4497 Add a portable job server that proxies the Dataflow backend. (#17189)
     add 267c16ca0f1 Improvements to dataflow job service for non-Python jobs.
     add e78f2d4dba3 Get dataflow working.
     add fb661154712 User friendly pipeline options.
     add d2ef2f6a3e9 Less classes, more functions.
     add 978fe6326bd Merge branch 'master' into javascript
     add 4b0cdc5bcfc Add new nullable standard coder.
     add f50cf66bd67 Make Apache Rat happy.
     add f092cb33d2a Disable broken codecov.
     add 23cc336cf1c Merge branch 'master' into javascript
     add 8a117e0c503 Remove last uses of base.ts.
     add 4e974d5f9b1 Remove unneedd file.
     add 68b26b3da43 Remove more uneeded/unused files.
     add 72d274700cc Cleanup tests.
     add 162453cfea7 Minor cleanups to coder tests.
     add ad295cadbff Addressing issues from the review.
     add fa36cb74c84 Apply suggestions from code review.
     add 6383e77edca Merge remote-tracking branch 'robertwb/javascript' into javascript
     add 2b0290a01e9 Post-merge fixes.
     add acb826f7fdb Update tests to use our actual serialization libraries.
     add 4e6768b762a Another pass at TODOs, removing finished items.
     add cb680295254 Merge pull request #17341 [BEAM-1754] Adds experimental Typescript Beam SDK
     add 099ff6317bc Delete tags.go
     add 39de4b2c3af Merge pull request #17541: [BEAM-14059] Delete tags.go
     add 30c3ea22d96 [BEAM-14332] Refactored cluster management for Flink on Dataproc (#17402)
     add 68e2a105a3f [BEAM-14146] Python Streaming job failing to drain with BigQueryIO write errors
     add a0684f502f0 Merge pull request #17566 from [BEAM-14146] Python Streaming job failing to drain with BigQueryIO write errors
     add f1f26f10698 [BEAM-13988] Update mtime to use time.UnixMilli() calls (#17578)
     add ad6e7b75395 Fixing patching error on missing dependencies (#17564)
     add 358782006e1 Merge pull request #17517 from [BEAM-14383] Improve "FailedRows" errors returned by beam.io.WriteToBigQuery
     add 6e772d67e75 Quote pip install package name
     add f432136d32d Merge pull request #17450 from kynx/patch-1

No new revisions were added by this update.

Summary of changes:
 .github/workflows/typescript_tests.yml             |   66 +
 .gitignore                                         |    3 +
 CHANGES.md                                         |    1 +
 build.gradle.kts                                   |    9 +-
 .../beam/model/fnexecution/v1/standard_coders.yaml |    2 +
 .../examples/build.gradle                          |   54 +-
 sdks/go/pkg/beam/core/graph/mtime/time.go          |    6 +-
 sdks/go/pkg/beam/core/graph/mtime/time_test.go     |   54 +
 sdks/go/pkg/beam/core/util/reflectx/tags.go        |   89 -
 .../sdk/extensions/gcp/auth/CredentialFactory.java |    2 +
 .../extensions/gcp/auth/GcpCredentialFactory.java  |   51 +-
 .../sdk/extensions/gcp/options/GcpOptions.java     |   19 +
 sdks/python/apache_beam/io/gcp/bigquery.py         |    8 +-
 sdks/python/apache_beam/io/gcp/bigquery_tools.py   |   18 +-
 .../apache_beam/io/gcp/bigquery_tools_test.py      |   14 +-
 .../apache_beam/io/gcp/bigquery_write_it_test.py   |   91 +
 .../dataproc/dataproc_cluster_manager.py           |  139 +-
 .../dataproc/dataproc_cluster_manager_test.py      |   49 +-
 .../runners/interactive/dataproc/types.py          |   25 +-
 .../runners/interactive/interactive_beam.py        |  341 +-
 .../runners/interactive/interactive_beam_test.py   |  435 +-
 .../runners/interactive/interactive_environment.py |   14 +-
 .../interactive/interactive_environment_test.py    |   19 +-
 .../runners/interactive/interactive_runner.py      |  124 +-
 .../runners/interactive/interactive_runner_test.py |  183 +-
 .../messaging/interactive_environment_inspector.py |   28 +-
 .../interactive_environment_inspector_test.py      |   69 +-
 .../runners/interactive/recording_manager.py       |   11 +-
 .../runners/interactive/testing/mock_env.py        |   90 +
 .../runners/interactive/testing/mock_ipython.py    |    2 +
 .../apache_beam/runners/interactive/utils.py       |   55 +-
 .../apache_beam/runners/interactive/utils_test.py  |   32 +-
 sdks/typescript/.gitignore                         |   41 +
 .../types.py => typescript/.prettierignore}        |   28 +-
 sdks/typescript/Dockerfile                         |   40 +
 sdks/typescript/README.md                          |  184 +
 sdks/typescript/boot.go                            |  107 +
 sdks/typescript/build_container.sh                 |   22 +
 sdks/typescript/package-lock.json                  | 3922 ++++++++++
 sdks/typescript/package.json                       |   45 +
 sdks/typescript/src/apache_beam/coders/coders.ts   |  142 +
 .../typescript/src/apache_beam/coders/js_coders.ts |  155 +
 .../src/apache_beam/coders/required_coders.ts      |  644 ++
 .../typescript/src/apache_beam/coders/row_coder.ts |  391 +
 .../src/apache_beam/coders/standard_coders.ts      |  236 +
 .../src/apache_beam/examples/wordcount.ts          |   64 +
 .../src/apache_beam/examples/wordcount_sql.ts      |   54 +
 .../src/apache_beam/examples/wordcount_textio.ts   |   63 +
 .../src/apache_beam/index.ts}                      |   12 +-
 .../src/apache_beam/internal/environments.ts       |   91 +
 .../src/apache_beam/internal/pipeline.ts           |  341 +
 .../src/apache_beam/internal/serialize.ts          |   58 +
 sdks/typescript/src/apache_beam/internal/urns.ts   |   42 +
 sdks/typescript/src/apache_beam/io/textio.ts       |   46 +
 .../src/apache_beam/options/pipeline_options.ts}   |   10 +-
 sdks/typescript/src/apache_beam/proto/README.md    |   24 +
 .../apache_beam/proto/beam_artifact_api.client.ts  |  257 +
 .../proto/beam_artifact_api.grpc-client.ts         |  267 +
 .../src/apache_beam/proto/beam_artifact_api.ts     | 1389 ++++
 .../apache_beam/proto/beam_expansion_api.client.ts |   64 +
 .../proto/beam_expansion_api.grpc-client.ts        |   65 +
 .../src/apache_beam/proto/beam_expansion_api.ts    |  236 +
 .../src/apache_beam/proto/beam_fn_api.client.ts    |  306 +
 .../apache_beam/proto/beam_fn_api.grpc-client.ts   |  317 +
 .../apache_beam/proto/beam_fn_api.grpc-server.ts   |  304 +
 .../src/apache_beam/proto/beam_fn_api.ts           | 5163 +++++++++++++
 .../src/apache_beam/proto/beam_job_api.client.ts   |  222 +
 .../apache_beam/proto/beam_job_api.grpc-client.ts  |  245 +
 .../src/apache_beam/proto/beam_job_api.ts          | 1737 +++++
 .../apache_beam/proto/beam_provision_api.client.ts |   72 +
 .../proto/beam_provision_api.grpc-client.ts        |   73 +
 .../proto/beam_provision_api.grpc-server.ts        |   67 +
 .../src/apache_beam/proto/beam_provision_api.ts    |  342 +
 .../apache_beam/proto/beam_runner_api.client.ts    |   64 +
 .../proto/beam_runner_api.grpc-client.ts           |   63 +
 .../proto/beam_runner_api.grpc-server.ts           |   63 +
 .../src/apache_beam/proto/beam_runner_api.ts       | 8149 ++++++++++++++++++++
 sdks/typescript/src/apache_beam/proto/endpoints.ts |  185 +
 .../src/apache_beam/proto/external_transforms.ts   |  378 +
 .../typescript/src/apache_beam/proto/gen_protos.sh |   46 +
 .../proto/google/protobuf/descriptor.ts            | 3445 +++++++++
 .../apache_beam/proto/google/protobuf/duration.ts  |  231 +
 .../apache_beam/proto/google/protobuf/struct.ts    |  480 ++
 .../apache_beam/proto/google/protobuf/timestamp.ts |  290 +
 sdks/typescript/src/apache_beam/proto/metrics.ts   |  876 +++
 sdks/typescript/src/apache_beam/proto/schema.ts    | 1568 ++++
 .../src/apache_beam/proto/standard_window_fns.ts   |  358 +
 sdks/typescript/src/apache_beam/pvalue.ts          |  289 +
 .../src/apache_beam/runners/artifacts.ts           |  205 +
 .../src/apache_beam/runners/direct_runner.ts       |  482 ++
 .../apache_beam/runners/portable_runner/runner.ts  |  213 +
 sdks/typescript/src/apache_beam/runners/runner.ts  |   73 +
 sdks/typescript/src/apache_beam/serialization.ts   |  102 +
 sdks/typescript/src/apache_beam/testing/assert.ts  |   96 +
 .../apache_beam/testing/proto_printing_runner.ts}  |   18 +-
 .../src/apache_beam/transforms/combiners.ts        |   71 +
 .../src/apache_beam/transforms/create.ts           |   50 +
 .../src/apache_beam/transforms/external.ts         |  342 +
 .../src/apache_beam/transforms/flatten.ts          |   44 +
 .../apache_beam/transforms/group_and_combine.ts    |  336 +
 .../src/apache_beam/transforms/index.ts}           |   18 +-
 .../src/apache_beam/transforms/internal.ts         |  184 +
 .../typescript/src/apache_beam/transforms/pardo.ts |  370 +
 sdks/typescript/src/apache_beam/transforms/sql.ts  |   99 +
 .../src/apache_beam/transforms/transform.ts        |  116 +
 .../src/apache_beam/transforms/window.ts           |  142 +
 .../src/apache_beam/transforms/windowings.ts       |  141 +
 sdks/typescript/src/apache_beam/utils/service.ts   |  258 +
 sdks/typescript/src/apache_beam/values.ts          |   69 +
 .../src/apache_beam/version.ts}                    |   12 +-
 sdks/typescript/src/apache_beam/worker/data.ts     |  238 +
 .../apache_beam/worker/external_worker_service.ts  |  115 +
 .../typescript/src/apache_beam/worker/operators.ts |  621 ++
 .../src/apache_beam/worker/pardo_context.ts        |  253 +
 sdks/typescript/src/apache_beam/worker/state.ts    |  247 +
 sdks/typescript/src/apache_beam/worker/worker.ts   |  372 +
 .../src/apache_beam/worker/worker_main.ts          |  102 +
 sdks/typescript/test/combine_test.ts               |  275 +
 sdks/typescript/test/js_coders_test.ts             |  182 +
 sdks/typescript/test/primitives_test.ts            |  229 +
 sdks/typescript/test/row_coder_test.ts             |   80 +
 sdks/typescript/test/serialize_test.ts             |   68 +
 sdks/typescript/test/standard_coders_test.ts       |  241 +
 sdks/typescript/test/wordcount.ts                  |   92 +
 sdks/typescript/test/worker_test.ts                |  250 +
 sdks/typescript/tsconfig.json                      |   28 +
 .../site/assets/icons/about/abstration_icon.svg    |   40 +
 .../www/site/assets/icons/about/adoption_icon.svg  |   24 +
 .../site/assets/icons/about/capabilities_icon.svg  |   31 +
 .../site/assets/icons/about/extencibility_icon.svg |   28 +
 .../site/assets/icons/about/flexibility_icon.svg   |   25 +
 website/www/site/assets/icons/about/model_icon.svg |   27 +
 .../site/assets/icons/about/portability_icon.svg   |   28 +
 website/www/site/assets/scss/_about.sass           |   66 +
 website/www/site/assets/scss/_lists.scss           |   13 +
 website/www/site/assets/scss/_navbar-desktop.scss  |    2 +-
 website/www/site/assets/scss/main.scss             |    1 +
 website/www/site/content/en/about/_index.md        |   79 +
 .../site/content/en/get-started/quickstart-py.md   |   10 +-
 website/www/site/data/en/about_list.yaml           |   45 +
 website/www/site/i18n/navbar/en.yaml               |    2 +
 website/www/site/layouts/about/baseof.html         |   31 +
 website/www/site/layouts/partials/header.html      |    4 +
 .../layouts/shortcodes/about/list_with_icons.html  |   28 +
 .../images/batch_stream_processing_desktop.png     |  Bin 0 -> 222611 bytes
 .../images/batch_stream_processing_mobile.png      |  Bin 0 -> 191302 bytes
 website/www/site/static/images/vertical_line.png   |  Bin 0 -> 133 bytes
 147 files changed, 42867 insertions(+), 927 deletions(-)
 create mode 100644 .github/workflows/typescript_tests.yml
 delete mode 100644 sdks/go/pkg/beam/core/util/reflectx/tags.go
 create mode 100644 sdks/python/apache_beam/runners/interactive/testing/mock_env.py
 create mode 100644 sdks/typescript/.gitignore
 copy sdks/{python/apache_beam/runners/interactive/dataproc/types.py => typescript/.prettierignore} (56%)
 create mode 100644 sdks/typescript/Dockerfile
 create mode 100644 sdks/typescript/README.md
 create mode 100644 sdks/typescript/boot.go
 create mode 100755 sdks/typescript/build_container.sh
 create mode 100644 sdks/typescript/package-lock.json
 create mode 100644 sdks/typescript/package.json
 create mode 100644 sdks/typescript/src/apache_beam/coders/coders.ts
 create mode 100644 sdks/typescript/src/apache_beam/coders/js_coders.ts
 create mode 100644 sdks/typescript/src/apache_beam/coders/required_coders.ts
 create mode 100644 sdks/typescript/src/apache_beam/coders/row_coder.ts
 create mode 100644 sdks/typescript/src/apache_beam/coders/standard_coders.ts
 create mode 100644 sdks/typescript/src/apache_beam/examples/wordcount.ts
 create mode 100644 sdks/typescript/src/apache_beam/examples/wordcount_sql.ts
 create mode 100644 sdks/typescript/src/apache_beam/examples/wordcount_textio.ts
 copy sdks/{java/extensions/google-cloud-platform-core/src/main/java/org/apache/beam/sdk/extensions/gcp/auth/CredentialFactory.java => typescript/src/apache_beam/index.ts} (69%)
 create mode 100644 sdks/typescript/src/apache_beam/internal/environments.ts
 create mode 100644 sdks/typescript/src/apache_beam/internal/pipeline.ts
 create mode 100644 sdks/typescript/src/apache_beam/internal/serialize.ts
 create mode 100644 sdks/typescript/src/apache_beam/internal/urns.ts
 create mode 100644 sdks/typescript/src/apache_beam/io/textio.ts
 copy sdks/{java/extensions/google-cloud-platform-core/src/main/java/org/apache/beam/sdk/extensions/gcp/auth/CredentialFactory.java => typescript/src/apache_beam/options/pipeline_options.ts} (69%)
 create mode 100644 sdks/typescript/src/apache_beam/proto/README.md
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_artifact_api.client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_artifact_api.grpc-client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_artifact_api.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_expansion_api.client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_expansion_api.grpc-client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_expansion_api.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_fn_api.client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_fn_api.grpc-client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_fn_api.grpc-server.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_fn_api.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_job_api.client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_job_api.grpc-client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_job_api.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_provision_api.client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_provision_api.grpc-client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_provision_api.grpc-server.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_provision_api.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_runner_api.client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_runner_api.grpc-client.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_runner_api.grpc-server.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/beam_runner_api.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/endpoints.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/external_transforms.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/gen_protos.sh
 create mode 100644 sdks/typescript/src/apache_beam/proto/google/protobuf/descriptor.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/google/protobuf/duration.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/google/protobuf/struct.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/google/protobuf/timestamp.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/metrics.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/schema.ts
 create mode 100644 sdks/typescript/src/apache_beam/proto/standard_window_fns.ts
 create mode 100644 sdks/typescript/src/apache_beam/pvalue.ts
 create mode 100644 sdks/typescript/src/apache_beam/runners/artifacts.ts
 create mode 100644 sdks/typescript/src/apache_beam/runners/direct_runner.ts
 create mode 100644 sdks/typescript/src/apache_beam/runners/portable_runner/runner.ts
 create mode 100644 sdks/typescript/src/apache_beam/runners/runner.ts
 create mode 100644 sdks/typescript/src/apache_beam/serialization.ts
 create mode 100644 sdks/typescript/src/apache_beam/testing/assert.ts
 copy sdks/{java/extensions/google-cloud-platform-core/src/main/java/org/apache/beam/sdk/extensions/gcp/auth/CredentialFactory.java => typescript/src/apache_beam/testing/proto_printing_runner.ts} (67%)
 create mode 100644 sdks/typescript/src/apache_beam/transforms/combiners.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/create.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/external.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/flatten.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/group_and_combine.ts
 copy sdks/{java/extensions/google-cloud-platform-core/src/main/java/org/apache/beam/sdk/extensions/gcp/auth/CredentialFactory.java => typescript/src/apache_beam/transforms/index.ts} (69%)
 create mode 100644 sdks/typescript/src/apache_beam/transforms/internal.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/pardo.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/sql.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/transform.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/window.ts
 create mode 100644 sdks/typescript/src/apache_beam/transforms/windowings.ts
 create mode 100644 sdks/typescript/src/apache_beam/utils/service.ts
 create mode 100644 sdks/typescript/src/apache_beam/values.ts
 copy sdks/{java/extensions/google-cloud-platform-core/src/main/java/org/apache/beam/sdk/extensions/gcp/auth/CredentialFactory.java => typescript/src/apache_beam/version.ts} (69%)
 create mode 100644 sdks/typescript/src/apache_beam/worker/data.ts
 create mode 100644 sdks/typescript/src/apache_beam/worker/external_worker_service.ts
 create mode 100644 sdks/typescript/src/apache_beam/worker/operators.ts
 create mode 100644 sdks/typescript/src/apache_beam/worker/pardo_context.ts
 create mode 100644 sdks/typescript/src/apache_beam/worker/state.ts
 create mode 100644 sdks/typescript/src/apache_beam/worker/worker.ts
 create mode 100644 sdks/typescript/src/apache_beam/worker/worker_main.ts
 create mode 100644 sdks/typescript/test/combine_test.ts
 create mode 100644 sdks/typescript/test/js_coders_test.ts
 create mode 100644 sdks/typescript/test/primitives_test.ts
 create mode 100644 sdks/typescript/test/row_coder_test.ts
 create mode 100644 sdks/typescript/test/serialize_test.ts
 create mode 100644 sdks/typescript/test/standard_coders_test.ts
 create mode 100644 sdks/typescript/test/wordcount.ts
 create mode 100644 sdks/typescript/test/worker_test.ts
 create mode 100644 sdks/typescript/tsconfig.json
 create mode 100644 website/www/site/assets/icons/about/abstration_icon.svg
 create mode 100644 website/www/site/assets/icons/about/adoption_icon.svg
 create mode 100644 website/www/site/assets/icons/about/capabilities_icon.svg
 create mode 100644 website/www/site/assets/icons/about/extencibility_icon.svg
 create mode 100644 website/www/site/assets/icons/about/flexibility_icon.svg
 create mode 100644 website/www/site/assets/icons/about/model_icon.svg
 create mode 100644 website/www/site/assets/icons/about/portability_icon.svg
 create mode 100644 website/www/site/assets/scss/_about.sass
 create mode 100644 website/www/site/content/en/about/_index.md
 create mode 100644 website/www/site/data/en/about_list.yaml
 create mode 100644 website/www/site/layouts/about/baseof.html
 create mode 100644 website/www/site/layouts/shortcodes/about/list_with_icons.html
 create mode 100644 website/www/site/static/images/batch_stream_processing_desktop.png
 create mode 100644 website/www/site/static/images/batch_stream_processing_mobile.png
 create mode 100644 website/www/site/static/images/vertical_line.png