diff --git a/sdks/python/apache_beam/runners/direct/watermark_manager.py b/sdks/python/apache_beam/runners/direct/watermark_manager.py index 854d6475de04..666ade6cf82d 100644 --- a/sdks/python/apache_beam/runners/direct/watermark_manager.py +++ b/sdks/python/apache_beam/runners/direct/watermark_manager.py @@ -28,8 +28,8 @@ from typing import Tuple from apache_beam import pipeline -from apache_beam.pipeline import AppliedPTransform from apache_beam import pvalue +from apache_beam.pipeline import AppliedPTransform from apache_beam.runners.direct.util import TimerFiring from apache_beam.utils.timestamp import MAX_TIMESTAMP from apache_beam.utils.timestamp import MIN_TIMESTAMP diff --git a/sdks/python/apache_beam/runners/pipeline_context.py b/sdks/python/apache_beam/runners/pipeline_context.py index 6af40e10332d..0a03c96bc19b 100644 --- a/sdks/python/apache_beam/runners/pipeline_context.py +++ b/sdks/python/apache_beam/runners/pipeline_context.py @@ -38,10 +38,10 @@ from typing_extensions import Protocol from apache_beam import coders -from apache_beam.coders.coder_impl import IterableStateReader -from apache_beam.coders.coder_impl import IterableStateWriter from apache_beam import pipeline from apache_beam import pvalue +from apache_beam.coders.coder_impl import IterableStateReader +from apache_beam.coders.coder_impl import IterableStateWriter from apache_beam.internal import pickler from apache_beam.pipeline import ComponentIdMap from apache_beam.portability.api import beam_fn_api_pb2 diff --git a/sdks/python/apache_beam/runners/portability/fn_api_runner/execution.py b/sdks/python/apache_beam/runners/portability/fn_api_runner/execution.py index 4976ff78aa99..e69e37495f64 100644 --- a/sdks/python/apache_beam/runners/portability/fn_api_runner/execution.py +++ b/sdks/python/apache_beam/runners/portability/fn_api_runner/execution.py @@ -48,19 +48,19 @@ from apache_beam import coders from apache_beam.coders.coder_impl import CoderImpl +from apache_beam.coders.coder_impl import WindowedValueCoderImpl from apache_beam.coders.coder_impl import create_InputStream from apache_beam.coders.coder_impl import create_OutputStream -from apache_beam.coders.coder_impl import WindowedValueCoderImpl from apache_beam.coders.coders import WindowedValueCoder from apache_beam.portability import common_urns from apache_beam.portability import python_urns from apache_beam.portability.api import beam_fn_api_pb2 from apache_beam.portability.api import beam_runner_api_pb2 +from apache_beam.portability.api import endpoints_pb2 from apache_beam.runners import pipeline_context from apache_beam.runners.common import ENCODED_IMPULSE_VALUE from apache_beam.runners.direct.clock import RealClock from apache_beam.runners.direct.clock import TestClock -from apache_beam.portability.api import endpoints_pb2 from apache_beam.runners.portability.fn_api_runner import translations from apache_beam.runners.portability.fn_api_runner.translations import DataInput from apache_beam.runners.portability.fn_api_runner.translations import DataOutput