Skip to content

Commit e3233d7

Browse files
committed
Fix linting error: unused imports
1 parent 8deb0f4 commit e3233d7

File tree

2 files changed

+1
-8
lines changed

2 files changed

+1
-8
lines changed

sdks/python/apache_beam/runners/interactive/interactive_beam_test.py

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -25,7 +25,7 @@
2525
import unittest
2626
from typing import NamedTuple
2727
from unittest.mock import patch
28-
from concurrent.futures import Future, TimeoutError
28+
from concurrent.futures import TimeoutError
2929

3030
import apache_beam as beam
3131
from apache_beam import dataframe as frames

sdks/python/apache_beam/runners/interactive/recording_manager.py

Lines changed: 0 additions & 7 deletions
Original file line numberDiff line numberDiff line change
@@ -15,7 +15,6 @@
1515
# limitations under the License.
1616
#
1717

18-
import asyncio
1918
import collections
2019
from concurrent.futures import Future, ThreadPoolExecutor
2120
import logging
@@ -37,7 +36,6 @@
3736
import apache_beam as beam
3837
from apache_beam.dataframe.frame_base import DeferredBase
3938
from apache_beam.options import pipeline_options
40-
from apache_beam.pipeline import PipelineVisitor
4139
from apache_beam.portability.api import beam_runner_api_pb2
4240
from apache_beam.runners import runner
4341
from apache_beam.runners.interactive import background_caching_job as bcj
@@ -47,7 +45,6 @@
4745
from apache_beam.runners.interactive import utils
4846
from apache_beam.runners.interactive.caching.cacheable import CacheKey
4947
from apache_beam.runners.interactive.display.pipeline_graph import PipelineGraph
50-
from apache_beam.runners.interactive.messaging.interactive_environment_inspector import meta
5148
from apache_beam.runners.interactive.options import capture_control
5249
from apache_beam.runners.runner import PipelineState
5350

@@ -721,10 +718,6 @@ def _get_pcoll_id_map(self):
721718
else:
722719
# Fallback for proto-based PipelineGraph, though less likely in this context
723720
proto = self._pipeline_graph._pipeline_proto
724-
for pid, pcoll_proto in proto.components.pcollections.items():
725-
# This is tricky, we don't have the direct Python object map here.
726-
# This path is less likely to be hit if PipelineGraph is init with a beam.Pipeline
727-
pass
728721
return {v: k for k, v in pcoll_to_id.items()}
729722

730723
def _get_all_dependencies(

0 commit comments

Comments
 (0)