Skip to content

Enable prism by default (where supported) #26666

Enable prism by default (where supported)

Enable prism by default (where supported) #26666

GitHub Actions / Test Results failed Apr 11, 2025 in 0s

6 fail, 24 skipped, 600 pass in 7m 54s

    4 files  +    4      4 suites  +4   7m 54s ⏱️ + 7m 54s
  630 tests +  630    600 ✅ +  600  24 💤 +24  6 ❌ +6 
1 260 runs  +1 260  1 198 ✅ +1 198  53 💤 +53  9 ❌ +9 

Results for commit 3233b69. ± Comparison against earlier commit e28e463.

Annotations

Check warning on line 0 in apache_beam.dataframe.io_test.IOTest

See this annotation in the file changed.

@github-actions github-actions / Test Results

1 out of 2 runs failed: test_read_write_4_json (apache_beam.dataframe.io_test.IOTest)

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 35s]
Raw output
AssertionError: DataFrame are different

DataFrame shape mismatch
[left]:  (1000, 3)
[right]: (2000, 3) [while running 'assert_that/Match']
>   return self.do_fn_invoker.invoke_process(windowed_value)

apache_beam/runners/common.py:1495: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/runners/common.py:684: in apache_beam.runners.common.SimpleInvoker.invoke_process
    windowed_value, self.process_method(windowed_value.value))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/transforms/core.py:2086: in <lambda>
    wrapper = lambda x: [fn(x)]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

actual =      number      float                                               text
2         2   1.414214                      ...ooooooooooooooooo...
997     997  31.575307  fooooooooooooooooooooooooooooooooooooooooooooo...

[2000 rows x 3 columns]

    def check(actual):
      expected = expected_
      try:
        actual = pd.concat(actual)
        if not check_index:
          expected = expected.sort_values(list(
              expected.columns)).reset_index(drop=True)
          actual = actual.sort_values(list(
              actual.columns)).reset_index(drop=True)
        if not check_names:
          actual = actual.rename(
              columns=dict(zip(actual.columns, expected.columns)))
>       return assert_frame_equal(expected, actual, check_like=True)
E       AssertionError: DataFrame are different
E       
E       DataFrame shape mismatch
E       [left]:  (1000, 3)
E       [right]: (2000, 3)

apache_beam/dataframe/io_test.py:215: AssertionError

During handling of the above exception, another exception occurred:

a = (<apache_beam.dataframe.io_test.IOTest testMethod=test_read_write_4_json>,)
kw = {}

    @wraps(func)
    def standalone_func(*a, **kw):
>       return func(*(a + p.args), **p.kwargs, **kw)

target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/parameterized/parameterized.py:620: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/dataframe/io_test.py:180: in test_read_write
    self._run_read_write_test(
apache_beam/dataframe/io_test.py:234: in _run_read_write_test
    with beam.Pipeline() as p:
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:644: in __exit__
    self.result = self.run()
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:618: in run
    return self.runner.run_pipeline(self, self._options)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/direct/direct_runner.py:190: in run_pipeline
    return runner.run_pipeline(pipeline, options)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:196: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:223: in run_via_runner_api
    return self.run_stages(stage_context, stages)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:470: in run_stages
    bundle_results = self._execute_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:795: in _execute_bundle
    self._run_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1034: in _run_bundle
    result, splits = bundle_manager.process_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1360: in process_bundle
    result_future = self._worker_handler.control_conn.push(process_bundle_req)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/worker_handlers.py:386: in push
    response = self.worker.do_instruction(request)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py:658: in do_instruction
    return getattr(self, request_type)(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py:696: in process_bundle
    bundle_processor.process_bundle(instruction_id))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py:1274: in process_bundle
    input_op_by_transform_id[element.transform_id].process_encoded(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py:237: in process_encoded
    self.output(decoded_value)
apache_beam/runners/worker/operations.py:566: in apache_beam.runners.worker.operations.Operation.output
    def output(self, windowed_value, output_index=0):
apache_beam/runners/worker/operations.py:568: in apache_beam.runners.worker.operations.Operation.output
    _cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
apache_beam/runners/worker/operations.py:259: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    def receive(self, windowed_value):
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1606: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise new_exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:684: in apache_beam.runners.common.SimpleInvoker.invoke_process
    windowed_value, self.process_method(windowed_value.value))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/transforms/core.py:2086: in <lambda>
    wrapper = lambda x: [fn(x)]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

actual =      number      float                                               text
2         2   1.414214                      ...ooooooooooooooooo...
997     997  31.575307  fooooooooooooooooooooooooooooooooooooooooooooo...

[2000 rows x 3 columns]

    def check(actual):
      expected = expected_
      try:
        actual = pd.concat(actual)
        if not check_index:
          expected = expected.sort_values(list(
              expected.columns)).reset_index(drop=True)
          actual = actual.sort_values(list(
              actual.columns)).reset_index(drop=True)
        if not check_names:
          actual = actual.rename(
              columns=dict(zip(actual.columns, expected.columns)))
>       return assert_frame_equal(expected, actual, check_like=True)
E       AssertionError: DataFrame are different
E       
E       DataFrame shape mismatch
E       [left]:  (1000, 3)
E       [right]: (2000, 3) [while running 'assert_that/Match']

apache_beam/dataframe/io_test.py:215: AssertionError

Check warning on line 0 in apache_beam.dataframe.doctests_test.DoctestTest

See this annotation in the file changed.

@github-actions github-actions / Test Results

All 2 runs failed: test_failure (apache_beam.dataframe.doctests_test.DoctestTest)

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 34s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 14s]
Raw output
AssertionError: 2 != 1
self = <apache_beam.dataframe.doctests_test.DoctestTest testMethod=test_failure>

    def test_failure(self):
      result = doctests.teststring(
          SAMPLE_DOCTEST.replace('25.0', '25.00001'), report=False)
      self.assertEqual(result.attempted, 3)
>     self.assertEqual(result.failed, 1)
E     AssertionError: 2 != 1

apache_beam/dataframe/doctests_test.py:156: AssertionError

Check warning on line 0 in apache_beam.dataframe.io_test.IOTest

See this annotation in the file changed.

@github-actions github-actions / Test Results

1 out of 2 runs failed: test_read_write_2_json (apache_beam.dataframe.io_test.IOTest)

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 38s]
Raw output
AssertionError: DataFrame are different

DataFrame shape mismatch
[left]:  (1000, 3)
[right]: (2000, 3) [while running 'assert_that/Match']
>   return self.do_fn_invoker.invoke_process(windowed_value)

apache_beam/runners/common.py:1495: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/runners/common.py:684: in apache_beam.runners.common.SimpleInvoker.invoke_process
    windowed_value, self.process_method(windowed_value.value))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/transforms/core.py:2086: in <lambda>
    wrapper = lambda x: [fn(x)]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

actual =      number      float                                               text
2         2   1.414214                      ...ooooooooooooooooo...
997     997  31.575307  fooooooooooooooooooooooooooooooooooooooooooooo...

[2000 rows x 3 columns]

    def check(actual):
      expected = expected_
      try:
        actual = pd.concat(actual)
        if not check_index:
          expected = expected.sort_values(list(
              expected.columns)).reset_index(drop=True)
          actual = actual.sort_values(list(
              actual.columns)).reset_index(drop=True)
        if not check_names:
          actual = actual.rename(
              columns=dict(zip(actual.columns, expected.columns)))
>       return assert_frame_equal(expected, actual, check_like=True)
E       AssertionError: DataFrame are different
E       
E       DataFrame shape mismatch
E       [left]:  (1000, 3)
E       [right]: (2000, 3)

apache_beam/dataframe/io_test.py:215: AssertionError

During handling of the above exception, another exception occurred:

a = (<apache_beam.dataframe.io_test.IOTest testMethod=test_read_write_2_json>,)
kw = {}

    @wraps(func)
    def standalone_func(*a, **kw):
>       return func(*(a + p.args), **p.kwargs, **kw)

target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/parameterized/parameterized.py:620: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/dataframe/io_test.py:180: in test_read_write
    self._run_read_write_test(
apache_beam/dataframe/io_test.py:234: in _run_read_write_test
    with beam.Pipeline() as p:
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:644: in __exit__
    self.result = self.run()
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:618: in run
    return self.runner.run_pipeline(self, self._options)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/direct/direct_runner.py:190: in run_pipeline
    return runner.run_pipeline(pipeline, options)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:196: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:223: in run_via_runner_api
    return self.run_stages(stage_context, stages)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:470: in run_stages
    bundle_results = self._execute_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:795: in _execute_bundle
    self._run_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1034: in _run_bundle
    result, splits = bundle_manager.process_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1360: in process_bundle
    result_future = self._worker_handler.control_conn.push(process_bundle_req)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/worker_handlers.py:386: in push
    response = self.worker.do_instruction(request)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py:658: in do_instruction
    return getattr(self, request_type)(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py:696: in process_bundle
    bundle_processor.process_bundle(instruction_id))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py:1274: in process_bundle
    input_op_by_transform_id[element.transform_id].process_encoded(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py:237: in process_encoded
    self.output(decoded_value)
apache_beam/runners/worker/operations.py:566: in apache_beam.runners.worker.operations.Operation.output
    def output(self, windowed_value, output_index=0):
apache_beam/runners/worker/operations.py:568: in apache_beam.runners.worker.operations.Operation.output
    _cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
apache_beam/runners/worker/operations.py:259: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    def receive(self, windowed_value):
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1606: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise new_exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:684: in apache_beam.runners.common.SimpleInvoker.invoke_process
    windowed_value, self.process_method(windowed_value.value))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/transforms/core.py:2086: in <lambda>
    wrapper = lambda x: [fn(x)]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

actual =      number      float                                               text
2         2   1.414214                      ...ooooooooooooooooo...
997     997  31.575307  fooooooooooooooooooooooooooooooooooooooooooooo...

[2000 rows x 3 columns]

    def check(actual):
      expected = expected_
      try:
        actual = pd.concat(actual)
        if not check_index:
          expected = expected.sort_values(list(
              expected.columns)).reset_index(drop=True)
          actual = actual.sort_values(list(
              actual.columns)).reset_index(drop=True)
        if not check_names:
          actual = actual.rename(
              columns=dict(zip(actual.columns, expected.columns)))
>       return assert_frame_equal(expected, actual, check_like=True)
E       AssertionError: DataFrame are different
E       
E       DataFrame shape mismatch
E       [left]:  (1000, 3)
E       [right]: (2000, 3) [while running 'assert_that/Match']

apache_beam/dataframe/io_test.py:215: AssertionError

Check warning on line 0 in apache_beam.dataframe.doctests_test.DoctestTest

See this annotation in the file changed.

@github-actions github-actions / Test Results

All 2 runs failed: test_file (apache_beam.dataframe.doctests_test.DoctestTest)

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 33s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 15s]
Raw output
AssertionError: 2 != 0
self = <apache_beam.dataframe.doctests_test.DoctestTest testMethod=test_file>

    def test_file(self):
      with tempfile.TemporaryDirectory() as dir:
        filename = os.path.join(dir, 'tests.py')
        with open(filename, 'w') as fout:
          fout.write(SAMPLE_DOCTEST)
        result = doctests.testfile(filename, module_relative=False, report=False)
      self.assertEqual(result.attempted, 3)
>     self.assertEqual(result.failed, 0)
E     AssertionError: 2 != 0

apache_beam/dataframe/doctests_test.py:170: AssertionError

Check warning on line 0 in apache_beam.dataframe.io_test.IOTest

See this annotation in the file changed.

@github-actions github-actions / Test Results

1 out of 2 runs failed: test_read_write_6_json (apache_beam.dataframe.io_test.IOTest)

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 39s]
Raw output
AssertionError: DataFrame are different

DataFrame shape mismatch
[left]:  (1000, 3)
[right]: (2000, 3) [while running 'assert_that/Match']
>   return self.do_fn_invoker.invoke_process(windowed_value)

apache_beam/runners/common.py:1495: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/runners/common.py:684: in apache_beam.runners.common.SimpleInvoker.invoke_process
    windowed_value, self.process_method(windowed_value.value))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/transforms/core.py:2086: in <lambda>
    wrapper = lambda x: [fn(x)]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

actual =       number      float                                               text
0          0   0.000000                    ...oooooooooooooooo...
1999     999  31.606961  fooooooooooooooooooooooooooooooooooooooooooooo...

[2000 rows x 3 columns]

    def check(actual):
      expected = expected_
      try:
        actual = pd.concat(actual)
        if not check_index:
          expected = expected.sort_values(list(
              expected.columns)).reset_index(drop=True)
          actual = actual.sort_values(list(
              actual.columns)).reset_index(drop=True)
        if not check_names:
          actual = actual.rename(
              columns=dict(zip(actual.columns, expected.columns)))
>       return assert_frame_equal(expected, actual, check_like=True)
E       AssertionError: DataFrame are different
E       
E       DataFrame shape mismatch
E       [left]:  (1000, 3)
E       [right]: (2000, 3)

apache_beam/dataframe/io_test.py:215: AssertionError

During handling of the above exception, another exception occurred:

a = (<apache_beam.dataframe.io_test.IOTest testMethod=test_read_write_6_json>,)
kw = {}

    @wraps(func)
    def standalone_func(*a, **kw):
>       return func(*(a + p.args), **p.kwargs, **kw)

target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/parameterized/parameterized.py:620: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/dataframe/io_test.py:180: in test_read_write
    self._run_read_write_test(
apache_beam/dataframe/io_test.py:234: in _run_read_write_test
    with beam.Pipeline() as p:
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:644: in __exit__
    self.result = self.run()
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/pipeline.py:618: in run
    return self.runner.run_pipeline(self, self._options)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/direct/direct_runner.py:190: in run_pipeline
    return runner.run_pipeline(pipeline, options)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:196: in run_pipeline
    self._latest_run_result = self.run_via_runner_api(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:223: in run_via_runner_api
    return self.run_stages(stage_context, stages)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:470: in run_stages
    bundle_results = self._execute_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:795: in _execute_bundle
    self._run_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1034: in _run_bundle
    result, splits = bundle_manager.process_bundle(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/fn_runner.py:1360: in process_bundle
    result_future = self._worker_handler.control_conn.push(process_bundle_req)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/portability/fn_api_runner/worker_handlers.py:386: in push
    response = self.worker.do_instruction(request)
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py:658: in do_instruction
    return getattr(self, request_type)(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/sdk_worker.py:696: in process_bundle
    bundle_processor.process_bundle(instruction_id))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py:1274: in process_bundle
    input_op_by_transform_id[element.transform_id].process_encoded(
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/runners/worker/bundle_processor.py:237: in process_encoded
    self.output(decoded_value)
apache_beam/runners/worker/operations.py:566: in apache_beam.runners.worker.operations.Operation.output
    def output(self, windowed_value, output_index=0):
apache_beam/runners/worker/operations.py:568: in apache_beam.runners.worker.operations.Operation.output
    _cast_to_receiver(self.receivers[output_index]).receive(windowed_value)
apache_beam/runners/worker/operations.py:259: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    def receive(self, windowed_value):
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1585: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:683: in apache_beam.runners.common.SimpleInvoker.invoke_process
    self.output_handler.handle_process_outputs(
apache_beam/runners/common.py:1680: in apache_beam.runners.common._OutputHandler.handle_process_outputs
    self._write_value_to_tag(tag, windowed_value, watermark_estimator)
apache_beam/runners/common.py:1793: in apache_beam.runners.common._OutputHandler._write_value_to_tag
    self.main_receivers.receive(windowed_value)
apache_beam/runners/worker/operations.py:262: in apache_beam.runners.worker.operations.SingletonElementConsumerSet.receive
    self.consumer.process(windowed_value)
apache_beam/runners/worker/operations.py:949: in apache_beam.runners.worker.operations.DoOperation.process
    with self.scoped_process_state:
apache_beam/runners/worker/operations.py:950: in apache_beam.runners.worker.operations.DoOperation.process
    delayed_applications = self.dofn_runner.process(o)
apache_beam/runners/common.py:1497: in apache_beam.runners.common.DoFnRunner.process
    self._reraise_augmented(exn, windowed_value)
apache_beam/runners/common.py:1606: in apache_beam.runners.common.DoFnRunner._reraise_augmented
    raise new_exn
apache_beam/runners/common.py:1495: in apache_beam.runners.common.DoFnRunner.process
    return self.do_fn_invoker.invoke_process(windowed_value)
apache_beam/runners/common.py:684: in apache_beam.runners.common.SimpleInvoker.invoke_process
    windowed_value, self.process_method(windowed_value.value))
target/.tox-py310-cloud/py310-cloud/lib/python3.10/site-packages/apache_beam/transforms/core.py:2086: in <lambda>
    wrapper = lambda x: [fn(x)]
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

actual =       number      float                                               text
0          0   0.000000                    ...oooooooooooooooo...
1999     999  31.606961  fooooooooooooooooooooooooooooooooooooooooooooo...

[2000 rows x 3 columns]

    def check(actual):
      expected = expected_
      try:
        actual = pd.concat(actual)
        if not check_index:
          expected = expected.sort_values(list(
              expected.columns)).reset_index(drop=True)
          actual = actual.sort_values(list(
              actual.columns)).reset_index(drop=True)
        if not check_names:
          actual = actual.rename(
              columns=dict(zip(actual.columns, expected.columns)))
>       return assert_frame_equal(expected, actual, check_like=True)
E       AssertionError: DataFrame are different
E       
E       DataFrame shape mismatch
E       [left]:  (1000, 3)
E       [right]: (2000, 3) [while running 'assert_that/Match']

apache_beam/dataframe/io_test.py:215: AssertionError

Check warning on line 0 in apache_beam.dataframe.doctests_test.DoctestTest

See this annotation in the file changed.

@github-actions github-actions / Test Results

All 2 runs failed: test_good (apache_beam.dataframe.doctests_test.DoctestTest)

sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310-cloud.xml [took 21s]
sdks/python/test-suites/tox/py310/build/srcs/sdks/python/pytest_py310.xml [took 10s]
Raw output
AssertionError: 1 != 0
self = <apache_beam.dataframe.doctests_test.DoctestTest testMethod=test_good>

    def test_good(self):
      result = doctests.teststring(SAMPLE_DOCTEST, report=False)
      self.assertEqual(result.attempted, 3)
>     self.assertEqual(result.failed, 0)
E     AssertionError: 1 != 0

apache_beam/dataframe/doctests_test.py:150: AssertionError

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Test Results

24 skipped tests found

There are 24 skipped tests, see "Raw output" for the full list of skipped tests.
Raw output
apache_beam.dataframe.frames_test.AggregationTest ‑ test_agg_min_count
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_level
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_level_bool_only
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_level_numeric_only
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_multifunc_level
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_level
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_multifunc_level
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_append_sort
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_append_verify_integrity
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_aggregate_grouped_column
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_dtypes
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_05_describe
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq_direct_read
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq_direct_read_with_project
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq_export_with_project
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq_with_computation
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_8_html
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_9_excel

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Test Results

630 tests found

There are 630 tests, see "Raw output" for the full list of tests.
Raw output
apache_beam.dataframe.convert_test.ConvertTest ‑ test_auto_convert
apache_beam.dataframe.convert_test.ConvertTest ‑ test_convert
apache_beam.dataframe.convert_test.ConvertTest ‑ test_convert_memoization
apache_beam.dataframe.convert_test.ConvertTest ‑ test_convert_memoization_clears_cache
apache_beam.dataframe.convert_test.ConvertTest ‑ test_convert_non_deferred
apache_beam.dataframe.convert_test.ConvertTest ‑ test_convert_scalar
apache_beam.dataframe.convert_test.ConvertTest ‑ test_convert_with_none
apache_beam.dataframe.convert_test.ConvertTest ‑ test_convert_yield_pandas
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_failed_assignment
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_failure
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_file
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_file_uses_beam_dataframes
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_good
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_not_implemented
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_not_implemented_followed_by_name_error
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_rst_ipython
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_uses_beam_dataframes
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_wont_implement
apache_beam.dataframe.doctests_test.DoctestTest ‑ test_wont_implement_followed_by_name_error
apache_beam.dataframe.expressions_test.ExpressionTest ‑ test_computed_expression
apache_beam.dataframe.expressions_test.ExpressionTest ‑ test_constant_expresion
apache_beam.dataframe.expressions_test.ExpressionTest ‑ test_expression_proxy
apache_beam.dataframe.expressions_test.ExpressionTest ‑ test_expression_proxy_error
apache_beam.dataframe.expressions_test.ExpressionTest ‑ test_placeholder_expression
apache_beam.dataframe.expressions_test.ExpressionTest ‑ test_preserves_index_output_partitioning
apache_beam.dataframe.expressions_test.ExpressionTest ‑ test_preserves_singleton_output_partitioning
apache_beam.dataframe.frame_base_test.FrameBaseTest ‑ test_args_to_kwargs
apache_beam.dataframe.frame_base_test.FrameBaseTest ‑ test_args_to_kwargs_populates_default_handles_kw_only
apache_beam.dataframe.frame_base_test.FrameBaseTest ‑ test_args_to_kwargs_populates_defaults
apache_beam.dataframe.frame_base_test.FrameBaseTest ‑ test_elementwise_func
apache_beam.dataframe.frame_base_test.FrameBaseTest ‑ test_elementwise_func_kwarg
apache_beam.dataframe.frame_base_test.FrameBaseTest ‑ test_maybe_inplace
apache_beam.dataframe.frame_base_test.FrameBaseTest ‑ test_populate_defaults_overwrites_copy
apache_beam.dataframe.frames_test.AggregationTest ‑ test_agg_min_count
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_00_all
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_01_any
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_02_max
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_03_min
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_04_prod
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_05_sum
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_06_size
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_07_count
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_08_mean
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_09_median
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_10_quantile
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_11_describe
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_12_sem
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_13_skew
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_14_kurt
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_15_kurtosis
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_16_std
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_17_var
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_18_corr
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_19_cov
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_20_nunique
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_bool_only
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_level
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_level_bool_only
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_level_numeric_only
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_00_all
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_01_any
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_02_corr
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_03_count
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_04_cov
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_05_describe
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_06_kurt
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_07_kurtosis
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_08_max
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_09_mean
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_10_median
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_11_min
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_12_nunique
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_13_prod
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_14_quantile
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_15_sem
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_16_skew
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_17_std
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_18_sum
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_method_19_var
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_modes
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_multifunc_level
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_numeric_only_0
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_agg_numeric_only_1
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_mode
apache_beam.dataframe.frames_test.AggregationTest ‑ test_dataframe_std
apache_beam.dataframe.frames_test.AggregationTest ‑ test_df_agg_invalid_kwarg_raises
apache_beam.dataframe.frames_test.AggregationTest ‑ test_df_agg_method_invalid_kwarg_raises
apache_beam.dataframe.frames_test.AggregationTest ‑ test_df_agg_operations_on_columns
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_00_all
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_01_any
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_02_count
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_03_describe
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_04_kurt
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_05_kurtosis
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_06_max
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_07_mean
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_08_median
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_09_min
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_10_nunique
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_11_prod
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_12_quantile
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_13_sem
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_14_size
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_15_skew
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_16_std
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_17_sum
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_18_var
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_level
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_00_all
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_01_any
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_02_count
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_03_describe
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_04_kurt
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_05_kurtosis
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_06_max
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_07_mean
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_08_median
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_09_min
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_10_nunique
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_11_prod
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_12_quantile
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_13_sem
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_14_skew
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_15_std
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_16_sum
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_17_var
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_method_invalid_kwarg_raises
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_modes
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_multifunc_level
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_np_size
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_agg_std
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_mean_skipna
apache_beam.dataframe.frames_test.AggregationTest ‑ test_series_mode
apache_beam.dataframe.frames_test.AggregationTest ‑ test_std_all_na
apache_beam.dataframe.frames_test.AggregationTest ‑ test_std_mostly_na_with_ddof
apache_beam.dataframe.frames_test.AllowNonParallelTest ‑ test_allow_non_parallel_in_context
apache_beam.dataframe.frames_test.AllowNonParallelTest ‑ test_allow_non_parallel_nesting
apache_beam.dataframe.frames_test.AllowNonParallelTest ‑ test_disallow_non_parallel
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_astype_categorical_rejected
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_drop_duplicates_keep_any
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_drop_duplicates_keep_any_subset
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_duplicated_keep_any
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_get_dummies_bools_casted_to_string
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_get_dummies_comma_separator
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_get_dummies_not_categoricaldtype
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_get_dummies_pandas_doc_example1
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_get_dummies_pandas_doc_example2
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_get_dummies_pass_nan_as_category
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_nlargest_any
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_nsmallest_any
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_pivot_pandas_example2
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_sample
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_sample_with_missing_weights
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_sample_with_weights
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_sample_with_weights_distribution
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_series_drop_duplicates_keep_any
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_split_pandas_examples_expand_not_categorical
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_split_pandas_examples_expand_pat_is_regex
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_split_pandas_examples_expand_pat_is_string_literal1
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_split_pandas_examples_expand_pat_is_string_literal2
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_split_pandas_examples_no_expand
apache_beam.dataframe.frames_test.BeamSpecificTest ‑ test_split_pat_is_regex
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_categorical_ordered
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_categories
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_dataframe_columns
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_dataframe_dtypes
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_datetime_tz
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_get_column_default_None
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_groupby_ndim
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_groupby_project_ndim
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_dtype_0_str_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_dtype_1_int_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_dtype_2_flt_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_dtype_3_cat_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_dtype_4_datetime_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_name_0_str_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_name_1_int_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_name_2_flt_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_name_3_cat_col
apache_beam.dataframe.frames_test.ConstructionTimeTest ‑ test_series_name_4_datetime_col
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_add_prefix
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_add_suffix
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_append_sort
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_append_verify_integrity
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_applymap_na_action
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_astype_categorical
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_astype_categorical_with_unstack
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_cat
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_categorical_groupby
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_combine_Series
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_combine_dataframe
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_combine_dataframe_fill
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_combine_first_dataframe
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_combine_first_series
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_compare_dataframe
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_compare_series
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_corrwith_bad_axis
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_create_methods_0
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_create_methods_1
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_create_methods_2
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_arithmetic
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_column_fillna_constant_as_value
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_cov_corr
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_drop_ignore_errors
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_eval_query
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_fillna_dataframe_as_value
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_fillna_series_as_value
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_getitem
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_melt
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_sum_nonnumeric_raises
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_truncate
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dataframe_xs
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_drop_duplicates
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_method_0_month_name
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_method_1_day_name
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_method_2_normalize
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_method_3_strftime
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_method_4_tz_convert
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_00_date
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_01_day
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_02_dayofweek
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_03_dayofyear
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_04_days_in_month
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_05_daysinmonth
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_06_hour
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_07_is_leap_year
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_08_is_month_end
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_09_is_month_start
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_10_is_quarter_end
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_11_is_quarter_start
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_12_is_year_end
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_13_is_year_start
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_14_microsecond
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_15_minute
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_16_month
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_17_nanosecond
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_18_quarter
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_19_second
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_20_time
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_21_timetz
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_22_weekday
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_property_23_year
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_tz_localize_ambiguous_series
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_dt_tz_localize_nonexistent
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_fillna_columns
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_get_column
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_idxmax
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_idxmin
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_index_name_assignment
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_insert
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_insert_does_not_support_list_value
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_loc
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_map_na_action
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_merge
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_merge_left_join
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_merge_on_index
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_merge_same_key
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_merge_same_key_doctest
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_merge_same_key_suffix_collision
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pipe
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pivot_no_index_provided_on_multiindex
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pivot_no_index_provided_on_single_level_index
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pivot_non_categorical
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pivot_pandas_example1
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pivot_pandas_example3
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pivot_pandas_example4
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pivot_pandas_example5
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_pivot_pandas_example6
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_quantile
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_replace
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_sample_columns
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_arithmetic
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_cov_corr
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_drop_ignore_errors
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_fillna_series_as_value
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_getitem
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_hasnans_0
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_hasnans_1
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_hasnans_2
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_hasnans_3
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_is_unique_0
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_is_unique_1
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_is_unique_2
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_is_unique_3
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_is_unique_4
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_set_axis
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_truncate
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_series_xs
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_set_axis
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_set_column
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_set_column_from_index
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_set_index
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_smallest_largest
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_sort_index_columns
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_swaplevel
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_tz_convert
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_tz_localize_ambiguous_series
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_tz_with_utc_zone_set_explicitly
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_unstack_bool
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_unstack_non_categorical_index
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_unstack_pandas_example1
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_unstack_pandas_example2
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_unstack_pandas_example3
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_unstack_pandas_series_not_multiindex
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_unstack_series_multiple_index_and_column_levels
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_unstack_series_multiple_index_levels
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_value_counts_does_not_support_sort
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_value_counts_dropna_false
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_value_counts_with_nans
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_where_callable_args
apache_beam.dataframe.frames_test.DeferredFrameTest ‑ test_where_concrete_args
apache_beam.dataframe.frames_test.DocstringTest ‑ test_docs_defined_0
apache_beam.dataframe.frames_test.DocstringTest ‑ test_docs_defined_1
apache_beam.dataframe.frames_test.DocstringTest ‑ test_docs_defined_2
apache_beam.dataframe.frames_test.DocstringTest ‑ test_docs_defined_3
apache_beam.dataframe.frames_test.DocstringTest ‑ test_docs_defined_4
apache_beam.dataframe.frames_test.DocstringTest ‑ test_docs_defined_5
apache_beam.dataframe.frames_test.DocstringTest ‑ test_docs_defined_6
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_00_all
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_01_any
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_03_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_06_max
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_07_mean
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_08_median
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_09_min
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_10_nunique
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_11_prod
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_12_quantile
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_13_sem
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_14_size
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_15_skew
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_16_std
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_17_sum
apache_beam.dataframe.frames_test.GroupByTest ‑ test_dataframe_groupby_series_18_var
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_00_all
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_01_any
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_03_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_06_max
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_07_mean
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_08_median
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_09_min
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_10_nunique
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_11_prod
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_12_quantile
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_13_sem
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_14_size
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_15_skew
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_16_std
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_17_sum
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_18_var
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_00_all
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_01_any
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_03_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_06_max
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_07_mean
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_08_median
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_09_min
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_10_nunique
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_11_prod
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_12_quantile
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_13_sem
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_14_size
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_15_skew
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_16_std
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_17_sum
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_agg_18_var
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_aggregate_grouped_column
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_apply
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_apply_modified_index
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_apply_preserves_column_order
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_callable
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_count_na
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_dtypes
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_errors_bad_projection
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_errors_non_existent_label
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_level_agg_0
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_level_agg_1
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_level_agg_2
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_level_agg_3
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_level_agg_4
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_level_agg_5
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_level_agg_6
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_level_agg_7
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_multiindex_keep_nans
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_pipe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_00_all
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_01_any
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_03_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_06_max
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_07_mean
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_08_median
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_09_min
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_10_nunique
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_11_prod
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_12_quantile
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_13_sem
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_14_size
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_15_skew
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_16_std
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_17_sum
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_dataframe_18_var
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_00_all
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_01_any
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_03_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_06_max
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_07_mean
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_08_median
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_09_min
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_10_nunique
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_11_prod
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_12_quantile
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_13_sem
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_14_size
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_15_skew
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_16_std
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_17_sum
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_project_series_18_var
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_00_all
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_01_any
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_03_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_06_max
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_07_mean
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_08_median
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_09_min
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_10_nunique
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_11_prod
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_12_quantile
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_13_sem
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_14_size
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_15_skew
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_16_std
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_17_sum
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_18_var
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_series_apply
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_sum_min_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_transform
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_user_guide
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_00_all
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_01_any
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_03_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_06_max
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_07_mean
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_08_median
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_09_min
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_10_nunique
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_11_prod
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_12_quantile
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_13_sem
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_14_size
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_15_skew
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_16_std
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_17_sum
apache_beam.dataframe.frames_test.GroupByTest ‑ test_groupby_with_filter_18_var
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_00_all
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_01_any
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_02_corr
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_03_count
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_04_cov
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_05_describe
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_06_max
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_07_mean
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_08_median
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_09_min
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_10_nunique
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_11_prod
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_12_quantile
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_13_sem
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_14_size
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_15_skew
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_16_std
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_17_sum
apache_beam.dataframe.frames_test.GroupByTest ‑ test_series_groupby_series_18_var
apache_beam.dataframe.frames_test.InteractiveDataFrameTest ‑ test_collect_merged_dataframes
apache_beam.dataframe.frames_test.ReprTest ‑ test_basic_dataframe
apache_beam.dataframe.frames_test.ReprTest ‑ test_basic_series
apache_beam.dataframe.frames_test.ReprTest ‑ test_dataframe_with_multiple_column_and_multiple_index_levels
apache_beam.dataframe.frames_test.ReprTest ‑ test_dataframe_with_multiple_column_levels
apache_beam.dataframe.frames_test.ReprTest ‑ test_dataframe_with_named_index
apache_beam.dataframe.frames_test.ReprTest ‑ test_dataframe_with_named_multi_index
apache_beam.dataframe.frames_test.ReprTest ‑ test_dataframe_with_partial_named_index
apache_beam.dataframe.frames_test.ReprTest ‑ test_series_with_named_index
apache_beam.dataframe.frames_test.ReprTest ‑ test_series_with_named_multi_index
apache_beam.dataframe.frames_test.ReprTest ‑ test_series_with_partial_named_index
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq_direct_read
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq_direct_read_with_project
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq_export_with_project
apache_beam.dataframe.io_it_test.ReadUsingReadGbqTests ‑ test_ReadGbq_with_computation
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_00_defaults
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_01_header
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_02_multi_header
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_03_multi_header
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_04_names
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_05_names_and_header
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_06_skip_blank_lines
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_07_skip_blank_lines
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_08_comment
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_09_comment
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_10_skiprows
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_11_skiprows
apache_beam.dataframe.io_test.IOTest ‑ test_csv_splitter_12_skiprows
apache_beam.dataframe.io_test.IOTest ‑ test_double_write
apache_beam.dataframe.io_test.IOTest ‑ test_file_not_found
apache_beam.dataframe.io_test.IOTest ‑ test_read_fwf
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_0_csv
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_1_csv
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_2_json
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_3_json
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_4_json
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_5_json
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_6_json
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_7_json
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_8_html
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_9_excel
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_csv
apache_beam.dataframe.io_test.IOTest ‑ test_read_write_parquet
apache_beam.dataframe.io_test.IOTest ‑ test_sharding_parameters
apache_beam.dataframe.io_test.IOTest ‑ test_truncating_filehandle
apache_beam.dataframe.io_test.IOTest ‑ test_truncating_filehandle_iter
apache_beam.dataframe.io_test.IOTest ‑ test_wide_csv_with_dtypes
apache_beam.dataframe.io_test.IOTest ‑ test_windowed_write
apache_beam.dataframe.io_test.ReadGbqTransformTests ‑ test_ReadGbq_unsupported_param
apache_beam.dataframe.io_test.ReadGbqTransformTests ‑ test_bad_schema_public_api_direct_read
apache_beam.dataframe.io_test.ReadGbqTransformTests ‑ test_unsupported_callable
apache_beam.dataframe.pandas_doctests_test.DoctestTest ‑ test_dataframe_tests
apache_beam.dataframe.pandas_doctests_test.DoctestTest ‑ test_datetime_tests
apache_beam.dataframe.pandas_doctests_test.DoctestTest ‑ test_groupby_tests
apache_beam.dataframe.pandas_doctests_test.DoctestTest ‑ test_indexing_tests
apache_beam.dataframe.pandas_doctests_test.DoctestTest ‑ test_ndframe_tests
apache_beam.dataframe.pandas_doctests_test.DoctestTest ‑ test_series_tests
apache_beam.dataframe.pandas_doctests_test.DoctestTest ‑ test_string_tests
apache_beam.dataframe.pandas_doctests_test.DoctestTest ‑ test_top_level
apache_beam.dataframe.partitionings_test.PartitioningsTest ‑ test_index_is_subpartition
apache_beam.dataframe.partitionings_test.PartitioningsTest ‑ test_index_partition
apache_beam.dataframe.partitionings_test.PartitioningsTest ‑ test_nothing_subpartition
apache_beam.dataframe.partitionings_test.PartitioningsTest ‑ test_singleton_partition
apache_beam.dataframe.partitionings_test.PartitioningsTest ‑ test_singleton_subpartition
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_batch_with_df_transform
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_bytes_proxy_roundtrip
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_generate_proxy
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_generate_proxy_beam_typehint
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_nice_types_proxy_roundtrip
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_simple_df
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_simple_df_with_beam_row
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_datetime
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_include_index_column_conflict_raises
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_include_index_nonunique_index_raises
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_include_index_unnamed_index_raises
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_DataFrame[int32,int64,Int32,Int64,float64,float32,bool,object,boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[Int32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[Int64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[bool]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[boolean]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[float32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[float64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[int32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[int64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[object]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_no_index_Series[string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[Int32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[Int64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[bool]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[boolean]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[float32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[float64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[int32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[int64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[object]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_series_with_index_warns_Series[string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[Int32,Int64,float64,float32,bool,object,boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[Int64,float64,float32,bool,object,boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[bool,object,boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[float32,bool,object,boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[float64,float32,bool,object,boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[int64,Int32,Int64,float64,float32,bool,object,boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[object,boolean,string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_DataFrame[string]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[Int32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[Int64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[bool]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[boolean]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[float32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[float64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[int32]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[int64]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[object]
apache_beam.dataframe.schemas_test.SchemasTest ‑ test_unbatch_with_index_Series[string]
apache_beam.dataframe.transforms_test.FusionTest ‑ test_column_manipulation
apache_beam.dataframe.transforms_test.FusionTest ‑ test_loc_filter
apache_beam.dataframe.transforms_test.TransformPartsTest ‑ test_rebatch
apache_beam.dataframe.transforms_test.TransformTest ‑ test_batching_beam_row_input
apache_beam.dataframe.transforms_test.TransformTest ‑ test_batching_beam_row_to_dataframe
apache_beam.dataframe.transforms_test.TransformTest ‑ test_batching_named_tuple_input
apache_beam.dataframe.transforms_test.TransformTest ‑ test_batching_passthrough_nested_array
apache_beam.dataframe.transforms_test.TransformTest ‑ test_batching_passthrough_nested_schema
apache_beam.dataframe.transforms_test.TransformTest ‑ test_cat
apache_beam.dataframe.transforms_test.TransformTest ‑ test_filter
apache_beam.dataframe.transforms_test.TransformTest ‑ test_getitem_projection
apache_beam.dataframe.transforms_test.TransformTest ‑ test_groupby_apply
apache_beam.dataframe.transforms_test.TransformTest ‑ test_groupby_sum_mean
apache_beam.dataframe.transforms_test.TransformTest ‑ test_identity
apache_beam.dataframe.transforms_test.TransformTest ‑ test_input_output_polymorphism
apache_beam.dataframe.transforms_test.TransformTest ‑ test_offset_elementwise
apache_beam.dataframe.transforms_test.TransformTest ‑ test_rename
apache_beam.dataframe.transforms_test.TransformTest ‑ test_repeat
apache_beam.dataframe.transforms_test.TransformTest ‑ test_scalar
apache_beam.dataframe.transforms_test.TransformTest ‑ test_unbatching_series